hash
stringlengths 40
40
| date
stringdate 2016-01-09 03:44:20
2025-03-21 23:04:15
| author
stringclasses 177
values | commit_message
stringlengths 11
157
| is_merge
bool 1
class | masked_commit_message
stringlengths 6
148
| type
stringclasses 87
values | git_diff
stringlengths 172
12.1M
|
|---|---|---|---|---|---|---|---|
6882a068ee5a659182095e8d8610fcff583e7573
|
2019-02-13 17:51:46
|
Tobias Schottdorf
|
roachtest: bump clearrange's timeout
| false
|
bump clearrange's timeout
|
roachtest
|
diff --git a/pkg/cmd/roachtest/clearrange.go b/pkg/cmd/roachtest/clearrange.go
index e577a1452148..eddb47241e4b 100644
--- a/pkg/cmd/roachtest/clearrange.go
+++ b/pkg/cmd/roachtest/clearrange.go
@@ -27,8 +27,10 @@ func registerClearRange(r *registry) {
for _, checks := range []bool{true, false} {
checks := checks
r.Add(testSpec{
- Name: fmt.Sprintf(`clearrange/checks=%t`, checks),
- Timeout: 3*time.Hour + 90*time.Minute, // 3h for import, 90 for the test
+ Name: fmt.Sprintf(`clearrange/checks=%t`, checks),
+ // 5h for import, 90 for the test. The import should take closer
+ // to <3:30h but it varies.
+ Timeout: 5*time.Hour + 90*time.Minute,
MinVersion: `v2.2.0`,
Cluster: makeClusterSpec(10),
Run: func(ctx context.Context, t *test, c *cluster) {
|
556354a37263ac048d3572b6d275b9cb948b06e7
|
2018-09-11 22:36:13
|
Andrew Couch
|
ui: add legend to tooltip on Statements pages
| false
|
add legend to tooltip on Statements pages
|
ui
|
diff --git a/pkg/ui/src/views/statements/barCharts.tsx b/pkg/ui/src/views/statements/barCharts.tsx
index fb2b057693f0..ec3a1b020288 100644
--- a/pkg/ui/src/views/statements/barCharts.tsx
+++ b/pkg/ui/src/views/statements/barCharts.tsx
@@ -1,5 +1,6 @@
import d3 from "d3";
import _ from "lodash";
+import Long from "long";
import React from "react";
import { ToolTipWrapper } from "src/views/shared/components/toolTip";
@@ -12,7 +13,7 @@ import * as protos from "src/js/protos";
type StatementStatistics = protos.cockroach.server.serverpb.StatementsResponse.ICollectedStatementStatistics;
-const longToInt = (d: number | Long) => FixLong(d).toInt();
+const longToInt = (d: number | Long) => Long.fromValue(FixLong(d)).toInt();
const clamp = (i: number) => i < 0 ? 0 : i;
const countBars = [
@@ -41,8 +42,30 @@ function bar(name: string, value: (d: StatementStatistics) => number) {
return { name, value };
}
+function renderNumericStatLegend(count: number | Long, stat: number, sd: number, formatter: (d: number) => string) {
+ return (
+ <table className="numeric-stat-legend">
+ <tbody>
+ <tr>
+ <th>
+ <div className="numeric-stat-legend__bar numeric-stat-legend__bar--mean" />
+ Mean
+ </th>
+ <td>{ formatter(stat) }</td>
+ </tr>
+ <tr>
+ <th>
+ <div className="numeric-stat-legend__bar numeric-stat-legend__bar--dev" />
+ Standard Deviation
+ </th>
+ <td>{ longToInt(count) < 2 ? "-" : sd ? formatter(sd) : "0" }</td>
+ </tr>
+ </tbody>
+ </table>
+ );
+}
+
function makeBarChart(
- title: string,
accessors: { name: string, value: (d: StatementStatistics) => number }[],
formatter: (d: number) => string = (x) => `${x}`,
stdDevAccessor?: { name: string, value: (d: StatementStatistics) => number },
@@ -100,23 +123,27 @@ function makeBarChart(
);
}
- let titleText = title + ": " + formatter(sum);
if (stdDevAccessor) {
const sd = stdDevAccessor.value(d);
- if (sd) {
- titleText += " Std. Dev.: " + formatter(sd);
- }
- }
+ const titleText = renderNumericStatLegend(rows.length, sum, sd, formatter);
- return (
- <div className={ "bar-chart" + (rows.length === 0 ? " bar-chart--singleton" : "") }>
- <ToolTipWrapper text={ titleText } short>
+ return (
+ <div className={ "bar-chart" + (rows.length === 0 ? " bar-chart--singleton" : "") }>
+ <ToolTipWrapper text={ titleText } short>
+ <div className="label">{ formatter(getTotal(d)) }</div>
+ { bars }
+ { renderStdDev() }
+ </ToolTipWrapper>
+ </div>
+ );
+ } else {
+ return (
+ <div className={ "bar-chart" + (rows.length === 0 ? " bar-chart--singleton" : "") }>
<div className="label">{ formatter(getTotal(d)) }</div>
{ bars }
- { renderStdDev() }
- </ToolTipWrapper>
- </div>
- );
+ </div>
+ );
+ }
};
};
}
@@ -138,10 +165,10 @@ export function approximify(value: number) {
return "" + Math.round(value);
}
-export const countBarChart = makeBarChart("Execution Count", countBars, approximify);
-export const retryBarChart = makeBarChart("Retry Count", retryBars, approximify);
-export const rowsBarChart = makeBarChart("Rows Affected. Mean", rowsBars, approximify, rowsStdDev);
-export const latencyBarChart = makeBarChart("Latency. Mean", latencyBars, v => Duration(v * 1e9), latencyStdDev);
+export const countBarChart = makeBarChart(countBars, approximify);
+export const retryBarChart = makeBarChart(retryBars, approximify);
+export const rowsBarChart = makeBarChart(rowsBars, approximify, rowsStdDev);
+export const latencyBarChart = makeBarChart(latencyBars, v => Duration(v * 1e9), latencyStdDev);
export function countBreakdown(s: StatementStatistics) {
const count = longToInt(s.stats.count);
@@ -210,7 +237,7 @@ export function rowsBreakdown(s: StatementStatistics) {
const width = scale(clamp(mean - sd));
const right = scale(mean);
const spread = scale(sd + (sd > mean ? mean : sd));
- const title = "Row Count. Mean: " + format(mean) + " Std.Dev.: " + format(sd);
+ const title = renderNumericStatLegend(s.stats.count, mean, sd, format);
return (
<div className="bar-chart bar-chart--breakdown">
<ToolTipWrapper text={ title } short>
@@ -264,7 +291,7 @@ export function latencyBreakdown(s: StatementStatistics) {
const width = scale(clamp(parseMean - parseSd));
const right = scale(parseMean);
const spread = scale(parseSd + (parseSd > parseMean ? parseMean : parseSd));
- const title = "Parse Latency. Mean: " + format(parseMean) + " Std. Dev.: " + format(parseSd);
+ const title = renderNumericStatLegend(s.stats.count, parseMean, parseSd, format);
return (
<div className="bar-chart bar-chart--breakdown">
<ToolTipWrapper text={ title } short>
@@ -286,7 +313,7 @@ export function latencyBreakdown(s: StatementStatistics) {
const width = scale(clamp(planMean - planSd));
const right = scale(planMean);
const spread = scale(planSd + (planSd > planMean ? planMean : planSd));
- const title = "Plan Latency. Mean: " + format(planMean) + " Std. Dev.: " + format(planSd);
+ const title = renderNumericStatLegend(s.stats.count, planMean, planSd, format);
return (
<div className="bar-chart bar-chart--breakdown">
<ToolTipWrapper text={ title } short>
@@ -308,7 +335,7 @@ export function latencyBreakdown(s: StatementStatistics) {
const width = scale(clamp(runMean - runSd));
const right = scale(runMean);
const spread = scale(runSd + (runSd > runMean ? runMean : runSd));
- const title = "Run Latency. Mean: " + format(runMean) + " Std. Dev.: " + format(runSd);
+ const title = renderNumericStatLegend(s.stats.count, runMean, runSd, format);
return (
<div className="bar-chart bar-chart--breakdown">
<ToolTipWrapper text={ title } short>
@@ -330,7 +357,7 @@ export function latencyBreakdown(s: StatementStatistics) {
const width = scale(clamp(overheadMean - overheadSd));
const right = scale(overheadMean);
const spread = scale(overheadSd + (overheadSd > overheadMean ? overheadMean : overheadSd));
- const title = "Overhead Latency. Mean: " + format(overheadMean) + " Std. Dev.: " + format(overheadSd);
+ const title = renderNumericStatLegend(s.stats.count, overheadMean, overheadSd, format);
return (
<div className="bar-chart bar-chart--breakdown">
<ToolTipWrapper text={ title } short>
@@ -354,7 +381,7 @@ export function latencyBreakdown(s: StatementStatistics) {
const overhead = scale(overheadMean);
const width = scale(clamp(overallMean - overallSd));
const spread = scale(overallSd + (overallSd > overallMean ? overallMean : overallSd));
- const title = "Overall Latency. Mean: " + format(overallMean) + " Std. Dev.: " + format(overallSd);
+ const title = renderNumericStatLegend(s.stats.count, overallMean, overallSd, format);
return (
<div className="bar-chart bar-chart--breakdown">
<ToolTipWrapper text={ title } short>
diff --git a/pkg/ui/src/views/statements/statements.styl b/pkg/ui/src/views/statements/statements.styl
index 7e864e165972..018ca7067fd7 100644
--- a/pkg/ui/src/views/statements/statements.styl
+++ b/pkg/ui/src/views/statements/statements.styl
@@ -102,10 +102,34 @@
background-color $link-color
.rows-dev, .latency-parse-dev, .latency-plan-dev, .latency-run-dev, .latency-overhead-dev, .latency-overall-dev
- background-color #F2C94C
+ background-color $warning-color
.numeric-stats-table
@extend $table-base
.details-bar
margin 12px 0
+
+.numeric-stat-legend
+ th
+ position relative
+ padding-left 24px
+ padding-right 5px
+
+ td
+ text-align right
+
+ &__bar
+ position absolute
+ width 21px
+ left 0
+
+ &--mean
+ height 14px
+ top 2px
+ background-color $link-color
+
+ &--dev
+ height 3px
+ top 8px
+ background-color $warning-color
|
4e182ad296df9660d44ec6905d4fd149f1c91a39
|
2016-09-27 00:53:52
|
Tamir Duberstein
|
cli: update user terminology
| false
|
update user terminology
|
cli
|
diff --git a/cli/user.go b/cli/user.go
index 85f3e63557dc..770c44c59e5b 100644
--- a/cli/user.go
+++ b/cli/user.go
@@ -30,9 +30,9 @@ var password string
// A getUserCmd command displays the config for the specified username.
var getUserCmd = &cobra.Command{
Use: "get [options] <username>",
- Short: "fetches and displays a user config",
+ Short: "fetches and displays a user",
Long: `
-Fetches and displays the user configuration for <username>.
+Fetches and displays the user for <username>.
`,
SilenceUsage: true,
RunE: panicGuard(runGetUser),
@@ -55,12 +55,12 @@ func runGetUser(cmd *cobra.Command, args []string) {
}
}
-// A lsUsersCmd command displays a list of user configs.
+// A lsUsersCmd command displays a list of users.
var lsUsersCmd = &cobra.Command{
Use: "ls [options]",
- Short: "list all user configs",
+ Short: "list all users",
Long: `
-List all user configs.
+List all users.
`,
SilenceUsage: true,
RunE: panicGuard(runLsUsers),
@@ -83,12 +83,12 @@ func runLsUsers(cmd *cobra.Command, args []string) {
}
}
-// A rmUserCmd command removes the user config for the specified username.
+// A rmUserCmd command removes the user for the specified username.
var rmUserCmd = &cobra.Command{
Use: "rm [options] <username>",
- Short: "remove a user config",
+ Short: "remove a user",
Long: `
-Remove an existing user config by username.
+Remove an existing user by username.
`,
SilenceUsage: true,
RunE: panicGuard(runRmUser),
@@ -111,12 +111,12 @@ func runRmUser(cmd *cobra.Command, args []string) {
}
}
-// A setUserCmd command creates a new or updates an existing user config.
+// A setUserCmd command creates a new or updates an existing user.
var setUserCmd = &cobra.Command{
Use: "set [options] <username>",
- Short: "create or update a user config for key prefix",
+ Short: "create or update a user",
Long: `
-Create or update a user config for the specified username, prompting
+Create or update a user for the specified username, prompting
for the password.
`,
SilenceUsage: true,
@@ -125,7 +125,7 @@ for the password.
// runSetUser prompts for a password, then inserts the user and hash
// into the system.users table.
-// TODO(marc): once we have more fields in the user config, we will need
+// TODO(marc): once we have more fields in the user, we will need
// to allow changing just some of them (eg: change email, but leave password).
func runSetUser(cmd *cobra.Command, args []string) {
if len(args) != 1 {
|
15e09a617217af0411aa11411c7e91eeec3e5f85
|
2016-09-16 20:52:08
|
Peter Mattis
|
storage: fix range quiescence
| false
|
fix range quiescence
|
storage
|
diff --git a/storage/client_raft_test.go b/storage/client_raft_test.go
index f3e8877acb5d..e822bc1b8334 100644
--- a/storage/client_raft_test.go
+++ b/storage/client_raft_test.go
@@ -2095,7 +2095,7 @@ func TestReplicaLazyLoad(t *testing.T) {
// Wait for a bunch of raft ticks.
ticks := mtc.stores[0].Metrics().RaftTicks.Count
- for targetTicks := ticks() + 5; targetTicks < ticks(); {
+ for targetTicks := ticks() + 5; ticks() < targetTicks; {
time.Sleep(time.Millisecond)
}
@@ -2493,7 +2493,7 @@ func TestRaftBlockedReplica(t *testing.T) {
// Verify that we're still ticking the non-blocked replica.
ticks := mtc.stores[0].Metrics().RaftTicks.Count
- for targetTicks := ticks() + 5; targetTicks < ticks(); {
+ for targetTicks := ticks() + 5; ticks() < targetTicks; {
time.Sleep(time.Millisecond)
}
@@ -2504,3 +2504,72 @@ func TestRaftBlockedReplica(t *testing.T) {
}
mtc.waitForValues(roachpb.Key("a"), []int64{5, 5, 5})
}
+
+// Test that ranges quiesce and if a follower unquiesces the leader is woken
+// up.
+func TestRangeQuiescence(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+
+ sc := storage.TestStoreContext()
+ sc.RaftTickInterval = 1 * time.Millisecond
+ sc.RaftHeartbeatIntervalTicks = 2
+ sc.RaftElectionTimeoutTicks = 10
+ sc.TestingKnobs.DisableScanner = true
+ mtc := multiTestContext{storeContext: &sc}
+ mtc.Start(t, 3)
+ defer mtc.Stop()
+
+ // Replica range 1 to all 3 nodes.
+ mtc.replicateRange(1, 1, 2)
+
+ waitForQuiescence := func(rangeID roachpb.RangeID) {
+ util.SucceedsSoon(t, func() error {
+ for _, s := range mtc.stores {
+ rep, err := s.GetReplica(rangeID)
+ if err != nil {
+ t.Fatal(err)
+ }
+ if !rep.IsQuiescent() {
+ return errors.Errorf("%s not quiescent", rep)
+ }
+ }
+ return nil
+ })
+ }
+
+ // Wait for the range to quiesce.
+ waitForQuiescence(1)
+
+ // Find the leader replica.
+ var rep *storage.Replica
+ var leaderIdx int
+ for leaderIdx = range mtc.stores {
+ var err error
+ if rep, err = mtc.stores[leaderIdx].GetReplica(1); err != nil {
+ t.Fatal(err)
+ }
+ if rep.RaftStatus().SoftState.RaftState == raft.StateLeader {
+ break
+ }
+ }
+
+ // Unquiesce a follower range, this should "wake the leader" and not result
+ // in an election.
+ followerIdx := (leaderIdx + 1) % len(mtc.stores)
+ mtc.stores[followerIdx].EnqueueRaftUpdateCheck(1)
+
+ // Wait for a bunch of ticks to occur which will allow the follower time to
+ // campaign.
+ ticks := mtc.stores[followerIdx].Metrics().RaftTicks.Count
+ for targetTicks := ticks() + int64(2*sc.RaftElectionTimeoutTicks); ticks() < targetTicks; {
+ time.Sleep(time.Millisecond)
+ }
+
+ // Wait for the range to quiesce again.
+ waitForQuiescence(1)
+
+ // The leadership should not have changed.
+ if state := rep.RaftStatus().SoftState.RaftState; state != raft.StateLeader {
+ t.Fatalf("%s should be the leader: %s", rep, state)
+ }
+}
diff --git a/storage/helpers_test.go b/storage/helpers_test.go
index 278cc7983220..dae723a65889 100644
--- a/storage/helpers_test.go
+++ b/storage/helpers_test.go
@@ -188,6 +188,13 @@ func (r *Replica) GetTimestampCacheLowWater() hlc.Timestamp {
return r.mu.tsCache.lowWater
}
+// IsQuiescent returns whether the replica is quiescent or not.
+func (r *Replica) IsQuiescent() bool {
+ r.mu.Lock()
+ defer r.mu.Unlock()
+ return r.mu.quiescent
+}
+
func GetGCQueueTxnCleanupThreshold() time.Duration {
return txnCleanupThreshold
}
diff --git a/storage/replica.go b/storage/replica.go
index 7fdbdc04da80..024cfb4c367e 100644
--- a/storage/replica.go
+++ b/storage/replica.go
@@ -376,9 +376,13 @@ var _ KeyRange = &Replica{}
// withRaftGroupLocked calls the supplied function with the (lazily
// initialized) Raft group. It assumes that the Replica lock is held. The
+// supplied function should return true for the unquiesceAndWakeLeader argument
+// if the replica should be unquiesced (and the leader awoken). See
+// handleRaftReady for an instance of where this value varies. The
// shouldCampaign argument indicates whether a new raft group should be
// campaigned upon creation and is used to eagerly campaign idle replicas.
-func (r *Replica) withRaftGroupLocked(shouldCampaign bool, f func(r *raft.RawNode) error) error {
+func (r *Replica) withRaftGroupLocked(
+ shouldCampaign bool, f func(r *raft.RawNode) (unquiesceAndWakeLeader bool, _ error)) error {
if r.mu.destroyed != nil {
// Silently ignore all operations on destroyed replicas. We can't return an
// error here as all errors returned from this method are considered fatal.
@@ -451,16 +455,17 @@ func (r *Replica) withRaftGroupLocked(shouldCampaign bool, f func(r *raft.RawNod
}
}
- // Any Raft operation moves the Replica out of quiescence.
- r.setQuiescentLocked(false)
-
- return f(r.mu.internalRaftGroup)
+ unquiesce, err := f(r.mu.internalRaftGroup)
+ if unquiesce {
+ r.unquiesceAndWakeLeaderLocked()
+ }
+ return err
}
// withRaftGroup calls the supplied function with the (lazily initialized)
// Raft group. It acquires and releases the Replica lock, so r.mu must not be
// held (or acquired by the supplied function).
-func (r *Replica) withRaftGroup(f func(r *raft.RawNode) error) error {
+func (r *Replica) withRaftGroup(f func(r *raft.RawNode) (unquiesceAndWakeLeader bool, _ error)) error {
r.mu.Lock()
defer r.mu.Unlock()
return r.withRaftGroupLocked(false, f)
@@ -1697,42 +1702,68 @@ func defaultProposeRaftCommandLocked(r *Replica, p *pendingCmd) error {
return err
}
- return r.withRaftGroupLocked(true, func(raftGroup *raft.RawNode) error {
- return raftGroup.ProposeConfChange(raftpb.ConfChange{
- Type: changeTypeInternalToRaft[crt.ChangeType],
- NodeID: uint64(crt.Replica.ReplicaID),
- Context: encodedCtx,
- })
+ return r.withRaftGroupLocked(true, func(raftGroup *raft.RawNode) (bool, error) {
+ // We're proposing a command here so there is no need to wake the
+ // leader if we were quiesced.
+ r.unquiesceLocked()
+ return false, /* !unquiesceAndWakeLeader */
+ raftGroup.ProposeConfChange(raftpb.ConfChange{
+ Type: changeTypeInternalToRaft[crt.ChangeType],
+ NodeID: uint64(crt.Replica.ReplicaID),
+ Context: encodedCtx,
+ })
})
}
hasSplit = ict.GetSplitTrigger() != nil
}
- return r.withRaftGroupLocked(true, func(raftGroup *raft.RawNode) error {
+ return r.withRaftGroupLocked(true, func(raftGroup *raft.RawNode) (bool, error) {
if log.V(4) {
log.Infof(r.ctx, "proposing command %x", p.idKey)
}
- return raftGroup.Propose(encodeRaftCommand(string(p.idKey), data, hasSplit))
+ // We're proposing a command so there is no need to wake the leader if we
+ // were quiesced.
+ r.unquiesceLocked()
+ return false, /* !unquiesceAndWakeLeader */
+ raftGroup.Propose(encodeRaftCommand(string(p.idKey), data, hasSplit))
})
}
-func (r *Replica) setQuiescent(v bool) {
+func (r *Replica) quiesce() {
r.mu.Lock()
- r.setQuiescentLocked(v)
+ r.quiesceLocked()
r.mu.Unlock()
}
-func (r *Replica) setQuiescentLocked(v bool) {
- if r.mu.quiescent != v {
- r.mu.quiescent = v
+func (r *Replica) quiesceLocked() {
+ if !r.mu.quiescent {
if log.V(3) {
- if r.mu.quiescent {
- log.Infof(r.ctx, "quiescing")
- } else {
- log.Infof(r.ctx, "unquiescing")
- }
+ log.Infof(r.ctx, "quiescing")
+ }
+ r.mu.quiescent = true
+ }
+}
+
+func (r *Replica) unquiesceLocked() {
+ if r.mu.quiescent {
+ if log.V(3) {
+ log.Infof(r.ctx, "unquiescing")
+ }
+ r.mu.quiescent = false
+ }
+}
+
+func (r *Replica) unquiesceAndWakeLeaderLocked() {
+ if r.mu.quiescent {
+ if log.V(3) {
+ log.Infof(r.ctx, "unquiescing: waking leader")
}
+ r.mu.quiescent = false
+ // Send an empty proposal which will wake the leader. Empty proposals also
+ // trigger reproposal of pending commands, but this is expected to be a
+ // very rare situation.
+ _ = r.mu.internalRaftGroup.Propose(nil)
}
}
@@ -1775,11 +1806,11 @@ func (r *Replica) handleRaftReady() error {
lastIndex := r.mu.lastIndex // used for append below
raftLogSize := r.mu.raftLogSize
leaderID := r.mu.leaderID
- err := r.withRaftGroupLocked(false, func(raftGroup *raft.RawNode) error {
+ err := r.withRaftGroupLocked(false, func(raftGroup *raft.RawNode) (bool, error) {
if hasReady = raftGroup.HasReady(); hasReady {
rd = raftGroup.Ready()
}
- return nil
+ return hasReady /* unquiesceAndWakeLeader */, nil
})
r.mu.Unlock()
if err != nil {
@@ -1958,9 +1989,9 @@ func (r *Replica) handleRaftReady() error {
cc = raftpb.ConfChange{}
}
// TODO(bdarnell): update coalesced heartbeat mapping on success.
- if err := r.withRaftGroup(func(raftGroup *raft.RawNode) error {
+ if err := r.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
raftGroup.ApplyConfChange(cc)
- return nil
+ return true, nil
}); err != nil {
return err
}
@@ -1980,9 +2011,9 @@ func (r *Replica) handleRaftReady() error {
// TODO(bdarnell): need to check replica id and not Advance if it
// has changed. Or do we need more locking to guarantee that replica
// ID cannot change during handleRaftReady?
- return r.withRaftGroup(func(raftGroup *raft.RawNode) error {
+ return r.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
raftGroup.Advance(rd)
- return nil
+ return true, nil
})
}
@@ -2027,7 +2058,7 @@ func (r *Replica) tickRaftMuLocked() (bool, error) {
return true, nil
}
-var enableQuiescence = envutil.EnvOrDefaultBool("COCKROACH_ENABLE_QUIESCENCE", false)
+var enableQuiescence = envutil.EnvOrDefaultBool("COCKROACH_ENABLE_QUIESCENCE", true)
// maybeQuiesceLocked checks to see if the replica is quiescable and initiates
// quiescence if it is. Returns true if the replica has been quiesced and false
@@ -2048,7 +2079,32 @@ var enableQuiescence = envutil.EnvOrDefaultBool("COCKROACH_ENABLE_QUIESCENCE", f
// follower which will send a MsgProp to the leader that will unquiesce the
// leader. If the leader of a quiesced range dies, followers will not notice,
// though any request directed to the range will eventually end up on a
-// follower which will unquiesce the follower and lead to an election.
+// follower which will unquiesce the follower and lead to an election. When a
+// follower unquiesces for a reason other than receiving a raft message or
+// proposing a raft command (for example the concurrent enqueuing of a tick),
+// it wakes the leader by sending an empty message proposal. This avoids
+// unnecessary elections due to bugs in which a follower is left unquiesced
+// while the leader is quiesced.
+//
+// Note that both the quiesce and wake-the-leader messages can be dropped or
+// reordered by the transport. The wake-the-leader message is termless so it
+// won't affect elections and, while it triggers reproprosals that won't cause
+// problems on reorderin. If the wake-the-leader message is dropped the leader
+// won't be woken and the follower will eventually call an election.
+//
+// If the quiesce message is dropped the follower which missed it will not
+// quiesce and will eventually cause an election. The quiesce message is tagged
+// with the current term and commit index. If the quiesce message is reordered
+// it will either still apply to the recipient or the recipient will have moved
+// forward and the quiesce message will fall back to being a heartbeat.
+//
+// TODO(peter): There remains a scenario in which a follower is left unquiesced
+// while the leader is quiesced: the follower's receive queue is full and the
+// "quiesce" message is dropped. This seems very very unlikely because if the
+// follower isn't keeping up with raft messages it is unlikely that the leader
+// would quiesce. The fallout from this situation are undesirable raft
+// elections which will cause throughput hiccups to the range, but not
+// correctness issues.
//
// TODO(peter): When a node goes down, any range which has a replica on the
// down node will not quiesce. This could be a significant performance
@@ -2123,7 +2179,7 @@ func (r *Replica) maybeQuiesceLocked() bool {
}
return false
}
- r.setQuiescentLocked(true)
+ r.quiesceLocked()
for id := range status.Progress {
if roachpb.ReplicaID(id) == r.mu.replicaID {
continue
@@ -2134,7 +2190,7 @@ func (r *Replica) maybeQuiesceLocked() bool {
if log.V(4) {
log.Infof(r.ctx, "failed to quiesce: cannot find to replica (%d)", id)
}
- r.setQuiescentLocked(false)
+ r.unquiesceLocked()
return false
}
if !r.sendRaftMessageRequest(&RaftMessageRequest{
@@ -2150,7 +2206,7 @@ func (r *Replica) maybeQuiesceLocked() bool {
},
Quiesce: true,
}) {
- r.setQuiescentLocked(false)
+ r.unquiesceLocked()
r.mu.droppedMessages++
r.mu.internalRaftGroup.ReportUnreachable(id)
return false
@@ -2269,10 +2325,10 @@ func (r *Replica) sendRaftMessage(msg raftpb.Message) {
FromReplica: fromReplica,
Message: msg,
}) {
- if err := r.withRaftGroup(func(raftGroup *raft.RawNode) error {
+ if err := r.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
r.mu.droppedMessages++
raftGroup.ReportUnreachable(msg.To)
- return nil
+ return true, nil
}); err != nil {
r.panic(err)
}
@@ -2304,9 +2360,9 @@ func (r *Replica) reportSnapshotStatus(to uint64, snapErr error) {
snapStatus = raft.SnapshotFailure
}
- if err := r.withRaftGroup(func(raftGroup *raft.RawNode) error {
+ if err := r.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
raftGroup.ReportSnapshot(to, snapStatus)
- return nil
+ return true, nil
}); err != nil {
r.panic(err)
}
diff --git a/storage/replica_trigger.go b/storage/replica_trigger.go
index c3e87c75c54f..f0a816fa6ff4 100644
--- a/storage/replica_trigger.go
+++ b/storage/replica_trigger.go
@@ -302,14 +302,14 @@ func (r *Replica) maybeTransferRaftLeadership(
replicaID roachpb.ReplicaID,
target roachpb.ReplicaID,
) {
- err := r.withRaftGroup(func(raftGroup *raft.RawNode) error {
+ err := r.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
if raftGroup.Status().RaftState == raft.StateLeader {
// Only the raft leader can attempt a leadership transfer.
log.Infof(ctx, "range %s: transferring raft leadership to replica ID %v",
r, target)
raftGroup.TransferLeader(uint64(target))
}
- return nil
+ return true, nil
})
if err != nil {
// An error here indicates that this Replica has been destroyed
diff --git a/storage/scheduler.go b/storage/scheduler.go
index 365d4e8ffc6e..17cf69ed1ff8 100644
--- a/storage/scheduler.go
+++ b/storage/scheduler.go
@@ -182,20 +182,27 @@ func (s *raftScheduler) worker(stopper *stop.Stopper) {
s.mu.state[id] = stateQueued
s.mu.Unlock()
- // Process the range ID.
if state&stateRaftTick != 0 {
// processRaftTick returns true if the range should perform ready
- // processing. Do not reorder this below the call to processRaftReady.
+ // processing. Do not reorder this below the call to processReady.
if s.processor.processTick(id) {
state |= stateRaftReady
}
}
- if state&stateRaftRequest != 0 {
- s.processor.processRequestQueue(id)
- }
if state&stateRaftReady != 0 {
s.processor.processReady(id)
}
+ // Process requests last. This avoids a scenario where a tick and a
+ // "quiesce" message are processed in the same iteration and intervening
+ // raft ready processing unquiesced the replica. Note that request
+ // processing could also occur first, it just shouldn't occur in between
+ // ticking and ready processing. It is possible for a tick to be enqueued
+ // concurrently with the quiescing in which case the replica will
+ // unquiesce when the tick is processed, but we'll wake the leader in
+ // that case.
+ if state&stateRaftRequest != 0 {
+ s.processor.processRequestQueue(id)
+ }
var queued bool
s.mu.Lock()
diff --git a/storage/store.go b/storage/store.go
index 3b8695e4c93b..648eb902a693 100644
--- a/storage/store.go
+++ b/storage/store.go
@@ -1592,11 +1592,11 @@ func splitTriggerPostCommit(
return
}
- if err := replica.withRaftGroup(func(raftGroup *raft.RawNode) error {
+ if err := replica.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
if err := raftGroup.Campaign(); err != nil {
log.Warningf(ctx, "%s: error %v", r, err)
}
- return nil
+ return true, nil
}); err != nil {
panic(err)
}
@@ -2345,7 +2345,7 @@ func (s *Store) processRaftRequest(
}
status := r.RaftStatus()
if status != nil && status.Term == req.Message.Term && status.Commit == req.Message.Commit {
- r.setQuiescent(true)
+ r.quiesce()
return
}
}
@@ -2548,8 +2548,12 @@ func (s *Store) processRaftRequest(
r.store.StoreID(), req.RangeID)
}
- if err := r.withRaftGroup(func(raftGroup *raft.RawNode) error {
- return raftGroup.Step(req.Message)
+ if err := r.withRaftGroup(func(raftGroup *raft.RawNode) (bool, error) {
+ // We're processing a message from another replica which means that the
+ // other replica is not quiesced, so we don't need to wake the leader.
+ r.unquiesceLocked()
+ return false, /* !unquiesceAndWakeLeader */
+ raftGroup.Step(req.Message)
}); err != nil {
return roachpb.NewError(err)
}
diff --git a/storage/store_test.go b/storage/store_test.go
index a1b6e39879ef..e66fb887dfc1 100644
--- a/storage/store_test.go
+++ b/storage/store_test.go
@@ -462,8 +462,8 @@ func TestStoreRemoveReplicaDestroy(t *testing.T) {
// Verify that removal of a replica marks it as destroyed so that future raft
// commands on the Replica will silently be dropped.
- if err := rng1.withRaftGroup(func(r *raft.RawNode) error {
- return errors.Errorf("unexpectedly created a raft group")
+ if err := rng1.withRaftGroup(func(r *raft.RawNode) (bool, error) {
+ return true, errors.Errorf("unexpectedly created a raft group")
}); err != nil {
t.Fatal(err)
}
|
400c8c2ee555de2ed8fde2ef11a99c4ef2796cc8
|
2024-10-17 03:22:27
|
Drew Kimball
|
plpgsql: allow assigning to an element of a composite-typed variable
| false
|
allow assigning to an element of a composite-typed variable
|
plpgsql
|
diff --git a/pkg/ccl/logictestccl/testdata/logic_test/plpgsql_assign b/pkg/ccl/logictestccl/testdata/logic_test/plpgsql_assign
new file mode 100644
index 000000000000..a6ca7e1542c5
--- /dev/null
+++ b/pkg/ccl/logictestccl/testdata/logic_test/plpgsql_assign
@@ -0,0 +1,124 @@
+statement ok
+CREATE TABLE xy (x INT, y INT);
+INSERT INTO xy VALUES (1, 2), (3, 4);
+
+subtest assign_elem
+
+# It is possible to assign to an element of a composite-typed variable.
+statement ok
+CREATE FUNCTION f(val xy) RETURNS xy AS $$
+ BEGIN
+ val.x := (val).x + 100;
+ RETURN val;
+ END
+$$ LANGUAGE PLpgSQL;
+
+query TTT
+SELECT f(ROW(1, 2)), f(ROW(NULL, -1)), f(NULL::xy);
+----
+(101,2) (,-1) (,)
+
+query T rowsort
+SELECT f(ROW(x, y)) FROM xy;
+----
+(101,2)
+(103,4)
+
+statement ok
+DROP FUNCTION f;
+
+statement ok
+CREATE PROCEDURE p() LANGUAGE PLpgSQL AS $$
+ DECLARE
+ foo xy; -- Starts off as NULL.
+ BEGIN
+ foo.x := 1;
+ RAISE NOTICE '%', foo;
+ foo.y := 2;
+ RAISE NOTICE '%', foo;
+ foo.x := (foo).x + (foo).y;
+ RAISE NOTICE '%', foo;
+ foo.x = NULL;
+ RAISE NOTICE '%', foo;
+ END
+$$;
+
+query T noticetrace
+CALL p();
+----
+NOTICE: (1,)
+NOTICE: (1,2)
+NOTICE: (3,2)
+NOTICE: (,2)
+
+statement ok
+DROP PROCEDURE p;
+
+# The assigned value will be coerced to the type of the tuple element.
+# The coercion may fail at execution time if the type is wrong.
+statement ok
+CREATE FUNCTION f(val xy) RETURNS xy AS $$
+ BEGIN
+ val.x := ROW(100, 200);
+ RETURN val;
+ END
+$$ LANGUAGE PLpgSQL;
+
+statement error pgcode 22P02 pq: could not parse "\(100,200\)" as type int: strconv.ParseInt: parsing "\(100,200\)": invalid syntax
+SELECT f(ROW(1, 2));
+
+statement ok
+DROP FUNCTION f;
+
+# Qualifying variable names with a block label is still not supported (#122322).
+statement error pgcode 42601 pq: "b" is not a known variable
+CREATE PROCEDURE p() LANGUAGE PLpgSQL AS $$
+ <<b>>
+ DECLARE
+ x INT;
+ BEGIN
+ b.x := 5;
+ END
+$$;
+
+# Prefer to resolve as a variable with an indirection over a block-qualified
+# variable reference.
+statement ok
+CREATE PROCEDURE p() LANGUAGE PLpgSQL AS $$
+ <<b>>
+ DECLARE
+ b xy;
+ BEGIN
+ b.x := 5;
+ RAISE NOTICE '%', b;
+ END
+$$;
+
+query T noticetrace
+CALL p();
+----
+NOTICE: (5,)
+
+statement ok
+DROP PROCEDURE p;
+
+# The type of the variable must be a tuple. NOTE: this is the same error as the
+# one Postgres gives.
+statement error pgcode 42601 pq: "val.x" is not a known variable
+CREATE FUNCTION f(val INT) RETURNS INT AS $$
+ BEGIN
+ val.x := 5;
+ RETURN val;
+ END
+$$ LANGUAGE PLpgSQL;
+
+# The referenced element must be a field of the tuple.
+statement error pgcode 42703 pq: record "val" has no field "z"
+CREATE FUNCTION f(val xy) RETURNS xy AS $$
+ BEGIN
+ val.z := 5;
+ RETURN val;
+ END
+$$ LANGUAGE PLpgSQL;
+
+subtest end
diff --git a/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go b/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go
index 1101d360e1b1..9e22f7c4c8e6 100644
--- a/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go
@@ -2689,6 +2689,13 @@ func TestTenantLogicCCL_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestTenantLogicCCL_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestTenantLogicCCL_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/fakedist-disk/BUILD.bazel b/pkg/ccl/logictestccl/tests/fakedist-disk/BUILD.bazel
index e8bbc3647c4d..6242b95536a3 100644
--- a/pkg/ccl/logictestccl/tests/fakedist-disk/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/fakedist-disk/BUILD.bazel
@@ -12,7 +12,7 @@ go_test(
"//build/toolchains:is_heavy": {"test.Pool": "heavy"},
"//conditions:default": {"test.Pool": "large"},
}),
- shard_count = 30,
+ shard_count = 31,
tags = ["cpu:2"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/fakedist-disk/generated_test.go b/pkg/ccl/logictestccl/tests/fakedist-disk/generated_test.go
index 745d2140119d..b88317af99d3 100644
--- a/pkg/ccl/logictestccl/tests/fakedist-disk/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/fakedist-disk/generated_test.go
@@ -124,6 +124,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/fakedist-vec-off/BUILD.bazel b/pkg/ccl/logictestccl/tests/fakedist-vec-off/BUILD.bazel
index ed20d166d24a..9c7fc4f3c431 100644
--- a/pkg/ccl/logictestccl/tests/fakedist-vec-off/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/fakedist-vec-off/BUILD.bazel
@@ -12,7 +12,7 @@ go_test(
"//build/toolchains:is_heavy": {"test.Pool": "heavy"},
"//conditions:default": {"test.Pool": "large"},
}),
- shard_count = 30,
+ shard_count = 31,
tags = ["cpu:2"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/fakedist-vec-off/generated_test.go b/pkg/ccl/logictestccl/tests/fakedist-vec-off/generated_test.go
index 6eea1f75f5f4..c0b9b2d2f37e 100644
--- a/pkg/ccl/logictestccl/tests/fakedist-vec-off/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/fakedist-vec-off/generated_test.go
@@ -124,6 +124,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/fakedist/BUILD.bazel b/pkg/ccl/logictestccl/tests/fakedist/BUILD.bazel
index 2887729097b5..5bc078f12fcf 100644
--- a/pkg/ccl/logictestccl/tests/fakedist/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/fakedist/BUILD.bazel
@@ -12,7 +12,7 @@ go_test(
"//build/toolchains:is_heavy": {"test.Pool": "heavy"},
"//conditions:default": {"test.Pool": "large"},
}),
- shard_count = 31,
+ shard_count = 32,
tags = ["cpu:2"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/fakedist/generated_test.go b/pkg/ccl/logictestccl/tests/fakedist/generated_test.go
index 28a26e47aa91..c6aa5bb0b5ae 100644
--- a/pkg/ccl/logictestccl/tests/fakedist/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/fakedist/generated_test.go
@@ -131,6 +131,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/BUILD.bazel b/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/BUILD.bazel
index 2d52175c8146..229112f58c04 100644
--- a/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/BUILD.bazel
@@ -9,7 +9,7 @@ go_test(
"//pkg/ccl/logictestccl:testdata", # keep
],
exec_properties = {"test.Pool": "large"},
- shard_count = 29,
+ shard_count = 30,
tags = ["cpu:1"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/generated_test.go b/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/generated_test.go
index 800b90104d43..aef55c8e91c3 100644
--- a/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-legacy-schema-changer/generated_test.go
@@ -124,6 +124,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-mixed-24.1/BUILD.bazel b/pkg/ccl/logictestccl/tests/local-mixed-24.1/BUILD.bazel
index 3ea21bf8c1eb..dcf119ffe577 100644
--- a/pkg/ccl/logictestccl/tests/local-mixed-24.1/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/local-mixed-24.1/BUILD.bazel
@@ -9,7 +9,7 @@ go_test(
"//pkg/ccl/logictestccl:testdata", # keep
],
exec_properties = {"test.Pool": "large"},
- shard_count = 28,
+ shard_count = 29,
tags = ["cpu:1"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/local-mixed-24.1/generated_test.go b/pkg/ccl/logictestccl/tests/local-mixed-24.1/generated_test.go
index 6790e3150e89..476cb7bfdef4 100644
--- a/pkg/ccl/logictestccl/tests/local-mixed-24.1/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-mixed-24.1/generated_test.go
@@ -124,6 +124,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-mixed-24.2/BUILD.bazel b/pkg/ccl/logictestccl/tests/local-mixed-24.2/BUILD.bazel
index 11838adc6da6..c856d3edbf03 100644
--- a/pkg/ccl/logictestccl/tests/local-mixed-24.2/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/local-mixed-24.2/BUILD.bazel
@@ -9,7 +9,7 @@ go_test(
"//pkg/ccl/logictestccl:testdata", # keep
],
exec_properties = {"test.Pool": "large"},
- shard_count = 29,
+ shard_count = 30,
tags = ["cpu:1"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/local-mixed-24.2/generated_test.go b/pkg/ccl/logictestccl/tests/local-mixed-24.2/generated_test.go
index 0903f53762a8..468e1d35cb04 100644
--- a/pkg/ccl/logictestccl/tests/local-mixed-24.2/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-mixed-24.2/generated_test.go
@@ -124,6 +124,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go b/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go
index 8df5ba792593..2c641d6bd116 100644
--- a/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go
@@ -2638,6 +2638,13 @@ func TestReadCommittedLogicCCL_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestReadCommittedLogicCCL_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestReadCommittedLogicCCL_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go b/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go
index bcc0595696d8..2765e2fd472e 100644
--- a/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go
@@ -2631,6 +2631,13 @@ func TestRepeatableReadLogicCCL_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestRepeatableReadLogicCCL_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestRepeatableReadLogicCCL_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-vec-off/BUILD.bazel b/pkg/ccl/logictestccl/tests/local-vec-off/BUILD.bazel
index 2593a77e3775..622cf8474ec3 100644
--- a/pkg/ccl/logictestccl/tests/local-vec-off/BUILD.bazel
+++ b/pkg/ccl/logictestccl/tests/local-vec-off/BUILD.bazel
@@ -9,7 +9,7 @@ go_test(
"//pkg/ccl/logictestccl:testdata", # keep
],
exec_properties = {"test.Pool": "large"},
- shard_count = 30,
+ shard_count = 31,
tags = ["cpu:1"],
deps = [
"//pkg/base",
diff --git a/pkg/ccl/logictestccl/tests/local-vec-off/generated_test.go b/pkg/ccl/logictestccl/tests/local-vec-off/generated_test.go
index 3df3e028acb6..71f7df678856 100644
--- a/pkg/ccl/logictestccl/tests/local-vec-off/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-vec-off/generated_test.go
@@ -124,6 +124,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local/generated_test.go b/pkg/ccl/logictestccl/tests/local/generated_test.go
index da317842ba43..ba83639ae5a5 100644
--- a/pkg/ccl/logictestccl/tests/local/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local/generated_test.go
@@ -229,6 +229,13 @@ func TestCCLLogic_pgcrypto_builtins(
runCCLLogicTest(t, "pgcrypto_builtins")
}
+func TestCCLLogic_plpgsql_assign(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runCCLLogicTest(t, "plpgsql_assign")
+}
+
func TestCCLLogic_plpgsql_block(
t *testing.T,
) {
diff --git a/pkg/sql/opt/optbuilder/plpgsql.go b/pkg/sql/opt/optbuilder/plpgsql.go
index cb0be98846bf..2b13853442bb 100644
--- a/pkg/sql/opt/optbuilder/plpgsql.go
+++ b/pkg/sql/opt/optbuilder/plpgsql.go
@@ -294,7 +294,9 @@ func (b *plpgsqlBuilder) buildRootBlock(
if param.class != tree.RoutineParamOut || param.name == "" {
continue
}
- s = b.addPLpgSQLAssign(s, param.name, &tree.CastExpr{Expr: tree.DNull, Type: param.typ})
+ s = b.addPLpgSQLAssign(
+ s, param.name, &tree.CastExpr{Expr: tree.DNull, Type: param.typ}, noIndirection,
+ )
}
if b.isProcedure {
var tc transactionControlVisitor
@@ -372,10 +374,12 @@ func (b *plpgsqlBuilder) buildBlock(astBlock *ast.Block, s *scope) *scope {
b.addVariable(dec.Var, typ)
if dec.Expr != nil {
// Some variable declarations initialize the variable.
- s = b.addPLpgSQLAssign(s, dec.Var, dec.Expr)
+ s = b.addPLpgSQLAssign(s, dec.Var, dec.Expr, noIndirection)
} else {
// Uninitialized variables are null.
- s = b.addPLpgSQLAssign(s, dec.Var, &tree.CastExpr{Expr: tree.DNull, Type: typ})
+ s = b.addPLpgSQLAssign(
+ s, dec.Var, &tree.CastExpr{Expr: tree.DNull, Type: typ}, noIndirection,
+ )
}
if dec.Constant {
// Add to the constants map after initializing the variable, since
@@ -385,7 +389,9 @@ func (b *plpgsqlBuilder) buildBlock(astBlock *ast.Block, s *scope) *scope {
case *ast.CursorDeclaration:
// Declaration of a bound cursor declares a variable of type refcursor.
b.addVariable(dec.Name, types.RefCursor)
- s = b.addPLpgSQLAssign(s, dec.Name, &tree.CastExpr{Expr: tree.DNull, Type: types.RefCursor})
+ s = b.addPLpgSQLAssign(
+ s, dec.Name, &tree.CastExpr{Expr: tree.DNull, Type: types.RefCursor}, noIndirection,
+ )
block.cursors[dec.Name] = *dec
}
}
@@ -495,7 +501,7 @@ func (b *plpgsqlBuilder) buildPLpgSQLStatements(stmts []ast.Statement, s *scope)
case *ast.Assignment:
// Assignment (:=) is handled by projecting a new column with the same
// name as the variable being assigned.
- s = b.addPLpgSQLAssign(s, t.Var, t.Value)
+ s = b.addPLpgSQLAssign(s, t.Var, t.Value, t.Indirection)
if b.hasExceptionHandler() {
// If exception handling is required, we have to start a new
// continuation after each variable assignment. This ensures that in the
@@ -1118,7 +1124,13 @@ func (b *plpgsqlBuilder) buildCursorNameGen(nameCon *continuation, nameVar ast.V
// new column with the variable name that projects the assigned expression.
// If there is a column with the same name in the previous scope, it will be
// replaced. This allows the plpgsqlBuilder to model variable mutations.
-func (b *plpgsqlBuilder) addPLpgSQLAssign(inScope *scope, ident ast.Variable, val ast.Expr) *scope {
+//
+// indirection is the optional name of a field from the (composite-typed)
+// variable. If it is set, then it is the field that is being assigned to, not
+// the variable itself.
+func (b *plpgsqlBuilder) addPLpgSQLAssign(
+ inScope *scope, ident ast.Variable, val ast.Expr, indirection tree.Name,
+) *scope {
typ := b.resolveVariableForAssign(ident)
assignScope := inScope.push()
for i := range inScope.cols {
@@ -1135,7 +1147,12 @@ func (b *plpgsqlBuilder) addPLpgSQLAssign(inScope *scope, ident ast.Variable, va
// volatile, add barriers before and after the projection to prevent optimizer
// rules from reordering or removing its side effects.
colName := scopeColName(ident)
- scalar := b.buildSQLExpr(val, typ, inScope)
+ var scalar opt.ScalarExpr
+ if indirection != noIndirection {
+ scalar = b.handleIndirectionForAssign(inScope, typ, ident, indirection, val)
+ } else {
+ scalar = b.buildSQLExpr(val, typ, inScope)
+ }
b.addBarrierIfVolatile(inScope, scalar)
b.ob.synthesizeColumn(assignScope, colName, typ, nil, scalar)
b.ob.constructProjectForScope(inScope, assignScope)
@@ -1143,6 +1160,62 @@ func (b *plpgsqlBuilder) addPLpgSQLAssign(inScope *scope, ident ast.Variable, va
return assignScope
}
+const noIndirection = ""
+
+// handleIndirectionForAssign is used to handle an assignment like "a.b := 2",
+// where "a" is a record variable and "b" is a field of that record. The
+// function constructs a new tuple with the field "b" replaced by the new value,
+// and all other fields copied from the original tuple.
+func (b *plpgsqlBuilder) handleIndirectionForAssign(
+ inScope *scope, typ *types.T, ident ast.Variable, indirection tree.Name, val tree.Expr,
+) opt.ScalarExpr {
+ elemName := indirection.Normalize()
+
+ // We do not yet support qualifying a variable with a block label.
+ b.checkBlockLabelReference(elemName)
+ if !b.buildSQL {
+ // For lazy SQL evaluation, replace all expressions with NULL.
+ return memo.NullSingleton
+ }
+ if typ.Family() != types.TupleFamily {
+ // Like Postgres, treat this as a failure to find a matching
+ // block.variable pair.
+ panic(pgerror.Newf(pgcode.Syntax, "\"%s.%s\" is not a known variable", ident, indirection))
+ }
+ var found bool
+ var elemIdx int
+ for i := range typ.TupleLabels() {
+ if typ.TupleLabels()[i] == elemName {
+ found = true
+ elemIdx = i
+ break
+ }
+ }
+ if !found {
+ panic(pgerror.Newf(pgcode.UndefinedColumn,
+ "record \"%s\" has no field \"%s\"", ident, elemName,
+ ))
+ }
+ _, source, _, err := inScope.FindSourceProvidingColumn(b.ob.ctx, ident)
+ if err != nil {
+ panic(errors.NewAssertionErrorWithWrappedErrf(err, "failed to find variable %s", ident))
+ }
+ if !source.(*scopeColumn).typ.Identical(typ) {
+ panic(errors.AssertionFailedf("unexpected type for variable %s", ident))
+ }
+ varCol := b.ob.factory.ConstructVariable(source.(*scopeColumn).id)
+ scalar := b.buildSQLExpr(val, typ.TupleContents()[elemIdx], inScope)
+ newElems := make([]opt.ScalarExpr, len(typ.TupleContents()))
+ for i := range typ.TupleContents() {
+ if i == elemIdx {
+ newElems[i] = scalar
+ } else {
+ newElems[i] = b.ob.factory.ConstructColumnAccess(varCol, memo.TupleOrdinal(i))
+ }
+ }
+ return b.ob.factory.ConstructTuple(newElems, typ)
+}
+
// buildInto handles the mapping from the columns of a SQL statement to the
// variables in an INTO target.
func (b *plpgsqlBuilder) buildInto(stmtScope *scope, target []ast.Variable) *scope {
@@ -2003,6 +2076,27 @@ func (b *plpgsqlBuilder) checkDuplicateTargets(target []ast.Variable, stmtName s
}
}
+// checkBlockLabelReference checks that the given name does not reference a
+// block label, since doing so is not yet supported. This is only necessary for
+// assignment statements, since all other cases currently do not allow the
+// "a.b" syntax.
+func (b *plpgsqlBuilder) checkBlockLabelReference(name string) {
+ for i := len(b.blocks) - 1; i >= 0; i-- {
+ for _, blockVarName := range b.blocks[i].vars {
+ if name == string(blockVarName) {
+ // We found the variable. Even if there is a block with the same name,
+ // it is shadowed by the variable.
+ return
+ }
+ }
+ if b.blocks[i].label == name {
+ panic(unimplemented.NewWithIssuef(122322,
+ "qualifying a variable with a block label is not yet supported: %s", name,
+ ))
+ }
+ }
+}
+
func (b *plpgsqlBuilder) prependStmt(stmt ast.Statement, stmts []ast.Statement) []ast.Statement {
newStmts := make([]ast.Statement, 0, len(stmts)+1)
newStmts = append(newStmts, stmt)
|
a7a1411ce32abba0757d1a5b6d4fb7c003967242
|
2020-01-30 23:28:08
|
Andrew Werner
|
server: construct the protectedts subsystem and plumb into storage
| false
|
construct the protectedts subsystem and plumb into storage
|
server
|
diff --git a/pkg/server/server.go b/pkg/server/server.go
index a651df723c0f..ab125db20cc1 100644
--- a/pkg/server/server.go
+++ b/pkg/server/server.go
@@ -65,6 +65,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/storage/cloud"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/storage/engine/enginepb"
+ "github.com/cockroachdb/cockroach/pkg/storage/protectedts"
+ "github.com/cockroachdb/cockroach/pkg/storage/protectedts/ptprovider"
"github.com/cockroachdb/cockroach/pkg/storage/reports"
"github.com/cockroachdb/cockroach/pkg/storage/storagebase"
"github.com/cockroachdb/cockroach/pkg/ts"
@@ -201,7 +203,8 @@ type Server struct {
internalMemMetrics sql.MemoryMetrics
adminMemMetrics sql.MemoryMetrics
// sqlMemMetrics are used to track memory usage of sql sessions.
- sqlMemMetrics sql.MemoryMetrics
+ sqlMemMetrics sql.MemoryMetrics
+ protectedtsProvider protectedts.Provider
}
// NewServer creates a Server from a server.Config.
@@ -475,6 +478,12 @@ func NewServer(cfg Config, stopper *stop.Stopper) (*Server, error) {
)
}
+ s.protectedtsProvider = ptprovider.New(ptprovider.Config{
+ DB: s.db,
+ InternalExecutor: internalExecutor,
+ Settings: st,
+ })
+
// Similarly for execCfg.
var execCfg sql.ExecutorConfig
@@ -523,9 +532,10 @@ func NewServer(cfg Config, stopper *stop.Stopper) (*Server, error) {
Dialer: s.nodeDialer.CTDialer(),
}),
- EnableEpochRangeLeases: true,
- ExternalStorage: externalStorage,
- ExternalStorageFromURI: externalStorageFromURI,
+ EnableEpochRangeLeases: true,
+ ExternalStorage: externalStorage,
+ ExternalStorageFromURI: externalStorageFromURI,
+ ProtectedTimestampCache: s.protectedtsProvider,
}
if storeTestingKnobs := s.cfg.TestingKnobs.Store; storeTestingKnobs != nil {
storeCfg.TestingKnobs = *storeTestingKnobs.(*storage.StoreTestingKnobs)
@@ -738,7 +748,8 @@ func NewServer(cfg Config, stopper *stop.Stopper) (*Server, error) {
true /*enableGc*/, true /*forceSyncWrites*/, true, /* enableMsgCount */
),
- QueryCache: querycache.New(s.cfg.SQLQueryCacheSize),
+ QueryCache: querycache.New(s.cfg.SQLQueryCacheSize),
+ ProtectedTimestampProvider: s.protectedtsProvider,
}
if sqlSchemaChangerTestingKnobs := s.cfg.TestingKnobs.SQLSchemaChanger; sqlSchemaChangerTestingKnobs != nil {
@@ -1591,6 +1602,10 @@ func (s *Server) Start(ctx context.Context) error {
return err
}
+ if err := s.protectedtsProvider.Start(ctx, s.stopper); err != nil {
+ return err
+ }
+
// Before serving SQL requests, we have to make sure the database is
// in an acceptable form for this version of the software.
// We have to do this after actually starting up the server to be able to
diff --git a/pkg/sql/exec_util.go b/pkg/sql/exec_util.go
index e95111b9ee32..a4c77ecf7e15 100644
--- a/pkg/sql/exec_util.go
+++ b/pkg/sql/exec_util.go
@@ -52,6 +52,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
"github.com/cockroachdb/cockroach/pkg/sql/types"
+ "github.com/cockroachdb/cockroach/pkg/storage/protectedts"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/errorutil/unimplemented"
@@ -552,6 +553,9 @@ type ExecutorConfig struct {
// Role membership cache.
RoleMemberCache *MembershipCache
+
+ // ProtectedTimestampProvider encapsulates the protected timestamp subsystem.
+ ProtectedTimestampProvider protectedts.Provider
}
// Organization returns the value of cluster.organization.
diff --git a/pkg/storage/protectedts/ptprovider/provider.go b/pkg/storage/protectedts/ptprovider/provider.go
index 23062b815d70..8297075ff7a1 100644
--- a/pkg/storage/protectedts/ptprovider/provider.go
+++ b/pkg/storage/protectedts/ptprovider/provider.go
@@ -29,7 +29,7 @@ import (
type Config struct {
Settings *cluster.Settings
DB *client.DB
- InternalExecutor sqlutil.InternalExecutorWithUser
+ InternalExecutor sqlutil.InternalExecutor
}
type provider struct {
diff --git a/pkg/storage/store.go b/pkg/storage/store.go
index d1c43c7eebbd..121754d97d55 100644
--- a/pkg/storage/store.go
+++ b/pkg/storage/store.go
@@ -163,6 +163,7 @@ func TestStoreConfig(clock *hlc.Clock) StoreConfig {
HistogramWindowInterval: metric.TestSampleInterval,
EnableEpochRangeLeases: true,
ClosedTimestamp: container.NoopContainer(),
+ ProtectedTimestampCache: protectedts.EmptyCache(clock),
}
// Use shorter Raft tick settings in order to minimize start up and failover
@@ -748,10 +749,6 @@ func (sc *StoreConfig) SetDefaults() {
if sc.GossipWhenCapacityDeltaExceedsFraction == 0 {
sc.GossipWhenCapacityDeltaExceedsFraction = defaultGossipWhenCapacityDeltaExceedsFraction
}
-
- if sc.ProtectedTimestampCache == nil {
- sc.ProtectedTimestampCache = protectedts.EmptyCache(sc.Clock)
- }
}
// LeaseExpiration returns an int64 to increment a manual clock with to
|
c58279d4ce53c26987ef238e2ef268d6f6125f04
|
2022-08-12 21:22:25
|
Sean Barag
|
ui: reintroduce end-to-end UI tests with cypress
| false
|
reintroduce end-to-end UI tests with cypress
|
ui
|
diff --git a/WORKSPACE b/WORKSPACE
index f79d2f2c5a39..87c4528b0af7 100644
--- a/WORKSPACE
+++ b/WORKSPACE
@@ -8,6 +8,7 @@ workspace(
"@npm_protos": ["pkg/ui/workspaces/db-console/src/js/node_modules"],
"@npm_cluster_ui": ["pkg/ui/workspaces/cluster_ui/node_modules"],
"@npm_db_console": ["pkg/ui/workspaces/db-console/node_modules"],
+ "@npm_e2e_tests": ["pkg/ui/workspaces/e2e-tests/node_modules"],
},
)
@@ -263,6 +264,21 @@ yarn_install(
symlink_node_modules = True,
)
+yarn_install(
+ name = "npm_e2e_tests",
+ args = [
+ "--offline",
+ ],
+ data = [
+ "//pkg/ui:.yarnrc",
+ "@yarn_cache//:.seed",
+ ],
+ package_json = "//pkg/ui/workspaces/e2e-tests:package.json",
+ strict_visibility = False,
+ yarn_lock = "//pkg/ui/workspaces/e2e-tests:yarn.lock",
+ symlink_node_modules = True,
+)
+
yarn_install(
name = "npm_protos",
args = [
diff --git a/build/deploy/cockroach.sh b/build/deploy/cockroach.sh
index 939e1f31a79f..46433b2a239d 100755
--- a/build/deploy/cockroach.sh
+++ b/build/deploy/cockroach.sh
@@ -15,7 +15,7 @@
# set -m: enable job control.
set -eum
-cockroach_entrypoint="/cockroach/cockroach"
+cockroach_entrypoint=${COCKROACH:-"/cockroach/cockroach"}
certs_dir="certs"
url=
diff --git a/build/teamcity/cockroach/ci/tests/ui_e2e_test_all.sh b/build/teamcity/cockroach/ci/tests/ui_e2e_test_all.sh
new file mode 100755
index 000000000000..ff240e9cc2cd
--- /dev/null
+++ b/build/teamcity/cockroach/ci/tests/ui_e2e_test_all.sh
@@ -0,0 +1,19 @@
+#!/usr/bin/env bash
+set -euo pipefail
+
+build="$(dirname $(dirname $(dirname $(dirname $(dirname "${0}")))))"
+# for tc_prepare, tc_start_block, and friends
+source "$build/teamcity-support.sh"
+# for build_docker_image and run_tests
+source "$build/teamcity/cockroach/ci/tests/ui_e2e_test_impl.sh"
+
+tc_prepare
+
+tc_start_block "Load cockroachdb/cockroach-ci image"
+load_cockroach_docker_image
+tc_end_block "Load cockroachdb/cockroach-ci image"
+
+tc_start_block "Run Cypress health checks"
+cd $root/pkg/ui/workspaces/e2e-tests
+run_tests health
+tc_end_block "Run Cypress health checks"
diff --git a/build/teamcity/cockroach/ci/tests/ui_e2e_test_health.sh b/build/teamcity/cockroach/ci/tests/ui_e2e_test_health.sh
new file mode 100755
index 000000000000..ff240e9cc2cd
--- /dev/null
+++ b/build/teamcity/cockroach/ci/tests/ui_e2e_test_health.sh
@@ -0,0 +1,19 @@
+#!/usr/bin/env bash
+set -euo pipefail
+
+build="$(dirname $(dirname $(dirname $(dirname $(dirname "${0}")))))"
+# for tc_prepare, tc_start_block, and friends
+source "$build/teamcity-support.sh"
+# for build_docker_image and run_tests
+source "$build/teamcity/cockroach/ci/tests/ui_e2e_test_impl.sh"
+
+tc_prepare
+
+tc_start_block "Load cockroachdb/cockroach-ci image"
+load_cockroach_docker_image
+tc_end_block "Load cockroachdb/cockroach-ci image"
+
+tc_start_block "Run Cypress health checks"
+cd $root/pkg/ui/workspaces/e2e-tests
+run_tests health
+tc_end_block "Run Cypress health checks"
diff --git a/build/teamcity/cockroach/ci/tests/ui_e2e_test_impl.sh b/build/teamcity/cockroach/ci/tests/ui_e2e_test_impl.sh
new file mode 100644
index 000000000000..2f2ea09f5bf4
--- /dev/null
+++ b/build/teamcity/cockroach/ci/tests/ui_e2e_test_impl.sh
@@ -0,0 +1,14 @@
+#!/usr/bin/env bash
+function load_cockroach_docker_image() {
+ docker load --input upstream_artifacts/cockroach-docker-image.tar.gz &> artifacts/docker-load.log || (cat artifacts/docker-load.log && false)
+ rm artifacts/docker-load.log
+}
+
+function run_tests() {
+ SPEC_ARG=""
+ if [ "health" = "${1:-'EMPTY'}" ]; then
+ SPEC_ARG="--spec 'cypress/e2e/health-check/**'"
+ fi
+
+ run docker compose run cypress -- $SPEC_ARG
+}
diff --git a/dev b/dev
index c6c1755a5a03..0ecc418e1c40 100755
--- a/dev
+++ b/dev
@@ -8,7 +8,7 @@ fi
set -euo pipefail
# Bump this counter to force rebuilding `dev` on all machines.
-DEV_VERSION=52
+DEV_VERSION=53
THIS_DIR=$(cd "$(dirname "$0")" && pwd)
BINARY_DIR=$THIS_DIR/bin/dev-versions
diff --git a/pkg/cmd/dev/testdata/datadriven/ui b/pkg/cmd/dev/testdata/datadriven/ui
index 32753b14d029..5656f786071b 100644
--- a/pkg/cmd/dev/testdata/datadriven/ui
+++ b/pkg/cmd/dev/testdata/datadriven/ui
@@ -145,3 +145,30 @@ rm -rf crdb-checkout/pkg/ui/node_modules
rm -rf crdb-checkout/pkg/ui/workspaces/db-console/node_modules
rm -rf crdb-checkout/pkg/ui/workspaces/db-console/src/js/node_modules
rm -rf crdb-checkout/pkg/ui/workspaces/cluster-ui/node_modules
+
+exec
+dev ui e2e
+----
+bazel info workspace --color=no
+bazel info workspace --color=no
+bazel run @yarn//:yarn -- --silent --cwd crdb-checkout/pkg/ui/workspaces/e2e-tests install
+bazel build //pkg/cmd/cockroach:cockroach --config=with_ui
+crdb-checkout/pkg/ui/workspaces/e2e-tests/build/start-crdb-then.sh bazel run @yarn//:yarn -- --silent --cwd crdb-checkout/pkg/ui/workspaces/e2e-tests cy:run
+
+exec
+dev ui e2e ./foo/bar
+----
+bazel info workspace --color=no
+bazel info workspace --color=no
+bazel run @yarn//:yarn -- --silent --cwd crdb-checkout/pkg/ui/workspaces/e2e-tests install
+bazel build //pkg/cmd/cockroach:cockroach --config=with_ui
+crdb-checkout/pkg/ui/workspaces/e2e-tests/build/start-crdb-then.sh bazel run @yarn//:yarn -- --silent --cwd crdb-checkout/pkg/ui/workspaces/e2e-tests cy:run ./foo/bar
+
+exec
+dev ui e2e --headed
+----
+bazel info workspace --color=no
+bazel info workspace --color=no
+bazel run @yarn//:yarn -- --silent --cwd crdb-checkout/pkg/ui/workspaces/e2e-tests install
+bazel build //pkg/cmd/cockroach:cockroach --config=with_ui
+crdb-checkout/pkg/ui/workspaces/e2e-tests/build/start-crdb-then.sh bazel run @yarn//:yarn -- --silent --cwd crdb-checkout/pkg/ui/workspaces/e2e-tests cy:debug
diff --git a/pkg/cmd/dev/ui.go b/pkg/cmd/dev/ui.go
index cfdb94316087..4d476011121f 100644
--- a/pkg/cmd/dev/ui.go
+++ b/pkg/cmd/dev/ui.go
@@ -17,6 +17,7 @@ import (
"os/signal"
"path"
"path/filepath"
+ "strings"
"github.com/spf13/cobra"
)
@@ -39,6 +40,7 @@ func makeUICmd(d *dev) *cobra.Command {
uiCmd.AddCommand(makeUILintCmd(d))
uiCmd.AddCommand(makeUITestCmd(d))
uiCmd.AddCommand(makeUIWatchCmd(d))
+ uiCmd.AddCommand(makeUIE2eCmd(d))
return uiCmd
}
@@ -49,6 +51,8 @@ type UIDirectories struct {
clusterUI string
// dbConsole is the absolute path to ./pkg/ui/workspaces/db-console.
dbConsole string
+ // e2eTests is the absolute path to ./pkg/ui/workspaces/e2e-tests.
+ e2eTests string
// eslintPlugin is the absolute path to ./pkg/ui/workspaces/eslint-plugin-crdb.
eslintPlugin string
}
@@ -63,6 +67,7 @@ func getUIDirs(d *dev) (*UIDirectories, error) {
return &UIDirectories{
clusterUI: path.Join(workspace, "./pkg/ui/workspaces/cluster-ui"),
dbConsole: path.Join(workspace, "./pkg/ui/workspaces/db-console"),
+ e2eTests: path.Join(workspace, "./pkg/ui/workspaces/e2e-tests"),
eslintPlugin: path.Join(workspace, "./pkg/ui/workspaces/eslint-plugin-crdb"),
}, nil
}
@@ -520,6 +525,83 @@ Replaces 'make ui-test' and 'make ui-test-watch'.`,
return testCmd
}
+func makeUIE2eCmd(d *dev) *cobra.Command {
+ const headedFlag = "headed"
+
+ e2eTestCmd := &cobra.Command{
+ Use: "e2e -- [args passed to Cypress ...]",
+ Short: "run e2e (Cypress) tests",
+ Long: strings.TrimSpace(`
+Run end-to-end tests with Cypress, spinning up a real local cluster and
+launching test in a real browser. Extra flags are passed directly to the
+'cypress' binary".
+`),
+ Args: cobra.ArbitraryArgs,
+ RunE: func(cmd *cobra.Command, commandLine []string) error {
+ ctx := cmd.Context()
+
+ isHeaded := mustGetFlagBool(cmd, headedFlag)
+ var yarnTarget string = "cy:run"
+ if isHeaded {
+ yarnTarget = "cy:debug"
+ }
+
+ uiDirs, err := getUIDirs(d)
+ if err != nil {
+ return err
+ }
+
+ workspace, err := d.getWorkspace(ctx)
+ if err != nil {
+ return err
+ }
+
+ // Ensure e2e-tests dependencies are installed
+ installArgv := buildBazelYarnArgv("--silent", "--cwd", uiDirs.e2eTests, "install")
+ logCommand("bazel", installArgv...)
+ err = d.exec.CommandContextInheritingStdStreams(ctx, "bazel", installArgv...)
+ if err != nil {
+ return fmt.Errorf("unable to install NPM dependencies: %w", err)
+ }
+
+ // Build cockroach (relying on Bazel to short-circuit repeated builds)
+ buildCockroachArgv := []string{
+ "build",
+ "//pkg/cmd/cockroach:cockroach",
+ "--config=with_ui",
+ }
+ logCommand("bazel", buildCockroachArgv...)
+ err = d.exec.CommandContextInheritingStdStreams(ctx, "bazel", buildCockroachArgv...)
+ if err != nil {
+ return fmt.Errorf("unable to build cockroach with UI: %w", err)
+ }
+
+ // Run Cypress tests, passing any extra args through to 'cypress'
+ startCrdbThenSh := path.Join(uiDirs.e2eTests, "build/start-crdb-then.sh")
+ runCypressArgv := append(
+ []string{"bazel"},
+ buildBazelYarnArgv("--silent", "--cwd", uiDirs.e2eTests, yarnTarget)...,
+ )
+ runCypressArgv = append(runCypressArgv, cmd.Flags().Args()...)
+
+ logCommand(startCrdbThenSh, runCypressArgv...)
+ env := append(
+ os.Environ(),
+ fmt.Sprintf("COCKROACH=%s", path.Join(workspace, "cockroach")),
+ )
+ err = d.exec.CommandContextWithEnv(ctx, env, startCrdbThenSh, runCypressArgv...)
+ if err != nil {
+ return fmt.Errorf("error while running Cypress tests: %w", err)
+ }
+
+ return nil
+ },
+ }
+ e2eTestCmd.Flags().Bool(headedFlag /* default */, false, "run tests in the interactive Cypres GUI")
+
+ return e2eTestCmd
+}
+
// buildBazelYarnArgv returns the provided argv formatted so it can be run with
// the bazel-provided version of yarn via `d.exec.CommandContextWithEnv`, e.g.:
//
diff --git a/pkg/ui/BUILD.bazel b/pkg/ui/BUILD.bazel
index 61902357a11a..2a3ef5d82ea5 100644
--- a/pkg/ui/BUILD.bazel
+++ b/pkg/ui/BUILD.bazel
@@ -49,6 +49,7 @@ test_suite(
tests = [
"//pkg/ui/workspaces/cluster-ui:lint",
"//pkg/ui/workspaces/db-console:lint",
+ "//pkg/ui/workspaces/e2e-tests:lint",
],
)
diff --git a/pkg/ui/not-yarn-workspace.sh b/pkg/ui/not-yarn-workspace.sh
index fbc80c3e90f4..c93a67ece977 100755
--- a/pkg/ui/not-yarn-workspace.sh
+++ b/pkg/ui/not-yarn-workspace.sh
@@ -7,6 +7,7 @@ set -euo pipefail
yarn --cwd workspaces/db-console/src/js install
yarn --cwd workspaces/cluster-ui install
yarn --cwd workspaces/db-console install
+ yarn --cwd workspaces/e2e-tests install
)
cat << "EOF"
diff --git a/pkg/ui/workspaces/e2e-tests/.eslintrc.json b/pkg/ui/workspaces/e2e-tests/.eslintrc.json
new file mode 100644
index 000000000000..b40955325936
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/.eslintrc.json
@@ -0,0 +1,10 @@
+{
+ "root": true,
+ "extends": "@cockroachlabs/eslint-config",
+ "settings": {
+ "react": {
+ "pragma": "React",
+ "version": "17.0"
+ }
+ }
+}
diff --git a/pkg/ui/workspaces/e2e-tests/.gitignore b/pkg/ui/workspaces/e2e-tests/.gitignore
new file mode 100644
index 000000000000..da39ab9b2fb6
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/.gitignore
@@ -0,0 +1,3 @@
+artifacts
+videos
+screenshots
diff --git a/pkg/ui/workspaces/e2e-tests/BUILD.bazel b/pkg/ui/workspaces/e2e-tests/BUILD.bazel
new file mode 100644
index 000000000000..50febc1027ac
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/BUILD.bazel
@@ -0,0 +1,25 @@
+load("@npm_e2e_tests//eslint:index.bzl", "eslint_test")
+
+eslint_test(
+ name = "lint",
+ data = [
+ ".eslintrc.json",
+ "cypress",
+ "cypress.config.ts",
+ "//pkg/ui/workspaces/eslint-plugin-crdb",
+ "@npm_e2e_tests//@cockroachlabs/eslint-config",
+ "@npm_e2e_tests//@typescript-eslint/eslint-plugin",
+ "@npm_e2e_tests//@typescript-eslint/parser",
+ "@npm_e2e_tests//eslint-plugin-prettier",
+ "@npm_e2e_tests//eslint-plugin-react",
+ "@npm_e2e_tests//eslint-plugin-react-hooks",
+ "@npm_e2e_tests//prettier",
+ ],
+ templated_args = [
+ "--ext .ts",
+ "-c",
+ "$$(rlocation $(rootpath .eslintrc.json))",
+ "$$(rlocation $(rootpath cypress))",
+ "$$(rlocation $(rootpath cypress.config.ts))",
+ ],
+)
diff --git a/pkg/ui/workspaces/e2e-tests/README.md b/pkg/ui/workspaces/e2e-tests/README.md
new file mode 100644
index 000000000000..81acb4f816a3
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/README.md
@@ -0,0 +1,60 @@
+# End-to-end Tests for CockroachDB UI
+This package contains end-to-end tests for the CockroachDB web UI served (by
+default) on port 8080. Tests are run via [Cypress](https://cypress.io) and
+use a combination of the default Cypress API and the dom-testing-library queries
+provided by [Cypress Testing
+Library](https://testing-library.com/docs/cypress-testing-library/intro).
+
+## Running Tests Locally
+### Via `yarn`
+If you've already built a `cockroach` binary and installed the dependencies in
+this directory with `yarn`, these tests can be run with `yarn` directly:
+
+```sh
+yarn test # run all tests
+yarn test ./path/to/some/file.cy.ts # run only a single test file
+```
+
+For "headed" test development, in which the Cypress UI and a browser are
+visible, run `yarn test:debug` and choose a test file in the Cypress UI.
+
+### Via `dev`
+The standard `dev` CLI used for other CockroachDB tasks can be used to run all
+(or a selected subset) of end-to-end tests via:
+
+```sh
+dev ui e2e # run all tests
+dev ui e2e ./path/to/some/file.cy.ts # run only a single test file
+```
+
+This will ensure the relevant NPM dependencies are installed and build
+CockroachDB (if necessary) before running any tests, which is especially helpful
+during a bisect. For more information, see `dev ui e2e --help`.
+
+For "headed" test development, in which the Cypress UI and a browser are
+visible, run `dev ui e2e --headed` and choose a test file in the Cypress UI.
+
+## Running Tests in TeamCity
+For CI purposes, these tests are also run in TeamCity via Docker's [Compose
+V2](https://docs.docker.com/compose) by combining the [CockroachDB Docker
+image](https://github.com/cockroachdb/cockroach/tree/master/build/deploy) from a
+[previous build
+step](https://teamcity.cockroachdb.com/buildConfiguration/Cockroach_ScratchProjectPutTcExperimentsInHere_JaneDockerImage)
+with an [upstream Cypress docker
+image](https://hub.docker.com/r/cypress/browsers). Testing this configuration
+requires a bit of manual file movement and is out of scope for this document.
+
+## Cluster Management in Tests
+Regardless of how tests are launched, each test suite spins up a single-node
+cluster with an empty 'movr' database that listens only on localhost. The test
+scripts waits for the HTTP server to be listening on port 8080 before invoking
+`cypress`, and tears down the cluster when `cypress` exits.
+
+## Health Checks vs All Tests
+Each CockroachDB pull request results in only the tests in
+`./cypress/e2e/health-checks` being executed. These are intended to confirm only
+the most basic functionality of the UI, to ensure it hasn't been completely
+broken or accidentally removed. A more comprehensive suite including all tests
+is run in a separate TeamCity job.
+
+In general: put only simple, short-lived tests in the health-checks tree.
diff --git a/pkg/ui/workspaces/e2e-tests/build/compose-entrypoint.sh b/pkg/ui/workspaces/e2e-tests/build/compose-entrypoint.sh
new file mode 100755
index 000000000000..d6c84c0a98bb
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/build/compose-entrypoint.sh
@@ -0,0 +1,22 @@
+#!/usr/bin/env bash
+set -uemo pipefail
+
+set -x
+
+# Copy the /e2e tree into /scratch and remove any existing node_modules, to
+# prevent files with unexpected owners from escaping
+mkdir /scratch
+cp --recursive --no-target-directory --no-preserve=owner /e2e /scratch
+cd /scratch
+
+# Write a minimal .yarnrc mirroring the one in cockroach.git/pkg/ui, to avoid
+# mounting that entire tree.
+echo "yarn-offline-mirror /yarn-vendor" > .yarnrc
+
+# Remove and reinstall any node_modules that may have been copied, since they're
+# potentially specific to the host platform.
+rm -rf node_modules/
+yarn install --force --offline
+
+# Run tests, passing extra CLI arguments through to Cypress
+yarn cy:run "$@"
diff --git a/pkg/ui/workspaces/e2e-tests/build/start-crdb-then.sh b/pkg/ui/workspaces/e2e-tests/build/start-crdb-then.sh
new file mode 100755
index 000000000000..465de2640118
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/build/start-crdb-then.sh
@@ -0,0 +1,113 @@
+#!/usr/bin/env bash
+set -ueo pipefail
+
+# Compute the absolute path to the root of the cockroach repo.
+root=$(dirname $(dirname $(dirname $(dirname $(dirname $(cd "$(dirname "${BASH_SOURCE[0]}")" &> /dev/null && pwd ))))))
+# Set up a working directory to ensure the original working directory isn't littered.
+WORKDIR=$(mktemp -d)
+# Stash the original working directory to return to later
+ORIGINAL_PWD=$PWD
+
+print_usage() {
+ cat<< EOF
+USAGE: $0 COMMAND [ARGS...]
+
+Starts a CockroachDB node with an empty 'movr' database, executing COMMAND with
+ARGS when the database serves HTTP traffic on port 8080.
+
+When COMMAND exits, the database is stopped.
+
+EXAMPLES:
+ $0 'curl http://localhost:8080'
+ Load index.html once the database has started.
+
+ $0 'yarn cy:run'
+ Run Cypress tests once the database has started.
+EOF
+}
+
+EXIT_CODE=-1
+cleanup() {
+ # Send an exit signal to the background CRDB job.
+ kill %1
+
+ # Wait for the background CRDB job to exit, using 'set +e' to allow 'wait' to
+ # exit with non-zero. CRDB will exit non-zero (and 'wait' will too), but with
+ # 'set -e' this entire script would normally exit *immediately*.
+ set +e; wait %1; set -e
+
+ # Clean up the working directory.
+ cd $ORIGINAL_PWD
+ rm -rf $WORKDIR
+
+ # Forward the exit code from COMMAND to the calling shell.
+ exit $EXIT_CODE;
+}
+
+# Command used improperly; print help and exit non-zero.
+if [ $# -lt 1 ] || [ -z "$1" ]; then
+ print_usage
+ exit 1
+fi
+
+# Help explicitly requested; print help and exit zero.
+if [ "$1" == "help" ] || [ "$1" == "-h" ] || [ "$1" == "--help" ]; then
+ print_usage
+ exit 0
+fi
+
+if curl --silent --head http://localhost:8080 > /dev/null; then
+ cat<< EOF
+ERROR: Another process is already listening on port 8080. It may be a CRDB
+ instance, but to be safe, this script is exiting early.
+
+ Here's what we know about that process, courtesy of 'ps':\n
+EOF
+
+ ps -o pid -o command -p $(lsof -t -i :8080)
+ exit 2
+fi
+
+# Use an arbitrary Cockroach binary via the $COCKROACH_ENTRYPOINT environment
+# variable
+COCKROACH=${COCKROACH:-$root/cockroach}
+
+# Run cockroach from within the temporary directory, so extra files don't
+# clutter the original PWD.
+pushd $WORKDIR
+
+# Start a single-node cluster using the cockroach.sh script, which automatically
+# creates a user and database from provided environment variables.
+# Use standard shell backgrounding (*not* the cockroach --background flag) so
+# that this cluster can be shut down when $COMMAND exits.
+COCKROACH=$COCKROACH \
+COCKROACH_USER=cypress \
+COCKROACH_PASSWORD=tests \
+COCKROACH_DATABASE=movr \
+$root/build/deploy/cockroach.sh \
+ start-single-node \
+ --http-port=8080 & &> /dev/null
+
+# Close that cluster whenever this script exits.
+trap 'cleanup' EXIT
+
+# Wait for the connection URL file to exist and for the database's HTTP server
+# to be available.
+until [ -r ./init_success ] && curl --fail --silent --head http://localhost:8080 > /dev/null; do
+ sleep 0.25
+done
+
+# Return to the original PWD before executing $COMMAND
+popd
+
+# Use eval() to execute the provided command so that environment variables are
+# expanded properly (e.g. `$0 'cat $SHLVL'`, where $SHLVL must
+# be evaluated after this file is executed, not before).
+(
+ # Temporarily disable globbing, so strings containing ** (e.g.
+ # '--spec "cypress/e2e/health-check/**"') aren't evaluated.
+ set -f; eval "$@"; set +f
+)
+
+# Stash COMMAND's exit code so we can return it in the cleanup hook.
+EXIT_CODE=$?
diff --git a/pkg/ui/workspaces/e2e-tests/compose.yaml b/pkg/ui/workspaces/e2e-tests/compose.yaml
new file mode 100644
index 000000000000..302471c27403
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/compose.yaml
@@ -0,0 +1,37 @@
+services:
+ crdb:
+ image: cockroachdb/cockroach-ci:latest
+ command: start-single-node --http-port=8080
+ hostname: crdbhost
+ networks:
+ - db
+ expose:
+ - "8080"
+ healthcheck:
+ test: "[ -r ./init_success ] && curl --fail --head http://localhost:8080 || exit 1"
+ interval: 0.5s
+ timeout: 10s
+ retries: 25
+ environment:
+ COCKROACH_USER: cypress
+ COCKROACH_PASSWORD: tests
+ COCKROACH_DATABASE: movr
+
+ cypress:
+ image: cypress/browsers:node16.14.2-slim-chrome100-ff99-edge
+ working_dir: /e2e
+ entrypoint: ./build/compose-entrypoint.sh
+ environment:
+ IS_DOCKER: "1"
+ depends_on:
+ crdb:
+ condition: service_healthy
+ networks:
+ - db
+ volumes:
+ - ./:/e2e
+ - ./artifacts:/artifacts
+ - ../../yarn-vendor:/yarn-vendor
+
+networks:
+ db:
diff --git a/pkg/ui/workspaces/e2e-tests/cypress.config.ts b/pkg/ui/workspaces/e2e-tests/cypress.config.ts
new file mode 100644
index 000000000000..9f867148cca5
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/cypress.config.ts
@@ -0,0 +1,32 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+import { defineConfig } from "cypress";
+
+const DOCKER_OVERRIDES: Partial<Cypress.UserConfigOptions["e2e"]> = {
+ baseUrl: "https://crdbhost:8080",
+ reporter: "teamcity",
+ downloadsFolder: "/artifacts/cypress/downloads",
+ screenshotsFolder: "/artifacts/cypress/screenshots",
+ videosFolder: "/artifacts/cypress/videos",
+};
+
+export default defineConfig({
+ e2e: {
+ baseUrl: "http://localhost:8080",
+ setupNodeEvents(on, config) {
+ config.env.username = "cypress";
+ config.env.password = "tests";
+ return config;
+ },
+ // Override some settings when running in Docker
+ ...(process.env.IS_DOCKER ? DOCKER_OVERRIDES : {}),
+ },
+});
diff --git a/pkg/ui/workspaces/e2e-tests/cypress/e2e/health-check/authenticated.cy.ts b/pkg/ui/workspaces/e2e-tests/cypress/e2e/health-check/authenticated.cy.ts
new file mode 100644
index 000000000000..c16cf3e9c9fe
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/cypress/e2e/health-check/authenticated.cy.ts
@@ -0,0 +1,46 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+describe("health check: authenticated user", () => {
+ it("serves a DB Console overview page", () => {
+ cy.login();
+
+ // Ensure that something reasonable renders at / when authenticated, making
+ // just enough assertions to ensure the right page loaded. If this test
+ // fails, the server probably isn't running or authentication is broken.
+ cy.visit({
+ url: "/",
+ failOnStatusCode: true,
+ });
+
+ // Ensure the Cluster ID appears
+ cy.findByText(
+ /^Cluster id: [0-9a-f]{8}-[0-9a-f]{4}-[0-9a-f]{4}-[0-9a-f]{4}-[0-9a-f]{12}$/,
+ { timeout: 30_000 },
+ );
+
+ // Check (roughly) for "Overview" tab contents
+ cy.findByText("Capacity Usage", { selector: "h3>span" });
+ cy.findByText("Node Status");
+ cy.findByText("Replication Status");
+ cy.findByText("Nodes (1)");
+
+ // Check for sidebar contents
+ cy.findByRole("navigation").within(() => {
+ cy.findByRole("link", { name: "Overview" });
+ cy.findByRole("link", { name: "Metrics" });
+ cy.findByRole("link", { name: "Databases" });
+ cy.findByRole("link", { name: "SQL Activity" });
+ cy.findByRole("link", { name: "Hot Ranges" });
+ cy.findByRole("link", { name: "Jobs" });
+ cy.findByRole("link", { name: "Advanced Debug" });
+ });
+ });
+});
diff --git a/pkg/ui/workspaces/e2e-tests/cypress/e2e/health-check/unauthenticated.cy.ts b/pkg/ui/workspaces/e2e-tests/cypress/e2e/health-check/unauthenticated.cy.ts
new file mode 100644
index 000000000000..11f46d8534d4
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/cypress/e2e/health-check/unauthenticated.cy.ts
@@ -0,0 +1,24 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+describe("health check: unauthenticated user", () => {
+ it("serves a DB Console login page", () => {
+ // Ensure that *something* renders at / as a canary for all other tests,
+ // making just enough assertions to ensure the right page loaded.
+ // If this test fails, the server probably isn't running.
+ cy.visit({
+ url: "/",
+ failOnStatusCode: true,
+ });
+ cy.findByText("Log in to the DB Console");
+ cy.findByPlaceholderText("Username");
+ cy.findByPlaceholderText("Password");
+ });
+});
diff --git a/pkg/ui/workspaces/e2e-tests/cypress/support/commands.ts b/pkg/ui/workspaces/e2e-tests/cypress/support/commands.ts
new file mode 100644
index 000000000000..f7b291b090fa
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/cypress/support/commands.ts
@@ -0,0 +1,35 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+import "@testing-library/cypress/add-commands";
+
+Cypress.Commands.add("login", () => {
+ cy.request({
+ method: "POST",
+ url: "/api/v2/login/",
+ form: true,
+ body: {
+ username: Cypress.env("username"),
+ password: Cypress.env("password"),
+ },
+ failOnStatusCode: true,
+ }).then(({ body }) => {
+ if ("session" in body) {
+ // Set the returned session token as a cookie, emulating the 'Set-Cookie'
+ // response header currently returned from CRDB:
+ // Set-Cookie: session=REDACTED; Path=/; HttpOnly
+ cy.setCookie("session", body.session, { path: "/", httpOnly: true });
+ } else {
+ throw new Error(
+ `Unexpected response from /api/v2/login: ${JSON.stringify(body)}`,
+ );
+ }
+ });
+});
diff --git a/pkg/ui/workspaces/e2e-tests/cypress/support/e2e.ts b/pkg/ui/workspaces/e2e-tests/cypress/support/e2e.ts
new file mode 100644
index 000000000000..4e220dcb5093
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/cypress/support/e2e.ts
@@ -0,0 +1,27 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+// ***********************************************************
+// This example support/e2e.ts is processed and
+// loaded automatically before your test files.
+//
+// This is a great place to put global configuration and
+// behavior that modifies Cypress.
+//
+// You can change the location of this file or turn off
+// automatically serving support files with the
+// 'supportFile' configuration option.
+//
+// You can read more here:
+// https://on.cypress.io/configuration
+// ***********************************************************
+
+// Import commands.js using ES2015 syntax:
+import "./commands";
diff --git a/pkg/ui/workspaces/e2e-tests/cypress/support/index.ts b/pkg/ui/workspaces/e2e-tests/cypress/support/index.ts
new file mode 100644
index 000000000000..f017e842a498
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/cypress/support/index.ts
@@ -0,0 +1,42 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+// ***********************************************************
+// This support/index.ts is processed and
+// loaded automatically before your test files.
+//
+// This is a great place to put global configuration and
+// behavior that modifies Cypress.
+//
+// You can change the location of this file or turn off
+// automatically serving support files with the
+// 'supportFile' configuration option.
+//
+// You can read more here:
+// https://on.cypress.io/configuration
+// ***********************************************************
+
+import "./commands";
+
+declare global {
+ // eslint-disable-next-line @typescript-eslint/no-namespace -- required for declaration merging
+ namespace Cypress {
+ interface Chainable {
+ /**
+ * Sets a session cookie for the demo user on the current
+ * database.
+ * @example
+ * cy.login();
+ * cy.visit("#/some/authenticated/route");
+ */
+ login(): void;
+ }
+ }
+}
diff --git a/pkg/ui/workspaces/e2e-tests/package.json b/pkg/ui/workspaces/e2e-tests/package.json
new file mode 100644
index 000000000000..bd7aae113e0e
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/package.json
@@ -0,0 +1,30 @@
+{
+ "name": "@cockroachlabs/e2e-tests",
+ "version": "1.0.0",
+ "description": "End-to-end tests for the CockroachDB UI",
+ "license": "BSL",
+ "private": true,
+ "scripts": {
+ "test": "./build/start-crdb-then.sh yarn cy:run",
+ "test:debug": "./build/start-crdb-then.sh yarn cy:debug",
+ "cy:run": "cypress run --e2e",
+ "cy:debug": "cypress open --e2e --browser=chrome",
+ "lint": "eslint './**/*.ts'",
+ "lint:fix": "eslint --fix './**/*.ts'"
+ },
+ "devDependencies": {
+ "@cockroachlabs/eslint-config": "0.1.11",
+ "@testing-library/cypress": "^8.0.2",
+ "@types/node": "16",
+ "cypress": "^10.3.0",
+ "eslint": "7.29.0",
+ "eslint-plugin-prettier": "3.4.0",
+ "eslint-plugin-react": "7.24.0",
+ "eslint-plugin-react-hooks": "4.2.0",
+ "prettier": "2.6.2",
+ "typescript": "^4.6.3"
+ },
+ "dependencies": {
+ "@typescript-eslint/eslint-plugin": "4.29.1"
+ }
+}
diff --git a/pkg/ui/workspaces/e2e-tests/tsconfig.json b/pkg/ui/workspaces/e2e-tests/tsconfig.json
new file mode 100644
index 000000000000..c66e4cbf741e
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/tsconfig.json
@@ -0,0 +1,8 @@
+{
+ "compilerOptions": {
+ "target": "es6",
+ "lib": ["es6", "dom"],
+ "types": ["cypress", "@testing-library/cypress", "node"]
+ },
+ "include": ["**/*.ts"]
+}
diff --git a/pkg/ui/workspaces/e2e-tests/yarn.lock b/pkg/ui/workspaces/e2e-tests/yarn.lock
new file mode 100644
index 000000000000..8a4acec9f374
--- /dev/null
+++ b/pkg/ui/workspaces/e2e-tests/yarn.lock
@@ -0,0 +1,2444 @@
+# THIS IS AN AUTOGENERATED FILE. DO NOT EDIT THIS FILE DIRECTLY.
+# yarn lockfile v1
+
+
+"@babel/[email protected]":
+ version "7.12.11"
+ resolved "https://registry.yarnpkg.com/@babel/code-frame/-/code-frame-7.12.11.tgz#f4ad435aa263db935b8f10f2c552d23fb716a63f"
+ integrity sha512-Zt1yodBx1UcyiePMSkWnU4hPqhwq7hGi2nFL1LeA3EUl+q2LQx16MISgJ0+z7dnmgvP9QtIleuETGOiOH1RcIw==
+ dependencies:
+ "@babel/highlight" "^7.10.4"
+
+"@babel/code-frame@^7.10.4":
+ version "7.18.6"
+ resolved "https://registry.yarnpkg.com/@babel/code-frame/-/code-frame-7.18.6.tgz#3b25d38c89600baa2dcc219edfa88a74eb2c427a"
+ integrity sha512-TDCmlK5eOvH+eH7cdAFlNXeVJqWIQ7gW9tY1GJIpUtFb6CmjVyq2VM3u71bOyR8CRihcCgMUYoDNyLXao3+70Q==
+ dependencies:
+ "@babel/highlight" "^7.18.6"
+
+"@babel/helper-validator-identifier@^7.18.6":
+ version "7.18.6"
+ resolved "https://registry.yarnpkg.com/@babel/helper-validator-identifier/-/helper-validator-identifier-7.18.6.tgz#9c97e30d31b2b8c72a1d08984f2ca9b574d7a076"
+ integrity sha512-MmetCkz9ej86nJQV+sFCxoGGrUbU3q02kgLciwkrt9QqEB7cP39oKEY0PakknEO0Gu20SskMRi+AYZ3b1TpN9g==
+
+"@babel/highlight@^7.10.4", "@babel/highlight@^7.18.6":
+ version "7.18.6"
+ resolved "https://registry.yarnpkg.com/@babel/highlight/-/highlight-7.18.6.tgz#81158601e93e2563795adcbfbdf5d64be3f2ecdf"
+ integrity sha512-u7stbOuYjaPezCuLj29hNW1v64M2Md2qupEKP1fHc7WdOA3DgLh37suiSrZYY7haUB7iBeQZ9P1uiRF359do3g==
+ dependencies:
+ "@babel/helper-validator-identifier" "^7.18.6"
+ chalk "^2.0.0"
+ js-tokens "^4.0.0"
+
+"@babel/runtime@^7.12.5", "@babel/runtime@^7.14.6":
+ version "7.18.6"
+ resolved "https://registry.yarnpkg.com/@babel/runtime/-/runtime-7.18.6.tgz#6a1ef59f838debd670421f8c7f2cbb8da9751580"
+ integrity sha512-t9wi7/AW6XtKahAe20Yw0/mMljKq0B1r2fPdvaAdV/KPDZewFXdaaa6K7lxmZBZ8FBNpCiAT6iHPmd6QO9bKfQ==
+ dependencies:
+ regenerator-runtime "^0.13.4"
+
+"@cockroachlabs/[email protected]":
+ version "0.1.11"
+ resolved "https://registry.yarnpkg.com/@cockroachlabs/eslint-config/-/eslint-config-0.1.11.tgz#b21d905bce4e3994c70aa9a09e00ddb17a42b450"
+ integrity sha512-lXeEfweDMg/g2a9KroNaLfa20cKFxUO5zWFlLty7ZHrGwSG7ndP9CYmXjokqBymhPa25NSOlWc4CetDFR0DXMQ==
+ dependencies:
+ "@typescript-eslint/parser" "^2.34.0"
+ eslint-config-prettier "^6.11.0"
+
+"@colors/[email protected]":
+ version "1.5.0"
+ resolved "https://registry.yarnpkg.com/@colors/colors/-/colors-1.5.0.tgz#bb504579c1cae923e6576a4f5da43d25f97bdbd9"
+ integrity sha512-ooWCrlZP11i8GImSjTHYHLkvFDP48nS4+204nGb1RiX/WXYHmJA2III9/e2DWVabCESdW7hBAEzHRqUn9OUVvQ==
+
+"@cypress/request@^2.88.10":
+ version "2.88.10"
+ resolved "https://registry.yarnpkg.com/@cypress/request/-/request-2.88.10.tgz#b66d76b07f860d3a4b8d7a0604d020c662752cce"
+ integrity sha512-Zp7F+R93N0yZyG34GutyTNr+okam7s/Fzc1+i3kcqOP8vk6OuajuE9qZJ6Rs+10/1JFtXFYMdyarnU1rZuJesg==
+ dependencies:
+ aws-sign2 "~0.7.0"
+ aws4 "^1.8.0"
+ caseless "~0.12.0"
+ combined-stream "~1.0.6"
+ extend "~3.0.2"
+ forever-agent "~0.6.1"
+ form-data "~2.3.2"
+ http-signature "~1.3.6"
+ is-typedarray "~1.0.0"
+ isstream "~0.1.2"
+ json-stringify-safe "~5.0.1"
+ mime-types "~2.1.19"
+ performance-now "^2.1.0"
+ qs "~6.5.2"
+ safe-buffer "^5.1.2"
+ tough-cookie "~2.5.0"
+ tunnel-agent "^0.6.0"
+ uuid "^8.3.2"
+
+"@cypress/xvfb@^1.2.4":
+ version "1.2.4"
+ resolved "https://registry.yarnpkg.com/@cypress/xvfb/-/xvfb-1.2.4.tgz#2daf42e8275b39f4aa53c14214e557bd14e7748a"
+ integrity sha512-skbBzPggOVYCbnGgV+0dmBdW/s77ZkAOXIC1knS8NagwDjBrNC1LuXtQJeiN6l+m7lzmHtaoUw/ctJKdqkG57Q==
+ dependencies:
+ debug "^3.1.0"
+ lodash.once "^4.1.1"
+
+"@eslint/eslintrc@^0.4.2":
+ version "0.4.3"
+ resolved "https://registry.yarnpkg.com/@eslint/eslintrc/-/eslintrc-0.4.3.tgz#9e42981ef035beb3dd49add17acb96e8ff6f394c"
+ integrity sha512-J6KFFz5QCYUJq3pf0mjEcCJVERbzv71PUIDczuh9JkwGEzced6CO5ADLHB1rbf/+oPBtoPfMYNOpGDzCANlbXw==
+ dependencies:
+ ajv "^6.12.4"
+ debug "^4.1.1"
+ espree "^7.3.0"
+ globals "^13.9.0"
+ ignore "^4.0.6"
+ import-fresh "^3.2.1"
+ js-yaml "^3.13.1"
+ minimatch "^3.0.4"
+ strip-json-comments "^3.1.1"
+
+"@nodelib/[email protected]":
+ version "2.1.5"
+ resolved "https://registry.yarnpkg.com/@nodelib/fs.scandir/-/fs.scandir-2.1.5.tgz#7619c2eb21b25483f6d167548b4cfd5a7488c3d5"
+ integrity sha512-vq24Bq3ym5HEQm2NKCr3yXDwjc7vTsEThRDnkp2DK9p1uqLR+DHurm/NOTo0KG7HYHU7eppKZj3MyqYuMBf62g==
+ dependencies:
+ "@nodelib/fs.stat" "2.0.5"
+ run-parallel "^1.1.9"
+
+"@nodelib/[email protected]", "@nodelib/fs.stat@^2.0.2":
+ version "2.0.5"
+ resolved "https://registry.yarnpkg.com/@nodelib/fs.stat/-/fs.stat-2.0.5.tgz#5bd262af94e9d25bd1e71b05deed44876a222e8b"
+ integrity sha512-RkhPPp2zrqDAQA/2jNhnztcPAlv64XdhIp7a7454A5ovI7Bukxgt7MX7udwAu3zg1DcpPU0rz3VV1SeaqvY4+A==
+
+"@nodelib/fs.walk@^1.2.3":
+ version "1.2.8"
+ resolved "https://registry.yarnpkg.com/@nodelib/fs.walk/-/fs.walk-1.2.8.tgz#e95737e8bb6746ddedf69c556953494f196fe69a"
+ integrity sha512-oGB+UxlgWcgQkgwo8GcEGwemoTFt3FIO9ababBmaGwXIoBKZ+GTy0pP185beGg7Llih/NSHSV2XAs1lnznocSg==
+ dependencies:
+ "@nodelib/fs.scandir" "2.1.5"
+ fastq "^1.6.0"
+
+"@testing-library/cypress@^8.0.2":
+ version "8.0.3"
+ resolved "https://registry.yarnpkg.com/@testing-library/cypress/-/cypress-8.0.3.tgz#24ab34df34d7896866603ade705afbdd186e273c"
+ integrity sha512-nY2YaSbmuPo5k6kL0iLj/pGPPfka3iwb3kpTx8QN/vOCns92Saz9wfACqB8FJzcR7+lfA4d5HUOWqmTddBzczg==
+ dependencies:
+ "@babel/runtime" "^7.14.6"
+ "@testing-library/dom" "^8.1.0"
+
+"@testing-library/dom@^8.1.0":
+ version "8.16.0"
+ resolved "https://registry.yarnpkg.com/@testing-library/dom/-/dom-8.16.0.tgz#d6fc50250aed17b1035ca1bd64655e342db3936a"
+ integrity sha512-uxF4zmnLHHDlmW4l+0WDjcgLVwCvH+OVLpD8Dfp+Bjfz85prwxWGbwXgJdLtkgjD0qfOzkJF9SmA6YZPsMYX4w==
+ dependencies:
+ "@babel/code-frame" "^7.10.4"
+ "@babel/runtime" "^7.12.5"
+ "@types/aria-query" "^4.2.0"
+ aria-query "^5.0.0"
+ chalk "^4.1.0"
+ dom-accessibility-api "^0.5.9"
+ lz-string "^1.4.4"
+ pretty-format "^27.0.2"
+
+"@types/aria-query@^4.2.0":
+ version "4.2.2"
+ resolved "https://registry.yarnpkg.com/@types/aria-query/-/aria-query-4.2.2.tgz#ed4e0ad92306a704f9fb132a0cfcf77486dbe2bc"
+ integrity sha512-HnYpAE1Y6kRyKM/XkEuiRQhTHvkzMBurTHnpFLYLBGPIylZNPs9jJcuOOYWxPLJCSEtmZT0Y8rHDokKN7rRTig==
+
+"@types/eslint-visitor-keys@^1.0.0":
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/@types/eslint-visitor-keys/-/eslint-visitor-keys-1.0.0.tgz#1ee30d79544ca84d68d4b3cdb0af4f205663dd2d"
+ integrity sha512-OCutwjDZ4aFS6PB1UZ988C4YgwlBHJd6wCeQqaLdmadZ/7e+w79+hbMUFC1QXDNCmdyoRfAFdm0RypzwR+Qpag==
+
+"@types/json-schema@^7.0.3", "@types/json-schema@^7.0.7":
+ version "7.0.11"
+ resolved "https://registry.yarnpkg.com/@types/json-schema/-/json-schema-7.0.11.tgz#d421b6c527a3037f7c84433fd2c4229e016863d3"
+ integrity sha512-wOuvG1SN4Us4rez+tylwwwCV1psiNVOkJeM3AUWUNWg/jDQY2+HE/444y5gc+jBmRqASOm2Oeh5c1axHobwRKQ==
+
+"@types/node@*":
+ version "18.6.1"
+ resolved "https://registry.yarnpkg.com/@types/node/-/node-18.6.1.tgz#828e4785ccca13f44e2fb6852ae0ef11e3e20ba5"
+ integrity sha512-z+2vB6yDt1fNwKOeGbckpmirO+VBDuQqecXkgeIqDlaOtmKn6hPR/viQ8cxCfqLU4fTlvM3+YjM367TukWdxpg==
+
+"@types/node@16":
+ version "16.11.45"
+ resolved "https://registry.yarnpkg.com/@types/node/-/node-16.11.45.tgz#155b13a33c665ef2b136f7f245fa525da419e810"
+ integrity sha512-3rKg/L5x0rofKuuUt5zlXzOnKyIHXmIu5R8A0TuNDMF2062/AOIDBciFIjToLEJ/9F9DzkHNot+BpNsMI1OLdQ==
+
+"@types/node@^14.14.31":
+ version "14.18.22"
+ resolved "https://registry.yarnpkg.com/@types/node/-/node-14.18.22.tgz#fd2a15dca290fc9ad565b672fde746191cd0c6e6"
+ integrity sha512-qzaYbXVzin6EPjghf/hTdIbnVW1ErMx8rPzwRNJhlbyJhu2SyqlvjGOY/tbUt6VFyzg56lROcOeSQRInpt63Yw==
+
+"@types/[email protected]":
+ version "8.1.1"
+ resolved "https://registry.yarnpkg.com/@types/sinonjs__fake-timers/-/sinonjs__fake-timers-8.1.1.tgz#b49c2c70150141a15e0fa7e79cf1f92a72934ce3"
+ integrity sha512-0kSuKjAS0TrGLJ0M/+8MaFkGsQhZpB6pxOmvS3K8FYI72K//YmdfoW9X2qPsAKh1mkwxGD5zib9s1FIFed6E8g==
+
+"@types/sizzle@^2.3.2":
+ version "2.3.3"
+ resolved "https://registry.yarnpkg.com/@types/sizzle/-/sizzle-2.3.3.tgz#ff5e2f1902969d305225a047c8a0fd5c915cebef"
+ integrity sha512-JYM8x9EGF163bEyhdJBpR2QX1R5naCJHC8ucJylJ3w9/CVBaskdQ8WqBf8MmQrd1kRvp/a4TS8HJ+bxzR7ZJYQ==
+
+"@types/yauzl@^2.9.1":
+ version "2.10.0"
+ resolved "https://registry.yarnpkg.com/@types/yauzl/-/yauzl-2.10.0.tgz#b3248295276cf8c6f153ebe6a9aba0c988cb2599"
+ integrity sha512-Cn6WYCm0tXv8p6k+A8PvbDG763EDpBoTzHdA+Q/MF6H3sapGjCm9NzoaJncJS9tUKSuCoDs9XHxYYsQDgxR6kw==
+ dependencies:
+ "@types/node" "*"
+
+"@typescript-eslint/[email protected]":
+ version "4.29.1"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/eslint-plugin/-/eslint-plugin-4.29.1.tgz#808d206e2278e809292b5de752a91105da85860b"
+ integrity sha512-AHqIU+SqZZgBEiWOrtN94ldR3ZUABV5dUG94j8Nms9rQnHFc8fvDOue/58K4CFz6r8OtDDc35Pw9NQPWo0Ayrw==
+ dependencies:
+ "@typescript-eslint/experimental-utils" "4.29.1"
+ "@typescript-eslint/scope-manager" "4.29.1"
+ debug "^4.3.1"
+ functional-red-black-tree "^1.0.1"
+ regexpp "^3.1.0"
+ semver "^7.3.5"
+ tsutils "^3.21.0"
+
+"@typescript-eslint/[email protected]":
+ version "2.34.0"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/experimental-utils/-/experimental-utils-2.34.0.tgz#d3524b644cdb40eebceca67f8cf3e4cc9c8f980f"
+ integrity sha512-eS6FTkq+wuMJ+sgtuNTtcqavWXqsflWcfBnlYhg/nS4aZ1leewkXGbvBhaapn1q6qf4M71bsR1tez5JTRMuqwA==
+ dependencies:
+ "@types/json-schema" "^7.0.3"
+ "@typescript-eslint/typescript-estree" "2.34.0"
+ eslint-scope "^5.0.0"
+ eslint-utils "^2.0.0"
+
+"@typescript-eslint/[email protected]":
+ version "4.29.1"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/experimental-utils/-/experimental-utils-4.29.1.tgz#0af2b17b0296b60c6b207f11062119fa9c5a8994"
+ integrity sha512-kl6QG6qpzZthfd2bzPNSJB2YcZpNOrP6r9jueXupcZHnL74WiuSjaft7WSu17J9+ae9zTlk0KJMXPUj0daBxMw==
+ dependencies:
+ "@types/json-schema" "^7.0.7"
+ "@typescript-eslint/scope-manager" "4.29.1"
+ "@typescript-eslint/types" "4.29.1"
+ "@typescript-eslint/typescript-estree" "4.29.1"
+ eslint-scope "^5.1.1"
+ eslint-utils "^3.0.0"
+
+"@typescript-eslint/parser@^2.34.0":
+ version "2.34.0"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/parser/-/parser-2.34.0.tgz#50252630ca319685420e9a39ca05fe185a256bc8"
+ integrity sha512-03ilO0ucSD0EPTw2X4PntSIRFtDPWjrVq7C3/Z3VQHRC7+13YB55rcJI3Jt+YgeHbjUdJPcPa7b23rXCBokuyA==
+ dependencies:
+ "@types/eslint-visitor-keys" "^1.0.0"
+ "@typescript-eslint/experimental-utils" "2.34.0"
+ "@typescript-eslint/typescript-estree" "2.34.0"
+ eslint-visitor-keys "^1.1.0"
+
+"@typescript-eslint/[email protected]":
+ version "4.29.1"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/scope-manager/-/scope-manager-4.29.1.tgz#f25da25bc6512812efa2ce5ebd36619d68e61358"
+ integrity sha512-Hzv/uZOa9zrD/W5mftZa54Jd5Fed3tL6b4HeaOpwVSabJK8CJ+2MkDasnX/XK4rqP5ZTWngK1ZDeCi6EnxPQ7A==
+ dependencies:
+ "@typescript-eslint/types" "4.29.1"
+ "@typescript-eslint/visitor-keys" "4.29.1"
+
+"@typescript-eslint/[email protected]":
+ version "4.29.1"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/types/-/types-4.29.1.tgz#94cce6cf7cc83451df03339cda99d326be2feaf5"
+ integrity sha512-Jj2yu78IRfw4nlaLtKjVaGaxh/6FhofmQ/j8v3NXmAiKafbIqtAPnKYrf0sbGjKdj0hS316J8WhnGnErbJ4RCA==
+
+"@typescript-eslint/[email protected]":
+ version "2.34.0"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/typescript-estree/-/typescript-estree-2.34.0.tgz#14aeb6353b39ef0732cc7f1b8285294937cf37d5"
+ integrity sha512-OMAr+nJWKdlVM9LOqCqh3pQQPwxHAN7Du8DR6dmwCrAmxtiXQnhHJ6tBNtf+cggqfo51SG/FCwnKhXCIM7hnVg==
+ dependencies:
+ debug "^4.1.1"
+ eslint-visitor-keys "^1.1.0"
+ glob "^7.1.6"
+ is-glob "^4.0.1"
+ lodash "^4.17.15"
+ semver "^7.3.2"
+ tsutils "^3.17.1"
+
+"@typescript-eslint/[email protected]":
+ version "4.29.1"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/typescript-estree/-/typescript-estree-4.29.1.tgz#7b32a25ff8e51f2671ccc6b26cdbee3b1e6c5e7f"
+ integrity sha512-lIkkrR9E4lwZkzPiRDNq0xdC3f2iVCUjw/7WPJ4S2Sl6C3nRWkeE1YXCQ0+KsiaQRbpY16jNaokdWnm9aUIsfw==
+ dependencies:
+ "@typescript-eslint/types" "4.29.1"
+ "@typescript-eslint/visitor-keys" "4.29.1"
+ debug "^4.3.1"
+ globby "^11.0.3"
+ is-glob "^4.0.1"
+ semver "^7.3.5"
+ tsutils "^3.21.0"
+
+"@typescript-eslint/[email protected]":
+ version "4.29.1"
+ resolved "https://registry.yarnpkg.com/@typescript-eslint/visitor-keys/-/visitor-keys-4.29.1.tgz#0615be8b55721f5e854f3ee99f1a714f2d093e5d"
+ integrity sha512-zLqtjMoXvgdZY/PG6gqA73V8BjqPs4af1v2kiiETBObp+uC6gRYnJLmJHxC0QyUrrHDLJPIWNYxoBV3wbcRlag==
+ dependencies:
+ "@typescript-eslint/types" "4.29.1"
+ eslint-visitor-keys "^2.0.0"
+
+acorn-jsx@^5.3.1:
+ version "5.3.2"
+ resolved "https://registry.yarnpkg.com/acorn-jsx/-/acorn-jsx-5.3.2.tgz#7ed5bb55908b3b2f1bc55c6af1653bada7f07937"
+ integrity sha512-rq9s+JNhf0IChjtDXxllJ7g41oZk5SlXtp0LHwyA5cejwn7vKmKp4pPri6YEePv2PU65sAsegbXtIinmDFDXgQ==
+
+acorn@^7.4.0:
+ version "7.4.1"
+ resolved "https://registry.yarnpkg.com/acorn/-/acorn-7.4.1.tgz#feaed255973d2e77555b83dbc08851a6c63520fa"
+ integrity sha512-nQyp0o1/mNdbTO1PO6kHkwSrmgZ0MT/jCCpNiwbUjGoRN4dlBhqJtoQuCnEOKzgTVwg0ZWiCoQy6SxMebQVh8A==
+
+aggregate-error@^3.0.0:
+ version "3.1.0"
+ resolved "https://registry.yarnpkg.com/aggregate-error/-/aggregate-error-3.1.0.tgz#92670ff50f5359bdb7a3e0d40d0ec30c5737687a"
+ integrity sha512-4I7Td01quW/RpocfNayFdFVk1qSuoh0E7JrbRJ16nH01HhKFQ88INq9Sd+nd72zqRySlr9BmDA8xlEJ6vJMrYA==
+ dependencies:
+ clean-stack "^2.0.0"
+ indent-string "^4.0.0"
+
+ajv@^6.10.0, ajv@^6.12.4:
+ version "6.12.6"
+ resolved "https://registry.yarnpkg.com/ajv/-/ajv-6.12.6.tgz#baf5a62e802b07d977034586f8c3baf5adf26df4"
+ integrity sha512-j3fVLgvTo527anyYyJOGTYJbG+vnnQYvE0m5mmkc1TK+nxAppkCLMIL0aZ4dblVCNoGShhm+kzE4ZUykBoMg4g==
+ dependencies:
+ fast-deep-equal "^3.1.1"
+ fast-json-stable-stringify "^2.0.0"
+ json-schema-traverse "^0.4.1"
+ uri-js "^4.2.2"
+
+ajv@^8.0.1:
+ version "8.11.0"
+ resolved "https://registry.yarnpkg.com/ajv/-/ajv-8.11.0.tgz#977e91dd96ca669f54a11e23e378e33b884a565f"
+ integrity sha512-wGgprdCvMalC0BztXvitD2hC04YffAvtsUn93JbGXYLAtCUO4xd17mCCZQxUOItiBwZvJScWo8NIvQMQ71rdpg==
+ dependencies:
+ fast-deep-equal "^3.1.1"
+ json-schema-traverse "^1.0.0"
+ require-from-string "^2.0.2"
+ uri-js "^4.2.2"
+
+ansi-colors@^4.1.1:
+ version "4.1.3"
+ resolved "https://registry.yarnpkg.com/ansi-colors/-/ansi-colors-4.1.3.tgz#37611340eb2243e70cc604cad35d63270d48781b"
+ integrity sha512-/6w/C21Pm1A7aZitlI5Ni/2J6FFQN8i1Cvz3kHABAAbw93v/NlvKdVOqz7CCWz/3iv/JplRSEEZ83XION15ovw==
+
+ansi-escapes@^4.3.0:
+ version "4.3.2"
+ resolved "https://registry.yarnpkg.com/ansi-escapes/-/ansi-escapes-4.3.2.tgz#6b2291d1db7d98b6521d5f1efa42d0f3a9feb65e"
+ integrity sha512-gKXj5ALrKWQLsYG9jlTRmR/xKluxHV+Z9QEwNIgCfM1/uwPMCuzVVnh5mwTd+OuBZcwSIMbqssNWRm1lE51QaQ==
+ dependencies:
+ type-fest "^0.21.3"
+
+ansi-regex@^5.0.1:
+ version "5.0.1"
+ resolved "https://registry.yarnpkg.com/ansi-regex/-/ansi-regex-5.0.1.tgz#082cb2c89c9fe8659a311a53bd6a4dc5301db304"
+ integrity sha512-quJQXlTSUGL2LH9SUXo8VwsY4soanhgo6LNSm84E1LBcE8s3O0wpdiRzyR9z/ZZJMlMWv37qOOb9pdJlMUEKFQ==
+
+ansi-styles@^3.2.1:
+ version "3.2.1"
+ resolved "https://registry.yarnpkg.com/ansi-styles/-/ansi-styles-3.2.1.tgz#41fbb20243e50b12be0f04b8dedbf07520ce841d"
+ integrity sha512-VT0ZI6kZRdTh8YyJw3SMbYm/u+NqfsAxEpWO0Pf9sq8/e94WxxOpPKx9FR1FlyCtOVDNOQ+8ntlqFxiRc+r5qA==
+ dependencies:
+ color-convert "^1.9.0"
+
+ansi-styles@^4.0.0, ansi-styles@^4.1.0:
+ version "4.3.0"
+ resolved "https://registry.yarnpkg.com/ansi-styles/-/ansi-styles-4.3.0.tgz#edd803628ae71c04c85ae7a0906edad34b648937"
+ integrity sha512-zbB9rCJAT1rbjiVDb2hqKFHNYLxgtk8NURxZ3IZwD3F6NtxbXZQCnnSi1Lkx+IDohdPlFp222wVALIheZJQSEg==
+ dependencies:
+ color-convert "^2.0.1"
+
+ansi-styles@^5.0.0:
+ version "5.2.0"
+ resolved "https://registry.yarnpkg.com/ansi-styles/-/ansi-styles-5.2.0.tgz#07449690ad45777d1924ac2abb2fc8895dba836b"
+ integrity sha512-Cxwpt2SfTzTtXcfOlzGEee8O+c+MmUgGrNiBcXnuWxuFJHe6a5Hz7qwhwe5OgaSYI0IJvkLqWX1ASG+cJOkEiA==
+
+arch@^2.2.0:
+ version "2.2.0"
+ resolved "https://registry.yarnpkg.com/arch/-/arch-2.2.0.tgz#1bc47818f305764f23ab3306b0bfc086c5a29d11"
+ integrity sha512-Of/R0wqp83cgHozfIYLbBMnej79U/SVGOOyuB3VVFv1NRM/PSFMK12x9KVtiYzJqmnU5WR2qp0Z5rHb7sWGnFQ==
+
+argparse@^1.0.7:
+ version "1.0.10"
+ resolved "https://registry.yarnpkg.com/argparse/-/argparse-1.0.10.tgz#bcd6791ea5ae09725e17e5ad988134cd40b3d911"
+ integrity sha512-o5Roy6tNG4SL/FOkCAN6RzjiakZS25RLYFrcMttJqbdd8BWrnA+fGz57iN5Pb06pvBGvl5gQ0B48dJlslXvoTg==
+ dependencies:
+ sprintf-js "~1.0.2"
+
+aria-query@^5.0.0:
+ version "5.0.0"
+ resolved "https://registry.yarnpkg.com/aria-query/-/aria-query-5.0.0.tgz#210c21aaf469613ee8c9a62c7f86525e058db52c"
+ integrity sha512-V+SM7AbUwJ+EBnB8+DXs0hPZHO0W6pqBcc0dW90OwtVG02PswOu/teuARoLQjdDOH+t9pJgGnW5/Qmouf3gPJg==
+
+array-includes@^3.1.3, array-includes@^3.1.5:
+ version "3.1.5"
+ resolved "https://registry.yarnpkg.com/array-includes/-/array-includes-3.1.5.tgz#2c320010db8d31031fd2a5f6b3bbd4b1aad31bdb"
+ integrity sha512-iSDYZMMyTPkiFasVqfuAQnWAYcvO/SeBSCGKePoEthjp4LEMTe4uLc7b025o4jAZpHhihh8xPo99TNWUWWkGDQ==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.4"
+ es-abstract "^1.19.5"
+ get-intrinsic "^1.1.1"
+ is-string "^1.0.7"
+
+array-union@^2.1.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/array-union/-/array-union-2.1.0.tgz#b798420adbeb1de828d84acd8a2e23d3efe85e8d"
+ integrity sha512-HGyxoOTYUyCM6stUe6EJgnd4EoewAI7zMdfqO+kGjnlZmBDz/cR5pf8r/cR4Wq60sL/p0IkcjUEEPwS3GFrIyw==
+
+array.prototype.flatmap@^1.2.4:
+ version "1.3.0"
+ resolved "https://registry.yarnpkg.com/array.prototype.flatmap/-/array.prototype.flatmap-1.3.0.tgz#a7e8ed4225f4788a70cd910abcf0791e76a5534f"
+ integrity sha512-PZC9/8TKAIxcWKdyeb77EzULHPrIX/tIZebLJUQOMR1OwYosT8yggdfWScfTBCDj5utONvOuPQQumYsU2ULbkg==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ es-abstract "^1.19.2"
+ es-shim-unscopables "^1.0.0"
+
+asn1@~0.2.3:
+ version "0.2.6"
+ resolved "https://registry.yarnpkg.com/asn1/-/asn1-0.2.6.tgz#0d3a7bb6e64e02a90c0303b31f292868ea09a08d"
+ integrity sha512-ix/FxPn0MDjeyJ7i/yoHGFt/EX6LyNbxSEhPPXODPL+KB0VPk86UYfL0lMdy+KCnv+fmvIzySwaK5COwqVbWTQ==
+ dependencies:
+ safer-buffer "~2.1.0"
+
[email protected], assert-plus@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/assert-plus/-/assert-plus-1.0.0.tgz#f12e0f3c5d77b0b1cdd9146942e4e96c1e4dd525"
+ integrity sha512-NfJ4UzBCcQGLDlQq7nHxH+tv3kyZ0hHQqF5BO6J7tNJeP5do1llPr8dZ8zHonfhAu0PHAdMkSo+8o0wxg9lZWw==
+
+astral-regex@^2.0.0:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/astral-regex/-/astral-regex-2.0.0.tgz#483143c567aeed4785759c0865786dc77d7d2e31"
+ integrity sha512-Z7tMw1ytTXt5jqMcOP+OQteU1VuNK9Y02uuJtKQ1Sv69jXQKKg5cibLwGJow8yzZP+eAc18EmLGPal0bp36rvQ==
+
+async@^3.2.0:
+ version "3.2.4"
+ resolved "https://registry.yarnpkg.com/async/-/async-3.2.4.tgz#2d22e00f8cddeb5fde5dd33522b56d1cf569a81c"
+ integrity sha512-iAB+JbDEGXhyIUavoDl9WP/Jj106Kz9DEn1DPgYw5ruDn0e3Wgi3sKFm55sASdGBNOQB8F59d9qQ7deqrHA8wQ==
+
+asynckit@^0.4.0:
+ version "0.4.0"
+ resolved "https://registry.yarnpkg.com/asynckit/-/asynckit-0.4.0.tgz#c79ed97f7f34cb8f2ba1bc9790bcc366474b4b79"
+ integrity sha512-Oei9OH4tRh0YqU3GxhX79dM/mwVgvbZJaSNaRk+bshkj0S5cfHcgYakreBjrHwatXKbz+IoIdYLxrKim2MjW0Q==
+
+at-least-node@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/at-least-node/-/at-least-node-1.0.0.tgz#602cd4b46e844ad4effc92a8011a3c46e0238dc2"
+ integrity sha512-+q/t7Ekv1EDY2l6Gda6LLiX14rU9TV20Wa3ofeQmwPFZbOMo9DXrLbOjFaaclkXKWidIaopwAObQDqwWtGUjqg==
+
+aws-sign2@~0.7.0:
+ version "0.7.0"
+ resolved "https://registry.yarnpkg.com/aws-sign2/-/aws-sign2-0.7.0.tgz#b46e890934a9591f2d2f6f86d7e6a9f1b3fe76a8"
+ integrity sha512-08kcGqnYf/YmjoRhfxyu+CLxBjUtHLXLXX/vUfx9l2LYzG3c1m61nrpyFUZI6zeS+Li/wWMMidD9KgrqtGq3mA==
+
+aws4@^1.8.0:
+ version "1.11.0"
+ resolved "https://registry.yarnpkg.com/aws4/-/aws4-1.11.0.tgz#d61f46d83b2519250e2784daf5b09479a8b41c59"
+ integrity sha512-xh1Rl34h6Fi1DC2WWKfxUTVqRsNnr6LsKz2+hfwDxQJWmrx8+c7ylaqBMcHfl1U1r2dsifOvKX3LQuLNZ+XSvA==
+
+balanced-match@^1.0.0:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/balanced-match/-/balanced-match-1.0.2.tgz#e83e3a7e3f300b34cb9d87f615fa0cbf357690ee"
+ integrity sha512-3oSeUO0TMV67hN1AmbXsK4yaqU7tjiHlbxRDZOpH0KW9+CeX4bRAaX0Anxt0tx2MrpRpWwQaPwIlISEJhYU5Pw==
+
+base64-js@^1.3.1:
+ version "1.5.1"
+ resolved "https://registry.yarnpkg.com/base64-js/-/base64-js-1.5.1.tgz#1b1b440160a5bf7ad40b650f095963481903930a"
+ integrity sha512-AKpaYlHn8t4SVbOHCy+b5+KKgvR4vrsD8vbvrbiQJps7fKDTkjkDry6ji0rUJjC0kzbNePLwzxq8iypo41qeWA==
+
+bcrypt-pbkdf@^1.0.0:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/bcrypt-pbkdf/-/bcrypt-pbkdf-1.0.2.tgz#a4301d389b6a43f9b67ff3ca11a3f6637e360e9e"
+ integrity sha512-qeFIXtP4MSoi6NLqO12WfqARWWuCKi2Rn/9hJLEmtB5yTNr9DqFWkJRCf2qShWzPeAMRnOgCrq0sg/KLv5ES9w==
+ dependencies:
+ tweetnacl "^0.14.3"
+
+blob-util@^2.0.2:
+ version "2.0.2"
+ resolved "https://registry.yarnpkg.com/blob-util/-/blob-util-2.0.2.tgz#3b4e3c281111bb7f11128518006cdc60b403a1eb"
+ integrity sha512-T7JQa+zsXXEa6/8ZhHcQEW1UFfVM49Ts65uBkFL6fz2QmrElqmbajIDJvuA0tEhRe5eIjpV9ZF+0RfZR9voJFQ==
+
+bluebird@^3.7.2:
+ version "3.7.2"
+ resolved "https://registry.yarnpkg.com/bluebird/-/bluebird-3.7.2.tgz#9f229c15be272454ffa973ace0dbee79a1b0c36f"
+ integrity sha512-XpNj6GDQzdfW+r2Wnn7xiSAd7TM3jzkxGXBGTtWKuSXv1xUV+azxAm8jdWZN06QTQk+2N2XB9jRDkvbmQmcRtg==
+
+brace-expansion@^1.1.7:
+ version "1.1.11"
+ resolved "https://registry.yarnpkg.com/brace-expansion/-/brace-expansion-1.1.11.tgz#3c7fcbf529d87226f3d2f52b966ff5271eb441dd"
+ integrity sha512-iCuPHDFgrHX7H2vEI/5xpz07zSHB00TpugqhmYtVmMO6518mCuRMoOYFldEBl0g187ufozdaHgWKcYFb61qGiA==
+ dependencies:
+ balanced-match "^1.0.0"
+ concat-map "0.0.1"
+
+braces@^3.0.2:
+ version "3.0.2"
+ resolved "https://registry.yarnpkg.com/braces/-/braces-3.0.2.tgz#3454e1a462ee8d599e236df336cd9ea4f8afe107"
+ integrity sha512-b8um+L1RzM3WDSzvhm6gIz1yfTbBt6YTlcEKAvsmqCZZFw46z626lVj9j1yEPW33H5H+lBQpZMP1k8l+78Ha0A==
+ dependencies:
+ fill-range "^7.0.1"
+
+buffer-crc32@~0.2.3:
+ version "0.2.13"
+ resolved "https://registry.yarnpkg.com/buffer-crc32/-/buffer-crc32-0.2.13.tgz#0d333e3f00eac50aa1454abd30ef8c2a5d9a7242"
+ integrity sha512-VO9Ht/+p3SN7SKWqcrgEzjGbRSJYTx+Q1pTQC0wrWqHx0vpJraQ6GtHx8tvcg1rlK1byhU5gccxgOgj7B0TDkQ==
+
+buffer@^5.6.0:
+ version "5.7.1"
+ resolved "https://registry.yarnpkg.com/buffer/-/buffer-5.7.1.tgz#ba62e7c13133053582197160851a8f648e99eed0"
+ integrity sha512-EHcyIPBQ4BSGlvjB16k5KgAJ27CIsHY/2JBmCRReo48y9rQ3MaUzWX3KVlBa4U7MyX02HdVj0K7C3WaB3ju7FQ==
+ dependencies:
+ base64-js "^1.3.1"
+ ieee754 "^1.1.13"
+
+cachedir@^2.3.0:
+ version "2.3.0"
+ resolved "https://registry.yarnpkg.com/cachedir/-/cachedir-2.3.0.tgz#0c75892a052198f0b21c7c1804d8331edfcae0e8"
+ integrity sha512-A+Fezp4zxnit6FanDmv9EqXNAi3vt9DWp51/71UEhXukb7QUuvtv9344h91dyAxuTLoSYJFU299qzR3tzwPAhw==
+
+call-bind@^1.0.0, call-bind@^1.0.2:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/call-bind/-/call-bind-1.0.2.tgz#b1d4e89e688119c3c9a903ad30abb2f6a919be3c"
+ integrity sha512-7O+FbCihrB5WGbFYesctwmTKae6rOiIzmz1icreWJ+0aA7LJfuqhEso2T9ncpcFtzMQtzXf2QGGueWJGTYsqrA==
+ dependencies:
+ function-bind "^1.1.1"
+ get-intrinsic "^1.0.2"
+
+callsites@^3.0.0:
+ version "3.1.0"
+ resolved "https://registry.yarnpkg.com/callsites/-/callsites-3.1.0.tgz#b3630abd8943432f54b3f0519238e33cd7df2f73"
+ integrity sha512-P8BjAsXvZS+VIDUI11hHCQEv74YT67YUi5JJFNWIqL235sBmjX4+qx9Muvls5ivyNENctx46xQLQ3aTuE7ssaQ==
+
+caseless@~0.12.0:
+ version "0.12.0"
+ resolved "https://registry.yarnpkg.com/caseless/-/caseless-0.12.0.tgz#1b681c21ff84033c826543090689420d187151dc"
+ integrity sha512-4tYFyifaFfGacoiObjJegolkwSU4xQNGbVgUiNYVUxbQ2x2lUsFvY4hVgVzGiIe6WLOPqycWXA40l+PWsxthUw==
+
+chalk@^2.0.0:
+ version "2.4.2"
+ resolved "https://registry.yarnpkg.com/chalk/-/chalk-2.4.2.tgz#cd42541677a54333cf541a49108c1432b44c9424"
+ integrity sha512-Mti+f9lpJNcwF4tWV8/OrTTtF1gZi+f8FqlyAdouralcFWFQWF2+NgCHShjkCb+IFBLq9buZwE1xckQU4peSuQ==
+ dependencies:
+ ansi-styles "^3.2.1"
+ escape-string-regexp "^1.0.5"
+ supports-color "^5.3.0"
+
+chalk@^4.0.0, chalk@^4.1.0:
+ version "4.1.2"
+ resolved "https://registry.yarnpkg.com/chalk/-/chalk-4.1.2.tgz#aac4e2b7734a740867aeb16bf02aad556a1e7a01"
+ integrity sha512-oKnbhFyRIXpUuez8iBMmyEa4nbj4IOQyuhc/wy9kY7/WVPcwIO9VA668Pu8RkO7+0G76SLROeyw9CpQ061i4mA==
+ dependencies:
+ ansi-styles "^4.1.0"
+ supports-color "^7.1.0"
+
+check-more-types@^2.24.0:
+ version "2.24.0"
+ resolved "https://registry.yarnpkg.com/check-more-types/-/check-more-types-2.24.0.tgz#1420ffb10fd444dcfc79b43891bbfffd32a84600"
+ integrity sha512-Pj779qHxV2tuapviy1bSZNEL1maXr13bPYpsvSDB68HlYcYuhlDrmGd63i0JHMCLKzc7rUSNIrpdJlhVlNwrxA==
+
+ci-info@^3.2.0:
+ version "3.3.2"
+ resolved "https://registry.yarnpkg.com/ci-info/-/ci-info-3.3.2.tgz#6d2967ffa407466481c6c90b6e16b3098f080128"
+ integrity sha512-xmDt/QIAdeZ9+nfdPsaBCpMvHNLFiLdjj59qjqn+6iPe6YmHGQ35sBnQ8uslRBXFmXkiZQOJRjvQeoGppoTjjg==
+
+clean-stack@^2.0.0:
+ version "2.2.0"
+ resolved "https://registry.yarnpkg.com/clean-stack/-/clean-stack-2.2.0.tgz#ee8472dbb129e727b31e8a10a427dee9dfe4008b"
+ integrity sha512-4diC9HaTE+KRAMWhDhrGOECgWZxoevMc5TlkObMqNSsVU62PYzXZ/SMTjzyGAFF1YusgxGcSWTEXBhp0CPwQ1A==
+
+cli-cursor@^3.1.0:
+ version "3.1.0"
+ resolved "https://registry.yarnpkg.com/cli-cursor/-/cli-cursor-3.1.0.tgz#264305a7ae490d1d03bf0c9ba7c925d1753af307"
+ integrity sha512-I/zHAwsKf9FqGoXM4WWRACob9+SNukZTd94DWF57E4toouRulbCxcUh6RKUEOQlYTHJnzkPMySvPNaaSLNfLZw==
+ dependencies:
+ restore-cursor "^3.1.0"
+
+cli-table3@~0.6.1:
+ version "0.6.2"
+ resolved "https://registry.yarnpkg.com/cli-table3/-/cli-table3-0.6.2.tgz#aaf5df9d8b5bf12634dc8b3040806a0c07120d2a"
+ integrity sha512-QyavHCaIC80cMivimWu4aWHilIpiDpfm3hGmqAmXVL1UsnbLuBSMd21hTX6VY4ZSDSM73ESLeF8TOYId3rBTbw==
+ dependencies:
+ string-width "^4.2.0"
+ optionalDependencies:
+ "@colors/colors" "1.5.0"
+
+cli-truncate@^2.1.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/cli-truncate/-/cli-truncate-2.1.0.tgz#c39e28bf05edcde5be3b98992a22deed5a2b93c7"
+ integrity sha512-n8fOixwDD6b/ObinzTrp1ZKFzbgvKZvuz/TvejnLn1aQfC6r52XEx85FmuC+3HI+JM7coBRXUvNqEU2PHVrHpg==
+ dependencies:
+ slice-ansi "^3.0.0"
+ string-width "^4.2.0"
+
+color-convert@^1.9.0:
+ version "1.9.3"
+ resolved "https://registry.yarnpkg.com/color-convert/-/color-convert-1.9.3.tgz#bb71850690e1f136567de629d2d5471deda4c1e8"
+ integrity sha512-QfAUtd+vFdAtFQcC8CCyYt1fYWxSqAiK2cSD6zDB8N3cpsEBAvRxp9zOGg6G/SHHJYAT88/az/IuDGALsNVbGg==
+ dependencies:
+ color-name "1.1.3"
+
+color-convert@^2.0.1:
+ version "2.0.1"
+ resolved "https://registry.yarnpkg.com/color-convert/-/color-convert-2.0.1.tgz#72d3a68d598c9bdb3af2ad1e84f21d896abd4de3"
+ integrity sha512-RRECPsj7iu/xb5oKYcsFHSppFNnsj/52OVTRKb4zP5onXwVF3zVmmToNcOfGC+CRDpfK/U584fMg38ZHCaElKQ==
+ dependencies:
+ color-name "~1.1.4"
+
[email protected]:
+ version "1.1.3"
+ resolved "https://registry.yarnpkg.com/color-name/-/color-name-1.1.3.tgz#a7d0558bd89c42f795dd42328f740831ca53bc25"
+ integrity sha512-72fSenhMw2HZMTVHeCA9KCmpEIbzWiQsjN+BHcBbS9vr1mtt+vJjPdksIBNUmKAW8TFUDPJK5SUU3QhE9NEXDw==
+
+color-name@~1.1.4:
+ version "1.1.4"
+ resolved "https://registry.yarnpkg.com/color-name/-/color-name-1.1.4.tgz#c2a09a87acbde69543de6f63fa3995c826c536a2"
+ integrity sha512-dOy+3AuW3a2wNbZHIuMZpTcgjGuLU/uBL/ubcZF9OXbDo8ff4O8yVp5Bf0efS8uEoYo5q4Fx7dY9OgQGXgAsQA==
+
+colorette@^2.0.16:
+ version "2.0.19"
+ resolved "https://registry.yarnpkg.com/colorette/-/colorette-2.0.19.tgz#cdf044f47ad41a0f4b56b3a0d5b4e6e1a2d5a798"
+ integrity sha512-3tlv/dIP7FWvj3BsbHrGLJ6l/oKh1O3TcgBqMn+yyCagOxc23fyzDS6HypQbgxWbkpDnf52p1LuR4eWDQ/K9WQ==
+
+combined-stream@^1.0.6, combined-stream@~1.0.6:
+ version "1.0.8"
+ resolved "https://registry.yarnpkg.com/combined-stream/-/combined-stream-1.0.8.tgz#c3d45a8b34fd730631a110a8a2520682b31d5a7f"
+ integrity sha512-FQN4MRfuJeHf7cBbBMJFXhKSDq+2kAArBlmRBvcvFE5BB1HZKXtSFASDhdlz9zOYwxh8lDdnvmMOe/+5cdoEdg==
+ dependencies:
+ delayed-stream "~1.0.0"
+
+commander@^5.1.0:
+ version "5.1.0"
+ resolved "https://registry.yarnpkg.com/commander/-/commander-5.1.0.tgz#46abbd1652f8e059bddaef99bbdcb2ad9cf179ae"
+ integrity sha512-P0CysNDQ7rtVw4QIQtm+MRxV66vKFSvlsQvGYXZWR3qFU0jlMKHZZZgw8e+8DSah4UDKMqnknRDQz+xuQXQ/Zg==
+
+common-tags@^1.8.0:
+ version "1.8.2"
+ resolved "https://registry.yarnpkg.com/common-tags/-/common-tags-1.8.2.tgz#94ebb3c076d26032745fd54face7f688ef5ac9c6"
+ integrity sha512-gk/Z852D2Wtb//0I+kRFNKKE9dIIVirjoqPoA1wJU+XePVXZfGeBpk45+A1rKO4Q43prqWBNY/MiIeRLbPWUaA==
+
[email protected]:
+ version "0.0.1"
+ resolved "https://registry.yarnpkg.com/concat-map/-/concat-map-0.0.1.tgz#d8a96bd77fd68df7793a73036a3ba0d5405d477b"
+ integrity sha512-/Srv4dswyQNBfohGpz9o6Yb3Gz3SrUDqBH5rTuhGR7ahtlbYKnVxw2bCFMRljaA7EXHaXZ8wsHdodFvbkhKmqg==
+
[email protected]:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/core-util-is/-/core-util-is-1.0.2.tgz#b5fd54220aa2bc5ab57aab7140c940754503c1a7"
+ integrity sha512-3lqz5YjWTYnW6dlDa5TLaTCcShfar1e40rmcJVwCBJC6mWlFuj0eCHIElmG1g5kyuJ/GD+8Wn4FFCcz4gJPfaQ==
+
+cross-spawn@^7.0.0, cross-spawn@^7.0.2:
+ version "7.0.3"
+ resolved "https://registry.yarnpkg.com/cross-spawn/-/cross-spawn-7.0.3.tgz#f73a85b9d5d41d045551c177e2882d4ac85728a6"
+ integrity sha512-iRDPJKUPVEND7dHPO8rkbOnPpyDygcDFtWjpeWNCgy8WP2rXcxXL8TskReQl6OrB2G7+UJrags1q15Fudc7G6w==
+ dependencies:
+ path-key "^3.1.0"
+ shebang-command "^2.0.0"
+ which "^2.0.1"
+
+cypress@^10.3.0:
+ version "10.3.1"
+ resolved "https://registry.yarnpkg.com/cypress/-/cypress-10.3.1.tgz#7fab4ef43481c05a9a17ebe9a0ec860e15b95a19"
+ integrity sha512-As9HrExjAgpgjCnbiQCuPdw5sWKx5HUJcK2EOKziu642akwufr/GUeqL5UnCPYXTyyibvEdWT/pSC2qnGW/e5w==
+ dependencies:
+ "@cypress/request" "^2.88.10"
+ "@cypress/xvfb" "^1.2.4"
+ "@types/node" "^14.14.31"
+ "@types/sinonjs__fake-timers" "8.1.1"
+ "@types/sizzle" "^2.3.2"
+ arch "^2.2.0"
+ blob-util "^2.0.2"
+ bluebird "^3.7.2"
+ buffer "^5.6.0"
+ cachedir "^2.3.0"
+ chalk "^4.1.0"
+ check-more-types "^2.24.0"
+ cli-cursor "^3.1.0"
+ cli-table3 "~0.6.1"
+ commander "^5.1.0"
+ common-tags "^1.8.0"
+ dayjs "^1.10.4"
+ debug "^4.3.2"
+ enquirer "^2.3.6"
+ eventemitter2 "^6.4.3"
+ execa "4.1.0"
+ executable "^4.1.1"
+ extract-zip "2.0.1"
+ figures "^3.2.0"
+ fs-extra "^9.1.0"
+ getos "^3.2.1"
+ is-ci "^3.0.0"
+ is-installed-globally "~0.4.0"
+ lazy-ass "^1.6.0"
+ listr2 "^3.8.3"
+ lodash "^4.17.21"
+ log-symbols "^4.0.0"
+ minimist "^1.2.6"
+ ospath "^1.2.2"
+ pretty-bytes "^5.6.0"
+ proxy-from-env "1.0.0"
+ request-progress "^3.0.0"
+ semver "^7.3.2"
+ supports-color "^8.1.1"
+ tmp "~0.2.1"
+ untildify "^4.0.0"
+ yauzl "^2.10.0"
+
+dashdash@^1.12.0:
+ version "1.14.1"
+ resolved "https://registry.yarnpkg.com/dashdash/-/dashdash-1.14.1.tgz#853cfa0f7cbe2fed5de20326b8dd581035f6e2f0"
+ integrity sha512-jRFi8UDGo6j+odZiEpjazZaWqEal3w/basFjQHQEwVtZJGDpxbH1MeYluwCS8Xq5wmLJooDlMgvVarmWfGM44g==
+ dependencies:
+ assert-plus "^1.0.0"
+
+dayjs@^1.10.4:
+ version "1.11.4"
+ resolved "https://registry.yarnpkg.com/dayjs/-/dayjs-1.11.4.tgz#3b3c10ca378140d8917e06ebc13a4922af4f433e"
+ integrity sha512-Zj/lPM5hOvQ1Bf7uAvewDaUcsJoI6JmNqmHhHl3nyumwe0XHwt8sWdOVAPACJzCebL8gQCi+K49w7iKWnGwX9g==
+
+debug@^3.1.0:
+ version "3.2.7"
+ resolved "https://registry.yarnpkg.com/debug/-/debug-3.2.7.tgz#72580b7e9145fb39b6676f9c5e5fb100b934179a"
+ integrity sha512-CFjzYYAi4ThfiQvizrFQevTTXHtnCqWfe7x1AhgEscTz6ZbLbfoLRLPugTQyBth6f8ZERVUSyWHFD/7Wu4t1XQ==
+ dependencies:
+ ms "^2.1.1"
+
+debug@^4.0.1, debug@^4.1.1, debug@^4.3.1, debug@^4.3.2:
+ version "4.3.4"
+ resolved "https://registry.yarnpkg.com/debug/-/debug-4.3.4.tgz#1319f6579357f2338d3337d2cdd4914bb5dcc865"
+ integrity sha512-PRWFHuSU3eDtQJPvnNY7Jcket1j0t5OuOsFzPPzsekD52Zl8qUfFIPEiswXqIvHWGVHOgX+7G/vCNNhehwxfkQ==
+ dependencies:
+ ms "2.1.2"
+
+deep-is@^0.1.3:
+ version "0.1.4"
+ resolved "https://registry.yarnpkg.com/deep-is/-/deep-is-0.1.4.tgz#a6f2dce612fadd2ef1f519b73551f17e85199831"
+ integrity sha512-oIPzksmTg4/MriiaYGO+okXDT7ztn/w3Eptv/+gSIdMdKsJo0u4CfYNFJPy+4SKMuCqGw2wxnA+URMg3t8a/bQ==
+
+define-properties@^1.1.3, define-properties@^1.1.4:
+ version "1.1.4"
+ resolved "https://registry.yarnpkg.com/define-properties/-/define-properties-1.1.4.tgz#0b14d7bd7fbeb2f3572c3a7eda80ea5d57fb05b1"
+ integrity sha512-uckOqKcfaVvtBdsVkdPv3XjveQJsNQqmhXgRi8uhvWWuPYZCNlzT8qAyblUgNoXdHdjMTzAqeGjAoli8f+bzPA==
+ dependencies:
+ has-property-descriptors "^1.0.0"
+ object-keys "^1.1.1"
+
+delayed-stream@~1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/delayed-stream/-/delayed-stream-1.0.0.tgz#df3ae199acadfb7d440aaae0b29e2272b24ec619"
+ integrity sha512-ZySD7Nf91aLB0RxL4KGrKHBXl7Eds1DAmEdcoVawXnLD7SDhpNgtuII2aAkg7a7QS41jxPSZ17p4VdGnMHk3MQ==
+
+dir-glob@^3.0.1:
+ version "3.0.1"
+ resolved "https://registry.yarnpkg.com/dir-glob/-/dir-glob-3.0.1.tgz#56dbf73d992a4a93ba1584f4534063fd2e41717f"
+ integrity sha512-WkrWp9GR4KXfKGYzOLmTuGVi1UWFfws377n9cc55/tb6DuqyF6pcQ5AbiHEshaDpY9v6oaSr2XCDidGmMwdzIA==
+ dependencies:
+ path-type "^4.0.0"
+
+doctrine@^2.1.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/doctrine/-/doctrine-2.1.0.tgz#5cd01fc101621b42c4cd7f5d1a66243716d3f39d"
+ integrity sha512-35mSku4ZXK0vfCuHEDAwt55dg2jNajHZ1odvF+8SSr82EsZY4QmXfuWso8oEd8zRhVObSN18aM0CjSdoBX7zIw==
+ dependencies:
+ esutils "^2.0.2"
+
+doctrine@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/doctrine/-/doctrine-3.0.0.tgz#addebead72a6574db783639dc87a121773973961"
+ integrity sha512-yS+Q5i3hBf7GBkd4KG8a7eBNNWNGLTaEwwYWUijIYM7zrlYDM0BFXHjjPWlWZ1Rg7UaddZeIDmi9jF3HmqiQ2w==
+ dependencies:
+ esutils "^2.0.2"
+
+dom-accessibility-api@^0.5.9:
+ version "0.5.14"
+ resolved "https://registry.yarnpkg.com/dom-accessibility-api/-/dom-accessibility-api-0.5.14.tgz#56082f71b1dc7aac69d83c4285eef39c15d93f56"
+ integrity sha512-NMt+m9zFMPZe0JcY9gN224Qvk6qLIdqex29clBvc/y75ZBX9YA9wNK3frsYvu2DI1xcCIwxwnX+TlsJ2DSOADg==
+
+ecc-jsbn@~0.1.1:
+ version "0.1.2"
+ resolved "https://registry.yarnpkg.com/ecc-jsbn/-/ecc-jsbn-0.1.2.tgz#3a83a904e54353287874c564b7549386849a98c9"
+ integrity sha512-eh9O+hwRHNbG4BLTjEl3nw044CkGm5X6LoaCf7LPp7UU8Qrt47JYNi6nPX8xjW97TKGKm1ouctg0QSpZe9qrnw==
+ dependencies:
+ jsbn "~0.1.0"
+ safer-buffer "^2.1.0"
+
+emoji-regex@^8.0.0:
+ version "8.0.0"
+ resolved "https://registry.yarnpkg.com/emoji-regex/-/emoji-regex-8.0.0.tgz#e818fd69ce5ccfcb404594f842963bf53164cc37"
+ integrity sha512-MSjYzcWNOA0ewAHpz0MxpYFvwg6yjy1NG3xteoqz644VCo/RPgnr1/GGt+ic3iJTzQ8Eu3TdM14SawnVUmGE6A==
+
+end-of-stream@^1.1.0:
+ version "1.4.4"
+ resolved "https://registry.yarnpkg.com/end-of-stream/-/end-of-stream-1.4.4.tgz#5ae64a5f45057baf3626ec14da0ca5e4b2431eb0"
+ integrity sha512-+uw1inIHVPQoaVuHzRyXd21icM+cnt4CzD5rW+NC1wjOUSTOs+Te7FOv7AhN7vS9x/oIyhLP5PR1H+phQAHu5Q==
+ dependencies:
+ once "^1.4.0"
+
+enquirer@^2.3.5, enquirer@^2.3.6:
+ version "2.3.6"
+ resolved "https://registry.yarnpkg.com/enquirer/-/enquirer-2.3.6.tgz#2a7fe5dd634a1e4125a975ec994ff5456dc3734d"
+ integrity sha512-yjNnPr315/FjS4zIsUxYguYUPP2e1NK4d7E7ZOLiyYCcbFBiTMyID+2wvm2w6+pZ/odMA7cRkjhsPbltwBOrLg==
+ dependencies:
+ ansi-colors "^4.1.1"
+
+es-abstract@^1.19.0, es-abstract@^1.19.1, es-abstract@^1.19.2, es-abstract@^1.19.5:
+ version "1.20.1"
+ resolved "https://registry.yarnpkg.com/es-abstract/-/es-abstract-1.20.1.tgz#027292cd6ef44bd12b1913b828116f54787d1814"
+ integrity sha512-WEm2oBhfoI2sImeM4OF2zE2V3BYdSF+KnSi9Sidz51fQHd7+JuF8Xgcj9/0o+OWeIeIS/MiuNnlruQrJf16GQA==
+ dependencies:
+ call-bind "^1.0.2"
+ es-to-primitive "^1.2.1"
+ function-bind "^1.1.1"
+ function.prototype.name "^1.1.5"
+ get-intrinsic "^1.1.1"
+ get-symbol-description "^1.0.0"
+ has "^1.0.3"
+ has-property-descriptors "^1.0.0"
+ has-symbols "^1.0.3"
+ internal-slot "^1.0.3"
+ is-callable "^1.2.4"
+ is-negative-zero "^2.0.2"
+ is-regex "^1.1.4"
+ is-shared-array-buffer "^1.0.2"
+ is-string "^1.0.7"
+ is-weakref "^1.0.2"
+ object-inspect "^1.12.0"
+ object-keys "^1.1.1"
+ object.assign "^4.1.2"
+ regexp.prototype.flags "^1.4.3"
+ string.prototype.trimend "^1.0.5"
+ string.prototype.trimstart "^1.0.5"
+ unbox-primitive "^1.0.2"
+
+es-shim-unscopables@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/es-shim-unscopables/-/es-shim-unscopables-1.0.0.tgz#702e632193201e3edf8713635d083d378e510241"
+ integrity sha512-Jm6GPcCdC30eMLbZ2x8z2WuRwAws3zTBBKuusffYVUrNj/GVSUAZ+xKMaUpfNDR5IbyNA5LJbaecoUVbmUcB1w==
+ dependencies:
+ has "^1.0.3"
+
+es-to-primitive@^1.2.1:
+ version "1.2.1"
+ resolved "https://registry.yarnpkg.com/es-to-primitive/-/es-to-primitive-1.2.1.tgz#e55cd4c9cdc188bcefb03b366c736323fc5c898a"
+ integrity sha512-QCOllgZJtaUo9miYBcLChTUaHNjJF3PYs1VidD7AwiEj1kYxKeQTctLAezAOH5ZKRH0g2IgPn6KwB4IT8iRpvA==
+ dependencies:
+ is-callable "^1.1.4"
+ is-date-object "^1.0.1"
+ is-symbol "^1.0.2"
+
+escape-string-regexp@^1.0.5:
+ version "1.0.5"
+ resolved "https://registry.yarnpkg.com/escape-string-regexp/-/escape-string-regexp-1.0.5.tgz#1b61c0562190a8dff6ae3bb2cf0200ca130b86d4"
+ integrity sha512-vbRorB5FUQWvla16U8R/qgaFIya2qGzwDrNmCZuYKrbdSUMG6I1ZCGQRefkRVhuOkIGVne7BQ35DSfo1qvJqFg==
+
+escape-string-regexp@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/escape-string-regexp/-/escape-string-regexp-4.0.0.tgz#14ba83a5d373e3d311e5afca29cf5bfad965bf34"
+ integrity sha512-TtpcNJ3XAzx3Gq8sWRzJaVajRs0uVxA2YAkdb1jm2YkPz4G6egUFAyA3n5vtEIZefPk5Wa4UXbKuS5fKkJWdgA==
+
+eslint-config-prettier@^6.11.0:
+ version "6.15.0"
+ resolved "https://registry.yarnpkg.com/eslint-config-prettier/-/eslint-config-prettier-6.15.0.tgz#7f93f6cb7d45a92f1537a70ecc06366e1ac6fed9"
+ integrity sha512-a1+kOYLR8wMGustcgAjdydMsQ2A/2ipRPwRKUmfYaSxc9ZPcrku080Ctl6zrZzZNs/U82MjSv+qKREkoq3bJaw==
+ dependencies:
+ get-stdin "^6.0.0"
+
[email protected]:
+ version "3.4.0"
+ resolved "https://registry.yarnpkg.com/eslint-plugin-prettier/-/eslint-plugin-prettier-3.4.0.tgz#cdbad3bf1dbd2b177e9825737fe63b476a08f0c7"
+ integrity sha512-UDK6rJT6INSfcOo545jiaOwB701uAIt2/dR7WnFQoGCVl1/EMqdANBmwUaqqQ45aXprsTGzSa39LI1PyuRBxxw==
+ dependencies:
+ prettier-linter-helpers "^1.0.0"
+
[email protected]:
+ version "4.2.0"
+ resolved "https://registry.yarnpkg.com/eslint-plugin-react-hooks/-/eslint-plugin-react-hooks-4.2.0.tgz#8c229c268d468956334c943bb45fc860280f5556"
+ integrity sha512-623WEiZJqxR7VdxFCKLI6d6LLpwJkGPYKODnkH3D7WpOG5KM8yWueBd8TLsNAetEJNF5iJmolaAKO3F8yzyVBQ==
+
[email protected]:
+ version "7.24.0"
+ resolved "https://registry.yarnpkg.com/eslint-plugin-react/-/eslint-plugin-react-7.24.0.tgz#eadedfa351a6f36b490aa17f4fa9b14e842b9eb4"
+ integrity sha512-KJJIx2SYx7PBx3ONe/mEeMz4YE0Lcr7feJTCMyyKb/341NcjuAgim3Acgan89GfPv7nxXK2+0slu0CWXYM4x+Q==
+ dependencies:
+ array-includes "^3.1.3"
+ array.prototype.flatmap "^1.2.4"
+ doctrine "^2.1.0"
+ has "^1.0.3"
+ jsx-ast-utils "^2.4.1 || ^3.0.0"
+ minimatch "^3.0.4"
+ object.entries "^1.1.4"
+ object.fromentries "^2.0.4"
+ object.values "^1.1.4"
+ prop-types "^15.7.2"
+ resolve "^2.0.0-next.3"
+ string.prototype.matchall "^4.0.5"
+
+eslint-scope@^5.0.0, eslint-scope@^5.1.1:
+ version "5.1.1"
+ resolved "https://registry.yarnpkg.com/eslint-scope/-/eslint-scope-5.1.1.tgz#e786e59a66cb92b3f6c1fb0d508aab174848f48c"
+ integrity sha512-2NxwbF/hZ0KpepYN0cNbo+FN6XoK7GaHlQhgx/hIZl6Va0bF45RQOOwhLIy8lQDbuCiadSLCBnH2CFYquit5bw==
+ dependencies:
+ esrecurse "^4.3.0"
+ estraverse "^4.1.1"
+
+eslint-utils@^2.0.0, eslint-utils@^2.1.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/eslint-utils/-/eslint-utils-2.1.0.tgz#d2de5e03424e707dc10c74068ddedae708741b27"
+ integrity sha512-w94dQYoauyvlDc43XnGB8lU3Zt713vNChgt4EWwhXAP2XkBvndfxF0AgIqKOOasjPIPzj9JqgwkwbCYD0/V3Zg==
+ dependencies:
+ eslint-visitor-keys "^1.1.0"
+
+eslint-utils@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/eslint-utils/-/eslint-utils-3.0.0.tgz#8aebaface7345bb33559db0a1f13a1d2d48c3672"
+ integrity sha512-uuQC43IGctw68pJA1RgbQS8/NP7rch6Cwd4j3ZBtgo4/8Flj4eGE7ZYSZRN3iq5pVUv6GPdW5Z1RFleo84uLDA==
+ dependencies:
+ eslint-visitor-keys "^2.0.0"
+
+eslint-visitor-keys@^1.1.0, eslint-visitor-keys@^1.3.0:
+ version "1.3.0"
+ resolved "https://registry.yarnpkg.com/eslint-visitor-keys/-/eslint-visitor-keys-1.3.0.tgz#30ebd1ef7c2fdff01c3a4f151044af25fab0523e"
+ integrity sha512-6J72N8UNa462wa/KFODt/PJ3IU60SDpC3QXC1Hjc1BXXpfL2C9R5+AU7jhe0F6GREqVMh4Juu+NY7xn+6dipUQ==
+
+eslint-visitor-keys@^2.0.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/eslint-visitor-keys/-/eslint-visitor-keys-2.1.0.tgz#f65328259305927392c938ed44eb0a5c9b2bd303"
+ integrity sha512-0rSmRBzXgDzIsD6mGdJgevzgezI534Cer5L/vyMX0kHzT/jiB43jRhd9YUlMGYLQy2zprNmoT8qasCGtY+QaKw==
+
[email protected]:
+ version "7.29.0"
+ resolved "https://registry.yarnpkg.com/eslint/-/eslint-7.29.0.tgz#ee2a7648f2e729485e4d0bd6383ec1deabc8b3c0"
+ integrity sha512-82G/JToB9qIy/ArBzIWG9xvvwL3R86AlCjtGw+A29OMZDqhTybz/MByORSukGxeI+YPCR4coYyITKk8BFH9nDA==
+ dependencies:
+ "@babel/code-frame" "7.12.11"
+ "@eslint/eslintrc" "^0.4.2"
+ ajv "^6.10.0"
+ chalk "^4.0.0"
+ cross-spawn "^7.0.2"
+ debug "^4.0.1"
+ doctrine "^3.0.0"
+ enquirer "^2.3.5"
+ escape-string-regexp "^4.0.0"
+ eslint-scope "^5.1.1"
+ eslint-utils "^2.1.0"
+ eslint-visitor-keys "^2.0.0"
+ espree "^7.3.1"
+ esquery "^1.4.0"
+ esutils "^2.0.2"
+ fast-deep-equal "^3.1.3"
+ file-entry-cache "^6.0.1"
+ functional-red-black-tree "^1.0.1"
+ glob-parent "^5.1.2"
+ globals "^13.6.0"
+ ignore "^4.0.6"
+ import-fresh "^3.0.0"
+ imurmurhash "^0.1.4"
+ is-glob "^4.0.0"
+ js-yaml "^3.13.1"
+ json-stable-stringify-without-jsonify "^1.0.1"
+ levn "^0.4.1"
+ lodash.merge "^4.6.2"
+ minimatch "^3.0.4"
+ natural-compare "^1.4.0"
+ optionator "^0.9.1"
+ progress "^2.0.0"
+ regexpp "^3.1.0"
+ semver "^7.2.1"
+ strip-ansi "^6.0.0"
+ strip-json-comments "^3.1.0"
+ table "^6.0.9"
+ text-table "^0.2.0"
+ v8-compile-cache "^2.0.3"
+
+espree@^7.3.0, espree@^7.3.1:
+ version "7.3.1"
+ resolved "https://registry.yarnpkg.com/espree/-/espree-7.3.1.tgz#f2df330b752c6f55019f8bd89b7660039c1bbbb6"
+ integrity sha512-v3JCNCE64umkFpmkFGqzVKsOT0tN1Zr+ueqLZfpV1Ob8e+CEgPWa+OxCoGH3tnhimMKIaBm4m/vaRpJ/krRz2g==
+ dependencies:
+ acorn "^7.4.0"
+ acorn-jsx "^5.3.1"
+ eslint-visitor-keys "^1.3.0"
+
+esprima@^4.0.0:
+ version "4.0.1"
+ resolved "https://registry.yarnpkg.com/esprima/-/esprima-4.0.1.tgz#13b04cdb3e6c5d19df91ab6987a8695619b0aa71"
+ integrity sha512-eGuFFw7Upda+g4p+QHvnW0RyTX/SVeJBDM/gCtMARO0cLuT2HcEKnTPvhjV6aGeqrCB/sbNop0Kszm0jsaWU4A==
+
+esquery@^1.4.0:
+ version "1.4.0"
+ resolved "https://registry.yarnpkg.com/esquery/-/esquery-1.4.0.tgz#2148ffc38b82e8c7057dfed48425b3e61f0f24a5"
+ integrity sha512-cCDispWt5vHHtwMY2YrAQ4ibFkAL8RbH5YGBnZBc90MolvvfkkQcJro/aZiAQUlQ3qgrYS6D6v8Gc5G5CQsc9w==
+ dependencies:
+ estraverse "^5.1.0"
+
+esrecurse@^4.3.0:
+ version "4.3.0"
+ resolved "https://registry.yarnpkg.com/esrecurse/-/esrecurse-4.3.0.tgz#7ad7964d679abb28bee72cec63758b1c5d2c9921"
+ integrity sha512-KmfKL3b6G+RXvP8N1vr3Tq1kL/oCFgn2NYXEtqP8/L3pKapUA4G8cFVaoF3SU323CD4XypR/ffioHmkti6/Tag==
+ dependencies:
+ estraverse "^5.2.0"
+
+estraverse@^4.1.1:
+ version "4.3.0"
+ resolved "https://registry.yarnpkg.com/estraverse/-/estraverse-4.3.0.tgz#398ad3f3c5a24948be7725e83d11a7de28cdbd1d"
+ integrity sha512-39nnKffWz8xN1BU/2c79n9nB9HDzo0niYUqx6xyqUnyoAnQyyWpOTdZEeiCch8BBu515t4wp9ZmgVfVhn9EBpw==
+
+estraverse@^5.1.0, estraverse@^5.2.0:
+ version "5.3.0"
+ resolved "https://registry.yarnpkg.com/estraverse/-/estraverse-5.3.0.tgz#2eea5290702f26ab8fe5370370ff86c965d21123"
+ integrity sha512-MMdARuVEQziNTeJD8DgMqmhwR11BRQ/cBP+pLtYdSTnf3MIO8fFeiINEbX36ZdNlfU/7A9f3gUw49B3oQsvwBA==
+
+esutils@^2.0.2:
+ version "2.0.3"
+ resolved "https://registry.yarnpkg.com/esutils/-/esutils-2.0.3.tgz#74d2eb4de0b8da1293711910d50775b9b710ef64"
+ integrity sha512-kVscqXk4OCp68SZ0dkgEKVi6/8ij300KBWTJq32P/dYeWTSwK41WyTxalN1eRmA5Z9UU/LX9D7FWSmV9SAYx6g==
+
+eventemitter2@^6.4.3:
+ version "6.4.6"
+ resolved "https://registry.yarnpkg.com/eventemitter2/-/eventemitter2-6.4.6.tgz#92d56569cc147a4d9b9da9e942e89b20ce236b0a"
+ integrity sha512-OHqo4wbHX5VbvlbB6o6eDwhYmiTjrpWACjF8Pmof/GTD6rdBNdZFNck3xlhqOiQFGCOoq3uzHvA0cQpFHIGVAQ==
+
[email protected]:
+ version "4.1.0"
+ resolved "https://registry.yarnpkg.com/execa/-/execa-4.1.0.tgz#4e5491ad1572f2f17a77d388c6c857135b22847a"
+ integrity sha512-j5W0//W7f8UxAn8hXVnwG8tLwdiUy4FJLcSupCg6maBYZDpyBvTApK7KyuI4bKj8KOh1r2YH+6ucuYtJv1bTZA==
+ dependencies:
+ cross-spawn "^7.0.0"
+ get-stream "^5.0.0"
+ human-signals "^1.1.1"
+ is-stream "^2.0.0"
+ merge-stream "^2.0.0"
+ npm-run-path "^4.0.0"
+ onetime "^5.1.0"
+ signal-exit "^3.0.2"
+ strip-final-newline "^2.0.0"
+
+executable@^4.1.1:
+ version "4.1.1"
+ resolved "https://registry.yarnpkg.com/executable/-/executable-4.1.1.tgz#41532bff361d3e57af4d763b70582db18f5d133c"
+ integrity sha512-8iA79xD3uAch729dUG8xaaBBFGaEa0wdD2VkYLFHwlqosEj/jT66AzcreRDSgV7ehnNLBW2WR5jIXwGKjVdTLg==
+ dependencies:
+ pify "^2.2.0"
+
+extend@~3.0.2:
+ version "3.0.2"
+ resolved "https://registry.yarnpkg.com/extend/-/extend-3.0.2.tgz#f8b1136b4071fbd8eb140aff858b1019ec2915fa"
+ integrity sha512-fjquC59cD7CyW6urNXK0FBufkZcoiGG80wTuPujX590cB5Ttln20E2UB4S/WARVqhXffZl2LNgS+gQdPIIim/g==
+
[email protected]:
+ version "2.0.1"
+ resolved "https://registry.yarnpkg.com/extract-zip/-/extract-zip-2.0.1.tgz#663dca56fe46df890d5f131ef4a06d22bb8ba13a"
+ integrity sha512-GDhU9ntwuKyGXdZBUgTIe+vXnWj0fppUEtMDL0+idd5Sta8TGpHssn/eusA9mrPr9qNDym6SxAYZjNvCn/9RBg==
+ dependencies:
+ debug "^4.1.1"
+ get-stream "^5.1.0"
+ yauzl "^2.10.0"
+ optionalDependencies:
+ "@types/yauzl" "^2.9.1"
+
[email protected]:
+ version "1.3.0"
+ resolved "https://registry.yarnpkg.com/extsprintf/-/extsprintf-1.3.0.tgz#96918440e3041a7a414f8c52e3c574eb3c3e1e05"
+ integrity sha512-11Ndz7Nv+mvAC1j0ktTa7fAb0vLyGGX+rMHNBYQviQDGU0Hw7lhctJANqbPhu9nV9/izT/IntTgZ7Im/9LJs9g==
+
+extsprintf@^1.2.0:
+ version "1.4.1"
+ resolved "https://registry.yarnpkg.com/extsprintf/-/extsprintf-1.4.1.tgz#8d172c064867f235c0c84a596806d279bf4bcc07"
+ integrity sha512-Wrk35e8ydCKDj/ArClo1VrPVmN8zph5V4AtHwIuHhvMXsKf73UT3BOD+azBIW+3wOJ4FhEH7zyaJCFvChjYvMA==
+
+fast-deep-equal@^3.1.1, fast-deep-equal@^3.1.3:
+ version "3.1.3"
+ resolved "https://registry.yarnpkg.com/fast-deep-equal/-/fast-deep-equal-3.1.3.tgz#3a7d56b559d6cbc3eb512325244e619a65c6c525"
+ integrity sha512-f3qQ9oQy9j2AhBe/H9VC91wLmKBCCU/gDOnKNAYG5hswO7BLKj09Hc5HYNz9cGI++xlpDCIgDaitVs03ATR84Q==
+
+fast-diff@^1.1.2:
+ version "1.2.0"
+ resolved "https://registry.yarnpkg.com/fast-diff/-/fast-diff-1.2.0.tgz#73ee11982d86caaf7959828d519cfe927fac5f03"
+ integrity sha512-xJuoT5+L99XlZ8twedaRf6Ax2TgQVxvgZOYoPKqZufmJib0tL2tegPBOZb1pVNgIhlqDlA0eO0c3wBvQcmzx4w==
+
+fast-glob@^3.2.9:
+ version "3.2.11"
+ resolved "https://registry.yarnpkg.com/fast-glob/-/fast-glob-3.2.11.tgz#a1172ad95ceb8a16e20caa5c5e56480e5129c1d9"
+ integrity sha512-xrO3+1bxSo3ZVHAnqzyuewYT6aMFHRAd4Kcs92MAonjwQZLsK9d0SF1IyQ3k5PoirxTW0Oe/RqFgMQ6TcNE5Ew==
+ dependencies:
+ "@nodelib/fs.stat" "^2.0.2"
+ "@nodelib/fs.walk" "^1.2.3"
+ glob-parent "^5.1.2"
+ merge2 "^1.3.0"
+ micromatch "^4.0.4"
+
+fast-json-stable-stringify@^2.0.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/fast-json-stable-stringify/-/fast-json-stable-stringify-2.1.0.tgz#874bf69c6f404c2b5d99c481341399fd55892633"
+ integrity sha512-lhd/wF+Lk98HZoTCtlVraHtfh5XYijIjalXck7saUtuanSDyLMxnHhSXEDJqHxD7msR8D0uCmqlkwjCV8xvwHw==
+
+fast-levenshtein@^2.0.6:
+ version "2.0.6"
+ resolved "https://registry.yarnpkg.com/fast-levenshtein/-/fast-levenshtein-2.0.6.tgz#3d8a5c66883a16a30ca8643e851f19baa7797917"
+ integrity sha512-DCXu6Ifhqcks7TZKY3Hxp3y6qphY5SJZmrWMDrKcERSOXWQdMhU9Ig/PYrzyw/ul9jOIyh0N4M0tbC5hodg8dw==
+
+fastq@^1.6.0:
+ version "1.13.0"
+ resolved "https://registry.yarnpkg.com/fastq/-/fastq-1.13.0.tgz#616760f88a7526bdfc596b7cab8c18938c36b98c"
+ integrity sha512-YpkpUnK8od0o1hmeSc7UUs/eB/vIPWJYjKck2QKIzAf71Vm1AAQ3EbuZB3g2JIy+pg+ERD0vqI79KyZiB2e2Nw==
+ dependencies:
+ reusify "^1.0.4"
+
+fd-slicer@~1.1.0:
+ version "1.1.0"
+ resolved "https://registry.yarnpkg.com/fd-slicer/-/fd-slicer-1.1.0.tgz#25c7c89cb1f9077f8891bbe61d8f390eae256f1e"
+ integrity sha512-cE1qsB/VwyQozZ+q1dGxR8LBYNZeofhEdUNGSMbQD3Gw2lAzX9Zb3uIU6Ebc/Fmyjo9AWWfnn0AUCHqtevs/8g==
+ dependencies:
+ pend "~1.2.0"
+
+figures@^3.2.0:
+ version "3.2.0"
+ resolved "https://registry.yarnpkg.com/figures/-/figures-3.2.0.tgz#625c18bd293c604dc4a8ddb2febf0c88341746af"
+ integrity sha512-yaduQFRKLXYOGgEn6AZau90j3ggSOyiqXU0F9JZfeXYhNa+Jk4X+s45A2zg5jns87GAFa34BBm2kXw4XpNcbdg==
+ dependencies:
+ escape-string-regexp "^1.0.5"
+
+file-entry-cache@^6.0.1:
+ version "6.0.1"
+ resolved "https://registry.yarnpkg.com/file-entry-cache/-/file-entry-cache-6.0.1.tgz#211b2dd9659cb0394b073e7323ac3c933d522027"
+ integrity sha512-7Gps/XWymbLk2QLYK4NzpMOrYjMhdIxXuIvy2QBsLE6ljuodKvdkWs/cpyJJ3CVIVpH0Oi1Hvg1ovbMzLdFBBg==
+ dependencies:
+ flat-cache "^3.0.4"
+
+fill-range@^7.0.1:
+ version "7.0.1"
+ resolved "https://registry.yarnpkg.com/fill-range/-/fill-range-7.0.1.tgz#1919a6a7c75fe38b2c7c77e5198535da9acdda40"
+ integrity sha512-qOo9F+dMUmC2Lcb4BbVvnKJxTPjCm+RRpe4gDuGrzkL7mEVl/djYSu2OdQ2Pa302N4oqkSg9ir6jaLWJ2USVpQ==
+ dependencies:
+ to-regex-range "^5.0.1"
+
+flat-cache@^3.0.4:
+ version "3.0.4"
+ resolved "https://registry.yarnpkg.com/flat-cache/-/flat-cache-3.0.4.tgz#61b0338302b2fe9f957dcc32fc2a87f1c3048b11"
+ integrity sha512-dm9s5Pw7Jc0GvMYbshN6zchCA9RgQlzzEZX3vylR9IqFfS8XciblUXOKfW6SiuJ0e13eDYZoZV5wdrev7P3Nwg==
+ dependencies:
+ flatted "^3.1.0"
+ rimraf "^3.0.2"
+
+flatted@^3.1.0:
+ version "3.2.6"
+ resolved "https://registry.yarnpkg.com/flatted/-/flatted-3.2.6.tgz#022e9218c637f9f3fc9c35ab9c9193f05add60b2"
+ integrity sha512-0sQoMh9s0BYsm+12Huy/rkKxVu4R1+r96YX5cG44rHV0pQ6iC3Q+mkoMFaGWObMFYQxCVT+ssG1ksneA2MI9KQ==
+
+forever-agent@~0.6.1:
+ version "0.6.1"
+ resolved "https://registry.yarnpkg.com/forever-agent/-/forever-agent-0.6.1.tgz#fbc71f0c41adeb37f96c577ad1ed42d8fdacca91"
+ integrity sha512-j0KLYPhm6zeac4lz3oJ3o65qvgQCcPubiyotZrXqEaG4hNagNYO8qdlUrX5vwqv9ohqeT/Z3j6+yW067yWWdUw==
+
+form-data@~2.3.2:
+ version "2.3.3"
+ resolved "https://registry.yarnpkg.com/form-data/-/form-data-2.3.3.tgz#dcce52c05f644f298c6a7ab936bd724ceffbf3a6"
+ integrity sha512-1lLKB2Mu3aGP1Q/2eCOx0fNbRMe7XdwktwOruhfqqd0rIJWwN4Dh+E3hrPSlDCXnSR7UtZ1N38rVXm+6+MEhJQ==
+ dependencies:
+ asynckit "^0.4.0"
+ combined-stream "^1.0.6"
+ mime-types "^2.1.12"
+
+fs-extra@^9.1.0:
+ version "9.1.0"
+ resolved "https://registry.yarnpkg.com/fs-extra/-/fs-extra-9.1.0.tgz#5954460c764a8da2094ba3554bf839e6b9a7c86d"
+ integrity sha512-hcg3ZmepS30/7BSFqRvoo3DOMQu7IjqxO5nCDt+zM9XWjb33Wg7ziNT+Qvqbuc3+gWpzO02JubVyk2G4Zvo1OQ==
+ dependencies:
+ at-least-node "^1.0.0"
+ graceful-fs "^4.2.0"
+ jsonfile "^6.0.1"
+ universalify "^2.0.0"
+
+fs.realpath@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/fs.realpath/-/fs.realpath-1.0.0.tgz#1504ad2523158caa40db4a2787cb01411994ea4f"
+ integrity sha512-OO0pH2lK6a0hZnAdau5ItzHPI6pUlvI7jMVnxUQRtw4owF2wk8lOSabtGDCTP4Ggrg2MbGnWO9X8K1t4+fGMDw==
+
+function-bind@^1.1.1:
+ version "1.1.1"
+ resolved "https://registry.yarnpkg.com/function-bind/-/function-bind-1.1.1.tgz#a56899d3ea3c9bab874bb9773b7c5ede92f4895d"
+ integrity sha512-yIovAzMX49sF8Yl58fSCWJ5svSLuaibPxXQJFLmBObTuCr0Mf1KiPopGM9NiFjiYBCbfaa2Fh6breQ6ANVTI0A==
+
+function.prototype.name@^1.1.5:
+ version "1.1.5"
+ resolved "https://registry.yarnpkg.com/function.prototype.name/-/function.prototype.name-1.1.5.tgz#cce0505fe1ffb80503e6f9e46cc64e46a12a9621"
+ integrity sha512-uN7m/BzVKQnCUF/iW8jYea67v++2u7m5UgENbHRtdDVclOUP+FMPlCNdmk0h/ysGyo2tavMJEDqJAkJdRa1vMA==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ es-abstract "^1.19.0"
+ functions-have-names "^1.2.2"
+
+functional-red-black-tree@^1.0.1:
+ version "1.0.1"
+ resolved "https://registry.yarnpkg.com/functional-red-black-tree/-/functional-red-black-tree-1.0.1.tgz#1b0ab3bd553b2a0d6399d29c0e3ea0b252078327"
+ integrity sha512-dsKNQNdj6xA3T+QlADDA7mOSlX0qiMINjn0cgr+eGHGsbSHzTabcIogz2+p/iqP1Xs6EP/sS2SbqH+brGTbq0g==
+
+functions-have-names@^1.2.2:
+ version "1.2.3"
+ resolved "https://registry.yarnpkg.com/functions-have-names/-/functions-have-names-1.2.3.tgz#0404fe4ee2ba2f607f0e0ec3c80bae994133b834"
+ integrity sha512-xckBUXyTIqT97tq2x2AMb+g163b5JFysYk0x4qxNFwbfQkmNZoiRHb6sPzI9/QV33WeuvVYBUIiD4NzNIyqaRQ==
+
+get-intrinsic@^1.0.2, get-intrinsic@^1.1.0, get-intrinsic@^1.1.1:
+ version "1.1.2"
+ resolved "https://registry.yarnpkg.com/get-intrinsic/-/get-intrinsic-1.1.2.tgz#336975123e05ad0b7ba41f152ee4aadbea6cf598"
+ integrity sha512-Jfm3OyCxHh9DJyc28qGk+JmfkpO41A4XkneDSujN9MDXrm4oDKdHvndhZ2dN94+ERNfkYJWDclW6k2L/ZGHjXA==
+ dependencies:
+ function-bind "^1.1.1"
+ has "^1.0.3"
+ has-symbols "^1.0.3"
+
+get-stdin@^6.0.0:
+ version "6.0.0"
+ resolved "https://registry.yarnpkg.com/get-stdin/-/get-stdin-6.0.0.tgz#9e09bf712b360ab9225e812048f71fde9c89657b"
+ integrity sha512-jp4tHawyV7+fkkSKyvjuLZswblUtz+SQKzSWnBbii16BuZksJlU1wuBYXY75r+duh/llF1ur6oNwi+2ZzjKZ7g==
+
+get-stream@^5.0.0, get-stream@^5.1.0:
+ version "5.2.0"
+ resolved "https://registry.yarnpkg.com/get-stream/-/get-stream-5.2.0.tgz#4966a1795ee5ace65e706c4b7beb71257d6e22d3"
+ integrity sha512-nBF+F1rAZVCu/p7rjzgA+Yb4lfYXrpl7a6VmJrU8wF9I1CKvP/QwPNZHnOlwbTkY6dvtFIzFMSyQXbLoTQPRpA==
+ dependencies:
+ pump "^3.0.0"
+
+get-symbol-description@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/get-symbol-description/-/get-symbol-description-1.0.0.tgz#7fdb81c900101fbd564dd5f1a30af5aadc1e58d6"
+ integrity sha512-2EmdH1YvIQiZpltCNgkuiUnyukzxM/R6NDJX31Ke3BG1Nq5b0S2PhX59UKi9vZpPDQVdqn+1IcaAwnzTT5vCjw==
+ dependencies:
+ call-bind "^1.0.2"
+ get-intrinsic "^1.1.1"
+
+getos@^3.2.1:
+ version "3.2.1"
+ resolved "https://registry.yarnpkg.com/getos/-/getos-3.2.1.tgz#0134d1f4e00eb46144c5a9c0ac4dc087cbb27dc5"
+ integrity sha512-U56CfOK17OKgTVqozZjUKNdkfEv6jk5WISBJ8SHoagjE6L69zOwl3Z+O8myjY9MEW3i2HPWQBt/LTbCgcC973Q==
+ dependencies:
+ async "^3.2.0"
+
+getpass@^0.1.1:
+ version "0.1.7"
+ resolved "https://registry.yarnpkg.com/getpass/-/getpass-0.1.7.tgz#5eff8e3e684d569ae4cb2b1282604e8ba62149fa"
+ integrity sha512-0fzj9JxOLfJ+XGLhR8ze3unN0KZCgZwiSSDz168VERjK8Wl8kVSdcu2kspd4s4wtAa1y/qrVRiAA0WclVsu0ng==
+ dependencies:
+ assert-plus "^1.0.0"
+
+glob-parent@^5.1.2:
+ version "5.1.2"
+ resolved "https://registry.yarnpkg.com/glob-parent/-/glob-parent-5.1.2.tgz#869832c58034fe68a4093c17dc15e8340d8401c4"
+ integrity sha512-AOIgSQCepiJYwP3ARnGx+5VnTu2HBYdzbGP45eLw1vr3zB3vZLeyed1sC9hnbcOc9/SrMyM5RPQrkGz4aS9Zow==
+ dependencies:
+ is-glob "^4.0.1"
+
+glob@^7.1.3, glob@^7.1.6:
+ version "7.2.3"
+ resolved "https://registry.yarnpkg.com/glob/-/glob-7.2.3.tgz#b8df0fb802bbfa8e89bd1d938b4e16578ed44f2b"
+ integrity sha512-nFR0zLpU2YCaRxwoCJvL6UvCH2JFyFVIvwTLsIf21AuHlMskA1hhTdk+LlYJtOlYt9v6dvszD2BGRqBL+iQK9Q==
+ dependencies:
+ fs.realpath "^1.0.0"
+ inflight "^1.0.4"
+ inherits "2"
+ minimatch "^3.1.1"
+ once "^1.3.0"
+ path-is-absolute "^1.0.0"
+
+global-dirs@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/global-dirs/-/global-dirs-3.0.0.tgz#70a76fe84ea315ab37b1f5576cbde7d48ef72686"
+ integrity sha512-v8ho2DS5RiCjftj1nD9NmnfaOzTdud7RRnVd9kFNOjqZbISlx5DQ+OrTkywgd0dIt7oFCvKetZSHoHcP3sDdiA==
+ dependencies:
+ ini "2.0.0"
+
+globals@^13.6.0, globals@^13.9.0:
+ version "13.17.0"
+ resolved "https://registry.yarnpkg.com/globals/-/globals-13.17.0.tgz#902eb1e680a41da93945adbdcb5a9f361ba69bd4"
+ integrity sha512-1C+6nQRb1GwGMKm2dH/E7enFAMxGTmGI7/dEdhy/DNelv85w9B72t3uc5frtMNXIbzrarJJ/lTCjcaZwbLJmyw==
+ dependencies:
+ type-fest "^0.20.2"
+
+globby@^11.0.3:
+ version "11.1.0"
+ resolved "https://registry.yarnpkg.com/globby/-/globby-11.1.0.tgz#bd4be98bb042f83d796f7e3811991fbe82a0d34b"
+ integrity sha512-jhIXaOzy1sb8IyocaruWSn1TjmnBVs8Ayhcy83rmxNJ8q2uWKCAj3CnJY+KpGSXCueAPc0i05kVvVKtP1t9S3g==
+ dependencies:
+ array-union "^2.1.0"
+ dir-glob "^3.0.1"
+ fast-glob "^3.2.9"
+ ignore "^5.2.0"
+ merge2 "^1.4.1"
+ slash "^3.0.0"
+
+graceful-fs@^4.1.6, graceful-fs@^4.2.0:
+ version "4.2.10"
+ resolved "https://registry.yarnpkg.com/graceful-fs/-/graceful-fs-4.2.10.tgz#147d3a006da4ca3ce14728c7aefc287c367d7a6c"
+ integrity sha512-9ByhssR2fPVsNZj478qUUbKfmL0+t5BDVyjShtyZZLiK7ZDAArFFfopyOTj0M05wE2tJPisA4iTnnXl2YoPvOA==
+
+has-bigints@^1.0.1, has-bigints@^1.0.2:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/has-bigints/-/has-bigints-1.0.2.tgz#0871bd3e3d51626f6ca0966668ba35d5602d6eaa"
+ integrity sha512-tSvCKtBr9lkF0Ex0aQiP9N+OpV4zi2r/Nee5VkRDbaqv35RLYMzbwQfFSZZH0kR+Rd6302UJZ2p/bJCEoR3VoQ==
+
+has-flag@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/has-flag/-/has-flag-3.0.0.tgz#b5d454dc2199ae225699f3467e5a07f3b955bafd"
+ integrity sha512-sKJf1+ceQBr4SMkvQnBDNDtf4TXpVhVGateu0t918bl30FnbE2m4vNLX+VWe/dpjlb+HugGYzW7uQXH98HPEYw==
+
+has-flag@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/has-flag/-/has-flag-4.0.0.tgz#944771fd9c81c81265c4d6941860da06bb59479b"
+ integrity sha512-EykJT/Q1KjTWctppgIAgfSO0tKVuZUjhgMr17kqTumMl6Afv3EISleU7qZUzoXDFTAHTDC4NOoG/ZxU3EvlMPQ==
+
+has-property-descriptors@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/has-property-descriptors/-/has-property-descriptors-1.0.0.tgz#610708600606d36961ed04c196193b6a607fa861"
+ integrity sha512-62DVLZGoiEBDHQyqG4w9xCuZ7eJEwNmJRWw2VY84Oedb7WFcA27fiEVe8oUQx9hAUJ4ekurquucTGwsyO1XGdQ==
+ dependencies:
+ get-intrinsic "^1.1.1"
+
+has-symbols@^1.0.1, has-symbols@^1.0.2, has-symbols@^1.0.3:
+ version "1.0.3"
+ resolved "https://registry.yarnpkg.com/has-symbols/-/has-symbols-1.0.3.tgz#bb7b2c4349251dce87b125f7bdf874aa7c8b39f8"
+ integrity sha512-l3LCuF6MgDNwTDKkdYGEihYjt5pRPbEg46rtlmnSPlUbgmB8LOIrKJbYYFBSbnPaJexMKtiPO8hmeRjRz2Td+A==
+
+has-tostringtag@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/has-tostringtag/-/has-tostringtag-1.0.0.tgz#7e133818a7d394734f941e73c3d3f9291e658b25"
+ integrity sha512-kFjcSNhnlGV1kyoGk7OXKSawH5JOb/LzUc5w9B02hOTO0dfFRjbHQKvg1d6cf3HbeUmtU9VbbV3qzZ2Teh97WQ==
+ dependencies:
+ has-symbols "^1.0.2"
+
+has@^1.0.3:
+ version "1.0.3"
+ resolved "https://registry.yarnpkg.com/has/-/has-1.0.3.tgz#722d7cbfc1f6aa8241f16dd814e011e1f41e8796"
+ integrity sha512-f2dvO0VU6Oej7RkWJGrehjbzMAjFp5/VKPp5tTpWIV4JHHZK1/BxbFRtf/siA2SWTe09caDmVtYYzWEIbBS4zw==
+ dependencies:
+ function-bind "^1.1.1"
+
+http-signature@~1.3.6:
+ version "1.3.6"
+ resolved "https://registry.yarnpkg.com/http-signature/-/http-signature-1.3.6.tgz#cb6fbfdf86d1c974f343be94e87f7fc128662cf9"
+ integrity sha512-3adrsD6zqo4GsTqtO7FyrejHNv+NgiIfAfv68+jVlFmSr9OGy7zrxONceFRLKvnnZA5jbxQBX1u9PpB6Wi32Gw==
+ dependencies:
+ assert-plus "^1.0.0"
+ jsprim "^2.0.2"
+ sshpk "^1.14.1"
+
+human-signals@^1.1.1:
+ version "1.1.1"
+ resolved "https://registry.yarnpkg.com/human-signals/-/human-signals-1.1.1.tgz#c5b1cd14f50aeae09ab6c59fe63ba3395fe4dfa3"
+ integrity sha512-SEQu7vl8KjNL2eoGBLF3+wAjpsNfA9XMlXAYj/3EdaNfAlxKthD1xjEQfGOUhllCGGJVNY34bRr6lPINhNjyZw==
+
+ieee754@^1.1.13:
+ version "1.2.1"
+ resolved "https://registry.yarnpkg.com/ieee754/-/ieee754-1.2.1.tgz#8eb7a10a63fff25d15a57b001586d177d1b0d352"
+ integrity sha512-dcyqhDvX1C46lXZcVqCpK+FtMRQVdIMN6/Df5js2zouUsqG7I6sFxitIC+7KYK29KdXOLHdu9zL4sFnoVQnqaA==
+
+ignore@^4.0.6:
+ version "4.0.6"
+ resolved "https://registry.yarnpkg.com/ignore/-/ignore-4.0.6.tgz#750e3db5862087b4737ebac8207ffd1ef27b25fc"
+ integrity sha512-cyFDKrqc/YdcWFniJhzI42+AzS+gNwmUzOSFcRCQYwySuBBBy/KjuxWLZ/FHEH6Moq1NizMOBWyTcv8O4OZIMg==
+
+ignore@^5.2.0:
+ version "5.2.0"
+ resolved "https://registry.yarnpkg.com/ignore/-/ignore-5.2.0.tgz#6d3bac8fa7fe0d45d9f9be7bac2fc279577e345a"
+ integrity sha512-CmxgYGiEPCLhfLnpPp1MoRmifwEIOgjcHXxOBjv7mY96c+eWScsOP9c112ZyLdWHi0FxHjI+4uVhKYp/gcdRmQ==
+
+import-fresh@^3.0.0, import-fresh@^3.2.1:
+ version "3.3.0"
+ resolved "https://registry.yarnpkg.com/import-fresh/-/import-fresh-3.3.0.tgz#37162c25fcb9ebaa2e6e53d5b4d88ce17d9e0c2b"
+ integrity sha512-veYYhQa+D1QBKznvhUHxb8faxlrwUnxseDAbAp457E0wLNio2bOSKnjYDhMj+YiAq61xrMGhQk9iXVk5FzgQMw==
+ dependencies:
+ parent-module "^1.0.0"
+ resolve-from "^4.0.0"
+
+imurmurhash@^0.1.4:
+ version "0.1.4"
+ resolved "https://registry.yarnpkg.com/imurmurhash/-/imurmurhash-0.1.4.tgz#9218b9b2b928a238b13dc4fb6b6d576f231453ea"
+ integrity sha512-JmXMZ6wuvDmLiHEml9ykzqO6lwFbof0GG4IkcGaENdCRDDmMVnny7s5HsIgHCbaq0w2MyPhDqkhTUgS2LU2PHA==
+
+indent-string@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/indent-string/-/indent-string-4.0.0.tgz#624f8f4497d619b2d9768531d58f4122854d7251"
+ integrity sha512-EdDDZu4A2OyIK7Lr/2zG+w5jmbuk1DVBnEwREQvBzspBJkCEbRa8GxU1lghYcaGJCnRWibjDXlq779X1/y5xwg==
+
+inflight@^1.0.4:
+ version "1.0.6"
+ resolved "https://registry.yarnpkg.com/inflight/-/inflight-1.0.6.tgz#49bd6331d7d02d0c09bc910a1075ba8165b56df9"
+ integrity sha512-k92I/b08q4wvFscXCLvqfsHCrjrF7yiXsQuIVvVE7N82W3+aqpzuUdBbfhWcy/FZR3/4IgflMgKLOsvPDrGCJA==
+ dependencies:
+ once "^1.3.0"
+ wrappy "1"
+
+inherits@2:
+ version "2.0.4"
+ resolved "https://registry.yarnpkg.com/inherits/-/inherits-2.0.4.tgz#0fa2c64f932917c3433a0ded55363aae37416b7c"
+ integrity sha512-k/vGaX4/Yla3WzyMCvTQOXYeIHvqOKtnqBduzTHpzpQZzAskKMhZ2K+EnBiSM9zGSoIFeMpXKxa4dYeZIQqewQ==
+
[email protected]:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/ini/-/ini-2.0.0.tgz#e5fd556ecdd5726be978fa1001862eacb0a94bc5"
+ integrity sha512-7PnF4oN3CvZF23ADhA5wRaYEQpJ8qygSkbtTXWBeXWXmEVRXK+1ITciHWwHhsjv1TmW0MgacIv6hEi5pX5NQdA==
+
+internal-slot@^1.0.3:
+ version "1.0.3"
+ resolved "https://registry.yarnpkg.com/internal-slot/-/internal-slot-1.0.3.tgz#7347e307deeea2faac2ac6205d4bc7d34967f59c"
+ integrity sha512-O0DB1JC/sPyZl7cIo78n5dR7eUSwwpYPiXRhTzNxZVAMUuB8vlnRFyLxdrVToks6XPLVnFfbzaVd5WLjhgg+vA==
+ dependencies:
+ get-intrinsic "^1.1.0"
+ has "^1.0.3"
+ side-channel "^1.0.4"
+
+is-bigint@^1.0.1:
+ version "1.0.4"
+ resolved "https://registry.yarnpkg.com/is-bigint/-/is-bigint-1.0.4.tgz#08147a1875bc2b32005d41ccd8291dffc6691df3"
+ integrity sha512-zB9CruMamjym81i2JZ3UMn54PKGsQzsJeo6xvN3HJJ4CAsQNB6iRutp2To77OfCNuoxspsIhzaPoO1zyCEhFOg==
+ dependencies:
+ has-bigints "^1.0.1"
+
+is-boolean-object@^1.1.0:
+ version "1.1.2"
+ resolved "https://registry.yarnpkg.com/is-boolean-object/-/is-boolean-object-1.1.2.tgz#5c6dc200246dd9321ae4b885a114bb1f75f63719"
+ integrity sha512-gDYaKHJmnj4aWxyj6YHyXVpdQawtVLHU5cb+eztPGczf6cjuTdwve5ZIEfgXqH4e57An1D1AKf8CZ3kYrQRqYA==
+ dependencies:
+ call-bind "^1.0.2"
+ has-tostringtag "^1.0.0"
+
+is-callable@^1.1.4, is-callable@^1.2.4:
+ version "1.2.4"
+ resolved "https://registry.yarnpkg.com/is-callable/-/is-callable-1.2.4.tgz#47301d58dd0259407865547853df6d61fe471945"
+ integrity sha512-nsuwtxZfMX67Oryl9LCQ+upnC0Z0BgpwntpS89m1H/TLF0zNfzfLMV/9Wa/6MZsj0acpEjAO0KF1xT6ZdLl95w==
+
+is-ci@^3.0.0:
+ version "3.0.1"
+ resolved "https://registry.yarnpkg.com/is-ci/-/is-ci-3.0.1.tgz#db6ecbed1bd659c43dac0f45661e7674103d1867"
+ integrity sha512-ZYvCgrefwqoQ6yTyYUbQu64HsITZ3NfKX1lzaEYdkTDcfKzzCI/wthRRYKkdjHKFVgNiXKAKm65Zo1pk2as/QQ==
+ dependencies:
+ ci-info "^3.2.0"
+
+is-core-module@^2.9.0:
+ version "2.9.0"
+ resolved "https://registry.yarnpkg.com/is-core-module/-/is-core-module-2.9.0.tgz#e1c34429cd51c6dd9e09e0799e396e27b19a9c69"
+ integrity sha512-+5FPy5PnwmO3lvfMb0AsoPaBG+5KHUI0wYFXOtYPnVVVspTFUuMZNfNaNVRt3FZadstu2c8x23vykRW/NBoU6A==
+ dependencies:
+ has "^1.0.3"
+
+is-date-object@^1.0.1:
+ version "1.0.5"
+ resolved "https://registry.yarnpkg.com/is-date-object/-/is-date-object-1.0.5.tgz#0841d5536e724c25597bf6ea62e1bd38298df31f"
+ integrity sha512-9YQaSxsAiSwcvS33MBk3wTCVnWK+HhF8VZR2jRxehM16QcVOdHqPn4VPHmRK4lSr38n9JriurInLcP90xsYNfQ==
+ dependencies:
+ has-tostringtag "^1.0.0"
+
+is-extglob@^2.1.1:
+ version "2.1.1"
+ resolved "https://registry.yarnpkg.com/is-extglob/-/is-extglob-2.1.1.tgz#a88c02535791f02ed37c76a1b9ea9773c833f8c2"
+ integrity sha512-SbKbANkN603Vi4jEZv49LeVJMn4yGwsbzZworEoyEiutsN3nJYdbO36zfhGJ6QEDpOZIFkDtnq5JRxmvl3jsoQ==
+
+is-fullwidth-code-point@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/is-fullwidth-code-point/-/is-fullwidth-code-point-3.0.0.tgz#f116f8064fe90b3f7844a38997c0b75051269f1d"
+ integrity sha512-zymm5+u+sCsSWyD9qNaejV3DFvhCKclKdizYaJUuHA83RLjb7nSuGnddCHGv0hk+KY7BMAlsWeK4Ueg6EV6XQg==
+
+is-glob@^4.0.0, is-glob@^4.0.1:
+ version "4.0.3"
+ resolved "https://registry.yarnpkg.com/is-glob/-/is-glob-4.0.3.tgz#64f61e42cbbb2eec2071a9dac0b28ba1e65d5084"
+ integrity sha512-xelSayHH36ZgE7ZWhli7pW34hNbNl8Ojv5KVmkJD4hBdD3th8Tfk9vYasLM+mXWOZhFkgZfxhLSnrwRr4elSSg==
+ dependencies:
+ is-extglob "^2.1.1"
+
+is-installed-globally@~0.4.0:
+ version "0.4.0"
+ resolved "https://registry.yarnpkg.com/is-installed-globally/-/is-installed-globally-0.4.0.tgz#9a0fd407949c30f86eb6959ef1b7994ed0b7b520"
+ integrity sha512-iwGqO3J21aaSkC7jWnHP/difazwS7SFeIqxv6wEtLU8Y5KlzFTjyqcSIT0d8s4+dDhKytsk9PJZ2BkS5eZwQRQ==
+ dependencies:
+ global-dirs "^3.0.0"
+ is-path-inside "^3.0.2"
+
+is-negative-zero@^2.0.2:
+ version "2.0.2"
+ resolved "https://registry.yarnpkg.com/is-negative-zero/-/is-negative-zero-2.0.2.tgz#7bf6f03a28003b8b3965de3ac26f664d765f3150"
+ integrity sha512-dqJvarLawXsFbNDeJW7zAz8ItJ9cd28YufuuFzh0G8pNHjJMnY08Dv7sYX2uF5UpQOwieAeOExEYAWWfu7ZZUA==
+
+is-number-object@^1.0.4:
+ version "1.0.7"
+ resolved "https://registry.yarnpkg.com/is-number-object/-/is-number-object-1.0.7.tgz#59d50ada4c45251784e9904f5246c742f07a42fc"
+ integrity sha512-k1U0IRzLMo7ZlYIfzRu23Oh6MiIFasgpb9X76eqfFZAqwH44UI4KTBvBYIZ1dSL9ZzChTB9ShHfLkR4pdW5krQ==
+ dependencies:
+ has-tostringtag "^1.0.0"
+
+is-number@^7.0.0:
+ version "7.0.0"
+ resolved "https://registry.yarnpkg.com/is-number/-/is-number-7.0.0.tgz#7535345b896734d5f80c4d06c50955527a14f12b"
+ integrity sha512-41Cifkg6e8TylSpdtTpeLVMqvSBEVzTttHvERD741+pnZ8ANv0004MRL43QKPDlK9cGvNp6NZWZUBlbGXYxxng==
+
+is-path-inside@^3.0.2:
+ version "3.0.3"
+ resolved "https://registry.yarnpkg.com/is-path-inside/-/is-path-inside-3.0.3.tgz#d231362e53a07ff2b0e0ea7fed049161ffd16283"
+ integrity sha512-Fd4gABb+ycGAmKou8eMftCupSir5lRxqf4aD/vd0cD2qc4HL07OjCeuHMr8Ro4CoMaeCKDB0/ECBOVWjTwUvPQ==
+
+is-regex@^1.1.4:
+ version "1.1.4"
+ resolved "https://registry.yarnpkg.com/is-regex/-/is-regex-1.1.4.tgz#eef5663cd59fa4c0ae339505323df6854bb15958"
+ integrity sha512-kvRdxDsxZjhzUX07ZnLydzS1TU/TJlTUHHY4YLL87e37oUA49DfkLqgy+VjFocowy29cKvcSiu+kIv728jTTVg==
+ dependencies:
+ call-bind "^1.0.2"
+ has-tostringtag "^1.0.0"
+
+is-shared-array-buffer@^1.0.2:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/is-shared-array-buffer/-/is-shared-array-buffer-1.0.2.tgz#8f259c573b60b6a32d4058a1a07430c0a7344c79"
+ integrity sha512-sqN2UDu1/0y6uvXyStCOzyhAjCSlHceFoMKJW8W9EU9cvic/QdsZ0kEU93HEy3IUEFZIiH/3w+AH/UQbPHNdhA==
+ dependencies:
+ call-bind "^1.0.2"
+
+is-stream@^2.0.0:
+ version "2.0.1"
+ resolved "https://registry.yarnpkg.com/is-stream/-/is-stream-2.0.1.tgz#fac1e3d53b97ad5a9d0ae9cef2389f5810a5c077"
+ integrity sha512-hFoiJiTl63nn+kstHGBtewWSKnQLpyb155KHheA1l39uvtO9nWIop1p3udqPcUd/xbF1VLMO4n7OI6p7RbngDg==
+
+is-string@^1.0.5, is-string@^1.0.7:
+ version "1.0.7"
+ resolved "https://registry.yarnpkg.com/is-string/-/is-string-1.0.7.tgz#0dd12bf2006f255bb58f695110eff7491eebc0fd"
+ integrity sha512-tE2UXzivje6ofPW7l23cjDOMa09gb7xlAqG6jG5ej6uPV32TlWP3NKPigtaGeHNu9fohccRYvIiZMfOOnOYUtg==
+ dependencies:
+ has-tostringtag "^1.0.0"
+
+is-symbol@^1.0.2, is-symbol@^1.0.3:
+ version "1.0.4"
+ resolved "https://registry.yarnpkg.com/is-symbol/-/is-symbol-1.0.4.tgz#a6dac93b635b063ca6872236de88910a57af139c"
+ integrity sha512-C/CPBqKWnvdcxqIARxyOh4v1UUEOCHpgDa0WYgpKDFMszcrPcffg5uhwSgPCLD2WWxmq6isisz87tzT01tuGhg==
+ dependencies:
+ has-symbols "^1.0.2"
+
+is-typedarray@~1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/is-typedarray/-/is-typedarray-1.0.0.tgz#e479c80858df0c1b11ddda6940f96011fcda4a9a"
+ integrity sha512-cyA56iCMHAh5CdzjJIa4aohJyeO1YbwLi3Jc35MmRU6poroFjIGZzUzupGiRPOjgHg9TLu43xbpwXk523fMxKA==
+
+is-unicode-supported@^0.1.0:
+ version "0.1.0"
+ resolved "https://registry.yarnpkg.com/is-unicode-supported/-/is-unicode-supported-0.1.0.tgz#3f26c76a809593b52bfa2ecb5710ed2779b522a7"
+ integrity sha512-knxG2q4UC3u8stRGyAVJCOdxFmv5DZiRcdlIaAQXAbSfJya+OhopNotLQrstBhququ4ZpuKbDc/8S6mgXgPFPw==
+
+is-weakref@^1.0.2:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/is-weakref/-/is-weakref-1.0.2.tgz#9529f383a9338205e89765e0392efc2f100f06f2"
+ integrity sha512-qctsuLZmIQ0+vSSMfoVvyFe2+GSEvnmZ2ezTup1SBse9+twCCeial6EEi3Nc2KFcf6+qz2FBPnjXsk8xhKSaPQ==
+ dependencies:
+ call-bind "^1.0.2"
+
+isexe@^2.0.0:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/isexe/-/isexe-2.0.0.tgz#e8fbf374dc556ff8947a10dcb0572d633f2cfa10"
+ integrity sha512-RHxMLp9lnKHGHRng9QFhRCMbYAcVpn69smSGcq3f36xjgVVWThj4qqLbTLlq7Ssj8B+fIQ1EuCEGI2lKsyQeIw==
+
+isstream@~0.1.2:
+ version "0.1.2"
+ resolved "https://registry.yarnpkg.com/isstream/-/isstream-0.1.2.tgz#47e63f7af55afa6f92e1500e690eb8b8529c099a"
+ integrity sha512-Yljz7ffyPbrLpLngrMtZ7NduUgVvi6wG9RJ9IUcyCd59YQ911PBJphODUcbOVbqYfxe1wuYf/LJ8PauMRwsM/g==
+
+"js-tokens@^3.0.0 || ^4.0.0", js-tokens@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/js-tokens/-/js-tokens-4.0.0.tgz#19203fb59991df98e3a287050d4647cdeaf32499"
+ integrity sha512-RdJUflcE3cUzKiMqQgsCu06FPu9UdIJO0beYbPhHN4k6apgJtifcoCtT9bcxOpYBtpD2kCM6Sbzg4CausW/PKQ==
+
+js-yaml@^3.13.1:
+ version "3.14.1"
+ resolved "https://registry.yarnpkg.com/js-yaml/-/js-yaml-3.14.1.tgz#dae812fdb3825fa306609a8717383c50c36a0537"
+ integrity sha512-okMH7OXXJ7YrN9Ok3/SXrnu4iX9yOk+25nqX4imS2npuvTYDmo/QEZoqwZkYaIDk3jVvBOTOIEgEhaLOynBS9g==
+ dependencies:
+ argparse "^1.0.7"
+ esprima "^4.0.0"
+
+jsbn@~0.1.0:
+ version "0.1.1"
+ resolved "https://registry.yarnpkg.com/jsbn/-/jsbn-0.1.1.tgz#a5e654c2e5a2deb5f201d96cefbca80c0ef2f513"
+ integrity sha512-UVU9dibq2JcFWxQPA6KCqj5O42VOmAY3zQUfEKxU0KpTGXwNoCjkX1e13eHNvw/xPynt6pU0rZ1htjWTNTSXsg==
+
+json-schema-traverse@^0.4.1:
+ version "0.4.1"
+ resolved "https://registry.yarnpkg.com/json-schema-traverse/-/json-schema-traverse-0.4.1.tgz#69f6a87d9513ab8bb8fe63bdb0979c448e684660"
+ integrity sha512-xbbCH5dCYU5T8LcEhhuh7HJ88HXuW3qsI3Y0zOZFKfZEHcpWiHU/Jxzk629Brsab/mMiHQti9wMP+845RPe3Vg==
+
+json-schema-traverse@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/json-schema-traverse/-/json-schema-traverse-1.0.0.tgz#ae7bcb3656ab77a73ba5c49bf654f38e6b6860e2"
+ integrity sha512-NM8/P9n3XjXhIZn1lLhkFaACTOURQXjWhV4BA/RnOv8xvgqtqpAX9IO4mRQxSx1Rlo4tqzeqb0sOlruaOy3dug==
+
[email protected]:
+ version "0.4.0"
+ resolved "https://registry.yarnpkg.com/json-schema/-/json-schema-0.4.0.tgz#f7de4cf6efab838ebaeb3236474cbba5a1930ab5"
+ integrity sha512-es94M3nTIfsEPisRafak+HDLfHXnKBhV3vU5eqPcS3flIWqcxJWgXHXiey3YrpaNsanY5ei1VoYEbOzijuq9BA==
+
+json-stable-stringify-without-jsonify@^1.0.1:
+ version "1.0.1"
+ resolved "https://registry.yarnpkg.com/json-stable-stringify-without-jsonify/-/json-stable-stringify-without-jsonify-1.0.1.tgz#9db7b59496ad3f3cfef30a75142d2d930ad72651"
+ integrity sha512-Bdboy+l7tA3OGW6FjyFHWkP5LuByj1Tk33Ljyq0axyzdk9//JSi2u3fP1QSmd1KNwq6VOKYGlAu87CisVir6Pw==
+
+json-stringify-safe@~5.0.1:
+ version "5.0.1"
+ resolved "https://registry.yarnpkg.com/json-stringify-safe/-/json-stringify-safe-5.0.1.tgz#1296a2d58fd45f19a0f6ce01d65701e2c735b6eb"
+ integrity sha512-ZClg6AaYvamvYEE82d3Iyd3vSSIjQ+odgjaTzRuO3s7toCdFKczob2i0zCh7JE8kWn17yvAWhUVxvqGwUalsRA==
+
+jsonfile@^6.0.1:
+ version "6.1.0"
+ resolved "https://registry.yarnpkg.com/jsonfile/-/jsonfile-6.1.0.tgz#bc55b2634793c679ec6403094eb13698a6ec0aae"
+ integrity sha512-5dgndWOriYSm5cnYaJNhalLNDKOqFwyDB/rr1E9ZsGciGvKPs8R2xYGCacuf3z6K1YKDz182fd+fY3cn3pMqXQ==
+ dependencies:
+ universalify "^2.0.0"
+ optionalDependencies:
+ graceful-fs "^4.1.6"
+
+jsprim@^2.0.2:
+ version "2.0.2"
+ resolved "https://registry.yarnpkg.com/jsprim/-/jsprim-2.0.2.tgz#77ca23dbcd4135cd364800d22ff82c2185803d4d"
+ integrity sha512-gqXddjPqQ6G40VdnI6T6yObEC+pDNvyP95wdQhkWkg7crHH3km5qP1FsOXEkzEQwnz6gz5qGTn1c2Y52wP3OyQ==
+ dependencies:
+ assert-plus "1.0.0"
+ extsprintf "1.3.0"
+ json-schema "0.4.0"
+ verror "1.10.0"
+
+"jsx-ast-utils@^2.4.1 || ^3.0.0":
+ version "3.3.2"
+ resolved "https://registry.yarnpkg.com/jsx-ast-utils/-/jsx-ast-utils-3.3.2.tgz#afe5efe4332cd3515c065072bd4d6b0aa22152bd"
+ integrity sha512-4ZCADZHRkno244xlNnn4AOG6sRQ7iBZ5BbgZ4vW4y5IZw7cVUD1PPeblm1xx/nfmMxPdt/LHsXZW8z/j58+l9Q==
+ dependencies:
+ array-includes "^3.1.5"
+ object.assign "^4.1.2"
+
+lazy-ass@^1.6.0:
+ version "1.6.0"
+ resolved "https://registry.yarnpkg.com/lazy-ass/-/lazy-ass-1.6.0.tgz#7999655e8646c17f089fdd187d150d3324d54513"
+ integrity sha512-cc8oEVoctTvsFZ/Oje/kGnHbpWHYBe8IAJe4C0QNc3t8uM/0Y8+erSz/7Y1ALuXTEZTMvxXwO6YbX1ey3ujiZw==
+
+levn@^0.4.1:
+ version "0.4.1"
+ resolved "https://registry.yarnpkg.com/levn/-/levn-0.4.1.tgz#ae4562c007473b932a6200d403268dd2fffc6ade"
+ integrity sha512-+bT2uH4E5LGE7h/n3evcS/sQlJXCpIp6ym8OWJ5eV6+67Dsql/LaaT7qJBAt2rzfoa/5QBGBhxDix1dMt2kQKQ==
+ dependencies:
+ prelude-ls "^1.2.1"
+ type-check "~0.4.0"
+
+listr2@^3.8.3:
+ version "3.14.0"
+ resolved "https://registry.yarnpkg.com/listr2/-/listr2-3.14.0.tgz#23101cc62e1375fd5836b248276d1d2b51fdbe9e"
+ integrity sha512-TyWI8G99GX9GjE54cJ+RrNMcIFBfwMPxc3XTFiAYGN4s10hWROGtOg7+O6u6LE3mNkyld7RSLE6nrKBvTfcs3g==
+ dependencies:
+ cli-truncate "^2.1.0"
+ colorette "^2.0.16"
+ log-update "^4.0.0"
+ p-map "^4.0.0"
+ rfdc "^1.3.0"
+ rxjs "^7.5.1"
+ through "^2.3.8"
+ wrap-ansi "^7.0.0"
+
+lodash.merge@^4.6.2:
+ version "4.6.2"
+ resolved "https://registry.yarnpkg.com/lodash.merge/-/lodash.merge-4.6.2.tgz#558aa53b43b661e1925a0afdfa36a9a1085fe57a"
+ integrity sha512-0KpjqXRVvrYyCsX1swR/XTK0va6VQkQM6MNo7PqW77ByjAhoARA8EfrP1N4+KlKj8YS0ZUCtRT/YUuhyYDujIQ==
+
+lodash.once@^4.1.1:
+ version "4.1.1"
+ resolved "https://registry.yarnpkg.com/lodash.once/-/lodash.once-4.1.1.tgz#0dd3971213c7c56df880977d504c88fb471a97ac"
+ integrity sha512-Sb487aTOCr9drQVL8pIxOzVhafOjZN9UU54hiN8PU3uAiSV7lx1yYNpbNmex2PK6dSJoNTSJUUswT651yww3Mg==
+
+lodash.truncate@^4.4.2:
+ version "4.4.2"
+ resolved "https://registry.yarnpkg.com/lodash.truncate/-/lodash.truncate-4.4.2.tgz#5a350da0b1113b837ecfffd5812cbe58d6eae193"
+ integrity sha512-jttmRe7bRse52OsWIMDLaXxWqRAmtIUccAQ3garviCqJjafXOfNMO0yMfNpdD6zbGaTU0P5Nz7e7gAT6cKmJRw==
+
+lodash@^4.17.15, lodash@^4.17.21:
+ version "4.17.21"
+ resolved "https://registry.yarnpkg.com/lodash/-/lodash-4.17.21.tgz#679591c564c3bffaae8454cf0b3df370c3d6911c"
+ integrity sha512-v2kDEe57lecTulaDIuNTPy3Ry4gLGJ6Z1O3vE1krgXZNrsQ+LFTGHVxVjcXPs17LhbZVGedAJv8XZ1tvj5FvSg==
+
+log-symbols@^4.0.0:
+ version "4.1.0"
+ resolved "https://registry.yarnpkg.com/log-symbols/-/log-symbols-4.1.0.tgz#3fbdbb95b4683ac9fc785111e792e558d4abd503"
+ integrity sha512-8XPvpAA8uyhfteu8pIvQxpJZ7SYYdpUivZpGy6sFsBuKRY/7rQGavedeB8aK+Zkyq6upMFVL/9AW6vOYzfRyLg==
+ dependencies:
+ chalk "^4.1.0"
+ is-unicode-supported "^0.1.0"
+
+log-update@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/log-update/-/log-update-4.0.0.tgz#589ecd352471f2a1c0c570287543a64dfd20e0a1"
+ integrity sha512-9fkkDevMefjg0mmzWFBW8YkFP91OrizzkW3diF7CpG+S2EYdy4+TVfGwz1zeF8x7hCx1ovSPTOE9Ngib74qqUg==
+ dependencies:
+ ansi-escapes "^4.3.0"
+ cli-cursor "^3.1.0"
+ slice-ansi "^4.0.0"
+ wrap-ansi "^6.2.0"
+
+loose-envify@^1.4.0:
+ version "1.4.0"
+ resolved "https://registry.yarnpkg.com/loose-envify/-/loose-envify-1.4.0.tgz#71ee51fa7be4caec1a63839f7e682d8132d30caf"
+ integrity sha512-lyuxPGr/Wfhrlem2CL/UcnUc1zcqKAImBDzukY7Y5F/yQiNdko6+fRLevlw1HgMySw7f611UIY408EtxRSoK3Q==
+ dependencies:
+ js-tokens "^3.0.0 || ^4.0.0"
+
+lru-cache@^6.0.0:
+ version "6.0.0"
+ resolved "https://registry.yarnpkg.com/lru-cache/-/lru-cache-6.0.0.tgz#6d6fe6570ebd96aaf90fcad1dafa3b2566db3a94"
+ integrity sha512-Jo6dJ04CmSjuznwJSS3pUeWmd/H0ffTlkXXgwZi+eq1UCmqQwCh+eLsYOYCwY991i2Fah4h1BEMCx4qThGbsiA==
+ dependencies:
+ yallist "^4.0.0"
+
+lz-string@^1.4.4:
+ version "1.4.4"
+ resolved "https://registry.yarnpkg.com/lz-string/-/lz-string-1.4.4.tgz#c0d8eaf36059f705796e1e344811cf4c498d3a26"
+ integrity sha512-0ckx7ZHRPqb0oUm8zNr+90mtf9DQB60H1wMCjBtfi62Kl3a7JbHob6gA2bC+xRvZoOL+1hzUK8jeuEIQE8svEQ==
+
+merge-stream@^2.0.0:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/merge-stream/-/merge-stream-2.0.0.tgz#52823629a14dd00c9770fb6ad47dc6310f2c1f60"
+ integrity sha512-abv/qOcuPfk3URPfDzmZU1LKmuw8kT+0nIHvKrKgFrwifol/doWcdA4ZqsWQ8ENrFKkd67Mfpo/LovbIUsbt3w==
+
+merge2@^1.3.0, merge2@^1.4.1:
+ version "1.4.1"
+ resolved "https://registry.yarnpkg.com/merge2/-/merge2-1.4.1.tgz#4368892f885e907455a6fd7dc55c0c9d404990ae"
+ integrity sha512-8q7VEgMJW4J8tcfVPy8g09NcQwZdbwFEqhe/WZkoIzjn/3TGDwtOCYtXGxA3O8tPzpczCCDgv+P2P5y00ZJOOg==
+
+micromatch@^4.0.4:
+ version "4.0.5"
+ resolved "https://registry.yarnpkg.com/micromatch/-/micromatch-4.0.5.tgz#bc8999a7cbbf77cdc89f132f6e467051b49090c6"
+ integrity sha512-DMy+ERcEW2q8Z2Po+WNXuw3c5YaUSFjAO5GsJqfEl7UjvtIuFKO6ZrKvcItdy98dwFI2N1tg3zNIdKaQT+aNdA==
+ dependencies:
+ braces "^3.0.2"
+ picomatch "^2.3.1"
+
[email protected]:
+ version "1.52.0"
+ resolved "https://registry.yarnpkg.com/mime-db/-/mime-db-1.52.0.tgz#bbabcdc02859f4987301c856e3387ce5ec43bf70"
+ integrity sha512-sPU4uV7dYlvtWJxwwxHD0PuihVNiE7TyAbQ5SWxDCB9mUYvOgroQOwYQQOKPJ8CIbE+1ETVlOoK1UC2nU3gYvg==
+
+mime-types@^2.1.12, mime-types@~2.1.19:
+ version "2.1.35"
+ resolved "https://registry.yarnpkg.com/mime-types/-/mime-types-2.1.35.tgz#381a871b62a734450660ae3deee44813f70d959a"
+ integrity sha512-ZDY+bPm5zTTF+YpCrAU9nK0UgICYPT0QtT1NZWFv4s++TNkcgVaT0g6+4R2uI4MjQjzysHB1zxuWL50hzaeXiw==
+ dependencies:
+ mime-db "1.52.0"
+
+mimic-fn@^2.1.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/mimic-fn/-/mimic-fn-2.1.0.tgz#7ed2c2ccccaf84d3ffcb7a69b57711fc2083401b"
+ integrity sha512-OqbOk5oEQeAZ8WXWydlu9HJjz9WVdEIvamMCcXmuqUYjTknH/sqsWvhQ3vgwKFRR1HpjvNBKQ37nbJgYzGqGcg==
+
+minimatch@^3.0.4, minimatch@^3.1.1:
+ version "3.1.2"
+ resolved "https://registry.yarnpkg.com/minimatch/-/minimatch-3.1.2.tgz#19cd194bfd3e428f049a70817c038d89ab4be35b"
+ integrity sha512-J7p63hRiAjw1NDEww1W7i37+ByIrOWO5XQQAzZ3VOcL0PNybwpfmV/N05zFAzwQ9USyEcX6t3UO+K5aqBQOIHw==
+ dependencies:
+ brace-expansion "^1.1.7"
+
+minimist@^1.2.6:
+ version "1.2.6"
+ resolved "https://registry.yarnpkg.com/minimist/-/minimist-1.2.6.tgz#8637a5b759ea0d6e98702cfb3a9283323c93af44"
+ integrity sha512-Jsjnk4bw3YJqYzbdyBiNsPWHPfO++UGG749Cxs6peCu5Xg4nrena6OVxOYxrQTqww0Jmwt+Ref8rggumkTLz9Q==
+
[email protected]:
+ version "2.1.2"
+ resolved "https://registry.yarnpkg.com/ms/-/ms-2.1.2.tgz#d09d1f357b443f493382a8eb3ccd183872ae6009"
+ integrity sha512-sGkPx+VjMtmA6MX27oA4FBFELFCZZ4S4XqeGOXCv68tT+jb3vk/RyaKWP0PTKyWtmLSM0b+adUTEvbs1PEaH2w==
+
+ms@^2.1.1:
+ version "2.1.3"
+ resolved "https://registry.yarnpkg.com/ms/-/ms-2.1.3.tgz#574c8138ce1d2b5861f0b44579dbadd60c6615b2"
+ integrity sha512-6FlzubTLZG3J2a/NVCAleEhjzq5oxgHyaCU9yYXvcLsvoVaHJq/s5xXI6/XXP6tz7R9xAOtHnSO/tXtF3WRTlA==
+
+natural-compare@^1.4.0:
+ version "1.4.0"
+ resolved "https://registry.yarnpkg.com/natural-compare/-/natural-compare-1.4.0.tgz#4abebfeed7541f2c27acfb29bdbbd15c8d5ba4f7"
+ integrity sha512-OWND8ei3VtNC9h7V60qff3SVobHr996CTwgxubgyQYEpg290h9J0buyECNNJexkFm5sOajh5G116RYA1c8ZMSw==
+
+npm-run-path@^4.0.0:
+ version "4.0.1"
+ resolved "https://registry.yarnpkg.com/npm-run-path/-/npm-run-path-4.0.1.tgz#b7ecd1e5ed53da8e37a55e1c2269e0b97ed748ea"
+ integrity sha512-S48WzZW777zhNIrn7gxOlISNAqi9ZC/uQFnRdbeIHhZhCA6UqpkOT8T1G7BvfdgP4Er8gF4sUbaS0i7QvIfCWw==
+ dependencies:
+ path-key "^3.0.0"
+
+object-assign@^4.1.1:
+ version "4.1.1"
+ resolved "https://registry.yarnpkg.com/object-assign/-/object-assign-4.1.1.tgz#2109adc7965887cfc05cbbd442cac8bfbb360863"
+ integrity sha512-rJgTQnkUnH1sFw8yT6VSU3zD3sWmu6sZhIseY8VX+GRu3P6F7Fu+JNDoXfklElbLJSnc3FUQHVe4cU5hj+BcUg==
+
+object-inspect@^1.12.0, object-inspect@^1.9.0:
+ version "1.12.2"
+ resolved "https://registry.yarnpkg.com/object-inspect/-/object-inspect-1.12.2.tgz#c0641f26394532f28ab8d796ab954e43c009a8ea"
+ integrity sha512-z+cPxW0QGUp0mcqcsgQyLVRDoXFQbXOwBaqyF7VIgI4TWNQsDHrBpUQslRmIfAoYWdYzs6UlKJtB2XJpTaNSpQ==
+
+object-keys@^1.1.1:
+ version "1.1.1"
+ resolved "https://registry.yarnpkg.com/object-keys/-/object-keys-1.1.1.tgz#1c47f272df277f3b1daf061677d9c82e2322c60e"
+ integrity sha512-NuAESUOUMrlIXOfHKzD6bpPu3tYt3xvjNdRIQ+FeT0lNb4K8WR70CaDxhuNguS2XG+GjkyMwOzsN5ZktImfhLA==
+
+object.assign@^4.1.2:
+ version "4.1.2"
+ resolved "https://registry.yarnpkg.com/object.assign/-/object.assign-4.1.2.tgz#0ed54a342eceb37b38ff76eb831a0e788cb63940"
+ integrity sha512-ixT2L5THXsApyiUPYKmW+2EHpXXe5Ii3M+f4e+aJFAHao5amFRW6J0OO6c/LU8Be47utCx2GL89hxGB6XSmKuQ==
+ dependencies:
+ call-bind "^1.0.0"
+ define-properties "^1.1.3"
+ has-symbols "^1.0.1"
+ object-keys "^1.1.1"
+
+object.entries@^1.1.4:
+ version "1.1.5"
+ resolved "https://registry.yarnpkg.com/object.entries/-/object.entries-1.1.5.tgz#e1acdd17c4de2cd96d5a08487cfb9db84d881861"
+ integrity sha512-TyxmjUoZggd4OrrU1W66FMDG6CuqJxsFvymeyXI51+vQLN67zYfZseptRge703kKQdo4uccgAKebXFcRCzk4+g==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ es-abstract "^1.19.1"
+
+object.fromentries@^2.0.4:
+ version "2.0.5"
+ resolved "https://registry.yarnpkg.com/object.fromentries/-/object.fromentries-2.0.5.tgz#7b37b205109c21e741e605727fe8b0ad5fa08251"
+ integrity sha512-CAyG5mWQRRiBU57Re4FKoTBjXfDoNwdFVH2Y1tS9PqCsfUTymAohOkEMSG3aRNKmv4lV3O7p1et7c187q6bynw==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ es-abstract "^1.19.1"
+
+object.values@^1.1.4:
+ version "1.1.5"
+ resolved "https://registry.yarnpkg.com/object.values/-/object.values-1.1.5.tgz#959f63e3ce9ef108720333082131e4a459b716ac"
+ integrity sha512-QUZRW0ilQ3PnPpbNtgdNV1PDbEqLIiSFB3l+EnGtBQ/8SUTLj1PZwtQHABZtLgwpJZTSZhuGLOGk57Drx2IvYg==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ es-abstract "^1.19.1"
+
+once@^1.3.0, once@^1.3.1, once@^1.4.0:
+ version "1.4.0"
+ resolved "https://registry.yarnpkg.com/once/-/once-1.4.0.tgz#583b1aa775961d4b113ac17d9c50baef9dd76bd1"
+ integrity sha512-lNaJgI+2Q5URQBkccEKHTQOPaXdUxnZZElQTZY0MFUAuaEqe1E+Nyvgdz/aIyNi6Z9MzO5dv1H8n58/GELp3+w==
+ dependencies:
+ wrappy "1"
+
+onetime@^5.1.0:
+ version "5.1.2"
+ resolved "https://registry.yarnpkg.com/onetime/-/onetime-5.1.2.tgz#d0e96ebb56b07476df1dd9c4806e5237985ca45e"
+ integrity sha512-kbpaSSGJTWdAY5KPVeMOKXSrPtr8C8C7wodJbcsd51jRnmD+GZu8Y0VoU6Dm5Z4vWr0Ig/1NKuWRKf7j5aaYSg==
+ dependencies:
+ mimic-fn "^2.1.0"
+
+optionator@^0.9.1:
+ version "0.9.1"
+ resolved "https://registry.yarnpkg.com/optionator/-/optionator-0.9.1.tgz#4f236a6373dae0566a6d43e1326674f50c291499"
+ integrity sha512-74RlY5FCnhq4jRxVUPKDaRwrVNXMqsGsiW6AJw4XK8hmtm10wC0ypZBLw5IIp85NZMr91+qd1RvvENwg7jjRFw==
+ dependencies:
+ deep-is "^0.1.3"
+ fast-levenshtein "^2.0.6"
+ levn "^0.4.1"
+ prelude-ls "^1.2.1"
+ type-check "^0.4.0"
+ word-wrap "^1.2.3"
+
+ospath@^1.2.2:
+ version "1.2.2"
+ resolved "https://registry.yarnpkg.com/ospath/-/ospath-1.2.2.tgz#1276639774a3f8ef2572f7fe4280e0ea4550c07b"
+ integrity sha512-o6E5qJV5zkAbIDNhGSIlyOhScKXgQrSRMilfph0clDfM0nEnBOlKlH4sWDmG95BW/CvwNz0vmm7dJVtU2KlMiA==
+
+p-map@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/p-map/-/p-map-4.0.0.tgz#bb2f95a5eda2ec168ec9274e06a747c3e2904d2b"
+ integrity sha512-/bjOqmgETBYB5BoEeGVea8dmvHb2m9GLy1E9W43yeyfP6QQCZGFNa+XRceJEuDB6zqr+gKpIAmlLebMpykw/MQ==
+ dependencies:
+ aggregate-error "^3.0.0"
+
+parent-module@^1.0.0:
+ version "1.0.1"
+ resolved "https://registry.yarnpkg.com/parent-module/-/parent-module-1.0.1.tgz#691d2709e78c79fae3a156622452d00762caaaa2"
+ integrity sha512-GQ2EWRpQV8/o+Aw8YqtfZZPfNRWZYkbidE9k5rpl/hC3vtHHBfGm2Ifi6qWV+coDGkrUKZAxE3Lot5kcsRlh+g==
+ dependencies:
+ callsites "^3.0.0"
+
+path-is-absolute@^1.0.0:
+ version "1.0.1"
+ resolved "https://registry.yarnpkg.com/path-is-absolute/-/path-is-absolute-1.0.1.tgz#174b9268735534ffbc7ace6bf53a5a9e1b5c5f5f"
+ integrity sha512-AVbw3UJ2e9bq64vSaS9Am0fje1Pa8pbGqTTsmXfaIiMpnr5DlDhfJOuLj9Sf95ZPVDAUerDfEk88MPmPe7UCQg==
+
+path-key@^3.0.0, path-key@^3.1.0:
+ version "3.1.1"
+ resolved "https://registry.yarnpkg.com/path-key/-/path-key-3.1.1.tgz#581f6ade658cbba65a0d3380de7753295054f375"
+ integrity sha512-ojmeN0qd+y0jszEtoY48r0Peq5dwMEkIlCOu6Q5f41lfkswXuKtYrhgoTpLnyIcHm24Uhqx+5Tqm2InSwLhE6Q==
+
+path-parse@^1.0.7:
+ version "1.0.7"
+ resolved "https://registry.yarnpkg.com/path-parse/-/path-parse-1.0.7.tgz#fbc114b60ca42b30d9daf5858e4bd68bbedb6735"
+ integrity sha512-LDJzPVEEEPR+y48z93A0Ed0yXb8pAByGWo/k5YYdYgpY2/2EsOsksJrq7lOHxryrVOn1ejG6oAp8ahvOIQD8sw==
+
+path-type@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/path-type/-/path-type-4.0.0.tgz#84ed01c0a7ba380afe09d90a8c180dcd9d03043b"
+ integrity sha512-gDKb8aZMDeD/tZWs9P6+q0J9Mwkdl6xMV8TjnGP3qJVJ06bdMgkbBlLU8IdfOsIsFz2BW1rNVT3XuNEl8zPAvw==
+
+pend@~1.2.0:
+ version "1.2.0"
+ resolved "https://registry.yarnpkg.com/pend/-/pend-1.2.0.tgz#7a57eb550a6783f9115331fcf4663d5c8e007a50"
+ integrity sha512-F3asv42UuXchdzt+xXqfW1OGlVBe+mxa2mqI0pg5yAHZPvFmY3Y6drSf/GQ1A86WgWEN9Kzh/WrgKa6iGcHXLg==
+
+performance-now@^2.1.0:
+ version "2.1.0"
+ resolved "https://registry.yarnpkg.com/performance-now/-/performance-now-2.1.0.tgz#6309f4e0e5fa913ec1c69307ae364b4b377c9e7b"
+ integrity sha512-7EAHlyLHI56VEIdK57uwHdHKIaAGbnXPiw0yWbarQZOKaKpvUIgW0jWRVLiatnM+XXlSwsanIBH/hzGMJulMow==
+
+picomatch@^2.3.1:
+ version "2.3.1"
+ resolved "https://registry.yarnpkg.com/picomatch/-/picomatch-2.3.1.tgz#3ba3833733646d9d3e4995946c1365a67fb07a42"
+ integrity sha512-JU3teHTNjmE2VCGFzuY8EXzCDVwEqB2a8fsIvwaStHhAWJEeVd1o1QD80CU6+ZdEXXSLbSsuLwJjkCBWqRQUVA==
+
+pify@^2.2.0:
+ version "2.3.0"
+ resolved "https://registry.yarnpkg.com/pify/-/pify-2.3.0.tgz#ed141a6ac043a849ea588498e7dca8b15330e90c"
+ integrity sha512-udgsAY+fTnvv7kI7aaxbqwWNb0AHiB0qBO89PZKPkoTmGOgdbrHDKD+0B2X4uTfJ/FT1R09r9gTsjUjNJotuog==
+
+prelude-ls@^1.2.1:
+ version "1.2.1"
+ resolved "https://registry.yarnpkg.com/prelude-ls/-/prelude-ls-1.2.1.tgz#debc6489d7a6e6b0e7611888cec880337d316396"
+ integrity sha512-vkcDPrRZo1QZLbn5RLGPpg/WmIQ65qoWWhcGKf/b5eplkkarX0m9z8ppCat4mlOqUsWpyNuYgO3VRyrYHSzX5g==
+
+prettier-linter-helpers@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/prettier-linter-helpers/-/prettier-linter-helpers-1.0.0.tgz#d23d41fe1375646de2d0104d3454a3008802cf7b"
+ integrity sha512-GbK2cP9nraSSUF9N2XwUwqfzlAFlMNYYl+ShE/V+H8a9uNl/oUqB1w2EL54Jh0OlyRSd8RfWYJ3coVS4TROP2w==
+ dependencies:
+ fast-diff "^1.1.2"
+
[email protected]:
+ version "2.6.2"
+ resolved "https://registry.yarnpkg.com/prettier/-/prettier-2.6.2.tgz#e26d71a18a74c3d0f0597f55f01fb6c06c206032"
+ integrity sha512-PkUpF+qoXTqhOeWL9fu7As8LXsIUZ1WYaJiY/a7McAQzxjk82OF0tibkFXVCDImZtWxbvojFjerkiLb0/q8mew==
+
+pretty-bytes@^5.6.0:
+ version "5.6.0"
+ resolved "https://registry.yarnpkg.com/pretty-bytes/-/pretty-bytes-5.6.0.tgz#356256f643804773c82f64723fe78c92c62beaeb"
+ integrity sha512-FFw039TmrBqFK8ma/7OL3sDz/VytdtJr044/QUJtH0wK9lb9jLq9tJyIxUwtQJHwar2BqtiA4iCWSwo9JLkzFg==
+
+pretty-format@^27.0.2:
+ version "27.5.1"
+ resolved "https://registry.yarnpkg.com/pretty-format/-/pretty-format-27.5.1.tgz#2181879fdea51a7a5851fb39d920faa63f01d88e"
+ integrity sha512-Qb1gy5OrP5+zDf2Bvnzdl3jsTf1qXVMazbvCoKhtKqVs4/YK4ozX4gKQJJVyNe+cajNPn0KoC0MC3FUmaHWEmQ==
+ dependencies:
+ ansi-regex "^5.0.1"
+ ansi-styles "^5.0.0"
+ react-is "^17.0.1"
+
+progress@^2.0.0:
+ version "2.0.3"
+ resolved "https://registry.yarnpkg.com/progress/-/progress-2.0.3.tgz#7e8cf8d8f5b8f239c1bc68beb4eb78567d572ef8"
+ integrity sha512-7PiHtLll5LdnKIMw100I+8xJXR5gW2QwWYkT6iJva0bXitZKa/XMrSbdmg3r2Xnaidz9Qumd0VPaMrZlF9V9sA==
+
+prop-types@^15.7.2:
+ version "15.8.1"
+ resolved "https://registry.yarnpkg.com/prop-types/-/prop-types-15.8.1.tgz#67d87bf1a694f48435cf332c24af10214a3140b5"
+ integrity sha512-oj87CgZICdulUohogVAR7AjlC0327U4el4L6eAvOqCeudMDVU0NThNaV+b9Df4dXgSP1gXMTnPdhfe/2qDH5cg==
+ dependencies:
+ loose-envify "^1.4.0"
+ object-assign "^4.1.1"
+ react-is "^16.13.1"
+
[email protected]:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/proxy-from-env/-/proxy-from-env-1.0.0.tgz#33c50398f70ea7eb96d21f7b817630a55791c7ee"
+ integrity sha512-F2JHgJQ1iqwnHDcQjVBsq3n/uoaFL+iPW/eAeL7kVxy/2RrWaN4WroKjjvbsoRtv0ftelNyC01bjRhn/bhcf4A==
+
+psl@^1.1.28:
+ version "1.9.0"
+ resolved "https://registry.yarnpkg.com/psl/-/psl-1.9.0.tgz#d0df2a137f00794565fcaf3b2c00cd09f8d5a5a7"
+ integrity sha512-E/ZsdU4HLs/68gYzgGTkMicWTLPdAftJLfJFlLUAAKZGkStNU72sZjT66SnMDVOfOWY/YAoiD7Jxa9iHvngcag==
+
+pump@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/pump/-/pump-3.0.0.tgz#b4a2116815bde2f4e1ea602354e8c75565107a64"
+ integrity sha512-LwZy+p3SFs1Pytd/jYct4wpv49HiYCqd9Rlc5ZVdk0V+8Yzv6jR5Blk3TRmPL1ft69TxP0IMZGJ+WPFU2BFhww==
+ dependencies:
+ end-of-stream "^1.1.0"
+ once "^1.3.1"
+
+punycode@^2.1.0, punycode@^2.1.1:
+ version "2.1.1"
+ resolved "https://registry.yarnpkg.com/punycode/-/punycode-2.1.1.tgz#b58b010ac40c22c5657616c8d2c2c02c7bf479ec"
+ integrity sha512-XRsRjdf+j5ml+y/6GKHPZbrF/8p2Yga0JPtdqTIY2Xe5ohJPD9saDJJLPvp9+NSBprVvevdXZybnj2cv8OEd0A==
+
+qs@~6.5.2:
+ version "6.5.3"
+ resolved "https://registry.yarnpkg.com/qs/-/qs-6.5.3.tgz#3aeeffc91967ef6e35c0e488ef46fb296ab76aad"
+ integrity sha512-qxXIEh4pCGfHICj1mAJQ2/2XVZkjCDTcEgfoSQxc/fYivUZxTkk7L3bDBJSoNrEzXI17oUO5Dp07ktqE5KzczA==
+
+queue-microtask@^1.2.2:
+ version "1.2.3"
+ resolved "https://registry.yarnpkg.com/queue-microtask/-/queue-microtask-1.2.3.tgz#4929228bbc724dfac43e0efb058caf7b6cfb6243"
+ integrity sha512-NuaNSa6flKT5JaSYQzJok04JzTL1CA6aGhv5rfLW3PgqA+M2ChpZQnAC8h8i4ZFkBS8X5RqkDBHA7r4hej3K9A==
+
+react-is@^16.13.1:
+ version "16.13.1"
+ resolved "https://registry.yarnpkg.com/react-is/-/react-is-16.13.1.tgz#789729a4dc36de2999dc156dd6c1d9c18cea56a4"
+ integrity sha512-24e6ynE2H+OKt4kqsOvNd8kBpV65zoxbA4BVsEOB3ARVWQki/DHzaUoC5KuON/BiccDaCCTZBuOcfZs70kR8bQ==
+
+react-is@^17.0.1:
+ version "17.0.2"
+ resolved "https://registry.yarnpkg.com/react-is/-/react-is-17.0.2.tgz#e691d4a8e9c789365655539ab372762b0efb54f0"
+ integrity sha512-w2GsyukL62IJnlaff/nRegPQR94C/XXamvMWmSHRJ4y7Ts/4ocGRmTHvOs8PSE6pB3dWOrD/nueuU5sduBsQ4w==
+
+regenerator-runtime@^0.13.4:
+ version "0.13.9"
+ resolved "https://registry.yarnpkg.com/regenerator-runtime/-/regenerator-runtime-0.13.9.tgz#8925742a98ffd90814988d7566ad30ca3b263b52"
+ integrity sha512-p3VT+cOEgxFsRRA9X4lkI1E+k2/CtnKtU4gcxyaCUreilL/vqI6CdZ3wxVUx3UOUg+gnUOQQcRI7BmSI656MYA==
+
+regexp.prototype.flags@^1.4.1, regexp.prototype.flags@^1.4.3:
+ version "1.4.3"
+ resolved "https://registry.yarnpkg.com/regexp.prototype.flags/-/regexp.prototype.flags-1.4.3.tgz#87cab30f80f66660181a3bb7bf5981a872b367ac"
+ integrity sha512-fjggEOO3slI6Wvgjwflkc4NFRCTZAu5CnNfBd5qOMYhWdn67nJBBu34/TkD++eeFmd8C9r9jfXJ27+nSiRkSUA==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ functions-have-names "^1.2.2"
+
+regexpp@^3.1.0:
+ version "3.2.0"
+ resolved "https://registry.yarnpkg.com/regexpp/-/regexpp-3.2.0.tgz#0425a2768d8f23bad70ca4b90461fa2f1213e1b2"
+ integrity sha512-pq2bWo9mVD43nbts2wGv17XLiNLya+GklZ8kaDLV2Z08gDCsGpnKn9BFMepvWuHCbyVvY7J5o5+BVvoQbmlJLg==
+
+request-progress@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/request-progress/-/request-progress-3.0.0.tgz#4ca754081c7fec63f505e4faa825aa06cd669dbe"
+ integrity sha512-MnWzEHHaxHO2iWiQuHrUPBi/1WeBf5PkxQqNyNvLl9VAYSdXkP8tQ3pBSeCPD+yw0v0Aq1zosWLz0BdeXpWwZg==
+ dependencies:
+ throttleit "^1.0.0"
+
+require-from-string@^2.0.2:
+ version "2.0.2"
+ resolved "https://registry.yarnpkg.com/require-from-string/-/require-from-string-2.0.2.tgz#89a7fdd938261267318eafe14f9c32e598c36909"
+ integrity sha512-Xf0nWe6RseziFMu+Ap9biiUbmplq6S9/p+7w7YXP/JBHhrUDDUhwa+vANyubuqfZWTveU//DYVGsDG7RKL/vEw==
+
+resolve-from@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/resolve-from/-/resolve-from-4.0.0.tgz#4abcd852ad32dd7baabfe9b40e00a36db5f392e6"
+ integrity sha512-pb/MYmXstAkysRFx8piNI1tGFNQIFA3vkE3Gq4EuA1dF6gHp/+vgZqsCGJapvy8N3Q+4o7FwvquPJcnZ7RYy4g==
+
+resolve@^2.0.0-next.3:
+ version "2.0.0-next.4"
+ resolved "https://registry.yarnpkg.com/resolve/-/resolve-2.0.0-next.4.tgz#3d37a113d6429f496ec4752d2a2e58efb1fd4660"
+ integrity sha512-iMDbmAWtfU+MHpxt/I5iWI7cY6YVEZUQ3MBgPQ++XD1PELuJHIl82xBmObyP2KyQmkNB2dsqF7seoQQiAn5yDQ==
+ dependencies:
+ is-core-module "^2.9.0"
+ path-parse "^1.0.7"
+ supports-preserve-symlinks-flag "^1.0.0"
+
+restore-cursor@^3.1.0:
+ version "3.1.0"
+ resolved "https://registry.yarnpkg.com/restore-cursor/-/restore-cursor-3.1.0.tgz#39f67c54b3a7a58cea5236d95cf0034239631f7e"
+ integrity sha512-l+sSefzHpj5qimhFSE5a8nufZYAM3sBSVMAPtYkmC+4EH2anSGaEMXSD0izRQbu9nfyQ9y5JrVmp7E8oZrUjvA==
+ dependencies:
+ onetime "^5.1.0"
+ signal-exit "^3.0.2"
+
+reusify@^1.0.4:
+ version "1.0.4"
+ resolved "https://registry.yarnpkg.com/reusify/-/reusify-1.0.4.tgz#90da382b1e126efc02146e90845a88db12925d76"
+ integrity sha512-U9nH88a3fc/ekCF1l0/UP1IosiuIjyTh7hBvXVMHYgVcfGvt897Xguj2UOLDeI5BG2m7/uwyaLVT6fbtCwTyzw==
+
+rfdc@^1.3.0:
+ version "1.3.0"
+ resolved "https://registry.yarnpkg.com/rfdc/-/rfdc-1.3.0.tgz#d0b7c441ab2720d05dc4cf26e01c89631d9da08b"
+ integrity sha512-V2hovdzFbOi77/WajaSMXk2OLm+xNIeQdMMuB7icj7bk6zi2F8GGAxigcnDFpJHbNyNcgyJDiP+8nOrY5cZGrA==
+
+rimraf@^3.0.0, rimraf@^3.0.2:
+ version "3.0.2"
+ resolved "https://registry.yarnpkg.com/rimraf/-/rimraf-3.0.2.tgz#f1a5402ba6220ad52cc1282bac1ae3aa49fd061a"
+ integrity sha512-JZkJMZkAGFFPP2YqXZXPbMlMBgsxzE8ILs4lMIX/2o0L9UBw9O/Y3o6wFw/i9YLapcUJWwqbi3kdxIPdC62TIA==
+ dependencies:
+ glob "^7.1.3"
+
+run-parallel@^1.1.9:
+ version "1.2.0"
+ resolved "https://registry.yarnpkg.com/run-parallel/-/run-parallel-1.2.0.tgz#66d1368da7bdf921eb9d95bd1a9229e7f21a43ee"
+ integrity sha512-5l4VyZR86LZ/lDxZTR6jqL8AFE2S0IFLMP26AbjsLVADxHdhB/c0GUsH+y39UfCi3dzz8OlQuPmnaJOMoDHQBA==
+ dependencies:
+ queue-microtask "^1.2.2"
+
+rxjs@^7.5.1:
+ version "7.5.6"
+ resolved "https://registry.yarnpkg.com/rxjs/-/rxjs-7.5.6.tgz#0446577557862afd6903517ce7cae79ecb9662bc"
+ integrity sha512-dnyv2/YsXhnm461G+R/Pe5bWP41Nm6LBXEYWI6eiFP4fiwx6WRI/CD0zbdVAudd9xwLEF2IDcKXLHit0FYjUzw==
+ dependencies:
+ tslib "^2.1.0"
+
+safe-buffer@^5.0.1, safe-buffer@^5.1.2:
+ version "5.2.1"
+ resolved "https://registry.yarnpkg.com/safe-buffer/-/safe-buffer-5.2.1.tgz#1eaf9fa9bdb1fdd4ec75f58f9cdb4e6b7827eec6"
+ integrity sha512-rp3So07KcdmmKbGvgaNxQSJr7bGVSVk5S9Eq1F+ppbRo70+YeaDxkw5Dd8NPN+GD6bjnYm2VuPuCXmpuYvmCXQ==
+
+safer-buffer@^2.0.2, safer-buffer@^2.1.0, safer-buffer@~2.1.0:
+ version "2.1.2"
+ resolved "https://registry.yarnpkg.com/safer-buffer/-/safer-buffer-2.1.2.tgz#44fa161b0187b9549dd84bb91802f9bd8385cd6a"
+ integrity sha512-YZo3K82SD7Riyi0E1EQPojLz7kpepnSQI9IyPbHHg1XXXevb5dJI7tpyN2ADxGcQbHG7vcyRHk0cbwqcQriUtg==
+
+semver@^7.2.1, semver@^7.3.2, semver@^7.3.5:
+ version "7.3.7"
+ resolved "https://registry.yarnpkg.com/semver/-/semver-7.3.7.tgz#12c5b649afdbf9049707796e22a4028814ce523f"
+ integrity sha512-QlYTucUYOews+WeEujDoEGziz4K6c47V/Bd+LjSSYcA94p+DmINdf7ncaUinThfvZyu13lN9OY1XDxt8C0Tw0g==
+ dependencies:
+ lru-cache "^6.0.0"
+
+shebang-command@^2.0.0:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/shebang-command/-/shebang-command-2.0.0.tgz#ccd0af4f8835fbdc265b82461aaf0c36663f34ea"
+ integrity sha512-kHxr2zZpYtdmrN1qDjrrX/Z1rR1kG8Dx+gkpK1G4eXmvXswmcE1hTWBWYUzlraYw1/yZp6YuDY77YtvbN0dmDA==
+ dependencies:
+ shebang-regex "^3.0.0"
+
+shebang-regex@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/shebang-regex/-/shebang-regex-3.0.0.tgz#ae16f1644d873ecad843b0307b143362d4c42172"
+ integrity sha512-7++dFhtcx3353uBaq8DDR4NuxBetBzC7ZQOhmTQInHEd6bSrXdiEyzCvG07Z44UYdLShWUyXt5M/yhz8ekcb1A==
+
+side-channel@^1.0.4:
+ version "1.0.4"
+ resolved "https://registry.yarnpkg.com/side-channel/-/side-channel-1.0.4.tgz#efce5c8fdc104ee751b25c58d4290011fa5ea2cf"
+ integrity sha512-q5XPytqFEIKHkGdiMIrY10mvLRvnQh42/+GoBlFW3b2LXLE2xxJpZFdm94we0BaoV3RwJyGqg5wS7epxTv0Zvw==
+ dependencies:
+ call-bind "^1.0.0"
+ get-intrinsic "^1.0.2"
+ object-inspect "^1.9.0"
+
+signal-exit@^3.0.2:
+ version "3.0.7"
+ resolved "https://registry.yarnpkg.com/signal-exit/-/signal-exit-3.0.7.tgz#a9a1767f8af84155114eaabd73f99273c8f59ad9"
+ integrity sha512-wnD2ZE+l+SPC/uoS0vXeE9L1+0wuaMqKlfz9AMUo38JsyLSBWSFcHR1Rri62LZc12vLr1gb3jl7iwQhgwpAbGQ==
+
+slash@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/slash/-/slash-3.0.0.tgz#6539be870c165adbd5240220dbe361f1bc4d4634"
+ integrity sha512-g9Q1haeby36OSStwb4ntCGGGaKsaVSjQ68fBxoQcutl5fS1vuY18H3wSt3jFyFtrkx+Kz0V1G85A4MyAdDMi2Q==
+
+slice-ansi@^3.0.0:
+ version "3.0.0"
+ resolved "https://registry.yarnpkg.com/slice-ansi/-/slice-ansi-3.0.0.tgz#31ddc10930a1b7e0b67b08c96c2f49b77a789787"
+ integrity sha512-pSyv7bSTC7ig9Dcgbw9AuRNUb5k5V6oDudjZoMBSr13qpLBG7tB+zgCkARjq7xIUgdz5P1Qe8u+rSGdouOOIyQ==
+ dependencies:
+ ansi-styles "^4.0.0"
+ astral-regex "^2.0.0"
+ is-fullwidth-code-point "^3.0.0"
+
+slice-ansi@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/slice-ansi/-/slice-ansi-4.0.0.tgz#500e8dd0fd55b05815086255b3195adf2a45fe6b"
+ integrity sha512-qMCMfhY040cVHT43K9BFygqYbUPFZKHOg7K73mtTWJRb8pyP3fzf4Ixd5SzdEJQ6MRUg/WBnOLxghZtKKurENQ==
+ dependencies:
+ ansi-styles "^4.0.0"
+ astral-regex "^2.0.0"
+ is-fullwidth-code-point "^3.0.0"
+
+sprintf-js@~1.0.2:
+ version "1.0.3"
+ resolved "https://registry.yarnpkg.com/sprintf-js/-/sprintf-js-1.0.3.tgz#04e6926f662895354f3dd015203633b857297e2c"
+ integrity sha512-D9cPgkvLlV3t3IzL0D0YLvGA9Ahk4PcvVwUbN0dSGr1aP0Nrt4AEnTUbuGvquEC0mA64Gqt1fzirlRs5ibXx8g==
+
+sshpk@^1.14.1:
+ version "1.17.0"
+ resolved "https://registry.yarnpkg.com/sshpk/-/sshpk-1.17.0.tgz#578082d92d4fe612b13007496e543fa0fbcbe4c5"
+ integrity sha512-/9HIEs1ZXGhSPE8X6Ccm7Nam1z8KcoCqPdI7ecm1N33EzAetWahvQWVqLZtaZQ+IDKX4IyA2o0gBzqIMkAagHQ==
+ dependencies:
+ asn1 "~0.2.3"
+ assert-plus "^1.0.0"
+ bcrypt-pbkdf "^1.0.0"
+ dashdash "^1.12.0"
+ ecc-jsbn "~0.1.1"
+ getpass "^0.1.1"
+ jsbn "~0.1.0"
+ safer-buffer "^2.0.2"
+ tweetnacl "~0.14.0"
+
+string-width@^4.1.0, string-width@^4.2.0, string-width@^4.2.3:
+ version "4.2.3"
+ resolved "https://registry.yarnpkg.com/string-width/-/string-width-4.2.3.tgz#269c7117d27b05ad2e536830a8ec895ef9c6d010"
+ integrity sha512-wKyQRQpjJ0sIp62ErSZdGsjMJWsap5oRNihHhu6G7JVO/9jIB6UyevL+tXuOqrng8j/cxKTWyWUwvSTriiZz/g==
+ dependencies:
+ emoji-regex "^8.0.0"
+ is-fullwidth-code-point "^3.0.0"
+ strip-ansi "^6.0.1"
+
+string.prototype.matchall@^4.0.5:
+ version "4.0.7"
+ resolved "https://registry.yarnpkg.com/string.prototype.matchall/-/string.prototype.matchall-4.0.7.tgz#8e6ecb0d8a1fb1fda470d81acecb2dba057a481d"
+ integrity sha512-f48okCX7JiwVi1NXCVWcFnZgADDC/n2vePlQ/KUCNqCikLLilQvwjMO8+BHVKvgzH0JB0J9LEPgxOGT02RoETg==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.3"
+ es-abstract "^1.19.1"
+ get-intrinsic "^1.1.1"
+ has-symbols "^1.0.3"
+ internal-slot "^1.0.3"
+ regexp.prototype.flags "^1.4.1"
+ side-channel "^1.0.4"
+
+string.prototype.trimend@^1.0.5:
+ version "1.0.5"
+ resolved "https://registry.yarnpkg.com/string.prototype.trimend/-/string.prototype.trimend-1.0.5.tgz#914a65baaab25fbdd4ee291ca7dde57e869cb8d0"
+ integrity sha512-I7RGvmjV4pJ7O3kdf+LXFpVfdNOxtCW/2C8f6jNiW4+PQchwxkCDzlk1/7p+Wl4bqFIZeF47qAHXLuHHWKAxog==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.4"
+ es-abstract "^1.19.5"
+
+string.prototype.trimstart@^1.0.5:
+ version "1.0.5"
+ resolved "https://registry.yarnpkg.com/string.prototype.trimstart/-/string.prototype.trimstart-1.0.5.tgz#5466d93ba58cfa2134839f81d7f42437e8c01fef"
+ integrity sha512-THx16TJCGlsN0o6dl2o6ncWUsdgnLRSA23rRE5pyGBw/mLr3Ej/R2LaqCtgP8VNMGZsvMWnf9ooZPyY2bHvUFg==
+ dependencies:
+ call-bind "^1.0.2"
+ define-properties "^1.1.4"
+ es-abstract "^1.19.5"
+
+strip-ansi@^6.0.0, strip-ansi@^6.0.1:
+ version "6.0.1"
+ resolved "https://registry.yarnpkg.com/strip-ansi/-/strip-ansi-6.0.1.tgz#9e26c63d30f53443e9489495b2105d37b67a85d9"
+ integrity sha512-Y38VPSHcqkFrCpFnQ9vuSXmquuv5oXOKpGeT6aGrr3o3Gc9AlVa6JBfUSOCnbxGGZF+/0ooI7KrPuUSztUdU5A==
+ dependencies:
+ ansi-regex "^5.0.1"
+
+strip-final-newline@^2.0.0:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/strip-final-newline/-/strip-final-newline-2.0.0.tgz#89b852fb2fcbe936f6f4b3187afb0a12c1ab58ad"
+ integrity sha512-BrpvfNAE3dcvq7ll3xVumzjKjZQ5tI1sEUIKr3Uoks0XUl45St3FlatVqef9prk4jRDzhW6WZg+3bk93y6pLjA==
+
+strip-json-comments@^3.1.0, strip-json-comments@^3.1.1:
+ version "3.1.1"
+ resolved "https://registry.yarnpkg.com/strip-json-comments/-/strip-json-comments-3.1.1.tgz#31f1281b3832630434831c310c01cccda8cbe006"
+ integrity sha512-6fPc+R4ihwqP6N/aIv2f1gMH8lOVtWQHoqC4yK6oSDVVocumAsfCqjkXnqiYMhmMwS/mEHLp7Vehlt3ql6lEig==
+
+supports-color@^5.3.0:
+ version "5.5.0"
+ resolved "https://registry.yarnpkg.com/supports-color/-/supports-color-5.5.0.tgz#e2e69a44ac8772f78a1ec0b35b689df6530efc8f"
+ integrity sha512-QjVjwdXIt408MIiAqCX4oUKsgU2EqAGzs2Ppkm4aQYbjm+ZEWEcW4SfFNTr4uMNZma0ey4f5lgLrkB0aX0QMow==
+ dependencies:
+ has-flag "^3.0.0"
+
+supports-color@^7.1.0:
+ version "7.2.0"
+ resolved "https://registry.yarnpkg.com/supports-color/-/supports-color-7.2.0.tgz#1b7dcdcb32b8138801b3e478ba6a51caa89648da"
+ integrity sha512-qpCAvRl9stuOHveKsn7HncJRvv501qIacKzQlO/+Lwxc9+0q2wLyv4Dfvt80/DPn2pqOBsJdDiogXGR9+OvwRw==
+ dependencies:
+ has-flag "^4.0.0"
+
+supports-color@^8.1.1:
+ version "8.1.1"
+ resolved "https://registry.yarnpkg.com/supports-color/-/supports-color-8.1.1.tgz#cd6fc17e28500cff56c1b86c0a7fd4a54a73005c"
+ integrity sha512-MpUEN2OodtUzxvKQl72cUF7RQ5EiHsGvSsVG0ia9c5RbWGL2CI4C7EpPS8UTBIplnlzZiNuV56w+FuNxy3ty2Q==
+ dependencies:
+ has-flag "^4.0.0"
+
+supports-preserve-symlinks-flag@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/supports-preserve-symlinks-flag/-/supports-preserve-symlinks-flag-1.0.0.tgz#6eda4bd344a3c94aea376d4cc31bc77311039e09"
+ integrity sha512-ot0WnXS9fgdkgIcePe6RHNk1WA8+muPa6cSjeR3V8K27q9BB1rTE3R1p7Hv0z1ZyAc8s6Vvv8DIyWf681MAt0w==
+
+table@^6.0.9:
+ version "6.8.0"
+ resolved "https://registry.yarnpkg.com/table/-/table-6.8.0.tgz#87e28f14fa4321c3377ba286f07b79b281a3b3ca"
+ integrity sha512-s/fitrbVeEyHKFa7mFdkuQMWlH1Wgw/yEXMt5xACT4ZpzWFluehAxRtUUQKPuWhaLAWhFcVx6w3oC8VKaUfPGA==
+ dependencies:
+ ajv "^8.0.1"
+ lodash.truncate "^4.4.2"
+ slice-ansi "^4.0.0"
+ string-width "^4.2.3"
+ strip-ansi "^6.0.1"
+
+text-table@^0.2.0:
+ version "0.2.0"
+ resolved "https://registry.yarnpkg.com/text-table/-/text-table-0.2.0.tgz#7f5ee823ae805207c00af2df4a84ec3fcfa570b4"
+ integrity sha512-N+8UisAXDGk8PFXP4HAzVR9nbfmVJ3zYLAWiTIoqC5v5isinhr+r5uaO8+7r3BMfuNIufIsA7RdpVgacC2cSpw==
+
+throttleit@^1.0.0:
+ version "1.0.0"
+ resolved "https://registry.yarnpkg.com/throttleit/-/throttleit-1.0.0.tgz#9e785836daf46743145a5984b6268d828528ac6c"
+ integrity sha512-rkTVqu6IjfQ/6+uNuuc3sZek4CEYxTJom3IktzgdSxcZqdARuebbA/f4QmAxMQIxqq9ZLEUkSYqvuk1I6VKq4g==
+
+through@^2.3.8:
+ version "2.3.8"
+ resolved "https://registry.yarnpkg.com/through/-/through-2.3.8.tgz#0dd4c9ffaabc357960b1b724115d7e0e86a2e1f5"
+ integrity sha512-w89qg7PI8wAdvX60bMDP+bFoD5Dvhm9oLheFp5O4a2QF0cSBGsBX4qZmadPMvVqlLJBBci+WqGGOAPvcDeNSVg==
+
+tmp@~0.2.1:
+ version "0.2.1"
+ resolved "https://registry.yarnpkg.com/tmp/-/tmp-0.2.1.tgz#8457fc3037dcf4719c251367a1af6500ee1ccf14"
+ integrity sha512-76SUhtfqR2Ijn+xllcI5P1oyannHNHByD80W1q447gU3mp9G9PSpGdWmjUOHRDPiHYacIk66W7ubDTuPF3BEtQ==
+ dependencies:
+ rimraf "^3.0.0"
+
+to-regex-range@^5.0.1:
+ version "5.0.1"
+ resolved "https://registry.yarnpkg.com/to-regex-range/-/to-regex-range-5.0.1.tgz#1648c44aae7c8d988a326018ed72f5b4dd0392e4"
+ integrity sha512-65P7iz6X5yEr1cwcgvQxbbIw7Uk3gOy5dIdtZ4rDveLqhrdJP+Li/Hx6tyK0NEb+2GCyneCMJiGqrADCSNk8sQ==
+ dependencies:
+ is-number "^7.0.0"
+
+tough-cookie@~2.5.0:
+ version "2.5.0"
+ resolved "https://registry.yarnpkg.com/tough-cookie/-/tough-cookie-2.5.0.tgz#cd9fb2a0aa1d5a12b473bd9fb96fa3dcff65ade2"
+ integrity sha512-nlLsUzgm1kfLXSXfRZMc1KLAugd4hqJHDTvc2hDIwS3mZAfMEuMbc03SujMF+GEcpaX/qboeycw6iO8JwVv2+g==
+ dependencies:
+ psl "^1.1.28"
+ punycode "^2.1.1"
+
+tslib@^1.8.1:
+ version "1.14.1"
+ resolved "https://registry.yarnpkg.com/tslib/-/tslib-1.14.1.tgz#cf2d38bdc34a134bcaf1091c41f6619e2f672d00"
+ integrity sha512-Xni35NKzjgMrwevysHTCArtLDpPvye8zV/0E4EyYn43P7/7qvQwPh9BGkHewbMulVntbigmcT7rdX3BNo9wRJg==
+
+tslib@^2.1.0:
+ version "2.4.0"
+ resolved "https://registry.yarnpkg.com/tslib/-/tslib-2.4.0.tgz#7cecaa7f073ce680a05847aa77be941098f36dc3"
+ integrity sha512-d6xOpEDfsi2CZVlPQzGeux8XMwLT9hssAsaPYExaQMuYskwb+x1x7J371tWlbBdWHroy99KnVB6qIkUbs5X3UQ==
+
+tsutils@^3.17.1, tsutils@^3.21.0:
+ version "3.21.0"
+ resolved "https://registry.yarnpkg.com/tsutils/-/tsutils-3.21.0.tgz#b48717d394cea6c1e096983eed58e9d61715b623"
+ integrity sha512-mHKK3iUXL+3UF6xL5k0PEhKRUBKPBCv/+RkEOpjRWxxx27KKRBmmA60A9pgOUvMi8GKhRMPEmjBRPzs2W7O1OA==
+ dependencies:
+ tslib "^1.8.1"
+
+tunnel-agent@^0.6.0:
+ version "0.6.0"
+ resolved "https://registry.yarnpkg.com/tunnel-agent/-/tunnel-agent-0.6.0.tgz#27a5dea06b36b04a0a9966774b290868f0fc40fd"
+ integrity sha512-McnNiV1l8RYeY8tBgEpuodCC1mLUdbSN+CYBL7kJsJNInOP8UjDDEwdk6Mw60vdLLrr5NHKZhMAOSrR2NZuQ+w==
+ dependencies:
+ safe-buffer "^5.0.1"
+
+tweetnacl@^0.14.3, tweetnacl@~0.14.0:
+ version "0.14.5"
+ resolved "https://registry.yarnpkg.com/tweetnacl/-/tweetnacl-0.14.5.tgz#5ae68177f192d4456269d108afa93ff8743f4f64"
+ integrity sha512-KXXFFdAbFXY4geFIwoyNK+f5Z1b7swfXABfL7HXCmoIWMKU3dmS26672A4EeQtDzLKy7SXmfBu51JolvEKwtGA==
+
+type-check@^0.4.0, type-check@~0.4.0:
+ version "0.4.0"
+ resolved "https://registry.yarnpkg.com/type-check/-/type-check-0.4.0.tgz#07b8203bfa7056c0657050e3ccd2c37730bab8f1"
+ integrity sha512-XleUoc9uwGXqjWwXaUTZAmzMcFZ5858QA2vvx1Ur5xIcixXIP+8LnFDgRplU30us6teqdlskFfu+ae4K79Ooew==
+ dependencies:
+ prelude-ls "^1.2.1"
+
+type-fest@^0.20.2:
+ version "0.20.2"
+ resolved "https://registry.yarnpkg.com/type-fest/-/type-fest-0.20.2.tgz#1bf207f4b28f91583666cb5fbd327887301cd5f4"
+ integrity sha512-Ne+eE4r0/iWnpAxD852z3A+N0Bt5RN//NjJwRd2VFHEmrywxf5vsZlh4R6lixl6B+wz/8d+maTSAkN1FIkI3LQ==
+
+type-fest@^0.21.3:
+ version "0.21.3"
+ resolved "https://registry.yarnpkg.com/type-fest/-/type-fest-0.21.3.tgz#d260a24b0198436e133fa26a524a6d65fa3b2e37"
+ integrity sha512-t0rzBq87m3fVcduHDUFhKmyyX+9eo6WQjZvf51Ea/M0Q7+T374Jp1aUiyUl0GKxp8M/OETVHSDvmkyPgvX+X2w==
+
+typescript@^4.6.3:
+ version "4.7.4"
+ resolved "https://registry.yarnpkg.com/typescript/-/typescript-4.7.4.tgz#1a88596d1cf47d59507a1bcdfb5b9dfe4d488235"
+ integrity sha512-C0WQT0gezHuw6AdY1M2jxUO83Rjf0HP7Sk1DtXj6j1EwkQNZrHAg2XPWlq62oqEhYvONq5pkC2Y9oPljWToLmQ==
+
+unbox-primitive@^1.0.2:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/unbox-primitive/-/unbox-primitive-1.0.2.tgz#29032021057d5e6cdbd08c5129c226dff8ed6f9e"
+ integrity sha512-61pPlCD9h51VoreyJ0BReideM3MDKMKnh6+V9L08331ipq6Q8OFXZYiqP6n/tbHx4s5I9uRhcye6BrbkizkBDw==
+ dependencies:
+ call-bind "^1.0.2"
+ has-bigints "^1.0.2"
+ has-symbols "^1.0.3"
+ which-boxed-primitive "^1.0.2"
+
+universalify@^2.0.0:
+ version "2.0.0"
+ resolved "https://registry.yarnpkg.com/universalify/-/universalify-2.0.0.tgz#75a4984efedc4b08975c5aeb73f530d02df25717"
+ integrity sha512-hAZsKq7Yy11Zu1DE0OzWjw7nnLZmJZYTDZZyEFHZdUhV8FkH5MCfoU1XMaxXovpyW5nq5scPqq0ZDP9Zyl04oQ==
+
+untildify@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/untildify/-/untildify-4.0.0.tgz#2bc947b953652487e4600949fb091e3ae8cd919b"
+ integrity sha512-KK8xQ1mkzZeg9inewmFVDNkg3l5LUhoq9kN6iWYB/CC9YMG8HA+c1Q8HwDe6dEX7kErrEVNVBO3fWsVq5iDgtw==
+
+uri-js@^4.2.2:
+ version "4.4.1"
+ resolved "https://registry.yarnpkg.com/uri-js/-/uri-js-4.4.1.tgz#9b1a52595225859e55f669d928f88c6c57f2a77e"
+ integrity sha512-7rKUyy33Q1yc98pQ1DAmLtwX109F7TIfWlW1Ydo8Wl1ii1SeHieeh0HHfPeL2fMXK6z0s8ecKs9frCuLJvndBg==
+ dependencies:
+ punycode "^2.1.0"
+
+uuid@^8.3.2:
+ version "8.3.2"
+ resolved "https://registry.yarnpkg.com/uuid/-/uuid-8.3.2.tgz#80d5b5ced271bb9af6c445f21a1a04c606cefbe2"
+ integrity sha512-+NYs2QeMWy+GWFOEm9xnn6HCDp0l7QBD7ml8zLUmJ+93Q5NF0NocErnwkTkXVFNiX3/fpC6afS8Dhb/gz7R7eg==
+
+v8-compile-cache@^2.0.3:
+ version "2.3.0"
+ resolved "https://registry.yarnpkg.com/v8-compile-cache/-/v8-compile-cache-2.3.0.tgz#2de19618c66dc247dcfb6f99338035d8245a2cee"
+ integrity sha512-l8lCEmLcLYZh4nbunNZvQCJc5pv7+RCwa8q/LdUx8u7lsWvPDKmpodJAJNwkAhJC//dFY48KuIEmjtd4RViDrA==
+
[email protected]:
+ version "1.10.0"
+ resolved "https://registry.yarnpkg.com/verror/-/verror-1.10.0.tgz#3a105ca17053af55d6e270c1f8288682e18da400"
+ integrity sha512-ZZKSmDAEFOijERBLkmYfJ+vmk3w+7hOLYDNkRCuRuMJGEmqYNCNLyBBFwWKVMhfwaEF3WOd0Zlw86U/WC/+nYw==
+ dependencies:
+ assert-plus "^1.0.0"
+ core-util-is "1.0.2"
+ extsprintf "^1.2.0"
+
+which-boxed-primitive@^1.0.2:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/which-boxed-primitive/-/which-boxed-primitive-1.0.2.tgz#13757bc89b209b049fe5d86430e21cf40a89a8e6"
+ integrity sha512-bwZdv0AKLpplFY2KZRX6TvyuN7ojjr7lwkg6ml0roIy9YeuSr7JS372qlNW18UQYzgYK9ziGcerWqZOmEn9VNg==
+ dependencies:
+ is-bigint "^1.0.1"
+ is-boolean-object "^1.1.0"
+ is-number-object "^1.0.4"
+ is-string "^1.0.5"
+ is-symbol "^1.0.3"
+
+which@^2.0.1:
+ version "2.0.2"
+ resolved "https://registry.yarnpkg.com/which/-/which-2.0.2.tgz#7c6a8dd0a636a0327e10b59c9286eee93f3f51b1"
+ integrity sha512-BLI3Tl1TW3Pvl70l3yq3Y64i+awpwXqsGBYWkkqMtnbXgrMD+yj7rhW0kuEDxzJaYXGjEW5ogapKNMEKNMjibA==
+ dependencies:
+ isexe "^2.0.0"
+
+word-wrap@^1.2.3:
+ version "1.2.3"
+ resolved "https://registry.yarnpkg.com/word-wrap/-/word-wrap-1.2.3.tgz#610636f6b1f703891bd34771ccb17fb93b47079c"
+ integrity sha512-Hz/mrNwitNRh/HUAtM/VT/5VH+ygD6DV7mYKZAtHOrbs8U7lvPS6xf7EJKMF0uW1KJCl0H701g3ZGus+muE5vQ==
+
+wrap-ansi@^6.2.0:
+ version "6.2.0"
+ resolved "https://registry.yarnpkg.com/wrap-ansi/-/wrap-ansi-6.2.0.tgz#e9393ba07102e6c91a3b221478f0257cd2856e53"
+ integrity sha512-r6lPcBGxZXlIcymEu7InxDMhdW0KDxpLgoFLcguasxCaJ/SOIZwINatK9KY/tf+ZrlywOKU0UDj3ATXUBfxJXA==
+ dependencies:
+ ansi-styles "^4.0.0"
+ string-width "^4.1.0"
+ strip-ansi "^6.0.0"
+
+wrap-ansi@^7.0.0:
+ version "7.0.0"
+ resolved "https://registry.yarnpkg.com/wrap-ansi/-/wrap-ansi-7.0.0.tgz#67e145cff510a6a6984bdf1152911d69d2eb9e43"
+ integrity sha512-YVGIj2kamLSTxw6NsZjoBxfSwsn0ycdesmc4p+Q21c5zPuZ1pl+NfxVdxPtdHvmNVOQ6XSYG4AUtyt/Fi7D16Q==
+ dependencies:
+ ansi-styles "^4.0.0"
+ string-width "^4.1.0"
+ strip-ansi "^6.0.0"
+
+wrappy@1:
+ version "1.0.2"
+ resolved "https://registry.yarnpkg.com/wrappy/-/wrappy-1.0.2.tgz#b5243d8f3ec1aa35f1364605bc0d1036e30ab69f"
+ integrity sha512-l4Sp/DRseor9wL6EvV2+TuQn63dMkPjZ/sp9XkghTEbV9KlPS1xUsZ3u7/IQO4wxtcFB4bgpQPRcR3QCvezPcQ==
+
+yallist@^4.0.0:
+ version "4.0.0"
+ resolved "https://registry.yarnpkg.com/yallist/-/yallist-4.0.0.tgz#9bb92790d9c0effec63be73519e11a35019a3a72"
+ integrity sha512-3wdGidZyq5PB084XLES5TpOSRA3wjXAlIWMhum2kRcv/41Sn2emQ0dycQW4uZXLejwKvg6EsvbdlVL+FYEct7A==
+
+yauzl@^2.10.0:
+ version "2.10.0"
+ resolved "https://registry.yarnpkg.com/yauzl/-/yauzl-2.10.0.tgz#c7eb17c93e112cb1086fa6d8e51fb0667b79a5f9"
+ integrity sha512-p4a9I6X6nu6IhoGmBqAcbJy1mlC4j27vEPZX9F4L4/vZT3Lyq1VkFHw/V/PUcB9Buo+DG3iHkT0x3Qya58zc3g==
+ dependencies:
+ buffer-crc32 "~0.2.3"
+ fd-slicer "~1.1.0"
diff --git a/pkg/ui/yarn-vendor b/pkg/ui/yarn-vendor
index 1dc2bf6fb232..c0d256e029be 160000
--- a/pkg/ui/yarn-vendor
+++ b/pkg/ui/yarn-vendor
@@ -1 +1 @@
-Subproject commit 1dc2bf6fb23267a8d5905a5b4817162d6718273e
+Subproject commit c0d256e029be53fae2abe2302a0988302a0bb4ec
|
a445110fa78bd72fcf1d0d50a8d9c6f4bbf1c380
|
2021-08-05 19:04:52
|
Azhng
|
sql: remove `count` from stmt/txn stats system table
| false
|
remove `count` from stmt/txn stats system table
|
sql
|
diff --git a/pkg/sql/catalog/systemschema/system.go b/pkg/sql/catalog/systemschema/system.go
index 00f2fa1fceb8..1c7856ba2786 100644
--- a/pkg/sql/catalog/systemschema/system.go
+++ b/pkg/sql/catalog/systemschema/system.go
@@ -377,16 +377,13 @@ CREATE TABLE system.join_tokens (
CREATE TABLE system.statement_statistics (
aggregated_ts TIMESTAMPTZ NOT NULL,
fingerprint_id BYTES NOT NULL,
- plan_hash INT NOT NULL,
+ plan_hash INT8 NOT NULL,
app_name STRING NOT NULL,
- node_id INT NOT NULL,
+ node_id INT8 NOT NULL,
- count INT NOT NULL,
agg_interval INTERVAL NOT NULL,
-
metadata JSONB NOT NULL,
statistics JSONB NOT NULL,
-
plan JSONB NOT NULL,
PRIMARY KEY (aggregated_ts, fingerprint_id, plan_hash, app_name, node_id)
@@ -399,7 +396,6 @@ CREATE TABLE system.statement_statistics (
plan_hash,
app_name,
node_id,
- count,
agg_interval,
metadata,
statistics,
@@ -413,11 +409,9 @@ CREATE TABLE system.transaction_statistics (
aggregated_ts TIMESTAMPTZ NOT NULL,
fingerprint_id BYTES NOT NULL,
app_name STRING NOT NULL,
- node_id INT NOT NULL,
+ node_id INT8 NOT NULL,
- count INT NOT NULL,
agg_interval INTERVAL NOT NULL,
-
metadata JSONB NOT NULL,
statistics JSONB NOT NULL,
@@ -430,7 +424,6 @@ CREATE TABLE system.transaction_statistics (
fingerprint_id,
app_name,
node_id,
- count,
agg_interval,
metadata,
statistics
@@ -1928,21 +1921,20 @@ var (
{Name: "plan_hash", ID: 3, Type: types.Int, Nullable: false},
{Name: "app_name", ID: 4, Type: types.String, Nullable: false},
{Name: "node_id", ID: 5, Type: types.Int, Nullable: false},
- {Name: "count", ID: 6, Type: types.Int, Nullable: false},
- {Name: "agg_interval", ID: 7, Type: types.Interval, Nullable: false},
- {Name: "metadata", ID: 8, Type: types.Jsonb, Nullable: false},
- {Name: "statistics", ID: 9, Type: types.Jsonb, Nullable: false},
- {Name: "plan", ID: 10, Type: types.Jsonb, Nullable: false},
+ {Name: "agg_interval", ID: 6, Type: types.Interval, Nullable: false},
+ {Name: "metadata", ID: 7, Type: types.Jsonb, Nullable: false},
+ {Name: "statistics", ID: 8, Type: types.Jsonb, Nullable: false},
+ {Name: "plan", ID: 9, Type: types.Jsonb, Nullable: false},
{
Name: "crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_plan_hash_shard_8",
- ID: 11,
+ ID: 10,
Type: types.Int4,
Nullable: false,
ComputeExpr: &sqlStmtHashComputeExpr,
Hidden: true,
},
},
- NextColumnID: 12,
+ NextColumnID: 11,
Families: []descpb.ColumnFamilyDescriptor{
{
Name: "primary",
@@ -1950,9 +1942,9 @@ var (
ColumnNames: []string{
"crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_plan_hash_shard_8",
"aggregated_ts", "fingerprint_id", "plan_hash", "app_name", "node_id",
- "count", "agg_interval", "metadata", "statistics", "plan",
+ "agg_interval", "metadata", "statistics", "plan",
},
- ColumnIDs: []descpb.ColumnID{11, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10},
+ ColumnIDs: []descpb.ColumnID{10, 1, 2, 3, 4, 5, 6, 7, 8, 9},
DefaultColumnID: 0,
},
},
@@ -1977,7 +1969,7 @@ var (
descpb.IndexDescriptor_ASC,
descpb.IndexDescriptor_ASC,
},
- KeyColumnIDs: []descpb.ColumnID{11, 1, 2, 3, 4, 5},
+ KeyColumnIDs: []descpb.ColumnID{10, 1, 2, 3, 4, 5},
Version: descpb.StrictIndexColumnIDGuaranteesVersion,
Sharded: descpb.ShardedDescriptor{
IsSharded: true,
@@ -1997,7 +1989,7 @@ var (
Expr: "crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_plan_hash_shard_8 IN (0:::INT8, 1:::INT8, 2:::INT8, 3:::INT8, 4:::INT8, 5:::INT8, 6:::INT8, 7:::INT8)",
Name: "check_crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_plan_hash_shard_8",
Validity: descpb.ConstraintValidity_Validated,
- ColumnIDs: []descpb.ColumnID{11},
+ ColumnIDs: []descpb.ColumnID{10},
IsNonNullConstraint: false,
Hidden: true,
},
@@ -2022,7 +2014,7 @@ var (
descpb.IndexDescriptor_ASC,
},
KeyColumnIDs: []descpb.ColumnID{2, 1, 3, 4, 5},
- KeySuffixColumnIDs: []descpb.ColumnID{11},
+ KeySuffixColumnIDs: []descpb.ColumnID{10},
Version: descpb.StrictIndexColumnIDGuaranteesVersion,
},
},
@@ -2046,20 +2038,19 @@ var (
{Name: "fingerprint_id", ID: 2, Type: types.Bytes, Nullable: false},
{Name: "app_name", ID: 3, Type: types.String, Nullable: false},
{Name: "node_id", ID: 4, Type: types.Int, Nullable: false},
- {Name: "count", ID: 5, Type: types.Int, Nullable: false},
- {Name: "agg_interval", ID: 6, Type: types.Interval, Nullable: false},
- {Name: "metadata", ID: 7, Type: types.Jsonb, Nullable: false},
- {Name: "statistics", ID: 8, Type: types.Jsonb, Nullable: false},
+ {Name: "agg_interval", ID: 5, Type: types.Interval, Nullable: false},
+ {Name: "metadata", ID: 6, Type: types.Jsonb, Nullable: false},
+ {Name: "statistics", ID: 7, Type: types.Jsonb, Nullable: false},
{
Name: "crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8",
- ID: 9,
+ ID: 8,
Type: types.Int4,
Nullable: false,
ComputeExpr: &sqlTxnHashComputeExpr,
Hidden: true,
},
},
- NextColumnID: 10,
+ NextColumnID: 9,
Families: []descpb.ColumnFamilyDescriptor{
{
Name: "primary",
@@ -2067,10 +2058,9 @@ var (
ColumnNames: []string{
"crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8",
"aggregated_ts", "fingerprint_id", "app_name", "node_id",
- "count", "agg_interval", "metadata", "statistics",
+ "agg_interval", "metadata", "statistics",
},
- ColumnIDs: []descpb.ColumnID{9, 1, 2, 3, 4, 5, 6, 7, 8},
-
+ ColumnIDs: []descpb.ColumnID{8, 1, 2, 3, 4, 5, 6, 7},
DefaultColumnID: 0,
},
},
@@ -2093,7 +2083,7 @@ var (
descpb.IndexDescriptor_ASC,
descpb.IndexDescriptor_ASC,
},
- KeyColumnIDs: []descpb.ColumnID{9, 1, 2, 3, 4},
+ KeyColumnIDs: []descpb.ColumnID{8, 1, 2, 3, 4},
Version: descpb.StrictIndexColumnIDGuaranteesVersion,
Sharded: descpb.ShardedDescriptor{
IsSharded: true,
@@ -2112,7 +2102,7 @@ var (
Expr: "crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8 IN (0:::INT8, 1:::INT8, 2:::INT8, 3:::INT8, 4:::INT8, 5:::INT8, 6:::INT8, 7:::INT8)",
Name: "check_crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8",
Validity: descpb.ConstraintValidity_Validated,
- ColumnIDs: []descpb.ColumnID{9},
+ ColumnIDs: []descpb.ColumnID{8},
IsNonNullConstraint: false,
Hidden: true,
},
@@ -2135,7 +2125,7 @@ var (
descpb.IndexDescriptor_ASC,
},
KeyColumnIDs: []descpb.ColumnID{2, 1, 3, 4},
- KeySuffixColumnIDs: []descpb.ColumnID{9},
+ KeySuffixColumnIDs: []descpb.ColumnID{8},
Version: descpb.StrictIndexColumnIDGuaranteesVersion,
},
},
diff --git a/pkg/sql/logictest/testdata/logic_test/information_schema b/pkg/sql/logictest/testdata/logic_test/information_schema
index 0f4d3328a2c3..4d06109f9579 100644
--- a/pkg/sql/logictest/testdata/logic_test/information_schema
+++ b/pkg/sql/logictest/testdata/logic_test/information_schema
@@ -1533,7 +1533,6 @@ system public 630200280_35_3_not_null
system public 630200280_35_5_not_null system public statement_diagnostics_requests CHECK NO NO
system public primary system public statement_diagnostics_requests PRIMARY KEY NO NO
system public 630200280_42_10_not_null system public statement_statistics CHECK NO NO
-system public 630200280_42_11_not_null system public statement_statistics CHECK NO NO
system public 630200280_42_1_not_null system public statement_statistics CHECK NO NO
system public 630200280_42_2_not_null system public statement_statistics CHECK NO NO
system public 630200280_42_3_not_null system public statement_statistics CHECK NO NO
@@ -1568,7 +1567,6 @@ system public 630200280_43_5_not_null
system public 630200280_43_6_not_null system public transaction_statistics CHECK NO NO
system public 630200280_43_7_not_null system public transaction_statistics CHECK NO NO
system public 630200280_43_8_not_null system public transaction_statistics CHECK NO NO
-system public 630200280_43_9_not_null system public transaction_statistics CHECK NO NO
system public check_crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8 system public transaction_statistics CHECK NO NO
system public primary system public transaction_statistics PRIMARY KEY NO NO
system public 630200280_14_1_not_null system public ui CHECK NO NO
@@ -1711,24 +1709,22 @@ system public 630200280_40_5_not_null
system public 630200280_41_1_not_null id IS NOT NULL
system public 630200280_41_2_not_null secret IS NOT NULL
system public 630200280_41_3_not_null expiration IS NOT NULL
-system public 630200280_42_10_not_null plan IS NOT NULL
system public 630200280_42_1_not_null aggregated_ts IS NOT NULL
system public 630200280_42_2_not_null fingerprint_id IS NOT NULL
system public 630200280_42_3_not_null plan_hash IS NOT NULL
system public 630200280_42_4_not_null app_name IS NOT NULL
system public 630200280_42_5_not_null node_id IS NOT NULL
-system public 630200280_42_6_not_null count IS NOT NULL
-system public 630200280_42_7_not_null agg_interval IS NOT NULL
-system public 630200280_42_8_not_null metadata IS NOT NULL
-system public 630200280_42_9_not_null statistics IS NOT NULL
+system public 630200280_42_6_not_null agg_interval IS NOT NULL
+system public 630200280_42_7_not_null metadata IS NOT NULL
+system public 630200280_42_8_not_null statistics IS NOT NULL
+system public 630200280_42_9_not_null plan IS NOT NULL
system public 630200280_43_1_not_null aggregated_ts IS NOT NULL
system public 630200280_43_2_not_null fingerprint_id IS NOT NULL
system public 630200280_43_3_not_null app_name IS NOT NULL
system public 630200280_43_4_not_null node_id IS NOT NULL
-system public 630200280_43_5_not_null count IS NOT NULL
-system public 630200280_43_6_not_null agg_interval IS NOT NULL
-system public 630200280_43_7_not_null metadata IS NOT NULL
-system public 630200280_43_8_not_null statistics IS NOT NULL
+system public 630200280_43_5_not_null agg_interval IS NOT NULL
+system public 630200280_43_6_not_null metadata IS NOT NULL
+system public 630200280_43_7_not_null statistics IS NOT NULL
system public 630200280_44_1_not_null database_id IS NOT NULL
system public 630200280_44_2_not_null role_name IS NOT NULL
system public 630200280_44_3_not_null settings IS NOT NULL
@@ -2052,17 +2048,16 @@ system public statement_diagnostics_requests id
system public statement_diagnostics_requests requested_at 5
system public statement_diagnostics_requests statement_diagnostics_id 4
system public statement_diagnostics_requests statement_fingerprint 3
-system public statement_statistics agg_interval 7
+system public statement_statistics agg_interval 6
system public statement_statistics aggregated_ts 1
system public statement_statistics app_name 4
-system public statement_statistics count 6
-system public statement_statistics crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_plan_hash_shard_8 11
+system public statement_statistics crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_plan_hash_shard_8 10
system public statement_statistics fingerprint_id 2
-system public statement_statistics metadata 8
+system public statement_statistics metadata 7
system public statement_statistics node_id 5
-system public statement_statistics plan 10
+system public statement_statistics plan 9
system public statement_statistics plan_hash 3
-system public statement_statistics statistics 9
+system public statement_statistics statistics 8
system public table_statistics columnIDs 4
system public table_statistics createdAt 5
system public table_statistics distinctCount 7
@@ -2092,15 +2087,14 @@ system public tenant_usage total_write_reques
system public tenants active 2
system public tenants id 1
system public tenants info 3
-system public transaction_statistics agg_interval 6
+system public transaction_statistics agg_interval 5
system public transaction_statistics aggregated_ts 1
system public transaction_statistics app_name 3
-system public transaction_statistics count 5
-system public transaction_statistics crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8 9
+system public transaction_statistics crdb_internal_aggregated_ts_app_name_fingerprint_id_node_id_shard_8 8
system public transaction_statistics fingerprint_id 2
-system public transaction_statistics metadata 7
+system public transaction_statistics metadata 6
system public transaction_statistics node_id 4
-system public transaction_statistics statistics 8
+system public transaction_statistics statistics 7
system public ui key 1
system public ui lastUpdated 3
system public ui value 2
diff --git a/pkg/sql/logictest/testdata/logic_test/statement_statistics b/pkg/sql/logictest/testdata/logic_test/statement_statistics
index c6ce62af54b1..547ae8faeb98 100644
--- a/pkg/sql/logictest/testdata/logic_test/statement_statistics
+++ b/pkg/sql/logictest/testdata/logic_test/statement_statistics
@@ -1,5 +1,11 @@
# LogicTest: local !3node-tenant(52763)
+# Disable SQL Stats flush to prevents stats from being cleared from the
+# in-memory store.
+
+statement ok
+SET CLUSTER SETTING sql.stats.flush.enabled = false;
+
# Check that node_statement_statistics report per application
statement ok
|
158fb9b0e39581f1e70c5288a06b8e31142aa33f
|
2023-05-25 03:17:23
|
Austen McClernon
|
kvserver: fix rebalance obj callback ctx
| false
|
fix rebalance obj callback ctx
|
kvserver
|
diff --git a/pkg/kv/kvserver/rebalance_objective.go b/pkg/kv/kvserver/rebalance_objective.go
index 268db3fb8c23..e1f96c3fc72b 100644
--- a/pkg/kv/kvserver/rebalance_objective.go
+++ b/pkg/kv/kvserver/rebalance_objective.go
@@ -208,7 +208,9 @@ func newRebalanceObjectiveManager(
capacityChangeNotifier.SetOnCapacityChange(
func(storeID roachpb.StoreID, old, cur roachpb.StoreCapacity) {
if (old.CPUPerSecond < 0) != (cur.CPUPerSecond < 0) {
- rom.maybeUpdateRebalanceObjective(ctx)
+ // NB: On capacity changes we don't have access to a context. Create a
+ // background context on callback.
+ rom.maybeUpdateRebalanceObjective(context.Background())
}
})
@@ -228,15 +230,16 @@ func (rom *RebalanceObjectiveManager) maybeUpdateRebalanceObjective(ctx context.
defer rom.mu.Unlock()
prev := rom.mu.obj
- new := ResolveLBRebalancingObjective(ctx, rom.st, rom.storeDescProvider.GetStores())
+ next := ResolveLBRebalancingObjective(ctx, rom.st, rom.storeDescProvider.GetStores())
// Nothing to do when the objective hasn't changed.
- if prev == new {
+ if prev == next {
return
}
- log.Infof(ctx, "Updating the rebalance objective from %s to %s", prev.ToDimension(), new.ToDimension())
+ log.Infof(ctx, "Updating the rebalance objective from %s to %s",
+ prev.ToDimension(), next.ToDimension())
- rom.mu.obj = new
+ rom.mu.obj = next
rom.mu.onChange(ctx, rom.mu.obj)
}
|
751b328b4c33d16e686fd144f12121909d3d7a6d
|
2021-06-02 03:20:04
|
Peyton Walters
|
authors: add pawalt to authors
| false
|
add pawalt to authors
|
authors
|
diff --git a/AUTHORS b/AUTHORS
index e0053f3fe244..7434f287a6fe 100644
--- a/AUTHORS
+++ b/AUTHORS
@@ -279,6 +279,7 @@ Paul Logston <[email protected]> <[email protected]>
Peng Gao <[email protected]>
Pete Vilter <[email protected]> <[email protected]>
Peter Mattis <[email protected]> <[email protected]>
+Peyton Walters <[email protected]> <[email protected]>
phelanm <[email protected]>
Philippe Laflamme <[email protected]>
phynalle <[email protected]>
|
86abde000613323ed2eeb157c890c9789c7efe6d
|
2017-07-06 16:19:15
|
Raphael 'kena' Poss
|
sql: define crdb_internal.cluster_settings, make SHOW ALL CLUSTER SETTINGS use it
| false
|
define crdb_internal.cluster_settings, make SHOW ALL CLUSTER SETTINGS use it
|
sql
|
diff --git a/pkg/sql/crdb_internal.go b/pkg/sql/crdb_internal.go
index 2d12acc1bdc9..e2fca2042840 100644
--- a/pkg/sql/crdb_internal.go
+++ b/pkg/sql/crdb_internal.go
@@ -25,6 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/build"
"github.com/cockroachdb/cockroach/pkg/security"
+ "github.com/cockroachdb/cockroach/pkg/settings"
"github.com/cockroachdb/cockroach/pkg/sql/jobs"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
@@ -42,6 +43,7 @@ var crdbInternal = virtualSchema{
crdbInternalStmtStatsTable,
crdbInternalJobsTable,
crdbInternalSessionTraceTable,
+ crdbInternalClusterSettingsTable,
},
}
@@ -490,3 +492,30 @@ CREATE TABLE crdb_internal.session_trace(
return nil
},
}
+
+// crdbInternalClusterSettingsTable exposes the list of current
+// cluster settings.
+var crdbInternalClusterSettingsTable = virtualSchemaTable{
+ schema: `
+CREATE TABLE crdb_internal.cluster_settings (
+ name STRING NOT NULL,
+ current_value STRING NOT NULL,
+ type STRING NOT NULL,
+ description STRING NOT NULL
+);
+`,
+ populate: func(ctx context.Context, p *planner, _ string, addRow func(...parser.Datum) error) error {
+ for _, k := range settings.Keys() {
+ setting, _ := settings.Lookup(k)
+ if err := addRow(
+ parser.NewDString(k),
+ parser.NewDString(setting.String()),
+ parser.NewDString(setting.Typ()),
+ parser.NewDString(setting.Description()),
+ ); err != nil {
+ return err
+ }
+ }
+ return nil
+ },
+}
diff --git a/pkg/sql/logictest/testdata/logic_test/explain b/pkg/sql/logictest/testdata/logic_test/explain
index 97b6d39403c5..4bbfc032d1c5 100644
--- a/pkg/sql/logictest/testdata/logic_test/explain
+++ b/pkg/sql/logictest/testdata/logic_test/explain
@@ -136,7 +136,7 @@ EXPLAIN SHOW TABLES
1 render
2 filter
3 values
-3 size 5 columns, 52 rows
+3 size 5 columns, 53 rows
query ITTT
EXPLAIN SHOW DATABASE
@@ -182,7 +182,7 @@ EXPLAIN SHOW COLUMNS FROM foo
5 render
6 filter
7 values
-7 size 13 columns, 459 rows
+7 size 13 columns, 463 rows
5 render
6 filter
7 values
diff --git a/pkg/sql/logictest/testdata/logic_test/information_schema b/pkg/sql/logictest/testdata/logic_test/information_schema
index cb1df2794a55..6618d73922e3 100644
--- a/pkg/sql/logictest/testdata/logic_test/information_schema
+++ b/pkg/sql/logictest/testdata/logic_test/information_schema
@@ -204,6 +204,7 @@ DROP DATABASE other_db
query TT
select table_schema, table_name FROM information_schema.tables ORDER BY 1, 2
----
+crdb_internal cluster_settings
crdb_internal jobs
crdb_internal leases
crdb_internal node_build_info
@@ -336,6 +337,7 @@ query TTTTI colnames
SELECT * FROM information_schema.tables
----
table_catalog table_schema table_name table_type version
+def crdb_internal cluster_settings SYSTEM VIEW 1
def crdb_internal jobs SYSTEM VIEW 1
def crdb_internal leases SYSTEM VIEW 1
def crdb_internal node_build_info SYSTEM VIEW 1
diff --git a/pkg/sql/plan.go b/pkg/sql/plan.go
index 4fbd32c19cae..19b2d5b0ff64 100644
--- a/pkg/sql/plan.go
+++ b/pkg/sql/plan.go
@@ -385,7 +385,7 @@ func (p *planner) newPlan(
case *parser.SetDefaultIsolation:
return p.SetDefaultIsolation(n)
case *parser.Show:
- return p.Show(n)
+ return p.Show(ctx, n)
case *parser.ShowColumns:
return p.ShowColumns(ctx, n)
case *parser.ShowConstraints:
@@ -411,7 +411,7 @@ func (p *planner) newPlan(
case *parser.ShowTrace:
return p.ShowTrace(ctx, n)
case *parser.ShowTransactionStatus:
- return p.ShowTransactionStatus()
+ return p.ShowTransactionStatus(ctx)
case *parser.ShowUsers:
return p.ShowUsers(ctx, n)
case *parser.ShowRanges:
@@ -456,7 +456,7 @@ func (p *planner) prepare(ctx context.Context, stmt parser.Statement) (planNode,
case *parser.SelectClause:
return p.SelectClause(ctx, n, nil, nil, nil, publicColumns)
case *parser.Show:
- return p.Show(n)
+ return p.Show(ctx, n)
case *parser.ShowCreateTable:
return p.ShowCreateTable(ctx, n)
case *parser.ShowCreateView:
@@ -484,7 +484,7 @@ func (p *planner) prepare(ctx context.Context, stmt parser.Statement) (planNode,
case *parser.ShowUsers:
return p.ShowUsers(ctx, n)
case *parser.ShowTransactionStatus:
- return p.ShowTransactionStatus()
+ return p.ShowTransactionStatus(ctx)
case *parser.ShowRanges:
return p.ShowRanges(ctx, n)
case *parser.Split:
diff --git a/pkg/sql/show.go b/pkg/sql/show.go
index 89fd0c426aac..2550958ab7b0 100644
--- a/pkg/sql/show.go
+++ b/pkg/sql/show.go
@@ -103,71 +103,57 @@ func checkTablePrivileges(ctx context.Context, p *planner, tn *parser.TableName)
return nil
}
-func (p *planner) showClusterSetting(name string) (planNode, error) {
- var columns sqlbase.ResultColumns
- var populate func(ctx context.Context, v *valuesNode) error
-
- switch name {
- case "all":
- columns = sqlbase.ResultColumns{
- {Name: "name", Typ: parser.TypeString},
- {Name: "current_value", Typ: parser.TypeString},
- {Name: "type", Typ: parser.TypeString},
- {Name: "description", Typ: parser.TypeString},
- }
- populate = func(ctx context.Context, v *valuesNode) error {
- for _, k := range settings.Keys() {
- setting, _ := settings.Lookup(k)
- if _, err := v.rows.AddRow(ctx, parser.Datums{
- parser.NewDString(k),
- parser.NewDString(setting.String()),
- parser.NewDString(setting.Typ()),
- parser.NewDString(setting.Description()),
- }); err != nil {
- return err
- }
- }
- return nil
- }
+func (p *planner) showClusterSetting(ctx context.Context, name string) (planNode, error) {
+ if name == "all" {
+ return p.delegateQuery(ctx, "SHOW CLUSTER SETTINGS",
+ "TABLE crdb_internal.cluster_settings", nil, nil)
+ }
+ val, ok := settings.Lookup(name)
+ if !ok {
+ return nil, errors.Errorf("unknown setting: %q", name)
+ }
+ var dType parser.Type
+ switch val.(type) {
+ case *settings.IntSetting, *settings.EnumSetting:
+ dType = parser.TypeInt
+ case *settings.StringSetting, *settings.ByteSizeSetting:
+ dType = parser.TypeString
+ case *settings.BoolSetting:
+ dType = parser.TypeBool
+ case *settings.FloatSetting:
+ dType = parser.TypeFloat
+ case *settings.DurationSetting:
+ dType = parser.TypeInterval
default:
- val, ok := settings.Lookup(name)
- if !ok {
- return nil, errors.Errorf("unknown setting: %q", name)
- }
- var d parser.Datum
- switch s := val.(type) {
- case *settings.IntSetting:
- d = parser.NewDInt(parser.DInt(s.Get()))
- case *settings.StringSetting:
- d = parser.NewDString(s.String())
- case *settings.BoolSetting:
- d = parser.MakeDBool(parser.DBool(s.Get()))
- case *settings.FloatSetting:
- d = parser.NewDFloat(parser.DFloat(s.Get()))
- case *settings.DurationSetting:
- d = &parser.DInterval{Duration: duration.Duration{Nanos: s.Get().Nanoseconds()}}
- case *settings.EnumSetting:
- d = parser.NewDInt(parser.DInt(s.Get()))
- case *settings.ByteSizeSetting:
- d = parser.NewDString(s.String())
- default:
- return nil, errors.Errorf("unknown setting type for %s: %s", name, val.Typ())
- }
- columns = sqlbase.ResultColumns{{Name: name, Typ: d.ResolvedType()}}
- populate = func(ctx context.Context, v *valuesNode) error {
- _, err := v.rows.AddRow(ctx, parser.Datums{d})
- return err
- }
+ return nil, errors.Errorf("unknown setting type for %s: %s", name, val.Typ())
}
+ columns := sqlbase.ResultColumns{{Name: name, Typ: dType}}
return &delayedNode{
name: "SHOW CLUSTER SETTING " + name,
columns: columns,
constructor: func(ctx context.Context, p *planner) (planNode, error) {
- v := p.newContainerValuesNode(columns, 1)
+ d := parser.DNull
+ switch s := val.(type) {
+ case *settings.IntSetting:
+ d = parser.NewDInt(parser.DInt(s.Get()))
+ case *settings.StringSetting:
+ d = parser.NewDString(s.String())
+ case *settings.BoolSetting:
+ d = parser.MakeDBool(parser.DBool(s.Get()))
+ case *settings.FloatSetting:
+ d = parser.NewDFloat(parser.DFloat(s.Get()))
+ case *settings.DurationSetting:
+ d = &parser.DInterval{Duration: duration.Duration{Nanos: s.Get().Nanoseconds()}}
+ case *settings.EnumSetting:
+ d = parser.NewDInt(parser.DInt(s.Get()))
+ case *settings.ByteSizeSetting:
+ d = parser.NewDString(s.String())
+ }
- if err := populate(ctx, v); err != nil {
+ v := p.newContainerValuesNode(columns, 0)
+ if _, err := v.rows.AddRow(ctx, parser.Datums{d}); err != nil {
v.rows.Close(ctx)
return nil, err
}
@@ -177,12 +163,12 @@ func (p *planner) showClusterSetting(name string) (planNode, error) {
}
// Show a session-local variable name.
-func (p *planner) Show(n *parser.Show) (planNode, error) {
+func (p *planner) Show(ctx context.Context, n *parser.Show) (planNode, error) {
origName := n.Name
name := strings.ToLower(n.Name)
if n.ClusterSetting {
- return p.showClusterSetting(name)
+ return p.showClusterSetting(ctx, name)
}
var columns sqlbase.ResultColumns
@@ -1069,8 +1055,8 @@ func (p *planner) ShowTables(ctx context.Context, n *parser.ShowTables) (planNod
// ShowTransactionStatus implements the plan for SHOW TRANSACTION STATUS.
// This statement is usually handled as a special case in Executor,
// but for FROM [SHOW TRANSACTION STATUS] we will arrive here too.
-func (p *planner) ShowTransactionStatus() (planNode, error) {
- return p.Show(&parser.Show{Name: "transaction status"})
+func (p *planner) ShowTransactionStatus(ctx context.Context) (planNode, error) {
+ return p.Show(ctx, &parser.Show{Name: "transaction status"})
}
// ShowUsers returns all the users.
|
0bc9f74f5d13cab24737b063411adff365140bfa
|
2022-05-03 00:51:45
|
e-mbrown
|
cli: de-emphasize sql.defaults
| false
|
de-emphasize sql.defaults
|
cli
|
diff --git a/docs/generated/settings/settings-for-tenants.txt b/docs/generated/settings/settings-for-tenants.txt
index ed9ad06da725..781064a985d4 100644
--- a/docs/generated/settings/settings-for-tenants.txt
+++ b/docs/generated/settings/settings-for-tenants.txt
@@ -96,49 +96,135 @@ sql.cross_db_fks.enabled boolean false if true, creating foreign key references
sql.cross_db_sequence_owners.enabled boolean false if true, creating sequences owned by tables from other databases is allowed
sql.cross_db_sequence_references.enabled boolean false if true, sequences referenced by tables from other databases are allowed
sql.cross_db_views.enabled boolean false if true, creating views that refer to other databases is allowed
-sql.defaults.cost_scans_with_default_col_size.enabled boolean false setting to true uses the same size for all columns to compute scan cost
-sql.defaults.datestyle enumeration iso, mdy default value for DateStyle session setting [iso, mdy = 0, iso, dmy = 1, iso, ymd = 2]
-sql.defaults.default_hash_sharded_index_bucket_count integer 16 used as bucket count if bucket count is not specified in hash sharded index definition
-sql.defaults.default_int_size integer 8 the size, in bytes, of an INT type
-sql.defaults.disallow_full_table_scans.enabled boolean false setting to true rejects queries that have planned a full table scan
-sql.defaults.distsql enumeration auto default distributed SQL execution mode [off = 0, auto = 1, on = 2, always = 3]
-sql.defaults.experimental_alter_column_type.enabled boolean false default value for experimental_alter_column_type session setting; enables the use of ALTER COLUMN TYPE for general conversions
-sql.defaults.experimental_auto_rehoming.enabled boolean false default value for experimental_enable_auto_rehoming; allows for rows in REGIONAL BY ROW tables to be auto-rehomed on UPDATE
-sql.defaults.experimental_distsql_planning enumeration off default experimental_distsql_planning mode; enables experimental opt-driven DistSQL planning [off = 0, on = 1]
-sql.defaults.experimental_enable_unique_without_index_constraints.enabled boolean false default value for experimental_enable_unique_without_index_constraints session setting;disables unique without index constraints by default
-sql.defaults.experimental_implicit_column_partitioning.enabled boolean false default value for experimental_enable_temp_tables; allows for the use of implicit column partitioning
-sql.defaults.experimental_stream_replication.enabled boolean false default value for experimental_stream_replication session setting;enables the ability to setup a replication stream
-sql.defaults.experimental_temporary_tables.enabled boolean false default value for experimental_enable_temp_tables; allows for use of temporary tables by default
-sql.defaults.foreign_key_cascades_limit integer 10000 default value for foreign_key_cascades_limit session setting; limits the number of cascading operations that run as part of a single query
-sql.defaults.idle_in_session_timeout duration 0s default value for the idle_in_session_timeout; default value for the idle_in_session_timeout session setting; controls the duration a session is permitted to idle before the session is terminated; if set to 0, there is no timeout
-sql.defaults.idle_in_transaction_session_timeout duration 0s default value for the idle_in_transaction_session_timeout; controls the duration a session is permitted to idle in a transaction before the session is terminated; if set to 0, there is no timeout
-sql.defaults.implicit_select_for_update.enabled boolean true default value for enable_implicit_select_for_update session setting; enables FOR UPDATE locking during the row-fetch phase of mutation statements
-sql.defaults.insert_fast_path.enabled boolean true default value for enable_insert_fast_path session setting; enables a specialized insert path
-sql.defaults.intervalstyle enumeration postgres default value for IntervalStyle session setting [postgres = 0, iso_8601 = 1, sql_standard = 2]
-sql.defaults.large_full_scan_rows float 1000 default value for large_full_scan_rows session setting which determines the maximum table size allowed for a full scan when disallow_full_table_scans is set to true
-sql.defaults.locality_optimized_partitioned_index_scan.enabled boolean true default value for locality_optimized_partitioned_index_scan session setting; enables searching for rows in the current region before searching remote regions
-sql.defaults.lock_timeout duration 0s default value for the lock_timeout; default value for the lock_timeout session setting; controls the duration a query is permitted to wait while attempting to acquire a lock on a key or while blocking on an existing lock in order to perform a non-locking read on a key; if set to 0, there is no timeout
-sql.defaults.on_update_rehome_row.enabled boolean true default value for on_update_rehome_row; enables ON UPDATE rehome_row() expressions to trigger on updates
-sql.defaults.optimizer_use_histograms.enabled boolean true default value for optimizer_use_histograms session setting; enables usage of histograms in the optimizer by default
-sql.defaults.optimizer_use_multicol_stats.enabled boolean true default value for optimizer_use_multicol_stats session setting; enables usage of multi-column stats in the optimizer by default
-sql.defaults.override_alter_primary_region_in_super_region.enabled boolean false default value for override_alter_primary_region_in_super_region; allows for altering the primary region even if the primary region is a member of a super region
-sql.defaults.override_multi_region_zone_config.enabled boolean false default value for override_multi_region_zone_config; allows for overriding the zone configs of a multi-region table or database
-sql.defaults.prefer_lookup_joins_for_fks.enabled boolean false default value for prefer_lookup_joins_for_fks session setting; causes foreign key operations to use lookup joins when possible
-sql.defaults.primary_region string if not empty, all databases created without a PRIMARY REGION will implicitly have the given PRIMARY REGION
-sql.defaults.reorder_joins_limit integer 8 default number of joins to reorder
-sql.defaults.require_explicit_primary_keys.enabled boolean false default value for requiring explicit primary keys in CREATE TABLE statements
-sql.defaults.results_buffer.size byte size 16 KiB default size of the buffer that accumulates results for a statement or a batch of statements before they are sent to the client. This can be overridden on an individual connection with the 'results_buffer_size' parameter. Note that auto-retries generally only happen while no results have been delivered to the client, so reducing this size can increase the number of retriable errors a client receives. On the other hand, increasing the buffer size can increase the delay until the client receives the first result row. Updating the setting only affects new connections. Setting to 0 disables any buffering.
-sql.defaults.serial_normalization enumeration rowid default handling of SERIAL in table definitions [rowid = 0, virtual_sequence = 1, sql_sequence = 2, sql_sequence_cached = 3, unordered_rowid = 4]
-sql.defaults.statement_timeout duration 0s default value for the statement_timeout; default value for the statement_timeout session setting; controls the duration a query is permitted to run before it is canceled; if set to 0, there is no timeout
-sql.defaults.stub_catalog_tables.enabled boolean true default value for stub_catalog_tables session setting
-sql.defaults.super_regions.enabled boolean false default value for enable_super_regions; allows for the usage of super regions
-sql.defaults.transaction_rows_read_err integer 0 the limit for the number of rows read by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable
-sql.defaults.transaction_rows_read_log integer 0 the threshold for the number of rows read by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable
-sql.defaults.transaction_rows_written_err integer 0 the limit for the number of rows written by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable
-sql.defaults.transaction_rows_written_log integer 0 the threshold for the number of rows written by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable
-sql.defaults.use_declarative_schema_changer enumeration on default value for use_declarative_schema_changer session setting;disables new schema changer by default [off = 0, on = 1, unsafe = 2, unsafe_always = 3]
-sql.defaults.vectorize enumeration on default vectorize mode [on = 0, on = 2, experimental_always = 3, off = 4]
-sql.defaults.zigzag_join.enabled boolean true default value for enable_zigzag_join session setting; allows use of zig-zag join by default
+sql.defaults.cost_scans_with_default_col_size.enabled boolean false "setting to true uses the same size for all columns to compute scan cost
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.datestyle enumeration iso, mdy "default value for DateStyle session setting [iso, mdy = 0, iso, dmy = 1, iso, ymd = 2]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.default_hash_sharded_index_bucket_count integer 16 "used as bucket count if bucket count is not specified in hash sharded index definition
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.default_int_size integer 8 "the size, in bytes, of an INT type
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.disallow_full_table_scans.enabled boolean false "setting to true rejects queries that have planned a full table scan
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.distsql enumeration auto "default distributed SQL execution mode [off = 0, auto = 1, on = 2, always = 3]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_alter_column_type.enabled boolean false "default value for experimental_alter_column_type session setting; enables the use of ALTER COLUMN TYPE for general conversions
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_auto_rehoming.enabled boolean false "default value for experimental_enable_auto_rehoming; allows for rows in REGIONAL BY ROW tables to be auto-rehomed on UPDATE
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_distsql_planning enumeration off "default experimental_distsql_planning mode; enables experimental opt-driven DistSQL planning [off = 0, on = 1]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_enable_unique_without_index_constraints.enabled boolean false "default value for experimental_enable_unique_without_index_constraints session setting;disables unique without index constraints by default
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_implicit_column_partitioning.enabled boolean false "default value for experimental_enable_temp_tables; allows for the use of implicit column partitioning
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_stream_replication.enabled boolean false "default value for experimental_stream_replication session setting;enables the ability to setup a replication stream
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.experimental_temporary_tables.enabled boolean false "default value for experimental_enable_temp_tables; allows for use of temporary tables by default
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.foreign_key_cascades_limit integer 10000 "default value for foreign_key_cascades_limit session setting; limits the number of cascading operations that run as part of a single query
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.idle_in_session_timeout duration 0s "default value for the idle_in_session_timeout; default value for the idle_in_session_timeout session setting; controls the duration a session is permitted to idle before the session is terminated; if set to 0, there is no timeout
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.idle_in_transaction_session_timeout duration 0s "default value for the idle_in_transaction_session_timeout; controls the duration a session is permitted to idle in a transaction before the session is terminated; if set to 0, there is no timeout
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.implicit_select_for_update.enabled boolean true "default value for enable_implicit_select_for_update session setting; enables FOR UPDATE locking during the row-fetch phase of mutation statements
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.insert_fast_path.enabled boolean true "default value for enable_insert_fast_path session setting; enables a specialized insert path
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.intervalstyle enumeration postgres "default value for IntervalStyle session setting [postgres = 0, iso_8601 = 1, sql_standard = 2]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.large_full_scan_rows float 1000 "default value for large_full_scan_rows session setting which determines the maximum table size allowed for a full scan when disallow_full_table_scans is set to true
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.locality_optimized_partitioned_index_scan.enabled boolean true "default value for locality_optimized_partitioned_index_scan session setting; enables searching for rows in the current region before searching remote regions
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.lock_timeout duration 0s "default value for the lock_timeout; default value for the lock_timeout session setting; controls the duration a query is permitted to wait while attempting to acquire a lock on a key or while blocking on an existing lock in order to perform a non-locking read on a key; if set to 0, there is no timeout
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.on_update_rehome_row.enabled boolean true "default value for on_update_rehome_row; enables ON UPDATE rehome_row() expressions to trigger on updates
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.optimizer_use_histograms.enabled boolean true "default value for optimizer_use_histograms session setting; enables usage of histograms in the optimizer by default
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.optimizer_use_multicol_stats.enabled boolean true "default value for optimizer_use_multicol_stats session setting; enables usage of multi-column stats in the optimizer by default
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.override_alter_primary_region_in_super_region.enabled boolean false "default value for override_alter_primary_region_in_super_region; allows for altering the primary region even if the primary region is a member of a super region
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.override_multi_region_zone_config.enabled boolean false "default value for override_multi_region_zone_config; allows for overriding the zone configs of a multi-region table or database
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.prefer_lookup_joins_for_fks.enabled boolean false "default value for prefer_lookup_joins_for_fks session setting; causes foreign key operations to use lookup joins when possible
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.primary_region string "if not empty, all databases created without a PRIMARY REGION will implicitly have the given PRIMARY REGION
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.reorder_joins_limit integer 8 "default number of joins to reorder
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.require_explicit_primary_keys.enabled boolean false "default value for requiring explicit primary keys in CREATE TABLE statements
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.results_buffer.size byte size 16 KiB "default size of the buffer that accumulates results for a statement or a batch of statements before they are sent to the client. This can be overridden on an individual connection with the 'results_buffer_size' parameter. Note that auto-retries generally only happen while no results have been delivered to the client, so reducing this size can increase the number of retriable errors a client receives. On the other hand, increasing the buffer size can increase the delay until the client receives the first result row. Updating the setting only affects new connections. Setting to 0 disables any buffering.
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.serial_normalization enumeration rowid "default handling of SERIAL in table definitions [rowid = 0, virtual_sequence = 1, sql_sequence = 2, sql_sequence_cached = 3, unordered_rowid = 4]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.statement_timeout duration 0s "default value for the statement_timeout; default value for the statement_timeout session setting; controls the duration a query is permitted to run before it is canceled; if set to 0, there is no timeout
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.stub_catalog_tables.enabled boolean true "default value for stub_catalog_tables session setting
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.super_regions.enabled boolean false "default value for enable_super_regions; allows for the usage of super regions
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.transaction_rows_read_err integer 0 "the limit for the number of rows read by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.transaction_rows_read_log integer 0 "the threshold for the number of rows read by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.transaction_rows_written_err integer 0 "the limit for the number of rows written by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.transaction_rows_written_log integer 0 "the threshold for the number of rows written by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.use_declarative_schema_changer enumeration on "default value for use_declarative_schema_changer session setting;disables new schema changer by default [off = 0, on = 1, unsafe = 2, unsafe_always = 3]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.vectorize enumeration on "default vectorize mode [on = 0, on = 2, experimental_always = 3, off = 4]
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
+sql.defaults.zigzag_join.enabled boolean true "default value for enable_zigzag_join session setting; allows use of zig-zag join by default
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html"
sql.distsql.max_running_flows integer -128 the value - when positive - used as is, or the value - when negative - multiplied by the number of CPUs on a node, to determine the maximum number of concurrent remote flows that can be run on the node
sql.distsql.temp_storage.workmem byte size 64 MiB maximum amount of memory in bytes a processor can use before falling back to temp storage
sql.guardrails.max_row_size_err byte size 512 MiB maximum size of row (or column family if multiple column families are in use) that SQL can write to the database, above which an error is returned; use 0 to disable
diff --git a/docs/generated/settings/settings.html b/docs/generated/settings/settings.html
index e444e83a3c6c..32dc219a666b 100644
--- a/docs/generated/settings/settings.html
+++ b/docs/generated/settings/settings.html
@@ -111,49 +111,49 @@
<tr><td><code>sql.cross_db_sequence_owners.enabled</code></td><td>boolean</td><td><code>false</code></td><td>if true, creating sequences owned by tables from other databases is allowed</td></tr>
<tr><td><code>sql.cross_db_sequence_references.enabled</code></td><td>boolean</td><td><code>false</code></td><td>if true, sequences referenced by tables from other databases are allowed</td></tr>
<tr><td><code>sql.cross_db_views.enabled</code></td><td>boolean</td><td><code>false</code></td><td>if true, creating views that refer to other databases is allowed</td></tr>
-<tr><td><code>sql.defaults.cost_scans_with_default_col_size.enabled</code></td><td>boolean</td><td><code>false</code></td><td>setting to true uses the same size for all columns to compute scan cost</td></tr>
-<tr><td><code>sql.defaults.datestyle</code></td><td>enumeration</td><td><code>iso, mdy</code></td><td>default value for DateStyle session setting [iso, mdy = 0, iso, dmy = 1, iso, ymd = 2]</td></tr>
-<tr><td><code>sql.defaults.default_hash_sharded_index_bucket_count</code></td><td>integer</td><td><code>16</code></td><td>used as bucket count if bucket count is not specified in hash sharded index definition</td></tr>
-<tr><td><code>sql.defaults.default_int_size</code></td><td>integer</td><td><code>8</code></td><td>the size, in bytes, of an INT type</td></tr>
-<tr><td><code>sql.defaults.disallow_full_table_scans.enabled</code></td><td>boolean</td><td><code>false</code></td><td>setting to true rejects queries that have planned a full table scan</td></tr>
-<tr><td><code>sql.defaults.distsql</code></td><td>enumeration</td><td><code>auto</code></td><td>default distributed SQL execution mode [off = 0, auto = 1, on = 2, always = 3]</td></tr>
-<tr><td><code>sql.defaults.experimental_alter_column_type.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_alter_column_type session setting; enables the use of ALTER COLUMN TYPE for general conversions</td></tr>
-<tr><td><code>sql.defaults.experimental_auto_rehoming.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_auto_rehoming; allows for rows in REGIONAL BY ROW tables to be auto-rehomed on UPDATE</td></tr>
-<tr><td><code>sql.defaults.experimental_distsql_planning</code></td><td>enumeration</td><td><code>off</code></td><td>default experimental_distsql_planning mode; enables experimental opt-driven DistSQL planning [off = 0, on = 1]</td></tr>
-<tr><td><code>sql.defaults.experimental_enable_unique_without_index_constraints.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_unique_without_index_constraints session setting;disables unique without index constraints by default</td></tr>
-<tr><td><code>sql.defaults.experimental_implicit_column_partitioning.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_temp_tables; allows for the use of implicit column partitioning</td></tr>
-<tr><td><code>sql.defaults.experimental_stream_replication.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_stream_replication session setting;enables the ability to setup a replication stream</td></tr>
-<tr><td><code>sql.defaults.experimental_temporary_tables.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_temp_tables; allows for use of temporary tables by default</td></tr>
-<tr><td><code>sql.defaults.foreign_key_cascades_limit</code></td><td>integer</td><td><code>10000</code></td><td>default value for foreign_key_cascades_limit session setting; limits the number of cascading operations that run as part of a single query</td></tr>
-<tr><td><code>sql.defaults.idle_in_session_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the idle_in_session_timeout; default value for the idle_in_session_timeout session setting; controls the duration a session is permitted to idle before the session is terminated; if set to 0, there is no timeout</td></tr>
-<tr><td><code>sql.defaults.idle_in_transaction_session_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the idle_in_transaction_session_timeout; controls the duration a session is permitted to idle in a transaction before the session is terminated; if set to 0, there is no timeout</td></tr>
-<tr><td><code>sql.defaults.implicit_select_for_update.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for enable_implicit_select_for_update session setting; enables FOR UPDATE locking during the row-fetch phase of mutation statements</td></tr>
-<tr><td><code>sql.defaults.insert_fast_path.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for enable_insert_fast_path session setting; enables a specialized insert path</td></tr>
-<tr><td><code>sql.defaults.intervalstyle</code></td><td>enumeration</td><td><code>postgres</code></td><td>default value for IntervalStyle session setting [postgres = 0, iso_8601 = 1, sql_standard = 2]</td></tr>
-<tr><td><code>sql.defaults.large_full_scan_rows</code></td><td>float</td><td><code>1000</code></td><td>default value for large_full_scan_rows session setting which determines the maximum table size allowed for a full scan when disallow_full_table_scans is set to true</td></tr>
-<tr><td><code>sql.defaults.locality_optimized_partitioned_index_scan.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for locality_optimized_partitioned_index_scan session setting; enables searching for rows in the current region before searching remote regions</td></tr>
-<tr><td><code>sql.defaults.lock_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the lock_timeout; default value for the lock_timeout session setting; controls the duration a query is permitted to wait while attempting to acquire a lock on a key or while blocking on an existing lock in order to perform a non-locking read on a key; if set to 0, there is no timeout</td></tr>
-<tr><td><code>sql.defaults.on_update_rehome_row.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for on_update_rehome_row; enables ON UPDATE rehome_row() expressions to trigger on updates</td></tr>
-<tr><td><code>sql.defaults.optimizer_use_histograms.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for optimizer_use_histograms session setting; enables usage of histograms in the optimizer by default</td></tr>
-<tr><td><code>sql.defaults.optimizer_use_multicol_stats.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for optimizer_use_multicol_stats session setting; enables usage of multi-column stats in the optimizer by default</td></tr>
-<tr><td><code>sql.defaults.override_alter_primary_region_in_super_region.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for override_alter_primary_region_in_super_region; allows for altering the primary region even if the primary region is a member of a super region</td></tr>
-<tr><td><code>sql.defaults.override_multi_region_zone_config.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for override_multi_region_zone_config; allows for overriding the zone configs of a multi-region table or database</td></tr>
-<tr><td><code>sql.defaults.prefer_lookup_joins_for_fks.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for prefer_lookup_joins_for_fks session setting; causes foreign key operations to use lookup joins when possible</td></tr>
-<tr><td><code>sql.defaults.primary_region</code></td><td>string</td><td><code></code></td><td>if not empty, all databases created without a PRIMARY REGION will implicitly have the given PRIMARY REGION</td></tr>
-<tr><td><code>sql.defaults.reorder_joins_limit</code></td><td>integer</td><td><code>8</code></td><td>default number of joins to reorder</td></tr>
-<tr><td><code>sql.defaults.require_explicit_primary_keys.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for requiring explicit primary keys in CREATE TABLE statements</td></tr>
-<tr><td><code>sql.defaults.results_buffer.size</code></td><td>byte size</td><td><code>16 KiB</code></td><td>default size of the buffer that accumulates results for a statement or a batch of statements before they are sent to the client. This can be overridden on an individual connection with the 'results_buffer_size' parameter. Note that auto-retries generally only happen while no results have been delivered to the client, so reducing this size can increase the number of retriable errors a client receives. On the other hand, increasing the buffer size can increase the delay until the client receives the first result row. Updating the setting only affects new connections. Setting to 0 disables any buffering.</td></tr>
-<tr><td><code>sql.defaults.serial_normalization</code></td><td>enumeration</td><td><code>rowid</code></td><td>default handling of SERIAL in table definitions [rowid = 0, virtual_sequence = 1, sql_sequence = 2, sql_sequence_cached = 3, unordered_rowid = 4]</td></tr>
-<tr><td><code>sql.defaults.statement_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the statement_timeout; default value for the statement_timeout session setting; controls the duration a query is permitted to run before it is canceled; if set to 0, there is no timeout</td></tr>
-<tr><td><code>sql.defaults.stub_catalog_tables.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for stub_catalog_tables session setting</td></tr>
-<tr><td><code>sql.defaults.super_regions.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for enable_super_regions; allows for the usage of super regions</td></tr>
-<tr><td><code>sql.defaults.transaction_rows_read_err</code></td><td>integer</td><td><code>0</code></td><td>the limit for the number of rows read by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable</td></tr>
-<tr><td><code>sql.defaults.transaction_rows_read_log</code></td><td>integer</td><td><code>0</code></td><td>the threshold for the number of rows read by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable</td></tr>
-<tr><td><code>sql.defaults.transaction_rows_written_err</code></td><td>integer</td><td><code>0</code></td><td>the limit for the number of rows written by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable</td></tr>
-<tr><td><code>sql.defaults.transaction_rows_written_log</code></td><td>integer</td><td><code>0</code></td><td>the threshold for the number of rows written by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable</td></tr>
-<tr><td><code>sql.defaults.use_declarative_schema_changer</code></td><td>enumeration</td><td><code>on</code></td><td>default value for use_declarative_schema_changer session setting;disables new schema changer by default [off = 0, on = 1, unsafe = 2, unsafe_always = 3]</td></tr>
-<tr><td><code>sql.defaults.vectorize</code></td><td>enumeration</td><td><code>on</code></td><td>default vectorize mode [on = 0, on = 2, experimental_always = 3, off = 4]</td></tr>
-<tr><td><code>sql.defaults.zigzag_join.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for enable_zigzag_join session setting; allows use of zig-zag join by default</td></tr>
+<tr><td><code>sql.defaults.cost_scans_with_default_col_size.enabled</code></td><td>boolean</td><td><code>false</code></td><td>setting to true uses the same size for all columns to compute scan cost<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.datestyle</code></td><td>enumeration</td><td><code>iso, mdy</code></td><td>default value for DateStyle session setting [iso, mdy = 0, iso, dmy = 1, iso, ymd = 2]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.default_hash_sharded_index_bucket_count</code></td><td>integer</td><td><code>16</code></td><td>used as bucket count if bucket count is not specified in hash sharded index definition<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.default_int_size</code></td><td>integer</td><td><code>8</code></td><td>the size, in bytes, of an INT type<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.disallow_full_table_scans.enabled</code></td><td>boolean</td><td><code>false</code></td><td>setting to true rejects queries that have planned a full table scan<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.distsql</code></td><td>enumeration</td><td><code>auto</code></td><td>default distributed SQL execution mode [off = 0, auto = 1, on = 2, always = 3]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_alter_column_type.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_alter_column_type session setting; enables the use of ALTER COLUMN TYPE for general conversions<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_auto_rehoming.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_auto_rehoming; allows for rows in REGIONAL BY ROW tables to be auto-rehomed on UPDATE<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_distsql_planning</code></td><td>enumeration</td><td><code>off</code></td><td>default experimental_distsql_planning mode; enables experimental opt-driven DistSQL planning [off = 0, on = 1]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_enable_unique_without_index_constraints.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_unique_without_index_constraints session setting;disables unique without index constraints by default<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_implicit_column_partitioning.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_temp_tables; allows for the use of implicit column partitioning<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_stream_replication.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_stream_replication session setting;enables the ability to setup a replication stream<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.experimental_temporary_tables.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for experimental_enable_temp_tables; allows for use of temporary tables by default<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.foreign_key_cascades_limit</code></td><td>integer</td><td><code>10000</code></td><td>default value for foreign_key_cascades_limit session setting; limits the number of cascading operations that run as part of a single query<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.idle_in_session_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the idle_in_session_timeout; default value for the idle_in_session_timeout session setting; controls the duration a session is permitted to idle before the session is terminated; if set to 0, there is no timeout<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.idle_in_transaction_session_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the idle_in_transaction_session_timeout; controls the duration a session is permitted to idle in a transaction before the session is terminated; if set to 0, there is no timeout<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.implicit_select_for_update.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for enable_implicit_select_for_update session setting; enables FOR UPDATE locking during the row-fetch phase of mutation statements<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.insert_fast_path.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for enable_insert_fast_path session setting; enables a specialized insert path<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.intervalstyle</code></td><td>enumeration</td><td><code>postgres</code></td><td>default value for IntervalStyle session setting [postgres = 0, iso_8601 = 1, sql_standard = 2]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.large_full_scan_rows</code></td><td>float</td><td><code>1000</code></td><td>default value for large_full_scan_rows session setting which determines the maximum table size allowed for a full scan when disallow_full_table_scans is set to true<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.locality_optimized_partitioned_index_scan.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for locality_optimized_partitioned_index_scan session setting; enables searching for rows in the current region before searching remote regions<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.lock_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the lock_timeout; default value for the lock_timeout session setting; controls the duration a query is permitted to wait while attempting to acquire a lock on a key or while blocking on an existing lock in order to perform a non-locking read on a key; if set to 0, there is no timeout<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.on_update_rehome_row.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for on_update_rehome_row; enables ON UPDATE rehome_row() expressions to trigger on updates<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.optimizer_use_histograms.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for optimizer_use_histograms session setting; enables usage of histograms in the optimizer by default<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.optimizer_use_multicol_stats.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for optimizer_use_multicol_stats session setting; enables usage of multi-column stats in the optimizer by default<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.override_alter_primary_region_in_super_region.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for override_alter_primary_region_in_super_region; allows for altering the primary region even if the primary region is a member of a super region<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.override_multi_region_zone_config.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for override_multi_region_zone_config; allows for overriding the zone configs of a multi-region table or database<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.prefer_lookup_joins_for_fks.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for prefer_lookup_joins_for_fks session setting; causes foreign key operations to use lookup joins when possible<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.primary_region</code></td><td>string</td><td><code></code></td><td>if not empty, all databases created without a PRIMARY REGION will implicitly have the given PRIMARY REGION<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.reorder_joins_limit</code></td><td>integer</td><td><code>8</code></td><td>default number of joins to reorder<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.require_explicit_primary_keys.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for requiring explicit primary keys in CREATE TABLE statements<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.results_buffer.size</code></td><td>byte size</td><td><code>16 KiB</code></td><td>default size of the buffer that accumulates results for a statement or a batch of statements before they are sent to the client. This can be overridden on an individual connection with the 'results_buffer_size' parameter. Note that auto-retries generally only happen while no results have been delivered to the client, so reducing this size can increase the number of retriable errors a client receives. On the other hand, increasing the buffer size can increase the delay until the client receives the first result row. Updating the setting only affects new connections. Setting to 0 disables any buffering.<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.serial_normalization</code></td><td>enumeration</td><td><code>rowid</code></td><td>default handling of SERIAL in table definitions [rowid = 0, virtual_sequence = 1, sql_sequence = 2, sql_sequence_cached = 3, unordered_rowid = 4]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.statement_timeout</code></td><td>duration</td><td><code>0s</code></td><td>default value for the statement_timeout; default value for the statement_timeout session setting; controls the duration a query is permitted to run before it is canceled; if set to 0, there is no timeout<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.stub_catalog_tables.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for stub_catalog_tables session setting<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.super_regions.enabled</code></td><td>boolean</td><td><code>false</code></td><td>default value for enable_super_regions; allows for the usage of super regions<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.transaction_rows_read_err</code></td><td>integer</td><td><code>0</code></td><td>the limit for the number of rows read by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.transaction_rows_read_log</code></td><td>integer</td><td><code>0</code></td><td>the threshold for the number of rows read by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.transaction_rows_written_err</code></td><td>integer</td><td><code>0</code></td><td>the limit for the number of rows written by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.transaction_rows_written_log</code></td><td>integer</td><td><code>0</code></td><td>the threshold for the number of rows written by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.use_declarative_schema_changer</code></td><td>enumeration</td><td><code>on</code></td><td>default value for use_declarative_schema_changer session setting;disables new schema changer by default [off = 0, on = 1, unsafe = 2, unsafe_always = 3]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.vectorize</code></td><td>enumeration</td><td><code>on</code></td><td>default vectorize mode [on = 0, on = 2, experimental_always = 3, off = 4]<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
+<tr><td><code>sql.defaults.zigzag_join.enabled</code></td><td>boolean</td><td><code>true</code></td><td>default value for enable_zigzag_join session setting; allows use of zig-zag join by default<br/>This cluster setting is being kept to preserve backwards-compatibility.<br/>This session variable default should now be configured using ALTER ROLE... SET: https://www.cockroachlabs.com/docs/stable/alter-role.html</td></tr>
<tr><td><code>sql.distsql.max_running_flows</code></td><td>integer</td><td><code>-128</code></td><td>the value - when positive - used as is, or the value - when negative - multiplied by the number of CPUs on a node, to determine the maximum number of concurrent remote flows that can be run on the node</td></tr>
<tr><td><code>sql.distsql.temp_storage.workmem</code></td><td>byte size</td><td><code>64 MiB</code></td><td>maximum amount of memory in bytes a processor can use before falling back to temp storage</td></tr>
<tr><td><code>sql.guardrails.max_row_size_err</code></td><td>byte size</td><td><code>512 MiB</code></td><td>maximum size of row (or column family if multiple column families are in use) that SQL can write to the database, above which an error is returned; use 0 to disable</td></tr>
diff --git a/pkg/cli/gen.go b/pkg/cli/gen.go
index 72811d8ad60c..1651b6c0e7ce 100644
--- a/pkg/cli/gen.go
+++ b/pkg/cli/gen.go
@@ -239,7 +239,18 @@ Output the list of cluster settings known to this binary.
defaultVal = override
}
}
- row := []string{wrapCode(name), typ, wrapCode(defaultVal), setting.Description()}
+
+ settingDesc := setting.Description()
+ if strings.Contains(name, "sql.defaults") {
+ settingDesc = fmt.Sprintf(`%s
+This cluster setting is being kept to preserve backwards-compatibility.
+This session variable default should now be configured using ALTER ROLE... SET: %s`,
+ setting.Description(),
+ "https://www.cockroachlabs.com/docs/stable/alter-role.html",
+ )
+ }
+
+ row := []string{wrapCode(name), typ, wrapCode(defaultVal), settingDesc}
rows = append(rows, row)
}
|
35cb6b00f217fe2c0a54e7c4376dbea9ce787013
|
2025-03-21 23:04:15
|
Marcus Gartner
|
sql: consider cost flags when choosing generic or custom plans
| false
|
consider cost flags when choosing generic or custom plans
|
sql
|
diff --git a/pkg/sql/logictest/testdata/logic_test/generic b/pkg/sql/logictest/testdata/logic_test/generic
index 43fe6ad5ee9b..11995fc83d8c 100644
--- a/pkg/sql/logictest/testdata/logic_test/generic
+++ b/pkg/sql/logictest/testdata/logic_test/generic
@@ -320,6 +320,41 @@ plan type: generic, reused
statement ok
DEALLOCATE p
+statement ok
+SET plan_cache_mode = auto
+
+statement ok
+ALTER TABLE g INJECT STATISTICS '[
+ {
+ "columns": ["k"],
+ "created_at": "2018-01-01 1:00:00.00000+00:00",
+ "row_count": 0,
+ "distinct_count": 0,
+ "avg_size": 1
+ }
+]';
+
+statement ok
+PREPARE p AS
+UPDATE t SET b = 0 WHERE a IN ($1, $2) AND b > $3
+
+statement ok
+EXECUTE p(1, 10, 100);
+EXECUTE p(1, 10, 100);
+EXECUTE p(1, 10, 100);
+EXECUTE p(1, 10, 100);
+EXECUTE p(1, 10, 100);
+
+# The generic query plan is not chosen because it has a full table scan on a
+# mutating table, while the custom plan does not.
+query T match((plan\stype|FULL\sSCAN))
+EXPLAIN ANALYZE EXECUTE p(1, 10, 100)
+----
+plan type: custom
+
+statement ok
+DEALLOCATE p
+
# Regression test for #132963. Do not cache non-reusable plans.
statement ok
SET plan_cache_mode = auto
diff --git a/pkg/sql/plan_opt.go b/pkg/sql/plan_opt.go
index c018def65abe..3255bc69484e 100644
--- a/pkg/sql/plan_opt.go
+++ b/pkg/sql/plan_opt.go
@@ -617,32 +617,31 @@ func (opc *optPlanningCtx) buildNonIdealGenericPlan() bool {
case sessiondatapb.PlanCacheModeAuto:
// We need to build CustomPlanThreshold custom plans before considering
// a generic plan.
- if prep.Costs.NumCustom() < CustomPlanThreshold {
- return false
- }
- // A generic plan should be built if we have CustomPlanThreshold custom
- // plan costs and:
- //
- // 1. The generic cost is unknown because a generic plan has not been
- // built.
- // 2. Or, the cost of the generic plan is less than the average cost
- // of the custom plans.
- //
- return prep.Costs.Generic().C == 0 || prep.Costs.Generic().Less(prep.Costs.AvgCustom())
+ return prep.Costs.NumCustom() >= CustomPlanThreshold
default:
return false
}
}
-// reuseGenericPlan returns true if a cached generic query plan should be
-// reused. An ideal generic query plan is always reused, if it exists.
-func (opc *optPlanningCtx) reuseGenericPlan() bool {
+// chooseGenericPlan returns true if a generic query plan should be chosen. An
+// ideal generic query plan is always chosen, if it exists. A non-ideal generic
+// plan is chosen if CustomPlanThreshold custom plans have already been built
+// and the generic plan is optimal or it has not yet been built.
+func (opc *optPlanningCtx) chooseGenericPlan() bool {
prep := opc.p.stmt.Prepared
// Always use an ideal generic plan.
if prep.IdealGenericPlan {
return true
}
- return opc.buildNonIdealGenericPlan()
+ switch opc.p.SessionData().PlanCacheMode {
+ case sessiondatapb.PlanCacheModeForceGeneric:
+ return true
+ case sessiondatapb.PlanCacheModeAuto:
+ return prep.Costs.NumCustom() >= CustomPlanThreshold &&
+ (!prep.Costs.HasGeneric() || prep.Costs.IsGenericOptimal())
+ default:
+ return false
+ }
}
// chooseValidPreparedMemo returns a pre-built memo. It may be an unoptimized
@@ -699,7 +698,7 @@ func (opc *optPlanningCtx) chooseValidPreparedMemo(ctx context.Context) (*memo.M
// NOTE: The generic or base memos returned below could be nil if they have
// not yet been built.
- if opc.reuseGenericPlan() {
+ if opc.chooseGenericPlan() {
return prep.GenericMemo, nil
}
return prep.BaseMemo, nil
@@ -768,7 +767,7 @@ func (opc *optPlanningCtx) fetchPreparedMemo(ctx context.Context) (_ *memo.Memo,
prep.Costs.SetGeneric(newMemo.RootExpr().(memo.RelExpr).Cost())
// Now that the cost of the generic plan is known, we need to
// re-evaluate the decision to use a generic or custom plan.
- if !opc.reuseGenericPlan() {
+ if !opc.chooseGenericPlan() {
// The generic plan that we just built is too expensive, so we need
// to build a custom plan. We recursively call fetchPreparedMemo in
// case we have a custom plan that can be reused as a starting point
diff --git a/pkg/sql/prepared_stmt.go b/pkg/sql/prepared_stmt.go
index c9ea650ad128..e8163f1f9dcb 100644
--- a/pkg/sql/prepared_stmt.go
+++ b/pkg/sql/prepared_stmt.go
@@ -134,9 +134,9 @@ type planCosts struct {
}
}
-// Generic returns the cost of the generic plan.
-func (p *planCosts) Generic() memo.Cost {
- return p.generic
+// HasGeneric returns true if the planCosts has a generic plan cost.
+func (p *planCosts) HasGeneric() bool {
+ return p.generic.C != 0
}
// SetGeneric sets the cost of the generic plan.
@@ -162,23 +162,50 @@ func (p *planCosts) NumCustom() int {
return p.custom.length
}
-// AvgCustom returns the average cost of all the custom plan costs in planCosts.
-// If there are no custom plan costs, it returns 0.
+// IsGenericOptimal returns true if the generic plan is optimal w.r.t. the
+// custom plans. Both the cost flags and the cost value are considered.
+//
+// There are currently three cost flags to consider:
+//
+// FullScanPenalty - The generic plan is not optimal if it has a full scan
+// penalty and at least one of the custom plans does not.
+//
+// HugeCostPenalty - We can ignore HugeCostPenalty because it is only used
+// for hints that force specific operators and the optimizer should error if
+// they cannot be used, so it should never be present here.
+//
+// UnboundedCardinality - The generic plan is not optimal if it has
+// unbounded cardinality and at least one of the custom plans does not. This
+// is only present if optimizer_prefer_bounded_cardinality is enabled.
//
-// TODO(mgartner): Figure out how this should incorporate cost flags. Some of
-// them, like UnboundedCardinality, are only set if session settings are set.
-// When those session settings change, do we need to clear and recompute the
-// average cost of custom plans?
-func (p *planCosts) AvgCustom() memo.Cost {
+// If the cost flags have not yielded a result, then the generic plan is optimal
+// if its cost value is less than the average cost of the custom plans.
+func (p *planCosts) IsGenericOptimal() bool {
+ // Check flags.
+ if !p.generic.Flags.Empty() {
+ for i := 0; i < p.custom.length; i++ {
+ if p.custom.costs[i].Flags.Less(p.generic.Flags) {
+ return false
+ }
+ }
+ }
+
+ // Clear the cost flags because they have already been handled above.
+ gen := memo.Cost{C: p.generic.C}
+ return gen.Less(p.avgCustom())
+}
+
+// avgCustom returns the average cost of all the custom plan costs in planCosts.
+// If there are no custom plan costs, it returns 0.
+func (p *planCosts) avgCustom() memo.Cost {
if p.custom.length == 0 {
return memo.Cost{C: 0}
}
- var sum memo.Cost
+ var sum float64
for i := 0; i < p.custom.length; i++ {
- sum.Add(p.custom.costs[i])
+ sum += p.custom.costs[i].C
}
- sum.C /= float64(p.custom.length)
- return sum
+ return memo.Cost{C: sum / float64(p.custom.length)}
}
// Reset clears any previously set costs.
diff --git a/pkg/sql/prepared_stmt_test.go b/pkg/sql/prepared_stmt_test.go
index e9f95107b6d5..e0bf08977cea 100644
--- a/pkg/sql/prepared_stmt_test.go
+++ b/pkg/sql/prepared_stmt_test.go
@@ -40,8 +40,8 @@ func TestPlanCosts(t *testing.T) {
t.Errorf("expected Len() to be %d, got %d", tc.expectedNum, pc.NumCustom())
}
expectedAvgCost := memo.Cost{C: tc.expectedAvg}
- if pc.AvgCustom() != expectedAvgCost {
- t.Errorf("expected Avg() to be %f, got %f", tc.expectedAvg, pc.AvgCustom().C)
+ if pc.avgCustom() != expectedAvgCost {
+ t.Errorf("expected Avg() to be %f, got %f", tc.expectedAvg, pc.avgCustom().C)
}
}
}
|
8e16dda2fb35f98486449835bbee4d98ec2f7f6a
|
2019-04-20 00:47:31
|
Andrew Kimball
|
sql: Move sql/sem/types package to sql/types
| false
|
Move sql/sem/types package to sql/types
|
sql
|
diff --git a/pkg/ccl/backupccl/backup.go b/pkg/ccl/backupccl/backup.go
index 885b3d8146a1..85621856cc0b 100644
--- a/pkg/ccl/backupccl/backup.go
+++ b/pkg/ccl/backupccl/backup.go
@@ -30,8 +30,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
diff --git a/pkg/ccl/backupccl/restore.go b/pkg/ccl/backupccl/restore.go
index fb5ae15c3f79..d1d67a06c234 100644
--- a/pkg/ccl/backupccl/restore.go
+++ b/pkg/ccl/backupccl/restore.go
@@ -31,9 +31,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/interval"
diff --git a/pkg/ccl/backupccl/show.go b/pkg/ccl/backupccl/show.go
index a6a4dfd2f5f0..f4970290c8d8 100644
--- a/pkg/ccl/backupccl/show.go
+++ b/pkg/ccl/backupccl/show.go
@@ -16,8 +16,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
diff --git a/pkg/ccl/changefeedccl/avro.go b/pkg/ccl/changefeedccl/avro.go
index f68a2ddd6833..1e97ed658354 100644
--- a/pkg/ccl/changefeedccl/avro.go
+++ b/pkg/ccl/changefeedccl/avro.go
@@ -16,8 +16,8 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/timeofday"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
diff --git a/pkg/ccl/changefeedccl/avro_test.go b/pkg/ccl/changefeedccl/avro_test.go
index 404841d06690..3184f0f04d3f 100644
--- a/pkg/ccl/changefeedccl/avro_test.go
+++ b/pkg/ccl/changefeedccl/avro_test.go
@@ -23,9 +23,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
diff --git a/pkg/ccl/changefeedccl/buffer.go b/pkg/ccl/changefeedccl/buffer.go
index 2ed44c81a381..84e82f650f35 100644
--- a/pkg/ccl/changefeedccl/buffer.go
+++ b/pkg/ccl/changefeedccl/buffer.go
@@ -16,8 +16,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/ccl/changefeedccl/changefeed_dist.go b/pkg/ccl/changefeedccl/changefeed_dist.go
index 6dba2668395f..5c2ac0f15ccf 100644
--- a/pkg/ccl/changefeedccl/changefeed_dist.go
+++ b/pkg/ccl/changefeedccl/changefeed_dist.go
@@ -19,7 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlplan"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
)
diff --git a/pkg/ccl/changefeedccl/changefeed_processors.go b/pkg/ccl/changefeedccl/changefeed_processors.go
index e71f42b1c389..8f5540abc7af 100644
--- a/pkg/ccl/changefeedccl/changefeed_processors.go
+++ b/pkg/ccl/changefeedccl/changefeed_processors.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/closedts"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/ccl/changefeedccl/changefeed_stmt.go b/pkg/ccl/changefeedccl/changefeed_stmt.go
index fdb0b8bea89c..be38449b48fe 100644
--- a/pkg/ccl/changefeedccl/changefeed_stmt.go
+++ b/pkg/ccl/changefeedccl/changefeed_stmt.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/retry"
diff --git a/pkg/ccl/importccl/exportcsv.go b/pkg/ccl/importccl/exportcsv.go
index 17429ca8f48f..50b8266e2519 100644
--- a/pkg/ccl/importccl/exportcsv.go
+++ b/pkg/ccl/importccl/exportcsv.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding/csv"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
diff --git a/pkg/ccl/importccl/import_stmt.go b/pkg/ccl/importccl/import_stmt.go
index b74aeaaf0c80..f700aeea2518 100644
--- a/pkg/ccl/importccl/import_stmt.go
+++ b/pkg/ccl/importccl/import_stmt.go
@@ -34,10 +34,10 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
diff --git a/pkg/ccl/importccl/read_import_mysql.go b/pkg/ccl/importccl/read_import_mysql.go
index c91bbaf683e1..1d11fca8187f 100644
--- a/pkg/ccl/importccl/read_import_mysql.go
+++ b/pkg/ccl/importccl/read_import_mysql.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/ccl/importccl/read_import_mysql_test.go b/pkg/ccl/importccl/read_import_mysql_test.go
index e80d10762f71..ddffbaf78f62 100644
--- a/pkg/ccl/importccl/read_import_mysql_test.go
+++ b/pkg/ccl/importccl/read_import_mysql_test.go
@@ -25,9 +25,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
diff --git a/pkg/ccl/importccl/read_import_proc.go b/pkg/ccl/importccl/read_import_proc.go
index 66225d35993f..2fffbc158255 100644
--- a/pkg/ccl/importccl/read_import_proc.go
+++ b/pkg/ccl/importccl/read_import_proc.go
@@ -31,8 +31,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/transform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/storagebase"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
diff --git a/pkg/ccl/importccl/read_import_workload.go b/pkg/ccl/importccl/read_import_workload.go
index b022cc6d607a..f89a68cbfe0d 100644
--- a/pkg/ccl/importccl/read_import_workload.go
+++ b/pkg/ccl/importccl/read_import_workload.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/workload"
diff --git a/pkg/ccl/importccl/sst_writer_proc.go b/pkg/ccl/importccl/sst_writer_proc.go
index 8bc152e009b9..9e62ab88f59b 100644
--- a/pkg/ccl/importccl/sst_writer_proc.go
+++ b/pkg/ccl/importccl/sst_writer_proc.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/bulk"
"github.com/cockroachdb/cockroach/pkg/storage/diskmap"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
diff --git a/pkg/ccl/partitionccl/partition.go b/pkg/ccl/partitionccl/partition.go
index 9a331bc5d141..fa1ecab3e751 100644
--- a/pkg/ccl/partitionccl/partition.go
+++ b/pkg/ccl/partitionccl/partition.go
@@ -17,8 +17,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/pkg/errors"
)
diff --git a/pkg/ccl/partitionccl/partition_test.go b/pkg/ccl/partitionccl/partition_test.go
index 33381f5422a5..3970d98d2e88 100644
--- a/pkg/ccl/partitionccl/partition_test.go
+++ b/pkg/ccl/partitionccl/partition_test.go
@@ -28,8 +28,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
diff --git a/pkg/cli/dump.go b/pkg/cli/dump.go
index f58cfd32610a..8026fb1307c3 100644
--- a/pkg/cli/dump.go
+++ b/pkg/cli/dump.go
@@ -27,7 +27,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
"github.com/cockroachdb/cockroach/pkg/util/timeofday"
"github.com/cockroachdb/cockroach/pkg/util/version"
diff --git a/pkg/cmd/cmp-protocol/main.go b/pkg/cmd/cmp-protocol/main.go
index d8b128945457..7c163aa83a50 100644
--- a/pkg/cmd/cmp-protocol/main.go
+++ b/pkg/cmd/cmp-protocol/main.go
@@ -30,8 +30,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/cmd/cmp-protocol/pgconnect"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgwirebase"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
"github.com/pkg/errors"
)
diff --git a/pkg/internal/rsg/rsg.go b/pkg/internal/rsg/rsg.go
index 00c502441aba..842532eee54a 100644
--- a/pkg/internal/rsg/rsg.go
+++ b/pkg/internal/rsg/rsg.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/rsg/yacc"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/syncutil"
)
diff --git a/pkg/internal/sqlsmith/relational.go b/pkg/internal/sqlsmith/relational.go
index 24ce3794a391..e5cf33815ac5 100644
--- a/pkg/internal/sqlsmith/relational.go
+++ b/pkg/internal/sqlsmith/relational.go
@@ -18,8 +18,8 @@ import (
"math/rand"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func (s *scope) makeStmt() (stmt tree.Statement, ok bool) {
diff --git a/pkg/internal/sqlsmith/scalar.go b/pkg/internal/sqlsmith/scalar.go
index 6c2f46b27fb7..0d4529249dfd 100644
--- a/pkg/internal/sqlsmith/scalar.go
+++ b/pkg/internal/sqlsmith/scalar.go
@@ -16,8 +16,8 @@ package sqlsmith
import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
var (
diff --git a/pkg/internal/sqlsmith/schema.go b/pkg/internal/sqlsmith/schema.go
index a7b000654e34..6a47ee8133cb 100644
--- a/pkg/internal/sqlsmith/schema.go
+++ b/pkg/internal/sqlsmith/schema.go
@@ -22,7 +22,7 @@ import (
// Import builtins so they are reflected in tree.FunDefs.
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/lib/pq/oid"
)
diff --git a/pkg/internal/sqlsmith/scope.go b/pkg/internal/sqlsmith/scope.go
index 5183a4f4004e..3d5ed89396a1 100644
--- a/pkg/internal/sqlsmith/scope.go
+++ b/pkg/internal/sqlsmith/scope.go
@@ -16,7 +16,7 @@ package sqlsmith
import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// colRef refers to a named result column. If it is from a table, def is
diff --git a/pkg/internal/sqlsmith/type.go b/pkg/internal/sqlsmith/type.go
index 4ed4ff13ef9d..dc8123bf7b81 100644
--- a/pkg/internal/sqlsmith/type.go
+++ b/pkg/internal/sqlsmith/type.go
@@ -18,8 +18,8 @@ import (
"fmt"
"strings"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
var typeNames = func() map[string]*types.T {
diff --git a/pkg/jobs/registry.go b/pkg/jobs/registry.go
index b883e4d0bab5..32714e596f1f 100644
--- a/pkg/jobs/registry.go
+++ b/pkg/jobs/registry.go
@@ -28,8 +28,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/storagepb"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/server/authentication.go b/pkg/server/authentication.go
index 83829facf3fb..7282836af5ba 100644
--- a/pkg/server/authentication.go
+++ b/pkg/server/authentication.go
@@ -30,7 +30,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings"
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
gwruntime "github.com/grpc-ecosystem/grpc-gateway/runtime"
diff --git a/pkg/server/settingsworker.go b/pkg/server/settingsworker.go
index bb20dc8378f7..ce06e49a6d03 100644
--- a/pkg/server/settingsworker.go
+++ b/pkg/server/settingsworker.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings"
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
diff --git a/pkg/sql/alter_table.go b/pkg/sql/alter_table.go
index 4f641acd4f3d..203c37af8c1c 100644
--- a/pkg/sql/alter_table.go
+++ b/pkg/sql/alter_table.go
@@ -25,9 +25,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/schemachange"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
"github.com/gogo/protobuf/proto"
)
diff --git a/pkg/sql/analyze_expr.go b/pkg/sql/analyze_expr.go
index 382feea513b4..da038d6640d0 100644
--- a/pkg/sql/analyze_expr.go
+++ b/pkg/sql/analyze_expr.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// analyzeExpr performs semantic analysis of an expression, including:
diff --git a/pkg/sql/backfill/backfill.go b/pkg/sql/backfill/backfill.go
index 09da3c6b4616..319e045abc18 100644
--- a/pkg/sql/backfill/backfill.go
+++ b/pkg/sql/backfill/backfill.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/sem/transform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/builtin_test.go b/pkg/sql/builtin_test.go
index bbf075a5967c..edc17d6a4429 100644
--- a/pkg/sql/builtin_test.go
+++ b/pkg/sql/builtin_test.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/cancel_queries.go b/pkg/sql/cancel_queries.go
index a9dfb7f4f633..8cdb5c6884b3 100644
--- a/pkg/sql/cancel_queries.go
+++ b/pkg/sql/cancel_queries.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/server/serverpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type cancelQueriesNode struct {
diff --git a/pkg/sql/cancel_sessions.go b/pkg/sql/cancel_sessions.go
index b14b6d6f4492..5eaf0703097e 100644
--- a/pkg/sql/cancel_sessions.go
+++ b/pkg/sql/cancel_sessions.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/server/serverpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type cancelSessionsNode struct {
diff --git a/pkg/sql/colencoding/key_encoding.go b/pkg/sql/colencoding/key_encoding.go
index 51d1a46cf66f..da92925f8806 100644
--- a/pkg/sql/colencoding/key_encoding.go
+++ b/pkg/sql/colencoding/key_encoding.go
@@ -19,8 +19,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/colencoding/value_encoding.go b/pkg/sql/colencoding/value_encoding.go
index c395f3846dc1..3d9a0ee10ddc 100644
--- a/pkg/sql/colencoding/value_encoding.go
+++ b/pkg/sql/colencoding/value_encoding.go
@@ -17,7 +17,7 @@ package colencoding
import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/colencoding/value_encoding_test.go b/pkg/sql/colencoding/value_encoding_test.go
index 75a4a12db3a6..657d6cf1c991 100644
--- a/pkg/sql/colencoding/value_encoding_test.go
+++ b/pkg/sql/colencoding/value_encoding_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/conn_executor.go b/pkg/sql/conn_executor.go
index 97b118261aad..4f39bfaa0b0f 100644
--- a/pkg/sql/conn_executor.go
+++ b/pkg/sql/conn_executor.go
@@ -34,11 +34,11 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
"github.com/cockroachdb/cockroach/pkg/util/errorutil"
diff --git a/pkg/sql/conn_executor_exec.go b/pkg/sql/conn_executor_exec.go
index 124077323e27..d36c9dbb8bb9 100644
--- a/pkg/sql/conn_executor_exec.go
+++ b/pkg/sql/conn_executor_exec.go
@@ -27,9 +27,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/fsm"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/control_jobs.go b/pkg/sql/control_jobs.go
index 0daad06b0aa9..ee1b32539416 100644
--- a/pkg/sql/control_jobs.go
+++ b/pkg/sql/control_jobs.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/jobs"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type controlJobsNode struct {
diff --git a/pkg/sql/copy.go b/pkg/sql/copy.go
index c711490d5356..806ea1614343 100644
--- a/pkg/sql/copy.go
+++ b/pkg/sql/copy.go
@@ -27,8 +27,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgwirebase"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
)
diff --git a/pkg/sql/copy_in_test.go b/pkg/sql/copy_in_test.go
index f50ff9ee571f..ed2442a251d3 100644
--- a/pkg/sql/copy_in_test.go
+++ b/pkg/sql/copy_in_test.go
@@ -25,9 +25,9 @@ import (
"time"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/tests"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/timeofday"
diff --git a/pkg/sql/crdb_internal.go b/pkg/sql/crdb_internal.go
index 64ba8ee287e4..df70b58346f4 100644
--- a/pkg/sql/crdb_internal.go
+++ b/pkg/sql/crdb_internal.go
@@ -38,8 +38,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/storagepb"
"github.com/cockroachdb/cockroach/pkg/util/json"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/create_sequence.go b/pkg/sql/create_sequence.go
index 2698fc1cf5ee..1d2636ddfb9a 100644
--- a/pkg/sql/create_sequence.go
+++ b/pkg/sql/create_sequence.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
)
diff --git a/pkg/sql/create_stats.go b/pkg/sql/create_stats.go
index ed809cab0f74..c9c9dee8ef11 100644
--- a/pkg/sql/create_stats.go
+++ b/pkg/sql/create_stats.go
@@ -28,10 +28,10 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/create_table.go b/pkg/sql/create_table.go
index 954fa88ecb9d..216e9a8a705e 100644
--- a/pkg/sql/create_table.go
+++ b/pkg/sql/create_table.go
@@ -29,8 +29,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/lib/pq/oid"
diff --git a/pkg/sql/delete.go b/pkg/sql/delete.go
index 9547b648abad..ad2100684c6d 100644
--- a/pkg/sql/delete.go
+++ b/pkg/sql/delete.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
)
diff --git a/pkg/sql/distinct.go b/pkg/sql/distinct.go
index 7b09c4cd139a..b9b773ee83e4 100644
--- a/pkg/sql/distinct.go
+++ b/pkg/sql/distinct.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/distsql_physical_planner.go b/pkg/sql/distsql_physical_planner.go
index 023bedddc39e..14039fa95b5f 100644
--- a/pkg/sql/distsql_physical_planner.go
+++ b/pkg/sql/distsql_physical_planner.go
@@ -36,8 +36,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
diff --git a/pkg/sql/distsql_plan_csv.go b/pkg/sql/distsql_plan_csv.go
index e3fe7a3070cf..086c5e96ddbe 100644
--- a/pkg/sql/distsql_plan_csv.go
+++ b/pkg/sql/distsql_plan_csv.go
@@ -33,8 +33,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/distsql_plan_stats.go b/pkg/sql/distsql_plan_stats.go
index 4f3f6af2bf76..44d54c96f1f0 100644
--- a/pkg/sql/distsql_plan_stats.go
+++ b/pkg/sql/distsql_plan_stats.go
@@ -22,9 +22,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/jobs/jobspb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
sqlstats "github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log/logtags"
diff --git a/pkg/sql/distsql_plan_window.go b/pkg/sql/distsql_plan_window.go
index 7cbcb9afaef1..32ad92478108 100644
--- a/pkg/sql/distsql_plan_window.go
+++ b/pkg/sql/distsql_plan_window.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsql_running.go b/pkg/sql/distsql_running.go
index 8209ef630835..0e8bb7c8cbf2 100644
--- a/pkg/sql/distsql_running.go
+++ b/pkg/sql/distsql_running.go
@@ -30,8 +30,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/distsqlpb/data.pb.go b/pkg/sql/distsqlpb/data.pb.go
index 49bad563159b..50d6d0673d1c 100644
--- a/pkg/sql/distsqlpb/data.pb.go
+++ b/pkg/sql/distsqlpb/data.pb.go
@@ -18,7 +18,7 @@ import sqlbase "github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
import tracing "github.com/cockroachdb/cockroach/pkg/util/tracing"
import github_com_cockroachdb_cockroach_pkg_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
-import github_com_cockroachdb_cockroach_pkg_sql_sem_types "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import github_com_cockroachdb_cockroach_pkg_sql_types "github.com/cockroachdb/cockroach/pkg/sql/types"
import io "io"
@@ -67,7 +67,7 @@ func (x *Ordering_Column_Direction) UnmarshalJSON(data []byte) error {
return nil
}
func (Ordering_Column_Direction) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{2, 0, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{2, 0, 0}
}
type StreamEndpointSpec_Type int32
@@ -112,7 +112,7 @@ func (x *StreamEndpointSpec_Type) UnmarshalJSON(data []byte) error {
return nil
}
func (StreamEndpointSpec_Type) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{3, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{3, 0}
}
type InputSyncSpec_Type int32
@@ -152,7 +152,7 @@ func (x *InputSyncSpec_Type) UnmarshalJSON(data []byte) error {
return nil
}
func (InputSyncSpec_Type) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{4, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{4, 0}
}
type OutputRouterSpec_Type int32
@@ -200,7 +200,7 @@ func (x *OutputRouterSpec_Type) UnmarshalJSON(data []byte) error {
return nil
}
func (OutputRouterSpec_Type) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{5, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{5, 0}
}
// Error is a generic representation including a string message.
@@ -216,7 +216,7 @@ type Error struct {
func (m *Error) Reset() { *m = Error{} }
func (*Error) ProtoMessage() {}
func (*Error) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{0}
}
func (m *Error) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -355,7 +355,7 @@ func _Error_OneofSizer(msg proto.Message) (n int) {
func (m *Expression) Reset() { *m = Expression{} }
func (*Expression) ProtoMessage() {}
func (*Expression) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{1}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{1}
}
func (m *Expression) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -392,7 +392,7 @@ func (m *Ordering) Reset() { *m = Ordering{} }
func (m *Ordering) String() string { return proto.CompactTextString(m) }
func (*Ordering) ProtoMessage() {}
func (*Ordering) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{2}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{2}
}
func (m *Ordering) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -428,7 +428,7 @@ func (m *Ordering_Column) Reset() { *m = Ordering_Column{} }
func (m *Ordering_Column) String() string { return proto.CompactTextString(m) }
func (*Ordering_Column) ProtoMessage() {}
func (*Ordering_Column) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{2, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{2, 0}
}
func (m *Ordering_Column) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -477,7 +477,7 @@ func (m *StreamEndpointSpec) Reset() { *m = StreamEndpointSpec{} }
func (m *StreamEndpointSpec) String() string { return proto.CompactTextString(m) }
func (*StreamEndpointSpec) ProtoMessage() {}
func (*StreamEndpointSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{3}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{3}
}
func (m *StreamEndpointSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -509,16 +509,16 @@ type InputSyncSpec struct {
Ordering Ordering `protobuf:"bytes,2,opt,name=ordering" json:"ordering"`
Streams []StreamEndpointSpec `protobuf:"bytes,3,rep,name=streams" json:"streams"`
// Schema for the streams entering this synchronizer.
- ColumnTypes []github_com_cockroachdb_cockroach_pkg_sql_sem_types.T `protobuf:"bytes,4,rep,name=column_types,json=columnTypes,customtype=github.com/cockroachdb/cockroach/pkg/sql/sem/types.T" json:"column_types"`
- XXX_NoUnkeyedLiteral struct{} `json:"-"`
- XXX_sizecache int32 `json:"-"`
+ ColumnTypes []github_com_cockroachdb_cockroach_pkg_sql_types.T `protobuf:"bytes,4,rep,name=column_types,json=columnTypes,customtype=github.com/cockroachdb/cockroach/pkg/sql/types.T" json:"column_types"`
+ XXX_NoUnkeyedLiteral struct{} `json:"-"`
+ XXX_sizecache int32 `json:"-"`
}
func (m *InputSyncSpec) Reset() { *m = InputSyncSpec{} }
func (m *InputSyncSpec) String() string { return proto.CompactTextString(m) }
func (*InputSyncSpec) ProtoMessage() {}
func (*InputSyncSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{4}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{4}
}
func (m *InputSyncSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -564,7 +564,7 @@ func (m *OutputRouterSpec) Reset() { *m = OutputRouterSpec{} }
func (m *OutputRouterSpec) String() string { return proto.CompactTextString(m) }
func (*OutputRouterSpec) ProtoMessage() {}
func (*OutputRouterSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{5}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{5}
}
func (m *OutputRouterSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -609,7 +609,7 @@ func (m *OutputRouterSpec_RangeRouterSpec) Reset() { *m = OutputRouterSp
func (m *OutputRouterSpec_RangeRouterSpec) String() string { return proto.CompactTextString(m) }
func (*OutputRouterSpec_RangeRouterSpec) ProtoMessage() {}
func (*OutputRouterSpec_RangeRouterSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{5, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{5, 0}
}
func (m *OutputRouterSpec_RangeRouterSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -653,7 +653,7 @@ func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) String() string {
}
func (*OutputRouterSpec_RangeRouterSpec_ColumnEncoding) ProtoMessage() {}
func (*OutputRouterSpec_RangeRouterSpec_ColumnEncoding) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{5, 0, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{5, 0, 0}
}
func (m *OutputRouterSpec_RangeRouterSpec_ColumnEncoding) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -692,7 +692,7 @@ func (m *OutputRouterSpec_RangeRouterSpec_Span) Reset() { *m = OutputRou
func (m *OutputRouterSpec_RangeRouterSpec_Span) String() string { return proto.CompactTextString(m) }
func (*OutputRouterSpec_RangeRouterSpec_Span) ProtoMessage() {}
func (*OutputRouterSpec_RangeRouterSpec_Span) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{5, 0, 1}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{5, 0, 1}
}
func (m *OutputRouterSpec_RangeRouterSpec_Span) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -718,17 +718,17 @@ func (m *OutputRouterSpec_RangeRouterSpec_Span) XXX_DiscardUnknown() {
var xxx_messageInfo_OutputRouterSpec_RangeRouterSpec_Span proto.InternalMessageInfo
type DatumInfo struct {
- Encoding sqlbase.DatumEncoding `protobuf:"varint,1,opt,name=encoding,enum=cockroach.sql.sqlbase.DatumEncoding" json:"encoding"`
- Type github_com_cockroachdb_cockroach_pkg_sql_sem_types.T `protobuf:"bytes,2,opt,name=type,customtype=github.com/cockroachdb/cockroach/pkg/sql/sem/types.T" json:"type"`
- XXX_NoUnkeyedLiteral struct{} `json:"-"`
- XXX_sizecache int32 `json:"-"`
+ Encoding sqlbase.DatumEncoding `protobuf:"varint,1,opt,name=encoding,enum=cockroach.sql.sqlbase.DatumEncoding" json:"encoding"`
+ Type github_com_cockroachdb_cockroach_pkg_sql_types.T `protobuf:"bytes,2,opt,name=type,customtype=github.com/cockroachdb/cockroach/pkg/sql/types.T" json:"type"`
+ XXX_NoUnkeyedLiteral struct{} `json:"-"`
+ XXX_sizecache int32 `json:"-"`
}
func (m *DatumInfo) Reset() { *m = DatumInfo{} }
func (m *DatumInfo) String() string { return proto.CompactTextString(m) }
func (*DatumInfo) ProtoMessage() {}
func (*DatumInfo) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{6}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{6}
}
func (m *DatumInfo) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -765,7 +765,7 @@ func (m *ProducerHeader) Reset() { *m = ProducerHeader{} }
func (m *ProducerHeader) String() string { return proto.CompactTextString(m) }
func (*ProducerHeader) ProtoMessage() {}
func (*ProducerHeader) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{7}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{7}
}
func (m *ProducerHeader) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -810,7 +810,7 @@ func (m *ProducerData) Reset() { *m = ProducerData{} }
func (m *ProducerData) String() string { return proto.CompactTextString(m) }
func (*ProducerData) ProtoMessage() {}
func (*ProducerData) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{8}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{8}
}
func (m *ProducerData) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -854,7 +854,7 @@ func (m *ProducerMessage) Reset() { *m = ProducerMessage{} }
func (m *ProducerMessage) String() string { return proto.CompactTextString(m) }
func (*ProducerMessage) ProtoMessage() {}
func (*ProducerMessage) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{9}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{9}
}
func (m *ProducerMessage) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -900,7 +900,7 @@ func (m *RemoteProducerMetadata) Reset() { *m = RemoteProducerMetadata{}
func (m *RemoteProducerMetadata) String() string { return proto.CompactTextString(m) }
func (*RemoteProducerMetadata) ProtoMessage() {}
func (*RemoteProducerMetadata) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{10}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{10}
}
func (m *RemoteProducerMetadata) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1166,7 +1166,7 @@ func (m *RemoteProducerMetadata_RangeInfos) Reset() { *m = RemoteProduce
func (m *RemoteProducerMetadata_RangeInfos) String() string { return proto.CompactTextString(m) }
func (*RemoteProducerMetadata_RangeInfos) ProtoMessage() {}
func (*RemoteProducerMetadata_RangeInfos) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{10, 0}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{10, 0}
}
func (m *RemoteProducerMetadata_RangeInfos) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1201,7 +1201,7 @@ func (m *RemoteProducerMetadata_TraceData) Reset() { *m = RemoteProducer
func (m *RemoteProducerMetadata_TraceData) String() string { return proto.CompactTextString(m) }
func (*RemoteProducerMetadata_TraceData) ProtoMessage() {}
func (*RemoteProducerMetadata_TraceData) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{10, 1}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{10, 1}
}
func (m *RemoteProducerMetadata_TraceData) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1244,7 +1244,7 @@ func (m *RemoteProducerMetadata_RowNum) Reset() { *m = RemoteProducerMet
func (m *RemoteProducerMetadata_RowNum) String() string { return proto.CompactTextString(m) }
func (*RemoteProducerMetadata_RowNum) ProtoMessage() {}
func (*RemoteProducerMetadata_RowNum) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{10, 2}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{10, 2}
}
func (m *RemoteProducerMetadata_RowNum) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1283,7 +1283,7 @@ func (m *RemoteProducerMetadata_SamplerProgress) Reset() {
func (m *RemoteProducerMetadata_SamplerProgress) String() string { return proto.CompactTextString(m) }
func (*RemoteProducerMetadata_SamplerProgress) ProtoMessage() {}
func (*RemoteProducerMetadata_SamplerProgress) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{10, 3}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{10, 3}
}
func (m *RemoteProducerMetadata_SamplerProgress) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1325,7 +1325,7 @@ func (m *DistSQLVersionGossipInfo) Reset() { *m = DistSQLVersionGossipIn
func (m *DistSQLVersionGossipInfo) String() string { return proto.CompactTextString(m) }
func (*DistSQLVersionGossipInfo) ProtoMessage() {}
func (*DistSQLVersionGossipInfo) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{11}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{11}
}
func (m *DistSQLVersionGossipInfo) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1363,7 +1363,7 @@ func (m *DistSQLDrainingInfo) Reset() { *m = DistSQLDrainingInfo{} }
func (m *DistSQLDrainingInfo) String() string { return proto.CompactTextString(m) }
func (*DistSQLDrainingInfo) ProtoMessage() {}
func (*DistSQLDrainingInfo) Descriptor() ([]byte, []int) {
- return fileDescriptor_data_1fb00e52ad578433, []int{12}
+ return fileDescriptor_data_8a87ba1bf4c4704b, []int{12}
}
func (m *DistSQLDrainingInfo) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -3328,7 +3328,7 @@ func (m *InputSyncSpec) Unmarshal(dAtA []byte) error {
if postIndex > l {
return io.ErrUnexpectedEOF
}
- var v github_com_cockroachdb_cockroach_pkg_sql_sem_types.T
+ var v github_com_cockroachdb_cockroach_pkg_sql_types.T
m.ColumnTypes = append(m.ColumnTypes, v)
if err := m.ColumnTypes[len(m.ColumnTypes)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
return err
@@ -5256,118 +5256,118 @@ var (
ErrIntOverflowData = fmt.Errorf("proto: integer overflow")
)
-func init() { proto.RegisterFile("sql/distsqlpb/data.proto", fileDescriptor_data_1fb00e52ad578433) }
-
-var fileDescriptor_data_1fb00e52ad578433 = []byte{
- // 1751 bytes of a gzipped FileDescriptorProto
- 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xa4, 0x58, 0xcf, 0x6f, 0x23, 0x49,
- 0xf5, 0x77, 0xdb, 0x8e, 0x7f, 0x3c, 0x3b, 0x8e, 0x53, 0xdf, 0xd1, 0xc8, 0xf2, 0x77, 0x88, 0x43,
- 0x2f, 0x42, 0x61, 0x59, 0xec, 0x99, 0x2c, 0xd2, 0x88, 0x80, 0xd8, 0x89, 0x63, 0x4f, 0xec, 0xdd,
- 0x4c, 0x1c, 0xda, 0x19, 0xd0, 0xec, 0x22, 0x35, 0xed, 0xee, 0x4a, 0xa7, 0xd9, 0xfe, 0x95, 0xaa,
- 0xea, 0x71, 0x72, 0xe1, 0xc4, 0x1f, 0x80, 0x84, 0x84, 0x38, 0x2e, 0x07, 0xb8, 0xf0, 0x07, 0xf0,
- 0x1f, 0xc0, 0x1c, 0x39, 0xae, 0x38, 0x44, 0x10, 0x2e, 0x1c, 0xf7, 0xca, 0x9e, 0x50, 0x55, 0x57,
- 0xf9, 0x47, 0x32, 0xd9, 0xdd, 0xec, 0x5c, 0x9c, 0xaa, 0x57, 0xef, 0x7d, 0xfa, 0x53, 0x9f, 0x7a,
- 0xf5, 0xaa, 0x2a, 0xd0, 0xa0, 0x67, 0x7e, 0xc7, 0xf1, 0x28, 0xa3, 0x67, 0x7e, 0x3c, 0xe9, 0x38,
- 0x16, 0xb3, 0xda, 0x31, 0x89, 0x58, 0x84, 0x1a, 0x76, 0x64, 0x7f, 0x4c, 0x22, 0xcb, 0x3e, 0x6d,
- 0xd3, 0x33, 0xbf, 0x2d, 0x7d, 0x48, 0x12, 0x36, 0xef, 0xff, 0x32, 0x9a, 0xd0, 0x0e, 0xff, 0x89,
- 0x27, 0xe2, 0x4f, 0x1a, 0xd1, 0x5c, 0x17, 0xde, 0xf1, 0xa4, 0x63, 0xc5, 0x9e, 0x34, 0x21, 0x65,
- 0x9a, 0x03, 0x37, 0xef, 0x29, 0x1b, 0x26, 0x24, 0x22, 0x2a, 0xb8, 0xc5, 0x89, 0xc4, 0xee, 0xd4,
- 0x23, 0xb8, 0x13, 0xbb, 0x62, 0x68, 0xd9, 0xe1, 0x01, 0x77, 0xa0, 0x67, 0xfe, 0xc4, 0xa2, 0xb8,
- 0x43, 0x19, 0x49, 0x6c, 0x96, 0x10, 0xec, 0x2c, 0x86, 0xab, 0x51, 0x1c, 0xda, 0x91, 0x83, 0x1d,
- 0xd3, 0xb1, 0x58, 0x12, 0x48, 0x87, 0xcd, 0x84, 0x79, 0x7e, 0x87, 0x11, 0xcb, 0xf6, 0x42, 0xb7,
- 0x43, 0xb0, 0x1d, 0x11, 0xee, 0x42, 0x63, 0x2b, 0x54, 0xbc, 0xdc, 0xc8, 0x8d, 0x44, 0xb3, 0xc3,
- 0x5b, 0xa9, 0x55, 0xff, 0x8b, 0x06, 0x2b, 0x7d, 0xce, 0x03, 0x75, 0xa1, 0x14, 0xbb, 0xa6, 0xe0,
- 0xd4, 0xd0, 0x36, 0xb5, 0xad, 0xca, 0x76, 0xa3, 0x3d, 0xd7, 0x48, 0x72, 0x6e, 0x0b, 0xdf, 0x6e,
- 0xe5, 0xea, 0xb2, 0x55, 0x3c, 0xda, 0x17, 0x9d, 0x41, 0xc6, 0x28, 0xc6, 0x6e, 0x8a, 0xf1, 0x21,
- 0xac, 0x13, 0xcc, 0xc8, 0x85, 0x35, 0xf1, 0xf1, 0xf1, 0x79, 0x28, 0x8c, 0x8d, 0xac, 0x00, 0x7b,
- 0x7b, 0x01, 0x4c, 0x2a, 0xd4, 0x7e, 0x1e, 0x9e, 0x5a, 0xa1, 0xe3, 0x63, 0xc7, 0x50, 0x41, 0x0a,
- 0xf1, 0x26, 0xcc, 0x4e, 0xfe, 0xf7, 0x9f, 0xb4, 0x32, 0xdd, 0x12, 0x14, 0x1c, 0xcc, 0x2c, 0xcf,
- 0xd7, 0x8f, 0x00, 0xfa, 0xe7, 0x31, 0xc1, 0x94, 0x7a, 0x51, 0x88, 0x36, 0xa0, 0xf8, 0x12, 0x13,
- 0xde, 0x14, 0xe4, 0xcb, 0xdd, 0xfc, 0xab, 0xcb, 0x56, 0xc6, 0x50, 0x46, 0xd4, 0x80, 0x3c, 0x3e,
- 0x8f, 0x53, 0x32, 0x6a, 0x50, 0x58, 0x76, 0x4a, 0x1c, 0xf7, 0xb3, 0x3f, 0xb4, 0x32, 0xfa, 0xaf,
- 0xb3, 0x50, 0x1a, 0x11, 0x07, 0x13, 0x2f, 0x74, 0xd1, 0x10, 0x8a, 0x76, 0xe4, 0x27, 0x41, 0x48,
- 0x1b, 0xda, 0x66, 0x6e, 0xab, 0xb2, 0xfd, 0x9d, 0xf6, 0x6d, 0x19, 0xd3, 0x56, 0x41, 0xed, 0x3d,
- 0x11, 0xa1, 0xbe, 0x2d, 0xe3, 0x9b, 0x7f, 0xd2, 0xa0, 0x90, 0x8e, 0xa0, 0x6f, 0x08, 0x54, 0xd3,
- 0x73, 0xce, 0x05, 0xcd, 0x55, 0xe9, 0x5a, 0xb0, 0x23, 0x7f, 0xe8, 0x9c, 0xa3, 0x9f, 0x41, 0xd9,
- 0xf1, 0x08, 0xb6, 0x19, 0x9f, 0x07, 0xa7, 0x5a, 0xdb, 0x7e, 0xf7, 0x2b, 0x7f, 0xb6, 0xdd, 0x53,
- 0xa1, 0x12, 0x75, 0x8e, 0xa5, 0x6f, 0x40, 0x79, 0x36, 0x8a, 0x8a, 0x90, 0xdb, 0x1d, 0xef, 0xd5,
- 0x33, 0xa8, 0x04, 0xf9, 0x5e, 0x7f, 0xbc, 0x57, 0xd7, 0x76, 0xf2, 0xff, 0xf9, 0xa4, 0x25, 0x7f,
- 0xf5, 0xbf, 0x65, 0x01, 0x8d, 0x19, 0xc1, 0x56, 0xd0, 0x0f, 0x9d, 0x38, 0xf2, 0x42, 0x36, 0x8e,
- 0xb1, 0x8d, 0x3e, 0x80, 0x3c, 0xbb, 0x88, 0xb1, 0xe0, 0x5d, 0xdb, 0x7e, 0x74, 0x3b, 0xad, 0x9b,
- 0xb1, 0xed, 0xe3, 0x8b, 0x18, 0x2b, 0xd1, 0x39, 0x08, 0xfa, 0x01, 0x94, 0xa9, 0x70, 0x33, 0x3d,
- 0x47, 0x4c, 0x74, 0xa5, 0xfb, 0x80, 0x0f, 0x5f, 0x5d, 0xb6, 0x4a, 0x69, 0xfc, 0xb0, 0xf7, 0xf9,
- 0x42, 0xdb, 0x28, 0xa5, 0xee, 0x43, 0x07, 0x9d, 0x41, 0x8d, 0x59, 0xc4, 0xc5, 0xcc, 0x0c, 0x23,
- 0x07, 0xf3, 0xf8, 0xbc, 0x88, 0xff, 0x40, 0xc6, 0x57, 0x8f, 0xc5, 0xe8, 0x61, 0xe4, 0x60, 0x81,
- 0xf1, 0xae, 0xeb, 0xb1, 0xd3, 0x64, 0xd2, 0xb6, 0xa3, 0xa0, 0x33, 0xe3, 0xec, 0x4c, 0xe6, 0xed,
- 0x4e, 0xfc, 0xb1, 0xdb, 0x51, 0x29, 0x99, 0x86, 0x19, 0x55, 0x36, 0x07, 0x71, 0xf4, 0x87, 0x90,
- 0xe7, 0x33, 0x40, 0x65, 0x58, 0x39, 0x18, 0xed, 0xed, 0x1e, 0xd4, 0x33, 0x08, 0xa0, 0x60, 0xf4,
- 0x9f, 0x8d, 0x8e, 0xfb, 0x75, 0x0d, 0xad, 0xc3, 0xea, 0xf8, 0xc5, 0xe1, 0x9e, 0x69, 0xf4, 0xc7,
- 0x47, 0xa3, 0xc3, 0x71, 0xbf, 0x9e, 0x7d, 0x3f, 0x5f, 0xca, 0xd5, 0xf3, 0xfa, 0x67, 0x59, 0x58,
- 0x1d, 0x86, 0x71, 0xc2, 0xc6, 0x17, 0xa1, 0x2d, 0x44, 0x7c, 0xba, 0x24, 0xe2, 0x3b, 0xb7, 0x8b,
- 0xb8, 0x14, 0x76, 0x53, 0xbf, 0x1e, 0x94, 0x22, 0xb9, 0xfa, 0x72, 0x7f, 0xe9, 0x5f, 0x9e, 0x27,
- 0x12, 0x61, 0x16, 0x89, 0x0e, 0xa0, 0x98, 0xca, 0x4a, 0x1b, 0x39, 0x91, 0xe3, 0xef, 0xdc, 0x65,
- 0x55, 0x55, 0x9a, 0x4b, 0x08, 0x64, 0x42, 0x35, 0xcd, 0x78, 0x93, 0x53, 0xa4, 0x8d, 0xfc, 0x66,
- 0x6e, 0xab, 0xda, 0xfd, 0x11, 0x77, 0xfa, 0xc7, 0x65, 0xeb, 0xfb, 0x5f, 0x69, 0x19, 0x44, 0x99,
- 0xc3, 0x41, 0x47, 0x20, 0xb4, 0x8f, 0x8d, 0x4a, 0x8a, 0xc8, 0xe7, 0x4f, 0x75, 0x5d, 0x2e, 0xc3,
- 0x2a, 0x94, 0x9f, 0x1f, 0x8e, 0x8c, 0x5e, 0xdf, 0xe8, 0xf7, 0xea, 0x19, 0x54, 0x81, 0xa2, 0xea,
- 0x68, 0xfa, 0x7f, 0x0b, 0x50, 0x1f, 0x25, 0x2c, 0x4e, 0x98, 0x11, 0x25, 0x0c, 0x13, 0xa1, 0xfa,
- 0x70, 0x49, 0xf5, 0xce, 0x17, 0x28, 0x75, 0x2d, 0xf2, 0xa6, 0xf0, 0x0b, 0x92, 0x65, 0xdf, 0x5c,
- 0xb2, 0x6f, 0x42, 0xf5, 0xd4, 0xa2, 0xa7, 0xa6, 0xaa, 0x34, 0x7c, 0x15, 0x56, 0x8d, 0x0a, 0xb7,
- 0xa5, 0x7b, 0x9a, 0x22, 0x1f, 0xd6, 0x89, 0x15, 0xba, 0xd8, 0x24, 0x82, 0x95, 0x49, 0x63, 0x6c,
- 0x8b, 0x8c, 0xaf, 0x6c, 0xef, 0xdc, 0x61, 0x22, 0x06, 0xc7, 0x98, 0xf7, 0x25, 0x91, 0x35, 0xb2,
- 0x6c, 0x46, 0x8f, 0x60, 0xdd, 0xf1, 0x28, 0xaf, 0xbb, 0xe6, 0x24, 0x39, 0x39, 0x49, 0x13, 0x6c,
- 0x65, 0x53, 0xdb, 0x2a, 0xc9, 0x88, 0xba, 0x1c, 0xee, 0xaa, 0xd1, 0xe6, 0x5f, 0x73, 0xb0, 0x76,
- 0x0d, 0x1d, 0x7d, 0x04, 0x2b, 0xfc, 0xe4, 0x51, 0xa5, 0xf3, 0xbd, 0xaf, 0x4f, 0xb4, 0x3d, 0x8e,
- 0x2d, 0x55, 0xcf, 0x52, 0x4c, 0x2e, 0x9a, 0x83, 0x4f, 0xac, 0xc4, 0x67, 0xa6, 0x83, 0x29, 0x4b,
- 0xcb, 0x87, 0x51, 0x91, 0xb6, 0x1e, 0xa6, 0x0c, 0x05, 0x50, 0x16, 0x87, 0xa4, 0x17, 0xba, 0x2a,
- 0xb5, 0x87, 0x6f, 0xc0, 0x21, 0x5d, 0x8b, 0xbe, 0x44, 0x54, 0xd5, 0x75, 0xf6, 0x85, 0xe6, 0x4b,
- 0xa8, 0x2d, 0xbb, 0xa0, 0x07, 0x50, 0x48, 0xd7, 0xf4, 0x46, 0x99, 0xe7, 0xa7, 0xc0, 0x53, 0x28,
- 0xa9, 0x60, 0x59, 0xe5, 0xbf, 0x75, 0x8d, 0x9d, 0x3c, 0xea, 0xdb, 0x3d, 0x7e, 0xc4, 0x5f, 0xfb,
- 0xf0, 0x2c, 0xb6, 0x79, 0x00, 0x79, 0x2e, 0x0f, 0xba, 0x07, 0x2b, 0x94, 0x59, 0x84, 0x89, 0x8f,
- 0x55, 0x8d, 0xb4, 0x83, 0xea, 0x90, 0xc3, 0x61, 0x5a, 0x5d, 0xab, 0x06, 0x6f, 0x72, 0x56, 0x69,
- 0xe6, 0x35, 0x72, 0xa2, 0x64, 0x4a, 0x56, 0xa9, 0x4d, 0x7f, 0x4f, 0x6e, 0xaf, 0x3a, 0x54, 0x8f,
- 0x76, 0xc7, 0x63, 0xf3, 0x78, 0x60, 0x8c, 0x9e, 0xef, 0x0f, 0xd2, 0x62, 0xf7, 0x6c, 0x68, 0x18,
- 0x23, 0xa3, 0xae, 0xf1, 0xdd, 0xd6, 0x7d, 0x61, 0x0e, 0x76, 0xc7, 0x83, 0x7a, 0x16, 0x55, 0xa1,
- 0xd4, 0x7d, 0x61, 0x1a, 0xbb, 0x87, 0xfb, 0xfd, 0x7a, 0x4e, 0xff, 0xa3, 0x06, 0x65, 0x41, 0x78,
- 0x18, 0x9e, 0x44, 0x4b, 0x93, 0xd4, 0xbe, 0xfe, 0x24, 0xd1, 0x91, 0xdc, 0xbc, 0x62, 0x1e, 0x6f,
- 0x58, 0x4e, 0x04, 0x92, 0xfe, 0x2b, 0xa8, 0x1d, 0x91, 0xc8, 0x49, 0x6c, 0x4c, 0x06, 0xd8, 0x72,
- 0x30, 0x41, 0x8f, 0xa0, 0x78, 0xe2, 0x47, 0x53, 0x7e, 0x98, 0x08, 0x09, 0xbb, 0x0d, 0xf9, 0x99,
- 0xc2, 0x53, 0x3f, 0x9a, 0x0e, 0x7b, 0x57, 0xb3, 0x96, 0x51, 0xe0, 0x8e, 0x43, 0xe7, 0x0d, 0x4e,
- 0x30, 0xfd, 0xcf, 0x1a, 0x54, 0x15, 0x81, 0x9e, 0xc5, 0x2c, 0xf4, 0xff, 0x50, 0x26, 0xd6, 0xd4,
- 0x9c, 0x5c, 0x30, 0x4c, 0xe5, 0x1a, 0x96, 0x88, 0x35, 0xed, 0xf2, 0x3e, 0x32, 0xa0, 0x14, 0x60,
- 0x66, 0xf1, 0x1b, 0xa6, 0x2c, 0x39, 0x0f, 0x6f, 0x4f, 0x65, 0x03, 0x07, 0x11, 0xc3, 0x0a, 0xfc,
- 0x99, 0x8c, 0x53, 0x9a, 0x2a, 0x1c, 0xf4, 0x36, 0xd4, 0xc2, 0x24, 0x30, 0x71, 0x10, 0xb3, 0x0b,
- 0x93, 0x44, 0x53, 0xba, 0x94, 0x10, 0xd5, 0x30, 0x09, 0xfa, 0x7c, 0xc8, 0x88, 0xa6, 0x54, 0xff,
- 0x54, 0x83, 0xb5, 0x39, 0x20, 0xa5, 0x96, 0x8b, 0xd1, 0x13, 0x28, 0x9c, 0x0a, 0xe5, 0xe4, 0x4d,
- 0x71, 0xeb, 0x76, 0x46, 0xcb, 0x4a, 0x1b, 0x32, 0x0e, 0xed, 0x42, 0x81, 0x5d, 0xc4, 0xe9, 0x06,
- 0xe0, 0x73, 0x7a, 0xeb, 0x76, 0x84, 0x59, 0x4a, 0xa9, 0x7c, 0x4d, 0x03, 0xd1, 0x13, 0xc8, 0x0b,
- 0x51, 0x72, 0x82, 0xc2, 0xb7, 0xbf, 0x9c, 0x42, 0x6f, 0x2e, 0x85, 0x88, 0xd4, 0x7f, 0x5b, 0x84,
- 0xfb, 0xaf, 0x57, 0x0c, 0xfd, 0x1c, 0x20, 0x2d, 0xbb, 0x5e, 0x78, 0x12, 0xc9, 0x59, 0xfe, 0xf0,
- 0xae, 0xba, 0xa7, 0x85, 0x84, 0x53, 0xa7, 0x83, 0x8c, 0x51, 0x26, 0xaa, 0x87, 0x1e, 0xc3, 0x0a,
- 0x5e, 0xb8, 0x1b, 0xb7, 0x6e, 0x07, 0x56, 0x17, 0xe2, 0xd4, 0x1f, 0x7d, 0x04, 0xc0, 0xef, 0xf8,
- 0xd8, 0x5c, 0x98, 0xf9, 0xce, 0x9d, 0x69, 0x1d, 0x73, 0x08, 0xae, 0x06, 0x67, 0xc5, 0x54, 0x07,
- 0xed, 0x43, 0x8d, 0x9d, 0x87, 0xa6, 0x1d, 0x45, 0xc4, 0x31, 0x79, 0xae, 0xc8, 0x73, 0xa6, 0xf5,
- 0x9a, 0xab, 0xfb, 0xf1, 0x79, 0xb8, 0xc7, 0xfd, 0x38, 0xe6, 0x20, 0x63, 0x54, 0xd9, 0x42, 0x1f,
- 0x19, 0x50, 0x24, 0xd1, 0xd4, 0x0c, 0x93, 0x40, 0x9c, 0x1d, 0x95, 0xed, 0xc7, 0x77, 0x57, 0x2e,
- 0x9a, 0x1e, 0x26, 0xc1, 0x20, 0x63, 0x14, 0x88, 0x68, 0xa1, 0x00, 0xea, 0xd4, 0x0a, 0x62, 0x1f,
- 0x13, 0x33, 0x26, 0x91, 0xcb, 0xef, 0xfd, 0x8d, 0xa2, 0x00, 0x7f, 0x72, 0x67, 0xf0, 0x71, 0x0a,
- 0x74, 0x24, 0x71, 0x06, 0x19, 0x63, 0x8d, 0x2e, 0x9b, 0x9a, 0x23, 0x80, 0xf9, 0xe2, 0xa1, 0xdd,
- 0x6b, 0xd9, 0xc0, 0x33, 0xf6, 0xc1, 0x6b, 0x54, 0x99, 0x85, 0xa8, 0x33, 0x62, 0xb6, 0xe4, 0xcd,
- 0x5f, 0x40, 0x79, 0x26, 0x3b, 0x1a, 0xc3, 0x9a, 0x1d, 0xf9, 0x3e, 0xb6, 0x99, 0x7c, 0xa3, 0xa9,
- 0x93, 0x72, 0xb1, 0x44, 0xf2, 0x17, 0x5d, 0x5b, 0xbe, 0xe8, 0xda, 0x86, 0x7c, 0xd1, 0x2d, 0x1c,
- 0x87, 0xb5, 0x19, 0x04, 0x37, 0xd2, 0xe6, 0x14, 0x0a, 0xa9, 0x6a, 0xe8, 0x7b, 0x50, 0xa6, 0x38,
- 0x74, 0x30, 0x51, 0x05, 0xad, 0xdc, 0xad, 0xcf, 0x6a, 0x93, 0x18, 0x10, 0xf5, 0x28, 0x6d, 0x39,
- 0xfc, 0x51, 0xa2, 0x96, 0x2b, 0xbb, 0x78, 0x2e, 0x48, 0xe5, 0x5b, 0x50, 0xf2, 0x2d, 0xca, 0xcc,
- 0x80, 0xba, 0x22, 0xe3, 0xd4, 0x55, 0xa0, 0xc8, 0xad, 0xcf, 0xa8, 0xdb, 0xfc, 0x31, 0xac, 0x5d,
- 0x53, 0x14, 0x7d, 0x17, 0x6a, 0xbc, 0xac, 0xf0, 0xa5, 0xb2, 0x31, 0xa5, 0x38, 0xa5, 0x91, 0x97,
- 0x91, 0xab, 0x7c, 0xec, 0x48, 0x0d, 0x75, 0x8b, 0xb0, 0xf2, 0xd2, 0xf2, 0x13, 0xfc, 0x7e, 0xbe,
- 0x54, 0xa8, 0x17, 0xf5, 0xdf, 0x69, 0xd0, 0xe8, 0x79, 0x94, 0x8d, 0x7f, 0x72, 0xf0, 0xd3, 0xf4,
- 0xf5, 0xb6, 0x1f, 0x51, 0xea, 0xc5, 0x62, 0xe7, 0x3c, 0x5c, 0x7e, 0xe7, 0xad, 0x76, 0xef, 0x73,
- 0xc4, 0xcf, 0x2f, 0x5b, 0xb5, 0xe5, 0x90, 0xf9, 0xcb, 0x6f, 0x00, 0xf7, 0x02, 0x2f, 0x34, 0x2d,
- 0xdb, 0xc6, 0x31, 0x97, 0x5b, 0x85, 0x67, 0xbf, 0x30, 0x1c, 0x05, 0x5e, 0xb8, 0x2b, 0x43, 0xa4,
- 0x4d, 0x7f, 0x0c, 0xff, 0x27, 0xbd, 0x7a, 0xc4, 0xf2, 0x42, 0x2f, 0x74, 0x05, 0xa5, 0x4d, 0x28,
- 0x39, 0xb2, 0x2f, 0x38, 0x29, 0x7d, 0x66, 0xd6, 0xee, 0x5b, 0xaf, 0xfe, 0xb5, 0x91, 0x79, 0x75,
- 0xb5, 0xa1, 0xfd, 0xfd, 0x6a, 0x43, 0xfb, 0xf4, 0x6a, 0x43, 0xfb, 0xe7, 0xd5, 0x86, 0xf6, 0x9b,
- 0x7f, 0x6f, 0x64, 0x3e, 0x2c, 0xcf, 0xfe, 0x37, 0xf1, 0xbf, 0x00, 0x00, 0x00, 0xff, 0xff, 0x87,
- 0x54, 0x78, 0xb0, 0xab, 0x10, 0x00, 0x00,
+func init() { proto.RegisterFile("sql/distsqlpb/data.proto", fileDescriptor_data_8a87ba1bf4c4704b) }
+
+var fileDescriptor_data_8a87ba1bf4c4704b = []byte{
+ // 1747 bytes of a gzipped FileDescriptorProto
+ 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xa4, 0x58, 0x4d, 0x73, 0x23, 0x47,
+ 0x19, 0xd6, 0x48, 0xb2, 0x3e, 0x5e, 0xc9, 0xb2, 0xdc, 0xa4, 0xb6, 0x54, 0x62, 0xb1, 0xcc, 0x84,
+ 0xa2, 0x4c, 0x08, 0xd2, 0xae, 0x73, 0x58, 0x30, 0x55, 0x64, 0x2d, 0x4b, 0x6b, 0x29, 0xf1, 0x5a,
+ 0x66, 0xe4, 0x85, 0xda, 0x2c, 0x55, 0xc3, 0x68, 0xa6, 0x3d, 0x1e, 0x32, 0x5f, 0xee, 0xee, 0x59,
+ 0xd9, 0x17, 0x4e, 0xfc, 0x00, 0xaa, 0xa8, 0xa2, 0x38, 0x26, 0x17, 0x2e, 0xfc, 0x00, 0xfe, 0x01,
+ 0xec, 0x91, 0x63, 0x8a, 0x83, 0x0b, 0xcc, 0x85, 0x03, 0x07, 0xae, 0xe4, 0x44, 0x75, 0x4f, 0xb7,
+ 0x3e, 0xec, 0x75, 0x12, 0x67, 0x2f, 0x72, 0x7f, 0xbc, 0xcf, 0x33, 0x4f, 0x3f, 0xfd, 0xce, 0xdb,
+ 0xd3, 0x86, 0x06, 0x3d, 0xf3, 0x3b, 0x8e, 0x47, 0x19, 0x3d, 0xf3, 0xe3, 0x49, 0xc7, 0xb1, 0x98,
+ 0xd5, 0x8e, 0x49, 0xc4, 0x22, 0xd4, 0xb0, 0x23, 0xfb, 0x63, 0x12, 0x59, 0xf6, 0x69, 0x9b, 0x9e,
+ 0xf9, 0x6d, 0x19, 0x43, 0x92, 0xb0, 0x79, 0xef, 0x57, 0xd1, 0x84, 0x76, 0xf8, 0x4f, 0x3c, 0x11,
+ 0x7f, 0x52, 0x44, 0x73, 0x5d, 0x44, 0xc7, 0x93, 0x8e, 0x15, 0x7b, 0x72, 0x08, 0xa9, 0xa1, 0x39,
+ 0x71, 0xf3, 0x2d, 0x35, 0x86, 0x09, 0x89, 0x88, 0x02, 0xb7, 0xb8, 0x90, 0xd8, 0x9d, 0x7a, 0x04,
+ 0x77, 0x62, 0x57, 0x4c, 0x2d, 0x07, 0xdc, 0xe7, 0x01, 0xf4, 0xcc, 0x9f, 0x58, 0x14, 0x77, 0x28,
+ 0x23, 0x89, 0xcd, 0x12, 0x82, 0x9d, 0x45, 0xb8, 0x9a, 0xc5, 0xa1, 0x1d, 0x39, 0xd8, 0x31, 0x1d,
+ 0x8b, 0x25, 0x81, 0x0c, 0xd8, 0x4c, 0x98, 0xe7, 0x77, 0x18, 0xb1, 0x6c, 0x2f, 0x74, 0x3b, 0x04,
+ 0xdb, 0x11, 0xe1, 0x21, 0x34, 0xb6, 0x42, 0xa5, 0xcb, 0x8d, 0xdc, 0x48, 0x34, 0x3b, 0xbc, 0x95,
+ 0x8e, 0xea, 0x7f, 0xd6, 0x60, 0xa5, 0xcf, 0x75, 0xa0, 0x2e, 0x94, 0x62, 0xd7, 0x14, 0x9a, 0x1a,
+ 0xda, 0xa6, 0xb6, 0x55, 0xd9, 0x6e, 0xb4, 0xe7, 0x1e, 0x49, 0xcd, 0x6d, 0x11, 0xdb, 0xad, 0x5c,
+ 0x5d, 0xb6, 0x8a, 0x47, 0xfb, 0xa2, 0x33, 0xc8, 0x18, 0xc5, 0xd8, 0x4d, 0x39, 0x3e, 0x82, 0x75,
+ 0x82, 0x19, 0xb9, 0xb0, 0x26, 0x3e, 0x3e, 0x3e, 0x0f, 0xc5, 0x60, 0x23, 0x2b, 0xc8, 0xde, 0x59,
+ 0x20, 0x93, 0x0e, 0xb5, 0x9f, 0x85, 0xa7, 0x56, 0xe8, 0xf8, 0xd8, 0x31, 0x14, 0x48, 0x31, 0xde,
+ 0xa4, 0xd9, 0xc9, 0xff, 0xe1, 0x93, 0x56, 0xa6, 0x5b, 0x82, 0x82, 0x83, 0x99, 0xe5, 0xf9, 0xfa,
+ 0x11, 0x40, 0xff, 0x3c, 0x26, 0x98, 0x52, 0x2f, 0x0a, 0xd1, 0x06, 0x14, 0x5f, 0x62, 0xc2, 0x9b,
+ 0x42, 0x7c, 0xb9, 0x9b, 0x7f, 0x75, 0xd9, 0xca, 0x18, 0x6a, 0x10, 0x35, 0x20, 0x8f, 0xcf, 0xe3,
+ 0x54, 0x8c, 0x9a, 0x14, 0x23, 0x3b, 0x25, 0xce, 0xfb, 0xdf, 0x4f, 0x5b, 0x19, 0xfd, 0x37, 0x59,
+ 0x28, 0x8d, 0x88, 0x83, 0x89, 0x17, 0xba, 0x68, 0x08, 0x45, 0x3b, 0xf2, 0x93, 0x20, 0xa4, 0x0d,
+ 0x6d, 0x33, 0xb7, 0x55, 0xd9, 0xfe, 0x5e, 0xfb, 0xb6, 0x8c, 0x69, 0x2b, 0x50, 0x7b, 0x4f, 0x20,
+ 0xd4, 0xb3, 0x25, 0xbe, 0xf9, 0x47, 0x0d, 0x0a, 0xe9, 0x0c, 0xfa, 0x96, 0x60, 0x35, 0x3d, 0xe7,
+ 0x5c, 0xc8, 0x5c, 0x95, 0xa1, 0x05, 0x3b, 0xf2, 0x87, 0xce, 0x39, 0xfa, 0x39, 0x94, 0x1d, 0x8f,
+ 0x60, 0x9b, 0xf1, 0x75, 0x70, 0xa9, 0xb5, 0xed, 0xf7, 0xbe, 0xf2, 0x63, 0xdb, 0x3d, 0x05, 0x95,
+ 0xac, 0x73, 0x2e, 0x7d, 0x03, 0xca, 0xb3, 0x59, 0x54, 0x84, 0xdc, 0xee, 0x78, 0xaf, 0x9e, 0x41,
+ 0x25, 0xc8, 0xf7, 0xfa, 0xe3, 0xbd, 0xba, 0xb6, 0x93, 0xff, 0xf7, 0x27, 0x2d, 0xf9, 0xab, 0xff,
+ 0x35, 0x0b, 0x68, 0xcc, 0x08, 0xb6, 0x82, 0x7e, 0xe8, 0xc4, 0x91, 0x17, 0xb2, 0x71, 0x8c, 0x6d,
+ 0xf4, 0x21, 0xe4, 0xd9, 0x45, 0x8c, 0x85, 0xee, 0xda, 0xf6, 0xc3, 0xdb, 0x65, 0xdd, 0xc4, 0xb6,
+ 0x8f, 0x2f, 0x62, 0xac, 0x4c, 0xe7, 0x24, 0xe8, 0x47, 0x50, 0xa6, 0x22, 0xcc, 0xf4, 0x1c, 0xb1,
+ 0xd0, 0x95, 0xee, 0x7d, 0x3e, 0x7d, 0x75, 0xd9, 0x2a, 0xa5, 0xf8, 0x61, 0xef, 0xf3, 0x85, 0xb6,
+ 0x51, 0x4a, 0xc3, 0x87, 0x0e, 0x3a, 0x83, 0x1a, 0xb3, 0x88, 0x8b, 0x99, 0x19, 0x46, 0x0e, 0xe6,
+ 0xf8, 0xbc, 0xc0, 0x7f, 0x28, 0xf1, 0xd5, 0x63, 0x31, 0x7b, 0x18, 0x39, 0x58, 0x70, 0xbc, 0xe7,
+ 0x7a, 0xec, 0x34, 0x99, 0xb4, 0xed, 0x28, 0xe8, 0xcc, 0x34, 0x3b, 0x93, 0x79, 0xbb, 0x13, 0x7f,
+ 0xec, 0x76, 0x54, 0x4a, 0xa6, 0x30, 0xa3, 0xca, 0xe6, 0x24, 0x8e, 0xfe, 0x00, 0xf2, 0x7c, 0x05,
+ 0xa8, 0x0c, 0x2b, 0x07, 0xa3, 0xbd, 0xdd, 0x83, 0x7a, 0x06, 0x01, 0x14, 0x8c, 0xfe, 0xd3, 0xd1,
+ 0x71, 0xbf, 0xae, 0xa1, 0x75, 0x58, 0x1d, 0x3f, 0x3f, 0xdc, 0x33, 0x8d, 0xfe, 0xf8, 0x68, 0x74,
+ 0x38, 0xee, 0xd7, 0xb3, 0x1f, 0xe4, 0x4b, 0xb9, 0x7a, 0x5e, 0xff, 0x4f, 0x16, 0x56, 0x87, 0x61,
+ 0x9c, 0xb0, 0xf1, 0x45, 0x68, 0x0b, 0x13, 0x9f, 0x2c, 0x99, 0xf8, 0xee, 0xed, 0x26, 0x2e, 0xc1,
+ 0x6e, 0xfa, 0xd7, 0x83, 0x52, 0x24, 0x77, 0x5f, 0xbe, 0x5f, 0xfa, 0x97, 0xe7, 0x89, 0x64, 0x98,
+ 0x21, 0xd1, 0x01, 0x14, 0x53, 0x5b, 0x69, 0x23, 0x27, 0x72, 0xfc, 0xdd, 0xbb, 0xec, 0xaa, 0x4a,
+ 0x73, 0x49, 0x81, 0x5e, 0x40, 0x35, 0xcd, 0x78, 0x93, 0x4b, 0xa4, 0x8d, 0xfc, 0x66, 0x6e, 0xab,
+ 0xda, 0xfd, 0x21, 0x0f, 0xfa, 0xfb, 0x65, 0xeb, 0xc1, 0x57, 0xda, 0x06, 0x5e, 0xe6, 0x04, 0xba,
+ 0x7d, 0x6c, 0x54, 0x52, 0x36, 0xbe, 0x76, 0xaa, 0xeb, 0x72, 0x0b, 0x56, 0xa1, 0xfc, 0xec, 0x70,
+ 0x64, 0xf4, 0xfa, 0x46, 0xbf, 0x57, 0xcf, 0xa0, 0x0a, 0x14, 0x55, 0x47, 0xd3, 0xff, 0x57, 0x80,
+ 0xfa, 0x28, 0x61, 0x71, 0xc2, 0x8c, 0x28, 0x61, 0x98, 0x08, 0xc7, 0x87, 0x4b, 0x8e, 0x77, 0xbe,
+ 0xc0, 0xa5, 0x6b, 0xc8, 0x9b, 0xa6, 0x2f, 0xd8, 0x95, 0x7d, 0x73, 0xbb, 0xbe, 0x0d, 0xd5, 0x53,
+ 0x8b, 0x9e, 0x9a, 0xaa, 0xca, 0xf0, 0x1d, 0x58, 0x35, 0x2a, 0x7c, 0x2c, 0x7d, 0x9f, 0x29, 0xf2,
+ 0x61, 0x9d, 0x58, 0xa1, 0x8b, 0x4d, 0x22, 0x54, 0x99, 0x34, 0xc6, 0xb6, 0xc8, 0xf6, 0xca, 0xf6,
+ 0xce, 0x1d, 0x16, 0x62, 0x70, 0x8e, 0x79, 0x5f, 0x0a, 0x59, 0x23, 0xcb, 0xc3, 0xe8, 0x21, 0xac,
+ 0x3b, 0x1e, 0xe5, 0x35, 0xd7, 0x9c, 0x24, 0x27, 0x27, 0x69, 0x72, 0xad, 0x6c, 0x6a, 0x5b, 0x25,
+ 0x89, 0xa8, 0xcb, 0xe9, 0xae, 0x9a, 0x6d, 0xfe, 0x25, 0x07, 0x6b, 0xd7, 0xd8, 0xd1, 0x0b, 0x58,
+ 0xe1, 0xa7, 0x8e, 0x2a, 0x9b, 0xef, 0x7f, 0x7d, 0xa1, 0xed, 0x71, 0x6c, 0xa9, 0x5a, 0x96, 0x72,
+ 0x72, 0xd3, 0x1c, 0x7c, 0x62, 0x25, 0x3e, 0x33, 0x1d, 0x4c, 0x59, 0x5a, 0x3a, 0x8c, 0x8a, 0x1c,
+ 0xeb, 0x61, 0xca, 0x50, 0x00, 0x65, 0x71, 0x40, 0x7a, 0xa1, 0xab, 0xd2, 0x7a, 0xf8, 0x06, 0x1a,
+ 0xd2, 0xbd, 0xe8, 0x4b, 0x46, 0x55, 0x59, 0x67, 0x4f, 0x68, 0xbe, 0x84, 0xda, 0x72, 0x08, 0xba,
+ 0x0f, 0x85, 0x74, 0x4f, 0x6f, 0x94, 0x78, 0x7e, 0x02, 0x3c, 0x81, 0x92, 0x02, 0xcb, 0x0a, 0xff,
+ 0x9d, 0x6b, 0xea, 0xe4, 0x31, 0xdf, 0xee, 0xf1, 0xe3, 0xfd, 0xda, 0x83, 0x67, 0xd8, 0xe6, 0x01,
+ 0xe4, 0xb9, 0x3d, 0xe8, 0x2d, 0x58, 0xa1, 0xcc, 0x22, 0x4c, 0x3c, 0xac, 0x6a, 0xa4, 0x1d, 0x54,
+ 0x87, 0x1c, 0x0e, 0xd3, 0xca, 0x5a, 0x35, 0x78, 0x93, 0xab, 0x4a, 0x33, 0xaf, 0x91, 0x13, 0xe5,
+ 0x52, 0xaa, 0x4a, 0xc7, 0xf4, 0xf7, 0xe5, 0xeb, 0x55, 0x87, 0xea, 0xd1, 0xee, 0x78, 0x6c, 0x1e,
+ 0x0f, 0x8c, 0xd1, 0xb3, 0xfd, 0x41, 0x5a, 0xe8, 0x9e, 0x0e, 0x0d, 0x63, 0x64, 0xd4, 0x35, 0xfe,
+ 0xb6, 0x75, 0x9f, 0x9b, 0x83, 0xdd, 0xf1, 0xa0, 0x9e, 0x45, 0x55, 0x28, 0x75, 0x9f, 0x9b, 0xc6,
+ 0xee, 0xe1, 0x7e, 0xbf, 0x9e, 0xd3, 0x3f, 0xd5, 0xa0, 0x2c, 0x04, 0x0f, 0xc3, 0x93, 0x68, 0x69,
+ 0x91, 0xda, 0xd7, 0x5f, 0x24, 0x3a, 0x90, 0x2f, 0xaf, 0x58, 0xc7, 0x1b, 0x94, 0x12, 0xc1, 0xa2,
+ 0xff, 0x1a, 0x6a, 0x47, 0x24, 0x72, 0x12, 0x1b, 0x93, 0x01, 0xb6, 0x1c, 0x4c, 0xd0, 0x43, 0x28,
+ 0x9e, 0xf8, 0xd1, 0x94, 0x1f, 0x22, 0xc2, 0xbe, 0x6e, 0x43, 0x3e, 0xa2, 0xf0, 0xc4, 0x8f, 0xa6,
+ 0xc3, 0xde, 0xd5, 0xac, 0x65, 0x14, 0x78, 0xe0, 0xd0, 0x79, 0x83, 0x93, 0x4b, 0xff, 0x93, 0x06,
+ 0x55, 0x25, 0xa0, 0x67, 0x31, 0x0b, 0x7d, 0x13, 0xca, 0xc4, 0x9a, 0x9a, 0x93, 0x0b, 0x86, 0xa9,
+ 0xdc, 0xbf, 0x12, 0xb1, 0xa6, 0x5d, 0xde, 0x47, 0x06, 0x94, 0x02, 0xcc, 0x2c, 0xfe, 0x65, 0x29,
+ 0xcb, 0xcd, 0x83, 0xdb, 0xd3, 0xd8, 0xc0, 0x41, 0xc4, 0xb0, 0x22, 0x7f, 0x2a, 0x71, 0xca, 0x4f,
+ 0xc5, 0x83, 0xde, 0x81, 0x5a, 0x98, 0x04, 0x26, 0x0e, 0x62, 0x76, 0x61, 0x92, 0x68, 0x4a, 0x97,
+ 0x92, 0xa1, 0x1a, 0x26, 0x41, 0x9f, 0x4f, 0x19, 0xd1, 0x94, 0xea, 0x9f, 0x69, 0xb0, 0x36, 0x27,
+ 0xa4, 0xd4, 0x72, 0x31, 0x7a, 0x0c, 0x85, 0x53, 0xe1, 0x9c, 0xfc, 0x42, 0xdc, 0xba, 0x5d, 0xd1,
+ 0xb2, 0xd3, 0x86, 0xc4, 0xa1, 0x5d, 0x28, 0xb0, 0x8b, 0x38, 0x4d, 0x7e, 0xbe, 0xa6, 0xb7, 0x6f,
+ 0x67, 0x98, 0xa5, 0x93, 0xca, 0xd5, 0x14, 0x88, 0x1e, 0x43, 0x5e, 0x98, 0x92, 0x13, 0x12, 0xbe,
+ 0xfb, 0xe5, 0x12, 0x7a, 0x73, 0x2b, 0x04, 0x52, 0xff, 0x5d, 0x11, 0xee, 0xbd, 0xde, 0x31, 0xf4,
+ 0x0b, 0x80, 0xb4, 0xe4, 0x7a, 0xe1, 0x49, 0x24, 0x57, 0xf9, 0xe3, 0xbb, 0xfa, 0x9e, 0x16, 0x11,
+ 0x2e, 0x9d, 0x0e, 0x32, 0x46, 0x99, 0xa8, 0x1e, 0x7a, 0x04, 0x2b, 0x78, 0xe1, 0x9b, 0xb8, 0x75,
+ 0x3b, 0xb1, 0xfa, 0x10, 0x4e, 0xe3, 0xd1, 0x0b, 0x00, 0xfe, 0x6d, 0x8f, 0xcd, 0x85, 0x95, 0xef,
+ 0xdc, 0x59, 0xd6, 0x31, 0xa7, 0xe0, 0x6e, 0x70, 0x55, 0x4c, 0x75, 0xd0, 0x3e, 0xd4, 0xd8, 0x79,
+ 0x68, 0xda, 0x51, 0x44, 0x1c, 0x93, 0xe7, 0x8a, 0x3c, 0x63, 0x5a, 0xaf, 0xf9, 0x64, 0x3f, 0x3e,
+ 0x0f, 0xf7, 0x78, 0x1c, 0xe7, 0x1c, 0x64, 0x8c, 0x2a, 0x5b, 0xe8, 0x23, 0x03, 0x8a, 0x24, 0x9a,
+ 0x9a, 0x61, 0x12, 0x88, 0x73, 0xa3, 0xb2, 0xfd, 0xe8, 0xee, 0xce, 0x45, 0xd3, 0xc3, 0x24, 0x18,
+ 0x64, 0x8c, 0x02, 0x11, 0x2d, 0x14, 0x40, 0x9d, 0x5a, 0x41, 0xec, 0x63, 0x62, 0xc6, 0x24, 0x72,
+ 0xf9, 0xf7, 0x7e, 0xa3, 0x28, 0xc8, 0x1f, 0xdf, 0x99, 0x7c, 0x9c, 0x12, 0x1d, 0x49, 0x9e, 0x41,
+ 0xc6, 0x58, 0xa3, 0xcb, 0x43, 0xcd, 0x11, 0xc0, 0x7c, 0xf3, 0xd0, 0xee, 0xb5, 0x6c, 0xe0, 0x19,
+ 0x7b, 0xff, 0x35, 0xae, 0xcc, 0x20, 0xea, 0x7c, 0x98, 0x6d, 0x79, 0xf3, 0x97, 0x50, 0x9e, 0xd9,
+ 0x8e, 0xc6, 0xb0, 0x66, 0x47, 0xbe, 0x8f, 0x6d, 0x26, 0xef, 0x66, 0xea, 0x94, 0x5c, 0x2c, 0x8f,
+ 0xfc, 0x26, 0xd7, 0x96, 0x37, 0xb9, 0xb6, 0x21, 0x6f, 0x72, 0x0b, 0x47, 0x61, 0x6d, 0x46, 0xc1,
+ 0x07, 0x69, 0x73, 0x0a, 0x85, 0xd4, 0x35, 0xf4, 0x03, 0x28, 0x53, 0x1c, 0x3a, 0x98, 0xa8, 0x82,
+ 0x56, 0xee, 0xd6, 0x67, 0xb5, 0x49, 0x4c, 0x88, 0x7a, 0x94, 0xb6, 0x1c, 0x7e, 0x19, 0x51, 0xdb,
+ 0x95, 0x5d, 0x3c, 0x13, 0xa4, 0xf3, 0x2d, 0x28, 0xf9, 0x16, 0x65, 0x66, 0x40, 0x5d, 0x91, 0x71,
+ 0xea, 0x33, 0xa0, 0xc8, 0x47, 0x9f, 0x52, 0xb7, 0xf9, 0x13, 0x58, 0xbb, 0xe6, 0x28, 0xfa, 0x3e,
+ 0xd4, 0x78, 0x59, 0xe1, 0x5b, 0x65, 0x63, 0x4a, 0x71, 0x2a, 0x23, 0x2f, 0x91, 0xab, 0x7c, 0xee,
+ 0x48, 0x4d, 0x75, 0x8b, 0xb0, 0xf2, 0xd2, 0xf2, 0x13, 0xfc, 0x41, 0xbe, 0x54, 0xa8, 0x17, 0xf5,
+ 0xdf, 0x6b, 0xd0, 0xe8, 0x79, 0x94, 0x8d, 0x7f, 0x7a, 0xf0, 0xb3, 0xf4, 0xd6, 0xb6, 0x1f, 0x51,
+ 0xea, 0xc5, 0xe2, 0xcd, 0x79, 0xb0, 0x7c, 0xbf, 0x5b, 0xed, 0xde, 0xe3, 0x8c, 0x9f, 0x5f, 0xb6,
+ 0x6a, 0xcb, 0x90, 0xf9, 0x8d, 0x6f, 0x00, 0x6f, 0x05, 0x5e, 0x68, 0x5a, 0xb6, 0x8d, 0x63, 0x6e,
+ 0xb7, 0x82, 0x67, 0xbf, 0x10, 0x8e, 0x02, 0x2f, 0xdc, 0x95, 0x10, 0x39, 0xa6, 0x3f, 0x82, 0x6f,
+ 0xc8, 0xa8, 0x1e, 0xb1, 0xbc, 0xd0, 0x0b, 0x5d, 0x21, 0x69, 0x13, 0x4a, 0x8e, 0xec, 0x0b, 0x4d,
+ 0xca, 0x9f, 0xd9, 0x68, 0xf7, 0xed, 0x57, 0xff, 0xdc, 0xc8, 0xbc, 0xba, 0xda, 0xd0, 0xfe, 0x76,
+ 0xb5, 0xa1, 0x7d, 0x76, 0xb5, 0xa1, 0xfd, 0xe3, 0x6a, 0x43, 0xfb, 0xed, 0xbf, 0x36, 0x32, 0x1f,
+ 0x95, 0x67, 0xff, 0x93, 0xf8, 0x7f, 0x00, 0x00, 0x00, 0xff, 0xff, 0x4c, 0x84, 0x45, 0xde, 0xa3,
+ 0x10, 0x00, 0x00,
}
diff --git a/pkg/sql/distsqlpb/data.proto b/pkg/sql/distsqlpb/data.proto
index 8925ad4483a3..bd48b207f905 100644
--- a/pkg/sql/distsqlpb/data.proto
+++ b/pkg/sql/distsqlpb/data.proto
@@ -130,7 +130,7 @@ message InputSyncSpec {
repeated StreamEndpointSpec streams = 3 [(gogoproto.nullable) = false];
// Schema for the streams entering this synchronizer.
- repeated bytes column_types = 4 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/sem/types.T"];
+ repeated bytes column_types = 4 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/types.T"];
}
// OutputRouterSpec is the specification for the output router of a processor;
@@ -194,7 +194,7 @@ message OutputRouterSpec {
message DatumInfo {
optional sqlbase.DatumEncoding encoding = 1 [(gogoproto.nullable) = false];
- optional bytes type = 2 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/sem/types.T"];
+ optional bytes type = 2 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/types.T"];
}
// ProducerHeader is a message that is sent once at the beginning of a stream.
diff --git a/pkg/sql/distsqlpb/processors.pb.go b/pkg/sql/distsqlpb/processors.pb.go
index e9df990ff10a..6683bb08bca6 100644
--- a/pkg/sql/distsqlpb/processors.pb.go
+++ b/pkg/sql/distsqlpb/processors.pb.go
@@ -20,7 +20,7 @@ import hlc "github.com/cockroachdb/cockroach/pkg/util/hlc"
import time "time"
import github_com_cockroachdb_cockroach_pkg_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
import github_com_cockroachdb_cockroach_pkg_sql_sqlbase "github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
-import github_com_cockroachdb_cockroach_pkg_sql_sem_types "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import github_com_cockroachdb_cockroach_pkg_sql_types "github.com/cockroachdb/cockroach/pkg/sql/types"
import github_com_gogo_protobuf_sortkeys "github.com/gogo/protobuf/sortkeys"
import encoding_binary "encoding/binary"
@@ -74,7 +74,7 @@ func (x *ScanVisibility) UnmarshalJSON(data []byte) error {
return nil
}
func (ScanVisibility) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{0}
}
type SketchType int32
@@ -110,7 +110,7 @@ func (x *SketchType) UnmarshalJSON(data []byte) error {
return nil
}
func (SketchType) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{1}
+ return fileDescriptor_processors_763502ebe68123bf, []int{1}
}
// These mirror the aggregate functions supported by sql/parser. See
@@ -206,7 +206,7 @@ func (x *AggregatorSpec_Func) UnmarshalJSON(data []byte) error {
return nil
}
func (AggregatorSpec_Func) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{17, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{17, 0}
}
type AggregatorSpec_Type int32
@@ -252,7 +252,7 @@ func (x *AggregatorSpec_Type) UnmarshalJSON(data []byte) error {
return nil
}
func (AggregatorSpec_Type) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{17, 1}
+ return fileDescriptor_processors_763502ebe68123bf, []int{17, 1}
}
type BackfillerSpec_Type int32
@@ -291,7 +291,7 @@ func (x *BackfillerSpec_Type) UnmarshalJSON(data []byte) error {
return nil
}
func (BackfillerSpec_Type) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{18, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{18, 0}
}
type WindowerSpec_WindowFunc int32
@@ -355,7 +355,7 @@ func (x *WindowerSpec_WindowFunc) UnmarshalJSON(data []byte) error {
return nil
}
func (WindowerSpec_WindowFunc) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 0}
}
// Mode indicates which mode of framing is used.
@@ -399,7 +399,7 @@ func (x *WindowerSpec_Frame_Mode) UnmarshalJSON(data []byte) error {
return nil
}
func (WindowerSpec_Frame_Mode) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 1, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 1, 0}
}
// BoundType indicates which type of boundary is used.
@@ -446,7 +446,7 @@ func (x *WindowerSpec_Frame_BoundType) UnmarshalJSON(data []byte) error {
return nil
}
func (WindowerSpec_Frame_BoundType) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 1, 1}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 1, 1}
}
// Each processor has the following components:
@@ -495,7 +495,7 @@ func (m *ProcessorSpec) Reset() { *m = ProcessorSpec{} }
func (m *ProcessorSpec) String() string { return proto.CompactTextString(m) }
func (*ProcessorSpec) ProtoMessage() {}
func (*ProcessorSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{0}
}
func (m *ProcessorSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -556,7 +556,7 @@ func (m *PostProcessSpec) Reset() { *m = PostProcessSpec{} }
func (m *PostProcessSpec) String() string { return proto.CompactTextString(m) }
func (*PostProcessSpec) ProtoMessage() {}
func (*PostProcessSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{1}
+ return fileDescriptor_processors_763502ebe68123bf, []int{1}
}
func (m *PostProcessSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -614,7 +614,7 @@ func (m *ProcessorCoreUnion) Reset() { *m = ProcessorCoreUnion{} }
func (m *ProcessorCoreUnion) String() string { return proto.CompactTextString(m) }
func (*ProcessorCoreUnion) ProtoMessage() {}
func (*ProcessorCoreUnion) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{2}
+ return fileDescriptor_processors_763502ebe68123bf, []int{2}
}
func (m *ProcessorCoreUnion) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -651,7 +651,7 @@ func (m *NoopCoreSpec) Reset() { *m = NoopCoreSpec{} }
func (m *NoopCoreSpec) String() string { return proto.CompactTextString(m) }
func (*NoopCoreSpec) ProtoMessage() {}
func (*NoopCoreSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{3}
+ return fileDescriptor_processors_763502ebe68123bf, []int{3}
}
func (m *NoopCoreSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -686,7 +686,7 @@ func (m *MetadataTestSenderSpec) Reset() { *m = MetadataTestSenderSpec{}
func (m *MetadataTestSenderSpec) String() string { return proto.CompactTextString(m) }
func (*MetadataTestSenderSpec) ProtoMessage() {}
func (*MetadataTestSenderSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{4}
+ return fileDescriptor_processors_763502ebe68123bf, []int{4}
}
func (m *MetadataTestSenderSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -721,7 +721,7 @@ func (m *MetadataTestReceiverSpec) Reset() { *m = MetadataTestReceiverSp
func (m *MetadataTestReceiverSpec) String() string { return proto.CompactTextString(m) }
func (*MetadataTestReceiverSpec) ProtoMessage() {}
func (*MetadataTestReceiverSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{5}
+ return fileDescriptor_processors_763502ebe68123bf, []int{5}
}
func (m *MetadataTestReceiverSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -765,7 +765,7 @@ func (m *ValuesCoreSpec) Reset() { *m = ValuesCoreSpec{} }
func (m *ValuesCoreSpec) String() string { return proto.CompactTextString(m) }
func (*ValuesCoreSpec) ProtoMessage() {}
func (*ValuesCoreSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{6}
+ return fileDescriptor_processors_763502ebe68123bf, []int{6}
}
func (m *ValuesCoreSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -803,7 +803,7 @@ func (m *TableReaderSpan) Reset() { *m = TableReaderSpan{} }
func (m *TableReaderSpan) String() string { return proto.CompactTextString(m) }
func (*TableReaderSpan) ProtoMessage() {}
func (*TableReaderSpan) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{7}
+ return fileDescriptor_processors_763502ebe68123bf, []int{7}
}
func (m *TableReaderSpan) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -873,7 +873,7 @@ func (m *TableReaderSpec) Reset() { *m = TableReaderSpec{} }
func (m *TableReaderSpec) String() string { return proto.CompactTextString(m) }
func (*TableReaderSpec) ProtoMessage() {}
func (*TableReaderSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{8}
+ return fileDescriptor_processors_763502ebe68123bf, []int{8}
}
func (m *TableReaderSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -958,7 +958,7 @@ func (m *JoinReaderSpec) Reset() { *m = JoinReaderSpec{} }
func (m *JoinReaderSpec) String() string { return proto.CompactTextString(m) }
func (*JoinReaderSpec) ProtoMessage() {}
func (*JoinReaderSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{9}
+ return fileDescriptor_processors_763502ebe68123bf, []int{9}
}
func (m *JoinReaderSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1004,7 +1004,7 @@ func (m *SorterSpec) Reset() { *m = SorterSpec{} }
func (m *SorterSpec) String() string { return proto.CompactTextString(m) }
func (*SorterSpec) ProtoMessage() {}
func (*SorterSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{10}
+ return fileDescriptor_processors_763502ebe68123bf, []int{10}
}
func (m *SorterSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1050,7 +1050,7 @@ func (m *DistinctSpec) Reset() { *m = DistinctSpec{} }
func (m *DistinctSpec) String() string { return proto.CompactTextString(m) }
func (*DistinctSpec) ProtoMessage() {}
func (*DistinctSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{11}
+ return fileDescriptor_processors_763502ebe68123bf, []int{11}
}
func (m *DistinctSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1108,7 +1108,7 @@ func (m *ZigzagJoinerSpec) Reset() { *m = ZigzagJoinerSpec{} }
func (m *ZigzagJoinerSpec) String() string { return proto.CompactTextString(m) }
func (*ZigzagJoinerSpec) ProtoMessage() {}
func (*ZigzagJoinerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{12}
+ return fileDescriptor_processors_763502ebe68123bf, []int{12}
}
func (m *ZigzagJoinerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1152,7 +1152,7 @@ func (m *LocalPlanNodeSpec) Reset() { *m = LocalPlanNodeSpec{} }
func (m *LocalPlanNodeSpec) String() string { return proto.CompactTextString(m) }
func (*LocalPlanNodeSpec) ProtoMessage() {}
func (*LocalPlanNodeSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{13}
+ return fileDescriptor_processors_763502ebe68123bf, []int{13}
}
func (m *LocalPlanNodeSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1187,7 +1187,7 @@ func (m *Columns) Reset() { *m = Columns{} }
func (m *Columns) String() string { return proto.CompactTextString(m) }
func (*Columns) ProtoMessage() {}
func (*Columns) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{14}
+ return fileDescriptor_processors_763502ebe68123bf, []int{14}
}
func (m *Columns) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1257,7 +1257,7 @@ func (m *MergeJoinerSpec) Reset() { *m = MergeJoinerSpec{} }
func (m *MergeJoinerSpec) String() string { return proto.CompactTextString(m) }
func (*MergeJoinerSpec) ProtoMessage() {}
func (*MergeJoinerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{15}
+ return fileDescriptor_processors_763502ebe68123bf, []int{15}
}
func (m *MergeJoinerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1346,7 +1346,7 @@ func (m *HashJoinerSpec) Reset() { *m = HashJoinerSpec{} }
func (m *HashJoinerSpec) String() string { return proto.CompactTextString(m) }
func (*HashJoinerSpec) ProtoMessage() {}
func (*HashJoinerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{16}
+ return fileDescriptor_processors_763502ebe68123bf, []int{16}
}
func (m *HashJoinerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1394,7 +1394,7 @@ func (m *AggregatorSpec) Reset() { *m = AggregatorSpec{} }
func (m *AggregatorSpec) String() string { return proto.CompactTextString(m) }
func (*AggregatorSpec) ProtoMessage() {}
func (*AggregatorSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{17}
+ return fileDescriptor_processors_763502ebe68123bf, []int{17}
}
func (m *AggregatorSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1447,7 +1447,7 @@ func (m *AggregatorSpec_Aggregation) Reset() { *m = AggregatorSpec_Aggre
func (m *AggregatorSpec_Aggregation) String() string { return proto.CompactTextString(m) }
func (*AggregatorSpec_Aggregation) ProtoMessage() {}
func (*AggregatorSpec_Aggregation) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{17, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{17, 0}
}
func (m *AggregatorSpec_Aggregation) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1507,7 +1507,7 @@ func (m *BackfillerSpec) Reset() { *m = BackfillerSpec{} }
func (m *BackfillerSpec) String() string { return proto.CompactTextString(m) }
func (*BackfillerSpec) ProtoMessage() {}
func (*BackfillerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{18}
+ return fileDescriptor_processors_763502ebe68123bf, []int{18}
}
func (m *BackfillerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1547,7 +1547,7 @@ func (m *FlowSpec) Reset() { *m = FlowSpec{} }
func (m *FlowSpec) String() string { return proto.CompactTextString(m) }
func (*FlowSpec) ProtoMessage() {}
func (*FlowSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{19}
+ return fileDescriptor_processors_763502ebe68123bf, []int{19}
}
func (m *FlowSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1589,7 +1589,7 @@ func (m *JobProgress) Reset() { *m = JobProgress{} }
func (m *JobProgress) String() string { return proto.CompactTextString(m) }
func (*JobProgress) ProtoMessage() {}
func (*JobProgress) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{20}
+ return fileDescriptor_processors_763502ebe68123bf, []int{20}
}
func (m *JobProgress) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1649,7 +1649,7 @@ func (m *ReadImportDataSpec) Reset() { *m = ReadImportDataSpec{} }
func (m *ReadImportDataSpec) String() string { return proto.CompactTextString(m) }
func (*ReadImportDataSpec) ProtoMessage() {}
func (*ReadImportDataSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{21}
+ return fileDescriptor_processors_763502ebe68123bf, []int{21}
}
func (m *ReadImportDataSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1696,7 +1696,7 @@ func (m *SSTWriterSpec) Reset() { *m = SSTWriterSpec{} }
func (m *SSTWriterSpec) String() string { return proto.CompactTextString(m) }
func (*SSTWriterSpec) ProtoMessage() {}
func (*SSTWriterSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{22}
+ return fileDescriptor_processors_763502ebe68123bf, []int{22}
}
func (m *SSTWriterSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1734,7 +1734,7 @@ func (m *SSTWriterSpec_SpanName) Reset() { *m = SSTWriterSpec_SpanName{}
func (m *SSTWriterSpec_SpanName) String() string { return proto.CompactTextString(m) }
func (*SSTWriterSpec_SpanName) ProtoMessage() {}
func (*SSTWriterSpec_SpanName) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{22, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{22, 0}
}
func (m *SSTWriterSpec_SpanName) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1778,7 +1778,7 @@ func (m *CSVWriterSpec) Reset() { *m = CSVWriterSpec{} }
func (m *CSVWriterSpec) String() string { return proto.CompactTextString(m) }
func (*CSVWriterSpec) ProtoMessage() {}
func (*CSVWriterSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{23}
+ return fileDescriptor_processors_763502ebe68123bf, []int{23}
}
func (m *CSVWriterSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1825,7 +1825,7 @@ func (m *SketchSpec) Reset() { *m = SketchSpec{} }
func (m *SketchSpec) String() string { return proto.CompactTextString(m) }
func (*SketchSpec) ProtoMessage() {}
func (*SketchSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{24}
+ return fileDescriptor_processors_763502ebe68123bf, []int{24}
}
func (m *SketchSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1901,7 +1901,7 @@ func (m *SamplerSpec) Reset() { *m = SamplerSpec{} }
func (m *SamplerSpec) String() string { return proto.CompactTextString(m) }
func (*SamplerSpec) ProtoMessage() {}
func (*SamplerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{25}
+ return fileDescriptor_processors_763502ebe68123bf, []int{25}
}
func (m *SamplerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1964,7 +1964,7 @@ func (m *SampleAggregatorSpec) Reset() { *m = SampleAggregatorSpec{} }
func (m *SampleAggregatorSpec) String() string { return proto.CompactTextString(m) }
func (*SampleAggregatorSpec) ProtoMessage() {}
func (*SampleAggregatorSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{26}
+ return fileDescriptor_processors_763502ebe68123bf, []int{26}
}
func (m *SampleAggregatorSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2029,7 +2029,7 @@ func (m *InterleavedReaderJoinerSpec) Reset() { *m = InterleavedReaderJo
func (m *InterleavedReaderJoinerSpec) String() string { return proto.CompactTextString(m) }
func (*InterleavedReaderJoinerSpec) ProtoMessage() {}
func (*InterleavedReaderJoinerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{27}
+ return fileDescriptor_processors_763502ebe68123bf, []int{27}
}
func (m *InterleavedReaderJoinerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2087,7 +2087,7 @@ func (m *InterleavedReaderJoinerSpec_Table) Reset() { *m = InterleavedRe
func (m *InterleavedReaderJoinerSpec_Table) String() string { return proto.CompactTextString(m) }
func (*InterleavedReaderJoinerSpec_Table) ProtoMessage() {}
func (*InterleavedReaderJoinerSpec_Table) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{27, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{27, 0}
}
func (m *InterleavedReaderJoinerSpec_Table) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2118,7 +2118,7 @@ type ProjectSetSpec struct {
// Expressions to be applied
Exprs []Expression `protobuf:"bytes,1,rep,name=exprs" json:"exprs"`
// Column types for the generated values
- GeneratedColumns []github_com_cockroachdb_cockroach_pkg_sql_sem_types.T `protobuf:"bytes,2,rep,name=generated_columns,json=generatedColumns,customtype=github.com/cockroachdb/cockroach/pkg/sql/sem/types.T" json:"generated_columns"`
+ GeneratedColumns []github_com_cockroachdb_cockroach_pkg_sql_types.T `protobuf:"bytes,2,rep,name=generated_columns,json=generatedColumns,customtype=github.com/cockroachdb/cockroach/pkg/sql/types.T" json:"generated_columns"`
// The number of columns each expression returns. Same length as exprs.
NumColsPerGen []uint32 `protobuf:"varint,3,rep,name=num_cols_per_gen,json=numColsPerGen" json:"num_cols_per_gen,omitempty"`
XXX_NoUnkeyedLiteral struct{} `json:"-"`
@@ -2129,7 +2129,7 @@ func (m *ProjectSetSpec) Reset() { *m = ProjectSetSpec{} }
func (m *ProjectSetSpec) String() string { return proto.CompactTextString(m) }
func (*ProjectSetSpec) ProtoMessage() {}
func (*ProjectSetSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{28}
+ return fileDescriptor_processors_763502ebe68123bf, []int{28}
}
func (m *ProjectSetSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2173,7 +2173,7 @@ func (m *WindowerSpec) Reset() { *m = WindowerSpec{} }
func (m *WindowerSpec) String() string { return proto.CompactTextString(m) }
func (*WindowerSpec) ProtoMessage() {}
func (*WindowerSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29}
}
func (m *WindowerSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2211,7 +2211,7 @@ func (m *WindowerSpec_Func) Reset() { *m = WindowerSpec_Func{} }
func (m *WindowerSpec_Func) String() string { return proto.CompactTextString(m) }
func (*WindowerSpec_Func) ProtoMessage() {}
func (*WindowerSpec_Func) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 0}
}
func (m *WindowerSpec_Func) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2248,7 +2248,7 @@ func (m *WindowerSpec_Frame) Reset() { *m = WindowerSpec_Frame{} }
func (m *WindowerSpec_Frame) String() string { return proto.CompactTextString(m) }
func (*WindowerSpec_Frame) ProtoMessage() {}
func (*WindowerSpec_Frame) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 1}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 1}
}
func (m *WindowerSpec_Frame) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2290,7 +2290,7 @@ func (m *WindowerSpec_Frame_Bound) Reset() { *m = WindowerSpec_Frame_Bou
func (m *WindowerSpec_Frame_Bound) String() string { return proto.CompactTextString(m) }
func (*WindowerSpec_Frame_Bound) ProtoMessage() {}
func (*WindowerSpec_Frame_Bound) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 1, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 1, 0}
}
func (m *WindowerSpec_Frame_Bound) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2328,7 +2328,7 @@ func (m *WindowerSpec_Frame_Bounds) Reset() { *m = WindowerSpec_Frame_Bo
func (m *WindowerSpec_Frame_Bounds) String() string { return proto.CompactTextString(m) }
func (*WindowerSpec_Frame_Bounds) ProtoMessage() {}
func (*WindowerSpec_Frame_Bounds) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 1, 1}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 1, 1}
}
func (m *WindowerSpec_Frame_Bounds) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2378,7 +2378,7 @@ func (m *WindowerSpec_WindowFn) Reset() { *m = WindowerSpec_WindowFn{} }
func (m *WindowerSpec_WindowFn) String() string { return proto.CompactTextString(m) }
func (*WindowerSpec_WindowFn) ProtoMessage() {}
func (*WindowerSpec_WindowFn) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{29, 2}
+ return fileDescriptor_processors_763502ebe68123bf, []int{29, 2}
}
func (m *WindowerSpec_WindowFn) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2417,7 +2417,7 @@ func (m *ChangeAggregatorSpec) Reset() { *m = ChangeAggregatorSpec{} }
func (m *ChangeAggregatorSpec) String() string { return proto.CompactTextString(m) }
func (*ChangeAggregatorSpec) ProtoMessage() {}
func (*ChangeAggregatorSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{30}
+ return fileDescriptor_processors_763502ebe68123bf, []int{30}
}
func (m *ChangeAggregatorSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2453,7 +2453,7 @@ func (m *ChangeAggregatorSpec_Watch) Reset() { *m = ChangeAggregatorSpec
func (m *ChangeAggregatorSpec_Watch) String() string { return proto.CompactTextString(m) }
func (*ChangeAggregatorSpec_Watch) ProtoMessage() {}
func (*ChangeAggregatorSpec_Watch) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{30, 0}
+ return fileDescriptor_processors_763502ebe68123bf, []int{30, 0}
}
func (m *ChangeAggregatorSpec_Watch) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2498,7 +2498,7 @@ func (m *ChangeFrontierSpec) Reset() { *m = ChangeFrontierSpec{} }
func (m *ChangeFrontierSpec) String() string { return proto.CompactTextString(m) }
func (*ChangeFrontierSpec) ProtoMessage() {}
func (*ChangeFrontierSpec) Descriptor() ([]byte, []int) {
- return fileDescriptor_processors_5b8d14d41ff9522f, []int{31}
+ return fileDescriptor_processors_763502ebe68123bf, []int{31}
}
func (m *ChangeFrontierSpec) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -12039,7 +12039,7 @@ func (m *ProjectSetSpec) Unmarshal(dAtA []byte) error {
if postIndex > l {
return io.ErrUnexpectedEOF
}
- var v github_com_cockroachdb_cockroach_pkg_sql_sem_types.T
+ var v github_com_cockroachdb_cockroach_pkg_sql_types.T
m.GeneratedColumns = append(m.GeneratedColumns, v)
if err := m.GeneratedColumns[len(m.GeneratedColumns)-1].Unmarshal(dAtA[iNdEx:postIndex]); err != nil {
return err
@@ -13401,269 +13401,268 @@ var (
)
func init() {
- proto.RegisterFile("sql/distsqlpb/processors.proto", fileDescriptor_processors_5b8d14d41ff9522f)
-}
-
-var fileDescriptor_processors_5b8d14d41ff9522f = []byte{
- // 4147 bytes of a gzipped FileDescriptorProto
- 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xc4, 0x5b, 0x4d, 0x8c, 0x1b, 0x47,
- 0x76, 0x16, 0xc9, 0xe6, 0xdf, 0xe3, 0xcf, 0xb4, 0x4a, 0x63, 0x8b, 0x1e, 0x3b, 0x1a, 0x89, 0xf6,
- 0x5a, 0x3f, 0xab, 0x9d, 0xb1, 0x64, 0xaf, 0x63, 0x7b, 0xbd, 0xb0, 0xf9, 0x3b, 0xea, 0x11, 0x87,
- 0x1c, 0x35, 0x39, 0xa3, 0xb5, 0x0f, 0xe9, 0x34, 0xd9, 0x35, 0x9c, 0xd6, 0x34, 0xbb, 0xa8, 0xee,
- 0xa6, 0x66, 0x46, 0x97, 0x9c, 0x82, 0x00, 0x39, 0xe4, 0x07, 0xb9, 0x06, 0xc1, 0x5e, 0xf6, 0x9a,
- 0x00, 0x41, 0x0e, 0x39, 0x05, 0x09, 0x10, 0x04, 0x46, 0x2e, 0xc9, 0x31, 0x08, 0x02, 0x21, 0xd1,
- 0x02, 0xc9, 0x2d, 0xd7, 0x00, 0x3e, 0x24, 0x41, 0xfd, 0x35, 0x9b, 0xf3, 0x4f, 0x49, 0xd8, 0xbd,
- 0x8c, 0xd8, 0xf5, 0xde, 0xfb, 0xaa, 0xea, 0xd5, 0xab, 0x57, 0xef, 0xbd, 0x2a, 0xc1, 0x35, 0xff,
- 0xa9, 0xb3, 0x6a, 0xd9, 0x7e, 0xe0, 0x3f, 0x75, 0xc6, 0xfd, 0xd5, 0xb1, 0x47, 0x06, 0xd8, 0xf7,
- 0x89, 0xe7, 0xaf, 0x8c, 0x3d, 0x12, 0x10, 0x54, 0x1a, 0x90, 0xc1, 0x9e, 0x47, 0xcc, 0xc1, 0xee,
- 0x8a, 0xff, 0xd4, 0x59, 0x11, 0x9c, 0xde, 0xc4, 0x5d, 0x7a, 0xfb, 0x09, 0xe9, 0xfb, 0xab, 0xf4,
- 0xcf, 0xb8, 0xcf, 0xfe, 0xe1, 0x12, 0x4b, 0x88, 0x71, 0x8f, 0xfb, 0xab, 0x96, 0x19, 0x98, 0xa2,
- 0xad, 0x24, 0xdb, 0x6c, 0xf2, 0xa3, 0x1d, 0xe2, 0x8d, 0xcc, 0x40, 0x72, 0xbf, 0x47, 0xfb, 0xf7,
- 0x9f, 0x3a, 0x7d, 0xd3, 0xc7, 0xab, 0x7e, 0xe0, 0x4d, 0x06, 0xc1, 0xc4, 0xc3, 0x96, 0xa0, 0xbe,
- 0x1b, 0xa5, 0x3e, 0x21, 0xb6, 0x6b, 0x04, 0x87, 0x63, 0x2c, 0x41, 0x67, 0x87, 0x1e, 0xed, 0x6e,
- 0x12, 0xd8, 0xce, 0xea, 0xae, 0x33, 0x58, 0x0d, 0xec, 0x11, 0xf6, 0x03, 0x73, 0x34, 0x16, 0x94,
- 0xc5, 0x21, 0x19, 0x12, 0xf6, 0x73, 0x95, 0xfe, 0xe2, 0xad, 0xe5, 0x3f, 0x4c, 0x40, 0x61, 0x53,
- 0xce, 0xbc, 0x3b, 0xc6, 0x03, 0x54, 0x83, 0xa4, 0xed, 0x8e, 0x27, 0x41, 0x29, 0x76, 0x3d, 0x71,
- 0x2b, 0x77, 0xff, 0xe6, 0xca, 0x69, 0x6a, 0x58, 0xd1, 0x28, 0x5b, 0xf7, 0xd0, 0x1d, 0x50, 0xb9,
- 0xaa, 0xf2, 0xdd, 0x8b, 0xe5, 0x4b, 0x3a, 0x97, 0x45, 0x4d, 0x50, 0x06, 0xc4, 0xc3, 0xa5, 0xf8,
- 0xf5, 0xd8, 0xad, 0xdc, 0xfd, 0xbb, 0xa7, 0x63, 0x84, 0x7d, 0xd7, 0x88, 0x87, 0xb7, 0x5c, 0x9b,
- 0xb8, 0x02, 0x88, 0xc9, 0xa3, 0x07, 0x90, 0x22, 0x93, 0x80, 0x8e, 0x26, 0xc1, 0x46, 0x73, 0xe7,
- 0x74, 0xa4, 0x0e, 0xe3, 0xd3, 0xc9, 0x24, 0xc0, 0x5e, 0x64, 0x40, 0x42, 0x1e, 0xd5, 0x40, 0x19,
- 0x13, 0x3f, 0x28, 0x29, 0x6c, 0x44, 0xb7, 0xcf, 0x18, 0x11, 0xf1, 0x03, 0x31, 0xaa, 0x08, 0x0c,
- 0x13, 0x46, 0x77, 0x20, 0xe3, 0x07, 0xe6, 0x10, 0x1b, 0xb6, 0x55, 0x4a, 0x5e, 0x8f, 0xdd, 0x4a,
- 0x56, 0x17, 0x28, 0xf5, 0xe5, 0x8b, 0xe5, 0x74, 0x97, 0xb6, 0x6b, 0x75, 0x3d, 0xcd, 0x18, 0x34,
- 0x0b, 0x7d, 0x0a, 0xf9, 0xd0, 0xa4, 0x28, 0x7f, 0x8a, 0xf1, 0x5f, 0x11, 0xfc, 0xb9, 0x70, 0xe2,
- 0x5a, 0x5d, 0xcf, 0x85, 0x8c, 0x9a, 0x55, 0xfe, 0x8b, 0x38, 0x2c, 0x1c, 0x19, 0x03, 0xaa, 0x42,
- 0x6a, 0xc7, 0x76, 0x02, 0xec, 0x95, 0x62, 0x6c, 0xf8, 0x1f, 0x9c, 0x3e, 0xfc, 0xc6, 0xc1, 0xd8,
- 0xc3, 0xbe, 0x3f, 0x55, 0xa4, 0x90, 0x44, 0x1f, 0x00, 0x8c, 0x3d, 0xf2, 0x04, 0x0f, 0x02, 0x9b,
- 0xb8, 0x6c, 0x61, 0x32, 0x82, 0x23, 0xd2, 0x8e, 0x6e, 0x43, 0x91, 0x2b, 0xcc, 0x18, 0x10, 0x67,
- 0x32, 0x72, 0x7d, 0xa6, 0xf8, 0x42, 0x35, 0xae, 0xc6, 0xf4, 0x02, 0xa7, 0xd4, 0x38, 0x01, 0x6d,
- 0x40, 0xde, 0xc3, 0xae, 0x85, 0x3d, 0x03, 0x1f, 0x8c, 0x3d, 0xbf, 0xa4, 0xb0, 0x15, 0x9a, 0x67,
- 0x68, 0x39, 0x2e, 0x4f, 0xdb, 0x7d, 0xf4, 0x1e, 0xa4, 0xc8, 0xce, 0x8e, 0x8f, 0x03, 0xa6, 0x59,
- 0x25, 0x5c, 0x3e, 0xd6, 0x86, 0x96, 0x20, 0xe9, 0xd8, 0x23, 0x3b, 0x60, 0x6a, 0x94, 0x44, 0xde,
- 0x54, 0xfe, 0xbf, 0x22, 0xa0, 0xe3, 0x76, 0x84, 0xbe, 0x00, 0xc5, 0x25, 0x64, 0x2c, 0x54, 0xf6,
- 0xe1, 0xe9, 0xe3, 0x6a, 0x13, 0x32, 0xa6, 0x62, 0x54, 0xd5, 0x3a, 0x93, 0x41, 0x0f, 0x21, 0x17,
- 0x98, 0x7d, 0x07, 0xeb, 0xd8, 0xb4, 0xb0, 0x27, 0xcc, 0xf8, 0x0c, 0xa3, 0xe9, 0x4d, 0x99, 0x19,
- 0x4a, 0x54, 0x1a, 0x3d, 0x00, 0xa0, 0x1b, 0x58, 0x60, 0x25, 0x18, 0xd6, 0xad, 0xd3, 0xb1, 0xd6,
- 0x43, 0x5e, 0x06, 0x15, 0x91, 0x45, 0x5f, 0x42, 0xca, 0x27, 0x1e, 0xb5, 0x03, 0xe5, 0x3c, 0x3b,
- 0xe8, 0x32, 0x3e, 0x86, 0x20, 0x64, 0xe8, 0x38, 0xcc, 0xe1, 0xd0, 0xc3, 0x43, 0x33, 0x20, 0x1e,
- 0xd3, 0xf2, 0x99, 0xe3, 0xa8, 0x84, 0xbc, 0x7c, 0x1c, 0x53, 0x59, 0x54, 0x85, 0x0c, 0x65, 0xb4,
- 0xdd, 0x41, 0x50, 0x4a, 0x9f, 0xa7, 0xde, 0xba, 0xe0, 0x64, 0x28, 0xa1, 0x1c, 0x55, 0xf1, 0x08,
- 0x7b, 0x43, 0x4c, 0xa7, 0x8b, 0xbd, 0x52, 0xe6, 0x3c, 0x15, 0x6f, 0x4c, 0x99, 0xb9, 0x8a, 0x23,
- 0xd2, 0x74, 0x6a, 0xbb, 0xa6, 0xbf, 0x2b, 0xb0, 0xb2, 0xe7, 0x4d, 0xed, 0x41, 0xc8, 0xcb, 0xa7,
- 0x36, 0x95, 0x45, 0x5f, 0x43, 0xea, 0x99, 0xe9, 0x4c, 0xb0, 0x5f, 0x82, 0xf3, 0x50, 0xb6, 0x19,
- 0x5f, 0x68, 0x39, 0x42, 0x8e, 0x8e, 0xa5, 0x6f, 0x0e, 0xf6, 0x76, 0x6c, 0xc7, 0xc1, 0x5e, 0x29,
- 0x77, 0x1e, 0x4a, 0x35, 0xe4, 0xe5, 0x63, 0x99, 0xca, 0xa2, 0x16, 0x80, 0x87, 0x4d, 0x4b, 0x1b,
- 0x8d, 0x89, 0x17, 0x94, 0x0a, 0xe7, 0xf9, 0x52, 0x3d, 0xe4, 0xad, 0x9b, 0x81, 0xc9, 0xd1, 0xa6,
- 0xf2, 0xa8, 0x01, 0xd9, 0x6e, 0xb7, 0xf7, 0xd8, 0xb3, 0xa9, 0xfd, 0x14, 0x19, 0xd8, 0x19, 0xce,
- 0x3d, 0x64, 0x65, 0x38, 0x53, 0x49, 0xf4, 0x15, 0xa4, 0xbb, 0xe6, 0x68, 0x4c, 0xe7, 0xb6, 0xc0,
- 0x40, 0x7e, 0x70, 0x06, 0x08, 0x67, 0x64, 0x10, 0x52, 0x0a, 0x7d, 0x0b, 0x2a, 0xff, 0x39, 0x35,
- 0xb0, 0x92, 0xca, 0x90, 0x56, 0xce, 0x43, 0x3a, 0x62, 0x92, 0xc7, 0x70, 0x10, 0x81, 0xab, 0xb6,
- 0x1b, 0x60, 0xcf, 0xc1, 0xe6, 0x33, 0x6c, 0xf1, 0x5d, 0x23, 0x8c, 0xe2, 0x32, 0xeb, 0xe2, 0xc7,
- 0x67, 0x1d, 0x67, 0x27, 0x0a, 0xb2, 0x9e, 0x4e, 0x43, 0x45, 0xbf, 0x0d, 0x68, 0x84, 0x03, 0x93,
- 0x9e, 0xc0, 0x3d, 0xec, 0x07, 0x5d, 0xe6, 0xd0, 0x4a, 0x88, 0xf5, 0xf5, 0xd1, 0x59, 0xc6, 0x7c,
- 0x54, 0x86, 0x75, 0x73, 0x02, 0x16, 0xda, 0x81, 0xc5, 0x68, 0xab, 0x8e, 0x07, 0xd8, 0x7e, 0x86,
- 0xbd, 0xd2, 0x15, 0xd6, 0xc7, 0xfd, 0x8b, 0xf5, 0x21, 0xa5, 0x58, 0x2f, 0x27, 0xe2, 0x51, 0xf3,
- 0xa8, 0x75, 0xb7, 0x85, 0x79, 0x2c, 0x9e, 0x67, 0x1e, 0x21, 0x2b, 0x37, 0x8f, 0xf0, 0x13, 0xb5,
- 0x21, 0xff, 0xdc, 0x1e, 0x3e, 0x37, 0x87, 0x42, 0xed, 0x6f, 0x31, 0xa4, 0x33, 0xce, 0xed, 0x6f,
- 0x23, 0xdc, 0x0c, 0x6c, 0x46, 0x9e, 0xee, 0x26, 0x71, 0x3c, 0x75, 0x71, 0x50, 0x7a, 0xfb, 0xbc,
- 0xdd, 0xb4, 0x19, 0xf2, 0x72, 0xfb, 0x9f, 0xca, 0x52, 0xa7, 0xb5, 0x6f, 0xbb, 0x16, 0xd9, 0xc7,
- 0x5e, 0xe9, 0xea, 0x79, 0x4e, 0xeb, 0xb1, 0xe0, 0xe4, 0x4e, 0x4b, 0xca, 0xa1, 0x47, 0x50, 0x70,
- 0xc8, 0xc0, 0x74, 0x36, 0x1d, 0xd3, 0x6d, 0x13, 0x0b, 0x97, 0x4a, 0x0c, 0xe8, 0x87, 0xa7, 0x03,
- 0xb5, 0xa2, 0xec, 0x0c, 0x6d, 0x16, 0x81, 0x6e, 0x87, 0xc1, 0xae, 0xe9, 0x0e, 0xa3, 0xdb, 0xe1,
- 0x9d, 0xf3, 0xb6, 0x43, 0xed, 0x88, 0x04, 0xdf, 0x0e, 0x47, 0x71, 0x50, 0x0f, 0x8a, 0xbc, 0xad,
- 0xe9, 0x11, 0x37, 0xb0, 0xb1, 0x57, 0x5a, 0x3a, 0xcf, 0x89, 0xd4, 0x66, 0xf8, 0x19, 0xee, 0x11,
- 0x8c, 0x2f, 0x94, 0xef, 0x7e, 0xbe, 0x1c, 0x5b, 0x57, 0x32, 0x29, 0x35, 0xbd, 0xae, 0x64, 0xf2,
- 0x6a, 0xa1, 0x5c, 0x84, 0x7c, 0xf4, 0x10, 0x2d, 0x7f, 0x02, 0x6f, 0x9f, 0x6c, 0xe1, 0x68, 0x09,
- 0xe2, 0xb6, 0xc5, 0x8e, 0xe4, 0x6c, 0x15, 0x44, 0x2c, 0x14, 0xd7, 0xea, 0x7a, 0xdc, 0xb6, 0xca,
- 0x0f, 0xa0, 0x74, 0x9a, 0xcd, 0xa2, 0xbb, 0x00, 0x3e, 0x0f, 0x36, 0x6c, 0xcb, 0x67, 0xa1, 0x69,
- 0xb6, 0x5a, 0x78, 0xf9, 0x62, 0x39, 0xcb, 0xb1, 0xb5, 0xba, 0xaf, 0x67, 0x39, 0x83, 0x66, 0xf9,
- 0xe5, 0x3f, 0x89, 0x41, 0x71, 0xd6, 0x3b, 0xa3, 0x1a, 0xa4, 0x65, 0x44, 0xc3, 0x03, 0xdb, 0xf7,
- 0xcf, 0x38, 0xb1, 0xcc, 0x60, 0x32, 0xd2, 0xdc, 0x1d, 0x22, 0xe2, 0x0c, 0x29, 0x89, 0xde, 0x85,
- 0xac, 0x67, 0xee, 0x1b, 0xfd, 0xc3, 0x00, 0xfb, 0xa5, 0xf8, 0xf5, 0xc4, 0xad, 0xbc, 0x9e, 0xf1,
- 0xcc, 0xfd, 0x2a, 0xfd, 0x46, 0xcb, 0x90, 0x71, 0x27, 0x23, 0xc3, 0x23, 0xfb, 0x3e, 0x3b, 0xe4,
- 0x65, 0x94, 0x92, 0x76, 0x27, 0x23, 0x9d, 0xec, 0xfb, 0xe5, 0x3a, 0x2c, 0xcc, 0xc4, 0x09, 0xa6,
- 0x8b, 0xee, 0x81, 0xe2, 0x8f, 0x4d, 0x57, 0xc4, 0x28, 0x57, 0x23, 0x43, 0x12, 0x69, 0xc3, 0x0a,
- 0x65, 0x93, 0x31, 0x28, 0x65, 0x2d, 0xff, 0x69, 0xe2, 0x08, 0x0c, 0x8b, 0x0f, 0x93, 0x2c, 0xe0,
- 0x38, 0x25, 0xd6, 0x11, 0x69, 0x04, 0x8f, 0x52, 0xea, 0xd8, 0x1f, 0x78, 0xf6, 0x38, 0x20, 0x9e,
- 0x8c, 0xa2, 0x98, 0x28, 0xba, 0x01, 0x59, 0xdb, 0xb5, 0xf0, 0x81, 0x61, 0x5b, 0x07, 0x2c, 0xe0,
- 0x29, 0x08, 0x7a, 0x86, 0x35, 0x6b, 0xd6, 0x01, 0xba, 0x06, 0x69, 0x0f, 0x3f, 0xc3, 0x9e, 0x8f,
- 0xd9, 0x04, 0x65, 0xfc, 0x28, 0x1b, 0x51, 0x03, 0x92, 0x74, 0x88, 0x32, 0x14, 0xbc, 0x68, 0xbc,
- 0x14, 0x4e, 0x90, 0x4b, 0xa3, 0xf7, 0x01, 0x58, 0x60, 0x67, 0xec, 0xda, 0x2e, 0x8f, 0x06, 0x13,
- 0x82, 0x21, 0xcb, 0xda, 0x1f, 0xd8, 0x6e, 0x40, 0xb5, 0x6d, 0xfb, 0xc6, 0x60, 0x17, 0x0f, 0xf6,
- 0x58, 0x4c, 0x18, 0x0e, 0xc6, 0xf6, 0x6b, 0xb4, 0x11, 0xb5, 0x01, 0x9e, 0xd9, 0xbe, 0xdd, 0xb7,
- 0x1d, 0x3b, 0x38, 0x64, 0x51, 0x4a, 0xf1, 0x2c, 0xc7, 0xd1, 0x1d, 0x98, 0xee, 0x76, 0xc8, 0x2f,
- 0x23, 0xe3, 0x29, 0x02, 0xfa, 0x01, 0xe4, 0x46, 0xe6, 0x81, 0xe1, 0x61, 0x7f, 0xe2, 0x04, 0x3e,
- 0x8b, 0x57, 0xe4, 0x0a, 0xc3, 0xc8, 0x3c, 0xd0, 0x79, 0x7b, 0xf9, 0x1f, 0x13, 0x50, 0x9c, 0x8d,
- 0xe0, 0x7e, 0x55, 0xab, 0x73, 0x1b, 0x8a, 0x0e, 0x21, 0x7b, 0x93, 0xf1, 0x49, 0xa1, 0x3b, 0xa7,
- 0xc8, 0xd0, 0xbd, 0x06, 0x69, 0xe2, 0xb2, 0xb0, 0xfd, 0xfc, 0x40, 0xf2, 0x78, 0x42, 0x41, 0x5c,
- 0xda, 0x86, 0xb6, 0xe1, 0x32, 0x1f, 0x12, 0x4f, 0x30, 0x38, 0x5c, 0x72, 0x6e, 0xb8, 0x05, 0x06,
- 0xd2, 0x64, 0x18, 0x0c, 0xf7, 0x73, 0x50, 0x68, 0xaa, 0xcb, 0x56, 0xb5, 0x78, 0x7f, 0xf9, 0x14,
- 0x6d, 0x51, 0x1d, 0xf7, 0x0e, 0xc7, 0x58, 0xee, 0x0d, 0x2a, 0xf2, 0xa6, 0xd7, 0x9c, 0xfa, 0x11,
- 0x98, 0x06, 0xd2, 0xe8, 0x11, 0x2c, 0x88, 0xe4, 0x88, 0x78, 0x16, 0xf6, 0x6c, 0x77, 0x28, 0x96,
- 0xb4, 0x7c, 0x46, 0x5a, 0x2a, 0x38, 0x05, 0xba, 0xc8, 0xae, 0x64, 0x2b, 0xba, 0x0f, 0x48, 0x62,
- 0x19, 0x23, 0x33, 0x18, 0xec, 0x1a, 0x0e, 0x76, 0x67, 0x16, 0x58, 0x95, 0xf4, 0x0d, 0x4a, 0x6e,
- 0x61, 0xb7, 0xdc, 0x87, 0x7c, 0x34, 0xa6, 0x46, 0x37, 0x61, 0x81, 0xf1, 0x60, 0xcb, 0x88, 0xba,
- 0xb8, 0x82, 0x5e, 0x14, 0xcd, 0x72, 0xd9, 0x6f, 0x83, 0x2a, 0xc3, 0xef, 0x90, 0x33, 0xce, 0x38,
- 0x17, 0x64, 0xbb, 0x60, 0x2d, 0xff, 0x41, 0x02, 0xd4, 0xa3, 0x27, 0x33, 0xaa, 0x43, 0x8a, 0x59,
- 0xa3, 0x74, 0xa1, 0xf3, 0x59, 0xb2, 0x90, 0x45, 0x4d, 0x00, 0xfc, 0x74, 0xa6, 0xff, 0xdc, 0xfd,
- 0x1b, 0x67, 0x1c, 0x48, 0x9c, 0x51, 0x7a, 0x00, 0xfc, 0x54, 0xce, 0x66, 0x79, 0xba, 0x25, 0xa2,
- 0xa6, 0x2e, 0x37, 0xc4, 0x1b, 0xb2, 0xf2, 0x87, 0x90, 0xdf, 0xb1, 0x0f, 0xb0, 0x65, 0x88, 0xac,
- 0x20, 0xc9, 0xc6, 0x7b, 0xf1, 0xac, 0x20, 0xc7, 0xa4, 0x79, 0xe3, 0x6b, 0x98, 0x76, 0xd9, 0x86,
- 0xcb, 0xc7, 0x42, 0x09, 0x54, 0x86, 0xbc, 0x4e, 0xf6, 0xbb, 0x64, 0xe2, 0x0d, 0xb0, 0x66, 0x1d,
- 0x30, 0x6b, 0x2c, 0xe8, 0x33, 0x6d, 0xe8, 0x3d, 0xc8, 0xb6, 0xe9, 0x69, 0x36, 0x9e, 0x04, 0x3e,
- 0x37, 0x2c, 0x7d, 0xda, 0x80, 0x10, 0x28, 0x6d, 0x73, 0xc4, 0xfd, 0x79, 0x56, 0x67, 0xbf, 0xcb,
- 0x37, 0x21, 0x2d, 0x75, 0xfc, 0xde, 0xec, 0xa9, 0xc9, 0x35, 0x2c, 0x9b, 0xca, 0xff, 0x16, 0x87,
- 0x85, 0x23, 0x69, 0x19, 0xda, 0x80, 0x82, 0x83, 0x77, 0x5e, 0x63, 0x87, 0xe4, 0xa9, 0x78, 0xb8,
- 0x3f, 0x3a, 0x50, 0xf4, 0xec, 0xe1, 0x6e, 0x04, 0x2f, 0x3e, 0x27, 0x5e, 0x81, 0xc9, 0x87, 0x80,
- 0x11, 0xa3, 0x48, 0xbe, 0xb2, 0x51, 0xbc, 0x86, 0x8b, 0xba, 0x0d, 0x05, 0x77, 0xe2, 0x38, 0x06,
- 0x7e, 0x3a, 0x31, 0x43, 0x2f, 0x25, 0x0f, 0xaf, 0x3c, 0x25, 0x35, 0x04, 0xa5, 0xfc, 0xc7, 0x09,
- 0x28, 0xce, 0x66, 0xaa, 0xe8, 0x0e, 0x2c, 0x30, 0xed, 0x46, 0x36, 0x50, 0x2c, 0xe2, 0xe4, 0xf1,
- 0x4e, 0xd0, 0x08, 0xf7, 0xc7, 0x5d, 0x50, 0xb9, 0xea, 0x8e, 0xec, 0x36, 0xce, 0xcc, 0xd5, 0x3a,
- 0xe5, 0xfe, 0x75, 0xeb, 0xe5, 0x87, 0x50, 0x64, 0x09, 0xfd, 0xd4, 0x87, 0x45, 0x15, 0x53, 0xe0,
- 0x34, 0x39, 0xd8, 0x2f, 0xe0, 0xea, 0x11, 0x35, 0x18, 0xa6, 0x87, 0x8d, 0x3d, 0x7c, 0xc8, 0xce,
- 0x65, 0x29, 0x75, 0x65, 0x46, 0x21, 0x15, 0x0f, 0x3f, 0xc4, 0x87, 0xe8, 0x4b, 0x28, 0x1d, 0x55,
- 0x4b, 0x28, 0x9c, 0x8d, 0x08, 0x2f, 0xce, 0x2a, 0x88, 0x4b, 0x97, 0xff, 0x3b, 0x05, 0xc5, 0xd9,
- 0xb0, 0x1b, 0xdd, 0x00, 0x18, 0x7a, 0x84, 0x1f, 0xbb, 0x51, 0x0d, 0x67, 0x59, 0x6b, 0x8d, 0x38,
- 0x3e, 0xfa, 0x2d, 0xc8, 0xcb, 0xea, 0x89, 0x4d, 0xc4, 0xc1, 0x9c, 0xbb, 0xff, 0xc9, 0x45, 0x6b,
- 0x2f, 0xe1, 0xe7, 0x54, 0xe3, 0x33, 0x78, 0xe8, 0x23, 0x71, 0x8a, 0x60, 0xcb, 0x88, 0x0c, 0x45,
- 0x09, 0x87, 0xa2, 0x0a, 0xea, 0x5a, 0x38, 0xa2, 0x35, 0xb1, 0x52, 0x49, 0xb6, 0x52, 0x3f, 0xba,
- 0xf0, 0x48, 0x8e, 0xae, 0xdb, 0xd2, 0xef, 0xc5, 0x21, 0x17, 0x19, 0x1e, 0x05, 0xde, 0x99, 0xb8,
- 0x03, 0xb6, 0xed, 0xe7, 0x01, 0x6e, 0x4e, 0xdc, 0xb0, 0xd6, 0x4a, 0x01, 0xd0, 0xf5, 0x48, 0x8d,
- 0x29, 0x5a, 0xad, 0x9c, 0x56, 0x90, 0x3e, 0x80, 0xa2, 0x08, 0x3d, 0x06, 0xc4, 0x61, 0x81, 0x91,
- 0xc2, 0xfd, 0x1f, 0x6f, 0xad, 0x11, 0x87, 0xfa, 0xbf, 0xab, 0xcc, 0x85, 0x31, 0x72, 0x92, 0x9d,
- 0x75, 0xa9, 0x01, 0x27, 0x3c, 0x80, 0xac, 0xe9, 0x0d, 0x27, 0x23, 0xec, 0x06, 0x7e, 0x29, 0x35,
- 0x77, 0xf1, 0x72, 0x2a, 0xbc, 0xae, 0x64, 0x12, 0xaa, 0x52, 0xfe, 0x45, 0x1c, 0x14, 0x3a, 0x0b,
- 0xa4, 0x42, 0xbe, 0xd2, 0xfe, 0xc6, 0x68, 0x77, 0x7a, 0x46, 0x7b, 0xab, 0xd5, 0x52, 0x2f, 0xa1,
- 0x34, 0x24, 0x2a, 0xdb, 0x6b, 0x6a, 0x0c, 0xe5, 0x21, 0x53, 0xed, 0x74, 0x5a, 0x46, 0xa5, 0x5d,
- 0x57, 0xe3, 0x28, 0x07, 0x69, 0xf6, 0xd5, 0xd1, 0xd5, 0x04, 0x2a, 0x02, 0xd4, 0x3a, 0xed, 0x5a,
- 0xa5, 0x67, 0x54, 0xd6, 0xd6, 0x54, 0x05, 0x65, 0x21, 0x59, 0xeb, 0x6c, 0xb5, 0x7b, 0x6a, 0x92,
- 0x8a, 0x6f, 0x54, 0x7e, 0xa6, 0xa6, 0xd9, 0x0f, 0xad, 0xad, 0x66, 0x10, 0x40, 0xaa, 0xdb, 0xab,
- 0xd7, 0x1b, 0xdb, 0x6a, 0x96, 0x36, 0x76, 0xb7, 0x36, 0x54, 0xa0, 0x70, 0xdd, 0xad, 0x0d, 0x43,
- 0x6b, 0xf7, 0xd4, 0x1c, 0xed, 0x69, 0xbb, 0xa2, 0x6b, 0x95, 0x76, 0xad, 0xa1, 0xe6, 0x29, 0xe9,
- 0x67, 0x1d, 0x9d, 0x21, 0x17, 0x78, 0x4f, 0x5b, 0xed, 0x9e, 0xa1, 0x77, 0x1e, 0x77, 0xd5, 0x22,
- 0x93, 0x7b, 0xa4, 0xd7, 0xb5, 0x66, 0x53, 0x5d, 0x40, 0x08, 0x8a, 0x4d, 0xad, 0x5d, 0x69, 0x19,
- 0xa1, 0xb4, 0x4a, 0x27, 0xc4, 0xdb, 0x44, 0x9f, 0x97, 0x51, 0x01, 0xb2, 0x15, 0x5d, 0xaf, 0x7c,
- 0xc3, 0x10, 0x11, 0xed, 0x6c, 0xbd, 0xdb, 0x69, 0xb3, 0xaf, 0x2b, 0x94, 0x48, 0xbf, 0xaa, 0xec,
- 0x73, 0x91, 0x76, 0xd7, 0xed, 0xe9, 0x5a, 0x7b, 0x8d, 0x7d, 0xbf, 0x55, 0xbe, 0x0b, 0x0a, 0xb5,
- 0x22, 0x94, 0x01, 0xa5, 0xb2, 0xd5, 0xeb, 0xa8, 0x97, 0xd8, 0x6c, 0x6a, 0x95, 0x56, 0x45, 0x57,
- 0x63, 0x94, 0xbb, 0xdd, 0x69, 0x1b, 0xe2, 0x3b, 0x5e, 0xfe, 0x3e, 0x01, 0xc5, 0xd9, 0x12, 0x59,
- 0x68, 0xbb, 0xe7, 0x9a, 0xd8, 0xac, 0xdc, 0x31, 0xdb, 0x9d, 0x06, 0xe6, 0xf1, 0x57, 0x0f, 0xcc,
- 0xc3, 0x9c, 0x27, 0xf1, 0x5a, 0x39, 0xcf, 0x3d, 0xc8, 0x58, 0x13, 0x8f, 0x6d, 0x21, 0x66, 0xc5,
- 0x89, 0xea, 0x5b, 0x94, 0xfc, 0xfd, 0x8b, 0xe5, 0x42, 0x60, 0x8f, 0xf0, 0x4a, 0x5d, 0x10, 0xf5,
- 0x90, 0x8d, 0xa6, 0x49, 0x83, 0xdd, 0x89, 0xbb, 0x67, 0xf8, 0xf6, 0x73, 0x3c, 0x9b, 0x26, 0xb1,
- 0xf6, 0xae, 0xfd, 0x1c, 0xa3, 0x0e, 0xe4, 0x49, 0xb0, 0x8b, 0x3d, 0x43, 0x04, 0x6e, 0xa9, 0x57,
- 0x08, 0xdc, 0x72, 0x0c, 0xa1, 0xc7, 0xa3, 0xb7, 0xaf, 0x20, 0xe3, 0x61, 0xd3, 0xaa, 0xf8, 0x9d,
- 0x1d, 0x51, 0xfa, 0xfd, 0x8d, 0x08, 0xd8, 0x24, 0xb0, 0x9d, 0x95, 0x5d, 0x67, 0xb0, 0xd2, 0x93,
- 0xb7, 0x4f, 0x72, 0xd7, 0x4a, 0xa1, 0xf2, 0x1d, 0xb1, 0xfc, 0x39, 0x48, 0x6b, 0xee, 0x33, 0xd3,
- 0xb1, 0x2d, 0x6e, 0x01, 0xdc, 0xcf, 0xaa, 0x31, 0x6a, 0xf8, 0x1a, 0x0d, 0xe1, 0xd4, 0x78, 0xf9,
- 0x97, 0x31, 0xc8, 0x34, 0x1d, 0xb2, 0xcf, 0x96, 0xfd, 0x1e, 0xa4, 0x77, 0x1c, 0xb2, 0x6f, 0x88,
- 0xfa, 0x41, 0xbe, 0x5a, 0xa2, 0xc8, 0xff, 0xfa, 0x62, 0x39, 0x45, 0x59, 0xb4, 0xfa, 0xcb, 0xf0,
- 0x97, 0x9e, 0xa2, 0x8c, 0x9a, 0x85, 0x36, 0x58, 0xf1, 0x48, 0x5c, 0xeb, 0x89, 0x50, 0xf3, 0xe6,
- 0x05, 0x2e, 0xa3, 0x22, 0x17, 0x3f, 0x11, 0x00, 0xb4, 0x05, 0xe9, 0xa1, 0x19, 0xe0, 0x7d, 0xf3,
- 0x90, 0xc5, 0x4b, 0xc9, 0xea, 0x4f, 0xc4, 0x1a, 0x7d, 0x3c, 0xb4, 0x83, 0xdd, 0x49, 0x7f, 0x65,
- 0x40, 0x46, 0xab, 0x21, 0xba, 0xd5, 0x9f, 0xfe, 0x5e, 0x1d, 0xef, 0x0d, 0x57, 0x65, 0x4a, 0x4f,
- 0xc3, 0x37, 0xad, 0xae, 0x4b, 0xac, 0xf2, 0x3e, 0xe4, 0xd6, 0x49, 0x7f, 0xd3, 0x23, 0x43, 0xea,
- 0x61, 0xd0, 0x07, 0x90, 0x7a, 0x42, 0xfa, 0x72, 0x9a, 0x89, 0x6a, 0x41, 0x94, 0x49, 0x92, 0xeb,
- 0xa4, 0xaf, 0xd5, 0xf5, 0xe4, 0x13, 0xd2, 0xd7, 0x2c, 0x74, 0x0b, 0xf2, 0x03, 0xe2, 0x06, 0x9e,
- 0xdd, 0x9f, 0x84, 0x17, 0x3a, 0x71, 0x79, 0x38, 0x44, 0x29, 0xa8, 0x04, 0x8a, 0xef, 0x90, 0x40,
- 0x0c, 0x59, 0x96, 0x12, 0x1c, 0x12, 0x94, 0xff, 0x32, 0x09, 0xe8, 0x78, 0xd1, 0x98, 0x66, 0xba,
- 0x3e, 0x2b, 0xac, 0x72, 0xcb, 0x8a, 0x47, 0xe4, 0x80, 0x13, 0x98, 0x69, 0xad, 0x41, 0x66, 0x2c,
- 0xc6, 0xcc, 0x0e, 0xfc, 0x33, 0x2b, 0xc1, 0x91, 0x09, 0x4a, 0x8b, 0x90, 0xc2, 0x68, 0x0d, 0x12,
- 0x13, 0xcf, 0x2e, 0xa5, 0xd9, 0xf2, 0xfc, 0x78, 0x9e, 0xfa, 0xf6, 0xca, 0x96, 0x67, 0x37, 0xdc,
- 0xc0, 0x3b, 0xd4, 0x29, 0x02, 0xfa, 0x29, 0xa4, 0xf8, 0x15, 0xab, 0xb8, 0x4d, 0x58, 0x3e, 0xa1,
- 0x9e, 0xa2, 0x75, 0x9a, 0xb6, 0x83, 0x9b, 0x8c, 0x2d, 0xbc, 0x21, 0x63, 0x5f, 0x68, 0x3b, 0x4c,
- 0x6f, 0xb2, 0x6c, 0x28, 0x9f, 0xcd, 0x35, 0x14, 0xbe, 0x3f, 0xd8, 0x68, 0x18, 0x6e, 0x2c, 0x4c,
- 0x78, 0xbe, 0x82, 0x77, 0xfc, 0x3d, 0x7b, 0x6c, 0x8c, 0x6c, 0xdf, 0xa7, 0x79, 0xde, 0x0e, 0xf1,
- 0xb0, 0x3d, 0x74, 0x69, 0xc4, 0xc1, 0x6f, 0x19, 0xe4, 0xd1, 0xf6, 0x36, 0x65, 0xdb, 0xe0, 0x5c,
- 0x4d, 0xce, 0xf4, 0x10, 0x1f, 0xfa, 0xe8, 0x0e, 0x14, 0xf6, 0x4d, 0xc7, 0xa1, 0x8e, 0xa0, 0x6d,
- 0xba, 0xc4, 0x67, 0x97, 0x0a, 0x72, 0xb3, 0xcf, 0x92, 0xd0, 0x5d, 0x28, 0xda, 0xee, 0x10, 0xfb,
- 0x41, 0xdd, 0xf6, 0xf0, 0x20, 0x70, 0x0e, 0x4b, 0xf9, 0x48, 0x0f, 0x47, 0x68, 0x4b, 0x26, 0xe4,
- 0x22, 0xe3, 0x46, 0x2a, 0x24, 0x68, 0x18, 0xc4, 0xca, 0x73, 0x3a, 0xfd, 0x89, 0xbe, 0x84, 0x24,
- 0x4b, 0x7c, 0xe6, 0x73, 0x91, 0x3a, 0x17, 0xfa, 0x22, 0xfe, 0x59, 0x6c, 0xe9, 0x53, 0xc8, 0xc8,
- 0x55, 0x8a, 0xe2, 0x27, 0x39, 0xfe, 0x62, 0x14, 0x3f, 0x1b, 0x91, 0x5b, 0x57, 0x32, 0x31, 0x35,
- 0xce, 0x8f, 0xd6, 0x75, 0x25, 0xa3, 0xa8, 0xc9, 0x75, 0x25, 0x93, 0x54, 0x53, 0xe5, 0xbf, 0x8e,
- 0x43, 0x61, 0xe6, 0x72, 0x02, 0x7d, 0x08, 0x39, 0x0b, 0xd3, 0x98, 0x80, 0xbb, 0x4f, 0x5e, 0x5c,
- 0x14, 0xae, 0x2b, 0x42, 0x38, 0xae, 0xc6, 0xc4, 0xe9, 0x6a, 0x6c, 0xcd, 0x96, 0xb2, 0x3e, 0xba,
- 0xe0, 0x45, 0x09, 0x2b, 0xd7, 0xd1, 0x24, 0x6a, 0xd6, 0xbb, 0x47, 0xb7, 0x4a, 0xf2, 0x35, 0xb6,
- 0x0a, 0x55, 0xa6, 0xec, 0x81, 0xee, 0x6b, 0x97, 0xa6, 0x6e, 0xd1, 0xf9, 0xb2, 0x16, 0xaa, 0x66,
- 0xec, 0x5a, 0x4c, 0xa5, 0x79, 0x9d, 0xfe, 0x5c, 0x57, 0x32, 0x71, 0x35, 0x51, 0xfe, 0xfb, 0x18,
- 0x14, 0x66, 0x0a, 0xf7, 0x17, 0x56, 0xdd, 0x4d, 0xc8, 0x53, 0x64, 0x63, 0x6c, 0x06, 0x01, 0xf6,
- 0xb8, 0xb7, 0x09, 0x19, 0x29, 0x65, 0x93, 0x13, 0xd0, 0x4f, 0x21, 0x4d, 0xc6, 0x32, 0xc8, 0x3d,
- 0x7a, 0x3a, 0xc8, 0x3d, 0x58, 0xeb, 0x6e, 0x77, 0x38, 0x93, 0x2c, 0xda, 0x09, 0x99, 0xe9, 0x99,
- 0xc6, 0xaa, 0xa8, 0xca, 0xb1, 0x33, 0x8d, 0xd5, 0x51, 0x7f, 0x37, 0x0e, 0xd0, 0xdd, 0xc3, 0xc1,
- 0x60, 0x97, 0xcd, 0xe1, 0x21, 0xe4, 0x7c, 0xf6, 0x65, 0x44, 0xa2, 0x82, 0xb3, 0x6e, 0x46, 0x19,
- 0x73, 0x24, 0x18, 0x00, 0x3f, 0x6c, 0x41, 0xa5, 0x69, 0xc2, 0xcb, 0x2b, 0x23, 0x61, 0xed, 0xf7,
- 0x63, 0x40, 0x43, 0xec, 0x62, 0xcf, 0x0c, 0xb0, 0xb1, 0x6b, 0xfb, 0x01, 0x19, 0x7a, 0xe6, 0x68,
- 0xa6, 0x0e, 0x7a, 0x59, 0xd2, 0x1f, 0x48, 0x32, 0xfa, 0x0c, 0xde, 0x0a, 0x79, 0x8d, 0x91, 0x79,
- 0x60, 0xf4, 0x27, 0x83, 0x3d, 0x1c, 0xf0, 0xa9, 0xc9, 0x0a, 0xcf, 0x95, 0x90, 0x65, 0xc3, 0x3c,
- 0xa8, 0x72, 0x06, 0x74, 0x03, 0xb2, 0x7e, 0x60, 0x06, 0x06, 0x5b, 0xe2, 0x64, 0x44, 0xdd, 0x19,
- 0xda, 0xcc, 0xf2, 0xf4, 0x3f, 0x8f, 0x41, 0x2e, 0x72, 0xc3, 0x86, 0x9a, 0x90, 0xe1, 0x33, 0x09,
- 0x0b, 0x34, 0xe7, 0x6a, 0x21, 0x72, 0xd0, 0x85, 0xb2, 0x27, 0xf9, 0xff, 0xc2, 0x09, 0xfe, 0xff,
- 0x23, 0xb8, 0x4c, 0x67, 0xb4, 0xe3, 0x99, 0xec, 0xe9, 0x80, 0x61, 0x5b, 0x0e, 0xaf, 0x23, 0xc4,
- 0x64, 0x65, 0x6f, 0x64, 0x1e, 0x34, 0x05, 0x55, 0xb3, 0x1c, 0x5c, 0xfe, 0xdb, 0x04, 0x2c, 0x9e,
- 0x74, 0x91, 0xf7, 0xab, 0x1e, 0xf9, 0xef, 0x00, 0xe2, 0x5f, 0x32, 0xd9, 0x8c, 0x94, 0x90, 0x1e,
- 0xbd, 0x7c, 0xb1, 0x2c, 0xee, 0x15, 0x45, 0xba, 0xa9, 0xd5, 0xfd, 0xef, 0x5f, 0x2c, 0x7f, 0x7e,
- 0xa1, 0x23, 0x3e, 0xf2, 0x68, 0x67, 0x45, 0x4a, 0xeb, 0xaa, 0x3f, 0x03, 0x67, 0xf9, 0xc8, 0x84,
- 0x0c, 0x3b, 0x1b, 0xe8, 0x21, 0xcf, 0x2d, 0xa1, 0x29, 0xdf, 0x91, 0x30, 0x4f, 0xaa, 0xd5, 0x2f,
- 0x1c, 0x54, 0x44, 0x7b, 0xa4, 0x41, 0x05, 0xc3, 0xd5, 0xac, 0x48, 0x14, 0x91, 0x3a, 0x23, 0x8a,
- 0xb8, 0x0d, 0x05, 0xba, 0xd3, 0x68, 0xde, 0x8f, 0x07, 0x01, 0xb6, 0x58, 0x48, 0x27, 0xcb, 0xda,
- 0x79, 0x4a, 0x6a, 0x08, 0x8a, 0xf0, 0xbe, 0xff, 0xab, 0xc0, 0xbb, 0x67, 0x5c, 0x94, 0xa2, 0x6f,
- 0x8e, 0x94, 0x08, 0x7f, 0xf2, 0x4a, 0xf7, 0xad, 0xfc, 0x3c, 0x39, 0x52, 0x37, 0x8c, 0xdc, 0x3e,
- 0xc4, 0x4f, 0xba, 0x7d, 0x98, 0xbd, 0x36, 0x48, 0x9c, 0x7c, 0x6d, 0xf0, 0x46, 0x6a, 0x82, 0x9f,
- 0xcf, 0x24, 0xcf, 0xf3, 0x94, 0x39, 0x96, 0xfe, 0x26, 0x0e, 0x49, 0x36, 0x39, 0xf4, 0x35, 0x28,
- 0x16, 0xf6, 0x07, 0xaf, 0x74, 0x29, 0xc0, 0x24, 0x2f, 0x72, 0x27, 0x20, 0x5f, 0x3d, 0x25, 0x5e,
- 0xe7, 0xd5, 0x53, 0x1d, 0x32, 0x61, 0xf5, 0x4d, 0x99, 0xb3, 0xfa, 0x16, 0x4a, 0x4e, 0x13, 0xa5,
- 0xe4, 0xeb, 0x24, 0x4a, 0xe5, 0xff, 0x8c, 0x41, 0x71, 0xf6, 0x92, 0x17, 0x7d, 0x0d, 0x49, 0xfe,
- 0x02, 0x29, 0x36, 0x77, 0x12, 0xcf, 0x05, 0x91, 0x0d, 0xa1, 0xef, 0xb6, 0x66, 0x6a, 0x65, 0xf9,
- 0xea, 0x97, 0x22, 0xc9, 0xf8, 0xe4, 0xe2, 0xbb, 0x11, 0x8f, 0x56, 0xe9, 0x5a, 0xfb, 0x2b, 0x3d,
- 0x5d, 0x0d, 0x61, 0x65, 0xe9, 0xea, 0x26, 0xa8, 0xee, 0x64, 0xc4, 0x0a, 0x34, 0xc6, 0x18, 0x7b,
- 0xc6, 0x10, 0xbb, 0xdc, 0xf3, 0xe8, 0x05, 0x77, 0x32, 0xaa, 0x11, 0xc7, 0xdf, 0xc4, 0xde, 0x1a,
- 0x76, 0xcb, 0x3f, 0xcf, 0x43, 0x3e, 0x7a, 0x0b, 0x8d, 0xae, 0x43, 0x6e, 0x6c, 0x7a, 0x81, 0xcd,
- 0xaa, 0x40, 0x87, 0xa2, 0xc4, 0x1f, 0x6d, 0x42, 0x5d, 0xc8, 0xf2, 0x9b, 0xea, 0x66, 0x58, 0x58,
- 0x5f, 0xbd, 0xd8, 0x15, 0xb7, 0xf8, 0x68, 0x86, 0xc5, 0x8d, 0x10, 0x67, 0xe9, 0xaf, 0x62, 0xa2,
- 0xac, 0xd1, 0x85, 0x82, 0x2c, 0x3a, 0xe1, 0xe6, 0xab, 0x96, 0x78, 0xf4, 0x59, 0x0c, 0xf4, 0x08,
- 0x40, 0x74, 0x45, 0x11, 0xe3, 0x0c, 0xf1, 0xde, 0x7c, 0x63, 0xa6, 0xa8, 0x11, 0x10, 0x7e, 0x3d,
- 0xbd, 0xf4, 0x5f, 0x49, 0x48, 0x36, 0x3d, 0x1a, 0x0d, 0x3d, 0x04, 0x65, 0x44, 0x2c, 0x19, 0x18,
- 0x5c, 0x14, 0x9c, 0xc9, 0xae, 0x6c, 0x10, 0x2b, 0xdc, 0xbf, 0x14, 0x04, 0x3d, 0x82, 0x54, 0x9f,
- 0x4c, 0x5c, 0xcb, 0x17, 0x01, 0xf1, 0xc7, 0x73, 0xc1, 0x55, 0x99, 0xa8, 0xf4, 0x26, 0x1c, 0x68,
- 0xe9, 0x7f, 0x62, 0x90, 0x64, 0x04, 0xf4, 0x2d, 0x64, 0x59, 0x5b, 0x6f, 0x1a, 0xc7, 0x7c, 0x3a,
- 0x3f, 0x7e, 0xc4, 0xe7, 0x4c, 0xe1, 0xa8, 0x77, 0xb4, 0xdd, 0xc0, 0x10, 0x4f, 0xec, 0xa2, 0xde,
- 0x22, 0x6b, 0xbb, 0x41, 0x87, 0xbf, 0xb2, 0xbb, 0x01, 0x79, 0x6a, 0xb9, 0x96, 0x64, 0x4b, 0xb0,
- 0x08, 0x32, 0xc7, 0xda, 0x04, 0xcb, 0x3a, 0xe4, 0x38, 0x91, 0x47, 0x5b, 0xdc, 0x1f, 0xcc, 0x71,
- 0x97, 0x0e, 0x5c, 0x9a, 0x8e, 0x69, 0xe9, 0xcf, 0x62, 0x90, 0xe2, 0x2a, 0x41, 0x6d, 0x48, 0xfa,
- 0x81, 0xe9, 0x05, 0xc2, 0x1d, 0xde, 0x9f, 0x7f, 0xda, 0xa1, 0x9b, 0xa0, 0x30, 0xa8, 0x3e, 0x0d,
- 0x81, 0x5f, 0x09, 0x8d, 0x85, 0xcd, 0xe5, 0x9b, 0xa0, 0x50, 0x0b, 0x40, 0x59, 0x48, 0xea, 0x95,
- 0xf6, 0x5a, 0x43, 0xbd, 0x84, 0x32, 0xa0, 0xb0, 0xb2, 0x59, 0x0c, 0x01, 0xa4, 0xd6, 0xf4, 0xce,
- 0xd6, 0x66, 0x57, 0x8d, 0x97, 0x9f, 0x43, 0x36, 0xd4, 0x3d, 0xba, 0x0a, 0x57, 0xb6, 0xda, 0xd5,
- 0xce, 0x56, 0xbb, 0xde, 0xa8, 0x1b, 0x9b, 0x7a, 0xa3, 0xd6, 0xa8, 0x6b, 0xed, 0x35, 0xf5, 0xd2,
- 0x2c, 0xa1, 0xd9, 0x69, 0xb5, 0x3a, 0x8f, 0x29, 0x21, 0x86, 0x16, 0x41, 0xed, 0x34, 0x9b, 0xdd,
- 0x46, 0x2f, 0xc2, 0x1e, 0x8f, 0xb4, 0x4e, 0x79, 0x13, 0x68, 0x01, 0x72, 0xb5, 0x2d, 0x5d, 0x6f,
- 0xf0, 0xfa, 0x9d, 0xaa, 0x2c, 0xfd, 0x53, 0x1c, 0x32, 0x72, 0xfb, 0xa2, 0x46, 0xa4, 0xfc, 0x7a,
- 0xe6, 0xbb, 0x94, 0xd9, 0x89, 0x1f, 0x2d, 0xbe, 0x7e, 0x08, 0x39, 0xd3, 0x1b, 0x6a, 0xd6, 0x41,
- 0x97, 0x2d, 0x4a, 0xd4, 0x5c, 0xa2, 0x04, 0x74, 0x1d, 0x32, 0xa6, 0x37, 0xac, 0x91, 0x89, 0x38,
- 0x71, 0xc3, 0x13, 0x48, 0xb6, 0xbe, 0xa1, 0xc3, 0xa3, 0x0a, 0xc9, 0x1d, 0x4f, 0x46, 0xc2, 0x67,
- 0xbe, 0x5f, 0x39, 0xbe, 0xa0, 0x3a, 0x17, 0x45, 0xb7, 0x60, 0xa6, 0x30, 0x2c, 0x1e, 0xe4, 0x8a,
- 0x50, 0x27, 0x4a, 0x29, 0xff, 0x22, 0x06, 0x30, 0x75, 0x2e, 0xa8, 0x08, 0xa0, 0x77, 0x1e, 0x1b,
- 0xed, 0xad, 0x8d, 0x6a, 0x43, 0x17, 0x26, 0x50, 0x69, 0x3f, 0xe4, 0xc5, 0xca, 0x7a, 0xa3, 0xdd,
- 0x6d, 0x18, 0xec, 0x3b, 0x8e, 0x54, 0xc8, 0x6f, 0x36, 0xf4, 0x1a, 0x5b, 0x1b, 0xda, 0x92, 0x40,
- 0x05, 0xc8, 0xd6, 0xb6, 0x36, 0x1a, 0x46, 0x5d, 0xeb, 0xf6, 0x78, 0x51, 0xb7, 0xdd, 0xd3, 0x5a,
- 0x0d, 0x5e, 0xd4, 0x6d, 0x55, 0xd6, 0xd4, 0x14, 0x85, 0x6b, 0x35, 0x2a, 0x75, 0x35, 0x4d, 0x97,
- 0xb6, 0xa9, 0xe9, 0xdd, 0x9e, 0xb1, 0x5d, 0x69, 0x6d, 0x35, 0xd4, 0x0c, 0xc5, 0x6f, 0x55, 0xc2,
- 0xef, 0x2c, 0x45, 0x6b, 0xf7, 0x1e, 0x88, 0x4f, 0x28, 0xff, 0x5d, 0x1c, 0x16, 0x4f, 0x7a, 0x09,
- 0x84, 0x7a, 0x90, 0xde, 0x37, 0xa3, 0xe1, 0xf4, 0x27, 0xf3, 0x3d, 0x25, 0x5a, 0x79, 0x4c, 0xa5,
- 0x65, 0x80, 0x25, 0xa0, 0x50, 0x13, 0x94, 0x1d, 0x8c, 0xad, 0x53, 0x1e, 0x75, 0xb3, 0x77, 0xf0,
- 0xfc, 0x4d, 0xbc, 0xc0, 0xa4, 0xcc, 0x75, 0x1c, 0x98, 0xb6, 0xe3, 0x87, 0xc6, 0x85, 0xb1, 0xb5,
- 0xf4, 0xfb, 0x31, 0x48, 0xb2, 0x0e, 0x50, 0x1b, 0x54, 0xdb, 0xb5, 0x03, 0xdb, 0x74, 0x0c, 0x0f,
- 0xfb, 0xc4, 0x79, 0x86, 0x2d, 0x61, 0xb9, 0x17, 0x2a, 0x2a, 0x2e, 0x08, 0x61, 0x5d, 0xc8, 0x86,
- 0xcf, 0x69, 0xe2, 0x17, 0x7f, 0x4e, 0xf3, 0x0f, 0x31, 0x40, 0xc7, 0xdf, 0x3c, 0xa1, 0x2a, 0x14,
- 0x02, 0xcf, 0x1c, 0xec, 0x61, 0xcb, 0xe0, 0x51, 0x0b, 0xd7, 0xe3, 0x39, 0x90, 0x79, 0x21, 0xd3,
- 0x65, 0x59, 0xff, 0x1b, 0xd2, 0x57, 0x24, 0x94, 0x4f, 0x9c, 0x1e, 0xca, 0xdf, 0xf9, 0x4d, 0x28,
- 0xce, 0xbe, 0x67, 0xa0, 0x0e, 0x6a, 0x73, 0xab, 0xda, 0xd2, 0x6a, 0xea, 0x25, 0xf4, 0x0e, 0xbc,
- 0xc5, 0x7f, 0x1b, 0x95, 0x76, 0x9d, 0x5d, 0x4d, 0x08, 0x52, 0xec, 0x4e, 0x59, 0x66, 0xd3, 0xcc,
- 0x79, 0x2d, 0x82, 0xfa, 0xa0, 0xd5, 0x32, 0x36, 0x5b, 0x5b, 0x5d, 0xfe, 0x67, 0xfb, 0x9e, 0x7a,
- 0xa9, 0xfa, 0xfe, 0x77, 0xff, 0x71, 0xed, 0xd2, 0x77, 0x2f, 0xaf, 0xc5, 0xfe, 0xf9, 0xe5, 0xb5,
- 0xd8, 0xbf, 0xbc, 0xbc, 0x16, 0xfb, 0xf7, 0x97, 0xd7, 0x62, 0x7f, 0xf4, 0xcb, 0x6b, 0x97, 0xbe,
- 0xcd, 0x86, 0xff, 0x0d, 0xe1, 0xff, 0x03, 0x00, 0x00, 0xff, 0xff, 0xd4, 0x71, 0xbf, 0x0b, 0x51,
- 0x31, 0x00, 0x00,
+ proto.RegisterFile("sql/distsqlpb/processors.proto", fileDescriptor_processors_763502ebe68123bf)
+}
+
+var fileDescriptor_processors_763502ebe68123bf = []byte{
+ // 4143 bytes of a gzipped FileDescriptorProto
+ 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xc4, 0x5b, 0x4d, 0x6c, 0x1b, 0x49,
+ 0x76, 0x36, 0xc9, 0xe6, 0xdf, 0xe3, 0x8f, 0xda, 0x65, 0x79, 0xcc, 0xd1, 0x4c, 0x2c, 0x9b, 0x33,
+ 0x3b, 0xfe, 0x59, 0xaf, 0x64, 0x7b, 0x66, 0x27, 0x33, 0xb3, 0xb3, 0x98, 0xe1, 0xaf, 0xdc, 0x32,
+ 0x45, 0xca, 0x4d, 0x4a, 0xde, 0x99, 0x43, 0x3a, 0x4d, 0x76, 0x89, 0x6a, 0xab, 0xd9, 0x45, 0x77,
+ 0x37, 0x2d, 0xc9, 0x97, 0x9c, 0x82, 0x00, 0x39, 0xe4, 0x07, 0xb9, 0x06, 0xc1, 0x5e, 0xf6, 0x9a,
+ 0x00, 0x41, 0x0e, 0x39, 0x05, 0x09, 0x10, 0x04, 0x83, 0x5c, 0x92, 0x63, 0x10, 0x04, 0x46, 0xa2,
+ 0x3d, 0xe4, 0x96, 0x6b, 0x80, 0x39, 0x24, 0x41, 0xfd, 0x35, 0x9b, 0xfa, 0x97, 0x6d, 0x4c, 0x2e,
+ 0x32, 0xbb, 0xde, 0x7b, 0x5f, 0x55, 0xbd, 0x7a, 0xf5, 0xea, 0xbd, 0x57, 0x65, 0xb8, 0xee, 0x3f,
+ 0x77, 0x96, 0x2d, 0xdb, 0x0f, 0xfc, 0xe7, 0xce, 0xb8, 0xbf, 0x3c, 0xf6, 0xc8, 0x00, 0xfb, 0x3e,
+ 0xf1, 0xfc, 0xa5, 0xb1, 0x47, 0x02, 0x82, 0x4a, 0x03, 0x32, 0xd8, 0xf1, 0x88, 0x39, 0xd8, 0x5e,
+ 0xf2, 0x9f, 0x3b, 0x4b, 0x82, 0xd3, 0x9b, 0xb8, 0x0b, 0xef, 0x3c, 0x23, 0x7d, 0x7f, 0x99, 0xfe,
+ 0x19, 0xf7, 0xd9, 0x3f, 0x5c, 0x62, 0x01, 0x31, 0xee, 0x71, 0x7f, 0xd9, 0x32, 0x03, 0x53, 0xb4,
+ 0x95, 0x64, 0x9b, 0x4d, 0x7e, 0xb2, 0x45, 0xbc, 0x91, 0x19, 0x48, 0xee, 0xf7, 0x69, 0xff, 0xfe,
+ 0x73, 0xa7, 0x6f, 0xfa, 0x78, 0xd9, 0x0f, 0xbc, 0xc9, 0x20, 0x98, 0x78, 0xd8, 0x12, 0xd4, 0xf7,
+ 0xa2, 0xd4, 0x67, 0xc4, 0x76, 0x8d, 0x60, 0x7f, 0x8c, 0x25, 0xe8, 0xec, 0xd0, 0xa3, 0xdd, 0x4d,
+ 0x02, 0xdb, 0x59, 0xde, 0x76, 0x06, 0xcb, 0x81, 0x3d, 0xc2, 0x7e, 0x60, 0x8e, 0xc6, 0x82, 0x32,
+ 0x3f, 0x24, 0x43, 0xc2, 0x7e, 0x2e, 0xd3, 0x5f, 0xbc, 0xb5, 0xfc, 0x87, 0x09, 0x28, 0xac, 0xcb,
+ 0x99, 0x77, 0xc7, 0x78, 0x80, 0x6a, 0x90, 0xb4, 0xdd, 0xf1, 0x24, 0x28, 0xc5, 0x6e, 0x24, 0x6e,
+ 0xe7, 0x1e, 0xde, 0x5a, 0x3a, 0x49, 0x0d, 0x4b, 0x1a, 0x65, 0xeb, 0xee, 0xbb, 0x03, 0x2a, 0x57,
+ 0x55, 0xbe, 0x7b, 0xb5, 0x78, 0x49, 0xe7, 0xb2, 0xa8, 0x09, 0xca, 0x80, 0x78, 0xb8, 0x14, 0xbf,
+ 0x11, 0xbb, 0x9d, 0x7b, 0x78, 0xef, 0x64, 0x8c, 0xb0, 0xef, 0x1a, 0xf1, 0xf0, 0x86, 0x6b, 0x13,
+ 0x57, 0x00, 0x31, 0x79, 0xf4, 0x08, 0x52, 0x64, 0x12, 0xd0, 0xd1, 0x24, 0xd8, 0x68, 0xee, 0x9e,
+ 0x8c, 0xd4, 0x61, 0x7c, 0x3a, 0x99, 0x04, 0xd8, 0x8b, 0x0c, 0x48, 0xc8, 0xa3, 0x1a, 0x28, 0x63,
+ 0xe2, 0x07, 0x25, 0x85, 0x8d, 0xe8, 0xce, 0x29, 0x23, 0x22, 0x7e, 0x20, 0x46, 0x15, 0x81, 0x61,
+ 0xc2, 0xe8, 0x2e, 0x64, 0xfc, 0xc0, 0x1c, 0x62, 0xc3, 0xb6, 0x4a, 0xc9, 0x1b, 0xb1, 0xdb, 0xc9,
+ 0xea, 0x1c, 0xa5, 0x1e, 0xbc, 0x5a, 0x4c, 0x77, 0x69, 0xbb, 0x56, 0xd7, 0xd3, 0x8c, 0x41, 0xb3,
+ 0xd0, 0xa7, 0x90, 0x0f, 0x4d, 0x8a, 0xf2, 0xa7, 0x18, 0xff, 0x15, 0xc1, 0x9f, 0x0b, 0x27, 0xae,
+ 0xd5, 0xf5, 0x5c, 0xc8, 0xa8, 0x59, 0xe5, 0xbf, 0x88, 0xc3, 0xdc, 0xa1, 0x31, 0xa0, 0x2a, 0xa4,
+ 0xb6, 0x6c, 0x27, 0xc0, 0x5e, 0x29, 0xc6, 0x86, 0xff, 0xe1, 0xc9, 0xc3, 0x6f, 0xec, 0x8d, 0x3d,
+ 0xec, 0xfb, 0x53, 0x45, 0x0a, 0x49, 0xf4, 0x21, 0xc0, 0xd8, 0x23, 0xcf, 0xf0, 0x20, 0xb0, 0x89,
+ 0xcb, 0x16, 0x26, 0x23, 0x38, 0x22, 0xed, 0xe8, 0x0e, 0x14, 0xb9, 0xc2, 0x8c, 0x01, 0x71, 0x26,
+ 0x23, 0xd7, 0x67, 0x8a, 0x2f, 0x54, 0xe3, 0x6a, 0x4c, 0x2f, 0x70, 0x4a, 0x8d, 0x13, 0xd0, 0x1a,
+ 0xe4, 0x3d, 0xec, 0x5a, 0xd8, 0x33, 0xf0, 0xde, 0xd8, 0xf3, 0x4b, 0x0a, 0x5b, 0xa1, 0x8b, 0x0c,
+ 0x2d, 0xc7, 0xe5, 0x69, 0xbb, 0x8f, 0xde, 0x87, 0x14, 0xd9, 0xda, 0xf2, 0x71, 0xc0, 0x34, 0xab,
+ 0x84, 0xcb, 0xc7, 0xda, 0xd0, 0x02, 0x24, 0x1d, 0x7b, 0x64, 0x07, 0x4c, 0x8d, 0x92, 0xc8, 0x9b,
+ 0xca, 0xff, 0x5b, 0x04, 0x74, 0xd4, 0x8e, 0xd0, 0x17, 0xa0, 0xb8, 0x84, 0x8c, 0x85, 0xca, 0x3e,
+ 0x3a, 0x79, 0x5c, 0x6d, 0x42, 0xc6, 0x54, 0x8c, 0xaa, 0x5a, 0x67, 0x32, 0xe8, 0x31, 0xe4, 0x02,
+ 0xb3, 0xef, 0x60, 0x1d, 0x9b, 0x16, 0xf6, 0x84, 0x19, 0x9f, 0x62, 0x34, 0xbd, 0x29, 0x33, 0x43,
+ 0x89, 0x4a, 0xa3, 0x47, 0x00, 0x74, 0x03, 0x0b, 0xac, 0x04, 0xc3, 0xba, 0x7d, 0x32, 0xd6, 0x6a,
+ 0xc8, 0xcb, 0xa0, 0x22, 0xb2, 0xe8, 0x4b, 0x48, 0xf9, 0xc4, 0xa3, 0x76, 0xa0, 0x9c, 0x65, 0x07,
+ 0x5d, 0xc6, 0xc7, 0x10, 0x84, 0x0c, 0x1d, 0x87, 0x39, 0x1c, 0x7a, 0x78, 0x68, 0x06, 0xc4, 0x63,
+ 0x5a, 0x3e, 0x75, 0x1c, 0x95, 0x90, 0x97, 0x8f, 0x63, 0x2a, 0x8b, 0xaa, 0x90, 0xa1, 0x8c, 0xb6,
+ 0x3b, 0x08, 0x4a, 0xe9, 0xb3, 0xd4, 0x5b, 0x17, 0x9c, 0x0c, 0x25, 0x94, 0xa3, 0x2a, 0x1e, 0x61,
+ 0x6f, 0x88, 0xe9, 0x74, 0xb1, 0x57, 0xca, 0x9c, 0xa5, 0xe2, 0xb5, 0x29, 0x33, 0x57, 0x71, 0x44,
+ 0x9a, 0x4e, 0x6d, 0xdb, 0xf4, 0xb7, 0x05, 0x56, 0xf6, 0xac, 0xa9, 0x3d, 0x0a, 0x79, 0xf9, 0xd4,
+ 0xa6, 0xb2, 0xe8, 0x6b, 0x48, 0xbd, 0x30, 0x9d, 0x09, 0xf6, 0x4b, 0x70, 0x16, 0xca, 0x26, 0xe3,
+ 0x0b, 0x2d, 0x47, 0xc8, 0xd1, 0xb1, 0xf4, 0xcd, 0xc1, 0xce, 0x96, 0xed, 0x38, 0xd8, 0x2b, 0xe5,
+ 0xce, 0x42, 0xa9, 0x86, 0xbc, 0x7c, 0x2c, 0x53, 0x59, 0xd4, 0x02, 0xf0, 0xb0, 0x69, 0x69, 0xa3,
+ 0x31, 0xf1, 0x82, 0x52, 0xe1, 0x2c, 0x5f, 0xaa, 0x87, 0xbc, 0x75, 0x33, 0x30, 0x39, 0xda, 0x54,
+ 0x1e, 0x35, 0x20, 0xdb, 0xed, 0xf6, 0x9e, 0x7a, 0x36, 0xb5, 0x9f, 0x22, 0x03, 0x3b, 0xc5, 0xb9,
+ 0x87, 0xac, 0x0c, 0x67, 0x2a, 0x89, 0xbe, 0x82, 0x74, 0xd7, 0x1c, 0x8d, 0xe9, 0xdc, 0xe6, 0x18,
+ 0xc8, 0x8f, 0x4e, 0x01, 0xe1, 0x8c, 0x0c, 0x42, 0x4a, 0xa1, 0x6f, 0x41, 0xe5, 0x3f, 0xa7, 0x06,
+ 0x56, 0x52, 0x19, 0xd2, 0xd2, 0x59, 0x48, 0x87, 0x4c, 0xf2, 0x08, 0x0e, 0x22, 0x70, 0xcd, 0x76,
+ 0x03, 0xec, 0x39, 0xd8, 0x7c, 0x81, 0x2d, 0xbe, 0x6b, 0x84, 0x51, 0x5c, 0x66, 0x5d, 0xfc, 0xf4,
+ 0xb4, 0xe3, 0xec, 0x58, 0x41, 0xd6, 0xd3, 0x49, 0xa8, 0xe8, 0xb7, 0x01, 0x8d, 0x70, 0x60, 0xd2,
+ 0x13, 0xb8, 0x87, 0xfd, 0xa0, 0xcb, 0x1c, 0x5a, 0x09, 0xb1, 0xbe, 0xee, 0x9f, 0x66, 0xcc, 0x87,
+ 0x65, 0x58, 0x37, 0xc7, 0x60, 0xa1, 0x2d, 0x98, 0x8f, 0xb6, 0xea, 0x78, 0x80, 0xed, 0x17, 0xd8,
+ 0x2b, 0x5d, 0x61, 0x7d, 0x3c, 0x3c, 0x5f, 0x1f, 0x52, 0x8a, 0xf5, 0x72, 0x2c, 0x1e, 0x35, 0x8f,
+ 0x5a, 0x77, 0x53, 0x98, 0xc7, 0xfc, 0x59, 0xe6, 0x11, 0xb2, 0x72, 0xf3, 0x08, 0x3f, 0x51, 0x1b,
+ 0xf2, 0x2f, 0xed, 0xe1, 0x4b, 0x73, 0x28, 0xd4, 0x7e, 0x95, 0x21, 0x9d, 0x72, 0x6e, 0x7f, 0x1b,
+ 0xe1, 0x66, 0x60, 0x33, 0xf2, 0x74, 0x37, 0x89, 0xe3, 0xa9, 0x8b, 0x83, 0xd2, 0x3b, 0x67, 0xed,
+ 0xa6, 0xf5, 0x90, 0x97, 0xdb, 0xff, 0x54, 0x96, 0x3a, 0xad, 0x5d, 0xdb, 0xb5, 0xc8, 0x2e, 0xf6,
+ 0x4a, 0xd7, 0xce, 0x72, 0x5a, 0x4f, 0x05, 0x27, 0x77, 0x5a, 0x52, 0x0e, 0x3d, 0x81, 0x82, 0x43,
+ 0x06, 0xa6, 0xb3, 0xee, 0x98, 0x6e, 0x9b, 0x58, 0xb8, 0x54, 0x62, 0x40, 0x3f, 0x3e, 0x19, 0xa8,
+ 0x15, 0x65, 0x67, 0x68, 0xb3, 0x08, 0x74, 0x3b, 0x0c, 0xb6, 0x4d, 0x77, 0x18, 0xdd, 0x0e, 0xef,
+ 0x9e, 0xb5, 0x1d, 0x6a, 0x87, 0x24, 0xf8, 0x76, 0x38, 0x8c, 0x83, 0x7a, 0x50, 0xe4, 0x6d, 0x4d,
+ 0x8f, 0xb8, 0x81, 0x8d, 0xbd, 0xd2, 0xc2, 0x59, 0x4e, 0xa4, 0x36, 0xc3, 0xcf, 0x70, 0x0f, 0x61,
+ 0x7c, 0xa1, 0x7c, 0xf7, 0xcb, 0xc5, 0xd8, 0xaa, 0x92, 0x49, 0xa9, 0xe9, 0x55, 0x25, 0x93, 0x57,
+ 0x0b, 0xe5, 0x22, 0xe4, 0xa3, 0x87, 0x68, 0xf9, 0x13, 0x78, 0xe7, 0x78, 0x0b, 0x47, 0x0b, 0x10,
+ 0xb7, 0x2d, 0x76, 0x24, 0x67, 0xab, 0x20, 0x62, 0xa1, 0xb8, 0x56, 0xd7, 0xe3, 0xb6, 0x55, 0x7e,
+ 0x04, 0xa5, 0x93, 0x6c, 0x16, 0xdd, 0x03, 0xf0, 0x79, 0xb0, 0x61, 0x5b, 0x3e, 0x0b, 0x4d, 0xb3,
+ 0xd5, 0xc2, 0xc1, 0xab, 0xc5, 0x2c, 0xc7, 0xd6, 0xea, 0xbe, 0x9e, 0xe5, 0x0c, 0x9a, 0xe5, 0x97,
+ 0xff, 0x24, 0x06, 0xc5, 0x59, 0xef, 0x8c, 0x6a, 0x90, 0x96, 0x11, 0x0d, 0x0f, 0x6c, 0x3f, 0x38,
+ 0xe5, 0xc4, 0x32, 0x83, 0xc9, 0x48, 0x73, 0xb7, 0x88, 0x88, 0x33, 0xa4, 0x24, 0x7a, 0x0f, 0xb2,
+ 0x9e, 0xb9, 0x6b, 0xf4, 0xf7, 0x03, 0xec, 0x97, 0xe2, 0x37, 0x12, 0xb7, 0xf3, 0x7a, 0xc6, 0x33,
+ 0x77, 0xab, 0xf4, 0x1b, 0x2d, 0x42, 0xc6, 0x9d, 0x8c, 0x0c, 0x8f, 0xec, 0xfa, 0xec, 0x90, 0x97,
+ 0x51, 0x4a, 0xda, 0x9d, 0x8c, 0x74, 0xb2, 0xeb, 0x97, 0xeb, 0x30, 0x37, 0x13, 0x27, 0x98, 0x2e,
+ 0x7a, 0x00, 0x8a, 0x3f, 0x36, 0x5d, 0x11, 0xa3, 0x5c, 0x8b, 0x0c, 0x49, 0xa4, 0x0d, 0x4b, 0x94,
+ 0x4d, 0xc6, 0xa0, 0x94, 0xb5, 0xfc, 0xa7, 0x89, 0x43, 0x30, 0x2c, 0x3e, 0x4c, 0xb2, 0x80, 0xe3,
+ 0x84, 0x58, 0x47, 0xa4, 0x11, 0x3c, 0x4a, 0xa9, 0x63, 0x7f, 0xe0, 0xd9, 0xe3, 0x80, 0x78, 0x32,
+ 0x8a, 0x62, 0xa2, 0xe8, 0x26, 0x64, 0x6d, 0xd7, 0xc2, 0x7b, 0x86, 0x6d, 0xed, 0xb1, 0x80, 0xa7,
+ 0x20, 0xe8, 0x19, 0xd6, 0xac, 0x59, 0x7b, 0xe8, 0x3a, 0xa4, 0x3d, 0xfc, 0x02, 0x7b, 0x3e, 0x66,
+ 0x13, 0x94, 0xf1, 0xa3, 0x6c, 0x44, 0x0d, 0x48, 0xd2, 0x21, 0xca, 0x50, 0xf0, 0xbc, 0xf1, 0x52,
+ 0x38, 0x41, 0x2e, 0x8d, 0x3e, 0x00, 0x60, 0x81, 0x9d, 0xb1, 0x6d, 0xbb, 0x3c, 0x1a, 0x4c, 0x08,
+ 0x86, 0x2c, 0x6b, 0x7f, 0x64, 0xbb, 0x01, 0xd5, 0xb6, 0xed, 0x1b, 0x83, 0x6d, 0x3c, 0xd8, 0x61,
+ 0x31, 0x61, 0x38, 0x18, 0xdb, 0xaf, 0xd1, 0x46, 0xd4, 0x06, 0x78, 0x61, 0xfb, 0x76, 0xdf, 0x76,
+ 0xec, 0x60, 0x9f, 0x45, 0x29, 0xc5, 0xd3, 0x1c, 0x47, 0x77, 0x60, 0xba, 0x9b, 0x21, 0xbf, 0x8c,
+ 0x8c, 0xa7, 0x08, 0xe8, 0x47, 0x90, 0x1b, 0x99, 0x7b, 0x86, 0x87, 0xfd, 0x89, 0x13, 0xf8, 0x2c,
+ 0x5e, 0x91, 0x2b, 0x0c, 0x23, 0x73, 0x4f, 0xe7, 0xed, 0xe5, 0x7f, 0x4c, 0x40, 0x71, 0x36, 0x82,
+ 0xfb, 0xa1, 0x56, 0xe7, 0x0e, 0x14, 0x1d, 0x42, 0x76, 0x26, 0xe3, 0xe3, 0x42, 0x77, 0x4e, 0x91,
+ 0xa1, 0x7b, 0x0d, 0xd2, 0xc4, 0x65, 0x61, 0xfb, 0xd9, 0x81, 0xe4, 0xd1, 0x84, 0x82, 0xb8, 0xb4,
+ 0x0d, 0x6d, 0xc2, 0x65, 0x3e, 0x24, 0x9e, 0x60, 0x70, 0xb8, 0xe4, 0x85, 0xe1, 0xe6, 0x18, 0x48,
+ 0x93, 0x61, 0x30, 0xdc, 0xcf, 0x41, 0xa1, 0xa9, 0x2e, 0x5b, 0xd5, 0xe2, 0xc3, 0xc5, 0x13, 0xb4,
+ 0x45, 0x75, 0xdc, 0xdb, 0x1f, 0x63, 0xb9, 0x37, 0xa8, 0xc8, 0xdb, 0x5e, 0x73, 0xea, 0x47, 0x60,
+ 0x1a, 0x48, 0xa3, 0x27, 0x30, 0x27, 0x92, 0x23, 0xe2, 0x59, 0xd8, 0xb3, 0xdd, 0xa1, 0x58, 0xd2,
+ 0xf2, 0x29, 0x69, 0xa9, 0xe0, 0x14, 0xe8, 0x22, 0xbb, 0x92, 0xad, 0xe8, 0x21, 0x20, 0x89, 0x65,
+ 0x8c, 0xcc, 0x60, 0xb0, 0x6d, 0x38, 0xd8, 0x9d, 0x59, 0x60, 0x55, 0xd2, 0xd7, 0x28, 0xb9, 0x85,
+ 0xdd, 0x72, 0x1f, 0xf2, 0xd1, 0x98, 0x1a, 0xdd, 0x82, 0x39, 0xc6, 0x83, 0x2d, 0x23, 0xea, 0xe2,
+ 0x0a, 0x7a, 0x51, 0x34, 0xcb, 0x65, 0xbf, 0x03, 0xaa, 0x0c, 0xbf, 0x43, 0xce, 0x38, 0xe3, 0x9c,
+ 0x93, 0xed, 0x82, 0xb5, 0xfc, 0x07, 0x09, 0x50, 0x0f, 0x9f, 0xcc, 0xa8, 0x0e, 0x29, 0x66, 0x8d,
+ 0xd2, 0x85, 0x5e, 0xcc, 0x92, 0x85, 0x2c, 0x6a, 0x02, 0xe0, 0xe7, 0x33, 0xfd, 0xe7, 0x1e, 0xde,
+ 0x3c, 0xe5, 0x40, 0xe2, 0x8c, 0xd2, 0x03, 0xe0, 0xe7, 0x72, 0x36, 0x8b, 0xd3, 0x2d, 0x11, 0x35,
+ 0x75, 0xb9, 0x21, 0xde, 0x92, 0x95, 0x3f, 0x86, 0xfc, 0x96, 0xbd, 0x87, 0x2d, 0x43, 0x64, 0x05,
+ 0x49, 0x36, 0xde, 0xf3, 0x67, 0x05, 0x39, 0x26, 0xcd, 0x1b, 0xdf, 0xc0, 0xb4, 0xcb, 0x36, 0x5c,
+ 0x3e, 0x12, 0x4a, 0xa0, 0x32, 0xe4, 0x75, 0xb2, 0xdb, 0x25, 0x13, 0x6f, 0x80, 0x35, 0x6b, 0x8f,
+ 0x59, 0x63, 0x41, 0x9f, 0x69, 0x43, 0xef, 0x43, 0xb6, 0x4d, 0x4f, 0xb3, 0xf1, 0x24, 0xf0, 0xb9,
+ 0x61, 0xe9, 0xd3, 0x06, 0x84, 0x40, 0x69, 0x9b, 0x23, 0xee, 0xcf, 0xb3, 0x3a, 0xfb, 0x5d, 0xbe,
+ 0x05, 0x69, 0xa9, 0xe3, 0xf7, 0x67, 0x4f, 0x4d, 0xae, 0x61, 0xd9, 0x54, 0xfe, 0xb7, 0x38, 0xcc,
+ 0x1d, 0x4a, 0xcb, 0xd0, 0x1a, 0x14, 0x1c, 0xbc, 0xf5, 0x06, 0x3b, 0x24, 0x4f, 0xc5, 0xc3, 0xfd,
+ 0xd1, 0x81, 0xa2, 0x67, 0x0f, 0xb7, 0x23, 0x78, 0xf1, 0x0b, 0xe2, 0x15, 0x98, 0x7c, 0x08, 0x18,
+ 0x31, 0x8a, 0xe4, 0x6b, 0x1b, 0xc5, 0x1b, 0xb8, 0xa8, 0x3b, 0x50, 0x70, 0x27, 0x8e, 0x63, 0xe0,
+ 0xe7, 0x13, 0x33, 0xf4, 0x52, 0xf2, 0xf0, 0xca, 0x53, 0x52, 0x43, 0x50, 0xca, 0x7f, 0x9c, 0x80,
+ 0xe2, 0x6c, 0xa6, 0x8a, 0xee, 0xc2, 0x1c, 0xd3, 0x6e, 0x64, 0x03, 0xc5, 0x22, 0x4e, 0x1e, 0x6f,
+ 0x05, 0x8d, 0x70, 0x7f, 0xdc, 0x03, 0x95, 0xab, 0xee, 0xd0, 0x6e, 0xe3, 0xcc, 0x5c, 0xad, 0x53,
+ 0xee, 0xff, 0x6f, 0xbd, 0xfc, 0x18, 0x8a, 0x2c, 0xa1, 0x9f, 0xfa, 0xb0, 0xa8, 0x62, 0x0a, 0x9c,
+ 0x26, 0x07, 0xfb, 0x05, 0x5c, 0x3b, 0xa4, 0x06, 0xc3, 0xf4, 0xb0, 0xb1, 0x83, 0xf7, 0xd9, 0xb9,
+ 0x2c, 0xa5, 0xae, 0xcc, 0x28, 0xa4, 0xe2, 0xe1, 0xc7, 0x78, 0x1f, 0x7d, 0x09, 0xa5, 0xc3, 0x6a,
+ 0x09, 0x85, 0xb3, 0x11, 0xe1, 0xf9, 0x59, 0x05, 0x71, 0xe9, 0xf2, 0x7f, 0xa5, 0xa0, 0x38, 0x1b,
+ 0x76, 0xa3, 0x9b, 0x00, 0x43, 0x8f, 0xf0, 0x63, 0x37, 0xaa, 0xe1, 0x2c, 0x6b, 0xad, 0x11, 0xc7,
+ 0x47, 0xbf, 0x05, 0x79, 0x59, 0x3d, 0xb1, 0x89, 0x38, 0x98, 0x73, 0x0f, 0x3f, 0x39, 0x6f, 0xed,
+ 0x25, 0xfc, 0x9c, 0x6a, 0x7c, 0x06, 0x0f, 0xdd, 0x17, 0xa7, 0x08, 0xb6, 0x8c, 0xc8, 0x50, 0x94,
+ 0x70, 0x28, 0xaa, 0xa0, 0xae, 0x84, 0x23, 0x5a, 0x11, 0x2b, 0x95, 0x64, 0x2b, 0xf5, 0x93, 0x73,
+ 0x8f, 0xe4, 0xf0, 0xba, 0x2d, 0xfc, 0x5e, 0x1c, 0x72, 0x91, 0xe1, 0x51, 0xe0, 0xad, 0x89, 0x3b,
+ 0x60, 0xdb, 0xfe, 0x22, 0xc0, 0xcd, 0x89, 0x1b, 0xd6, 0x5a, 0x29, 0x00, 0xba, 0x11, 0xa9, 0x31,
+ 0x45, 0xab, 0x95, 0xd3, 0x0a, 0xd2, 0x87, 0x50, 0x14, 0xa1, 0xc7, 0x80, 0x38, 0x2c, 0x30, 0x52,
+ 0xb8, 0xff, 0xe3, 0xad, 0x35, 0xe2, 0x50, 0xff, 0x77, 0x8d, 0xb9, 0x30, 0x46, 0x4e, 0xb2, 0xb3,
+ 0x2e, 0x35, 0xe0, 0x84, 0x47, 0x90, 0x35, 0xbd, 0xe1, 0x64, 0x84, 0xdd, 0xc0, 0x2f, 0xa5, 0x2e,
+ 0x5c, 0xbc, 0x9c, 0x0a, 0xaf, 0x2a, 0x99, 0x84, 0xaa, 0x94, 0x7f, 0x15, 0x07, 0x85, 0xce, 0x02,
+ 0xa9, 0x90, 0xaf, 0xb4, 0xbf, 0x31, 0xda, 0x9d, 0x9e, 0xd1, 0xde, 0x68, 0xb5, 0xd4, 0x4b, 0x28,
+ 0x0d, 0x89, 0xca, 0xe6, 0x8a, 0x1a, 0x43, 0x79, 0xc8, 0x54, 0x3b, 0x9d, 0x96, 0x51, 0x69, 0xd7,
+ 0xd5, 0x38, 0xca, 0x41, 0x9a, 0x7d, 0x75, 0x74, 0x35, 0x81, 0x8a, 0x00, 0xb5, 0x4e, 0xbb, 0x56,
+ 0xe9, 0x19, 0x95, 0x95, 0x15, 0x55, 0x41, 0x59, 0x48, 0xd6, 0x3a, 0x1b, 0xed, 0x9e, 0x9a, 0xa4,
+ 0xe2, 0x6b, 0x95, 0x5f, 0xa8, 0x69, 0xf6, 0x43, 0x6b, 0xab, 0x19, 0x04, 0x90, 0xea, 0xf6, 0xea,
+ 0xf5, 0xc6, 0xa6, 0x9a, 0xa5, 0x8d, 0xdd, 0x8d, 0x35, 0x15, 0x28, 0x5c, 0x77, 0x63, 0xcd, 0xd0,
+ 0xda, 0x3d, 0x35, 0x47, 0x7b, 0xda, 0xac, 0xe8, 0x5a, 0xa5, 0x5d, 0x6b, 0xa8, 0x79, 0x4a, 0xfa,
+ 0x45, 0x47, 0x67, 0xc8, 0x05, 0xde, 0xd3, 0x46, 0xbb, 0x67, 0xe8, 0x9d, 0xa7, 0x5d, 0xb5, 0xc8,
+ 0xe4, 0x9e, 0xe8, 0x75, 0xad, 0xd9, 0x54, 0xe7, 0x10, 0x82, 0x62, 0x53, 0x6b, 0x57, 0x5a, 0x46,
+ 0x28, 0xad, 0xd2, 0x09, 0xf1, 0x36, 0xd1, 0xe7, 0x65, 0x54, 0x80, 0x6c, 0x45, 0xd7, 0x2b, 0xdf,
+ 0x30, 0x44, 0x44, 0x3b, 0x5b, 0xed, 0x76, 0xda, 0xec, 0xeb, 0x0a, 0x25, 0xd2, 0xaf, 0x2a, 0xfb,
+ 0x9c, 0xa7, 0xdd, 0x75, 0x7b, 0xba, 0xd6, 0x5e, 0x61, 0xdf, 0x57, 0xcb, 0xf7, 0x40, 0xa1, 0x56,
+ 0x84, 0x32, 0xa0, 0x54, 0x36, 0x7a, 0x1d, 0xf5, 0x12, 0x9b, 0x4d, 0xad, 0xd2, 0xaa, 0xe8, 0x6a,
+ 0x8c, 0x72, 0xb7, 0x3b, 0x6d, 0x43, 0x7c, 0xc7, 0xcb, 0xdf, 0x27, 0xa0, 0x38, 0x5b, 0x22, 0x0b,
+ 0x6d, 0xf7, 0x4c, 0x13, 0x9b, 0x95, 0x3b, 0x62, 0xbb, 0xd3, 0xc0, 0x3c, 0xfe, 0xfa, 0x81, 0x79,
+ 0x98, 0xf3, 0x24, 0xde, 0x28, 0xe7, 0x79, 0x00, 0x19, 0x6b, 0xe2, 0xb1, 0x2d, 0xc4, 0xac, 0x38,
+ 0x51, 0xbd, 0x4a, 0xc9, 0xdf, 0xbf, 0x5a, 0x2c, 0x04, 0xf6, 0x08, 0x2f, 0xd5, 0x05, 0x51, 0x0f,
+ 0xd9, 0x68, 0x9a, 0x34, 0xd8, 0x9e, 0xb8, 0x3b, 0x86, 0x6f, 0xbf, 0xc4, 0xb3, 0x69, 0x12, 0x6b,
+ 0xef, 0xda, 0x2f, 0x31, 0xea, 0x40, 0x9e, 0x04, 0xdb, 0xd8, 0x33, 0x44, 0xe0, 0x96, 0x7a, 0x8d,
+ 0xc0, 0x2d, 0xc7, 0x10, 0x7a, 0x3c, 0x7a, 0xfb, 0x0a, 0x32, 0x1e, 0x36, 0xad, 0x8a, 0xdf, 0xd9,
+ 0x12, 0xa5, 0xdf, 0xdf, 0x88, 0x80, 0x4d, 0x02, 0xdb, 0x59, 0xda, 0x76, 0x06, 0x4b, 0x3d, 0x79,
+ 0xfb, 0x24, 0x77, 0xad, 0x14, 0x2a, 0xdf, 0x15, 0xcb, 0x9f, 0x83, 0xb4, 0xe6, 0xbe, 0x30, 0x1d,
+ 0xdb, 0xe2, 0x16, 0xc0, 0xfd, 0xac, 0x1a, 0xa3, 0x86, 0xaf, 0xd1, 0x10, 0x4e, 0x8d, 0x97, 0x7f,
+ 0x1d, 0x83, 0x4c, 0xd3, 0x21, 0xbb, 0x6c, 0xd9, 0x1f, 0x40, 0x7a, 0xcb, 0x21, 0xbb, 0x86, 0xa8,
+ 0x1f, 0xe4, 0xab, 0x25, 0x8a, 0xfc, 0xaf, 0xaf, 0x16, 0x53, 0x94, 0x45, 0xab, 0x1f, 0x84, 0xbf,
+ 0xf4, 0x14, 0x65, 0xd4, 0x2c, 0xb4, 0xc6, 0x8a, 0x47, 0xe2, 0x5a, 0x4f, 0x84, 0x9a, 0xb7, 0xce,
+ 0x71, 0x19, 0x15, 0xb9, 0xf8, 0x89, 0x00, 0xa0, 0x0d, 0x48, 0x0f, 0xcd, 0x00, 0xef, 0x9a, 0xfb,
+ 0x2c, 0x5e, 0x4a, 0x56, 0x7f, 0x26, 0xd6, 0xe8, 0xe3, 0xa1, 0x1d, 0x6c, 0x4f, 0xfa, 0x4b, 0x03,
+ 0x32, 0x5a, 0x0e, 0xd1, 0xad, 0xfe, 0xf4, 0xf7, 0xf2, 0x78, 0x67, 0xb8, 0x2c, 0x53, 0x7a, 0x1a,
+ 0xbe, 0x69, 0x75, 0x5d, 0x62, 0x95, 0x77, 0x21, 0xb7, 0x4a, 0xfa, 0xeb, 0x1e, 0x19, 0x52, 0x0f,
+ 0x83, 0x3e, 0x84, 0xd4, 0x33, 0xd2, 0x97, 0xd3, 0x4c, 0x54, 0x0b, 0xa2, 0x4c, 0x92, 0x5c, 0x25,
+ 0x7d, 0xad, 0xae, 0x27, 0x9f, 0x91, 0xbe, 0x66, 0xa1, 0xdb, 0x90, 0x1f, 0x10, 0x37, 0xf0, 0xec,
+ 0xfe, 0x24, 0xbc, 0xd0, 0x89, 0xcb, 0xc3, 0x21, 0x4a, 0x41, 0x25, 0x50, 0x7c, 0x87, 0x04, 0x62,
+ 0xc8, 0xb2, 0x94, 0xe0, 0x90, 0xa0, 0xfc, 0x97, 0x49, 0x40, 0x47, 0x8b, 0xc6, 0x34, 0xd3, 0xf5,
+ 0x59, 0x61, 0x95, 0x5b, 0x56, 0x3c, 0x22, 0x07, 0x9c, 0xc0, 0x4c, 0x6b, 0x05, 0x32, 0x63, 0x31,
+ 0x66, 0x76, 0xe0, 0x9f, 0x5a, 0x09, 0x8e, 0x4c, 0x50, 0x5a, 0x84, 0x14, 0x46, 0x2b, 0x90, 0x98,
+ 0x78, 0x76, 0x29, 0xcd, 0x96, 0xe7, 0xa7, 0x17, 0xa9, 0x6f, 0x2f, 0x6d, 0x78, 0x76, 0xc3, 0x0d,
+ 0xbc, 0x7d, 0x9d, 0x22, 0xa0, 0x9f, 0x43, 0x8a, 0x5f, 0xb1, 0x8a, 0xdb, 0x84, 0xc5, 0x63, 0xea,
+ 0x29, 0x5a, 0xa7, 0x69, 0x3b, 0xb8, 0xc9, 0xd8, 0xc2, 0x1b, 0x32, 0xf6, 0x85, 0x36, 0xc3, 0xf4,
+ 0x26, 0xcb, 0x86, 0xf2, 0xd9, 0x85, 0x86, 0xc2, 0xf7, 0x07, 0x1b, 0x0d, 0xc3, 0x8d, 0x85, 0x09,
+ 0xcf, 0x57, 0xf0, 0xae, 0xbf, 0x63, 0x8f, 0x8d, 0x91, 0xed, 0xfb, 0x34, 0xcf, 0xdb, 0x22, 0x1e,
+ 0xb6, 0x87, 0x2e, 0x8d, 0x38, 0xf8, 0x2d, 0x83, 0x3c, 0xda, 0xde, 0xa1, 0x6c, 0x6b, 0x9c, 0xab,
+ 0xc9, 0x99, 0x1e, 0xe3, 0x7d, 0x1f, 0xdd, 0x85, 0xc2, 0xae, 0xe9, 0x38, 0xd4, 0x11, 0xb4, 0x4d,
+ 0x97, 0xf8, 0xec, 0x52, 0x41, 0x6e, 0xf6, 0x59, 0x12, 0xba, 0x07, 0x45, 0xdb, 0x1d, 0x62, 0x3f,
+ 0xa8, 0xdb, 0x1e, 0x1e, 0x04, 0xce, 0x7e, 0x29, 0x1f, 0xe9, 0xe1, 0x10, 0x6d, 0xc1, 0x84, 0x5c,
+ 0x64, 0xdc, 0x48, 0x85, 0x04, 0x0d, 0x83, 0x58, 0x79, 0x4e, 0xa7, 0x3f, 0xd1, 0x97, 0x90, 0x64,
+ 0x89, 0xcf, 0xc5, 0x5c, 0xa4, 0xce, 0x85, 0xbe, 0x88, 0x7f, 0x16, 0x5b, 0xf8, 0x14, 0x32, 0x72,
+ 0x95, 0xa2, 0xf8, 0x49, 0x8e, 0x3f, 0x1f, 0xc5, 0xcf, 0x46, 0xe4, 0x56, 0x95, 0x4c, 0x4c, 0x8d,
+ 0xf3, 0xa3, 0x75, 0x55, 0xc9, 0x28, 0x6a, 0x72, 0x55, 0xc9, 0x24, 0xd5, 0x54, 0xf9, 0xaf, 0xe3,
+ 0x50, 0x98, 0xb9, 0x9c, 0x40, 0x1f, 0x41, 0xce, 0xc2, 0x34, 0x26, 0xe0, 0xee, 0x93, 0x17, 0x17,
+ 0x85, 0xeb, 0x8a, 0x10, 0x8e, 0xaa, 0x31, 0x71, 0xb2, 0x1a, 0x5b, 0xb3, 0xa5, 0xac, 0xfb, 0xe7,
+ 0xbc, 0x28, 0x61, 0xe5, 0x3a, 0x9a, 0x44, 0xcd, 0x7a, 0xf7, 0xe8, 0x56, 0x49, 0xbe, 0xc1, 0x56,
+ 0xa1, 0xca, 0x94, 0x3d, 0xd0, 0x7d, 0xed, 0xd2, 0xd4, 0x2d, 0x3a, 0x5f, 0xd6, 0x42, 0xd5, 0x8c,
+ 0x5d, 0x8b, 0xa9, 0x34, 0xaf, 0xd3, 0x9f, 0xab, 0x4a, 0x26, 0xae, 0x26, 0xca, 0x7f, 0x1f, 0x83,
+ 0xc2, 0x4c, 0xe1, 0xfe, 0xdc, 0xaa, 0xbb, 0x05, 0x79, 0x8a, 0x6c, 0x8c, 0xcd, 0x20, 0xc0, 0x1e,
+ 0xf7, 0x36, 0x21, 0x23, 0xa5, 0xac, 0x73, 0x02, 0xfa, 0x39, 0xa4, 0xc9, 0x58, 0x06, 0xb9, 0x87,
+ 0x4f, 0x07, 0xb9, 0x07, 0x6b, 0xdd, 0xcd, 0x0e, 0x67, 0x92, 0x45, 0x3b, 0x21, 0x33, 0x3d, 0xd3,
+ 0x58, 0x15, 0x55, 0x39, 0x72, 0xa6, 0xb1, 0x3a, 0xea, 0xef, 0xc6, 0x01, 0xba, 0x3b, 0x38, 0x18,
+ 0x6c, 0xb3, 0x39, 0x3c, 0x86, 0x9c, 0xcf, 0xbe, 0x8c, 0x48, 0x54, 0x70, 0xda, 0xcd, 0x28, 0x63,
+ 0x8e, 0x04, 0x03, 0xe0, 0x87, 0x2d, 0xa8, 0x34, 0x4d, 0x78, 0x79, 0x65, 0x24, 0xac, 0xfd, 0x7e,
+ 0x0c, 0x68, 0x88, 0x5d, 0xec, 0x99, 0x01, 0x36, 0xb6, 0x6d, 0x3f, 0x20, 0x43, 0xcf, 0x1c, 0xcd,
+ 0xd4, 0x41, 0x2f, 0x4b, 0xfa, 0x23, 0x49, 0x46, 0x9f, 0xc1, 0xd5, 0x90, 0xd7, 0x18, 0x99, 0x7b,
+ 0x46, 0x7f, 0x32, 0xd8, 0xc1, 0x01, 0x9f, 0x9a, 0xac, 0xf0, 0x5c, 0x09, 0x59, 0xd6, 0xcc, 0xbd,
+ 0x2a, 0x67, 0x40, 0x37, 0x21, 0xeb, 0x07, 0x66, 0x60, 0xb0, 0x25, 0x4e, 0x46, 0xd4, 0x9d, 0xa1,
+ 0xcd, 0x2c, 0x4f, 0xff, 0xf3, 0x18, 0xe4, 0x22, 0x37, 0x6c, 0xa8, 0x09, 0x19, 0x3e, 0x93, 0xb0,
+ 0x40, 0x73, 0xa6, 0x16, 0x22, 0x07, 0x5d, 0x28, 0x7b, 0x9c, 0xff, 0x2f, 0x1c, 0xe3, 0xff, 0xef,
+ 0xc3, 0x65, 0x3a, 0xa3, 0x2d, 0xcf, 0x64, 0x4f, 0x07, 0x0c, 0xdb, 0x72, 0x78, 0x1d, 0x21, 0x26,
+ 0x2b, 0x7b, 0x23, 0x73, 0xaf, 0x29, 0xa8, 0x9a, 0xe5, 0xe0, 0xf2, 0xdf, 0x26, 0x60, 0xfe, 0xb8,
+ 0x8b, 0xbc, 0x1f, 0x7a, 0xe4, 0xbf, 0x03, 0x88, 0x7f, 0xc9, 0x64, 0x33, 0x52, 0x42, 0x7a, 0x72,
+ 0xf0, 0x6a, 0x51, 0xdc, 0x2b, 0x8a, 0x74, 0x53, 0xab, 0xfb, 0xdf, 0xbf, 0x5a, 0xfc, 0xfc, 0x5c,
+ 0x47, 0x7c, 0xe4, 0xd1, 0xce, 0x92, 0x94, 0xd6, 0x55, 0x7f, 0x06, 0xce, 0xf2, 0x91, 0x09, 0x19,
+ 0x76, 0x36, 0xd0, 0x43, 0x9e, 0x5b, 0x42, 0x53, 0xbe, 0x23, 0x61, 0x9e, 0x54, 0xab, 0x9f, 0x3b,
+ 0xa8, 0x88, 0xf6, 0x48, 0x83, 0x0a, 0x86, 0xab, 0x59, 0x91, 0x28, 0x22, 0x75, 0x4a, 0x14, 0x71,
+ 0x07, 0x0a, 0x74, 0xa7, 0xd1, 0xbc, 0x1f, 0x0f, 0x02, 0x6c, 0xb1, 0x90, 0x4e, 0x96, 0xb5, 0xf3,
+ 0x94, 0xd4, 0x10, 0x14, 0xe1, 0x7d, 0xff, 0x47, 0x81, 0xf7, 0x4e, 0xb9, 0x28, 0x45, 0xdf, 0x1c,
+ 0x2a, 0x11, 0xfe, 0xec, 0xb5, 0xee, 0x5b, 0xf9, 0x79, 0x72, 0xa8, 0x6e, 0x18, 0xb9, 0x7d, 0x88,
+ 0x1f, 0x77, 0xfb, 0x30, 0x7b, 0x6d, 0x90, 0x38, 0xfe, 0xda, 0xe0, 0xad, 0xd4, 0x04, 0x3f, 0x9f,
+ 0x49, 0x9e, 0x2f, 0x52, 0xe6, 0x58, 0xf8, 0x9b, 0x38, 0x24, 0xd9, 0xe4, 0xd0, 0xd7, 0xa0, 0x58,
+ 0xd8, 0x1f, 0xbc, 0xd6, 0xa5, 0x00, 0x93, 0x3c, 0xcf, 0x9d, 0x80, 0x7c, 0xf5, 0x94, 0x78, 0x93,
+ 0x57, 0x4f, 0x75, 0xc8, 0x84, 0xd5, 0x37, 0xe5, 0x82, 0xd5, 0xb7, 0x50, 0x72, 0x9a, 0x28, 0x25,
+ 0xdf, 0x24, 0x51, 0x2a, 0x1f, 0xc4, 0xa0, 0x38, 0x7b, 0xc9, 0x8b, 0xbe, 0x86, 0x24, 0x7f, 0x81,
+ 0x14, 0xbb, 0x70, 0x12, 0xcf, 0x05, 0x11, 0x86, 0xd0, 0x77, 0x5b, 0x33, 0xb5, 0xb2, 0x7c, 0xf5,
+ 0x33, 0x91, 0x64, 0xdc, 0x3f, 0xf7, 0x6e, 0xa4, 0xeb, 0xec, 0x2f, 0xf5, 0x74, 0x35, 0x84, 0x94,
+ 0x65, 0xab, 0x5b, 0xa0, 0xba, 0x93, 0x11, 0x2b, 0xce, 0x18, 0x63, 0xec, 0x19, 0x43, 0xec, 0x72,
+ 0xaf, 0xa3, 0x17, 0xdc, 0xc9, 0xa8, 0x46, 0x1c, 0x7f, 0x1d, 0x7b, 0x2b, 0xd8, 0x2d, 0xff, 0x32,
+ 0x0f, 0xf9, 0xe8, 0x0d, 0x34, 0xba, 0x01, 0xb9, 0xb1, 0xe9, 0x05, 0x36, 0xab, 0x00, 0xed, 0x8b,
+ 0xf2, 0x7e, 0xb4, 0x09, 0x75, 0x21, 0xcb, 0x6f, 0xa9, 0x9b, 0x61, 0x51, 0x7d, 0xf9, 0x7c, 0xd7,
+ 0xdb, 0xe2, 0xa3, 0x19, 0x16, 0x36, 0x42, 0x9c, 0x85, 0xbf, 0x8a, 0x89, 0x92, 0x46, 0x17, 0x0a,
+ 0xb2, 0xe0, 0x84, 0x9b, 0xaf, 0x5b, 0xde, 0xd1, 0x67, 0x31, 0xd0, 0x13, 0x00, 0xd1, 0x15, 0x45,
+ 0x8c, 0x33, 0xc4, 0x07, 0x17, 0x1b, 0x33, 0x45, 0x8d, 0x80, 0xf0, 0xab, 0xe9, 0x85, 0xff, 0x4c,
+ 0x42, 0xb2, 0xe9, 0xd1, 0x48, 0xe8, 0x31, 0x28, 0x23, 0x62, 0xc9, 0xa0, 0xe0, 0xbc, 0xe0, 0x4c,
+ 0x76, 0x69, 0x8d, 0x58, 0xe1, 0xde, 0xa5, 0x20, 0xe8, 0x09, 0xa4, 0xfa, 0x64, 0xe2, 0x5a, 0xbe,
+ 0x08, 0x86, 0x3f, 0xbe, 0x10, 0x5c, 0x95, 0x89, 0x4a, 0x4f, 0xc2, 0x81, 0x16, 0xfe, 0x3b, 0x06,
+ 0x49, 0x46, 0x40, 0xdf, 0x42, 0x96, 0xb5, 0xf5, 0xa6, 0x31, 0xcc, 0xa7, 0x17, 0xc7, 0x8f, 0xf8,
+ 0x9b, 0x29, 0x1c, 0xf5, 0x8c, 0xb6, 0x1b, 0x18, 0xe2, 0x79, 0x5d, 0xd4, 0x53, 0x64, 0x6d, 0x37,
+ 0xe8, 0xf0, 0x17, 0x76, 0x37, 0x21, 0x4f, 0x2d, 0xd7, 0x92, 0x6c, 0x09, 0x16, 0x3d, 0xe6, 0x58,
+ 0x9b, 0x60, 0x59, 0x85, 0x1c, 0x27, 0xf2, 0x48, 0x8b, 0xfb, 0x82, 0x0b, 0xdc, 0xa3, 0x03, 0x97,
+ 0xa6, 0x63, 0x5a, 0xf8, 0xb3, 0x18, 0xa4, 0xb8, 0x4a, 0x50, 0x1b, 0x92, 0x7e, 0x60, 0x7a, 0x81,
+ 0x70, 0x85, 0x0f, 0x2f, 0x3e, 0xed, 0xd0, 0x45, 0x50, 0x18, 0x54, 0x9f, 0x86, 0xbf, 0xaf, 0x85,
+ 0xc6, 0x42, 0xe6, 0xf2, 0x2d, 0x50, 0xa8, 0x05, 0xa0, 0x2c, 0x24, 0xf5, 0x4a, 0x7b, 0xa5, 0xa1,
+ 0x5e, 0x42, 0x19, 0x50, 0x58, 0xc9, 0x2c, 0x86, 0x00, 0x52, 0x2b, 0x7a, 0x67, 0x63, 0xbd, 0xab,
+ 0xc6, 0xcb, 0x2f, 0x21, 0x1b, 0xea, 0x1e, 0x5d, 0x83, 0x2b, 0x1b, 0xed, 0x6a, 0x67, 0xa3, 0x5d,
+ 0x6f, 0xd4, 0x8d, 0x75, 0xbd, 0x51, 0x6b, 0xd4, 0xb5, 0xf6, 0x8a, 0x7a, 0x69, 0x96, 0xd0, 0xec,
+ 0xb4, 0x5a, 0x9d, 0xa7, 0x94, 0x10, 0x43, 0xf3, 0xa0, 0x76, 0x9a, 0xcd, 0x6e, 0xa3, 0x17, 0x61,
+ 0x8f, 0x47, 0x5a, 0xa7, 0xbc, 0x09, 0x34, 0x07, 0xb9, 0xda, 0x86, 0xae, 0x37, 0x78, 0xed, 0x4e,
+ 0x55, 0x16, 0xfe, 0x29, 0x0e, 0x19, 0xb9, 0x7d, 0x51, 0x23, 0x52, 0x7a, 0x3d, 0xf5, 0x4d, 0xca,
+ 0xec, 0xc4, 0x0f, 0x17, 0x5e, 0x3f, 0x82, 0x9c, 0xe9, 0x0d, 0x35, 0x6b, 0xaf, 0xcb, 0x16, 0x25,
+ 0x6a, 0x2e, 0x51, 0x02, 0xba, 0x01, 0x19, 0xd3, 0x1b, 0xd6, 0xc8, 0x44, 0x9c, 0xb6, 0xe1, 0xe9,
+ 0x23, 0x5b, 0xdf, 0xd2, 0xc1, 0x51, 0x85, 0xe4, 0x96, 0x27, 0xa3, 0xe0, 0x53, 0xdf, 0xae, 0x1c,
+ 0x5d, 0x50, 0x9d, 0x8b, 0xa2, 0xdb, 0x30, 0x53, 0x14, 0x16, 0x8f, 0x71, 0x45, 0x98, 0x13, 0xa5,
+ 0x94, 0x7f, 0x15, 0x03, 0x98, 0x3a, 0x17, 0x54, 0x04, 0xd0, 0x3b, 0x4f, 0x8d, 0xf6, 0xc6, 0x5a,
+ 0xb5, 0xa1, 0x0b, 0x13, 0xa8, 0xb4, 0x1f, 0xf3, 0x42, 0x65, 0xbd, 0xd1, 0xee, 0x36, 0x0c, 0xf6,
+ 0x1d, 0x47, 0x2a, 0xe4, 0xd7, 0x1b, 0x7a, 0x8d, 0xad, 0x0d, 0x6d, 0x49, 0xa0, 0x02, 0x64, 0x6b,
+ 0x1b, 0x6b, 0x0d, 0xa3, 0xae, 0x75, 0x7b, 0xbc, 0xa0, 0xdb, 0xee, 0x69, 0xad, 0x06, 0x2f, 0xe8,
+ 0xb6, 0x2a, 0x2b, 0x6a, 0x8a, 0xc2, 0xb5, 0x1a, 0x95, 0xba, 0x9a, 0xa6, 0x4b, 0xdb, 0xd4, 0xf4,
+ 0x6e, 0xcf, 0xd8, 0xac, 0xb4, 0x36, 0x1a, 0x6a, 0x86, 0xe2, 0xb7, 0x2a, 0xe1, 0x77, 0x96, 0xa2,
+ 0xb5, 0x7b, 0x8f, 0xc4, 0x27, 0x94, 0xff, 0x2e, 0x0e, 0xf3, 0xc7, 0xbd, 0x02, 0x42, 0x3d, 0x48,
+ 0xef, 0x9a, 0xd1, 0x50, 0xfa, 0x93, 0x8b, 0x3d, 0x23, 0x5a, 0x7a, 0x4a, 0xa5, 0x65, 0x70, 0x25,
+ 0xa0, 0x50, 0x13, 0x94, 0x2d, 0x8c, 0xad, 0x13, 0x1e, 0x74, 0xb3, 0x37, 0xf0, 0xfc, 0x3d, 0xbc,
+ 0xc0, 0xa4, 0xcc, 0x75, 0x1c, 0x98, 0xb6, 0xe3, 0x87, 0xc6, 0x85, 0xb1, 0xb5, 0xf0, 0xfb, 0x31,
+ 0x48, 0xb2, 0x0e, 0x50, 0x1b, 0x54, 0xdb, 0xb5, 0x03, 0xdb, 0x74, 0x0c, 0x0f, 0xfb, 0xc4, 0x79,
+ 0x81, 0x2d, 0x61, 0xb9, 0xe7, 0x2a, 0x28, 0xce, 0x09, 0x61, 0x5d, 0xc8, 0x86, 0x4f, 0x69, 0xe2,
+ 0xe7, 0x7f, 0x4a, 0xf3, 0x0f, 0x31, 0x40, 0x47, 0xdf, 0x3b, 0xa1, 0x2a, 0x14, 0x02, 0xcf, 0x1c,
+ 0xec, 0x60, 0xcb, 0xe0, 0x11, 0x0b, 0xd7, 0xe3, 0x19, 0x90, 0x79, 0x21, 0xd3, 0x65, 0x19, 0xff,
+ 0x5b, 0xd2, 0x57, 0x24, 0x8c, 0x4f, 0x9c, 0x1c, 0xc6, 0xdf, 0xfd, 0x4d, 0x28, 0xce, 0xbe, 0x65,
+ 0xa0, 0x0e, 0x6a, 0x7d, 0xa3, 0xda, 0xd2, 0x6a, 0xea, 0x25, 0xf4, 0x2e, 0x5c, 0xe5, 0xbf, 0x8d,
+ 0x4a, 0xbb, 0xce, 0xae, 0x25, 0x04, 0x29, 0x76, 0xb7, 0x2c, 0x33, 0x69, 0xe6, 0xbc, 0xe6, 0x41,
+ 0x7d, 0xd4, 0x6a, 0x19, 0xeb, 0xad, 0x8d, 0x2e, 0xff, 0xb3, 0xf9, 0x40, 0xbd, 0x54, 0xfd, 0xe0,
+ 0xbb, 0xff, 0xb8, 0x7e, 0xe9, 0xbb, 0x83, 0xeb, 0xb1, 0x7f, 0x3e, 0xb8, 0x1e, 0xfb, 0x97, 0x83,
+ 0xeb, 0xb1, 0x7f, 0x3f, 0xb8, 0x1e, 0xfb, 0xa3, 0x5f, 0x5f, 0xbf, 0xf4, 0x6d, 0x36, 0xfc, 0x2f,
+ 0x08, 0xff, 0x17, 0x00, 0x00, 0xff, 0xff, 0xf7, 0x87, 0x5c, 0x3e, 0x4d, 0x31, 0x00, 0x00,
}
diff --git a/pkg/sql/distsqlpb/processors.proto b/pkg/sql/distsqlpb/processors.proto
index c63c1ec74e94..aecb1c10e154 100644
--- a/pkg/sql/distsqlpb/processors.proto
+++ b/pkg/sql/distsqlpb/processors.proto
@@ -908,7 +908,7 @@ message ProjectSetSpec {
repeated Expression exprs = 1 [(gogoproto.nullable) = false];
// Column types for the generated values
- repeated bytes generated_columns = 2 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/sem/types.T"];
+ repeated bytes generated_columns = 2 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/types.T"];
// The number of columns each expression returns. Same length as exprs.
repeated uint32 num_cols_per_gen = 3;
diff --git a/pkg/sql/distsqlplan/aggregator_funcs.go b/pkg/sql/distsqlplan/aggregator_funcs.go
index 888d6509ad84..7ec9ee680dd4 100644
--- a/pkg/sql/distsqlplan/aggregator_funcs.go
+++ b/pkg/sql/distsqlplan/aggregator_funcs.go
@@ -17,7 +17,7 @@ package distsqlplan
import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// FinalStageInfo is a wrapper around an aggregation function performed
diff --git a/pkg/sql/distsqlplan/aggregator_funcs_test.go b/pkg/sql/distsqlplan/aggregator_funcs_test.go
index 3775ab1f3ea7..120bd7583108 100644
--- a/pkg/sql/distsqlplan/aggregator_funcs_test.go
+++ b/pkg/sql/distsqlplan/aggregator_funcs_test.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlplan/expression.go b/pkg/sql/distsqlplan/expression.go
index 51845009e557..15561e2f50eb 100644
--- a/pkg/sql/distsqlplan/expression.go
+++ b/pkg/sql/distsqlplan/expression.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/distsqlplan/physical_plan.go b/pkg/sql/distsqlplan/physical_plan.go
index dc5e67996146..61929f41a400 100644
--- a/pkg/sql/distsqlplan/physical_plan.go
+++ b/pkg/sql/distsqlplan/physical_plan.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/uuid"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlplan/physical_plan_test.go b/pkg/sql/distsqlplan/physical_plan_test.go
index f2cca2e7cc23..f266eb4e79b2 100644
--- a/pkg/sql/distsqlplan/physical_plan_test.go
+++ b/pkg/sql/distsqlplan/physical_plan_test.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/aggregator.go b/pkg/sql/distsqlrun/aggregator.go
index 54254de755f5..05a39e4f6843 100644
--- a/pkg/sql/distsqlrun/aggregator.go
+++ b/pkg/sql/distsqlrun/aggregator.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/distsqlrun/aggregator_test.go b/pkg/sql/distsqlrun/aggregator_test.go
index 1881335abf02..6b15df0dbc97 100644
--- a/pkg/sql/distsqlrun/aggregator_test.go
+++ b/pkg/sql/distsqlrun/aggregator_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/backfiller.go b/pkg/sql/distsqlrun/backfiller.go
index 561b5e953e4d..a52dd7228004 100644
--- a/pkg/sql/distsqlrun/backfiller.go
+++ b/pkg/sql/distsqlrun/backfiller.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/backfill"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/log/logtags"
diff --git a/pkg/sql/distsqlrun/base.go b/pkg/sql/distsqlrun/base.go
index 974ee9d2c7d4..68e8088eb060 100644
--- a/pkg/sql/distsqlrun/base.go
+++ b/pkg/sql/distsqlrun/base.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/syncutil"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
diff --git a/pkg/sql/distsqlrun/base_test.go b/pkg/sql/distsqlrun/base_test.go
index 88758b07a0ef..57e37f3747cf 100644
--- a/pkg/sql/distsqlrun/base_test.go
+++ b/pkg/sql/distsqlrun/base_test.go
@@ -21,8 +21,8 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/cluster_test.go b/pkg/sql/distsqlrun/cluster_test.go
index c3dd8f228c01..85562e28e2cc 100644
--- a/pkg/sql/distsqlrun/cluster_test.go
+++ b/pkg/sql/distsqlrun/cluster_test.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/storage/storagebase"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
diff --git a/pkg/sql/distsqlrun/column_exec_setup.go b/pkg/sql/distsqlrun/column_exec_setup.go
index 1cf57714a9da..652a40ff4e87 100644
--- a/pkg/sql/distsqlrun/column_exec_setup.go
+++ b/pkg/sql/distsqlrun/column_exec_setup.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
diff --git a/pkg/sql/distsqlrun/columnar_operators_test.go b/pkg/sql/distsqlrun/columnar_operators_test.go
index cf21d1dabf41..9a42ac595ec4 100644
--- a/pkg/sql/distsqlrun/columnar_operators_test.go
+++ b/pkg/sql/distsqlrun/columnar_operators_test.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/distsqlrun/columnar_utils_test.go b/pkg/sql/distsqlrun/columnar_utils_test.go
index 7153589881bc..3c88d1b13638 100644
--- a/pkg/sql/distsqlrun/columnar_utils_test.go
+++ b/pkg/sql/distsqlrun/columnar_utils_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/exec"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/columnarizer_test.go b/pkg/sql/distsqlrun/columnarizer_test.go
index c1d3fb1501f5..f90e36c750c7 100644
--- a/pkg/sql/distsqlrun/columnarizer_test.go
+++ b/pkg/sql/distsqlrun/columnarizer_test.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func BenchmarkColumnarize(b *testing.B) {
diff --git a/pkg/sql/distsqlrun/countrows.go b/pkg/sql/distsqlrun/countrows.go
index ee40d19562a4..658291f2b1d2 100644
--- a/pkg/sql/distsqlrun/countrows.go
+++ b/pkg/sql/distsqlrun/countrows.go
@@ -19,8 +19,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
"github.com/opentracing/opentracing-go"
)
diff --git a/pkg/sql/distsqlrun/distinct.go b/pkg/sql/distsqlrun/distinct.go
index d792bcbf9ddd..aa36986ddde0 100644
--- a/pkg/sql/distsqlrun/distinct.go
+++ b/pkg/sql/distsqlrun/distinct.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/distsqlrun/distinct_test.go b/pkg/sql/distsqlrun/distinct_test.go
index b80b22244ca6..5062cbe40557 100644
--- a/pkg/sql/distsqlrun/distinct_test.go
+++ b/pkg/sql/distsqlrun/distinct_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/expr.go b/pkg/sql/distsqlrun/expr.go
index c723add88437..19a59f7c3c55 100644
--- a/pkg/sql/distsqlrun/expr.go
+++ b/pkg/sql/distsqlrun/expr.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/transform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/expr_test.go b/pkg/sql/distsqlrun/expr_test.go
index 145a9bd2129c..d99b9dec38d8 100644
--- a/pkg/sql/distsqlrun/expr_test.go
+++ b/pkg/sql/distsqlrun/expr_test.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/flow_registry_test.go b/pkg/sql/distsqlrun/flow_registry_test.go
index aa71d8acdd76..8fda8f788176 100644
--- a/pkg/sql/distsqlrun/flow_registry_test.go
+++ b/pkg/sql/distsqlrun/flow_registry_test.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlrun/hashjoiner_test.go b/pkg/sql/distsqlrun/hashjoiner_test.go
index a18fb70b01cb..688cfdf0b0a4 100644
--- a/pkg/sql/distsqlrun/hashjoiner_test.go
+++ b/pkg/sql/distsqlrun/hashjoiner_test.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlrun/inbound.go b/pkg/sql/distsqlrun/inbound.go
index 1fe8257140f9..5f3c80b2edcb 100644
--- a/pkg/sql/distsqlrun/inbound.go
+++ b/pkg/sql/distsqlrun/inbound.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/distsqlrun/inbound_test.go b/pkg/sql/distsqlrun/inbound_test.go
index 7147e36b7c8b..fbef15ac6d1a 100644
--- a/pkg/sql/distsqlrun/inbound_test.go
+++ b/pkg/sql/distsqlrun/inbound_test.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlrun/indexjoiner_test.go b/pkg/sql/distsqlrun/indexjoiner_test.go
index d79c2df8252d..7ea8aa8027ed 100644
--- a/pkg/sql/distsqlrun/indexjoiner_test.go
+++ b/pkg/sql/distsqlrun/indexjoiner_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlrun/input_sync.go b/pkg/sql/distsqlrun/input_sync.go
index 22167396c378..b9f2edfaf4a7 100644
--- a/pkg/sql/distsqlrun/input_sync.go
+++ b/pkg/sql/distsqlrun/input_sync.go
@@ -22,8 +22,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/input_sync_test.go b/pkg/sql/distsqlrun/input_sync_test.go
index b6e4db9350e5..940fbb3a26a5 100644
--- a/pkg/sql/distsqlrun/input_sync_test.go
+++ b/pkg/sql/distsqlrun/input_sync_test.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/pkg/errors"
diff --git a/pkg/sql/distsqlrun/joiner_test.go b/pkg/sql/distsqlrun/joiner_test.go
index 708f93462d57..3b7129bac9e0 100644
--- a/pkg/sql/distsqlrun/joiner_test.go
+++ b/pkg/sql/distsqlrun/joiner_test.go
@@ -17,8 +17,8 @@ package distsqlrun
import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/joinerbase.go b/pkg/sql/distsqlrun/joinerbase.go
index 8e76de02fd5e..475a80fe4b39 100644
--- a/pkg/sql/distsqlrun/joinerbase.go
+++ b/pkg/sql/distsqlrun/joinerbase.go
@@ -17,8 +17,8 @@ package distsqlrun
import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/joinreader.go b/pkg/sql/distsqlrun/joinreader.go
index 0b7313c66490..19eee9bb788d 100644
--- a/pkg/sql/distsqlrun/joinreader.go
+++ b/pkg/sql/distsqlrun/joinreader.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
diff --git a/pkg/sql/distsqlrun/joinreader_test.go b/pkg/sql/distsqlrun/joinreader_test.go
index 20c21e3b6635..0b03156f156f 100644
--- a/pkg/sql/distsqlrun/joinreader_test.go
+++ b/pkg/sql/distsqlrun/joinreader_test.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlrun/materializer.go b/pkg/sql/distsqlrun/materializer.go
index daf31dab84aa..ff6f85bc4fe8 100644
--- a/pkg/sql/distsqlrun/materializer.go
+++ b/pkg/sql/distsqlrun/materializer.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec"
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/lib/pq/oid"
)
diff --git a/pkg/sql/distsqlrun/materializer_test.go b/pkg/sql/distsqlrun/materializer_test.go
index 86ff21588895..12b8e2e6155e 100644
--- a/pkg/sql/distsqlrun/materializer_test.go
+++ b/pkg/sql/distsqlrun/materializer_test.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/mergejoiner_test.go b/pkg/sql/distsqlrun/mergejoiner_test.go
index 2979a837d264..6bcab221d301 100644
--- a/pkg/sql/distsqlrun/mergejoiner_test.go
+++ b/pkg/sql/distsqlrun/mergejoiner_test.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/noop_test.go b/pkg/sql/distsqlrun/noop_test.go
index f6a50305c1e4..74667f6da9cd 100644
--- a/pkg/sql/distsqlrun/noop_test.go
+++ b/pkg/sql/distsqlrun/noop_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func BenchmarkNoop(b *testing.B) {
diff --git a/pkg/sql/distsqlrun/outbox.go b/pkg/sql/distsqlrun/outbox.go
index 7655f1702dfe..cc3d65b3dd68 100644
--- a/pkg/sql/distsqlrun/outbox.go
+++ b/pkg/sql/distsqlrun/outbox.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/contextutil"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
diff --git a/pkg/sql/distsqlrun/outbox_test.go b/pkg/sql/distsqlrun/outbox_test.go
index 5453d21b53ee..a2e768ecbf8a 100644
--- a/pkg/sql/distsqlrun/outbox_test.go
+++ b/pkg/sql/distsqlrun/outbox_test.go
@@ -27,8 +27,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/stop"
diff --git a/pkg/sql/distsqlrun/processor_utils_test.go b/pkg/sql/distsqlrun/processor_utils_test.go
index 25c2e12d7e1c..c8e385b3cb80 100644
--- a/pkg/sql/distsqlrun/processor_utils_test.go
+++ b/pkg/sql/distsqlrun/processor_utils_test.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type ProcessorTestConfig struct {
diff --git a/pkg/sql/distsqlrun/processors.go b/pkg/sql/distsqlrun/processors.go
index aba7fbc9abfb..3ed3f313f68f 100644
--- a/pkg/sql/distsqlrun/processors.go
+++ b/pkg/sql/distsqlrun/processors.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/distsqlrun/processors_test.go b/pkg/sql/distsqlrun/processors_test.go
index 114574bc0a59..02b86fbc17ca 100644
--- a/pkg/sql/distsqlrun/processors_test.go
+++ b/pkg/sql/distsqlrun/processors_test.go
@@ -29,8 +29,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
diff --git a/pkg/sql/distsqlrun/project_set_test.go b/pkg/sql/distsqlrun/project_set_test.go
index d74e24041462..326deb7217c8 100644
--- a/pkg/sql/distsqlrun/project_set_test.go
+++ b/pkg/sql/distsqlrun/project_set_test.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/routers.go b/pkg/sql/distsqlrun/routers.go
index 8d91c2a0302b..da4aa4d1145f 100644
--- a/pkg/sql/distsqlrun/routers.go
+++ b/pkg/sql/distsqlrun/routers.go
@@ -29,8 +29,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/cockroachdb/cockroach/pkg/util/syncutil"
diff --git a/pkg/sql/distsqlrun/routers_test.go b/pkg/sql/distsqlrun/routers_test.go
index f648213d5d0e..910d0a57782c 100644
--- a/pkg/sql/distsqlrun/routers_test.go
+++ b/pkg/sql/distsqlrun/routers_test.go
@@ -30,8 +30,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
diff --git a/pkg/sql/distsqlrun/sample_aggregator.go b/pkg/sql/distsqlrun/sample_aggregator.go
index baef8d3f70b9..980155bc25af 100644
--- a/pkg/sql/distsqlrun/sample_aggregator.go
+++ b/pkg/sql/distsqlrun/sample_aggregator.go
@@ -24,9 +24,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
diff --git a/pkg/sql/distsqlrun/sample_aggregator_test.go b/pkg/sql/distsqlrun/sample_aggregator_test.go
index 21a182b074cf..09c266265469 100644
--- a/pkg/sql/distsqlrun/sample_aggregator_test.go
+++ b/pkg/sql/distsqlrun/sample_aggregator_test.go
@@ -24,10 +24,10 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/distsqlrun/sampler.go b/pkg/sql/distsqlrun/sampler.go
index a238adddb68e..44589940044c 100644
--- a/pkg/sql/distsqlrun/sampler.go
+++ b/pkg/sql/distsqlrun/sampler.go
@@ -23,9 +23,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
diff --git a/pkg/sql/distsqlrun/sampler_test.go b/pkg/sql/distsqlrun/sampler_test.go
index c7ea1394ce80..8a161e476b54 100644
--- a/pkg/sql/distsqlrun/sampler_test.go
+++ b/pkg/sql/distsqlrun/sampler_test.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/distsqlrun/scrub_tablereader.go b/pkg/sql/distsqlrun/scrub_tablereader.go
index f8193c95410b..db4c32a2b26a 100644
--- a/pkg/sql/distsqlrun/scrub_tablereader.go
+++ b/pkg/sql/distsqlrun/scrub_tablereader.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
diff --git a/pkg/sql/distsqlrun/set_op_test.go b/pkg/sql/distsqlrun/set_op_test.go
index e4ddf8fd8873..684460b2df41 100644
--- a/pkg/sql/distsqlrun/set_op_test.go
+++ b/pkg/sql/distsqlrun/set_op_test.go
@@ -17,8 +17,8 @@ package distsqlrun
import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
)
diff --git a/pkg/sql/distsqlrun/sorter_test.go b/pkg/sql/distsqlrun/sorter_test.go
index 703d1b176750..8d9a346d62f4 100644
--- a/pkg/sql/distsqlrun/sorter_test.go
+++ b/pkg/sql/distsqlrun/sorter_test.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
diff --git a/pkg/sql/distsqlrun/stream_data_test.go b/pkg/sql/distsqlrun/stream_data_test.go
index 3c33a2db2ce4..6289e894c751 100644
--- a/pkg/sql/distsqlrun/stream_data_test.go
+++ b/pkg/sql/distsqlrun/stream_data_test.go
@@ -21,8 +21,8 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/distsqlrun/stream_decoder.go b/pkg/sql/distsqlrun/stream_decoder.go
index d2c3ff22b38e..f1781c56e823 100644
--- a/pkg/sql/distsqlrun/stream_decoder.go
+++ b/pkg/sql/distsqlrun/stream_decoder.go
@@ -16,8 +16,8 @@ package distsqlrun
import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/stream_encoder.go b/pkg/sql/distsqlrun/stream_encoder.go
index 8fdbf55d23c1..fedd2150ab94 100644
--- a/pkg/sql/distsqlrun/stream_encoder.go
+++ b/pkg/sql/distsqlrun/stream_encoder.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/stream_group_accumulator.go b/pkg/sql/distsqlrun/stream_group_accumulator.go
index a77134256d4c..7e717dc32373 100644
--- a/pkg/sql/distsqlrun/stream_group_accumulator.go
+++ b/pkg/sql/distsqlrun/stream_group_accumulator.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/distsqlrun/stream_merger.go b/pkg/sql/distsqlrun/stream_merger.go
index e5011db78e5a..6c2c64c6cf12 100644
--- a/pkg/sql/distsqlrun/stream_merger.go
+++ b/pkg/sql/distsqlrun/stream_merger.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/pkg/errors"
diff --git a/pkg/sql/distsqlrun/tablereader.go b/pkg/sql/distsqlrun/tablereader.go
index d8c8b713e69d..75e2c6a2ec70 100644
--- a/pkg/sql/distsqlrun/tablereader.go
+++ b/pkg/sql/distsqlrun/tablereader.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/row"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
diff --git a/pkg/sql/distsqlrun/utils_test.go b/pkg/sql/distsqlrun/utils_test.go
index 3b6cf9f3478e..bff94cca82cc 100644
--- a/pkg/sql/distsqlrun/utils_test.go
+++ b/pkg/sql/distsqlrun/utils_test.go
@@ -28,8 +28,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/distsqlrun/values.go b/pkg/sql/distsqlrun/values.go
index 9966908995a7..84f641d30b96 100644
--- a/pkg/sql/distsqlrun/values.go
+++ b/pkg/sql/distsqlrun/values.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// valuesProcessor is a processor that has no inputs and generates "pre-canned"
diff --git a/pkg/sql/distsqlrun/values_test.go b/pkg/sql/distsqlrun/values_test.go
index 5db8c1fa0b81..47762cfbf5f0 100644
--- a/pkg/sql/distsqlrun/values_test.go
+++ b/pkg/sql/distsqlrun/values_test.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/distsqlrun/windower.go b/pkg/sql/distsqlrun/windower.go
index 1117f0bd9e91..2e293f74b080 100644
--- a/pkg/sql/distsqlrun/windower.go
+++ b/pkg/sql/distsqlrun/windower.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/distsqlrun/zigzagjoiner.go b/pkg/sql/distsqlrun/zigzagjoiner.go
index 06dc3d66bd3e..9c4d9fdf74fb 100644
--- a/pkg/sql/distsqlrun/zigzagjoiner.go
+++ b/pkg/sql/distsqlrun/zigzagjoiner.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/distsqlrun/zigzagjoiner_test.go b/pkg/sql/distsqlrun/zigzagjoiner_test.go
index 743a4e606c2f..6956dd9998f0 100644
--- a/pkg/sql/distsqlrun/zigzagjoiner_test.go
+++ b/pkg/sql/distsqlrun/zigzagjoiner_test.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/exec/execgen/cmd/execgen/projection_ops_gen.go b/pkg/sql/exec/execgen/cmd/execgen/projection_ops_gen.go
index a43bb5f6f3d0..a61893d1f2c1 100644
--- a/pkg/sql/exec/execgen/cmd/execgen/projection_ops_gen.go
+++ b/pkg/sql/exec/execgen/cmd/execgen/projection_ops_gen.go
@@ -32,7 +32,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/exec/execgen/cmd/execgen/rowstovec_gen.go b/pkg/sql/exec/execgen/cmd/execgen/rowstovec_gen.go
index 179a27ceefea..461963fed302 100644
--- a/pkg/sql/exec/execgen/cmd/execgen/rowstovec_gen.go
+++ b/pkg/sql/exec/execgen/cmd/execgen/rowstovec_gen.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Width is used when a SemanticType has a width that has an associated distinct
diff --git a/pkg/sql/exec/execgen/cmd/execgen/selection_ops_gen.go b/pkg/sql/exec/execgen/cmd/execgen/selection_ops_gen.go
index 09b040dae8ef..8ce3cd2d5d9c 100644
--- a/pkg/sql/exec/execgen/cmd/execgen/selection_ops_gen.go
+++ b/pkg/sql/exec/execgen/cmd/execgen/selection_ops_gen.go
@@ -32,7 +32,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/exec/projection_ops_test.go b/pkg/sql/exec/projection_ops_test.go
index 8404905481fc..7392753c87a2 100644
--- a/pkg/sql/exec/projection_ops_test.go
+++ b/pkg/sql/exec/projection_ops_test.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/exec/rowstovec_test.go b/pkg/sql/exec/rowstovec_test.go
index b9455b0ff54b..13f6124bd853 100644
--- a/pkg/sql/exec/rowstovec_test.go
+++ b/pkg/sql/exec/rowstovec_test.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
)
var alloc = sqlbase.DatumAlloc{}
diff --git a/pkg/sql/exec/rowstovec_tmpl.go b/pkg/sql/exec/rowstovec_tmpl.go
index aeb8f294fc69..e0ab4f5e0ee2 100644
--- a/pkg/sql/exec/rowstovec_tmpl.go
+++ b/pkg/sql/exec/rowstovec_tmpl.go
@@ -30,8 +30,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// {{/*
diff --git a/pkg/sql/exec/selection_ops_test.go b/pkg/sql/exec/selection_ops_test.go
index 8bdff72904e2..b76c4e72482f 100644
--- a/pkg/sql/exec/selection_ops_test.go
+++ b/pkg/sql/exec/selection_ops_test.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/coldata"
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/exec/types/conv/conv.go b/pkg/sql/exec/types/conv/conv.go
index 8652e85df2e8..58b7cdf982be 100644
--- a/pkg/sql/exec/types/conv/conv.go
+++ b/pkg/sql/exec/types/conv/conv.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/exec_util.go b/pkg/sql/exec_util.go
index 1899a156d6f7..ae65066008cd 100644
--- a/pkg/sql/exec_util.go
+++ b/pkg/sql/exec_util.go
@@ -47,11 +47,11 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/querycache"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
diff --git a/pkg/sql/expr_filter.go b/pkg/sql/expr_filter.go
index dbd05ad6c23e..29bc10486d5c 100644
--- a/pkg/sql/expr_filter.go
+++ b/pkg/sql/expr_filter.go
@@ -20,7 +20,7 @@ import (
"fmt"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/filter.go b/pkg/sql/filter.go
index fb6a88d3a7b0..b98c7ef1429b 100644
--- a/pkg/sql/filter.go
+++ b/pkg/sql/filter.go
@@ -18,7 +18,7 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// filterNode implements a filtering stage. It is intended to be used
diff --git a/pkg/sql/group.go b/pkg/sql/group.go
index 38d7dfc136e3..2d35f1b408d3 100644
--- a/pkg/sql/group.go
+++ b/pkg/sql/group.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/information_schema.go b/pkg/sql/information_schema.go
index bdd224bf39d5..af8a85c9a25e 100644
--- a/pkg/sql/information_schema.go
+++ b/pkg/sql/information_schema.go
@@ -24,9 +24,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/security"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/sql/vtable"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/insert.go b/pkg/sql/insert.go
index ca36514c16dc..f425263fc6ea 100644
--- a/pkg/sql/insert.go
+++ b/pkg/sql/insert.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
)
diff --git a/pkg/sql/join.go b/pkg/sql/join.go
index e4e50ddc4e52..d3e42c487d1e 100644
--- a/pkg/sql/join.go
+++ b/pkg/sql/join.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/join_predicate.go b/pkg/sql/join_predicate.go
index bfa6c51aec18..818c5425b384 100644
--- a/pkg/sql/join_predicate.go
+++ b/pkg/sql/join_predicate.go
@@ -17,8 +17,8 @@ package sql
import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/limit.go b/pkg/sql/limit.go
index bbdf437868df..2701d6364065 100644
--- a/pkg/sql/limit.go
+++ b/pkg/sql/limit.go
@@ -20,7 +20,7 @@ import (
"math"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// limitNode represents a node that limits the number of rows
diff --git a/pkg/sql/opt/cat/column.go b/pkg/sql/opt/cat/column.go
index c6d6c14b9492..b0ad764c719c 100644
--- a/pkg/sql/opt/cat/column.go
+++ b/pkg/sql/opt/cat/column.go
@@ -16,7 +16,7 @@ package cat
import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Column is an interface to a table column, exposing only the information
diff --git a/pkg/sql/opt/column_meta.go b/pkg/sql/opt/column_meta.go
index a4a3fcc2d917..4971a46c5f1d 100644
--- a/pkg/sql/opt/column_meta.go
+++ b/pkg/sql/opt/column_meta.go
@@ -15,7 +15,7 @@
package opt
import (
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/constraint/constraint.go b/pkg/sql/opt/constraint/constraint.go
index 9f3632859c6f..a008ea6cf5da 100644
--- a/pkg/sql/opt/constraint/constraint.go
+++ b/pkg/sql/opt/constraint/constraint.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/exec/execbuilder/scalar_builder.go b/pkg/sql/opt/exec/execbuilder/scalar_builder.go
index facd937dba7b..02be459c32ae 100644
--- a/pkg/sql/opt/exec/execbuilder/scalar_builder.go
+++ b/pkg/sql/opt/exec/execbuilder/scalar_builder.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/opt/exec/factory.go b/pkg/sql/opt/exec/factory.go
index 1dd3f1c5b1c1..d3827cba58fb 100644
--- a/pkg/sql/opt/exec/factory.go
+++ b/pkg/sql/opt/exec/factory.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/idxconstraint/index_constraints.go b/pkg/sql/opt/idxconstraint/index_constraints.go
index 3040eab7e125..aee4fcc42dd1 100644
--- a/pkg/sql/opt/idxconstraint/index_constraints.go
+++ b/pkg/sql/opt/idxconstraint/index_constraints.go
@@ -25,7 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/norm"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/json"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/idxconstraint/index_constraints_test.go b/pkg/sql/opt/idxconstraint/index_constraints_test.go
index 342760c10146..2b7c5d5aef64 100644
--- a/pkg/sql/opt/idxconstraint/index_constraints_test.go
+++ b/pkg/sql/opt/idxconstraint/index_constraints_test.go
@@ -32,7 +32,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/optgen/exprgen"
"github.com/cockroachdb/cockroach/pkg/sql/opt/testutils"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/datadriven"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/opt/memo/constraint_builder.go b/pkg/sql/opt/memo/constraint_builder.go
index 9081e97a1f0b..1041a8ca0d48 100644
--- a/pkg/sql/opt/memo/constraint_builder.go
+++ b/pkg/sql/opt/memo/constraint_builder.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/constraint"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/memo/expr.go b/pkg/sql/opt/memo/expr.go
index bdc30a7d88ce..2b3ccaf975a5 100644
--- a/pkg/sql/opt/memo/expr.go
+++ b/pkg/sql/opt/memo/expr.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/memo/expr_format.go b/pkg/sql/opt/memo/expr_format.go
index 7345aaa48ac9..c2f2fcfae665 100644
--- a/pkg/sql/opt/memo/expr_format.go
+++ b/pkg/sql/opt/memo/expr_format.go
@@ -24,7 +24,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props"
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/treeprinter"
)
diff --git a/pkg/sql/opt/memo/interner.go b/pkg/sql/opt/memo/interner.go
index b858f022f2eb..7b521f794c58 100644
--- a/pkg/sql/opt/memo/interner.go
+++ b/pkg/sql/opt/memo/interner.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
)
diff --git a/pkg/sql/opt/memo/interner_test.go b/pkg/sql/opt/memo/interner_test.go
index 5f965108532f..900703bd2ed7 100644
--- a/pkg/sql/opt/memo/interner_test.go
+++ b/pkg/sql/opt/memo/interner_test.go
@@ -24,7 +24,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt"
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/timeofday"
"golang.org/x/tools/container/intsets"
diff --git a/pkg/sql/opt/memo/statistics_builder.go b/pkg/sql/opt/memo/statistics_builder.go
index 86aa48d72031..56a0da26992b 100644
--- a/pkg/sql/opt/memo/statistics_builder.go
+++ b/pkg/sql/opt/memo/statistics_builder.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/json"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/opt/memo/typing.go b/pkg/sql/opt/memo/typing.go
index dbafda259169..a7e489ea179a 100644
--- a/pkg/sql/opt/memo/typing.go
+++ b/pkg/sql/opt/memo/typing.go
@@ -19,7 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/memo/typing_test.go b/pkg/sql/opt/memo/typing_test.go
index 76872e185eaf..b36d4a46da92 100644
--- a/pkg/sql/opt/memo/typing_test.go
+++ b/pkg/sql/opt/memo/typing_test.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestTyping(t *testing.T) {
diff --git a/pkg/sql/opt/metadata.go b/pkg/sql/opt/metadata.go
index 5197360210fb..d190e62fee72 100644
--- a/pkg/sql/opt/metadata.go
+++ b/pkg/sql/opt/metadata.go
@@ -24,7 +24,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// SchemaID uniquely identifies the usage of a schema within the scope of a
diff --git a/pkg/sql/opt/metadata_test.go b/pkg/sql/opt/metadata_test.go
index 16c9a1728423..5cd6bc886cc5 100644
--- a/pkg/sql/opt/metadata_test.go
+++ b/pkg/sql/opt/metadata_test.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/testutils/testcat"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/norm/custom_funcs.go b/pkg/sql/opt/norm/custom_funcs.go
index 0c7cd3f4bd0d..223c86b5bb86 100644
--- a/pkg/sql/opt/norm/custom_funcs.go
+++ b/pkg/sql/opt/norm/custom_funcs.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/json"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/opt/norm/decorrelate.go b/pkg/sql/opt/norm/decorrelate.go
index 89a8756d96cd..6822cca8dda3 100644
--- a/pkg/sql/opt/norm/decorrelate.go
+++ b/pkg/sql/opt/norm/decorrelate.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props"
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/norm/factory.go b/pkg/sql/opt/norm/factory.go
index 8403744c3981..9cfca57d5581 100644
--- a/pkg/sql/opt/norm/factory.go
+++ b/pkg/sql/opt/norm/factory.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/norm/factory_test.go b/pkg/sql/opt/norm/factory_test.go
index fc1e9200af51..b129c03531ff 100644
--- a/pkg/sql/opt/norm/factory_test.go
+++ b/pkg/sql/opt/norm/factory_test.go
@@ -25,7 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/testutils/testcat"
"github.com/cockroachdb/cockroach/pkg/sql/opt/xform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// TestSimplifyFilters tests factory.SimplifyFilters. It's hard to fully test
diff --git a/pkg/sql/opt/norm/prune_cols.go b/pkg/sql/opt/norm/prune_cols.go
index 70272b240549..80608f70a07e 100644
--- a/pkg/sql/opt/norm/prune_cols.go
+++ b/pkg/sql/opt/norm/prune_cols.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/opt/props"
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// NeededGroupingCols returns the columns needed by a grouping operator's
diff --git a/pkg/sql/opt/operator.go b/pkg/sql/opt/operator.go
index 575a6638b1e9..0ce50e96a0bb 100644
--- a/pkg/sql/opt/operator.go
+++ b/pkg/sql/opt/operator.go
@@ -18,7 +18,7 @@ import (
"fmt"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Operator describes the type of operation that a memo expression performs.
diff --git a/pkg/sql/opt/optbuilder/builder_test.go b/pkg/sql/opt/optbuilder/builder_test.go
index ff960e0591e8..25679c51e000 100644
--- a/pkg/sql/opt/optbuilder/builder_test.go
+++ b/pkg/sql/opt/optbuilder/builder_test.go
@@ -30,7 +30,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/xform"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/datadriven"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/opt/optbuilder/create_table.go b/pkg/sql/opt/optbuilder/create_table.go
index f33c398710ac..43451002d9ea 100644
--- a/pkg/sql/opt/optbuilder/create_table.go
+++ b/pkg/sql/opt/optbuilder/create_table.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/optbuilder/groupby.go b/pkg/sql/opt/optbuilder/groupby.go
index 5fea20478182..adf7bc32f737 100644
--- a/pkg/sql/opt/optbuilder/groupby.go
+++ b/pkg/sql/opt/optbuilder/groupby.go
@@ -46,7 +46,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// groupby information stored in scopes.
diff --git a/pkg/sql/opt/optbuilder/insert.go b/pkg/sql/opt/optbuilder/insert.go
index e6d1194d054b..a20399957b92 100644
--- a/pkg/sql/opt/optbuilder/insert.go
+++ b/pkg/sql/opt/optbuilder/insert.go
@@ -24,7 +24,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/optbuilder/join.go b/pkg/sql/opt/optbuilder/join.go
index c8138065919f..d89078e9e393 100644
--- a/pkg/sql/opt/optbuilder/join.go
+++ b/pkg/sql/opt/optbuilder/join.go
@@ -22,9 +22,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/optbuilder/limit.go b/pkg/sql/opt/optbuilder/limit.go
index 8d455fb440f5..692d4a8b31e8 100644
--- a/pkg/sql/opt/optbuilder/limit.go
+++ b/pkg/sql/opt/optbuilder/limit.go
@@ -17,7 +17,7 @@ package optbuilder
import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// buildLimit adds Limit and Offset operators according to the Limit clause.
diff --git a/pkg/sql/opt/optbuilder/mutation_builder.go b/pkg/sql/opt/optbuilder/mutation_builder.go
index 5b044a9839a4..7a673589aaa6 100644
--- a/pkg/sql/opt/optbuilder/mutation_builder.go
+++ b/pkg/sql/opt/optbuilder/mutation_builder.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/optbuilder/orderby.go b/pkg/sql/opt/optbuilder/orderby.go
index fc290346abf8..8b2d37d84374 100644
--- a/pkg/sql/opt/optbuilder/orderby.go
+++ b/pkg/sql/opt/optbuilder/orderby.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/cat"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// analyzeOrderBy analyzes an Ordering physical property from the ORDER BY
diff --git a/pkg/sql/opt/optbuilder/project.go b/pkg/sql/opt/optbuilder/project.go
index c60343dabf1e..eba768653444 100644
--- a/pkg/sql/opt/optbuilder/project.go
+++ b/pkg/sql/opt/optbuilder/project.go
@@ -19,7 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// constructProjectForScope constructs a projection if it will result in a
diff --git a/pkg/sql/opt/optbuilder/scalar.go b/pkg/sql/opt/optbuilder/scalar.go
index 515dedf0d68b..51b4a90d2810 100644
--- a/pkg/sql/opt/optbuilder/scalar.go
+++ b/pkg/sql/opt/optbuilder/scalar.go
@@ -24,9 +24,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/norm"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// buildScalar builds a set of memo groups that represent the given scalar
diff --git a/pkg/sql/opt/optbuilder/scope.go b/pkg/sql/opt/optbuilder/scope.go
index 24d6a56d4f7d..1d30cfe6456c 100644
--- a/pkg/sql/opt/optbuilder/scope.go
+++ b/pkg/sql/opt/optbuilder/scope.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// scopeOrdinal identifies an ordinal position with a list of scope columns.
diff --git a/pkg/sql/opt/optbuilder/scope_column.go b/pkg/sql/opt/optbuilder/scope_column.go
index f69fda882588..2b074d8dcbbf 100644
--- a/pkg/sql/opt/optbuilder/scope_column.go
+++ b/pkg/sql/opt/optbuilder/scope_column.go
@@ -18,7 +18,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// scopeColumn holds per-column information that is scoped to a particular
diff --git a/pkg/sql/opt/optbuilder/select.go b/pkg/sql/opt/optbuilder/select.go
index 3e392afce8cc..46bb1d323181 100644
--- a/pkg/sql/opt/optbuilder/select.go
+++ b/pkg/sql/opt/optbuilder/select.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/opt/optbuilder/srfs.go b/pkg/sql/opt/optbuilder/srfs.go
index 19c2aaa31ccb..2abe0ec5e9fe 100644
--- a/pkg/sql/opt/optbuilder/srfs.go
+++ b/pkg/sql/opt/optbuilder/srfs.go
@@ -19,7 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// srf represents an srf expression in an expression tree
diff --git a/pkg/sql/opt/optbuilder/subquery.go b/pkg/sql/opt/optbuilder/subquery.go
index 47b9422a24af..8020ba40ff26 100644
--- a/pkg/sql/opt/optbuilder/subquery.go
+++ b/pkg/sql/opt/optbuilder/subquery.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// subquery represents a subquery expression in an expression tree
diff --git a/pkg/sql/opt/optbuilder/union.go b/pkg/sql/opt/optbuilder/union.go
index 523ea260c1c7..e6b5bd67fcbf 100644
--- a/pkg/sql/opt/optbuilder/union.go
+++ b/pkg/sql/opt/optbuilder/union.go
@@ -19,7 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// buildUnion builds a set of memo groups that represent the given union
diff --git a/pkg/sql/opt/optbuilder/update.go b/pkg/sql/opt/optbuilder/update.go
index 7bd0fe39a8fa..7d4681181c77 100644
--- a/pkg/sql/opt/optbuilder/update.go
+++ b/pkg/sql/opt/optbuilder/update.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// buildUpdate builds a memo group for an UpdateOp expression. First, an input
diff --git a/pkg/sql/opt/optbuilder/util.go b/pkg/sql/opt/optbuilder/util.go
index 46264666d075..119cc67aed60 100644
--- a/pkg/sql/opt/optbuilder/util.go
+++ b/pkg/sql/opt/optbuilder/util.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func checkFrom(expr tree.Expr, inScope *scope) {
diff --git a/pkg/sql/opt/optbuilder/values.go b/pkg/sql/opt/optbuilder/values.go
index 11d8a89e1c9d..67cbb31a7706 100644
--- a/pkg/sql/opt/optbuilder/values.go
+++ b/pkg/sql/opt/optbuilder/values.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// buildValuesClause builds a set of memo groups that represent the given values
diff --git a/pkg/sql/opt/optbuilder/window.go b/pkg/sql/opt/optbuilder/window.go
index fde30b02b263..1ed0ef720de5 100644
--- a/pkg/sql/opt/optbuilder/window.go
+++ b/pkg/sql/opt/optbuilder/window.go
@@ -18,7 +18,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/memo"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// windowInfo stores information about a window function call.
diff --git a/pkg/sql/opt/optgen/cmd/optgen/exprs_gen.go b/pkg/sql/opt/optgen/cmd/optgen/exprs_gen.go
index d802a4cb0495..55e0529e3d6e 100644
--- a/pkg/sql/opt/optgen/cmd/optgen/exprs_gen.go
+++ b/pkg/sql/opt/optgen/cmd/optgen/exprs_gen.go
@@ -45,7 +45,7 @@ func (g *exprsGen) generate(compiled *lang.CompiledExpr, w io.Writer) {
fmt.Fprintf(g.w, " \"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical\"\n")
fmt.Fprintf(g.w, " \"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror\"\n")
fmt.Fprintf(g.w, " \"github.com/cockroachdb/cockroach/pkg/sql/sem/tree\"\n")
- fmt.Fprintf(g.w, " \"github.com/cockroachdb/cockroach/pkg/sql/sem/types\"\n")
+ fmt.Fprintf(g.w, " \"github.com/cockroachdb/cockroach/pkg/sql/types\"\n")
fmt.Fprintf(g.w, ")\n\n")
for _, define := range g.compiled.Defines {
diff --git a/pkg/sql/opt/optgen/cmd/optgen/factory_gen.go b/pkg/sql/opt/optgen/cmd/optgen/factory_gen.go
index 972894bf10c7..0364d405c928 100644
--- a/pkg/sql/opt/optgen/cmd/optgen/factory_gen.go
+++ b/pkg/sql/opt/optgen/cmd/optgen/factory_gen.go
@@ -44,7 +44,7 @@ func (g *factoryGen) generate(compiled *lang.CompiledExpr, w io.Writer) {
g.w.writeIndent("\"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical\"\n")
g.w.writeIndent("\"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror\"\n")
g.w.writeIndent("\"github.com/cockroachdb/cockroach/pkg/sql/sem/tree\"\n")
- g.w.writeIndent("\"github.com/cockroachdb/cockroach/pkg/sql/sem/types\"\n")
+ g.w.writeIndent("\"github.com/cockroachdb/cockroach/pkg/sql/types\"\n")
g.w.writeIndent("\"github.com/cockroachdb/cockroach/pkg/util/log\"\n")
g.w.unnest(")\n\n")
diff --git a/pkg/sql/opt/optgen/cmd/optgen/testdata/exprs b/pkg/sql/opt/optgen/cmd/optgen/testdata/exprs
index 6f03beab0479..32aebccd2df6 100644
--- a/pkg/sql/opt/optgen/cmd/optgen/testdata/exprs
+++ b/pkg/sql/opt/optgen/cmd/optgen/testdata/exprs
@@ -53,7 +53,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// ProjectExpr is a projection operator.
diff --git a/pkg/sql/opt/optgen/cmd/optgen/testdata/factory b/pkg/sql/opt/optgen/cmd/optgen/testdata/factory
index b0477fbb4f1f..34c959fde99e 100644
--- a/pkg/sql/opt/optgen/cmd/optgen/testdata/factory
+++ b/pkg/sql/opt/optgen/cmd/optgen/testdata/factory
@@ -70,7 +70,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/opt/optgen/exprgen/expr_gen.go b/pkg/sql/opt/optgen/exprgen/expr_gen.go
index 0e8607c80e79..91672e8f16cc 100644
--- a/pkg/sql/opt/optgen/exprgen/expr_gen.go
+++ b/pkg/sql/opt/optgen/exprgen/expr_gen.go
@@ -29,7 +29,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/opt/xform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Build generates an expression from an optgen string (the kind of expression
diff --git a/pkg/sql/opt/optgen/exprgen/parse_type.go b/pkg/sql/opt/optgen/exprgen/parse_type.go
index eb3eea28303f..395639de464c 100644
--- a/pkg/sql/opt/optgen/exprgen/parse_type.go
+++ b/pkg/sql/opt/optgen/exprgen/parse_type.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// ParseType parses a string describing a type.
diff --git a/pkg/sql/opt/testutils/testcat/alter_table.go b/pkg/sql/opt/testutils/testcat/alter_table.go
index 3361c9f5ebb2..9c6d3a348bcc 100644
--- a/pkg/sql/opt/testutils/testcat/alter_table.go
+++ b/pkg/sql/opt/testutils/testcat/alter_table.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// AlterTable is a partial implementation of the ALTER TABLE statement.
diff --git a/pkg/sql/opt/testutils/testcat/create_table.go b/pkg/sql/opt/testutils/testcat/create_table.go
index d9f32ae26492..6d1ffac762a2 100644
--- a/pkg/sql/opt/testutils/testcat/create_table.go
+++ b/pkg/sql/opt/testutils/testcat/create_table.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/config"
"github.com/cockroachdb/cockroach/pkg/sql/opt/cat"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt/testutils/testcat/test_catalog.go b/pkg/sql/opt/testutils/testcat/test_catalog.go
index 3d2ea73774aa..2645b844147d 100644
--- a/pkg/sql/opt/testutils/testcat/test_catalog.go
+++ b/pkg/sql/opt/testutils/testcat/test_catalog.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/treeprinter"
)
diff --git a/pkg/sql/opt/testutils/utils.go b/pkg/sql/opt/testutils/utils.go
index f047d70c5842..59577e32ca91 100644
--- a/pkg/sql/opt/testutils/utils.go
+++ b/pkg/sql/opt/testutils/utils.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// ParseScalarExpr parses a scalar expression and converts it to a
diff --git a/pkg/sql/opt/xform/custom_funcs.go b/pkg/sql/opt/xform/custom_funcs.go
index d99305f47db3..1051dcca6627 100644
--- a/pkg/sql/opt/xform/custom_funcs.go
+++ b/pkg/sql/opt/xform/custom_funcs.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/opt/props/physical"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/opt_decompose_test.go b/pkg/sql/opt_decompose_test.go
index 6cbbcd6a60ff..c93fc3ba9894 100644
--- a/pkg/sql/opt_decompose_test.go
+++ b/pkg/sql/opt_decompose_test.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/opt_exec_factory.go b/pkg/sql/opt_exec_factory.go
index 31becbaf0641..b1caf5e1df4b 100644
--- a/pkg/sql/opt_exec_factory.go
+++ b/pkg/sql/opt_exec_factory.go
@@ -32,8 +32,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/pkg/errors"
diff --git a/pkg/sql/ordinality.go b/pkg/sql/ordinality.go
index cba0fe14fd2b..37933e70eaf3 100644
--- a/pkg/sql/ordinality.go
+++ b/pkg/sql/ordinality.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
)
diff --git a/pkg/sql/parser/lexer.go b/pkg/sql/parser/lexer.go
index 38e57dc478d3..da3c2a7dd4d3 100644
--- a/pkg/sql/parser/lexer.go
+++ b/pkg/sql/parser/lexer.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type lexer struct {
diff --git a/pkg/sql/parser/parse.go b/pkg/sql/parser/parse.go
index 9ab89d9c5b76..b355d54f2eb0 100644
--- a/pkg/sql/parser/parse.go
+++ b/pkg/sql/parser/parse.go
@@ -29,7 +29,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Statement is the result of parsing a single statement. It contains the AST
diff --git a/pkg/sql/pg_catalog.go b/pkg/sql/pg_catalog.go
index 6ece2e08200e..0e7a2e7df46f 100644
--- a/pkg/sql/pg_catalog.go
+++ b/pkg/sql/pg_catalog.go
@@ -28,8 +28,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/lib/pq/oid"
"github.com/pkg/errors"
"golang.org/x/text/collate"
diff --git a/pkg/sql/pgwire/conn.go b/pkg/sql/pgwire/conn.go
index 6d15cf908cfd..ec63cbfbbab0 100644
--- a/pkg/sql/pgwire/conn.go
+++ b/pkg/sql/pgwire/conn.go
@@ -38,10 +38,10 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgwirebase"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/log/logtags"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/pgwire/encoding_test.go b/pkg/sql/pgwire/encoding_test.go
index e0b40a6fd080..2462405c0d1b 100644
--- a/pkg/sql/pgwire/encoding_test.go
+++ b/pkg/sql/pgwire/encoding_test.go
@@ -29,8 +29,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgwirebase"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/metric"
"github.com/lib/pq/oid"
diff --git a/pkg/sql/pgwire/pgwirebase/encoding.go b/pkg/sql/pgwire/pgwirebase/encoding.go
index 73935a04dcab..fd194246f26c 100644
--- a/pkg/sql/pgwire/pgwirebase/encoding.go
+++ b/pkg/sql/pgwire/pgwirebase/encoding.go
@@ -28,7 +28,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/ipaddr"
diff --git a/pkg/sql/pgwire/types.go b/pkg/sql/pgwire/types.go
index 1e6ea798ef29..05420976bd27 100644
--- a/pkg/sql/pgwire/types.go
+++ b/pkg/sql/pgwire/types.go
@@ -30,9 +30,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgwirebase"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/ipaddr"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/pgwire/types_test.go b/pkg/sql/pgwire/types_test.go
index 89867195a70f..df2a74b0e082 100644
--- a/pkg/sql/pgwire/types_test.go
+++ b/pkg/sql/pgwire/types_test.go
@@ -26,9 +26,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgwirebase"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/metric"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
diff --git a/pkg/sql/plan.go b/pkg/sql/plan.go
index 27ac63f6eaae..3b62bde3740e 100644
--- a/pkg/sql/plan.go
+++ b/pkg/sql/plan.go
@@ -22,9 +22,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
)
diff --git a/pkg/sql/plan_node_to_row_source.go b/pkg/sql/plan_node_to_row_source.go
index 5dead6d04d75..3e5ea156d0b6 100644
--- a/pkg/sql/plan_node_to_row_source.go
+++ b/pkg/sql/plan_node_to_row_source.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlpb"
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/planhook.go b/pkg/sql/planhook.go
index 39cc7ccee861..05555d3e5578 100644
--- a/pkg/sql/planhook.go
+++ b/pkg/sql/planhook.go
@@ -18,9 +18,9 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
)
diff --git a/pkg/sql/planner.go b/pkg/sql/planner.go
index 48c492458aa2..3ad6fb35b7f0 100644
--- a/pkg/sql/planner.go
+++ b/pkg/sql/planner.go
@@ -29,9 +29,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/transform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/project_set.go b/pkg/sql/project_set.go
index 6696fa4f3396..b755438052f3 100644
--- a/pkg/sql/project_set.go
+++ b/pkg/sql/project_set.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// projectSetNode zips through a list of generators for every row of
diff --git a/pkg/sql/relocate.go b/pkg/sql/relocate.go
index 5120a7d1f656..88dd719bcf4f 100644
--- a/pkg/sql/relocate.go
+++ b/pkg/sql/relocate.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/render.go b/pkg/sql/render.go
index b043ed1c5d90..be08e370de52 100644
--- a/pkg/sql/render.go
+++ b/pkg/sql/render.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
)
diff --git a/pkg/sql/returning.go b/pkg/sql/returning.go
index 9b1a847dffae..49fae50f7865 100644
--- a/pkg/sql/returning.go
+++ b/pkg/sql/returning.go
@@ -19,8 +19,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/row/cfetcher.go b/pkg/sql/row/cfetcher.go
index 9037e078966b..c249ab6f556d 100644
--- a/pkg/sql/row/cfetcher.go
+++ b/pkg/sql/row/cfetcher.go
@@ -29,8 +29,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/exec/types/conv"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- semtypes "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ semtypes "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/row/fetcher.go b/pkg/sql/row/fetcher.go
index 0b3844ef5a20..d511d090f700 100644
--- a/pkg/sql/row/fetcher.go
+++ b/pkg/sql/row/fetcher.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
diff --git a/pkg/sql/rowcontainer/datum_row_container_test.go b/pkg/sql/rowcontainer/datum_row_container_test.go
index 9e107fa10845..b00ed62362ee 100644
--- a/pkg/sql/rowcontainer/datum_row_container_test.go
+++ b/pkg/sql/rowcontainer/datum_row_container_test.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/mon"
)
diff --git a/pkg/sql/rowcontainer/disk_row_container.go b/pkg/sql/rowcontainer/disk_row_container.go
index 6358cdcc7428..0a6575c80a6d 100644
--- a/pkg/sql/rowcontainer/disk_row_container.go
+++ b/pkg/sql/rowcontainer/disk_row_container.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/diskmap"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/rowcontainer/disk_row_container_test.go b/pkg/sql/rowcontainer/disk_row_container_test.go
index 7b348ff0b518..bc253152083c 100644
--- a/pkg/sql/rowcontainer/disk_row_container_test.go
+++ b/pkg/sql/rowcontainer/disk_row_container_test.go
@@ -25,8 +25,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/rowcontainer/hash_row_container.go b/pkg/sql/rowcontainer/hash_row_container.go
index 0a28ae97fc08..079d0851e4ce 100644
--- a/pkg/sql/rowcontainer/hash_row_container.go
+++ b/pkg/sql/rowcontainer/hash_row_container.go
@@ -20,8 +20,8 @@ import (
"unsafe"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/diskmap"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/rowcontainer/hash_row_container_test.go b/pkg/sql/rowcontainer/hash_row_container_test.go
index 4813015d40e4..670d6b9e5738 100644
--- a/pkg/sql/rowcontainer/hash_row_container_test.go
+++ b/pkg/sql/rowcontainer/hash_row_container_test.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/rowcontainer/row_container.go b/pkg/sql/rowcontainer/row_container.go
index 9dbd8b5a6f92..0ec41b4a795e 100644
--- a/pkg/sql/rowcontainer/row_container.go
+++ b/pkg/sql/rowcontainer/row_container.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/diskmap"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
diff --git a/pkg/sql/rowcontainer/row_container_test.go b/pkg/sql/rowcontainer/row_container_test.go
index b1c50d2a043e..42db237849a1 100644
--- a/pkg/sql/rowcontainer/row_container_test.go
+++ b/pkg/sql/rowcontainer/row_container_test.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/scan.go b/pkg/sql/scan.go
index b1e82c723b1a..661ea78f13a9 100644
--- a/pkg/sql/scan.go
+++ b/pkg/sql/scan.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/scatter.go b/pkg/sql/scatter.go
index b32b99a73857..0be4114c592b 100644
--- a/pkg/sql/scatter.go
+++ b/pkg/sql/scatter.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/schemachange/alter_column_type.go b/pkg/sql/schemachange/alter_column_type.go
index d51e8fead2b1..c339172b3dca 100644
--- a/pkg/sql/schemachange/alter_column_type.go
+++ b/pkg/sql/schemachange/alter_column_type.go
@@ -17,7 +17,7 @@ package schemachange
import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
//go:generate stringer -type=ColumnConversionKind -trimprefix ColumnConversion
diff --git a/pkg/sql/schemachange/alter_column_type_test.go b/pkg/sql/schemachange/alter_column_type_test.go
index e4b168551e9b..29125ca7a384 100644
--- a/pkg/sql/schemachange/alter_column_type_test.go
+++ b/pkg/sql/schemachange/alter_column_type_test.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/scrub.go b/pkg/sql/scrub.go
index b5d6938d8e59..9e250a325aaf 100644
--- a/pkg/sql/scrub.go
+++ b/pkg/sql/scrub.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
diff --git a/pkg/sql/scrub_constraint.go b/pkg/sql/scrub_constraint.go
index 95126c74e7df..fe1494be0229 100644
--- a/pkg/sql/scrub_constraint.go
+++ b/pkg/sql/scrub_constraint.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
)
diff --git a/pkg/sql/scrub_fk.go b/pkg/sql/scrub_fk.go
index 7e8fa5589897..48fcf41d783a 100644
--- a/pkg/sql/scrub_fk.go
+++ b/pkg/sql/scrub_fk.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/scrub"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/sem/builtins/aggregate_builtins.go b/pkg/sql/sem/builtins/aggregate_builtins.go
index d9c0e4022010..941a65a91a62 100644
--- a/pkg/sql/sem/builtins/aggregate_builtins.go
+++ b/pkg/sql/sem/builtins/aggregate_builtins.go
@@ -24,7 +24,7 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/arith"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/json"
diff --git a/pkg/sql/sem/builtins/aggregate_builtins_test.go b/pkg/sql/sem/builtins/aggregate_builtins_test.go
index 2a12e27a0f75..b952eb5d339c 100644
--- a/pkg/sql/sem/builtins/aggregate_builtins_test.go
+++ b/pkg/sql/sem/builtins/aggregate_builtins_test.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/sem/builtins/all_builtins.go b/pkg/sql/sem/builtins/all_builtins.go
index 390b9a3aefa8..223c6f44d719 100644
--- a/pkg/sql/sem/builtins/all_builtins.go
+++ b/pkg/sql/sem/builtins/all_builtins.go
@@ -18,7 +18,7 @@ import (
"sort"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// AllBuiltinNames is an array containing all the built-in function
diff --git a/pkg/sql/sem/builtins/builtins.go b/pkg/sql/sem/builtins/builtins.go
index 968d87b3b779..669c8e20d585 100644
--- a/pkg/sql/sem/builtins/builtins.go
+++ b/pkg/sql/sem/builtins/builtins.go
@@ -43,9 +43,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
"github.com/cockroachdb/cockroach/pkg/util/ipaddr"
diff --git a/pkg/sql/sem/builtins/builtins_test.go b/pkg/sql/sem/builtins/builtins_test.go
index 2dd33b823dab..19daaf750f27 100644
--- a/pkg/sql/sem/builtins/builtins_test.go
+++ b/pkg/sql/sem/builtins/builtins_test.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestCategory(t *testing.T) {
diff --git a/pkg/sql/sem/builtins/generator_builtins.go b/pkg/sql/sem/builtins/generator_builtins.go
index 4f6a2ff57fff..d9bcaa4beccf 100644
--- a/pkg/sql/sem/builtins/generator_builtins.go
+++ b/pkg/sql/sem/builtins/generator_builtins.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/arith"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/json"
diff --git a/pkg/sql/sem/builtins/pg_builtins.go b/pkg/sql/sem/builtins/pg_builtins.go
index 8d506416e485..3cc7525e2dd7 100644
--- a/pkg/sql/sem/builtins/pg_builtins.go
+++ b/pkg/sql/sem/builtins/pg_builtins.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/ipaddr"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/lib/pq/oid"
diff --git a/pkg/sql/sem/builtins/window_builtins.go b/pkg/sql/sem/builtins/window_builtins.go
index ecb7255e4058..1c172386cdba 100644
--- a/pkg/sql/sem/builtins/window_builtins.go
+++ b/pkg/sql/sem/builtins/window_builtins.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func initWindowBuiltins() {
diff --git a/pkg/sql/sem/tree/alter_table.go b/pkg/sql/sem/tree/alter_table.go
index f36beed44bce..dd815197bded 100644
--- a/pkg/sql/sem/tree/alter_table.go
+++ b/pkg/sql/sem/tree/alter_table.go
@@ -14,7 +14,7 @@
package tree
-import "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import "github.com/cockroachdb/cockroach/pkg/sql/types"
// AlterTable represents an ALTER TABLE statement.
type AlterTable struct {
diff --git a/pkg/sql/sem/tree/as_of.go b/pkg/sql/sem/tree/as_of.go
index 56fbbe57d191..822ce3678431 100644
--- a/pkg/sql/sem/tree/as_of.go
+++ b/pkg/sql/sem/tree/as_of.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/pkg/errors"
diff --git a/pkg/sql/sem/tree/col_types_test.go b/pkg/sql/sem/tree/col_types_test.go
index 79d2dc9e0e01..d036c83316fa 100644
--- a/pkg/sql/sem/tree/col_types_test.go
+++ b/pkg/sql/sem/tree/col_types_test.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestParseColumnType(t *testing.T) {
diff --git a/pkg/sql/sem/tree/collatedstring_test.go b/pkg/sql/sem/tree/collatedstring_test.go
index 0892d2bf0830..f54ad6afb393 100644
--- a/pkg/sql/sem/tree/collatedstring_test.go
+++ b/pkg/sql/sem/tree/collatedstring_test.go
@@ -19,7 +19,7 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestCastToCollatedString(t *testing.T) {
diff --git a/pkg/sql/sem/tree/compare_test.go b/pkg/sql/sem/tree/compare_test.go
index aba8ffd5846c..f8d09e4fc31f 100644
--- a/pkg/sql/sem/tree/compare_test.go
+++ b/pkg/sql/sem/tree/compare_test.go
@@ -19,7 +19,7 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestEvalComparisonExprCaching(t *testing.T) {
diff --git a/pkg/sql/sem/tree/constant.go b/pkg/sql/sem/tree/constant.go
index b55ae4dec630..af2f4dd55b4f 100644
--- a/pkg/sql/sem/tree/constant.go
+++ b/pkg/sql/sem/tree/constant.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/lib/pq/oid"
)
diff --git a/pkg/sql/sem/tree/constant_eval_test.go b/pkg/sql/sem/tree/constant_eval_test.go
index e8749a5097bd..7238e369fdc9 100644
--- a/pkg/sql/sem/tree/constant_eval_test.go
+++ b/pkg/sql/sem/tree/constant_eval_test.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestConstantEvalArrayComparison(t *testing.T) {
diff --git a/pkg/sql/sem/tree/constant_test.go b/pkg/sql/sem/tree/constant_test.go
index 9de0adee6222..f03027d04d93 100644
--- a/pkg/sql/sem/tree/constant_test.go
+++ b/pkg/sql/sem/tree/constant_test.go
@@ -28,7 +28,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// TestNumericConstantVerifyAndResolveAvailableTypes verifies that test NumVals will
diff --git a/pkg/sql/sem/tree/create.go b/pkg/sql/sem/tree/create.go
index 703deff2a2fa..f25dd804a871 100644
--- a/pkg/sql/sem/tree/create.go
+++ b/pkg/sql/sem/tree/create.go
@@ -29,7 +29,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"golang.org/x/text/language"
)
diff --git a/pkg/sql/sem/tree/datum.go b/pkg/sql/sem/tree/datum.go
index 18a723150dfc..ad6fb9c90fdf 100644
--- a/pkg/sql/sem/tree/datum.go
+++ b/pkg/sql/sem/tree/datum.go
@@ -31,7 +31,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/ipaddr"
diff --git a/pkg/sql/sem/tree/datum_invariants_test.go b/pkg/sql/sem/tree/datum_invariants_test.go
index d7e49fb974f4..a89bce428625 100644
--- a/pkg/sql/sem/tree/datum_invariants_test.go
+++ b/pkg/sql/sem/tree/datum_invariants_test.go
@@ -17,7 +17,7 @@ package tree
import (
"testing"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestAllTypesCastableToString(t *testing.T) {
diff --git a/pkg/sql/sem/tree/datum_test.go b/pkg/sql/sem/tree/datum_test.go
index 4b1a8f4d6b9e..b95ae3efcc2f 100644
--- a/pkg/sql/sem/tree/datum_test.go
+++ b/pkg/sql/sem/tree/datum_test.go
@@ -25,7 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/timeofday"
)
diff --git a/pkg/sql/sem/tree/eval.go b/pkg/sql/sem/tree/eval.go
index 27d457e9425f..10858863e127 100644
--- a/pkg/sql/sem/tree/eval.go
+++ b/pkg/sql/sem/tree/eval.go
@@ -33,9 +33,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/arith"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
diff --git a/pkg/sql/sem/tree/eval_test.go b/pkg/sql/sem/tree/eval_test.go
index aa2142700c0c..afb7663f3aa7 100644
--- a/pkg/sql/sem/tree/eval_test.go
+++ b/pkg/sql/sem/tree/eval_test.go
@@ -29,7 +29,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/datadriven"
)
diff --git a/pkg/sql/sem/tree/expr.go b/pkg/sql/sem/tree/expr.go
index 5eb68193328c..6824dbf37332 100644
--- a/pkg/sql/sem/tree/expr.go
+++ b/pkg/sql/sem/tree/expr.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/server/telemetry"
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/sem/tree/expr_test.go b/pkg/sql/sem/tree/expr_test.go
index 9dae6e90b750..84bf600e4c59 100644
--- a/pkg/sql/sem/tree/expr_test.go
+++ b/pkg/sql/sem/tree/expr_test.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// TestUnresolvedNameString tests the string representation of tree.UnresolvedName and thus tree.Name.
diff --git a/pkg/sql/sem/tree/format.go b/pkg/sql/sem/tree/format.go
index 597b799f4f91..c99671d4f7e5 100644
--- a/pkg/sql/sem/tree/format.go
+++ b/pkg/sql/sem/tree/format.go
@@ -20,7 +20,7 @@ import (
"sync"
"github.com/cockroachdb/cockroach/pkg/sql/lex"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/sem/tree/format_test.go b/pkg/sql/sem/tree/format_test.go
index 415e36ec338a..e9ed98065512 100644
--- a/pkg/sql/sem/tree/format_test.go
+++ b/pkg/sql/sem/tree/format_test.go
@@ -24,7 +24,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestFormatStatement(t *testing.T) {
diff --git a/pkg/sql/sem/tree/generators.go b/pkg/sql/sem/tree/generators.go
index 633e9bcb5677..c7f367f35f56 100644
--- a/pkg/sql/sem/tree/generators.go
+++ b/pkg/sql/sem/tree/generators.go
@@ -14,7 +14,7 @@
package tree
-import "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import "github.com/cockroachdb/cockroach/pkg/sql/types"
// Table generators, also called "set-generating functions", are
// special functions that return an entire table.
diff --git a/pkg/sql/sem/tree/indexed_vars.go b/pkg/sql/sem/tree/indexed_vars.go
index bb84aca914c2..5c5fd8f80adb 100644
--- a/pkg/sql/sem/tree/indexed_vars.go
+++ b/pkg/sql/sem/tree/indexed_vars.go
@@ -16,7 +16,7 @@ package tree
import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/sem/tree/indexed_vars_test.go b/pkg/sql/sem/tree/indexed_vars_test.go
index 48e4a8895280..fb068a75832b 100644
--- a/pkg/sql/sem/tree/indexed_vars_test.go
+++ b/pkg/sql/sem/tree/indexed_vars_test.go
@@ -20,7 +20,7 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type testVarContainer []Datum
diff --git a/pkg/sql/sem/tree/interval.go b/pkg/sql/sem/tree/interval.go
index 1192f9e0fa1b..4bf5f1c94581 100644
--- a/pkg/sql/sem/tree/interval.go
+++ b/pkg/sql/sem/tree/interval.go
@@ -21,7 +21,7 @@ import (
"time"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/duration"
)
diff --git a/pkg/sql/sem/tree/like_test.go b/pkg/sql/sem/tree/like_test.go
index b036a8c15dfc..e3340939f52c 100644
--- a/pkg/sql/sem/tree/like_test.go
+++ b/pkg/sql/sem/tree/like_test.go
@@ -19,7 +19,7 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestLike(t *testing.T) {
diff --git a/pkg/sql/sem/tree/normalize.go b/pkg/sql/sem/tree/normalize.go
index 3f9cb95d7fe7..d02266e8a936 100644
--- a/pkg/sql/sem/tree/normalize.go
+++ b/pkg/sql/sem/tree/normalize.go
@@ -16,7 +16,7 @@ package tree
import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/json"
)
diff --git a/pkg/sql/sem/tree/normalize_test.go b/pkg/sql/sem/tree/normalize_test.go
index 030453ee0e91..981c0bc71e8e 100644
--- a/pkg/sql/sem/tree/normalize_test.go
+++ b/pkg/sql/sem/tree/normalize_test.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestContainsVars(t *testing.T) {
diff --git a/pkg/sql/sem/tree/operators.go b/pkg/sql/sem/tree/operators.go
index 35d8515506a6..1ffea77a5d70 100644
--- a/pkg/sql/sem/tree/operators.go
+++ b/pkg/sql/sem/tree/operators.go
@@ -17,8 +17,8 @@ package tree
import (
"fmt"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// This file implements the generation of unique names for every
diff --git a/pkg/sql/sem/tree/overload.go b/pkg/sql/sem/tree/overload.go
index 186484497d9d..92dac521a6ef 100644
--- a/pkg/sql/sem/tree/overload.go
+++ b/pkg/sql/sem/tree/overload.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/server/telemetry"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/sem/tree/overload_test.go b/pkg/sql/sem/tree/overload_test.go
index ea732e588ee3..2eaea75a3d8d 100644
--- a/pkg/sql/sem/tree/overload_test.go
+++ b/pkg/sql/sem/tree/overload_test.go
@@ -21,7 +21,7 @@ import (
"strings"
"testing"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type variadicTestCase struct {
diff --git a/pkg/sql/sem/tree/parse_array.go b/pkg/sql/sem/tree/parse_array.go
index e87748f864ad..fd2fec536a02 100644
--- a/pkg/sql/sem/tree/parse_array.go
+++ b/pkg/sql/sem/tree/parse_array.go
@@ -21,7 +21,7 @@ import (
"unicode/utf8"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
var enclosingError = pgerror.NewErrorf(pgerror.CodeInvalidTextRepresentationError, "array must be enclosed in { and }")
diff --git a/pkg/sql/sem/tree/parse_array_test.go b/pkg/sql/sem/tree/parse_array_test.go
index 93883ecdbca0..530f7ad3c7b4 100644
--- a/pkg/sql/sem/tree/parse_array_test.go
+++ b/pkg/sql/sem/tree/parse_array_test.go
@@ -20,7 +20,7 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestParseArray(t *testing.T) {
diff --git a/pkg/sql/sem/tree/parse_string.go b/pkg/sql/sem/tree/parse_string.go
index e830bbef87e8..42dc7aa1bb01 100644
--- a/pkg/sql/sem/tree/parse_string.go
+++ b/pkg/sql/sem/tree/parse_string.go
@@ -18,7 +18,7 @@ import (
"time"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// ParseStringAs reads s as type t. If t is Bytes or String, s is returned
diff --git a/pkg/sql/sem/tree/parse_string_test.go b/pkg/sql/sem/tree/parse_string_test.go
index cf14bef69046..c76bc2747986 100644
--- a/pkg/sql/sem/tree/parse_string_test.go
+++ b/pkg/sql/sem/tree/parse_string_test.go
@@ -20,7 +20,7 @@ import (
"strconv"
"testing"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/uuid"
)
diff --git a/pkg/sql/sem/tree/placeholders.go b/pkg/sql/sem/tree/placeholders.go
index 3c94a2e3cc7d..3f14b0a59acf 100644
--- a/pkg/sql/sem/tree/placeholders.go
+++ b/pkg/sql/sem/tree/placeholders.go
@@ -22,7 +22,7 @@ import (
"strings"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
)
diff --git a/pkg/sql/sem/tree/placeholders_test.go b/pkg/sql/sem/tree/placeholders_test.go
index 7c178c7c6665..7bf4badb62f7 100644
--- a/pkg/sql/sem/tree/placeholders_test.go
+++ b/pkg/sql/sem/tree/placeholders_test.go
@@ -18,7 +18,7 @@ import (
"fmt"
"testing"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestPlaceholderTypesEquals(t *testing.T) {
diff --git a/pkg/sql/sem/tree/prepare.go b/pkg/sql/sem/tree/prepare.go
index 4e1d4200d7ea..34edf28adc24 100644
--- a/pkg/sql/sem/tree/prepare.go
+++ b/pkg/sql/sem/tree/prepare.go
@@ -16,7 +16,7 @@ package tree
import (
"github.com/cockroachdb/cockroach/pkg/sql/lex"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Prepare represents a PREPARE statement.
diff --git a/pkg/sql/sem/tree/pretty.go b/pkg/sql/sem/tree/pretty.go
index 33b041366d7f..3e0e592ee283 100644
--- a/pkg/sql/sem/tree/pretty.go
+++ b/pkg/sql/sem/tree/pretty.go
@@ -19,7 +19,7 @@ import (
"strings"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/pretty"
)
diff --git a/pkg/sql/sem/tree/pretty_test.go b/pkg/sql/sem/tree/pretty_test.go
index 3d5d53ec2d07..3e4365b56bf6 100644
--- a/pkg/sql/sem/tree/pretty_test.go
+++ b/pkg/sql/sem/tree/pretty_test.go
@@ -28,7 +28,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/pretty"
"golang.org/x/sync/errgroup"
diff --git a/pkg/sql/sem/tree/testutils.go b/pkg/sql/sem/tree/testutils.go
index 3005885dc095..aa341098eeed 100644
--- a/pkg/sql/sem/tree/testutils.go
+++ b/pkg/sql/sem/tree/testutils.go
@@ -18,7 +18,7 @@ import (
"fmt"
"time"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/timeofday"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
)
diff --git a/pkg/sql/sem/tree/type_check.go b/pkg/sql/sem/tree/type_check.go
index bd40cbaedc08..d421f1e2f065 100644
--- a/pkg/sql/sem/tree/type_check.go
+++ b/pkg/sql/sem/tree/type_check.go
@@ -22,9 +22,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/server/telemetry"
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/sem/tree/type_check_internal_test.go b/pkg/sql/sem/tree/type_check_internal_test.go
index 01d5315a9fd4..0db2d6ccbc35 100644
--- a/pkg/sql/sem/tree/type_check_internal_test.go
+++ b/pkg/sql/sem/tree/type_check_internal_test.go
@@ -25,7 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
)
diff --git a/pkg/sql/sem/tree/type_check_test.go b/pkg/sql/sem/tree/type_check_test.go
index ae7e7a050163..44c45021d4bc 100644
--- a/pkg/sql/sem/tree/type_check_test.go
+++ b/pkg/sql/sem/tree/type_check_test.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
_ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
)
diff --git a/pkg/sql/sem/tree/var_name.go b/pkg/sql/sem/tree/var_name.go
index 8c926c32b180..cd8de04952d7 100644
--- a/pkg/sql/sem/tree/var_name.go
+++ b/pkg/sql/sem/tree/var_name.go
@@ -16,7 +16,7 @@ package tree
import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// VarName occurs inside scalar expressions.
diff --git a/pkg/sql/sem/tree/window_funcs.go b/pkg/sql/sem/tree/window_funcs.go
index d83dec0d18b8..5bd3db9b57fd 100644
--- a/pkg/sql/sem/tree/window_funcs.go
+++ b/pkg/sql/sem/tree/window_funcs.go
@@ -19,7 +19,7 @@ import (
"sort"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/sem/tree/window_funcs_test.go b/pkg/sql/sem/tree/window_funcs_test.go
index 59fe17b0eb5b..9feb41bc436e 100644
--- a/pkg/sql/sem/tree/window_funcs_test.go
+++ b/pkg/sql/sem/tree/window_funcs_test.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
)
diff --git a/pkg/sql/sequence_select.go b/pkg/sql/sequence_select.go
index 18aa46ad747c..c149a41a0bcd 100644
--- a/pkg/sql/sequence_select.go
+++ b/pkg/sql/sequence_select.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/serial.go b/pkg/sql/serial.go
index 8bdd3c420c14..422f7f0e1b5d 100644
--- a/pkg/sql/serial.go
+++ b/pkg/sql/serial.go
@@ -21,9 +21,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/server/telemetry"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/set_cluster_setting.go b/pkg/sql/set_cluster_setting.go
index ef69c32e54e7..68d513a391c4 100644
--- a/pkg/sql/set_cluster_setting.go
+++ b/pkg/sql/set_cluster_setting.go
@@ -25,9 +25,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/retry"
diff --git a/pkg/sql/set_var.go b/pkg/sql/set_var.go
index ff4c340ef8d2..fc34851e8526 100644
--- a/pkg/sql/set_var.go
+++ b/pkg/sql/set_var.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
)
diff --git a/pkg/sql/set_zone_config.go b/pkg/sql/set_zone_config.go
index 458c4a0e1c4b..a084edb190dd 100644
--- a/pkg/sql/set_zone_config.go
+++ b/pkg/sql/set_zone_config.go
@@ -27,8 +27,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
"github.com/gogo/protobuf/proto"
yaml "gopkg.in/yaml.v2"
diff --git a/pkg/sql/show_cluster_setting.go b/pkg/sql/show_cluster_setting.go
index f686e769ccf4..5c6ca5e048e3 100644
--- a/pkg/sql/show_cluster_setting.go
+++ b/pkg/sql/show_cluster_setting.go
@@ -26,8 +26,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/contextutil"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/retry"
diff --git a/pkg/sql/show_fingerprints.go b/pkg/sql/show_fingerprints.go
index b513b6e5128a..bbe024eef355 100644
--- a/pkg/sql/show_fingerprints.go
+++ b/pkg/sql/show_fingerprints.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
type showFingerprintsNode struct {
diff --git a/pkg/sql/show_histogram.go b/pkg/sql/show_histogram.go
index fcd6c3f95b3f..64f1cf3ea862 100644
--- a/pkg/sql/show_histogram.go
+++ b/pkg/sql/show_histogram.go
@@ -20,9 +20,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
)
diff --git a/pkg/sql/show_stats.go b/pkg/sql/show_stats.go
index 18728cb1cb19..1ad976ca81b1 100644
--- a/pkg/sql/show_stats.go
+++ b/pkg/sql/show_stats.go
@@ -19,9 +19,9 @@ import (
encjson "encoding/json"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/stats"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/json"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/show_zone_config.go b/pkg/sql/show_zone_config.go
index 229a6b8cd00f..3ebda2b4398b 100644
--- a/pkg/sql/show_zone_config.go
+++ b/pkg/sql/show_zone_config.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/sql/lex"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
yaml "gopkg.in/yaml.v2"
)
diff --git a/pkg/sql/sort.go b/pkg/sql/sort.go
index 389b44f9c8e4..bd94a969536d 100644
--- a/pkg/sql/sort.go
+++ b/pkg/sql/sort.go
@@ -19,8 +19,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
diff --git a/pkg/sql/split.go b/pkg/sql/split.go
index 04e8e8da5f72..74df05993f1e 100644
--- a/pkg/sql/split.go
+++ b/pkg/sql/split.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/storage/storagebase"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/sqlbase/check.go b/pkg/sql/sqlbase/check.go
index 032269d7aadc..2e3b49771f7c 100644
--- a/pkg/sql/sqlbase/check.go
+++ b/pkg/sql/sqlbase/check.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/sqlbase/col_type_info.go b/pkg/sql/sqlbase/col_type_info.go
index 8db4bbfa052e..040f72aff1bc 100644
--- a/pkg/sql/sqlbase/col_type_info.go
+++ b/pkg/sql/sqlbase/col_type_info.go
@@ -14,7 +14,7 @@
package sqlbase
-import "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import "github.com/cockroachdb/cockroach/pkg/sql/types"
// ColTypeInfo is a type that allows multiple representations of column type
// information (to avoid conversions and allocations).
diff --git a/pkg/sql/sqlbase/column_type_encoding.go b/pkg/sql/sqlbase/column_type_encoding.go
index 28025d867606..b7739dad7fd6 100644
--- a/pkg/sql/sqlbase/column_type_encoding.go
+++ b/pkg/sql/sqlbase/column_type_encoding.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
diff --git a/pkg/sql/sqlbase/column_type_properties.go b/pkg/sql/sqlbase/column_type_properties.go
index aec1708861d4..6f2b3352f574 100644
--- a/pkg/sql/sqlbase/column_type_properties.go
+++ b/pkg/sql/sqlbase/column_type_properties.go
@@ -20,7 +20,7 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/lib/pq/oid"
)
diff --git a/pkg/sql/sqlbase/computed_exprs.go b/pkg/sql/sqlbase/computed_exprs.go
index 0e45604b0f6d..4a2d5f8c93a4 100644
--- a/pkg/sql/sqlbase/computed_exprs.go
+++ b/pkg/sql/sqlbase/computed_exprs.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/transform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// RowIndexedVarContainer is used to evaluate expressions over various rows.
diff --git a/pkg/sql/sqlbase/encoded_datum.go b/pkg/sql/sqlbase/encoded_datum.go
index 6196f58dc108..f605216f46b5 100644
--- a/pkg/sql/sqlbase/encoded_datum.go
+++ b/pkg/sql/sqlbase/encoded_datum.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
diff --git a/pkg/sql/sqlbase/encoded_datum_test.go b/pkg/sql/sqlbase/encoded_datum_test.go
index 2d481613195d..bb0b4b73109f 100644
--- a/pkg/sql/sqlbase/encoded_datum_test.go
+++ b/pkg/sql/sqlbase/encoded_datum_test.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
diff --git a/pkg/sql/sqlbase/evalctx.go b/pkg/sql/sqlbase/evalctx.go
index 432bc9c37f0c..d69e5248f601 100644
--- a/pkg/sql/sqlbase/evalctx.go
+++ b/pkg/sql/sqlbase/evalctx.go
@@ -18,7 +18,7 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/sqlbase/index_encoding.go b/pkg/sql/sqlbase/index_encoding.go
index f8351dc09485..ccba36c2270c 100644
--- a/pkg/sql/sqlbase/index_encoding.go
+++ b/pkg/sql/sqlbase/index_encoding.go
@@ -23,7 +23,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/json"
"github.com/pkg/errors"
diff --git a/pkg/sql/sqlbase/prepared_statement.go b/pkg/sql/sqlbase/prepared_statement.go
index 5a7d7fb191bd..526c746b518f 100644
--- a/pkg/sql/sqlbase/prepared_statement.go
+++ b/pkg/sql/sqlbase/prepared_statement.go
@@ -19,7 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/lib/pq/oid"
)
diff --git a/pkg/sql/sqlbase/result_columns.go b/pkg/sql/sqlbase/result_columns.go
index 9c6ca5738c87..f57c88a23fcb 100644
--- a/pkg/sql/sqlbase/result_columns.go
+++ b/pkg/sql/sqlbase/result_columns.go
@@ -17,7 +17,7 @@ package sqlbase
import (
"fmt"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// ResultColumn contains the name and type of a SQL "cell".
diff --git a/pkg/sql/sqlbase/result_columns_test.go b/pkg/sql/sqlbase/result_columns_test.go
index a2a34776483b..48ce5afc36a3 100644
--- a/pkg/sql/sqlbase/result_columns_test.go
+++ b/pkg/sql/sqlbase/result_columns_test.go
@@ -18,7 +18,7 @@ import (
"fmt"
"testing"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func TestResultColumnsTypesEqual(t *testing.T) {
diff --git a/pkg/sql/sqlbase/select_name_resolution.go b/pkg/sql/sqlbase/select_name_resolution.go
index 726fbbcaef0e..e4692f6be457 100644
--- a/pkg/sql/sqlbase/select_name_resolution.go
+++ b/pkg/sql/sqlbase/select_name_resolution.go
@@ -23,8 +23,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// NameResolutionVisitor is a tree.Visitor implementation used to
diff --git a/pkg/sql/sqlbase/structured.go b/pkg/sql/sqlbase/structured.go
index fd6a5b9996b9..dec418dd56a0 100644
--- a/pkg/sql/sqlbase/structured.go
+++ b/pkg/sql/sqlbase/structured.go
@@ -30,7 +30,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/interval"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/sql/sqlbase/structured.pb.go b/pkg/sql/sqlbase/structured.pb.go
index c9c03ff144b4..73561f2deba9 100644
--- a/pkg/sql/sqlbase/structured.pb.go
+++ b/pkg/sql/sqlbase/structured.pb.go
@@ -8,7 +8,7 @@ import fmt "fmt"
import math "math"
import hlc "github.com/cockroachdb/cockroach/pkg/util/hlc"
-import github_com_cockroachdb_cockroach_pkg_sql_sem_types "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import github_com_cockroachdb_cockroach_pkg_sql_types "github.com/cockroachdb/cockroach/pkg/sql/types"
import github_com_cockroachdb_cockroach_pkg_roachpb "github.com/cockroachdb/cockroach/pkg/roachpb"
import io "io"
@@ -67,7 +67,7 @@ func (x *ConstraintValidity) UnmarshalJSON(data []byte) error {
return nil
}
func (ConstraintValidity) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{0}
}
type ForeignKeyReference_Action int32
@@ -112,7 +112,7 @@ func (x *ForeignKeyReference_Action) UnmarshalJSON(data []byte) error {
return nil
}
func (ForeignKeyReference_Action) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{0, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{0, 0}
}
// Match is the algorithm used to compare composite keys.
@@ -152,7 +152,7 @@ func (x *ForeignKeyReference_Match) UnmarshalJSON(data []byte) error {
return nil
}
func (ForeignKeyReference_Match) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{0, 1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{0, 1}
}
// The direction of a column in the index.
@@ -189,7 +189,7 @@ func (x *IndexDescriptor_Direction) UnmarshalJSON(data []byte) error {
return nil
}
func (IndexDescriptor_Direction) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{5, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{5, 0}
}
// The direction of a column in the index.
@@ -226,7 +226,7 @@ func (x *IndexDescriptor_Type) UnmarshalJSON(data []byte) error {
return nil
}
func (IndexDescriptor_Type) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{5, 1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{5, 1}
}
type ConstraintToUpdate_ConstraintType int32
@@ -259,7 +259,7 @@ func (x *ConstraintToUpdate_ConstraintType) UnmarshalJSON(data []byte) error {
return nil
}
func (ConstraintToUpdate_ConstraintType) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{6, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{6, 0}
}
// A descriptor within a mutation is unavailable for reads, writes
@@ -324,7 +324,7 @@ func (x *DescriptorMutation_State) UnmarshalJSON(data []byte) error {
return nil
}
func (DescriptorMutation_State) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{7, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{7, 0}
}
// Direction of mutation.
@@ -367,7 +367,7 @@ func (x *DescriptorMutation_Direction) UnmarshalJSON(data []byte) error {
return nil
}
func (DescriptorMutation_Direction) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{7, 1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{7, 1}
}
// State is set if this TableDescriptor is in the process of being added or deleted.
@@ -414,7 +414,7 @@ func (x *TableDescriptor_State) UnmarshalJSON(data []byte) error {
return nil
}
func (TableDescriptor_State) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 0}
}
// AuditMode indicates which auditing actions to take when this table is used.
@@ -451,7 +451,7 @@ func (x *TableDescriptor_AuditMode) UnmarshalJSON(data []byte) error {
return nil
}
func (TableDescriptor_AuditMode) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 1}
}
type ForeignKeyReference struct {
@@ -475,7 +475,7 @@ func (m *ForeignKeyReference) Reset() { *m = ForeignKeyReference{} }
func (m *ForeignKeyReference) String() string { return proto.CompactTextString(m) }
func (*ForeignKeyReference) ProtoMessage() {}
func (*ForeignKeyReference) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{0}
}
func (m *ForeignKeyReference) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -501,10 +501,10 @@ func (m *ForeignKeyReference) XXX_DiscardUnknown() {
var xxx_messageInfo_ForeignKeyReference proto.InternalMessageInfo
type ColumnDescriptor struct {
- Name string `protobuf:"bytes,1,opt,name=name" json:"name"`
- ID ColumnID `protobuf:"varint,2,opt,name=id,casttype=ColumnID" json:"id"`
- Type github_com_cockroachdb_cockroach_pkg_sql_sem_types.T `protobuf:"bytes,3,opt,name=type,customtype=github.com/cockroachdb/cockroach/pkg/sql/sem/types.T" json:"type"`
- Nullable bool `protobuf:"varint,4,opt,name=nullable" json:"nullable"`
+ Name string `protobuf:"bytes,1,opt,name=name" json:"name"`
+ ID ColumnID `protobuf:"varint,2,opt,name=id,casttype=ColumnID" json:"id"`
+ Type github_com_cockroachdb_cockroach_pkg_sql_types.T `protobuf:"bytes,3,opt,name=type,customtype=github.com/cockroachdb/cockroach/pkg/sql/types.T" json:"type"`
+ Nullable bool `protobuf:"varint,4,opt,name=nullable" json:"nullable"`
// Default expression to use to populate the column on insert if no
// value is provided.
DefaultExpr *string `protobuf:"bytes,5,opt,name=default_expr,json=defaultExpr" json:"default_expr,omitempty"`
@@ -522,7 +522,7 @@ func (m *ColumnDescriptor) Reset() { *m = ColumnDescriptor{} }
func (m *ColumnDescriptor) String() string { return proto.CompactTextString(m) }
func (*ColumnDescriptor) ProtoMessage() {}
func (*ColumnDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{1}
}
func (m *ColumnDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -575,7 +575,7 @@ func (m *ColumnFamilyDescriptor) Reset() { *m = ColumnFamilyDescriptor{}
func (m *ColumnFamilyDescriptor) String() string { return proto.CompactTextString(m) }
func (*ColumnFamilyDescriptor) ProtoMessage() {}
func (*ColumnFamilyDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{2}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{2}
}
func (m *ColumnFamilyDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -623,7 +623,7 @@ func (m *InterleaveDescriptor) Reset() { *m = InterleaveDescriptor{} }
func (m *InterleaveDescriptor) String() string { return proto.CompactTextString(m) }
func (*InterleaveDescriptor) ProtoMessage() {}
func (*InterleaveDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{3}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{3}
}
func (m *InterleaveDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -669,7 +669,7 @@ func (m *InterleaveDescriptor_Ancestor) Reset() { *m = InterleaveDescrip
func (m *InterleaveDescriptor_Ancestor) String() string { return proto.CompactTextString(m) }
func (*InterleaveDescriptor_Ancestor) ProtoMessage() {}
func (*InterleaveDescriptor_Ancestor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{3, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{3, 0}
}
func (m *InterleaveDescriptor_Ancestor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -716,7 +716,7 @@ func (m *PartitioningDescriptor) Reset() { *m = PartitioningDescriptor{}
func (m *PartitioningDescriptor) String() string { return proto.CompactTextString(m) }
func (*PartitioningDescriptor) ProtoMessage() {}
func (*PartitioningDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{4}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{4}
}
func (m *PartitioningDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -761,7 +761,7 @@ func (m *PartitioningDescriptor_List) Reset() { *m = PartitioningDescrip
func (m *PartitioningDescriptor_List) String() string { return proto.CompactTextString(m) }
func (*PartitioningDescriptor_List) ProtoMessage() {}
func (*PartitioningDescriptor_List) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{4, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{4, 0}
}
func (m *PartitioningDescriptor_List) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -808,7 +808,7 @@ func (m *PartitioningDescriptor_Range) Reset() { *m = PartitioningDescri
func (m *PartitioningDescriptor_Range) String() string { return proto.CompactTextString(m) }
func (*PartitioningDescriptor_Range) ProtoMessage() {}
func (*PartitioningDescriptor_Range) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{4, 1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{4, 1}
}
func (m *PartitioningDescriptor_Range) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -942,7 +942,7 @@ func (m *IndexDescriptor) Reset() { *m = IndexDescriptor{} }
func (m *IndexDescriptor) String() string { return proto.CompactTextString(m) }
func (*IndexDescriptor) ProtoMessage() {}
func (*IndexDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{5}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{5}
}
func (m *IndexDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -992,7 +992,7 @@ func (m *ConstraintToUpdate) Reset() { *m = ConstraintToUpdate{} }
func (m *ConstraintToUpdate) String() string { return proto.CompactTextString(m) }
func (*ConstraintToUpdate) ProtoMessage() {}
func (*ConstraintToUpdate) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{6}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{6}
}
func (m *ConstraintToUpdate) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1048,7 +1048,7 @@ func (m *DescriptorMutation) Reset() { *m = DescriptorMutation{} }
func (m *DescriptorMutation) String() string { return proto.CompactTextString(m) }
func (*DescriptorMutation) ProtoMessage() {}
func (*DescriptorMutation) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{7}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{7}
}
func (m *DescriptorMutation) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1332,7 +1332,7 @@ func (m *TableDescriptor) Reset() { *m = TableDescriptor{} }
func (m *TableDescriptor) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor) ProtoMessage() {}
func (*TableDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8}
}
func (m *TableDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1584,7 +1584,7 @@ func (m *TableDescriptor_SchemaChangeLease) Reset() { *m = TableDescript
func (m *TableDescriptor_SchemaChangeLease) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_SchemaChangeLease) ProtoMessage() {}
func (*TableDescriptor_SchemaChangeLease) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 0}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 0}
}
func (m *TableDescriptor_SchemaChangeLease) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1623,7 +1623,7 @@ func (m *TableDescriptor_CheckConstraint) Reset() { *m = TableDescriptor
func (m *TableDescriptor_CheckConstraint) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_CheckConstraint) ProtoMessage() {}
func (*TableDescriptor_CheckConstraint) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 1}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 1}
}
func (m *TableDescriptor_CheckConstraint) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1728,7 +1728,7 @@ func (m *TableDescriptor_NameInfo) Reset() { *m = TableDescriptor_NameIn
func (m *TableDescriptor_NameInfo) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_NameInfo) ProtoMessage() {}
func (*TableDescriptor_NameInfo) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 2}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 2}
}
func (m *TableDescriptor_NameInfo) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1770,7 +1770,7 @@ func (m *TableDescriptor_Reference) Reset() { *m = TableDescriptor_Refer
func (m *TableDescriptor_Reference) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_Reference) ProtoMessage() {}
func (*TableDescriptor_Reference) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 3}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 3}
}
func (m *TableDescriptor_Reference) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1809,7 +1809,7 @@ func (m *TableDescriptor_MutationJob) Reset() { *m = TableDescriptor_Mut
func (m *TableDescriptor_MutationJob) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_MutationJob) ProtoMessage() {}
func (*TableDescriptor_MutationJob) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 4}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 4}
}
func (m *TableDescriptor_MutationJob) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1853,7 +1853,7 @@ func (m *TableDescriptor_SequenceOpts) Reset() { *m = TableDescriptor_Se
func (m *TableDescriptor_SequenceOpts) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_SequenceOpts) ProtoMessage() {}
func (*TableDescriptor_SequenceOpts) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 5}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 5}
}
func (m *TableDescriptor_SequenceOpts) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1889,7 +1889,7 @@ func (m *TableDescriptor_Replacement) Reset() { *m = TableDescriptor_Rep
func (m *TableDescriptor_Replacement) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_Replacement) ProtoMessage() {}
func (*TableDescriptor_Replacement) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 6}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 6}
}
func (m *TableDescriptor_Replacement) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1928,7 +1928,7 @@ func (m *TableDescriptor_GCDescriptorMutation) Reset() { *m = TableDescr
func (m *TableDescriptor_GCDescriptorMutation) String() string { return proto.CompactTextString(m) }
func (*TableDescriptor_GCDescriptorMutation) ProtoMessage() {}
func (*TableDescriptor_GCDescriptorMutation) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{8, 7}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{8, 7}
}
func (m *TableDescriptor_GCDescriptorMutation) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1969,7 +1969,7 @@ func (m *DatabaseDescriptor) Reset() { *m = DatabaseDescriptor{} }
func (m *DatabaseDescriptor) String() string { return proto.CompactTextString(m) }
func (*DatabaseDescriptor) ProtoMessage() {}
func (*DatabaseDescriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{9}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{9}
}
func (m *DatabaseDescriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -2029,7 +2029,7 @@ func (m *Descriptor) Reset() { *m = Descriptor{} }
func (m *Descriptor) String() string { return proto.CompactTextString(m) }
func (*Descriptor) ProtoMessage() {}
func (*Descriptor) Descriptor() ([]byte, []int) {
- return fileDescriptor_structured_6b5fff951c7e53e5, []int{10}
+ return fileDescriptor_structured_4ac31b2906fb710c, []int{10}
}
func (m *Descriptor) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -8576,186 +8576,186 @@ var (
)
func init() {
- proto.RegisterFile("sql/sqlbase/structured.proto", fileDescriptor_structured_6b5fff951c7e53e5)
-}
-
-var fileDescriptor_structured_6b5fff951c7e53e5 = []byte{
- // 2830 bytes of a gzipped FileDescriptorProto
- 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xa4, 0x59, 0xcd, 0x6f, 0xe3, 0xc6,
- 0x15, 0x37, 0xf5, 0x49, 0x3d, 0x7d, 0xd1, 0xb3, 0x1f, 0xe1, 0x6a, 0x37, 0xb6, 0x56, 0xc9, 0xa6,
- 0x6e, 0x3e, 0xe4, 0x8d, 0x37, 0x6d, 0x83, 0x36, 0x08, 0xaa, 0x2f, 0xaf, 0xe5, 0x95, 0x25, 0x2f,
- 0x2d, 0xaf, 0x93, 0x22, 0xad, 0x40, 0x93, 0x63, 0x9b, 0x59, 0x8a, 0xd4, 0x92, 0x94, 0x6b, 0xff,
- 0x07, 0x39, 0x15, 0x3d, 0xb5, 0xb7, 0xa0, 0x08, 0x7a, 0x28, 0xd0, 0x6b, 0x0f, 0xfd, 0x13, 0x72,
- 0x2c, 0x7a, 0x2a, 0x7a, 0x30, 0x5a, 0x17, 0x3d, 0x17, 0xe8, 0x71, 0xd1, 0x02, 0xc5, 0x0c, 0x67,
- 0x28, 0xd2, 0x96, 0x5c, 0x79, 0xf7, 0x26, 0xbe, 0x99, 0xf7, 0x9b, 0x99, 0x37, 0xef, 0xfd, 0xde,
- 0x7b, 0x23, 0xb8, 0xe7, 0xbe, 0x30, 0x57, 0xdd, 0x17, 0xe6, 0xbe, 0xea, 0xe2, 0x55, 0xd7, 0x73,
- 0xc6, 0x9a, 0x37, 0x76, 0xb0, 0x5e, 0x1d, 0x39, 0xb6, 0x67, 0xa3, 0x5b, 0x9a, 0xad, 0x3d, 0x77,
- 0x6c, 0x55, 0x3b, 0xaa, 0xba, 0x2f, 0xcc, 0x2a, 0x9b, 0x57, 0x92, 0xc7, 0x9e, 0x61, 0xae, 0x1e,
- 0x99, 0xda, 0xaa, 0x67, 0x0c, 0xb1, 0xeb, 0xa9, 0xc3, 0x91, 0xaf, 0x50, 0xba, 0x1b, 0x86, 0x1b,
- 0x39, 0xc6, 0xb1, 0x61, 0xe2, 0x43, 0xcc, 0x06, 0x6f, 0x1e, 0xda, 0x87, 0x36, 0xfd, 0xb9, 0x4a,
- 0x7e, 0xf9, 0xd2, 0xca, 0x7f, 0x12, 0x70, 0x63, 0xdd, 0x76, 0xb0, 0x71, 0x68, 0x3d, 0xc1, 0xa7,
- 0x0a, 0x3e, 0xc0, 0x0e, 0xb6, 0x34, 0x8c, 0xca, 0x90, 0xf4, 0xd4, 0x7d, 0x13, 0xcb, 0x42, 0x59,
- 0x58, 0xc9, 0xd7, 0xe1, 0xdb, 0xb3, 0xe5, 0x85, 0x97, 0x67, 0xcb, 0xb1, 0x76, 0x53, 0xf1, 0x07,
- 0xd0, 0x03, 0x48, 0x1a, 0x96, 0x8e, 0x4f, 0xe4, 0x18, 0x9d, 0x51, 0x64, 0x33, 0xd2, 0x6d, 0x22,
- 0x24, 0xd3, 0xe8, 0x28, 0x92, 0x21, 0x61, 0xa9, 0x43, 0x2c, 0xc7, 0xcb, 0xc2, 0x4a, 0xa6, 0x9e,
- 0x20, 0xb3, 0x14, 0x2a, 0x41, 0x4f, 0x40, 0x3c, 0x56, 0x4d, 0x43, 0x37, 0xbc, 0x53, 0x39, 0x51,
- 0x16, 0x56, 0x0a, 0x6b, 0xdf, 0xad, 0x4e, 0x3d, 0x71, 0xb5, 0x61, 0x5b, 0xae, 0xe7, 0xa8, 0x86,
- 0xe5, 0x3d, 0x63, 0x0a, 0x0c, 0x28, 0x00, 0x40, 0x0f, 0x61, 0xd1, 0x3d, 0x52, 0x1d, 0xac, 0x0f,
- 0x46, 0x0e, 0x3e, 0x30, 0x4e, 0x06, 0x26, 0xb6, 0xe4, 0x64, 0x59, 0x58, 0x49, 0xb2, 0xa9, 0x45,
- 0x7f, 0x78, 0x9b, 0x8e, 0x76, 0xb0, 0x85, 0xfa, 0x90, 0xb1, 0xad, 0x81, 0x8e, 0x4d, 0xec, 0x61,
- 0x39, 0x45, 0xd7, 0xff, 0x70, 0xc6, 0xfa, 0x53, 0x0c, 0x54, 0xad, 0x69, 0x9e, 0x61, 0x5b, 0x7c,
- 0x1f, 0xb6, 0xd5, 0xa4, 0x40, 0x0c, 0x75, 0x3c, 0xd2, 0x55, 0x0f, 0xcb, 0xe9, 0xd7, 0x46, 0xdd,
- 0xa5, 0x40, 0xa8, 0x03, 0xc9, 0xa1, 0xea, 0x69, 0x47, 0xb2, 0x48, 0x11, 0x1f, 0x5e, 0x03, 0x71,
- 0x8b, 0xe8, 0x31, 0x40, 0x1f, 0xa4, 0xb2, 0x07, 0x29, 0x7f, 0x1d, 0x94, 0x87, 0x4c, 0xb7, 0x37,
- 0xa8, 0x35, 0xfa, 0xed, 0x5e, 0x57, 0x5a, 0x40, 0x39, 0x10, 0x95, 0xd6, 0x4e, 0x5f, 0x69, 0x37,
- 0xfa, 0x92, 0x40, 0xbe, 0x76, 0x5a, 0xfd, 0x41, 0x77, 0xb7, 0xd3, 0x91, 0x62, 0xa8, 0x08, 0x59,
- 0xf2, 0xd5, 0x6c, 0xad, 0xd7, 0x76, 0x3b, 0x7d, 0x29, 0x8e, 0xb2, 0x90, 0x6e, 0xd4, 0x76, 0x1a,
- 0xb5, 0x66, 0x4b, 0x4a, 0x94, 0x12, 0xbf, 0xfb, 0xed, 0xd2, 0x42, 0xe5, 0x21, 0x24, 0xe9, 0x72,
- 0x08, 0x20, 0xb5, 0xd3, 0xde, 0xda, 0xee, 0xb4, 0xa4, 0x05, 0x24, 0x42, 0x62, 0x9d, 0x40, 0x08,
- 0x44, 0x63, 0xbb, 0xa6, 0xf4, 0xdb, 0xb5, 0x8e, 0x14, 0x63, 0x1a, 0xff, 0x8e, 0x81, 0xd4, 0xb0,
- 0xcd, 0xf1, 0xd0, 0x6a, 0x62, 0x57, 0x73, 0x8c, 0x91, 0x67, 0x3b, 0x81, 0xcb, 0x08, 0x97, 0x5c,
- 0xe6, 0x1d, 0x88, 0x19, 0x3a, 0x73, 0xb8, 0xdb, 0x44, 0x7e, 0x4e, 0x5d, 0xf2, 0xe5, 0xd9, 0xb2,
- 0xe8, 0xa3, 0xb4, 0x9b, 0x4a, 0xcc, 0xd0, 0xd1, 0x36, 0x24, 0xbc, 0xd3, 0x91, 0xef, 0x74, 0xb9,
- 0xfa, 0x27, 0x64, 0xe6, 0x5f, 0xcf, 0x96, 0x3f, 0x3a, 0x34, 0xbc, 0xa3, 0xf1, 0x7e, 0x55, 0xb3,
- 0x87, 0xab, 0x81, 0x01, 0xf5, 0xfd, 0xc9, 0xef, 0xd5, 0xd1, 0xf3, 0xc3, 0x55, 0x1a, 0x43, 0x78,
- 0xb8, 0x4a, 0x00, 0xdc, 0x6a, 0x5f, 0xa1, 0x48, 0xa8, 0x0c, 0xa2, 0x35, 0x36, 0x4d, 0x1a, 0x12,
- 0xc4, 0x59, 0x45, 0x7e, 0x47, 0x5c, 0x8a, 0xee, 0x43, 0x4e, 0xc7, 0x07, 0xea, 0xd8, 0xf4, 0x06,
- 0xf8, 0x64, 0xe4, 0x50, 0xe7, 0xcb, 0x28, 0x59, 0x26, 0x6b, 0x9d, 0x8c, 0x1c, 0x74, 0x0f, 0x52,
- 0x47, 0x86, 0xae, 0x63, 0x8b, 0xfa, 0x1b, 0x87, 0x60, 0x32, 0xb4, 0x06, 0x8b, 0x63, 0x17, 0xbb,
- 0x03, 0x17, 0xbf, 0x18, 0x93, 0xab, 0x1b, 0x18, 0xba, 0x2b, 0x43, 0x39, 0xbe, 0x92, 0xaf, 0xa7,
- 0x58, 0xe8, 0x15, 0xc9, 0x84, 0x1d, 0x36, 0xde, 0xd6, 0x5d, 0xb2, 0xa8, 0x66, 0x0f, 0x47, 0x63,
- 0x0f, 0xfb, 0x8b, 0x66, 0xfd, 0x45, 0x99, 0x8c, 0x2c, 0xba, 0x99, 0x10, 0x45, 0x29, 0xb3, 0x99,
- 0x10, 0x33, 0x12, 0x6c, 0x26, 0xc4, 0xb4, 0x24, 0x56, 0xbe, 0x8a, 0xc1, 0x6d, 0xdf, 0x5c, 0xeb,
- 0xea, 0xd0, 0x30, 0x4f, 0x5f, 0xd7, 0xf4, 0x3e, 0x0a, 0x33, 0x3d, 0xdd, 0x11, 0xc1, 0x1e, 0x10,
- 0x35, 0x57, 0x8e, 0x97, 0xe3, 0xfe, 0x8e, 0x88, 0xac, 0x4b, 0x44, 0xe8, 0x63, 0x00, 0x36, 0x85,
- 0x9c, 0x30, 0x41, 0x4f, 0x78, 0xe7, 0xfc, 0x6c, 0x39, 0xc3, 0xef, 0xd0, 0x8d, 0x5c, 0x68, 0xc6,
- 0x9f, 0x4c, 0x8e, 0xdb, 0x83, 0x45, 0x6e, 0xe3, 0x00, 0x81, 0x1a, 0x3a, 0x5f, 0x7f, 0x8b, 0xed,
- 0xa9, 0xd8, 0xf4, 0x27, 0x70, 0xf5, 0x08, 0x54, 0x51, 0x8f, 0x0c, 0xea, 0x95, 0xdf, 0xc7, 0xe0,
- 0x66, 0xdb, 0xf2, 0xb0, 0x63, 0x62, 0xf5, 0x18, 0x87, 0x0c, 0xf1, 0x19, 0x64, 0x54, 0x4b, 0xc3,
- 0xae, 0x67, 0x3b, 0xae, 0x2c, 0x94, 0xe3, 0x2b, 0xd9, 0xb5, 0x8f, 0x66, 0x44, 0xdd, 0x34, 0xfd,
- 0x6a, 0x8d, 0x29, 0x33, 0x1b, 0x4e, 0xc0, 0x4a, 0x7f, 0x14, 0x40, 0xe4, 0xa3, 0xe8, 0x21, 0x88,
- 0x94, 0x4d, 0xc9, 0x39, 0x7c, 0xa6, 0xbd, 0xc5, 0xce, 0x91, 0xee, 0x13, 0x39, 0xdd, 0x3f, 0xb9,
- 0xf9, 0x34, 0x9d, 0xd6, 0xd6, 0xd1, 0xf7, 0x40, 0xa4, 0xc4, 0x3a, 0x08, 0x6e, 0xa3, 0xc4, 0x35,
- 0x18, 0xf3, 0x86, 0x49, 0x38, 0x4d, 0xe7, 0xb6, 0x75, 0xd4, 0x98, 0xc6, 0x8f, 0x71, 0xaa, 0xff,
- 0x06, 0xb7, 0xdc, 0x4e, 0x94, 0x21, 0x2f, 0x51, 0x66, 0xe5, 0x9f, 0x71, 0xb8, 0xbd, 0xad, 0x3a,
- 0x9e, 0x41, 0xc8, 0xc3, 0xb0, 0x0e, 0x43, 0xf6, 0x7a, 0x00, 0x59, 0x6b, 0x3c, 0x64, 0xb7, 0xe2,
- 0xb2, 0xb3, 0xf8, 0x67, 0x07, 0x6b, 0x3c, 0xf4, 0x0d, 0xee, 0xa2, 0x0e, 0x24, 0x4c, 0xc3, 0xf5,
- 0xe4, 0x18, 0xb5, 0xe8, 0xda, 0x0c, 0x8b, 0x4e, 0x5f, 0xa3, 0xda, 0x31, 0x5c, 0x8f, 0xfb, 0x24,
- 0x41, 0x41, 0x3d, 0x48, 0x3a, 0xaa, 0x75, 0x88, 0xa9, 0x93, 0x65, 0xd7, 0x1e, 0x5d, 0x0f, 0x4e,
- 0x21, 0xaa, 0x9c, 0x19, 0x29, 0x4e, 0xe9, 0xd7, 0x02, 0x24, 0xc8, 0x2a, 0x57, 0xc4, 0xc1, 0x6d,
- 0x48, 0x1d, 0xab, 0xe6, 0x18, 0xbb, 0xf4, 0x0c, 0x39, 0x85, 0x7d, 0xa1, 0x9f, 0x42, 0xd1, 0x1d,
- 0xef, 0x8f, 0x42, 0x4b, 0x51, 0xf3, 0x66, 0xd7, 0x3e, 0xb8, 0xd6, 0xae, 0x82, 0x6c, 0x15, 0xc5,
- 0x2a, 0x3d, 0x87, 0x24, 0xdd, 0xef, 0x15, 0x3b, 0xbb, 0x0f, 0x39, 0xcf, 0x1e, 0xe0, 0x13, 0xcd,
- 0x1c, 0xbb, 0xc6, 0x31, 0xa6, 0xde, 0x91, 0x53, 0xb2, 0x9e, 0xdd, 0xe2, 0x22, 0xf4, 0x00, 0x0a,
- 0x07, 0x8e, 0x3d, 0x1c, 0x18, 0x16, 0x9f, 0x44, 0x19, 0x52, 0xc9, 0x13, 0x69, 0x9b, 0x0b, 0x2b,
- 0xff, 0x15, 0xa1, 0x48, 0x3d, 0x68, 0x2e, 0x66, 0x78, 0x10, 0x62, 0x86, 0x5b, 0x11, 0x66, 0x08,
- 0xdc, 0x90, 0x10, 0xc3, 0x3d, 0x48, 0x8d, 0x2d, 0xe3, 0xc5, 0xd8, 0x5f, 0x33, 0x20, 0x3f, 0x5f,
- 0x76, 0x89, 0x36, 0x12, 0x97, 0x69, 0xe3, 0x7d, 0x40, 0x24, 0x66, 0xf0, 0x20, 0x32, 0x31, 0x49,
- 0x27, 0x4a, 0x74, 0xa4, 0x31, 0x93, 0x64, 0x52, 0xd7, 0x20, 0x99, 0x0d, 0x90, 0xf0, 0x89, 0xe7,
- 0xa8, 0x83, 0x90, 0x7e, 0x9a, 0xea, 0x2f, 0x9d, 0x9f, 0x2d, 0x17, 0x5a, 0x64, 0x6c, 0x3a, 0x48,
- 0x01, 0x87, 0xc6, 0x74, 0xe2, 0x13, 0x8b, 0x0c, 0x43, 0x37, 0x1c, 0x4c, 0x53, 0xae, 0x2b, 0x8b,
- 0xe5, 0xf8, 0x15, 0x29, 0xfc, 0x82, 0xd9, 0xab, 0x4d, 0xae, 0xa8, 0x48, 0x3e, 0x54, 0x20, 0x70,
- 0xd1, 0x53, 0xc8, 0x1e, 0xf8, 0x19, 0x7f, 0xf0, 0x1c, 0x9f, 0xca, 0x19, 0xea, 0x6e, 0xef, 0xce,
- 0x5f, 0x1b, 0xf0, 0xf8, 0x3c, 0x08, 0x86, 0xd0, 0x2e, 0xe4, 0x1d, 0x3e, 0xac, 0x0f, 0xf6, 0x4f,
- 0x69, 0xfe, 0x79, 0x15, 0xd0, 0xdc, 0x04, 0xa6, 0x7e, 0x8a, 0x9e, 0x02, 0x18, 0x01, 0x4b, 0xd2,
- 0x24, 0x95, 0x5d, 0x7b, 0xef, 0x1a, 0x74, 0xca, 0x77, 0x3a, 0x01, 0x41, 0x7b, 0x50, 0x98, 0x7c,
- 0xd1, 0xad, 0xe6, 0x5e, 0x71, 0xab, 0xf9, 0x10, 0x4e, 0xfd, 0x14, 0xf5, 0xe1, 0x26, 0x49, 0x9f,
- 0xb6, 0x6b, 0x78, 0x38, 0xec, 0x02, 0x79, 0xea, 0x02, 0x95, 0xf3, 0xb3, 0x65, 0xd4, 0xe0, 0xe3,
- 0xd3, 0xdd, 0x00, 0x69, 0x17, 0xc6, 0x7d, 0xa7, 0x8a, 0x38, 0x2f, 0x41, 0x2c, 0x4c, 0x9c, 0x6a,
- 0x67, 0xe2, 0xbe, 0x97, 0x9c, 0x2a, 0xe4, 0xda, 0x04, 0x69, 0x0f, 0x72, 0x11, 0x96, 0x29, 0xbe,
- 0x3a, 0xcb, 0x44, 0x80, 0x50, 0x8b, 0x15, 0x4d, 0x12, 0xad, 0x31, 0xdf, 0x9b, 0xd3, 0x41, 0xfb,
- 0xa7, 0x23, 0x6e, 0x48, 0xaa, 0x5e, 0x59, 0x82, 0x4c, 0xe0, 0xa3, 0x28, 0x0d, 0xf1, 0xda, 0x4e,
- 0xc3, 0xaf, 0x02, 0x9b, 0xad, 0x9d, 0x86, 0x24, 0x54, 0xee, 0x43, 0x82, 0xe8, 0x90, 0x6a, 0x70,
- 0xbd, 0xa7, 0xec, 0xd5, 0x94, 0xa6, 0x5f, 0x79, 0xb6, 0xbb, 0xcf, 0x5a, 0x4a, 0xbf, 0xd5, 0x94,
- 0x04, 0x52, 0xa0, 0xa0, 0x49, 0xcd, 0xdf, 0xb7, 0x59, 0x15, 0x7c, 0x08, 0x45, 0x2d, 0x90, 0x0e,
- 0xe8, 0x5e, 0x85, 0x72, 0x6c, 0xa5, 0xb0, 0xf6, 0xf1, 0xff, 0xed, 0x1b, 0x38, 0x46, 0x58, 0x34,
- 0xd9, 0x78, 0x41, 0x8b, 0x48, 0x03, 0xae, 0x8b, 0x95, 0x63, 0x17, 0xb8, 0x4e, 0x81, 0xa4, 0x76,
- 0x84, 0xb5, 0xe7, 0x8c, 0xdb, 0xbf, 0x3f, 0x63, 0x61, 0x9a, 0xbb, 0x43, 0x46, 0x6a, 0x10, 0x9d,
- 0xc9, 0xd2, 0x3c, 0xe9, 0x50, 0xa8, 0xca, 0x5d, 0x28, 0x44, 0x77, 0x85, 0x32, 0x90, 0x6c, 0x6c,
- 0xb4, 0x1a, 0x4f, 0xa4, 0x85, 0xca, 0xbf, 0x12, 0x80, 0x26, 0x40, 0x5b, 0x63, 0x4f, 0xa5, 0x76,
- 0xad, 0x41, 0xca, 0x77, 0x24, 0xca, 0xc7, 0xd9, 0xb5, 0xef, 0xcc, 0xb4, 0x40, 0xb4, 0xb6, 0xde,
- 0x58, 0x50, 0x98, 0x22, 0xfa, 0x34, 0xdc, 0xbf, 0x65, 0xd7, 0xde, 0x99, 0xef, 0xbe, 0x37, 0x16,
- 0x78, 0x63, 0xf7, 0x04, 0x92, 0xae, 0x47, 0xba, 0x9c, 0x38, 0xf5, 0x97, 0xd5, 0x19, 0xfa, 0x97,
- 0x37, 0x5f, 0xdd, 0x21, 0x6a, 0xdc, 0x06, 0x14, 0x03, 0xed, 0x41, 0x26, 0xa0, 0x48, 0xd6, 0x0c,
- 0x3e, 0x9a, 0x1f, 0x30, 0xf0, 0x37, 0x5e, 0x6d, 0x05, 0x58, 0xa8, 0x06, 0xd9, 0x21, 0x9b, 0x36,
- 0xa9, 0x15, 0xcb, 0x2c, 0x4b, 0x01, 0x47, 0xa0, 0xd9, 0x2a, 0xf4, 0xa5, 0x00, 0x57, 0x6a, 0xeb,
- 0xa4, 0xf4, 0x77, 0x6c, 0xd3, 0xdc, 0x57, 0xb5, 0xe7, 0xb4, 0xa3, 0x0b, 0x4a, 0x7f, 0x2e, 0x45,
- 0x4f, 0x48, 0xae, 0xe1, 0x37, 0x48, 0x7b, 0xb4, 0xec, 0x1c, 0xbd, 0x2c, 0xf7, 0xc9, 0x8d, 0x05,
- 0x25, 0xa4, 0x5e, 0xf9, 0x31, 0x24, 0xa9, 0x81, 0x48, 0x80, 0xec, 0x76, 0x9f, 0x74, 0x7b, 0x7b,
- 0xa4, 0x35, 0x2b, 0x42, 0xb6, 0xd9, 0xea, 0xb4, 0xfa, 0xad, 0x41, 0xaf, 0xdb, 0xf9, 0x5c, 0x12,
- 0xd0, 0x1d, 0xb8, 0xc5, 0x04, 0xb5, 0x6e, 0x73, 0xb0, 0xa7, 0xb4, 0xf9, 0x50, 0xac, 0xb2, 0x12,
- 0x8e, 0x40, 0x11, 0x12, 0xdd, 0x5e, 0x97, 0x34, 0x62, 0x24, 0x16, 0x9b, 0x4d, 0x49, 0xa0, 0xb1,
- 0xa8, 0xf4, 0xb6, 0xa5, 0x58, 0x3d, 0x07, 0xa0, 0x07, 0xe6, 0xdc, 0x4c, 0x88, 0x29, 0x29, 0x5d,
- 0xf9, 0xc5, 0x5d, 0x28, 0x5e, 0xf0, 0xdf, 0x2b, 0x92, 0x7f, 0x99, 0x26, 0x7f, 0xbf, 0x90, 0x94,
- 0x22, 0xc9, 0x3f, 0xc6, 0xf2, 0xfe, 0x23, 0xc8, 0x8c, 0x54, 0x07, 0x5b, 0x1e, 0xb1, 0x7f, 0x22,
- 0xd2, 0x3f, 0x88, 0xdb, 0x74, 0x20, 0x98, 0x2e, 0xfa, 0x13, 0xdb, 0x44, 0x29, 0x7d, 0x8c, 0x1d,
- 0x97, 0x78, 0x83, 0x7f, 0x65, 0x77, 0xd8, 0xf3, 0xc2, 0xe2, 0x64, 0x57, 0xcf, 0xfc, 0x09, 0x0a,
- 0x9f, 0x89, 0xb6, 0x61, 0x71, 0x68, 0xeb, 0xc6, 0x81, 0xa1, 0xf9, 0xf7, 0xed, 0x19, 0x43, 0xbf,
- 0x07, 0xcf, 0xae, 0xbd, 0x19, 0xba, 0x8d, 0xb1, 0x67, 0x98, 0xd5, 0x23, 0x53, 0xab, 0xf6, 0xf9,
- 0xf3, 0x09, 0x3b, 0x91, 0x14, 0xd6, 0x26, 0x83, 0xe8, 0x31, 0xa4, 0x79, 0x45, 0x2b, 0xd2, 0xec,
- 0x32, 0x6f, 0x9c, 0x31, 0x44, 0xae, 0x8d, 0xd6, 0xa1, 0x60, 0xe1, 0x93, 0x70, 0xd7, 0x92, 0x89,
- 0x78, 0x62, 0xae, 0x8b, 0x4f, 0xa6, 0xb7, 0x2c, 0x39, 0x6b, 0x32, 0xa2, 0xa3, 0xa7, 0x90, 0x1f,
- 0x39, 0xc6, 0x50, 0x75, 0x4e, 0x07, 0x7e, 0xf0, 0xc2, 0x75, 0x82, 0x37, 0xa0, 0x7d, 0x1f, 0x82,
- 0x8e, 0xa2, 0x75, 0xf0, 0x9b, 0x04, 0xec, 0xca, 0x59, 0x7a, 0xc6, 0xeb, 0x81, 0x71, 0x65, 0x54,
- 0x87, 0x3c, 0x3d, 0x62, 0xd0, 0x9d, 0xe4, 0xe8, 0x09, 0x97, 0xd8, 0x09, 0xb3, 0xe4, 0x84, 0x53,
- 0x3a, 0x94, 0xac, 0x15, 0xc8, 0x75, 0xb4, 0x09, 0x10, 0x3c, 0x5b, 0x91, 0x8c, 0x7b, 0x55, 0x41,
- 0xb3, 0xcd, 0x27, 0x4e, 0xb6, 0xa4, 0x84, 0xb4, 0xd1, 0x16, 0x64, 0x78, 0x10, 0xfb, 0xa9, 0x76,
- 0x76, 0x4c, 0x5e, 0xa6, 0x14, 0x4e, 0x24, 0x01, 0x02, 0xea, 0x42, 0xd2, 0xc4, 0xaa, 0x8b, 0x59,
- 0xbe, 0xfd, 0x78, 0x4e, 0xe6, 0xdf, 0xd1, 0x8e, 0xf0, 0x50, 0x6d, 0x1c, 0x91, 0xda, 0xbd, 0x43,
- 0xf4, 0x15, 0x1f, 0x06, 0x75, 0x41, 0xa2, 0xe6, 0x0a, 0xb3, 0x93, 0x44, 0x2d, 0xf6, 0x36, 0xb3,
- 0x58, 0x81, 0x58, 0x6c, 0x26, 0x43, 0x51, 0x7f, 0xda, 0x9a, 0xb0, 0xd4, 0x27, 0x50, 0x38, 0xb0,
- 0x9d, 0xa1, 0xea, 0x0d, 0x78, 0xe0, 0x2c, 0x4e, 0x2a, 0xf2, 0x97, 0x67, 0xcb, 0xf9, 0x75, 0x3a,
- 0xca, 0x83, 0x26, 0x7f, 0x10, 0xfe, 0x44, 0x1b, 0x9c, 0xcc, 0x6f, 0x50, 0xee, 0x7d, 0x7f, 0xde,
- 0xd3, 0x5d, 0x66, 0xf2, 0x2e, 0xa4, 0x68, 0x5a, 0x73, 0xe5, 0x9b, 0xd4, 0xe6, 0xaf, 0x98, 0x22,
- 0x15, 0x86, 0x82, 0xbe, 0x80, 0x82, 0x4e, 0x24, 0x86, 0x75, 0xc8, 0x2a, 0xfe, 0x5b, 0x14, 0x77,
- 0x75, 0x4e, 0x5c, 0xd2, 0x0d, 0xb4, 0xad, 0x03, 0x9b, 0x17, 0x7b, 0x1c, 0xcc, 0xef, 0x12, 0x7a,
- 0x20, 0x1e, 0xa8, 0x43, 0xc3, 0x34, 0xb0, 0x2b, 0xdf, 0xa6, 0xb8, 0x1f, 0x5c, 0x19, 0xe1, 0x17,
- 0x1f, 0x4c, 0x78, 0x2a, 0xe0, 0x20, 0x41, 0xa0, 0x53, 0xc1, 0x29, 0xb9, 0xd4, 0x37, 0x2e, 0x07,
- 0x3a, 0x7f, 0x30, 0x89, 0x3c, 0x9e, 0xd0, 0x40, 0x67, 0x5f, 0x3a, 0x7a, 0x0b, 0xe0, 0xd8, 0xc0,
- 0x3f, 0x1f, 0xbc, 0x18, 0x63, 0xe7, 0x54, 0x96, 0x43, 0xbc, 0x9b, 0x21, 0xf2, 0xa7, 0x44, 0x8c,
- 0x3e, 0x84, 0x8c, 0x8e, 0x47, 0xd8, 0xd2, 0xdd, 0x9e, 0x25, 0xdf, 0xa1, 0xd5, 0xe4, 0x0d, 0xd2,
- 0xe2, 0x34, 0xb9, 0x90, 0xf1, 0xea, 0x64, 0x16, 0xfa, 0x12, 0x72, 0xfe, 0x07, 0xd6, 0x7b, 0x56,
- 0xfd, 0x54, 0x2e, 0xd1, 0x43, 0x3f, 0x9c, 0xd3, 0x98, 0x93, 0xd2, 0xf9, 0x26, 0x3f, 0x4f, 0x33,
- 0x84, 0xa6, 0x44, 0xb0, 0xd1, 0x17, 0x90, 0xe3, 0xde, 0xbd, 0x69, 0xef, 0xbb, 0xf2, 0xdd, 0x2b,
- 0x9b, 0xfe, 0x8b, 0x6b, 0x6d, 0x4d, 0x54, 0x39, 0x6f, 0x85, 0xd1, 0xd0, 0x67, 0x90, 0x0f, 0x5e,
- 0xca, 0xec, 0x91, 0xe7, 0xca, 0xf7, 0x68, 0x60, 0x3e, 0x9a, 0xd7, 0x75, 0x99, 0x6e, 0x6f, 0xe4,
- 0xb9, 0x4a, 0xce, 0x0d, 0x7d, 0xa1, 0xfb, 0x90, 0xd1, 0x1d, 0x7b, 0xe4, 0xe7, 0x8f, 0x37, 0xcb,
- 0xc2, 0x4a, 0x9c, 0x5f, 0x33, 0x11, 0xd3, 0xc4, 0x30, 0x80, 0x82, 0x83, 0x47, 0xa6, 0xaa, 0xe1,
- 0x21, 0xc9, 0x6c, 0xf6, 0x81, 0xbc, 0x44, 0x57, 0x5f, 0x9b, 0xdb, 0x90, 0x81, 0x32, 0x77, 0xcc,
- 0x10, 0x5e, 0xef, 0x00, 0xed, 0x02, 0xa8, 0x63, 0xdd, 0xf0, 0x06, 0x43, 0x5b, 0xc7, 0xf2, 0xf2,
- 0x95, 0xcf, 0xbe, 0x17, 0xc1, 0x6b, 0x44, 0x71, 0xcb, 0xd6, 0x71, 0xf0, 0xf8, 0xc4, 0x05, 0xe8,
- 0x43, 0xc8, 0xd2, 0xa3, 0x7d, 0x69, 0xef, 0x13, 0xdf, 0x2c, 0xd3, 0xc3, 0x2d, 0xb2, 0xbb, 0xcc,
- 0x34, 0x1d, 0x7b, 0xb4, 0x69, 0xef, 0x53, 0x8f, 0x61, 0x3f, 0x75, 0xe4, 0x42, 0xee, 0x50, 0x1b,
- 0x4c, 0xa8, 0xf4, 0x3e, 0xbd, 0xc5, 0x1f, 0xcd, 0xb9, 0x97, 0xc7, 0x8d, 0x29, 0xe4, 0x7a, 0x83,
- 0xe7, 0x84, 0xc7, 0x0d, 0x2e, 0x73, 0x95, 0xec, 0xa1, 0x16, 0x7c, 0x94, 0xbe, 0x11, 0x60, 0xf1,
- 0x12, 0x75, 0xa2, 0x9f, 0x41, 0xda, 0xb2, 0xf5, 0xd0, 0x63, 0x59, 0x8b, 0x01, 0xa5, 0xba, 0xb6,
- 0xee, 0xbf, 0x95, 0x3d, 0x9a, 0xeb, 0x8d, 0x97, 0xfe, 0x1a, 0xed, 0x57, 0x7d, 0x35, 0x25, 0x45,
- 0x50, 0xdb, 0x3a, 0xfa, 0x00, 0x8a, 0xf8, 0x64, 0x64, 0x38, 0xa1, 0xf2, 0x21, 0x16, 0xba, 0xfe,
- 0xc2, 0x64, 0x90, 0x38, 0x41, 0xe9, 0xcf, 0x02, 0x14, 0x2f, 0xd0, 0x16, 0xa9, 0x94, 0xe8, 0x43,
- 0x6c, 0xa4, 0x52, 0x22, 0x92, 0x50, 0x53, 0x71, 0xd5, 0x1f, 0x21, 0xf1, 0xd7, 0xfd, 0x23, 0x24,
- 0xfa, 0xee, 0x91, 0x9c, 0xff, 0xdd, 0x63, 0x33, 0x21, 0x26, 0xa4, 0x64, 0xe9, 0x73, 0x10, 0x39,
- 0x65, 0x46, 0x4b, 0x37, 0x61, 0xce, 0xd2, 0x6d, 0xe6, 0x39, 0x4b, 0x5f, 0x0b, 0x90, 0x09, 0xff,
- 0xc3, 0x14, 0x0b, 0x50, 0xa7, 0x57, 0x8e, 0xaf, 0xf8, 0xd4, 0x19, 0xb5, 0x40, 0x7c, 0x7e, 0x0b,
- 0x94, 0x8e, 0x21, 0x1b, 0x62, 0x9d, 0x8b, 0xbd, 0x83, 0xf0, 0x0a, 0xbd, 0xc3, 0xdb, 0x90, 0x62,
- 0xa1, 0xe6, 0x3b, 0x52, 0x9e, 0x69, 0x27, 0xfd, 0x30, 0x4b, 0x7e, 0x49, 0x42, 0xac, 0xf4, 0x07,
- 0x01, 0x72, 0x61, 0x3e, 0x42, 0x15, 0xc8, 0x18, 0x96, 0xe6, 0x50, 0x32, 0xa0, 0xeb, 0x72, 0x17,
- 0x9c, 0x88, 0x09, 0x4b, 0x0d, 0x0d, 0x6b, 0x40, 0x9f, 0x1f, 0x23, 0x6e, 0x2a, 0x0e, 0x0d, 0xeb,
- 0x19, 0x91, 0xd2, 0x29, 0xea, 0x09, 0x9b, 0x12, 0x8f, 0x4c, 0x51, 0x4f, 0xfc, 0x29, 0x25, 0x9a,
- 0xf8, 0x1d, 0x8f, 0x56, 0xe6, 0xf1, 0x50, 0x2a, 0x77, 0x3c, 0xb4, 0x04, 0xe9, 0x63, 0xc3, 0xf1,
- 0xc6, 0xaa, 0x49, 0x8b, 0x70, 0xde, 0xf7, 0x70, 0x61, 0xe9, 0x08, 0xb2, 0x21, 0x1e, 0x9b, 0xe3,
- 0x42, 0x7f, 0x00, 0x89, 0x20, 0xa8, 0xe6, 0xac, 0xc9, 0xa9, 0x42, 0xe9, 0x57, 0x02, 0xdc, 0x9c,
- 0xc6, 0x24, 0x11, 0x17, 0xf1, 0xed, 0x34, 0x97, 0x8b, 0x44, 0x18, 0x3e, 0x36, 0x95, 0xe1, 0x27,
- 0x37, 0x17, 0x9f, 0x7d, 0x73, 0x95, 0x77, 0x78, 0xb3, 0x06, 0x90, 0xda, 0xde, 0xad, 0x77, 0xda,
- 0x8d, 0xa9, 0x8d, 0x16, 0x69, 0xc9, 0x02, 0x56, 0x46, 0x39, 0x10, 0x9b, 0xed, 0x9d, 0x5a, 0xbd,
- 0xd3, 0x6a, 0x4a, 0x0b, 0x28, 0x0f, 0x19, 0xa5, 0x55, 0x6b, 0xd2, 0x0e, 0x4e, 0x12, 0x7e, 0x98,
- 0xf8, 0xea, 0x37, 0xcb, 0x82, 0xdf, 0x8a, 0x6d, 0x26, 0x44, 0x24, 0xdd, 0xa8, 0x7c, 0x23, 0x00,
- 0x6a, 0xaa, 0x9e, 0x4a, 0x18, 0xe0, 0x1a, 0x3d, 0x59, 0xec, 0x8a, 0x8b, 0x88, 0xd6, 0xd9, 0xf1,
- 0xd7, 0xa9, 0xb3, 0xfd, 0x0d, 0x57, 0xbe, 0x16, 0x00, 0x42, 0x9b, 0xfb, 0x34, 0xfc, 0xf7, 0xf1,
- 0xec, 0x96, 0xe2, 0x42, 0xb6, 0xd8, 0x58, 0xe0, 0x7f, 0x2e, 0x3f, 0x06, 0x51, 0x67, 0x47, 0x66,
- 0xde, 0x32, 0xb3, 0x76, 0xbf, 0x64, 0x99, 0x0d, 0x72, 0x8d, 0x4c, 0x5a, 0x4f, 0x43, 0x72, 0x6c,
- 0x19, 0xb6, 0xf5, 0x6e, 0x33, 0xfc, 0xa4, 0xc4, 0xd9, 0x93, 0x18, 0x9f, 0xfe, 0x56, 0x3d, 0xac,
- 0xfb, 0x5d, 0xf6, 0xae, 0x75, 0x1c, 0x08, 0x04, 0x54, 0x00, 0x60, 0xe3, 0x86, 0x75, 0x28, 0xc5,
- 0xea, 0xf7, 0xbf, 0xfd, 0xfb, 0xd2, 0xc2, 0xb7, 0xe7, 0x4b, 0xc2, 0x9f, 0xce, 0x97, 0x84, 0xbf,
- 0x9c, 0x2f, 0x09, 0x7f, 0x3b, 0x5f, 0x12, 0x7e, 0xf9, 0x8f, 0xa5, 0x85, 0x9f, 0xa4, 0xd9, 0x86,
- 0xfe, 0x17, 0x00, 0x00, 0xff, 0xff, 0xe0, 0x1f, 0x27, 0x92, 0xd4, 0x1f, 0x00, 0x00,
+ proto.RegisterFile("sql/sqlbase/structured.proto", fileDescriptor_structured_4ac31b2906fb710c)
+}
+
+var fileDescriptor_structured_4ac31b2906fb710c = []byte{
+ // 2825 bytes of a gzipped FileDescriptorProto
+ 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xa4, 0x59, 0x4b, 0x6f, 0xe3, 0xc8,
+ 0x11, 0x36, 0xf5, 0xa4, 0x4a, 0x2f, 0xba, 0xe7, 0xb1, 0x1c, 0xcd, 0xac, 0xad, 0xd1, 0xee, 0x6c,
+ 0x9c, 0x7d, 0xc8, 0xb3, 0x9e, 0x3c, 0x06, 0x49, 0xb0, 0x88, 0x5e, 0x1e, 0xcb, 0x23, 0x4b, 0x1e,
+ 0x5a, 0x1e, 0xef, 0x06, 0x9b, 0x08, 0x34, 0xd9, 0xb6, 0xb9, 0x43, 0x91, 0x1a, 0x92, 0x72, 0xec,
+ 0x7f, 0xb0, 0xa7, 0x20, 0xa7, 0xe4, 0xb6, 0x08, 0x16, 0x39, 0x04, 0xc8, 0x35, 0x87, 0xfc, 0x84,
+ 0x3d, 0x06, 0x39, 0x05, 0x39, 0x18, 0x89, 0x83, 0x5c, 0x93, 0xfb, 0x20, 0x01, 0x82, 0x6e, 0x76,
+ 0x53, 0xa4, 0x2d, 0x39, 0xf2, 0xcc, 0x4d, 0xac, 0xee, 0xfa, 0xba, 0xbb, 0xba, 0xea, 0xab, 0xaa,
+ 0x16, 0xdc, 0x73, 0x5f, 0x9a, 0xab, 0xee, 0x4b, 0x73, 0x5f, 0x75, 0xf1, 0xaa, 0xeb, 0x39, 0x63,
+ 0xcd, 0x1b, 0x3b, 0x58, 0xaf, 0x8e, 0x1c, 0xdb, 0xb3, 0xd1, 0x2d, 0xcd, 0xd6, 0x5e, 0x38, 0xb6,
+ 0xaa, 0x1d, 0x55, 0xdd, 0x97, 0x66, 0x95, 0xcd, 0x2b, 0xc9, 0x63, 0xcf, 0x30, 0x57, 0x8f, 0x4c,
+ 0x6d, 0xd5, 0x33, 0x86, 0xd8, 0xf5, 0xd4, 0xe1, 0xc8, 0x57, 0x28, 0xdd, 0x0d, 0xc3, 0x8d, 0x1c,
+ 0xe3, 0xd8, 0x30, 0xf1, 0x21, 0x66, 0x83, 0x37, 0x0f, 0xed, 0x43, 0x9b, 0xfe, 0x5c, 0x25, 0xbf,
+ 0x7c, 0x69, 0xe5, 0x3f, 0x09, 0xb8, 0xb1, 0x6e, 0x3b, 0xd8, 0x38, 0xb4, 0x9e, 0xe2, 0x53, 0x05,
+ 0x1f, 0x60, 0x07, 0x5b, 0x1a, 0x46, 0x65, 0x48, 0x7a, 0xea, 0xbe, 0x89, 0x65, 0xa1, 0x2c, 0xac,
+ 0xe4, 0xeb, 0xf0, 0xcd, 0xd9, 0xf2, 0xc2, 0xab, 0xb3, 0xe5, 0x58, 0xbb, 0xa9, 0xf8, 0x03, 0xe8,
+ 0x01, 0x24, 0x0d, 0x4b, 0xc7, 0x27, 0x72, 0x8c, 0xce, 0x28, 0xb2, 0x19, 0xe9, 0x36, 0x11, 0x92,
+ 0x69, 0x74, 0x14, 0xc9, 0x90, 0xb0, 0xd4, 0x21, 0x96, 0xe3, 0x65, 0x61, 0x25, 0x53, 0x4f, 0x90,
+ 0x59, 0x0a, 0x95, 0xa0, 0xa7, 0x20, 0x1e, 0xab, 0xa6, 0xa1, 0x1b, 0xde, 0xa9, 0x9c, 0x28, 0x0b,
+ 0x2b, 0x85, 0xb5, 0x6f, 0x57, 0xa7, 0x9e, 0xb8, 0xda, 0xb0, 0x2d, 0xd7, 0x73, 0x54, 0xc3, 0xf2,
+ 0x9e, 0x33, 0x05, 0x06, 0x14, 0x00, 0xa0, 0x87, 0xb0, 0xe8, 0x1e, 0xa9, 0x0e, 0xd6, 0x07, 0x23,
+ 0x07, 0x1f, 0x18, 0x27, 0x03, 0x13, 0x5b, 0x72, 0xb2, 0x2c, 0xac, 0x24, 0xd9, 0xd4, 0xa2, 0x3f,
+ 0xbc, 0x4d, 0x47, 0x3b, 0xd8, 0x42, 0x7d, 0xc8, 0xd8, 0xd6, 0x40, 0xc7, 0x26, 0xf6, 0xb0, 0x9c,
+ 0xa2, 0xeb, 0x7f, 0x3c, 0x63, 0xfd, 0x29, 0x06, 0xaa, 0xd6, 0x34, 0xcf, 0xb0, 0x2d, 0xbe, 0x0f,
+ 0xdb, 0x6a, 0x52, 0x20, 0x86, 0x3a, 0x1e, 0xe9, 0xaa, 0x87, 0xe5, 0xf4, 0x1b, 0xa3, 0xee, 0x52,
+ 0x20, 0xd4, 0x81, 0xe4, 0x50, 0xf5, 0xb4, 0x23, 0x59, 0xa4, 0x88, 0x0f, 0xaf, 0x81, 0xb8, 0x45,
+ 0xf4, 0x18, 0xa0, 0x0f, 0x52, 0xd9, 0x83, 0x94, 0xbf, 0x0e, 0xca, 0x43, 0xa6, 0xdb, 0x1b, 0xd4,
+ 0x1a, 0xfd, 0x76, 0xaf, 0x2b, 0x2d, 0xa0, 0x1c, 0x88, 0x4a, 0x6b, 0xa7, 0xaf, 0xb4, 0x1b, 0x7d,
+ 0x49, 0x20, 0x5f, 0x3b, 0xad, 0xfe, 0xa0, 0xbb, 0xdb, 0xe9, 0x48, 0x31, 0x54, 0x84, 0x2c, 0xf9,
+ 0x6a, 0xb6, 0xd6, 0x6b, 0xbb, 0x9d, 0xbe, 0x14, 0x47, 0x59, 0x48, 0x37, 0x6a, 0x3b, 0x8d, 0x5a,
+ 0xb3, 0x25, 0x25, 0x4a, 0x89, 0xdf, 0xfd, 0x76, 0x69, 0xa1, 0xf2, 0x10, 0x92, 0x74, 0x39, 0x04,
+ 0x90, 0xda, 0x69, 0x6f, 0x6d, 0x77, 0x5a, 0xd2, 0x02, 0x12, 0x21, 0xb1, 0x4e, 0x20, 0x04, 0xa2,
+ 0xb1, 0x5d, 0x53, 0xfa, 0xed, 0x5a, 0x47, 0x8a, 0x31, 0x8d, 0x7f, 0xc5, 0x40, 0x6a, 0xd8, 0xe6,
+ 0x78, 0x68, 0x35, 0xb1, 0xab, 0x39, 0xc6, 0xc8, 0xb3, 0x9d, 0xc0, 0x65, 0x84, 0x4b, 0x2e, 0xf3,
+ 0x1e, 0xc4, 0x0c, 0x9d, 0x39, 0xdc, 0x6d, 0x22, 0x3f, 0xa7, 0x2e, 0xf9, 0xea, 0x6c, 0x59, 0xf4,
+ 0x51, 0xda, 0x4d, 0x25, 0x66, 0xe8, 0xa8, 0x03, 0x09, 0xef, 0x74, 0xe4, 0x3b, 0x5d, 0xae, 0xfe,
+ 0x98, 0xcc, 0xfc, 0xeb, 0xd9, 0xf2, 0xc3, 0x43, 0xc3, 0x3b, 0x1a, 0xef, 0x57, 0x35, 0x7b, 0xb8,
+ 0x1a, 0x18, 0x50, 0xdf, 0x9f, 0xfc, 0x5e, 0x1d, 0xbd, 0x38, 0x24, 0xf1, 0xb3, 0x4a, 0x94, 0xdd,
+ 0x6a, 0x5f, 0xa1, 0x28, 0xa8, 0x0c, 0xa2, 0x35, 0x36, 0x4d, 0x1a, 0x0e, 0xc4, 0x51, 0x45, 0x7e,
+ 0x3f, 0x5c, 0x8a, 0xee, 0x43, 0x4e, 0xc7, 0x07, 0xea, 0xd8, 0xf4, 0x06, 0xf8, 0x64, 0xe4, 0x50,
+ 0xc7, 0xcb, 0x28, 0x59, 0x26, 0x6b, 0x9d, 0x8c, 0x1c, 0x74, 0x0f, 0x52, 0x47, 0x86, 0xae, 0x63,
+ 0x8b, 0xfa, 0x1a, 0x87, 0x60, 0x32, 0xb4, 0x06, 0x8b, 0x63, 0x17, 0xbb, 0x03, 0x17, 0xbf, 0x1c,
+ 0x93, 0x6b, 0x1b, 0x18, 0xba, 0x2b, 0x43, 0x39, 0xbe, 0x92, 0xaf, 0xa7, 0x58, 0xd8, 0x15, 0xc9,
+ 0x84, 0x1d, 0x36, 0xde, 0xd6, 0x5d, 0xb2, 0xa8, 0x66, 0x0f, 0x47, 0x63, 0x0f, 0xfb, 0x8b, 0x66,
+ 0xfd, 0x45, 0x99, 0x8c, 0x2c, 0xba, 0x99, 0x10, 0x45, 0x29, 0xb3, 0x99, 0x10, 0x33, 0x12, 0x6c,
+ 0x26, 0xc4, 0xb4, 0x24, 0x56, 0xbe, 0x8c, 0xc1, 0x6d, 0xdf, 0x54, 0xeb, 0xea, 0xd0, 0x30, 0x4f,
+ 0xdf, 0xd4, 0xec, 0x3e, 0x0a, 0x33, 0x3b, 0xdd, 0x11, 0xc1, 0x1e, 0x10, 0x35, 0x57, 0x8e, 0x97,
+ 0xe3, 0xfe, 0x8e, 0x88, 0xac, 0x4b, 0x44, 0xe8, 0x31, 0x00, 0x9b, 0x42, 0x4e, 0x98, 0xa0, 0x27,
+ 0xbc, 0x73, 0x7e, 0xb6, 0x9c, 0xe1, 0xf7, 0xe7, 0x46, 0x2e, 0x33, 0xe3, 0x4f, 0x26, 0xc7, 0xed,
+ 0xc1, 0x22, 0xb7, 0x71, 0x80, 0x40, 0x0d, 0x9d, 0xaf, 0xbf, 0xc3, 0xf6, 0x54, 0x6c, 0xfa, 0x13,
+ 0xb8, 0x7a, 0x04, 0xaa, 0xa8, 0x47, 0x06, 0xf5, 0xca, 0xef, 0x63, 0x70, 0xb3, 0x6d, 0x79, 0xd8,
+ 0x31, 0xb1, 0x7a, 0x8c, 0x43, 0x86, 0xf8, 0x14, 0x32, 0xaa, 0xa5, 0x61, 0xd7, 0xb3, 0x1d, 0x57,
+ 0x16, 0xca, 0xf1, 0x95, 0xec, 0xda, 0x77, 0x66, 0x44, 0xdc, 0x34, 0xfd, 0x6a, 0x8d, 0x29, 0x33,
+ 0x1b, 0x4e, 0xc0, 0x4a, 0x7f, 0x14, 0x40, 0xe4, 0xa3, 0xe8, 0x21, 0x88, 0x94, 0x49, 0xc9, 0x39,
+ 0x7c, 0x96, 0xbd, 0xc5, 0xce, 0x91, 0xee, 0x13, 0x39, 0xdd, 0x3f, 0xb9, 0xf9, 0x34, 0x9d, 0xd6,
+ 0xd6, 0xd1, 0x77, 0x41, 0xa4, 0xa4, 0x3a, 0x08, 0x6e, 0xa3, 0xc4, 0x35, 0x18, 0xeb, 0x86, 0x09,
+ 0x38, 0x4d, 0xe7, 0xb6, 0x75, 0xd4, 0x98, 0xc6, 0x8d, 0x71, 0xaa, 0xff, 0x16, 0xb7, 0xdc, 0x4e,
+ 0x94, 0x1d, 0x2f, 0xd1, 0x65, 0xe5, 0x9f, 0x71, 0xb8, 0xbd, 0xad, 0x3a, 0x9e, 0x41, 0x88, 0xc3,
+ 0xb0, 0x0e, 0x43, 0xf6, 0x7a, 0x00, 0x59, 0x6b, 0x3c, 0x64, 0xb7, 0xe2, 0xb2, 0xb3, 0xf8, 0x67,
+ 0x07, 0x6b, 0x3c, 0xf4, 0x0d, 0xee, 0x92, 0xa0, 0x34, 0x0d, 0xd7, 0x93, 0x63, 0xd4, 0xa2, 0x6b,
+ 0x33, 0x2c, 0x3a, 0x7d, 0x8d, 0x6a, 0xc7, 0x70, 0x3d, 0xee, 0x93, 0x04, 0x05, 0xf5, 0x20, 0xe9,
+ 0xa8, 0xd6, 0x21, 0xa6, 0x4e, 0x96, 0x5d, 0x7b, 0x74, 0x3d, 0x38, 0x85, 0xa8, 0x72, 0x56, 0xa4,
+ 0x38, 0xa5, 0x5f, 0x0b, 0x90, 0x20, 0xab, 0x5c, 0x11, 0x07, 0xb7, 0x21, 0x75, 0xac, 0x9a, 0x63,
+ 0xec, 0xd2, 0x33, 0xe4, 0x14, 0xf6, 0x85, 0x7e, 0x0a, 0x45, 0x77, 0xbc, 0x3f, 0x0a, 0x2d, 0x45,
+ 0xcd, 0x9b, 0x5d, 0xfb, 0xe8, 0x5a, 0xbb, 0x0a, 0x32, 0x55, 0x14, 0xab, 0xf4, 0x02, 0x92, 0x74,
+ 0xbf, 0x57, 0xec, 0xec, 0x3e, 0xe4, 0x3c, 0x7b, 0x80, 0x4f, 0x34, 0x73, 0xec, 0x1a, 0xc7, 0x98,
+ 0x7a, 0x47, 0x4e, 0xc9, 0x7a, 0x76, 0x8b, 0x8b, 0xd0, 0x03, 0x28, 0x1c, 0x38, 0xf6, 0x70, 0x60,
+ 0x58, 0x7c, 0x12, 0x65, 0x47, 0x25, 0x4f, 0xa4, 0x6d, 0x2e, 0xac, 0xfc, 0x57, 0x84, 0x22, 0xf5,
+ 0xa0, 0xb9, 0x98, 0xe1, 0x41, 0x88, 0x19, 0x6e, 0x45, 0x98, 0x21, 0x70, 0x43, 0x42, 0x0c, 0xf7,
+ 0x20, 0x35, 0xb6, 0x8c, 0x97, 0x63, 0x7f, 0xcd, 0x80, 0xfc, 0x7c, 0xd9, 0x25, 0xda, 0x48, 0x5c,
+ 0xa6, 0x8d, 0x0f, 0x01, 0x91, 0x98, 0xc1, 0x83, 0xc8, 0xc4, 0x24, 0x9d, 0x28, 0xd1, 0x91, 0xc6,
+ 0x4c, 0x92, 0x49, 0x5d, 0x83, 0x64, 0x36, 0x40, 0xc2, 0x27, 0x9e, 0xa3, 0x0e, 0x42, 0xfa, 0x69,
+ 0xaa, 0xbf, 0x74, 0x7e, 0xb6, 0x5c, 0x68, 0x91, 0xb1, 0xe9, 0x20, 0x05, 0x1c, 0x1a, 0xd3, 0x89,
+ 0x4f, 0x2c, 0x32, 0x0c, 0xdd, 0x70, 0x30, 0x4d, 0xb7, 0xae, 0x2c, 0x96, 0xe3, 0x57, 0xa4, 0xef,
+ 0x0b, 0x66, 0xaf, 0x36, 0xb9, 0xa2, 0x22, 0xf9, 0x50, 0x81, 0xc0, 0x45, 0xcf, 0x20, 0x7b, 0xe0,
+ 0x67, 0xfb, 0xc1, 0x0b, 0x7c, 0x2a, 0x67, 0xa8, 0xbb, 0xbd, 0x3f, 0x7f, 0x5d, 0xc0, 0xe3, 0xf3,
+ 0x20, 0x18, 0x42, 0xbb, 0x90, 0x77, 0xf8, 0xb0, 0x3e, 0xd8, 0x3f, 0xa5, 0xf9, 0xe7, 0x75, 0x40,
+ 0x73, 0x13, 0x98, 0xfa, 0x29, 0x7a, 0x06, 0x60, 0x04, 0x2c, 0x49, 0x93, 0x54, 0x76, 0xed, 0x83,
+ 0x6b, 0xd0, 0x29, 0xdf, 0xe9, 0x04, 0x04, 0xed, 0x41, 0x61, 0xf2, 0x45, 0xb7, 0x9a, 0x7b, 0xcd,
+ 0xad, 0xe6, 0x43, 0x38, 0xf5, 0x53, 0xd4, 0x87, 0x9b, 0x24, 0x7d, 0xda, 0xae, 0xe1, 0xe1, 0xb0,
+ 0x0b, 0xe4, 0xa9, 0x0b, 0x54, 0xce, 0xcf, 0x96, 0x51, 0x83, 0x8f, 0x4f, 0x77, 0x03, 0xa4, 0x5d,
+ 0x18, 0xf7, 0x9d, 0x2a, 0xe2, 0xbc, 0x04, 0xb1, 0x30, 0x71, 0xaa, 0x9d, 0x89, 0xfb, 0x5e, 0x72,
+ 0xaa, 0x90, 0x6b, 0x13, 0xa4, 0x3d, 0xc8, 0x45, 0x58, 0xa6, 0xf8, 0xfa, 0x2c, 0x13, 0x01, 0x42,
+ 0x2d, 0x56, 0x30, 0x49, 0xb4, 0xbe, 0xfc, 0x60, 0x4e, 0x07, 0xed, 0x9f, 0x8e, 0xb8, 0x21, 0xa9,
+ 0x7a, 0x65, 0x09, 0x32, 0x81, 0x8f, 0xa2, 0x34, 0xc4, 0x6b, 0x3b, 0x0d, 0xbf, 0x02, 0x6c, 0xb6,
+ 0x76, 0x1a, 0x92, 0x50, 0xb9, 0x0f, 0x09, 0xa2, 0x43, 0x2a, 0xc1, 0xf5, 0x9e, 0xb2, 0x57, 0x53,
+ 0x9a, 0x7e, 0xd5, 0xd9, 0xee, 0x3e, 0x6f, 0x29, 0xfd, 0x56, 0x53, 0x12, 0x48, 0x81, 0x82, 0x26,
+ 0xf5, 0x7e, 0xdf, 0x66, 0x15, 0xf0, 0x21, 0x14, 0xb5, 0x40, 0x3a, 0xa0, 0x7b, 0x15, 0xca, 0xb1,
+ 0x95, 0xc2, 0xda, 0xe3, 0xff, 0xdb, 0x33, 0x70, 0x8c, 0xb0, 0x68, 0xb2, 0xf1, 0x82, 0x16, 0x91,
+ 0x06, 0x5c, 0x17, 0x2b, 0xc7, 0x2e, 0x70, 0x9d, 0x02, 0x49, 0xed, 0x08, 0x6b, 0x2f, 0x18, 0xb7,
+ 0x7f, 0x6f, 0xc6, 0xc2, 0x34, 0x77, 0x87, 0x8c, 0xd4, 0x20, 0x3a, 0x93, 0xa5, 0x79, 0xd2, 0xa1,
+ 0x50, 0x95, 0xbb, 0x50, 0x88, 0xee, 0x0a, 0x65, 0x20, 0xd9, 0xd8, 0x68, 0x35, 0x9e, 0x4a, 0x0b,
+ 0x95, 0x7f, 0x27, 0x00, 0x4d, 0x80, 0xb6, 0xc6, 0x9e, 0x4a, 0xed, 0x5a, 0x83, 0x94, 0xef, 0x48,
+ 0x94, 0x8f, 0xb3, 0x6b, 0xdf, 0x9a, 0x69, 0x81, 0x68, 0x5d, 0xbd, 0xb1, 0xa0, 0x30, 0x45, 0xf4,
+ 0x49, 0xb8, 0x77, 0xcb, 0xae, 0xbd, 0x37, 0xdf, 0x7d, 0x6f, 0x2c, 0xf0, 0xa6, 0xee, 0x29, 0x24,
+ 0x5d, 0x8f, 0x74, 0x38, 0x71, 0xea, 0x2f, 0xab, 0x33, 0xf4, 0x2f, 0x6f, 0xbe, 0xba, 0x43, 0xd4,
+ 0xb8, 0x0d, 0x28, 0x06, 0xda, 0x83, 0x4c, 0x40, 0x91, 0xac, 0x11, 0x7c, 0x34, 0x3f, 0x60, 0xe0,
+ 0x6f, 0xbc, 0xda, 0x0a, 0xb0, 0x50, 0x0d, 0xb2, 0x43, 0x36, 0x6d, 0x52, 0x2b, 0x96, 0x59, 0x96,
+ 0x02, 0x8e, 0x40, 0xb3, 0x55, 0xe8, 0x4b, 0x01, 0xae, 0xd4, 0xd6, 0x49, 0xe9, 0xef, 0xd8, 0xa6,
+ 0xb9, 0xaf, 0x6a, 0x2f, 0x68, 0x37, 0x17, 0x94, 0xfe, 0x5c, 0x8a, 0x9e, 0x92, 0x5c, 0xc3, 0x6f,
+ 0x90, 0xf6, 0x67, 0xd9, 0x39, 0xfa, 0x58, 0xee, 0x93, 0x1b, 0x0b, 0x4a, 0x48, 0xbd, 0xf2, 0x63,
+ 0x48, 0x52, 0x03, 0x91, 0x00, 0xd9, 0xed, 0x3e, 0xed, 0xf6, 0xf6, 0x48, 0x5b, 0x56, 0x84, 0x6c,
+ 0xb3, 0xd5, 0x69, 0xf5, 0x5b, 0x83, 0x5e, 0xb7, 0xf3, 0x99, 0x24, 0xa0, 0x3b, 0x70, 0x8b, 0x09,
+ 0x6a, 0xdd, 0xe6, 0x60, 0x4f, 0x69, 0xf3, 0xa1, 0x58, 0x65, 0x25, 0x1c, 0x81, 0x22, 0x24, 0xba,
+ 0xbd, 0x2e, 0x69, 0xc2, 0x48, 0x2c, 0x36, 0x9b, 0x92, 0x40, 0x63, 0x51, 0xe9, 0x6d, 0x4b, 0xb1,
+ 0x7a, 0x0e, 0x40, 0x0f, 0xcc, 0xb9, 0x99, 0x10, 0x53, 0x52, 0xba, 0xf2, 0x8b, 0xbb, 0x50, 0xbc,
+ 0xe0, 0xbf, 0x57, 0x24, 0xff, 0x32, 0x4d, 0xfe, 0x7e, 0x21, 0x29, 0x45, 0x92, 0x7f, 0x8c, 0xe5,
+ 0xfd, 0x47, 0x90, 0x19, 0xa9, 0x0e, 0xb6, 0x3c, 0x62, 0xff, 0x44, 0xa4, 0x7f, 0x10, 0xb7, 0xe9,
+ 0x40, 0x30, 0x5d, 0xf4, 0x27, 0xb6, 0x89, 0x52, 0xfa, 0x18, 0x3b, 0x2e, 0xf1, 0x06, 0xff, 0xca,
+ 0xee, 0xb0, 0xa7, 0x85, 0xc5, 0xc9, 0xae, 0x9e, 0xfb, 0x13, 0x14, 0x3e, 0x13, 0x6d, 0xc3, 0xe2,
+ 0xd0, 0xd6, 0x8d, 0x03, 0x43, 0xf3, 0xef, 0xdb, 0x33, 0x86, 0x7e, 0xff, 0x9d, 0x5d, 0x7b, 0x3b,
+ 0x74, 0x1b, 0x63, 0xcf, 0x30, 0xab, 0x47, 0xa6, 0x56, 0xed, 0xf3, 0xa7, 0x13, 0x76, 0x22, 0x29,
+ 0xac, 0x4d, 0x06, 0xd1, 0x13, 0x48, 0xf3, 0x8a, 0x56, 0xa4, 0xd9, 0x65, 0xde, 0x38, 0x63, 0x88,
+ 0x5c, 0x1b, 0xad, 0x43, 0xc1, 0xc2, 0x27, 0xe1, 0xae, 0x25, 0x13, 0xf1, 0xc4, 0x5c, 0x17, 0x9f,
+ 0x4c, 0x6f, 0x59, 0x72, 0xd6, 0x64, 0x44, 0x47, 0xcf, 0x20, 0x3f, 0x72, 0x8c, 0xa1, 0xea, 0x9c,
+ 0x0e, 0xfc, 0xe0, 0x85, 0xeb, 0x04, 0x6f, 0x40, 0xfb, 0x3e, 0x04, 0x1d, 0x45, 0xeb, 0xe0, 0x37,
+ 0x09, 0xd8, 0x95, 0xb3, 0xf4, 0x8c, 0xd7, 0x03, 0xe3, 0xca, 0xa8, 0x0e, 0x79, 0x7a, 0xc4, 0xa0,
+ 0x3b, 0xc9, 0xd1, 0x13, 0x2e, 0xb1, 0x13, 0x66, 0xc9, 0x09, 0xa7, 0x74, 0x28, 0x59, 0x2b, 0x90,
+ 0xeb, 0x68, 0x13, 0x20, 0x78, 0xb2, 0x22, 0x19, 0xf7, 0xaa, 0x82, 0x66, 0x9b, 0x4f, 0x9c, 0x6c,
+ 0x49, 0x09, 0x69, 0xa3, 0x2d, 0xc8, 0xf0, 0x20, 0xf6, 0x53, 0xed, 0xec, 0x98, 0xbc, 0x4c, 0x29,
+ 0x9c, 0x48, 0x02, 0x04, 0xd4, 0x85, 0xa4, 0x89, 0x55, 0x17, 0xb3, 0x7c, 0xfb, 0x78, 0x4e, 0xe6,
+ 0xdf, 0xd1, 0x8e, 0xf0, 0x50, 0x6d, 0x1c, 0x91, 0xda, 0xbd, 0x43, 0xf4, 0x15, 0x1f, 0x06, 0x75,
+ 0x41, 0xa2, 0xe6, 0x0a, 0xb3, 0x93, 0x44, 0x2d, 0xf6, 0x2e, 0xb3, 0x58, 0x81, 0x58, 0x6c, 0x26,
+ 0x43, 0x51, 0x7f, 0xda, 0x9a, 0xb0, 0xd4, 0x8f, 0xa0, 0x70, 0x60, 0x3b, 0x43, 0xd5, 0x1b, 0xf0,
+ 0xc0, 0x59, 0x9c, 0x54, 0xe4, 0xaf, 0xce, 0x96, 0xf3, 0xeb, 0x74, 0x94, 0x07, 0x4d, 0xfe, 0x20,
+ 0xfc, 0x89, 0x36, 0x38, 0x99, 0xdf, 0xa0, 0xdc, 0xfb, 0xe1, 0xbc, 0xa7, 0xbb, 0xcc, 0xe4, 0x5d,
+ 0x48, 0xd1, 0xb4, 0xe6, 0xca, 0x37, 0xa9, 0xcd, 0x5f, 0x33, 0x45, 0x2a, 0x0c, 0x05, 0x7d, 0x0e,
+ 0x05, 0x9d, 0x48, 0x0c, 0xeb, 0x90, 0x55, 0xfc, 0xb7, 0x28, 0xee, 0xea, 0x9c, 0xb8, 0xa4, 0x1b,
+ 0x68, 0x5b, 0x07, 0x36, 0x2f, 0xf6, 0x38, 0x98, 0xdf, 0x25, 0xf4, 0x40, 0x3c, 0x50, 0x87, 0x86,
+ 0x69, 0x60, 0x57, 0xbe, 0x4d, 0x71, 0x3f, 0xba, 0x32, 0xc2, 0x2f, 0x3e, 0x98, 0xf0, 0x54, 0xc0,
+ 0x41, 0x82, 0x40, 0xa7, 0x82, 0x53, 0x72, 0xa9, 0x6f, 0x5d, 0x0e, 0x74, 0xfe, 0x60, 0x12, 0x79,
+ 0x3c, 0xa1, 0x81, 0xce, 0xbe, 0x74, 0xf4, 0x0e, 0xc0, 0xb1, 0x81, 0x7f, 0x3e, 0x78, 0x39, 0xc6,
+ 0xce, 0xa9, 0x2c, 0x87, 0x78, 0x37, 0x43, 0xe4, 0xcf, 0x88, 0x18, 0x7d, 0x0c, 0x19, 0x1d, 0x8f,
+ 0xb0, 0xa5, 0xbb, 0x3d, 0x4b, 0xbe, 0x43, 0xab, 0xc9, 0x1b, 0xa4, 0xc5, 0x69, 0x72, 0x21, 0xe3,
+ 0xd5, 0xc9, 0x2c, 0xf4, 0x05, 0xe4, 0xfc, 0x0f, 0xac, 0xf7, 0xac, 0xfa, 0xa9, 0x5c, 0xa2, 0x87,
+ 0x7e, 0x38, 0xa7, 0x31, 0x27, 0xa5, 0xf3, 0x4d, 0x7e, 0x9e, 0x66, 0x08, 0x4d, 0x89, 0x60, 0xa3,
+ 0xcf, 0x21, 0xc7, 0xbd, 0x7b, 0xd3, 0xde, 0x77, 0xe5, 0xbb, 0x57, 0x36, 0xfd, 0x17, 0xd7, 0xda,
+ 0x9a, 0xa8, 0x72, 0xde, 0x0a, 0xa3, 0xa1, 0x4f, 0x21, 0x1f, 0xbc, 0x94, 0xd9, 0x23, 0xcf, 0x95,
+ 0xef, 0xd1, 0xc0, 0x7c, 0x34, 0xaf, 0xeb, 0x32, 0xdd, 0xde, 0xc8, 0x73, 0x95, 0x9c, 0x1b, 0xfa,
+ 0x42, 0xf7, 0x21, 0xa3, 0x3b, 0xf6, 0xc8, 0xcf, 0x1f, 0x6f, 0x97, 0x85, 0x95, 0x38, 0xbf, 0x66,
+ 0x22, 0xa6, 0x89, 0x61, 0x00, 0x05, 0x07, 0x8f, 0x4c, 0x55, 0xc3, 0x43, 0x92, 0xd9, 0xec, 0x03,
+ 0x79, 0x89, 0xae, 0xbe, 0x36, 0xb7, 0x21, 0x03, 0x65, 0xee, 0x98, 0x21, 0xbc, 0xde, 0x01, 0xda,
+ 0x05, 0x50, 0xc7, 0xba, 0xe1, 0x0d, 0x86, 0xb6, 0x8e, 0xe5, 0xe5, 0x2b, 0x9f, 0x7c, 0x2f, 0x82,
+ 0xd7, 0x88, 0xe2, 0x96, 0xad, 0xe3, 0xe0, 0xf1, 0x89, 0x0b, 0xd0, 0xc7, 0x90, 0xa5, 0x47, 0xfb,
+ 0xc2, 0xde, 0x27, 0xbe, 0x59, 0xa6, 0x87, 0x5b, 0x64, 0x77, 0x99, 0x69, 0x3a, 0xf6, 0x68, 0xd3,
+ 0xde, 0xa7, 0x1e, 0xc3, 0x7e, 0xea, 0xc8, 0x85, 0xdc, 0xa1, 0x36, 0x98, 0x50, 0xe9, 0x7d, 0x7a,
+ 0x8b, 0x3f, 0x9c, 0x73, 0x2f, 0x4f, 0x1a, 0x53, 0xc8, 0xf5, 0x06, 0xcf, 0x09, 0x4f, 0x1a, 0x5c,
+ 0xe6, 0x2a, 0xd9, 0x43, 0x2d, 0xf8, 0x28, 0x7d, 0x2d, 0xc0, 0xe2, 0x25, 0xea, 0x44, 0x3f, 0x83,
+ 0xb4, 0x65, 0xeb, 0xa1, 0xc7, 0xb2, 0x16, 0x03, 0x4a, 0x75, 0x6d, 0xdd, 0x7f, 0x2b, 0x7b, 0x34,
+ 0xd7, 0xfb, 0x2e, 0xfd, 0x35, 0xda, 0xaf, 0xfa, 0x6a, 0x4a, 0x8a, 0xa0, 0xb6, 0x75, 0xf4, 0x11,
+ 0x14, 0xf1, 0xc9, 0xc8, 0x70, 0x42, 0xe5, 0x43, 0x2c, 0x74, 0xfd, 0x85, 0xc9, 0x20, 0x71, 0x82,
+ 0xd2, 0x9f, 0x05, 0x28, 0x5e, 0xa0, 0x2d, 0x52, 0x29, 0xd1, 0x87, 0xd8, 0x48, 0xa5, 0x44, 0x24,
+ 0xa1, 0xa6, 0xe2, 0xaa, 0x3f, 0x41, 0xe2, 0x6f, 0xfa, 0x27, 0x48, 0xf4, 0xdd, 0x23, 0x39, 0xff,
+ 0xbb, 0xc7, 0x66, 0x42, 0x4c, 0x48, 0xc9, 0xd2, 0x67, 0x20, 0x72, 0xca, 0x8c, 0x96, 0x6e, 0xc2,
+ 0x9c, 0xa5, 0xdb, 0xcc, 0x73, 0x96, 0xbe, 0x12, 0x20, 0x13, 0xfe, 0x77, 0x29, 0x16, 0xa0, 0x4e,
+ 0xaf, 0x1c, 0x5f, 0xf3, 0xa9, 0x33, 0x6a, 0x81, 0xf8, 0xfc, 0x16, 0x28, 0x1d, 0x43, 0x36, 0xc4,
+ 0x3a, 0x17, 0x7b, 0x07, 0xe1, 0x35, 0x7a, 0x87, 0x77, 0x21, 0xc5, 0x42, 0xcd, 0x77, 0xa4, 0x3c,
+ 0xd3, 0x4e, 0xfa, 0x61, 0x96, 0xfc, 0x82, 0x84, 0x58, 0xe9, 0x0f, 0x02, 0xe4, 0xc2, 0x7c, 0x84,
+ 0x2a, 0x90, 0x31, 0x2c, 0xcd, 0xa1, 0x64, 0x40, 0xd7, 0xe5, 0x2e, 0x38, 0x11, 0x13, 0x96, 0x1a,
+ 0x1a, 0xd6, 0x80, 0x3e, 0x3f, 0x46, 0xdc, 0x54, 0x1c, 0x1a, 0xd6, 0x73, 0x22, 0xa5, 0x53, 0xd4,
+ 0x13, 0x36, 0x25, 0x1e, 0x99, 0xa2, 0x9e, 0xf8, 0x53, 0x4a, 0x34, 0xf1, 0x3b, 0x1e, 0xad, 0xcc,
+ 0xe3, 0xa1, 0x54, 0xee, 0x78, 0x68, 0x09, 0xd2, 0xc7, 0x86, 0xe3, 0x8d, 0x55, 0x93, 0x16, 0xe1,
+ 0xbc, 0xef, 0xe1, 0xc2, 0xd2, 0x11, 0x64, 0x43, 0x3c, 0x36, 0xc7, 0x85, 0x7e, 0x1f, 0x12, 0x41,
+ 0x50, 0xcd, 0x59, 0x93, 0x53, 0x85, 0xd2, 0xaf, 0x04, 0xb8, 0x39, 0x8d, 0x49, 0x22, 0x2e, 0xe2,
+ 0xdb, 0x69, 0x2e, 0x17, 0x89, 0x30, 0x7c, 0x6c, 0x2a, 0xc3, 0x4f, 0x6e, 0x2e, 0x3e, 0xfb, 0xe6,
+ 0x2a, 0xef, 0xf1, 0x66, 0x0d, 0x20, 0xb5, 0xbd, 0x5b, 0xef, 0xb4, 0x1b, 0x53, 0x1b, 0x2d, 0xd2,
+ 0x92, 0x05, 0xac, 0x8c, 0x72, 0x20, 0x36, 0xdb, 0x3b, 0xb5, 0x7a, 0xa7, 0xd5, 0x94, 0x16, 0x50,
+ 0x1e, 0x32, 0x4a, 0xab, 0xd6, 0xa4, 0x1d, 0x9c, 0x24, 0xfc, 0x20, 0xf1, 0xe5, 0x6f, 0x96, 0x05,
+ 0xbf, 0x15, 0xdb, 0x4c, 0x88, 0x48, 0xba, 0x51, 0xf9, 0x5a, 0x00, 0xd4, 0x54, 0x3d, 0x95, 0x30,
+ 0xc0, 0x35, 0x7a, 0xb2, 0xd8, 0x15, 0x17, 0x11, 0xad, 0xb3, 0xe3, 0x6f, 0x52, 0x67, 0xfb, 0x1b,
+ 0xae, 0x7c, 0x25, 0x00, 0x84, 0x36, 0xf7, 0x49, 0xf8, 0xaf, 0xe3, 0xd9, 0x2d, 0xc5, 0x85, 0x6c,
+ 0xb1, 0xb1, 0xc0, 0xff, 0x58, 0x7e, 0x02, 0xa2, 0xce, 0x8e, 0xcc, 0xbc, 0x65, 0x66, 0xed, 0x7e,
+ 0xc9, 0x32, 0x1b, 0xe4, 0x1a, 0x99, 0xb4, 0x9e, 0x86, 0xe4, 0xd8, 0x32, 0x6c, 0xeb, 0xfd, 0x66,
+ 0xf8, 0x49, 0x89, 0xb3, 0x27, 0x31, 0x3e, 0xfd, 0xad, 0x7a, 0x58, 0xf7, 0xbb, 0xec, 0x5d, 0xeb,
+ 0x38, 0x10, 0x08, 0xa8, 0x00, 0xc0, 0xc6, 0x0d, 0xeb, 0x50, 0x8a, 0xd5, 0xef, 0x7f, 0xf3, 0xf7,
+ 0xa5, 0x85, 0x6f, 0xce, 0x97, 0x84, 0x3f, 0x9d, 0x2f, 0x09, 0x7f, 0x39, 0x5f, 0x12, 0xfe, 0x76,
+ 0xbe, 0x24, 0xfc, 0xf2, 0x1f, 0x4b, 0x0b, 0x3f, 0x49, 0xb3, 0x0d, 0xfd, 0x2f, 0x00, 0x00, 0xff,
+ 0xff, 0xd8, 0x5f, 0x8e, 0x22, 0xd0, 0x1f, 0x00, 0x00,
}
diff --git a/pkg/sql/sqlbase/structured.proto b/pkg/sql/sqlbase/structured.proto
index 3ee5d4f0cdde..0e7b30a76d21 100644
--- a/pkg/sql/sqlbase/structured.proto
+++ b/pkg/sql/sqlbase/structured.proto
@@ -68,7 +68,7 @@ message ColumnDescriptor {
optional string name = 1 [(gogoproto.nullable) = false];
optional uint32 id = 2 [(gogoproto.nullable) = false,
(gogoproto.customname) = "ID", (gogoproto.casttype) = "ColumnID"];
- optional bytes type = 3 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/sem/types.T"];
+ optional bytes type = 3 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/types.T"];
optional bool nullable = 4 [(gogoproto.nullable) = false];
reserved 8;
// Default expression to use to populate the column on insert if no
diff --git a/pkg/sql/sqlbase/structured_test.go b/pkg/sql/sqlbase/structured_test.go
index 1d0c133a2a67..eae7fe7e482a 100644
--- a/pkg/sql/sqlbase/structured_test.go
+++ b/pkg/sql/sqlbase/structured_test.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
diff --git a/pkg/sql/sqlbase/system.go b/pkg/sql/sqlbase/system.go
index 228aad6cbfdf..86b596fc5e0d 100644
--- a/pkg/sql/sqlbase/system.go
+++ b/pkg/sql/sqlbase/system.go
@@ -22,7 +22,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/security"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
func init() {
diff --git a/pkg/sql/sqlbase/table.go b/pkg/sql/sqlbase/table.go
index 500bea68f02a..daa7d4eff827 100644
--- a/pkg/sql/sqlbase/table.go
+++ b/pkg/sql/sqlbase/table.go
@@ -21,7 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/pkg/errors"
"golang.org/x/text/language"
diff --git a/pkg/sql/sqlbase/table_test.go b/pkg/sql/sqlbase/table_test.go
index 33367f7f6b4d..09b2def53be0 100644
--- a/pkg/sql/sqlbase/table_test.go
+++ b/pkg/sql/sqlbase/table_test.go
@@ -28,7 +28,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
diff --git a/pkg/sql/sqlbase/testutils.go b/pkg/sql/sqlbase/testutils.go
index 13148bede605..8b0b59d93de2 100644
--- a/pkg/sql/sqlbase/testutils.go
+++ b/pkg/sql/sqlbase/testutils.go
@@ -26,7 +26,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/duration"
"github.com/cockroachdb/cockroach/pkg/util/ipaddr"
diff --git a/pkg/sql/stats/automatic_stats_test.go b/pkg/sql/stats/automatic_stats_test.go
index 31a544b64d21..7c7ff19c011d 100644
--- a/pkg/sql/stats/automatic_stats_test.go
+++ b/pkg/sql/stats/automatic_stats_test.go
@@ -25,9 +25,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/stats/delete_stats.go b/pkg/sql/stats/delete_stats.go
index 1cb1caa02c13..0fbd367f5478 100644
--- a/pkg/sql/stats/delete_stats.go
+++ b/pkg/sql/stats/delete_stats.go
@@ -19,9 +19,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
const (
diff --git a/pkg/sql/stats/histogram.pb.go b/pkg/sql/stats/histogram.pb.go
index e69333c05b6d..7d5b11b12d24 100644
--- a/pkg/sql/stats/histogram.pb.go
+++ b/pkg/sql/stats/histogram.pb.go
@@ -7,7 +7,7 @@ import proto "github.com/gogo/protobuf/proto"
import fmt "fmt"
import math "math"
-import github_com_cockroachdb_cockroach_pkg_sql_sem_types "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+import github_com_cockroachdb_cockroach_pkg_sql_types "github.com/cockroachdb/cockroach/pkg/sql/types"
import io "io"
@@ -26,7 +26,7 @@ const _ = proto.GoGoProtoPackageIsVersion2 // please upgrade the proto package
// distribution of values on a specific column.
type HistogramData struct {
// Value type for the column.
- ColumnType github_com_cockroachdb_cockroach_pkg_sql_sem_types.T `protobuf:"bytes,2,opt,name=column_type,json=columnType,proto3,customtype=github.com/cockroachdb/cockroach/pkg/sql/sem/types.T" json:"column_type"`
+ ColumnType github_com_cockroachdb_cockroach_pkg_sql_types.T `protobuf:"bytes,2,opt,name=column_type,json=columnType,proto3,customtype=github.com/cockroachdb/cockroach/pkg/sql/types.T" json:"column_type"`
// Histogram buckets. Note that NULL values are excluded from the
// histogram.
Buckets []HistogramData_Bucket `protobuf:"bytes,1,rep,name=buckets,proto3" json:"buckets"`
@@ -38,7 +38,7 @@ func (m *HistogramData) Reset() { *m = HistogramData{} }
func (m *HistogramData) String() string { return proto.CompactTextString(m) }
func (*HistogramData) ProtoMessage() {}
func (*HistogramData) Descriptor() ([]byte, []int) {
- return fileDescriptor_histogram_08b25f7fa516d28a, []int{0}
+ return fileDescriptor_histogram_6516002510d2a33e, []int{0}
}
func (m *HistogramData) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -86,7 +86,7 @@ func (m *HistogramData_Bucket) Reset() { *m = HistogramData_Bucket{} }
func (m *HistogramData_Bucket) String() string { return proto.CompactTextString(m) }
func (*HistogramData_Bucket) ProtoMessage() {}
func (*HistogramData_Bucket) Descriptor() ([]byte, []int) {
- return fileDescriptor_histogram_08b25f7fa516d28a, []int{0, 0}
+ return fileDescriptor_histogram_6516002510d2a33e, []int{0, 0}
}
func (m *HistogramData_Bucket) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -581,29 +581,29 @@ var (
)
func init() {
- proto.RegisterFile("sql/stats/histogram.proto", fileDescriptor_histogram_08b25f7fa516d28a)
+ proto.RegisterFile("sql/stats/histogram.proto", fileDescriptor_histogram_6516002510d2a33e)
}
-var fileDescriptor_histogram_08b25f7fa516d28a = []byte{
- // 311 bytes of a gzipped FileDescriptorProto
+var fileDescriptor_histogram_6516002510d2a33e = []byte{
+ // 308 bytes of a gzipped FileDescriptorProto
0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x6c, 0x90, 0xbf, 0x4e, 0xeb, 0x30,
0x18, 0xc5, 0xeb, 0xe6, 0xb6, 0x17, 0x5c, 0x58, 0x02, 0x48, 0xa1, 0x48, 0x49, 0xc5, 0x54, 0x16,
- 0x5b, 0x02, 0x46, 0xa6, 0x08, 0x24, 0x58, 0xa3, 0x4e, 0x48, 0x55, 0x95, 0xb8, 0x96, 0x5b, 0xb5,
- 0xfe, 0x93, 0xd8, 0x1e, 0xfa, 0x16, 0x8c, 0x3c, 0x52, 0x46, 0x46, 0xc4, 0x50, 0x41, 0x78, 0x11,
- 0x64, 0x47, 0x05, 0x21, 0xb1, 0x7d, 0x3e, 0x3e, 0xbf, 0x73, 0xec, 0x0f, 0x9e, 0xea, 0x72, 0x8d,
- 0xb5, 0xc9, 0x8d, 0xc6, 0x8b, 0xa5, 0x36, 0x92, 0x55, 0x39, 0x47, 0xaa, 0x92, 0x46, 0x86, 0x47,
- 0x44, 0x92, 0x55, 0x25, 0x73, 0xb2, 0x40, 0xba, 0x5c, 0x23, 0x6f, 0x1a, 0x1e, 0x33, 0xc9, 0xa4,
- 0xbf, 0xc7, 0x6e, 0x6a, 0xad, 0xe7, 0xcf, 0x5d, 0x78, 0x78, 0xbf, 0xc3, 0x6f, 0x73, 0x93, 0x87,
- 0x0f, 0xf0, 0x7f, 0x61, 0xc9, 0x8a, 0x1a, 0x1d, 0x81, 0x51, 0x30, 0x1e, 0x5c, 0x5e, 0xa0, 0x3f,
- 0xe2, 0xd0, 0x2f, 0x08, 0xa5, 0x9e, 0x48, 0xff, 0xd5, 0xdb, 0xa4, 0x93, 0xed, 0xf8, 0x70, 0x0a,
- 0x07, 0x44, 0xae, 0x2d, 0x17, 0x33, 0xb3, 0x51, 0x34, 0xea, 0x8e, 0xc0, 0xf8, 0x20, 0xbd, 0x71,
- 0x9e, 0xb7, 0x6d, 0x72, 0xcd, 0x96, 0x66, 0x61, 0x0b, 0x44, 0x24, 0xc7, 0xdf, 0x05, 0xf3, 0xe2,
- 0x67, 0xc6, 0x6a, 0xc5, 0xb0, 0xff, 0x24, 0xe5, 0xd8, 0x05, 0x68, 0x34, 0xc9, 0x60, 0x1b, 0x38,
- 0xd9, 0x28, 0x3a, 0x9c, 0xc2, 0x7e, 0xdb, 0x1b, 0x9e, 0xc0, 0xbe, 0xb0, 0x7c, 0x46, 0xcb, 0x08,
- 0x8c, 0xc0, 0x38, 0xc8, 0x7a, 0xc2, 0xf2, 0xbb, 0x32, 0x3c, 0x83, 0xfb, 0x4e, 0xae, 0x72, 0xc1,
- 0xda, 0xf6, 0x20, 0xdb, 0x13, 0x96, 0x67, 0xee, 0x1c, 0x26, 0x70, 0x60, 0x95, 0xa2, 0xd5, 0xac,
- 0x90, 0x56, 0xcc, 0xa3, 0xc0, 0x3d, 0x2e, 0x83, 0x5e, 0x4a, 0x9d, 0x92, 0x26, 0xf5, 0x47, 0xdc,
- 0xa9, 0x9b, 0x18, 0xbc, 0x34, 0x31, 0x78, 0x6d, 0x62, 0xf0, 0xde, 0xc4, 0xe0, 0xe9, 0x33, 0xee,
- 0x3c, 0xf6, 0xfc, 0x0a, 0x8a, 0xbe, 0x5f, 0xe1, 0xd5, 0x57, 0x00, 0x00, 0x00, 0xff, 0xff, 0x22,
- 0xbf, 0xdf, 0x6b, 0x8a, 0x01, 0x00, 0x00,
+ 0x07, 0xc1, 0xc2, 0x1c, 0x81, 0x04, 0xab, 0xd5, 0x05, 0x24, 0x54, 0x39, 0x6e, 0xe4, 0x56, 0xad,
+ 0xff, 0x24, 0xb6, 0x87, 0xbe, 0x05, 0x03, 0x0f, 0x95, 0x91, 0x11, 0x31, 0x54, 0x10, 0x5e, 0x04,
+ 0xd9, 0x51, 0x41, 0x48, 0x6c, 0x9f, 0x8f, 0xcf, 0xef, 0x3b, 0x3e, 0x86, 0xc7, 0xba, 0x5c, 0xa5,
+ 0xda, 0x10, 0xa3, 0xd3, 0xf9, 0x42, 0x1b, 0xc9, 0x2a, 0xc2, 0x91, 0xaa, 0xa4, 0x91, 0xe1, 0x01,
+ 0x95, 0x74, 0x59, 0x49, 0x42, 0xe7, 0x48, 0x97, 0x2b, 0xe4, 0x4d, 0xc3, 0x43, 0x26, 0x99, 0xf4,
+ 0xf7, 0xa9, 0x9b, 0x5a, 0xeb, 0xe9, 0x73, 0x17, 0xee, 0xdf, 0x6e, 0xf1, 0x6b, 0x62, 0x48, 0x78,
+ 0x07, 0xff, 0xe7, 0x96, 0x2e, 0x0b, 0xa3, 0x23, 0x30, 0x0a, 0xc6, 0x83, 0x8b, 0x33, 0xf4, 0xc7,
+ 0x3a, 0xf4, 0x0b, 0x42, 0x99, 0x27, 0xb2, 0x7f, 0xf5, 0x26, 0xe9, 0xe0, 0x2d, 0x1f, 0xde, 0xc3,
+ 0x01, 0x95, 0x2b, 0xcb, 0xc5, 0xd4, 0xac, 0x55, 0x11, 0x75, 0x47, 0x60, 0xbc, 0x97, 0x5d, 0x39,
+ 0xcf, 0xdb, 0x26, 0x39, 0x67, 0x0b, 0x33, 0xb7, 0x39, 0xa2, 0x92, 0xa7, 0xdf, 0x01, 0xb3, 0xfc,
+ 0x67, 0x4e, 0xd5, 0x92, 0xa5, 0xae, 0xa4, 0x83, 0x35, 0x9a, 0x60, 0xd8, 0x2e, 0x9b, 0xac, 0x55,
+ 0x31, 0x7c, 0x84, 0xfd, 0x36, 0x33, 0x3c, 0x82, 0x7d, 0x61, 0xf9, 0xb4, 0x28, 0x23, 0x30, 0x02,
+ 0xe3, 0x00, 0xf7, 0x84, 0xe5, 0x37, 0x65, 0x78, 0x02, 0x77, 0x9d, 0x5c, 0x11, 0xc1, 0xda, 0xe4,
+ 0x00, 0xef, 0x08, 0xcb, 0xb1, 0x3b, 0x87, 0x09, 0x1c, 0x58, 0xa5, 0x8a, 0x6a, 0x9a, 0x4b, 0x2b,
+ 0x66, 0x51, 0xe0, 0x1e, 0x86, 0xa1, 0x97, 0x32, 0xa7, 0x64, 0x49, 0xfd, 0x11, 0x77, 0xea, 0x26,
+ 0x06, 0x2f, 0x4d, 0x0c, 0x5e, 0x9b, 0x18, 0xbc, 0x37, 0x31, 0x78, 0xfa, 0x8c, 0x3b, 0x0f, 0x3d,
+ 0x5f, 0x3f, 0xef, 0xfb, 0xef, 0xbb, 0xfc, 0x0a, 0x00, 0x00, 0xff, 0xff, 0xa2, 0x0b, 0x02, 0x9c,
+ 0x86, 0x01, 0x00, 0x00,
}
diff --git a/pkg/sql/stats/histogram.proto b/pkg/sql/stats/histogram.proto
index 0e7362da0ea7..6adb22eb1723 100644
--- a/pkg/sql/stats/histogram.proto
+++ b/pkg/sql/stats/histogram.proto
@@ -45,7 +45,7 @@ message HistogramData {
}
// Value type for the column.
- bytes column_type = 2 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/sem/types.T"];
+ bytes column_type = 2 [(gogoproto.nullable) = false, (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/sql/types.T"];
// Histogram buckets. Note that NULL values are excluded from the
// histogram.
diff --git a/pkg/sql/stats/json.go b/pkg/sql/stats/json.go
index bab0987e8280..41147247388f 100644
--- a/pkg/sql/stats/json.go
+++ b/pkg/sql/stats/json.go
@@ -19,8 +19,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
)
diff --git a/pkg/sql/stats/new_stat.go b/pkg/sql/stats/new_stat.go
index dc820c04e9eb..8a69d0f450d0 100644
--- a/pkg/sql/stats/new_stat.go
+++ b/pkg/sql/stats/new_stat.go
@@ -20,9 +20,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/gossip"
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
)
diff --git a/pkg/sql/stats/row_sampling.go b/pkg/sql/stats/row_sampling.go
index 6b9207f66589..76fffb2cb7ab 100644
--- a/pkg/sql/stats/row_sampling.go
+++ b/pkg/sql/stats/row_sampling.go
@@ -17,8 +17,8 @@ package stats
import (
"container/heap"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// SampledRow is a row that was sampled.
diff --git a/pkg/sql/stats/row_sampling_test.go b/pkg/sql/stats/row_sampling_test.go
index 95d6ea33a86b..2891de39869c 100644
--- a/pkg/sql/stats/row_sampling_test.go
+++ b/pkg/sql/stats/row_sampling_test.go
@@ -21,8 +21,8 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
)
diff --git a/pkg/sql/stats/stats_cache.go b/pkg/sql/stats/stats_cache.go
index 8a6fc4b80e8e..7ffd91b4c0d4 100644
--- a/pkg/sql/stats/stats_cache.go
+++ b/pkg/sql/stats/stats_cache.go
@@ -24,9 +24,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/cache"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
diff --git a/pkg/sql/stats/stats_cache_test.go b/pkg/sql/stats/stats_cache_test.go
index d8fbdacc9c4a..b238a6cf22b8 100644
--- a/pkg/sql/stats/stats_cache_test.go
+++ b/pkg/sql/stats/stats_cache_test.go
@@ -26,9 +26,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/sqlutil"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/subquery.go b/pkg/sql/subquery.go
index 1daf47c032ce..9528ba00bf80 100644
--- a/pkg/sql/subquery.go
+++ b/pkg/sql/subquery.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/distsqlrun"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/table_test.go b/pkg/sql/table_test.go
index 6b9042375851..1065447312ce 100644
--- a/pkg/sql/table_test.go
+++ b/pkg/sql/table_test.go
@@ -20,8 +20,8 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
diff --git a/pkg/sql/targets.go b/pkg/sql/targets.go
index ee7396922521..80c2a6c236ca 100644
--- a/pkg/sql/targets.go
+++ b/pkg/sql/targets.go
@@ -18,8 +18,8 @@ import (
"context"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
const autoGenerateRenderOutputName = ""
diff --git a/pkg/sql/tests/planhook.go b/pkg/sql/tests/planhook.go
index d0268b116da2..4117e913a066 100644
--- a/pkg/sql/tests/planhook.go
+++ b/pkg/sql/tests/planhook.go
@@ -19,8 +19,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// Add a placeholder implementation to test the plan hook. It accepts statements
diff --git a/pkg/sql/tests/rsg_test.go b/pkg/sql/tests/rsg_test.go
index 887ba0c98563..08e8a37b7a97 100644
--- a/pkg/sql/tests/rsg_test.go
+++ b/pkg/sql/tests/rsg_test.go
@@ -38,9 +38,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/builtins"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
"github.com/cockroachdb/cockroach/pkg/sql/tests"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/util/ctxgroup"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
diff --git a/pkg/sql/sem/types/oid.go b/pkg/sql/types/oid.go
similarity index 100%
rename from pkg/sql/sem/types/oid.go
rename to pkg/sql/types/oid.go
diff --git a/pkg/sql/sem/types/types.go b/pkg/sql/types/types.go
similarity index 100%
rename from pkg/sql/sem/types/types.go
rename to pkg/sql/types/types.go
diff --git a/pkg/sql/sem/types/types.pb.go b/pkg/sql/types/types.pb.go
similarity index 87%
rename from pkg/sql/sem/types/types.pb.go
rename to pkg/sql/types/types.pb.go
index fcecc9ff7121..3585068a9c92 100644
--- a/pkg/sql/sem/types/types.pb.go
+++ b/pkg/sql/types/types.pb.go
@@ -1,5 +1,5 @@
// Code generated by protoc-gen-gogo. DO NOT EDIT.
-// source: sql/sem/types/types.proto
+// source: sql/types/types.proto
package types
@@ -369,7 +369,7 @@ func (x *SemanticType) UnmarshalJSON(data []byte) error {
return nil
}
func (SemanticType) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_types_590ae0e7819e34f1, []int{0}
+ return fileDescriptor_types_3d4b78bea0da8847, []int{0}
}
// InternalType is the protobuf encoding for SQL types. It is always wrapped by
@@ -425,7 +425,7 @@ func (m *InternalType) Reset() { *m = InternalType{} }
func (m *InternalType) String() string { return proto.CompactTextString(m) }
func (*InternalType) ProtoMessage() {}
func (*InternalType) Descriptor() ([]byte, []int) {
- return fileDescriptor_types_590ae0e7819e34f1, []int{0}
+ return fileDescriptor_types_3d4b78bea0da8847, []int{0}
}
func (m *InternalType) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -1072,48 +1072,48 @@ var (
ErrIntOverflowTypes = fmt.Errorf("proto: integer overflow")
)
-func init() { proto.RegisterFile("sql/sem/types/types.proto", fileDescriptor_types_590ae0e7819e34f1) }
+func init() { proto.RegisterFile("sql/types/types.proto", fileDescriptor_types_3d4b78bea0da8847) }
-var fileDescriptor_types_590ae0e7819e34f1 = []byte{
- // 635 bytes of a gzipped FileDescriptorProto
- 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x94, 0x52, 0xcd, 0x6e, 0xd3, 0x4a,
- 0x14, 0xce, 0xd4, 0x76, 0x62, 0x4f, 0x9c, 0x74, 0xee, 0xb4, 0xf7, 0x5e, 0xb7, 0x8b, 0xc4, 0x44,
- 0x42, 0x18, 0x84, 0x1c, 0xc4, 0x92, 0x9d, 0xdd, 0x18, 0x64, 0x70, 0xec, 0xca, 0x99, 0x80, 0xda,
- 0x4d, 0x94, 0xd8, 0xa3, 0xd6, 0xc2, 0x3f, 0x69, 0xec, 0x82, 0xfa, 0x06, 0x2c, 0x59, 0xb3, 0x85,
- 0x87, 0x49, 0x77, 0x2c, 0x11, 0x8b, 0x0a, 0xc2, 0x8b, 0xa0, 0xb1, 0x4d, 0xc9, 0x86, 0x05, 0x1b,
- 0xeb, 0xf8, 0xfb, 0x3b, 0xdf, 0x91, 0x06, 0x1e, 0xe4, 0x17, 0xf1, 0x30, 0xa7, 0xc9, 0xb0, 0xb8,
- 0x5a, 0xd2, 0xbc, 0xfa, 0xea, 0xcb, 0x55, 0x56, 0x64, 0xf8, 0xff, 0x20, 0x0b, 0x5e, 0xaf, 0xb2,
- 0x79, 0x70, 0xae, 0xe7, 0x17, 0xb1, 0x9e, 0xd3, 0x44, 0x2f, 0xe9, 0xc3, 0xfd, 0xb3, 0xec, 0x2c,
- 0x2b, 0x35, 0x43, 0x36, 0x55, 0xf2, 0xc1, 0x07, 0x1e, 0xca, 0x76, 0x5a, 0xd0, 0x55, 0x3a, 0x8f,
- 0xc9, 0xd5, 0x92, 0xe2, 0x63, 0xd8, 0xc9, 0x69, 0x32, 0x4f, 0x8b, 0x28, 0x98, 0x31, 0xa3, 0x02,
- 0x54, 0xa0, 0x75, 0x1f, 0xdf, 0xd5, 0xff, 0x90, 0xab, 0x4f, 0x6a, 0x35, 0x73, 0x9b, 0xfc, 0xfa,
- 0xa6, 0xdf, 0xf0, 0xe5, 0x7c, 0x0b, 0xc3, 0x87, 0x50, 0x78, 0x1b, 0x85, 0xc5, 0xb9, 0xb2, 0xa3,
- 0x02, 0x4d, 0xa8, 0x25, 0x15, 0x84, 0x07, 0x50, 0x5a, 0xae, 0x68, 0x10, 0xe5, 0x51, 0x96, 0x2a,
- 0xdc, 0x16, 0xff, 0x1b, 0xc6, 0xf7, 0x21, 0x9a, 0xaf, 0x56, 0xf3, 0xab, 0x59, 0x18, 0x25, 0x34,
- 0x65, 0x50, 0xae, 0xf0, 0x2a, 0xa7, 0x09, 0xfe, 0x6e, 0x89, 0x8f, 0x6e, 0x61, 0xfc, 0x1f, 0x6c,
- 0xc6, 0x59, 0x30, 0x8f, 0xa9, 0x22, 0xa8, 0x40, 0x93, 0xfc, 0xfa, 0x0f, 0xdf, 0x83, 0xf2, 0x9b,
- 0x28, 0x8f, 0x16, 0x31, 0xad, 0x6e, 0x6a, 0x6e, 0x6d, 0x6a, 0xd7, 0x4c, 0xd9, 0x75, 0x0c, 0xab,
- 0xcc, 0x19, 0x8d, 0x69, 0x52, 0x69, 0x5b, 0x7f, 0x71, 0xbf, 0xdf, 0x29, 0xdd, 0x56, 0x4c, 0x93,
- 0x32, 0xee, 0x11, 0xec, 0x16, 0x97, 0xcb, 0x98, 0xce, 0x82, 0x2c, 0x2d, 0x68, 0x5a, 0xe4, 0x8a,
- 0xa8, 0x72, 0x9a, 0x6c, 0x4a, 0x6c, 0xf3, 0xd7, 0x9b, 0x3e, 0x20, 0x7e, 0xa7, 0x14, 0x1c, 0xd5,
- 0x3c, 0xbe, 0x03, 0xe5, 0xca, 0x11, 0xcf, 0x17, 0x34, 0xce, 0x15, 0x49, 0xe5, 0x34, 0xc9, 0x6f,
- 0x97, 0x98, 0x53, 0x42, 0xf8, 0x09, 0xe4, 0xb2, 0x28, 0x54, 0xa0, 0x0a, 0xb4, 0x8e, 0xa9, 0xd5,
- 0x49, 0x07, 0x67, 0x51, 0x71, 0x7e, 0xb9, 0xd0, 0x83, 0x2c, 0x19, 0xc6, 0xd1, 0x62, 0xb8, 0xbc,
- 0x18, 0x66, 0x51, 0xa8, 0x7b, 0x51, 0xb8, 0xb9, 0xe9, 0x73, 0x5e, 0x14, 0xfa, 0xcc, 0x84, 0x1f,
- 0xc2, 0x6e, 0x75, 0xdf, 0x6d, 0xa1, 0xb6, 0x0a, 0x34, 0xd9, 0x14, 0xea, 0x32, 0x25, 0xf9, 0xab,
- 0xcc, 0x83, 0x4f, 0x3b, 0x50, 0xde, 0x3e, 0x0f, 0x8b, 0x90, 0x37, 0x3d, 0xcf, 0x41, 0x0d, 0xdc,
- 0x82, 0x9c, 0xed, 0x12, 0x04, 0xb0, 0x04, 0x85, 0xa7, 0x8e, 0x67, 0x10, 0xb4, 0x83, 0xdb, 0xb0,
- 0x35, 0xb2, 0x8e, 0xec, 0xb1, 0xe1, 0x20, 0x8e, 0x49, 0x47, 0x06, 0xb1, 0x10, 0x8f, 0x3b, 0x50,
- 0x22, 0xf6, 0xd8, 0x9a, 0x10, 0x63, 0x7c, 0x8c, 0x04, 0x2c, 0x43, 0xd1, 0x76, 0x89, 0xe5, 0xbf,
- 0x34, 0x1c, 0xd4, 0xc4, 0x10, 0x36, 0x27, 0xc4, 0xb7, 0xdd, 0x67, 0xa8, 0xc5, 0xa2, 0xcc, 0x13,
- 0x62, 0x4d, 0x90, 0x88, 0x77, 0x61, 0xfb, 0xd6, 0x43, 0x4e, 0x91, 0x84, 0x31, 0xec, 0x1e, 0x79,
- 0x8e, 0x63, 0x10, 0x6b, 0x54, 0xeb, 0x21, 0xeb, 0xe0, 0xd9, 0x23, 0x24, 0xb3, 0xc5, 0x53, 0xf7,
- 0x85, 0xeb, 0xbd, 0x72, 0x51, 0x87, 0x2d, 0x9e, 0x4e, 0xed, 0x11, 0xea, 0xb2, 0x3c, 0xc3, 0xf7,
- 0x8d, 0x13, 0xb4, 0xcb, 0x40, 0xdb, 0xb5, 0x08, 0x42, 0x6c, 0x62, 0xc9, 0xe8, 0x1f, 0x36, 0x3d,
- 0x9f, 0x78, 0x2e, 0xc2, 0x4c, 0x48, 0xa6, 0xc7, 0x8e, 0x85, 0xf6, 0x59, 0xa6, 0x69, 0x13, 0xf4,
- 0x2f, 0x1b, 0x0c, 0xf7, 0x04, 0x85, 0x87, 0xfc, 0xbb, 0x8f, 0xbd, 0xc6, 0x80, 0x17, 0xdb, 0xa8,
- 0x3d, 0xe0, 0xc5, 0x3d, 0xb4, 0x37, 0x68, 0x8a, 0x6b, 0x80, 0xd6, 0x60, 0xd0, 0x14, 0xaf, 0x01,
- 0xba, 0x06, 0x66, 0x7f, 0xfd, 0xbd, 0xd7, 0x58, 0x6f, 0x7a, 0xe0, 0xf3, 0xa6, 0x07, 0xbe, 0x6c,
- 0x7a, 0xe0, 0xdb, 0xa6, 0x07, 0xde, 0xff, 0xe8, 0x35, 0x4e, 0x85, 0xf2, 0x89, 0xfc, 0x0c, 0x00,
- 0x00, 0xff, 0xff, 0x52, 0x20, 0x31, 0xac, 0xaf, 0x03, 0x00, 0x00,
+var fileDescriptor_types_3d4b78bea0da8847 = []byte{
+ // 632 bytes of a gzipped FileDescriptorProto
+ 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x94, 0x52, 0x4f, 0x8f, 0x93, 0x4c,
+ 0x18, 0xef, 0x2c, 0xd0, 0xc2, 0x94, 0x76, 0xe7, 0x9d, 0xdd, 0x7d, 0x5f, 0xde, 0x3d, 0xb4, 0xd8,
+ 0xc4, 0x88, 0xc6, 0x50, 0xe3, 0xd1, 0x1b, 0x6c, 0xd1, 0xa0, 0x14, 0x36, 0x74, 0xaa, 0xd9, 0xbd,
+ 0x34, 0x14, 0x26, 0xbb, 0x44, 0x0a, 0xdd, 0xc2, 0x6a, 0xf6, 0x1b, 0x78, 0xf4, 0xec, 0x55, 0x3f,
+ 0x4c, 0xf7, 0xe6, 0xd1, 0x78, 0xd8, 0x68, 0xfd, 0x22, 0x66, 0x00, 0xd7, 0x5e, 0x3c, 0x78, 0x21,
+ 0x0f, 0xbf, 0x7f, 0xcf, 0xef, 0x49, 0x06, 0x1e, 0xe4, 0x17, 0xc9, 0xb0, 0xb8, 0x5a, 0xd2, 0xbc,
+ 0xfa, 0xea, 0xcb, 0x55, 0x56, 0x64, 0xf8, 0xbf, 0x30, 0x0b, 0x5f, 0xaf, 0xb2, 0x20, 0x3c, 0xd7,
+ 0xf3, 0x8b, 0x44, 0xcf, 0xe9, 0x42, 0x2f, 0xe9, 0xc3, 0xfd, 0xb3, 0xec, 0x2c, 0x2b, 0x35, 0x43,
+ 0x36, 0x55, 0xf2, 0xc1, 0x07, 0x1e, 0xca, 0x76, 0x5a, 0xd0, 0x55, 0x1a, 0x24, 0xe4, 0x6a, 0x49,
+ 0xf1, 0x31, 0xec, 0xe4, 0x74, 0x11, 0xa4, 0x45, 0x1c, 0xce, 0x98, 0x51, 0x01, 0x2a, 0xd0, 0xba,
+ 0x8f, 0xef, 0xea, 0x7f, 0xc8, 0xd5, 0x27, 0xb5, 0x9a, 0xb9, 0x4d, 0x7e, 0x7d, 0xd3, 0x6f, 0xf8,
+ 0x72, 0xbe, 0x85, 0xe1, 0x43, 0x28, 0xbc, 0x8d, 0xa3, 0xe2, 0x5c, 0xd9, 0x51, 0x81, 0x26, 0xd4,
+ 0x92, 0x0a, 0xc2, 0x03, 0x28, 0x2d, 0x57, 0x34, 0x8c, 0xf3, 0x38, 0x4b, 0x15, 0x6e, 0x8b, 0xff,
+ 0x0d, 0xe3, 0xfb, 0x10, 0x05, 0xab, 0x55, 0x70, 0x35, 0x8b, 0xe2, 0x05, 0x4d, 0x19, 0x94, 0x2b,
+ 0xbc, 0xca, 0x69, 0x82, 0xbf, 0x5b, 0xe2, 0xa3, 0x5b, 0x18, 0xff, 0x0b, 0x9b, 0x49, 0x16, 0x06,
+ 0x09, 0x55, 0x04, 0x15, 0x68, 0x92, 0x5f, 0xff, 0xe1, 0x7b, 0x50, 0x7e, 0x13, 0xe7, 0xf1, 0x3c,
+ 0xa1, 0xd5, 0x4d, 0xcd, 0xad, 0x4d, 0xed, 0x9a, 0x29, 0xbb, 0x8e, 0x61, 0x95, 0x39, 0xa3, 0x09,
+ 0x5d, 0x54, 0xda, 0xd6, 0x5f, 0xdc, 0xef, 0x77, 0x4a, 0xb7, 0x95, 0xd0, 0x45, 0x19, 0xf7, 0x08,
+ 0x76, 0x8b, 0xcb, 0x65, 0x42, 0x67, 0x61, 0x96, 0x16, 0x34, 0x2d, 0x72, 0x45, 0x54, 0x39, 0x4d,
+ 0x36, 0x25, 0xb6, 0xf9, 0xeb, 0x4d, 0x1f, 0x10, 0xbf, 0x53, 0x0a, 0x8e, 0x6a, 0x1e, 0xdf, 0x81,
+ 0x72, 0xe5, 0x48, 0x82, 0x39, 0x4d, 0x72, 0x45, 0x52, 0x39, 0x4d, 0xf2, 0xdb, 0x25, 0xe6, 0x94,
+ 0x10, 0x7e, 0x02, 0xb9, 0x2c, 0x8e, 0x14, 0xa8, 0x02, 0xad, 0x63, 0x6a, 0x75, 0xd2, 0xff, 0x67,
+ 0x71, 0x71, 0x7e, 0x39, 0xd7, 0xc3, 0x6c, 0x31, 0x4c, 0xe2, 0xf9, 0x70, 0x79, 0x31, 0xcc, 0xe2,
+ 0x48, 0xf7, 0xe2, 0x68, 0x73, 0xd3, 0xe7, 0xbc, 0x38, 0xf2, 0x99, 0x09, 0x3f, 0x84, 0xdd, 0xea,
+ 0xbe, 0xdb, 0x42, 0x6d, 0x15, 0x68, 0xb2, 0x29, 0xd4, 0x65, 0x4a, 0xf2, 0x57, 0x99, 0x07, 0x9f,
+ 0x76, 0xa0, 0xbc, 0x7d, 0x1e, 0x16, 0x21, 0x6f, 0x7a, 0x9e, 0x83, 0x1a, 0xb8, 0x05, 0x39, 0xdb,
+ 0x25, 0x08, 0x60, 0x09, 0x0a, 0x4f, 0x1d, 0xcf, 0x20, 0x68, 0x07, 0xb7, 0x61, 0x6b, 0x64, 0x1d,
+ 0xd9, 0x63, 0xc3, 0x41, 0x1c, 0x93, 0x8e, 0x0c, 0x62, 0x21, 0x1e, 0x77, 0xa0, 0x44, 0xec, 0xb1,
+ 0x35, 0x21, 0xc6, 0xf8, 0x18, 0x09, 0x58, 0x86, 0xa2, 0xed, 0x12, 0xcb, 0x7f, 0x69, 0x38, 0xa8,
+ 0x89, 0x21, 0x6c, 0x4e, 0x88, 0x6f, 0xbb, 0xcf, 0x50, 0x8b, 0x45, 0x99, 0x27, 0xc4, 0x9a, 0x20,
+ 0x11, 0xef, 0xc2, 0xf6, 0xad, 0x87, 0x9c, 0x22, 0x09, 0x63, 0xd8, 0x3d, 0xf2, 0x1c, 0xc7, 0x20,
+ 0xd6, 0xa8, 0xd6, 0x43, 0xd6, 0xc1, 0xb3, 0x47, 0x48, 0x66, 0x8b, 0xa7, 0xee, 0x0b, 0xd7, 0x7b,
+ 0xe5, 0xa2, 0x0e, 0x5b, 0x3c, 0x9d, 0xda, 0x23, 0xd4, 0x65, 0x79, 0x86, 0xef, 0x1b, 0x27, 0x68,
+ 0x97, 0x81, 0xb6, 0x6b, 0x11, 0x84, 0xd8, 0xc4, 0x92, 0xd1, 0x3f, 0x6c, 0x7a, 0x3e, 0xf1, 0x5c,
+ 0x84, 0x99, 0x90, 0x4c, 0x8f, 0x1d, 0x0b, 0xed, 0xb3, 0x4c, 0xd3, 0x26, 0xe8, 0x80, 0x0d, 0x86,
+ 0x7b, 0x82, 0xa2, 0x43, 0xfe, 0xdd, 0xc7, 0x5e, 0x63, 0xc0, 0x8b, 0x6d, 0xd4, 0x1e, 0xf0, 0xe2,
+ 0x1e, 0xda, 0x1b, 0x34, 0xc5, 0x35, 0x40, 0x6b, 0x30, 0x68, 0x8a, 0xd7, 0x00, 0x5d, 0x03, 0xb3,
+ 0xbf, 0xfe, 0xde, 0x6b, 0xac, 0x37, 0x3d, 0xf0, 0x79, 0xd3, 0x03, 0x5f, 0x36, 0x3d, 0xf0, 0x6d,
+ 0xd3, 0x03, 0xef, 0x7f, 0xf4, 0x1a, 0xa7, 0x42, 0xf9, 0x44, 0x7e, 0x06, 0x00, 0x00, 0xff, 0xff,
+ 0x27, 0x2d, 0xd8, 0x5a, 0xab, 0x03, 0x00, 0x00,
}
diff --git a/pkg/sql/sem/types/types.proto b/pkg/sql/types/types.proto
similarity index 100%
rename from pkg/sql/sem/types/types.proto
rename to pkg/sql/types/types.proto
diff --git a/pkg/sql/sem/types/types_test.go b/pkg/sql/types/types_test.go
similarity index 100%
rename from pkg/sql/sem/types/types_test.go
rename to pkg/sql/types/types_test.go
diff --git a/pkg/sql/union.go b/pkg/sql/union.go
index 6bc7f1d5cc3f..e45d6997813d 100644
--- a/pkg/sql/union.go
+++ b/pkg/sql/union.go
@@ -20,8 +20,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/pkg/errors"
)
diff --git a/pkg/sql/update.go b/pkg/sql/update.go
index 5523ff587a6d..e2de639ae78f 100644
--- a/pkg/sql/update.go
+++ b/pkg/sql/update.go
@@ -24,8 +24,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
)
diff --git a/pkg/sql/upsert.go b/pkg/sql/upsert.go
index 0c2dafa28de0..c06d0417b898 100644
--- a/pkg/sql/upsert.go
+++ b/pkg/sql/upsert.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/row"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/tracing"
)
diff --git a/pkg/sql/values.go b/pkg/sql/values.go
index 4d8d00ec3f2f..882cce364d27 100644
--- a/pkg/sql/values.go
+++ b/pkg/sql/values.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
)
diff --git a/pkg/sql/values_test.go b/pkg/sql/values_test.go
index f3a70fcfe442..1740cb44d153 100644
--- a/pkg/sql/values_test.go
+++ b/pkg/sql/values_test.go
@@ -27,8 +27,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/security"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/bitarray"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
diff --git a/pkg/sql/views.go b/pkg/sql/views.go
index c02329d70f48..6f4c73a17bdf 100644
--- a/pkg/sql/views.go
+++ b/pkg/sql/views.go
@@ -21,8 +21,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
)
// planDependencyInfo collects the dependencies related to a single
diff --git a/pkg/sql/window.go b/pkg/sql/window.go
index eea57ba57398..c7bd73899b46 100644
--- a/pkg/sql/window.go
+++ b/pkg/sql/window.go
@@ -22,8 +22,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/rowcontainer"
"github.com/cockroachdb/cockroach/pkg/sql/sem/transform"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
"github.com/cockroachdb/cockroach/pkg/util/mon"
)
diff --git a/pkg/sqlmigrations/migrations.go b/pkg/sqlmigrations/migrations.go
index 7bcbec5ef9b3..a99858f1593f 100644
--- a/pkg/sqlmigrations/migrations.go
+++ b/pkg/sqlmigrations/migrations.go
@@ -28,9 +28,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/log"
diff --git a/pkg/testutils/lint/lint_test.go b/pkg/testutils/lint/lint_test.go
index 17aa79fc12de..85fcd5672569 100644
--- a/pkg/testutils/lint/lint_test.go
+++ b/pkg/testutils/lint/lint_test.go
@@ -1451,7 +1451,7 @@ func TestLint(t *testing.T) {
stream.GrepNot("_fsm.go.*should not use dot imports"),
stream.GrepNot("sql/.*exported func .* returns unexported type sql.planNode"),
stream.GrepNot("struct field (XXX_NoUnkeyedLiteral|XXX_sizecache) should be"),
- stream.GrepNot("pkg/sql/sem/types/types.go.* var Uuid should be UUID"),
+ stream.GrepNot("pkg/sql/types/types.go.* var Uuid should be UUID"),
), func(s string) {
t.Errorf("\n%s", s)
}); err != nil {
diff --git a/pkg/workload/querylog/querylog.go b/pkg/workload/querylog/querylog.go
index b94299ae6d60..1aa1a7c77a13 100644
--- a/pkg/workload/querylog/querylog.go
+++ b/pkg/workload/querylog/querylog.go
@@ -30,8 +30,8 @@ import (
"time"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
"github.com/cockroachdb/cockroach/pkg/util/uuid"
diff --git a/pkg/workload/rand/rand.go b/pkg/workload/rand/rand.go
index f503fbf9093c..e9fef7d95a44 100644
--- a/pkg/workload/rand/rand.go
+++ b/pkg/workload/rand/rand.go
@@ -27,8 +27,8 @@ import (
"testing"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/types"
"github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
"github.com/cockroachdb/cockroach/pkg/workload"
"github.com/cockroachdb/cockroach/pkg/workload/histogram"
|
d3afb8b26f9d09adda30b5c9ef1a3ae799139cf9
|
2023-04-14 17:10:08
|
Tobias Grieger
|
kvserver: remove below-raft PreIngestDelay during SST application
| false
|
remove below-raft PreIngestDelay during SST application
|
kvserver
|
diff --git a/pkg/kv/kvserver/replica_proposal.go b/pkg/kv/kvserver/replica_proposal.go
index 067c2cc72b4d..1a1c416d75c4 100644
--- a/pkg/kv/kvserver/replica_proposal.go
+++ b/pkg/kv/kvserver/replica_proposal.go
@@ -537,19 +537,15 @@ func addSSTablePreApply(
}
tBegin := timeutil.Now()
- var tEndDelayed time.Time
defer func() {
if dur := timeutil.Since(tBegin); dur > addSSTPreApplyWarn.threshold && addSSTPreApplyWarn.ShouldLog() {
log.Infof(ctx,
- "ingesting SST of size %s at index %d took %.2fs (%.2fs on which in PreIngestDelay)",
- humanizeutil.IBytes(int64(len(sst.Data))), index, dur.Seconds(), tEndDelayed.Sub(tBegin).Seconds(),
+ "ingesting SST of size %s at index %d took %.2fs",
+ humanizeutil.IBytes(int64(len(sst.Data))), index, dur.Seconds(),
)
}
}()
- eng.PreIngestDelay(ctx)
- tEndDelayed = timeutil.Now()
-
ingestPath := path + ".ingested"
// The SST may already be on disk, thanks to the sideloading mechanism. If
|
311047edcfdb16359145ddee3d89aa6e753b105b
|
2021-12-30 00:07:36
|
David Taylor
|
build: use valid_archive=False in bazel proto gen
| false
|
use valid_archive=False in bazel proto gen
|
build
|
diff --git a/pkg/cmd/protoc-gen-gogoroach/BUILD.bazel b/pkg/cmd/protoc-gen-gogoroach/BUILD.bazel
index 6ec63c78c81a..0e5b5e763108 100644
--- a/pkg/cmd/protoc-gen-gogoroach/BUILD.bazel
+++ b/pkg/cmd/protoc-gen-gogoroach/BUILD.bazel
@@ -38,7 +38,7 @@ go_proto_compiler(
"Mgoogle/protobuf/duration.proto=github.com/gogo/protobuf/types",
],
plugin = ":protoc-gen-gogoroach",
- valid_archive = True,
+ valid_archive = False,
visibility = ["//visibility:public"],
deps = [
"@com_github_gogo_protobuf//proto",
@@ -59,7 +59,7 @@ go_proto_compiler(
"Mgoogle/protobuf/duration.proto=github.com/gogo/protobuf/types",
],
plugin = ":protoc-gen-gogoroach",
- valid_archive = True,
+ valid_archive = False,
visibility = ["//visibility:public"],
deps = [
"@com_github_gogo_protobuf//proto",
|
73bca58dce56251a98d90b6c66cae85f8b7eafaa
|
2022-08-02 00:52:50
|
Rebecca Taft
|
opt: allow auto-commit with distribute operator
| false
|
allow auto-commit with distribute operator
|
opt
|
diff --git a/pkg/ccl/logictestccl/testdata/logic_test/multi_region_query_behavior b/pkg/ccl/logictestccl/testdata/logic_test/multi_region_query_behavior
index 75fcf62cfe7f..db945f174adc 100644
--- a/pkg/ccl/logictestccl/testdata/logic_test/multi_region_query_behavior
+++ b/pkg/ccl/logictestccl/testdata/logic_test/multi_region_query_behavior
@@ -426,3 +426,32 @@ USE multi_region_test_db; SELECT g FROM t74890 ORDER BY g
3
4
5
+
+# Regression test for #85043. Distribute enforcer should not prevent the
+# optimizer from planning auto-commit.
+statement ok
+CREATE DATABASE one_region_test_db PRIMARY REGION "ca-central-1";
+USE one_region_test_db;
+CREATE TABLE t85043 (
+ id UUID PRIMARY KEY DEFAULT gen_random_uuid(),
+ ts TIMESTAMP
+);
+
+query T
+EXPLAIN UPDATE t85043 SET ts = '2022-08-01 18:07:07' WHERE id = 'ab020c49-ba5e-4800-8000-00000000014e'
+----
+distribution: local
+vectorized: true
+·
+• update
+│ table: t85043
+│ set: ts
+│ auto commit
+│
+└── • render
+ │
+ └── • scan
+ missing stats
+ table: t85043@t85043_pkey
+ spans: [/'ab020c49-ba5e-4800-8000-00000000014e' - /'ab020c49-ba5e-4800-8000-00000000014e']
+ locking strength: for update
diff --git a/pkg/sql/opt/exec/execbuilder/mutation.go b/pkg/sql/opt/exec/execbuilder/mutation.go
index d89ef7622cf7..201b82ad179f 100644
--- a/pkg/sql/opt/exec/execbuilder/mutation.go
+++ b/pkg/sql/opt/exec/execbuilder/mutation.go
@@ -926,6 +926,11 @@ func (b *Builder) canAutoCommit(rel memo.RelExpr) bool {
}
return b.canAutoCommit(proj.Input)
+ case opt.DistributeOp:
+ // Distribute is currently a no-op, so check whether the input can
+ // auto-commit.
+ return b.canAutoCommit(rel.(*memo.DistributeExpr).Input)
+
default:
return false
}
|
e817be9445e9f0de2d57af682d0975f66d35435f
|
2021-06-24 19:51:11
|
Paul Bardea
|
backupccl: change import to ingest where relevant
| false
|
change import to ingest where relevant
|
backupccl
|
diff --git a/pkg/ccl/backupccl/restore_data_processor.go b/pkg/ccl/backupccl/restore_data_processor.go
index da309c202ba7..ee6c9323f897 100644
--- a/pkg/ccl/backupccl/restore_data_processor.go
+++ b/pkg/ccl/backupccl/restore_data_processor.go
@@ -286,7 +286,7 @@ func (rd *restoreDataProcessor) processRestoreSpanEntry(
}
batcher, err := bulk.MakeSSTBatcher(ctx, db, evalCtx.Settings,
- func() int64 { return storageccl.MaxImportBatchSize(evalCtx.Settings) })
+ func() int64 { return storageccl.MaxIngestBatchSize(evalCtx.Settings) })
if err != nil {
return summary, err
}
diff --git a/pkg/ccl/backupccl/restore_data_processor_test.go b/pkg/ccl/backupccl/restore_data_processor_test.go
index c4f7880f0a76..edf7437123f0 100644
--- a/pkg/ccl/backupccl/restore_data_processor_test.go
+++ b/pkg/ccl/backupccl/restore_data_processor_test.go
@@ -46,25 +46,25 @@ import (
"github.com/stretchr/testify/require"
)
-func TestMaxImportBatchSize(t *testing.T) {
+func TestMaxIngestBatchSize(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
testCases := []struct {
- importBatchSize int64
+ ingestBatchSize int64
maxCommandSize int64
expected int64
}{
- {importBatchSize: 2 << 20, maxCommandSize: 64 << 20, expected: 2 << 20},
- {importBatchSize: 128 << 20, maxCommandSize: 64 << 20, expected: 63 << 20},
- {importBatchSize: 64 << 20, maxCommandSize: 64 << 20, expected: 63 << 20},
- {importBatchSize: 63 << 20, maxCommandSize: 64 << 20, expected: 63 << 20},
+ {ingestBatchSize: 2 << 20, maxCommandSize: 64 << 20, expected: 2 << 20},
+ {ingestBatchSize: 128 << 20, maxCommandSize: 64 << 20, expected: 63 << 20},
+ {ingestBatchSize: 64 << 20, maxCommandSize: 64 << 20, expected: 63 << 20},
+ {ingestBatchSize: 63 << 20, maxCommandSize: 64 << 20, expected: 63 << 20},
}
for i, testCase := range testCases {
st := cluster.MakeTestingClusterSettings()
- storageccl.ImportBatchSize.Override(ctx, &st.SV, testCase.importBatchSize)
+ storageccl.IngestBatchSize.Override(ctx, &st.SV, testCase.ingestBatchSize)
kvserver.MaxCommandSize.Override(ctx, &st.SV, testCase.maxCommandSize)
- if e, a := storageccl.MaxImportBatchSize(st), testCase.expected; e != a {
+ if e, a := storageccl.MaxIngestBatchSize(st), testCase.expected; e != a {
t.Errorf("%d: expected max batch size %d, but got %d", i, e, a)
}
}
@@ -162,23 +162,23 @@ func clientKVsToEngineKVs(kvs []kv.KeyValue) []storage.MVCCKeyValue {
return ret
}
-func TestImport(t *testing.T) {
+func TestIngest(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
t.Run("batch=default", func(t *testing.T) {
- runTestImport(t, func(_ *cluster.Settings) {})
+ runTestIngest(t, func(_ *cluster.Settings) {})
})
t.Run("batch=1", func(t *testing.T) {
// The test normally doesn't trigger the batching behavior, so lower
// the threshold to force it.
init := func(st *cluster.Settings) {
- storageccl.ImportBatchSize.Override(ctx, &st.SV, 1)
+ storageccl.IngestBatchSize.Override(ctx, &st.SV, 1)
}
- runTestImport(t, init)
+ runTestIngest(t, init)
})
}
-func runTestImport(t *testing.T, init func(*cluster.Settings)) {
+func runTestIngest(t *testing.T, init func(*cluster.Settings)) {
defer leaktest.AfterTest(t)()
dir, dirCleanupFn := testutils.TempDir(t)
diff --git a/pkg/ccl/importccl/import_processor.go b/pkg/ccl/importccl/import_processor.go
index 93586ea86150..a8727c7fa328 100644
--- a/pkg/ccl/importccl/import_processor.go
+++ b/pkg/ccl/importccl/import_processor.go
@@ -312,7 +312,7 @@ func ingestKvs(
writeTS := hlc.Timestamp{WallTime: spec.WalltimeNanos}
- flushSize := func() int64 { return storageccl.MaxImportBatchSize(flowCtx.Cfg.Settings) }
+ flushSize := func() int64 { return storageccl.MaxIngestBatchSize(flowCtx.Cfg.Settings) }
// We create two bulk adders so as to combat the excessive flushing of small
// SSTs which was observed when using a single adder for both primary and
diff --git a/pkg/ccl/storageccl/import.go b/pkg/ccl/storageccl/import.go
index c904d306d836..27eb18d1d1a4 100644
--- a/pkg/ccl/storageccl/import.go
+++ b/pkg/ccl/storageccl/import.go
@@ -17,9 +17,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/util/humanizeutil"
)
-// ImportBatchSize is a cluster setting that controls the maximum size of the
+// IngestBatchSize is a cluster setting that controls the maximum size of the
// payload in an AddSSTable request.
-var ImportBatchSize = func() *settings.ByteSizeSetting {
+var IngestBatchSize = func() *settings.ByteSizeSetting {
s := settings.RegisterByteSizeSetting(
"kv.bulk_ingest.batch_size",
"the maximum size of the payload in an AddSSTable request",
@@ -43,12 +43,12 @@ func init() {
}
}
-// MaxImportBatchSize determines the maximum size of the payload in an
-// AddSSTable request. It uses the ImportBatchSize setting directly unless the
+// MaxIngestBatchSize determines the maximum size of the payload in an
+// AddSSTable request. It uses the IngestBatchSize setting directly unless the
// specified value would exceed the maximum Raft command size, in which case it
// returns the maximum batch size that will fit within a Raft command.
-func MaxImportBatchSize(st *cluster.Settings) int64 {
- desiredSize := ImportBatchSize.Get(&st.SV)
+func MaxIngestBatchSize(st *cluster.Settings) int64 {
+ desiredSize := IngestBatchSize.Get(&st.SV)
maxCommandSize := kvserver.MaxCommandSize.Get(&st.SV)
if desiredSize+commandMetadataEstimate > maxCommandSize {
return maxCommandSize - commandMetadataEstimate
diff --git a/pkg/ccl/streamingccl/streamingest/stream_ingestion_processor.go b/pkg/ccl/streamingccl/streamingest/stream_ingestion_processor.go
index abefff5e434c..b29fc2a4601e 100644
--- a/pkg/ccl/streamingccl/streamingest/stream_ingestion_processor.go
+++ b/pkg/ccl/streamingccl/streamingest/stream_ingestion_processor.go
@@ -177,7 +177,7 @@ func (sip *streamIngestionProcessor) Start(ctx context.Context) {
db := sip.FlowCtx.Cfg.DB
var err error
sip.batcher, err = bulk.MakeStreamSSTBatcher(ctx, db, evalCtx.Settings,
- func() int64 { return storageccl.MaxImportBatchSize(evalCtx.Settings) })
+ func() int64 { return storageccl.MaxIngestBatchSize(evalCtx.Settings) })
if err != nil {
sip.MoveToDraining(errors.Wrap(err, "creating stream sst batcher"))
return
|
5854124314d40e5058756b2b2e12540fb1c0b9a2
|
2017-09-26 18:02:15
|
Nathan VanBenschoten
|
server: avoid all allocations with gzipResponseWriter
| false
|
avoid all allocations with gzipResponseWriter
|
server
|
diff --git a/pkg/server/server.go b/pkg/server/server.go
index 37aee6e3bc0b..b2e31708f32c 100644
--- a/pkg/server/server.go
+++ b/pkg/server/server.go
@@ -77,8 +77,8 @@ import (
)
var (
- // Allocation pool for gzip writers.
- gzipWriterPool sync.Pool
+ // Allocation pool for gzipResponseWriters.
+ gzipResponseWriterPool sync.Pool
// GracefulDrainModes is the standard succession of drain modes entered
// for a graceful shutdown.
@@ -1235,19 +1235,24 @@ func (s *Server) ServeHTTP(w http.ResponseWriter, r *http.Request) {
}
type gzipResponseWriter struct {
- gz *gzip.Writer
+ gz gzip.Writer
http.ResponseWriter
}
-func newGzipResponseWriter(w http.ResponseWriter) *gzipResponseWriter {
- var gz *gzip.Writer
- if gzI := gzipWriterPool.Get(); gzI == nil {
- gz = gzip.NewWriter(w)
+func newGzipResponseWriter(rw http.ResponseWriter) *gzipResponseWriter {
+ var w *gzipResponseWriter
+ if wI := gzipResponseWriterPool.Get(); wI == nil {
+ w = new(gzipResponseWriter)
} else {
- gz = gzI.(*gzip.Writer)
- gz.Reset(w)
+ w = wI.(*gzipResponseWriter)
}
- return &gzipResponseWriter{gz: gz, ResponseWriter: w}
+ w.Reset(rw)
+ return w
+}
+
+func (w *gzipResponseWriter) Reset(rw http.ResponseWriter) {
+ w.gz.Reset(rw)
+ w.ResponseWriter = rw
}
func (w *gzipResponseWriter) Write(b []byte) (int, error) {
@@ -1268,14 +1273,12 @@ func (w *gzipResponseWriter) Flush() {
}
}
+// Close implements the io.Closer interface. It is not safe to use the
+// writer after calling Close.
func (w *gzipResponseWriter) Close() error {
- if w.gz == nil {
- return nil
- }
-
err := w.gz.Close()
- gzipWriterPool.Put(w.gz)
- w.gz = nil
+ w.Reset(nil) // release ResponseWriter reference.
+ gzipResponseWriterPool.Put(w)
return err
}
|
dcbcca9468d0e25dd790ea880d6bb3dacb82f36c
|
2023-04-07 19:07:02
|
Jane Xing
|
sql: store retErr and retPayload for pausable portals
| false
|
store retErr and retPayload for pausable portals
|
sql
|
diff --git a/pkg/sql/conn_executor_exec.go b/pkg/sql/conn_executor_exec.go
index 40e498577a5b..d865774a2624 100644
--- a/pkg/sql/conn_executor_exec.go
+++ b/pkg/sql/conn_executor_exec.go
@@ -285,6 +285,17 @@ func (ex *connExecutor) execStmtInOpenState(
// underlying statement contains sub/post queries. Thus, we should evaluate
// whether a portal is pausable when executing the cleanup step.
isPausablePortal := func() bool { return portal != nil && portal.isPausable() }
+ // updateRetErrAndPayload ensures that the latest event payload and error is
+ // always recorded by portal.pauseInfo.
+ // TODO(janexing): add test for this.
+ updateRetErrAndPayload := func(err error, payload fsm.EventPayload) {
+ retPayload = payload
+ retErr = err
+ if isPausablePortal() {
+ portal.pauseInfo.execStmtInOpenState.retPayload = payload
+ portal.pauseInfo.execStmtInOpenState.retErr = err
+ }
+ }
// For pausable portals, we delay the clean-up until closing the portal by
// adding the function to the execStmtInOpenStateCleanup.
// Otherwise, perform the clean-up step within every execution.
@@ -294,7 +305,12 @@ func (ex *connExecutor) execStmtInOpenState(
} else if !portal.pauseInfo.execStmtInOpenState.cleanup.isComplete {
portal.pauseInfo.execStmtInOpenState.cleanup.appendFunc(namedFunc{
fName: fName,
- f: f,
+ f: func() {
+ f()
+ // Some cleanup steps modify the retErr and retPayload. We need to
+ // ensure that cleanup after them can see the update.
+ updateRetErrAndPayload(retErr, retPayload)
+ },
})
}
}
@@ -306,12 +322,23 @@ func (ex *connExecutor) execStmtInOpenState(
}
// If there's any error, do the cleanup right here.
if (retErr != nil || payloadHasError(retPayload)) && isPausablePortal() {
+ updateRetErrAndPayload(retErr, retPayload)
portal.pauseInfo.resumableFlow.cleanup.run()
portal.pauseInfo.dispatchToExecutionEngine.cleanup.run()
portal.pauseInfo.execStmtInOpenState.cleanup.run()
}
}()
+ // We need this part so that when we check if we need to increment the count
+ // of executed stmt, we are checking the latest error and payload. Otherwise,
+ // we would be checking the ones evaluated at the portal's first-time
+ // execution.
+ defer func() {
+ if isPausablePortal() {
+ updateRetErrAndPayload(retErr, retPayload)
+ }
+ }()
+
ast := parserStmt.AST
var sp *tracing.Span
if !isPausablePortal() || !portal.pauseInfo.execStmtInOpenState.cleanup.isComplete {
@@ -393,6 +420,12 @@ func (ex *connExecutor) execStmtInOpenState(
processCleanupFunc(
"increment executed stmt cnt",
func() {
+ // We need to check the latest errors rather than the ones evaluated
+ // when this function is created.
+ if isPausablePortal() {
+ retErr = portal.pauseInfo.execStmtInOpenState.retErr
+ retPayload = portal.pauseInfo.execStmtInOpenState.retPayload
+ }
if retErr == nil && !payloadHasError(retPayload) {
ex.incrementExecutedStmtCounter(ast)
}
@@ -628,6 +661,8 @@ func (ex *connExecutor) execStmtInOpenState(
if isPausablePortal() {
ihToFinish = &portal.pauseInfo.execStmtInOpenState.ihWrapper.ih
curRes = portal.pauseInfo.curRes
+ retErr = portal.pauseInfo.execStmtInOpenState.retErr
+ retPayload = portal.pauseInfo.execStmtInOpenState.retPayload
}
retErr = ihToFinish.Finish(
ex.server.cfg,
diff --git a/pkg/sql/prepared_stmt.go b/pkg/sql/prepared_stmt.go
index 6713a751c26a..6f8cea3469c2 100644
--- a/pkg/sql/prepared_stmt.go
+++ b/pkg/sql/prepared_stmt.go
@@ -25,6 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
"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/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
)
@@ -318,6 +319,12 @@ type portalPauseInfo struct {
cancelQueryFunc context.CancelFunc
// cancelQueryCtx is the context to be canceled when closing the portal.
cancelQueryCtx context.Context
+ // retPayload is needed for the cleanup steps as we will have to check the
+ // latest encountered error, so this field should be updated for each execution.
+ retPayload fsm.EventPayload
+ // retErr is needed for the cleanup steps as we will have to check the latest
+ // encountered error, so this field should be updated for each execution.
+ retErr error
cleanup cleanupFuncStack
}
|
0afbecda3d5f0237081a1d3acdbef8a15c641207
|
2017-03-16 23:01:24
|
David Taylor
|
sqlccl: default to err if restore missing referenced table
| false
|
default to err if restore missing referenced table
|
sqlccl
|
diff --git a/pkg/ccl/sqlccl/backup_test.go b/pkg/ccl/sqlccl/backup_test.go
index 7b82893e2e2e..341f6aaf95e4 100644
--- a/pkg/ccl/sqlccl/backup_test.go
+++ b/pkg/ccl/sqlccl/backup_test.go
@@ -387,12 +387,42 @@ func TestBackupRestoreFKs(t *testing.T) {
})
+ t.Run("restore customers to new cluster", func(t *testing.T) {
+ tc := testcluster.StartTestCluster(t, singleNode, base.TestClusterArgs{})
+ defer tc.Stopper().Stop()
+ db := sqlutils.MakeSQLRunner(t, tc.Conns[0])
+ db.Exec(createStore)
+ db.Exec(fmt.Sprintf(`RESTORE store.customers, store.orders FROM '%s'`, dir))
+ // Restore's Validate checks all the tables point to each other correctly.
+
+ // FK validation on customers from orders is preserved.
+ if _, err := db.DB.Exec(
+ `UPDATE store.customers SET id = id*100`,
+ ); !testutils.IsError(err, "foreign key violation.* referenced in table \"orders\"") {
+ t.Fatal(err)
+ }
+
+ // FK validation on customers from receipts is gone.
+ db.Exec(`UPDATE store.customers SET email = id::string`)
+ })
+
t.Run("restore orders to new cluster", func(t *testing.T) {
tc := testcluster.StartTestCluster(t, singleNode, base.TestClusterArgs{})
defer tc.Stopper().Stop()
db := sqlutils.MakeSQLRunner(t, tc.Conns[0])
db.Exec(createStore)
- db.Exec(fmt.Sprintf(`RESTORE store.orders FROM '%s'`, dir))
+
+ // FK validation of self-FK is preserved.
+ if _, err := db.DB.Exec(
+ fmt.Sprintf(`RESTORE store.orders FROM '%s'`, dir),
+ ); !testutils.IsError(
+ err, "cannot restore table \"orders\" without referenced table 53 \\(or \"skip_missing_foreign_keys\" option\\)",
+ ) {
+ t.Fatal(err)
+ }
+
+ db.Exec(
+ fmt.Sprintf(`RESTORE store.orders FROM '%s' WITH OPTIONS ('skip_missing_foreign_keys')`, dir))
// Restore's Validate checks all the tables point to each other correctly.
// FK validation is gone.
@@ -405,7 +435,8 @@ func TestBackupRestoreFKs(t *testing.T) {
defer tc.Stopper().Stop()
db := sqlutils.MakeSQLRunner(t, tc.Conns[0])
db.Exec(createStore)
- db.Exec(fmt.Sprintf(`RESTORE store.receipts FROM '%s'`, dir))
+ db.Exec(fmt.Sprintf(
+ `RESTORE store.receipts FROM '%s' WITH OPTIONS ('skip_missing_foreign_keys')`, dir))
// Restore's Validate checks all the tables point to each other correctly.
// FK validation of orders and customer is gone.
@@ -424,7 +455,8 @@ func TestBackupRestoreFKs(t *testing.T) {
defer tc.Stopper().Stop()
db := sqlutils.MakeSQLRunner(t, tc.Conns[0])
db.Exec(createStore)
- db.Exec(fmt.Sprintf(`RESTORE store.receipts, store.customers FROM '%s'`, dir))
+ db.Exec(fmt.Sprintf(
+ `RESTORE store.receipts, store.customers FROM '%s' WITH OPTIONS ('skip_missing_foreign_keys')`, dir))
// Restore's Validate checks all the tables point to each other correctly.
// FK validation of orders is gone.
diff --git a/pkg/ccl/sqlccl/restore.go b/pkg/ccl/sqlccl/restore.go
index 20a666a60e5c..a28eb8369fab 100644
--- a/pkg/ccl/sqlccl/restore.go
+++ b/pkg/ccl/sqlccl/restore.go
@@ -32,7 +32,8 @@ import (
)
const (
- restoreOptIntoDB = "into_db"
+ restoreOptIntoDB = "into_db"
+ restoreOptSkipMissingFKs = "skip_missing_foreign_keys"
)
// Import loads some data in sstables into an empty range. Only the keys between
@@ -169,7 +170,7 @@ func reassignParentIDs(
// new IDs. It returns a KeyRewriter that can be used to transform KV data to
// reflect the ID remapping it has done in the descriptors.
func reassignTableIDs(
- ctx context.Context, db client.DB, tables []*sqlbase.TableDescriptor,
+ ctx context.Context, db client.DB, tables []*sqlbase.TableDescriptor, opt parser.KVOptions,
) (storageccl.KeyRewriter, error) {
var newTableIDs map[sqlbase.ID]sqlbase.ID
var kr storageccl.KeyRewriter
@@ -192,7 +193,7 @@ func reassignTableIDs(
return nil, err
}
- if err := reassignReferencedTables(tables, newTableIDs); err != nil {
+ if err := reassignReferencedTables(tables, newTableIDs, opt); err != nil {
return nil, err
}
@@ -200,7 +201,7 @@ func reassignTableIDs(
}
func reassignReferencedTables(
- tables []*sqlbase.TableDescriptor, newTableIDs map[sqlbase.ID]sqlbase.ID,
+ tables []*sqlbase.TableDescriptor, newTableIDs map[sqlbase.ID]sqlbase.ID, opt parser.KVOptions,
) error {
for _, table := range tables {
if err := table.ForeachNonDropIndex(func(index *sqlbase.IndexDescriptor) error {
@@ -233,10 +234,21 @@ func reassignReferencedTables(
if newID, ok := newTableIDs[to]; ok {
index.ForeignKey.Table = newID
} else {
+ if empty, ok := opt.Get(restoreOptSkipMissingFKs); ok {
+ if empty != "" {
+ return errors.Errorf("option %q does not take a value", restoreOptSkipMissingFKs)
+ }
+ index.ForeignKey = sqlbase.ForeignKeyReference{}
+ } else {
+ return errors.Errorf(
+ "cannot restore table %q without referenced table %d (or %q option)",
+ table.Name, to, restoreOptSkipMissingFKs,
+ )
+ }
+
// TODO(dt): if there is an existing (i.e. non-restoring) table with
// a db and name matching the one the FK pointed to at backup, should
// we update the FK to point to it?
- index.ForeignKey = sqlbase.ForeignKeyReference{}
}
}
@@ -575,9 +587,10 @@ func Restore(
// restore since restarts would be terrible (and our bulk import primitive
// are non-transactional), but this does mean if something fails during Import,
// we've "leaked" the IDs, in that the generator will have been incremented.
- kr, err := reassignTableIDs(ctx, db, tables)
+ kr, err := reassignTableIDs(ctx, db, tables, opt)
if err != nil {
- return errors.Wrapf(err, "reserving %d new table IDs for restore", len(tables))
+ // We expect user-facing usage errors here, so don't wrapf.
+ return err
}
// Pivot the backups, which are grouped by time, into requests for import,
|
9f6cc9cf1384e70be01496b5c9560ece6a50c8a7
|
2021-10-05 20:32:50
|
Marius Posta
|
sql: fix FK check bug in ALTER COLUMN TYPE
| false
|
fix FK check bug in ALTER COLUMN TYPE
|
sql
|
diff --git a/pkg/sql/alter_column_type.go b/pkg/sql/alter_column_type.go
index c3a149a08622..b4ce7e2a5b04 100644
--- a/pkg/sql/alter_column_type.go
+++ b/pkg/sql/alter_column_type.go
@@ -203,9 +203,18 @@ func alterColumnTypeGeneral(
// Disallow ALTER COLUMN TYPE general for columns that have a foreign key
// constraint.
for _, fk := range tableDesc.AllActiveAndInactiveForeignKeys() {
- for _, id := range append(fk.OriginColumnIDs, fk.ReferencedColumnIDs...) {
- if col.GetID() == id {
- return colWithConstraintNotSupportedErr
+ if fk.OriginTableID == tableDesc.GetID() {
+ for _, id := range fk.OriginColumnIDs {
+ if col.GetID() == id {
+ return colWithConstraintNotSupportedErr
+ }
+ }
+ }
+ if fk.ReferencedTableID == tableDesc.GetID() {
+ for _, id := range fk.ReferencedColumnIDs {
+ if col.GetID() == id {
+ return colWithConstraintNotSupportedErr
+ }
}
}
}
diff --git a/pkg/sql/logictest/testdata/logic_test/alter_column_type b/pkg/sql/logictest/testdata/logic_test/alter_column_type
index f3800069fa66..44d0ae7c1173 100644
--- a/pkg/sql/logictest/testdata/logic_test/alter_column_type
+++ b/pkg/sql/logictest/testdata/logic_test/alter_column_type
@@ -523,6 +523,15 @@ SELECT x FROM t29 ORDER BY x
2
3
+# Regression 71089, check that foreign key references are checked properly.
+
+statement ok
+CREATE TABLE parent_71089 (id INT PRIMARY KEY);
+CREATE TABLE child_71089 (a INT, b INT REFERENCES parent_71089 (id) NOT NULL)
+
+statement ok
+ALTER TABLE child_71089 ALTER COLUMN a TYPE FLOAT;
+
# ColumnConversionValidate should error out if the conversion is not valid.
# STRING -> BYTES is a ColumnConversionValidate type conversion, it should
# try the conversion and error out if the cast cannot be applied.
|
76c63ded01f18aa31c08ed6a2e9cf4972b0b0459
|
2020-06-03 23:46:57
|
Alex Lunev
|
kv: introduce a rate limiter for the range consistency checker
| false
|
introduce a rate limiter for the range consistency checker
|
kv
|
diff --git a/docs/generated/settings/settings.html b/docs/generated/settings/settings.html
index ec5eab9c965f..8f305f05b16e 100644
--- a/docs/generated/settings/settings.html
+++ b/docs/generated/settings/settings.html
@@ -32,6 +32,7 @@
<tr><td><code>server.auth_log.sql_sessions.enabled</code></td><td>boolean</td><td><code>false</code></td><td>if set, log SQL session login/disconnection events (note: may hinder performance on loaded nodes)</td></tr>
<tr><td><code>server.clock.forward_jump_check_enabled</code></td><td>boolean</td><td><code>false</code></td><td>if enabled, forward clock jumps > max_offset/2 will cause a panic</td></tr>
<tr><td><code>server.clock.persist_upper_bound_interval</code></td><td>duration</td><td><code>0s</code></td><td>the interval between persisting the wall time upper bound of the clock. The clock does not generate a wall time greater than the persisted timestamp and will panic if it sees a wall time greater than this value. When cockroach starts, it waits for the wall time to catch-up till this persisted timestamp. This guarantees monotonic wall time across server restarts. Not setting this or setting a value of 0 disables this feature.</td></tr>
+<tr><td><code>server.consistency_check.max_rate</code></td><td>byte size</td><td><code>8.0 MiB</code></td><td>the rate limit (bytes/sec) to use for consistency checks; used in conjunction with server.consistency_check.interval to control the frequency of consistency checks. Note that setting this too high can negatively impact performance.</td></tr>
<tr><td><code>server.eventlog.ttl</code></td><td>duration</td><td><code>2160h0m0s</code></td><td>if nonzero, event log entries older than this duration are deleted every 10m0s. Should not be lowered below 24 hours.</td></tr>
<tr><td><code>server.host_based_authentication.configuration</code></td><td>string</td><td><code></code></td><td>host-based authentication configuration to use during connection authentication</td></tr>
<tr><td><code>server.rangelog.ttl</code></td><td>duration</td><td><code>720h0m0s</code></td><td>if nonzero, range log entries older than this duration are deleted every 10m0s. Should not be lowered below 24 hours.</td></tr>
diff --git a/pkg/kv/kvserver/consistency_queue.go b/pkg/kv/kvserver/consistency_queue.go
index 380078b3bec2..40e0bb3e3328 100644
--- a/pkg/kv/kvserver/consistency_queue.go
+++ b/pkg/kv/kvserver/consistency_queue.go
@@ -31,6 +31,16 @@ var consistencyCheckInterval = settings.RegisterNonNegativeDurationSetting(
24*time.Hour,
)
+var consistencyCheckRate = settings.RegisterPublicValidatedByteSizeSetting(
+ "server.consistency_check.max_rate",
+ "the rate limit (bytes/sec) to use for consistency checks; used in "+
+ "conjunction with server.consistency_check.interval to control the "+
+ "frequency of consistency checks. Note that setting this too high can "+
+ "negatively impact performance.",
+ 8<<20, // 8MB
+ validatePositive,
+)
+
var testingAggressiveConsistencyChecks = envutil.EnvOrDefaultBool("COCKROACH_CONSISTENCY_AGGRESSIVE", false)
type consistencyQueue struct {
@@ -58,6 +68,7 @@ func newConsistencyQueue(store *Store, gossip *gossip.Gossip) *consistencyQueue
failures: store.metrics.ConsistencyQueueFailures,
pending: store.metrics.ConsistencyQueuePending,
processingNanos: store.metrics.ConsistencyQueueProcessingNanos,
+ processTimeoutFunc: makeRateLimitedTimeoutFunc(consistencyCheckRate),
},
)
return q
diff --git a/pkg/kv/kvserver/merge_queue.go b/pkg/kv/kvserver/merge_queue.go
index 9c53238c40c1..1d649bc45327 100644
--- a/pkg/kv/kvserver/merge_queue.go
+++ b/pkg/kv/kvserver/merge_queue.go
@@ -109,7 +109,7 @@ func newMergeQueue(store *Store, db *kv.DB, gossip *gossip.Gossip) *mergeQueue {
// hard to determine ahead of time. An alternative would be to calculate
// the timeout with a function that additionally considers the replication
// factor.
- processTimeoutFunc: makeQueueSnapshotTimeoutFunc(rebalanceSnapshotRate),
+ processTimeoutFunc: makeRateLimitedTimeoutFunc(rebalanceSnapshotRate),
needsLease: true,
needsSystemConfig: true,
acceptsUnsplitRanges: false,
diff --git a/pkg/kv/kvserver/queue.go b/pkg/kv/kvserver/queue.go
index 0622dafa049d..05f288d02651 100644
--- a/pkg/kv/kvserver/queue.go
+++ b/pkg/kv/kvserver/queue.go
@@ -65,12 +65,13 @@ func defaultProcessTimeoutFunc(cs *cluster.Settings, _ replicaInQueue) time.Dura
return queueGuaranteedProcessingTimeBudget.Get(&cs.SV)
}
-// The queues which send snapshots while processing should have a timeout which
+// The queues which traverse through the data in the range (i.e. send a snapshot
+// or calculate a range checksum) while processing should have a timeout which
// is a function of the size of the range and the maximum allowed rate of data
// transfer that adheres to a minimum timeout specified in a cluster setting.
//
// The parameter controls which rate to use.
-func makeQueueSnapshotTimeoutFunc(rateSetting *settings.ByteSizeSetting) queueProcessTimeoutFunc {
+func makeRateLimitedTimeoutFunc(rateSetting *settings.ByteSizeSetting) queueProcessTimeoutFunc {
return func(cs *cluster.Settings, r replicaInQueue) time.Duration {
minimumTimeout := queueGuaranteedProcessingTimeBudget.Get(&cs.SV)
// NB: In production code this will type assertion will always succeed.
@@ -84,7 +85,7 @@ func makeQueueSnapshotTimeoutFunc(rateSetting *settings.ByteSizeSetting) queuePr
stats := repl.GetMVCCStats()
totalBytes := stats.KeyBytes + stats.ValBytes + stats.IntentBytes + stats.SysBytes
estimatedDuration := time.Duration(totalBytes/snapshotRate) * time.Second
- timeout := estimatedDuration * permittedSnapshotSlowdown
+ timeout := estimatedDuration * permittedRangeScanSlowdown
if timeout < minimumTimeout {
timeout = minimumTimeout
}
@@ -92,10 +93,10 @@ func makeQueueSnapshotTimeoutFunc(rateSetting *settings.ByteSizeSetting) queuePr
}
}
-// permittedSnapshotSlowdown is the factor of the above the estimated duration
-// for a snapshot given the configured snapshot rate which we use to configure
-// the snapshot's timeout.
-const permittedSnapshotSlowdown = 10
+// permittedRangeScanSlowdown is the factor of the above the estimated duration
+// for a range scan given the configured rate which we use to configure
+// the operations's timeout.
+const permittedRangeScanSlowdown = 10
// a purgatoryError indicates a replica processing failure which indicates
// the replica can be placed into purgatory for faster retries when the
diff --git a/pkg/kv/kvserver/queue_test.go b/pkg/kv/kvserver/queue_test.go
index 88e89e8b6e20..1aa708e0fade 100644
--- a/pkg/kv/kvserver/queue_test.go
+++ b/pkg/kv/kvserver/queue_test.go
@@ -897,11 +897,11 @@ func (r mvccStatsReplicaInQueue) GetMVCCStats() enginepb.MVCCStats {
return enginepb.MVCCStats{ValBytes: r.size}
}
-func TestQueueSnapshotTimeoutFunc(t *testing.T) {
+func TestQueueRateLimitedTimeoutFunc(t *testing.T) {
defer leaktest.AfterTest(t)()
type testCase struct {
guaranteedProcessingTime time.Duration
- snapshotRate int64 // bytes/s
+ rateLimit int64 // bytes/s
replicaSize int64 // bytes
expectedTimeout time.Duration
}
@@ -909,8 +909,8 @@ func TestQueueSnapshotTimeoutFunc(t *testing.T) {
return fmt.Sprintf("%+v", tc), func(t *testing.T) {
st := cluster.MakeTestingClusterSettings()
queueGuaranteedProcessingTimeBudget.Override(&st.SV, tc.guaranteedProcessingTime)
- recoverySnapshotRate.Override(&st.SV, tc.snapshotRate)
- tf := makeQueueSnapshotTimeoutFunc(recoverySnapshotRate)
+ recoverySnapshotRate.Override(&st.SV, tc.rateLimit)
+ tf := makeRateLimitedTimeoutFunc(recoverySnapshotRate)
repl := mvccStatsReplicaInQueue{
size: tc.replicaSize,
}
@@ -920,27 +920,27 @@ func TestQueueSnapshotTimeoutFunc(t *testing.T) {
for _, tc := range []testCase{
{
guaranteedProcessingTime: time.Minute,
- snapshotRate: 1 << 30,
+ rateLimit: 1 << 30,
replicaSize: 1 << 20,
expectedTimeout: time.Minute,
},
{
guaranteedProcessingTime: time.Minute,
- snapshotRate: 1 << 20,
+ rateLimit: 1 << 20,
replicaSize: 100 << 20,
- expectedTimeout: 100 * time.Second * permittedSnapshotSlowdown,
+ expectedTimeout: 100 * time.Second * permittedRangeScanSlowdown,
},
{
guaranteedProcessingTime: time.Hour,
- snapshotRate: 1 << 20,
+ rateLimit: 1 << 20,
replicaSize: 100 << 20,
expectedTimeout: time.Hour,
},
{
guaranteedProcessingTime: time.Minute,
- snapshotRate: 1 << 10,
+ rateLimit: 1 << 10,
replicaSize: 100 << 20,
- expectedTimeout: 100 * (1 << 10) * time.Second * permittedSnapshotSlowdown,
+ expectedTimeout: 100 * (1 << 10) * time.Second * permittedRangeScanSlowdown,
},
} {
t.Run(makeTest(tc))
diff --git a/pkg/kv/kvserver/raft_snapshot_queue.go b/pkg/kv/kvserver/raft_snapshot_queue.go
index 07f006bb69cf..3bba46fecf00 100644
--- a/pkg/kv/kvserver/raft_snapshot_queue.go
+++ b/pkg/kv/kvserver/raft_snapshot_queue.go
@@ -51,7 +51,7 @@ func newRaftSnapshotQueue(store *Store, g *gossip.Gossip) *raftSnapshotQueue {
needsLease: false,
needsSystemConfig: false,
acceptsUnsplitRanges: true,
- processTimeoutFunc: makeQueueSnapshotTimeoutFunc(recoverySnapshotRate),
+ processTimeoutFunc: makeRateLimitedTimeoutFunc(recoverySnapshotRate),
successes: store.metrics.RaftSnapshotQueueSuccesses,
failures: store.metrics.RaftSnapshotQueueFailures,
pending: store.metrics.RaftSnapshotQueuePending,
diff --git a/pkg/kv/kvserver/replica_consistency.go b/pkg/kv/kvserver/replica_consistency.go
index e670c2d0ac98..71e3f9075db9 100644
--- a/pkg/kv/kvserver/replica_consistency.go
+++ b/pkg/kv/kvserver/replica_consistency.go
@@ -32,9 +32,9 @@ import (
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/storage/enginepb"
"github.com/cockroachdb/cockroach/pkg/util/bufalloc"
- "github.com/cockroachdb/cockroach/pkg/util/contextutil"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
+ "github.com/cockroachdb/cockroach/pkg/util/limit"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
@@ -56,15 +56,6 @@ import (
// know old CRDB versions (<19.1 at time of writing) were not involved.
var fatalOnStatsMismatch = envutil.EnvOrDefaultBool("COCKROACH_ENFORCE_CONSISTENT_STATS", false)
-const (
- // collectChecksumTimeout controls how long we'll wait to collect a checksum
- // for a CheckConsistency request. We need to bound the time that we wait
- // because the checksum might never be computed for a replica if that replica
- // is caught up via a snapshot and never performs the ComputeChecksum
- // operation.
- collectChecksumTimeout = 15 * time.Second
-)
-
// ReplicaChecksum contains progress on a replica checksum computation.
type ReplicaChecksum struct {
CollectChecksumResponse
@@ -372,17 +363,11 @@ func (r *Replica) RunConsistencyCheck(
func(ctx context.Context) {
defer wg.Done()
- var resp CollectChecksumResponse
- err := contextutil.RunWithTimeout(ctx, "collect checksum", collectChecksumTimeout,
- func(ctx context.Context) error {
- var masterChecksum []byte
- if len(results) > 0 {
- masterChecksum = results[0].Response.Checksum
- }
- var err error
- resp, err = r.collectChecksumFromReplica(ctx, replica, ccRes.ChecksumID, masterChecksum)
- return err
- })
+ var masterChecksum []byte
+ if len(results) > 0 {
+ masterChecksum = results[0].Response.Checksum
+ }
+ resp, err := r.collectChecksumFromReplica(ctx, replica, ccRes.ChecksumID, masterChecksum)
resultCh <- ConsistencyCheckResult{
Replica: replica,
Response: resp,
@@ -505,6 +490,7 @@ func (r *Replica) sha512(
snap storage.Reader,
snapshot *roachpb.RaftSnapshotData,
mode roachpb.ChecksumMode,
+ limiter *limit.LimiterBurstDisabled,
) (*replicaHash, error) {
statsOnly := mode == roachpb.ChecksumMode_CHECK_STATS
@@ -519,6 +505,11 @@ func (r *Replica) sha512(
hasher := sha512.New()
visitor := func(unsafeKey storage.MVCCKey, unsafeValue []byte) error {
+ // Rate Limit the scan through the range
+ if err := limiter.WaitN(ctx, len(unsafeKey.Key)+len(unsafeValue)); err != nil {
+ return err
+ }
+
if snapshot != nil {
// Add (a copy of) the kv pair into the debug message.
kv := roachpb.RaftSnapshotData_KeyValue{
diff --git a/pkg/kv/kvserver/replica_proposal.go b/pkg/kv/kvserver/replica_proposal.go
index 51082d56082d..9dea22aa6d01 100644
--- a/pkg/kv/kvserver/replica_proposal.go
+++ b/pkg/kv/kvserver/replica_proposal.go
@@ -35,6 +35,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/storage/enginepb"
"github.com/cockroachdb/cockroach/pkg/util"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
+ "github.com/cockroachdb/cockroach/pkg/util/limit"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/quotapool"
"github.com/cockroachdb/cockroach/pkg/util/sysutil"
@@ -228,6 +229,8 @@ func (r *Replica) computeChecksumPostApply(ctx context.Context, cc kvserverpb.Co
}
}
+ limiter := limit.NewLimiter(rate.Limit(consistencyCheckRate.Get(&r.store.ClusterSettings().SV)))
+
// Compute SHA asynchronously and store it in a map by UUID.
if err := stopper.RunAsyncTask(ctx, "storage.Replica: computing checksum", func(ctx context.Context) {
func() {
@@ -236,7 +239,8 @@ func (r *Replica) computeChecksumPostApply(ctx context.Context, cc kvserverpb.Co
if cc.SaveSnapshot {
snapshot = &roachpb.RaftSnapshotData{}
}
- result, err := r.sha512(ctx, desc, snap, snapshot, cc.Mode)
+
+ result, err := r.sha512(ctx, desc, snap, snapshot, cc.Mode, limiter)
if err != nil {
log.Errorf(ctx, "%v", err)
result = nil
diff --git a/pkg/kv/kvserver/replica_test.go b/pkg/kv/kvserver/replica_test.go
index e538d269f4e8..2f191e5f0bb9 100644
--- a/pkg/kv/kvserver/replica_test.go
+++ b/pkg/kv/kvserver/replica_test.go
@@ -56,6 +56,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
+ "github.com/cockroachdb/cockroach/pkg/util/limit"
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/metric"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
@@ -75,6 +76,7 @@ import (
"go.etcd.io/etcd/raft/raftpb"
"go.etcd.io/etcd/raft/tracker"
"golang.org/x/net/trace"
+ "golang.org/x/time/rate"
)
// allSpans is a SpanSet that covers *everything* for use in tests that don't
@@ -9616,7 +9618,7 @@ func TestReplicaServersideRefreshes(t *testing.T) {
// Regression test for #31870.
snap := tc.engine.NewSnapshot()
defer snap.Close()
- res, err := tc.repl.sha512(context.Background(), *tc.repl.Desc(), tc.engine, nil /* diff */, roachpb.ChecksumMode_CHECK_FULL)
+ res, err := tc.repl.sha512(context.Background(), *tc.repl.Desc(), tc.engine, nil /* diff */, roachpb.ChecksumMode_CHECK_FULL, limit.NewLimiter(rate.Inf))
if err != nil {
return hlc.Timestamp{}, err
}
diff --git a/pkg/kv/kvserver/replicate_queue.go b/pkg/kv/kvserver/replicate_queue.go
index b7d37114e649..a2b48678b866 100644
--- a/pkg/kv/kvserver/replicate_queue.go
+++ b/pkg/kv/kvserver/replicate_queue.go
@@ -167,7 +167,7 @@ func newReplicateQueue(store *Store, g *gossip.Gossip, allocator Allocator) *rep
// so we use the raftSnapshotQueueTimeoutFunc. This function sets a
// timeout based on the range size and the sending rate in addition
// to consulting the setting which controls the minimum timeout.
- processTimeoutFunc: makeQueueSnapshotTimeoutFunc(rebalanceSnapshotRate),
+ processTimeoutFunc: makeRateLimitedTimeoutFunc(rebalanceSnapshotRate),
successes: store.metrics.ReplicateQueueSuccesses,
failures: store.metrics.ReplicateQueueFailures,
pending: store.metrics.ReplicateQueuePending,
diff --git a/pkg/util/limit/rate_limiter.go b/pkg/util/limit/rate_limiter.go
new file mode 100644
index 000000000000..fa69259264b3
--- /dev/null
+++ b/pkg/util/limit/rate_limiter.go
@@ -0,0 +1,72 @@
+// Copyright 2020 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+package limit
+
+import (
+ "context"
+ "math/big"
+
+ "golang.org/x/time/rate"
+)
+
+// maxInt is the maximum int allowed by the architecture running this code i.e.
+// it could be int32 or int64, unfortunately golang does not have a built in
+// field for this.
+const maxInt = int(^uint(0) >> 1)
+
+// LimiterBurstDisabled is used to solve a complication in rate.Limiter.
+// The rate.Limiter requires a burst parameter and if the throttled value
+// exceeds the burst it just fails. This not always the desired behavior,
+// sometimes we want the limiter to apply the throttle and not enforce any
+// hard limits on an arbitrarily large value. This feature is particularly
+// useful in Cockroach, when we want to throttle on the KV pair, the size
+// of which is not strictly enforced.
+type LimiterBurstDisabled struct {
+ // Avoid embedding, as most methods on the limiter take the parameter
+ // burst into consideration.
+ limiter *rate.Limiter
+}
+
+// NewLimiter returns a new LimiterBurstDisabled that allows events up to rate r.
+func NewLimiter(r rate.Limit) *LimiterBurstDisabled {
+ // Unfortunately we can't disable the burst parameter on the
+ // limiter, so we have to provide some value to it. To remove the cognitive
+ // burden from the user, we set this value to be equal to the limit.
+ // Semantically the choice of burst parameter does not matter, since
+ // we will loop the limiter until all the tokens have been consumed. However
+ // we want to minimize the number of loops for performance, which is why
+ // setting the burst parameter to the limit is a good trade off.
+ var burst, _ = big.NewFloat(float64(r)).Int64()
+ if burst > int64(maxInt) {
+ burst = int64(maxInt)
+ }
+ return &LimiterBurstDisabled{
+ limiter: rate.NewLimiter(r, int(burst)),
+ }
+}
+
+// WaitN blocks until lim permits n events to happen.
+//
+// This function will now only return an error if the Context is canceled and
+// should never in practice hit the burst check in the underlying limiter.
+func (lim *LimiterBurstDisabled) WaitN(ctx context.Context, n int) error {
+ for n > 0 {
+ cur := n
+ if cur > lim.limiter.Burst() {
+ cur = lim.limiter.Burst()
+ }
+ if err := lim.limiter.WaitN(ctx, cur); err != nil {
+ return err
+ }
+ n -= cur
+ }
+ return nil
+}
diff --git a/pkg/util/limit/rate_limiter_test.go b/pkg/util/limit/rate_limiter_test.go
new file mode 100644
index 000000000000..4dab6521c0ce
--- /dev/null
+++ b/pkg/util/limit/rate_limiter_test.go
@@ -0,0 +1,31 @@
+// Copyright 2020 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+package limit
+
+import (
+ "context"
+ "math"
+ "testing"
+
+ "github.com/stretchr/testify/require"
+ "golang.org/x/time/rate"
+)
+
+func TestLimiterBurstDisabled(t *testing.T) {
+ limiter := NewLimiter(100)
+
+ if err := limiter.WaitN(context.Background(), 101); err != nil {
+ t.Fatal(err)
+ }
+
+ limiter = NewLimiter(rate.Limit(math.MaxFloat64))
+ require.Equal(t, maxInt, limiter.limiter.Burst())
+}
|
097a201a77e7b122cb7aeca85cc94faa7474e7ef
|
2024-10-05 05:35:01
|
Pavel Kalinnikov
|
raft: remove unused nodeTestHarness
| false
|
remove unused nodeTestHarness
|
raft
|
diff --git a/pkg/raft/BUILD.bazel b/pkg/raft/BUILD.bazel
index eb1c500c2937..edb0b5e95cc0 100644
--- a/pkg/raft/BUILD.bazel
+++ b/pkg/raft/BUILD.bazel
@@ -40,7 +40,6 @@ go_test(
"log_unstable_test.go",
"node_bench_test.go",
"node_test.go",
- "node_util_test.go",
"raft_flow_control_test.go",
"raft_paper_test.go",
"raft_snap_test.go",
diff --git a/pkg/raft/node_test.go b/pkg/raft/node_test.go
index 2344ed073cbb..28c54e685fd6 100644
--- a/pkg/raft/node_test.go
+++ b/pkg/raft/node_test.go
@@ -32,25 +32,6 @@ import (
"github.com/stretchr/testify/require"
)
-// readyWithTimeout selects from n.Ready() with a 1-second timeout. It
-// panics on timeout, which is better than the indefinite wait that
-// would occur if this channel were read without being wrapped in a
-// select.
-func readyWithTimeout(n Node) Ready {
- select {
- case rd := <-n.Ready():
- if nn, ok := n.(*nodeTestHarness); ok {
- n = nn.node
- }
- if nn, ok := n.(*node); ok {
- nn.rn.raft.logger.Infof("emitted ready: %s", DescribeReady(rd, nil))
- }
- return rd
- case <-time.After(time.Second):
- panic("timed out waiting for ready")
- }
-}
-
// TestNodeStep ensures that node.Step sends msgProp to propc chan
// and other kinds of messages to recvc chan.
func TestNodeStep(t *testing.T) {
diff --git a/pkg/raft/node_util_test.go b/pkg/raft/node_util_test.go
deleted file mode 100644
index a0d960006174..000000000000
--- a/pkg/raft/node_util_test.go
+++ /dev/null
@@ -1,115 +0,0 @@
-// This code has been modified from its original form by The Cockroach Authors.
-// All modifications are Copyright 2024 The Cockroach Authors.
-//
-// Copyright 2022 The etcd Authors
-//
-// Licensed under the Apache License, Version 2.0 (the "License");
-// you may not use this file except in compliance with the License.
-// You may obtain a copy of the License at
-//
-// http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing, software
-// distributed under the License is distributed on an "AS IS" BASIS,
-// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-// See the License for the specific language governing permissions and
-// limitations under the License.
-
-package raft
-
-import (
- "context"
- "fmt"
- "testing"
- "time"
-)
-
-type nodeTestHarness struct {
- *node
- t *testing.T
-}
-
-func (l *nodeTestHarness) Debug(v ...interface{}) {
- l.t.Log(v...)
-}
-
-func (l *nodeTestHarness) Debugf(format string, v ...interface{}) {
- l.t.Logf(format, v...)
-}
-
-func (l *nodeTestHarness) Error(v ...interface{}) {
- l.t.Error(v...)
-}
-
-func (l *nodeTestHarness) Errorf(format string, v ...interface{}) {
- l.t.Errorf(format, v...)
-}
-
-func (l *nodeTestHarness) Info(v ...interface{}) {
- l.t.Log(v...)
-}
-
-func (l *nodeTestHarness) Infof(format string, v ...interface{}) {
- l.t.Logf(format, v...)
-}
-
-func (l *nodeTestHarness) Warning(v ...interface{}) {
- l.t.Log(v...)
-}
-
-func (l *nodeTestHarness) Warningf(format string, v ...interface{}) {
- l.t.Logf(format, v...)
-}
-
-func (l *nodeTestHarness) Fatal(v ...interface{}) {
- l.t.Error(v...)
- panic(fmt.Sprint(v...))
-}
-
-func (l *nodeTestHarness) Fatalf(format string, v ...interface{}) {
- l.t.Errorf(format, v...)
- panic(fmt.Sprintf(format, v...))
-}
-
-func (l *nodeTestHarness) Panic(v ...interface{}) {
- l.t.Log(v...)
- panic(fmt.Sprint(v...))
-}
-
-func (l *nodeTestHarness) Panicf(format string, v ...interface{}) {
- l.t.Errorf(format, v...)
- panic(fmt.Sprintf(format, v...))
-}
-
-func newNodeTestHarness(
- ctx context.Context, t *testing.T, cfg *Config, peers ...Peer,
-) (_ context.Context, cancel func(), _ *nodeTestHarness) {
- // Wrap context in a 10s timeout to make tests more robust. Otherwise,
- // it's likely that deadlock will occur unless Node behaves exactly as
- // expected - when you expect a Ready and start waiting on the channel
- // but no Ready ever shows up, for example.
- ctx, cancel = context.WithTimeout(ctx, 10*time.Second)
- var n *node
- if len(peers) > 0 {
- n = setupNode(cfg, peers)
- } else {
- rn, err := NewRawNode(cfg)
- if err != nil {
- t.Fatal(err)
- }
- nn := newNode(rn)
- n = &nn
- }
- go func() {
- defer func() {
- if r := recover(); r != nil {
- t.Error(r)
- }
- }()
- defer cancel()
- defer n.Stop()
- n.run()
- }()
- t.Cleanup(n.Stop)
- return ctx, cancel, &nodeTestHarness{node: n, t: t}
-}
|
1f22eacbed2b5d72e3ba507e7be6e3e707b20d55
|
2018-02-17 03:59:38
|
Peter Mattis
|
roachtest: periodically output progress when not logging to stdout
| false
|
periodically output progress when not logging to stdout
|
roachtest
|
diff --git a/pkg/cmd/roachtest/cluster.go b/pkg/cmd/roachtest/cluster.go
index 687262faeb7d..52886144fc4d 100644
--- a/pkg/cmd/roachtest/cluster.go
+++ b/pkg/cmd/roachtest/cluster.go
@@ -262,10 +262,11 @@ func (n nodeListOption) String() string {
// between a test and a subtest is current disallowed (see cluster.assertT). A
// cluster is safe for concurrent use by multiple goroutines.
type cluster struct {
- name string
- nodes int
- t testI
- l *logger
+ name string
+ nodes int
+ status func(...interface{})
+ t testI
+ l *logger
}
// TODO(peter): Should set the lifetime of clusters to 2x the expected test
@@ -278,18 +279,24 @@ func newCluster(ctx context.Context, t testI, nodes int, args ...interface{}) *c
}
c := &cluster{
- name: makeClusterName(t),
- nodes: nodes,
- t: t,
- l: l,
+ name: makeClusterName(t),
+ nodes: nodes,
+ status: func(...interface{}) {},
+ t: t,
+ l: l,
}
registerCluster(c.name)
+ if impl, ok := t.(*test); ok {
+ c.status = impl.Status
+ }
+
sargs := []string{"roachprod", "create", c.name, "-n", fmt.Sprint(nodes)}
for _, arg := range args {
sargs = append(sargs, fmt.Sprint(arg))
}
+ c.status("creating cluster")
if err := execCmd(ctx, l, sargs...); err != nil {
t.Fatal(err)
return nil
@@ -323,9 +330,11 @@ func (c *cluster) Destroy(ctx context.Context) {
if !c.isLocal() {
// TODO(peter): Figure out how to retrieve local logs. One option would be
// to stop the cluster and mv ~/local to wherever we want it.
+ c.status("retrieving logs")
_ = execCmd(ctx, c.l, "roachprod", "get", c.name, "logs",
- filepath.Join(artifacts, c.t.Name()))
+ filepath.Join(artifacts, c.t.Name(), "logs"))
}
+ c.status("destroying cluster")
if err := execCmd(ctx, c.l, "roachprod", "destroy", c.name); err != nil {
c.l.errorf("%s", err)
}
@@ -350,6 +359,7 @@ func (c *cluster) Put(ctx context.Context, src, dest string) {
return
}
}
+ c.status("uploading binary")
err := execCmd(ctx, c.l, "roachprod", "put", c.name, src, c.expand(dest))
if err != nil {
c.t.Fatal(err)
@@ -368,6 +378,7 @@ func (c *cluster) Start(ctx context.Context, opts ...option) {
if c.isLocal() {
binary = cockroach
}
+ c.status("starting cluster")
err := execCmd(ctx, c.l, "roachprod", "start", "-b", binary, c.makeNodes(opts))
if err != nil {
c.t.Fatal(err)
@@ -381,6 +392,7 @@ func (c *cluster) Stop(ctx context.Context, opts ...option) {
// If the test has failed, don't try to limp along.
return
}
+ c.status("stopping cluster")
err := execCmd(ctx, c.l, "roachprod", "stop", c.makeNodes(opts))
if err != nil {
c.t.Fatal(err)
@@ -394,6 +406,7 @@ func (c *cluster) Wipe(ctx context.Context, opts ...option) {
// If the test has failed, don't try to limp along.
return
}
+ c.status("wiping cluster")
err := execCmd(ctx, c.l, "roachprod", "wipe", c.makeNodes(opts))
if err != nil {
c.t.Fatal(err)
diff --git a/pkg/cmd/roachtest/import.go b/pkg/cmd/roachtest/import.go
index b771af0f8b7b..378668481278 100644
--- a/pkg/cmd/roachtest/import.go
+++ b/pkg/cmd/roachtest/import.go
@@ -28,11 +28,13 @@ func init() {
c.Put(ctx, cockroach, "<cockroach>")
c.Put(ctx, workload, "<workload>")
+ t.Status("starting csv servers")
for node := 1; node <= nodes; node++ {
c.Run(ctx, node, `<workload> csv-server --port=8081 &> /dev/null < /dev/null &`)
}
c.Start(ctx, c.Range(1, nodes))
+ t.Status("running workload")
m := newMonitor(ctx, c, c.Range(1, nodes))
m.Go(func(ctx context.Context) error {
cmd := fmt.Sprintf(
diff --git a/pkg/cmd/roachtest/kv.go b/pkg/cmd/roachtest/kv.go
index da054de6f8f5..fdb116947157 100644
--- a/pkg/cmd/roachtest/kv.go
+++ b/pkg/cmd/roachtest/kv.go
@@ -31,6 +31,7 @@ func init() {
c.Put(ctx, workload, "<workload>")
c.Start(ctx, c.Range(1, nodes))
+ t.Status("running workload")
m := newMonitor(ctx, c, c.Range(1, nodes))
m.Go(func(ctx context.Context) error {
concurrency := ifLocal("", " --concurrency=384")
@@ -68,6 +69,7 @@ func init() {
c.Put(ctx, workload, "<workload>")
c.Start(ctx, c.Range(1, nodes))
+ t.Status("running workload")
m := newMonitor(ctx, c, c.Range(1, nodes))
m.Go(func(ctx context.Context) error {
concurrency := ifLocal("", " --concurrency=384")
@@ -117,6 +119,7 @@ func init() {
c.Wipe(ctx, c.Range(1, nodes))
c.Start(ctx, c.Range(1, nodes))
+ t.Status("running workload")
m := newMonitor(ctx, c, c.Range(1, nodes))
m.Go(func(ctx context.Context) error {
cmd := fmt.Sprintf("<workload> run kv --init --read-percent=%d "+
diff --git a/pkg/cmd/roachtest/roachmart.go b/pkg/cmd/roachtest/roachmart.go
index eb41c824b1cd..e5230d58d17c 100644
--- a/pkg/cmd/roachtest/roachmart.go
+++ b/pkg/cmd/roachtest/roachmart.go
@@ -55,10 +55,12 @@ func init() {
defer l.close()
c.RunL(ctx, l, nodes[i].i, args...)
}
+ t.Status("initializing workload")
roachmartRun(ctx, 0, "<workload>", "init", "roachmart")
duration := " --duration=" + ifLocal("10s", "10m")
+ t.Status("running workload")
m := newMonitor(ctx, c)
for i := range nodes {
i := i
diff --git a/pkg/cmd/roachtest/test.go b/pkg/cmd/roachtest/test.go
index 8a4038110baa..2874883a8360 100644
--- a/pkg/cmd/roachtest/test.go
+++ b/pkg/cmd/roachtest/test.go
@@ -104,35 +104,89 @@ func (r *registry) Run(filter []string) int {
parallelism = len(tests)
}
+ var running struct {
+ syncutil.Mutex
+ m map[*test]struct{}
+ }
+ running.m = make(map[*test]struct{})
+
var pass, fail int32
go func() {
sem := make(chan struct{}, parallelism)
- for _, t := range tests {
+ for i := range tests {
+ t := tests[i]
sem <- struct{}{}
fmt.Fprintf(r.out, "=== RUN %s\n", t.name)
+ t.Status("starting")
+ running.Lock()
+ running.m[t] = struct{}{}
+ running.Unlock()
t.run(r.out, func(failed bool) {
if failed {
atomic.AddInt32(&fail, 1)
} else {
atomic.AddInt32(&pass, 1)
}
+ running.Lock()
+ delete(running.m, t)
+ running.Unlock()
wg.Done()
<-sem
})
}
}()
- // TODO(peter): While tests are running, if we're not logging to
- // stdout/stderr (i.e. parallelism > 1), then periodically display test
- // progress.
- wg.Wait()
+ done := make(chan struct{})
+ go func() {
+ wg.Wait()
+ close(done)
+ }()
+
+ // If we're running with parallelism > 1, periodically output test status to
+ // give an indication of progress.
+ var tick <-chan time.Time
+ if parallelism > 1 {
+ ticker := time.NewTicker(time.Minute)
+ defer ticker.Stop()
+ tick = ticker.C
+ }
+
+ for i := 1; ; i++ {
+ select {
+ case <-done:
+ if fail > 0 {
+ fmt.Fprintln(r.out, "FAIL")
+ return 1
+ }
+ fmt.Fprintln(r.out, "PASS")
+ return 0
- if fail > 0 {
- fmt.Fprintln(r.out, "FAIL")
- return 1
+ case <-tick:
+ running.Lock()
+ runningTests := make([]*test, 0, len(running.m))
+ for t := range running.m {
+ runningTests = append(runningTests, t)
+ }
+ sort.Slice(runningTests, func(i, j int) bool {
+ return runningTests[i].name < runningTests[j].name
+ })
+ var buf bytes.Buffer
+ for _, t := range runningTests {
+ t.mu.Lock()
+ done := t.mu.done
+ status := t.mu.status
+ statusTime := t.mu.statusTime
+ t.mu.Unlock()
+ if !done {
+ duration := timeutil.Now().Sub(statusTime)
+ fmt.Fprintf(&buf, "[%4d] %s: %s (%s)\n", i, t.name, status,
+ time.Duration(duration.Seconds()+0.5)*time.Second)
+ }
+ }
+ fmt.Fprint(r.out, buf.String())
+ running.Unlock()
+ }
}
- fmt.Fprintln(r.out, "PASS")
- return 0
}
type test struct {
@@ -142,8 +196,11 @@ type test struct {
start time.Time
mu struct {
syncutil.RWMutex
- failed bool
- output []byte
+ done bool
+ failed bool
+ status string
+ statusTime time.Time
+ output []byte
}
}
@@ -151,6 +208,13 @@ func (t *test) Name() string {
return t.name
}
+func (t *test) Status(args ...interface{}) {
+ t.mu.Lock()
+ defer t.mu.Unlock()
+ t.mu.status = fmt.Sprint(args...)
+ t.mu.statusTime = timeutil.Now()
+}
+
func (t *test) Fatal(args ...interface{}) {
t.mu.Lock()
defer t.mu.Unlock()
@@ -230,11 +294,6 @@ func (t *test) run(out io.Writer, done func(failed bool)) {
return frame.Function
}
- t = &test{
- name: t.name,
- fn: t.fn,
- }
-
go func() {
t.runner = callerName()
@@ -245,6 +304,10 @@ func (t *test) run(out io.Writer, done func(failed bool)) {
t.Fatal(err)
}
+ t.mu.Lock()
+ t.mu.done = true
+ t.mu.Unlock()
+
if !dryrun {
dstr := fmt.Sprintf("%.2fs", duration.Seconds())
if t.Failed() {
diff --git a/pkg/cmd/roachtest/tpcc.go b/pkg/cmd/roachtest/tpcc.go
index 7cc0501f61c6..cbffa2d6ca19 100644
--- a/pkg/cmd/roachtest/tpcc.go
+++ b/pkg/cmd/roachtest/tpcc.go
@@ -30,6 +30,7 @@ func init() {
c.Put(ctx, workload, "<workload>")
c.Start(ctx, c.Range(1, nodes))
+ t.Status("running workload")
m := newMonitor(ctx, c, c.Range(1, nodes))
m.Go(func(ctx context.Context) error {
duration := " --duration=" + ifLocal("10s", "10m")
|
3c54c49eec4b51238e5f7ea6dc4c69e505fadb71
|
2019-04-19 19:00:55
|
Andrew Kimball
|
sql: Use SemanticType and Equivalent exclusively
| false
|
Use SemanticType and Equivalent exclusively
|
sql
|
diff --git a/pkg/ccl/changefeedccl/avro_test.go b/pkg/ccl/changefeedccl/avro_test.go
index 9fc2c9057c7b..967a50365f3f 100644
--- a/pkg/ccl/changefeedccl/avro_test.go
+++ b/pkg/ccl/changefeedccl/avro_test.go
@@ -157,7 +157,7 @@ func TestAvroSchema(t *testing.T) {
for semTypeID, semTypeName := range types.SemanticType_name {
typ := types.ColumnType{SemanticType: types.SemanticType(semTypeID)}
switch typ.SemanticType {
- case types.NAME, types.OID, types.TUPLE:
+ case types.NAME, types.OID, types.TUPLE, types.ANY:
// These aren't expected to be needed for changefeeds.
continue
case types.INTERVAL, types.ARRAY, types.BIT,
@@ -283,7 +283,7 @@ func TestAvroSchema(t *testing.T) {
case types.INTERVAL, types.NAME, types.OID,
types.ARRAY, types.BIT, types.TUPLE,
types.COLLATEDSTRING, types.INT2VECTOR,
- types.OIDVECTOR, types.NULL:
+ types.OIDVECTOR, types.NULL, types.ANY:
continue
case types.DECIMAL:
typ.Precision = 3
diff --git a/pkg/ccl/importccl/read_import_mysql.go b/pkg/ccl/importccl/read_import_mysql.go
index 0931422ef67e..9820c7d4b6cf 100644
--- a/pkg/ccl/importccl/read_import_mysql.go
+++ b/pkg/ccl/importccl/read_import_mysql.go
@@ -191,12 +191,12 @@ func mysqlValueToDatum(
// https://github.com/cockroachdb/cockroach/issues/29298
if strings.HasPrefix(s, zeroYear) {
- switch desired {
- case types.TimestampTZ, types.Timestamp:
+ switch desired.SemanticType() {
+ case types.TIMESTAMPTZ, types.TIMESTAMP:
if s == zeroTime {
return tree.DNull, nil
}
- case types.Date:
+ case types.DATE:
if s == zeroDate {
return tree.DNull, nil
}
diff --git a/pkg/ccl/importccl/read_import_workload.go b/pkg/ccl/importccl/read_import_workload.go
index fe3b5e22b8cf..b43ba339d34e 100644
--- a/pkg/ccl/importccl/read_import_workload.go
+++ b/pkg/ccl/importccl/read_import_workload.go
@@ -67,10 +67,10 @@ func makeDatumFromRaw(
case []byte:
return alloc.NewDBytes(tree.DBytes(t)), nil
case time.Time:
- switch hint {
- case types.TimestampTZ:
+ switch hint.SemanticType() {
+ case types.TIMESTAMPTZ:
return tree.MakeDTimestampTZ(t, time.Microsecond), nil
- case types.Timestamp:
+ case types.TIMESTAMP:
return tree.MakeDTimestamp(t, time.Microsecond), nil
}
case tree.DString:
diff --git a/pkg/ccl/partitionccl/partition_test.go b/pkg/ccl/partitionccl/partition_test.go
index 5cf8ffd748bd..e9f68225592f 100644
--- a/pkg/ccl/partitionccl/partition_test.go
+++ b/pkg/ccl/partitionccl/partition_test.go
@@ -850,7 +850,7 @@ func allPartitioningTests(rng *rand.Rand) []partitioningTest {
for semTypeID, semTypeName := range types.SemanticType_name {
semType := types.SemanticType(semTypeID)
switch semType {
- case types.ARRAY, types.TUPLE, types.JSONB:
+ case types.ARRAY, types.TUPLE, types.JSONB, types.ANY:
// Not indexable.
continue
}
diff --git a/pkg/internal/sqlsmith/relational.go b/pkg/internal/sqlsmith/relational.go
index 6783ab6047e1..3ff8934640f6 100644
--- a/pkg/internal/sqlsmith/relational.go
+++ b/pkg/internal/sqlsmith/relational.go
@@ -754,7 +754,7 @@ func (s *scope) makeOrderBy(refs colRefs) tree.OrderBy {
for coin() {
ref := refs[s.schema.rnd.Intn(len(refs))]
// We don't support order by jsonb columns.
- if ref.typ == types.JSON {
+ if ref.typ.SemanticType() == types.JSONB {
continue
}
ob = append(ob, &tree.Order{
diff --git a/pkg/internal/sqlsmith/scalar.go b/pkg/internal/sqlsmith/scalar.go
index 22f896bde118..4ec59c39e443 100644
--- a/pkg/internal/sqlsmith/scalar.go
+++ b/pkg/internal/sqlsmith/scalar.go
@@ -194,7 +194,7 @@ func getColRef(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, *colRef, bo
// Filter by needed type.
cols := make(colRefs, 0, len(refs))
for _, c := range refs {
- if typ == types.Any || c.typ == typ {
+ if typ.SemanticType() == types.ANY || c.typ.Equivalent(typ) {
cols = append(cols, c)
}
}
@@ -228,7 +228,9 @@ func typedParen(expr tree.TypedExpr, typ types.T) tree.TypedExpr {
}
func makeOr(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
- if typ != types.Bool && typ != types.Any {
+ switch typ.SemanticType() {
+ case types.BOOL, types.ANY:
+ default:
return nil, false
}
left := makeBoolExpr(s, refs)
@@ -237,7 +239,9 @@ func makeOr(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
}
func makeAnd(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
- if typ != types.Bool && typ != types.Any {
+ switch typ.SemanticType() {
+ case types.BOOL, types.ANY:
+ default:
return nil, false
}
left := makeBoolExpr(s, refs)
@@ -246,7 +250,9 @@ func makeAnd(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
}
func makeNot(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
- if typ != types.Bool && typ != types.Any {
+ switch typ.SemanticType() {
+ case types.BOOL, types.ANY:
+ default:
return nil, false
}
expr := makeBoolExpr(s, refs)
@@ -456,7 +462,9 @@ func makeWindowFrame(s *scope, refs colRefs) *tree.WindowFrame {
}
func makeExists(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
- if typ != types.Bool && typ != types.Any {
+ switch typ.SemanticType() {
+ case types.BOOL, types.ANY:
+ default:
return nil, false
}
@@ -474,7 +482,9 @@ func makeExists(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
}
func makeIn(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
- if typ != types.Bool && typ != types.Any {
+ switch typ.SemanticType() {
+ case types.BOOL, types.ANY:
+ default:
return nil, false
}
@@ -518,7 +528,9 @@ func makeIn(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
}
func makeStringComparison(s *scope, typ types.T, refs colRefs) (tree.TypedExpr, bool) {
- if typ != types.Bool && typ != types.Any {
+ switch typ.SemanticType() {
+ case types.BOOL, types.ANY:
+ default:
return nil, false
}
return tree.NewTypedComparisonExpr(
diff --git a/pkg/internal/sqlsmith/schema.go b/pkg/internal/sqlsmith/schema.go
index 860f6c5fa01c..495e777d36d4 100644
--- a/pkg/internal/sqlsmith/schema.go
+++ b/pkg/internal/sqlsmith/schema.go
@@ -285,7 +285,7 @@ var functions = func() map[tree.FunctionClass]map[oid.Oid][]function {
typ := ov.FixedReturnType()
found := false
for _, nonArrayTyp := range types.AnyNonArray {
- if typ == nonArrayTyp {
+ if typ.SemanticType() == nonArrayTyp.SemanticType() {
found = true
}
}
diff --git a/pkg/internal/sqlsmith/type.go b/pkg/internal/sqlsmith/type.go
index 38e96e7c8511..8ef651c4ed70 100644
--- a/pkg/internal/sqlsmith/type.go
+++ b/pkg/internal/sqlsmith/type.go
@@ -56,7 +56,7 @@ func getRandType() types.T {
// pickAnyType returns a concrete type if typ is types.Any, otherwise typ.
func pickAnyType(typ types.T) types.T {
- if typ == types.Any {
+ if typ.SemanticType() == types.ANY {
return getRandType()
}
return typ
diff --git a/pkg/server/authentication.go b/pkg/server/authentication.go
index 256d254bb0a1..fb467511aa3e 100644
--- a/pkg/server/authentication.go
+++ b/pkg/server/authentication.go
@@ -226,9 +226,9 @@ WHERE id = $1`
}
if row.Len() != 4 ||
- row[0].ResolvedType() != types.Bytes ||
- row[1].ResolvedType() != types.String ||
- row[2].ResolvedType() != types.Timestamp {
+ row[0].ResolvedType().SemanticType() != types.BYTES ||
+ row[1].ResolvedType().SemanticType() != types.STRING ||
+ row[2].ResolvedType().SemanticType() != types.TIMESTAMP {
return false, "", errors.Errorf("values returned from auth session lookup do not match expectation")
}
@@ -236,7 +236,7 @@ WHERE id = $1`
hashedSecret = []byte(*row[0].(*tree.DBytes))
username = string(*row[1].(*tree.DString))
expiresAt = row[2].(*tree.DTimestamp).Time
- isRevoked = row[3].ResolvedType() != types.Unknown
+ isRevoked = row[3].ResolvedType().SemanticType() != types.NULL
if isRevoked {
return false, "", nil
@@ -309,7 +309,7 @@ RETURNING id
if err != nil {
return 0, nil, err
}
- if row.Len() != 1 || row[0].ResolvedType() != types.Int {
+ if row.Len() != 1 || row[0].ResolvedType().SemanticType() != types.INT {
return 0, nil, errors.Errorf(
"expected create auth session statement to return exactly one integer, returned %v",
row,
diff --git a/pkg/sql/builtin_test.go b/pkg/sql/builtin_test.go
index 2bec9084e9d4..fd9df22ad7eb 100644
--- a/pkg/sql/builtin_test.go
+++ b/pkg/sql/builtin_test.go
@@ -100,9 +100,9 @@ func TestFuncNull(t *testing.T) {
if i > 0 {
sb.WriteString(", ")
}
- if typ.FamilyEqual(types.FamArray) {
+ if typ.SemanticType() == types.ARRAY {
hasArray = true
- if typ == types.AnyArray {
+ if arr, ok := typ.(types.TArray); ok && arr.Typ.SemanticType() == types.ANY {
fmt.Fprintf(&sb, "ARRAY[NULL]::STRING[]")
} else {
fmt.Fprintf(&sb, "ARRAY[NULL]::%s", typ)
diff --git a/pkg/sql/cancel_sessions.go b/pkg/sql/cancel_sessions.go
index f08b22be78b9..38fd6e1bb02c 100644
--- a/pkg/sql/cancel_sessions.go
+++ b/pkg/sql/cancel_sessions.go
@@ -39,7 +39,7 @@ func (p *planner) CancelSessions(ctx context.Context, n *tree.CancelSessions) (p
return nil, pgerror.NewErrorf(pgerror.CodeSyntaxError,
"CANCEL SESSIONS expects a single column source, got %d columns", len(cols))
}
- if !cols[0].Typ.Equivalent(types.String) {
+ if cols[0].Typ.SemanticType() != types.STRING {
return nil, pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"CANCEL SESSIONS requires string values, not type %s", cols[0].Typ)
}
diff --git a/pkg/sql/coltypes/conv.go b/pkg/sql/coltypes/conv.go
index aa9af8444d75..45bdba54f573 100644
--- a/pkg/sql/coltypes/conv.go
+++ b/pkg/sql/coltypes/conv.go
@@ -19,6 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/lib/pq/oid"
)
// TOidToType produces a Datum type equivalent to the given
@@ -45,67 +46,63 @@ func TOidToType(ct *TOid) types.T {
// OidTypeToColType produces an TOid equivalent to the given
// Datum type.
func OidTypeToColType(t types.T) *TOid {
- switch t {
- case types.Oid:
- return Oid
- case types.RegClass:
- return RegClass
- case types.RegNamespace:
- return RegNamespace
- case types.RegProc:
- return RegProc
- case types.RegProcedure:
- return RegProcedure
- case types.RegType:
- return RegType
- default:
- panic(fmt.Sprintf("unexpected type: %v", t))
+ if t.SemanticType() == types.OID {
+ switch t.Oid() {
+ case oid.T_oid:
+ return Oid
+ case oid.T_regclass:
+ return RegClass
+ case oid.T_regnamespace:
+ return RegNamespace
+ case oid.T_regproc:
+ return RegProc
+ case oid.T_regprocedure:
+ return RegProcedure
+ case oid.T_regtype:
+ return RegType
+ }
}
+ panic(fmt.Sprintf("unexpected type: %v", t))
}
// DatumTypeToColumnType produces a SQL column type equivalent to the
// given Datum type. Used to generate CastExpr nodes during
// normalization.
func DatumTypeToColumnType(t types.T) (T, error) {
- switch t {
- case types.Bool:
+ switch t.SemanticType() {
+ case types.BOOL:
return Bool, nil
- case types.BitArray:
+ case types.BIT:
return VarBit, nil
- case types.Int:
+ case types.INT:
return Int8, nil
- case types.Float:
+ case types.FLOAT:
return Float8, nil
- case types.Decimal:
+ case types.DECIMAL:
return Decimal, nil
- case types.Timestamp:
+ case types.TIMESTAMP:
return Timestamp, nil
- case types.TimestampTZ:
+ case types.TIMESTAMPTZ:
return TimestampWithTZ, nil
- case types.Interval:
+ case types.INTERVAL:
return Interval, nil
- case types.JSON:
+ case types.JSONB:
return JSON, nil
- case types.Uuid:
+ case types.UUID:
return UUID, nil
- case types.INet:
+ case types.INET:
return INet, nil
- case types.Date:
+ case types.DATE:
return Date, nil
- case types.Time:
+ case types.TIME:
return Time, nil
- case types.String:
+ case types.STRING:
return String, nil
- case types.Name:
+ case types.NAME:
return Name, nil
- case types.Bytes:
+ case types.BYTES:
return Bytes, nil
- case types.Oid,
- types.RegClass,
- types.RegNamespace,
- types.RegProc,
- types.RegProcedure,
- types.RegType:
+ case types.OID:
return OidTypeToColType(t), nil
}
diff --git a/pkg/sql/control_jobs.go b/pkg/sql/control_jobs.go
index 0f6d5b8c46ec..afeb215102e2 100644
--- a/pkg/sql/control_jobs.go
+++ b/pkg/sql/control_jobs.go
@@ -46,7 +46,7 @@ func (p *planner) ControlJobs(ctx context.Context, n *tree.ControlJobs) (planNod
"%s JOBS expects a single column source, got %d columns",
tree.JobCommandToStatement[n.Command], len(cols))
}
- if !cols[0].Typ.Equivalent(types.Int) {
+ if cols[0].Typ.SemanticType() != types.INT {
return nil, pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"%s JOBS requires int values, not type %s",
tree.JobCommandToStatement[n.Command], cols[0].Typ)
diff --git a/pkg/sql/copy.go b/pkg/sql/copy.go
index 9c66122b7f93..5d96a9c79e47 100644
--- a/pkg/sql/copy.go
+++ b/pkg/sql/copy.go
@@ -365,15 +365,15 @@ func (c *copyMachine) addRow(ctx context.Context, line []byte) error {
exprs[i] = tree.DNull
continue
}
- switch t := c.resultColumns[i].Typ; t {
- case types.Bytes,
- types.Date,
- types.Interval,
- types.INet,
- types.String,
- types.Timestamp,
- types.TimestampTZ,
- types.Uuid:
+ switch t := c.resultColumns[i].Typ; t.SemanticType() {
+ case types.BYTES,
+ types.DATE,
+ types.INTERVAL,
+ types.INET,
+ types.STRING,
+ types.TIMESTAMP,
+ types.TIMESTAMPTZ,
+ types.UUID:
s, err = decodeCopy(s)
if err != nil {
return err
diff --git a/pkg/sql/distsqlplan/aggregator_funcs.go b/pkg/sql/distsqlplan/aggregator_funcs.go
index ac4cb2b5fc4c..47f3804d0731 100644
--- a/pkg/sql/distsqlplan/aggregator_funcs.go
+++ b/pkg/sql/distsqlplan/aggregator_funcs.go
@@ -216,7 +216,7 @@ var DistAggregationTable = map[distsqlpb.AggregatorSpec_Func]DistAggregationInfo
// There is no "FLOAT / INT" operator; cast the denominator to float in
// this case. Note that there is a "DECIMAL / INT" operator, so we don't
// need the same handling for that case.
- if sum.ResolvedType().Equivalent(types.Float) {
+ if sum.ResolvedType().SemanticType() == types.FLOAT {
expr.Right = &tree.CastExpr{
Expr: count,
Type: coltypes.Float8,
diff --git a/pkg/sql/distsqlplan/aggregator_funcs_test.go b/pkg/sql/distsqlplan/aggregator_funcs_test.go
index b5a5ff561d12..a96db700b3dc 100644
--- a/pkg/sql/distsqlplan/aggregator_funcs_test.go
+++ b/pkg/sql/distsqlplan/aggregator_funcs_test.go
@@ -314,7 +314,7 @@ func checkDistAggregationInfo(
for i := range rowsDist[0] {
rowDist := rowsDist[0][i]
rowNonDist := rowsNonDist[0][i]
- if !rowDist.Datum.ResolvedType().FamilyEqual(rowNonDist.Datum.ResolvedType()) {
+ if rowDist.Datum.ResolvedType().SemanticType() != rowNonDist.Datum.ResolvedType().SemanticType() {
t.Fatalf("different type for column %d (dist: %s non-dist: %s)", i, rowDist.Datum.ResolvedType(), rowNonDist.Datum.ResolvedType())
}
diff --git a/pkg/sql/distsqlplan/expression.go b/pkg/sql/distsqlplan/expression.go
index a3857a7f8703..5b0236029074 100644
--- a/pkg/sql/distsqlplan/expression.go
+++ b/pkg/sql/distsqlplan/expression.go
@@ -127,7 +127,7 @@ func (e *evalAndReplaceSubqueryVisitor) VisitPre(expr tree.Expr) (bool, tree.Exp
return false, expr
}
var newExpr tree.Expr = val
- if _, isTuple := val.(*tree.DTuple); !isTuple && expr.ResolvedType() != types.Unknown {
+ if _, isTuple := val.(*tree.DTuple); !isTuple && expr.ResolvedType().SemanticType() != types.NULL {
colType, err := coltypes.DatumTypeToColumnType(expr.ResolvedType())
if err != nil {
e.err = err
diff --git a/pkg/sql/exec_util.go b/pkg/sql/exec_util.go
index 8a565ed2cde7..9c9a8b5fafab 100644
--- a/pkg/sql/exec_util.go
+++ b/pkg/sql/exec_util.go
@@ -677,51 +677,44 @@ func golangFillQueryArguments(args ...interface{}) tree.Datums {
// client.
func checkResultType(typ types.T) error {
// Compare all types that can rely on == equality.
- switch types.UnwrapType(typ) {
- case types.Unknown:
- case types.BitArray:
- case types.Bool:
- case types.Int:
- case types.Float:
- case types.Decimal:
- case types.Bytes:
- case types.String:
- case types.Date:
- case types.Time:
- case types.Timestamp:
- case types.TimestampTZ:
- case types.Interval:
- case types.JSON:
- case types.Uuid:
- case types.INet:
- case types.NameArray:
- case types.Oid:
- case types.RegClass:
- case types.RegNamespace:
- case types.RegProc:
- case types.RegProcedure:
- case types.RegType:
- default:
- // Compare all types that cannot rely on == equality.
- istype := typ.FamilyEqual
- switch {
- case istype(types.FamArray):
- if istype(types.UnwrapType(typ).(types.TArray).Typ) {
- // Technically we could probably return arrays of arrays to a
- // client (the encoding exists) but we don't want to give
- // mixed signals -- that nested arrays appear to be supported
- // in this case, and not in other cases (eg. CREATE). So we
- // reject them in every case instead.
- return pgerror.UnimplementedWithIssueDetailError(32552,
- "result", "arrays cannot have arrays as element type")
- }
- case istype(types.FamCollatedString):
- case istype(types.FamTuple):
- case istype(types.FamPlaceholder):
- return errors.Errorf("could not determine data type of %s", typ)
- default:
- return errors.Errorf("unsupported result type: %s", typ)
+ switch typ.SemanticType() {
+ case types.NULL:
+ case types.BIT:
+ case types.BOOL:
+ case types.INT:
+ case types.FLOAT:
+ case types.DECIMAL:
+ case types.BYTES:
+ case types.STRING:
+ case types.COLLATEDSTRING:
+ case types.DATE:
+ case types.TIMESTAMP:
+ case types.TIME:
+ case types.TIMESTAMPTZ:
+ case types.INTERVAL:
+ case types.JSONB:
+ case types.UUID:
+ case types.INET:
+ case types.NAME:
+ case types.OID:
+ case types.OIDVECTOR:
+ case types.INT2VECTOR:
+ case types.TUPLE:
+ case types.ARRAY:
+ if types.UnwrapType(typ).(types.TArray).Typ.SemanticType() == types.ARRAY {
+ // Technically we could probably return arrays of arrays to a
+ // client (the encoding exists) but we don't want to give
+ // mixed signals -- that nested arrays appear to be supported
+ // in this case, and not in other cases (eg. CREATE). So we
+ // reject them in every case instead.
+ return pgerror.UnimplementedWithIssueDetailError(32552,
+ "result", "arrays cannot have arrays as element type")
}
+ case types.ANY:
+ // Placeholder case.
+ return errors.Errorf("could not determine data type of %s", typ)
+ default:
+ return errors.Errorf("unsupported result type: %s", typ)
}
return nil
}
diff --git a/pkg/sql/expr_filter.go b/pkg/sql/expr_filter.go
index c646855089d8..abc3a9497cdd 100644
--- a/pkg/sql/expr_filter.go
+++ b/pkg/sql/expr_filter.go
@@ -480,9 +480,9 @@ func extractNotNullConstraintsFromNotNullExpr(expr tree.TypedExpr) util.FastIntS
// NULL; a filter "x > y" implies that both x and y are not NULL. It is
// best-effort so there may be false negatives (but no false positives).
func extractNotNullConstraints(filter tree.TypedExpr) util.FastIntSet {
- if typ := filter.ResolvedType(); typ == types.Unknown {
+ if typ := filter.ResolvedType(); typ.SemanticType() == types.NULL {
return util.FastIntSet{}
- } else if typ != types.Bool {
+ } else if typ.SemanticType() != types.BOOL {
panic(fmt.Sprintf("non-bool filter expression: %s (type: %s)", filter, filter.ResolvedType()))
}
switch t := filter.(type) {
diff --git a/pkg/sql/opt/constraint/constraint.go b/pkg/sql/opt/constraint/constraint.go
index 1f8227ff3f13..9f3632859c6f 100644
--- a/pkg/sql/opt/constraint/constraint.go
+++ b/pkg/sql/opt/constraint/constraint.go
@@ -617,7 +617,8 @@ func (c *Constraint) CalculateMaxResults(
// updateDistinctCountsFromConstraint. It would be nice to extract this
// logic somewhere.
colIdx := numCols - 1
- if start.Value(colIdx).ResolvedType() != types.Int || end.Value(colIdx).ResolvedType() != types.Int {
+ if start.Value(colIdx).ResolvedType().SemanticType() != types.INT ||
+ end.Value(colIdx).ResolvedType().SemanticType() != types.INT {
return 0
}
startVal := int(*start.Value(colIdx).(*tree.DInt))
diff --git a/pkg/sql/opt/idxconstraint/index_constraints.go b/pkg/sql/opt/idxconstraint/index_constraints.go
index 59ddf0c01db6..64093eb08149 100644
--- a/pkg/sql/opt/idxconstraint/index_constraints.go
+++ b/pkg/sql/opt/idxconstraint/index_constraints.go
@@ -139,7 +139,7 @@ func (c *indexConstraintCtx) makeStringPrefixSpan(
// given type. We disallow mixed-type comparisons because it would result in
// incorrect encodings (#4313).
func (c *indexConstraintCtx) verifyType(offset int, typ types.T) bool {
- return typ == types.Unknown || c.colType(offset).Equivalent(typ)
+ return typ.SemanticType() == types.NULL || c.colType(offset).Equivalent(typ)
}
// makeSpansForSingleColumn creates spans for a single index column from a
@@ -630,13 +630,13 @@ func (c *indexConstraintCtx) makeSpansForExpr(
case *memo.VariableExpr:
// Support (@1) as (@1 = TRUE) if @1 is boolean.
- if c.colType(offset) == types.Bool && c.isIndexColumn(t, offset) {
+ if c.colType(offset).SemanticType() == types.BOOL && c.isIndexColumn(t, offset) {
return c.makeSpansForSingleColumnDatum(offset, opt.EqOp, tree.DBoolTrue, out)
}
case *memo.NotExpr:
// Support (NOT @1) as (@1 = FALSE) if @1 is boolean.
- if c.colType(offset) == types.Bool && c.isIndexColumn(t.Input, offset) {
+ if c.colType(offset).SemanticType() == types.BOOL && c.isIndexColumn(t.Input, offset) {
return c.makeSpansForSingleColumnDatum(offset, opt.EqOp, tree.DBoolFalse, out)
}
diff --git a/pkg/sql/opt/memo/constraint_builder.go b/pkg/sql/opt/memo/constraint_builder.go
index 5867b5f841a6..44aabcb87de9 100644
--- a/pkg/sql/opt/memo/constraint_builder.go
+++ b/pkg/sql/opt/memo/constraint_builder.go
@@ -416,7 +416,7 @@ func (cb *constraintsBuilder) buildConstraints(e opt.ScalarExpr) (_ *constraint.
case *VariableExpr:
// (x) is equivalent to (x = TRUE) if x is boolean.
- if cb.md.ColumnMeta(t.Col).Type.Equivalent(types.Bool) {
+ if cb.md.ColumnMeta(t.Col).Type.SemanticType() == types.BOOL {
return cb.buildSingleColumnConstraintConst(t.Col, opt.EqOp, tree.DBoolTrue)
}
return unconstrained, false
@@ -424,7 +424,7 @@ func (cb *constraintsBuilder) buildConstraints(e opt.ScalarExpr) (_ *constraint.
case *NotExpr:
// (NOT x) is equivalent to (x = FALSE) if x is boolean.
if v, ok := t.Input.(*VariableExpr); ok {
- if cb.md.ColumnMeta(v.Col).Type.Equivalent(types.Bool) {
+ if cb.md.ColumnMeta(v.Col).Type.SemanticType() == types.BOOL {
return cb.buildSingleColumnConstraintConst(v.Col, opt.EqOp, tree.DBoolFalse)
}
}
@@ -523,5 +523,5 @@ func (cb *constraintsBuilder) makeStringPrefixSpan(
// mixed-type comparisons because if they become index constraints, we would
// generate incorrect encodings (#4313).
func (cb *constraintsBuilder) verifyType(col opt.ColumnID, typ types.T) bool {
- return typ == types.Unknown || cb.md.ColumnMeta(col).Type.Equivalent(typ)
+ return typ.SemanticType() == types.NULL || cb.md.ColumnMeta(col).Type.Equivalent(typ)
}
diff --git a/pkg/sql/opt/memo/expr_format.go b/pkg/sql/opt/memo/expr_format.go
index a5a5d520af5c..7448e8d897aa 100644
--- a/pkg/sql/opt/memo/expr_format.go
+++ b/pkg/sql/opt/memo/expr_format.go
@@ -577,7 +577,7 @@ func (f *ExprFmtCtx) FormatScalarProps(scalar opt.ScalarExpr) {
fmt.Fprintf(f.Buffer, format, args...)
}
- if !f.HasFlags(ExprFmtHideTypes) && typ != types.Any {
+ if !f.HasFlags(ExprFmtHideTypes) && typ.SemanticType() != types.ANY {
writeProp("type=%s", typ)
}
diff --git a/pkg/sql/opt/memo/statistics_builder.go b/pkg/sql/opt/memo/statistics_builder.go
index 9f7f679d0aab..86aa48d72031 100644
--- a/pkg/sql/opt/memo/statistics_builder.go
+++ b/pkg/sql/opt/memo/statistics_builder.go
@@ -397,7 +397,7 @@ func (sb *statisticsBuilder) colStatLeaf(
col, _ := colSet.Next(0)
colStat.DistinctCount = unknownDistinctCountRatio * s.RowCount
colStat.NullCount = unknownNullCountRatio * s.RowCount
- if sb.md.ColumnMeta(opt.ColumnID(col)).Type == types.Bool {
+ if sb.md.ColumnMeta(opt.ColumnID(col)).Type.SemanticType() == types.BOOL {
colStat.DistinctCount = min(colStat.DistinctCount, 2)
}
if notNullCols.Contains(col) {
@@ -2401,7 +2401,8 @@ func (sb *statisticsBuilder) updateDistinctCountsFromConstraint(
if startVal.Compare(sb.evalCtx, endVal) != 0 {
// TODO(rytaft): are there other types we should handle here
// besides int?
- if startVal.ResolvedType() == types.Int && endVal.ResolvedType() == types.Int {
+ if startVal.ResolvedType().SemanticType() == types.INT &&
+ endVal.ResolvedType().SemanticType() == types.INT {
start := int(*startVal.(*tree.DInt))
end := int(*endVal.(*tree.DInt))
// We assume that both start and end boundaries are inclusive. This
diff --git a/pkg/sql/opt/memo/typing.go b/pkg/sql/opt/memo/typing.go
index 35172ab97258..1c160b00b8fc 100644
--- a/pkg/sql/opt/memo/typing.go
+++ b/pkg/sql/opt/memo/typing.go
@@ -77,7 +77,7 @@ func InferBinaryType(op opt.Operator, leftType, rightType types.T) types.T {
func InferWhensType(whens ScalarListExpr, orElse opt.ScalarExpr) types.T {
for _, when := range whens {
childType := when.DataType()
- if childType != types.Unknown {
+ if childType.SemanticType() != types.NULL {
return childType
}
}
@@ -301,7 +301,7 @@ func typeAsAggregate(e opt.ScalarExpr) types.T {
func typeCoalesce(e opt.ScalarExpr) types.T {
for _, arg := range e.(*CoalesceExpr).Args {
childType := arg.DataType()
- if childType != types.Unknown {
+ if childType.SemanticType() != types.NULL {
return childType
}
}
@@ -361,11 +361,11 @@ func FindBinaryOverload(op opt.Operator, leftType, rightType types.T) (_ *tree.B
for _, binOverloads := range tree.BinOps[bin] {
o := binOverloads.(*tree.BinOp)
- if leftType == types.Unknown {
+ if leftType.SemanticType() == types.NULL {
if rightType.Equivalent(o.RightType) {
return o, true
}
- } else if rightType == types.Unknown {
+ } else if rightType.SemanticType() == types.NULL {
if leftType.Equivalent(o.LeftType) {
return o, true
}
@@ -419,11 +419,11 @@ func FindComparisonOverload(
for _, cmpOverloads := range tree.CmpOps[comp] {
o := cmpOverloads.(*tree.CmpOp)
- if leftType == types.Unknown {
+ if leftType.SemanticType() == types.NULL {
if rightType.Equivalent(o.RightType) {
return o, flipped, not, true
}
- } else if rightType == types.Unknown {
+ } else if rightType.SemanticType() == types.NULL {
if leftType.Equivalent(o.LeftType) {
return o, flipped, not, true
}
diff --git a/pkg/sql/opt/metadata_test.go b/pkg/sql/opt/metadata_test.go
index b158675cc46f..16c9a1728423 100644
--- a/pkg/sql/opt/metadata_test.go
+++ b/pkg/sql/opt/metadata_test.go
@@ -107,7 +107,7 @@ func TestMetadataColumns(t *testing.T) {
t.Fatalf("unexpected column alias: %s", colMeta.Alias)
}
- if colMeta.Type != types.Int {
+ if colMeta.Type.SemanticType() != types.INT {
t.Fatalf("unexpected column type: %s", colMeta.Type)
}
@@ -126,7 +126,7 @@ func TestMetadataColumns(t *testing.T) {
t.Fatalf("unexpected column alias: %s", colMeta.Alias)
}
- if colMeta.Type != types.String {
+ if colMeta.Type.SemanticType() != types.STRING {
t.Fatalf("unexpected column type: %s", colMeta.Type)
}
diff --git a/pkg/sql/opt/norm/custom_funcs.go b/pkg/sql/opt/norm/custom_funcs.go
index 2a2479d660b6..12b806d85dae 100644
--- a/pkg/sql/opt/norm/custom_funcs.go
+++ b/pkg/sql/opt/norm/custom_funcs.go
@@ -134,7 +134,7 @@ func (c *CustomFuncs) HasColType(scalar opt.ScalarExpr, dstTyp coltypes.T) bool
// IsString returns true if the given scalar expression is of type String.
func (c *CustomFuncs) IsString(scalar opt.ScalarExpr) bool {
- return scalar.DataType() == types.String
+ return scalar.DataType().SemanticType() == types.STRING
}
// ColTypeToDatumType maps the given column type to a datum type.
@@ -1332,7 +1332,7 @@ func (c *CustomFuncs) SimplifyWhens(
// ensureTyped makes sure that any NULL passing through gets tagged with an
// appropriate type.
func (c *CustomFuncs) ensureTyped(d opt.ScalarExpr, typ types.T) opt.ScalarExpr {
- if d.DataType() == types.Unknown {
+ if d.DataType().SemanticType() == types.NULL {
return c.f.ConstructNull(typ)
}
return d
diff --git a/pkg/sql/opt/optbuilder/join.go b/pkg/sql/opt/optbuilder/join.go
index 5f9d38345605..19190da05ec6 100644
--- a/pkg/sql/opt/optbuilder/join.go
+++ b/pkg/sql/opt/optbuilder/join.go
@@ -449,7 +449,7 @@ func (jb *usingJoinBuilder) addEqualityCondition(leftCol, rightCol *scopeColumn)
} else {
// Construct a new merged column to represent IFNULL(left, right).
var typ types.T
- if leftCol.typ != types.Unknown {
+ if leftCol.typ.SemanticType() != types.NULL {
typ = leftCol.typ
} else {
typ = rightCol.typ
diff --git a/pkg/sql/opt/optbuilder/orderby.go b/pkg/sql/opt/optbuilder/orderby.go
index 3a13287788ec..ccfac8c44bca 100644
--- a/pkg/sql/opt/optbuilder/orderby.go
+++ b/pkg/sql/opt/optbuilder/orderby.go
@@ -252,10 +252,10 @@ func (b *Builder) analyzeExtraArgument(
func ensureColumnOrderable(e tree.TypedExpr) {
typ := e.ResolvedType()
- if _, ok := typ.(types.TArray); ok {
+ if typ.SemanticType() == types.ARRAY {
panic(unimplementedWithIssueDetailf(32707, "", "can't order by column type %s", typ))
}
- if typ == types.JSON {
+ if typ.SemanticType() == types.JSONB {
panic(unimplementedWithIssueDetailf(32706, "", "can't order by column type JSONB"))
}
}
diff --git a/pkg/sql/opt/optbuilder/scope.go b/pkg/sql/opt/optbuilder/scope.go
index d929d485949d..48051d18ba95 100644
--- a/pkg/sql/opt/optbuilder/scope.go
+++ b/pkg/sql/opt/optbuilder/scope.go
@@ -339,7 +339,7 @@ func (s *scope) resolveAndRequireType(expr tree.Expr, desired types.T) tree.Type
// it is not types.Any). types.Unknown is a special type used for null values,
// and can be cast to any other type.
func (s *scope) ensureNullType(texpr tree.TypedExpr, desired types.T) tree.TypedExpr {
- if desired != types.Any && texpr.ResolvedType() == types.Unknown {
+ if desired.SemanticType() != types.ANY && texpr.ResolvedType().SemanticType() == types.NULL {
// Should always be able to convert null value to any other type.
colType, err := coltypes.DatumTypeToColumnType(desired)
if err != nil {
diff --git a/pkg/sql/opt/optbuilder/union.go b/pkg/sql/opt/optbuilder/union.go
index 0b0f9258a058..fa78f36d0a58 100644
--- a/pkg/sql/opt/optbuilder/union.go
+++ b/pkg/sql/opt/optbuilder/union.go
@@ -77,7 +77,7 @@ func (b *Builder) buildUnion(
// TODO(dan): This currently checks whether the types are exactly the same,
// but Postgres is more lenient:
// http://www.postgresql.org/docs/9.5/static/typeconv-union-case.html.
- if !(l.typ.Equivalent(r.typ) || l.typ == types.Unknown || r.typ == types.Unknown) {
+ if !(l.typ.Equivalent(r.typ) || l.typ.SemanticType() == types.NULL || r.typ.SemanticType() == types.NULL) {
panic(pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"%v types %s and %s cannot be matched", clause.Type, l.typ, r.typ))
}
@@ -87,14 +87,14 @@ func (b *Builder) buildUnion(
}
var typ types.T
- if l.typ != types.Unknown {
+ if l.typ.SemanticType() != types.NULL {
typ = l.typ
- if r.typ == types.Unknown {
+ if r.typ.SemanticType() == types.NULL {
propagateTypesRight = true
}
} else {
typ = r.typ
- if r.typ != types.Unknown {
+ if r.typ.SemanticType() != types.NULL {
propagateTypesLeft = true
}
}
@@ -164,7 +164,7 @@ func (b *Builder) propagateTypes(dst, src *scope) *scope {
for i := 0; i < len(dstCols); i++ {
dstType := dstCols[i].typ
srcType := src.cols[i].typ
- if dstType == types.Unknown && srcType != types.Unknown {
+ if dstType.SemanticType() == types.NULL && srcType.SemanticType() != types.NULL {
// Create a new column which casts the old column to the correct type.
colType, _ := coltypes.DatumTypeToColumnType(srcType)
castExpr := b.factory.ConstructCast(b.factory.ConstructVariable(dstCols[i].id), colType)
diff --git a/pkg/sql/opt/optbuilder/values.go b/pkg/sql/opt/optbuilder/values.go
index f7fd8bed9c2a..a445c7d46bfb 100644
--- a/pkg/sql/opt/optbuilder/values.go
+++ b/pkg/sql/opt/optbuilder/values.go
@@ -68,9 +68,9 @@ func (b *Builder) buildValuesClause(
elems[i] = b.buildScalar(texpr, inScope, nil, nil, nil)
// Verify that types of each tuple match one another.
- if colTypes[i] == types.Unknown {
+ if colTypes[i].SemanticType() == types.NULL {
colTypes[i] = typ
- } else if typ != types.Unknown && !typ.Equivalent(colTypes[i]) {
+ } else if typ.SemanticType() != types.NULL && !typ.Equivalent(colTypes[i]) {
panic(pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"VALUES types %s and %s cannot be matched", typ, colTypes[i]))
}
diff --git a/pkg/sql/pg_catalog.go b/pkg/sql/pg_catalog.go
index ca2ad8f7d8ba..3f2c073d9c2b 100644
--- a/pkg/sql/pg_catalog.go
+++ b/pkg/sql/pg_catalog.go
@@ -21,7 +21,6 @@ import (
"fmt"
"hash"
"hash/fnv"
- "reflect"
"strings"
"unicode"
@@ -2075,8 +2074,8 @@ CREATE TABLE pg_catalog.pg_type (
typArray := oidZero
builtinPrefix := builtins.PGIOBuiltinPrefix(typ)
if cat == typCategoryArray {
- switch typ {
- case types.IntVector:
+ switch typ.Oid() {
+ case oid.T_int2vector:
// IntVector needs a special case because its a special snowflake
// type. It's just like an Int2Array, but it has its own OID. We
// can't just wrap our Int2Array type in an OID wrapper, though,
@@ -2084,7 +2083,7 @@ CREATE TABLE pg_catalog.pg_type (
// input-only type that translates immediately to int8array. This
// would go away if we decided to export Int2Array as a real type.
typElem = tree.NewDOid(tree.DInt(oid.T_int2))
- case types.OidVector:
+ case oid.T_oidvector:
// Same story as above for OidVector.
typElem = tree.NewDOid(tree.DInt(oid.T_oid))
default:
@@ -2285,46 +2284,50 @@ func typByVal(typ types.T) tree.Datum {
// The default collation is en-US, which is equivalent to but spelled
// differently than the default database collation, en_US.utf8.
func typColl(typ types.T, h oidHasher) tree.Datum {
- if typ.FamilyEqual(types.Any) {
+ switch typ.SemanticType() {
+ case types.ANY:
return oidZero
- } else if typ.Equivalent(types.String) || typ.Equivalent(types.TArray{Typ: types.String}) {
+ case types.STRING:
return h.CollationOid(defaultCollationTag)
- } else if typ.FamilyEqual(types.FamCollatedString) {
+ case types.COLLATEDSTRING:
return h.CollationOid(typ.(types.TCollatedString).Locale)
}
+
+ if typ.Equivalent(types.TArray{Typ: types.String}) {
+ return h.CollationOid(defaultCollationTag)
+ }
return oidZero
}
// This mapping should be kept sync with PG's categorization.
-var datumToTypeCategory = map[reflect.Type]*tree.DString{
- reflect.TypeOf(types.Any): typCategoryPseudo,
- reflect.TypeOf(types.BitArray): typCategoryBitString,
- reflect.TypeOf(types.Bool): typCategoryBoolean,
- reflect.TypeOf(types.Bytes): typCategoryUserDefined,
- reflect.TypeOf(types.Date): typCategoryDateTime,
- reflect.TypeOf(types.Time): typCategoryDateTime,
- reflect.TypeOf(types.Float): typCategoryNumeric,
- reflect.TypeOf(types.Int): typCategoryNumeric,
- reflect.TypeOf(types.Interval): typCategoryTimespan,
- reflect.TypeOf(types.JSON): typCategoryUserDefined,
- reflect.TypeOf(types.Decimal): typCategoryNumeric,
- reflect.TypeOf(types.String): typCategoryString,
- reflect.TypeOf(types.Timestamp): typCategoryDateTime,
- reflect.TypeOf(types.TimestampTZ): typCategoryDateTime,
- reflect.TypeOf(types.FamTuple): typCategoryPseudo,
- reflect.TypeOf(types.Oid): typCategoryNumeric,
- reflect.TypeOf(types.Uuid): typCategoryUserDefined,
- reflect.TypeOf(types.INet): typCategoryNetworkAddr,
+var datumToTypeCategory = map[types.SemanticType]*tree.DString{
+ types.ANY: typCategoryPseudo,
+ types.BIT: typCategoryBitString,
+ types.BOOL: typCategoryBoolean,
+ types.BYTES: typCategoryUserDefined,
+ types.DATE: typCategoryDateTime,
+ types.TIME: typCategoryDateTime,
+ types.FLOAT: typCategoryNumeric,
+ types.INT: typCategoryNumeric,
+ types.INTERVAL: typCategoryTimespan,
+ types.JSONB: typCategoryUserDefined,
+ types.DECIMAL: typCategoryNumeric,
+ types.STRING: typCategoryString,
+ types.TIMESTAMP: typCategoryDateTime,
+ types.TIMESTAMPTZ: typCategoryDateTime,
+ types.ARRAY: typCategoryArray,
+ types.TUPLE: typCategoryPseudo,
+ types.OID: typCategoryNumeric,
+ types.UUID: typCategoryUserDefined,
+ types.INET: typCategoryNetworkAddr,
}
func typCategory(typ types.T) tree.Datum {
- if typ.FamilyEqual(types.FamArray) {
- if typ == types.AnyArray {
- return typCategoryPseudo
- }
- return typCategoryArray
+ // Special case ARRAY of ANY.
+ if arr, ok := typ.(types.TArray); ok && arr.Typ.SemanticType() == types.ANY {
+ return typCategoryPseudo
}
- return datumToTypeCategory[reflect.TypeOf(types.UnwrapType(typ))]
+ return datumToTypeCategory[typ.SemanticType()]
}
var pgCatalogViewsTable = virtualSchemaTable{
diff --git a/pkg/sql/pgwire/encoding_test.go b/pkg/sql/pgwire/encoding_test.go
index c6bf69846a70..56aac2860052 100644
--- a/pkg/sql/pgwire/encoding_test.go
+++ b/pkg/sql/pgwire/encoding_test.go
@@ -174,7 +174,8 @@ func TestEncodings(t *testing.T) {
}
// Text decoding returns a string for some kinds of arrays. If that's the
// case, manually do the conversion to array.
- if darr, isdarr := tc.Datum.(*tree.DArray); isdarr && d.ResolvedType() == types.String {
+ darr, isdarr := tc.Datum.(*tree.DArray)
+ if isdarr && d.ResolvedType().SemanticType() == types.STRING {
t.Log("convert string to array")
var typ coltypes.T
typ, err = coltypes.DatumTypeToColumnType(darr.ParamTyp)
diff --git a/pkg/sql/pgwire/types.go b/pkg/sql/pgwire/types.go
index dcf3711b6862..ebfd94e874a1 100644
--- a/pkg/sql/pgwire/types.go
+++ b/pkg/sql/pgwire/types.go
@@ -432,7 +432,7 @@ func (b *writeBuffer) writeBinaryDatum(
b.writeLengthPrefixedBuffer(&subWriter.wrapped)
case *tree.DArray:
- if v.ParamTyp.FamilyEqual(types.AnyArray) {
+ if v.ParamTyp.SemanticType() == types.ARRAY {
b.setError(pgerror.UnimplementedWithIssueDetailError(32552,
"binenc", "unsupported binary serialization of multidimensional arrays"))
return
diff --git a/pkg/sql/pgwire/types_test.go b/pkg/sql/pgwire/types_test.go
index 1cbc9e6032b6..c9a7d023fcda 100644
--- a/pkg/sql/pgwire/types_test.go
+++ b/pkg/sql/pgwire/types_test.go
@@ -240,11 +240,7 @@ func TestCanWriteAllDatums(t *testing.T) {
for _, typ := range types.AnyNonArray {
buf := newWriteBuffer(nil /* bytecount */)
- semtyp, err := sqlbase.TestingDatumTypeToColumnSemanticType(typ)
- if err != nil {
- t.Fatal(err)
- }
-
+ semtyp := typ.SemanticType()
for i := 0; i < 10; i++ {
d := sqlbase.RandDatum(rng, types.ColumnType{SemanticType: semtyp}, true)
diff --git a/pkg/sql/sem/builtins/builtins.go b/pkg/sql/sem/builtins/builtins.go
index 152596d00a1f..df4e0204f4aa 100644
--- a/pkg/sql/sem/builtins/builtins.go
+++ b/pkg/sql/sem/builtins/builtins.go
@@ -93,12 +93,12 @@ const (
)
func categorizeType(t types.T) string {
- switch t {
- case types.Date, types.Interval, types.Timestamp, types.TimestampTZ:
+ switch t.SemanticType() {
+ case types.DATE, types.INTERVAL, types.TIMESTAMP, types.TIMESTAMPTZ:
return categoryDateAndTime
- case types.Int, types.Decimal, types.Float:
+ case types.INT, types.DECIMAL, types.FLOAT:
return categoryMath
- case types.String, types.Bytes:
+ case types.STRING, types.BYTES:
return categoryString
default:
return strings.ToUpper(t.String())
diff --git a/pkg/sql/sem/builtins/generator_builtins.go b/pkg/sql/sem/builtins/generator_builtins.go
index 0fa5ddd3ed4a..c168711d4dea 100644
--- a/pkg/sql/sem/builtins/generator_builtins.go
+++ b/pkg/sql/sem/builtins/generator_builtins.go
@@ -110,7 +110,7 @@ var generators = map[string]builtinDefinition{
makeGeneratorOverloadWithReturnType(
tree.ArgTypes{{"input", types.AnyArray}},
func(args []tree.TypedExpr) types.T {
- if len(args) == 0 || args[0].ResolvedType() == types.Unknown {
+ if len(args) == 0 || args[0].ResolvedType().SemanticType() == types.NULL {
return tree.UnknownReturnType
}
return types.UnwrapType(args[0].ResolvedType()).(types.TArray).Typ
@@ -124,7 +124,7 @@ var generators = map[string]builtinDefinition{
makeGeneratorOverloadWithReturnType(
tree.ArgTypes{{"input", types.AnyArray}},
func(args []tree.TypedExpr) types.T {
- if len(args) == 0 || args[0].ResolvedType() == types.Unknown {
+ if len(args) == 0 || args[0].ResolvedType().SemanticType() == types.NULL {
return tree.UnknownReturnType
}
t := types.UnwrapType(args[0].ResolvedType()).(types.TArray).Typ
diff --git a/pkg/sql/sem/builtins/pg_builtins.go b/pkg/sql/sem/builtins/pg_builtins.go
index 87f2118352d1..42f50329e54f 100644
--- a/pkg/sql/sem/builtins/pg_builtins.go
+++ b/pkg/sql/sem/builtins/pg_builtins.go
@@ -70,7 +70,7 @@ var typeBuiltinsHaveUnderscore = map[oid.Oid]struct{}{
oid.T_bit: {},
types.Timestamp.Oid(): {},
types.TimestampTZ.Oid(): {},
- types.FamTuple.Oid(): {},
+ types.EmptyTuple.Oid(): {},
}
// PGIOBuiltinPrefix returns the string prefix to a type's IO functions. This
@@ -96,9 +96,13 @@ func initPGBuiltins() {
// Make non-array type i/o builtins.
for _, typ := range types.OidToType {
- // Skip array types. We're doing them separately below.
- if typ != types.Any && typ != types.IntVector && typ != types.OidVector && typ.Equivalent(types.AnyArray) {
- continue
+ // Skip most array types. We're doing them separately below.
+ switch typ.Oid() {
+ case oid.T_int2vector, oid.T_oidvector:
+ default:
+ if typ.SemanticType() == types.ARRAY {
+ continue
+ }
}
builtinPrefix := PGIOBuiltinPrefix(typ)
for name, builtin := range makeTypeIOBuiltins(builtinPrefix, typ) {
diff --git a/pkg/sql/sem/tree/constant.go b/pkg/sql/sem/tree/constant.go
index 14e580a10eb2..46db998e21aa 100644
--- a/pkg/sql/sem/tree/constant.go
+++ b/pkg/sql/sem/tree/constant.go
@@ -61,7 +61,7 @@ func isConstant(expr Expr) bool {
func typeCheckConstant(c Constant, ctx *SemaContext, desired types.T) (ret TypedExpr, err error) {
avail := c.AvailableTypes()
- if desired != types.Any {
+ if desired.SemanticType() != types.ANY {
for _, typ := range avail {
if desired.Equivalent(typ) {
return c.ResolveAsType(ctx, desired)
@@ -72,7 +72,7 @@ func typeCheckConstant(c Constant, ctx *SemaContext, desired types.T) (ret Typed
// If a numeric constant will be promoted to a DECIMAL because it was out
// of range of an INT, but an INT is desired, throw an error here so that
// the error message specifically mentions the overflow.
- if desired.FamilyEqual(types.Int) {
+ if desired.SemanticType() == types.INT {
if n, ok := c.(*NumVal); ok {
_, err := n.AsInt64()
switch err {
@@ -245,8 +245,8 @@ func (expr *NumVal) DesirableTypes() []types.T {
// ResolveAsType implements the Constant interface.
func (expr *NumVal) ResolveAsType(ctx *SemaContext, typ types.T) (Datum, error) {
- switch typ {
- case types.Int:
+ switch typ.SemanticType() {
+ case types.INT:
// We may have already set expr.resInt in AsInt64.
if expr.resInt == 0 {
if _, err := expr.AsInt64(); err != nil {
@@ -254,14 +254,14 @@ func (expr *NumVal) ResolveAsType(ctx *SemaContext, typ types.T) (Datum, error)
}
}
return &expr.resInt, nil
- case types.Float:
+ case types.FLOAT:
f, _ := constant.Float64Val(expr.Value)
if expr.Negative {
f = -f
}
expr.resFloat = DFloat(f)
return &expr.resFloat, nil
- case types.Decimal:
+ case types.DECIMAL:
dd := &expr.resDecimal
s := expr.OrigString
if s == "" {
@@ -303,13 +303,7 @@ func (expr *NumVal) ResolveAsType(ctx *SemaContext, typ types.T) (Datum, error)
dd.Negative = expr.Negative
}
return dd, nil
- case types.Oid,
- types.RegClass,
- types.RegNamespace,
- types.RegProc,
- types.RegProcedure,
- types.RegType:
-
+ case types.OID:
d, err := expr.ResolveAsType(ctx, types.Int)
if err != nil {
return nil, err
@@ -471,13 +465,13 @@ func (expr *StrVal) DesirableTypes() []types.T {
func (expr *StrVal) ResolveAsType(ctx *SemaContext, typ types.T) (Datum, error) {
if expr.scannedAsBytes {
// We're looking at typing a byte literal constant into some value type.
- switch typ {
- case types.Bytes:
+ switch typ.SemanticType() {
+ case types.BYTES:
expr.resBytes = DBytes(expr.s)
return &expr.resBytes, nil
- case types.Uuid:
+ case types.UUID:
return ParseDUuidFromBytes([]byte(expr.s))
- case types.String:
+ case types.STRING:
expr.resString = DString(expr.s)
return &expr.resString, nil
}
@@ -485,14 +479,14 @@ func (expr *StrVal) ResolveAsType(ctx *SemaContext, typ types.T) (Datum, error)
}
// Typing a string literal constant into some value type.
- switch typ {
- case types.String:
+ switch typ.SemanticType() {
+ case types.STRING:
expr.resString = DString(expr.s)
return &expr.resString, nil
- case types.Name:
+ case types.NAME:
expr.resString = DString(expr.s)
return NewDNameFromDString(&expr.resString), nil
- case types.Bytes:
+ case types.BYTES:
return ParseDByte(expr.s)
}
diff --git a/pkg/sql/sem/tree/datum.go b/pkg/sql/sem/tree/datum.go
index 01ae4bb06cd7..e49b99a83349 100644
--- a/pkg/sql/sem/tree/datum.go
+++ b/pkg/sql/sem/tree/datum.go
@@ -3493,18 +3493,9 @@ func NewDOidVectorFromDArray(d *DArray) Datum {
func DatumTypeSize(t types.T) (uintptr, bool) {
// The following are composite types.
switch ty := t.(type) {
- case types.TOid:
- // Note: we have multiple Type instances of tOid (TypeOid,
- // TypeRegClass, etc). Instead of listing all of them in
- // baseDatumTypeSizes below, we use a single case here.
- return unsafe.Sizeof(DInt(0)), fixedSize
-
case types.TOidWrapper:
return DatumTypeSize(ty.T)
- case types.TCollatedString:
- return unsafe.Sizeof(DCollatedString{"", "", nil}), variableSize
-
case types.TTuple:
sz := uintptr(0)
variable := false
@@ -3514,14 +3505,10 @@ func DatumTypeSize(t types.T) (uintptr, bool) {
variable = variable || typvariable
}
return sz, variable
-
- case types.TArray:
- // TODO(jordan,justin): This seems suspicious.
- return unsafe.Sizeof(DString("")), variableSize
}
// All the primary types have fixed size information.
- if bSzInfo, ok := baseDatumTypeSizes[t]; ok {
+ if bSzInfo, ok := baseDatumTypeSizes[t.SemanticType()]; ok {
return bSzInfo.sz, bSzInfo.variable
}
@@ -3533,26 +3520,32 @@ const (
variableSize = true
)
-var baseDatumTypeSizes = map[types.T]struct {
+var baseDatumTypeSizes = map[types.SemanticType]struct {
sz uintptr
variable bool
}{
- types.Unknown: {unsafe.Sizeof(dNull{}), fixedSize},
- types.Bool: {unsafe.Sizeof(DBool(false)), fixedSize},
- types.BitArray: {unsafe.Sizeof(DBitArray{}), variableSize},
- types.Int: {unsafe.Sizeof(DInt(0)), fixedSize},
- types.Float: {unsafe.Sizeof(DFloat(0.0)), fixedSize},
- types.Decimal: {unsafe.Sizeof(DDecimal{}), variableSize},
- types.String: {unsafe.Sizeof(DString("")), variableSize},
- types.Bytes: {unsafe.Sizeof(DBytes("")), variableSize},
- types.Date: {unsafe.Sizeof(DDate(0)), fixedSize},
- types.Time: {unsafe.Sizeof(DTime(0)), fixedSize},
- types.Timestamp: {unsafe.Sizeof(DTimestamp{}), fixedSize},
- types.TimestampTZ: {unsafe.Sizeof(DTimestampTZ{}), fixedSize},
- types.Interval: {unsafe.Sizeof(DInterval{}), fixedSize},
- types.JSON: {unsafe.Sizeof(DJSON{}), variableSize},
- types.Uuid: {unsafe.Sizeof(DUuid{}), fixedSize},
- types.INet: {unsafe.Sizeof(DIPAddr{}), fixedSize},
+ types.NULL: {unsafe.Sizeof(dNull{}), fixedSize},
+ types.BOOL: {unsafe.Sizeof(DBool(false)), fixedSize},
+ types.BIT: {unsafe.Sizeof(DBitArray{}), variableSize},
+ types.INT: {unsafe.Sizeof(DInt(0)), fixedSize},
+ types.FLOAT: {unsafe.Sizeof(DFloat(0.0)), fixedSize},
+ types.DECIMAL: {unsafe.Sizeof(DDecimal{}), variableSize},
+ types.STRING: {unsafe.Sizeof(DString("")), variableSize},
+ types.COLLATEDSTRING: {unsafe.Sizeof(DCollatedString{"", "", nil}), variableSize},
+ types.BYTES: {unsafe.Sizeof(DBytes("")), variableSize},
+ types.DATE: {unsafe.Sizeof(DDate(0)), fixedSize},
+ types.TIME: {unsafe.Sizeof(DTime(0)), fixedSize},
+ types.TIMESTAMP: {unsafe.Sizeof(DTimestamp{}), fixedSize},
+ types.TIMESTAMPTZ: {unsafe.Sizeof(DTimestampTZ{}), fixedSize},
+ types.INTERVAL: {unsafe.Sizeof(DInterval{}), fixedSize},
+ types.JSONB: {unsafe.Sizeof(DJSON{}), variableSize},
+ types.UUID: {unsafe.Sizeof(DUuid{}), fixedSize},
+ types.INET: {unsafe.Sizeof(DIPAddr{}), fixedSize},
+ types.OID: {unsafe.Sizeof(DInt(0)), fixedSize},
+
+ // TODO(jordan,justin): This seems suspicious.
+ types.ARRAY: {unsafe.Sizeof(DString("")), variableSize},
+
// TODO(jordan,justin): This seems suspicious.
- types.Any: {unsafe.Sizeof(DString("")), variableSize},
+ types.ANY: {unsafe.Sizeof(DString("")), variableSize},
}
diff --git a/pkg/sql/sem/tree/eval.go b/pkg/sql/sem/tree/eval.go
index 742b007960a2..878fce6faffc 100644
--- a/pkg/sql/sem/tree/eval.go
+++ b/pkg/sql/sem/tree/eval.go
@@ -1710,7 +1710,7 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
makeEqFn(types.Bytes, types.Bytes),
makeEqFn(types.Date, types.Date),
makeEqFn(types.Decimal, types.Decimal),
- makeEqFn(types.FamCollatedString, types.FamCollatedString),
+ makeEqFn(types.EmptyCollatedString, types.EmptyCollatedString),
makeEqFn(types.Float, types.Float),
makeEqFn(types.INet, types.INet),
makeEqFn(types.Int, types.Int),
@@ -1740,8 +1740,8 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
// Tuple comparison.
&CmpOp{
- LeftType: types.FamTuple,
- RightType: types.FamTuple,
+ LeftType: types.EmptyTuple,
+ RightType: types.EmptyTuple,
Fn: func(ctx *EvalContext, left Datum, right Datum) (Datum, error) {
return cmpOpTupleFn(ctx, *left.(*DTuple), *right.(*DTuple), EQ), nil
},
@@ -1754,7 +1754,7 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
makeLtFn(types.Bytes, types.Bytes),
makeLtFn(types.Date, types.Date),
makeLtFn(types.Decimal, types.Decimal),
- makeLtFn(types.FamCollatedString, types.FamCollatedString),
+ makeLtFn(types.EmptyCollatedString, types.EmptyCollatedString),
makeLtFn(types.Float, types.Float),
makeLtFn(types.INet, types.INet),
makeLtFn(types.Int, types.Int),
@@ -1783,8 +1783,8 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
// Tuple comparison.
&CmpOp{
- LeftType: types.FamTuple,
- RightType: types.FamTuple,
+ LeftType: types.EmptyTuple,
+ RightType: types.EmptyTuple,
Fn: func(ctx *EvalContext, left Datum, right Datum) (Datum, error) {
return cmpOpTupleFn(ctx, *left.(*DTuple), *right.(*DTuple), LT), nil
},
@@ -1797,7 +1797,7 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
makeLeFn(types.Bytes, types.Bytes),
makeLeFn(types.Date, types.Date),
makeLeFn(types.Decimal, types.Decimal),
- makeLeFn(types.FamCollatedString, types.FamCollatedString),
+ makeLeFn(types.EmptyCollatedString, types.EmptyCollatedString),
makeLeFn(types.Float, types.Float),
makeLeFn(types.INet, types.INet),
makeLeFn(types.Int, types.Int),
@@ -1826,8 +1826,8 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
// Tuple comparison.
&CmpOp{
- LeftType: types.FamTuple,
- RightType: types.FamTuple,
+ LeftType: types.EmptyTuple,
+ RightType: types.EmptyTuple,
Fn: func(ctx *EvalContext, left Datum, right Datum) (Datum, error) {
return cmpOpTupleFn(ctx, *left.(*DTuple), *right.(*DTuple), LE), nil
},
@@ -1848,7 +1848,7 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
makeIsFn(types.Bytes, types.Bytes),
makeIsFn(types.Date, types.Date),
makeIsFn(types.Decimal, types.Decimal),
- makeIsFn(types.FamCollatedString, types.FamCollatedString),
+ makeIsFn(types.EmptyCollatedString, types.EmptyCollatedString),
makeIsFn(types.Float, types.Float),
makeIsFn(types.INet, types.INet),
makeIsFn(types.Int, types.Int),
@@ -1878,8 +1878,8 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
// Tuple comparison.
&CmpOp{
- LeftType: types.FamTuple,
- RightType: types.FamTuple,
+ LeftType: types.EmptyTuple,
+ RightType: types.EmptyTuple,
NullableArgs: true,
Fn: func(ctx *EvalContext, left Datum, right Datum) (Datum, error) {
if left == DNull || right == DNull {
@@ -1895,8 +1895,8 @@ var CmpOps = cmpOpFixups(map[ComparisonOperator]cmpOpOverload{
makeEvalTupleIn(types.Bytes),
makeEvalTupleIn(types.Date),
makeEvalTupleIn(types.Decimal),
- makeEvalTupleIn(types.FamCollatedString),
- makeEvalTupleIn(types.FamTuple),
+ makeEvalTupleIn(types.EmptyCollatedString),
+ makeEvalTupleIn(types.EmptyTuple),
makeEvalTupleIn(types.Float),
makeEvalTupleIn(types.INet),
makeEvalTupleIn(types.Int),
@@ -2167,7 +2167,7 @@ func cmpOpTupleFn(ctx *EvalContext, left, right DTuple, op ComparisonOperator) D
func makeEvalTupleIn(typ types.T) *CmpOp {
return &CmpOp{
LeftType: typ,
- RightType: types.FamTuple,
+ RightType: types.EmptyTuple,
Fn: func(ctx *EvalContext, arg, values Datum) (Datum, error) {
vtuple := values.(*DTuple)
// If the tuple was sorted during normalization, we can perform an
@@ -3700,7 +3700,7 @@ func (expr *FuncExpr) Eval(ctx *EvalContext) (Datum, error) {
// provided type. If the expected type is Any or if the datum is a Null
// type, then no error will be returned.
func ensureExpectedType(exp types.T, d Datum) error {
- if !(exp.FamilyEqual(types.Any) || d.ResolvedType().Equivalent(types.Unknown) ||
+ if !(exp.SemanticType() == types.ANY || d.ResolvedType().SemanticType() == types.NULL ||
d.ResolvedType().Equivalent(exp)) {
return pgerror.NewAssertionErrorf(
"expected return type %q, got: %q", log.Safe(exp), log.Safe(d.ResolvedType()))
diff --git a/pkg/sql/sem/tree/expr.go b/pkg/sql/sem/tree/expr.go
index 90cf92bed29b..76060a385102 100644
--- a/pkg/sql/sem/tree/expr.go
+++ b/pkg/sql/sem/tree/expr.go
@@ -1486,74 +1486,69 @@ type castInfo struct {
}
var (
- bitArrayCastTypes = annotateCast(types.BitArray, []types.T{types.Unknown, types.BitArray, types.Int, types.String, types.FamCollatedString})
- boolCastTypes = annotateCast(types.Bool, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.FamCollatedString})
- intCastTypes = annotateCast(types.Int, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.FamCollatedString,
+ bitArrayCastTypes = annotateCast(types.BitArray, []types.T{types.Unknown, types.BitArray, types.Int, types.String, types.EmptyCollatedString})
+ boolCastTypes = annotateCast(types.Bool, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.EmptyCollatedString})
+ intCastTypes = annotateCast(types.Int, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.EmptyCollatedString,
types.Timestamp, types.TimestampTZ, types.Date, types.Interval, types.Oid, types.BitArray})
- floatCastTypes = annotateCast(types.Float, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.FamCollatedString,
+ floatCastTypes = annotateCast(types.Float, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.EmptyCollatedString,
types.Timestamp, types.TimestampTZ, types.Date, types.Interval})
- decimalCastTypes = annotateCast(types.Decimal, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.FamCollatedString,
+ decimalCastTypes = annotateCast(types.Decimal, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.EmptyCollatedString,
types.Timestamp, types.TimestampTZ, types.Date, types.Interval})
- stringCastTypes = annotateCast(types.String, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.FamCollatedString,
+ stringCastTypes = annotateCast(types.String, []types.T{types.Unknown, types.Bool, types.Int, types.Float, types.Decimal, types.String, types.EmptyCollatedString,
types.BitArray,
- types.FamArray, types.FamTuple,
+ types.AnyArray, types.EmptyTuple,
types.Bytes, types.Timestamp, types.TimestampTZ, types.Interval, types.Uuid, types.Date, types.Time, types.Oid, types.INet, types.JSON})
- bytesCastTypes = annotateCast(types.Bytes, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Bytes, types.Uuid})
- dateCastTypes = annotateCast(types.Date, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Date, types.Timestamp, types.TimestampTZ, types.Int})
- timeCastTypes = annotateCast(types.Time, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Time,
+ bytesCastTypes = annotateCast(types.Bytes, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Bytes, types.Uuid})
+ dateCastTypes = annotateCast(types.Date, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Date, types.Timestamp, types.TimestampTZ, types.Int})
+ timeCastTypes = annotateCast(types.Time, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Time,
types.Timestamp, types.TimestampTZ, types.Interval})
- timestampCastTypes = annotateCast(types.Timestamp, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Date, types.Timestamp, types.TimestampTZ, types.Int})
- intervalCastTypes = annotateCast(types.Interval, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Int, types.Time, types.Interval, types.Float, types.Decimal})
- oidCastTypes = annotateCast(types.Oid, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Int, types.Oid})
- uuidCastTypes = annotateCast(types.Uuid, []types.T{types.Unknown, types.String, types.FamCollatedString, types.Bytes, types.Uuid})
- inetCastTypes = annotateCast(types.INet, []types.T{types.Unknown, types.String, types.FamCollatedString, types.INet})
- arrayCastTypes = annotateCast(types.FamArray, []types.T{types.Unknown, types.String})
+ timestampCastTypes = annotateCast(types.Timestamp, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Date, types.Timestamp, types.TimestampTZ, types.Int})
+ intervalCastTypes = annotateCast(types.Interval, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Int, types.Time, types.Interval, types.Float, types.Decimal})
+ oidCastTypes = annotateCast(types.Oid, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Int, types.Oid})
+ uuidCastTypes = annotateCast(types.Uuid, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.Bytes, types.Uuid})
+ inetCastTypes = annotateCast(types.INet, []types.T{types.Unknown, types.String, types.EmptyCollatedString, types.INet})
+ arrayCastTypes = annotateCast(types.AnyArray, []types.T{types.Unknown, types.String})
jsonCastTypes = annotateCast(types.JSON, []types.T{types.Unknown, types.String, types.JSON})
)
// validCastTypes returns a set of types that can be cast into the provided type.
func validCastTypes(t types.T) []castInfo {
- switch types.UnwrapType(t) {
- case types.BitArray:
+ switch types.UnwrapType(t).SemanticType() {
+ case types.BIT:
return bitArrayCastTypes
- case types.Bool:
+ case types.BOOL:
return boolCastTypes
- case types.Int:
+ case types.INT:
return intCastTypes
- case types.Float:
+ case types.FLOAT:
return floatCastTypes
- case types.Decimal:
+ case types.DECIMAL:
return decimalCastTypes
- case types.String:
+ case types.STRING, types.COLLATEDSTRING:
return stringCastTypes
- case types.Bytes:
+ case types.BYTES:
return bytesCastTypes
- case types.Date:
+ case types.DATE:
return dateCastTypes
- case types.Time:
+ case types.TIME:
return timeCastTypes
- case types.Timestamp, types.TimestampTZ:
+ case types.TIMESTAMP, types.TIMESTAMPTZ:
return timestampCastTypes
- case types.Interval:
+ case types.INTERVAL:
return intervalCastTypes
- case types.JSON:
+ case types.JSONB:
return jsonCastTypes
- case types.Uuid:
+ case types.UUID:
return uuidCastTypes
- case types.INet:
+ case types.INET:
return inetCastTypes
- case types.Oid, types.RegClass, types.RegNamespace, types.RegProc, types.RegProcedure, types.RegType:
+ case types.OID:
return oidCastTypes
+ case types.ARRAY:
+ ret := make([]castInfo, len(arrayCastTypes))
+ copy(ret, arrayCastTypes)
+ return ret
default:
- // TODO(eisen): currently dead -- there is no syntax yet for casting
- // directly to collated string.
- if t.FamilyEqual(types.FamCollatedString) {
- return stringCastTypes
- } else if t.FamilyEqual(types.FamArray) {
- ret := make([]castInfo, len(arrayCastTypes))
- copy(ret, arrayCastTypes)
- return ret
- }
return nil
}
}
diff --git a/pkg/sql/sem/tree/normalize.go b/pkg/sql/sem/tree/normalize.go
index af53c99cb378..7d332db9e6f7 100644
--- a/pkg/sql/sem/tree/normalize.go
+++ b/pkg/sql/sem/tree/normalize.go
@@ -92,7 +92,7 @@ func (expr *UnaryExpr) normalize(v *NormalizeVisitor) TypedExpr {
switch expr.Operator {
case UnaryMinus:
// -0 -> 0 (except for float which has negative zero)
- if val.ResolvedType() != types.Float && v.isNumericZero(val) {
+ if val.ResolvedType().SemanticType() != types.FLOAT && v.isNumericZero(val) {
return val
}
switch b := val.(type) {
@@ -419,7 +419,7 @@ func (expr *ComparisonExpr) normalize(v *NormalizeVisitor) TypedExpr {
// x->y=z to x @> {y:z} which can be used to build spans for inverted index
// lookups.
- if left.TypedRight().ResolvedType() != types.String {
+ if left.TypedRight().ResolvedType().SemanticType() != types.STRING {
break
}
diff --git a/pkg/sql/sem/tree/overload.go b/pkg/sql/sem/tree/overload.go
index c202c7020cb8..e3455bd20771 100644
--- a/pkg/sql/sem/tree/overload.go
+++ b/pkg/sql/sem/tree/overload.go
@@ -161,13 +161,13 @@ func (a ArgTypes) Match(types []types.T) bool {
func (a ArgTypes) MatchAt(typ types.T, i int) bool {
// The parameterized types for Tuples are checked in the type checking
// routines before getting here, so we only need to check if the argument
- // type is a types.FamTuple below. This allows us to avoid defining overloads
- // for types.FamTuple{}, types.FamTuple{types.Any}, types.FamTuple{types.Any, types.Any}, etc.
- // for Tuple operators.
- if typ.FamilyEqual(types.FamTuple) {
- typ = types.FamTuple
+ // type is a types.TUPLE below. This allows us to avoid defining overloads
+ // for types.Tuple{}, types.Tuple{types.Any}, types.Tuple{types.Any, types.Any},
+ // etc. for Tuple operators.
+ if typ.SemanticType() == types.TUPLE {
+ typ = types.EmptyTuple
}
- return i < len(a) && (typ == types.Unknown || a[i].Typ.Equivalent(typ))
+ return i < len(a) && (typ.SemanticType() == types.NULL || a[i].Typ.Equivalent(typ))
}
// MatchLen is part of the TypeList interface.
@@ -268,9 +268,9 @@ func (v VariadicType) Match(types []types.T) bool {
// MatchAt is part of the TypeList interface.
func (v VariadicType) MatchAt(typ types.T, i int) bool {
if i < len(v.FixedTypes) {
- return typ == types.Unknown || v.FixedTypes[i].Equivalent(typ)
+ return typ.SemanticType() == types.NULL || v.FixedTypes[i].Equivalent(typ)
}
- return typ == types.Unknown || v.VarType.Equivalent(typ)
+ return typ.SemanticType() == types.NULL || v.VarType.Equivalent(typ)
}
// MatchLen is part of the TypeList interface.
@@ -356,7 +356,7 @@ func FirstNonNullReturnType() ReturnTyper {
return UnknownReturnType
}
for _, arg := range args {
- if t := arg.ResolvedType(); t != types.Unknown {
+ if t := arg.ResolvedType(); t.SemanticType() != types.NULL {
return t
}
}
@@ -491,7 +491,7 @@ func typeCheckOverloadedExprs(
}
// The first heuristic is to prefer candidates that return the desired type.
- if desired != types.Any {
+ if desired.SemanticType() != types.ANY {
s.overloadIdxs = filterOverloads(s.overloads, s.overloadIdxs,
func(o overloadImpl) bool {
// For now, we only filter on the return type for overloads with
@@ -654,8 +654,8 @@ func typeCheckOverloadedExprs(
}
leftType := left.ResolvedType()
rightType := right.ResolvedType()
- leftIsNull := leftType == types.Unknown
- rightIsNull := rightType == types.Unknown
+ leftIsNull := leftType.SemanticType() == types.NULL
+ rightIsNull := rightType.SemanticType() == types.NULL
oneIsNull := (leftIsNull || rightIsNull) && !(leftIsNull && rightIsNull)
if oneIsNull {
if leftIsNull {
diff --git a/pkg/sql/sem/tree/parse_string.go b/pkg/sql/sem/tree/parse_string.go
index 91942d9111ed..b4a7bbe9bb85 100644
--- a/pkg/sql/sem/tree/parse_string.go
+++ b/pkg/sql/sem/tree/parse_string.go
@@ -27,27 +27,25 @@ import (
func ParseStringAs(t types.T, s string, evalCtx *EvalContext) (Datum, error) {
var d Datum
var err error
- switch t {
- case types.Bytes:
+ switch t.SemanticType() {
+ case types.BYTES:
d = NewDBytes(DBytes(s))
+ case types.COLLATEDSTRING:
+ d = NewDCollatedString(s, t.(types.TCollatedString).Locale, &evalCtx.CollationEnv)
+ case types.ARRAY:
+ t := t.(types.TArray)
+ typ, err := coltypes.DatumTypeToColumnType(t.Typ)
+ if err != nil {
+ return nil, err
+ }
+ d, err = ParseDArrayFromString(evalCtx, s, typ)
+ if err != nil {
+ return nil, err
+ }
default:
- switch t := t.(type) {
- case types.TArray:
- typ, err := coltypes.DatumTypeToColumnType(t.Typ)
- if err != nil {
- return nil, err
- }
- d, err = ParseDArrayFromString(evalCtx, s, typ)
- if err != nil {
- return nil, err
- }
- case types.TCollatedString:
- d = NewDCollatedString(s, t.Locale, &evalCtx.CollationEnv)
- default:
- d, err = parseStringAs(t, s, evalCtx)
- if d == nil && err == nil {
- return nil, pgerror.NewAssertionErrorf("unknown type %s (%T)", t, t)
- }
+ d, err = parseStringAs(t, s, evalCtx)
+ if d == nil && err == nil {
+ return nil, pgerror.NewAssertionErrorf("unknown type %s (%T)", t, t)
}
}
return d, err
@@ -56,8 +54,8 @@ func ParseStringAs(t types.T, s string, evalCtx *EvalContext) (Datum, error) {
// ParseDatumStringAs parses s as type t. This function is guaranteed to
// round-trip when printing a Datum with FmtExport.
func ParseDatumStringAs(t types.T, s string, evalCtx *EvalContext) (Datum, error) {
- switch t {
- case types.Bytes:
+ switch t.SemanticType() {
+ case types.BYTES:
return ParseDByte(s)
default:
return ParseStringAs(t, s, evalCtx)
@@ -67,34 +65,34 @@ func ParseDatumStringAs(t types.T, s string, evalCtx *EvalContext) (Datum, error
// parseStringAs parses s as type t for simple types. Bytes, arrays, collated
// strings are not handled. nil, nil is returned if t is not a supported type.
func parseStringAs(t types.T, s string, ctx ParseTimeContext) (Datum, error) {
- switch t {
- case types.BitArray:
+ switch t.SemanticType() {
+ case types.BIT:
return ParseDBitArray(s)
- case types.Bool:
+ case types.BOOL:
return ParseDBool(s)
- case types.Date:
+ case types.DATE:
return ParseDDate(ctx, s)
- case types.Decimal:
+ case types.DECIMAL:
return ParseDDecimal(s)
- case types.Float:
+ case types.FLOAT:
return ParseDFloat(s)
- case types.INet:
+ case types.INET:
return ParseDIPAddrFromINetString(s)
- case types.Int:
+ case types.INT:
return ParseDInt(s)
- case types.Interval:
+ case types.INTERVAL:
return ParseDInterval(s)
- case types.JSON:
+ case types.JSONB:
return ParseDJSON(s)
- case types.String:
+ case types.STRING:
return NewDString(s), nil
- case types.Time:
+ case types.TIME:
return ParseDTime(ctx, s)
- case types.Timestamp:
+ case types.TIMESTAMP:
return ParseDTimestamp(ctx, s, time.Microsecond)
- case types.TimestampTZ:
+ case types.TIMESTAMPTZ:
return ParseDTimestampTZ(ctx, s, time.Microsecond)
- case types.Uuid:
+ case types.UUID:
return ParseDUuidFromString(s)
default:
return nil, nil
diff --git a/pkg/sql/sem/tree/parse_string_test.go b/pkg/sql/sem/tree/parse_string_test.go
index 351ee0ae35bc..6c4c16dc8ee8 100644
--- a/pkg/sql/sem/tree/parse_string_test.go
+++ b/pkg/sql/sem/tree/parse_string_test.go
@@ -127,7 +127,7 @@ func TestParseDatumStringAs(t *testing.T) {
if err != nil {
t.Fatal(err)
}
- if d.ResolvedType() != typ {
+ if d.ResolvedType().SemanticType() != typ.SemanticType() {
t.Fatalf("unexpected type: %s", d.ResolvedType())
}
ds := AsStringWithFlags(d, FmtExport)
diff --git a/pkg/sql/sem/tree/testutils.go b/pkg/sql/sem/tree/testutils.go
index b37b576eadfb..84a3a7a4b6b9 100644
--- a/pkg/sql/sem/tree/testutils.go
+++ b/pkg/sql/sem/tree/testutils.go
@@ -38,47 +38,47 @@ func MockNameTypes(types map[string]types.T) func() {
// SampleDatum is intended to be a more lightweight version of RandDatum for
// when you just need one consistent example of a datum.
func SampleDatum(t types.T) Datum {
- switch t {
- case types.BitArray:
+ switch t.SemanticType() {
+ case types.BIT:
a, _ := NewDBitArrayFromInt(123, 40)
return a
- case types.Bool:
+ case types.BOOL:
return MakeDBool(true)
- case types.Int:
+ case types.INT:
return NewDInt(123)
- case types.Float:
+ case types.FLOAT:
f := DFloat(123.456)
return &f
- case types.Decimal:
+ case types.DECIMAL:
d := &DDecimal{}
// int64(rng.Uint64()) to get negative numbers, too
d.Decimal.SetFinite(3, 6)
return d
- case types.String:
+ case types.STRING:
return NewDString("Carl")
- case types.Bytes:
+ case types.BYTES:
return NewDBytes("Princess")
- case types.Date:
+ case types.DATE:
return NewDDate(123123)
- case types.Time:
+ case types.TIME:
return MakeDTime(timeofday.FromInt(789))
- case types.Timestamp:
+ case types.TIMESTAMP:
return MakeDTimestamp(timeutil.Unix(123, 123), time.Second)
- case types.TimestampTZ:
+ case types.TIMESTAMPTZ:
return MakeDTimestampTZ(timeutil.Unix(123, 123), time.Second)
- case types.Interval:
+ case types.INTERVAL:
i, _ := ParseDInterval("1h1m1s")
return i
- case types.Uuid:
+ case types.UUID:
u, _ := ParseDUuidFromString("3189ad07-52f2-4d60-83e8-4a8347fef718")
return u
- case types.INet:
+ case types.INET:
i, _ := ParseDIPAddrFromINetString("127.0.0.1")
return i
- case types.JSON:
+ case types.JSONB:
j, _ := ParseDJSON(`{"a": "b"}`)
return j
- case types.Oid:
+ case types.OID:
return NewDOid(DInt(1009))
default:
panic(fmt.Sprintf("SampleDatum not implemented for %s", t))
diff --git a/pkg/sql/sem/tree/type_check.go b/pkg/sql/sem/tree/type_check.go
index 99a7da2dccc5..9712ccaf4622 100644
--- a/pkg/sql/sem/tree/type_check.go
+++ b/pkg/sql/sem/tree/type_check.go
@@ -270,7 +270,7 @@ func TypeCheckAndRequire(
if err != nil {
return nil, err
}
- if typ := typedExpr.ResolvedType(); !(typ.Equivalent(required) || typ == types.Unknown) {
+ if typ := typedExpr.ResolvedType(); !(typ.Equivalent(required) || typ.SemanticType() == types.NULL) {
return typedExpr, pgerror.NewErrorf(
pgerror.CodeDatatypeMismatchError, "argument of %s must be type %s, not type %s", op, required, typ)
}
@@ -307,7 +307,7 @@ func (expr *BinaryExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr,
// Return NULL if at least one overload is possible, NULL is an argument,
// and none of the overloads accept NULL.
- if leftReturn == types.Unknown || rightReturn == types.Unknown {
+ if leftReturn.SemanticType() == types.NULL || rightReturn.SemanticType() == types.NULL {
if len(fns) > 0 {
noneAcceptNull := true
for _, e := range fns {
@@ -326,7 +326,7 @@ func (expr *BinaryExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr,
// or if it found an ambiguity.
if len(fns) != 1 {
var desStr string
- if desired != types.Any {
+ if desired.SemanticType() != types.ANY {
desStr = fmt.Sprintf(" (desired <%s>)", desired)
}
sig := fmt.Sprintf("<%s> %s <%s>%s", leftReturn, expr.Operator, rightReturn, desStr)
@@ -408,7 +408,7 @@ func (expr *CaseExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr, e
func isCastDeepValid(castFrom, castTo types.T) (bool, telemetry.Counter) {
castFrom = types.UnwrapType(castFrom)
castTo = types.UnwrapType(castTo)
- if castTo.FamilyEqual(types.FamArray) && castFrom.FamilyEqual(types.FamArray) {
+ if castTo.SemanticType() == types.ARRAY && castFrom.SemanticType() == types.ARRAY {
ok, c := isCastDeepValid(castFrom.(types.TArray).Typ, castTo.(types.TArray).Typ)
if ok {
telemetry.Inc(sqltelemetry.ArrayCastCounter)
@@ -416,7 +416,7 @@ func isCastDeepValid(castFrom, castTo types.T) (bool, telemetry.Counter) {
return ok, c
}
for _, t := range validCastTypes(castTo) {
- if castFrom.FamilyEqual(t.fromT) {
+ if castFrom.SemanticType() == t.fromT.SemanticType() {
return true, t.counter
}
}
@@ -528,7 +528,7 @@ func (expr *CollateExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr
return nil, err
}
t := subExpr.ResolvedType()
- if types.IsStringType(t) || t == types.Unknown {
+ if types.IsStringType(t) || t.SemanticType() == types.NULL {
expr.Expr = subExpr
expr.typ = types.TCollatedString{Locale: expr.Locale}
return expr, nil
@@ -809,7 +809,7 @@ func (expr *FuncExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr, e
// as an argument.
if !def.NullableArgs && def.FunctionProperties.Class != GeneratorClass {
for _, expr := range typedSubExprs {
- if expr.ResolvedType() == types.Unknown {
+ if expr.ResolvedType().SemanticType() == types.NULL {
return DNull, nil
}
}
@@ -825,7 +825,7 @@ func (expr *FuncExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr, e
typeNames = append(typeNames, expr.ResolvedType().String())
}
var desStr string
- if desired != types.Any {
+ if desired.SemanticType() != types.ANY {
desStr = fmt.Sprintf(" (desired <%s>)", desired)
}
sig := fmt.Sprintf("%s(%s)%s", &expr.Func, strings.Join(typeNames, ", "), desStr)
@@ -1159,7 +1159,7 @@ func (expr *UnaryExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr,
// Return NULL if at least one overload is possible and NULL is an argument.
if len(fns) > 0 {
- if exprReturn == types.Unknown {
+ if exprReturn.SemanticType() == types.NULL {
return DNull, nil
}
}
@@ -1168,7 +1168,7 @@ func (expr *UnaryExpr) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr,
// or if it found an ambiguity.
if len(fns) != 1 {
var desStr string
- if desired != types.Any {
+ if desired.SemanticType() != types.ANY {
desStr = fmt.Sprintf(" (desired <%s>)", desired)
}
sig := fmt.Sprintf("%s <%s>%s", expr.Operator, exprReturn, desStr)
@@ -1274,7 +1274,7 @@ func (expr *Array) TypeCheck(ctx *SemaContext, desired types.T) (TypedExpr, erro
}
if len(expr.Exprs) == 0 {
- if desiredParam == types.Any {
+ if desiredParam.SemanticType() == types.ANY {
return nil, errAmbiguousArrayType
}
expr.typ = types.TArray{Typ: desiredParam}
@@ -1464,7 +1464,7 @@ func typeCheckAndRequire(
if err != nil {
return nil, err
}
- if typ := typedExpr.ResolvedType(); !(typ == types.Unknown || typ.Equivalent(required)) {
+ if typ := typedExpr.ResolvedType(); !(typ.SemanticType() == types.NULL || typ.Equivalent(required)) {
return nil, pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError, "incompatible %s type: %s", op, typ)
}
return typedExpr, nil
@@ -1528,7 +1528,7 @@ func typeCheckComparisonOpWithSubOperator(
cmpTypeRight = retType
// Return early without looking up a CmpOp if the comparison type is types.Null.
- if leftTyped.ResolvedType() == types.Unknown || retType == types.Unknown {
+ if leftTyped.ResolvedType().SemanticType() == types.NULL || retType.SemanticType() == types.NULL {
return leftTyped, rightTyped, nil, true /* alwaysNull */, nil
}
} else {
@@ -1560,7 +1560,7 @@ func typeCheckComparisonOpWithSubOperator(
}
rightReturn := rightTyped.ResolvedType()
- if cmpTypeLeft == types.Unknown || rightReturn == types.Unknown {
+ if cmpTypeLeft.SemanticType() == types.NULL || rightReturn.SemanticType() == types.NULL {
return leftTyped, rightTyped, nil, true /* alwaysNull */, nil
}
@@ -1637,9 +1637,9 @@ func typeCheckComparisonOp(
pgerror.NewErrorf(pgerror.CodeInvalidParameterValueError, unsupportedCompErrFmt, sigWithErr)
}
- fn, ok := ops.lookupImpl(retType, types.FamTuple)
+ fn, ok := ops.lookupImpl(retType, types.EmptyTuple)
if !ok {
- sig := fmt.Sprintf(compSignatureFmt, retType, op, types.FamTuple)
+ sig := fmt.Sprintf(compSignatureFmt, retType, op, types.EmptyTuple)
return nil, nil, nil, false,
pgerror.NewErrorf(pgerror.CodeInvalidParameterValueError, unsupportedCompErrFmt, sig)
}
@@ -1658,9 +1658,9 @@ func typeCheckComparisonOp(
return typedLeft, rightTuple, fn, false, nil
case leftIsTuple && rightIsTuple:
- fn, ok := ops.lookupImpl(types.FamTuple, types.FamTuple)
+ fn, ok := ops.lookupImpl(types.EmptyTuple, types.EmptyTuple)
if !ok {
- sig := fmt.Sprintf(compSignatureFmt, types.FamTuple, op, types.FamTuple)
+ sig := fmt.Sprintf(compSignatureFmt, types.EmptyTuple, op, types.EmptyTuple)
return nil, nil, nil, false,
pgerror.NewErrorf(pgerror.CodeInvalidParameterValueError, unsupportedCompErrFmt, sig)
}
@@ -1699,7 +1699,7 @@ func typeCheckComparisonOp(
// Return early if at least one overload is possible, NULL is an argument,
// and none of the overloads accept NULL.
- if leftReturn == types.Unknown || rightReturn == types.Unknown {
+ if leftReturn.SemanticType() == types.NULL || rightReturn.SemanticType() == types.NULL {
if len(fns) > 0 {
noneAcceptNull := true
for _, e := range fns {
@@ -1716,7 +1716,8 @@ func typeCheckComparisonOp(
// Throw a typing error if overload resolution found either no compatible candidates
// or if it found an ambiguity.
- collationMismatch := leftReturn.FamilyEqual(types.FamCollatedString) && !leftReturn.Equivalent(rightReturn)
+ collationMismatch :=
+ leftReturn.SemanticType() == types.COLLATEDSTRING && !leftReturn.Equivalent(rightReturn)
if len(fns) != 1 || collationMismatch {
sig := fmt.Sprintf(compSignatureFmt, leftReturn, op, rightReturn)
if len(fns) == 0 || collationMismatch {
@@ -1796,14 +1797,14 @@ func TypeCheckSameTypedExprs(
return nil, nil, err
}
typedExprs[j] = typedExpr
- if returnType := typedExpr.ResolvedType(); returnType != types.Unknown {
+ if returnType := typedExpr.ResolvedType(); returnType.SemanticType() != types.NULL {
firstValidType = returnType
firstValidIdx = i
break
}
}
- if firstValidType == types.Unknown {
+ if firstValidType.SemanticType() == types.NULL {
switch {
case len(constIdxs) > 0:
return typeCheckConstsAndPlaceholdersWithDesired(s, desired)
@@ -1820,7 +1821,7 @@ func TypeCheckSameTypedExprs(
if err != nil {
return nil, nil, err
}
- if typ := typedExpr.ResolvedType(); !(typ.Equivalent(firstValidType) || typ == types.Unknown) {
+ if typ := typedExpr.ResolvedType(); !(typ.Equivalent(firstValidType) || typ.SemanticType() == types.NULL) {
return nil, nil, unexpectedTypeError(exprs[i], firstValidType, typ)
}
typedExprs[i] = typedExpr
@@ -1870,7 +1871,7 @@ func typeCheckSameTypedConsts(s typeCheckExprsState, typ types.T, required bool)
}
// If typ is not a wildcard, all consts try to become typ.
- if typ != types.Any {
+ if typ.SemanticType() != types.ANY {
all := true
for _, i := range s.constIdxs {
if !canConstantBecome(s.exprs[i].(Constant), typ) {
@@ -1907,7 +1908,7 @@ func typeCheckSameTypedConsts(s typeCheckExprsState, typ types.T, required bool)
if typ := typedExpr.ResolvedType(); !typ.Equivalent(reqTyp) {
return nil, unexpectedTypeError(s.exprs[i], reqTyp, typ)
}
- if reqTyp == types.Any {
+ if reqTyp.SemanticType() == types.ANY {
reqTyp = typedExpr.ResolvedType()
}
}
@@ -2045,7 +2046,7 @@ func checkAllExprsAreTuples(ctx *SemaContext, exprs []Expr) error {
if err != nil {
return err
}
- return unexpectedTypeError(expr, types.FamTuple, typedExpr.ResolvedType())
+ return unexpectedTypeError(expr, types.EmptyTuple, typedExpr.ResolvedType())
}
}
return nil
diff --git a/pkg/sql/sem/tree/window_funcs_test.go b/pkg/sql/sem/tree/window_funcs_test.go
index 4d9a659f3e15..9572966e2463 100644
--- a/pkg/sql/sem/tree/window_funcs_test.go
+++ b/pkg/sql/sem/tree/window_funcs_test.go
@@ -70,12 +70,12 @@ func testStartPreceding(
}
for offset := minOffset; offset < maxOffset; offset += rand.Intn(maxOffset / 10) {
var typedOffset Datum
- switch offsetType {
- case types.Int:
+ switch offsetType.SemanticType() {
+ case types.INT:
typedOffset = NewDInt(DInt(offset))
- case types.Float:
+ case types.FLOAT:
typedOffset = NewDFloat(DFloat(offset))
- case types.Decimal:
+ case types.DECIMAL:
decimal := apd.Decimal{}
decimal.SetInt64(int64(offset))
typedOffset = &DDecimal{Decimal: decimal}
@@ -120,12 +120,12 @@ func testStartFollowing(
}
for offset := minOffset; offset < maxOffset; offset += rand.Intn(maxOffset / 10) {
var typedOffset Datum
- switch offsetType {
- case types.Int:
+ switch offsetType.SemanticType() {
+ case types.INT:
typedOffset = NewDInt(DInt(offset))
- case types.Float:
+ case types.FLOAT:
typedOffset = NewDFloat(DFloat(offset))
- case types.Decimal:
+ case types.DECIMAL:
decimal := apd.Decimal{}
decimal.SetInt64(int64(offset))
typedOffset = &DDecimal{Decimal: decimal}
@@ -177,12 +177,12 @@ func testEndPreceding(t *testing.T, evalCtx *EvalContext, wfr *WindowFrameRun, o
}
for offset := minOffset; offset < maxOffset; offset += rand.Intn(maxOffset / 10) {
var typedOffset Datum
- switch offsetType {
- case types.Int:
+ switch offsetType.SemanticType() {
+ case types.INT:
typedOffset = NewDInt(DInt(offset))
- case types.Float:
+ case types.FLOAT:
typedOffset = NewDFloat(DFloat(offset))
- case types.Decimal:
+ case types.DECIMAL:
decimal := apd.Decimal{}
decimal.SetInt64(int64(offset))
typedOffset = &DDecimal{Decimal: decimal}
@@ -225,12 +225,12 @@ func testEndFollowing(t *testing.T, evalCtx *EvalContext, wfr *WindowFrameRun, o
}
for offset := minOffset; offset < maxOffset; offset += rand.Intn(maxOffset / 10) {
var typedOffset Datum
- switch offsetType {
- case types.Int:
+ switch offsetType.SemanticType() {
+ case types.INT:
typedOffset = NewDInt(DInt(offset))
- case types.Float:
+ case types.FLOAT:
typedOffset = NewDFloat(DFloat(offset))
- case types.Decimal:
+ case types.DECIMAL:
decimal := apd.Decimal{}
decimal.SetInt64(int64(offset))
typedOffset = &DDecimal{Decimal: decimal}
diff --git a/pkg/sql/sem/types/oid.go b/pkg/sql/sem/types/oid.go
index 33afc5a6ea36..d905099dd40e 100644
--- a/pkg/sql/sem/types/oid.go
+++ b/pkg/sql/sem/types/oid.go
@@ -43,9 +43,6 @@ var (
// OidVector is a type-alias for an OidArray with a different OID. Can
// be compared with ==.
OidVector = WrapTypeWithOid(TArray{Oid}, oid.T_oidvector)
- // NameArray is the type family of a DArray containing the Name alias type.
- // Can be compared with ==.
- NameArray T = TArray{Name}
)
var (
@@ -120,7 +117,7 @@ var OidToType = map[oid.Oid]T{
oid.T_regprocedure: RegProcedure,
oid.T_regtype: RegType,
// TODO(jordan): I think this entry for T_record is out of place.
- oid.T_record: FamTuple,
+ oid.T_record: EmptyTuple,
}
// oidToArrayOid maps scalar type Oids to their corresponding array type Oid.
@@ -156,13 +153,13 @@ type TOid struct {
oidType oid.Oid
}
+// SemanticType returns the semantic type.
+func (TOid) SemanticType() SemanticType { return OID }
+
func (t TOid) String() string { return t.SQLName() }
// Equivalent implements the T interface.
-func (t TOid) Equivalent(other T) bool { return t.FamilyEqual(other) || other == Any }
-
-// FamilyEqual implements the T interface.
-func (TOid) FamilyEqual(other T) bool { _, ok := UnwrapType(other).(TOid); return ok }
+func (t TOid) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), OID) }
// Oid implements the T interface.
func (t TOid) Oid() oid.Oid { return t.oidType }
diff --git a/pkg/sql/sem/types/types.go b/pkg/sql/sem/types/types.go
index d8fe2e179706..40cdb7569cb0 100644
--- a/pkg/sql/sem/types/types.go
+++ b/pkg/sql/sem/types/types.go
@@ -21,24 +21,26 @@ import (
"strings"
"unicode/utf8"
- "github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/lib/pq/oid"
)
// T represents a SQL type.
type T interface {
fmt.Stringer
+
+ // SemanticType is temporary.
+ // TODO(andyk): Remove in future commit.
+ SemanticType() SemanticType
+
// Equivalent returns whether the receiver and the other type are equivalent.
// We say that two type patterns are "equivalent" when they are structurally
// equivalent given that a wildcard is equivalent to any type. When neither
// Type is ambiguous (see IsAmbiguous), equivalency is the same as type equality.
Equivalent(other T) bool
- // FamilyEqual returns whether the receiver and the other type have the same
- // constructor.
- FamilyEqual(other T) bool
// Oid returns the type's Postgres object ID.
Oid() oid.Oid
+
// SQLName returns the type's SQL standard name. This can be looked up for a
// type `t` in postgres by running `SELECT format_type(t::regtype, NULL)`.
SQLName() string
@@ -51,25 +53,25 @@ type T interface {
var (
// Unknown is the type of an expression that statically evaluates to
- // NULL. Can be compared with ==.
+ // NULL.
Unknown T = tUnknown{}
- // Bool is the type of a DBool. Can be compared with ==.
+ // Bool is the type of a DBool.
Bool T = tBool{}
- // BitArray is the type of a DBitArray. Can be compared with ==.
+ // BitArray is the type of a DBitArray.
BitArray T = tBitArray{}
- // Int is the type of a DInt. Can be compared with ==.
+ // Int is the type of a DInt.
Int T = tInt{}
- // Float is the type of a DFloat. Can be compared with ==.
+ // Float is the type of a DFloat.
Float T = tFloat{}
- // Decimal is the type of a DDecimal. Can be compared with ==.
+ // Decimal is the type of a DDecimal.
Decimal T = tDecimal{}
- // String is the type of a DString. Can be compared with ==.
+ // String is the type of a DString.
String T = tString{}
- // Bytes is the type of a DBytes. Can be compared with ==.
+ // Bytes is the type of a DBytes.
Bytes T = tBytes{}
- // Date is the type of a DDate. Can be compared with ==.
+ // Date is the type of a DDate.
Date T = tDate{}
- // Time is the type of a DTime. Can be compared with ==.
+ // Time is the type of a DTime.
Time T = tTime{}
// Timestamp is the type of a DTimestamp. Can be compared with ==.
Timestamp T = tTimestamp{}
@@ -109,91 +111,90 @@ var (
Oid,
}
- // FamCollatedString is the type family of a DString. CANNOT be
- // compared with ==.
- FamCollatedString T = TCollatedString{}
- // FamTuple is the type family of a DTuple. CANNOT be compared with ==.
- FamTuple T = TTuple{}
- // FamArray is the type family of a DArray. CANNOT be compared with ==.
- FamArray T = TArray{}
- // FamPlaceholder is the type family of a placeholder. CANNOT be compared
- // with ==.
- FamPlaceholder T = TPlaceholder{}
+ // EmptyTuple is the tuple type with no fields.
+ EmptyTuple T = TTuple{}
+
+ // EmptyCollatedString is the collated string type with an empty locale.
+ EmptyCollatedString T = TCollatedString{}
)
+func isTypeOrAny(typ, isTyp SemanticType) bool {
+ return typ == isTyp || typ == ANY
+}
+
// Do not instantiate the tXxx types elsewhere. The variables above are intended
// to be singletons.
type tUnknown struct{}
-func (tUnknown) String() string { return "unknown" }
-func (tUnknown) Equivalent(other T) bool { return other == Unknown || other == Any }
-func (tUnknown) FamilyEqual(other T) bool { return other == Unknown }
-func (tUnknown) Oid() oid.Oid { return oid.T_unknown }
-func (tUnknown) SQLName() string { return "unknown" }
-func (tUnknown) IsAmbiguous() bool { return true }
+func (tUnknown) SemanticType() SemanticType { return NULL }
+func (tUnknown) String() string { return "unknown" }
+func (tUnknown) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), NULL) }
+func (tUnknown) Oid() oid.Oid { return oid.T_unknown }
+func (tUnknown) SQLName() string { return "unknown" }
+func (tUnknown) IsAmbiguous() bool { return true }
type tBool struct{}
-func (tBool) String() string { return "bool" }
-func (tBool) Equivalent(other T) bool { return UnwrapType(other) == Bool || other == Any }
-func (tBool) FamilyEqual(other T) bool { return UnwrapType(other) == Bool }
-func (tBool) Oid() oid.Oid { return oid.T_bool }
-func (tBool) SQLName() string { return "boolean" }
-func (tBool) IsAmbiguous() bool { return false }
+func (tBool) SemanticType() SemanticType { return BOOL }
+func (tBool) String() string { return "bool" }
+func (tBool) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), BOOL) }
+func (tBool) Oid() oid.Oid { return oid.T_bool }
+func (tBool) SQLName() string { return "boolean" }
+func (tBool) IsAmbiguous() bool { return false }
type tInt struct{}
-func (tInt) String() string { return "int" }
-func (tInt) Equivalent(other T) bool { return UnwrapType(other) == Int || other == Any }
-func (tInt) FamilyEqual(other T) bool { return UnwrapType(other) == Int }
-func (tInt) Oid() oid.Oid { return oid.T_int8 }
-func (tInt) SQLName() string { return "bigint" }
-func (tInt) IsAmbiguous() bool { return false }
+func (tInt) SemanticType() SemanticType { return INT }
+func (tInt) String() string { return "int" }
+func (tInt) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), INT) }
+func (tInt) Oid() oid.Oid { return oid.T_int8 }
+func (tInt) SQLName() string { return "bigint" }
+func (tInt) IsAmbiguous() bool { return false }
type tBitArray struct{}
-func (tBitArray) String() string { return "varbit" }
-func (tBitArray) Equivalent(other T) bool { return UnwrapType(other) == BitArray || other == Any }
-func (tBitArray) FamilyEqual(other T) bool { return UnwrapType(other) == BitArray }
-func (tBitArray) Oid() oid.Oid { return oid.T_varbit }
-func (tBitArray) SQLName() string { return "bit varying" }
-func (tBitArray) IsAmbiguous() bool { return false }
+func (tBitArray) SemanticType() SemanticType { return BIT }
+func (tBitArray) String() string { return "varbit" }
+func (tBitArray) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), BIT) }
+func (tBitArray) Oid() oid.Oid { return oid.T_varbit }
+func (tBitArray) SQLName() string { return "bit varying" }
+func (tBitArray) IsAmbiguous() bool { return false }
type tFloat struct{}
-func (tFloat) String() string { return "float" }
-func (tFloat) Equivalent(other T) bool { return UnwrapType(other) == Float || other == Any }
-func (tFloat) FamilyEqual(other T) bool { return UnwrapType(other) == Float }
-func (tFloat) Oid() oid.Oid { return oid.T_float8 }
-func (tFloat) SQLName() string { return "double precision" }
-func (tFloat) IsAmbiguous() bool { return false }
+func (tFloat) SemanticType() SemanticType { return FLOAT }
+func (tFloat) String() string { return "float" }
+func (tFloat) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), FLOAT) }
+func (tFloat) Oid() oid.Oid { return oid.T_float8 }
+func (tFloat) SQLName() string { return "double precision" }
+func (tFloat) IsAmbiguous() bool { return false }
type tDecimal struct{}
-func (tDecimal) String() string { return "decimal" }
-func (tDecimal) Equivalent(other T) bool {
- return UnwrapType(other) == Decimal || other == Any
-}
-
-func (tDecimal) FamilyEqual(other T) bool { return UnwrapType(other) == Decimal }
-func (tDecimal) Oid() oid.Oid { return oid.T_numeric }
-func (tDecimal) SQLName() string { return "numeric" }
-func (tDecimal) IsAmbiguous() bool { return false }
+func (tDecimal) SemanticType() SemanticType { return DECIMAL }
+func (tDecimal) String() string { return "decimal" }
+func (tDecimal) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), DECIMAL) }
+func (tDecimal) Oid() oid.Oid { return oid.T_numeric }
+func (tDecimal) SQLName() string { return "numeric" }
+func (tDecimal) IsAmbiguous() bool { return false }
type tString struct{}
-func (tString) String() string { return "string" }
-func (tString) Equivalent(other T) bool { return UnwrapType(other) == String || other == Any }
-func (tString) FamilyEqual(other T) bool { return UnwrapType(other) == String }
-func (tString) Oid() oid.Oid { return oid.T_text }
-func (tString) SQLName() string { return "text" }
-func (tString) IsAmbiguous() bool { return false }
+func (tString) SemanticType() SemanticType { return STRING }
+func (tString) String() string { return "string" }
+func (tString) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), STRING) }
+func (tString) Oid() oid.Oid { return oid.T_text }
+func (tString) SQLName() string { return "text" }
+func (tString) IsAmbiguous() bool { return false }
// TCollatedString is the type of strings with a locale.
type TCollatedString struct {
Locale string
}
+// SemanticType returns the semantic type.
+func (TCollatedString) SemanticType() SemanticType { return COLLATEDSTRING }
+
// String implements the fmt.Stringer interface.
func (t TCollatedString) String() string {
if t.Locale == "" {
@@ -205,7 +206,7 @@ func (t TCollatedString) String() string {
// Equivalent implements the T interface.
func (t TCollatedString) Equivalent(other T) bool {
- if other == Any {
+ if other.SemanticType() == ANY {
return true
}
u, ok := UnwrapType(other).(TCollatedString)
@@ -215,12 +216,6 @@ func (t TCollatedString) Equivalent(other T) bool {
return false
}
-// FamilyEqual implements the T interface.
-func (TCollatedString) FamilyEqual(other T) bool {
- _, ok := UnwrapType(other).(TCollatedString)
- return ok
-}
-
// Oid implements the T interface.
func (TCollatedString) Oid() oid.Oid { return oid.T_text }
@@ -234,96 +229,84 @@ func (t TCollatedString) IsAmbiguous() bool {
type tBytes struct{}
-func (tBytes) String() string { return "bytes" }
-func (tBytes) Equivalent(other T) bool { return UnwrapType(other) == Bytes || other == Any }
-func (tBytes) FamilyEqual(other T) bool { return UnwrapType(other) == Bytes }
-func (tBytes) Oid() oid.Oid { return oid.T_bytea }
-func (tBytes) SQLName() string { return "bytea" }
-func (tBytes) IsAmbiguous() bool { return false }
+func (tBytes) SemanticType() SemanticType { return BYTES }
+func (tBytes) String() string { return "bytes" }
+func (tBytes) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), BYTES) }
+func (tBytes) Oid() oid.Oid { return oid.T_bytea }
+func (tBytes) SQLName() string { return "bytea" }
+func (tBytes) IsAmbiguous() bool { return false }
type tDate struct{}
-func (tDate) String() string { return "date" }
-func (tDate) Equivalent(other T) bool { return UnwrapType(other) == Date || other == Any }
-func (tDate) FamilyEqual(other T) bool { return UnwrapType(other) == Date }
-func (tDate) Oid() oid.Oid { return oid.T_date }
-func (tDate) SQLName() string { return "date" }
-func (tDate) IsAmbiguous() bool { return false }
+func (tDate) SemanticType() SemanticType { return DATE }
+func (tDate) String() string { return "date" }
+func (tDate) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), DATE) }
+func (tDate) Oid() oid.Oid { return oid.T_date }
+func (tDate) SQLName() string { return "date" }
+func (tDate) IsAmbiguous() bool { return false }
type tTime struct{}
-func (tTime) String() string { return "time" }
-func (tTime) Equivalent(other T) bool { return UnwrapType(other) == Time || other == Any }
-func (tTime) FamilyEqual(other T) bool { return UnwrapType(other) == Time }
-func (tTime) Oid() oid.Oid { return oid.T_time }
-func (tTime) SQLName() string { return "time" }
-func (tTime) IsAmbiguous() bool { return false }
+func (tTime) SemanticType() SemanticType { return TIME }
+func (tTime) String() string { return "time" }
+func (tTime) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), TIME) }
+func (tTime) Oid() oid.Oid { return oid.T_time }
+func (tTime) SQLName() string { return "time" }
+func (tTime) IsAmbiguous() bool { return false }
type tTimestamp struct{}
-func (tTimestamp) String() string { return "timestamp" }
-func (tTimestamp) Equivalent(other T) bool {
- return UnwrapType(other) == Timestamp || other == Any
-}
-
-func (tTimestamp) FamilyEqual(other T) bool { return UnwrapType(other) == Timestamp }
-func (tTimestamp) Oid() oid.Oid { return oid.T_timestamp }
-func (tTimestamp) SQLName() string { return "timestamp without time zone" }
-func (tTimestamp) IsAmbiguous() bool { return false }
+func (tTimestamp) SemanticType() SemanticType { return TIMESTAMP }
+func (tTimestamp) String() string { return "timestamp" }
+func (tTimestamp) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), TIMESTAMP) }
+func (tTimestamp) Oid() oid.Oid { return oid.T_timestamp }
+func (tTimestamp) SQLName() string { return "timestamp without time zone" }
+func (tTimestamp) IsAmbiguous() bool { return false }
type tTimestampTZ struct{}
-func (tTimestampTZ) String() string { return "timestamptz" }
-func (tTimestampTZ) Equivalent(other T) bool {
- return UnwrapType(other) == TimestampTZ || other == Any
-}
-
-func (tTimestampTZ) FamilyEqual(other T) bool { return UnwrapType(other) == TimestampTZ }
-func (tTimestampTZ) Oid() oid.Oid { return oid.T_timestamptz }
-func (tTimestampTZ) SQLName() string { return "timestamp with time zone" }
-func (tTimestampTZ) IsAmbiguous() bool { return false }
+func (tTimestampTZ) SemanticType() SemanticType { return TIMESTAMPTZ }
+func (tTimestampTZ) String() string { return "timestamptz" }
+func (tTimestampTZ) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), TIMESTAMPTZ) }
+func (tTimestampTZ) Oid() oid.Oid { return oid.T_timestamptz }
+func (tTimestampTZ) SQLName() string { return "timestamp with time zone" }
+func (tTimestampTZ) IsAmbiguous() bool { return false }
type tInterval struct{}
-func (tInterval) String() string { return "interval" }
-func (tInterval) Equivalent(other T) bool {
- return UnwrapType(other) == Interval || other == Any
-}
-
-func (tInterval) FamilyEqual(other T) bool { return UnwrapType(other) == Interval }
-func (tInterval) Oid() oid.Oid { return oid.T_interval }
-func (tInterval) SQLName() string { return "interval" }
-func (tInterval) IsAmbiguous() bool { return false }
+func (tInterval) SemanticType() SemanticType { return INTERVAL }
+func (tInterval) String() string { return "interval" }
+func (tInterval) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), INTERVAL) }
+func (tInterval) Oid() oid.Oid { return oid.T_interval }
+func (tInterval) SQLName() string { return "interval" }
+func (tInterval) IsAmbiguous() bool { return false }
type tJSON struct{}
-func (tJSON) String() string { return "jsonb" }
-func (tJSON) Equivalent(other T) bool {
- return UnwrapType(other) == JSON || other == Any
-}
-
-func (tJSON) FamilyEqual(other T) bool { return UnwrapType(other) == JSON }
-func (tJSON) Oid() oid.Oid { return oid.T_jsonb }
-func (tJSON) SQLName() string { return "json" }
-func (tJSON) IsAmbiguous() bool { return false }
+func (tJSON) SemanticType() SemanticType { return JSONB }
+func (tJSON) String() string { return "jsonb" }
+func (tJSON) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), JSONB) }
+func (tJSON) Oid() oid.Oid { return oid.T_jsonb }
+func (tJSON) SQLName() string { return "json" }
+func (tJSON) IsAmbiguous() bool { return false }
type tUUID struct{}
-func (tUUID) String() string { return "uuid" }
-func (tUUID) Equivalent(other T) bool { return UnwrapType(other) == Uuid || other == Any }
-func (tUUID) FamilyEqual(other T) bool { return UnwrapType(other) == Uuid }
-func (tUUID) Oid() oid.Oid { return oid.T_uuid }
-func (tUUID) SQLName() string { return "uuid" }
-func (tUUID) IsAmbiguous() bool { return false }
+func (tUUID) SemanticType() SemanticType { return UUID }
+func (tUUID) String() string { return "uuid" }
+func (tUUID) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), UUID) }
+func (tUUID) Oid() oid.Oid { return oid.T_uuid }
+func (tUUID) SQLName() string { return "uuid" }
+func (tUUID) IsAmbiguous() bool { return false }
type tINet struct{}
-func (tINet) String() string { return "inet" }
-func (tINet) Equivalent(other T) bool { return UnwrapType(other) == INet || other == Any }
-func (tINet) FamilyEqual(other T) bool { return UnwrapType(other) == INet }
-func (tINet) Oid() oid.Oid { return oid.T_inet }
-func (tINet) SQLName() string { return "inet" }
-func (tINet) IsAmbiguous() bool { return false }
+func (tINet) SemanticType() SemanticType { return INET }
+func (tINet) String() string { return "inet" }
+func (tINet) Equivalent(other T) bool { return isTypeOrAny(other.SemanticType(), INET) }
+func (tINet) Oid() oid.Oid { return oid.T_inet }
+func (tINet) SQLName() string { return "inet" }
+func (tINet) IsAmbiguous() bool { return false }
// TTuple is the type of a DTuple.
type TTuple struct {
@@ -331,6 +314,9 @@ type TTuple struct {
Labels []string
}
+// SemanticType returns the semantic type.
+func (TTuple) SemanticType() SemanticType { return TUPLE }
+
// String implements the fmt.Stringer interface.
func (t TTuple) String() string {
var buf bytes.Buffer
@@ -354,7 +340,7 @@ func (t TTuple) String() string {
// Equivalent implements the T interface.
func (t TTuple) Equivalent(other T) bool {
- if other == Any {
+ if other.SemanticType() == ANY {
return true
}
u, ok := UnwrapType(other).(TTuple)
@@ -378,12 +364,6 @@ func (t TTuple) Equivalent(other T) bool {
return true
}
-// FamilyEqual implements the T interface.
-func (TTuple) FamilyEqual(other T) bool {
- _, ok := UnwrapType(other).(TTuple)
- return ok
-}
-
// Oid implements the T interface.
func (TTuple) Oid() oid.Oid { return oid.T_record }
@@ -419,12 +399,15 @@ type TPlaceholder struct {
Idx PlaceholderIdx
}
+// SemanticType returns the semantic type.
+func (TPlaceholder) SemanticType() SemanticType { return ANY }
+
// String implements the fmt.Stringer interface.
func (t TPlaceholder) String() string { return fmt.Sprintf("placeholder{%d}", t.Idx+1) }
// Equivalent implements the T interface.
func (t TPlaceholder) Equivalent(other T) bool {
- if other == Any {
+ if other.SemanticType() == ANY {
return true
}
if other.IsAmbiguous() {
@@ -434,12 +417,6 @@ func (t TPlaceholder) Equivalent(other T) bool {
return ok && t.Idx == u.Idx
}
-// FamilyEqual implements the T interface.
-func (TPlaceholder) FamilyEqual(other T) bool {
- _, ok := UnwrapType(other).(TPlaceholder)
- return ok
-}
-
// Oid implements the T interface.
func (TPlaceholder) Oid() oid.Oid { panic("TPlaceholder.Oid() is undefined") }
@@ -452,6 +429,9 @@ func (TPlaceholder) IsAmbiguous() bool { panic("TPlaceholder.IsAmbiguous() is un
// TArray is the type of a DArray.
type TArray struct{ Typ T }
+// SemanticType returns the semantic type.
+func (TArray) SemanticType() SemanticType { return ARRAY }
+
func (a TArray) String() string {
if a.Typ == nil {
// Used in telemetry.
@@ -462,7 +442,7 @@ func (a TArray) String() string {
// Equivalent implements the T interface.
func (a TArray) Equivalent(other T) bool {
- if other == Any {
+ if other.SemanticType() == ANY {
return true
}
if u, ok := UnwrapType(other).(TArray); ok {
@@ -471,12 +451,6 @@ func (a TArray) Equivalent(other T) bool {
return false
}
-// FamilyEqual implements the T interface.
-func (TArray) FamilyEqual(other T) bool {
- _, ok := UnwrapType(other).(TArray)
- return ok
-}
-
const noArrayType = 0
// ArrayOids is a set of all oids which correspond to an array type.
@@ -508,18 +482,18 @@ func (a TArray) IsAmbiguous() bool {
type tAny struct{}
-func (tAny) String() string { return "anyelement" }
-func (tAny) Equivalent(other T) bool { return true }
-func (tAny) FamilyEqual(other T) bool { return other == Any }
-func (tAny) Oid() oid.Oid { return oid.T_anyelement }
-func (tAny) SQLName() string { return "anyelement" }
-func (tAny) IsAmbiguous() bool { return true }
+func (tAny) SemanticType() SemanticType { return ANY }
+func (tAny) String() string { return "anyelement" }
+func (tAny) Equivalent(other T) bool { return true }
+func (tAny) Oid() oid.Oid { return oid.T_anyelement }
+func (tAny) SQLName() string { return "anyelement" }
+func (tAny) IsAmbiguous() bool { return true }
// IsStringType returns true iff t is String
// or a collated string type.
func IsStringType(t T) bool {
- switch t.(type) {
- case tString, TCollatedString:
+ switch t.SemanticType() {
+ case STRING, COLLATEDSTRING:
return true
default:
return false
@@ -531,8 +505,8 @@ func IsStringType(t T) bool {
// If the valid return is false, the issue number should
// be included in the error report to inform the user.
func IsValidArrayElementType(t T) (valid bool, issueNum int) {
- switch t {
- case JSON:
+ switch t.SemanticType() {
+ case JSONB:
return false, 23468
default:
return true, 0
@@ -542,16 +516,16 @@ func IsValidArrayElementType(t T) (valid bool, issueNum int) {
// IsDateTimeType returns true if the T is
// date- or time-related type.
func IsDateTimeType(t T) bool {
- switch t {
- case Date:
+ switch t.SemanticType() {
+ case DATE:
return true
- case Time:
+ case TIME:
return true
- case Timestamp:
+ case TIMESTAMP:
return true
- case TimestampTZ:
+ case TIMESTAMPTZ:
return true
- case Interval:
+ case INTERVAL:
return true
default:
return false
@@ -561,12 +535,12 @@ func IsDateTimeType(t T) bool {
// IsAdditiveType returns true if the T
// supports addition and subtraction.
func IsAdditiveType(t T) bool {
- switch t {
- case Int:
+ switch t.SemanticType() {
+ case INT:
return true
- case Float:
+ case FLOAT:
return true
- case Decimal:
+ case DECIMAL:
return true
default:
return IsDateTimeType(t)
@@ -860,67 +834,6 @@ func (c *ColumnType) FloatProperties() (int32, int32) {
}
}
-// DatumTypeToColumnSemanticType converts a types.T to a SemanticType.
-//
-// This is mainly used by DatumTypeToColumnType() above; it is also
-// used to derive the semantic type of array elements and the
-// determination of DatumTypeHasCompositeKeyEncoding().
-func DatumTypeToColumnSemanticType(ptyp T) (SemanticType, error) {
- switch ptyp {
- case BitArray:
- return BIT, nil
- case Bool:
- return BOOL, nil
- case Int:
- return INT, nil
- case Float:
- return FLOAT, nil
- case Decimal:
- return DECIMAL, nil
- case Bytes:
- return BYTES, nil
- case String:
- return STRING, nil
- case Name:
- return NAME, nil
- case Date:
- return DATE, nil
- case Time:
- return TIME, nil
- case Timestamp:
- return TIMESTAMP, nil
- case TimestampTZ:
- return TIMESTAMPTZ, nil
- case Interval:
- return INTERVAL, nil
- case Uuid:
- return UUID, nil
- case INet:
- return INET, nil
- case Oid, RegClass, RegNamespace, RegProc, RegType, RegProcedure:
- return OID, nil
- case Unknown:
- return NULL, nil
- case IntVector:
- return INT2VECTOR, nil
- case OidVector:
- return OIDVECTOR, nil
- case JSON:
- return JSONB, nil
- default:
- if ptyp.FamilyEqual(FamCollatedString) {
- return COLLATEDSTRING, nil
- }
- if ptyp.FamilyEqual(FamTuple) {
- return TUPLE, nil
- }
- if wrapper, ok := ptyp.(TOidWrapper); ok {
- return DatumTypeToColumnSemanticType(wrapper.T)
- }
- return -1, pgerror.NewErrorf(pgerror.CodeFeatureNotSupportedError, "unsupported result type: %s, %T, %+v", ptyp, ptyp, ptyp)
- }
-}
-
// ColumnSemanticTypeToDatumType determines a types.T that can be used
// to instantiate an in-memory representation of values for the given
// column type.
@@ -957,7 +870,7 @@ func ColumnSemanticTypeToDatumType(c *ColumnType, k SemanticType) T {
case JSONB:
return JSON
case TUPLE:
- return FamTuple
+ return EmptyTuple
case COLLATEDSTRING:
if c.Locale == nil {
panic("locale is required for COLLATEDSTRING")
diff --git a/pkg/sql/sem/types/types.pb.go b/pkg/sql/sem/types/types.pb.go
index fad0cf9ff23f..b98fbbbf4ae4 100644
--- a/pkg/sql/sem/types/types.pb.go
+++ b/pkg/sql/sem/types/types.pb.go
@@ -48,6 +48,9 @@ const (
BIT SemanticType = 21
INT2VECTOR SemanticType = 200
OIDVECTOR SemanticType = 201
+ // Special type used during static analysis. This should never be present
+ // at execution time.
+ ANY SemanticType = 100
)
var SemanticType_name = map[int32]string{
@@ -74,6 +77,7 @@ var SemanticType_name = map[int32]string{
21: "BIT",
200: "INT2VECTOR",
201: "OIDVECTOR",
+ 100: "ANY",
}
var SemanticType_value = map[string]int32{
"BOOL": 0,
@@ -99,6 +103,7 @@ var SemanticType_value = map[string]int32{
"BIT": 21,
"INT2VECTOR": 200,
"OIDVECTOR": 201,
+ "ANY": 100,
}
func (x SemanticType) Enum() *SemanticType {
@@ -118,7 +123,7 @@ func (x *SemanticType) UnmarshalJSON(data []byte) error {
return nil
}
func (SemanticType) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_types_674d57d9ae00029c, []int{0}
+ return fileDescriptor_types_77fe5a0620518a56, []int{0}
}
type VisibleType int32
@@ -178,7 +183,7 @@ func (x *VisibleType) UnmarshalJSON(data []byte) error {
return nil
}
func (VisibleType) EnumDescriptor() ([]byte, []int) {
- return fileDescriptor_types_674d57d9ae00029c, []int{1}
+ return fileDescriptor_types_77fe5a0620518a56, []int{1}
}
type ColumnType struct {
@@ -210,7 +215,7 @@ func (m *ColumnType) Reset() { *m = ColumnType{} }
func (m *ColumnType) String() string { return proto.CompactTextString(m) }
func (*ColumnType) ProtoMessage() {}
func (*ColumnType) Descriptor() ([]byte, []int) {
- return fileDescriptor_types_674d57d9ae00029c, []int{0}
+ return fileDescriptor_types_77fe5a0620518a56, []int{0}
}
func (m *ColumnType) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -863,16 +868,16 @@ var (
ErrIntOverflowTypes = fmt.Errorf("proto: integer overflow")
)
-func init() { proto.RegisterFile("sql/sem/types/types.proto", fileDescriptor_types_674d57d9ae00029c) }
+func init() { proto.RegisterFile("sql/sem/types/types.proto", fileDescriptor_types_77fe5a0620518a56) }
-var fileDescriptor_types_674d57d9ae00029c = []byte{
- // 680 bytes of a gzipped FileDescriptorProto
- 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x94, 0x52, 0xcd, 0x72, 0xd2, 0x50,
- 0x14, 0x26, 0x90, 0x00, 0x39, 0xfc, 0x1d, 0x6f, 0xab, 0x22, 0x8b, 0x14, 0x51, 0x67, 0xb0, 0x0b,
- 0x3a, 0xd3, 0xa5, 0xbb, 0x84, 0x5c, 0x6b, 0x9c, 0x4b, 0x82, 0x97, 0x0b, 0x33, 0xed, 0xa6, 0x43,
- 0x69, 0xa6, 0x65, 0x0c, 0x84, 0x12, 0x5a, 0xa7, 0x6f, 0xe0, 0xd2, 0x47, 0x70, 0xa6, 0xae, 0x7d,
- 0x00, 0x9f, 0x00, 0x77, 0x2e, 0x5d, 0x39, 0x8a, 0x1b, 0x5f, 0xc1, 0x9d, 0x73, 0x03, 0x53, 0xd8,
- 0x74, 0xe1, 0x26, 0xf3, 0xdd, 0xef, 0x7c, 0xe7, 0xbb, 0xdf, 0x39, 0xb9, 0xf0, 0x28, 0xba, 0x08,
+var fileDescriptor_types_77fe5a0620518a56 = []byte{
+ // 686 bytes of a gzipped FileDescriptorProto
+ 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x94, 0x52, 0xcd, 0x6e, 0x12, 0x51,
+ 0x14, 0x66, 0x60, 0x06, 0x98, 0xc3, 0xdf, 0xf1, 0xb6, 0x2a, 0xb2, 0x98, 0x22, 0x6a, 0x82, 0x5d,
+ 0xd0, 0xa4, 0x4b, 0x77, 0x33, 0xcc, 0xb5, 0x8e, 0xb9, 0xcc, 0xe0, 0xe5, 0x42, 0xd2, 0x6e, 0x1a,
+ 0x4a, 0x27, 0x2d, 0x71, 0x60, 0x28, 0x43, 0x6b, 0xfa, 0x06, 0x2e, 0x7d, 0x04, 0x93, 0xfa, 0x0e,
+ 0x26, 0x3e, 0x01, 0xee, 0x5c, 0xba, 0x32, 0x8a, 0x1b, 0x5f, 0xc1, 0x9d, 0xb9, 0x03, 0x29, 0x6c,
+ 0xba, 0x70, 0x33, 0xf9, 0xee, 0x77, 0xbe, 0xf3, 0xdd, 0xf3, 0x9d, 0xb9, 0xf0, 0x28, 0xba, 0x08,
0xf6, 0x22, 0x7f, 0xb4, 0x37, 0xbb, 0x9e, 0xf8, 0xd1, 0xf2, 0xdb, 0x98, 0x4c, 0xc3, 0x59, 0x48,
0x1e, 0x0e, 0xc2, 0xc1, 0xdb, 0x69, 0xd8, 0x1f, 0x9c, 0x37, 0xa2, 0x8b, 0xa0, 0x11, 0xf9, 0xa3,
0x46, 0x5c, 0xae, 0x6c, 0x9f, 0x85, 0x67, 0x61, 0xac, 0xd9, 0x93, 0x68, 0x29, 0xaf, 0xfd, 0x4d,
@@ -884,30 +889,30 @@ var fileDescriptor_types_674d57d9ae00029c = []byte{
0xc0, 0xfe, 0x74, 0xda, 0xbf, 0x3e, 0x3e, 0x1d, 0x8e, 0xfc, 0xb1, 0xa4, 0xa2, 0xb2, 0x5a, 0x4d,
0xd5, 0x35, 0x5e, 0x8a, 0x79, 0xfb, 0x96, 0x26, 0x0f, 0x20, 0x1d, 0x84, 0x83, 0x7e, 0xe0, 0x97,
0xb5, 0xaa, 0x52, 0xd7, 0xf9, 0xea, 0x44, 0x5a, 0x90, 0xbf, 0x1a, 0x46, 0xc3, 0x93, 0xc0, 0x5f,
- 0xce, 0x94, 0x8e, 0x67, 0x7a, 0x7a, 0xe7, 0x4c, 0xbd, 0xa5, 0x78, 0x63, 0xa4, 0xdc, 0xd5, 0x9a,
- 0x22, 0x0c, 0x8a, 0xcb, 0x44, 0x83, 0x70, 0x3c, 0xf3, 0xc7, 0xb3, 0xa8, 0x9c, 0xf9, 0x8f, 0x25,
- 0xf1, 0x42, 0xdc, 0xdc, 0x5c, 0xf5, 0x92, 0x36, 0x14, 0x67, 0x97, 0x93, 0xc0, 0x5f, 0xbb, 0x65,
- 0xab, 0xa9, 0x7a, 0x6e, 0xff, 0xc9, 0x9d, 0x6e, 0xeb, 0xdf, 0xb5, 0x4a, 0x57, 0x88, 0x0d, 0x6e,
- 0x1d, 0x1f, 0x43, 0x7e, 0xe9, 0x18, 0xf4, 0x4f, 0xfc, 0x20, 0x2a, 0xeb, 0xd5, 0x54, 0x5d, 0xe7,
- 0xb9, 0x98, 0x63, 0x31, 0xf5, 0x42, 0xfd, 0xf3, 0x71, 0x47, 0xd9, 0xfd, 0x9c, 0x84, 0xfc, 0x66,
- 0x34, 0x92, 0x05, 0xd5, 0xf2, 0x3c, 0x86, 0x09, 0x92, 0x81, 0x94, 0xe3, 0x0a, 0x54, 0x88, 0x0e,
- 0xda, 0x4b, 0xe6, 0x99, 0x02, 0x93, 0x24, 0x07, 0x19, 0x9b, 0x36, 0x9d, 0x96, 0xc9, 0x30, 0x25,
- 0xa5, 0xb6, 0x29, 0x28, 0xaa, 0xa4, 0x00, 0xba, 0x70, 0x5a, 0xb4, 0x23, 0xcc, 0x56, 0x1b, 0x35,
- 0x92, 0x87, 0xac, 0xe3, 0x0a, 0xca, 0x7b, 0x26, 0xc3, 0x34, 0x01, 0x48, 0x77, 0x04, 0x77, 0xdc,
- 0x03, 0xcc, 0x48, 0x2b, 0xeb, 0x50, 0xd0, 0x0e, 0x66, 0x49, 0x09, 0x72, 0xb7, 0x3d, 0xe2, 0x08,
- 0x75, 0x42, 0xa0, 0xd8, 0xf4, 0x18, 0x33, 0x05, 0xb5, 0x57, 0x7a, 0x90, 0x57, 0xb8, 0x66, 0x8b,
- 0x62, 0x4e, 0xa6, 0xf1, 0x1c, 0x1b, 0xf3, 0x31, 0xd5, 0x65, 0x0c, 0x0b, 0x12, 0x75, 0xbb, 0x8e,
+ 0x66, 0x4a, 0xc7, 0x99, 0x9e, 0xde, 0x99, 0xa9, 0xb7, 0x14, 0x6f, 0x44, 0xca, 0x5d, 0xad, 0x29,
+ 0xc2, 0xa0, 0xb8, 0x9c, 0x68, 0x10, 0x8e, 0x67, 0xfe, 0x78, 0x16, 0x95, 0x33, 0xff, 0xb1, 0x24,
+ 0x5e, 0x88, 0x9b, 0x9b, 0xab, 0x5e, 0xd2, 0x86, 0xe2, 0xec, 0x72, 0x12, 0xf8, 0x6b, 0xb7, 0x6c,
+ 0x35, 0x55, 0xcf, 0xed, 0x3f, 0xb9, 0xd3, 0x6d, 0xfd, 0xbb, 0x56, 0xd3, 0x15, 0x62, 0x83, 0x5b,
+ 0xc7, 0xc7, 0x90, 0x5f, 0x3a, 0x06, 0xfd, 0x13, 0x3f, 0x88, 0xca, 0x7a, 0x35, 0x55, 0xd7, 0x79,
+ 0x2e, 0xe6, 0x58, 0x4c, 0xbd, 0x50, 0xff, 0x7c, 0xdc, 0x51, 0x76, 0x3f, 0x27, 0x21, 0xbf, 0x39,
+ 0x1a, 0xc9, 0x82, 0x6a, 0x79, 0x1e, 0xc3, 0x04, 0xc9, 0x40, 0xca, 0x71, 0x05, 0x2a, 0x44, 0x07,
+ 0xed, 0x25, 0xf3, 0x4c, 0x81, 0x49, 0x92, 0x83, 0x8c, 0x4d, 0x9b, 0x4e, 0xcb, 0x64, 0x98, 0x92,
+ 0x52, 0xdb, 0x14, 0x14, 0x55, 0x52, 0x00, 0x5d, 0x38, 0x2d, 0xda, 0x11, 0x66, 0xab, 0x8d, 0x1a,
+ 0xc9, 0x43, 0xd6, 0x71, 0x05, 0xe5, 0x3d, 0x93, 0x61, 0x9a, 0x00, 0xa4, 0x3b, 0x82, 0x3b, 0xee,
+ 0x01, 0x66, 0xa4, 0x95, 0x75, 0x28, 0x68, 0x07, 0xb3, 0xa4, 0x04, 0xb9, 0xdb, 0x1e, 0x71, 0x84,
+ 0x3a, 0x21, 0x50, 0x6c, 0x7a, 0x8c, 0x99, 0x82, 0xda, 0x2b, 0x3d, 0xc8, 0x2b, 0x5c, 0xb3, 0x45,
+ 0x31, 0x27, 0xa7, 0xf1, 0x1c, 0x1b, 0xf3, 0x31, 0xd5, 0x65, 0x0c, 0x0b, 0x12, 0x75, 0xbb, 0x8e,
0x8d, 0x45, 0x69, 0x6b, 0x72, 0x6e, 0x1e, 0x62, 0x49, 0x92, 0x8e, 0x4b, 0x05, 0xa2, 0x44, 0xf2,
0x02, 0xbc, 0x27, 0xcb, 0xaf, 0x3b, 0x9e, 0x6b, 0x21, 0x91, 0x50, 0x74, 0xdb, 0x8c, 0xe2, 0xb6,
0x74, 0xb4, 0x1c, 0x81, 0xf7, 0x49, 0x09, 0xc0, 0x71, 0xc5, 0x7e, 0x8f, 0x36, 0x85, 0xc7, 0x71,
- 0xae, 0x90, 0x22, 0xe8, 0x9e, 0x63, 0xaf, 0xce, 0x5f, 0x95, 0x8a, 0xfa, 0xfe, 0xc6, 0x48, 0xd4,
- 0xd4, 0xec, 0x16, 0x6e, 0xed, 0xde, 0x28, 0x90, 0xdb, 0x78, 0x1c, 0x71, 0x1c, 0xcf, 0xa5, 0x98,
- 0x90, 0xbb, 0x91, 0x53, 0x1f, 0x50, 0x8e, 0x8a, 0x5c, 0x41, 0xa7, 0x65, 0x32, 0x26, 0x37, 0x98,
- 0x94, 0x2b, 0xb0, 0x9c, 0x03, 0x89, 0xe3, 0xad, 0x71, 0x6a, 0x32, 0xd4, 0xc8, 0x36, 0xa0, 0xed,
- 0x75, 0x2d, 0x46, 0x8f, 0xdb, 0x9c, 0x36, 0x9d, 0x8e, 0xe3, 0xb9, 0x98, 0x96, 0x36, 0x3d, 0x93,
- 0x37, 0x5f, 0x99, 0x1c, 0x33, 0x52, 0x1c, 0xa3, 0xac, 0x0c, 0xfe, 0x26, 0x86, 0xba, 0x74, 0xeb,
- 0x99, 0x5c, 0x66, 0x87, 0x4a, 0xe9, 0xcb, 0x27, 0x63, 0x33, 0x4f, 0x4d, 0xcd, 0xaa, 0xa8, 0x5a,
- 0x3b, 0xf3, 0x5f, 0x46, 0x62, 0xbe, 0x30, 0x94, 0x6f, 0x0b, 0x43, 0xf9, 0xbe, 0x30, 0x94, 0x9f,
- 0x0b, 0x43, 0xf9, 0xf0, 0xdb, 0x48, 0x1c, 0x69, 0xf1, 0x03, 0xfa, 0x17, 0x00, 0x00, 0xff, 0xff,
- 0x4b, 0xdc, 0x34, 0xd0, 0x3e, 0x04, 0x00, 0x00,
+ 0xae, 0x90, 0x22, 0xe8, 0x9e, 0x63, 0xaf, 0xce, 0x5f, 0x15, 0xa9, 0x34, 0xdd, 0x43, 0x3c, 0xad,
+ 0xa8, 0xef, 0x6f, 0x8c, 0x44, 0x4d, 0xcd, 0x6e, 0xe1, 0xd6, 0xee, 0x8d, 0x02, 0xb9, 0x8d, 0x57,
+ 0x12, 0xcf, 0xe5, 0xb9, 0x14, 0x13, 0x72, 0x49, 0x32, 0xfe, 0x01, 0xe5, 0xa8, 0xc8, 0x5d, 0x74,
+ 0x5a, 0x26, 0x63, 0x72, 0x95, 0x49, 0xb9, 0x0b, 0xcb, 0x39, 0x90, 0x38, 0x5e, 0x1f, 0xa7, 0x26,
+ 0x43, 0x8d, 0x6c, 0x03, 0xda, 0x5e, 0xd7, 0x62, 0xf4, 0xb8, 0xcd, 0x69, 0xd3, 0xe9, 0x38, 0x9e,
+ 0x8b, 0x69, 0x69, 0xd3, 0x33, 0x79, 0xf3, 0x95, 0xc9, 0x31, 0x23, 0xc5, 0x31, 0xca, 0xca, 0x04,
+ 0x6f, 0x62, 0xa8, 0x4b, 0xb7, 0x9e, 0xc9, 0x65, 0x08, 0xa8, 0x94, 0xbe, 0x7c, 0x32, 0x36, 0xe7,
+ 0xa9, 0xa9, 0x59, 0x15, 0x55, 0x6b, 0x67, 0xfe, 0xcb, 0x48, 0xcc, 0x17, 0x86, 0xf2, 0x6d, 0x61,
+ 0x28, 0xdf, 0x17, 0x86, 0xf2, 0x73, 0x61, 0x28, 0x1f, 0x7e, 0x1b, 0x89, 0x23, 0x2d, 0x7e, 0x49,
+ 0xff, 0x02, 0x00, 0x00, 0xff, 0xff, 0x91, 0xa0, 0x4a, 0x34, 0x47, 0x04, 0x00, 0x00,
}
diff --git a/pkg/sql/sem/types/types.proto b/pkg/sql/sem/types/types.proto
index e8c37b207f34..6d849b51e652 100644
--- a/pkg/sql/sem/types/types.proto
+++ b/pkg/sql/sem/types/types.proto
@@ -150,6 +150,10 @@ enum SemanticType {
INT2VECTOR = 200;
OIDVECTOR = 201;
+
+ // Special type used during static analysis. This should never be present
+ // at execution time.
+ ANY = 100;
}
enum VisibleType {
diff --git a/pkg/sql/set_zone_config.go b/pkg/sql/set_zone_config.go
index 5b602b8cf14e..bf3d951b5451 100644
--- a/pkg/sql/set_zone_config.go
+++ b/pkg/sql/set_zone_config.go
@@ -110,11 +110,11 @@ func (p *planner) SetZoneConfig(ctx context.Context, n *tree.SetZoneConfig) (pla
return nil, err
}
- switch typ := yamlConfig.ResolvedType(); typ {
- case types.Unknown:
+ switch typ := yamlConfig.ResolvedType(); typ.SemanticType() {
+ case types.NULL:
// Unknown occurs if the user entered a literal NULL. That's OK and will mean deletion.
- case types.String:
- case types.Bytes:
+ case types.STRING:
+ case types.BYTES:
default:
return nil, pgerror.NewErrorf(pgerror.CodeInvalidParameterValueError,
"zone config must be of type string or bytes, not %s", typ)
diff --git a/pkg/sql/sort.go b/pkg/sql/sort.go
index 534ef66123ea..cda636204088 100644
--- a/pkg/sql/sort.go
+++ b/pkg/sql/sort.go
@@ -227,10 +227,10 @@ func (n *sortNode) Close(ctx context.Context) {
}
func ensureColumnOrderable(c sqlbase.ResultColumn) error {
- if _, ok := c.Typ.(types.TArray); ok {
+ if c.Typ.SemanticType() == types.ARRAY {
return pgerror.UnimplementedWithIssueErrorf(32707, "can't order by column type %s", c.Typ)
}
- if c.Typ == types.JSON {
+ if c.Typ.SemanticType() == types.JSONB {
return pgerror.UnimplementedWithIssueError(32706, "can't order by column type JSONB")
}
return nil
diff --git a/pkg/sql/sqlbase/column_type_encoding.go b/pkg/sql/sqlbase/column_type_encoding.go
index 0f9ee00cb056..730cb72013a6 100644
--- a/pkg/sql/sqlbase/column_type_encoding.go
+++ b/pkg/sql/sqlbase/column_type_encoding.go
@@ -180,8 +180,8 @@ func DecodeTableKey(
}
var rkey []byte
var err error
- switch valType {
- case types.BitArray:
+ switch valType.SemanticType() {
+ case types.BIT:
var r bitarray.BitArray
if dir == encoding.Ascending {
rkey, r, err = encoding.DecodeBitArrayAscending(key)
@@ -189,7 +189,7 @@ func DecodeTableKey(
rkey, r, err = encoding.DecodeBitArrayDescending(key)
}
return a.NewDBitArray(tree.DBitArray{BitArray: r}), rkey, err
- case types.Bool:
+ case types.BOOL:
var i int64
if dir == encoding.Ascending {
rkey, i, err = encoding.DecodeVarintAscending(key)
@@ -199,7 +199,7 @@ func DecodeTableKey(
// No need to chunk allocate DBool as MakeDBool returns either
// tree.DBoolTrue or tree.DBoolFalse.
return tree.MakeDBool(tree.DBool(i != 0)), rkey, err
- case types.Int:
+ case types.INT:
var i int64
if dir == encoding.Ascending {
rkey, i, err = encoding.DecodeVarintAscending(key)
@@ -207,7 +207,7 @@ func DecodeTableKey(
rkey, i, err = encoding.DecodeVarintDescending(key)
}
return a.NewDInt(tree.DInt(i)), rkey, err
- case types.Float:
+ case types.FLOAT:
var f float64
if dir == encoding.Ascending {
rkey, f, err = encoding.DecodeFloatAscending(key)
@@ -215,7 +215,7 @@ func DecodeTableKey(
rkey, f, err = encoding.DecodeFloatDescending(key)
}
return a.NewDFloat(tree.DFloat(f)), rkey, err
- case types.Decimal:
+ case types.DECIMAL:
var d apd.Decimal
if dir == encoding.Ascending {
rkey, d, err = encoding.DecodeDecimalAscending(key, nil)
@@ -224,7 +224,7 @@ func DecodeTableKey(
}
dd := a.NewDDecimal(tree.DDecimal{Decimal: d})
return dd, rkey, err
- case types.String:
+ case types.STRING:
var r string
if dir == encoding.Ascending {
rkey, r, err = encoding.DecodeUnsafeStringAscending(key, nil)
@@ -232,7 +232,15 @@ func DecodeTableKey(
rkey, r, err = encoding.DecodeUnsafeStringDescending(key, nil)
}
return a.NewDString(tree.DString(r)), rkey, err
- case types.Name:
+ case types.COLLATEDSTRING:
+ var r string
+ rkey, r, err = encoding.DecodeUnsafeStringAscending(key, nil)
+ if err != nil {
+ return nil, nil, err
+ }
+ t := valType.(types.TCollatedString)
+ return tree.NewDCollatedString(r, t.Locale, &a.env), rkey, err
+ case types.NAME:
var r string
if dir == encoding.Ascending {
rkey, r, err = encoding.DecodeUnsafeStringAscending(key, nil)
@@ -240,9 +248,9 @@ func DecodeTableKey(
rkey, r, err = encoding.DecodeUnsafeStringDescending(key, nil)
}
return a.NewDName(tree.DString(r)), rkey, err
- case types.JSON:
+ case types.JSONB:
return tree.DNull, []byte{}, nil
- case types.Bytes:
+ case types.BYTES:
var r []byte
if dir == encoding.Ascending {
rkey, r, err = encoding.DecodeBytesAscending(key, nil)
@@ -250,7 +258,7 @@ func DecodeTableKey(
rkey, r, err = encoding.DecodeBytesDescending(key, nil)
}
return a.NewDBytes(tree.DBytes(r)), rkey, err
- case types.Date:
+ case types.DATE:
var t int64
if dir == encoding.Ascending {
rkey, t, err = encoding.DecodeVarintAscending(key)
@@ -258,7 +266,7 @@ func DecodeTableKey(
rkey, t, err = encoding.DecodeVarintDescending(key)
}
return a.NewDDate(tree.DDate(t)), rkey, err
- case types.Time:
+ case types.TIME:
var t int64
if dir == encoding.Ascending {
rkey, t, err = encoding.DecodeVarintAscending(key)
@@ -266,7 +274,7 @@ func DecodeTableKey(
rkey, t, err = encoding.DecodeVarintDescending(key)
}
return a.NewDTime(tree.DTime(t)), rkey, err
- case types.Timestamp:
+ case types.TIMESTAMP:
var t time.Time
if dir == encoding.Ascending {
rkey, t, err = encoding.DecodeTimeAscending(key)
@@ -274,7 +282,7 @@ func DecodeTableKey(
rkey, t, err = encoding.DecodeTimeDescending(key)
}
return a.NewDTimestamp(tree.DTimestamp{Time: t}), rkey, err
- case types.TimestampTZ:
+ case types.TIMESTAMPTZ:
var t time.Time
if dir == encoding.Ascending {
rkey, t, err = encoding.DecodeTimeAscending(key)
@@ -282,7 +290,7 @@ func DecodeTableKey(
rkey, t, err = encoding.DecodeTimeDescending(key)
}
return a.NewDTimestampTZ(tree.DTimestampTZ{Time: t}), rkey, err
- case types.Interval:
+ case types.INTERVAL:
var d duration.Duration
if dir == encoding.Ascending {
rkey, d, err = encoding.DecodeDurationAscending(key)
@@ -290,7 +298,7 @@ func DecodeTableKey(
rkey, d, err = encoding.DecodeDurationDescending(key)
}
return a.NewDInterval(tree.DInterval{Duration: d}), rkey, err
- case types.Uuid:
+ case types.UUID:
var r []byte
if dir == encoding.Ascending {
rkey, r, err = encoding.DecodeBytesAscending(key, nil)
@@ -302,7 +310,7 @@ func DecodeTableKey(
}
u, err := uuid.FromBytes(r)
return a.NewDUuid(tree.DUuid{UUID: u}), rkey, err
- case types.INet:
+ case types.INET:
var r []byte
if dir == encoding.Ascending {
rkey, r, err = encoding.DecodeBytesAscending(key, nil)
@@ -315,7 +323,7 @@ func DecodeTableKey(
var ipAddr ipaddr.IPAddr
_, err := ipAddr.FromBuffer(r)
return a.NewDIPAddr(tree.DIPAddr{IPAddr: ipAddr}), rkey, err
- case types.Oid:
+ case types.OID:
var i int64
if dir == encoding.Ascending {
rkey, i, err = encoding.DecodeVarintAscending(key)
@@ -324,15 +332,6 @@ func DecodeTableKey(
}
return a.NewDOid(tree.MakeDOid(tree.DInt(i))), rkey, err
default:
- switch t := valType.(type) {
- case types.TCollatedString:
- var r string
- rkey, r, err = encoding.DecodeUnsafeStringAscending(key, nil)
- if err != nil {
- return nil, nil, err
- }
- return tree.NewDCollatedString(r, t.Locale, &a.env), rkey, err
- }
return nil, nil, errors.Errorf("TODO(pmattis): decoded index key: %s", valType)
}
}
@@ -416,7 +415,7 @@ func DecodeTableValue(a *DatumAlloc, valType types.T, b []byte) (tree.Datum, []b
return tree.DNull, b[dataOffset:], nil
}
// Bool is special because the value is stored in the value tag.
- if valType != types.Bool {
+ if valType.SemanticType() != types.BOOL {
b = b[dataOffset:]
}
return decodeUntaggedDatum(a, valType, b)
@@ -431,23 +430,41 @@ func DecodeTableValue(a *DatumAlloc, valType types.T, b []byte) (tree.Datum, []b
// If t is types.Bool, the value tag must be present, as its value is encoded in
// the tag directly.
func decodeUntaggedDatum(a *DatumAlloc, t types.T, buf []byte) (tree.Datum, []byte, error) {
- switch t {
- case types.Int:
+ // Check for OID wrapper first, since SemanticType ignores it.
+ switch typ := t.(type) {
+ case types.TOidWrapper:
+ wrapped := typ.T
+ d, rest, err := decodeUntaggedDatum(a, wrapped, buf)
+ if err != nil {
+ return d, rest, err
+ }
+ return &tree.DOidWrapper{
+ Wrapped: d,
+ Oid: typ.Oid(),
+ }, rest, nil
+ }
+
+ switch t.SemanticType() {
+ case types.INT:
b, i, err := encoding.DecodeUntaggedIntValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDInt(tree.DInt(i)), b, nil
- case types.String, types.Name:
+ case types.STRING, types.NAME:
b, data, err := encoding.DecodeUntaggedBytesValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDString(tree.DString(data)), b, nil
- case types.BitArray:
+ case types.COLLATEDSTRING:
+ typ := t.(types.TCollatedString)
+ b, data, err := encoding.DecodeUntaggedBytesValue(buf)
+ return tree.NewDCollatedString(string(data), typ.Locale, &a.env), b, err
+ case types.BIT:
b, data, err := encoding.DecodeUntaggedBitArrayValue(buf)
return a.NewDBitArray(tree.DBitArray{BitArray: data}), b, err
- case types.Bool:
+ case types.BOOL:
// A boolean's value is encoded in its tag directly, so we don't have an
// "Untagged" version of this function.
b, data, err := encoding.DecodeBoolValue(buf)
@@ -455,58 +472,58 @@ func decodeUntaggedDatum(a *DatumAlloc, t types.T, buf []byte) (tree.Datum, []by
return nil, b, err
}
return tree.MakeDBool(tree.DBool(data)), b, nil
- case types.Float:
+ case types.FLOAT:
b, data, err := encoding.DecodeUntaggedFloatValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDFloat(tree.DFloat(data)), b, nil
- case types.Decimal:
+ case types.DECIMAL:
b, data, err := encoding.DecodeUntaggedDecimalValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDDecimal(tree.DDecimal{Decimal: data}), b, nil
- case types.Bytes:
+ case types.BYTES:
b, data, err := encoding.DecodeUntaggedBytesValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDBytes(tree.DBytes(data)), b, nil
- case types.Date:
+ case types.DATE:
b, data, err := encoding.DecodeUntaggedIntValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDDate(tree.DDate(data)), b, nil
- case types.Time:
+ case types.TIME:
b, data, err := encoding.DecodeUntaggedIntValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDTime(tree.DTime(data)), b, nil
- case types.Timestamp:
+ case types.TIMESTAMP:
b, data, err := encoding.DecodeUntaggedTimeValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDTimestamp(tree.DTimestamp{Time: data}), b, nil
- case types.TimestampTZ:
+ case types.TIMESTAMPTZ:
b, data, err := encoding.DecodeUntaggedTimeValue(buf)
if err != nil {
return nil, b, err
}
return a.NewDTimestampTZ(tree.DTimestampTZ{Time: data}), b, nil
- case types.Interval:
+ case types.INTERVAL:
b, data, err := encoding.DecodeUntaggedDurationValue(buf)
return a.NewDInterval(tree.DInterval{Duration: data}), b, err
- case types.Uuid:
+ case types.UUID:
b, data, err := encoding.DecodeUntaggedUUIDValue(buf)
return a.NewDUuid(tree.DUuid{UUID: data}), b, err
- case types.INet:
+ case types.INET:
b, data, err := encoding.DecodeUntaggedIPAddrValue(buf)
return a.NewDIPAddr(tree.DIPAddr{IPAddr: data}), b, err
- case types.JSON:
+ case types.JSONB:
b, data, err := encoding.DecodeUntaggedBytesValue(buf)
if err != nil {
return nil, b, err
@@ -516,29 +533,16 @@ func decodeUntaggedDatum(a *DatumAlloc, t types.T, buf []byte) (tree.Datum, []by
return nil, b, err
}
return a.NewDJSON(tree.DJSON{JSON: j}), b, nil
- case types.Oid:
+ case types.OID:
b, data, err := encoding.DecodeUntaggedIntValue(buf)
return a.NewDOid(tree.MakeDOid(tree.DInt(data))), b, err
+ case types.ARRAY:
+ typ := t.(types.TArray)
+ return decodeArray(a, typ.Typ, buf)
+ case types.TUPLE:
+ typ := t.(types.TTuple)
+ return decodeTuple(a, typ, buf)
default:
- switch typ := t.(type) {
- case types.TOidWrapper:
- wrapped := typ.T
- d, rest, err := decodeUntaggedDatum(a, wrapped, buf)
- if err != nil {
- return d, rest, err
- }
- return &tree.DOidWrapper{
- Wrapped: d,
- Oid: typ.Oid(),
- }, rest, nil
- case types.TCollatedString:
- b, data, err := encoding.DecodeUntaggedBytesValue(buf)
- return tree.NewDCollatedString(string(data), typ.Locale, &a.env), b, err
- case types.TArray:
- return decodeArray(a, typ.Typ, buf)
- case types.TTuple:
- return decodeTuple(a, typ, buf)
- }
return nil, buf, errors.Errorf("couldn't decode type %s", t)
}
}
@@ -1074,48 +1078,41 @@ func decodeArrayHeader(b []byte) (arrayHeader, []byte, error) {
// place in the array header given a datum type. The element encoding
// type is then used to encode/decode array elements.
func datumTypeToArrayElementEncodingType(t types.T) (encoding.Type, error) {
- switch t {
- case types.Int:
+ switch t.SemanticType() {
+ case types.INT:
return encoding.Int, nil
- case types.Oid:
+ case types.OID:
return encoding.Int, nil
- case types.Float:
+ case types.FLOAT:
return encoding.Float, nil
- case types.Decimal:
+ case types.DECIMAL:
return encoding.Decimal, nil
- case types.Bytes, types.String, types.Name:
+ case types.BYTES, types.STRING, types.COLLATEDSTRING, types.NAME:
return encoding.Bytes, nil
- case types.Timestamp, types.TimestampTZ:
+ case types.TIMESTAMP, types.TIMESTAMPTZ:
return encoding.Time, nil
// Note: types.Date was incorrectly mapped to encoding.Time when arrays were
// first introduced. If any 1.1 users used date arrays, they would have been
// persisted with incorrect elementType values.
- case types.Date, types.Time:
+ case types.DATE, types.TIME:
return encoding.Int, nil
- case types.Interval:
+ case types.INTERVAL:
return encoding.Duration, nil
- case types.Bool:
+ case types.BOOL:
return encoding.True, nil
- case types.BitArray:
+ case types.BIT:
return encoding.BitArray, nil
- case types.Uuid:
+ case types.UUID:
return encoding.UUID, nil
- case types.INet:
+ case types.INET:
return encoding.IPAddr, nil
default:
- if t.FamilyEqual(types.FamCollatedString) {
- return encoding.Bytes, nil
- }
return 0, errors.Errorf("Don't know encoding type for %s", t)
}
}
func checkElementType(paramType types.T, columnType types.ColumnType) error {
- semanticType, err := types.DatumTypeToColumnSemanticType(paramType)
- if err != nil {
- return err
- }
- if semanticType != *columnType.ArrayContents {
+ if paramType.SemanticType() != *columnType.ArrayContents {
return errors.Errorf("type of array contents %s doesn't match column type %s",
paramType, columnType.ArrayContents)
}
diff --git a/pkg/sql/sqlbase/column_type_properties.go b/pkg/sql/sqlbase/column_type_properties.go
index e67cffccd251..a4c601c672eb 100644
--- a/pkg/sql/sqlbase/column_type_properties.go
+++ b/pkg/sql/sqlbase/column_type_properties.go
@@ -24,6 +24,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
"github.com/cockroachdb/cockroach/pkg/sql/sem/types"
+ "github.com/lib/pq/oid"
"github.com/pkg/errors"
)
@@ -72,12 +73,9 @@ func DatumTypeToColumnType(ptyp types.T) (types.ColumnType, error) {
ctyp.Locale = &t.Locale
case types.TArray:
ctyp.SemanticType = types.ARRAY
- contents, err := types.DatumTypeToColumnSemanticType(t.Typ)
- if err != nil {
- return types.ColumnType{}, err
- }
+ contents := t.Typ.SemanticType()
ctyp.ArrayContents = &contents
- if t.Typ.FamilyEqual(types.FamCollatedString) {
+ if t.Typ.SemanticType() == types.COLLATEDSTRING {
cs := t.Typ.(types.TCollatedString)
ctyp.Locale = &cs.Locale
}
@@ -93,12 +91,19 @@ func DatumTypeToColumnType(ptyp types.T) (types.ColumnType, error) {
}
ctyp.TupleLabels = t.Labels
return ctyp, nil
- default:
- semanticType, err := types.DatumTypeToColumnSemanticType(ptyp)
- if err != nil {
- return types.ColumnType{}, err
+ case types.TOidWrapper:
+ switch t.Oid() {
+ case oid.T_name:
+ ctyp.SemanticType = types.NAME
+ case oid.T_oidvector:
+ ctyp.SemanticType = types.OIDVECTOR
+ case oid.T_int2vector:
+ ctyp.SemanticType = types.INT2VECTOR
+ default:
+ ctyp.SemanticType = ptyp.SemanticType()
}
- ctyp.SemanticType = semanticType
+ default:
+ ctyp.SemanticType = ptyp.SemanticType()
}
return ctyp, nil
}
@@ -176,7 +181,12 @@ func PopulateTypeAttrs(base types.ColumnType, typ coltypes.T) (types.ColumnType,
case *coltypes.TVector:
switch t.ParamType.(type) {
- case *coltypes.TInt, *coltypes.TOid:
+ case *coltypes.TInt:
+ contents := types.INT
+ base.ArrayContents = &contents
+ case *coltypes.TOid:
+ contents := types.OID
+ base.ArrayContents = &contents
default:
return types.ColumnType{}, errors.Errorf("vectors of type %s are unsupported", t.ParamType)
}
@@ -336,7 +346,7 @@ func LimitValueWidth(
func CheckDatumTypeFitsColumnType(
col ColumnDescriptor, typ types.T, pmap *tree.PlaceholderInfo,
) error {
- if typ == types.Unknown {
+ if typ.SemanticType() == types.NULL {
return nil
}
// If the value is a placeholder, then the column check above has
diff --git a/pkg/sql/sqlbase/encoded_datum_test.go b/pkg/sql/sqlbase/encoded_datum_test.go
index 5ad7bc0aa26a..4d74d7273a89 100644
--- a/pkg/sql/sqlbase/encoded_datum_test.go
+++ b/pkg/sql/sqlbase/encoded_datum_test.go
@@ -217,7 +217,7 @@ func TestEncDatumCompare(t *testing.T) {
kind := types.SemanticType(kind)
if kind == types.NULL || kind == types.ARRAY ||
kind == types.INT2VECTOR || kind == types.OIDVECTOR ||
- kind == types.JSONB || kind == types.TUPLE {
+ kind == types.JSONB || kind == types.TUPLE || kind == types.ANY {
continue
}
typ := types.ColumnType{SemanticType: kind}
diff --git a/pkg/sql/sqlbase/result_columns.go b/pkg/sql/sqlbase/result_columns.go
index 7ca962123e96..51e8b6ba633c 100644
--- a/pkg/sql/sqlbase/result_columns.go
+++ b/pkg/sql/sqlbase/result_columns.go
@@ -62,7 +62,7 @@ func (r ResultColumns) TypesEqual(other ResultColumns) bool {
// NULLs are considered equal because some types of queries (SELECT CASE,
// for example) can change their output types between a type and NULL based
// on input.
- if other[i].Typ == types.Unknown {
+ if other[i].Typ.SemanticType() == types.NULL {
continue
}
if !c.Typ.Equivalent(other[i].Typ) {
diff --git a/pkg/sql/sqlbase/structured.go b/pkg/sql/sqlbase/structured.go
index 54acae6e40b1..ed94368d03e6 100644
--- a/pkg/sql/sqlbase/structured.go
+++ b/pkg/sql/sqlbase/structured.go
@@ -810,8 +810,7 @@ func HasCompositeKeyEncoding(semanticType types.SemanticType) bool {
// DatumTypeHasCompositeKeyEncoding is a version of HasCompositeKeyEncoding
// which works on datum types.
func DatumTypeHasCompositeKeyEncoding(typ types.T) bool {
- colType, err := types.DatumTypeToColumnSemanticType(typ)
- return err == nil && HasCompositeKeyEncoding(colType)
+ return HasCompositeKeyEncoding(typ.SemanticType())
}
// MustBeValueEncoded returns true if columns of the given kind can only be value
diff --git a/pkg/sql/sqlbase/structured_test.go b/pkg/sql/sqlbase/structured_test.go
index 6a4c01d70819..31e70ff6cfa8 100644
--- a/pkg/sql/sqlbase/structured_test.go
+++ b/pkg/sql/sqlbase/structured_test.go
@@ -1316,14 +1316,3 @@ func TestKeysPerRow(t *testing.T) {
})
}
}
-
-func TestDatumTypeToColumnSemanticType(t *testing.T) {
- defer leaktest.AfterTest(t)()
-
- for _, typ := range types.AnyNonArray {
- _, err := types.DatumTypeToColumnSemanticType(typ)
- if err != nil {
- t.Errorf("couldn't get semantic type: %s", err)
- }
- }
-}
diff --git a/pkg/sql/sqlbase/testutils.go b/pkg/sql/sqlbase/testutils.go
index ea7fad0b4fae..fafab88b541a 100644
--- a/pkg/sql/sqlbase/testutils.go
+++ b/pkg/sql/sqlbase/testutils.go
@@ -195,7 +195,7 @@ func RandDatumWithNullChance(rng *rand.Rand, typ types.ColumnType, nullChance in
case types.NULL:
return tree.DNull
case types.ARRAY:
- if typ.ArrayContents == nil {
+ if typ.ArrayContents == nil || *typ.ArrayContents == types.ANY {
var contentsTyp = RandArrayContentsColumnType(rng)
typ.ArrayContents = &contentsTyp.SemanticType
typ.Locale = contentsTyp.Locale
@@ -228,18 +228,17 @@ var (
func init() {
for k := range types.SemanticType_name {
- columnSemanticTypes = append(columnSemanticTypes, types.SemanticType(k))
+ // Don't add ANY, as it's not allowed at execution time.
+ if typ := types.SemanticType(k); typ != types.ANY {
+ columnSemanticTypes = append(columnSemanticTypes, typ)
+ }
}
for _, t := range types.AnyNonArray {
encTyp, err := datumTypeToArrayElementEncodingType(t)
if err != nil || encTyp == 0 {
continue
}
- semTyp, err := types.DatumTypeToColumnSemanticType(t)
- if err != nil {
- continue
- }
- arrayElemSemanticTypes = append(arrayElemSemanticTypes, semTyp)
+ arrayElemSemanticTypes = append(arrayElemSemanticTypes, t.SemanticType())
}
}
@@ -437,11 +436,6 @@ func TestingMakePrimaryIndexKey(desc *TableDescriptor, vals ...interface{}) (roa
return roachpb.Key(key), nil
}
-// TestingDatumTypeToColumnSemanticType is used in pgwire tests.
-func TestingDatumTypeToColumnSemanticType(ptyp types.T) (types.SemanticType, error) {
- return types.DatumTypeToColumnSemanticType(ptyp)
-}
-
// RandCreateTable creates a random CreateTable definition.
func RandCreateTable(rng *rand.Rand, tableIdx int) *tree.CreateTable {
// columnDefs contains the list of Columns we'll add to our table.
@@ -586,8 +580,8 @@ func randIndexTableDefFromCols(
indexElemList := make(tree.IndexElemList, 0, len(cols))
for i := range cols {
- semType, err := TestingDatumTypeToColumnSemanticType(coltypes.CastTargetToDatumType(cols[i].Type))
- if err != nil || MustBeValueEncoded(semType) {
+ semType := coltypes.CastTargetToDatumType(cols[i].Type).SemanticType()
+ if MustBeValueEncoded(semType) {
continue
}
indexElemList = append(indexElemList, tree.IndexElem{
diff --git a/pkg/sql/stats/json.go b/pkg/sql/stats/json.go
index 3bcaf428bd7d..355f74f620d4 100644
--- a/pkg/sql/stats/json.go
+++ b/pkg/sql/stats/json.go
@@ -86,7 +86,7 @@ func (js *JSONStatistic) DecodeAndSetHistogram(datum tree.Datum) error {
if datum == tree.DNull {
return nil
}
- if datum.ResolvedType() != types.Bytes {
+ if datum.ResolvedType().SemanticType() != types.BYTES {
return fmt.Errorf("histogram datum type should be Bytes")
}
h := &HistogramData{}
diff --git a/pkg/sql/stats/stats_cache.go b/pkg/sql/stats/stats_cache.go
index a9f2c71d16f3..69a98ce81188 100644
--- a/pkg/sql/stats/stats_cache.go
+++ b/pkg/sql/stats/stats_cache.go
@@ -300,7 +300,7 @@ func parseStats(datums tree.Datums) (*TableStatistic, error) {
}
for _, v := range expectedTypes {
if datums[v.fieldIndex].ResolvedType() != v.expectedType &&
- (!v.nullable || datums[v.fieldIndex].ResolvedType() != types.Unknown) {
+ (!v.nullable || datums[v.fieldIndex].ResolvedType().SemanticType() != types.NULL) {
return nil, errors.Errorf("%s returned from table statistics lookup has type %s. Expected %s",
v.fieldName, datums[v.fieldIndex].ResolvedType(), v.expectedType)
}
diff --git a/pkg/sql/union.go b/pkg/sql/union.go
index 2e286d120fd0..e70a5c21bd25 100644
--- a/pkg/sql/union.go
+++ b/pkg/sql/union.go
@@ -129,14 +129,14 @@ func (p *planner) newUnionNode(
// TODO(dan): This currently checks whether the types are exactly the same,
// but Postgres is more lenient:
// http://www.postgresql.org/docs/9.5/static/typeconv-union-case.html.
- if !(l.Typ.Equivalent(r.Typ) || l.Typ == types.Unknown || r.Typ == types.Unknown) {
+ if !(l.Typ.Equivalent(r.Typ) || l.Typ.SemanticType() == types.NULL || r.Typ.SemanticType() == types.NULL) {
return nil, pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"%v types %s and %s cannot be matched", typ, l.Typ, r.Typ)
}
if l.Hidden != r.Hidden {
return nil, fmt.Errorf("%v types cannot be matched", typ)
}
- if l.Typ == types.Unknown {
+ if l.Typ.SemanticType() == types.NULL {
unionColumns[i].Typ = r.Typ
}
}
diff --git a/pkg/sql/values.go b/pkg/sql/values.go
index c302343e297a..a42c2bc1b1e8 100644
--- a/pkg/sql/values.go
+++ b/pkg/sql/values.go
@@ -109,9 +109,9 @@ func (p *planner) Values(
typ := typedExpr.ResolvedType()
if num == 0 {
v.columns = append(v.columns, sqlbase.ResultColumn{Name: "column" + strconv.Itoa(i+1), Typ: typ})
- } else if v.columns[i].Typ == types.Unknown {
+ } else if v.columns[i].Typ.SemanticType() == types.NULL {
v.columns[i].Typ = typ
- } else if typ != types.Unknown && !typ.Equivalent(v.columns[i].Typ) {
+ } else if typ.SemanticType() != types.NULL && !typ.Equivalent(v.columns[i].Typ) {
return nil, pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"VALUES types %s and %s cannot be matched", typ, v.columns[i].Typ)
}
diff --git a/pkg/sql/window.go b/pkg/sql/window.go
index febdd0f3c970..b41b5f15c8bf 100644
--- a/pkg/sql/window.go
+++ b/pkg/sql/window.go
@@ -283,7 +283,7 @@ func (p *planner) constructWindowDefinitions(
if err != nil {
return err
}
- if renderExpr.ResolvedType() != types.Bool {
+ if renderExpr.ResolvedType().SemanticType() != types.BOOL {
return pgerror.NewErrorf(pgerror.CodeDatatypeMismatchError,
"argument of FILTER must be type boolean, not type %s", renderExpr.ResolvedType(),
)
|
410ef29941f29dac1ccb8a81124a2dab579d7b7d
|
2022-01-10 09:37:57
|
Nathan VanBenschoten
|
kv: protect Replica's lastToReplica and lastFromReplica fields with raftMu
| false
|
protect Replica's lastToReplica and lastFromReplica fields with raftMu
|
kv
|
diff --git a/pkg/kv/kvserver/replica.go b/pkg/kv/kvserver/replica.go
index 141a838aff6c..aac0bed70040 100644
--- a/pkg/kv/kvserver/replica.go
+++ b/pkg/kv/kvserver/replica.go
@@ -279,6 +279,47 @@ type Replica struct {
stateMachine replicaStateMachine
// decoder is used to decode committed raft entries.
decoder replicaDecoder
+
+ // The last seen replica descriptors from incoming Raft messages. These are
+ // stored so that the replica still knows the replica descriptors for itself
+ // and for its message recipients in the circumstances when its RangeDescriptor
+ // is out of date.
+ //
+ // Normally, a replica knows about the other replica descriptors for a
+ // range via the RangeDescriptor stored in Replica.mu.state.Desc. But that
+ // descriptor is only updated during a Split or ChangeReplicas operation.
+ // There are periods during a Replica's lifetime when that information is
+ // out of date:
+ //
+ // 1. When a replica is being newly created as the result of an incoming
+ // Raft message for it. This is the common case for ChangeReplicas and an
+ // uncommon case for Splits. The leader will be sending the replica
+ // messages and the replica needs to be able to respond before it can
+ // receive an updated range descriptor (via a snapshot,
+ // changeReplicasTrigger, or splitTrigger).
+ //
+ // 2. If the node containing a replica is partitioned or down while the
+ // replicas for the range are updated. When the node comes back up, other
+ // replicas may begin communicating with it and it needs to be able to
+ // respond. Unlike 1 where there is no range descriptor, in this situation
+ // the replica has a range descriptor but it is out of date. Note that a
+ // replica being removed from a node and then quickly re-added before the
+ // replica has been GC'd will also use the last seen descriptors. In
+ // effect, this is another path for which the replica's local range
+ // descriptor is out of date.
+ //
+ // The last seen replica descriptors are updated on receipt of every raft
+ // message via Replica.setLastReplicaDescriptors (see
+ // Store.HandleRaftRequest). These last seen descriptors are used when
+ // the replica's RangeDescriptor contains missing or out of date descriptors
+ // for a replica (see Replica.sendRaftMessageRaftMuLocked).
+ //
+ // Removing a replica from Store.mu.replicas is not a problem because
+ // when a replica is completely removed, it won't be recreated until
+ // there is another event that will repopulate the replicas map in the
+ // range descriptor. When it is temporarily dropped and recreated, the
+ // newly recreated replica will have a complete range descriptor.
+ lastToReplica, lastFromReplica roachpb.ReplicaDescriptor
}
// Contains the lease history when enabled.
@@ -499,47 +540,6 @@ type Replica struct {
// live node will not lose leaseholdership.
lastUpdateTimes lastUpdateTimesMap
- // The last seen replica descriptors from incoming Raft messages. These are
- // stored so that the replica still knows the replica descriptors for itself
- // and for its message recipients in the circumstances when its RangeDescriptor
- // is out of date.
- //
- // Normally, a replica knows about the other replica descriptors for a
- // range via the RangeDescriptor stored in Replica.mu.state.Desc. But that
- // descriptor is only updated during a Split or ChangeReplicas operation.
- // There are periods during a Replica's lifetime when that information is
- // out of date:
- //
- // 1. When a replica is being newly created as the result of an incoming
- // Raft message for it. This is the common case for ChangeReplicas and an
- // uncommon case for Splits. The leader will be sending the replica
- // messages and the replica needs to be able to respond before it can
- // receive an updated range descriptor (via a snapshot,
- // changeReplicasTrigger, or splitTrigger).
- //
- // 2. If the node containing a replica is partitioned or down while the
- // replicas for the range are updated. When the node comes back up, other
- // replicas may begin communicating with it and it needs to be able to
- // respond. Unlike 1 where there is no range descriptor, in this situation
- // the replica has a range descriptor but it is out of date. Note that a
- // replica being removed from a node and then quickly re-added before the
- // replica has been GC'd will also use the last seen descriptors. In
- // effect, this is another path for which the replica's local range
- // descriptor is out of date.
- //
- // The last seen replica descriptors are updated on receipt of every raft
- // message via Replica.setLastReplicaDescriptors (see
- // Store.HandleRaftRequest). These last seen descriptors are used when
- // the replica's RangeDescriptor contains missing or out of date descriptors
- // for a replica (see Replica.sendRaftMessage).
- //
- // Removing a replica from Store.mu.replicas is not a problem because
- // when a replica is completely removed, it won't be recreated until
- // there is another event that will repopulate the replicas map in the
- // range descriptor. When it is temporarily dropped and recreated, the
- // newly recreated replica will have a complete range descriptor.
- lastToReplica, lastFromReplica roachpb.ReplicaDescriptor
-
// Computed checksum at a snapshot UUID.
checksums map[uuid.UUID]ReplicaChecksum
@@ -1063,13 +1063,11 @@ func (r *Replica) mergeInProgressRLocked() bool {
}
// setLastReplicaDescriptors sets the most recently seen replica
-// descriptors to those contained in the *RaftMessageRequest, acquiring r.mu
-// to do so.
-func (r *Replica) setLastReplicaDescriptors(req *RaftMessageRequest) {
- r.mu.Lock()
- r.mu.lastFromReplica = req.FromReplica
- r.mu.lastToReplica = req.ToReplica
- r.mu.Unlock()
+// descriptors to those contained in the *RaftMessageRequest.
+func (r *Replica) setLastReplicaDescriptorsRaftMuLocked(req *RaftMessageRequest) {
+ r.raftMu.AssertHeld()
+ r.raftMu.lastFromReplica = req.FromReplica
+ r.raftMu.lastToReplica = req.ToReplica
}
// GetMVCCStats returns a copy of the MVCC stats object for this range.
diff --git a/pkg/kv/kvserver/replica_raft.go b/pkg/kv/kvserver/replica_raft.go
index 7f6166730630..b7717203bdc2 100644
--- a/pkg/kv/kvserver/replica_raft.go
+++ b/pkg/kv/kvserver/replica_raft.go
@@ -752,7 +752,7 @@ func (r *Replica) handleRaftReadyRaftMuLocked(
msgApps, otherMsgs := splitMsgApps(rd.Messages)
r.traceMessageSends(msgApps, "sending msgApp")
- r.sendRaftMessages(ctx, msgApps)
+ r.sendRaftMessagesRaftMuLocked(ctx, msgApps)
// Use a more efficient write-only batch because we don't need to do any
// reads from the batch. Any reads are performed on the underlying DB.
@@ -862,7 +862,7 @@ func (r *Replica) handleRaftReadyRaftMuLocked(
// Update raft log entry cache. We clear any older, uncommitted log entries
// and cache the latest ones.
r.store.raftEntryCache.Add(r.RangeID, rd.Entries, true /* truncate */)
- r.sendRaftMessages(ctx, otherMsgs)
+ r.sendRaftMessagesRaftMuLocked(ctx, otherMsgs)
r.traceEntries(rd.CommittedEntries, "committed, before applying any entries")
applicationStart := timeutil.Now()
@@ -1010,7 +1010,7 @@ func (r *Replica) tick(ctx context.Context, livenessMap liveness.IsLiveMap) (boo
}
now := r.store.Clock().NowAsClockTimestamp()
- if r.maybeQuiesceLocked(ctx, now, livenessMap) {
+ if r.maybeQuiesceRaftMuLockedReplicaMuLocked(ctx, now, livenessMap) {
return false, nil
}
@@ -1207,7 +1207,7 @@ func (r *Replica) maybeCoalesceHeartbeat(
return true
}
-func (r *Replica) sendRaftMessages(ctx context.Context, messages []raftpb.Message) {
+func (r *Replica) sendRaftMessagesRaftMuLocked(ctx context.Context, messages []raftpb.Message) {
var lastAppResp raftpb.Message
for _, message := range messages {
drop := false
@@ -1275,19 +1275,19 @@ func (r *Replica) sendRaftMessages(ctx context.Context, messages []raftpb.Messag
}
if !drop {
- r.sendRaftMessage(ctx, message)
+ r.sendRaftMessageRaftMuLocked(ctx, message)
}
}
if lastAppResp.Index > 0 {
- r.sendRaftMessage(ctx, lastAppResp)
+ r.sendRaftMessageRaftMuLocked(ctx, lastAppResp)
}
}
-// sendRaftMessage sends a Raft message.
-func (r *Replica) sendRaftMessage(ctx context.Context, msg raftpb.Message) {
+// sendRaftMessageRaftMuLocked sends a Raft message.
+func (r *Replica) sendRaftMessageRaftMuLocked(ctx context.Context, msg raftpb.Message) {
r.mu.RLock()
- fromReplica, fromErr := r.getReplicaDescriptorByIDRLocked(roachpb.ReplicaID(msg.From), r.mu.lastToReplica)
- toReplica, toErr := r.getReplicaDescriptorByIDRLocked(roachpb.ReplicaID(msg.To), r.mu.lastFromReplica)
+ fromReplica, fromErr := r.getReplicaDescriptorByIDRLocked(roachpb.ReplicaID(msg.From), r.raftMu.lastToReplica)
+ toReplica, toErr := r.getReplicaDescriptorByIDRLocked(roachpb.ReplicaID(msg.To), r.raftMu.lastFromReplica)
var startKey roachpb.RKey
if msg.Type == raftpb.MsgApp && r.mu.internalRaftGroup != nil {
// When the follower is potentially an uninitialized replica waiting for
diff --git a/pkg/kv/kvserver/replica_raft_quiesce.go b/pkg/kv/kvserver/replica_raft_quiesce.go
index 63ae153c2a2a..258665ef14df 100644
--- a/pkg/kv/kvserver/replica_raft_quiesce.go
+++ b/pkg/kv/kvserver/replica_raft_quiesce.go
@@ -121,9 +121,9 @@ func (r *Replica) canUnquiesceRLocked() bool {
r.mu.internalRaftGroup != nil
}
-// maybeQuiesceLocked checks to see if the replica is quiescable and initiates
-// quiescence if it is. Returns true if the replica has been quiesced and false
-// otherwise.
+// maybeQuiesceRaftMuLockedReplicaMuLocked checks to see if the replica is
+// quiescable and initiates quiescence if it is. Returns true if the replica has
+// been quiesced and false otherwise.
//
// A quiesced range is not ticked and thus doesn't create MsgHeartbeat requests
// or cause elections. The Raft leader for a range checks various
@@ -178,14 +178,14 @@ func (r *Replica) canUnquiesceRLocked() bool {
// would quiesce. The fallout from this situation are undesirable raft
// elections which will cause throughput hiccups to the range, but not
// correctness issues.
-func (r *Replica) maybeQuiesceLocked(
+func (r *Replica) maybeQuiesceRaftMuLockedReplicaMuLocked(
ctx context.Context, now hlc.ClockTimestamp, livenessMap liveness.IsLiveMap,
) bool {
status, lagging, ok := shouldReplicaQuiesce(ctx, r, now, livenessMap)
if !ok {
return false
}
- return r.quiesceAndNotifyLocked(ctx, status, lagging)
+ return r.quiesceAndNotifyRaftMuLockedReplicaMuLocked(ctx, status, lagging)
}
type quiescer interface {
@@ -398,10 +398,10 @@ func shouldReplicaQuiesce(
return status, lagging, true
}
-func (r *Replica) quiesceAndNotifyLocked(
+func (r *Replica) quiesceAndNotifyRaftMuLockedReplicaMuLocked(
ctx context.Context, status *raft.Status, lagging laggingReplicaSet,
) bool {
- fromReplica, fromErr := r.getReplicaDescriptorByIDRLocked(r.mu.replicaID, r.mu.lastToReplica)
+ fromReplica, fromErr := r.getReplicaDescriptorByIDRLocked(r.mu.replicaID, r.raftMu.lastToReplica)
if fromErr != nil {
if log.V(4) {
log.Infof(ctx, "not quiescing: cannot find from replica (%d)", r.mu.replicaID)
@@ -416,7 +416,7 @@ func (r *Replica) quiesceAndNotifyLocked(
continue
}
toReplica, toErr := r.getReplicaDescriptorByIDRLocked(
- roachpb.ReplicaID(id), r.mu.lastFromReplica)
+ roachpb.ReplicaID(id), r.raftMu.lastFromReplica)
if toErr != nil {
if log.V(4) {
log.Infof(ctx, "failed to quiesce: cannot find to replica (%d)", id)
diff --git a/pkg/kv/kvserver/store.go b/pkg/kv/kvserver/store.go
index b80a122d611b..6c19235cdc05 100644
--- a/pkg/kv/kvserver/store.go
+++ b/pkg/kv/kvserver/store.go
@@ -516,7 +516,7 @@ Store.HandleRaftRequest (which is part of the RaftMessageHandler interface),
ultimately resulting in a call to Replica.handleRaftReadyRaftMuLocked, which
houses the integration with the etcd/raft library (raft.RawNode). This may
generate Raft messages to be sent to other Stores; these are handed to
-Replica.sendRaftMessages which ultimately hands them to the Store's
+Replica.sendRaftMessagesRaftMuLocked which ultimately hands them to the Store's
RaftTransport.SendAsync method. Raft uses message passing (not
request-response), and outgoing messages will use a gRPC stream that differs
from that used for incoming messages (which makes asymmetric partitions more
diff --git a/pkg/kv/kvserver/store_raft.go b/pkg/kv/kvserver/store_raft.go
index 89a70537990a..e7cc24dba5f1 100644
--- a/pkg/kv/kvserver/store_raft.go
+++ b/pkg/kv/kvserver/store_raft.go
@@ -213,7 +213,7 @@ func (s *Store) withReplicaForRequest(
return roachpb.NewError(err)
}
defer r.raftMu.Unlock()
- r.setLastReplicaDescriptors(req)
+ r.setLastReplicaDescriptorsRaftMuLocked(req)
return f(ctx, r)
}
|
2085aa4f82117e2f253b35592ca41335a97c73bd
|
2022-11-29 18:06:42
|
David Taylor
|
jobs: add cleanup of job_info records to cleanup
| false
|
add cleanup of job_info records to cleanup
|
jobs
|
diff --git a/pkg/jobs/registry.go b/pkg/jobs/registry.go
index e12d2344da22..8cdb3d38ad56 100644
--- a/pkg/jobs/registry.go
+++ b/pkg/jobs/registry.go
@@ -991,15 +991,22 @@ func (r *Registry) cleanupOldJobsPage(
if len(toDelete.Array) > 0 {
log.VEventf(ctx, 2, "attempting to clean up %d expired job records", len(toDelete.Array))
const stmt = `DELETE FROM system.jobs WHERE id = ANY($1)`
- var nDeleted int
+ const infoStmt = `DELETE FROM system.job_info WHERE job_id = ANY($1)`
+ var nDeleted, nDeletedInfos int
if nDeleted, err = r.ex.Exec(
ctx, "gc-jobs", nil /* txn */, stmt, toDelete,
); err != nil {
log.Warningf(ctx, "error cleaning up %d jobs: %v", len(toDelete.Array), err)
return false, 0, errors.Wrap(err, "deleting old jobs")
}
+ nDeletedInfos, err = r.ex.Exec(
+ ctx, "gc-job-infos", nil /* txn */, infoStmt, toDelete,
+ )
+ if err != nil {
+ return false, 0, errors.Wrap(err, "deleting old job infos")
+ }
if nDeleted > 0 {
- log.Infof(ctx, "cleaned up %d expired job records", nDeleted)
+ log.Infof(ctx, "cleaned up %d expired job records and %d expired info records", nDeleted, nDeletedInfos)
}
}
// If we got as many rows as we asked for, there might be more.
|
8f1ebe40bc1585259887b1734d27b9fd5f43ac4f
|
2020-04-09 17:13:33
|
Tobias Schottdorf
|
roachtest: automate and de-flake version-upgrade
| false
|
automate and de-flake version-upgrade
|
roachtest
|
diff --git a/pkg/cmd/roachtest/acceptance.go b/pkg/cmd/roachtest/acceptance.go
index 7965d827a557..1770bb3cab9c 100644
--- a/pkg/cmd/roachtest/acceptance.go
+++ b/pkg/cmd/roachtest/acceptance.go
@@ -46,8 +46,13 @@ func registerAcceptance(r *testRegistry) {
{name: "status-server", fn: runStatusServer},
{
name: "version-upgrade",
- fn: runVersionUpgrade,
- skip: "skipped due to flakiness",
+ fn: func(ctx context.Context, t *test, c *cluster) {
+ predV, err := PredecessorVersion(r.buildVersion)
+ if err != nil {
+ t.Fatal(err)
+ }
+ runVersionUpgrade(ctx, t, c, predV)
+ },
// This test doesn't like running on old versions because it upgrades to
// the latest released version and then it tries to "head", where head is
// the cockroach binary built from the branch on which the test is
diff --git a/pkg/cmd/roachtest/versionupgrade.go b/pkg/cmd/roachtest/versionupgrade.go
index a743e71d3a9e..f1f3c265f1bc 100644
--- a/pkg/cmd/roachtest/versionupgrade.go
+++ b/pkg/cmd/roachtest/versionupgrade.go
@@ -80,21 +80,20 @@ const (
headVersion = "HEAD"
)
-func runVersionUpgrade(ctx context.Context, t *test, c *cluster) {
+func runVersionUpgrade(ctx context.Context, t *test, c *cluster, predecessorVersion string) {
// This is ugly, but we can't pass `--encrypt=false` to old versions of
// Cockroach.
//
// TODO(tbg): revisit as old versions are aged out of this test.
c.encryptDefault = false
- const baseVersion = "19.1.5"
u := newVersionUpgradeTest(c, versionUpgradeTestFeatures,
// Load baseVersion fixture. That fixture's cluster version may be
// at the predecessor version, so add a waitForUpgradeStep to make
// sure we're actually running at baseVersion before moving on.
//
// See the comment on createCheckpoints for details on fixtures.
- uploadAndStartFromCheckpointFixture(baseVersion),
+ uploadAndStartFromCheckpointFixture(predecessorVersion),
waitForUpgradeStep(),
// NB: before the next step, cluster and binary version equals baseVersion,
|
cdcbdfc75110e1ba1745709ecbf945809836106d
|
2023-03-29 20:16:39
|
Nathan VanBenschoten
|
kv: remove stale comment about snapshot isolation
| false
|
remove stale comment about snapshot isolation
|
kv
|
diff --git a/pkg/storage/enginepb/mvcc3.proto b/pkg/storage/enginepb/mvcc3.proto
index b7a1d60f869b..3b3299dc786b 100644
--- a/pkg/storage/enginepb/mvcc3.proto
+++ b/pkg/storage/enginepb/mvcc3.proto
@@ -51,11 +51,9 @@ message TxnMeta {
// Note that reads do not occur at this timestamp; they instead occur at
// ReadTimestamp, which is tracked in the containing roachpb.Transaction.
//
- // Writes used to be performed at the txn's read timestamp, which was
- // necessary to avoid lost update anomalies in snapshot isolation mode. We no
- // longer support snapshot isolation mode, and there are now several important
- // reasons that writes are performed at this timestamp instead of the txn's
- // original timestamp:
+ // Writes used to be performed at the txn's read timestamp before 57d02014.
+ // However, there are now several important reasons to perform writes at the
+ // write timestamp instead of the txn's read timestamp:
//
// 1. This timestamp is forwarded by the timestamp cache when this
// transaction attempts to write beneath a more recent read. Leaving the
|
ac33b7cc25513a5db9725f6471300a18b8d0e075
|
2023-09-27 10:45:17
|
Andy Yang
|
roachtest: add test to ruby-pg blocklist
| false
|
add test to ruby-pg blocklist
|
roachtest
|
diff --git a/pkg/cmd/roachtest/tests/ruby_pg_blocklist.go b/pkg/cmd/roachtest/tests/ruby_pg_blocklist.go
index 164bfd76a584..190538734062 100644
--- a/pkg/cmd/roachtest/tests/ruby_pg_blocklist.go
+++ b/pkg/cmd/roachtest/tests/ruby_pg_blocklist.go
@@ -135,6 +135,7 @@ var rubyPGBlocklist = blocklist{
`running with sync_* methods PG::Connection connection information related to SSL can retrieve a single ssl connection attribute`: "unknown",
`running with sync_* methods PG::Connection connection information related to SSL can retrieve connection's ssl state`: "unknown",
`running with sync_* methods PG::Connection connects using URI with UnixSocket host`: "unknown",
+ `running with sync_* methods PG::Connection consume_input should raise ConnectionBad for a closed connection`: "unknown",
`running with sync_* methods PG::Connection deprecated forms of methods should forward exec to exec_params`: "unknown",
`running with sync_* methods PG::Connection deprecated forms of methods should forward send_query to send_query_params`: "unknown",
`running with sync_* methods PG::Connection doesn't collapse sequential notifications`: "unknown",
|
6523c221f294b8d6604b987ced84fd89254a23ef
|
2020-10-20 15:06:16
|
Tobias Grieger
|
server: skip unit'ed engines in tombstone storage
| false
|
skip unit'ed engines in tombstone storage
|
server
|
diff --git a/pkg/server/node_tombstone_storage.go b/pkg/server/node_tombstone_storage.go
index 2513731d83c8..caa517d6a472 100644
--- a/pkg/server/node_tombstone_storage.go
+++ b/pkg/server/node_tombstone_storage.go
@@ -15,6 +15,7 @@ import (
"time"
"github.com/cockroachdb/cockroach/pkg/keys"
+ "github.com/cockroachdb/cockroach/pkg/kv/kvserver"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
@@ -117,6 +118,18 @@ func (s *nodeTombstoneStorage) SetDecommissioned(
// We've populated the cache, now write through to disk.
k := s.key(nodeID)
for _, eng := range s.engs {
+ // Read the store ident before trying to write to this
+ // engine. An engine that is not bootstrapped should not be
+ // written to, as we check (in InitEngine) that it is empty.
+ //
+ // One initialized engine is always available when this method
+ // is called, so we're still persisting on at least one engine.
+ if _, err := kvserver.ReadStoreIdent(ctx, eng); err != nil {
+ if errors.Is(err, &kvserver.NotBootstrappedError{}) {
+ continue
+ }
+ return err
+ }
var v roachpb.Value
if err := v.SetProto(&hlc.Timestamp{WallTime: ts.UnixNano()}); err != nil {
return err
diff --git a/pkg/server/node_tombstone_storage_test.go b/pkg/server/node_tombstone_storage_test.go
index 1675f5618fcc..092c6da53094 100644
--- a/pkg/server/node_tombstone_storage_test.go
+++ b/pkg/server/node_tombstone_storage_test.go
@@ -15,9 +15,13 @@ import (
"testing"
"time"
+ "github.com/cockroachdb/cockroach/pkg/clusterversion"
+ "github.com/cockroachdb/cockroach/pkg/kv/kvserver"
+ "github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/storage"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
+ "github.com/cockroachdb/cockroach/pkg/util/uuid"
"github.com/stretchr/testify/require"
)
@@ -29,6 +33,21 @@ func TestNodeTombstoneStorage(t *testing.T) {
eng2 := storage.NewDefaultInMem()
defer eng2.Close()
+ engs := []storage.Engine{eng1, eng2}
+
+ // The tombstone storage only writes to initialized engines.
+ // We'll test uninited engines at the end of the test.
+ id, err := uuid.NewV4()
+ require.NoError(t, err)
+ for i := range engs {
+ require.NoError(t, kvserver.WriteClusterVersion(ctx, engs[i], clusterversion.TestingClusterVersion))
+ require.NoError(t, kvserver.InitEngine(ctx, engs[i], roachpb.StoreIdent{
+ ClusterID: id,
+ NodeID: 1,
+ StoreID: roachpb.StoreID(1 + i),
+ }))
+ }
+
mustTime := func(ts time.Time, err error) time.Time {
t.Helper()
require.NoError(t, err)
@@ -67,7 +86,6 @@ func TestNodeTombstoneStorage(t *testing.T) {
// We're not hitting the disks any more; the decommissioned
// status is cached. This includes both the decommissioned nodes
// and n3, which is not decommissioned but was checked above.
- engs := s.engs
s.engs = nil
require.Equal(t, ts1, mustTime(s.IsDecommissioned(ctx, 2)))
require.Equal(t, ts2, mustTime(s.IsDecommissioned(ctx, 1)))
@@ -78,4 +96,20 @@ func TestNodeTombstoneStorage(t *testing.T) {
require.Equal(t, ts1, mustTime(s.IsDecommissioned(ctx, 2)))
require.Equal(t, ts2, mustTime(s.IsDecommissioned(ctx, 1)))
require.Equal(t, time.Time{}, mustTime(s.IsDecommissioned(ctx, 3)))
+
+ // Throw an uninitialized engine in the mix. It should be skipped over.
+ eng3 := storage.NewDefaultInMem()
+ defer eng3.Close()
+ s = &nodeTombstoneStorage{engs: []storage.Engine{eng1, eng2, eng3}}
+ // Decommission n100.
+ ts3 := timeutil.Unix(15, 30).UTC()
+ require.NoError(t, s.SetDecommissioned(ctx, 100, ts3))
+ require.Equal(t, ts3, mustTime(s.IsDecommissioned(ctx, 100)))
+ // Rehydrate.
+ s = &nodeTombstoneStorage{engs: []storage.Engine{eng1, eng2, eng3}}
+ require.Equal(t, ts3, mustTime(s.IsDecommissioned(ctx, 100)))
+ // Rehydrate, but only from eng3. Now the entry is gone, meaning it
+ // wasn't written to n3.
+ s = &nodeTombstoneStorage{engs: []storage.Engine{eng3}}
+ require.Equal(t, time.Time{}, mustTime(s.IsDecommissioned(ctx, 100)))
}
|
3a29bb342e83fdc65ace64ba93e29073831e8f17
|
2016-03-22 18:19:14
|
Ben Darnell
|
storage: Reduce log spam from raft transport
| false
|
Reduce log spam from raft transport
|
storage
|
diff --git a/storage/store.go b/storage/store.go
index 3dd2ed0e2491..a9d671d466a2 100644
--- a/storage/store.go
+++ b/storage/store.go
@@ -1754,8 +1754,19 @@ func (s *Store) handleRaftMessage(req *RaftMessageRequest) error {
// It deadlocks to hold s.Mutex while calling raftGroup.Step.
s.mu.Unlock()
if err != nil {
- return util.Errorf("refusing incoming Raft message %s for group %d from %s to %s: %s",
- req.Message.Type, req.GroupID, req.FromReplica, req.ToReplica, err)
+ // If getOrCreateReplicaLocked returns an error, log it at V(1)
+ // instead of returning it (where the caller will log it as
+ // Error). Errors here generally mean that the sender is out of
+ // date, and it may remain so until replicaGCQueue runs, so when
+ // these messages occur they will repeat many times.
+ // TODO(bdarnell): if we had a better way to report errors to the
+ // sender then we could prompt the sender to GC this replica
+ // immediately.
+ if log.V(1) {
+ log.Infof("refusing incoming Raft message %s for group %d from %s to %s: %s",
+ req.Message.Type, req.GroupID, req.FromReplica, req.ToReplica, err)
+ }
+ return nil
}
r.mu.Lock()
err = r.mu.raftGroup.Step(req.Message)
|
42dbdc264498c8cb76cb6b4dcc122d9d3a5d6b45
|
2023-03-03 20:45:33
|
Marcus Gartner
|
sql: fix internal error with ambiguous overloads
| false
|
fix internal error with ambiguous overloads
|
sql
|
diff --git a/pkg/sql/logictest/testdata/logic_test/udf b/pkg/sql/logictest/testdata/logic_test/udf
index 1220dbec62c8..7b3ef111928f 100644
--- a/pkg/sql/logictest/testdata/logic_test/udf
+++ b/pkg/sql/logictest/testdata/logic_test/udf
@@ -3152,3 +3152,14 @@ query I
SELECT public.abs(-1)
----
99
+
+subtest regression_97854
+
+# Regression test for #97854.
+statement ok
+CREATE FUNCTION f_97854 (i INT) RETURNS CHAR LANGUAGE SQL AS $$ SELECT 'i' $$;
+CREATE FUNCTION f_97854 (f FLOAT) RETURNS CHAR LANGUAGE SQL AS $$ SELECT 'f' $$;
+
+# TODO(#88318): In Postgres, the float overload is chosen.
+statement error pgcode 42725 ambiguous call: f_97854\(decimal\).*
+SELECT f_97854(1.0)
diff --git a/pkg/sql/opt/testutils/testcat/function.go b/pkg/sql/opt/testutils/testcat/function.go
index 7ecc604e0bb7..4d5867e43690 100644
--- a/pkg/sql/opt/testutils/testcat/function.go
+++ b/pkg/sql/opt/testutils/testcat/function.go
@@ -62,6 +62,8 @@ func (tc *Catalog) CreateFunction(c *tree.CreateFunction) {
panic(fmt.Errorf("built-in function with name %q already exists", name))
}
if _, ok := tc.udfs[name]; ok {
+ // TODO(mgartner): The test catalog should support multiple overloads
+ // with the same name if their arguments are different.
panic(fmt.Errorf("user-defined function with name %q already exists", name))
}
if c.RoutineBody != nil {
diff --git a/pkg/sql/sem/tree/type_check.go b/pkg/sql/sem/tree/type_check.go
index f0439c5e71dc..d5cd5c753195 100644
--- a/pkg/sql/sem/tree/type_check.go
+++ b/pkg/sql/sem/tree/type_check.go
@@ -3110,6 +3110,9 @@ func getMostSignificantOverload(
matchIdx = k
}
}
+ if !foundMatch {
+ return QualifiedOverload{}, ambiguousError()
+ }
return qualifiedOverloads[oImpls[matchIdx]], nil
}
|
e184d516149399d74804395407f624a9eca46f97
|
2021-04-19 15:31:49
|
Raphael 'kena' Poss
|
build: update the go version requirement for `make`
| false
|
update the go version requirement for `make`
|
build
|
diff --git a/build/go-version-check.sh b/build/go-version-check.sh
index b285997526d0..719eabe48b59 100755
--- a/build/go-version-check.sh
+++ b/build/go-version-check.sh
@@ -7,7 +7,8 @@
required_version_major=1
minimum_version_minor=15
-minimum_version_15_patch=3
+minimum_version_15_patch=10 # update to 11 when issue #63836 is addressed
+minimum_version_16_patch=3
go=${1-go}
|
fc5973b84a5d8209ee5dedaad410075fb8bbc742
|
2024-05-29 23:22:23
|
Yahor Yuzefovich
|
sql: simplify newFlowCtxForExplainPurposes a bit
| false
|
simplify newFlowCtxForExplainPurposes a bit
|
sql
|
diff --git a/pkg/sql/distsql_physical_planner.go b/pkg/sql/distsql_physical_planner.go
index 225d833454a3..a9f66f702870 100644
--- a/pkg/sql/distsql_physical_planner.go
+++ b/pkg/sql/distsql_physical_planner.go
@@ -993,8 +993,7 @@ func getDefaultSaveFlowsFunc(
var explainVec []string
var explainVecVerbose []string
if planner.instrumentation.collectBundle && vectorized {
- flowCtx, cleanup := newFlowCtxForExplainPurposes(ctx, planner)
- defer cleanup()
+ flowCtx := newFlowCtxForExplainPurposes(ctx, planner)
flowCtx.Local = !planner.curPlan.flags.IsDistributed()
getExplain := func(verbose bool) []string {
gatewaySQLInstanceID := planner.extendedEvalCtx.DistSQLPlanner.gatewaySQLInstanceID
diff --git a/pkg/sql/explain_vec.go b/pkg/sql/explain_vec.go
index 3e02322d5a07..789197f04e17 100644
--- a/pkg/sql/explain_vec.go
+++ b/pkg/sql/explain_vec.go
@@ -12,6 +12,7 @@ package sql
import (
"context"
+ "math"
"github.com/cockroachdb/cockroach/pkg/sql/colflow"
"github.com/cockroachdb/cockroach/pkg/sql/execinfra"
@@ -61,8 +62,7 @@ func (n *explainVecNode) startExec(params runParams) error {
finalizePlanWithRowCount(params.ctx, planCtx, physPlan, n.plan.mainRowCount)
flows := physPlan.GenerateFlowSpecs()
- flowCtx, cleanup := newFlowCtxForExplainPurposes(params.ctx, params.p)
- defer cleanup()
+ flowCtx := newFlowCtxForExplainPurposes(params.ctx, params.p)
// We want to get the vectorized plan which would be executed with the
// current 'vectorize' option. If 'vectorize' is set to 'off', then the
@@ -89,17 +89,17 @@ func (n *explainVecNode) startExec(params runParams) error {
return nil
}
-func newFlowCtxForExplainPurposes(
- ctx context.Context, p *planner,
-) (_ *execinfra.FlowCtx, cleanup func()) {
+func newFlowCtxForExplainPurposes(ctx context.Context, p *planner) *execinfra.FlowCtx {
monitor := mon.NewMonitor(mon.Options{
Name: "explain",
Settings: p.execCfg.Settings,
})
- monitor.StartNoReserved(ctx, p.Mon())
- cleanup = func() {
- monitor.Stop(ctx)
- }
+ // Note that we do not use planner's monitor here in order to not link any
+ // monitors created later to the planner's monitor (since we might not close
+ // the components that use them). This also allows us to not close this
+ // monitor because eventually the whole monitor tree rooted in this monitor
+ // will be garbage collected.
+ monitor.Start(ctx, nil /* pool */, mon.NewStandaloneBudget(math.MaxInt64))
return &execinfra.FlowCtx{
NodeID: p.EvalContext().NodeID,
EvalCtx: p.EvalContext(),
@@ -113,7 +113,7 @@ func newFlowCtxForExplainPurposes(
},
Descriptors: p.Descriptors(),
DiskMonitor: &mon.BytesMonitor{},
- }, cleanup
+ }
}
func newPlanningCtxForExplainPurposes(
|
3fa55dfe04aa258c0f5fec2634f679012479d084
|
2018-02-27 04:50:20
|
Nathan VanBenschoten
|
storage: create tracing span when requesting range leases, improve cleanup
| false
|
create tracing span when requesting range leases, improve cleanup
|
storage
|
diff --git a/pkg/storage/replica.go b/pkg/storage/replica.go
index 833cbb27f0be..b2ea45bc33a9 100644
--- a/pkg/storage/replica.go
+++ b/pkg/storage/replica.go
@@ -1387,7 +1387,7 @@ func (r *Replica) redirectOnOrAcquireLease(ctx context.Context) (LeaseStatus, *r
// Otherwise, we don't need to wait for the extension and simply
// ignore the returned handle (whose channel is buffered) and continue.
if status.State == LeaseState_STASIS {
- return r.requestLeaseLocked(status), nil
+ return r.requestLeaseLocked(ctx, status), nil
}
// Extend the lease if this range uses expiration-based
@@ -1403,14 +1403,14 @@ func (r *Replica) redirectOnOrAcquireLease(ctx context.Context) (LeaseStatus, *r
// We had an active lease to begin with, but we want to trigger
// a lease extension. We explicitly ignore the returned handle
// as we won't block on it.
- _ = r.requestLeaseLocked(status)
+ _ = r.requestLeaseLocked(ctx, status)
}
}
case LeaseState_EXPIRED:
// No active lease: Request renewal if a renewal is not already pending.
log.VEventf(ctx, 2, "request range lease (attempt #%d)", attempt)
- return r.requestLeaseLocked(status), nil
+ return r.requestLeaseLocked(ctx, status), nil
case LeaseState_PROSCRIBED:
// Lease proposed timestamp is earlier than the min proposed
@@ -1418,7 +1418,7 @@ func (r *Replica) redirectOnOrAcquireLease(ctx context.Context) (LeaseStatus, *r
// owns the lease, re-request. Otherwise, redirect.
if status.Lease.OwnedBy(r.store.StoreID()) {
log.VEventf(ctx, 2, "request range lease (attempt #%d)", attempt)
- return r.requestLeaseLocked(status), nil
+ return r.requestLeaseLocked(ctx, status), nil
}
// If lease is currently held by another, redirect to holder.
return nil, roachpb.NewError(
diff --git a/pkg/storage/replica_range_lease.go b/pkg/storage/replica_range_lease.go
index 8982ed67aeb2..abc397d72bf2 100644
--- a/pkg/storage/replica_range_lease.go
+++ b/pkg/storage/replica_range_lease.go
@@ -21,6 +21,7 @@ import (
"fmt"
"time"
+ opentracing "github.com/opentracing/opentracing-go"
"github.com/pkg/errors"
"github.com/cockroachdb/cockroach/pkg/keys"
@@ -57,7 +58,7 @@ func (h *leaseRequestHandle) Cancel() {
delete(h.p.llHandles, h)
// Cancel request, if necessary.
if len(h.p.llHandles) == 0 {
- h.p.cancel()
+ h.p.cancelLocked()
}
}
// Mark handle as canceled.
@@ -92,9 +93,13 @@ type pendingLeaseRequest struct {
// Set of request handles attached to the lease acquisition.
// All accesses require repl.mu to be exclusively locked.
llHandles map[*leaseRequestHandle]struct{}
- // cancel is the context cancellation function for the async lease
- // request, if one exists. If nil, then no request is in progress.
- cancel func()
+ // cancelLocked is a context cancellation function for the async lease
+ // request, if one exists. It cancels an ongoing lease request and cleans up
+ // the requests state, including setting the cancelLocked function itself to
+ // nil. It will be called when a lease request is canceled because all
+ // handles cancel or when a lease request completes. If nil, then no request
+ // is in progress. repl.mu to be exclusively locked to call the function.
+ cancelLocked func()
// nextLease is the pending RequestLease request, if any. It can be used to
// figure out if we're in the process of extending our own lease, or
// transferring it to another replica.
@@ -113,7 +118,7 @@ func makePendingLeaseRequest(repl *Replica) pendingLeaseRequest {
//
// Requires repl.mu is read locked.
func (p *pendingLeaseRequest) RequestPending() (roachpb.Lease, bool) {
- pending := p.cancel != nil
+ pending := p.cancelLocked != nil
if pending {
return p.nextLease, true
}
@@ -136,6 +141,7 @@ func (p *pendingLeaseRequest) RequestPending() (roachpb.Lease, bool) {
//
// Requires repl.mu is exclusively locked.
func (p *pendingLeaseRequest) InitOrJoinRequest(
+ ctx context.Context,
nextLeaseHolder roachpb.ReplicaDescriptor,
status LeaseStatus,
startKey roachpb.Key,
@@ -202,7 +208,7 @@ func (p *pendingLeaseRequest) InitOrJoinRequest(
}
}
- if err := p.requestLeaseAsync(nextLeaseHolder, reqLease, status, leaseReq); err != nil {
+ if err := p.requestLeaseAsync(ctx, nextLeaseHolder, reqLease, status, leaseReq); err != nil {
// We failed to start the asynchronous task. Send a blank NotLeaseHolderError
// back to indicate that we have no idea who the range lease holder might
// be; we've withdrawn from active duty.
@@ -223,24 +229,44 @@ func (p *pendingLeaseRequest) InitOrJoinRequest(
// requestLeaseAsync sends a transfer lease or lease request to the
// specified replica. The request is sent in an async task.
func (p *pendingLeaseRequest) requestLeaseAsync(
+ parentCtx context.Context,
nextLeaseHolder roachpb.ReplicaDescriptor,
reqLease roachpb.Lease,
status LeaseStatus,
leaseReq roachpb.Request,
) error {
+ const opName = "request range lease"
+ var sp opentracing.Span
+ tr := p.repl.AmbientContext.Tracer
+ if parentSp := opentracing.SpanFromContext(parentCtx); parentSp != nil {
+ // We use FollowsFrom because the lease request's span can outlive the
+ // parent request. This is possible if parentCtx is canceled after others
+ // have coalesced on to this lease request (see leaseRequestHandle.Cancel).
+ sp = tr.StartSpan(opName, opentracing.FollowsFrom(parentSp.Context()))
+ } else {
+ sp = tr.StartSpan(opName)
+ }
+
// Create a new context *without* a timeout. Instead, we multiplex the
// cancellation of all contexts onto this new one, only canceling it if all
- // coalesced requests timeout/cancel. p.cancel (defined below) is the cancel
- // function that must be called; calling just cancel is insufficient.
+ // coalesced requests timeout/cancel. p.cancelLocked (defined below) is the
+ // cancel function that must be called; calling just cancel is insufficient.
ctx := p.repl.AnnotateCtx(context.Background())
+ ctx = opentracing.ContextWithSpan(ctx, sp)
ctx, cancel := context.WithCancel(ctx)
- p.cancel = func() {
+
+ // Make sure we clean up the context and request state. This will be called
+ // either when the request completes cleanly or when it is terminated early.
+ p.cancelLocked = func() {
cancel()
- p.cleanupAfterReq()
+ p.cancelLocked = nil
+ p.nextLease = roachpb.Lease{}
}
- return p.repl.store.Stopper().RunAsyncTask(
- ctx, "storage.pendingLeaseRequest: requesting lease",
- func(ctx context.Context) {
+
+ err := p.repl.store.Stopper().RunAsyncTask(
+ ctx, "storage.pendingLeaseRequest: requesting lease", func(ctx context.Context) {
+ defer sp.Finish()
+
// If requesting an epoch-based lease & current state is expired,
// potentially heartbeat our own liveness or increment epoch of
// prior owner. Note we only do this if the previous lease was
@@ -294,11 +320,13 @@ func (p *pendingLeaseRequest) requestLeaseAsync(
p.repl.mu.Lock()
defer p.repl.mu.Unlock()
if ctx.Err() != nil {
- // We were canceled. At this point, another async request could
- // be active so we don't want to do anything else.
+ // We were canceled and this request was already cleaned up
+ // under lock. At this point, another async request could be
+ // active so we don't want to do anything else.
return
}
- // Send result of lease to all waiter channels.
+
+ // Send result of lease to all waiter channels and cleanup request.
for llHandle := range p.llHandles {
// Don't send the same transaction object twice; this can lead to races.
if pErr != nil {
@@ -310,14 +338,14 @@ func (p *pendingLeaseRequest) requestLeaseAsync(
}
delete(p.llHandles, llHandle)
}
- p.cleanupAfterReq()
+ p.cancelLocked()
})
-}
-
-// Requires repl.mu is exclusively locked.
-func (p *pendingLeaseRequest) cleanupAfterReq() {
- p.cancel = nil
- p.nextLease = roachpb.Lease{}
+ if err != nil {
+ p.cancelLocked()
+ sp.Finish()
+ return err
+ }
+ return nil
}
// JoinRequest adds one more waiter to the currently pending request.
@@ -329,7 +357,7 @@ func (p *pendingLeaseRequest) cleanupAfterReq() {
// Requires repl.mu is exclusively locked.
func (p *pendingLeaseRequest) JoinRequest() *leaseRequestHandle {
llHandle := p.newHandle()
- if len(p.llHandles) == 0 {
+ if _, ok := p.RequestPending(); !ok {
llHandle.resolve(roachpb.NewErrorf("no request in progress"))
return llHandle
}
@@ -475,7 +503,7 @@ func (r *Replica) requiresExpiringLeaseRLocked() bool {
// for a time interval containing the requested timestamp.
// If a transfer is in progress, a NotLeaseHolderError directing to the recipient is
// sent on the returned chan.
-func (r *Replica) requestLeaseLocked(status LeaseStatus) *leaseRequestHandle {
+func (r *Replica) requestLeaseLocked(ctx context.Context, status LeaseStatus) *leaseRequestHandle {
if r.store.TestingKnobs().LeaseRequestEvent != nil {
r.store.TestingKnobs().LeaseRequestEvent(status.Timestamp)
}
@@ -500,7 +528,7 @@ func (r *Replica) requestLeaseLocked(status LeaseStatus) *leaseRequestHandle {
return llHandle
}
return r.mu.pendingLeaseRequest.InitOrJoinRequest(
- repDesc, status, r.mu.state.Desc.StartKey.AsRawKey(), false /* transfer */)
+ ctx, repDesc, status, r.mu.state.Desc.StartKey.AsRawKey(), false /* transfer */)
}
// AdminTransferLease transfers the LeaderLease to another replica. A
@@ -563,7 +591,7 @@ func (r *Replica) AdminTransferLease(ctx context.Context, target roachpb.StoreID
// Stop using the current lease.
r.mu.minLeaseProposedTS = status.Timestamp
transfer = r.mu.pendingLeaseRequest.InitOrJoinRequest(
- nextLeaseHolder, status, desc.StartKey.AsRawKey(), true, /* transfer */
+ ctx, nextLeaseHolder, status, desc.StartKey.AsRawKey(), true, /* transfer */
)
return nil, transfer, nil
}
diff --git a/pkg/storage/replica_test.go b/pkg/storage/replica_test.go
index d44162a667a2..0bb8000ee439 100644
--- a/pkg/storage/replica_test.go
+++ b/pkg/storage/replica_test.go
@@ -1212,14 +1212,15 @@ func TestReplicaDrainLease(t *testing.T) {
tc.Start(t, stopper)
// Acquire initial lease.
- status, pErr := tc.repl.redirectOnOrAcquireLease(context.Background())
+ ctx := context.Background()
+ status, pErr := tc.repl.redirectOnOrAcquireLease(ctx)
if pErr != nil {
t.Fatal(pErr)
}
tc.store.SetDraining(true)
tc.repl.mu.Lock()
- pErr = <-tc.repl.requestLeaseLocked(status).C()
+ pErr = <-tc.repl.requestLeaseLocked(ctx, status).C()
tc.repl.mu.Unlock()
_, ok := pErr.GetDetail().(*roachpb.NotLeaseHolderError)
if !ok {
@@ -1227,7 +1228,7 @@ func TestReplicaDrainLease(t *testing.T) {
}
tc.store.SetDraining(false)
// Newly undrained, leases work again.
- if _, pErr := tc.repl.redirectOnOrAcquireLease(context.Background()); pErr != nil {
+ if _, pErr := tc.repl.redirectOnOrAcquireLease(ctx); pErr != nil {
t.Fatal(pErr)
}
}
@@ -1912,7 +1913,7 @@ func TestLeaseConcurrent(t *testing.T) {
if err := stopper.RunAsyncTask(context.Background(), "test", func(ctx context.Context) {
tc.repl.mu.Lock()
status := tc.repl.leaseStatus(*tc.repl.mu.state.Lease, ts, hlc.Timestamp{})
- llHandle := tc.repl.requestLeaseLocked(status)
+ llHandle := tc.repl.requestLeaseLocked(ctx, status)
tc.repl.mu.Unlock()
wg.Done()
pErr := <-llHandle.C()
|
634991770ad09f824fedcb43de17acb19746691a
|
2018-04-21 15:51:21
|
Raphael 'kena' Poss
|
sql: move tableUpdater to its own file
| false
|
move tableUpdater to its own file
|
sql
|
diff --git a/pkg/sql/tablewriter.go b/pkg/sql/tablewriter.go
index 20a56bf7f952..b9b5bee4d710 100644
--- a/pkg/sql/tablewriter.go
+++ b/pkg/sql/tablewriter.go
@@ -224,67 +224,8 @@ func (ti *tableInserter) fkSpanCollector() sqlbase.FkSpanCollector {
return ti.ri.Fks
}
-// tableUpdater handles writing kvs and forming table rows for updates.
-type tableUpdater struct {
- tableWriterBase
- ru sqlbase.RowUpdater
-}
-
func (ti *tableInserter) close(_ context.Context) {}
-// walkExprs is part of the tableWriter interface.
-func (tu *tableUpdater) walkExprs(_ func(desc string, index int, expr tree.TypedExpr)) {}
-
-// init is part of the tableWriter interface.
-func (tu *tableUpdater) init(txn *client.Txn, _ *tree.EvalContext) error {
- tu.tableWriterBase.init(txn)
- return nil
-}
-
-// row is part of the tableWriter interface.
-// We don't implement this because tu.ru.UpdateRow wants two slices
-// and it would be a shame to split the incoming slice on every call.
-// Instead provide a separate rowForUpdate() below.
-func (tu *tableUpdater) row(context.Context, tree.Datums, bool) (tree.Datums, error) {
- panic("unimplemented")
-}
-
-// rowForUpdate extends row() from the tableWriter interface.
-func (tu *tableUpdater) rowForUpdate(
- ctx context.Context, oldValues, updateValues tree.Datums, traceKV bool,
-) (tree.Datums, error) {
- tu.batchSize++
- return tu.ru.UpdateRow(ctx, tu.b, oldValues, updateValues, sqlbase.CheckFKs, traceKV)
-}
-
-// atBatchEnd is part of the extendedTableWriter interface.
-func (tu *tableUpdater) atBatchEnd(_ context.Context) error { return nil }
-
-// flushAndStartNewBatch is part of the extendedTableWriter interface.
-func (tu *tableUpdater) flushAndStartNewBatch(ctx context.Context) error {
- return tu.tableWriterBase.flushAndStartNewBatch(ctx, tu.tableDesc())
-}
-
-// finalize is part of the tableWriter interface.
-func (tu *tableUpdater) finalize(
- ctx context.Context, autoCommit autoCommitOpt, _ bool,
-) (*sqlbase.RowContainer, error) {
- return nil, tu.tableWriterBase.finalize(ctx, autoCommit, tu.tableDesc())
-}
-
-// tableDesc is part of the tableWriter interface.
-func (tu *tableUpdater) tableDesc() *sqlbase.TableDescriptor {
- return tu.ru.Helper.TableDesc
-}
-
-// fkSpanCollector is part of the tableWriter interface.
-func (tu *tableUpdater) fkSpanCollector() sqlbase.FkSpanCollector {
- return tu.ru.Fks
-}
-
-// close is part of the tableWriter interface.
-func (tu *tableUpdater) close(_ context.Context) {}
-
type tableUpsertEvaler interface {
expressionCarrier
diff --git a/pkg/sql/tablewriter_update.go b/pkg/sql/tablewriter_update.go
new file mode 100644
index 000000000000..994f3798b5ea
--- /dev/null
+++ b/pkg/sql/tablewriter_update.go
@@ -0,0 +1,82 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
+
+package sql
+
+import (
+ "context"
+
+ "github.com/cockroachdb/cockroach/pkg/internal/client"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
+ "github.com/cockroachdb/cockroach/pkg/sql/sqlbase"
+)
+
+// tableUpdater handles writing kvs and forming table rows for updates.
+type tableUpdater struct {
+ tableWriterBase
+ ru sqlbase.RowUpdater
+}
+
+// init is part of the tableWriter interface.
+func (tu *tableUpdater) init(txn *client.Txn, _ *tree.EvalContext) error {
+ tu.tableWriterBase.init(txn)
+ return nil
+}
+
+// row is part of the tableWriter interface.
+// We don't implement this because tu.ru.UpdateRow wants two slices
+// and it would be a shame to split the incoming slice on every call.
+// Instead provide a separate rowForUpdate() below.
+func (tu *tableUpdater) row(context.Context, tree.Datums, bool) (tree.Datums, error) {
+ panic("unimplemented")
+}
+
+// rowForUpdate extends row() from the tableWriter interface.
+func (tu *tableUpdater) rowForUpdate(
+ ctx context.Context, oldValues, updateValues tree.Datums, traceKV bool,
+) (tree.Datums, error) {
+ tu.batchSize++
+ return tu.ru.UpdateRow(ctx, tu.b, oldValues, updateValues, sqlbase.CheckFKs, traceKV)
+}
+
+// atBatchEnd is part of the extendedTableWriter interface.
+func (tu *tableUpdater) atBatchEnd(_ context.Context) error { return nil }
+
+// flushAndStartNewBatch is part of the extendedTableWriter interface.
+func (tu *tableUpdater) flushAndStartNewBatch(ctx context.Context) error {
+ return tu.tableWriterBase.flushAndStartNewBatch(ctx, tu.tableDesc())
+}
+
+// finalize is part of the tableWriter interface.
+func (tu *tableUpdater) finalize(
+ ctx context.Context, autoCommit autoCommitOpt, _ bool,
+) (*sqlbase.RowContainer, error) {
+ return nil, tu.tableWriterBase.finalize(ctx, autoCommit, tu.tableDesc())
+}
+
+// tableDesc is part of the tableWriter interface.
+func (tu *tableUpdater) tableDesc() *sqlbase.TableDescriptor {
+ return tu.ru.Helper.TableDesc
+}
+
+// fkSpanCollector is part of the tableWriter interface.
+func (tu *tableUpdater) fkSpanCollector() sqlbase.FkSpanCollector {
+ return tu.ru.Fks
+}
+
+// close is part of the tableWriter interface.
+func (tu *tableUpdater) close(_ context.Context) {}
+
+// walkExprs is part of the tableWriter interface.
+func (tu *tableUpdater) walkExprs(_ func(desc string, index int, expr tree.TypedExpr)) {}
|
15f94260ba11a712b87bbeacf477d22828894569
|
2017-01-24 05:03:10
|
Andrei Matei
|
sql: don't set Result.Err only to have it overwritten later
| false
|
don't set Result.Err only to have it overwritten later
|
sql
|
diff --git a/pkg/sql/executor.go b/pkg/sql/executor.go
index 4bcd10f71926..5738db26c955 100644
--- a/pkg/sql/executor.go
+++ b/pkg/sql/executor.go
@@ -641,10 +641,11 @@ func (e *Executor) execRequest(session *Session, sql string, copymsg copyMsg) St
// This is where the magic happens - we ask db to run a KV txn and possibly retry it.
txn := txnState.txn // this might be nil if the txn was already aborted.
err := txn.Exec(execOpt, txnClosure)
- if len(results) > 0 {
- // Override the error in the last result, if any. We might have had a
- // RetryableTxnError that got converted to a non-retryable error when the
- // txn closure was done.
+ if err != nil && len(results) > 0 {
+ // Set or override the error in the last result, if any.
+ // The error might have come from auto-commit, in which case it wasn't
+ // captured in a result. Or, we might have had a RetryableTxnError that
+ // got converted to a non-retryable error when the txn closure was done.
lastRes := &results[len(results)-1]
lastRes.Err = convertToErrWithPGCode(err)
}
@@ -653,7 +654,6 @@ func (e *Executor) execRequest(session *Session, sql string, copymsg copyMsg) St
// auto commit. The error was generated outside of the txn closure, so it was not
// set in any result.
if err != nil {
- lastResult := &results[len(results)-1]
if aErr, ok := err.(*client.AutoCommitError); ok {
// TODO(andrei): Until #7881 fixed.
{
@@ -668,15 +668,9 @@ func (e *Executor) execRequest(session *Session, sql string, copymsg copyMsg) St
txnState.sp.SetBaggageItem(keyFor7881Sample, "sample me please")
}
}
- lastResult.Err = aErr
e.TxnAbortCount.Inc(1)
txn.CleanupOnError(err)
}
- if lastResult.Err == nil {
- log.Fatalf(session.Ctx(),
- "error (%s) was returned, but it was not set in the last result (%v)",
- err, lastResult)
- }
}
// Sanity check about not leaving KV txns open on errors.
@@ -818,8 +812,10 @@ func runTxnAttempt(
// - the statements that haven't been executed because the transaction has
// been committed or rolled back. In returning an error, this will be nil.
// - the error encountered while executing statements, if any. If an error
-// occurred, it is also the last result returned. Subsequent statements
-// have not been executed.
+// occurred, it corresponds to the last result returned. Subsequent statements
+// have not been executed. Note that usually the error is not reflected in
+// this last result; the caller is responsible copying it into the result
+// after converting it adequately.
func (e *Executor) execStmtsInCurrentTxn(
stmts parser.StatementList,
planMaker *planner,
@@ -937,7 +933,7 @@ func (e *Executor) execStmtInAbortedTxn(
panic("unreachable")
}
if err := parser.ValidateRestartCheckpoint(spName); err != nil {
- return Result{Err: err}, err
+ return Result{}, err
}
if txnState.State == RestartWait {
// Reset the state. Txn is Open again.
@@ -949,10 +945,10 @@ func (e *Executor) execStmtInAbortedTxn(
err := sqlbase.NewTransactionAbortedError(fmt.Sprintf(
"SAVEPOINT %s has not been used or a non-retriable error was encountered",
parser.RestartSavepointName))
- return Result{Err: err}, err
+ return Result{}, err
default:
err := sqlbase.NewTransactionAbortedError("")
- return Result{Err: err}, err
+ return Result{}, err
}
}
@@ -974,7 +970,7 @@ func (e *Executor) execStmtInCommitWaitTxn(
return result, nil
default:
err := sqlbase.NewTransactionCommittedError()
- return Result{Err: err}, err
+ return Result{}, err
}
}
@@ -1031,7 +1027,7 @@ func (e *Executor) execStmtInOpenTxn(
case *parser.BeginTransaction:
if !firstInTxn {
txnState.updateStateAndCleanupOnErr(errTransactionInProgress, e)
- return Result{Err: errTransactionInProgress}, errTransactionInProgress
+ return Result{}, errTransactionInProgress
}
case *parser.CommitTransaction:
if implicitTxn {
@@ -1046,7 +1042,7 @@ func (e *Executor) execStmtInOpenTxn(
return e.noTransactionHelper(txnState)
}
if err := parser.ValidateRestartCheckpoint(s.Savepoint); err != nil {
- return Result{Err: err}, err
+ return Result{}, err
}
// ReleaseSavepoint is executed fully here; there's no planNode for it
// and the planner is not involved at all.
@@ -1069,7 +1065,7 @@ func (e *Executor) execStmtInOpenTxn(
return e.noTransactionHelper(txnState)
}
if err := parser.ValidateRestartCheckpoint(s.Name); err != nil {
- return Result{Err: err}, err
+ return Result{}, err
}
// We want to disallow SAVEPOINTs to be issued after a transaction has
// started running, but such enforcement is problematic in the
@@ -1086,7 +1082,7 @@ func (e *Executor) execStmtInOpenTxn(
err := fmt.Errorf("SAVEPOINT %s needs to be the first statement in a transaction",
parser.RestartSavepointName)
txnState.updateStateAndCleanupOnErr(err, e)
- return Result{Err: err}, err
+ return Result{}, err
}
// Note that Savepoint doesn't have a corresponding plan node.
// This here is all the execution there is.
@@ -1100,17 +1096,17 @@ func (e *Executor) execStmtInOpenTxn(
err = errNotRetriable
}
txnState.updateStateAndCleanupOnErr(err, e)
- return Result{Err: err}, err
+ return Result{}, err
case *parser.Prepare:
err := util.UnimplementedWithIssueErrorf(7568,
"Prepared statements are supported only via the Postgres wire protocol")
txnState.updateStateAndCleanupOnErr(err, e)
- return Result{Err: err}, err
+ return Result{}, err
case *parser.Execute:
err := util.UnimplementedWithIssueErrorf(7568,
"Executing prepared statements is supported only via the Postgres wire protocol")
txnState.updateStateAndCleanupOnErr(err, e)
- return Result{Err: err}, err
+ return Result{}, err
case *parser.Deallocate:
if s.Name == "" {
planMaker.session.PreparedStatements.DeleteAll()
@@ -1118,7 +1114,7 @@ func (e *Executor) execStmtInOpenTxn(
if found := planMaker.session.PreparedStatements.Delete(string(s.Name)); !found {
err := fmt.Errorf("prepared statement %s does not exist", s.Name)
txnState.updateStateAndCleanupOnErr(err, e)
- return Result{Err: err}, err
+ return Result{}, err
}
}
return Result{PGTag: s.StatementTag()}, nil
@@ -1136,7 +1132,7 @@ func (e *Executor) execStmtInOpenTxn(
}
log.ErrEventf(session.context, "ERROR: %v", err)
txnState.updateStateAndCleanupOnErr(err, e)
- return Result{Err: err}, err
+ return Result{}, err
}
tResult := &traceResult{tag: result.PGTag, count: -1}
@@ -1158,7 +1154,7 @@ func (e *Executor) execStmtInOpenTxn(
func (e *Executor) noTransactionHelper(txnState *txnState) (Result, error) {
// Clean up the KV txn and set the SQL state to Aborted.
txnState.updateStateAndCleanupOnErr(errNoTransactionInProgress, e)
- return Result{Err: errNoTransactionInProgress}, errNoTransactionInProgress
+ return Result{}, errNoTransactionInProgress
}
// rollbackSQLTransaction rolls back a transaction. All errors are swallowed.
@@ -1213,7 +1209,6 @@ func commitSQLTransaction(
// here. We ignore all of this here and do regular cleanup. A higher layer
// handles closing the txn if the auto-retry doesn't get rid of the error.
txnState.updateStateAndCleanupOnErr(err, e)
- result.Err = err
} else {
switch commitType {
case release:
diff --git a/pkg/sql/planner.go b/pkg/sql/planner.go
index 180527f62f91..6d510562a7e8 100644
--- a/pkg/sql/planner.go
+++ b/pkg/sql/planner.go
@@ -226,7 +226,6 @@ func (p *planner) runShowTransactionState(txnState *txnState, implicitTxn bool)
}
if _, err := result.Rows.AddRow(parser.DTuple{parser.NewDString(state.String())}); err != nil {
result.Rows.Close()
- result.Err = err
return result, err
}
return result, nil
|
8ccf6a9a3bac32a4de820b7fba757f9e9353f4d2
|
2021-08-26 03:25:59
|
sumeerbhola
|
admission: simplify ioLoadListener token calculation
| false
|
simplify ioLoadListener token calculation
|
admission
|
diff --git a/pkg/util/admission/granter.go b/pkg/util/admission/granter.go
index 84515f414d85..fcc2d3c1abd6 100644
--- a/pkg/util/admission/granter.go
+++ b/pkg/util/admission/granter.go
@@ -1208,9 +1208,9 @@ func (sgc *StoreGrantCoordinators) initGrantCoordinator(storeID int32) *GrantCoo
storeID: storeID,
settings: sgc.settings,
kvRequester: coord.queues[KVWork],
- mu: &coord.mu,
- kvGranter: coord.granters[KVWork].(*kvGranter),
}
+ coord.ioLoadListener.mu.Mutex = &coord.mu
+ coord.ioLoadListener.mu.kvGranter = coord.granters[KVWork].(*kvGranter)
return coord
}
@@ -1379,9 +1379,12 @@ type ioLoadListener struct {
storeID int32
settings *cluster.Settings
kvRequester requester
- // mu is used when changing state in kvGranter.
- mu *syncutil.Mutex
- kvGranter granterWithIOTokens
+ mu struct {
+ // Used when changing state in kvGranter. This is a pointer since it is
+ // the same as GrantCoordinator.mu.
+ *syncutil.Mutex
+ kvGranter granterWithIOTokens
+ }
// Cumulative stats used to compute interval stats.
statsInitialized bool
@@ -1459,15 +1462,28 @@ func (io *ioLoadListener) pebbleMetricsTick(m pebble.Metrics) {
// allocateTokensTick gives out 1/adjustmentInterval of the totalTokens every
// 1s.
func (io *ioLoadListener) allocateTokensTick() {
- toAllocate := int64(math.Ceil(float64(io.totalTokens) / adjustmentInterval))
- if io.totalTokens != unlimitedTokens && toAllocate+io.tokensAllocated > io.totalTokens {
- toAllocate = io.totalTokens - io.tokensAllocated
+ var toAllocate int64
+ if io.totalTokens == unlimitedTokens {
+ toAllocate = io.totalTokens / adjustmentInterval
+ } else {
+ // Round up so that we don't accumulate tokens to give in a burst on the
+ // last tick.
+ toAllocate = (io.totalTokens + adjustmentInterval - 1) / adjustmentInterval
+ if toAllocate < 0 {
+ panic(errors.AssertionFailedf("toAllocate is negative %d", toAllocate))
+ }
+ if toAllocate+io.tokensAllocated > io.totalTokens {
+ toAllocate = io.totalTokens - io.tokensAllocated
+ }
}
if toAllocate > 0 {
io.mu.Lock()
defer io.mu.Unlock()
io.tokensAllocated += toAllocate
- io.kvGranter.setAvailableIOTokensLocked(toAllocate)
+ if io.tokensAllocated < 0 {
+ panic(errors.AssertionFailedf("tokens allocated is negative %d", io.tokensAllocated))
+ }
+ io.mu.kvGranter.setAvailableIOTokensLocked(toAllocate)
}
}
diff --git a/pkg/util/admission/granter_test.go b/pkg/util/admission/granter_test.go
index fe2605929b6c..b6c694385b7e 100644
--- a/pkg/util/admission/granter_test.go
+++ b/pkg/util/admission/granter_test.go
@@ -299,7 +299,7 @@ func (g *testGranterWithIOTokens) setAvailableIOTokensLocked(tokens int64) {
fmt.Fprintf(&g.buf, "setAvailableIOTokens: %s", tokensFor1sToString(tokens))
}
-func tokensFor60sToString(tokens int64) string {
+func tokensForIntervalToString(tokens int64) string {
if tokens == unlimitedTokens {
return "unlimited"
}
@@ -307,9 +307,7 @@ func tokensFor60sToString(tokens int64) string {
}
func tokensFor1sToString(tokens int64) string {
- // ioLoadListener works with floats, so we just approximate the unlimited
- // calculation here.
- if tokens >= (unlimitedTokens/adjustmentInterval - 15) {
+ if tokens >= unlimitedTokens/adjustmentInterval {
return "unlimited"
}
return fmt.Sprintf("%d", tokens)
@@ -350,13 +348,13 @@ func TestIOLoadListener(t *testing.T) {
ioll = &ioLoadListener{
settings: st,
kvRequester: req,
- // The mutex is needed by ioLoadListener but is not useful in this
- // test -- the channels provide synchronization and prevent this
- // test code and the ioLoadListener from being concurrently
- // active.
- mu: &syncutil.Mutex{},
- kvGranter: kvGranter,
}
+ // The mutex is needed by ioLoadListener but is not useful in this
+ // test -- the channels provide synchronization and prevent this
+ // test code and the ioLoadListener from being concurrently
+ // active.
+ ioll.mu.Mutex = &syncutil.Mutex{}
+ ioll.mu.kvGranter = kvGranter
}
ioll.pebbleMetricsTick(metrics)
// Do the ticks until just before next adjustment.
@@ -364,7 +362,7 @@ func TestIOLoadListener(t *testing.T) {
fmt.Fprintf(&buf, "admitted: %d, bytes: %d, added-bytes: %d,\nsmoothed-removed: %d, "+
"smoothed-admit: %d,\ntokens: %s, tokens-allocated: %s\n", ioll.admittedCount,
ioll.l0Bytes, ioll.l0AddedBytes, ioll.smoothedBytesRemoved,
- int64(ioll.smoothedNumAdmit), tokensFor60sToString(ioll.totalTokens),
+ int64(ioll.smoothedNumAdmit), tokensForIntervalToString(ioll.totalTokens),
tokensFor1sToString(ioll.tokensAllocated))
for i := 0; i < adjustmentInterval; i++ {
ioll.allocateTokensTick()
|
00489364c4bfdfeb48b5438ec0abb11775d1bfce
|
2022-02-26 00:06:26
|
rharding6373
|
sql: update tpcc and tpch stats
| false
|
update tpcc and tpch stats
|
sql
|
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpcc b/pkg/sql/opt/memo/testdata/stats_quality/tpcc
index 2cb13903260d..4dbaa70fb26a 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpcc
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpcc
@@ -23,7 +23,7 @@ project
├── save-table-name: new_order_01_project_1
├── columns: w_tax:8(decimal)
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(8)=1, null(8)=0, avgsize(8)=4]
+ ├── stats: [rows=1, distinct(8)=1, null(8)=0, avgsize(8)=6]
├── key: ()
├── fd: ()-->(8)
└── scan warehouse
@@ -31,7 +31,7 @@ project
├── columns: w_id:1(int!null) w_tax:8(decimal)
├── constraint: /1: [/1 - /1]
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=4, distinct(8)=1, null(8)=0, avgsize(8)=4]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=1, distinct(8)=1, null(8)=0, avgsize(8)=6]
├── key: ()
└── fd: ()-->(1,8)
@@ -56,7 +56,7 @@ project
├── save-table-name: new_order_02_project_1
├── columns: c_discount:16(decimal) c_last:6(varchar) c_credit:14(char)
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(6)=0.999502, null(6)=0, avgsize(6)=4, distinct(14)=0.78694, null(14)=0, avgsize(14)=4, distinct(16)=0.999902, null(16)=0, avgsize(16)=4]
+ ├── stats: [rows=1, distinct(6)=0.999502, null(6)=0, avgsize(6)=14, distinct(14)=0.78694, null(14)=0, avgsize(14)=4, distinct(16)=0.999902, null(16)=0, avgsize(16)=6]
├── key: ()
├── fd: ()-->(6,14,16)
└── scan customer
@@ -64,7 +64,7 @@ project
├── columns: c_id:1(int!null) c_d_id:2(int!null) c_w_id:3(int!null) c_last:6(varchar) c_credit:14(char) c_discount:16(decimal)
├── constraint: /3/2/1: [/1/1/50 - /1/1/50]
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(6)=0.999502, null(6)=0, avgsize(6)=4, distinct(14)=0.78694, null(14)=0, avgsize(14)=4, distinct(16)=0.999902, null(16)=0, avgsize(16)=4, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=12]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(6)=0.999502, null(6)=0, avgsize(6)=14, distinct(14)=0.78694, null(14)=0, avgsize(14)=4, distinct(16)=0.999902, null(16)=0, avgsize(16)=6, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=5]
├── key: ()
└── fd: ()-->(1-3,6,14,16)
@@ -111,7 +111,7 @@ scan item
│ ├── [/275 - /275]
│ └── [/300 - /300]
├── cardinality: [0 - 12]
- ├── stats: [rows=12, distinct(1)=12, null(1)=0, avgsize(1)=4, distinct(3)=11.8958, null(3)=0, avgsize(3)=4, distinct(4)=11.9934, null(4)=0, avgsize(4)=4, distinct(5)=11.9946, null(5)=0, avgsize(5)=4]
+ ├── stats: [rows=12, distinct(1)=12, null(1)=0, avgsize(1)=4, distinct(3)=11.8958, null(3)=0, avgsize(3)=22, distinct(4)=11.9934, null(4)=0, avgsize(4)=6, distinct(5)=11.9946, null(5)=0, avgsize(5)=41]
├── key: (1)
├── fd: (1)-->(3-5)
└── ordering: +1
@@ -142,7 +142,7 @@ project
├── save-table-name: new_order_04_project_1
├── columns: s_quantity:3(int) s_ytd:14(int) s_order_cnt:15(int) s_remote_cnt:16(int) s_data:17(varchar) s_dist_05:8(char) [hidden: s_i_id:1(int!null)]
├── cardinality: [0 - 5]
- ├── stats: [rows=5, distinct(1)=5, null(1)=0, avgsize(1)=4, distinct(3)=4.86513, null(3)=0, avgsize(3)=4, distinct(8)=4.80371, null(8)=0, avgsize(8)=4, distinct(14)=0.993262, null(14)=0, avgsize(14)=4, distinct(15)=0.993262, null(15)=0, avgsize(15)=4, distinct(16)=0.993262, null(16)=0, avgsize(16)=4, distinct(17)=4.99973, null(17)=0, avgsize(17)=4]
+ ├── stats: [rows=5, distinct(1)=5, null(1)=0, avgsize(1)=4, distinct(3)=4.86513, null(3)=0, avgsize(3)=3, distinct(8)=4.80371, null(8)=0, avgsize(8)=26, distinct(14)=0.993262, null(14)=0, avgsize(14)=2, distinct(15)=0.993262, null(15)=0, avgsize(15)=2, distinct(16)=0.993262, null(16)=0, avgsize(16)=2, distinct(17)=4.99973, null(17)=0, avgsize(17)=40]
├── key: (1)
├── fd: (1)-->(3,8,14-17)
├── ordering: +1
@@ -156,7 +156,7 @@ project
│ ├── [/4/1400 - /4/1400]
│ └── [/4/1500 - /4/1500]
├── cardinality: [0 - 5]
- ├── stats: [rows=5, distinct(1)=5, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=4.86513, null(3)=0, avgsize(3)=4, distinct(8)=4.80371, null(8)=0, avgsize(8)=4, distinct(14)=0.993262, null(14)=0, avgsize(14)=4, distinct(15)=0.993262, null(15)=0, avgsize(15)=4, distinct(16)=0.993262, null(16)=0, avgsize(16)=4, distinct(17)=4.99973, null(17)=0, avgsize(17)=4, distinct(1,2)=5, null(1,2)=0, avgsize(1,2)=8]
+ ├── stats: [rows=5, distinct(1)=5, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=4.86513, null(3)=0, avgsize(3)=3, distinct(8)=4.80371, null(8)=0, avgsize(8)=26, distinct(14)=0.993262, null(14)=0, avgsize(14)=2, distinct(15)=0.993262, null(15)=0, avgsize(15)=2, distinct(16)=0.993262, null(16)=0, avgsize(16)=2, distinct(17)=4.99973, null(17)=0, avgsize(17)=40, distinct(1,2)=5, null(1,2)=0, avgsize(1,2)=5]
├── key: (1)
├── fd: ()-->(2), (1)-->(3,8,14-17)
└── ordering: +1 opt(2) [actual: +1]
@@ -203,7 +203,7 @@ ORDER BY c_first ASC
project
├── save-table-name: payment_01_project_1
├── columns: c_id:1(int!null) [hidden: c_first:4(varchar)]
- ├── stats: [rows=2.02643, distinct(1)=2.02575, null(1)=0, avgsize(1)=4, distinct(4)=2.02276, null(4)=0, avgsize(4)=4]
+ ├── stats: [rows=2.198952, distinct(1)=2.19815, null(1)=0, avgsize(1)=3, distinct(4)=2.19463, null(4)=0, avgsize(4)=14]
├── key: (1)
├── fd: (1)-->(4)
├── ordering: +4
@@ -211,12 +211,12 @@ project
├── save-table-name: payment_01_scan_2
├── columns: c_id:1(int!null) c_d_id:2(int!null) c_w_id:3(int!null) c_first:4(varchar) c_last:6(varchar!null)
├── constraint: /3/2/6/4/1: [/1/1/'ANTIABLEABLE' - /1/1/'ANTIABLEABLE']
- ├── stats: [rows=2.02643, distinct(1)=2.02575, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(4)=2.02276, null(4)=0, avgsize(4)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(2,3,6)=1, null(2,3,6)=0, avgsize(2,3,6)=12]
- │ histogram(2)= 0 2.0264
- │ <---- 1 --
- │ histogram(3)= 0 2.0264
- │ <---- 1 --
- │ histogram(6)= 0 2.0264
+ ├── stats: [rows=2.198952, distinct(1)=2.19815, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(4)=2.19463, null(4)=0, avgsize(4)=14, distinct(6)=1, null(6)=0, avgsize(6)=14, distinct(2,3,6)=1, null(2,3,6)=0, avgsize(2,3,6)=16]
+ │ histogram(2)= 0 2.199
+ │ <---- 1 -
+ │ histogram(3)= 0 2.199
+ │ <---- 1 -
+ │ histogram(6)= 0 2.199
│ <--- 'ANTIABLEABLE'
├── key: (1)
├── fd: ()-->(2,3,6), (1)-->(4)
@@ -258,7 +258,7 @@ project
├── save-table-name: order_status_01_project_1
├── columns: c_balance:17(decimal) c_first:4(varchar) c_middle:5(char) c_last:6(varchar)
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(4)=0.999106, null(4)=0, avgsize(4)=4, distinct(5)=0.632121, null(5)=0, avgsize(5)=4, distinct(6)=0.999502, null(6)=0, avgsize(6)=4, distinct(17)=0.632121, null(17)=0, avgsize(17)=4]
+ ├── stats: [rows=1, distinct(4)=0.999106, null(4)=0, avgsize(4)=14, distinct(5)=0.632121, null(5)=0, avgsize(5)=4, distinct(6)=0.999502, null(6)=0, avgsize(6)=14, distinct(17)=0.632121, null(17)=0, avgsize(17)=6]
├── key: ()
├── fd: ()-->(4-6,17)
└── scan customer
@@ -266,7 +266,7 @@ project
├── columns: c_id:1(int!null) c_d_id:2(int!null) c_w_id:3(int!null) c_first:4(varchar) c_middle:5(char) c_last:6(varchar) c_balance:17(decimal)
├── constraint: /3/2/1: [/1/1/50 - /1/1/50]
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(4)=0.999106, null(4)=0, avgsize(4)=4, distinct(5)=0.632121, null(5)=0, avgsize(5)=4, distinct(6)=0.999502, null(6)=0, avgsize(6)=4, distinct(17)=0.632121, null(17)=0, avgsize(17)=4, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=12]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(4)=0.999106, null(4)=0, avgsize(4)=14, distinct(5)=0.632121, null(5)=0, avgsize(5)=4, distinct(6)=0.999502, null(6)=0, avgsize(6)=14, distinct(17)=0.632121, null(17)=0, avgsize(17)=6, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=5]
├── key: ()
└── fd: ()-->(1-6,17)
@@ -301,19 +301,19 @@ ORDER BY c_first ASC
project
├── save-table-name: order_status_02_project_1
├── columns: c_id:1(int!null) c_balance:17(decimal) c_first:4(varchar) c_middle:5(char)
- ├── stats: [rows=1.940592, distinct(1)=1.93997, null(1)=0, avgsize(1)=4, distinct(4)=1.93723, null(4)=0, avgsize(4)=4, distinct(5)=0.856382, null(5)=0, avgsize(5)=4, distinct(17)=0.856382, null(17)=0, avgsize(17)=4]
+ ├── stats: [rows=2.092573, distinct(1)=2.09185, null(1)=0, avgsize(1)=3, distinct(4)=2.08866, null(4)=0, avgsize(4)=14, distinct(5)=0.876632, null(5)=0, avgsize(5)=4, distinct(17)=0.876632, null(17)=0, avgsize(17)=6]
├── key: (1)
├── fd: (1)-->(4,5,17)
├── ordering: +4
└── index-join customer
├── save-table-name: order_status_02_index_join_2
├── columns: c_id:1(int!null) c_d_id:2(int!null) c_w_id:3(int!null) c_first:4(varchar) c_middle:5(char) c_last:6(varchar!null) c_balance:17(decimal)
- ├── stats: [rows=1.940592, distinct(1)=1.93997, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(4)=1.93723, null(4)=0, avgsize(4)=4, distinct(5)=0.856382, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(17)=0.856382, null(17)=0, avgsize(17)=4, distinct(2,3,6)=1, null(2,3,6)=0, avgsize(2,3,6)=12]
- │ histogram(2)= 0 1.9406
+ ├── stats: [rows=2.092573, distinct(1)=2.09185, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(4)=2.08866, null(4)=0, avgsize(4)=14, distinct(5)=0.876632, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=14, distinct(17)=0.876632, null(17)=0, avgsize(17)=6, distinct(2,3,6)=1, null(2,3,6)=0, avgsize(2,3,6)=16]
+ │ histogram(2)= 0 2.0926
│ <---- 2 --
- │ histogram(3)= 0 1.9406
+ │ histogram(3)= 0 2.0926
│ <---- 2 --
- │ histogram(6)= 0 1.9406
+ │ histogram(6)= 0 2.0926
│ <--- 'ANTIBARESE'
├── key: (1)
├── fd: ()-->(2,3,6), (1)-->(4,5,17)
@@ -322,16 +322,16 @@ project
├── save-table-name: order_status_02_scan_3
├── columns: c_id:1(int!null) c_d_id:2(int!null) c_w_id:3(int!null) c_first:4(varchar) c_last:6(varchar!null)
├── constraint: /3/2/6/4/1: [/2/2/'ANTIBARESE' - /2/2/'ANTIBARESE']
- ├── stats: [rows=1.940592, distinct(1)=1.93997, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(4)=1.93723, null(4)=0, avgsize(4)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(2,3,6)=1, null(2,3,6)=0, avgsize(2,3,6)=12]
- │ histogram(1)= 0 0.00058218 0.0093148 0.0015525 0.0091208 0.00058218 0.0095089 0.00058218 0.0089267 0.00077624 0.0095089 0.00077624 0.0091208 0.00058218 0.0093148 0.00058218 0.0095089 0.0009703 0.0091208 0.0011644 0.0095089 0.00019406 0.0095089 0.00038812 0.0081505 0.0019406 0.0087327 0.0013584 0.0093148 0.0009703 0.0093148 0.00077624 0.0087327 0.0013584 0.0089267 0.00077624 0.0093148 0.0009703 0.0095089 0.00038812 0.0087327 0.0011644 0.0085386 0.0011644 0.0091208 0.0013584 0.0089267 0.00077624 0.0083445 0.0013584 0.0095089 0.00038812 0.0095089 0.00077624 0.0095089 0.00058218 0.0091208 0.00058218 0.0095089 0.0011644 0.0089267 0.00058218 0.0087327 0.00077624 0.0089267 0.0011644 0.0089267 0.00058218 0.0093148 0.0011644 0.0085386 0.0011644 0.0093148 0.00058218 0.0093148 0.00019406 0.0083445 0.0011644 0.0093148 0.00077624 0.0091208 0.00058218 0.0091208 0.00038812 0.0089267 0.0009703 0.0091208 0.00077624 0.0087327 0.0011644 0.0091208 0.00038812 0.0091208 0.00058218 0.0093148 0.00019406 0.0085386 0.0009703 0.0085386 0.0011644 0.0083445 0.0011644 0.0087327 0.00077624 0.0091208 0.0009703 0.0093148 0.00077624 0.0093148 0.00038812 0.0091208 0.00077624 0.0087327 0.0015525 0.0091208 0.00058218 0.0081505 0.0015525 0.0089267 0.0011644 0.0093148 0.0011644 0.0093148 0.0013584 0.0091208 0.00077624 0.0089267 0.0015525 0.0091208 0.00077624 0.0093148 0.00058218 0.0093148 0.00038812 0.0093148 0.00058218 0.0089267 0.00058218 0.0081505 0.0013584 0.0093148 0.0009703 0.0085386 0.0013584 0.0091208 0.0009703 0.0093148 0.00019406 0.0093148 0.00058218 0.0087327 0.00077624 0.0093148 0.00038812 0.0093148 0.00077624 0.0079564 0.0017465 0.0091208 0.00077624 0.0091208 0.00058218 0.0089267 0.00077624 0.0085386 0.0011644 0.0093148 0.00038812 0.0091208 0.0009703 0.0091208 0.0011644 0.0087327 0.0013584 0.0093148 0.0009703 0.0093148 0.0013584 0.0091208 0.00038812 0.0089267 0.00077624 0.0091208 0.00058218 0.0091208 0.00058218 0.0093148 0.00077624 0.0091208 0.00058218 0.0089267 0.00058218 0.0089267 0.0009703 0.0091208 0.00038812 0.0093148 0.0009703 0.0091208 0.00058218 0.0093148 0.0011644 0.0089267 0.0009703 0.0089267 0.0015525 0.0093148 0.00058218 0.0093148 0.00038812 0.0089267 0.00058218 0.0085386 0.0009703 0.0091208 0.00038812 0.0089267 0.0013584 0.0089267 0.00077624 0.0087327 0.00077624 0.0089267 0.00077624 0.0085386 0.0009703 0.0087327 0.00077624 0.0091208 0.00058218 0.0093148 0.00038812 0.0093148 0.0011644 0.0091208 0.00058218 0.0085386 0.0011644 0.0089267 0.00058218 0.0089267 0.00058218 0.0091208 0.00038812 0.0091208 0.00038812 0.0093148 0.00058218 0.0091208 0.0011644 0.0085386 0.0011644 0.0093148 0.00058218 0.0093148 0.0011644 0.0091208 0.00077624 0.0083445 0.0013584 0.0091208 0.0017465 0.0087327 0.0013584 0.0081505 0.0011644 0.0089267 0.00058218 0.0087327 0.00077624 0.0091208 0.00077624 0.0091208 0.00019406 0.0089267 0.00058218 0.0087327 0.00058218 0.0091208 0.00019406 0.0085386 0.0015525 0.0091208 0.00077624 0.0087327 0.00058218 0.0089267 0.00058218 0.0083445 0.0011644 0.0087327 0.00058218 0.0091208 0.00019406 0.0087327 0.00058218 0.0085386 0.00077624 0.0087327 0.00058218 0.0089267 0.00077624 0.0091208 0.00058218 0.0089267 0.00058218 0.0085386 0.0009703 0.0091208 0.00019406 0.0089267 0.00038812 0.0083445 0.0009703 0.0089267 0.00058218 0.0087327 0.00058218 0.0085386 0.0011644 0.0079564 0.0013584 0.0089267 0.00038812 0.0079564 0.0013584 0.0085386 0.0009703 0.0087327 0.00058218 0.0091208 0.00038812 0.0091208 0.00058218 0.0091208 0.00038812 0.0089267 0.00038812 0.0091208 0.00038812 0.0089267 0.0009703 0.0085386 0.00077624 0.0087327 0.0009703 0.0091208 0.0013584 0.0087327 0.0011644 0.0087327 0.0011644 0.0089267 0.0009703 0.0089267 0.00077624 0.0089267 0.00058218 0.0089267 0.00077624 0.0085386 0.00077624 0.0085386 0.0009703 0.0083445 0.0009703 0.0089267 0.00077624 0.0085386 0.0013584 0.0085386 0.00077624 0.0081505 0.0009703 0.0087327 0.00077624 0.0081505 0.0009703 0.0089267 0.00038812 0.0085386 0.00058218 0.0087327 0.00038812 0.0083445 0.00077624 0.0087327 0.00077624 0.0085386 0.0013584 0.0083445 0.0009703 0.0087327 0.00077624 0.0079564 0.00077624 0.0081505 0.00077624 0.0079564 0.0009703
- │ <------ 1 ----------------- 14 ----------------- 30 ----------------- 44 ----------------- 59 ----------------- 74 ----------------- 94 ---------------- 113 ---------------- 130 --------------- 148 --------------- 164 ---------------- 178 ---------------- 189 --------------- 207 --------------- 222 --------------- 240 ---------------- 257 --------------- 270 ---------------- 283 --------------- 296 ---------------- 312 --------------- 326 --------------- 341 --------------- 355 ---------------- 368 --------------- 382 ---------------- 400 ---------------- 414 ---------------- 433 ---------------- 448 --------------- 460 ---------------- 472 ---------------- 486 --------------- 503 ---------------- 520 --------------- 533 --------------- 548 ---------------- 563 ---------------- 577 --------------- 590 ---------------- 605 ---------------- 620 ---------------- 633 --------------- 648 ---------------- 662 --------------- 676 ---------------- 693 ---------------- 710 ---------------- 722 --------------- 738 --------------- 752 --------------- 767 ---------------- 784 --------------- 800 ---------------- 815 ---------------- 825 ---------------- 839 --------------- 853 ---------------- 867 --------------- 881 --------------- 895 --------------- 915 --------------- 928 ---------------- 942 --------------- 958 ---------------- 975 ---------------- 991 ---------------- 1008 --------------- 1023 -------------- 1036 -------------- 1053 -------------- 1067 -------------- 1083 --------------- 1099 --------------- 1116 --------------- 1134 --------------- 1146 --------------- 1165 -------------- 1184 --------------- 1200 --------------- 1217 --------------- 1230 -------------- 1247 --------------- 1260 -------------- 1276 -------------- 1288 -------------- 1301 -------------- 1315 -------------- 1328 --------------- 1344 --------------- 1361 --------------- 1377 --------------- 1391 --------------- 1410 --------------- 1424 --------------- 1440 -------------- 1455 --------------- 1470 -------------- 1486 --------------- 1502 -------------- 1514 -------------- 1528 -------------- 1541 --------------- 1558 --------------- 1574 --------------- 1587 -------------- 1602 --------------- 1618 -------------- 1632 --------------- 1646 --------------- 1657 --------------- 1670 -------------- 1687 --------------- 1702 --------------- 1719 --------------- 1735 -------------- 1750 --------------- 1765 -------------- 1781 --------------- 1799 --------------- 1816 --------------- 1835 --------------- 1851 --------------- 1868 -------------- 1881 -------------- 1897 --------------- 1910 -------------- 1923 --------------- 1939 -------------- 1954 -------------- 1965 -------------- 1979 -------------- 1993 --------------- 2008 --------------- 2020 --------------- 2034 --------------- 2048 --------------- 2066 --------------- 2081 --------------- 2097 -------------- 2110 --------------- 2130 --------------- 2144 --------------- 2159 -------------- 2175 --------------- 2191 --------------- 2208 --------------- 2224 --------------- 2243 --------------- 2258 --------------- 2271 --------------- 2282 --------------- 2295 -------------- 2308 --------------- 2322 --------------- 2336 -------------- 2350 --------------- 2366 --------------- 2382 -------------- 2400 -------------- 2412 --------------- 2428 -------------- 2444 -------------- 2456 --------------- 2466 --------------- 2481 --------------- 2496 --------------- 2511 --------------- 2524 --------------- 2537 -------------- 2553 --------------- 2566 -------------- 2582 -------------- 2597 -------------- 2609 -------------- 2625 -------------- 2644 --------------- 2659 --------------- 2675 --------------- 2690 --------------- 2706 -------------- 2723 -------------- 2739 --------------- 2752 -------------- 2768 --------------- 2782 -------------- 2797 --------------- 2813 -------------- 2829 --------------- 2845 --------------- 2858 --------------- 2875 --------------- 2894 --------------- 2905 -------------- 2922 -------------- 2935 --------------- 2954 --------------- 2969 --------------- 2987 -------------- 3000 --
- │ histogram(2)= 0 1.9406
+ ├── stats: [rows=2.092573, distinct(1)=2.09185, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(4)=2.08866, null(4)=0, avgsize(4)=14, distinct(6)=1, null(6)=0, avgsize(6)=14, distinct(2,3,6)=1, null(2,3,6)=0, avgsize(2,3,6)=16]
+ │ histogram(1)= 0 0.0010463 0.0096258 0.00083703 0.010254 0.0014648 0.010044 0.0010463 0.010254 0.00041851 0.0096258 0.00083703 0.0094166 0.0010463 0.010254 0.00062777 0.010254 0.00041851 0.010254 0.00062777 0.010254 0.00062777 0.010044 0.0010463 0.0098351 0.0016741 0.010254 0.00041851 0.010254 0.00041851 0.010254 0.00062777 0.010044 0.00062777 0.010044 0.00041851 0.0098351 0.00062777 0.0096258 0.0014648 0.010044 0.00083703 0.010254 0.00062777 0.010254 0.00062777 0.0092073 0.0014648 0.0098351 0.00083703 0.0098351 0.00062777 0.010044 0.00041851 0.0096258 0.0010463 0.0096258 0.00083703 0.010044 0.0012555 0.0096258 0.00083703 0.0098351 0.00041851 0.010044 0.00062777 0.0096258 0.00062777 0.0098351 0.0010463 0.010044 0.0014648 0.010044 0.00041851 0.010044 0.00062777 0.0092073 0.0012555 0.010044 0.00020926 0.010044 0.00083703 0.0094166 0.0018833 0.0096258 0.0010463 0.010044 0.00020926 0.0096258 0.00083703 0.0092073 0.0016741 0.0092073 0.0010463 0.0096258 0.00083703 0.0089981 0.0012555 0.0098351 0.00062777 0.010044 0.00041851 0.010044 0.0012555 0.0098351 0.0010463 0.0092073 0.0016741 0.0094166 0.0012555 0.010044 0.0010463 0.0098351 0.00083703 0.0094166 0.0010463 0.010044 0.0012555 0.010044 0.0010463 0.0098351 0.0010463 0.0089981 0.0012555 0.0098351 0.0010463 0.0094166 0.0012555 0.0096258 0.0012555 0.010044 0.00020926 0.0096258 0.00062777 0.010044 0.00020926 0.010044 0.00083703 0.010044 0.00062777 0.0096258 0.0010463 0.010044 0.00062777 0.0096258 0.00062777 0.0089981 0.0012555 0.0094166 0.00083703 0.0096258 0.00062777 0.0098351 0.00041851 0.0094166 0.0010463 0.0089981 0.0012555 0.0094166 0.00083703 0.0092073 0.0018833 0.010044 0.00041851 0.010044 0.0010463 0.0094166 0.0012555 0.0098351 0.00083703 0.0089981 0.0014648 0.0098351 0.00062777 0.010044 0.00062777 0.0098351 0.00062777 0.010044 0.00083703 0.0096258 0.0012555 0.0094166 0.00083703 0.010044 0.0010463 0.010044 0.00062777 0.0098351 0.00041851 0.010044 0.0014648 0.0092073 0.0012555 0.0092073 0.0012555 0.0098351 0.00041851 0.0098351 0.00041851 0.0096258 0.00062777 0.0096258 0.0010463 0.0096258 0.0012555 0.010044 0.00062777 0.0098351 0.00041851 0.010044 0.00083703 0.0096258 0.00083703 0.0098351 0.00041851 0.0096258 0.00083703 0.0092073 0.0018833 0.0089981 0.0020926 0.010044 0.0012555 0.010044 0.00062777 0.0094166 0.0012555 0.0096258 0.0014648 0.0096258 0.0010463 0.0089981 0.0012555 0.0092073 0.0014648 0.0092073 0.0012555 0.0098351 0.0010463 0.0096258 0.00083703 0.0094166 0.0010463 0.010044 0.00083703 0.0098351 0.00083703 0.0098351 0.0012555 0.0089981 0.0010463 0.0096258 0.0012555 0.0094166 0.00083703 0.0092073 0.0012555 0.0098351 0.0010463 0.0092073 0.0010463 0.0096258 0.0016741 0.0096258 0.0010463 0.0096258 0.00062777 0.0087888 0.0012555 0.0096258 0.00083703 0.0089981 0.0010463 0.0094166 0.00083703 0.0085795 0.0018833 0.0098351 0.0014648 0.0092073 0.0010463 0.0096258 0.00062777 0.0094166 0.0010463 0.0096258 0.0010463 0.0094166 0.00083703 0.0092073 0.00083703 0.0094166 0.00083703 0.0092073 0.00083703 0.0096258 0.00062777 0.0098351 0.00062777 0.0094166 0.0012555 0.0096258 0.00062777 0.0098351 0.00041851 0.0098351 0.00083703 0.0098351 0.00062777 0.0096258 0.00041851 0.0096258 0.00083703 0.0096258 0.00041851 0.0094166 0.00083703 0.0085795 0.0014648 0.0098351 0.0012555 0.0096258 0.00041851 0.0096258 0.0010463 0.0098351 0.00083703 0.0094166 0.0010463 0.0096258 0.0010463 0.0092073 0.0010463 0.0096258 0.00062777 0.0089981 0.0010463 0.0096258 0.00041851 0.0089981 0.00083703 0.0085795 0.0014648 0.0096258 0.00083703 0.0096258 0.00041851 0.0094166 0.00083703 0.0085795 0.0012555 0.0092073 0.00083703 0.0096258 0.00062777 0.0092073 0.00083703 0.0085795 0.0012555 0.0089981 0.0010463 0.0092073 0.00083703 0.0089981 0.0010463 0.0085795 0.0014648 0.0096258 0.00083703 0.0092073 0.00062777 0.0096258 0.00041851 0.0096258 0.0010463 0.0092073 0.00083703 0.0096258 0.00041851 0.0094166 0.0010463 0.0092073 0.00041851 0.0092073 0.00083703 0.0089981 0.00083703 0.0094166 0.00083703 0.0092073 0.00083703 0.0087888 0.00062777 0.008161 0.0016741 0.0083703 0.0014648 0.0079518 0.0010463
+ │ <------ 1 ----------------- 17 --------------- 37 --------------- 55 ---------------- 70 ----------------- 85 ---------------- 101 -------------- 115 --------------- 127 --------------- 144 --------------- 159 --------------- 173 --------------- 191 -------------- 206 --------------- 222 --------------- 236 --------------- 254 --------------- 272 ---------------- 286 ---------------- 303 -------------- 317 --------------- 333 --------------- 348 ---------------- 361 --------------- 377 ---------------- 390 --------------- 408 ---------------- 421 --------------- 433 --------------- 450 --------------- 466 ---------------- 479 --------------- 491 ---------------- 507 ---------------- 518 -------------- 533 -------------- 544 --------------- 559 ---------------- 570 -------------- 585 --------------- 602 ---------------- 615 --------------- 630 -------------- 646 ---------------- 664 ---------------- 679 --------------- 694 --------------- 711 ---------------- 725 --------------- 737 --------------- 752 --------------- 767 --------------- 782 --------------- 794 --------------- 806 -------------- 824 --------------- 838 ---------------- 854 -------------- 869 -------------- 885 --------------- 902 --------------- 916 --------------- 930 --------------- 945 --------------- 961 -------------- 974 ---------------- 986 --------------- 1001 -------------- 1018 -------------- 1032 -------------- 1048 -------------- 1069 --------------- 1082 -------------- 1095 --------------- 1109 --------------- 1123 --------------- 1143 -------------- 1160 -------------- 1176 --------------- 1193 -------------- 1207 -------------- 1220 ------------- 1236 -------------- 1249 --------------- 1266 -------------- 1280 --------------- 1292 -------------- 1308 --------------- 1326 -------------- 1341 -------------- 1352 --------------- 1366 ------------- 1381 -------------- 1397 --------------- 1412 ------------- 1427 -------------- 1441 -------------- 1454 --------------- 1471 --------------- 1486 --------------- 1499 -------------- 1516 -------------- 1535 -------------- 1551 --------------- 1565 -------------- 1587 --------------- 1602 --------------- 1621 --------------- 1635 -------------- 1649 -------------- 1664 ------------- 1678 -------------- 1694 -------------- 1711 -------------- 1729 -------------- 1741 -------------- 1755 -------------- 1771 -------------- 1786 -------------- 1801 --------------- 1818 -------------- 1834 -------------- 1849 --------------- 1864 -------------- 1883 -------------- 1898 -------------- 1915 --------------- 1931 -------------- 1944 -------------- 1959 -------------- 1974 -------------- 1992 -------------- 2007 --------------- 2024 -------------- 2036 --------------- 2054 -------------- 2070 --------------- 2086 -------------- 2101 -------------- 2119 -------------- 2137 --------------- 2148 -------------- 2161 -------------- 2180 --------------- 2198 --------------- 2213 --------------- 2227 --------------- 2240 --------------- 2255 --------------- 2274 -------------- 2289 --------------- 2303 --------------- 2321 --------------- 2335 --------------- 2350 --------------- 2366 --------------- 2380 --------------- 2391 --------------- 2407 -------------- 2420 -------------- 2434 --------------- 2450 -------------- 2469 --------------- 2489 -------------- 2504 -------------- 2518 -------------- 2530 --------------- 2543 -------------- 2557 --------------- 2572 --------------- 2584 -------------- 2598 --------------- 2614 --------------- 2625 --------------- 2638 -------------- 2650 --------------- 2663 --------------- 2677 --------------- 2691 -------------- 2705 -------------- 2720 --------------- 2735 -------------- 2746 -------------- 2761 --------------- 2776 --------------- 2789 --------------- 2804 -------------- 2821 --------------- 2837 --------------- 2858 -------------- 2872 --------------- 2892 --------------- 2905 --------------- 2919 --------------- 2934 --------------- 2946 --------------- 2959 ------------- 2974 -------------- 2986 -------------- 3000 --
+ │ histogram(2)= 0 2.0926
│ <---- 2 --
- │ histogram(3)= 0 1.9406
+ │ histogram(3)= 0 2.0926
│ <---- 2 --
- │ histogram(4)= 0 0.0031049 0.006598 0.0031049 0.006404 0.0034931 0.0091208 0.003299 0.0091208 0.003299 0.0073742 0.0048515 0.0087327 0.0015525 0.0081505 0.0038812 0.0077624 0.0031049 0.0062099 0.003299 0.0077624 0.0040752 0.0056277 0.0048515 0.0085386 0.0021347 0.0060158 0.0044634 0.0091208 0.0029109 0.0087327 0.003299 0.0071802 0.0038812 0.0062099 0.0036871 0.0079564 0.003299 0.0058218 0.0040752 0.0067921 0.0036871 0.0085386 0.0027168 0.0089267 0.0038812 0.0071802 0.0023287 0.006598 0.0034931 0.0062099 0.0034931 0.0089267 0.0031049 0.0089267 0.0031049 0.0075683 0.0046574 0.0079564 0.0036871 0.0077624 0.0034931 0.006598 0.0038812 0.0060158 0.0046574 0.0083445 0.0036871 0.006598 0.0048515 0.006598 0.003299 0.0075683 0.0046574 0.0075683 0.0040752 0.0083445 0.0031049 0.0062099 0.0044634 0.0087327 0.003299 0.0067921 0.0029109 0.0081505 0.003299 0.0062099 0.0036871 0.0075683 0.0038812 0.0085386 0.0036871 0.0054337 0.0042693 0.0071802 0.0054337 0.0052396 0.0046574 0.006598 0.0029109 0.0083445 0.003299 0.0079564 0.0046574 0.0083445 0.0040752 0.006404 0.0034931 0.0058218 0.0034931 0.006404 0.0038812 0.0087327 0.0029109 0.0081505 0.003299 0.0089267 0.0034931 0.0073742 0.0021347 0.0073742 0.0025228 0.0071802 0.0040752 0.0058218 0.0040752 0.0062099 0.0031049 0.0073742 0.0038812 0.0071802 0.0034931 0.0075683 0.0042693 0.0077624 0.0038812 0.0075683 0.0036871 0.0062099 0.003299 0.0060158 0.0036871 0.0054337 0.0042693 0.0075683 0.0042693 0.0056277 0.0044634 0.0087327 0.0034931 0.006404 0.0036871 0.0067921 0.0031049 0.0077624 0.003299 0.0062099 0.0029109 0.0077624 0.0044634 0.0071802 0.0042693 0.0077624 0.0031049 0.0079564 0.0038812 0.0083445 0.0017465 0.0079564 0.0044634 0.006404 0.0034931 0.0052396 0.0034931 0.0052396 0.0038812 0.0069861 0.0036871 0.0075683 0.0044634 0.0067921 0.0023287 0.006404 0.0034931 0.0081505 0.0031049 0.0073742 0.0036871 0.0077624 0.0038812 0.0056277 0.0036871 0.0079564 0.0027168 0.0079564 0.0046574 0.0031049 0.0058218 0.0058218 0.0029109 0.0067921 0.0048515 0.0083445 0.0031049 0.006404 0.0044634 0.0058218 0.0031049 0.0073742 0.0027168 0.0081505 0.0040752 0.0075683 0.0031049 0.0077624 0.003299 0.0077624 0.0027168 0.0038812 0.0044634 0.0056277 0.003299 0.006598 0.0048515 0.0058218 0.0029109 0.006598 0.0034931 0.0031049 0.0058218 0.0036871 0.0048515 0.0058218 0.0042693 0.006598 0.0023287 0.0056277 0.003299 0.0073742 0.003299 0.0069861 0.0034931 0.0056277 0.0027168 0.0044634 0.0042693 0.0034931 0.0052396 0.0071802 0.0038812 0.0071802 0.003299 0.006404 0.0044634 0.0048515 0.0031049 0.0067921 0.0027168 0.0067921 0.0036871 0.0073742 0.0034931 0.0075683 0.0034931 0.0071802 0.0040752 0.0056277 0.0034931 0.0069861 0.0029109 0.0075683 0.0044634 0.0040752 0.0042693 0.003299 0.0048515 0.0038812 0.0042693 0.0058218 0.0038812 0.006404 0.0040752 0.006404 0.0025228 0.0042693 0.0038812 0.0046574 0.0029109 0.0060158 0.0050455 0.0040752 0.0036871 0.0060158 0.0034931 0.0060158 0.0023287 0.0069861 0.0042693 0.0046574 0.0052396 0.0067921 0.0034931 0.0058218 0.0027168 0.0058218 0.0031049 0.0034931 0.0044634 0.003299 0.0044634 0.0056277 0.0025228 0.0040752 0.003299 0.0031049 0.0042693 0.0048515 0.0046574 0.0044634 0.0029109 0.0038812 0.003299 0.0067921 0.0038812 0.0050455 0.0019406 0.0038812 0.003299 0.006404 0.0031049 0.0036871 0.0036871 0.0062099 0.0038812 0.006404 0.0054337 0.0040752 0.0046574 0.0036871 0.0042693 0.0040752 0.0036871 0.0046574 0.0025228 0.0034931 0.0046574 0.0038812 0.0034931 0.006404 0.0036871 0.0044634 0.0034931 0.0036871 0.0042693 0.0034931 0.003299 0.003299 0.0036871 0.0042693 0.0038812 0.0048515 0.0046574 0.003299 0.0031049 0.0038812 0.003299 0.0042693 0.0034931 0.0038812 0.0029109 0.0044634 0.0048515 0.0050455 0.0029109 0.0023287 0.0038812 0.0029109 0.003299 0.0038812 0.0038812 0.0027168 0.0023287 0.003299 0.0036871 0.0036871 0.0025228 0.0040752 0.0031049 0 0.0048515 0.0034931 0.0034931 0 0.0044634 0 0.0040752 0 0.0031049
- │ <--- '1U5yraPx' ---------- '1U5yraPxxELo' ---------- '1U5yraPxxELo5B1' ----------- '1fcW8RsaCX' ----------- '1fcW8RsaCXoEz' ----------- '1fcW8RsaCXoEzmss' ----------- '3v1U5yraPxx' ----------- '3v1U5yraPxxELo' ----------- '5B1fcW8Rs' ----------- '5B1fcW8RsaCX' ----------- '5B1fcW8RsaCXoEz' ----------- '5yraPxxEL' ----------- '5yraPxxELo5B1' ----------- '5yraPxxELo5B1fcW' ----------- '6NHnwiwKdcg' ----------- '6NHnwiwKdcgphy3' ----------- '6rumMmp6N' ----------- '6rumMmp6NHnw' ----------- '6rumMmp6NHnwiwK' ----------- '8RsaCXoE' ----------- '8RsaCXoEzmss' ----------- '8RsaCXoEzmssaF9' ----------- '9cdLXe0Yhg' ----------- '9cdLXe0YhgLRr' ---------- '9cdLXe0YhgLRrwsm' ----------- '9m9cdLXe0Y' ----------- '9m9cdLXe0YhgLR' ----------- 'B1fcW8Rsa' ----------- 'B1fcW8RsaCXo' ----------- 'B1fcW8RsaCXoEzm' ----------- 'CXoEzmssaF' ---------- 'CXoEzmssaF9m9' ----------- 'CXoEzmssaF9m9cdL' ----------- 'ELo5B1fcW8' ---------- 'ELo5B1fcW8Rsa' ---------- 'ELo5B1fcW8RsaCXo' ----------- 'EzmssaF9m9c' ----------- 'EzmssaF9m9cdLX' ----------- 'F9m9cdLXe' ----------- 'F9m9cdLXe0Yh' ----------- 'F9m9cdLXe0YhgLR' ----------- 'HnwiwKdcg' ----------- 'HnwiwKdcgphy' ----------- 'HnwiwKdcgphy3v1' ----------- 'Kdcgphy3v' ----------- 'Kdcgphy3v1U5' ----------- 'Kdcgphy3v1U5yr' ----------- 'LXe0YhgLR' ----------- 'LXe0YhgLRrws' ---------- 'LXe0YhgLRrwsmd6' ----------- 'Lo5B1fcW8' ----------- 'Lo5B1fcW8Rsa' ----------- 'Lo5B1fcW8RsaCXo' ---------- 'Mmp6NHnwi' ----------- 'Mmp6NHnwiwKd' ---------- 'Mmp6NHnwiwKdcgp' ----------- 'NHnwiwKdcg' ----------- 'NHnwiwKdcgphy' ----------- 'PxxELo5B' ----------- 'PxxELo5B1fc' ----------- 'PxxELo5B1fcW8Rs' ----------- 'RsaCXoEzm' ----------- 'RsaCXoEzmssa' ----------- 'RsaCXoEzmssaF9m' ----------- 'U5yraPxxE' ----------- 'U5yraPxxELo5' ----------- 'U5yraPxxELo5B1f' ----------- 'W8RsaCXoE' ----------- 'W8RsaCXoEzms' ----------- 'W8RsaCXoEzmssaF' ----------- 'Xe0YhgLRr' ----------- 'Xe0YhgLRrwsm' ----------- 'Xe0YhgLRrwsmd68' ----------- 'XoEzmssa' ----------- 'XoEzmssaF9m' ---------- 'XoEzmssaF9m9cd' ----------- 'aCXoEzms' ----------- 'aCXoEzmssaF9' ----------- 'aCXoEzmssaF9m9c' ----------- 'aF9m9cdLX' ----------- 'aF9m9cdLXe0Y' ----------- 'aF9m9cdLXe0YhgLR' ----------- 'aPxxELo5B1f' ----------- 'aPxxELo5B1fcW8R' ----------- 'cW8RsaCXo' ---------- 'cW8RsaCXoEzm' ----------- 'cW8RsaCXoEzmss' ----------- 'cdLXe0Yh' ----------- 'cdLXe0YhgLR' ----------- 'cdLXe0YhgLRrws' ----------- 'cgphy3v1' ---------- 'cgphy3v1U5y' ----------- 'cgphy3v1U5yraP' ----------- 'dLXe0Yhg' ----------- 'dLXe0YhgLRr' ----------- 'dLXe0YhgLRrws' ----------- 'dLXe0YhgLRrwsmd6' ----------- 'dcgphy3v1U' ----------- 'dcgphy3v1U5y' ----------- 'dcgphy3v1U5yraP' ----------- 'fcW8RsaCX' ----------- 'fcW8RsaCXoEz' ---------- 'fcW8RsaCXoEzmss' ----------- 'gphy3v1U5' ----------- 'gphy3v1U5yra' ----------- 'gphy3v1U5yraPxx' ----------- 'hy3v1U5yr' ----------- 'hy3v1U5yraPx' ----------- 'hy3v1U5yraPxxEL' ----------- 'iwKdcgph' ----------- 'iwKdcgphy3v' ---------- 'iwKdcgphy3v1U5' ----------- 'm9cdLXe0' ---------- 'm9cdLXe0Yhg' ----------- 'm9cdLXe0YhgLR' ----------- 'm9cdLXe0YhgLRrw' ----------- 'mMmp6NHnw' ---------- 'mMmp6NHnwiwK' ----------- 'mMmp6NHnwiwKdcg' ----------- 'mp6NHnwiw' ----------- 'mp6NHnwiwKdc' ----------- 'mp6NHnwiwKdcgph' ----------- 'mssaF9m9c' ----------- 'mssaF9m9cdL' ----------- 'mssaF9m9cdLXe0' ----------- 'nwiwKdcg' ---------- 'nwiwKdcgphy' ----------- 'nwiwKdcgphy3v' ----------- 'nwiwKdcgphy3v1U5' ----------- 'o5B1fcW8Rs' ----------- 'o5B1fcW8RsaCX' ----------- 'o5B1fcW8RsaCXoEz' ----------- 'oEzmssaF9m' ----------- 'oEzmssaF9m9cd' ----------- 'oEzmssaF9m9cdLXe' ----------- 'p6NHnwiwKd' ----------- 'p6NHnwiwKdcg' ---------- 'p6NHnwiwKdcgph' ----------- 'p6NHnwiwKdcgphy3' ----------- 'phy3v1U5yr' ---------- 'phy3v1U5yraPx' ---------- 'phy3v1U5yraPxxEL' ----------- 'raPxxELo5' ----------- 'raPxxELo5B1' ----------- 'raPxxELo5B1fcW' ----------- 'raPxxELo5B1fcW8R' ----------- 'rumMmp6NHn' ----------- 'rumMmp6NHnwiw' ----------- 'rumMmp6NHnwiwKdc' ----------- 'saCXoEzms' ----------- 'saCXoEzmssaF' ----------- 'saCXoEzmssaF9m9' ----------- 'saF9m9cdL' ----------- 'saF9m9cdLXe' ---------- 'saF9m9cdLXe0Y' ----------- 'saF9m9cdLXe0YhgL' ----------- 'ssaF9m9cd' ----------- 'ssaF9m9cdLX' ----------- 'ssaF9m9cdLXe0' ----------- 'ssaF9m9cdLXe0Yhg' ----------- 'umMmp6NHn' ----------- 'umMmp6NHnwiw' ----------- 'umMmp6NHnwiwKd' ----------- 'umMmp6NHnwiwKdcg' ---------- 'v1U5yraPxx' ----------- 'v1U5yraPxxEL' ----------- 'v1U5yraPxxELo5B' ---------- 'wKdcgphy3' ----------- 'wKdcgphy3v1' ----------- 'wKdcgphy3v1U5' ----------- 'wKdcgphy3v1U5yr' ----------- 'wiwKdcgp' ----------- 'wiwKdcgphy' ----------- 'wiwKdcgphy3v' ---------- 'wiwKdcgphy3v1U5' ----------- 'xELo5B1f' ----------- 'xELo5B1fcW' ----------- 'xELo5B1fcW8R' ---------- 'xELo5B1fcW8Rsa' ----------- 'xELo5B1fcW8RsaCX' ----------- 'xxELo5B1f' ---------- 'xxELo5B1fcW' ----------- 'xxELo5B1fcW8R' ----------- 'xxELo5B1fcW8Rsa' ----------- 'y3v1U5yr' ----------- 'y3v1U5yraPx' ----------- 'y3v1U5yraPxxEL' ----------- 'y3v1U5yraPxxELo5' ----------- 'yraPxxELo' ----------- 'yraPxxELo5B' ----------- 'yraPxxELo5B1f' ---------- 'yraPxxELo5B1fcW' ----------- 'zmssaF9m' ----------- 'zmssaF9m9c' --- 'zmssaF9m9cd' ----------- 'zmssaF9m9cdLX' --- 'zmssaF9m9cdLXe' --- 'zmssaF9m9cdLXe0' --- 'zmssaF9m9cdLXe0Y'
- │ histogram(6)= 0 1.9406
+ │ histogram(4)= 0 0.0027203 0.007324 0.0033481 0.0085795 0.0037666 0.0092073 0.0027203 0.0096258 0.0043944 0.007324 0.0039759 0.0077425 0.0043944 0.0085795 0.0023018 0.0069055 0.0039759 0.0096258 0.0020926 0.0083703 0.0029296 0.0056499 0.0048129 0.0087888 0.0029296 0.0054407 0.0048129 0.007324 0.0048129 0.0092073 0.0037666 0.008161 0.0043944 0.0077425 0.0048129 0.0096258 0.0035574 0.010044 0.0029296 0.0066962 0.0035574 0.008161 0.0023018 0.010044 0.0048129 0.006487 0.0037666 0.006487 0.0039759 0.0089981 0.0037666 0.010044 0.0035574 0.0083703 0.0023018 0.0085795 0.0054407 0.0092073 0.0033481 0.007324 0.0039759 0.0079518 0.0043944 0.0096258 0.0029296 0.0087888 0.0031389 0.0062777 0.0039759 0.0089981 0.0023018 0.0069055 0.0039759 0.0087888 0.0035574 0.0092073 0.0027203 0.0085795 0.0056499 0.007324 0.0029296 0.0098351 0.0039759 0.0069055 0.0037666 0.0098351 0.0033481 0.0069055 0.0062777 0.0092073 0.0029296 0.0062777 0.0037666 0.0075333 0.0025111 0.008161 0.0035574 0.0075333 0.0039759 0.0087888 0.0029296 0.0062777 0.0043944 0.0085795 0.0033481 0.0052314 0.0048129 0.0069055 0.0035574 0.0075333 0.0031389 0.0083703 0.0035574 0.0071147 0.0035574 0.0066962 0.0039759 0.0079518 0.0039759 0.0060685 0.0041851 0.0094166 0.0031389 0.0083703 0.0046037 0.0085795 0.0048129 0.006487 0.0035574 0.0077425 0.0041851 0.0062777 0.0035574 0.0077425 0.0041851 0.006487 0.0035574 0.0094166 0.0031389 0.0071147 0.0052314 0.0075333 0.0033481 0.0039759 0.0060685 0.0060685 0.0037666 0.0071147 0.0039759 0.0092073 0.0039759 0.0043944 0.0054407 0.0041851 0.0054407 0.0062777 0.0043944 0.0079518 0.0043944 0.008161 0.0039759 0.0071147 0.0056499 0.0075333 0.0041851 0.0085795 0.0029296 0.0062777 0.0033481 0.0085795 0.0043944 0.0092073 0.0041851 0.008161 0.0050222 0.0069055 0.0041851 0.008161 0.0039759 0.007324 0.0020926 0.0075333 0.0031389 0.008161 0.0031389 0.0071147 0.0025111 0.0060685 0.0035574 0.0066962 0.0031389 0.008161 0.0050222 0.008161 0.0037666 0.0066962 0.0033481 0.0075333 0.0035574 0.0071147 0.0058592 0.0089981 0.0043944 0.0075333 0.0035574 0.008161 0.0039759 0.0087888 0.0037666 0.0062777 0.0031389 0.0085795 0.0046037 0.0069055 0.0023018 0.0079518 0.0023018 0.006487 0.0041851 0.0066962 0.0041851 0.008161 0.0037666 0.0046037 0.0046037 0.0069055 0.0039759 0.0056499 0.0041851 0.006487 0.0048129 0.0083703 0.0050222 0.0083703 0.0052314 0.007324 0.0046037 0.007324 0.0025111 0.0056499 0.0046037 0.007324 0.0023018 0.0077425 0.0033481 0.0079518 0.0035574 0.0083703 0.0046037 0.0052314 0.0043944 0.0075333 0.0035574 0.0079518 0.0035574 0.0071147 0.0037666 0.0062777 0.0027203 0.0052314 0.0048129 0.007324 0.0048129 0.0058592 0.0037666 0.0056499 0.0031389 0.008161 0.0037666 0.006487 0.0043944 0.0077425 0.0039759 0.0069055 0.0027203 0.0043944 0.0048129 0.0075333 0.0033481 0.0060685 0.0054407 0.0069055 0.0039759 0.0077425 0.0035574 0.0052314 0.0041851 0.007324 0.0035574 0.0058592 0.0041851 0.0048129 0.0043944 0.007324 0.0031389 0.0069055 0.0031389 0.0075333 0.0031389 0.0048129 0.0031389 0.0039759 0.0039759 0.007324 0.0025111 0.0033481 0.0060685 0.0050222 0.0043944 0.0071147 0.0025111 0.007324 0.0048129 0.0069055 0.0041851 0.0071147 0.0041851 0.0033481 0.0048129 0.0048129 0.0029296 0.0071147 0.0033481 0.0043944 0.0041851 0.0062777 0.0037666 0.0033481 0.0041851 0.0037666 0.0035574 0.0039759 0.0046037 0.0050222 0.0029296 0.0041851 0.0031389 0.0060685 0.0033481 0.0062777 0.0033481 0.0031389 0.0041851 0.0066962 0.0043944 0.0054407 0.0033481 0.0039759 0.0058592 0.0050222 0.0035574 0.0041851 0.0031389 0.0033481 0.0035574 0.0039759 0.0031389 0.0041851 0.0039759 0.0043944 0.0058592 0.0060685 0.0041851 0.0043944 0.0035574 0.0048129 0.0031389 0.0035574 0.0043944 0.0027203 0.0035574 0.0035574 0.0033481 0.0033481 0.0035574 0.0033481 0.0035574 0.0046037 0.0048129 0.0029296 0.0033481 0.0027203 0.0037666 0.0037666 0.0041851 0.0035574 0.0023018 0.0041851 0.0025111 0.0037666 0.0041851 0 0.0048129 0 0.0031389 0 0.0039759
+ │ <--- '1U5yraPx' ---------- '1U5yraPxxEL' ----------- '1U5yraPxxELo5B' ----------- '1fcW8Rsa' ----------- '1fcW8RsaCXoE' ---------- '1fcW8RsaCXoEzms' ----------- '3v1U5yraP' ----------- '3v1U5yraPxxE' ----------- '3v1U5yraPxxELo5' ----------- '5B1fcW8Rsa' ----------- '5B1fcW8RsaCXo' ----------- '5B1fcW8RsaCXoEz' ----------- '5yraPxxEL' ----------- '5yraPxxELo5B' ---------- '5yraPxxELo5B1fc' ----------- '6NHnwiwKd' ---------- '6NHnwiwKdcgp' ----------- '6NHnwiwKdcgphy3' ----------- '6rumMmp6NH' ---------- '6rumMmp6NHnwiw' ----------- '8RsaCXoE' ---------- '8RsaCXoEzms' ---------- '8RsaCXoEzmssaF9' ---------- '9cdLXe0Yh' ---------- '9cdLXe0YhgLR' ----------- '9cdLXe0YhgLRrws' ---------- '9m9cdLXe0' ----------- '9m9cdLXe0YhgL' ----------- '9m9cdLXe0YhgLRrw' ----------- 'B1fcW8RsaC' ---------- 'B1fcW8RsaCXoE' ----------- 'B1fcW8RsaCXoEzms' ----------- 'CXoEzmssaF' ----------- 'CXoEzmssaF9m9' ----------- 'CXoEzmssaF9m9cdL' ----------- 'ELo5B1fcW8R' ----------- 'ELo5B1fcW8RsaC' ----------- 'EzmssaF9m' ----------- 'EzmssaF9m9cdL' ----------- 'EzmssaF9m9cdLXe0' ---------- 'F9m9cdLXe0' ----------- 'F9m9cdLXe0YhgL' ----------- 'HnwiwKdc' ----------- 'HnwiwKdcgphy' ----------- 'HnwiwKdcgphy3v1' ----------- 'Kdcgphy3v1' ----------- 'Kdcgphy3v1U5y' ----------- 'Kdcgphy3v1U5yraP' ---------- 'LXe0YhgLRr' ----------- 'LXe0YhgLRrwsm' ----------- 'Lo5B1fcW' ----------- 'Lo5B1fcW8Rs' ----------- 'Lo5B1fcW8RsaCX' ----------- 'Lo5B1fcW8RsaCXoE' ----------- 'Mmp6NHnwiw' ----------- 'Mmp6NHnwiwKdc' ----------- 'Mmp6NHnwiwKdcgph' ----------- 'NHnwiwKdcg' ----------- 'NHnwiwKdcgphy' ----------- 'NHnwiwKdcgphy3v1' ----------- 'PxxELo5B1f' ----------- 'PxxELo5B1fcW8R' ----------- 'RsaCXoEzm' ----------- 'RsaCXoEzmssa' ---------- 'RsaCXoEzmssaF9m' ----------- 'U5yraPxxE' ----------- 'U5yraPxxELo5' ----------- 'U5yraPxxELo5B1f' ---------- 'W8RsaCXoE' ----------- 'W8RsaCXoEzms' ----------- 'W8RsaCXoEzmssaF' ----------- 'Xe0YhgLRr' ----------- 'Xe0YhgLRrws' ----------- 'Xe0YhgLRrwsmd6' ----------- 'XoEzmssa' ----------- 'XoEzmssaF9m' ----------- 'XoEzmssaF9m9c' ----------- 'XoEzmssaF9m9cdL' ----------- 'aCXoEzms' ----------- 'aCXoEzmssaF' ---------- 'aCXoEzmssaF9m9c' ----------- 'aF9m9cdLX' ----------- 'aF9m9cdLXe0Y' ----------- 'aF9m9cdLXe0YhgL' ----------- 'aPxxELo5B' ----------- 'aPxxELo5B1fc' ----------- 'aPxxELo5B1fcW8R' ---------- 'cW8RsaCXo' ----------- 'cW8RsaCXoEzm' ---------- 'cW8RsaCXoEzmssa' ---------- 'cdLXe0Yhg' ----------- 'cdLXe0YhgLRr' ---------- 'cdLXe0YhgLRrwsm' ----------- 'cgphy3v1U' ----------- 'cgphy3v1U5yr' ----------- 'cgphy3v1U5yraPx' ---------- 'dLXe0YhgL' ---------- 'dLXe0YhgLRrws' ----------- 'dLXe0YhgLRrwsmd6' ----------- 'dcgphy3v1U' ----------- 'dcgphy3v1U5yr' ----------- 'dcgphy3v1U5yraPx' ----------- 'fcW8RsaCXo' ---------- 'fcW8RsaCXoEzms' ----------- 'gphy3v1U' ----------- 'gphy3v1U5yr' ----------- 'gphy3v1U5yraPx' ----------- 'hy3v1U5y' ----------- 'hy3v1U5yraP' ---------- 'hy3v1U5yraPxxE' ----------- 'iwKdcgph' ---------- 'iwKdcgphy3v' ----------- 'iwKdcgphy3v1U' ----------- 'iwKdcgphy3v1U5yr' ----------- 'm9cdLXe0Y' ---------- 'm9cdLXe0YhgL' ----------- 'm9cdLXe0YhgLRrw' ----------- 'mMmp6NHnw' ---------- 'mMmp6NHnwiwK' ---------- 'mMmp6NHnwiwKdcg' ----------- 'mp6NHnwiw' ---------- 'mp6NHnwiwKdc' ----------- 'mp6NHnwiwKdcgph' ----------- 'mssaF9m9c' ----------- 'mssaF9m9cdLX' ----------- 'mssaF9m9cdLXe0' ----------- 'nwiwKdcg' ----------- 'nwiwKdcgphy' ----------- 'nwiwKdcgphy3v1' ----------- 'o5B1fcW8' ----------- 'o5B1fcW8Rs' ---------- 'o5B1fcW8RsaCX' ----------- 'o5B1fcW8RsaCXoEz' ----------- 'oEzmssaF9m' ---------- 'oEzmssaF9m9cd' ---------- 'oEzmssaF9m9cdLXe' ----------- 'p6NHnwiwKd' ----------- 'p6NHnwiwKdcgp' ----------- 'p6NHnwiwKdcgphy' ----------- 'phy3v1U5y' ----------- 'phy3v1U5yra' ----------- 'phy3v1U5yraPxx' ----------- 'raPxxELo' ----------- 'raPxxELo5B' ---------- 'raPxxELo5B1fc' ----------- 'raPxxELo5B1fcW8R' ----------- 'rumMmp6NH' ---------- 'rumMmp6NHnwi' ----------- 'rumMmp6NHnwiwKd' ----------- 'saCXoEzms' ----------- 'saCXoEzmssa' ----------- 'saCXoEzmssaF9' ---------- 'saCXoEzmssaF9m9c' ----------- 'saF9m9cdL' ----------- 'saF9m9cdLXe' ----------- 'saF9m9cdLXe0Yh' ---------- 'ssaF9m9c' ----------- 'ssaF9m9cdLX' ----------- 'ssaF9m9cdLXe0Y' ----------- 'ssaF9m9cdLXe0Yhg' ----------- 'umMmp6NHn' ----------- 'umMmp6NHnwiw' ----------- 'umMmp6NHnwiwKd' ----------- 'v1U5yraP' ----------- 'v1U5yraPxx' ----------- 'v1U5yraPxxEL' ----------- 'v1U5yraPxxELo5' ----------- 'v1U5yraPxxELo5B1' ----------- 'wKdcgphy3' ----------- 'wKdcgphy3v1U' ----------- 'wKdcgphy3v1U5yr' ----------- 'wiwKdcgp' ----------- 'wiwKdcgphy3' ----------- 'wiwKdcgphy3v1' ----------- 'wiwKdcgphy3v1U5' ----------- 'xELo5B1f' ----------- 'xELo5B1fcW' ----------- 'xELo5B1fcW8R' ----------- 'xELo5B1fcW8Rsa' ----------- 'xELo5B1fcW8RsaCX' ----------- 'xxELo5B1f' ----------- 'xxELo5B1fcW8' ----------- 'xxELo5B1fcW8Rs' ----------- 'xxELo5B1fcW8RsaC' ----------- 'y3v1U5yra' ----------- 'y3v1U5yraPx' ----------- 'y3v1U5yraPxxE' ----------- 'y3v1U5yraPxxELo' ----------- 'yraPxxEL' ----------- 'yraPxxELo5' ----------- 'yraPxxELo5B1' ----------- 'yraPxxELo5B1fc' ----------- 'yraPxxELo5B1fcW8' ----------- 'zmssaF9m9' ----------- 'zmssaF9m9cd' ----------- 'zmssaF9m9cdLX' --- 'zmssaF9m9cdLXe' --- 'zmssaF9m9cdLXe0' --- 'zmssaF9m9cdLXe0Y'
+ │ histogram(6)= 0 2.0926
│ <--- 'ANTIBARESE'
├── key: (1)
├── fd: ()-->(2,3,6), (1)-->(4)
@@ -370,7 +370,7 @@ project
├── save-table-name: order_status_03_project_1
├── columns: o_id:1(int!null) o_entry_d:5(timestamp) o_carrier_id:6(int)
├── cardinality: [0 - 1]
- ├── stats: [rows=0.9803631, distinct(1)=0.980204, null(1)=0, avgsize(1)=4, distinct(5)=0.624826, null(5)=0, avgsize(5)=4, distinct(6)=0.937947, null(6)=0.294109, avgsize(6)=4]
+ ├── stats: [rows=0.9420474, distinct(1)=0.941901, null(1)=0, avgsize(1)=3, distinct(5)=0.610172, null(5)=0, avgsize(5)=7, distinct(6)=0.902837, null(6)=0.282614, avgsize(6)=2]
├── key: ()
├── fd: ()-->(1,5,6)
└── scan order@order_idx
@@ -378,7 +378,7 @@ project
├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null) o_c_id:4(int!null) o_entry_d:5(timestamp) o_carrier_id:6(int)
├── constraint: /3/2/4/-1: [/4/3/10 - /4/3/10]
├── limit: 1
- ├── stats: [rows=0.9803631, distinct(1)=0.980204, null(1)=0, avgsize(1)=4, distinct(2)=0.980363, null(2)=0, avgsize(2)=4, distinct(3)=0.980363, null(3)=0, avgsize(3)=4, distinct(4)=0.980363, null(4)=0, avgsize(4)=4, distinct(5)=0.624826, null(5)=0, avgsize(5)=4, distinct(6)=0.937947, null(6)=0.294109, avgsize(6)=4]
+ ├── stats: [rows=0.9420474, distinct(1)=0.941901, null(1)=0, avgsize(1)=3, distinct(2)=0.942047, null(2)=0, avgsize(2)=1, distinct(3)=0.942047, null(3)=0, avgsize(3)=1, distinct(4)=0.942047, null(4)=0, avgsize(4)=3, distinct(5)=0.610172, null(5)=0, avgsize(5)=7, distinct(6)=0.902837, null(6)=0.282614, avgsize(6)=2]
├── key: ()
└── fd: ()-->(1-6)
@@ -410,17 +410,17 @@ WHERE ol_w_id = 1 AND ol_d_id = 1 AND ol_o_id = 1000
project
├── save-table-name: order_status_04_project_1
├── columns: ol_i_id:5(int!null) ol_supply_w_id:6(int) ol_quantity:8(int) ol_amount:9(decimal) ol_delivery_d:7(timestamp)
- ├── stats: [rows=8.899768, distinct(5)=8.89938, null(5)=0, avgsize(5)=4, distinct(6)=5.89335, null(6)=0, avgsize(6)=4, distinct(7)=1.97664, null(7)=2.66628, avgsize(7)=4, distinct(8)=0.999864, null(8)=0, avgsize(8)=4, distinct(9)=8.89971, null(9)=0, avgsize(9)=4]
+ ├── stats: [rows=11.09853, distinct(5)=11.0979, null(5)=0, avgsize(5)=4, distinct(6)=6.70393, null(6)=0, avgsize(6)=2, distinct(7)=1.99222, null(7)=3.325, avgsize(7)=5, distinct(8)=0.999985, null(8)=0, avgsize(8)=2, distinct(9)=11.0984, null(9)=0, avgsize(9)=5]
└── scan order_line
├── save-table-name: order_status_04_scan_2
├── columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null) ol_i_id:5(int!null) ol_supply_w_id:6(int) ol_delivery_d:7(timestamp) ol_quantity:8(int) ol_amount:9(decimal)
├── constraint: /3/2/-1/4: [/1/1/1000 - /1/1/1000]
- ├── stats: [rows=8.899768, distinct(1)=1, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(5)=8.89938, null(5)=0, avgsize(5)=4, distinct(6)=5.89335, null(6)=0, avgsize(6)=4, distinct(7)=1.97664, null(7)=2.66628, avgsize(7)=4, distinct(8)=0.999864, null(8)=0, avgsize(8)=4, distinct(9)=8.89971, null(9)=0, avgsize(9)=4, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=12]
- │ histogram(1)= 0 8.8998
+ ├── stats: [rows=11.09853, distinct(1)=1, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(5)=11.0979, null(5)=0, avgsize(5)=4, distinct(6)=6.70393, null(6)=0, avgsize(6)=2, distinct(7)=1.99222, null(7)=3.325, avgsize(7)=5, distinct(8)=0.999985, null(8)=0, avgsize(8)=2, distinct(9)=11.0984, null(9)=0, avgsize(9)=5, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=5]
+ │ histogram(1)= 0 11.099
│ <--- 1000
- │ histogram(2)= 0 8.8998
+ │ histogram(2)= 0 11.099
│ <---- 1 --
- │ histogram(3)= 0 8.8998
+ │ histogram(3)= 0 11.099
│ <---- 1 --
└── fd: ()-->(1-3)
@@ -436,14 +436,14 @@ column_names row_count distinct_count null_count
{ol_w_id} 12 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{ol_amount} 9.00 1.33 9.00 9.00 <== 0.00 1.00
-{ol_d_id} 9.00 1.33 1.00 1.00 0.00 1.00
-{ol_delivery_d} 9.00 1.33 2.00 2.00 <== 3.00 +Inf <==
-{ol_i_id} 9.00 1.33 9.00 1.33 0.00 1.00
-{ol_o_id} 9.00 1.33 1.00 1.00 0.00 1.00
-{ol_quantity} 9.00 1.33 1.00 1.00 0.00 1.00
-{ol_supply_w_id} 9.00 1.33 6.00 6.00 <== 0.00 1.00
-{ol_w_id} 9.00 1.33 1.00 1.00 0.00 1.00
+{ol_amount} 11.00 1.09 11.00 11.00 <== 0.00 1.00
+{ol_d_id} 11.00 1.09 1.00 1.00 0.00 1.00
+{ol_delivery_d} 11.00 1.09 2.00 2.00 <== 3.00 +Inf <==
+{ol_i_id} 11.00 1.09 11.00 1.09 0.00 1.00
+{ol_o_id} 11.00 1.09 1.00 1.00 0.00 1.00
+{ol_quantity} 11.00 1.09 1.00 1.00 0.00 1.00
+{ol_supply_w_id} 11.00 1.09 7.00 7.00 <== 0.00 1.00
+{ol_w_id} 11.00 1.09 1.00 1.00 0.00 1.00
----
----
@@ -475,7 +475,7 @@ project
├── save-table-name: delivery_01_project_1
├── columns: no_o_id:1(int!null)
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(1)=0.999678, null(1)=0, avgsize(1)=4]
+ ├── stats: [rows=1, distinct(1)=0.999675, null(1)=0, avgsize(1)=3]
├── key: ()
├── fd: ()-->(1)
└── scan new_order
@@ -483,7 +483,7 @@ project
├── columns: no_o_id:1(int!null) no_d_id:2(int!null) no_w_id:3(int!null)
├── constraint: /3/2/1: [/7/6 - /7/6]
├── limit: 1
- ├── stats: [rows=1, distinct(1)=0.999678, null(1)=0, avgsize(1)=4, distinct(2)=0.632318, null(2)=0, avgsize(2)=4, distinct(3)=0.632318, null(3)=0, avgsize(3)=4]
+ ├── stats: [rows=1, distinct(1)=0.999675, null(1)=0, avgsize(1)=3, distinct(2)=0.632308, null(2)=0, avgsize(2)=1, distinct(3)=0.632308, null(3)=0, avgsize(3)=1]
├── key: ()
└── fd: ()-->(1-3)
@@ -517,12 +517,12 @@ scalar-group-by
│ ├── save-table-name: delivery_02_scan_2
│ ├── columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null) ol_amount:9(decimal)
│ ├── constraint: /3/2/-1/4: [/8/6/1000 - /8/6/1000]
- │ ├── stats: [rows=10.05526, distinct(1)=1, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(9)=10.0552, null(9)=0, avgsize(9)=4, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=12]
- │ │ histogram(1)= 0 10.055
+ │ ├── stats: [rows=11.81251, distinct(1)=1, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(9)=11.8124, null(9)=0, avgsize(9)=5, distinct(1-3)=1, null(1-3)=0, avgsize(1-3)=5]
+ │ │ histogram(1)= 0 11.813
│ │ <--- 1000
- │ │ histogram(2)= 0 10.055
+ │ │ histogram(2)= 0 11.813
│ │ <---- 6 --
- │ │ histogram(3)= 0 10.055
+ │ │ histogram(3)= 0 11.813
│ │ <---- 8 --
│ └── fd: ()-->(1-3)
└── aggregations
@@ -544,10 +544,10 @@ column_names row_count distinct_count null_count
{ol_w_id} 7 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{ol_amount} 10.00 1.43 10.00 10.00 <== 0.00 1.00
-{ol_d_id} 10.00 1.43 1.00 1.00 0.00 1.00
-{ol_o_id} 10.00 1.43 1.00 1.00 0.00 1.00
-{ol_w_id} 10.00 1.43 1.00 1.00 0.00 1.00
+{ol_amount} 12.00 1.71 12.00 12.00 <== 0.00 1.00
+{ol_d_id} 12.00 1.71 1.00 1.00 0.00 1.00
+{ol_o_id} 12.00 1.71 1.00 1.00 0.00 1.00
+{ol_w_id} 12.00 1.71 1.00 1.00 0.00 1.00
----
----
@@ -569,7 +569,7 @@ project
├── save-table-name: stock_level_01_project_1
├── columns: d_next_o_id:11(int)
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(11)=0.633968, null(11)=0, avgsize(11)=4]
+ ├── stats: [rows=1, distinct(11)=0.633968, null(11)=0, avgsize(11)=3]
├── key: ()
├── fd: ()-->(11)
└── scan district
@@ -577,7 +577,7 @@ project
├── columns: d_id:1(int!null) d_w_id:2(int!null) d_next_o_id:11(int)
├── constraint: /2/1: [/4/9 - /4/9]
├── cardinality: [0 - 1]
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(11)=0.633968, null(11)=0, avgsize(11)=4, distinct(1,2)=1, null(1,2)=0, avgsize(1,2)=8]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=1, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(11)=0.633968, null(11)=0, avgsize(11)=3, distinct(1,2)=1, null(1,2)=0, avgsize(1,2)=2]
├── key: ()
└── fd: ()-->(1,2,11)
@@ -616,25 +616,25 @@ scalar-group-by
│ ├── save-table-name: stock_level_02_distinct_on_2
│ ├── columns: s_i_id:13(int!null)
│ ├── grouping columns: s_i_id:13(int!null)
- │ ├── stats: [rows=188.6738, distinct(13)=188.674, null(13)=0, avgsize(13)=4]
+ │ ├── stats: [rows=195.6265, distinct(13)=195.626, null(13)=0, avgsize(13)=4]
│ ├── key: (13)
│ └── inner-join (lookup stock)
│ ├── save-table-name: stock_level_02_lookup_join_3
│ ├── columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null) ol_i_id:5(int!null) s_i_id:13(int!null) s_w_id:14(int!null) s_quantity:15(int!null)
│ ├── key columns: [3 5] = [14 13]
│ ├── lookup columns are key
- │ ├── stats: [rows=193.5302, distinct(1)=19.9923, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(5)=188.674, null(5)=0, avgsize(5)=4, distinct(13)=188.674, null(13)=0, avgsize(13)=4, distinct(14)=1, null(14)=0, avgsize(14)=4, distinct(15)=5, null(15)=0, avgsize(15)=4]
+ │ ├── stats: [rows=200.6382, distinct(1)=19.9991, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(5)=195.626, null(5)=0, avgsize(5)=4, distinct(13)=195.626, null(13)=0, avgsize(13)=4, distinct(14)=1, null(14)=0, avgsize(14)=1, distinct(15)=5, null(15)=0, avgsize(15)=3]
│ ├── fd: ()-->(2,3,14), (13)-->(15), (5)==(13), (13)==(5), (3)==(14), (14)==(3)
│ ├── scan order_line
│ │ ├── save-table-name: stock_level_02_scan_4
│ │ ├── columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null) ol_i_id:5(int!null)
│ │ ├── constraint: /3/2/-1/4: [/1/1/999 - /1/1/980]
- │ │ ├── stats: [rows=188.8466, distinct(1)=19.9936, null(1)=0, avgsize(1)=4, distinct(2)=1, null(2)=0, avgsize(2)=4, distinct(3)=1, null(3)=0, avgsize(3)=4, distinct(5)=188.674, null(5)=0, avgsize(5)=4, distinct(2,3)=1, null(2,3)=0, avgsize(2,3)=8, distinct(1-3)=19.9936, null(1-3)=0, avgsize(1-3)=12]
- │ │ │ histogram(1)= 0 0 61.592 11.599 106.76 8.8966
- │ │ │ <--- 979 -------- 986 --------- 999 -
- │ │ │ histogram(2)= 0 188.85
+ │ │ ├── stats: [rows=195.8123, distinct(1)=20, null(1)=0, avgsize(1)=3, distinct(2)=1, null(2)=0, avgsize(2)=1, distinct(3)=1, null(3)=0, avgsize(3)=1, distinct(5)=195.626, null(5)=0, avgsize(5)=4, distinct(2,3)=1, null(2,3)=0, avgsize(2,3)=2, distinct(1-3)=20, null(1-3)=0, avgsize(1-3)=5]
+ │ │ │ histogram(1)= 0 0 123.67 5.5472 55.493 11.099
+ │ │ │ <--- 979 -------- 993 --------- 999 -
+ │ │ │ histogram(2)= 0 195.81
│ │ │ <---- 1 --
- │ │ │ histogram(3)= 0 188.85
+ │ │ │ histogram(3)= 0 195.81
│ │ │ <---- 1 --
│ │ └── fd: ()-->(2,3)
│ └── filters
@@ -655,7 +655,7 @@ column_names row_count distinct_count null_count
{s_i_id} 15 15 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{s_i_id} 189.00 12.60 <== 189.00 12.60 <== 0.00 1.00
+{s_i_id} 196.00 13.07 <== 196.00 13.07 <== 0.00 1.00
----Stats for stock_level_02_lookup_join_3----
column_names row_count distinct_count null_count
@@ -668,13 +668,13 @@ column_names row_count distinct_count null_count
{s_w_id} 15 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{ol_d_id} 194.00 12.93 <== 1.00 1.00 0.00 1.00
-{ol_i_id} 194.00 12.93 <== 189.00 12.60 <== 0.00 1.00
-{ol_o_id} 194.00 12.93 <== 20.00 1.82 0.00 1.00
-{ol_w_id} 194.00 12.93 <== 1.00 1.00 0.00 1.00
-{s_i_id} 194.00 12.93 <== 189.00 12.60 <== 0.00 1.00
-{s_quantity} 194.00 12.93 <== 5.00 1.00 0.00 1.00
-{s_w_id} 194.00 12.93 <== 1.00 1.00 0.00 1.00
+{ol_d_id} 201.00 13.40 <== 1.00 1.00 0.00 1.00
+{ol_i_id} 201.00 13.40 <== 196.00 13.07 <== 0.00 1.00
+{ol_o_id} 201.00 13.40 <== 20.00 1.82 0.00 1.00
+{ol_w_id} 201.00 13.40 <== 1.00 1.00 0.00 1.00
+{s_i_id} 201.00 13.40 <== 196.00 13.07 <== 0.00 1.00
+{s_quantity} 201.00 13.40 <== 5.00 1.00 0.00 1.00
+{s_w_id} 201.00 13.40 <== 1.00 1.00 0.00 1.00
----Stats for stock_level_02_scan_4----
column_names row_count distinct_count null_count
@@ -684,10 +684,10 @@ column_names row_count distinct_count null_count
{ol_w_id} 193 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{ol_d_id} 189.00 1.02 1.00 1.00 0.00 1.00
-{ol_i_id} 189.00 1.02 189.00 1.02 0.00 1.00
-{ol_o_id} 189.00 1.02 20.00 1.00 0.00 1.00
-{ol_w_id} 189.00 1.02 1.00 1.00 0.00 1.00
+{ol_d_id} 196.00 1.02 1.00 1.00 0.00 1.00
+{ol_i_id} 196.00 1.02 196.00 1.02 0.00 1.00
+{ol_o_id} 196.00 1.02 20.00 1.00 0.00 1.00
+{ol_w_id} 196.00 1.02 1.00 1.00 0.00 1.00
----
----
@@ -724,13 +724,13 @@ scalar-group-by
│ ├── left ordering: +1
│ ├── right ordering: +13
│ ├── immutable
- │ ├── stats: [rows=3.333333, distinct(1)=3.33333, null(1)=0, avgsize(1)=4, distinct(9)=1, null(9)=0, avgsize(9)=4, distinct(13)=3.33333, null(13)=0, avgsize(13)=4, distinct(25)=3.33333, null(25)=0, avgsize(25)=4]
+ │ ├── stats: [rows=3.333333, distinct(1)=3.33333, null(1)=0, avgsize(1)=1, distinct(9)=1, null(9)=0, avgsize(9)=8, distinct(13)=3.33333, null(13)=0, avgsize(13)=1, distinct(25)=3.33333, null(25)=0, avgsize(25)=1]
│ ├── key: (13)
│ ├── fd: (1)-->(9), (13)-->(25), (1)==(13), (13)==(1)
│ ├── scan warehouse
│ │ ├── save-table-name: consistency_01_scan_3
│ │ ├── columns: w_id:1(int!null) w_ytd:9(decimal)
- │ │ ├── stats: [rows=10, distinct(1)=10, null(1)=0, avgsize(1)=4, distinct(9)=1, null(9)=0, avgsize(9)=4]
+ │ │ ├── stats: [rows=10, distinct(1)=10, null(1)=0, avgsize(1)=1, distinct(9)=1, null(9)=0, avgsize(9)=8]
│ │ │ histogram(1)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9
│ │ │ histogram(9)= 0 10
@@ -742,14 +742,14 @@ scalar-group-by
│ │ ├── save-table-name: consistency_01_group_by_4
│ │ ├── columns: d_w_id:13(int!null) sum:25(decimal)
│ │ ├── grouping columns: d_w_id:13(int!null)
- │ │ ├── stats: [rows=10, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(25)=10, null(25)=0, avgsize(25)=4]
+ │ │ ├── stats: [rows=10, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(25)=10, null(25)=0, avgsize(25)=1]
│ │ ├── key: (13)
│ │ ├── fd: (13)-->(25)
│ │ ├── ordering: +13
│ │ ├── scan district
│ │ │ ├── save-table-name: consistency_01_scan_5
│ │ │ ├── columns: d_w_id:13(int!null) d_ytd:21(decimal)
- │ │ │ ├── stats: [rows=100, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(21)=1, null(21)=0, avgsize(21)=4]
+ │ │ │ ├── stats: [rows=100, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(21)=1, null(21)=0, avgsize(21)=7]
│ │ │ │ histogram(13)= 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10
│ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9
│ │ │ │ histogram(21)= 0 100
@@ -821,7 +821,7 @@ ORDER BY d_w_id, d_id
scan district
├── save-table-name: consistency_02_scan_1
├── columns: d_next_o_id:11(int) [hidden: d_id:1(int!null) d_w_id:2(int!null)]
- ├── stats: [rows=100, distinct(1)=10, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(11)=1, null(11)=0, avgsize(11)=4]
+ ├── stats: [rows=100, distinct(1)=10, null(1)=0, avgsize(1)=1, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(11)=1, null(11)=0, avgsize(11)=3]
│ histogram(1)= 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10
│ <--- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10
│ histogram(2)= 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10 0 10
@@ -856,19 +856,19 @@ group-by (streaming)
├── save-table-name: consistency_03_group_by_1
├── columns: max:6(int!null) [hidden: no_d_id:2(int!null) no_w_id:3(int!null)]
├── grouping columns: no_d_id:2(int!null) no_w_id:3(int!null)
- ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(6)=100, null(6)=0, avgsize(6)=8, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(6)=100, null(6)=0, avgsize(6)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
├── key: (2,3)
├── fd: (2,3)-->(6)
├── ordering: +3,+2
├── scan new_order
│ ├── save-table-name: consistency_03_scan_2
│ ├── columns: no_o_id:1(int!null) no_d_id:2(int!null) no_w_id:3(int!null)
- │ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ histogram(1)= 0 117 405 81 423 63 441 99 360 135 423 108 351 198 351 108 414 99 423 99 387 108 405 117 414 36 414 108 432 126 333 108 396 108 360 108 405 81 414 126 378 72 432 135 351 117 369 126 369 117 423 99 342 126 360 144 360 117 360 99 396 99 405 81 432 81 396 72 396 54 342 108 414 81 414 72 351 90 405 99 333 135 333 126 432 54 360 135 315 117 333 117 369 81 405 63 378 171 396 99 360 135 423 63 315 126 324 108 279 153 342 90 387 63 288 153 351 108 396 180 297 135 387 81 360 153 414 144 414 54 333 144 333 135 387 144 423 108 387 72 342 117 315 144 396 45 405 117 405 72 378 135 396 63 351 117 297 126 360 108 378 54 396 189 342 90 378 108 342 126 396 108 378 90 315 108 297 126 396 117 351 126 405 99 405 99 360 99 342 99 369 81 414 99 306 144 306 108 333 126 387 117 360 54 360 108 351 81 342 126 405 135 369 54 333 81 324 144 396 72 342 90 351 99 396 45 387 126 351 126 342 153 405 171 315 126 369 117 351 63 297 126 333 162 270 153 324 108 306 117 396 81 306 144 351 135 351 54 351 135 342 72 396 153 369 135 378 126 297 117 360 117 333 90 351 117 360 90 387 153 369 81 315 117 324 63 315 90 297 108 315 90 306 81 315 117 378 108 342 126 306 108 324 90 360 135 252 180 333 144 360 99 369 135 279 126 315 117 297 90 351 81 306 81 279 126 252 135 315 90 279 99 288 81 351 90 324 99 207 153 261 153 306 81 243 135 351 72 351 54 288 90 342 81 288 108 333 90 324 99 333 54 234 144 297 72 297 99 252 162 252 108 279 90 207 126 252 108 261 72 270 99 198 189 270 81 234 90 234 99 180 126 261 117 216 99 171 99 117 108
- │ │ <--- 2101 ----- 2106 ----- 2111 ----- 2117 ----- 2121 ----- 2126 ----- 2132 ----- 2136 ----- 2141 ----- 2147 ----- 2152 ----- 2156 ----- 2162 ----- 2167 ----- 2172 ----- 2177 ----- 2181 ----- 2186 ----- 2190 ----- 2196 ----- 2201 ----- 2205 ----- 2210 ----- 2217 ----- 2222 ----- 2227 ----- 2232 ----- 2237 ----- 2242 ----- 2247 ----- 2252 ----- 2257 ----- 2263 ----- 2268 ----- 2273 ----- 2278 ----- 2284 ----- 2290 ----- 2294 ----- 2299 ----- 2303 ----- 2308 ----- 2313 ----- 2318 ----- 2321 ----- 2325 ----- 2330 ----- 2335 ----- 2340 ----- 2345 ----- 2350 ----- 2355 ----- 2359 ----- 2363 ----- 2367 ----- 2372 ----- 2377 ----- 2380 ----- 2385 ----- 2390 ----- 2394 ----- 2399 ----- 2404 ----- 2409 ----- 2414 ----- 2418 ----- 2422 ----- 2426 ----- 2431 ----- 2436 ----- 2440 ----- 2444 ----- 2449 ----- 2454 ----- 2460 ----- 2465 ----- 2471 ----- 2476 ----- 2480 ----- 2484 ----- 2488 ----- 2493 ----- 2498 ----- 2503 ----- 2507 ----- 2511 ----- 2516 ----- 2520 ----- 2524 ----- 2530 ----- 2535 ----- 2540 ----- 2545 ----- 2549 ----- 2554 ----- 2559 ----- 2565 ----- 2569 ----- 2573 ----- 2578 ----- 2582 ----- 2586 ----- 2590 ----- 2594 ----- 2599 ----- 2604 ----- 2609 ----- 2614 ----- 2618 ----- 2623 ----- 2629 ----- 2634 ----- 2640 ----- 2645 ----- 2648 ----- 2653 ----- 2657 ----- 2662 ----- 2666 ----- 2671 ----- 2675 ----- 2679 ----- 2683 ----- 2688 ----- 2692 ----- 2697 ----- 2701 ----- 2707 ----- 2711 ----- 2716 ----- 2720 ----- 2724 ----- 2729 ----- 2734 ----- 2739 ----- 2743 ----- 2748 ----- 2754 ----- 2759 ----- 2764 ----- 2768 ----- 2772 ----- 2776 ----- 2781 ----- 2785 ----- 2790 ----- 2794 ----- 2798 ----- 2803 ----- 2807 ----- 2811 ----- 2815 ----- 2819 ----- 2822 ----- 2826 ----- 2831 ----- 2837 ----- 2841 ----- 2845 ----- 2849 ----- 2853 ----- 2858 ----- 2861 ----- 2864 ----- 2868 ----- 2872 ----- 2877 ----- 2882 ----- 2886 ----- 2890 ----- 2894 ----- 2899 ----- 2903 ----- 2908 ----- 2912 ----- 2916 ----- 2920 ----- 2924 ----- 2928 ----- 2932 ----- 2937 ----- 2940 ----- 2944 ----- 2948 ----- 2952 ----- 2955 ----- 2960 ----- 2963 ----- 2966 ----- 2970 ----- 2974 ----- 2977 ----- 2980 ----- 2983 ----- 2986 ----- 2989 ----- 2992 ----- 2995 ----- 2998 ----- 3000
- │ │ histogram(2)= 0 9117 0 9054 0 8748 0 8748 0 8946 0 8973 0 9189 0 8910 0 9297 0 9018
+ │ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ histogram(1)= 0 90 351 108 324 144 351 108 387 81 432 63 387 90 387 81 333 117 387 108 369 117 414 90 396 126 369 126 423 90 342 99 378 90 432 126 378 108 369 81 432 144 414 99 423 72 387 126 423 99 378 135 432 108 405 54 423 117 270 189 405 45 432 99 324 126 405 108 378 135 396 99 369 90 360 144 378 90 351 99 423 117 351 99 369 72 396 108 360 90 396 108 387 81 333 117 414 99 396 63 423 135 414 54 333 162 342 144 315 135 396 90 378 144 414 63 378 99 396 153 324 117 297 135 360 117 333 162 369 108 423 117 414 99 315 117 414 81 315 126 387 81 279 153 378 81 360 144 423 90 396 99 360 90 351 126 270 153 414 81 360 144 306 144 297 144 369 99 360 72 351 117 288 135 315 135 405 117 342 99 396 108 396 81 342 99 351 99 405 99 414 108 369 90 414 90 396 99 333 108 297 135 333 117 378 99 387 81 333 135 333 135 297 126 342 108 342 144 342 90 351 63 405 63 396 126 369 153 315 144 279 144 306 126 333 108 252 171 279 135 306 144 297 126 387 45 279 126 369 81 387 81 342 153 315 99 369 126 360 117 387 117 342 126 351 81 360 72 351 99 369 81 306 108 378 126 324 117 387 117 369 135 342 72 324 90 369 108 306 108 351 144 324 117 306 99 360 90 333 117 315 72 288 108 279 117 333 72 288 99 279 117 369 63 279 135 342 72 333 135 252 180 315 171 333 45 270 153 288 108 342 54 342 72 342 135 243 126 351 99 297 81 270 126 324 81 270 144 270 99 360 144 324 54 333 108 306 108 342 135 315 81 315 108 234 126 297 117 279 54 270 126 306 63 189 171 288 99 279 99 243 108 288 99 225 108 261 54 297 153 234 99 216 180 171 135 144 90 0 126
+ │ │ <--- 2101 ----- 2106 ----- 2110 ----- 2115 ----- 2121 ----- 2127 ----- 2132 ----- 2137 ----- 2142 ----- 2146 ----- 2150 ----- 2155 ----- 2160 ----- 2164 ----- 2170 ----- 2175 ----- 2179 ----- 2184 ----- 2189 ----- 2194 ----- 2200 ----- 2205 ----- 2211 ----- 2216 ----- 2221 ----- 2226 ----- 2231 ----- 2236 ----- 2242 ----- 2246 ----- 2251 ----- 2257 ----- 2262 ----- 2266 ----- 2271 ----- 2276 ----- 2280 ----- 2284 ----- 2289 ----- 2293 ----- 2298 ----- 2302 ----- 2307 ----- 2314 ----- 2318 ----- 2323 ----- 2328 ----- 2332 ----- 2337 ----- 2342 ----- 2347 ----- 2352 ----- 2357 ----- 2361 ----- 2365 ----- 2370 ----- 2376 ----- 2382 ----- 2387 ----- 2392 ----- 2397 ----- 2401 ----- 2406 ----- 2411 ----- 2416 ----- 2421 ----- 2427 ----- 2431 ----- 2436 ----- 2441 ----- 2446 ----- 2450 ----- 2455 ----- 2460 ----- 2465 ----- 2470 ----- 2475 ----- 2480 ----- 2484 ----- 2489 ----- 2493 ----- 2497 ----- 2501 ----- 2506 ----- 2510 ----- 2515 ----- 2519 ----- 2524 ----- 2529 ----- 2533 ----- 2538 ----- 2543 ----- 2547 ----- 2551 ----- 2557 ----- 2561 ----- 2565 ----- 2569 ----- 2574 ----- 2578 ----- 2582 ----- 2586 ----- 2591 ----- 2595 ----- 2600 ----- 2605 ----- 2609 ----- 2613 ----- 2618 ----- 2622 ----- 2627 ----- 2632 ----- 2637 ----- 2642 ----- 2646 ----- 2649 ----- 2653 ----- 2657 ----- 2661 ----- 2665 ----- 2669 ----- 2673 ----- 2677 ----- 2681 ----- 2686 ----- 2690 ----- 2694 ----- 2698 ----- 2703 ----- 2708 ----- 2714 ----- 2718 ----- 2723 ----- 2728 ----- 2733 ----- 2737 ----- 2741 ----- 2746 ----- 2750 ----- 2756 ----- 2761 ----- 2766 ----- 2770 ----- 2775 ----- 2779 ----- 2784 ----- 2788 ----- 2792 ----- 2797 ----- 2802 ----- 2807 ----- 2811 ----- 2815 ----- 2820 ----- 2823 ----- 2827 ----- 2831 ----- 2835 ----- 2840 ----- 2845 ----- 2849 ----- 2854 ----- 2858 ----- 2861 ----- 2866 ----- 2871 ----- 2875 ----- 2879 ----- 2883 ----- 2887 ----- 2890 ----- 2893 ----- 2897 ----- 2901 ----- 2905 ----- 2910 ----- 2914 ----- 2919 ----- 2923 ----- 2927 ----- 2931 ----- 2936 ----- 2939 ----- 2942 ----- 2946 ----- 2951 ----- 2956 ----- 2959 ----- 2963 ----- 2967 ----- 2971 ----- 2974 ----- 2977 ----- 2981 ----- 2985 ----- 2988 ----- 2992 ----- 2996 ----- 2999 --- 3000
+ │ │ histogram(2)= 0 8622 0 8928 0 8883 0 9279 0 8946 0 9315 0 9171 0 9063 0 8613 0 9180
│ │ <--- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 ---- 10
- │ │ histogram(3)= 0 8838 0 8802 0 9531 0 8595 0 8820 0 9369 0 8748 0 9342 0 8784 0 9171
+ │ │ histogram(3)= 0 9171 0 9198 0 8919 0 8586 0 8712 0 9414 0 8694 0 9495 0 9378 0 8433
│ │ <--- 0 ---- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 -
│ ├── key: (1-3)
│ └── ordering: +3,+2
@@ -911,19 +911,19 @@ group-by (streaming)
├── save-table-name: consistency_04_group_by_1
├── columns: max:11(int!null) [hidden: o_d_id:2(int!null) o_w_id:3(int!null)]
├── grouping columns: o_d_id:2(int!null) o_w_id:3(int!null)
- ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(11)=100, null(11)=0, avgsize(11)=8, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(11)=100, null(11)=0, avgsize(11)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
├── key: (2,3)
├── fd: (2,3)-->(11)
├── ordering: +3,+2
├── scan order@order_idx
│ ├── save-table-name: consistency_04_scan_2
│ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null)
- │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ histogram(1)= 0 60 1470 90 1410 150 1470 150 1350 180 1470 120 1410 120 1410 90 1470 120 1350 150 1440 60 1350 210 1380 120 1410 90 1440 90 1470 120 1470 90 1320 240 1440 60 1410 150 1470 180 1470 90 1410 90 1380 150 1320 180 1470 90 1320 270 1470 120 1470 60 1470 90 1470 120 1440 150 1410 90 1380 120 1290 180 1320 180 1440 60 1230 240 1380 90 1440 150 1410 150 1230 240 1410 210 1440 150 1380 240 1320 300 1440 90 1440 60 1290 210 1440 240 1380 180 1350 150 1320 150 1380 120 1440 150 1380 120 1410 120 1230 300 1440 60 1350 150 1410 120 1410 60 1410 90 1440 30 1380 90 1440 60 1440 30 1290 240 1380 90 1410 120 1350 120 1380 150 1440 120 1350 240 1410 120 1440 60 1410 90 1410 60 1440 60 1440 150 1410 210 1440 90 1170 330 1440 90 1290 270 1200 300 1440 150 1380 90 1410 90 1440 120 1380 90 1380 120 1290 180 1350 150 1350 180 1410 60 1290 180 1410 150 1410 60 1440 60 1440 60 1440 150 1440 120 1410 180 1440 60 1350 180 1440 90 1440 180 1380 90 1380 90 1350 180 1380 120 1410 60 1440 60 1350 120 1410 120 1350 120 1410 90 1350 150 1350 150 1410 180 1410 90 1380 120 1410 60 1380 120 1410 90 1410 90 1440 60 1380 90 1410 150 1380 120 1290 210 1440 90 1410 90 1410 90 1410 150 1260 180 1350 150 1320 240 1320 180 1380 60 1320 120 1410 90 1350 150 1350 150 1350 120 1380 150 1410 60 1410 270 1350 150 1320 150 1320 150 1380 180 1350 90 1260 300 1350 180 1380 90 1320 150 1410 60 1380 90 1410 120 1380 90 1230 300 1380 120 1410 60 1320 150 1350 120 1410 30 1380 210 1380 120 1290 120 1380 180 1380 120 1320 90 1170 270 1290 120 1320 120 1380 120 1380 60 1230 180 1290 150 1320 90 1350 60 1320 180 1380 60 1350 60 1380 120 1350 90 1350 120 1320 210 1320 150 1320 60 1350 210 1230 180 1260 150 1260 150 1230 90 1170 210 1290 90 1200 90
- │ │ <--- 1 ------ 14 ------ 30 ------ 44 ------ 54 ------ 68 ------ 81 ------ 98 ------ 111 ------ 125 ------ 138 ------ 157 ------ 173 ------ 188 ------ 203 ------ 219 ------ 240 ------ 255 ------ 272 ------ 287 ------ 303 ------ 320 ------ 333 ------ 349 ------ 360 ------ 379 ------ 393 ------ 408 ------ 424 ------ 439 ------ 458 ------ 474 ------ 489 ------ 506 ------ 519 ------ 532 ------ 549 ------ 563 ------ 577 ------ 593 ------ 613 ------ 627 ------ 642 ------ 658 ------ 676 ------ 691 ------ 705 ------ 720 ------ 736 ------ 749 ------ 767 ------ 782 ------ 794 ------ 808 ------ 825 ------ 839 ------ 856 ------ 868 ------ 885 ------ 899 ------ 914 ------ 930 ------ 946 ------ 963 ------ 982 ------ 998 ------ 1014 ------ 1029 ------ 1047 ------ 1064 ------ 1080 ------ 1095 ------ 1110 ------ 1126 ------ 1143 ------ 1161 ------ 1176 ------ 1190 ------ 1204 ------ 1225 ------ 1240 ------ 1255 ------ 1271 ------ 1285 ------ 1302 ------ 1317 ------ 1333 ------ 1348 ------ 1364 ------ 1379 ------ 1396 ------ 1412 ------ 1427 ------ 1443 ------ 1456 ------ 1474 ------ 1484 ------ 1500 ------ 1512 ------ 1528 ------ 1543 ------ 1559 ------ 1576 ------ 1592 ------ 1606 ------ 1619 ------ 1636 ------ 1655 ------ 1669 ------ 1686 ------ 1705 ------ 1721 ------ 1734 ------ 1746 ------ 1761 ------ 1777 ------ 1789 ------ 1803 ------ 1816 ------ 1831 ------ 1847 ------ 1861 ------ 1875 ------ 1893 ------ 1910 ------ 1926 ------ 1941 ------ 1955 ------ 1966 ------ 1981 ------ 1996 ------ 2011 ------ 2024 ------ 2039 ------ 2053 ------ 2067 ------ 2083 ------ 2099 ------ 2116 ------ 2130 ------ 2148 ------ 2165 ------ 2182 ------ 2198 ------ 2209 ------ 2224 ------ 2237 ------ 2251 ------ 2270 ------ 2282 ------ 2293 ------ 2307 ------ 2324 ------ 2338 ------ 2351 ------ 2365 ------ 2383 ------ 2397 ------ 2413 ------ 2427 ------ 2440 ------ 2453 ------ 2467 ------ 2480 ------ 2494 ------ 2508 ------ 2523 ------ 2538 ------ 2553 ------ 2568 ------ 2586 ------ 2601 ------ 2616 ------ 2629 ------ 2641 ------ 2655 ------ 2669 ------ 2684 ------ 2701 ------ 2717 ------ 2735 ------ 2747 ------ 2760 ------ 2774 ------ 2789 ------ 2806 ------ 2821 ------ 2835 ------ 2848 ------ 2862 ------ 2877 ------ 2892 ------ 2907 ------ 2918 ------ 2935 ------ 2951 ------ 2963 ------ 2974 ------ 2988 ------ 3000
- │ │ histogram(2)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ histogram(1)= 0 60 1380 120 1440 180 1380 180 1440 60 1470 150 1410 240 1410 90 1350 210 1440 150 1380 120 1410 120 1410 150 1380 120 1440 120 1470 180 1440 120 1410 90 1410 120 1380 210 1440 60 1440 60 1410 150 1440 180 1350 150 1440 150 1440 150 1440 60 1440 90 1380 150 1350 150 1350 120 1410 120 1350 150 1410 90 1410 60 1380 90 1290 210 1410 180 1230 270 1440 210 1320 150 1410 120 1320 180 1440 180 1410 90 1350 150 1260 240 1290 210 1410 180 1380 150 1320 180 1380 120 1440 180 1320 150 1290 180 1410 90 1410 60 1380 120 1320 180 1380 150 1410 180 1380 150 1380 120 1380 120 1410 60 1350 150 1440 30 1320 150 1320 210 1350 120 1440 30 1440 30 1350 150 1350 270 1440 60 1380 90 1440 180 1410 60 1290 180 1410 120 1440 90 1440 60 1440 90 1260 210 1380 120 1380 150 1440 120 1440 90 1320 240 1320 150 1260 210 1290 180 1290 210 1410 120 1380 90 1410 150 1440 90 1440 60 1440 60 1440 210 1440 120 1410 120 1320 150 1440 30 1410 150 1380 120 1440 120 1410 60 1350 150 1410 120 1350 120 1440 90 1440 150 1290 180 1350 180 1320 150 1440 60 1410 90 1350 120 1410 210 1380 150 1350 270 1320 180 1350 150 1440 120 1410 90 1380 180 1440 150 1380 90 1200 270 1410 240 1440 30 1410 60 1440 90 1380 120 1410 120 1440 60 1440 60 1380 90 1410 120 1380 90 1410 30 1440 60 1410 120 1350 120 1290 210 1380 150 1380 90 1410 90 1380 90 1320 210 1290 180 1380 90 1350 90 1320 150 1380 120 1410 150 1410 30 1380 90 1410 120 1410 60 1410 30 1410 180 1410 60 1380 60 1410 120 1290 270 1350 120 1380 60 1410 60 1260 180 1290 150 1410 210 1410 60 1380 90 1380 60 1320 120 1380 180 1290 150 1380 60 1290 150 1290 150 1260 210 1290 120 1320 90 1380 60 1350 60 1350 90 1410 210 1320 150 1380 120 1260 150 1260 150 1320 120 1320 90 1260 120 1200 240 1230 210 1290 30
+ │ │ <--- 1 ------ 17 ------ 31 ------ 46 ------ 62 ------ 77 ------ 90 ------ 107 ------ 120 ------ 135 ------ 151 ------ 163 ------ 178 ------ 189 ------ 204 ------ 222 ------ 239 ------ 254 ------ 268 ------ 285 ------ 298 ------ 310 ------ 324 ------ 338 ------ 354 ------ 368 ------ 386 ------ 398 ------ 412 ------ 426 ------ 443 ------ 459 ------ 478 ------ 494 ------ 510 ------ 524 ------ 539 ------ 555 ------ 570 ------ 584 ------ 601 ------ 612 ------ 626 ------ 641 ------ 656 ------ 670 ------ 686 ------ 698 ------ 709 ------ 720 ------ 738 ------ 758 ------ 773 ------ 786 ------ 799 ------ 813 ------ 833 ------ 847 ------ 863 ------ 878 ------ 893 ------ 910 ------ 925 ------ 938 ------ 955 ------ 971 ------ 983 ------ 999 ------ 1017 ------ 1030 ------ 1044 ------ 1063 ------ 1077 ------ 1092 ------ 1108 ------ 1126 ------ 1139 ------ 1160 ------ 1176 ------ 1192 ------ 1208 ------ 1226 ------ 1239 ------ 1252 ------ 1266 ------ 1280 ------ 1294 ------ 1310 ------ 1326 ------ 1342 ------ 1352 ------ 1365 ------ 1378 ------ 1393 ------ 1409 ------ 1423 ------ 1439 ------ 1457 ------ 1470 ------ 1489 ------ 1507 ------ 1522 ------ 1532 ------ 1545 ------ 1558 ------ 1571 ------ 1583 ------ 1600 ------ 1614 ------ 1626 ------ 1641 ------ 1660 ------ 1673 ------ 1688 ------ 1701 ------ 1718 ------ 1731 ------ 1745 ------ 1762 ------ 1781 ------ 1797 ------ 1809 ------ 1825 ------ 1839 ------ 1852 ------ 1869 ------ 1882 ------ 1898 ------ 1916 ------ 1930 ------ 1945 ------ 1958 ------ 1974 ------ 1989 ------ 2006 ------ 2028 ------ 2044 ------ 2060 ------ 2080 ------ 2094 ------ 2112 ------ 2123 ------ 2138 ------ 2153 ------ 2168 ------ 2181 ------ 2196 ------ 2213 ------ 2228 ------ 2244 ------ 2260 ------ 2275 ------ 2288 ------ 2301 ------ 2316 ------ 2330 ------ 2347 ------ 2363 ------ 2378 ------ 2393 ------ 2411 ------ 2429 ------ 2443 ------ 2459 ------ 2478 ------ 2493 ------ 2509 ------ 2524 ------ 2541 ------ 2557 ------ 2575 ------ 2588 ------ 2603 ------ 2617 ------ 2628 ------ 2640 ------ 2656 ------ 2671 ------ 2684 ------ 2697 ------ 2714 ------ 2727 ------ 2748 ------ 2766 ------ 2780 ------ 2797 ------ 2811 ------ 2828 ------ 2839 ------ 2856 ------ 2873 ------ 2887 ------ 2904 ------ 2919 ------ 2931 ------ 2947 ------ 2960 ------ 2971 ------ 2984 ------ 3000
+ │ │ histogram(2)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ │ histogram(3)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ │ histogram(3)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
│ ├── key: (1-3)
│ └── ordering: +3,+2
@@ -978,7 +978,7 @@ scalar-group-by
│ ├── save-table-name: consistency_05_select_2
│ ├── columns: no_d_id:2(int!null) no_w_id:3(int!null) max:6(int!null) min:7(int!null) count_rows:8(int!null)
│ ├── immutable
- │ ├── stats: [rows=33.33333, distinct(2)=9.82658, null(2)=0, avgsize(2)=4, distinct(3)=9.82658, null(3)=0, avgsize(3)=4, distinct(6)=33.3333, null(6)=0, avgsize(6)=8, distinct(7)=33.3333, null(7)=0, avgsize(7)=8, distinct(8)=33.3333, null(8)=0, avgsize(8)=8]
+ │ ├── stats: [rows=33.33333, distinct(2)=9.82658, null(2)=0, avgsize(2)=1, distinct(3)=9.82658, null(3)=0, avgsize(3)=1, distinct(6)=33.3333, null(6)=0, avgsize(6)=2, distinct(7)=33.3333, null(7)=0, avgsize(7)=2, distinct(8)=33.3333, null(8)=0, avgsize(8)=2]
│ ├── key: (2,3)
│ ├── fd: (2,3)-->(6-8)
│ ├── group-by (streaming)
@@ -986,18 +986,18 @@ scalar-group-by
│ │ ├── columns: no_d_id:2(int!null) no_w_id:3(int!null) max:6(int!null) min:7(int!null) count_rows:8(int!null)
│ │ ├── grouping columns: no_d_id:2(int!null) no_w_id:3(int!null)
│ │ ├── internal-ordering: +3,+2
- │ │ ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(6)=100, null(6)=0, avgsize(6)=8, distinct(7)=100, null(7)=0, avgsize(7)=8, distinct(8)=100, null(8)=0, avgsize(8)=8, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ │ │ ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(6)=100, null(6)=0, avgsize(6)=2, distinct(7)=100, null(7)=0, avgsize(7)=2, distinct(8)=100, null(8)=0, avgsize(8)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
│ │ ├── key: (2,3)
│ │ ├── fd: (2,3)-->(6-8)
│ │ ├── scan new_order
│ │ │ ├── save-table-name: consistency_05_scan_4
│ │ │ ├── columns: no_o_id:1(int!null) no_d_id:2(int!null) no_w_id:3(int!null)
- │ │ │ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ │ │ histogram(1)= 0 117 405 81 423 63 441 99 360 135 423 108 351 198 351 108 414 99 423 99 387 108 405 117 414 36 414 108 432 126 333 108 396 108 360 108 405 81 414 126 378 72 432 135 351 117 369 126 369 117 423 99 342 126 360 144 360 117 360 99 396 99 405 81 432 81 396 72 396 54 342 108 414 81 414 72 351 90 405 99 333 135 333 126 432 54 360 135 315 117 333 117 369 81 405 63 378 171 396 99 360 135 423 63 315 126 324 108 279 153 342 90 387 63 288 153 351 108 396 180 297 135 387 81 360 153 414 144 414 54 333 144 333 135 387 144 423 108 387 72 342 117 315 144 396 45 405 117 405 72 378 135 396 63 351 117 297 126 360 108 378 54 396 189 342 90 378 108 342 126 396 108 378 90 315 108 297 126 396 117 351 126 405 99 405 99 360 99 342 99 369 81 414 99 306 144 306 108 333 126 387 117 360 54 360 108 351 81 342 126 405 135 369 54 333 81 324 144 396 72 342 90 351 99 396 45 387 126 351 126 342 153 405 171 315 126 369 117 351 63 297 126 333 162 270 153 324 108 306 117 396 81 306 144 351 135 351 54 351 135 342 72 396 153 369 135 378 126 297 117 360 117 333 90 351 117 360 90 387 153 369 81 315 117 324 63 315 90 297 108 315 90 306 81 315 117 378 108 342 126 306 108 324 90 360 135 252 180 333 144 360 99 369 135 279 126 315 117 297 90 351 81 306 81 279 126 252 135 315 90 279 99 288 81 351 90 324 99 207 153 261 153 306 81 243 135 351 72 351 54 288 90 342 81 288 108 333 90 324 99 333 54 234 144 297 72 297 99 252 162 252 108 279 90 207 126 252 108 261 72 270 99 198 189 270 81 234 90 234 99 180 126 261 117 216 99 171 99 117 108
- │ │ │ │ <--- 2101 ----- 2106 ----- 2111 ----- 2117 ----- 2121 ----- 2126 ----- 2132 ----- 2136 ----- 2141 ----- 2147 ----- 2152 ----- 2156 ----- 2162 ----- 2167 ----- 2172 ----- 2177 ----- 2181 ----- 2186 ----- 2190 ----- 2196 ----- 2201 ----- 2205 ----- 2210 ----- 2217 ----- 2222 ----- 2227 ----- 2232 ----- 2237 ----- 2242 ----- 2247 ----- 2252 ----- 2257 ----- 2263 ----- 2268 ----- 2273 ----- 2278 ----- 2284 ----- 2290 ----- 2294 ----- 2299 ----- 2303 ----- 2308 ----- 2313 ----- 2318 ----- 2321 ----- 2325 ----- 2330 ----- 2335 ----- 2340 ----- 2345 ----- 2350 ----- 2355 ----- 2359 ----- 2363 ----- 2367 ----- 2372 ----- 2377 ----- 2380 ----- 2385 ----- 2390 ----- 2394 ----- 2399 ----- 2404 ----- 2409 ----- 2414 ----- 2418 ----- 2422 ----- 2426 ----- 2431 ----- 2436 ----- 2440 ----- 2444 ----- 2449 ----- 2454 ----- 2460 ----- 2465 ----- 2471 ----- 2476 ----- 2480 ----- 2484 ----- 2488 ----- 2493 ----- 2498 ----- 2503 ----- 2507 ----- 2511 ----- 2516 ----- 2520 ----- 2524 ----- 2530 ----- 2535 ----- 2540 ----- 2545 ----- 2549 ----- 2554 ----- 2559 ----- 2565 ----- 2569 ----- 2573 ----- 2578 ----- 2582 ----- 2586 ----- 2590 ----- 2594 ----- 2599 ----- 2604 ----- 2609 ----- 2614 ----- 2618 ----- 2623 ----- 2629 ----- 2634 ----- 2640 ----- 2645 ----- 2648 ----- 2653 ----- 2657 ----- 2662 ----- 2666 ----- 2671 ----- 2675 ----- 2679 ----- 2683 ----- 2688 ----- 2692 ----- 2697 ----- 2701 ----- 2707 ----- 2711 ----- 2716 ----- 2720 ----- 2724 ----- 2729 ----- 2734 ----- 2739 ----- 2743 ----- 2748 ----- 2754 ----- 2759 ----- 2764 ----- 2768 ----- 2772 ----- 2776 ----- 2781 ----- 2785 ----- 2790 ----- 2794 ----- 2798 ----- 2803 ----- 2807 ----- 2811 ----- 2815 ----- 2819 ----- 2822 ----- 2826 ----- 2831 ----- 2837 ----- 2841 ----- 2845 ----- 2849 ----- 2853 ----- 2858 ----- 2861 ----- 2864 ----- 2868 ----- 2872 ----- 2877 ----- 2882 ----- 2886 ----- 2890 ----- 2894 ----- 2899 ----- 2903 ----- 2908 ----- 2912 ----- 2916 ----- 2920 ----- 2924 ----- 2928 ----- 2932 ----- 2937 ----- 2940 ----- 2944 ----- 2948 ----- 2952 ----- 2955 ----- 2960 ----- 2963 ----- 2966 ----- 2970 ----- 2974 ----- 2977 ----- 2980 ----- 2983 ----- 2986 ----- 2989 ----- 2992 ----- 2995 ----- 2998 ----- 3000
- │ │ │ │ histogram(2)= 0 9117 0 9054 0 8748 0 8748 0 8946 0 8973 0 9189 0 8910 0 9297 0 9018
+ │ │ │ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ │ │ histogram(1)= 0 90 351 108 324 144 351 108 387 81 432 63 387 90 387 81 333 117 387 108 369 117 414 90 396 126 369 126 423 90 342 99 378 90 432 126 378 108 369 81 432 144 414 99 423 72 387 126 423 99 378 135 432 108 405 54 423 117 270 189 405 45 432 99 324 126 405 108 378 135 396 99 369 90 360 144 378 90 351 99 423 117 351 99 369 72 396 108 360 90 396 108 387 81 333 117 414 99 396 63 423 135 414 54 333 162 342 144 315 135 396 90 378 144 414 63 378 99 396 153 324 117 297 135 360 117 333 162 369 108 423 117 414 99 315 117 414 81 315 126 387 81 279 153 378 81 360 144 423 90 396 99 360 90 351 126 270 153 414 81 360 144 306 144 297 144 369 99 360 72 351 117 288 135 315 135 405 117 342 99 396 108 396 81 342 99 351 99 405 99 414 108 369 90 414 90 396 99 333 108 297 135 333 117 378 99 387 81 333 135 333 135 297 126 342 108 342 144 342 90 351 63 405 63 396 126 369 153 315 144 279 144 306 126 333 108 252 171 279 135 306 144 297 126 387 45 279 126 369 81 387 81 342 153 315 99 369 126 360 117 387 117 342 126 351 81 360 72 351 99 369 81 306 108 378 126 324 117 387 117 369 135 342 72 324 90 369 108 306 108 351 144 324 117 306 99 360 90 333 117 315 72 288 108 279 117 333 72 288 99 279 117 369 63 279 135 342 72 333 135 252 180 315 171 333 45 270 153 288 108 342 54 342 72 342 135 243 126 351 99 297 81 270 126 324 81 270 144 270 99 360 144 324 54 333 108 306 108 342 135 315 81 315 108 234 126 297 117 279 54 270 126 306 63 189 171 288 99 279 99 243 108 288 99 225 108 261 54 297 153 234 99 216 180 171 135 144 90 0 126
+ │ │ │ │ <--- 2101 ----- 2106 ----- 2110 ----- 2115 ----- 2121 ----- 2127 ----- 2132 ----- 2137 ----- 2142 ----- 2146 ----- 2150 ----- 2155 ----- 2160 ----- 2164 ----- 2170 ----- 2175 ----- 2179 ----- 2184 ----- 2189 ----- 2194 ----- 2200 ----- 2205 ----- 2211 ----- 2216 ----- 2221 ----- 2226 ----- 2231 ----- 2236 ----- 2242 ----- 2246 ----- 2251 ----- 2257 ----- 2262 ----- 2266 ----- 2271 ----- 2276 ----- 2280 ----- 2284 ----- 2289 ----- 2293 ----- 2298 ----- 2302 ----- 2307 ----- 2314 ----- 2318 ----- 2323 ----- 2328 ----- 2332 ----- 2337 ----- 2342 ----- 2347 ----- 2352 ----- 2357 ----- 2361 ----- 2365 ----- 2370 ----- 2376 ----- 2382 ----- 2387 ----- 2392 ----- 2397 ----- 2401 ----- 2406 ----- 2411 ----- 2416 ----- 2421 ----- 2427 ----- 2431 ----- 2436 ----- 2441 ----- 2446 ----- 2450 ----- 2455 ----- 2460 ----- 2465 ----- 2470 ----- 2475 ----- 2480 ----- 2484 ----- 2489 ----- 2493 ----- 2497 ----- 2501 ----- 2506 ----- 2510 ----- 2515 ----- 2519 ----- 2524 ----- 2529 ----- 2533 ----- 2538 ----- 2543 ----- 2547 ----- 2551 ----- 2557 ----- 2561 ----- 2565 ----- 2569 ----- 2574 ----- 2578 ----- 2582 ----- 2586 ----- 2591 ----- 2595 ----- 2600 ----- 2605 ----- 2609 ----- 2613 ----- 2618 ----- 2622 ----- 2627 ----- 2632 ----- 2637 ----- 2642 ----- 2646 ----- 2649 ----- 2653 ----- 2657 ----- 2661 ----- 2665 ----- 2669 ----- 2673 ----- 2677 ----- 2681 ----- 2686 ----- 2690 ----- 2694 ----- 2698 ----- 2703 ----- 2708 ----- 2714 ----- 2718 ----- 2723 ----- 2728 ----- 2733 ----- 2737 ----- 2741 ----- 2746 ----- 2750 ----- 2756 ----- 2761 ----- 2766 ----- 2770 ----- 2775 ----- 2779 ----- 2784 ----- 2788 ----- 2792 ----- 2797 ----- 2802 ----- 2807 ----- 2811 ----- 2815 ----- 2820 ----- 2823 ----- 2827 ----- 2831 ----- 2835 ----- 2840 ----- 2845 ----- 2849 ----- 2854 ----- 2858 ----- 2861 ----- 2866 ----- 2871 ----- 2875 ----- 2879 ----- 2883 ----- 2887 ----- 2890 ----- 2893 ----- 2897 ----- 2901 ----- 2905 ----- 2910 ----- 2914 ----- 2919 ----- 2923 ----- 2927 ----- 2931 ----- 2936 ----- 2939 ----- 2942 ----- 2946 ----- 2951 ----- 2956 ----- 2959 ----- 2963 ----- 2967 ----- 2971 ----- 2974 ----- 2977 ----- 2981 ----- 2985 ----- 2988 ----- 2992 ----- 2996 ----- 2999 --- 3000
+ │ │ │ │ histogram(2)= 0 8622 0 8928 0 8883 0 9279 0 8946 0 9315 0 9171 0 9063 0 8613 0 9180
│ │ │ │ <--- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 ---- 10
- │ │ │ │ histogram(3)= 0 8838 0 8802 0 9531 0 8595 0 8820 0 9369 0 8748 0 9342 0 8784 0 9171
+ │ │ │ │ histogram(3)= 0 9171 0 9198 0 8919 0 8586 0 8712 0 9414 0 8694 0 9495 0 9378 0 8433
│ │ │ │ <--- 0 ---- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 -
│ │ │ ├── key: (1-3)
│ │ │ └── ordering: +3,+2
@@ -1073,19 +1073,19 @@ group-by (streaming)
├── save-table-name: consistency_06_group_by_1
├── columns: sum:11(decimal) [hidden: o_d_id:2(int!null) o_w_id:3(int!null)]
├── grouping columns: o_d_id:2(int!null) o_w_id:3(int!null)
- ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(11)=100, null(11)=0, avgsize(11)=8, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(11)=100, null(11)=0, avgsize(11)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
├── key: (2,3)
├── fd: (2,3)-->(11)
├── ordering: +3,+2
├── scan order
│ ├── save-table-name: consistency_06_scan_2
│ ├── columns: o_d_id:2(int!null) o_w_id:3(int!null) o_ol_cnt:7(int)
- │ ├── stats: [rows=300000, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ histogram(2)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ │ ├── stats: [rows=300000, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(7)=11, null(7)=0, avgsize(7)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ histogram(2)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ │ histogram(3)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ │ histogram(3)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
- │ │ histogram(7)= 0 26280 2.4576e+05 27960
+ │ │ histogram(7)= 0 26550 2.4696e+05 26490
│ │ <---- 5 ------------- 15 -
│ └── ordering: +3,+2
└── aggregations
@@ -1127,17 +1127,17 @@ group-by (streaming)
├── save-table-name: consistency_07_group_by_1
├── columns: count:13(int!null) [hidden: ol_d_id:2(int!null) ol_w_id:3(int!null)]
├── grouping columns: ol_d_id:2(int!null) ol_w_id:3(int!null)
- ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(13)=100, null(13)=0, avgsize(13)=8, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ ├── stats: [rows=100, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(13)=100, null(13)=0, avgsize(13)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
├── key: (2,3)
├── fd: (2,3)-->(13)
├── ordering: +3,+2
├── scan order_line
│ ├── save-table-name: consistency_07_scan_2
│ ├── columns: ol_d_id:2(int!null) ol_w_id:3(int!null)
- │ ├── stats: [rows=3001222, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ histogram(2)= 0 2.9292e+05 0 3.0582e+05 0 3.0312e+05 0 2.9712e+05 0 2.9922e+05 0 3.1033e+05 0 3.0132e+05 0 2.9832e+05 0 2.9442e+05 0 2.9862e+05
+ │ ├── stats: [rows=3001222, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ histogram(2)= 0 2.8722e+05 0 3.0822e+05 0 3.0162e+05 0 2.9682e+05 0 3.1063e+05 0 3.0252e+05 0 3.0312e+05 0 3.0432e+05 0 2.9322e+05 0 2.9352e+05
│ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ---------- 10 ---
- │ │ histogram(3)= 0 3.0762e+05 0 2.9352e+05 0 2.9532e+05 0 2.8332e+05 0 2.9142e+05 0 2.9862e+05 0 3.1393e+05 0 2.9442e+05 0 3.1303e+05 0 3.1003e+05
+ │ │ histogram(3)= 0 2.9082e+05 0 2.8632e+05 0 3.1093e+05 0 3.1093e+05 0 3.0732e+05 0 3.1783e+05 0 2.8902e+05 0 3.0342e+05 0 2.8932e+05 0 2.9532e+05
│ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ----
│ └── ordering: +3,+2
└── aggregations
@@ -1176,28 +1176,28 @@ except-all
├── columns: no_w_id:3(int!null) no_d_id:2(int!null) no_o_id:1(int!null)
├── left columns: no_w_id:3(int!null) no_d_id:2(int!null) no_o_id:1(int!null)
├── right columns: o_w_id:8(int) o_d_id:7(int) o_id:6(int)
- ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4]
+ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1]
├── key: (1-3)
├── scan new_order
│ ├── save-table-name: consistency_08_scan_2
│ ├── columns: no_o_id:1(int!null) no_d_id:2(int!null) no_w_id:3(int!null)
- │ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ histogram(1)= 0 117 405 81 423 63 441 99 360 135 423 108 351 198 351 108 414 99 423 99 387 108 405 117 414 36 414 108 432 126 333 108 396 108 360 108 405 81 414 126 378 72 432 135 351 117 369 126 369 117 423 99 342 126 360 144 360 117 360 99 396 99 405 81 432 81 396 72 396 54 342 108 414 81 414 72 351 90 405 99 333 135 333 126 432 54 360 135 315 117 333 117 369 81 405 63 378 171 396 99 360 135 423 63 315 126 324 108 279 153 342 90 387 63 288 153 351 108 396 180 297 135 387 81 360 153 414 144 414 54 333 144 333 135 387 144 423 108 387 72 342 117 315 144 396 45 405 117 405 72 378 135 396 63 351 117 297 126 360 108 378 54 396 189 342 90 378 108 342 126 396 108 378 90 315 108 297 126 396 117 351 126 405 99 405 99 360 99 342 99 369 81 414 99 306 144 306 108 333 126 387 117 360 54 360 108 351 81 342 126 405 135 369 54 333 81 324 144 396 72 342 90 351 99 396 45 387 126 351 126 342 153 405 171 315 126 369 117 351 63 297 126 333 162 270 153 324 108 306 117 396 81 306 144 351 135 351 54 351 135 342 72 396 153 369 135 378 126 297 117 360 117 333 90 351 117 360 90 387 153 369 81 315 117 324 63 315 90 297 108 315 90 306 81 315 117 378 108 342 126 306 108 324 90 360 135 252 180 333 144 360 99 369 135 279 126 315 117 297 90 351 81 306 81 279 126 252 135 315 90 279 99 288 81 351 90 324 99 207 153 261 153 306 81 243 135 351 72 351 54 288 90 342 81 288 108 333 90 324 99 333 54 234 144 297 72 297 99 252 162 252 108 279 90 207 126 252 108 261 72 270 99 198 189 270 81 234 90 234 99 180 126 261 117 216 99 171 99 117 108
- │ │ <--- 2101 ----- 2106 ----- 2111 ----- 2117 ----- 2121 ----- 2126 ----- 2132 ----- 2136 ----- 2141 ----- 2147 ----- 2152 ----- 2156 ----- 2162 ----- 2167 ----- 2172 ----- 2177 ----- 2181 ----- 2186 ----- 2190 ----- 2196 ----- 2201 ----- 2205 ----- 2210 ----- 2217 ----- 2222 ----- 2227 ----- 2232 ----- 2237 ----- 2242 ----- 2247 ----- 2252 ----- 2257 ----- 2263 ----- 2268 ----- 2273 ----- 2278 ----- 2284 ----- 2290 ----- 2294 ----- 2299 ----- 2303 ----- 2308 ----- 2313 ----- 2318 ----- 2321 ----- 2325 ----- 2330 ----- 2335 ----- 2340 ----- 2345 ----- 2350 ----- 2355 ----- 2359 ----- 2363 ----- 2367 ----- 2372 ----- 2377 ----- 2380 ----- 2385 ----- 2390 ----- 2394 ----- 2399 ----- 2404 ----- 2409 ----- 2414 ----- 2418 ----- 2422 ----- 2426 ----- 2431 ----- 2436 ----- 2440 ----- 2444 ----- 2449 ----- 2454 ----- 2460 ----- 2465 ----- 2471 ----- 2476 ----- 2480 ----- 2484 ----- 2488 ----- 2493 ----- 2498 ----- 2503 ----- 2507 ----- 2511 ----- 2516 ----- 2520 ----- 2524 ----- 2530 ----- 2535 ----- 2540 ----- 2545 ----- 2549 ----- 2554 ----- 2559 ----- 2565 ----- 2569 ----- 2573 ----- 2578 ----- 2582 ----- 2586 ----- 2590 ----- 2594 ----- 2599 ----- 2604 ----- 2609 ----- 2614 ----- 2618 ----- 2623 ----- 2629 ----- 2634 ----- 2640 ----- 2645 ----- 2648 ----- 2653 ----- 2657 ----- 2662 ----- 2666 ----- 2671 ----- 2675 ----- 2679 ----- 2683 ----- 2688 ----- 2692 ----- 2697 ----- 2701 ----- 2707 ----- 2711 ----- 2716 ----- 2720 ----- 2724 ----- 2729 ----- 2734 ----- 2739 ----- 2743 ----- 2748 ----- 2754 ----- 2759 ----- 2764 ----- 2768 ----- 2772 ----- 2776 ----- 2781 ----- 2785 ----- 2790 ----- 2794 ----- 2798 ----- 2803 ----- 2807 ----- 2811 ----- 2815 ----- 2819 ----- 2822 ----- 2826 ----- 2831 ----- 2837 ----- 2841 ----- 2845 ----- 2849 ----- 2853 ----- 2858 ----- 2861 ----- 2864 ----- 2868 ----- 2872 ----- 2877 ----- 2882 ----- 2886 ----- 2890 ----- 2894 ----- 2899 ----- 2903 ----- 2908 ----- 2912 ----- 2916 ----- 2920 ----- 2924 ----- 2928 ----- 2932 ----- 2937 ----- 2940 ----- 2944 ----- 2948 ----- 2952 ----- 2955 ----- 2960 ----- 2963 ----- 2966 ----- 2970 ----- 2974 ----- 2977 ----- 2980 ----- 2983 ----- 2986 ----- 2989 ----- 2992 ----- 2995 ----- 2998 ----- 3000
- │ │ histogram(2)= 0 9117 0 9054 0 8748 0 8748 0 8946 0 8973 0 9189 0 8910 0 9297 0 9018
+ │ ├── stats: [rows=90000, distinct(1)=900, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ histogram(1)= 0 90 351 108 324 144 351 108 387 81 432 63 387 90 387 81 333 117 387 108 369 117 414 90 396 126 369 126 423 90 342 99 378 90 432 126 378 108 369 81 432 144 414 99 423 72 387 126 423 99 378 135 432 108 405 54 423 117 270 189 405 45 432 99 324 126 405 108 378 135 396 99 369 90 360 144 378 90 351 99 423 117 351 99 369 72 396 108 360 90 396 108 387 81 333 117 414 99 396 63 423 135 414 54 333 162 342 144 315 135 396 90 378 144 414 63 378 99 396 153 324 117 297 135 360 117 333 162 369 108 423 117 414 99 315 117 414 81 315 126 387 81 279 153 378 81 360 144 423 90 396 99 360 90 351 126 270 153 414 81 360 144 306 144 297 144 369 99 360 72 351 117 288 135 315 135 405 117 342 99 396 108 396 81 342 99 351 99 405 99 414 108 369 90 414 90 396 99 333 108 297 135 333 117 378 99 387 81 333 135 333 135 297 126 342 108 342 144 342 90 351 63 405 63 396 126 369 153 315 144 279 144 306 126 333 108 252 171 279 135 306 144 297 126 387 45 279 126 369 81 387 81 342 153 315 99 369 126 360 117 387 117 342 126 351 81 360 72 351 99 369 81 306 108 378 126 324 117 387 117 369 135 342 72 324 90 369 108 306 108 351 144 324 117 306 99 360 90 333 117 315 72 288 108 279 117 333 72 288 99 279 117 369 63 279 135 342 72 333 135 252 180 315 171 333 45 270 153 288 108 342 54 342 72 342 135 243 126 351 99 297 81 270 126 324 81 270 144 270 99 360 144 324 54 333 108 306 108 342 135 315 81 315 108 234 126 297 117 279 54 270 126 306 63 189 171 288 99 279 99 243 108 288 99 225 108 261 54 297 153 234 99 216 180 171 135 144 90 0 126
+ │ │ <--- 2101 ----- 2106 ----- 2110 ----- 2115 ----- 2121 ----- 2127 ----- 2132 ----- 2137 ----- 2142 ----- 2146 ----- 2150 ----- 2155 ----- 2160 ----- 2164 ----- 2170 ----- 2175 ----- 2179 ----- 2184 ----- 2189 ----- 2194 ----- 2200 ----- 2205 ----- 2211 ----- 2216 ----- 2221 ----- 2226 ----- 2231 ----- 2236 ----- 2242 ----- 2246 ----- 2251 ----- 2257 ----- 2262 ----- 2266 ----- 2271 ----- 2276 ----- 2280 ----- 2284 ----- 2289 ----- 2293 ----- 2298 ----- 2302 ----- 2307 ----- 2314 ----- 2318 ----- 2323 ----- 2328 ----- 2332 ----- 2337 ----- 2342 ----- 2347 ----- 2352 ----- 2357 ----- 2361 ----- 2365 ----- 2370 ----- 2376 ----- 2382 ----- 2387 ----- 2392 ----- 2397 ----- 2401 ----- 2406 ----- 2411 ----- 2416 ----- 2421 ----- 2427 ----- 2431 ----- 2436 ----- 2441 ----- 2446 ----- 2450 ----- 2455 ----- 2460 ----- 2465 ----- 2470 ----- 2475 ----- 2480 ----- 2484 ----- 2489 ----- 2493 ----- 2497 ----- 2501 ----- 2506 ----- 2510 ----- 2515 ----- 2519 ----- 2524 ----- 2529 ----- 2533 ----- 2538 ----- 2543 ----- 2547 ----- 2551 ----- 2557 ----- 2561 ----- 2565 ----- 2569 ----- 2574 ----- 2578 ----- 2582 ----- 2586 ----- 2591 ----- 2595 ----- 2600 ----- 2605 ----- 2609 ----- 2613 ----- 2618 ----- 2622 ----- 2627 ----- 2632 ----- 2637 ----- 2642 ----- 2646 ----- 2649 ----- 2653 ----- 2657 ----- 2661 ----- 2665 ----- 2669 ----- 2673 ----- 2677 ----- 2681 ----- 2686 ----- 2690 ----- 2694 ----- 2698 ----- 2703 ----- 2708 ----- 2714 ----- 2718 ----- 2723 ----- 2728 ----- 2733 ----- 2737 ----- 2741 ----- 2746 ----- 2750 ----- 2756 ----- 2761 ----- 2766 ----- 2770 ----- 2775 ----- 2779 ----- 2784 ----- 2788 ----- 2792 ----- 2797 ----- 2802 ----- 2807 ----- 2811 ----- 2815 ----- 2820 ----- 2823 ----- 2827 ----- 2831 ----- 2835 ----- 2840 ----- 2845 ----- 2849 ----- 2854 ----- 2858 ----- 2861 ----- 2866 ----- 2871 ----- 2875 ----- 2879 ----- 2883 ----- 2887 ----- 2890 ----- 2893 ----- 2897 ----- 2901 ----- 2905 ----- 2910 ----- 2914 ----- 2919 ----- 2923 ----- 2927 ----- 2931 ----- 2936 ----- 2939 ----- 2942 ----- 2946 ----- 2951 ----- 2956 ----- 2959 ----- 2963 ----- 2967 ----- 2971 ----- 2974 ----- 2977 ----- 2981 ----- 2985 ----- 2988 ----- 2992 ----- 2996 ----- 2999 --- 3000
+ │ │ histogram(2)= 0 8622 0 8928 0 8883 0 9279 0 8946 0 9315 0 9171 0 9063 0 8613 0 9180
│ │ <--- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 ---- 10
- │ │ histogram(3)= 0 8838 0 8802 0 9531 0 8595 0 8820 0 9369 0 8748 0 9342 0 8784 0 9171
+ │ │ histogram(3)= 0 9171 0 9198 0 8919 0 8586 0 8712 0 9414 0 8694 0 9495 0 9378 0 8433
│ │ <--- 0 ---- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 -
│ └── key: (1-3)
└── project
├── save-table-name: consistency_08_project_3
├── columns: o_id:6(int!null) o_d_id:7(int!null) o_w_id:8(int!null)
- ├── stats: [rows=90000, distinct(6)=2999, null(6)=0, avgsize(6)=4, distinct(7)=10, null(7)=0, avgsize(7)=4, distinct(8)=10, null(8)=0, avgsize(8)=4, distinct(7,8)=100, null(7,8)=0, avgsize(7,8)=8]
+ ├── stats: [rows=90000, distinct(6)=2999, null(6)=0, avgsize(6)=3, distinct(7)=10, null(7)=0, avgsize(7)=1, distinct(8)=10, null(8)=0, avgsize(8)=1, distinct(7,8)=100, null(7,8)=0, avgsize(7,8)=2]
├── key: (6-8)
└── select
├── save-table-name: consistency_08_select_4
├── columns: o_id:6(int!null) o_d_id:7(int!null) o_w_id:8(int!null) o_carrier_id:11(int)
- ├── stats: [rows=90000, distinct(6)=2999, null(6)=0, avgsize(6)=4, distinct(7)=10, null(7)=0, avgsize(7)=4, distinct(8)=10, null(8)=0, avgsize(8)=4, distinct(11)=1, null(11)=90000, avgsize(11)=4, distinct(7,8)=100, null(7,8)=0, avgsize(7,8)=8]
+ ├── stats: [rows=90000, distinct(6)=2999, null(6)=0, avgsize(6)=3, distinct(7)=10, null(7)=0, avgsize(7)=1, distinct(8)=10, null(8)=0, avgsize(8)=1, distinct(11)=1, null(11)=90000, avgsize(11)=2, distinct(7,8)=100, null(7,8)=0, avgsize(7,8)=2]
│ histogram(11)= 0 90000
│ <--- NULL
├── key: (6-8)
@@ -1205,14 +1205,14 @@ except-all
├── scan order@order_idx
│ ├── save-table-name: consistency_08_scan_5
│ ├── columns: o_id:6(int!null) o_d_id:7(int!null) o_w_id:8(int!null) o_carrier_id:11(int)
- │ ├── stats: [rows=300000, distinct(6)=2999, null(6)=0, avgsize(6)=4, distinct(7)=10, null(7)=0, avgsize(7)=4, distinct(8)=10, null(8)=0, avgsize(8)=4, distinct(11)=11, null(11)=90000, avgsize(11)=4, distinct(7,8)=100, null(7,8)=0, avgsize(7,8)=8]
- │ │ histogram(6)= 0 60 1470 90 1410 150 1470 150 1350 180 1470 120 1410 120 1410 90 1470 120 1350 150 1440 60 1350 210 1380 120 1410 90 1440 90 1470 120 1470 90 1320 240 1440 60 1410 150 1470 180 1470 90 1410 90 1380 150 1320 180 1470 90 1320 270 1470 120 1470 60 1470 90 1470 120 1440 150 1410 90 1380 120 1290 180 1320 180 1440 60 1230 240 1380 90 1440 150 1410 150 1230 240 1410 210 1440 150 1380 240 1320 300 1440 90 1440 60 1290 210 1440 240 1380 180 1350 150 1320 150 1380 120 1440 150 1380 120 1410 120 1230 300 1440 60 1350 150 1410 120 1410 60 1410 90 1440 30 1380 90 1440 60 1440 30 1290 240 1380 90 1410 120 1350 120 1380 150 1440 120 1350 240 1410 120 1440 60 1410 90 1410 60 1440 60 1440 150 1410 210 1440 90 1170 330 1440 90 1290 270 1200 300 1440 150 1380 90 1410 90 1440 120 1380 90 1380 120 1290 180 1350 150 1350 180 1410 60 1290 180 1410 150 1410 60 1440 60 1440 60 1440 150 1440 120 1410 180 1440 60 1350 180 1440 90 1440 180 1380 90 1380 90 1350 180 1380 120 1410 60 1440 60 1350 120 1410 120 1350 120 1410 90 1350 150 1350 150 1410 180 1410 90 1380 120 1410 60 1380 120 1410 90 1410 90 1440 60 1380 90 1410 150 1380 120 1290 210 1440 90 1410 90 1410 90 1410 150 1260 180 1350 150 1320 240 1320 180 1380 60 1320 120 1410 90 1350 150 1350 150 1350 120 1380 150 1410 60 1410 270 1350 150 1320 150 1320 150 1380 180 1350 90 1260 300 1350 180 1380 90 1320 150 1410 60 1380 90 1410 120 1380 90 1230 300 1380 120 1410 60 1320 150 1350 120 1410 30 1380 210 1380 120 1290 120 1380 180 1380 120 1320 90 1170 270 1290 120 1320 120 1380 120 1380 60 1230 180 1290 150 1320 90 1350 60 1320 180 1380 60 1350 60 1380 120 1350 90 1350 120 1320 210 1320 150 1320 60 1350 210 1230 180 1260 150 1260 150 1230 90 1170 210 1290 90 1200 90
- │ │ <--- 1 ------ 14 ------ 30 ------ 44 ------ 54 ------ 68 ------ 81 ------ 98 ------ 111 ------ 125 ------ 138 ------ 157 ------ 173 ------ 188 ------ 203 ------ 219 ------ 240 ------ 255 ------ 272 ------ 287 ------ 303 ------ 320 ------ 333 ------ 349 ------ 360 ------ 379 ------ 393 ------ 408 ------ 424 ------ 439 ------ 458 ------ 474 ------ 489 ------ 506 ------ 519 ------ 532 ------ 549 ------ 563 ------ 577 ------ 593 ------ 613 ------ 627 ------ 642 ------ 658 ------ 676 ------ 691 ------ 705 ------ 720 ------ 736 ------ 749 ------ 767 ------ 782 ------ 794 ------ 808 ------ 825 ------ 839 ------ 856 ------ 868 ------ 885 ------ 899 ------ 914 ------ 930 ------ 946 ------ 963 ------ 982 ------ 998 ------ 1014 ------ 1029 ------ 1047 ------ 1064 ------ 1080 ------ 1095 ------ 1110 ------ 1126 ------ 1143 ------ 1161 ------ 1176 ------ 1190 ------ 1204 ------ 1225 ------ 1240 ------ 1255 ------ 1271 ------ 1285 ------ 1302 ------ 1317 ------ 1333 ------ 1348 ------ 1364 ------ 1379 ------ 1396 ------ 1412 ------ 1427 ------ 1443 ------ 1456 ------ 1474 ------ 1484 ------ 1500 ------ 1512 ------ 1528 ------ 1543 ------ 1559 ------ 1576 ------ 1592 ------ 1606 ------ 1619 ------ 1636 ------ 1655 ------ 1669 ------ 1686 ------ 1705 ------ 1721 ------ 1734 ------ 1746 ------ 1761 ------ 1777 ------ 1789 ------ 1803 ------ 1816 ------ 1831 ------ 1847 ------ 1861 ------ 1875 ------ 1893 ------ 1910 ------ 1926 ------ 1941 ------ 1955 ------ 1966 ------ 1981 ------ 1996 ------ 2011 ------ 2024 ------ 2039 ------ 2053 ------ 2067 ------ 2083 ------ 2099 ------ 2116 ------ 2130 ------ 2148 ------ 2165 ------ 2182 ------ 2198 ------ 2209 ------ 2224 ------ 2237 ------ 2251 ------ 2270 ------ 2282 ------ 2293 ------ 2307 ------ 2324 ------ 2338 ------ 2351 ------ 2365 ------ 2383 ------ 2397 ------ 2413 ------ 2427 ------ 2440 ------ 2453 ------ 2467 ------ 2480 ------ 2494 ------ 2508 ------ 2523 ------ 2538 ------ 2553 ------ 2568 ------ 2586 ------ 2601 ------ 2616 ------ 2629 ------ 2641 ------ 2655 ------ 2669 ------ 2684 ------ 2701 ------ 2717 ------ 2735 ------ 2747 ------ 2760 ------ 2774 ------ 2789 ------ 2806 ------ 2821 ------ 2835 ------ 2848 ------ 2862 ------ 2877 ------ 2892 ------ 2907 ------ 2918 ------ 2935 ------ 2951 ------ 2963 ------ 2974 ------ 2988 ------ 3000
- │ │ histogram(7)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ │ ├── stats: [rows=300000, distinct(6)=2999, null(6)=0, avgsize(6)=3, distinct(7)=10, null(7)=0, avgsize(7)=1, distinct(8)=10, null(8)=0, avgsize(8)=1, distinct(11)=11, null(11)=90000, avgsize(11)=2, distinct(7,8)=100, null(7,8)=0, avgsize(7,8)=2]
+ │ │ histogram(6)= 0 60 1380 120 1440 180 1380 180 1440 60 1470 150 1410 240 1410 90 1350 210 1440 150 1380 120 1410 120 1410 150 1380 120 1440 120 1470 180 1440 120 1410 90 1410 120 1380 210 1440 60 1440 60 1410 150 1440 180 1350 150 1440 150 1440 150 1440 60 1440 90 1380 150 1350 150 1350 120 1410 120 1350 150 1410 90 1410 60 1380 90 1290 210 1410 180 1230 270 1440 210 1320 150 1410 120 1320 180 1440 180 1410 90 1350 150 1260 240 1290 210 1410 180 1380 150 1320 180 1380 120 1440 180 1320 150 1290 180 1410 90 1410 60 1380 120 1320 180 1380 150 1410 180 1380 150 1380 120 1380 120 1410 60 1350 150 1440 30 1320 150 1320 210 1350 120 1440 30 1440 30 1350 150 1350 270 1440 60 1380 90 1440 180 1410 60 1290 180 1410 120 1440 90 1440 60 1440 90 1260 210 1380 120 1380 150 1440 120 1440 90 1320 240 1320 150 1260 210 1290 180 1290 210 1410 120 1380 90 1410 150 1440 90 1440 60 1440 60 1440 210 1440 120 1410 120 1320 150 1440 30 1410 150 1380 120 1440 120 1410 60 1350 150 1410 120 1350 120 1440 90 1440 150 1290 180 1350 180 1320 150 1440 60 1410 90 1350 120 1410 210 1380 150 1350 270 1320 180 1350 150 1440 120 1410 90 1380 180 1440 150 1380 90 1200 270 1410 240 1440 30 1410 60 1440 90 1380 120 1410 120 1440 60 1440 60 1380 90 1410 120 1380 90 1410 30 1440 60 1410 120 1350 120 1290 210 1380 150 1380 90 1410 90 1380 90 1320 210 1290 180 1380 90 1350 90 1320 150 1380 120 1410 150 1410 30 1380 90 1410 120 1410 60 1410 30 1410 180 1410 60 1380 60 1410 120 1290 270 1350 120 1380 60 1410 60 1260 180 1290 150 1410 210 1410 60 1380 90 1380 60 1320 120 1380 180 1290 150 1380 60 1290 150 1290 150 1260 210 1290 120 1320 90 1380 60 1350 60 1350 90 1410 210 1320 150 1380 120 1260 150 1260 150 1320 120 1320 90 1260 120 1200 240 1230 210 1290 30
+ │ │ <--- 1 ------ 17 ------ 31 ------ 46 ------ 62 ------ 77 ------ 90 ------ 107 ------ 120 ------ 135 ------ 151 ------ 163 ------ 178 ------ 189 ------ 204 ------ 222 ------ 239 ------ 254 ------ 268 ------ 285 ------ 298 ------ 310 ------ 324 ------ 338 ------ 354 ------ 368 ------ 386 ------ 398 ------ 412 ------ 426 ------ 443 ------ 459 ------ 478 ------ 494 ------ 510 ------ 524 ------ 539 ------ 555 ------ 570 ------ 584 ------ 601 ------ 612 ------ 626 ------ 641 ------ 656 ------ 670 ------ 686 ------ 698 ------ 709 ------ 720 ------ 738 ------ 758 ------ 773 ------ 786 ------ 799 ------ 813 ------ 833 ------ 847 ------ 863 ------ 878 ------ 893 ------ 910 ------ 925 ------ 938 ------ 955 ------ 971 ------ 983 ------ 999 ------ 1017 ------ 1030 ------ 1044 ------ 1063 ------ 1077 ------ 1092 ------ 1108 ------ 1126 ------ 1139 ------ 1160 ------ 1176 ------ 1192 ------ 1208 ------ 1226 ------ 1239 ------ 1252 ------ 1266 ------ 1280 ------ 1294 ------ 1310 ------ 1326 ------ 1342 ------ 1352 ------ 1365 ------ 1378 ------ 1393 ------ 1409 ------ 1423 ------ 1439 ------ 1457 ------ 1470 ------ 1489 ------ 1507 ------ 1522 ------ 1532 ------ 1545 ------ 1558 ------ 1571 ------ 1583 ------ 1600 ------ 1614 ------ 1626 ------ 1641 ------ 1660 ------ 1673 ------ 1688 ------ 1701 ------ 1718 ------ 1731 ------ 1745 ------ 1762 ------ 1781 ------ 1797 ------ 1809 ------ 1825 ------ 1839 ------ 1852 ------ 1869 ------ 1882 ------ 1898 ------ 1916 ------ 1930 ------ 1945 ------ 1958 ------ 1974 ------ 1989 ------ 2006 ------ 2028 ------ 2044 ------ 2060 ------ 2080 ------ 2094 ------ 2112 ------ 2123 ------ 2138 ------ 2153 ------ 2168 ------ 2181 ------ 2196 ------ 2213 ------ 2228 ------ 2244 ------ 2260 ------ 2275 ------ 2288 ------ 2301 ------ 2316 ------ 2330 ------ 2347 ------ 2363 ------ 2378 ------ 2393 ------ 2411 ------ 2429 ------ 2443 ------ 2459 ------ 2478 ------ 2493 ------ 2509 ------ 2524 ------ 2541 ------ 2557 ------ 2575 ------ 2588 ------ 2603 ------ 2617 ------ 2628 ------ 2640 ------ 2656 ------ 2671 ------ 2684 ------ 2697 ------ 2714 ------ 2727 ------ 2748 ------ 2766 ------ 2780 ------ 2797 ------ 2811 ------ 2828 ------ 2839 ------ 2856 ------ 2873 ------ 2887 ------ 2904 ------ 2919 ------ 2931 ------ 2947 ------ 2960 ------ 2971 ------ 2984 ------ 3000
+ │ │ histogram(7)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ │ histogram(8)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ │ histogram(8)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
- │ │ histogram(11)= 0 90000 0 20768 1.6732e+05 21913
+ │ │ histogram(11)= 0 90000 0 21169 1.6751e+05 21318
│ │ <--- NULL ---- 1 ------------- 10 -
│ ├── key: (6-8)
│ └── fd: (6-8)-->(11)
@@ -1291,17 +1291,17 @@ except-all
├── columns: o_w_id:3(int!null) o_d_id:2(int!null) o_id:1(int!null)
├── left columns: o_w_id:3(int!null) o_d_id:2(int!null) o_id:1(int!null)
├── right columns: no_w_id:13(int) no_d_id:12(int) no_o_id:11(int)
- ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4]
+ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1]
├── key: (1-3)
├── project
│ ├── save-table-name: consistency_09_project_2
│ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null)
- │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
│ ├── key: (1-3)
│ └── select
│ ├── save-table-name: consistency_09_select_3
│ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null) o_carrier_id:6(int)
- │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(6)=1, null(6)=90000, avgsize(6)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
+ │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(6)=1, null(6)=90000, avgsize(6)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
│ │ histogram(6)= 0 90000
│ │ <--- NULL
│ ├── key: (1-3)
@@ -1309,14 +1309,14 @@ except-all
│ ├── scan order@order_idx
│ │ ├── save-table-name: consistency_09_scan_4
│ │ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null) o_carrier_id:6(int)
- │ │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(6)=11, null(6)=90000, avgsize(6)=4, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=8]
- │ │ │ histogram(1)= 0 60 1470 90 1410 150 1470 150 1350 180 1470 120 1410 120 1410 90 1470 120 1350 150 1440 60 1350 210 1380 120 1410 90 1440 90 1470 120 1470 90 1320 240 1440 60 1410 150 1470 180 1470 90 1410 90 1380 150 1320 180 1470 90 1320 270 1470 120 1470 60 1470 90 1470 120 1440 150 1410 90 1380 120 1290 180 1320 180 1440 60 1230 240 1380 90 1440 150 1410 150 1230 240 1410 210 1440 150 1380 240 1320 300 1440 90 1440 60 1290 210 1440 240 1380 180 1350 150 1320 150 1380 120 1440 150 1380 120 1410 120 1230 300 1440 60 1350 150 1410 120 1410 60 1410 90 1440 30 1380 90 1440 60 1440 30 1290 240 1380 90 1410 120 1350 120 1380 150 1440 120 1350 240 1410 120 1440 60 1410 90 1410 60 1440 60 1440 150 1410 210 1440 90 1170 330 1440 90 1290 270 1200 300 1440 150 1380 90 1410 90 1440 120 1380 90 1380 120 1290 180 1350 150 1350 180 1410 60 1290 180 1410 150 1410 60 1440 60 1440 60 1440 150 1440 120 1410 180 1440 60 1350 180 1440 90 1440 180 1380 90 1380 90 1350 180 1380 120 1410 60 1440 60 1350 120 1410 120 1350 120 1410 90 1350 150 1350 150 1410 180 1410 90 1380 120 1410 60 1380 120 1410 90 1410 90 1440 60 1380 90 1410 150 1380 120 1290 210 1440 90 1410 90 1410 90 1410 150 1260 180 1350 150 1320 240 1320 180 1380 60 1320 120 1410 90 1350 150 1350 150 1350 120 1380 150 1410 60 1410 270 1350 150 1320 150 1320 150 1380 180 1350 90 1260 300 1350 180 1380 90 1320 150 1410 60 1380 90 1410 120 1380 90 1230 300 1380 120 1410 60 1320 150 1350 120 1410 30 1380 210 1380 120 1290 120 1380 180 1380 120 1320 90 1170 270 1290 120 1320 120 1380 120 1380 60 1230 180 1290 150 1320 90 1350 60 1320 180 1380 60 1350 60 1380 120 1350 90 1350 120 1320 210 1320 150 1320 60 1350 210 1230 180 1260 150 1260 150 1230 90 1170 210 1290 90 1200 90
- │ │ │ <--- 1 ------ 14 ------ 30 ------ 44 ------ 54 ------ 68 ------ 81 ------ 98 ------ 111 ------ 125 ------ 138 ------ 157 ------ 173 ------ 188 ------ 203 ------ 219 ------ 240 ------ 255 ------ 272 ------ 287 ------ 303 ------ 320 ------ 333 ------ 349 ------ 360 ------ 379 ------ 393 ------ 408 ------ 424 ------ 439 ------ 458 ------ 474 ------ 489 ------ 506 ------ 519 ------ 532 ------ 549 ------ 563 ------ 577 ------ 593 ------ 613 ------ 627 ------ 642 ------ 658 ------ 676 ------ 691 ------ 705 ------ 720 ------ 736 ------ 749 ------ 767 ------ 782 ------ 794 ------ 808 ------ 825 ------ 839 ------ 856 ------ 868 ------ 885 ------ 899 ------ 914 ------ 930 ------ 946 ------ 963 ------ 982 ------ 998 ------ 1014 ------ 1029 ------ 1047 ------ 1064 ------ 1080 ------ 1095 ------ 1110 ------ 1126 ------ 1143 ------ 1161 ------ 1176 ------ 1190 ------ 1204 ------ 1225 ------ 1240 ------ 1255 ------ 1271 ------ 1285 ------ 1302 ------ 1317 ------ 1333 ------ 1348 ------ 1364 ------ 1379 ------ 1396 ------ 1412 ------ 1427 ------ 1443 ------ 1456 ------ 1474 ------ 1484 ------ 1500 ------ 1512 ------ 1528 ------ 1543 ------ 1559 ------ 1576 ------ 1592 ------ 1606 ------ 1619 ------ 1636 ------ 1655 ------ 1669 ------ 1686 ------ 1705 ------ 1721 ------ 1734 ------ 1746 ------ 1761 ------ 1777 ------ 1789 ------ 1803 ------ 1816 ------ 1831 ------ 1847 ------ 1861 ------ 1875 ------ 1893 ------ 1910 ------ 1926 ------ 1941 ------ 1955 ------ 1966 ------ 1981 ------ 1996 ------ 2011 ------ 2024 ------ 2039 ------ 2053 ------ 2067 ------ 2083 ------ 2099 ------ 2116 ------ 2130 ------ 2148 ------ 2165 ------ 2182 ------ 2198 ------ 2209 ------ 2224 ------ 2237 ------ 2251 ------ 2270 ------ 2282 ------ 2293 ------ 2307 ------ 2324 ------ 2338 ------ 2351 ------ 2365 ------ 2383 ------ 2397 ------ 2413 ------ 2427 ------ 2440 ------ 2453 ------ 2467 ------ 2480 ------ 2494 ------ 2508 ------ 2523 ------ 2538 ------ 2553 ------ 2568 ------ 2586 ------ 2601 ------ 2616 ------ 2629 ------ 2641 ------ 2655 ------ 2669 ------ 2684 ------ 2701 ------ 2717 ------ 2735 ------ 2747 ------ 2760 ------ 2774 ------ 2789 ------ 2806 ------ 2821 ------ 2835 ------ 2848 ------ 2862 ------ 2877 ------ 2892 ------ 2907 ------ 2918 ------ 2935 ------ 2951 ------ 2963 ------ 2974 ------ 2988 ------ 3000
- │ │ │ histogram(2)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ │ │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(6)=11, null(6)=90000, avgsize(6)=2, distinct(2,3)=100, null(2,3)=0, avgsize(2,3)=2]
+ │ │ │ histogram(1)= 0 60 1380 120 1440 180 1380 180 1440 60 1470 150 1410 240 1410 90 1350 210 1440 150 1380 120 1410 120 1410 150 1380 120 1440 120 1470 180 1440 120 1410 90 1410 120 1380 210 1440 60 1440 60 1410 150 1440 180 1350 150 1440 150 1440 150 1440 60 1440 90 1380 150 1350 150 1350 120 1410 120 1350 150 1410 90 1410 60 1380 90 1290 210 1410 180 1230 270 1440 210 1320 150 1410 120 1320 180 1440 180 1410 90 1350 150 1260 240 1290 210 1410 180 1380 150 1320 180 1380 120 1440 180 1320 150 1290 180 1410 90 1410 60 1380 120 1320 180 1380 150 1410 180 1380 150 1380 120 1380 120 1410 60 1350 150 1440 30 1320 150 1320 210 1350 120 1440 30 1440 30 1350 150 1350 270 1440 60 1380 90 1440 180 1410 60 1290 180 1410 120 1440 90 1440 60 1440 90 1260 210 1380 120 1380 150 1440 120 1440 90 1320 240 1320 150 1260 210 1290 180 1290 210 1410 120 1380 90 1410 150 1440 90 1440 60 1440 60 1440 210 1440 120 1410 120 1320 150 1440 30 1410 150 1380 120 1440 120 1410 60 1350 150 1410 120 1350 120 1440 90 1440 150 1290 180 1350 180 1320 150 1440 60 1410 90 1350 120 1410 210 1380 150 1350 270 1320 180 1350 150 1440 120 1410 90 1380 180 1440 150 1380 90 1200 270 1410 240 1440 30 1410 60 1440 90 1380 120 1410 120 1440 60 1440 60 1380 90 1410 120 1380 90 1410 30 1440 60 1410 120 1350 120 1290 210 1380 150 1380 90 1410 90 1380 90 1320 210 1290 180 1380 90 1350 90 1320 150 1380 120 1410 150 1410 30 1380 90 1410 120 1410 60 1410 30 1410 180 1410 60 1380 60 1410 120 1290 270 1350 120 1380 60 1410 60 1260 180 1290 150 1410 210 1410 60 1380 90 1380 60 1320 120 1380 180 1290 150 1380 60 1290 150 1290 150 1260 210 1290 120 1320 90 1380 60 1350 60 1350 90 1410 210 1320 150 1380 120 1260 150 1260 150 1320 120 1320 90 1260 120 1200 240 1230 210 1290 30
+ │ │ │ <--- 1 ------ 17 ------ 31 ------ 46 ------ 62 ------ 77 ------ 90 ------ 107 ------ 120 ------ 135 ------ 151 ------ 163 ------ 178 ------ 189 ------ 204 ------ 222 ------ 239 ------ 254 ------ 268 ------ 285 ------ 298 ------ 310 ------ 324 ------ 338 ------ 354 ------ 368 ------ 386 ------ 398 ------ 412 ------ 426 ------ 443 ------ 459 ------ 478 ------ 494 ------ 510 ------ 524 ------ 539 ------ 555 ------ 570 ------ 584 ------ 601 ------ 612 ------ 626 ------ 641 ------ 656 ------ 670 ------ 686 ------ 698 ------ 709 ------ 720 ------ 738 ------ 758 ------ 773 ------ 786 ------ 799 ------ 813 ------ 833 ------ 847 ------ 863 ------ 878 ------ 893 ------ 910 ------ 925 ------ 938 ------ 955 ------ 971 ------ 983 ------ 999 ------ 1017 ------ 1030 ------ 1044 ------ 1063 ------ 1077 ------ 1092 ------ 1108 ------ 1126 ------ 1139 ------ 1160 ------ 1176 ------ 1192 ------ 1208 ------ 1226 ------ 1239 ------ 1252 ------ 1266 ------ 1280 ------ 1294 ------ 1310 ------ 1326 ------ 1342 ------ 1352 ------ 1365 ------ 1378 ------ 1393 ------ 1409 ------ 1423 ------ 1439 ------ 1457 ------ 1470 ------ 1489 ------ 1507 ------ 1522 ------ 1532 ------ 1545 ------ 1558 ------ 1571 ------ 1583 ------ 1600 ------ 1614 ------ 1626 ------ 1641 ------ 1660 ------ 1673 ------ 1688 ------ 1701 ------ 1718 ------ 1731 ------ 1745 ------ 1762 ------ 1781 ------ 1797 ------ 1809 ------ 1825 ------ 1839 ------ 1852 ------ 1869 ------ 1882 ------ 1898 ------ 1916 ------ 1930 ------ 1945 ------ 1958 ------ 1974 ------ 1989 ------ 2006 ------ 2028 ------ 2044 ------ 2060 ------ 2080 ------ 2094 ------ 2112 ------ 2123 ------ 2138 ------ 2153 ------ 2168 ------ 2181 ------ 2196 ------ 2213 ------ 2228 ------ 2244 ------ 2260 ------ 2275 ------ 2288 ------ 2301 ------ 2316 ------ 2330 ------ 2347 ------ 2363 ------ 2378 ------ 2393 ------ 2411 ------ 2429 ------ 2443 ------ 2459 ------ 2478 ------ 2493 ------ 2509 ------ 2524 ------ 2541 ------ 2557 ------ 2575 ------ 2588 ------ 2603 ------ 2617 ------ 2628 ------ 2640 ------ 2656 ------ 2671 ------ 2684 ------ 2697 ------ 2714 ------ 2727 ------ 2748 ------ 2766 ------ 2780 ------ 2797 ------ 2811 ------ 2828 ------ 2839 ------ 2856 ------ 2873 ------ 2887 ------ 2904 ------ 2919 ------ 2931 ------ 2947 ------ 2960 ------ 2971 ------ 2984 ------ 3000
+ │ │ │ histogram(2)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ │ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ │ │ histogram(3)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ │ │ histogram(3)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ │ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
- │ │ │ histogram(6)= 0 90000 0 20768 1.6732e+05 21913
+ │ │ │ histogram(6)= 0 90000 0 21169 1.6751e+05 21318
│ │ │ <--- NULL ---- 1 ------------- 10 -
│ │ ├── key: (1-3)
│ │ └── fd: (1-3)-->(6)
@@ -1325,12 +1325,12 @@ except-all
└── scan new_order
├── save-table-name: consistency_09_scan_5
├── columns: no_o_id:11(int!null) no_d_id:12(int!null) no_w_id:13(int!null)
- ├── stats: [rows=90000, distinct(11)=900, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(12,13)=100, null(12,13)=0, avgsize(12,13)=8]
- │ histogram(11)= 0 117 405 81 423 63 441 99 360 135 423 108 351 198 351 108 414 99 423 99 387 108 405 117 414 36 414 108 432 126 333 108 396 108 360 108 405 81 414 126 378 72 432 135 351 117 369 126 369 117 423 99 342 126 360 144 360 117 360 99 396 99 405 81 432 81 396 72 396 54 342 108 414 81 414 72 351 90 405 99 333 135 333 126 432 54 360 135 315 117 333 117 369 81 405 63 378 171 396 99 360 135 423 63 315 126 324 108 279 153 342 90 387 63 288 153 351 108 396 180 297 135 387 81 360 153 414 144 414 54 333 144 333 135 387 144 423 108 387 72 342 117 315 144 396 45 405 117 405 72 378 135 396 63 351 117 297 126 360 108 378 54 396 189 342 90 378 108 342 126 396 108 378 90 315 108 297 126 396 117 351 126 405 99 405 99 360 99 342 99 369 81 414 99 306 144 306 108 333 126 387 117 360 54 360 108 351 81 342 126 405 135 369 54 333 81 324 144 396 72 342 90 351 99 396 45 387 126 351 126 342 153 405 171 315 126 369 117 351 63 297 126 333 162 270 153 324 108 306 117 396 81 306 144 351 135 351 54 351 135 342 72 396 153 369 135 378 126 297 117 360 117 333 90 351 117 360 90 387 153 369 81 315 117 324 63 315 90 297 108 315 90 306 81 315 117 378 108 342 126 306 108 324 90 360 135 252 180 333 144 360 99 369 135 279 126 315 117 297 90 351 81 306 81 279 126 252 135 315 90 279 99 288 81 351 90 324 99 207 153 261 153 306 81 243 135 351 72 351 54 288 90 342 81 288 108 333 90 324 99 333 54 234 144 297 72 297 99 252 162 252 108 279 90 207 126 252 108 261 72 270 99 198 189 270 81 234 90 234 99 180 126 261 117 216 99 171 99 117 108
- │ <--- 2101 ----- 2106 ----- 2111 ----- 2117 ----- 2121 ----- 2126 ----- 2132 ----- 2136 ----- 2141 ----- 2147 ----- 2152 ----- 2156 ----- 2162 ----- 2167 ----- 2172 ----- 2177 ----- 2181 ----- 2186 ----- 2190 ----- 2196 ----- 2201 ----- 2205 ----- 2210 ----- 2217 ----- 2222 ----- 2227 ----- 2232 ----- 2237 ----- 2242 ----- 2247 ----- 2252 ----- 2257 ----- 2263 ----- 2268 ----- 2273 ----- 2278 ----- 2284 ----- 2290 ----- 2294 ----- 2299 ----- 2303 ----- 2308 ----- 2313 ----- 2318 ----- 2321 ----- 2325 ----- 2330 ----- 2335 ----- 2340 ----- 2345 ----- 2350 ----- 2355 ----- 2359 ----- 2363 ----- 2367 ----- 2372 ----- 2377 ----- 2380 ----- 2385 ----- 2390 ----- 2394 ----- 2399 ----- 2404 ----- 2409 ----- 2414 ----- 2418 ----- 2422 ----- 2426 ----- 2431 ----- 2436 ----- 2440 ----- 2444 ----- 2449 ----- 2454 ----- 2460 ----- 2465 ----- 2471 ----- 2476 ----- 2480 ----- 2484 ----- 2488 ----- 2493 ----- 2498 ----- 2503 ----- 2507 ----- 2511 ----- 2516 ----- 2520 ----- 2524 ----- 2530 ----- 2535 ----- 2540 ----- 2545 ----- 2549 ----- 2554 ----- 2559 ----- 2565 ----- 2569 ----- 2573 ----- 2578 ----- 2582 ----- 2586 ----- 2590 ----- 2594 ----- 2599 ----- 2604 ----- 2609 ----- 2614 ----- 2618 ----- 2623 ----- 2629 ----- 2634 ----- 2640 ----- 2645 ----- 2648 ----- 2653 ----- 2657 ----- 2662 ----- 2666 ----- 2671 ----- 2675 ----- 2679 ----- 2683 ----- 2688 ----- 2692 ----- 2697 ----- 2701 ----- 2707 ----- 2711 ----- 2716 ----- 2720 ----- 2724 ----- 2729 ----- 2734 ----- 2739 ----- 2743 ----- 2748 ----- 2754 ----- 2759 ----- 2764 ----- 2768 ----- 2772 ----- 2776 ----- 2781 ----- 2785 ----- 2790 ----- 2794 ----- 2798 ----- 2803 ----- 2807 ----- 2811 ----- 2815 ----- 2819 ----- 2822 ----- 2826 ----- 2831 ----- 2837 ----- 2841 ----- 2845 ----- 2849 ----- 2853 ----- 2858 ----- 2861 ----- 2864 ----- 2868 ----- 2872 ----- 2877 ----- 2882 ----- 2886 ----- 2890 ----- 2894 ----- 2899 ----- 2903 ----- 2908 ----- 2912 ----- 2916 ----- 2920 ----- 2924 ----- 2928 ----- 2932 ----- 2937 ----- 2940 ----- 2944 ----- 2948 ----- 2952 ----- 2955 ----- 2960 ----- 2963 ----- 2966 ----- 2970 ----- 2974 ----- 2977 ----- 2980 ----- 2983 ----- 2986 ----- 2989 ----- 2992 ----- 2995 ----- 2998 ----- 3000
- │ histogram(12)= 0 9117 0 9054 0 8748 0 8748 0 8946 0 8973 0 9189 0 8910 0 9297 0 9018
+ ├── stats: [rows=90000, distinct(11)=900, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(12,13)=100, null(12,13)=0, avgsize(12,13)=2]
+ │ histogram(11)= 0 90 351 108 324 144 351 108 387 81 432 63 387 90 387 81 333 117 387 108 369 117 414 90 396 126 369 126 423 90 342 99 378 90 432 126 378 108 369 81 432 144 414 99 423 72 387 126 423 99 378 135 432 108 405 54 423 117 270 189 405 45 432 99 324 126 405 108 378 135 396 99 369 90 360 144 378 90 351 99 423 117 351 99 369 72 396 108 360 90 396 108 387 81 333 117 414 99 396 63 423 135 414 54 333 162 342 144 315 135 396 90 378 144 414 63 378 99 396 153 324 117 297 135 360 117 333 162 369 108 423 117 414 99 315 117 414 81 315 126 387 81 279 153 378 81 360 144 423 90 396 99 360 90 351 126 270 153 414 81 360 144 306 144 297 144 369 99 360 72 351 117 288 135 315 135 405 117 342 99 396 108 396 81 342 99 351 99 405 99 414 108 369 90 414 90 396 99 333 108 297 135 333 117 378 99 387 81 333 135 333 135 297 126 342 108 342 144 342 90 351 63 405 63 396 126 369 153 315 144 279 144 306 126 333 108 252 171 279 135 306 144 297 126 387 45 279 126 369 81 387 81 342 153 315 99 369 126 360 117 387 117 342 126 351 81 360 72 351 99 369 81 306 108 378 126 324 117 387 117 369 135 342 72 324 90 369 108 306 108 351 144 324 117 306 99 360 90 333 117 315 72 288 108 279 117 333 72 288 99 279 117 369 63 279 135 342 72 333 135 252 180 315 171 333 45 270 153 288 108 342 54 342 72 342 135 243 126 351 99 297 81 270 126 324 81 270 144 270 99 360 144 324 54 333 108 306 108 342 135 315 81 315 108 234 126 297 117 279 54 270 126 306 63 189 171 288 99 279 99 243 108 288 99 225 108 261 54 297 153 234 99 216 180 171 135 144 90 0 126
+ │ <--- 2101 ----- 2106 ----- 2110 ----- 2115 ----- 2121 ----- 2127 ----- 2132 ----- 2137 ----- 2142 ----- 2146 ----- 2150 ----- 2155 ----- 2160 ----- 2164 ----- 2170 ----- 2175 ----- 2179 ----- 2184 ----- 2189 ----- 2194 ----- 2200 ----- 2205 ----- 2211 ----- 2216 ----- 2221 ----- 2226 ----- 2231 ----- 2236 ----- 2242 ----- 2246 ----- 2251 ----- 2257 ----- 2262 ----- 2266 ----- 2271 ----- 2276 ----- 2280 ----- 2284 ----- 2289 ----- 2293 ----- 2298 ----- 2302 ----- 2307 ----- 2314 ----- 2318 ----- 2323 ----- 2328 ----- 2332 ----- 2337 ----- 2342 ----- 2347 ----- 2352 ----- 2357 ----- 2361 ----- 2365 ----- 2370 ----- 2376 ----- 2382 ----- 2387 ----- 2392 ----- 2397 ----- 2401 ----- 2406 ----- 2411 ----- 2416 ----- 2421 ----- 2427 ----- 2431 ----- 2436 ----- 2441 ----- 2446 ----- 2450 ----- 2455 ----- 2460 ----- 2465 ----- 2470 ----- 2475 ----- 2480 ----- 2484 ----- 2489 ----- 2493 ----- 2497 ----- 2501 ----- 2506 ----- 2510 ----- 2515 ----- 2519 ----- 2524 ----- 2529 ----- 2533 ----- 2538 ----- 2543 ----- 2547 ----- 2551 ----- 2557 ----- 2561 ----- 2565 ----- 2569 ----- 2574 ----- 2578 ----- 2582 ----- 2586 ----- 2591 ----- 2595 ----- 2600 ----- 2605 ----- 2609 ----- 2613 ----- 2618 ----- 2622 ----- 2627 ----- 2632 ----- 2637 ----- 2642 ----- 2646 ----- 2649 ----- 2653 ----- 2657 ----- 2661 ----- 2665 ----- 2669 ----- 2673 ----- 2677 ----- 2681 ----- 2686 ----- 2690 ----- 2694 ----- 2698 ----- 2703 ----- 2708 ----- 2714 ----- 2718 ----- 2723 ----- 2728 ----- 2733 ----- 2737 ----- 2741 ----- 2746 ----- 2750 ----- 2756 ----- 2761 ----- 2766 ----- 2770 ----- 2775 ----- 2779 ----- 2784 ----- 2788 ----- 2792 ----- 2797 ----- 2802 ----- 2807 ----- 2811 ----- 2815 ----- 2820 ----- 2823 ----- 2827 ----- 2831 ----- 2835 ----- 2840 ----- 2845 ----- 2849 ----- 2854 ----- 2858 ----- 2861 ----- 2866 ----- 2871 ----- 2875 ----- 2879 ----- 2883 ----- 2887 ----- 2890 ----- 2893 ----- 2897 ----- 2901 ----- 2905 ----- 2910 ----- 2914 ----- 2919 ----- 2923 ----- 2927 ----- 2931 ----- 2936 ----- 2939 ----- 2942 ----- 2946 ----- 2951 ----- 2956 ----- 2959 ----- 2963 ----- 2967 ----- 2971 ----- 2974 ----- 2977 ----- 2981 ----- 2985 ----- 2988 ----- 2992 ----- 2996 ----- 2999 --- 3000
+ │ histogram(12)= 0 8622 0 8928 0 8883 0 9279 0 8946 0 9315 0 9171 0 9063 0 8613 0 9180
│ <--- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 ---- 10
- │ histogram(13)= 0 8838 0 8802 0 9531 0 8595 0 8820 0 9369 0 8748 0 9342 0 8784 0 9171
+ │ histogram(13)= 0 9171 0 9198 0 8919 0 8586 0 8712 0 9414 0 8694 0 9495 0 9378 0 8433
│ <--- 0 ---- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 -
└── key: (11-13)
@@ -1416,20 +1416,20 @@ except-all
├── left columns: o_w_id:3(int!null) o_d_id:2(int!null) o_id:1(int!null) o_ol_cnt:7(int)
├── right columns: ol_w_id:13(int) ol_d_id:12(int) ol_o_id:11(int) count_rows:23(int)
├── internal-ordering: +3,+2,-1,+7
- ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(7)=11, null(7)=0, avgsize(7)=4]
+ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(7)=11, null(7)=0, avgsize(7)=2]
├── key: (1-3)
├── fd: (1-3)-->(7)
├── scan order
│ ├── save-table-name: consistency_10_scan_2
│ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null) o_ol_cnt:7(int)
- │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(7)=11, null(7)=0, avgsize(7)=4]
- │ │ histogram(1)= 0 60 1470 90 1410 150 1470 150 1350 180 1470 120 1410 120 1410 90 1470 120 1350 150 1440 60 1350 210 1380 120 1410 90 1440 90 1470 120 1470 90 1320 240 1440 60 1410 150 1470 180 1470 90 1410 90 1380 150 1320 180 1470 90 1320 270 1470 120 1470 60 1470 90 1470 120 1440 150 1410 90 1380 120 1290 180 1320 180 1440 60 1230 240 1380 90 1440 150 1410 150 1230 240 1410 210 1440 150 1380 240 1320 300 1440 90 1440 60 1290 210 1440 240 1380 180 1350 150 1320 150 1380 120 1440 150 1380 120 1410 120 1230 300 1440 60 1350 150 1410 120 1410 60 1410 90 1440 30 1380 90 1440 60 1440 30 1290 240 1380 90 1410 120 1350 120 1380 150 1440 120 1350 240 1410 120 1440 60 1410 90 1410 60 1440 60 1440 150 1410 210 1440 90 1170 330 1440 90 1290 270 1200 300 1440 150 1380 90 1410 90 1440 120 1380 90 1380 120 1290 180 1350 150 1350 180 1410 60 1290 180 1410 150 1410 60 1440 60 1440 60 1440 150 1440 120 1410 180 1440 60 1350 180 1440 90 1440 180 1380 90 1380 90 1350 180 1380 120 1410 60 1440 60 1350 120 1410 120 1350 120 1410 90 1350 150 1350 150 1410 180 1410 90 1380 120 1410 60 1380 120 1410 90 1410 90 1440 60 1380 90 1410 150 1380 120 1290 210 1440 90 1410 90 1410 90 1410 150 1260 180 1350 150 1320 240 1320 180 1380 60 1320 120 1410 90 1350 150 1350 150 1350 120 1380 150 1410 60 1410 270 1350 150 1320 150 1320 150 1380 180 1350 90 1260 300 1350 180 1380 90 1320 150 1410 60 1380 90 1410 120 1380 90 1230 300 1380 120 1410 60 1320 150 1350 120 1410 30 1380 210 1380 120 1290 120 1380 180 1380 120 1320 90 1170 270 1290 120 1320 120 1380 120 1380 60 1230 180 1290 150 1320 90 1350 60 1320 180 1380 60 1350 60 1380 120 1350 90 1350 120 1320 210 1320 150 1320 60 1350 210 1230 180 1260 150 1260 150 1230 90 1170 210 1290 90 1200 90
- │ │ <--- 1 ------ 14 ------ 30 ------ 44 ------ 54 ------ 68 ------ 81 ------ 98 ------ 111 ------ 125 ------ 138 ------ 157 ------ 173 ------ 188 ------ 203 ------ 219 ------ 240 ------ 255 ------ 272 ------ 287 ------ 303 ------ 320 ------ 333 ------ 349 ------ 360 ------ 379 ------ 393 ------ 408 ------ 424 ------ 439 ------ 458 ------ 474 ------ 489 ------ 506 ------ 519 ------ 532 ------ 549 ------ 563 ------ 577 ------ 593 ------ 613 ------ 627 ------ 642 ------ 658 ------ 676 ------ 691 ------ 705 ------ 720 ------ 736 ------ 749 ------ 767 ------ 782 ------ 794 ------ 808 ------ 825 ------ 839 ------ 856 ------ 868 ------ 885 ------ 899 ------ 914 ------ 930 ------ 946 ------ 963 ------ 982 ------ 998 ------ 1014 ------ 1029 ------ 1047 ------ 1064 ------ 1080 ------ 1095 ------ 1110 ------ 1126 ------ 1143 ------ 1161 ------ 1176 ------ 1190 ------ 1204 ------ 1225 ------ 1240 ------ 1255 ------ 1271 ------ 1285 ------ 1302 ------ 1317 ------ 1333 ------ 1348 ------ 1364 ------ 1379 ------ 1396 ------ 1412 ------ 1427 ------ 1443 ------ 1456 ------ 1474 ------ 1484 ------ 1500 ------ 1512 ------ 1528 ------ 1543 ------ 1559 ------ 1576 ------ 1592 ------ 1606 ------ 1619 ------ 1636 ------ 1655 ------ 1669 ------ 1686 ------ 1705 ------ 1721 ------ 1734 ------ 1746 ------ 1761 ------ 1777 ------ 1789 ------ 1803 ------ 1816 ------ 1831 ------ 1847 ------ 1861 ------ 1875 ------ 1893 ------ 1910 ------ 1926 ------ 1941 ------ 1955 ------ 1966 ------ 1981 ------ 1996 ------ 2011 ------ 2024 ------ 2039 ------ 2053 ------ 2067 ------ 2083 ------ 2099 ------ 2116 ------ 2130 ------ 2148 ------ 2165 ------ 2182 ------ 2198 ------ 2209 ------ 2224 ------ 2237 ------ 2251 ------ 2270 ------ 2282 ------ 2293 ------ 2307 ------ 2324 ------ 2338 ------ 2351 ------ 2365 ------ 2383 ------ 2397 ------ 2413 ------ 2427 ------ 2440 ------ 2453 ------ 2467 ------ 2480 ------ 2494 ------ 2508 ------ 2523 ------ 2538 ------ 2553 ------ 2568 ------ 2586 ------ 2601 ------ 2616 ------ 2629 ------ 2641 ------ 2655 ------ 2669 ------ 2684 ------ 2701 ------ 2717 ------ 2735 ------ 2747 ------ 2760 ------ 2774 ------ 2789 ------ 2806 ------ 2821 ------ 2835 ------ 2848 ------ 2862 ------ 2877 ------ 2892 ------ 2907 ------ 2918 ------ 2935 ------ 2951 ------ 2963 ------ 2974 ------ 2988 ------ 3000
- │ │ histogram(2)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(7)=11, null(7)=0, avgsize(7)=2]
+ │ │ histogram(1)= 0 60 1380 120 1440 180 1380 180 1440 60 1470 150 1410 240 1410 90 1350 210 1440 150 1380 120 1410 120 1410 150 1380 120 1440 120 1470 180 1440 120 1410 90 1410 120 1380 210 1440 60 1440 60 1410 150 1440 180 1350 150 1440 150 1440 150 1440 60 1440 90 1380 150 1350 150 1350 120 1410 120 1350 150 1410 90 1410 60 1380 90 1290 210 1410 180 1230 270 1440 210 1320 150 1410 120 1320 180 1440 180 1410 90 1350 150 1260 240 1290 210 1410 180 1380 150 1320 180 1380 120 1440 180 1320 150 1290 180 1410 90 1410 60 1380 120 1320 180 1380 150 1410 180 1380 150 1380 120 1380 120 1410 60 1350 150 1440 30 1320 150 1320 210 1350 120 1440 30 1440 30 1350 150 1350 270 1440 60 1380 90 1440 180 1410 60 1290 180 1410 120 1440 90 1440 60 1440 90 1260 210 1380 120 1380 150 1440 120 1440 90 1320 240 1320 150 1260 210 1290 180 1290 210 1410 120 1380 90 1410 150 1440 90 1440 60 1440 60 1440 210 1440 120 1410 120 1320 150 1440 30 1410 150 1380 120 1440 120 1410 60 1350 150 1410 120 1350 120 1440 90 1440 150 1290 180 1350 180 1320 150 1440 60 1410 90 1350 120 1410 210 1380 150 1350 270 1320 180 1350 150 1440 120 1410 90 1380 180 1440 150 1380 90 1200 270 1410 240 1440 30 1410 60 1440 90 1380 120 1410 120 1440 60 1440 60 1380 90 1410 120 1380 90 1410 30 1440 60 1410 120 1350 120 1290 210 1380 150 1380 90 1410 90 1380 90 1320 210 1290 180 1380 90 1350 90 1320 150 1380 120 1410 150 1410 30 1380 90 1410 120 1410 60 1410 30 1410 180 1410 60 1380 60 1410 120 1290 270 1350 120 1380 60 1410 60 1260 180 1290 150 1410 210 1410 60 1380 90 1380 60 1320 120 1380 180 1290 150 1380 60 1290 150 1290 150 1260 210 1290 120 1320 90 1380 60 1350 60 1350 90 1410 210 1320 150 1380 120 1260 150 1260 150 1320 120 1320 90 1260 120 1200 240 1230 210 1290 30
+ │ │ <--- 1 ------ 17 ------ 31 ------ 46 ------ 62 ------ 77 ------ 90 ------ 107 ------ 120 ------ 135 ------ 151 ------ 163 ------ 178 ------ 189 ------ 204 ------ 222 ------ 239 ------ 254 ------ 268 ------ 285 ------ 298 ------ 310 ------ 324 ------ 338 ------ 354 ------ 368 ------ 386 ------ 398 ------ 412 ------ 426 ------ 443 ------ 459 ------ 478 ------ 494 ------ 510 ------ 524 ------ 539 ------ 555 ------ 570 ------ 584 ------ 601 ------ 612 ------ 626 ------ 641 ------ 656 ------ 670 ------ 686 ------ 698 ------ 709 ------ 720 ------ 738 ------ 758 ------ 773 ------ 786 ------ 799 ------ 813 ------ 833 ------ 847 ------ 863 ------ 878 ------ 893 ------ 910 ------ 925 ------ 938 ------ 955 ------ 971 ------ 983 ------ 999 ------ 1017 ------ 1030 ------ 1044 ------ 1063 ------ 1077 ------ 1092 ------ 1108 ------ 1126 ------ 1139 ------ 1160 ------ 1176 ------ 1192 ------ 1208 ------ 1226 ------ 1239 ------ 1252 ------ 1266 ------ 1280 ------ 1294 ------ 1310 ------ 1326 ------ 1342 ------ 1352 ------ 1365 ------ 1378 ------ 1393 ------ 1409 ------ 1423 ------ 1439 ------ 1457 ------ 1470 ------ 1489 ------ 1507 ------ 1522 ------ 1532 ------ 1545 ------ 1558 ------ 1571 ------ 1583 ------ 1600 ------ 1614 ------ 1626 ------ 1641 ------ 1660 ------ 1673 ------ 1688 ------ 1701 ------ 1718 ------ 1731 ------ 1745 ------ 1762 ------ 1781 ------ 1797 ------ 1809 ------ 1825 ------ 1839 ------ 1852 ------ 1869 ------ 1882 ------ 1898 ------ 1916 ------ 1930 ------ 1945 ------ 1958 ------ 1974 ------ 1989 ------ 2006 ------ 2028 ------ 2044 ------ 2060 ------ 2080 ------ 2094 ------ 2112 ------ 2123 ------ 2138 ------ 2153 ------ 2168 ------ 2181 ------ 2196 ------ 2213 ------ 2228 ------ 2244 ------ 2260 ------ 2275 ------ 2288 ------ 2301 ------ 2316 ------ 2330 ------ 2347 ------ 2363 ------ 2378 ------ 2393 ------ 2411 ------ 2429 ------ 2443 ------ 2459 ------ 2478 ------ 2493 ------ 2509 ------ 2524 ------ 2541 ------ 2557 ------ 2575 ------ 2588 ------ 2603 ------ 2617 ------ 2628 ------ 2640 ------ 2656 ------ 2671 ------ 2684 ------ 2697 ------ 2714 ------ 2727 ------ 2748 ------ 2766 ------ 2780 ------ 2797 ------ 2811 ------ 2828 ------ 2839 ------ 2856 ------ 2873 ------ 2887 ------ 2904 ------ 2919 ------ 2931 ------ 2947 ------ 2960 ------ 2971 ------ 2984 ------ 3000
+ │ │ histogram(2)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ │ histogram(3)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ │ histogram(3)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
- │ │ histogram(7)= 0 26280 2.4576e+05 27960
+ │ │ histogram(7)= 0 26550 2.4696e+05 26490
│ │ <---- 5 ------------- 15 -
│ ├── key: (1-3)
│ ├── fd: (1-3)-->(7)
@@ -1438,19 +1438,19 @@ except-all
├── save-table-name: consistency_10_group_by_3
├── columns: ol_o_id:11(int!null) ol_d_id:12(int!null) ol_w_id:13(int!null) count_rows:23(int!null)
├── grouping columns: ol_o_id:11(int!null) ol_d_id:12(int!null) ol_w_id:13(int!null)
- ├── stats: [rows=295745, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(23)=295745, null(23)=0, avgsize(23)=12, distinct(11-13)=295745, null(11-13)=0, avgsize(11-13)=12]
+ ├── stats: [rows=295745, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(23)=295745, null(23)=0, avgsize(23)=5, distinct(11-13)=295745, null(11-13)=0, avgsize(11-13)=5]
├── key: (11-13)
├── fd: (11-13)-->(23)
├── ordering: +13,+12,-11
├── scan order_line
│ ├── save-table-name: consistency_10_scan_4
│ ├── columns: ol_o_id:11(int!null) ol_d_id:12(int!null) ol_w_id:13(int!null)
- │ ├── stats: [rows=3001222, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(11-13)=295745, null(11-13)=0, avgsize(11-13)=12]
- │ │ histogram(11)= 0 900 13806 1801 13205 1801 14706 600 14106 1801 13806 1200 13806 1801 14706 600 14406 1801 13806 1200 14106 1200 14706 1501 14706 1501 14106 2101 14406 900 13505 1501 14706 1200 13806 1200 14106 1200 14106 900 14706 900 13505 1501 14106 900 14106 900 14106 1200 14406 1501 13806 2101 14106 900 14406 600 14406 600 14406 600 14706 900 12605 2701 13505 1801 14706 900 13806 1801 13205 1501 13205 1801 13806 1200 14706 600 14106 1501 13806 1501 14106 600 14406 900 14106 1501 14406 600 14106 900 13806 1200 14406 300 14106 1801 14406 1501 14406 300 13505 1801 14106 900 13205 1501 12605 2101 14106 1501 14106 600 13505 1501 12905 1801 14106 1501 14406 1501 13205 2101 13806 2401 13806 1200 13806 900 13205 2101 13505 1501 14406 1501 13806 900 13205 1801 14406 300 14106 1200 14106 1501 13505 1501 14106 600 14406 600 13205 2701 12605 2101 14106 1501 14106 2101 13806 1200 13505 1801 14106 1200 13806 2101 13806 2401 14406 1200 13505 1501 14406 1501 13505 1200 13505 1200 13806 900 14406 600 14406 1200 13806 1801 13806 2101 13806 900 14406 900 13205 1501 13806 900 13505 1501 13205 1501 13806 1200 14106 900 14406 300 14106 1200 13505 1501 14406 600 14106 600 14406 900 13806 1200 13505 1501 14106 900 13505 1200 13806 1200 13806 1801 14106 1200 12905 1801 13806 1200 14106 600 14406 1200 14406 600 14106 900 14406 600 14106 600 13806 1200 14406 1200 12905 2101 14106 900 14406 900 14406 1200 13806 1501 13505 1200 14406 900 14406 300 14106 600 14106 900 13806 1200 13505 1501 14106 900 13806 2101 14106 1200 14406 900 14406 600 14106 900 13806 900 13806 900 13205 1501 14106 1501 12905 1501 13806 900 13505 900 14106 1501 13806 900 13806 900 14106 300 14106 1501 14106 1501 14106 300 13205 1801 13505 1200 14106 1501 14106 900 13806 1501 14106 300 13205 1501 12605 1801 14106 900 14106 600 13806 600 13806 1801 13505 1200 13505 1801 13205 1501 12905 1501 14106 900 13205 1501 14106 1200 13505 900 14106 600 13806 600 13505 1801 12905 2401 12605 1501 13806 600 13205 1200 13205 1501 13806 1200 13806 1801 13205 900 13505 1801 13205 600 13505 600 13205 600 12005 2401 12905 1200 13205 600 13505 600 13205 900 12605 900
- │ │ <--- 1 ------- 17 ------- 28 ------- 43 ------- 55 ------- 70 ------- 82 ------- 99 ------- 116 ------- 131 ------- 146 ------- 161 ------- 175 ------- 193 ------- 206 ------- 226 ------- 245 ------- 261 ------- 273 ------- 289 ------- 308 ------- 324 ------- 341 ------- 356 ------- 372 ------- 386 ------- 401 ------- 417 ------- 434 ------- 449 ------- 461 ------- 480 ------- 493 ------- 508 ------- 525 ------- 538 ------- 551 ------- 566 ------- 586 ------- 602 ------- 617 ------- 635 ------- 650 ------- 662 ------- 680 ------- 695 ------- 710 ------- 728 ------- 744 ------- 761 ------- 782 ------- 798 ------- 813 ------- 826 ------- 841 ------- 854 ------- 872 ------- 888 ------- 904 ------- 918 ------- 931 ------- 947 ------- 961 ------- 972 ------- 986 ------- 1002 ------- 1017 ------- 1029 ------- 1047 ------- 1062 ------- 1078 ------- 1091 ------- 1104 ------- 1117 ------- 1135 ------- 1152 ------- 1173 ------- 1185 ------- 1202 ------- 1217 ------- 1233 ------- 1245 ------- 1257 ------- 1274 ------- 1288 ------- 1305 ------- 1318 ------- 1330 ------- 1347 ------- 1362 ------- 1374 ------- 1392 ------- 1408 ------- 1425 ------- 1441 ------- 1451 ------- 1465 ------- 1478 ------- 1495 ------- 1513 ------- 1530 ------- 1543 ------- 1559 ------- 1572 ------- 1587 ------- 1604 ------- 1620 ------- 1636 ------- 1648 ------- 1664 ------- 1678 ------- 1693 ------- 1708 ------- 1722 ------- 1737 ------- 1752 ------- 1767 ------- 1778 ------- 1793 ------- 1808 ------- 1826 ------- 1841 ------- 1854 ------- 1872 ------- 1885 ------- 1898 ------- 1914 ------- 1926 ------- 1938 ------- 1952 ------- 1965 ------- 1982 ------- 1998 ------- 2013 ------- 2027 ------- 2039 ------- 2056 ------- 2069 ------- 2083 ------- 2099 ------- 2115 ------- 2129 ------- 2141 ------- 2160 ------- 2174 ------- 2189 ------- 2203 ------- 2219 ------- 2235 ------- 2251 ------- 2269 ------- 2285 ------- 2297 ------- 2316 ------- 2332 ------- 2348 ------- 2368 ------- 2388 ------- 2402 ------- 2417 ------- 2433 ------- 2448 ------- 2464 ------- 2475 ------- 2490 ------- 2502 ------- 2514 ------- 2529 ------- 2544 ------- 2561 ------- 2579 ------- 2593 ------- 2606 ------- 2624 ------- 2637 ------- 2652 ------- 2664 ------- 2679 ------- 2693 ------- 2707 ------- 2721 ------- 2738 ------- 2753 ------- 2764 ------- 2776 ------- 2795 ------- 2808 ------- 2824 ------- 2836 ------- 2856 ------- 2870 ------- 2882 ------- 2899 ------- 2912 ------- 2923 ------- 2938 ------- 2953 ------- 2968 ------- 2983 ------- 3000
- │ │ histogram(12)= 0 2.9292e+05 0 3.0582e+05 0 3.0312e+05 0 2.9712e+05 0 2.9922e+05 0 3.1033e+05 0 3.0132e+05 0 2.9832e+05 0 2.9442e+05 0 2.9862e+05
+ │ ├── stats: [rows=3001222, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(11-13)=295745, null(11-13)=0, avgsize(11-13)=5]
+ │ │ histogram(11)= 0 300 14406 1200 14406 600 13806 1501 14706 900 14406 1501 14706 1501 14406 600 14706 1200 14106 900 13505 1801 14706 300 13205 1801 14406 600 14406 1200 14706 900 13806 1801 13806 1501 14106 1200 14706 900 13205 1801 14706 600 14406 600 14406 1200 14706 900 14406 600 14406 900 14106 900 14706 1200 14406 900 14106 3001 14706 900 13806 1801 13806 1200 14106 1200 14706 1801 14106 600 13806 900 14406 3001 13806 900 14106 900 12905 1801 13505 1501 14406 600 14406 900 13505 1501 12905 2701 13205 1501 13806 1801 12605 2101 14106 600 14406 1501 12905 1801 13806 1200 13505 1200 13505 1501 13205 1501 13806 1200 13806 1200 13205 2701 13806 900 13505 1801 13505 1200 13205 1501 14406 600 13205 1801 13806 2101 14406 1200 13806 1501 14406 1200 14406 600 14106 600 14406 1501 14406 1501 14106 1200 14106 1501 12905 2101 14406 1801 14406 1200 13505 1200 13505 1200 12005 3001 14106 1801 13205 1501 13806 2401 14406 1501 13806 900 13806 1501 13505 2101 14406 600 13505 1200 13505 1200 14406 2101 14406 900 13806 1200 13806 900 14106 1200 13205 2101 13505 1501 14406 300 14406 1501 13806 900 14106 1501 14406 1801 12905 2101 14106 1200 14106 1501 14406 900 14406 1200 14406 1801 14106 2701 12305 2401 13505 1501 14406 1200 14106 1501 13505 1501 13505 1801 13806 1200 14106 600 12605 2101 12905 2101 13205 1501 14106 600 14106 1501 14106 600 14406 1200 12605 2701 13205 1200 14406 1200 14106 300 12605 2101 13505 1200 13205 1200 14106 600 14106 900 14106 900 12905 2101 14106 300 13205 1801 12605 1801 13806 1200 14106 1501 14106 600 12605 2101 13806 1200 14106 1501 13505 1501 13205 1501 14106 600 14106 1501 13806 600 13205 1801 13806 900 13505 1501 13806 1200 13205 1200 14106 300 12605 1801 14106 1501 12905 1501 13205 2101 13806 600 13205 1200 14106 900 13205 1200 13505 900 14106 600 14106 2101 14106 600 13806 1801 12605 1801 14106 1200 12305 2101 13505 1501 13806 900 14106 900 12305 2401 12905 1801 13806 900 13505 900 13806 900 13806 900 13806 2101 12605 2101 13806 600 13505 1200 13806 300 12305 2401 13505 1501 13505 600 12305 1801 13505 1200 13505 900 12605 1501 13205 1501 12905 2401 12305 1200 12605 1501 11705 900 11705 600
+ │ │ <--- 2 ------- 14 ------- 34 ------- 52 ------- 67 ------- 85 ------- 101 ------- 114 ------- 133 ------- 148 ------- 160 ------- 177 ------- 190 ------- 213 ------- 232 ------- 247 ------- 261 ------- 276 ------- 294 ------- 308 ------- 328 ------- 344 ------- 360 ------- 378 ------- 394 ------- 409 ------- 423 ------- 435 ------- 450 ------- 466 ------- 480 ------- 497 ------- 510 ------- 526 ------- 540 ------- 556 ------- 569 ------- 584 ------- 597 ------- 612 ------- 629 ------- 642 ------- 659 ------- 674 ------- 691 ------- 708 ------- 725 ------- 738 ------- 754 ------- 768 ------- 786 ------- 803 ------- 818 ------- 834 ------- 850 ------- 862 ------- 874 ------- 888 ------- 900 ------- 916 ------- 931 ------- 949 ------- 963 ------- 978 ------- 993 ------- 1005 ------- 1019 ------- 1037 ------- 1052 ------- 1065 ------- 1082 ------- 1098 ------- 1116 ------- 1131 ------- 1151 ------- 1166 ------- 1180 ------- 1196 ------- 1210 ------- 1227 ------- 1243 ------- 1256 ------- 1272 ------- 1285 ------- 1300 ------- 1315 ------- 1329 ------- 1345 ------- 1361 ------- 1378 ------- 1393 ------- 1408 ------- 1425 ------- 1441 ------- 1459 ------- 1476 ------- 1492 ------- 1507 ------- 1518 ------- 1532 ------- 1546 ------- 1561 ------- 1579 ------- 1594 ------- 1606 ------- 1622 ------- 1635 ------- 1646 ------- 1662 ------- 1678 ------- 1693 ------- 1705 ------- 1717 ------- 1734 ------- 1750 ------- 1764 ------- 1779 ------- 1791 ------- 1804 ------- 1821 ------- 1832 ------- 1843 ------- 1858 ------- 1875 ------- 1888 ------- 1902 ------- 1920 ------- 1935 ------- 1952 ------- 1971 ------- 1985 ------- 2002 ------- 2014 ------- 2028 ------- 2039 ------- 2052 ------- 2065 ------- 2078 ------- 2090 ------- 2108 ------- 2126 ------- 2139 ------- 2156 ------- 2172 ------- 2187 ------- 2201 ------- 2214 ------- 2227 ------- 2241 ------- 2258 ------- 2272 ------- 2286 ------- 2304 ------- 2318 ------- 2333 ------- 2347 ------- 2360 ------- 2372 ------- 2388 ------- 2405 ------- 2422 ------- 2437 ------- 2452 ------- 2469 ------- 2485 ------- 2498 ------- 2512 ------- 2526 ------- 2540 ------- 2553 ------- 2563 ------- 2580 ------- 2595 ------- 2609 ------- 2626 ------- 2641 ------- 2657 ------- 2674 ------- 2688 ------- 2701 ------- 2715 ------- 2728 ------- 2745 ------- 2758 ------- 2773 ------- 2790 ------- 2802 ------- 2815 ------- 2832 ------- 2850 ------- 2865 ------- 2883 ------- 2899 ------- 2915 ------- 2932 ------- 2946 ------- 2958 ------- 2973 ------- 2984 ------- 3000
+ │ │ histogram(12)= 0 2.8722e+05 0 3.0822e+05 0 3.0162e+05 0 2.9682e+05 0 3.1063e+05 0 3.0252e+05 0 3.0312e+05 0 3.0432e+05 0 2.9322e+05 0 2.9352e+05
│ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ---------- 10 ---
- │ │ histogram(13)= 0 3.0762e+05 0 2.9352e+05 0 2.9532e+05 0 2.8332e+05 0 2.9142e+05 0 2.9862e+05 0 3.1393e+05 0 2.9442e+05 0 3.1303e+05 0 3.1003e+05
+ │ │ histogram(13)= 0 2.9082e+05 0 2.8632e+05 0 3.1093e+05 0 3.1093e+05 0 3.0732e+05 0 3.1783e+05 0 2.8902e+05 0 3.0342e+05 0 2.8932e+05 0 2.9532e+05
│ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ----
│ └── ordering: +13,+12,-11
└── aggregations
@@ -1529,26 +1529,26 @@ except-all
├── left columns: ol_w_id:3(int!null) ol_d_id:2(int!null) ol_o_id:1(int!null) count_rows:13(int)
├── right columns: o_w_id:16(int) o_d_id:15(int) o_id:14(int) o_ol_cnt:20(int)
├── internal-ordering: +3,+2,-1,+13
- ├── stats: [rows=295745, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(13)=295745, null(13)=0, avgsize(13)=12]
+ ├── stats: [rows=295745, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(13)=295745, null(13)=0, avgsize(13)=5]
├── key: (1-3)
├── fd: (1-3)-->(13)
├── group-by (streaming)
│ ├── save-table-name: consistency_11_group_by_2
│ ├── columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null) count_rows:13(int!null)
│ ├── grouping columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null)
- │ ├── stats: [rows=295745, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(13)=295745, null(13)=0, avgsize(13)=12, distinct(1-3)=295745, null(1-3)=0, avgsize(1-3)=12]
+ │ ├── stats: [rows=295745, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(13)=295745, null(13)=0, avgsize(13)=5, distinct(1-3)=295745, null(1-3)=0, avgsize(1-3)=5]
│ ├── key: (1-3)
│ ├── fd: (1-3)-->(13)
│ ├── ordering: +3,+2,-1
│ ├── scan order_line
│ │ ├── save-table-name: consistency_11_scan_3
│ │ ├── columns: ol_o_id:1(int!null) ol_d_id:2(int!null) ol_w_id:3(int!null)
- │ │ ├── stats: [rows=3001222, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(1-3)=295745, null(1-3)=0, avgsize(1-3)=12]
- │ │ │ histogram(1)= 0 900 13806 1801 13205 1801 14706 600 14106 1801 13806 1200 13806 1801 14706 600 14406 1801 13806 1200 14106 1200 14706 1501 14706 1501 14106 2101 14406 900 13505 1501 14706 1200 13806 1200 14106 1200 14106 900 14706 900 13505 1501 14106 900 14106 900 14106 1200 14406 1501 13806 2101 14106 900 14406 600 14406 600 14406 600 14706 900 12605 2701 13505 1801 14706 900 13806 1801 13205 1501 13205 1801 13806 1200 14706 600 14106 1501 13806 1501 14106 600 14406 900 14106 1501 14406 600 14106 900 13806 1200 14406 300 14106 1801 14406 1501 14406 300 13505 1801 14106 900 13205 1501 12605 2101 14106 1501 14106 600 13505 1501 12905 1801 14106 1501 14406 1501 13205 2101 13806 2401 13806 1200 13806 900 13205 2101 13505 1501 14406 1501 13806 900 13205 1801 14406 300 14106 1200 14106 1501 13505 1501 14106 600 14406 600 13205 2701 12605 2101 14106 1501 14106 2101 13806 1200 13505 1801 14106 1200 13806 2101 13806 2401 14406 1200 13505 1501 14406 1501 13505 1200 13505 1200 13806 900 14406 600 14406 1200 13806 1801 13806 2101 13806 900 14406 900 13205 1501 13806 900 13505 1501 13205 1501 13806 1200 14106 900 14406 300 14106 1200 13505 1501 14406 600 14106 600 14406 900 13806 1200 13505 1501 14106 900 13505 1200 13806 1200 13806 1801 14106 1200 12905 1801 13806 1200 14106 600 14406 1200 14406 600 14106 900 14406 600 14106 600 13806 1200 14406 1200 12905 2101 14106 900 14406 900 14406 1200 13806 1501 13505 1200 14406 900 14406 300 14106 600 14106 900 13806 1200 13505 1501 14106 900 13806 2101 14106 1200 14406 900 14406 600 14106 900 13806 900 13806 900 13205 1501 14106 1501 12905 1501 13806 900 13505 900 14106 1501 13806 900 13806 900 14106 300 14106 1501 14106 1501 14106 300 13205 1801 13505 1200 14106 1501 14106 900 13806 1501 14106 300 13205 1501 12605 1801 14106 900 14106 600 13806 600 13806 1801 13505 1200 13505 1801 13205 1501 12905 1501 14106 900 13205 1501 14106 1200 13505 900 14106 600 13806 600 13505 1801 12905 2401 12605 1501 13806 600 13205 1200 13205 1501 13806 1200 13806 1801 13205 900 13505 1801 13205 600 13505 600 13205 600 12005 2401 12905 1200 13205 600 13505 600 13205 900 12605 900
- │ │ │ <--- 1 ------- 17 ------- 28 ------- 43 ------- 55 ------- 70 ------- 82 ------- 99 ------- 116 ------- 131 ------- 146 ------- 161 ------- 175 ------- 193 ------- 206 ------- 226 ------- 245 ------- 261 ------- 273 ------- 289 ------- 308 ------- 324 ------- 341 ------- 356 ------- 372 ------- 386 ------- 401 ------- 417 ------- 434 ------- 449 ------- 461 ------- 480 ------- 493 ------- 508 ------- 525 ------- 538 ------- 551 ------- 566 ------- 586 ------- 602 ------- 617 ------- 635 ------- 650 ------- 662 ------- 680 ------- 695 ------- 710 ------- 728 ------- 744 ------- 761 ------- 782 ------- 798 ------- 813 ------- 826 ------- 841 ------- 854 ------- 872 ------- 888 ------- 904 ------- 918 ------- 931 ------- 947 ------- 961 ------- 972 ------- 986 ------- 1002 ------- 1017 ------- 1029 ------- 1047 ------- 1062 ------- 1078 ------- 1091 ------- 1104 ------- 1117 ------- 1135 ------- 1152 ------- 1173 ------- 1185 ------- 1202 ------- 1217 ------- 1233 ------- 1245 ------- 1257 ------- 1274 ------- 1288 ------- 1305 ------- 1318 ------- 1330 ------- 1347 ------- 1362 ------- 1374 ------- 1392 ------- 1408 ------- 1425 ------- 1441 ------- 1451 ------- 1465 ------- 1478 ------- 1495 ------- 1513 ------- 1530 ------- 1543 ------- 1559 ------- 1572 ------- 1587 ------- 1604 ------- 1620 ------- 1636 ------- 1648 ------- 1664 ------- 1678 ------- 1693 ------- 1708 ------- 1722 ------- 1737 ------- 1752 ------- 1767 ------- 1778 ------- 1793 ------- 1808 ------- 1826 ------- 1841 ------- 1854 ------- 1872 ------- 1885 ------- 1898 ------- 1914 ------- 1926 ------- 1938 ------- 1952 ------- 1965 ------- 1982 ------- 1998 ------- 2013 ------- 2027 ------- 2039 ------- 2056 ------- 2069 ------- 2083 ------- 2099 ------- 2115 ------- 2129 ------- 2141 ------- 2160 ------- 2174 ------- 2189 ------- 2203 ------- 2219 ------- 2235 ------- 2251 ------- 2269 ------- 2285 ------- 2297 ------- 2316 ------- 2332 ------- 2348 ------- 2368 ------- 2388 ------- 2402 ------- 2417 ------- 2433 ------- 2448 ------- 2464 ------- 2475 ------- 2490 ------- 2502 ------- 2514 ------- 2529 ------- 2544 ------- 2561 ------- 2579 ------- 2593 ------- 2606 ------- 2624 ------- 2637 ------- 2652 ------- 2664 ------- 2679 ------- 2693 ------- 2707 ------- 2721 ------- 2738 ------- 2753 ------- 2764 ------- 2776 ------- 2795 ------- 2808 ------- 2824 ------- 2836 ------- 2856 ------- 2870 ------- 2882 ------- 2899 ------- 2912 ------- 2923 ------- 2938 ------- 2953 ------- 2968 ------- 2983 ------- 3000
- │ │ │ histogram(2)= 0 2.9292e+05 0 3.0582e+05 0 3.0312e+05 0 2.9712e+05 0 2.9922e+05 0 3.1033e+05 0 3.0132e+05 0 2.9832e+05 0 2.9442e+05 0 2.9862e+05
+ │ │ ├── stats: [rows=3001222, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(1-3)=295745, null(1-3)=0, avgsize(1-3)=5]
+ │ │ │ histogram(1)= 0 300 14406 1200 14406 600 13806 1501 14706 900 14406 1501 14706 1501 14406 600 14706 1200 14106 900 13505 1801 14706 300 13205 1801 14406 600 14406 1200 14706 900 13806 1801 13806 1501 14106 1200 14706 900 13205 1801 14706 600 14406 600 14406 1200 14706 900 14406 600 14406 900 14106 900 14706 1200 14406 900 14106 3001 14706 900 13806 1801 13806 1200 14106 1200 14706 1801 14106 600 13806 900 14406 3001 13806 900 14106 900 12905 1801 13505 1501 14406 600 14406 900 13505 1501 12905 2701 13205 1501 13806 1801 12605 2101 14106 600 14406 1501 12905 1801 13806 1200 13505 1200 13505 1501 13205 1501 13806 1200 13806 1200 13205 2701 13806 900 13505 1801 13505 1200 13205 1501 14406 600 13205 1801 13806 2101 14406 1200 13806 1501 14406 1200 14406 600 14106 600 14406 1501 14406 1501 14106 1200 14106 1501 12905 2101 14406 1801 14406 1200 13505 1200 13505 1200 12005 3001 14106 1801 13205 1501 13806 2401 14406 1501 13806 900 13806 1501 13505 2101 14406 600 13505 1200 13505 1200 14406 2101 14406 900 13806 1200 13806 900 14106 1200 13205 2101 13505 1501 14406 300 14406 1501 13806 900 14106 1501 14406 1801 12905 2101 14106 1200 14106 1501 14406 900 14406 1200 14406 1801 14106 2701 12305 2401 13505 1501 14406 1200 14106 1501 13505 1501 13505 1801 13806 1200 14106 600 12605 2101 12905 2101 13205 1501 14106 600 14106 1501 14106 600 14406 1200 12605 2701 13205 1200 14406 1200 14106 300 12605 2101 13505 1200 13205 1200 14106 600 14106 900 14106 900 12905 2101 14106 300 13205 1801 12605 1801 13806 1200 14106 1501 14106 600 12605 2101 13806 1200 14106 1501 13505 1501 13205 1501 14106 600 14106 1501 13806 600 13205 1801 13806 900 13505 1501 13806 1200 13205 1200 14106 300 12605 1801 14106 1501 12905 1501 13205 2101 13806 600 13205 1200 14106 900 13205 1200 13505 900 14106 600 14106 2101 14106 600 13806 1801 12605 1801 14106 1200 12305 2101 13505 1501 13806 900 14106 900 12305 2401 12905 1801 13806 900 13505 900 13806 900 13806 900 13806 2101 12605 2101 13806 600 13505 1200 13806 300 12305 2401 13505 1501 13505 600 12305 1801 13505 1200 13505 900 12605 1501 13205 1501 12905 2401 12305 1200 12605 1501 11705 900 11705 600
+ │ │ │ <--- 2 ------- 14 ------- 34 ------- 52 ------- 67 ------- 85 ------- 101 ------- 114 ------- 133 ------- 148 ------- 160 ------- 177 ------- 190 ------- 213 ------- 232 ------- 247 ------- 261 ------- 276 ------- 294 ------- 308 ------- 328 ------- 344 ------- 360 ------- 378 ------- 394 ------- 409 ------- 423 ------- 435 ------- 450 ------- 466 ------- 480 ------- 497 ------- 510 ------- 526 ------- 540 ------- 556 ------- 569 ------- 584 ------- 597 ------- 612 ------- 629 ------- 642 ------- 659 ------- 674 ------- 691 ------- 708 ------- 725 ------- 738 ------- 754 ------- 768 ------- 786 ------- 803 ------- 818 ------- 834 ------- 850 ------- 862 ------- 874 ------- 888 ------- 900 ------- 916 ------- 931 ------- 949 ------- 963 ------- 978 ------- 993 ------- 1005 ------- 1019 ------- 1037 ------- 1052 ------- 1065 ------- 1082 ------- 1098 ------- 1116 ------- 1131 ------- 1151 ------- 1166 ------- 1180 ------- 1196 ------- 1210 ------- 1227 ------- 1243 ------- 1256 ------- 1272 ------- 1285 ------- 1300 ------- 1315 ------- 1329 ------- 1345 ------- 1361 ------- 1378 ------- 1393 ------- 1408 ------- 1425 ------- 1441 ------- 1459 ------- 1476 ------- 1492 ------- 1507 ------- 1518 ------- 1532 ------- 1546 ------- 1561 ------- 1579 ------- 1594 ------- 1606 ------- 1622 ------- 1635 ------- 1646 ------- 1662 ------- 1678 ------- 1693 ------- 1705 ------- 1717 ------- 1734 ------- 1750 ------- 1764 ------- 1779 ------- 1791 ------- 1804 ------- 1821 ------- 1832 ------- 1843 ------- 1858 ------- 1875 ------- 1888 ------- 1902 ------- 1920 ------- 1935 ------- 1952 ------- 1971 ------- 1985 ------- 2002 ------- 2014 ------- 2028 ------- 2039 ------- 2052 ------- 2065 ------- 2078 ------- 2090 ------- 2108 ------- 2126 ------- 2139 ------- 2156 ------- 2172 ------- 2187 ------- 2201 ------- 2214 ------- 2227 ------- 2241 ------- 2258 ------- 2272 ------- 2286 ------- 2304 ------- 2318 ------- 2333 ------- 2347 ------- 2360 ------- 2372 ------- 2388 ------- 2405 ------- 2422 ------- 2437 ------- 2452 ------- 2469 ------- 2485 ------- 2498 ------- 2512 ------- 2526 ------- 2540 ------- 2553 ------- 2563 ------- 2580 ------- 2595 ------- 2609 ------- 2626 ------- 2641 ------- 2657 ------- 2674 ------- 2688 ------- 2701 ------- 2715 ------- 2728 ------- 2745 ------- 2758 ------- 2773 ------- 2790 ------- 2802 ------- 2815 ------- 2832 ------- 2850 ------- 2865 ------- 2883 ------- 2899 ------- 2915 ------- 2932 ------- 2946 ------- 2958 ------- 2973 ------- 2984 ------- 3000
+ │ │ │ histogram(2)= 0 2.8722e+05 0 3.0822e+05 0 3.0162e+05 0 2.9682e+05 0 3.1063e+05 0 3.0252e+05 0 3.0312e+05 0 3.0432e+05 0 2.9322e+05 0 2.9352e+05
│ │ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ---------- 10 ---
- │ │ │ histogram(3)= 0 3.0762e+05 0 2.9352e+05 0 2.9532e+05 0 2.8332e+05 0 2.9142e+05 0 2.9862e+05 0 3.1393e+05 0 2.9442e+05 0 3.1303e+05 0 3.1003e+05
+ │ │ │ histogram(3)= 0 2.9082e+05 0 2.8632e+05 0 3.1093e+05 0 3.1093e+05 0 3.0732e+05 0 3.1783e+05 0 2.8902e+05 0 3.0342e+05 0 2.8932e+05 0 2.9532e+05
│ │ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ----
│ │ └── ordering: +3,+2,-1
│ └── aggregations
@@ -1556,14 +1556,14 @@ except-all
└── scan order
├── save-table-name: consistency_11_scan_4
├── columns: o_id:14(int!null) o_d_id:15(int!null) o_w_id:16(int!null) o_ol_cnt:20(int)
- ├── stats: [rows=300000, distinct(14)=2999, null(14)=0, avgsize(14)=4, distinct(15)=10, null(15)=0, avgsize(15)=4, distinct(16)=10, null(16)=0, avgsize(16)=4, distinct(20)=11, null(20)=0, avgsize(20)=4]
- │ histogram(14)= 0 60 1470 90 1410 150 1470 150 1350 180 1470 120 1410 120 1410 90 1470 120 1350 150 1440 60 1350 210 1380 120 1410 90 1440 90 1470 120 1470 90 1320 240 1440 60 1410 150 1470 180 1470 90 1410 90 1380 150 1320 180 1470 90 1320 270 1470 120 1470 60 1470 90 1470 120 1440 150 1410 90 1380 120 1290 180 1320 180 1440 60 1230 240 1380 90 1440 150 1410 150 1230 240 1410 210 1440 150 1380 240 1320 300 1440 90 1440 60 1290 210 1440 240 1380 180 1350 150 1320 150 1380 120 1440 150 1380 120 1410 120 1230 300 1440 60 1350 150 1410 120 1410 60 1410 90 1440 30 1380 90 1440 60 1440 30 1290 240 1380 90 1410 120 1350 120 1380 150 1440 120 1350 240 1410 120 1440 60 1410 90 1410 60 1440 60 1440 150 1410 210 1440 90 1170 330 1440 90 1290 270 1200 300 1440 150 1380 90 1410 90 1440 120 1380 90 1380 120 1290 180 1350 150 1350 180 1410 60 1290 180 1410 150 1410 60 1440 60 1440 60 1440 150 1440 120 1410 180 1440 60 1350 180 1440 90 1440 180 1380 90 1380 90 1350 180 1380 120 1410 60 1440 60 1350 120 1410 120 1350 120 1410 90 1350 150 1350 150 1410 180 1410 90 1380 120 1410 60 1380 120 1410 90 1410 90 1440 60 1380 90 1410 150 1380 120 1290 210 1440 90 1410 90 1410 90 1410 150 1260 180 1350 150 1320 240 1320 180 1380 60 1320 120 1410 90 1350 150 1350 150 1350 120 1380 150 1410 60 1410 270 1350 150 1320 150 1320 150 1380 180 1350 90 1260 300 1350 180 1380 90 1320 150 1410 60 1380 90 1410 120 1380 90 1230 300 1380 120 1410 60 1320 150 1350 120 1410 30 1380 210 1380 120 1290 120 1380 180 1380 120 1320 90 1170 270 1290 120 1320 120 1380 120 1380 60 1230 180 1290 150 1320 90 1350 60 1320 180 1380 60 1350 60 1380 120 1350 90 1350 120 1320 210 1320 150 1320 60 1350 210 1230 180 1260 150 1260 150 1230 90 1170 210 1290 90 1200 90
- │ <--- 1 ------ 14 ------ 30 ------ 44 ------ 54 ------ 68 ------ 81 ------ 98 ------ 111 ------ 125 ------ 138 ------ 157 ------ 173 ------ 188 ------ 203 ------ 219 ------ 240 ------ 255 ------ 272 ------ 287 ------ 303 ------ 320 ------ 333 ------ 349 ------ 360 ------ 379 ------ 393 ------ 408 ------ 424 ------ 439 ------ 458 ------ 474 ------ 489 ------ 506 ------ 519 ------ 532 ------ 549 ------ 563 ------ 577 ------ 593 ------ 613 ------ 627 ------ 642 ------ 658 ------ 676 ------ 691 ------ 705 ------ 720 ------ 736 ------ 749 ------ 767 ------ 782 ------ 794 ------ 808 ------ 825 ------ 839 ------ 856 ------ 868 ------ 885 ------ 899 ------ 914 ------ 930 ------ 946 ------ 963 ------ 982 ------ 998 ------ 1014 ------ 1029 ------ 1047 ------ 1064 ------ 1080 ------ 1095 ------ 1110 ------ 1126 ------ 1143 ------ 1161 ------ 1176 ------ 1190 ------ 1204 ------ 1225 ------ 1240 ------ 1255 ------ 1271 ------ 1285 ------ 1302 ------ 1317 ------ 1333 ------ 1348 ------ 1364 ------ 1379 ------ 1396 ------ 1412 ------ 1427 ------ 1443 ------ 1456 ------ 1474 ------ 1484 ------ 1500 ------ 1512 ------ 1528 ------ 1543 ------ 1559 ------ 1576 ------ 1592 ------ 1606 ------ 1619 ------ 1636 ------ 1655 ------ 1669 ------ 1686 ------ 1705 ------ 1721 ------ 1734 ------ 1746 ------ 1761 ------ 1777 ------ 1789 ------ 1803 ------ 1816 ------ 1831 ------ 1847 ------ 1861 ------ 1875 ------ 1893 ------ 1910 ------ 1926 ------ 1941 ------ 1955 ------ 1966 ------ 1981 ------ 1996 ------ 2011 ------ 2024 ------ 2039 ------ 2053 ------ 2067 ------ 2083 ------ 2099 ------ 2116 ------ 2130 ------ 2148 ------ 2165 ------ 2182 ------ 2198 ------ 2209 ------ 2224 ------ 2237 ------ 2251 ------ 2270 ------ 2282 ------ 2293 ------ 2307 ------ 2324 ------ 2338 ------ 2351 ------ 2365 ------ 2383 ------ 2397 ------ 2413 ------ 2427 ------ 2440 ------ 2453 ------ 2467 ------ 2480 ------ 2494 ------ 2508 ------ 2523 ------ 2538 ------ 2553 ------ 2568 ------ 2586 ------ 2601 ------ 2616 ------ 2629 ------ 2641 ------ 2655 ------ 2669 ------ 2684 ------ 2701 ------ 2717 ------ 2735 ------ 2747 ------ 2760 ------ 2774 ------ 2789 ------ 2806 ------ 2821 ------ 2835 ------ 2848 ------ 2862 ------ 2877 ------ 2892 ------ 2907 ------ 2918 ------ 2935 ------ 2951 ------ 2963 ------ 2974 ------ 2988 ------ 3000
- │ histogram(15)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ ├── stats: [rows=300000, distinct(14)=2999, null(14)=0, avgsize(14)=3, distinct(15)=10, null(15)=0, avgsize(15)=1, distinct(16)=10, null(16)=0, avgsize(16)=1, distinct(20)=11, null(20)=0, avgsize(20)=2]
+ │ histogram(14)= 0 60 1380 120 1440 180 1380 180 1440 60 1470 150 1410 240 1410 90 1350 210 1440 150 1380 120 1410 120 1410 150 1380 120 1440 120 1470 180 1440 120 1410 90 1410 120 1380 210 1440 60 1440 60 1410 150 1440 180 1350 150 1440 150 1440 150 1440 60 1440 90 1380 150 1350 150 1350 120 1410 120 1350 150 1410 90 1410 60 1380 90 1290 210 1410 180 1230 270 1440 210 1320 150 1410 120 1320 180 1440 180 1410 90 1350 150 1260 240 1290 210 1410 180 1380 150 1320 180 1380 120 1440 180 1320 150 1290 180 1410 90 1410 60 1380 120 1320 180 1380 150 1410 180 1380 150 1380 120 1380 120 1410 60 1350 150 1440 30 1320 150 1320 210 1350 120 1440 30 1440 30 1350 150 1350 270 1440 60 1380 90 1440 180 1410 60 1290 180 1410 120 1440 90 1440 60 1440 90 1260 210 1380 120 1380 150 1440 120 1440 90 1320 240 1320 150 1260 210 1290 180 1290 210 1410 120 1380 90 1410 150 1440 90 1440 60 1440 60 1440 210 1440 120 1410 120 1320 150 1440 30 1410 150 1380 120 1440 120 1410 60 1350 150 1410 120 1350 120 1440 90 1440 150 1290 180 1350 180 1320 150 1440 60 1410 90 1350 120 1410 210 1380 150 1350 270 1320 180 1350 150 1440 120 1410 90 1380 180 1440 150 1380 90 1200 270 1410 240 1440 30 1410 60 1440 90 1380 120 1410 120 1440 60 1440 60 1380 90 1410 120 1380 90 1410 30 1440 60 1410 120 1350 120 1290 210 1380 150 1380 90 1410 90 1380 90 1320 210 1290 180 1380 90 1350 90 1320 150 1380 120 1410 150 1410 30 1380 90 1410 120 1410 60 1410 30 1410 180 1410 60 1380 60 1410 120 1290 270 1350 120 1380 60 1410 60 1260 180 1290 150 1410 210 1410 60 1380 90 1380 60 1320 120 1380 180 1290 150 1380 60 1290 150 1290 150 1260 210 1290 120 1320 90 1380 60 1350 60 1350 90 1410 210 1320 150 1380 120 1260 150 1260 150 1320 120 1320 90 1260 120 1200 240 1230 210 1290 30
+ │ <--- 1 ------ 17 ------ 31 ------ 46 ------ 62 ------ 77 ------ 90 ------ 107 ------ 120 ------ 135 ------ 151 ------ 163 ------ 178 ------ 189 ------ 204 ------ 222 ------ 239 ------ 254 ------ 268 ------ 285 ------ 298 ------ 310 ------ 324 ------ 338 ------ 354 ------ 368 ------ 386 ------ 398 ------ 412 ------ 426 ------ 443 ------ 459 ------ 478 ------ 494 ------ 510 ------ 524 ------ 539 ------ 555 ------ 570 ------ 584 ------ 601 ------ 612 ------ 626 ------ 641 ------ 656 ------ 670 ------ 686 ------ 698 ------ 709 ------ 720 ------ 738 ------ 758 ------ 773 ------ 786 ------ 799 ------ 813 ------ 833 ------ 847 ------ 863 ------ 878 ------ 893 ------ 910 ------ 925 ------ 938 ------ 955 ------ 971 ------ 983 ------ 999 ------ 1017 ------ 1030 ------ 1044 ------ 1063 ------ 1077 ------ 1092 ------ 1108 ------ 1126 ------ 1139 ------ 1160 ------ 1176 ------ 1192 ------ 1208 ------ 1226 ------ 1239 ------ 1252 ------ 1266 ------ 1280 ------ 1294 ------ 1310 ------ 1326 ------ 1342 ------ 1352 ------ 1365 ------ 1378 ------ 1393 ------ 1409 ------ 1423 ------ 1439 ------ 1457 ------ 1470 ------ 1489 ------ 1507 ------ 1522 ------ 1532 ------ 1545 ------ 1558 ------ 1571 ------ 1583 ------ 1600 ------ 1614 ------ 1626 ------ 1641 ------ 1660 ------ 1673 ------ 1688 ------ 1701 ------ 1718 ------ 1731 ------ 1745 ------ 1762 ------ 1781 ------ 1797 ------ 1809 ------ 1825 ------ 1839 ------ 1852 ------ 1869 ------ 1882 ------ 1898 ------ 1916 ------ 1930 ------ 1945 ------ 1958 ------ 1974 ------ 1989 ------ 2006 ------ 2028 ------ 2044 ------ 2060 ------ 2080 ------ 2094 ------ 2112 ------ 2123 ------ 2138 ------ 2153 ------ 2168 ------ 2181 ------ 2196 ------ 2213 ------ 2228 ------ 2244 ------ 2260 ------ 2275 ------ 2288 ------ 2301 ------ 2316 ------ 2330 ------ 2347 ------ 2363 ------ 2378 ------ 2393 ------ 2411 ------ 2429 ------ 2443 ------ 2459 ------ 2478 ------ 2493 ------ 2509 ------ 2524 ------ 2541 ------ 2557 ------ 2575 ------ 2588 ------ 2603 ------ 2617 ------ 2628 ------ 2640 ------ 2656 ------ 2671 ------ 2684 ------ 2697 ------ 2714 ------ 2727 ------ 2748 ------ 2766 ------ 2780 ------ 2797 ------ 2811 ------ 2828 ------ 2839 ------ 2856 ------ 2873 ------ 2887 ------ 2904 ------ 2919 ------ 2931 ------ 2947 ------ 2960 ------ 2971 ------ 2984 ------ 3000
+ │ histogram(15)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ histogram(16)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ histogram(16)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
- │ histogram(20)= 0 26280 2.4576e+05 27960
+ │ histogram(20)= 0 26550 2.4696e+05 26490
│ <---- 5 ------------- 15 -
├── key: (14-16)
├── fd: (14-16)-->(20)
@@ -1649,70 +1649,74 @@ scalar-group-by
├── select
│ ├── save-table-name: consistency_12_select_2
│ ├── columns: o_id:1(int) o_d_id:2(int) o_w_id:3(int) ol_o_id:11(int) ol_d_id:12(int) ol_w_id:13(int)
- │ ├── stats: [rows=629603.7, distinct(1)=2999, null(1)=440660, avgsize(1)=4, distinct(2)=10, null(2)=440660, avgsize(2)=4, distinct(3)=10, null(3)=440660, avgsize(3)=4, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4]
- │ ├── full-join (hash)
- │ │ ├── save-table-name: consistency_12_full_join_3
+ │ ├── stats: [rows=629603.7, distinct(1)=2999, null(1)=440660, avgsize(1)=3, distinct(2)=10, null(2)=440660, avgsize(2)=1, distinct(3)=10, null(3)=440660, avgsize(3)=1, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1]
+ │ ├── full-join (merge)
+ │ │ ├── save-table-name: consistency_12_merge_join_3
│ │ ├── columns: o_id:1(int) o_d_id:2(int) o_w_id:3(int) ol_o_id:11(int) ol_d_id:12(int) ol_w_id:13(int)
- │ │ ├── multiplicity: left-rows(exactly-one), right-rows(one-or-more)
- │ │ ├── stats: [rows=899134, distinct(1)=2999, null(1)=629304, avgsize(1)=4, distinct(2)=10, null(2)=629304, avgsize(2)=4, distinct(3)=10, null(3)=629304, avgsize(3)=4, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4]
+ │ │ ├── left ordering: +13,+12,-11
+ │ │ ├── right ordering: +3,+2,-1
+ │ │ ├── stats: [rows=899134, distinct(1)=2999, null(1)=629304, avgsize(1)=3, distinct(2)=10, null(2)=629304, avgsize(2)=1, distinct(3)=10, null(3)=629304, avgsize(3)=1, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1]
│ │ ├── project
│ │ │ ├── save-table-name: consistency_12_project_4
│ │ │ ├── columns: ol_o_id:11(int!null) ol_d_id:12(int!null) ol_w_id:13(int!null)
- │ │ │ ├── stats: [rows=899134, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4]
+ │ │ │ ├── stats: [rows=899134, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1]
+ │ │ │ ├── ordering: +13,+12,-11
│ │ │ └── select
│ │ │ ├── save-table-name: consistency_12_select_5
│ │ │ ├── columns: ol_o_id:11(int!null) ol_d_id:12(int!null) ol_w_id:13(int!null) ol_delivery_d:17(timestamp)
- │ │ │ ├── stats: [rows=899134, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(17)=1, null(17)=899134, avgsize(17)=4]
+ │ │ │ ├── stats: [rows=899134, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(17)=1, null(17)=899134, avgsize(17)=5]
│ │ │ │ histogram(17)= 0 8.9913e+05
│ │ │ │ <----- NULL --
│ │ │ ├── fd: ()-->(17)
+ │ │ │ ├── ordering: +13,+12,-11 opt(17) [actual: +13,+12,-11]
│ │ │ ├── scan order_line
│ │ │ │ ├── save-table-name: consistency_12_scan_6
│ │ │ │ ├── columns: ol_o_id:11(int!null) ol_d_id:12(int!null) ol_w_id:13(int!null) ol_delivery_d:17(timestamp)
- │ │ │ │ └── stats: [rows=3001222, distinct(11)=2999, null(11)=0, avgsize(11)=4, distinct(12)=10, null(12)=0, avgsize(12)=4, distinct(13)=10, null(13)=0, avgsize(13)=4, distinct(17)=2, null(17)=899134, avgsize(17)=4]
- │ │ │ │ histogram(11)= 0 900 13806 1801 13205 1801 14706 600 14106 1801 13806 1200 13806 1801 14706 600 14406 1801 13806 1200 14106 1200 14706 1501 14706 1501 14106 2101 14406 900 13505 1501 14706 1200 13806 1200 14106 1200 14106 900 14706 900 13505 1501 14106 900 14106 900 14106 1200 14406 1501 13806 2101 14106 900 14406 600 14406 600 14406 600 14706 900 12605 2701 13505 1801 14706 900 13806 1801 13205 1501 13205 1801 13806 1200 14706 600 14106 1501 13806 1501 14106 600 14406 900 14106 1501 14406 600 14106 900 13806 1200 14406 300 14106 1801 14406 1501 14406 300 13505 1801 14106 900 13205 1501 12605 2101 14106 1501 14106 600 13505 1501 12905 1801 14106 1501 14406 1501 13205 2101 13806 2401 13806 1200 13806 900 13205 2101 13505 1501 14406 1501 13806 900 13205 1801 14406 300 14106 1200 14106 1501 13505 1501 14106 600 14406 600 13205 2701 12605 2101 14106 1501 14106 2101 13806 1200 13505 1801 14106 1200 13806 2101 13806 2401 14406 1200 13505 1501 14406 1501 13505 1200 13505 1200 13806 900 14406 600 14406 1200 13806 1801 13806 2101 13806 900 14406 900 13205 1501 13806 900 13505 1501 13205 1501 13806 1200 14106 900 14406 300 14106 1200 13505 1501 14406 600 14106 600 14406 900 13806 1200 13505 1501 14106 900 13505 1200 13806 1200 13806 1801 14106 1200 12905 1801 13806 1200 14106 600 14406 1200 14406 600 14106 900 14406 600 14106 600 13806 1200 14406 1200 12905 2101 14106 900 14406 900 14406 1200 13806 1501 13505 1200 14406 900 14406 300 14106 600 14106 900 13806 1200 13505 1501 14106 900 13806 2101 14106 1200 14406 900 14406 600 14106 900 13806 900 13806 900 13205 1501 14106 1501 12905 1501 13806 900 13505 900 14106 1501 13806 900 13806 900 14106 300 14106 1501 14106 1501 14106 300 13205 1801 13505 1200 14106 1501 14106 900 13806 1501 14106 300 13205 1501 12605 1801 14106 900 14106 600 13806 600 13806 1801 13505 1200 13505 1801 13205 1501 12905 1501 14106 900 13205 1501 14106 1200 13505 900 14106 600 13806 600 13505 1801 12905 2401 12605 1501 13806 600 13205 1200 13205 1501 13806 1200 13806 1801 13205 900 13505 1801 13205 600 13505 600 13205 600 12005 2401 12905 1200 13205 600 13505 600 13205 900 12605 900
- │ │ │ │ <--- 1 ------- 17 ------- 28 ------- 43 ------- 55 ------- 70 ------- 82 ------- 99 ------- 116 ------- 131 ------- 146 ------- 161 ------- 175 ------- 193 ------- 206 ------- 226 ------- 245 ------- 261 ------- 273 ------- 289 ------- 308 ------- 324 ------- 341 ------- 356 ------- 372 ------- 386 ------- 401 ------- 417 ------- 434 ------- 449 ------- 461 ------- 480 ------- 493 ------- 508 ------- 525 ------- 538 ------- 551 ------- 566 ------- 586 ------- 602 ------- 617 ------- 635 ------- 650 ------- 662 ------- 680 ------- 695 ------- 710 ------- 728 ------- 744 ------- 761 ------- 782 ------- 798 ------- 813 ------- 826 ------- 841 ------- 854 ------- 872 ------- 888 ------- 904 ------- 918 ------- 931 ------- 947 ------- 961 ------- 972 ------- 986 ------- 1002 ------- 1017 ------- 1029 ------- 1047 ------- 1062 ------- 1078 ------- 1091 ------- 1104 ------- 1117 ------- 1135 ------- 1152 ------- 1173 ------- 1185 ------- 1202 ------- 1217 ------- 1233 ------- 1245 ------- 1257 ------- 1274 ------- 1288 ------- 1305 ------- 1318 ------- 1330 ------- 1347 ------- 1362 ------- 1374 ------- 1392 ------- 1408 ------- 1425 ------- 1441 ------- 1451 ------- 1465 ------- 1478 ------- 1495 ------- 1513 ------- 1530 ------- 1543 ------- 1559 ------- 1572 ------- 1587 ------- 1604 ------- 1620 ------- 1636 ------- 1648 ------- 1664 ------- 1678 ------- 1693 ------- 1708 ------- 1722 ------- 1737 ------- 1752 ------- 1767 ------- 1778 ------- 1793 ------- 1808 ------- 1826 ------- 1841 ------- 1854 ------- 1872 ------- 1885 ------- 1898 ------- 1914 ------- 1926 ------- 1938 ------- 1952 ------- 1965 ------- 1982 ------- 1998 ------- 2013 ------- 2027 ------- 2039 ------- 2056 ------- 2069 ------- 2083 ------- 2099 ------- 2115 ------- 2129 ------- 2141 ------- 2160 ------- 2174 ------- 2189 ------- 2203 ------- 2219 ------- 2235 ------- 2251 ------- 2269 ------- 2285 ------- 2297 ------- 2316 ------- 2332 ------- 2348 ------- 2368 ------- 2388 ------- 2402 ------- 2417 ------- 2433 ------- 2448 ------- 2464 ------- 2475 ------- 2490 ------- 2502 ------- 2514 ------- 2529 ------- 2544 ------- 2561 ------- 2579 ------- 2593 ------- 2606 ------- 2624 ------- 2637 ------- 2652 ------- 2664 ------- 2679 ------- 2693 ------- 2707 ------- 2721 ------- 2738 ------- 2753 ------- 2764 ------- 2776 ------- 2795 ------- 2808 ------- 2824 ------- 2836 ------- 2856 ------- 2870 ------- 2882 ------- 2899 ------- 2912 ------- 2923 ------- 2938 ------- 2953 ------- 2968 ------- 2983 ------- 3000
- │ │ │ │ histogram(12)= 0 2.9292e+05 0 3.0582e+05 0 3.0312e+05 0 2.9712e+05 0 2.9922e+05 0 3.1033e+05 0 3.0132e+05 0 2.9832e+05 0 2.9442e+05 0 2.9862e+05
- │ │ │ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ---------- 10 ---
- │ │ │ │ histogram(13)= 0 3.0762e+05 0 2.9352e+05 0 2.9532e+05 0 2.8332e+05 0 2.9142e+05 0 2.9862e+05 0 3.1393e+05 0 2.9442e+05 0 3.1303e+05 0 3.1003e+05
- │ │ │ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ----
- │ │ │ │ histogram(17)= 0 8.9913e+05 0 2.1021e+06
- │ │ │ │ <----- NULL ----- '2006-01-02 15:04:05'
+ │ │ │ │ ├── stats: [rows=3001222, distinct(11)=2999, null(11)=0, avgsize(11)=3, distinct(12)=10, null(12)=0, avgsize(12)=1, distinct(13)=10, null(13)=0, avgsize(13)=1, distinct(17)=2, null(17)=899134, avgsize(17)=5]
+ │ │ │ │ │ histogram(11)= 0 300 14406 1200 14406 600 13806 1501 14706 900 14406 1501 14706 1501 14406 600 14706 1200 14106 900 13505 1801 14706 300 13205 1801 14406 600 14406 1200 14706 900 13806 1801 13806 1501 14106 1200 14706 900 13205 1801 14706 600 14406 600 14406 1200 14706 900 14406 600 14406 900 14106 900 14706 1200 14406 900 14106 3001 14706 900 13806 1801 13806 1200 14106 1200 14706 1801 14106 600 13806 900 14406 3001 13806 900 14106 900 12905 1801 13505 1501 14406 600 14406 900 13505 1501 12905 2701 13205 1501 13806 1801 12605 2101 14106 600 14406 1501 12905 1801 13806 1200 13505 1200 13505 1501 13205 1501 13806 1200 13806 1200 13205 2701 13806 900 13505 1801 13505 1200 13205 1501 14406 600 13205 1801 13806 2101 14406 1200 13806 1501 14406 1200 14406 600 14106 600 14406 1501 14406 1501 14106 1200 14106 1501 12905 2101 14406 1801 14406 1200 13505 1200 13505 1200 12005 3001 14106 1801 13205 1501 13806 2401 14406 1501 13806 900 13806 1501 13505 2101 14406 600 13505 1200 13505 1200 14406 2101 14406 900 13806 1200 13806 900 14106 1200 13205 2101 13505 1501 14406 300 14406 1501 13806 900 14106 1501 14406 1801 12905 2101 14106 1200 14106 1501 14406 900 14406 1200 14406 1801 14106 2701 12305 2401 13505 1501 14406 1200 14106 1501 13505 1501 13505 1801 13806 1200 14106 600 12605 2101 12905 2101 13205 1501 14106 600 14106 1501 14106 600 14406 1200 12605 2701 13205 1200 14406 1200 14106 300 12605 2101 13505 1200 13205 1200 14106 600 14106 900 14106 900 12905 2101 14106 300 13205 1801 12605 1801 13806 1200 14106 1501 14106 600 12605 2101 13806 1200 14106 1501 13505 1501 13205 1501 14106 600 14106 1501 13806 600 13205 1801 13806 900 13505 1501 13806 1200 13205 1200 14106 300 12605 1801 14106 1501 12905 1501 13205 2101 13806 600 13205 1200 14106 900 13205 1200 13505 900 14106 600 14106 2101 14106 600 13806 1801 12605 1801 14106 1200 12305 2101 13505 1501 13806 900 14106 900 12305 2401 12905 1801 13806 900 13505 900 13806 900 13806 900 13806 2101 12605 2101 13806 600 13505 1200 13806 300 12305 2401 13505 1501 13505 600 12305 1801 13505 1200 13505 900 12605 1501 13205 1501 12905 2401 12305 1200 12605 1501 11705 900 11705 600
+ │ │ │ │ │ <--- 2 ------- 14 ------- 34 ------- 52 ------- 67 ------- 85 ------- 101 ------- 114 ------- 133 ------- 148 ------- 160 ------- 177 ------- 190 ------- 213 ------- 232 ------- 247 ------- 261 ------- 276 ------- 294 ------- 308 ------- 328 ------- 344 ------- 360 ------- 378 ------- 394 ------- 409 ------- 423 ------- 435 ------- 450 ------- 466 ------- 480 ------- 497 ------- 510 ------- 526 ------- 540 ------- 556 ------- 569 ------- 584 ------- 597 ------- 612 ------- 629 ------- 642 ------- 659 ------- 674 ------- 691 ------- 708 ------- 725 ------- 738 ------- 754 ------- 768 ------- 786 ------- 803 ------- 818 ------- 834 ------- 850 ------- 862 ------- 874 ------- 888 ------- 900 ------- 916 ------- 931 ------- 949 ------- 963 ------- 978 ------- 993 ------- 1005 ------- 1019 ------- 1037 ------- 1052 ------- 1065 ------- 1082 ------- 1098 ------- 1116 ------- 1131 ------- 1151 ------- 1166 ------- 1180 ------- 1196 ------- 1210 ------- 1227 ------- 1243 ------- 1256 ------- 1272 ------- 1285 ------- 1300 ------- 1315 ------- 1329 ------- 1345 ------- 1361 ------- 1378 ------- 1393 ------- 1408 ------- 1425 ------- 1441 ------- 1459 ------- 1476 ------- 1492 ------- 1507 ------- 1518 ------- 1532 ------- 1546 ------- 1561 ------- 1579 ------- 1594 ------- 1606 ------- 1622 ------- 1635 ------- 1646 ------- 1662 ------- 1678 ------- 1693 ------- 1705 ------- 1717 ------- 1734 ------- 1750 ------- 1764 ------- 1779 ------- 1791 ------- 1804 ------- 1821 ------- 1832 ------- 1843 ------- 1858 ------- 1875 ------- 1888 ------- 1902 ------- 1920 ------- 1935 ------- 1952 ------- 1971 ------- 1985 ------- 2002 ------- 2014 ------- 2028 ------- 2039 ------- 2052 ------- 2065 ------- 2078 ------- 2090 ------- 2108 ------- 2126 ------- 2139 ------- 2156 ------- 2172 ------- 2187 ------- 2201 ------- 2214 ------- 2227 ------- 2241 ------- 2258 ------- 2272 ------- 2286 ------- 2304 ------- 2318 ------- 2333 ------- 2347 ------- 2360 ------- 2372 ------- 2388 ------- 2405 ------- 2422 ------- 2437 ------- 2452 ------- 2469 ------- 2485 ------- 2498 ------- 2512 ------- 2526 ------- 2540 ------- 2553 ------- 2563 ------- 2580 ------- 2595 ------- 2609 ------- 2626 ------- 2641 ------- 2657 ------- 2674 ------- 2688 ------- 2701 ------- 2715 ------- 2728 ------- 2745 ------- 2758 ------- 2773 ------- 2790 ------- 2802 ------- 2815 ------- 2832 ------- 2850 ------- 2865 ------- 2883 ------- 2899 ------- 2915 ------- 2932 ------- 2946 ------- 2958 ------- 2973 ------- 2984 ------- 3000
+ │ │ │ │ │ histogram(12)= 0 2.8722e+05 0 3.0822e+05 0 3.0162e+05 0 2.9682e+05 0 3.1063e+05 0 3.0252e+05 0 3.0312e+05 0 3.0432e+05 0 2.9322e+05 0 2.9352e+05
+ │ │ │ │ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ---------- 10 ---
+ │ │ │ │ │ histogram(13)= 0 2.9082e+05 0 2.8632e+05 0 3.1093e+05 0 3.1093e+05 0 3.0732e+05 0 3.1783e+05 0 2.8902e+05 0 3.0342e+05 0 2.8932e+05 0 2.9532e+05
+ │ │ │ │ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 ---------- 4 ---------- 5 ---------- 6 ---------- 7 ---------- 8 ---------- 9 ----
+ │ │ │ │ │ histogram(17)= 0 8.9913e+05 0 2.1021e+06
+ │ │ │ │ │ <----- NULL ----- '2006-01-02 15:04:05'
+ │ │ │ │ └── ordering: +13,+12,-11
│ │ │ └── filters
│ │ │ └── ol_delivery_d:17 IS NULL [type=bool, outer=(17), constraints=(/17: [/NULL - /NULL]; tight), fd=()-->(17)]
│ │ ├── project
│ │ │ ├── save-table-name: consistency_12_project_7
│ │ │ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null)
- │ │ │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4]
+ │ │ │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1]
│ │ │ ├── key: (1-3)
+ │ │ │ ├── ordering: +3,+2,-1
│ │ │ └── select
│ │ │ ├── save-table-name: consistency_12_select_8
│ │ │ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null) o_carrier_id:6(int)
- │ │ │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(6)=1, null(6)=90000, avgsize(6)=4]
+ │ │ │ ├── stats: [rows=90000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(6)=1, null(6)=90000, avgsize(6)=2]
│ │ │ │ histogram(6)= 0 90000
│ │ │ │ <--- NULL
│ │ │ ├── key: (1-3)
│ │ │ ├── fd: ()-->(6)
- │ │ │ ├── scan order@order_idx
+ │ │ │ ├── ordering: +3,+2,-1 opt(6) [actual: +3,+2,-1]
+ │ │ │ ├── scan order
│ │ │ │ ├── save-table-name: consistency_12_scan_9
│ │ │ │ ├── columns: o_id:1(int!null) o_d_id:2(int!null) o_w_id:3(int!null) o_carrier_id:6(int)
- │ │ │ │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=4, distinct(2)=10, null(2)=0, avgsize(2)=4, distinct(3)=10, null(3)=0, avgsize(3)=4, distinct(6)=11, null(6)=90000, avgsize(6)=4]
- │ │ │ │ │ histogram(1)= 0 60 1470 90 1410 150 1470 150 1350 180 1470 120 1410 120 1410 90 1470 120 1350 150 1440 60 1350 210 1380 120 1410 90 1440 90 1470 120 1470 90 1320 240 1440 60 1410 150 1470 180 1470 90 1410 90 1380 150 1320 180 1470 90 1320 270 1470 120 1470 60 1470 90 1470 120 1440 150 1410 90 1380 120 1290 180 1320 180 1440 60 1230 240 1380 90 1440 150 1410 150 1230 240 1410 210 1440 150 1380 240 1320 300 1440 90 1440 60 1290 210 1440 240 1380 180 1350 150 1320 150 1380 120 1440 150 1380 120 1410 120 1230 300 1440 60 1350 150 1410 120 1410 60 1410 90 1440 30 1380 90 1440 60 1440 30 1290 240 1380 90 1410 120 1350 120 1380 150 1440 120 1350 240 1410 120 1440 60 1410 90 1410 60 1440 60 1440 150 1410 210 1440 90 1170 330 1440 90 1290 270 1200 300 1440 150 1380 90 1410 90 1440 120 1380 90 1380 120 1290 180 1350 150 1350 180 1410 60 1290 180 1410 150 1410 60 1440 60 1440 60 1440 150 1440 120 1410 180 1440 60 1350 180 1440 90 1440 180 1380 90 1380 90 1350 180 1380 120 1410 60 1440 60 1350 120 1410 120 1350 120 1410 90 1350 150 1350 150 1410 180 1410 90 1380 120 1410 60 1380 120 1410 90 1410 90 1440 60 1380 90 1410 150 1380 120 1290 210 1440 90 1410 90 1410 90 1410 150 1260 180 1350 150 1320 240 1320 180 1380 60 1320 120 1410 90 1350 150 1350 150 1350 120 1380 150 1410 60 1410 270 1350 150 1320 150 1320 150 1380 180 1350 90 1260 300 1350 180 1380 90 1320 150 1410 60 1380 90 1410 120 1380 90 1230 300 1380 120 1410 60 1320 150 1350 120 1410 30 1380 210 1380 120 1290 120 1380 180 1380 120 1320 90 1170 270 1290 120 1320 120 1380 120 1380 60 1230 180 1290 150 1320 90 1350 60 1320 180 1380 60 1350 60 1380 120 1350 90 1350 120 1320 210 1320 150 1320 60 1350 210 1230 180 1260 150 1260 150 1230 90 1170 210 1290 90 1200 90
- │ │ │ │ │ <--- 1 ------ 14 ------ 30 ------ 44 ------ 54 ------ 68 ------ 81 ------ 98 ------ 111 ------ 125 ------ 138 ------ 157 ------ 173 ------ 188 ------ 203 ------ 219 ------ 240 ------ 255 ------ 272 ------ 287 ------ 303 ------ 320 ------ 333 ------ 349 ------ 360 ------ 379 ------ 393 ------ 408 ------ 424 ------ 439 ------ 458 ------ 474 ------ 489 ------ 506 ------ 519 ------ 532 ------ 549 ------ 563 ------ 577 ------ 593 ------ 613 ------ 627 ------ 642 ------ 658 ------ 676 ------ 691 ------ 705 ------ 720 ------ 736 ------ 749 ------ 767 ------ 782 ------ 794 ------ 808 ------ 825 ------ 839 ------ 856 ------ 868 ------ 885 ------ 899 ------ 914 ------ 930 ------ 946 ------ 963 ------ 982 ------ 998 ------ 1014 ------ 1029 ------ 1047 ------ 1064 ------ 1080 ------ 1095 ------ 1110 ------ 1126 ------ 1143 ------ 1161 ------ 1176 ------ 1190 ------ 1204 ------ 1225 ------ 1240 ------ 1255 ------ 1271 ------ 1285 ------ 1302 ------ 1317 ------ 1333 ------ 1348 ------ 1364 ------ 1379 ------ 1396 ------ 1412 ------ 1427 ------ 1443 ------ 1456 ------ 1474 ------ 1484 ------ 1500 ------ 1512 ------ 1528 ------ 1543 ------ 1559 ------ 1576 ------ 1592 ------ 1606 ------ 1619 ------ 1636 ------ 1655 ------ 1669 ------ 1686 ------ 1705 ------ 1721 ------ 1734 ------ 1746 ------ 1761 ------ 1777 ------ 1789 ------ 1803 ------ 1816 ------ 1831 ------ 1847 ------ 1861 ------ 1875 ------ 1893 ------ 1910 ------ 1926 ------ 1941 ------ 1955 ------ 1966 ------ 1981 ------ 1996 ------ 2011 ------ 2024 ------ 2039 ------ 2053 ------ 2067 ------ 2083 ------ 2099 ------ 2116 ------ 2130 ------ 2148 ------ 2165 ------ 2182 ------ 2198 ------ 2209 ------ 2224 ------ 2237 ------ 2251 ------ 2270 ------ 2282 ------ 2293 ------ 2307 ------ 2324 ------ 2338 ------ 2351 ------ 2365 ------ 2383 ------ 2397 ------ 2413 ------ 2427 ------ 2440 ------ 2453 ------ 2467 ------ 2480 ------ 2494 ------ 2508 ------ 2523 ------ 2538 ------ 2553 ------ 2568 ------ 2586 ------ 2601 ------ 2616 ------ 2629 ------ 2641 ------ 2655 ------ 2669 ------ 2684 ------ 2701 ------ 2717 ------ 2735 ------ 2747 ------ 2760 ------ 2774 ------ 2789 ------ 2806 ------ 2821 ------ 2835 ------ 2848 ------ 2862 ------ 2877 ------ 2892 ------ 2907 ------ 2918 ------ 2935 ------ 2951 ------ 2963 ------ 2974 ------ 2988 ------ 3000
- │ │ │ │ │ histogram(2)= 0 30450 0 29880 0 31230 0 29850 0 28410 0 29250 0 29580 0 30840 0 30450 0 30060
+ │ │ │ │ ├── stats: [rows=300000, distinct(1)=2999, null(1)=0, avgsize(1)=3, distinct(2)=10, null(2)=0, avgsize(2)=1, distinct(3)=10, null(3)=0, avgsize(3)=1, distinct(6)=11, null(6)=90000, avgsize(6)=2]
+ │ │ │ │ │ histogram(1)= 0 60 1380 120 1440 180 1380 180 1440 60 1470 150 1410 240 1410 90 1350 210 1440 150 1380 120 1410 120 1410 150 1380 120 1440 120 1470 180 1440 120 1410 90 1410 120 1380 210 1440 60 1440 60 1410 150 1440 180 1350 150 1440 150 1440 150 1440 60 1440 90 1380 150 1350 150 1350 120 1410 120 1350 150 1410 90 1410 60 1380 90 1290 210 1410 180 1230 270 1440 210 1320 150 1410 120 1320 180 1440 180 1410 90 1350 150 1260 240 1290 210 1410 180 1380 150 1320 180 1380 120 1440 180 1320 150 1290 180 1410 90 1410 60 1380 120 1320 180 1380 150 1410 180 1380 150 1380 120 1380 120 1410 60 1350 150 1440 30 1320 150 1320 210 1350 120 1440 30 1440 30 1350 150 1350 270 1440 60 1380 90 1440 180 1410 60 1290 180 1410 120 1440 90 1440 60 1440 90 1260 210 1380 120 1380 150 1440 120 1440 90 1320 240 1320 150 1260 210 1290 180 1290 210 1410 120 1380 90 1410 150 1440 90 1440 60 1440 60 1440 210 1440 120 1410 120 1320 150 1440 30 1410 150 1380 120 1440 120 1410 60 1350 150 1410 120 1350 120 1440 90 1440 150 1290 180 1350 180 1320 150 1440 60 1410 90 1350 120 1410 210 1380 150 1350 270 1320 180 1350 150 1440 120 1410 90 1380 180 1440 150 1380 90 1200 270 1410 240 1440 30 1410 60 1440 90 1380 120 1410 120 1440 60 1440 60 1380 90 1410 120 1380 90 1410 30 1440 60 1410 120 1350 120 1290 210 1380 150 1380 90 1410 90 1380 90 1320 210 1290 180 1380 90 1350 90 1320 150 1380 120 1410 150 1410 30 1380 90 1410 120 1410 60 1410 30 1410 180 1410 60 1380 60 1410 120 1290 270 1350 120 1380 60 1410 60 1260 180 1290 150 1410 210 1410 60 1380 90 1380 60 1320 120 1380 180 1290 150 1380 60 1290 150 1290 150 1260 210 1290 120 1320 90 1380 60 1350 60 1350 90 1410 210 1320 150 1380 120 1260 150 1260 150 1320 120 1320 90 1260 120 1200 240 1230 210 1290 30
+ │ │ │ │ │ <--- 1 ------ 17 ------ 31 ------ 46 ------ 62 ------ 77 ------ 90 ------ 107 ------ 120 ------ 135 ------ 151 ------ 163 ------ 178 ------ 189 ------ 204 ------ 222 ------ 239 ------ 254 ------ 268 ------ 285 ------ 298 ------ 310 ------ 324 ------ 338 ------ 354 ------ 368 ------ 386 ------ 398 ------ 412 ------ 426 ------ 443 ------ 459 ------ 478 ------ 494 ------ 510 ------ 524 ------ 539 ------ 555 ------ 570 ------ 584 ------ 601 ------ 612 ------ 626 ------ 641 ------ 656 ------ 670 ------ 686 ------ 698 ------ 709 ------ 720 ------ 738 ------ 758 ------ 773 ------ 786 ------ 799 ------ 813 ------ 833 ------ 847 ------ 863 ------ 878 ------ 893 ------ 910 ------ 925 ------ 938 ------ 955 ------ 971 ------ 983 ------ 999 ------ 1017 ------ 1030 ------ 1044 ------ 1063 ------ 1077 ------ 1092 ------ 1108 ------ 1126 ------ 1139 ------ 1160 ------ 1176 ------ 1192 ------ 1208 ------ 1226 ------ 1239 ------ 1252 ------ 1266 ------ 1280 ------ 1294 ------ 1310 ------ 1326 ------ 1342 ------ 1352 ------ 1365 ------ 1378 ------ 1393 ------ 1409 ------ 1423 ------ 1439 ------ 1457 ------ 1470 ------ 1489 ------ 1507 ------ 1522 ------ 1532 ------ 1545 ------ 1558 ------ 1571 ------ 1583 ------ 1600 ------ 1614 ------ 1626 ------ 1641 ------ 1660 ------ 1673 ------ 1688 ------ 1701 ------ 1718 ------ 1731 ------ 1745 ------ 1762 ------ 1781 ------ 1797 ------ 1809 ------ 1825 ------ 1839 ------ 1852 ------ 1869 ------ 1882 ------ 1898 ------ 1916 ------ 1930 ------ 1945 ------ 1958 ------ 1974 ------ 1989 ------ 2006 ------ 2028 ------ 2044 ------ 2060 ------ 2080 ------ 2094 ------ 2112 ------ 2123 ------ 2138 ------ 2153 ------ 2168 ------ 2181 ------ 2196 ------ 2213 ------ 2228 ------ 2244 ------ 2260 ------ 2275 ------ 2288 ------ 2301 ------ 2316 ------ 2330 ------ 2347 ------ 2363 ------ 2378 ------ 2393 ------ 2411 ------ 2429 ------ 2443 ------ 2459 ------ 2478 ------ 2493 ------ 2509 ------ 2524 ------ 2541 ------ 2557 ------ 2575 ------ 2588 ------ 2603 ------ 2617 ------ 2628 ------ 2640 ------ 2656 ------ 2671 ------ 2684 ------ 2697 ------ 2714 ------ 2727 ------ 2748 ------ 2766 ------ 2780 ------ 2797 ------ 2811 ------ 2828 ------ 2839 ------ 2856 ------ 2873 ------ 2887 ------ 2904 ------ 2919 ------ 2931 ------ 2947 ------ 2960 ------ 2971 ------ 2984 ------ 3000
+ │ │ │ │ │ histogram(2)= 0 30990 0 30780 0 28650 0 30570 0 30060 0 30060 0 30690 0 28020 0 30180 0 30000
│ │ │ │ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 ---- 10 -
- │ │ │ │ │ histogram(3)= 0 31260 0 29820 0 29520 0 30000 0 29670 0 29340 0 28530 0 29760 0 30810 0 31290
+ │ │ │ │ │ histogram(3)= 0 29970 0 30090 0 29760 0 29040 0 29820 0 29580 0 30660 0 29280 0 31080 0 30720
│ │ │ │ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 ----- 8 ----- 9 -
- │ │ │ │ │ histogram(6)= 0 90000 0 20768 1.6732e+05 21913
+ │ │ │ │ │ histogram(6)= 0 90000 0 21169 1.6751e+05 21318
│ │ │ │ │ <--- NULL ---- 1 ------------- 10 -
│ │ │ │ ├── key: (1-3)
- │ │ │ │ └── fd: (1-3)-->(6)
+ │ │ │ │ ├── fd: (1-3)-->(6)
+ │ │ │ │ └── ordering: +3,+2,-1
│ │ │ └── filters
│ │ │ └── o_carrier_id:6 IS NULL [type=bool, outer=(6), constraints=(/6: [/NULL - /NULL]; tight), fd=()-->(6)]
- │ │ └── filters
- │ │ ├── ol_w_id:13 = o_w_id:3 [type=bool, outer=(3,13), constraints=(/3: (/NULL - ]; /13: (/NULL - ]), fd=(3)==(13), (13)==(3)]
- │ │ ├── ol_d_id:12 = o_d_id:2 [type=bool, outer=(2,12), constraints=(/2: (/NULL - ]; /12: (/NULL - ]), fd=(2)==(12), (12)==(2)]
- │ │ └── ol_o_id:11 = o_id:1 [type=bool, outer=(1,11), constraints=(/1: (/NULL - ]; /11: (/NULL - ]), fd=(1)==(11), (11)==(1)]
+ │ │ └── filters (true)
│ └── filters
│ └── (ol_o_id:11 IS NULL) OR (o_id:1 IS NULL) [type=bool, outer=(1,11)]
└── aggregations
@@ -1742,7 +1746,7 @@ column_names row_count_est row_count_err distinct_count_est distinct_count_e
{ol_o_id} 629604.00 +Inf <== 2999.00 +Inf <== 0.00 1.00
{ol_w_id} 629604.00 +Inf <== 10.00 +Inf <== 0.00 1.00
-----Stats for consistency_12_full_join_3----
+----Stats for consistency_12_merge_join_3----
column_names row_count distinct_count null_count
{o_d_id} 899134 10 0
{o_id} 899134 900 0
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q01 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q01
index 856a6abbf7cd..61255730a94f 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q01
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q01
@@ -45,7 +45,7 @@ sort
├── save-table-name: q1_sort_1
├── columns: l_returnflag:9(char!null) l_linestatus:10(char!null) sum_qty:19(float!null) sum_base_price:20(float!null) sum_disc_price:22(float!null) sum_charge:24(float!null) avg_qty:25(float!null) avg_price:26(float!null) avg_disc:27(float!null) count_order:28(int!null)
├── immutable
- ├── stats: [rows=6, distinct(9)=3, null(9)=0, avgsize(9)=4, distinct(10)=2, null(10)=0, avgsize(10)=4, distinct(19)=6, null(19)=0, avgsize(19)=8, distinct(20)=6, null(20)=0, avgsize(20)=8, distinct(22)=6, null(22)=0, avgsize(22)=8, distinct(24)=6, null(24)=0, avgsize(24)=8, distinct(25)=6, null(25)=0, avgsize(25)=8, distinct(26)=6, null(26)=0, avgsize(26)=8, distinct(27)=6, null(27)=0, avgsize(27)=8, distinct(28)=6, null(28)=0, avgsize(28)=8, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=8]
+ ├── stats: [rows=6, distinct(9)=3, null(9)=0, avgsize(9)=3, distinct(10)=2, null(10)=0, avgsize(10)=3, distinct(19)=6, null(19)=0, avgsize(19)=6, distinct(20)=6, null(20)=0, avgsize(20)=6, distinct(22)=6, null(22)=0, avgsize(22)=6, distinct(24)=6, null(24)=0, avgsize(24)=6, distinct(25)=6, null(25)=0, avgsize(25)=6, distinct(26)=6, null(26)=0, avgsize(26)=6, distinct(27)=6, null(27)=0, avgsize(27)=6, distinct(28)=6, null(28)=0, avgsize(28)=6, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=6]
├── key: (9,10)
├── fd: (9,10)-->(19,20,22,24-28)
├── ordering: +9,+10
@@ -54,39 +54,39 @@ sort
├── columns: l_returnflag:9(char!null) l_linestatus:10(char!null) sum:19(float!null) sum:20(float!null) sum:22(float!null) sum:24(float!null) avg:25(float!null) avg:26(float!null) avg:27(float!null) count_rows:28(int!null)
├── grouping columns: l_returnflag:9(char!null) l_linestatus:10(char!null)
├── immutable
- ├── stats: [rows=6, distinct(9)=3, null(9)=0, avgsize(9)=4, distinct(10)=2, null(10)=0, avgsize(10)=4, distinct(19)=6, null(19)=0, avgsize(19)=8, distinct(20)=6, null(20)=0, avgsize(20)=8, distinct(22)=6, null(22)=0, avgsize(22)=8, distinct(24)=6, null(24)=0, avgsize(24)=8, distinct(25)=6, null(25)=0, avgsize(25)=8, distinct(26)=6, null(26)=0, avgsize(26)=8, distinct(27)=6, null(27)=0, avgsize(27)=8, distinct(28)=6, null(28)=0, avgsize(28)=8, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=8]
+ ├── stats: [rows=6, distinct(9)=3, null(9)=0, avgsize(9)=3, distinct(10)=2, null(10)=0, avgsize(10)=3, distinct(19)=6, null(19)=0, avgsize(19)=6, distinct(20)=6, null(20)=0, avgsize(20)=6, distinct(22)=6, null(22)=0, avgsize(22)=6, distinct(24)=6, null(24)=0, avgsize(24)=6, distinct(25)=6, null(25)=0, avgsize(25)=6, distinct(26)=6, null(26)=0, avgsize(26)=6, distinct(27)=6, null(27)=0, avgsize(27)=6, distinct(28)=6, null(28)=0, avgsize(28)=6, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=6]
├── key: (9,10)
├── fd: (9,10)-->(19,20,22,24-28)
├── project
│ ├── save-table-name: q1_project_3
│ ├── columns: column21:21(float!null) column23:23(float!null) l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_returnflag:9(char!null) l_linestatus:10(char!null)
│ ├── immutable
- │ ├── stats: [rows=5920656, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=971211, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(9)=3, null(9)=0, avgsize(9)=4, distinct(10)=2, null(10)=0, avgsize(10)=4, distinct(21)=5.92066e+06, null(21)=0, avgsize(21)=8, distinct(23)=5.92066e+06, null(23)=0, avgsize(23)=12, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=8]
+ │ ├── stats: [rows=5915479, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=925955, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(9)=3, null(9)=0, avgsize(9)=3, distinct(10)=2, null(10)=0, avgsize(10)=3, distinct(21)=5.91548e+06, null(21)=0, avgsize(21)=18, distinct(23)=5.91548e+06, null(23)=0, avgsize(23)=27, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=6]
│ ├── fd: (6,7)-->(21)
│ ├── select
│ │ ├── save-table-name: q1_select_4
│ │ ├── columns: l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_tax:8(float!null) l_returnflag:9(char!null) l_linestatus:10(char!null) l_shipdate:11(date!null)
- │ │ ├── stats: [rows=5920656, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=971211, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(8)=9, null(8)=0, avgsize(8)=4, distinct(9)=3, null(9)=0, avgsize(9)=4, distinct(10)=2, null(10)=0, avgsize(10)=4, distinct(11)=2438, null(11)=0, avgsize(11)=4, distinct(6,7)=5.92066e+06, null(6,7)=0, avgsize(6,7)=8, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=8, distinct(6-8)=5.92066e+06, null(6-8)=0, avgsize(6-8)=12]
- │ │ │ histogram(11)= 0 0 7 600 29411 1801 28811 1801 27010 3001 27610 6002 27010 3001 27610 5402 29411 2401 27010 3001 29411 1200 28811 1801 29411 1801 28811 3001 29411 2401 28811 2401 29411 4802 28811 2401 27610 3601 28211 2401 28811 3601 29411 3001 28811 1200 28811 2401 28811 2401 28211 1200 28811 2401 27010 3601 28811 600 27610 1801 28211 2401 28811 3001 27610 3601 27010 2401 28811 1200 27610 4202 25810 3601 27610 2401 26410 3601 28811 1200 28811 1801 25810 6002 28811 5402 28811 6002 28811 3601 28211 1801 28811 1801 27610 1801 25210 4202 28811 1801 27610 2401 28211 1801 27010 3001 27610 1801 25210 4202 26410 3001 27010 3001 28811 3001 28211 4802 28811 1200 28811 3001 28211 1801 27610 3001 27010 3001 28211 3001 28211 1200 27610 3601 28811 2401 27610 3601 28211 1801 28811 1200 27010 4202 27010 3601 27010 3601 26410 3601 27610 2401 28211 4202 27010 3601 25810 3601 28811 3601 28811 2401 27010 3001 28211 2401 28211 2401 28211 2401 27610 3001 27610 2401 28811 3001 28811 1801 28211 3601 27010 2401 28811 2401 28211 1200 27010 3001 27010 3001 28211 2401 28211 2401 27010 4802 28211 1200 27610 2401 27010 2401 27610 1801 28811 2401 27010 3601 28211 6002 27610 2401 27010 2401 28811 5402 28811 3601 26410 2401 27010 4202 26410 4802 25810 3601 26410 2401 28211 1200 26410 3601 26410 3001 24609 4802 27010 4802 26410 6603 25810 4202 28211 3001 24609 4202 28211 4802 26410 2401 27010 3001 28211 3001 27610 3601 28211 2401 28211 3001 27610 1200 26410 3001 26410 3001 27010 1801 27010 4202 26410 2401 27010 1801 25810 3001 27610 1200 26410 3001 27610 3601 27610 3601 28211 2401 26410 3601 28211 1801 27610 1801 26410 4202 27610 1200 25810 5402 25210 3601 27010 2401 27010 3001 27010 1200 27610 3001 25210 3001 26410 3601 27010 3601 26410 2401 27610 3001 27610 3601 27610 1200 26410 1801 26410 3001 25810 4202 24609 4802 27610 1801 25810 3001 27010 3001 27610 1200 25210 4202 27010 1200 26410 2401 25210 3001 24609 4802 27010 4802 27610 2401 26410 2401 26410 2401 26410 3601 26410 3001 25810 5402 25810 3601 27010 1200 25210 5402 25210 1801 22208 4802 25210 3001 25210 1801 24009 3001 25810 3001 25810 1200 26410 1200 24009 4802 25810 3601 24609 3601 22208 4202 25210 1200 24378 2031.5
- │ │ │ <--- '-infinity' --- '1992-01-07' ------- '1992-02-22' ------- '1992-03-12' ------- '1992-04-02' ------- '1992-04-17' ------- '1992-04-30' ------- '1992-05-13' ------- '1992-05-25' ------- '1992-06-07' ------- '1992-06-20' ------- '1992-07-06' ------- '1992-07-18' ------- '1992-07-30' ------- '1992-08-12' ------- '1992-08-24' ------- '1992-09-10' ------- '1992-09-23' ------- '1992-10-04' ------- '1992-10-16' ------- '1992-10-29' ------- '1992-11-14' ------- '1992-11-28' ------- '1992-12-12' ------- '1992-12-27' ------- '1993-01-07' ------- '1993-01-20' ------- '1993-02-01' ------- '1993-02-12' ------- '1993-02-25' ------- '1993-03-11' ------- '1993-03-22' ------- '1993-04-04' ------- '1993-04-15' ------- '1993-04-28' ------- '1993-05-13' ------- '1993-05-26' ------- '1993-06-07' ------- '1993-06-18' ------- '1993-06-28' ------- '1993-07-14' ------- '1993-07-26' ------- '1993-08-08' ------- '1993-08-20' ------- '1993-09-03' ------- '1993-09-14' ------- '1993-09-26' ------- '1993-10-09' ------- '1993-10-20' ------- '1993-11-02' ------- '1993-11-15' ------- '1993-11-29' ------- '1993-12-10' ------- '1993-12-22' ------- '1994-01-01' ------- '1994-01-11' ------- '1994-01-22' ------- '1994-02-05' ------- '1994-02-18' ------- '1994-03-01' ------- '1994-03-13' ------- '1994-03-26' ------- '1994-04-06' ------- '1994-04-17' ------- '1994-04-27' ------- '1994-05-10' ------- '1994-05-21' ------- '1994-06-03' ------- '1994-06-17' ------- '1994-06-27' ------- '1994-07-13' ------- '1994-07-27' ------- '1994-08-06' ------- '1994-08-19' ------- '1994-08-30' ------- '1994-09-11' ------- '1994-09-21' ------- '1994-10-03' ------- '1994-10-13' ------- '1994-10-26' ------- '1994-11-08' ------- '1994-11-19' ------- '1994-12-01' ------- '1994-12-13' ------- '1994-12-23' ------- '1995-01-04' ------- '1995-01-15' ------- '1995-01-28' ------- '1995-02-10' ------- '1995-02-21' ------- '1995-03-09' ------- '1995-03-21' ------- '1995-04-02' ------- '1995-04-11' ------- '1995-04-22' ------- '1995-05-03' ------- '1995-05-15' ------- '1995-05-28' ------- '1995-06-11' ------- '1995-06-24' ------- '1995-07-04' ------- '1995-07-15' ------- '1995-07-25' ------- '1995-08-10' ------- '1995-08-20' ------- '1995-09-03' ------- '1995-09-13' ------- '1995-09-24' ------- '1995-10-07' ------- '1995-10-18' ------- '1995-10-31' ------- '1995-11-13' ------- '1995-11-24' ------- '1995-12-04' ------- '1995-12-16' ------- '1995-12-26' ------- '1996-01-07' ------- '1996-01-21' ------- '1996-02-01' ------- '1996-02-14' ------- '1996-02-23' ------- '1996-03-07' ------- '1996-03-21' ------- '1996-04-02' ------- '1996-04-14' ------- '1996-04-28' ------- '1996-05-12' ------- '1996-05-26' ------- '1996-06-06' ------- '1996-06-19' ------- '1996-07-02' ------- '1996-07-10' ------- '1996-07-23' ------- '1996-08-03' ------- '1996-08-16' ------- '1996-08-29' ------- '1996-09-08' ------- '1996-09-18' ------- '1996-10-01' ------- '1996-10-13' ------- '1996-10-25' ------- '1996-11-07' ------- '1996-11-20' ------- '1996-12-02' ------- '1996-12-15' ------- '1996-12-27' ------- '1997-01-08' ------- '1997-01-19' ------- '1997-01-30' ------- '1997-02-09' ------- '1997-02-21' ------- '1997-03-06' ------- '1997-03-18' ------- '1997-03-29' ------- '1997-04-10' ------- '1997-04-21' ------- '1997-05-03' ------- '1997-05-14' ------- '1997-05-29' ------- '1997-06-10' ------- '1997-06-24' ------- '1997-07-06' ------- '1997-07-20' ------- '1997-08-01' ------- '1997-08-10' ------- '1997-08-23' ------- '1997-09-02' ------- '1997-09-15' ------- '1997-09-24' ------- '1997-10-08' ------- '1997-10-25' ------- '1997-11-07' ------- '1997-11-17' ------- '1997-11-29' ------- '1997-12-12' ------- '1997-12-24' ------- '1998-01-02' ------- '1998-01-16' ------- '1998-01-29' ------- '1998-02-11' ------- '1998-02-25' ------- '1998-03-11' ------- '1998-03-20' ------- '1998-03-31' ------- '1998-04-12' ------- '1998-04-24' ------- '1998-05-04' ------- '1998-05-14' ------- '1998-05-23' ------- '1998-06-03' ------- '1998-06-13' ------- '1998-06-24' ------- '1998-07-05' ------- '1998-07-15' ------- '1998-07-30' ------- '1998-08-08' ------- '1998-08-20' ------- '1998-09-02'
+ │ │ ├── stats: [rows=5915479, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=925955, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(8)=9, null(8)=0, avgsize(8)=9, distinct(9)=3, null(9)=0, avgsize(9)=3, distinct(10)=2, null(10)=0, avgsize(10)=3, distinct(11)=2438, null(11)=0, avgsize(11)=4, distinct(6,7)=5.91548e+06, null(6,7)=0, avgsize(6,7)=18, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=6, distinct(6-8)=5.91548e+06, null(6-8)=0, avgsize(6-8)=27]
+ │ │ │ histogram(11)= 0 0 4 600 29406 600 28806 2400 28206 2400 28206 1800 28806 1200 28206 2400 26405 3601 27606 3601 28206 2400 28806 3001 28206 2400 27606 2400 29406 1800 29406 3601 28806 1800 27606 4201 27005 3001 25205 4801 25805 4801 27005 4201 28206 1800 26405 3601 26405 3601 23405 7201 29406 2400 26405 3601 28206 2400 27005 3601 28206 3001 29406 1800 25805 4801 28806 3001 28806 1800 29406 1800 27005 4201 29406 4201 27606 2400 28206 3601 28806 1800 26405 3001 27606 3601 24605 4801 27005 5401 28206 2400 28806 1200 28206 4201 27005 2400 27606 3601 27606 2400 28206 2400 28206 1200 28806 3001 28206 1200 25805 6001 28806 1800 27606 4201 27005 5401 28806 3001 27606 2400 24005 5401 24605 5401 28206 3601 26405 3001 27005 2400 28806 3601 28206 1800 28806 2400 28806 1800 28206 1800 27606 3601 28206 3001 26405 3001 28206 1200 28206 2400 28806 1200 27606 3001 24605 5401 28806 1800 25805 3601 27005 2400 28806 1800 28806 600 28806 600 27606 3601 28206 3001 27005 3601 27606 2400 26405 5401 28806 1800 28206 4201 26405 6601 27606 2400 27005 3601 28806 3601 28806 3001 28206 3001 27005 3001 28206 1800 28206 4801 25205 5401 27005 4201 24605 5401 28806 3601 24605 6001 26405 3001 28806 2400 28806 1800 28206 1800 28806 4201 28806 1800 28806 3601 28206 4201 28206 3001 28206 1200 28206 600 27606 3601 25805 3001 25805 3001 27606 2400 26405 3001 25805 4801 27005 1800 28206 3601 28206 1200 25805 3601 27005 4201 28206 3601 27606 3001 26405 3601 24605 4201 24605 4201 27606 2400 25805 3001 28206 2400 28206 4201 27005 3001 25205 3601 26405 2400 27005 3601 25805 3601 27606 1200 25805 3001 27005 3001 26405 2400 28206 3601 28206 2400 27005 4201 27606 1800 27606 3001 24605 4801 28206 3001 28206 3001 27606 2400 26405 3601 27005 2400 27005 1800 26405 3001 25205 4201 25205 3601 27606 3601 27005 1800 25205 3001 26405 3601 25205 3001 26405 1800 25805 3001 25205 3601 23405 5401 27606 2400 27005 3001 25805 2400 27005 2400 25205 4201 27606 5401 24005 4201 26405 3001 24005 4201 27005 1800 26405 1200 27005 3601 26405 3601 26405 1800 27005 2400 27005 3001 24605 3001 24005 3601 27005 2400 26405 2400 25205 2400 25805 1800 25805 3001 24605 2400 24605 2400 25805 3001 25805 1800 19332 1757.5
+ │ │ │ <--- '-infinity' --- '1992-01-04' ------- '1992-02-26' ------- '1992-03-21' ------- '1992-04-04' ------- '1992-04-17' ------- '1992-05-04' ------- '1992-05-17' ------- '1992-05-29' ------- '1992-06-09' ------- '1992-06-22' ------- '1992-07-06' ------- '1992-07-19' ------- '1992-08-01' ------- '1992-08-13' ------- '1992-08-26' ------- '1992-09-07' ------- '1992-09-19' ------- '1992-10-01' ------- '1992-10-14' ------- '1992-10-26' ------- '1992-11-06' ------- '1992-11-21' ------- '1992-12-04' ------- '1992-12-15' ------- '1992-12-24' ------- '1993-01-06' ------- '1993-01-18' ------- '1993-01-31' ------- '1993-02-13' ------- '1993-02-25' ------- '1993-03-09' ------- '1993-03-19' ------- '1993-03-31' ------- '1993-04-11' ------- '1993-04-27' ------- '1993-05-06' ------- '1993-05-18' ------- '1993-06-01' ------- '1993-06-13' ------- '1993-06-25' ------- '1993-07-08' ------- '1993-07-21' ------- '1993-08-03' ------- '1993-08-16' ------- '1993-08-29' ------- '1993-09-10' ------- '1993-09-19' ------- '1993-10-02' ------- '1993-10-13' ------- '1993-10-25' ------- '1993-11-06' ------- '1993-11-18' ------- '1993-11-29' ------- '1993-12-12' ------- '1993-12-24' ------- '1994-01-06' ------- '1994-01-20' ------- '1994-02-01' ------- '1994-02-14' ------- '1994-02-25' ------- '1994-03-11' ------- '1994-03-24' ------- '1994-04-07' ------- '1994-04-19' ------- '1994-05-03' ------- '1994-05-14' ------- '1994-05-24' ------- '1994-06-04' ------- '1994-06-14' ------- '1994-06-26' ------- '1994-07-06' ------- '1994-07-17' ------- '1994-08-01' ------- '1994-08-11' ------- '1994-08-25' ------- '1994-09-05' ------- '1994-09-16' ------- '1994-09-26' ------- '1994-10-07' ------- '1994-10-17' ------- '1994-10-27' ------- '1994-11-09' ------- '1994-11-22' ------- '1994-12-04' ------- '1994-12-16' ------- '1995-01-01' ------- '1995-01-14' ------- '1995-01-26' ------- '1995-02-06' ------- '1995-02-19' ------- '1995-03-03' ------- '1995-03-17' ------- '1995-04-01' ------- '1995-04-13' ------- '1995-04-26' ------- '1995-05-12' ------- '1995-05-25' ------- '1995-06-06' ------- '1995-06-19' ------- '1995-07-02' ------- '1995-07-12' ------- '1995-07-27' ------- '1995-08-08' ------- '1995-08-20' ------- '1995-08-31' ------- '1995-09-11' ------- '1995-09-23' ------- '1995-10-07' ------- '1995-10-18' ------- '1995-11-01' ------- '1995-11-13' ------- '1995-11-26' ------- '1995-12-09' ------- '1995-12-22' ------- '1996-01-02' ------- '1996-01-14' ------- '1996-01-25' ------- '1996-02-07' ------- '1996-02-18' ------- '1996-02-28' ------- '1996-03-12' ------- '1996-03-22' ------- '1996-04-01' ------- '1996-04-13' ------- '1996-04-23' ------- '1996-05-04' ------- '1996-05-18' ------- '1996-05-30' ------- '1996-06-12' ------- '1996-06-24' ------- '1996-07-05' ------- '1996-07-19' ------- '1996-07-31' ------- '1996-08-10' ------- '1996-08-24' ------- '1996-09-07' ------- '1996-09-20' ------- '1996-10-02' ------- '1996-10-14' ------- '1996-10-24' ------- '1996-11-05' ------- '1996-11-20' ------- '1996-12-01' ------- '1996-12-13' ------- '1996-12-25' ------- '1997-01-07' ------- '1997-01-19' ------- '1997-02-02' ------- '1997-02-13' ------- '1997-02-24' ------- '1997-03-08' ------- '1997-03-21' ------- '1997-04-01' ------- '1997-04-14' ------- '1997-04-26' ------- '1997-05-09' ------- '1997-05-18' ------- '1997-05-31' ------- '1997-06-13' ------- '1997-06-27' ------- '1997-07-09' ------- '1997-07-22' ------- '1997-07-31' ------- '1997-08-11' ------- '1997-08-25' ------- '1997-09-05' ------- '1997-09-17' ------- '1997-09-29' ------- '1997-10-10' ------- '1997-10-26' ------- '1997-11-07' ------- '1997-11-18' ------- '1997-12-03' ------- '1997-12-15' ------- '1997-12-27' ------- '1998-01-11' ------- '1998-01-24' ------- '1998-02-02' ------- '1998-02-14' ------- '1998-03-01' ------- '1998-03-10' ------- '1998-03-20' ------- '1998-04-02' ------- '1998-04-14' ------- '1998-04-26' ------- '1998-05-09' ------- '1998-05-18' ------- '1998-05-27' ------- '1998-06-06' ------- '1998-06-18' ------- '1998-06-29' ------- '1998-07-10' ------- '1998-07-22' ------- '1998-08-01' ------- '1998-08-10' ------- '1998-08-21' ------- '1998-09-02'
│ │ ├── scan lineitem
│ │ │ ├── save-table-name: q1_scan_5
│ │ │ ├── columns: l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_tax:8(float!null) l_returnflag:9(char!null) l_linestatus:10(char!null) l_shipdate:11(date!null)
- │ │ │ └── stats: [rows=6002293, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=971211, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(8)=9, null(8)=0, avgsize(8)=4, distinct(9)=3, null(9)=0, avgsize(9)=4, distinct(10)=2, null(10)=0, avgsize(10)=4, distinct(11)=2526, null(11)=0, avgsize(11)=4, distinct(6,7)=6.00229e+06, null(6,7)=0, avgsize(6,7)=8, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=8, distinct(6-8)=6.00229e+06, null(6-8)=0, avgsize(6-8)=12]
- │ │ │ histogram(5)= 0 1.1524e+05 5.7772e+06 1.0984e+05
- │ │ │ <----- 1.0 ----------------- 50.0 --
- │ │ │ histogram(6)= 0 600 6.0011e+06 600
- │ │ │ <--- 926.010009765625 ------------ 102066.5078125
- │ │ │ histogram(7)= 0 5.318e+05 4.9159e+06 5.5461e+05
- │ │ │ <----- 0.0 -------------- 0.10000000149011612
- │ │ │ histogram(8)= 0 6.7826e+05 4.6674e+06 6.5665e+05
- │ │ │ <----- 0.0 --------------- 0.07999999821186066
- │ │ │ histogram(9)= 0 1.5264e+06 3.039e+06 1.4369e+06
- │ │ │ <----- 'A' ---------------- 'R' ---
- │ │ │ histogram(10)= 0 3.0029e+06 0 2.9993e+06
- │ │ │ <----- 'F' -------- 'O' ---
- │ │ │ histogram(11)= 0 0 7 600 29411 1801 28811 1801 27010 3001 27610 6002 27010 3001 27610 5402 29411 2401 27010 3001 29411 1200 28811 1801 29411 1801 28811 3001 29411 2401 28811 2401 29411 4802 28811 2401 27610 3601 28211 2401 28811 3601 29411 3001 28811 1200 28811 2401 28811 2401 28211 1200 28811 2401 27010 3601 28811 600 27610 1801 28211 2401 28811 3001 27610 3601 27010 2401 28811 1200 27610 4202 25810 3601 27610 2401 26410 3601 28811 1200 28811 1801 25810 6002 28811 5402 28811 6002 28811 3601 28211 1801 28811 1801 27610 1801 25210 4202 28811 1801 27610 2401 28211 1801 27010 3001 27610 1801 25210 4202 26410 3001 27010 3001 28811 3001 28211 4802 28811 1200 28811 3001 28211 1801 27610 3001 27010 3001 28211 3001 28211 1200 27610 3601 28811 2401 27610 3601 28211 1801 28811 1200 27010 4202 27010 3601 27010 3601 26410 3601 27610 2401 28211 4202 27010 3601 25810 3601 28811 3601 28811 2401 27010 3001 28211 2401 28211 2401 28211 2401 27610 3001 27610 2401 28811 3001 28811 1801 28211 3601 27010 2401 28811 2401 28211 1200 27010 3001 27010 3001 28211 2401 28211 2401 27010 4802 28211 1200 27610 2401 27010 2401 27610 1801 28811 2401 27010 3601 28211 6002 27610 2401 27010 2401 28811 5402 28811 3601 26410 2401 27010 4202 26410 4802 25810 3601 26410 2401 28211 1200 26410 3601 26410 3001 24609 4802 27010 4802 26410 6603 25810 4202 28211 3001 24609 4202 28211 4802 26410 2401 27010 3001 28211 3001 27610 3601 28211 2401 28211 3001 27610 1200 26410 3001 26410 3001 27010 1801 27010 4202 26410 2401 27010 1801 25810 3001 27610 1200 26410 3001 27610 3601 27610 3601 28211 2401 26410 3601 28211 1801 27610 1801 26410 4202 27610 1200 25810 5402 25210 3601 27010 2401 27010 3001 27010 1200 27610 3001 25210 3001 26410 3601 27010 3601 26410 2401 27610 3001 27610 3601 27610 1200 26410 1801 26410 3001 25810 4202 24609 4802 27610 1801 25810 3001 27010 3001 27610 1200 25210 4202 27010 1200 26410 2401 25210 3001 24609 4802 27010 4802 27610 2401 26410 2401 26410 2401 26410 3601 26410 3001 25810 5402 25810 3601 27010 1200 25210 5402 25210 1801 22208 4802 25210 3001 25210 1801 24009 3001 25810 3001 25810 1200 26410 1200 24009 4802 25810 3601 24609 3601 22208 4202 25210 1200 26410 2401 24009 2401 25810 1200 24609 1200 7 0
- │ │ │ <--- '-infinity' --- '1992-01-07' ------- '1992-02-22' ------- '1992-03-12' ------- '1992-04-02' ------- '1992-04-17' ------- '1992-04-30' ------- '1992-05-13' ------- '1992-05-25' ------- '1992-06-07' ------- '1992-06-20' ------- '1992-07-06' ------- '1992-07-18' ------- '1992-07-30' ------- '1992-08-12' ------- '1992-08-24' ------- '1992-09-10' ------- '1992-09-23' ------- '1992-10-04' ------- '1992-10-16' ------- '1992-10-29' ------- '1992-11-14' ------- '1992-11-28' ------- '1992-12-12' ------- '1992-12-27' ------- '1993-01-07' ------- '1993-01-20' ------- '1993-02-01' ------- '1993-02-12' ------- '1993-02-25' ------- '1993-03-11' ------- '1993-03-22' ------- '1993-04-04' ------- '1993-04-15' ------- '1993-04-28' ------- '1993-05-13' ------- '1993-05-26' ------- '1993-06-07' ------- '1993-06-18' ------- '1993-06-28' ------- '1993-07-14' ------- '1993-07-26' ------- '1993-08-08' ------- '1993-08-20' ------- '1993-09-03' ------- '1993-09-14' ------- '1993-09-26' ------- '1993-10-09' ------- '1993-10-20' ------- '1993-11-02' ------- '1993-11-15' ------- '1993-11-29' ------- '1993-12-10' ------- '1993-12-22' ------- '1994-01-01' ------- '1994-01-11' ------- '1994-01-22' ------- '1994-02-05' ------- '1994-02-18' ------- '1994-03-01' ------- '1994-03-13' ------- '1994-03-26' ------- '1994-04-06' ------- '1994-04-17' ------- '1994-04-27' ------- '1994-05-10' ------- '1994-05-21' ------- '1994-06-03' ------- '1994-06-17' ------- '1994-06-27' ------- '1994-07-13' ------- '1994-07-27' ------- '1994-08-06' ------- '1994-08-19' ------- '1994-08-30' ------- '1994-09-11' ------- '1994-09-21' ------- '1994-10-03' ------- '1994-10-13' ------- '1994-10-26' ------- '1994-11-08' ------- '1994-11-19' ------- '1994-12-01' ------- '1994-12-13' ------- '1994-12-23' ------- '1995-01-04' ------- '1995-01-15' ------- '1995-01-28' ------- '1995-02-10' ------- '1995-02-21' ------- '1995-03-09' ------- '1995-03-21' ------- '1995-04-02' ------- '1995-04-11' ------- '1995-04-22' ------- '1995-05-03' ------- '1995-05-15' ------- '1995-05-28' ------- '1995-06-11' ------- '1995-06-24' ------- '1995-07-04' ------- '1995-07-15' ------- '1995-07-25' ------- '1995-08-10' ------- '1995-08-20' ------- '1995-09-03' ------- '1995-09-13' ------- '1995-09-24' ------- '1995-10-07' ------- '1995-10-18' ------- '1995-10-31' ------- '1995-11-13' ------- '1995-11-24' ------- '1995-12-04' ------- '1995-12-16' ------- '1995-12-26' ------- '1996-01-07' ------- '1996-01-21' ------- '1996-02-01' ------- '1996-02-14' ------- '1996-02-23' ------- '1996-03-07' ------- '1996-03-21' ------- '1996-04-02' ------- '1996-04-14' ------- '1996-04-28' ------- '1996-05-12' ------- '1996-05-26' ------- '1996-06-06' ------- '1996-06-19' ------- '1996-07-02' ------- '1996-07-10' ------- '1996-07-23' ------- '1996-08-03' ------- '1996-08-16' ------- '1996-08-29' ------- '1996-09-08' ------- '1996-09-18' ------- '1996-10-01' ------- '1996-10-13' ------- '1996-10-25' ------- '1996-11-07' ------- '1996-11-20' ------- '1996-12-02' ------- '1996-12-15' ------- '1996-12-27' ------- '1997-01-08' ------- '1997-01-19' ------- '1997-01-30' ------- '1997-02-09' ------- '1997-02-21' ------- '1997-03-06' ------- '1997-03-18' ------- '1997-03-29' ------- '1997-04-10' ------- '1997-04-21' ------- '1997-05-03' ------- '1997-05-14' ------- '1997-05-29' ------- '1997-06-10' ------- '1997-06-24' ------- '1997-07-06' ------- '1997-07-20' ------- '1997-08-01' ------- '1997-08-10' ------- '1997-08-23' ------- '1997-09-02' ------- '1997-09-15' ------- '1997-09-24' ------- '1997-10-08' ------- '1997-10-25' ------- '1997-11-07' ------- '1997-11-17' ------- '1997-11-29' ------- '1997-12-12' ------- '1997-12-24' ------- '1998-01-02' ------- '1998-01-16' ------- '1998-01-29' ------- '1998-02-11' ------- '1998-02-25' ------- '1998-03-11' ------- '1998-03-20' ------- '1998-03-31' ------- '1998-04-12' ------- '1998-04-24' ------- '1998-05-04' ------- '1998-05-14' ------- '1998-05-23' ------- '1998-06-03' ------- '1998-06-13' ------- '1998-06-24' ------- '1998-07-05' ------- '1998-07-15' ------- '1998-07-30' ------- '1998-08-08' ------- '1998-08-20' ------- '1998-09-03' ------- '1998-09-20' ------- '1998-10-12' ------- '1998-11-21' --- 'infinity'
+ │ │ │ └── stats: [rows=6001215, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=925955, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(8)=9, null(8)=0, avgsize(8)=9, distinct(9)=3, null(9)=0, avgsize(9)=3, distinct(10)=2, null(10)=0, avgsize(10)=3, distinct(11)=2526, null(11)=0, avgsize(11)=4, distinct(6,7)=6.00122e+06, null(6,7)=0, avgsize(6,7)=18, distinct(9,10)=6, null(9,10)=0, avgsize(9,10)=6, distinct(6-8)=6.00122e+06, null(6-8)=0, avgsize(6-8)=27]
+ │ │ │ histogram(5)= 0 1.1342e+05 5.766e+06 1.2182e+05
+ │ │ │ <----- 1.0 ---------------- 50.0 --
+ │ │ │ histogram(6)= 0 600 6e+06 600
+ │ │ │ <--- 929.02 ------- 104249.0
+ │ │ │ histogram(7)= 0 5.4971e+05 4.9108e+06 5.4071e+05
+ │ │ │ <----- 0.0 ----------------- 0.1 ---
+ │ │ │ histogram(8)= 0 6.5833e+05 4.6815e+06 6.6133e+05
+ │ │ │ <----- 0.0 ----------------- 0.08 --
+ │ │ │ histogram(9)= 0 1.4955e+06 3.0372e+06 1.4685e+06
+ │ │ │ <----- 'A' ----------------- 'R' ---
+ │ │ │ histogram(10)= 0 3.009e+06 0 2.9922e+06
+ │ │ │ <----- 'F' ------- 'O' ---
+ │ │ │ histogram(11)= 0 0 4 600 29406 600 28806 2400 28206 2400 28206 1800 28806 1200 28206 2400 26405 3601 27606 3601 28206 2400 28806 3001 28206 2400 27606 2400 29406 1800 29406 3601 28806 1800 27606 4201 27005 3001 25205 4801 25805 4801 27005 4201 28206 1800 26405 3601 26405 3601 23405 7201 29406 2400 26405 3601 28206 2400 27005 3601 28206 3001 29406 1800 25805 4801 28806 3001 28806 1800 29406 1800 27005 4201 29406 4201 27606 2400 28206 3601 28806 1800 26405 3001 27606 3601 24605 4801 27005 5401 28206 2400 28806 1200 28206 4201 27005 2400 27606 3601 27606 2400 28206 2400 28206 1200 28806 3001 28206 1200 25805 6001 28806 1800 27606 4201 27005 5401 28806 3001 27606 2400 24005 5401 24605 5401 28206 3601 26405 3001 27005 2400 28806 3601 28206 1800 28806 2400 28806 1800 28206 1800 27606 3601 28206 3001 26405 3001 28206 1200 28206 2400 28806 1200 27606 3001 24605 5401 28806 1800 25805 3601 27005 2400 28806 1800 28806 600 28806 600 27606 3601 28206 3001 27005 3601 27606 2400 26405 5401 28806 1800 28206 4201 26405 6601 27606 2400 27005 3601 28806 3601 28806 3001 28206 3001 27005 3001 28206 1800 28206 4801 25205 5401 27005 4201 24605 5401 28806 3601 24605 6001 26405 3001 28806 2400 28806 1800 28206 1800 28806 4201 28806 1800 28806 3601 28206 4201 28206 3001 28206 1200 28206 600 27606 3601 25805 3001 25805 3001 27606 2400 26405 3001 25805 4801 27005 1800 28206 3601 28206 1200 25805 3601 27005 4201 28206 3601 27606 3001 26405 3601 24605 4201 24605 4201 27606 2400 25805 3001 28206 2400 28206 4201 27005 3001 25205 3601 26405 2400 27005 3601 25805 3601 27606 1200 25805 3001 27005 3001 26405 2400 28206 3601 28206 2400 27005 4201 27606 1800 27606 3001 24605 4801 28206 3001 28206 3001 27606 2400 26405 3601 27005 2400 27005 1800 26405 3001 25205 4201 25205 3601 27606 3601 27005 1800 25205 3001 26405 3601 25205 3001 26405 1800 25805 3001 25205 3601 23405 5401 27606 2400 27005 3001 25805 2400 27005 2400 25205 4201 27606 5401 24005 4201 26405 3001 24005 4201 27005 1800 26405 1200 27005 3601 26405 3601 26405 1800 27005 2400 27005 3001 24605 3001 24005 3601 27005 2400 26405 2400 25205 2400 25805 1800 25805 3001 24605 2400 24605 2400 25805 3001 25805 1800 24605 3001 22805 3601 25205 1800 25205 600 4 0
+ │ │ │ <--- '-infinity' --- '1992-01-04' ------- '1992-02-26' ------- '1992-03-21' ------- '1992-04-04' ------- '1992-04-17' ------- '1992-05-04' ------- '1992-05-17' ------- '1992-05-29' ------- '1992-06-09' ------- '1992-06-22' ------- '1992-07-06' ------- '1992-07-19' ------- '1992-08-01' ------- '1992-08-13' ------- '1992-08-26' ------- '1992-09-07' ------- '1992-09-19' ------- '1992-10-01' ------- '1992-10-14' ------- '1992-10-26' ------- '1992-11-06' ------- '1992-11-21' ------- '1992-12-04' ------- '1992-12-15' ------- '1992-12-24' ------- '1993-01-06' ------- '1993-01-18' ------- '1993-01-31' ------- '1993-02-13' ------- '1993-02-25' ------- '1993-03-09' ------- '1993-03-19' ------- '1993-03-31' ------- '1993-04-11' ------- '1993-04-27' ------- '1993-05-06' ------- '1993-05-18' ------- '1993-06-01' ------- '1993-06-13' ------- '1993-06-25' ------- '1993-07-08' ------- '1993-07-21' ------- '1993-08-03' ------- '1993-08-16' ------- '1993-08-29' ------- '1993-09-10' ------- '1993-09-19' ------- '1993-10-02' ------- '1993-10-13' ------- '1993-10-25' ------- '1993-11-06' ------- '1993-11-18' ------- '1993-11-29' ------- '1993-12-12' ------- '1993-12-24' ------- '1994-01-06' ------- '1994-01-20' ------- '1994-02-01' ------- '1994-02-14' ------- '1994-02-25' ------- '1994-03-11' ------- '1994-03-24' ------- '1994-04-07' ------- '1994-04-19' ------- '1994-05-03' ------- '1994-05-14' ------- '1994-05-24' ------- '1994-06-04' ------- '1994-06-14' ------- '1994-06-26' ------- '1994-07-06' ------- '1994-07-17' ------- '1994-08-01' ------- '1994-08-11' ------- '1994-08-25' ------- '1994-09-05' ------- '1994-09-16' ------- '1994-09-26' ------- '1994-10-07' ------- '1994-10-17' ------- '1994-10-27' ------- '1994-11-09' ------- '1994-11-22' ------- '1994-12-04' ------- '1994-12-16' ------- '1995-01-01' ------- '1995-01-14' ------- '1995-01-26' ------- '1995-02-06' ------- '1995-02-19' ------- '1995-03-03' ------- '1995-03-17' ------- '1995-04-01' ------- '1995-04-13' ------- '1995-04-26' ------- '1995-05-12' ------- '1995-05-25' ------- '1995-06-06' ------- '1995-06-19' ------- '1995-07-02' ------- '1995-07-12' ------- '1995-07-27' ------- '1995-08-08' ------- '1995-08-20' ------- '1995-08-31' ------- '1995-09-11' ------- '1995-09-23' ------- '1995-10-07' ------- '1995-10-18' ------- '1995-11-01' ------- '1995-11-13' ------- '1995-11-26' ------- '1995-12-09' ------- '1995-12-22' ------- '1996-01-02' ------- '1996-01-14' ------- '1996-01-25' ------- '1996-02-07' ------- '1996-02-18' ------- '1996-02-28' ------- '1996-03-12' ------- '1996-03-22' ------- '1996-04-01' ------- '1996-04-13' ------- '1996-04-23' ------- '1996-05-04' ------- '1996-05-18' ------- '1996-05-30' ------- '1996-06-12' ------- '1996-06-24' ------- '1996-07-05' ------- '1996-07-19' ------- '1996-07-31' ------- '1996-08-10' ------- '1996-08-24' ------- '1996-09-07' ------- '1996-09-20' ------- '1996-10-02' ------- '1996-10-14' ------- '1996-10-24' ------- '1996-11-05' ------- '1996-11-20' ------- '1996-12-01' ------- '1996-12-13' ------- '1996-12-25' ------- '1997-01-07' ------- '1997-01-19' ------- '1997-02-02' ------- '1997-02-13' ------- '1997-02-24' ------- '1997-03-08' ------- '1997-03-21' ------- '1997-04-01' ------- '1997-04-14' ------- '1997-04-26' ------- '1997-05-09' ------- '1997-05-18' ------- '1997-05-31' ------- '1997-06-13' ------- '1997-06-27' ------- '1997-07-09' ------- '1997-07-22' ------- '1997-07-31' ------- '1997-08-11' ------- '1997-08-25' ------- '1997-09-05' ------- '1997-09-17' ------- '1997-09-29' ------- '1997-10-10' ------- '1997-10-26' ------- '1997-11-07' ------- '1997-11-18' ------- '1997-12-03' ------- '1997-12-15' ------- '1997-12-27' ------- '1998-01-11' ------- '1998-01-24' ------- '1998-02-02' ------- '1998-02-14' ------- '1998-03-01' ------- '1998-03-10' ------- '1998-03-20' ------- '1998-04-02' ------- '1998-04-14' ------- '1998-04-26' ------- '1998-05-09' ------- '1998-05-18' ------- '1998-05-27' ------- '1998-06-06' ------- '1998-06-18' ------- '1998-06-29' ------- '1998-07-10' ------- '1998-07-22' ------- '1998-08-01' ------- '1998-08-10' ------- '1998-08-21' ------- '1998-09-05' ------- '1998-09-21' ------- '1998-10-14' ------- '1998-11-25' --- 'infinity'
│ │ └── filters
│ │ └── l_shipdate:11 <= '1998-09-02' [type=bool, outer=(11), constraints=(/11: (/NULL - /'1998-09-02']; tight)]
│ └── projections
@@ -170,13 +170,13 @@ column_names row_count distinct_count null_count
{l_returnflag} 5916591 3 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column21} 5920656.00 1.00 5920656.00 1.43 0.00 1.00
-{column23} 5920656.00 1.00 5920656.00 1.05 0.00 1.00
-{l_discount} 5920656.00 1.00 11.00 1.00 0.00 1.00
-{l_extendedprice} 5920656.00 1.00 971211.00 1.05 0.00 1.00
-{l_linestatus} 5920656.00 1.00 2.00 1.00 0.00 1.00
-{l_quantity} 5920656.00 1.00 50.00 1.00 0.00 1.00
-{l_returnflag} 5920656.00 1.00 3.00 1.00 0.00 1.00
+{column21} 5915479.00 1.00 5915479.00 1.43 0.00 1.00
+{column23} 5915479.00 1.00 5915479.00 1.04 0.00 1.00
+{l_discount} 5915479.00 1.00 11.00 1.00 0.00 1.00
+{l_extendedprice} 5915479.00 1.00 925955.00 1.00 0.00 1.00
+{l_linestatus} 5915479.00 1.00 2.00 1.00 0.00 1.00
+{l_quantity} 5915479.00 1.00 50.00 1.00 0.00 1.00
+{l_returnflag} 5915479.00 1.00 3.00 1.00 0.00 1.00
----Stats for q1_select_4----
column_names row_count distinct_count null_count
@@ -189,13 +189,13 @@ column_names row_count distinct_count null_count
{l_tax} 5916591 9 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 5920656.00 1.00 11.00 1.00 0.00 1.00
-{l_extendedprice} 5920656.00 1.00 971211.00 1.05 0.00 1.00
-{l_linestatus} 5920656.00 1.00 2.00 1.00 0.00 1.00
-{l_quantity} 5920656.00 1.00 50.00 1.00 0.00 1.00
-{l_returnflag} 5920656.00 1.00 3.00 1.00 0.00 1.00
-{l_shipdate} 5920656.00 1.00 2438.00 1.00 0.00 1.00
-{l_tax} 5920656.00 1.00 9.00 1.00 0.00 1.00
+{l_discount} 5915479.00 1.00 11.00 1.00 0.00 1.00
+{l_extendedprice} 5915479.00 1.00 925955.00 1.00 0.00 1.00
+{l_linestatus} 5915479.00 1.00 2.00 1.00 0.00 1.00
+{l_quantity} 5915479.00 1.00 50.00 1.00 0.00 1.00
+{l_returnflag} 5915479.00 1.00 3.00 1.00 0.00 1.00
+{l_shipdate} 5915479.00 1.00 2438.00 1.00 0.00 1.00
+{l_tax} 5915479.00 1.00 9.00 1.00 0.00 1.00
----Stats for q1_scan_5----
column_names row_count distinct_count null_count
@@ -208,12 +208,12 @@ column_names row_count distinct_count null_count
{l_tax} 6001215 9 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 6002293.00 1.00 11.00 1.00 0.00 1.00
-{l_extendedprice} 6002293.00 1.00 971211.00 1.05 0.00 1.00
-{l_linestatus} 6002293.00 1.00 2.00 1.00 0.00 1.00
-{l_quantity} 6002293.00 1.00 50.00 1.00 0.00 1.00
-{l_returnflag} 6002293.00 1.00 3.00 1.00 0.00 1.00
-{l_shipdate} 6002293.00 1.00 2526.00 1.00 0.00 1.00
-{l_tax} 6002293.00 1.00 9.00 1.00 0.00 1.00
+{l_discount} 6001215.00 1.00 11.00 1.00 0.00 1.00
+{l_extendedprice} 6001215.00 1.00 925955.00 1.00 0.00 1.00
+{l_linestatus} 6001215.00 1.00 2.00 1.00 0.00 1.00
+{l_quantity} 6001215.00 1.00 50.00 1.00 0.00 1.00
+{l_returnflag} 6001215.00 1.00 3.00 1.00 0.00 1.00
+{l_shipdate} 6001215.00 1.00 2526.00 1.00 0.00 1.00
+{l_tax} 6001215.00 1.00 9.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q02 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q02
index d68420f202ff..9a7f21af1218 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q02
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q02
@@ -73,7 +73,7 @@ project
├── save-table-name: q2_project_1
├── columns: s_acctbal:17(float!null) s_name:13(char!null) n_name:29(char!null) p_partkey:1(int!null) p_mfgr:3(char!null) s_address:14(varchar!null) s_phone:16(char!null) s_comment:18(varchar!null)
├── cardinality: [0 - 100]
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=8, distinct(3)=1, null(3)=0, avgsize(3)=8, distinct(13)=1, null(13)=0, avgsize(13)=8, distinct(14)=1, null(14)=0, avgsize(14)=8, distinct(16)=1, null(16)=0, avgsize(16)=8, distinct(17)=1, null(17)=0, avgsize(17)=8, distinct(18)=1, null(18)=0, avgsize(18)=8, distinct(29)=1, null(29)=0, avgsize(29)=8]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=7, distinct(3)=1, null(3)=0, avgsize(3)=7, distinct(13)=1, null(13)=0, avgsize(13)=7, distinct(14)=1, null(14)=0, avgsize(14)=7, distinct(16)=1, null(16)=0, avgsize(16)=7, distinct(17)=1, null(17)=0, avgsize(17)=7, distinct(18)=1, null(18)=0, avgsize(18)=7, distinct(29)=1, null(29)=0, avgsize(29)=7]
├── fd: (1)-->(3)
├── ordering: -17,+29,+13,+1
└── top-k
@@ -82,70 +82,70 @@ project
├── internal-ordering: -17,+29,+13,+(1|21)
├── k: 100
├── cardinality: [0 - 100]
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=8, distinct(3)=1, null(3)=0, avgsize(3)=8, distinct(13)=1, null(13)=0, avgsize(13)=8, distinct(14)=1, null(14)=0, avgsize(14)=8, distinct(16)=1, null(16)=0, avgsize(16)=8, distinct(17)=1, null(17)=0, avgsize(17)=8, distinct(18)=1, null(18)=0, avgsize(18)=8, distinct(21)=0.999912, null(21)=0, avgsize(21)=4, distinct(22)=0.999982, null(22)=0, avgsize(22)=4, distinct(24)=1, null(24)=0, avgsize(24)=8, distinct(29)=1, null(29)=0, avgsize(29)=8, distinct(66)=1, null(66)=0, avgsize(66)=8]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=7, distinct(3)=1, null(3)=0, avgsize(3)=7, distinct(13)=1, null(13)=0, avgsize(13)=7, distinct(14)=1, null(14)=0, avgsize(14)=7, distinct(16)=1, null(16)=0, avgsize(16)=7, distinct(17)=1, null(17)=0, avgsize(17)=7, distinct(18)=1, null(18)=0, avgsize(18)=7, distinct(21)=0.999912, null(21)=0, avgsize(21)=4, distinct(22)=0.999982, null(22)=0, avgsize(22)=3, distinct(24)=1, null(24)=0, avgsize(24)=7, distinct(29)=1, null(29)=0, avgsize(29)=7, distinct(66)=1, null(66)=0, avgsize(66)=7]
├── key: (21,22)
├── fd: (1)-->(3), (21,22)-->(1,3,13,14,16-18,24,29,66), (1)==(21), (21)==(1), (22)-->(13,14,16-18,29), (24)==(66), (66)==(24)
├── ordering: -17,+29,+13,+(1|21) [actual: -17,+29,+13,+1]
└── select
├── save-table-name: q2_select_3
├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) s_name:13(char!null) s_address:14(varchar!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null) ps_partkey:21(int!null) ps_suppkey:22(int!null) ps_supplycost:24(float!null) n_name:29(char!null) min:66(float!null)
- ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=8, distinct(3)=1, null(3)=0, avgsize(3)=8, distinct(13)=1, null(13)=0, avgsize(13)=8, distinct(14)=1, null(14)=0, avgsize(14)=8, distinct(16)=1, null(16)=0, avgsize(16)=8, distinct(17)=1, null(17)=0, avgsize(17)=8, distinct(18)=1, null(18)=0, avgsize(18)=8, distinct(21)=0.999912, null(21)=0, avgsize(21)=4, distinct(22)=0.999982, null(22)=0, avgsize(22)=4, distinct(24)=1, null(24)=0, avgsize(24)=8, distinct(29)=1, null(29)=0, avgsize(29)=8, distinct(66)=1, null(66)=0, avgsize(66)=8]
+ ├── stats: [rows=1, distinct(1)=1, null(1)=0, avgsize(1)=7, distinct(3)=1, null(3)=0, avgsize(3)=7, distinct(13)=1, null(13)=0, avgsize(13)=7, distinct(14)=1, null(14)=0, avgsize(14)=7, distinct(16)=1, null(16)=0, avgsize(16)=7, distinct(17)=1, null(17)=0, avgsize(17)=7, distinct(18)=1, null(18)=0, avgsize(18)=7, distinct(21)=0.999912, null(21)=0, avgsize(21)=4, distinct(22)=0.999982, null(22)=0, avgsize(22)=3, distinct(24)=1, null(24)=0, avgsize(24)=7, distinct(29)=1, null(29)=0, avgsize(29)=7, distinct(66)=1, null(66)=0, avgsize(66)=7]
├── key: (21,22)
├── fd: (1)-->(3), (21,22)-->(1,3,13,14,16-18,24,29,66), (1)==(21), (21)==(1), (22)-->(13,14,16-18,29), (24)==(66), (66)==(24)
├── group-by (hash)
│ ├── save-table-name: q2_group_by_4
│ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) s_name:13(char!null) s_address:14(varchar!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null) ps_partkey:21(int!null) ps_suppkey:22(int!null) ps_supplycost:24(float!null) n_name:29(char!null) min:66(float!null)
│ ├── grouping columns: ps_partkey:21(int!null) ps_suppkey:22(int!null)
- │ ├── stats: [rows=1482.014, distinct(1)=1482.01, null(1)=0, avgsize(1)=8, distinct(3)=1482.01, null(3)=0, avgsize(3)=8, distinct(13)=1482.01, null(13)=0, avgsize(13)=8, distinct(14)=1482.01, null(14)=0, avgsize(14)=8, distinct(16)=1482.01, null(16)=0, avgsize(16)=8, distinct(17)=1482.01, null(17)=0, avgsize(17)=8, distinct(18)=1482.01, null(18)=0, avgsize(18)=8, distinct(21)=1176.27, null(21)=0, avgsize(21)=4, distinct(22)=1407.43, null(22)=0, avgsize(22)=4, distinct(24)=1482.01, null(24)=0, avgsize(24)=8, distinct(29)=1482.01, null(29)=0, avgsize(29)=8, distinct(66)=1482.01, null(66)=0, avgsize(66)=8, distinct(21,22)=1482.01, null(21,22)=0, avgsize(21,22)=8]
+ │ ├── stats: [rows=1475.884, distinct(1)=1475.88, null(1)=0, avgsize(1)=7, distinct(3)=1475.88, null(3)=0, avgsize(3)=7, distinct(13)=1475.88, null(13)=0, avgsize(13)=7, distinct(14)=1475.88, null(14)=0, avgsize(14)=7, distinct(16)=1475.88, null(16)=0, avgsize(16)=7, distinct(17)=1475.88, null(17)=0, avgsize(17)=7, distinct(18)=1475.88, null(18)=0, avgsize(18)=7, distinct(21)=1171.39, null(21)=0, avgsize(21)=4, distinct(22)=1401.91, null(22)=0, avgsize(22)=3, distinct(24)=1475.88, null(24)=0, avgsize(24)=7, distinct(29)=1475.88, null(29)=0, avgsize(29)=7, distinct(66)=1475.88, null(66)=0, avgsize(66)=7, distinct(21,22)=1475.88, null(21,22)=0, avgsize(21,22)=7]
│ ├── key: (21,22)
│ ├── fd: (1)-->(3), (21,22)-->(1,3,13,14,16-18,24,29,66), (1)==(21), (21)==(1), (22)-->(13,14,16-18,29)
│ ├── inner-join (hash)
│ │ ├── save-table-name: q2_inner_join_5
│ │ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) p_type:5(varchar!null) p_size:6(int!null) s_suppkey:12(int!null) s_name:13(char!null) s_address:14(varchar!null) s_nationkey:15(int!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null) ps_partkey:21(int!null) ps_suppkey:22(int!null) ps_supplycost:24(float!null) n_nationkey:28(int!null) n_name:29(char!null) n_regionkey:30(int!null) r_regionkey:34(int!null) r_name:35(char!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null) s_suppkey:46(int!null) s_nationkey:49(int!null) n_nationkey:55(int!null) n_regionkey:57(int!null) r_regionkey:61(int!null) r_name:62(char!null)
│ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ ├── stats: [rows=2827.737, distinct(1)=1337.9, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=4, distinct(5)=150, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(12)=1407.43, null(12)=0, avgsize(12)=4, distinct(13)=1407.99, null(13)=0, avgsize(13)=4, distinct(14)=1408.06, null(14)=0, avgsize(14)=4, distinct(15)=5, null(15)=0, avgsize(15)=4, distinct(16)=1406.78, null(16)=0, avgsize(16)=4, distinct(17)=1408.06, null(17)=0, avgsize(17)=4, distinct(18)=1407.29, null(18)=0, avgsize(18)=4, distinct(21)=1176.27, null(21)=0, avgsize(21)=4, distinct(22)=1407.43, null(22)=0, avgsize(22)=4, distinct(24)=824.603, null(24)=0, avgsize(24)=4, distinct(28)=5, null(28)=0, avgsize(28)=4, distinct(29)=5, null(29)=0, avgsize(29)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(34)=1, null(34)=0, avgsize(34)=4, distinct(35)=0.996222, null(35)=0, avgsize(35)=4, distinct(39)=1337.9, null(39)=0, avgsize(39)=4, distinct(40)=1446.46, null(40)=0, avgsize(40)=4, distinct(42)=940.854, null(42)=0, avgsize(42)=4, distinct(46)=1446.46, null(46)=0, avgsize(46)=4, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(55)=5, null(55)=0, avgsize(55)=4, distinct(57)=1, null(57)=0, avgsize(57)=4, distinct(61)=1, null(61)=0, avgsize(61)=4, distinct(62)=0.996222, null(62)=0, avgsize(62)=4, distinct(21,22)=1482.01, null(21,22)=0, avgsize(21,22)=8]
+ │ │ ├── stats: [rows=2815.995, distinct(1)=1332.34, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=16, distinct(5)=150, null(5)=0, avgsize(5)=23, distinct(6)=1, null(6)=0, avgsize(6)=2, distinct(12)=1401.91, null(12)=0, avgsize(12)=3, distinct(13)=1402.47, null(13)=0, avgsize(13)=20, distinct(14)=1402.54, null(14)=0, avgsize(14)=27, distinct(15)=5, null(15)=0, avgsize(15)=2, distinct(16)=1402.54, null(16)=0, avgsize(16)=17, distinct(17)=1402.29, null(17)=0, avgsize(17)=9, distinct(18)=1402.02, null(18)=0, avgsize(18)=65, distinct(21)=1171.39, null(21)=0, avgsize(21)=4, distinct(22)=1401.91, null(22)=0, avgsize(22)=3, distinct(24)=1471.7, null(24)=0, avgsize(24)=9, distinct(28)=5, null(28)=0, avgsize(28)=1, distinct(29)=5, null(29)=0, avgsize(29)=10, distinct(30)=1, null(30)=0, avgsize(30)=2, distinct(34)=1, null(34)=0, avgsize(34)=1, distinct(35)=0.996222, null(35)=0, avgsize(35)=9, distinct(39)=1332.34, null(39)=0, avgsize(39)=4, distinct(40)=1443.92, null(40)=0, avgsize(40)=3, distinct(42)=2767.17, null(42)=0, avgsize(42)=9, distinct(46)=1443.92, null(46)=0, avgsize(46)=3, distinct(49)=5, null(49)=0, avgsize(49)=2, distinct(55)=5, null(55)=0, avgsize(55)=1, distinct(57)=1, null(57)=0, avgsize(57)=2, distinct(61)=1, null(61)=0, avgsize(61)=1, distinct(62)=0.996222, null(62)=0, avgsize(62)=9, distinct(21,22)=1475.88, null(21,22)=0, avgsize(21,22)=7]
│ │ ├── key: (22,39,46)
│ │ ├── fd: ()-->(6,35,62), (1)-->(3,5), (12)-->(13-18), (21,22)-->(24), (12)==(22), (22)==(12), (28)-->(29,30), (30)==(34), (34)==(30), (15)==(28), (28)==(15), (1)==(21,39), (21)==(1,39), (39,40)-->(42), (46)-->(49), (55)-->(57), (57)==(61), (61)==(57), (49)==(55), (55)==(49), (40)==(46), (46)==(40), (39)==(1,21)
│ │ ├── inner-join (lookup partsupp)
│ │ │ ├── save-table-name: q2_lookup_join_6
│ │ │ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) p_type:5(varchar!null) p_size:6(int!null) s_suppkey:12(int!null) s_name:13(char!null) s_address:14(varchar!null) s_nationkey:15(int!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null) ps_partkey:21(int!null) ps_suppkey:22(int!null) ps_supplycost:24(float!null) n_nationkey:28(int!null) n_name:29(char!null) n_regionkey:30(int!null) r_regionkey:34(int!null) r_name:35(char!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null)
│ │ │ ├── key columns: [1] = [39]
- │ │ │ ├── stats: [rows=4467.679, distinct(1)=1337.9, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=4, distinct(5)=150, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(12)=3597.08, null(12)=0, avgsize(12)=4, distinct(13)=3602.34, null(13)=0, avgsize(13)=4, distinct(14)=3603.08, null(14)=0, avgsize(14)=4, distinct(15)=25, null(15)=0, avgsize(15)=4, distinct(16)=3591, null(16)=0, avgsize(16)=4, distinct(17)=3603.08, null(17)=0, avgsize(17)=4, distinct(18)=3595.8, null(18)=0, avgsize(18)=4, distinct(21)=1337.9, null(21)=0, avgsize(21)=4, distinct(22)=3597.08, null(22)=0, avgsize(22)=4, distinct(24)=988.526, null(24)=0, avgsize(24)=4, distinct(28)=25, null(28)=0, avgsize(28)=4, distinct(29)=25, null(29)=0, avgsize(29)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(34)=1, null(34)=0, avgsize(34)=4, distinct(35)=1, null(35)=0, avgsize(35)=4, distinct(39)=4416.62, null(39)=0, avgsize(39)=4, distinct(40)=3597.08, null(40)=0, avgsize(40)=4, distinct(42)=988.526, null(42)=0, avgsize(42)=4]
+ │ │ │ ├── stats: [rows=4449.128, distinct(1)=1332.34, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=16, distinct(5)=150, null(5)=0, avgsize(5)=23, distinct(6)=1, null(6)=0, avgsize(6)=2, distinct(12)=3585.25, null(12)=0, avgsize(12)=3, distinct(13)=3590.47, null(13)=0, avgsize(13)=20, distinct(14)=3591.21, null(14)=0, avgsize(14)=27, distinct(15)=25, null(15)=0, avgsize(15)=2, distinct(16)=3591.21, null(16)=0, avgsize(16)=17, distinct(17)=3588.76, null(17)=0, avgsize(17)=9, distinct(18)=3586.29, null(18)=0, avgsize(18)=65, distinct(21)=1332.34, null(21)=0, avgsize(21)=4, distinct(22)=3585.25, null(22)=0, avgsize(22)=3, distinct(24)=4351.91, null(24)=0, avgsize(24)=9, distinct(28)=25, null(28)=0, avgsize(28)=1, distinct(29)=25, null(29)=0, avgsize(29)=10, distinct(30)=1, null(30)=0, avgsize(30)=2, distinct(34)=1, null(34)=0, avgsize(34)=1, distinct(35)=1, null(35)=0, avgsize(35)=9, distinct(39)=4398.49, null(39)=0, avgsize(39)=4, distinct(40)=3585.25, null(40)=0, avgsize(40)=3, distinct(42)=4351.91, null(42)=0, avgsize(42)=9]
│ │ │ ├── key: (22,39,40)
│ │ │ ├── fd: ()-->(6,35), (1)-->(3,5), (28)-->(29,30), (12)-->(13-18), (21,22)-->(24), (39,40)-->(42), (21)==(1,39), (39)==(1,21), (12)==(22), (22)==(12), (15)==(28), (28)==(15), (30)==(34), (34)==(30), (1)==(21,39)
│ │ │ ├── inner-join (hash)
│ │ │ │ ├── save-table-name: q2_inner_join_7
│ │ │ │ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) p_type:5(varchar!null) p_size:6(int!null) s_suppkey:12(int!null) s_name:13(char!null) s_address:14(varchar!null) s_nationkey:15(int!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null) ps_partkey:21(int!null) ps_suppkey:22(int!null) ps_supplycost:24(float!null) n_nationkey:28(int!null) n_name:29(char!null) n_regionkey:30(int!null) r_regionkey:34(int!null) r_name:35(char!null)
│ │ │ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ │ │ ├── stats: [rows=1938.482, distinct(1)=1337.9, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=4, distinct(5)=150, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(12)=1760.85, null(12)=0, avgsize(12)=4, distinct(13)=1762.01, null(13)=0, avgsize(13)=4, distinct(14)=1762.18, null(14)=0, avgsize(14)=4, distinct(15)=5, null(15)=0, avgsize(15)=4, distinct(16)=1759.49, null(16)=0, avgsize(16)=4, distinct(17)=1762.18, null(17)=0, avgsize(17)=4, distinct(18)=1760.56, null(18)=0, avgsize(18)=4, distinct(21)=1337.9, null(21)=0, avgsize(21)=4, distinct(22)=1760.85, null(22)=0, avgsize(22)=4, distinct(24)=856.079, null(24)=0, avgsize(24)=4, distinct(28)=5, null(28)=0, avgsize(28)=4, distinct(29)=5, null(29)=0, avgsize(29)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(34)=1, null(34)=0, avgsize(34)=4, distinct(35)=0.996222, null(35)=0, avgsize(35)=4, distinct(21,22)=1925.19, null(21,22)=0, avgsize(21,22)=8]
+ │ │ │ │ ├── stats: [rows=1930.433, distinct(1)=1332.34, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=16, distinct(5)=150, null(5)=0, avgsize(5)=23, distinct(6)=1, null(6)=0, avgsize(6)=2, distinct(12)=1754.22, null(12)=0, avgsize(12)=3, distinct(13)=1755.38, null(13)=0, avgsize(13)=20, distinct(14)=1755.54, null(14)=0, avgsize(14)=27, distinct(15)=5, null(15)=0, avgsize(15)=2, distinct(16)=1755.54, null(16)=0, avgsize(16)=17, distinct(17)=1755, null(17)=0, avgsize(17)=9, distinct(18)=1754.46, null(18)=0, avgsize(18)=65, distinct(21)=1332.34, null(21)=0, avgsize(21)=4, distinct(22)=1754.22, null(22)=0, avgsize(22)=3, distinct(24)=1907.59, null(24)=0, avgsize(24)=9, distinct(28)=5, null(28)=0, avgsize(28)=1, distinct(29)=5, null(29)=0, avgsize(29)=10, distinct(30)=1, null(30)=0, avgsize(30)=2, distinct(34)=1, null(34)=0, avgsize(34)=1, distinct(35)=0.996222, null(35)=0, avgsize(35)=9, distinct(21,22)=1917.25, null(21,22)=0, avgsize(21,22)=7]
│ │ │ │ ├── key: (21,22)
│ │ │ │ ├── fd: ()-->(6,35), (1)-->(3,5), (12)-->(13-18), (21,22)-->(24), (12)==(22), (22)==(12), (28)-->(29,30), (30)==(34), (34)==(30), (15)==(28), (28)==(15), (1)==(21), (21)==(1)
│ │ │ │ ├── inner-join (lookup partsupp)
│ │ │ │ │ ├── save-table-name: q2_lookup_join_8
│ │ │ │ │ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) p_type:5(varchar!null) p_size:6(int!null) ps_partkey:21(int!null) ps_suppkey:22(int!null) ps_supplycost:24(float!null)
│ │ │ │ │ ├── key columns: [1] = [21]
- │ │ │ │ │ ├── stats: [rows=5372.054, distinct(1)=1337.9, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=4, distinct(5)=150, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=4, distinct(21)=1337.9, null(21)=0, avgsize(21)=4, distinct(22)=4148.03, null(22)=0, avgsize(22)=4, distinct(24)=995.355, null(24)=0, avgsize(24)=4]
+ │ │ │ │ │ ├── stats: [rows=5349.747, distinct(1)=1332.34, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=16, distinct(5)=150, null(5)=0, avgsize(5)=23, distinct(6)=1, null(6)=0, avgsize(6)=2, distinct(21)=1332.34, null(21)=0, avgsize(21)=4, distinct(22)=4135.03, null(22)=0, avgsize(22)=3, distinct(24)=5209.7, null(24)=0, avgsize(24)=9]
│ │ │ │ │ ├── key: (21,22)
│ │ │ │ │ ├── fd: ()-->(6), (1)-->(3,5), (21,22)-->(24), (1)==(21), (21)==(1)
│ │ │ │ │ ├── select
│ │ │ │ │ │ ├── save-table-name: q2_select_9
│ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) p_type:5(varchar!null) p_size:6(int!null)
- │ │ │ │ │ │ ├── stats: [rows=1337.917, distinct(1)=1337.9, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=4, distinct(5)=150, null(5)=0, avgsize(5)=4, distinct(6)=1, null(6)=0, avgsize(6)=4]
- │ │ │ │ │ │ │ histogram(6)= 0 1337.9
+ │ │ │ │ │ │ ├── stats: [rows=1332.361, distinct(1)=1332.34, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=16, distinct(5)=150, null(5)=0, avgsize(5)=23, distinct(6)=1, null(6)=0, avgsize(6)=2]
+ │ │ │ │ │ │ │ histogram(6)= 0 1332.4
│ │ │ │ │ │ │ <---- 15 -
│ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ ├── fd: ()-->(6), (1)-->(3,5)
│ │ │ │ │ │ ├── scan part
│ │ │ │ │ │ │ ├── save-table-name: q2_scan_10
│ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_mfgr:3(char!null) p_type:5(varchar!null) p_size:6(int!null)
- │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(1)=199241, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=4, distinct(5)=150, null(5)=0, avgsize(5)=4, distinct(6)=50, null(6)=0, avgsize(6)=4]
- │ │ │ │ │ │ │ │ histogram(1)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ │ │ │ histogram(3)= 0 39660 1.199e+05 40440
- │ │ │ │ │ │ │ │ <--- 'Manufacturer#1' ----------- 'Manufacturer#5'
- │ │ │ │ │ │ │ │ histogram(5)= 0 1340 1.975e+05 1160
- │ │ │ │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ----------- 'STANDARD POLISHED TIN'
- │ │ │ │ │ │ │ │ histogram(6)= 0 3740 1.9266e+05 3600
+ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(1)=199241, null(1)=0, avgsize(1)=4, distinct(3)=5, null(3)=0, avgsize(3)=16, distinct(5)=150, null(5)=0, avgsize(5)=23, distinct(6)=50, null(6)=0, avgsize(6)=2]
+ │ │ │ │ │ │ │ │ histogram(1)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ │ │ │ histogram(3)= 0 40940 1.1794e+05 41120
+ │ │ │ │ │ │ │ │ <--- 'Manufacturer#1' ------------ 'Manufacturer#5'
+ │ │ │ │ │ │ │ │ histogram(5)= 0 1360 1.9708e+05 1560
+ │ │ │ │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ------------ 'STANDARD POLISHED TIN'
+ │ │ │ │ │ │ │ │ histogram(6)= 0 4240 1.9186e+05 3900
│ │ │ │ │ │ │ │ <--- 1 ------------- 50
│ │ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ │ └── fd: (1)-->(3,5,6)
@@ -157,40 +157,40 @@ project
│ │ │ │ │ ├── save-table-name: q2_inner_join_11
│ │ │ │ │ ├── columns: s_suppkey:12(int!null) s_name:13(char!null) s_address:14(varchar!null) s_nationkey:15(int!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null) n_nationkey:28(int!null) n_name:29(char!null) n_regionkey:30(int!null) r_regionkey:34(int!null) r_name:35(char!null)
│ │ │ │ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ │ │ │ ├── stats: [rows=2000, distinct(12)=1844.81, null(12)=0, avgsize(12)=4, distinct(13)=1846.09, null(13)=0, avgsize(13)=4, distinct(14)=1846.27, null(14)=0, avgsize(14)=4, distinct(15)=5, null(15)=0, avgsize(15)=4, distinct(16)=1843.32, null(16)=0, avgsize(16)=4, distinct(17)=1846.27, null(17)=0, avgsize(17)=4, distinct(18)=1844.49, null(18)=0, avgsize(18)=4, distinct(28)=5, null(28)=0, avgsize(28)=4, distinct(29)=5, null(29)=0, avgsize(29)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(34)=1, null(34)=0, avgsize(34)=4, distinct(35)=0.996222, null(35)=0, avgsize(35)=4]
+ │ │ │ │ │ ├── stats: [rows=2000, distinct(12)=1844.81, null(12)=0, avgsize(12)=3, distinct(13)=1846.09, null(13)=0, avgsize(13)=20, distinct(14)=1846.27, null(14)=0, avgsize(14)=27, distinct(15)=5, null(15)=0, avgsize(15)=2, distinct(16)=1846.27, null(16)=0, avgsize(16)=17, distinct(17)=1845.67, null(17)=0, avgsize(17)=9, distinct(18)=1845.06, null(18)=0, avgsize(18)=65, distinct(28)=5, null(28)=0, avgsize(28)=1, distinct(29)=5, null(29)=0, avgsize(29)=10, distinct(30)=1, null(30)=0, avgsize(30)=2, distinct(34)=1, null(34)=0, avgsize(34)=1, distinct(35)=0.996222, null(35)=0, avgsize(35)=9]
│ │ │ │ │ ├── key: (12)
│ │ │ │ │ ├── fd: ()-->(35), (12)-->(13-18), (28)-->(29,30), (30)==(34), (34)==(30), (15)==(28), (28)==(15)
│ │ │ │ │ ├── scan supplier
│ │ │ │ │ │ ├── save-table-name: q2_scan_12
│ │ │ │ │ │ ├── columns: s_suppkey:12(int!null) s_name:13(char!null) s_address:14(varchar!null) s_nationkey:15(int!null) s_phone:16(char!null) s_acctbal:17(float!null) s_comment:18(varchar!null)
- │ │ │ │ │ │ ├── stats: [rows=10000, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(13)=9990, null(13)=0, avgsize(13)=4, distinct(14)=10000, null(14)=0, avgsize(14)=4, distinct(15)=25, null(15)=0, avgsize(15)=4, distinct(16)=9840, null(16)=0, avgsize(16)=4, distinct(17)=10000, null(17)=0, avgsize(17)=4, distinct(18)=9903, null(18)=0, avgsize(18)=4]
+ │ │ │ │ │ │ ├── stats: [rows=10000, distinct(12)=9920, null(12)=0, avgsize(12)=3, distinct(13)=9990, null(13)=0, avgsize(13)=20, distinct(14)=10000, null(14)=0, avgsize(14)=27, distinct(15)=25, null(15)=0, avgsize(15)=2, distinct(16)=10000, null(16)=0, avgsize(16)=17, distinct(17)=9967, null(17)=0, avgsize(17)=9, distinct(18)=9934, null(18)=0, avgsize(18)=65]
│ │ │ │ │ │ │ histogram(12)= 0 0 0 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 0 0
│ │ │ │ │ │ │ <--- -9223372036854775808 --- 1 ---- 51 ---- 101 ---- 151 ---- 201 ---- 251 ---- 301 ---- 351 ---- 401 ---- 451 ---- 501 ---- 551 ---- 601 ---- 651 ---- 701 ---- 751 ---- 801 ---- 851 ---- 901 ---- 951 ---- 1001 ---- 1051 ---- 1101 ---- 1151 ---- 1201 ---- 1251 ---- 1301 ---- 1351 ---- 1401 ---- 1451 ---- 1501 ---- 1551 ---- 1601 ---- 1651 ---- 1701 ---- 1751 ---- 1801 ---- 1851 ---- 1901 ---- 1951 ---- 2001 ---- 2051 ---- 2101 ---- 2151 ---- 2201 ---- 2251 ---- 2301 ---- 2351 ---- 2401 ---- 2451 ---- 2501 ---- 2551 ---- 2601 ---- 2651 ---- 2701 ---- 2751 ---- 2801 ---- 2851 ---- 2901 ---- 2951 ---- 3001 ---- 3051 ---- 3101 ---- 3151 ---- 3201 ---- 3251 ---- 3301 ---- 3351 ---- 3401 ---- 3451 ---- 3501 ---- 3551 ---- 3601 ---- 3651 ---- 3701 ---- 3751 ---- 3801 ---- 3851 ---- 3901 ---- 3951 ---- 4001 ---- 4051 ---- 4101 ---- 4151 ---- 4201 ---- 4251 ---- 4301 ---- 4351 ---- 4401 ---- 4451 ---- 4501 ---- 4551 ---- 4601 ---- 4651 ---- 4701 ---- 4751 ---- 4801 ---- 4851 ---- 4901 ---- 4951 ---- 5001 ---- 5051 ---- 5101 ---- 5151 ---- 5201 ---- 5251 ---- 5301 ---- 5351 ---- 5401 ---- 5451 ---- 5501 ---- 5551 ---- 5601 ---- 5651 ---- 5701 ---- 5751 ---- 5801 ---- 5851 ---- 5901 ---- 5951 ---- 6001 ---- 6051 ---- 6101 ---- 6151 ---- 6201 ---- 6251 ---- 6301 ---- 6351 ---- 6401 ---- 6451 ---- 6501 ---- 6551 ---- 6601 ---- 6651 ---- 6701 ---- 6751 ---- 6801 ---- 6851 ---- 6901 ---- 6951 ---- 7001 ---- 7051 ---- 7101 ---- 7151 ---- 7201 ---- 7251 ---- 7301 ---- 7351 ---- 7401 ---- 7451 ---- 7501 ---- 7552 ---- 7603 ---- 7654 ---- 7705 ---- 7756 ---- 7807 ---- 7858 ---- 7909 ---- 7960 ---- 8011 ---- 8062 ---- 8113 ---- 8164 ---- 8215 ---- 8266 ---- 8317 ---- 8368 ---- 8419 ---- 8470 ---- 8521 ---- 8572 ---- 8623 ---- 8674 ---- 8725 ---- 8776 ---- 8827 ---- 8878 ---- 8929 ---- 8980 ---- 9031 ---- 9082 ---- 9133 ---- 9184 ---- 9235 ---- 9286 ---- 9337 ---- 9388 ---- 9439 ---- 9490 ---- 9541 ---- 9592 ---- 9643 ---- 9694 ---- 9745 ---- 9796 ---- 9847 ---- 9898 ---- 9949 ---- 10000 --- 9223372036854775807
│ │ │ │ │ │ │ histogram(13)= 0 1 9998 1
│ │ │ │ │ │ │ <--- 'Supplier#000000001' ------ 'Supplier#000010000'
- │ │ │ │ │ │ │ histogram(14)= 0 1 9998 1
- │ │ │ │ │ │ │ <--- ' 7thzdOKLdVP yR7ZbOMnubI6,PrkxBX ZYw1' ------ 'zzvmS9DyfR'
- │ │ │ │ │ │ │ histogram(15)= 0 403 0 384 0 391 0 396 0 406 0 396 0 393 0 399 0 406 0 393 0 383 0 398 0 394 0 414 0 422 0 387 0 435 0 403 0 441 0 357 0 394 0 390 0 421 0 411 0 383
+ │ │ │ │ │ │ │ histogram(14)= 0 1 9998 1
+ │ │ │ │ │ │ │ <--- ' 9aW1wwnBJJPnCx,nox0MA48Y0zpI1IeVfYZ' ------ 'zzfDhdtZcvmVzA8rNFU,Yctj1zBN'
+ │ │ │ │ │ │ │ histogram(15)= 0 420 0 413 0 397 0 412 0 415 0 380 0 402 0 396 0 415 0 405 0 393 0 438 0 377 0 362 0 376 0 373 0 406 0 421 0 407 0 398 0 411 0 399 0 401 0 390 0 393
│ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ histogram(16)= 0 1 9998 1
- │ │ │ │ │ │ │ <--- '10-101-276-5805' ------ '34-997-188-3418'
- │ │ │ │ │ │ │ histogram(17)= 0 1 9998 1
- │ │ │ │ │ │ │ <--- -999.72998046875 ------ 9999.509765625
- │ │ │ │ │ │ │ histogram(18)= 0 1 9998 1
- │ │ │ │ │ │ │ <--- ' A ability south main close despite clearly. Who hold sense everyone. Cou' ------ 'zine know whatever discuss. Realize brother co'
+ │ │ │ │ │ │ │ <--- '10-102-116-6785' ------ '34-998-900-4911'
+ │ │ │ │ │ │ │ histogram(17)= 0 1 9998 1
+ │ │ │ │ │ │ │ <--- -998.22 ------ 9999.72
+ │ │ │ │ │ │ │ histogram(18)= 0 1 9998 1
+ │ │ │ │ │ │ │ <--- ' about the blithely express foxes. bli' ------ 'zzle furiously. bold accounts haggle furiously ironic excuses. fur'
│ │ │ │ │ │ ├── key: (12)
│ │ │ │ │ │ └── fd: (12)-->(13-18)
│ │ │ │ │ ├── inner-join (hash)
│ │ │ │ │ │ ├── save-table-name: q2_inner_join_13
│ │ │ │ │ │ ├── columns: n_nationkey:28(int!null) n_name:29(char!null) n_regionkey:30(int!null) r_regionkey:34(int!null) r_name:35(char!null)
│ │ │ │ │ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ │ │ │ │ ├── stats: [rows=5, distinct(28)=5, null(28)=0, avgsize(28)=4, distinct(29)=5, null(29)=0, avgsize(29)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(34)=1, null(34)=0, avgsize(34)=4, distinct(35)=0.996222, null(35)=0, avgsize(35)=4]
+ │ │ │ │ │ │ ├── stats: [rows=5, distinct(28)=5, null(28)=0, avgsize(28)=1, distinct(29)=5, null(29)=0, avgsize(29)=10, distinct(30)=1, null(30)=0, avgsize(30)=2, distinct(34)=1, null(34)=0, avgsize(34)=1, distinct(35)=0.996222, null(35)=0, avgsize(35)=9]
│ │ │ │ │ │ ├── key: (28)
│ │ │ │ │ │ ├── fd: ()-->(35), (28)-->(29,30), (30)==(34), (34)==(30)
│ │ │ │ │ │ ├── scan nation
│ │ │ │ │ │ │ ├── save-table-name: q2_scan_14
│ │ │ │ │ │ │ ├── columns: n_nationkey:28(int!null) n_name:29(char!null) n_regionkey:30(int!null)
- │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(28)=25, null(28)=0, avgsize(28)=4, distinct(29)=25, null(29)=0, avgsize(29)=4, distinct(30)=5, null(30)=0, avgsize(30)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(28)=25, null(28)=0, avgsize(28)=1, distinct(29)=25, null(29)=0, avgsize(29)=10, distinct(30)=5, null(30)=0, avgsize(30)=2]
│ │ │ │ │ │ │ │ histogram(28)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ histogram(29)= 0 1 23 1
@@ -202,7 +202,7 @@ project
│ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ ├── save-table-name: q2_select_15
│ │ │ │ │ │ │ ├── columns: r_regionkey:34(int!null) r_name:35(char!null)
- │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(34)=1, null(34)=0, avgsize(34)=4, distinct(35)=1, null(35)=0, avgsize(35)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(34)=1, null(34)=0, avgsize(34)=1, distinct(35)=1, null(35)=0, avgsize(35)=9]
│ │ │ │ │ │ │ │ histogram(35)= 0 1
│ │ │ │ │ │ │ │ <--- 'EUROPE'
│ │ │ │ │ │ │ ├── key: (34)
@@ -210,7 +210,7 @@ project
│ │ │ │ │ │ │ ├── scan region
│ │ │ │ │ │ │ │ ├── save-table-name: q2_scan_16
│ │ │ │ │ │ │ │ ├── columns: r_regionkey:34(int!null) r_name:35(char!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(34)=5, null(34)=0, avgsize(34)=4, distinct(35)=5, null(35)=0, avgsize(35)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(34)=5, null(34)=0, avgsize(34)=1, distinct(35)=5, null(35)=0, avgsize(35)=9]
│ │ │ │ │ │ │ │ │ histogram(34)= 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4
│ │ │ │ │ │ │ │ │ histogram(35)= 0 1 3 1
@@ -230,20 +230,20 @@ project
│ │ │ ├── save-table-name: q2_lookup_join_17
│ │ │ ├── columns: s_suppkey:46(int!null) s_nationkey:49(int!null) n_nationkey:55(int!null) n_regionkey:57(int!null) r_regionkey:61(int!null) r_name:62(char!null)
│ │ │ ├── key columns: [55] = [49]
- │ │ │ ├── stats: [rows=2000, distinct(46)=1844.81, null(46)=0, avgsize(46)=4, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(55)=5, null(55)=0, avgsize(55)=4, distinct(57)=1, null(57)=0, avgsize(57)=4, distinct(61)=1, null(61)=0, avgsize(61)=4, distinct(62)=0.996222, null(62)=0, avgsize(62)=4]
+ │ │ │ ├── stats: [rows=2000, distinct(46)=1844.81, null(46)=0, avgsize(46)=3, distinct(49)=5, null(49)=0, avgsize(49)=2, distinct(55)=5, null(55)=0, avgsize(55)=1, distinct(57)=1, null(57)=0, avgsize(57)=2, distinct(61)=1, null(61)=0, avgsize(61)=1, distinct(62)=0.996222, null(62)=0, avgsize(62)=9]
│ │ │ ├── key: (46)
│ │ │ ├── fd: ()-->(62), (46)-->(49), (55)-->(57), (57)==(61), (61)==(57), (49)==(55), (55)==(49)
│ │ │ ├── inner-join (lookup nation@n_rk)
│ │ │ │ ├── save-table-name: q2_lookup_join_18
│ │ │ │ ├── columns: n_nationkey:55(int!null) n_regionkey:57(int!null) r_regionkey:61(int!null) r_name:62(char!null)
│ │ │ │ ├── key columns: [61] = [57]
- │ │ │ │ ├── stats: [rows=5, distinct(55)=5, null(55)=0, avgsize(55)=4, distinct(57)=1, null(57)=0, avgsize(57)=4, distinct(61)=1, null(61)=0, avgsize(61)=4, distinct(62)=0.996222, null(62)=0, avgsize(62)=4]
+ │ │ │ │ ├── stats: [rows=5, distinct(55)=5, null(55)=0, avgsize(55)=1, distinct(57)=1, null(57)=0, avgsize(57)=2, distinct(61)=1, null(61)=0, avgsize(61)=1, distinct(62)=0.996222, null(62)=0, avgsize(62)=9]
│ │ │ │ ├── key: (55)
│ │ │ │ ├── fd: ()-->(62), (55)-->(57), (57)==(61), (61)==(57)
│ │ │ │ ├── select
│ │ │ │ │ ├── save-table-name: q2_select_19
│ │ │ │ │ ├── columns: r_regionkey:61(int!null) r_name:62(char!null)
- │ │ │ │ │ ├── stats: [rows=1, distinct(61)=1, null(61)=0, avgsize(61)=4, distinct(62)=1, null(62)=0, avgsize(62)=4]
+ │ │ │ │ │ ├── stats: [rows=1, distinct(61)=1, null(61)=0, avgsize(61)=1, distinct(62)=1, null(62)=0, avgsize(62)=9]
│ │ │ │ │ │ histogram(62)= 0 1
│ │ │ │ │ │ <--- 'EUROPE'
│ │ │ │ │ ├── key: (61)
@@ -251,7 +251,7 @@ project
│ │ │ │ │ ├── scan region
│ │ │ │ │ │ ├── save-table-name: q2_scan_20
│ │ │ │ │ │ ├── columns: r_regionkey:61(int!null) r_name:62(char!null)
- │ │ │ │ │ │ ├── stats: [rows=5, distinct(61)=5, null(61)=0, avgsize(61)=4, distinct(62)=5, null(62)=0, avgsize(62)=4]
+ │ │ │ │ │ │ ├── stats: [rows=5, distinct(61)=5, null(61)=0, avgsize(61)=1, distinct(62)=5, null(62)=0, avgsize(62)=9]
│ │ │ │ │ │ │ histogram(61)= 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4
│ │ │ │ │ │ │ histogram(62)= 0 1 3 1
@@ -383,18 +383,18 @@ column_names row_count distinct_count null_count
{s_phone} 642 548 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{min} 1482.00 2.31 <== 1482.00 3.24 <== 0.00 1.00
-{n_name} 1482.00 2.31 <== 1482.00 296.40 <== 0.00 1.00
-{p_mfgr} 1482.00 2.31 <== 1482.00 296.40 <== 0.00 1.00
-{p_partkey} 1482.00 2.31 <== 1482.00 3.22 <== 0.00 1.00
-{ps_partkey} 1482.00 2.31 <== 1176.00 2.56 <== 0.00 1.00
-{ps_suppkey} 1482.00 2.31 <== 1407.00 2.57 <== 0.00 1.00
-{ps_supplycost} 1482.00 2.31 <== 1482.00 2.32 <== 0.00 1.00
-{s_acctbal} 1482.00 2.31 <== 1482.00 2.70 <== 0.00 1.00
-{s_address} 1482.00 2.31 <== 1482.00 2.70 <== 0.00 1.00
-{s_comment} 1482.00 2.31 <== 1482.00 2.70 <== 0.00 1.00
-{s_name} 1482.00 2.31 <== 1482.00 2.70 <== 0.00 1.00
-{s_phone} 1482.00 2.31 <== 1482.00 2.70 <== 0.00 1.00
+{min} 1476.00 2.30 <== 1476.00 3.22 <== 0.00 1.00
+{n_name} 1476.00 2.30 <== 1476.00 295.20 <== 0.00 1.00
+{p_mfgr} 1476.00 2.30 <== 1476.00 295.20 <== 0.00 1.00
+{p_partkey} 1476.00 2.30 <== 1476.00 3.21 <== 0.00 1.00
+{ps_partkey} 1476.00 2.30 <== 1171.00 2.55 <== 0.00 1.00
+{ps_suppkey} 1476.00 2.30 <== 1402.00 2.56 <== 0.00 1.00
+{ps_supplycost} 1476.00 2.30 <== 1476.00 2.31 <== 0.00 1.00
+{s_acctbal} 1476.00 2.30 <== 1476.00 2.69 <== 0.00 1.00
+{s_address} 1476.00 2.30 <== 1476.00 2.69 <== 0.00 1.00
+{s_comment} 1476.00 2.30 <== 1476.00 2.69 <== 0.00 1.00
+{s_name} 1476.00 2.30 <== 1476.00 2.69 <== 0.00 1.00
+{s_phone} 1476.00 2.30 <== 1476.00 2.69 <== 0.00 1.00
----Stats for q2_inner_join_5----
column_names row_count distinct_count null_count
@@ -428,34 +428,34 @@ column_names row_count distinct_count null_count
{s_suppkey} 1070 548 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{n_name} 2828.00 2.64 <== 5.00 1.00 0.00 1.00
-{n_nationkey} 2828.00 2.64 <== 5.00 1.00 0.00 1.00
-{n_nationkey_1} 2828.00 2.64 <== 5.00 1.00 0.00 1.00
-{n_regionkey} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{n_regionkey_1} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{p_mfgr} 2828.00 2.64 <== 5.00 1.00 0.00 1.00
-{p_partkey} 2828.00 2.64 <== 1338.00 2.91 <== 0.00 1.00
-{p_size} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{p_type} 2828.00 2.64 <== 150.00 5.00 <== 0.00 1.00
-{ps_partkey} 2828.00 2.64 <== 1176.00 2.56 <== 0.00 1.00
-{ps_partkey_1} 2828.00 2.64 <== 1338.00 2.91 <== 0.00 1.00
-{ps_suppkey} 2828.00 2.64 <== 1407.00 2.57 <== 0.00 1.00
-{ps_suppkey_1} 2828.00 2.64 <== 1446.00 2.64 <== 0.00 1.00
-{ps_supplycost} 2828.00 2.64 <== 825.00 1.29 0.00 1.00
-{ps_supplycost_1} 2828.00 2.64 <== 941.00 1.47 0.00 1.00
-{r_name} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{r_name_1} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{r_regionkey} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{r_regionkey_1} 2828.00 2.64 <== 1.00 1.00 0.00 1.00
-{s_acctbal} 2828.00 2.64 <== 1408.00 2.57 <== 0.00 1.00
-{s_address} 2828.00 2.64 <== 1408.00 2.57 <== 0.00 1.00
-{s_comment} 2828.00 2.64 <== 1407.00 2.57 <== 0.00 1.00
-{s_name} 2828.00 2.64 <== 1408.00 2.57 <== 0.00 1.00
-{s_nationkey} 2828.00 2.64 <== 5.00 1.00 0.00 1.00
-{s_nationkey_1} 2828.00 2.64 <== 5.00 1.00 0.00 1.00
-{s_phone} 2828.00 2.64 <== 1407.00 2.57 <== 0.00 1.00
-{s_suppkey} 2828.00 2.64 <== 1407.00 2.57 <== 0.00 1.00
-{s_suppkey_1} 2828.00 2.64 <== 1446.00 2.64 <== 0.00 1.00
+{n_name} 2816.00 2.63 <== 5.00 1.00 0.00 1.00
+{n_nationkey} 2816.00 2.63 <== 5.00 1.00 0.00 1.00
+{n_nationkey_1} 2816.00 2.63 <== 5.00 1.00 0.00 1.00
+{n_regionkey} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{n_regionkey_1} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{p_mfgr} 2816.00 2.63 <== 5.00 1.00 0.00 1.00
+{p_partkey} 2816.00 2.63 <== 1332.00 2.90 <== 0.00 1.00
+{p_size} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{p_type} 2816.00 2.63 <== 150.00 5.00 <== 0.00 1.00
+{ps_partkey} 2816.00 2.63 <== 1171.00 2.55 <== 0.00 1.00
+{ps_partkey_1} 2816.00 2.63 <== 1332.00 2.90 <== 0.00 1.00
+{ps_suppkey} 2816.00 2.63 <== 1402.00 2.56 <== 0.00 1.00
+{ps_suppkey_1} 2816.00 2.63 <== 1444.00 2.64 <== 0.00 1.00
+{ps_supplycost} 2816.00 2.63 <== 1472.00 2.30 <== 0.00 1.00
+{ps_supplycost_1} 2816.00 2.63 <== 2767.00 4.32 <== 0.00 1.00
+{r_name} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{r_name_1} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{r_regionkey} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{r_regionkey_1} 2816.00 2.63 <== 1.00 1.00 0.00 1.00
+{s_acctbal} 2816.00 2.63 <== 1402.00 2.56 <== 0.00 1.00
+{s_address} 2816.00 2.63 <== 1403.00 2.56 <== 0.00 1.00
+{s_comment} 2816.00 2.63 <== 1402.00 2.56 <== 0.00 1.00
+{s_name} 2816.00 2.63 <== 1402.00 2.56 <== 0.00 1.00
+{s_nationkey} 2816.00 2.63 <== 5.00 1.00 0.00 1.00
+{s_nationkey_1} 2816.00 2.63 <== 5.00 1.00 0.00 1.00
+{s_phone} 2816.00 2.63 <== 1403.00 2.56 <== 0.00 1.00
+{s_suppkey} 2816.00 2.63 <== 1402.00 2.56 <== 0.00 1.00
+{s_suppkey_1} 2816.00 2.63 <== 1444.00 2.64 <== 0.00 1.00
----Stats for q2_lookup_join_6----
column_names row_count distinct_count null_count
@@ -483,28 +483,28 @@ column_names row_count distinct_count null_count
{s_suppkey} 2568 548 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{n_name} 4468.00 1.74 25.00 5.00 <== 0.00 1.00
-{n_nationkey} 4468.00 1.74 25.00 5.00 <== 0.00 1.00
-{n_regionkey} 4468.00 1.74 1.00 1.00 0.00 1.00
-{p_mfgr} 4468.00 1.74 5.00 1.00 0.00 1.00
-{p_partkey} 4468.00 1.74 1338.00 2.91 <== 0.00 1.00
-{p_size} 4468.00 1.74 1.00 1.00 0.00 1.00
-{p_type} 4468.00 1.74 150.00 5.00 <== 0.00 1.00
-{ps_partkey} 4468.00 1.74 1338.00 2.91 <== 0.00 1.00
-{ps_partkey_1} 4468.00 1.74 4417.00 9.60 <== 0.00 1.00
-{ps_suppkey} 4468.00 1.74 3597.00 6.56 <== 0.00 1.00
-{ps_suppkey_1} 4468.00 1.74 3597.00 2.17 <== 0.00 1.00
-{ps_supplycost} 4468.00 1.74 989.00 1.55 0.00 1.00
-{ps_supplycost_1} 4468.00 1.74 989.00 1.85 0.00 1.00
-{r_name} 4468.00 1.74 1.00 1.00 0.00 1.00
-{r_regionkey} 4468.00 1.74 1.00 1.00 0.00 1.00
-{s_acctbal} 4468.00 1.74 3603.00 6.57 <== 0.00 1.00
-{s_address} 4468.00 1.74 3603.00 6.57 <== 0.00 1.00
-{s_comment} 4468.00 1.74 3596.00 6.56 <== 0.00 1.00
-{s_name} 4468.00 1.74 3602.00 6.57 <== 0.00 1.00
-{s_nationkey} 4468.00 1.74 25.00 5.00 <== 0.00 1.00
-{s_phone} 4468.00 1.74 3591.00 6.55 <== 0.00 1.00
-{s_suppkey} 4468.00 1.74 3597.00 6.56 <== 0.00 1.00
+{n_name} 4449.00 1.73 25.00 5.00 <== 0.00 1.00
+{n_nationkey} 4449.00 1.73 25.00 5.00 <== 0.00 1.00
+{n_regionkey} 4449.00 1.73 1.00 1.00 0.00 1.00
+{p_mfgr} 4449.00 1.73 5.00 1.00 0.00 1.00
+{p_partkey} 4449.00 1.73 1332.00 2.90 <== 0.00 1.00
+{p_size} 4449.00 1.73 1.00 1.00 0.00 1.00
+{p_type} 4449.00 1.73 150.00 5.00 <== 0.00 1.00
+{ps_partkey} 4449.00 1.73 1332.00 2.90 <== 0.00 1.00
+{ps_partkey_1} 4449.00 1.73 4398.00 9.56 <== 0.00 1.00
+{ps_suppkey} 4449.00 1.73 3585.00 6.54 <== 0.00 1.00
+{ps_suppkey_1} 4449.00 1.73 3585.00 2.16 <== 0.00 1.00
+{ps_supplycost} 4449.00 1.73 4352.00 6.80 <== 0.00 1.00
+{ps_supplycost_1} 4449.00 1.73 4352.00 2.38 <== 0.00 1.00
+{r_name} 4449.00 1.73 1.00 1.00 0.00 1.00
+{r_regionkey} 4449.00 1.73 1.00 1.00 0.00 1.00
+{s_acctbal} 4449.00 1.73 3589.00 6.55 <== 0.00 1.00
+{s_address} 4449.00 1.73 3591.00 6.55 <== 0.00 1.00
+{s_comment} 4449.00 1.73 3586.00 6.54 <== 0.00 1.00
+{s_name} 4449.00 1.73 3590.00 6.55 <== 0.00 1.00
+{s_nationkey} 4449.00 1.73 25.00 5.00 <== 0.00 1.00
+{s_phone} 4449.00 1.73 3591.00 6.55 <== 0.00 1.00
+{s_suppkey} 4449.00 1.73 3585.00 6.54 <== 0.00 1.00
----Stats for q2_inner_join_7----
column_names row_count distinct_count null_count
@@ -529,25 +529,25 @@ column_names row_count distinct_count null_count
{s_suppkey} 642 548 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{n_name} 1938.00 3.02 <== 5.00 1.00 0.00 1.00
-{n_nationkey} 1938.00 3.02 <== 5.00 1.00 0.00 1.00
-{n_regionkey} 1938.00 3.02 <== 1.00 1.00 0.00 1.00
-{p_mfgr} 1938.00 3.02 <== 5.00 1.00 0.00 1.00
-{p_partkey} 1938.00 3.02 <== 1338.00 2.91 <== 0.00 1.00
-{p_size} 1938.00 3.02 <== 1.00 1.00 0.00 1.00
-{p_type} 1938.00 3.02 <== 150.00 5.00 <== 0.00 1.00
-{ps_partkey} 1938.00 3.02 <== 1338.00 2.91 <== 0.00 1.00
-{ps_suppkey} 1938.00 3.02 <== 1761.00 3.21 <== 0.00 1.00
-{ps_supplycost} 1938.00 3.02 <== 856.00 1.34 0.00 1.00
-{r_name} 1938.00 3.02 <== 1.00 1.00 0.00 1.00
-{r_regionkey} 1938.00 3.02 <== 1.00 1.00 0.00 1.00
-{s_acctbal} 1938.00 3.02 <== 1762.00 3.22 <== 0.00 1.00
-{s_address} 1938.00 3.02 <== 1762.00 3.22 <== 0.00 1.00
-{s_comment} 1938.00 3.02 <== 1761.00 3.21 <== 0.00 1.00
-{s_name} 1938.00 3.02 <== 1762.00 3.22 <== 0.00 1.00
-{s_nationkey} 1938.00 3.02 <== 5.00 1.00 0.00 1.00
-{s_phone} 1938.00 3.02 <== 1759.00 3.21 <== 0.00 1.00
-{s_suppkey} 1938.00 3.02 <== 1761.00 3.21 <== 0.00 1.00
+{n_name} 1930.00 3.01 <== 5.00 1.00 0.00 1.00
+{n_nationkey} 1930.00 3.01 <== 5.00 1.00 0.00 1.00
+{n_regionkey} 1930.00 3.01 <== 1.00 1.00 0.00 1.00
+{p_mfgr} 1930.00 3.01 <== 5.00 1.00 0.00 1.00
+{p_partkey} 1930.00 3.01 <== 1332.00 2.90 <== 0.00 1.00
+{p_size} 1930.00 3.01 <== 1.00 1.00 0.00 1.00
+{p_type} 1930.00 3.01 <== 150.00 5.00 <== 0.00 1.00
+{ps_partkey} 1930.00 3.01 <== 1332.00 2.90 <== 0.00 1.00
+{ps_suppkey} 1930.00 3.01 <== 1754.00 3.20 <== 0.00 1.00
+{ps_supplycost} 1930.00 3.01 <== 1908.00 2.98 <== 0.00 1.00
+{r_name} 1930.00 3.01 <== 1.00 1.00 0.00 1.00
+{r_regionkey} 1930.00 3.01 <== 1.00 1.00 0.00 1.00
+{s_acctbal} 1930.00 3.01 <== 1755.00 3.20 <== 0.00 1.00
+{s_address} 1930.00 3.01 <== 1756.00 3.20 <== 0.00 1.00
+{s_comment} 1930.00 3.01 <== 1754.00 3.20 <== 0.00 1.00
+{s_name} 1930.00 3.01 <== 1755.00 3.20 <== 0.00 1.00
+{s_nationkey} 1930.00 3.01 <== 5.00 1.00 0.00 1.00
+{s_phone} 1930.00 3.01 <== 1756.00 3.20 <== 0.00 1.00
+{s_suppkey} 1930.00 3.01 <== 1754.00 3.20 <== 0.00 1.00
----Stats for q2_lookup_join_8----
column_names row_count distinct_count null_count
@@ -560,13 +560,13 @@ column_names row_count distinct_count null_count
{ps_supplycost} 2988 2948 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_mfgr} 5372.00 1.80 5.00 1.00 0.00 1.00
-{p_partkey} 5372.00 1.80 1338.00 1.79 0.00 1.00
-{p_size} 5372.00 1.80 1.00 1.00 0.00 1.00
-{p_type} 5372.00 1.80 150.00 5.00 <== 0.00 1.00
-{ps_partkey} 5372.00 1.80 1338.00 1.79 0.00 1.00
-{ps_suppkey} 5372.00 1.80 4148.00 1.61 0.00 1.00
-{ps_supplycost} 5372.00 1.80 995.00 2.96 <== 0.00 1.00
+{p_mfgr} 5350.00 1.79 5.00 1.00 0.00 1.00
+{p_partkey} 5350.00 1.79 1332.00 1.78 0.00 1.00
+{p_size} 5350.00 1.79 1.00 1.00 0.00 1.00
+{p_type} 5350.00 1.79 150.00 5.00 <== 0.00 1.00
+{ps_partkey} 5350.00 1.79 1332.00 1.78 0.00 1.00
+{ps_suppkey} 5350.00 1.79 4135.00 1.61 0.00 1.00
+{ps_supplycost} 5350.00 1.79 5210.00 1.77 0.00 1.00
----Stats for q2_select_9----
column_names row_count distinct_count null_count
@@ -576,10 +576,10 @@ column_names row_count distinct_count null_count
{p_type} 747 30 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_mfgr} 1338.00 1.79 5.00 1.00 0.00 1.00
-{p_partkey} 1338.00 1.79 1338.00 1.79 0.00 1.00
-{p_size} 1338.00 1.79 1.00 1.00 0.00 1.00
-{p_type} 1338.00 1.79 150.00 5.00 <== 0.00 1.00
+{p_mfgr} 1332.00 1.78 5.00 1.00 0.00 1.00
+{p_partkey} 1332.00 1.78 1332.00 1.78 0.00 1.00
+{p_size} 1332.00 1.78 1.00 1.00 0.00 1.00
+{p_type} 1332.00 1.78 150.00 5.00 <== 0.00 1.00
----Stats for q2_scan_10----
column_names row_count distinct_count null_count
@@ -617,10 +617,10 @@ column_names row_count_est row_count_err distinct_count_est distinct_count_
{r_regionkey} 2000.00 1.01 1.00 1.00 0.00 1.00
{s_acctbal} 2000.00 1.01 1846.00 1.07 0.00 1.00
{s_address} 2000.00 1.01 1846.00 1.08 0.00 1.00
-{s_comment} 2000.00 1.01 1844.00 1.08 0.00 1.00
+{s_comment} 2000.00 1.01 1845.00 1.08 0.00 1.00
{s_name} 2000.00 1.01 1846.00 1.08 0.00 1.00
{s_nationkey} 2000.00 1.01 5.00 1.00 0.00 1.00
-{s_phone} 2000.00 1.01 1843.00 1.08 0.00 1.00
+{s_phone} 2000.00 1.01 1846.00 1.08 0.00 1.00
{s_suppkey} 2000.00 1.01 1845.00 1.08 0.00 1.00
----Stats for q2_scan_12----
@@ -634,12 +634,12 @@ column_names row_count distinct_count null_count
{s_suppkey} 10000 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{s_acctbal} 10000.00 1.00 10000.00 1.00 0.00 1.00
+{s_acctbal} 10000.00 1.00 9967.00 1.00 0.00 1.00
{s_address} 10000.00 1.00 10000.00 1.00 0.00 1.00
-{s_comment} 10000.00 1.00 9903.00 1.00 0.00 1.00
+{s_comment} 10000.00 1.00 9934.00 1.00 0.00 1.00
{s_name} 10000.00 1.00 9990.00 1.00 0.00 1.00
{s_nationkey} 10000.00 1.00 25.00 1.00 0.00 1.00
-{s_phone} 10000.00 1.00 9840.00 1.02 0.00 1.00
+{s_phone} 10000.00 1.00 10000.00 1.00 0.00 1.00
{s_suppkey} 10000.00 1.00 9920.00 1.00 0.00 1.00
----Stats for q2_inner_join_13----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q03 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q03
index d1a175c7d7e0..4c9ad01b0b5c 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q03
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q03
@@ -57,46 +57,46 @@ top-k
├── columns: o_orderdate:15(date!null) o_shippriority:18(int!null) l_orderkey:22(int!null) sum:41(float!null)
├── grouping columns: l_orderkey:22(int!null)
├── immutable
- ├── stats: [rows=364699, distinct(15)=364699, null(15)=0, avgsize(15)=4, distinct(18)=364699, null(18)=0, avgsize(18)=4, distinct(22)=364699, null(22)=0, avgsize(22)=4, distinct(41)=364699, null(41)=0, avgsize(41)=4]
+ ├── stats: [rows=358456.7, distinct(15)=358457, null(15)=0, avgsize(15)=4, distinct(18)=358457, null(18)=0, avgsize(18)=4, distinct(22)=358457, null(22)=0, avgsize(22)=4, distinct(41)=358457, null(41)=0, avgsize(41)=4]
├── key: (22)
├── fd: (22)-->(15,18,41)
├── project
│ ├── save-table-name: q3_project_3
│ ├── columns: column40:40(float!null) o_orderdate:15(date!null) o_shippriority:18(int!null) l_orderkey:22(int!null)
│ ├── immutable
- │ ├── stats: [rows=501066, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=4, distinct(22)=364699, null(22)=0, avgsize(22)=4, distinct(40)=415698, null(40)=0, avgsize(40)=8]
+ │ ├── stats: [rows=493436.5, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=2, distinct(22)=358457, null(22)=0, avgsize(22)=4, distinct(40)=408763, null(40)=0, avgsize(40)=18]
│ ├── fd: (22)-->(15,18)
│ ├── inner-join (lookup lineitem)
│ │ ├── save-table-name: q3_lookup_join_4
│ │ ├── columns: c_custkey:1(int!null) c_mktsegment:7(char!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) o_shippriority:18(int!null) l_orderkey:22(int!null) l_extendedprice:27(float!null) l_discount:28(float!null) l_shipdate:32(date!null)
│ │ ├── key columns: [11] = [22]
- │ │ ├── stats: [rows=501066, distinct(1)=30139, null(1)=0, avgsize(1)=4, distinct(7)=1, null(7)=0, avgsize(7)=4, distinct(11)=364699, null(11)=0, avgsize(11)=4, distinct(12)=30139, null(12)=0, avgsize(12)=4, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=4, distinct(22)=364699, null(22)=0, avgsize(22)=4, distinct(27)=371185, null(27)=0, avgsize(27)=4, distinct(28)=11, null(28)=0, avgsize(28)=4, distinct(32)=1354, null(32)=0, avgsize(32)=4, distinct(27,28)=415698, null(27,28)=0, avgsize(27,28)=8]
+ │ │ ├── stats: [rows=493436.5, distinct(1)=30523.3, null(1)=0, avgsize(1)=4, distinct(7)=1, null(7)=0, avgsize(7)=11, distinct(11)=358457, null(11)=0, avgsize(11)=4, distinct(12)=30523.3, null(12)=0, avgsize(12)=4, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=2, distinct(22)=358457, null(22)=0, avgsize(22)=4, distinct(27)=362999, null(27)=0, avgsize(27)=9, distinct(28)=11, null(28)=0, avgsize(28)=9, distinct(32)=1355, null(32)=0, avgsize(32)=4, distinct(27,28)=408763, null(27,28)=0, avgsize(27,28)=18]
│ │ ├── fd: ()-->(7), (11)-->(12,15,18), (11)==(22), (22)==(11), (1)==(12), (12)==(1)
│ │ ├── inner-join (hash)
│ │ │ ├── save-table-name: q3_inner_join_5
│ │ │ ├── columns: c_custkey:1(int!null) c_mktsegment:7(char!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) o_shippriority:18(int!null)
│ │ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ │ ├── stats: [rows=224946.8, distinct(1)=30139, null(1)=0, avgsize(1)=4, distinct(7)=1, null(7)=0, avgsize(7)=4, distinct(11)=194147, null(11)=0, avgsize(11)=4, distinct(12)=30139, null(12)=0, avgsize(12)=4, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=4]
+ │ │ │ ├── stats: [rows=222934.7, distinct(1)=30523.3, null(1)=0, avgsize(1)=4, distinct(7)=1, null(7)=0, avgsize(7)=11, distinct(11)=192056, null(11)=0, avgsize(11)=4, distinct(12)=30523.3, null(12)=0, avgsize(12)=4, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=2]
│ │ │ ├── key: (11)
│ │ │ ├── fd: ()-->(7), (11)-->(12,15,18), (1)==(12), (12)==(1)
│ │ │ ├── select
│ │ │ │ ├── save-table-name: q3_select_6
│ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) o_shippriority:18(int!null)
- │ │ │ │ ├── stats: [rows=744600, distinct(11)=744600, null(11)=0, avgsize(11)=4, distinct(12)=99849.7, null(12)=0, avgsize(12)=4, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=4]
- │ │ │ │ │ histogram(15)= 0 750 7350 450 6600 900 7200 750 7350 450 6750 750 7350 750 7200 300 6600 1050 7350 600 7350 600 7200 900 7350 750 6900 750 6900 900 6600 900 7350 1200 6600 1350 6900 900 7200 300 7050 600 7350 750 7200 300 6300 1050 6900 600 7050 900 6450 900 6150 1200 6750 750 7050 750 6750 750 6900 1050 6450 900 6450 900 6300 1200 7200 900 6600 750 6900 1200 7050 1200 7200 600 6750 1200 6900 750 6900 450 6900 600 6750 1650 5850 1500 7200 300 7200 600 6600 750 7200 900 6900 900 6900 450 6600 750 6750 1200 6750 600 7200 150 6900 1350 6300 1050 7200 600 7050 600 7200 1050 7050 450 7050 900 7200 750 6450 1200 6900 1050 6600 900 7050 750 6750 900 6900 600 7200 450 6900 600 7050 900 6600 1050 6900 600 7050 1350 7200 450 6450 900 7050 1350 7200 150 7050 750 6900 1050 7050 900 6750 600 7050 1800 6600 750 6300 1350 7200 600 7200 450 6600 900 6900 450 6750 600 6600 900 7050 300 7050 450 7050 750 6900 600 2875 575
- │ │ │ │ │ <--- '1992-01-01' ------ '1992-01-14' ------ '1992-01-25' ------ '1992-02-09' ------ '1992-02-23' ------ '1992-03-06' ------ '1992-03-19' ------ '1992-03-30' ------ '1992-04-12' ------ '1992-04-24' ------ '1992-05-07' ------ '1992-05-20' ------ '1992-05-31' ------ '1992-06-13' ------ '1992-06-27' ------ '1992-07-09' ------ '1992-07-21' ------ '1992-08-03' ------ '1992-08-17' ------ '1992-09-01' ------ '1992-09-13' ------ '1992-09-23' ------ '1992-10-06' ------ '1992-10-16' ------ '1992-10-29' ------ '1992-11-09' ------ '1992-11-20' ------ '1992-12-03' ------ '1992-12-14' ------ '1992-12-27' ------ '1993-01-09' ------ '1993-01-21' ------ '1993-02-01' ------ '1993-02-13' ------ '1993-02-23' ------ '1993-03-07' ------ '1993-03-17' ------ '1993-03-30' ------ '1993-04-12' ------ '1993-04-24' ------ '1993-05-08' ------ '1993-05-19' ------ '1993-06-01' ------ '1993-06-12' ------ '1993-06-20' ------ '1993-06-30' ------ '1993-07-11' ------ '1993-07-22' ------ '1993-08-02' ------ '1993-08-14' ------ '1993-08-25' ------ '1993-09-05' ------ '1993-09-16' ------ '1993-09-27' ------ '1993-10-10' ------ '1993-10-24' ------ '1993-11-04' ------ '1993-11-15' ------ '1993-11-27' ------ '1993-12-10' ------ '1993-12-25' ------ '1994-01-08' ------ '1994-01-19' ------ '1994-01-30' ------ '1994-02-12' ------ '1994-02-25' ------ '1994-03-06' ------ '1994-03-19' ------ '1994-03-31' ------ '1994-04-12' ------ '1994-04-22' ------ '1994-05-05' ------ '1994-05-19' ------ '1994-05-30' ------ '1994-06-10' ------ '1994-06-23' ------ '1994-07-05' ------ '1994-07-16' ------ '1994-07-25' ------ '1994-08-06' ------ '1994-08-18' ------ '1994-08-31' ------ '1994-09-10' ------ '1994-09-25' ------ '1994-10-06' ------ '1994-10-21' ------ '1994-11-01' ------ '1994-11-12' ------ '1994-11-27' ------ '1994-12-08' ------ '1994-12-21' ------ '1995-01-04' ------ '1995-01-17' ------ '1995-02-01' ------ '1995-02-11' ------ '1995-02-23' ------ '1995-03-08' ------ '1995-03-14'
+ │ │ │ │ ├── stats: [rows=728580, distinct(11)=728580, null(11)=0, avgsize(11)=4, distinct(12)=99841.4, null(12)=0, avgsize(12)=4, distinct(15)=1169, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=2]
+ │ │ │ │ │ histogram(15)= 0 450 6900 600 7350 600 6750 900 7050 1350 7350 1350 6750 900 6600 900 7350 600 7200 600 7350 1050 6900 750 6900 750 7350 450 7350 600 7200 750 7350 450 7200 750 7350 750 6150 1200 7050 300 7200 600 7200 300 6600 1350 7050 450 6750 600 7200 750 7050 450 6750 600 7200 900 7050 900 7050 750 7050 600 7200 750 6150 1200 7200 1200 6000 1350 6300 1200 7200 750 6750 1200 6600 900 7050 750 7050 450 7050 900 7200 450 7200 1050 6900 900 6300 1200 6750 600 7050 900 7050 450 6900 1200 6750 600 7050 750 6750 1350 7050 600 7050 300 7200 450 7050 600 6900 450 6900 450 7200 600 6600 900 6900 750 5700 1800 6900 750 6300 1050 7050 900 7200 300 7050 450 6600 750 6450 1200 6900 600 7050 1050 7050 450 6600 750 7050 600 6450 900 7050 600 7200 900 6750 900 7200 750 7200 1050 6750 600 6900 600 6900 1050 7050 450 7050 750 6000 1350 6750 900 6900 900 6900 900 7050 1050 6750 600 7050 900 1935 645
+ │ │ │ │ │ <--- '1992-01-01' ------ '1992-01-13' ------ '1992-01-25' ------ '1992-02-05' ------ '1992-02-18' ------ '1992-02-29' ------ '1992-03-12' ------ '1992-03-23' ------ '1992-04-05' ------ '1992-04-17' ------ '1992-04-30' ------ '1992-05-16' ------ '1992-05-28' ------ '1992-06-09' ------ '1992-06-22' ------ '1992-07-04' ------ '1992-07-15' ------ '1992-07-26' ------ '1992-08-09' ------ '1992-08-19' ------ '1992-09-01' ------ '1992-09-12' ------ '1992-09-23' ------ '1992-10-04' ------ '1992-10-17' ------ '1992-10-27' ------ '1992-11-06' ------ '1992-11-19' ------ '1992-11-30' ------ '1992-12-12' ------ '1992-12-23' ------ '1993-01-06' ------ '1993-01-18' ------ '1993-01-31' ------ '1993-02-08' ------ '1993-02-21' ------ '1993-03-01' ------ '1993-03-16' ------ '1993-03-27' ------ '1993-04-07' ------ '1993-04-21' ------ '1993-05-02' ------ '1993-05-14' ------ '1993-05-28' ------ '1993-06-08' ------ '1993-06-20' ------ '1993-07-02' ------ '1993-07-16' ------ '1993-07-29' ------ '1993-08-12' ------ '1993-08-25' ------ '1993-09-07' ------ '1993-09-22' ------ '1993-10-05' ------ '1993-10-18' ------ '1993-10-31' ------ '1993-11-14' ------ '1993-11-25' ------ '1993-12-06' ------ '1993-12-20' ------ '1994-01-03' ------ '1994-01-15' ------ '1994-01-23' ------ '1994-02-04' ------ '1994-02-15' ------ '1994-02-27' ------ '1994-03-09' ------ '1994-03-19' ------ '1994-04-05' ------ '1994-04-16' ------ '1994-04-29' ------ '1994-05-10' ------ '1994-05-24' ------ '1994-06-04' ------ '1994-06-16' ------ '1994-06-30' ------ '1994-07-16' ------ '1994-07-31' ------ '1994-08-13' ------ '1994-08-27' ------ '1994-09-08' ------ '1994-09-23' ------ '1994-10-06' ------ '1994-10-17' ------ '1994-10-28' ------ '1994-11-11' ------ '1994-11-25' ------ '1994-12-11' ------ '1994-12-22' ------ '1995-01-03' ------ '1995-01-17' ------ '1995-01-30' ------ '1995-02-09' ------ '1995-02-23' ------ '1995-03-10' ------ '1995-03-14'
│ │ │ │ ├── key: (11)
│ │ │ │ ├── fd: (11)-->(12,15,18)
│ │ │ │ ├── scan orders
│ │ │ │ │ ├── save-table-name: q3_scan_7
│ │ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) o_shippriority:18(int!null)
- │ │ │ │ │ ├── stats: [rows=1500000, distinct(11)=1.5e+06, null(11)=0, avgsize(11)=4, distinct(12)=99853, null(12)=0, avgsize(12)=4, distinct(15)=2406, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=4]
- │ │ │ │ │ │ histogram(11)= 0 0 0 0.99998 7461.9 0.99998 7285.9 0.99998 7544.9 0.99998 7589.9 0.99998 7222.9 0.99998 7324.9 0.99998 7506.9 0.99998 7351.9 0.99998 7777.9 0.99998 7576.9 0.99998 7731.9 0.99998 7694.9 0.99998 7586.9 0.99998 7569.9 0.99998 7757.9 0.99998 7624.9 0.99998 7506.9 0.99998 7245.9 0.99998 7820.9 0.99998 7539.9 0.99998 7455.9 0.99998 7589.9 0.99998 7740.9 0.99998 7604.9 0.99998 7710.9 0.99998 7709.9 0.99998 7708.9 0.99998 7490.9 0.99998 7527.9 0.99998 7331.9 0.99998 7311.9 0.99998 7576.9 0.99998 7545.9 0.99998 7277.9 0.99998 7392.9 0.99998 7508.9 0.99998 7622.9 0.99998 7581.9 0.99998 7775.9 0.99998 7523.9 0.99998 7568.9 0.99998 7483.9 0.99998 7662.9 0.99998 7368.9 0.99998 7470.9 0.99998 7380.9 0.99998 7647.9 0.99998 7381.9 0.99998 7635.9 0.99998 7490.9 0.99998 7446.9 0.99998 7526.9 0.99998 7441.9 0.99998 7265.9 0.99998 7960.9 0.99998 7251.9 0.99998 7514.9 0.99998 7294.9 0.99998 7502.9 0.99998 7285.9 0.99998 7320.9 0.99998 7235.9 0.99998 7451.9 0.99998 7810.9 0.99998 7378.9 0.99998 7418.9 0.99998 7661.9 0.99998 7404.9 0.99998 7432.9 0.99998 7579.9 0.99998 7836.9 0.99998 7445.9 0.99998 7355.9 0.99998 7617.9 0.99998 7110.9 0.99998 7398.9 0.99998 7622.9 0.99998 7655.9 0.99998 7433.9 0.99998 7656.9 0.99998 7404.9 0.99998 7474.9 0.99998 7572.9 0.99998 7688.9 0.99998 7559.9 0.99998 7414.9 0.99998 7523.9 0.99998 7558.9 0.99998 7330.9 0.99998 7587.9 0.99998 7388.9 0.99998 7327.9 0.99998 7671.9 0.99998 7523.9 0.99998 7687.9 0.99998 7524.9 0.99998 7614.9 0.99998 7463.9 0.99998 7594.9 0.99998 7372.9 0.99998 7670.9 0.99998 7310.9 0.99998 7270.9 0.99998 7399.9 0.99998 7688.9 0.99998 7487.9 0.99998 7556.9 0.99998 7365.9 0.99998 7521.9 0.99998 7762.9 0.99998 7386.9 0.99998 7399.9 0.99998 7562.9 0.99998 7502.9 0.99998 7201.9 0.99998 7595.9 0.99998 7525.9 0.99998 7451.9 0.99998 7280.9 0.99998 7307.9 0.99998 7386.9 0.99998 7345.9 0.99998 7383.9 0.99998 7530.9 0.99998 7706.9 0.99998 7581.9 0.99998 7512.9 0.99998 7536.9 0.99998 7210.9 0.99998 7689.9 0.99998 7658.9 0.99998 7358.9 0.99998 7646.9 0.99998 7252.9 0.99998 7327.9 0.99998 7525.9 0.99998 7564.9 0.99998 7524.9 0.99998 7438.9 0.99998 7493.9 0.99998 7419.9 0.99998 7509.9 0.99998 7595.9 0.99998 7396.9 0.99998 7378.9 0.99998 7330.9 0.99998 7387.9 0.99998 7552.9 0.99998 7330.9 0.99998 7431.9 0.99998 7773.9 0.99998 7853.9 0.99998 7562.9 0.99998 7548.9 0.99998 7847.9 0.99998 7933.9 0.99998 7768.9 0.99998 7738.9 0.99998 7480.9 0.99998 7679.9 0.99998 7663.9 0.99998 7587.9 0.99998 7527.9 0.99998 7466.9 0.99998 7444.9 0.99998 7519.9 0.99998 7830.9 0.99998 7568.9 0.99998 7671.9 0.99998 7637.9 0.99998 7462.9 0.99998 7851.9 0.99998 7483.9 0.99998 7765.9 0.99998 7451.9 0.99998 8050.9 0.99998 7644.9 0.99998 7724.9 0.99998 7471.9 0.99998 7517.9 0.99998 7830.9 0.99998 7387.9 0.99998 7749.9 0.99998 7545.9 0.99998 7718.9 0.99998 7384.9 0.99998 7464.9 0.99998 7467.9 0.99998 7809.9 0.99998 7766.9 0.99998 7511.9 0.99998 7641.9 0.99998 7711.9 0.99998 7729.9 0.99998 7631.9 0.99998 7734.9 0.99998 7931.9 0.99998 7586.9 0.99998 7964.9 0.99998 0 0
- │ │ │ │ │ │ <--- -9223372036854775808 --- 1472 --------- 30469 -------- 54689 -------- 85922 -------- 118369 -------- 140867 -------- 166146 -------- 196357 -------- 222375 -------- 259877 -------- 291970 -------- 328227 -------- 363490 -------- 395873 -------- 427783 -------- 464741 -------- 498146 -------- 528358 -------- 551493 -------- 590144 -------- 621254 -------- 650083 -------- 682531 -------- 719041 -------- 751906 -------- 787617 -------- 823298 -------- 858944 -------- 888739 -------- 919527 -------- 944996 -------- 969922 -------- 1002020 -------- 1033280 -------- 1057284 -------- 1084416 -------- 1114693 -------- 1148034 -------- 1180262 -------- 1217697 -------- 1248386 -------- 1280261 -------- 1309862 -------- 1344263 -------- 1370759 -------- 1400003 -------- 1426822 -------- 1460837 -------- 1487680 -------- 1521376 -------- 1551174 -------- 1579779 -------- 1610532 -------- 1638983 -------- 1662660 -------- 1705024 -------- 1728321 -------- 1758757 -------- 1783239 -------- 1813344 -------- 1837573 -------- 1862757 -------- 1885607 -------- 1914340 -------- 1952706 -------- 1979458 -------- 2007302 -------- 2041697 -------- 2069157 -------- 2097383 -------- 2129571 -------- 2168643 -------- 2197223 -------- 2223363 -------- 2256577 -------- 2275975 -------- 2303264 -------- 2336608 -------- 2370823 -------- 2399074 -------- 2433315 -------- 2460771 -------- 2490114 -------- 2522119 -------- 2557218 -------- 2588866 -------- 2616610 -------- 2647296 -------- 2678913 -------- 2704354 -------- 2736743 -------- 2763779 -------- 2789157 -------- 2823812 -------- 2854502 -------- 2889572 -------- 2920263 -------- 2953378 -------- 2982439 -------- 3015013 -------- 3041603 -------- 3076227 -------- 3101125 -------- 3124930 -------- 3152260 -------- 3187366 -------- 3217059 -------- 3248611 -------- 3275008 -------- 3305634 -------- 3342721 -------- 3369702 -------- 3397031 -------- 3428771 -------- 3458885 -------- 3480806 -------- 3513408 -------- 3544129 -------- 3572866 -------- 3596965 -------- 3621794 -------- 3648771 -------- 3674624 -------- 3701510 -------- 3732387 -------- 3767974 -------- 3800224 -------- 3830599 -------- 3861635 -------- 3883808 -------- 3918949 -------- 3953249 -------- 3979456 -------- 4013443 -------- 4036775 -------- 4062148 -------- 4092867 -------- 4124641 -------- 4155333 -------- 4183718 -------- 4213574 -------- 4241445 -------- 4271751 -------- 4304354 -------- 4331590 -------- 4358338 -------- 4383782 -------- 4410791 -------- 4442244 -------- 4467687 -------- 4495876 -------- 4529761 -------- 4565792 -------- 4593991 -------- 4621829 -------- 4657703 -------- 4695878 -------- 4729632 -------- 4762593 -------- 4788581 -------- 4819943 -------- 4850885 -------- 4879777 -------- 4907042 -------- 4932640 -------- 4957638 -------- 4984675 -------- 5020100 -------- 5048481 -------- 5079622 -------- 5109862 -------- 5135363 -------- 5171364 -------- 5197414 -------- 5231104 -------- 5256289 -------- 5297604 -------- 5328038 -------- 5360608 -------- 5386337 -------- 5413315 -------- 5448743 -------- 5472197 -------- 5505440 -------- 5533184 -------- 5565603 -------- 5588963 -------- 5614503 -------- 5640135 -------- 5675008 -------- 5708709 -------- 5735522 -------- 5765862 -------- 5798085 -------- 5830787 -------- 5860867 -------- 5893703 -------- 5931844 -------- 5960706 -------- 5999719 --- 9223372036854775807
- │ │ │ │ │ │ histogram(12)= 0 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7200 450 7350 150 7200 300 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7200 300 7350 150 7200 300 7350 300 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 450 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 300 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 150 7500 150 7350 300 7500 150 7500 150 7500 150 7500 150 7500 150
- │ │ │ │ │ │ <--- 25 ------ 758 ------ 1460 ------ 2207 ------ 2911 ------ 3766 ------ 4592 ------ 5371 ------ 6080 ------ 6773 ------ 7421 ------ 8009 ------ 8668 ------ 9583 ------ 10459 ------ 11120 ------ 11872 ------ 12722 ------ 13612 ------ 14390 ------ 15179 ------ 15862 ------ 16658 ------ 17234 ------ 18083 ------ 18862 ------ 19577 ------ 20138 ------ 20869 ------ 21644 ------ 22265 ------ 23105 ------ 23966 ------ 24782 ------ 25532 ------ 26317 ------ 27071 ------ 27664 ------ 28414 ------ 29291 ------ 30097 ------ 30917 ------ 31571 ------ 32357 ------ 33175 ------ 33820 ------ 34678 ------ 35311 ------ 35935 ------ 36689 ------ 37360 ------ 37969 ------ 38792 ------ 39442 ------ 40268 ------ 41044 ------ 41656 ------ 42370 ------ 43085 ------ 43909 ------ 44672 ------ 45326 ------ 46310 ------ 47150 ------ 47801 ------ 48563 ------ 49336 ------ 50111 ------ 50747 ------ 51631 ------ 52250 ------ 52873 ------ 53753 ------ 54632 ------ 55324 ------ 56141 ------ 56924 ------ 57524 ------ 58382 ------ 59069 ------ 59915 ------ 60779 ------ 61466 ------ 62306 ------ 63041 ------ 63799 ------ 64415 ------ 65452 ------ 66266 ------ 67055 ------ 67754 ------ 68510 ------ 69350 ------ 70127 ------ 70702 ------ 71462 ------ 72428 ------ 73267 ------ 74005 ------ 74719 ------ 75695 ------ 76400 ------ 77000 ------ 77953 ------ 78557 ------ 79315 ------ 79925 ------ 80530 ------ 81220 ------ 81902 ------ 82607 ------ 83179 ------ 84025 ------ 84970 ------ 85844 ------ 86657 ------ 87184 ------ 88037 ------ 88840 ------ 89531 ------ 90134 ------ 90893 ------ 91651 ------ 92528 ------ 93278 ------ 93944 ------ 94579 ------ 95708 ------ 96323 ------ 97174 ------ 97856 ------ 98602 ------ 99260 ------ 99967 ------ 100567 ------ 101209 ------ 101923 ------ 102734 ------ 103540 ------ 104402 ------ 105101 ------ 105854 ------ 106667 ------ 107584 ------ 108601 ------ 109366 ------ 110185 ------ 111109 ------ 112079 ------ 112712 ------ 113375 ------ 114088 ------ 114719 ------ 115409 ------ 116246 ------ 117028 ------ 117703 ------ 118441 ------ 119161 ------ 119911 ------ 120542 ------ 121391 ------ 122210 ------ 123049 ------ 123794 ------ 124418 ------ 125149 ------ 125963 ------ 126791 ------ 127537 ------ 128390 ------ 129067 ------ 129604 ------ 130400 ------ 131039 ------ 131752 ------ 132460 ------ 133154 ------ 133693 ------ 134515 ------ 135289 ------ 135959 ------ 136651 ------ 137456 ------ 138158 ------ 138947 ------ 139789 ------ 140599 ------ 141446 ------ 142318 ------ 143132 ------ 143698 ------ 144484 ------ 145376 ------ 146068 ------ 146774 ------ 147730 ------ 148436 ------ 149324 ------ 149992
- │ │ │ │ │ │ histogram(15)= 0 750 7350 450 6600 900 7200 750 7350 450 6750 750 7350 750 7200 300 6600 1050 7350 600 7350 600 7200 900 7350 750 6900 750 6900 900 6600 900 7350 1200 6600 1350 6900 900 7200 300 7050 600 7350 750 7200 300 6300 1050 6900 600 7050 900 6450 900 6150 1200 6750 750 7050 750 6750 750 6900 1050 6450 900 6450 900 6300 1200 7200 900 6600 750 6900 1200 7050 1200 7200 600 6750 1200 6900 750 6900 450 6900 600 6750 1650 5850 1500 7200 300 7200 600 6600 750 7200 900 6900 900 6900 450 6600 750 6750 1200 6750 600 7200 150 6900 1350 6300 1050 7200 600 7050 600 7200 1050 7050 450 7050 900 7200 750 6450 1200 6900 1050 6600 900 7050 750 6750 900 6900 600 7200 450 6900 600 7050 900 6600 1050 6900 600 7050 1350 7200 450 6450 900 7050 1350 7200 150 7050 750 6900 1050 7050 900 6750 600 7050 1800 6600 750 6300 1350 7200 600 7200 450 6600 900 6900 450 6750 600 6600 900 7050 300 7050 450 7050 750 6900 600 6900 750 7050 300 7050 450 7200 600 7200 750 7200 150 7050 750 6750 1050 7050 750 7050 450 6600 600 6750 600 7050 300 6750 900 6900 450 6900 450 6600 1050 7050 450 6300 1200 6750 600 6900 750 6600 750 6750 450 6750 600 7050 900 6750 600 6600 750 6900 600 6750 750 6750 750 6900 600 6600 600 6300 1050 7050 450 6750 1050 6750 750 6750 900 6900 450 6450 750 6900 300 6450 750 6900 1050 7050 600 6900 750 7050 750 6600 1200 6600 1050 6750 1050 6600 750 6900 600 7050 150 7050 450 6450 1200 6750 750 7050 600 6600 450 6750 750 6450 750 6750 750 6600 600 5700 1350 6300 900 6900 600 6750 750 6300 900 6450 600 6600 450 6000 1050 6750 450 6300 900 6900 900 6450 600 6900 750 6450 750 6600 1200 6750 450 6300 900 6600 600 6600 1200 6750 1200 6600 1050 6300 1050 6450 900 6600 450 6750 600 6300 600 6300 600 6000 1200 6450 1050 6150 750 6300 600 6600 600 6450 600 6600 900 5550 1200 6450 900 5550 1050 6000 900 5850 900 6300 300 6450 600 6450 450 5850 450
- │ │ │ │ │ │ <--- '1992-01-01' ------ '1992-01-14' ------ '1992-01-25' ------ '1992-02-09' ------ '1992-02-23' ------ '1992-03-06' ------ '1992-03-19' ------ '1992-03-30' ------ '1992-04-12' ------ '1992-04-24' ------ '1992-05-07' ------ '1992-05-20' ------ '1992-05-31' ------ '1992-06-13' ------ '1992-06-27' ------ '1992-07-09' ------ '1992-07-21' ------ '1992-08-03' ------ '1992-08-17' ------ '1992-09-01' ------ '1992-09-13' ------ '1992-09-23' ------ '1992-10-06' ------ '1992-10-16' ------ '1992-10-29' ------ '1992-11-09' ------ '1992-11-20' ------ '1992-12-03' ------ '1992-12-14' ------ '1992-12-27' ------ '1993-01-09' ------ '1993-01-21' ------ '1993-02-01' ------ '1993-02-13' ------ '1993-02-23' ------ '1993-03-07' ------ '1993-03-17' ------ '1993-03-30' ------ '1993-04-12' ------ '1993-04-24' ------ '1993-05-08' ------ '1993-05-19' ------ '1993-06-01' ------ '1993-06-12' ------ '1993-06-20' ------ '1993-06-30' ------ '1993-07-11' ------ '1993-07-22' ------ '1993-08-02' ------ '1993-08-14' ------ '1993-08-25' ------ '1993-09-05' ------ '1993-09-16' ------ '1993-09-27' ------ '1993-10-10' ------ '1993-10-24' ------ '1993-11-04' ------ '1993-11-15' ------ '1993-11-27' ------ '1993-12-10' ------ '1993-12-25' ------ '1994-01-08' ------ '1994-01-19' ------ '1994-01-30' ------ '1994-02-12' ------ '1994-02-25' ------ '1994-03-06' ------ '1994-03-19' ------ '1994-03-31' ------ '1994-04-12' ------ '1994-04-22' ------ '1994-05-05' ------ '1994-05-19' ------ '1994-05-30' ------ '1994-06-10' ------ '1994-06-23' ------ '1994-07-05' ------ '1994-07-16' ------ '1994-07-25' ------ '1994-08-06' ------ '1994-08-18' ------ '1994-08-31' ------ '1994-09-10' ------ '1994-09-25' ------ '1994-10-06' ------ '1994-10-21' ------ '1994-11-01' ------ '1994-11-12' ------ '1994-11-27' ------ '1994-12-08' ------ '1994-12-21' ------ '1995-01-04' ------ '1995-01-17' ------ '1995-02-01' ------ '1995-02-11' ------ '1995-02-23' ------ '1995-03-08' ------ '1995-03-21' ------ '1995-04-05' ------ '1995-04-18' ------ '1995-04-30' ------ '1995-05-13' ------ '1995-05-25' ------ '1995-06-08' ------ '1995-06-22' ------ '1995-07-07' ------ '1995-07-19' ------ '1995-07-29' ------ '1995-08-13' ------ '1995-08-24' ------ '1995-09-05' ------ '1995-09-20' ------ '1995-10-05' ------ '1995-10-14' ------ '1995-10-25' ------ '1995-11-06' ------ '1995-11-16' ------ '1995-11-26' ------ '1995-12-09' ------ '1995-12-21' ------ '1995-12-31' ------ '1996-01-11' ------ '1996-01-23' ------ '1996-02-03' ------ '1996-02-21' ------ '1996-03-02' ------ '1996-03-16' ------ '1996-03-27' ------ '1996-04-08' ------ '1996-04-20' ------ '1996-05-03' ------ '1996-05-13' ------ '1996-05-24' ------ '1996-06-06' ------ '1996-06-19' ------ '1996-06-30' ------ '1996-07-14' ------ '1996-07-25' ------ '1996-08-04' ------ '1996-08-19' ------ '1996-09-03' ------ '1996-09-14' ------ '1996-09-25' ------ '1996-10-09' ------ '1996-10-19' ------ '1996-11-01' ------ '1996-11-11' ------ '1996-11-23' ------ '1996-12-05' ------ '1996-12-19' ------ '1996-12-29' ------ '1997-01-12' ------ '1997-01-22' ------ '1997-02-06' ------ '1997-02-24' ------ '1997-03-08' ------ '1997-03-19' ------ '1997-04-01' ------ '1997-04-12' ------ '1997-04-23' ------ '1997-05-05' ------ '1997-05-15' ------ '1997-05-25' ------ '1997-06-07' ------ '1997-06-18' ------ '1997-07-02' ------ '1997-07-11' ------ '1997-07-24' ------ '1997-08-04' ------ '1997-08-17' ------ '1997-08-26' ------ '1997-09-09' ------ '1997-09-19' ------ '1997-09-28' ------ '1997-10-09' ------ '1997-10-19' ------ '1997-11-01' ------ '1997-11-13' ------ '1997-11-24' ------ '1997-12-05' ------ '1997-12-20' ------ '1997-12-30' ------ '1998-01-12' ------ '1998-01-23' ------ '1998-02-05' ------ '1998-02-17' ------ '1998-02-26' ------ '1998-03-12' ------ '1998-03-23' ------ '1998-04-03' ------ '1998-04-13' ------ '1998-04-24' ------ '1998-05-07' ------ '1998-05-19' ------ '1998-06-01' ------ '1998-06-13' ------ '1998-06-27' ------ '1998-07-12' ------ '1998-07-26' ------ '1998-08-02'
+ │ │ │ │ │ ├── stats: [rows=1500000, distinct(11)=1.5e+06, null(11)=0, avgsize(11)=4, distinct(12)=99846, null(12)=0, avgsize(12)=4, distinct(15)=2406, null(15)=0, avgsize(15)=4, distinct(18)=1, null(18)=0, avgsize(18)=2]
+ │ │ │ │ │ │ histogram(11)= 0 0 0 0.99998 7406.9 0.99998 7327.9 0.99998 7748.9 0.99998 7433.9 0.99998 8029.9 0.99998 7265.9 0.99998 7439.9 0.99998 7823.9 0.99998 7526.9 0.99998 7553.9 0.99998 7426.9 0.99998 7490.9 0.99998 7595.9 0.99998 7527.9 0.99998 7640.9 0.99998 7593.9 0.99998 7384.9 0.99998 7713.9 0.99998 7409.9 0.99998 7249.9 0.99998 7518.9 0.99998 7434.9 0.99998 7575.9 0.99998 7471.9 0.99998 7302.9 0.99998 7109.9 0.99998 7646.9 0.99998 7619.9 0.99998 7579.9 0.99998 7489.9 0.99998 7409.9 0.99998 7619.9 0.99998 7805.9 0.99998 7418.9 0.99998 7454.9 0.99998 7651.9 0.99998 7407.9 0.99998 7278.9 0.99998 7402.9 0.99998 7375.9 0.99998 7375.9 0.99998 7517.9 0.99998 7626.9 0.99998 7675.9 0.99998 7470.9 0.99998 7352.9 0.99998 7597.9 0.99998 7649.9 0.99998 7509.9 0.99998 7320.9 0.99998 7287.9 0.99998 7365.9 0.99998 7381.9 0.99998 7478.9 0.99998 7526.9 0.99998 7233.9 0.99998 7676.9 0.99998 7400.9 0.99998 7739.9 0.99998 7638.9 0.99998 7515.9 0.99998 7211.9 0.99998 7231.9 0.99998 7194.9 0.99998 7187.9 0.99998 7885.9 0.99998 7359.9 0.99998 7301.9 0.99998 7493.9 0.99998 7529.9 0.99998 7558.9 0.99998 7148.9 0.99998 7437.9 0.99998 7337.9 0.99998 7299.9 0.99998 7683.9 0.99998 7430.9 0.99998 7252.9 0.99998 7440.9 0.99998 7467.9 0.99998 7694.9 0.99998 7528.9 0.99998 7441.9 0.99998 7694.9 0.99998 7737.9 0.99998 7523.9 0.99998 7400.9 0.99998 7523.9 0.99998 7700.9 0.99998 7156.9 0.99998 7352.9 0.99998 7359.9 0.99998 7334.9 0.99998 7444.9 0.99998 7766.9 0.99998 7675.9 0.99998 7511.9 0.99998 7616.9 0.99998 7308.9 0.99998 7593.9 0.99998 7296.9 0.99998 7557.9 0.99998 7416.9 0.99998 7613.9 0.99998 7421.9 0.99998 7322.9 0.99998 7584.9 0.99998 7726.9 0.99998 7495.9 0.99998 7434.9 0.99998 7337.9 0.99998 7450.9 0.99998 7576.9 0.99998 7245.9 0.99998 7625.9 0.99998 7748.9 0.99998 7417.9 0.99998 7701.9 0.99998 7437.9 0.99998 7345.9 0.99998 7517.9 0.99998 7621.9 0.99998 7359.9 0.99998 7393.9 0.99998 7632.9 0.99998 7715.9 0.99998 7558.9 0.99998 7350.9 0.99998 7557.9 0.99998 7400.9 0.99998 7297.9 0.99998 7875.9 0.99998 7364.9 0.99998 7332.9 0.99998 7458.9 0.99998 7471.9 0.99998 7564.9 0.99998 7523.9 0.99998 7270.9 0.99998 7309.9 0.99998 7418.9 0.99998 7959.9 0.99998 7382.9 0.99998 7507.9 0.99998 7524.9 0.99998 7566.9 0.99998 7705.9 0.99998 7841.9 0.99998 7483.9 0.99998 7685.9 0.99998 7605.9 0.99998 7677.9 0.99998 7647.9 0.99998 7985.9 0.99998 7859.9 0.99998 7673.9 0.99998 7732.9 0.99998 7501.9 0.99998 7498.9 0.99998 7596.9 0.99998 7572.9 0.99998 7848.9 0.99998 7567.9 0.99998 7549.9 0.99998 7493.9 0.99998 7869.9 0.99998 7508.9 0.99998 7626.9 0.99998 7774.9 0.99998 7908.9 0.99998 7501.9 0.99998 7841.9 0.99998 7542.9 0.99998 7623.9 0.99998 7523.9 0.99998 7548.9 0.99998 7977.9 0.99998 7569.9 0.99998 7916.9 0.99998 7613.9 0.99998 7883.9 0.99998 7579.9 0.99998 8076.9 0.99998 7698.9 0.99998 7635.9 0.99998 7530.9 0.99998 7515.9 0.99998 7673.9 0.99998 7781.9 0.99998 7698.9 0.99998 7482.9 0.99998 7805.9 0.99998 7774.9 0.99998 7657.9 0.99998 7655.9 0.99998 7579.9 0.99998 7506.9 0.99998 7736.9 0.99998 7584.9 0.99998 0 0
+ │ │ │ │ │ │ <--- -9223372036854775808 --- 1505 --------- 29025 -------- 54400 -------- 91106 -------- 119366 -------- 163554 -------- 187236 -------- 215651 -------- 254373 -------- 285123 -------- 316614 -------- 344678 -------- 374465 -------- 407078 -------- 437861 -------- 471683 -------- 504230 -------- 531168 -------- 566951 -------- 594561 -------- 617825 -------- 648358 -------- 676640 -------- 708706 -------- 737986 -------- 762690 -------- 782081 -------- 816064 -------- 849318 -------- 881511 -------- 911271 -------- 938885 -------- 972135 -------- 1010370 -------- 1038212 -------- 1067041 -------- 1101158 -------- 1128704 -------- 1152742 -------- 1180165 -------- 1206852 -------- 1233537 -------- 1264064 -------- 1297504 -------- 1332260 -------- 1361504 -------- 1387553 -------- 1420224 -------- 1454275 -------- 1484580 -------- 1509766 -------- 1534050 -------- 1560452 -------- 1587299 -------- 1616771 -------- 1647526 -------- 1670343 -------- 1705121 -------- 1732486 -------- 1768967 -------- 1802725 -------- 1833189 -------- 1855398 -------- 1878146 -------- 1899877 -------- 1921414 -------- 1961765 -------- 1988000 -------- 2012672 -------- 2042529 -------- 2073381 -------- 2104999 -------- 2125477 -------- 2153825 -------- 2179462 -------- 2204065 -------- 2239044 -------- 2267205 -------- 2290530 -------- 2318977 -------- 2348134 -------- 2383399 -------- 2414215 -------- 2442695 -------- 2477955 -------- 2514372 -------- 2545062 -------- 2572418 -------- 2603108 -------- 2638534 -------- 2659232 -------- 2685286 -------- 2711527 -------- 2737088 -------- 2765639 -------- 2802818 -------- 2837570 -------- 2867911 -------- 2901088 -------- 2925954 -------- 2958501 -------- 2983042 -------- 3014626 -------- 3042406 -------- 3075489 -------- 3103425 -------- 3128673 -------- 3160994 -------- 3197125 -------- 3227043 -------- 3255328 -------- 3280965 -------- 3309669 -------- 3341767 -------- 3364898 -------- 3398305 -------- 3435008 -------- 3462818 -------- 3498272 -------- 3526631 -------- 3552485 -------- 3583014 -------- 3616322 -------- 3642566 -------- 3669732 -------- 3703330 -------- 3739170 -------- 3770791 -------- 3796804 -------- 3828387 -------- 3855751 -------- 3880321 -------- 3920422 -------- 3946818 -------- 3972322 -------- 4001250 -------- 4030533 -------- 4062306 -------- 4092992 -------- 4116803 -------- 4141697 -------- 4169536 -------- 4211878 -------- 4238753 -------- 4268994 -------- 4299686 -------- 4331525 -------- 4367079 -------- 4406277 -------- 4435878 -------- 4470914 -------- 4500294 -------- 4531617 -------- 4562114 -------- 4601666 -------- 4637856 -------- 4669060 -------- 4701861 -------- 4728416 -------- 4754881 -------- 4784001 -------- 4812482 -------- 4848389 -------- 4876741 -------- 4904612 -------- 4930945 -------- 4967397 -------- 4994146 -------- 5024099 -------- 5058023 -------- 5095527 -------- 5122081 -------- 5157798 -------- 5185472 -------- 5215332 -------- 5242497 -------- 5270338 -------- 5309699 -------- 5338112 -------- 5375843 -------- 5405441 -------- 5442277 -------- 5470945 -------- 5512930 -------- 5544807 -------- 5574980 -------- 5602340 -------- 5629280 -------- 5660482 -------- 5694599 -------- 5726466 -------- 5752519 -------- 5787268 -------- 5821185 -------- 5851973 -------- 5882689 -------- 5911363 -------- 5938052 -------- 5970949 -------- 5999748 --- 9223372036854775807
+ │ │ │ │ │ │ histogram(12)= 0 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7200 450 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 300 7350 300 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7500 150 7500 300 7350 150 7500 300 7350 150 7500 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 300 7350 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150
+ │ │ │ │ │ │ <--- 4 ------ 959 ------ 1858 ------ 2773 ------ 3466 ------ 4333 ------ 5026 ------ 5872 ------ 6571 ------ 7069 ------ 7897 ------ 8611 ------ 9514 ------ 10309 ------ 11038 ------ 11893 ------ 12632 ------ 13450 ------ 14104 ------ 14923 ------ 15719 ------ 16382 ------ 17119 ------ 17882 ------ 18701 ------ 19576 ------ 20314 ------ 20950 ------ 21727 ------ 22261 ------ 23059 ------ 23692 ------ 24488 ------ 25144 ------ 25895 ------ 26747 ------ 27650 ------ 28408 ------ 29140 ------ 29920 ------ 30511 ------ 31261 ------ 31999 ------ 32920 ------ 33688 ------ 34525 ------ 35197 ------ 35876 ------ 36580 ------ 37313 ------ 37924 ------ 38768 ------ 39440 ------ 40127 ------ 41005 ------ 41810 ------ 42422 ------ 43310 ------ 44095 ------ 44644 ------ 45347 ------ 45970 ------ 46634 ------ 47284 ------ 48055 ------ 48850 ------ 49712 ------ 50356 ------ 51268 ------ 52048 ------ 52571 ------ 53125 ------ 54088 ------ 54913 ------ 55771 ------ 56386 ------ 57085 ------ 57877 ------ 58729 ------ 59353 ------ 60133 ------ 60947 ------ 61672 ------ 62411 ------ 63296 ------ 64000 ------ 64586 ------ 65251 ------ 65914 ------ 66403 ------ 66991 ------ 67798 ------ 68494 ------ 69406 ------ 70106 ------ 70921 ------ 71770 ------ 72482 ------ 73256 ------ 74083 ------ 74681 ------ 75412 ------ 76201 ------ 76876 ------ 77684 ------ 78421 ------ 79058 ------ 79909 ------ 80591 ------ 81247 ------ 81964 ------ 82835 ------ 83731 ------ 84467 ------ 85012 ------ 85874 ------ 86647 ------ 87151 ------ 87853 ------ 88543 ------ 89425 ------ 90046 ------ 90640 ------ 91544 ------ 92257 ------ 93107 ------ 93835 ------ 94424 ------ 95383 ------ 96313 ------ 96938 ------ 97808 ------ 98689 ------ 99505 ------ 100144 ------ 100981 ------ 101797 ------ 102556 ------ 103504 ------ 104113 ------ 104980 ------ 105622 ------ 106241 ------ 106988 ------ 107578 ------ 108302 ------ 108905 ------ 109765 ------ 110663 ------ 111409 ------ 112093 ------ 113033 ------ 113683 ------ 114346 ------ 115006 ------ 115798 ------ 116261 ------ 116908 ------ 117610 ------ 118319 ------ 119203 ------ 120058 ------ 120922 ------ 121702 ------ 122486 ------ 123253 ------ 124142 ------ 124795 ------ 125689 ------ 126277 ------ 126904 ------ 127684 ------ 128251 ------ 129032 ------ 129916 ------ 130717 ------ 131554 ------ 132482 ------ 133408 ------ 134272 ------ 135073 ------ 135869 ------ 136963 ------ 137806 ------ 138412 ------ 139103 ------ 139982 ------ 140794 ------ 141455 ------ 142396 ------ 143047 ------ 143788 ------ 144620 ------ 145336 ------ 146170 ------ 147014 ------ 147769 ------ 148508 ------ 149234 ------ 149995
+ │ │ │ │ │ │ histogram(15)= 0 450 6900 600 7350 600 6750 900 7050 1350 7350 1350 6750 900 6600 900 7350 600 7200 600 7350 1050 6900 750 6900 750 7350 450 7350 600 7200 750 7350 450 7200 750 7350 750 6150 1200 7050 300 7200 600 7200 300 6600 1350 7050 450 6750 600 7200 750 7050 450 6750 600 7200 900 7050 900 7050 750 7050 600 7200 750 6150 1200 7200 1200 6000 1350 6300 1200 7200 750 6750 1200 6600 900 7050 750 7050 450 7050 900 7200 450 7200 1050 6900 900 6300 1200 6750 600 7050 900 7050 450 6900 1200 6750 600 7050 750 6750 1350 7050 600 7050 300 7200 450 7050 600 6900 450 6900 450 7200 600 6600 900 6900 750 5700 1800 6900 750 6300 1050 7050 900 7200 300 7050 450 6600 750 6450 1200 6900 600 7050 1050 7050 450 6600 750 7050 600 6450 900 7050 600 7200 900 6750 900 7200 750 7200 1050 6750 600 6900 600 6900 1050 7050 450 7050 750 6000 1350 6750 900 6900 900 6900 900 7050 1050 6750 600 7050 900 6450 900 7050 300 6600 750 7050 1350 7200 450 7200 750 7200 600 6300 900 7050 750 6450 900 6900 900 6600 600 6600 600 6900 750 7050 600 6150 1050 6750 600 6600 600 7050 900 7050 1650 6750 600 6750 600 6750 450 7050 1050 6900 1350 6600 600 6300 900 6600 600 6300 1050 6750 900 6300 900 7050 1200 6600 1200 6750 750 6900 900 6750 600 6750 600 6150 1200 6450 1050 7050 750 6300 1050 7050 450 6750 600 6750 600 7050 600 7050 900 6900 600 6900 900 6900 600 6450 1200 6600 450 6900 450 6750 600 6750 750 6750 1350 6750 450 6600 750 6600 450 6450 750 6450 600 6750 600 6900 900 6300 750 6450 1200 6000 1500 6900 900 6000 1200 6300 750 6450 600 6900 1050 6600 600 6900 1650 5850 1050 6600 750 6600 450 6300 900 6600 300 6600 600 6750 900 6750 450 6600 750 6600 300 6150 900 6750 600 5850 1050 6750 450 6750 750 6600 900 6150 600 6600 450 6150 750 6600 1350 6600 450 6000 1200 5550 1350 6150 450 6300 450 6450 900 6450 750 6000 1650 5850 750 6000 450 5250 900 5400 1050 5400 600
+ │ │ │ │ │ │ <--- '1992-01-01' ------ '1992-01-13' ------ '1992-01-25' ------ '1992-02-05' ------ '1992-02-18' ------ '1992-02-29' ------ '1992-03-12' ------ '1992-03-23' ------ '1992-04-05' ------ '1992-04-17' ------ '1992-04-30' ------ '1992-05-16' ------ '1992-05-28' ------ '1992-06-09' ------ '1992-06-22' ------ '1992-07-04' ------ '1992-07-15' ------ '1992-07-26' ------ '1992-08-09' ------ '1992-08-19' ------ '1992-09-01' ------ '1992-09-12' ------ '1992-09-23' ------ '1992-10-04' ------ '1992-10-17' ------ '1992-10-27' ------ '1992-11-06' ------ '1992-11-19' ------ '1992-11-30' ------ '1992-12-12' ------ '1992-12-23' ------ '1993-01-06' ------ '1993-01-18' ------ '1993-01-31' ------ '1993-02-08' ------ '1993-02-21' ------ '1993-03-01' ------ '1993-03-16' ------ '1993-03-27' ------ '1993-04-07' ------ '1993-04-21' ------ '1993-05-02' ------ '1993-05-14' ------ '1993-05-28' ------ '1993-06-08' ------ '1993-06-20' ------ '1993-07-02' ------ '1993-07-16' ------ '1993-07-29' ------ '1993-08-12' ------ '1993-08-25' ------ '1993-09-07' ------ '1993-09-22' ------ '1993-10-05' ------ '1993-10-18' ------ '1993-10-31' ------ '1993-11-14' ------ '1993-11-25' ------ '1993-12-06' ------ '1993-12-20' ------ '1994-01-03' ------ '1994-01-15' ------ '1994-01-23' ------ '1994-02-04' ------ '1994-02-15' ------ '1994-02-27' ------ '1994-03-09' ------ '1994-03-19' ------ '1994-04-05' ------ '1994-04-16' ------ '1994-04-29' ------ '1994-05-10' ------ '1994-05-24' ------ '1994-06-04' ------ '1994-06-16' ------ '1994-06-30' ------ '1994-07-16' ------ '1994-07-31' ------ '1994-08-13' ------ '1994-08-27' ------ '1994-09-08' ------ '1994-09-23' ------ '1994-10-06' ------ '1994-10-17' ------ '1994-10-28' ------ '1994-11-11' ------ '1994-11-25' ------ '1994-12-11' ------ '1994-12-22' ------ '1995-01-03' ------ '1995-01-17' ------ '1995-01-30' ------ '1995-02-09' ------ '1995-02-23' ------ '1995-03-10' ------ '1995-03-21' ------ '1995-04-04' ------ '1995-04-15' ------ '1995-04-27' ------ '1995-05-12' ------ '1995-05-26' ------ '1995-06-04' ------ '1995-06-13' ------ '1995-06-26' ------ '1995-07-08' ------ '1995-07-19' ------ '1995-07-31' ------ '1995-08-12' ------ '1995-08-21' ------ '1995-09-04' ------ '1995-09-13' ------ '1995-09-25' ------ '1995-10-06' ------ '1995-10-22' ------ '1995-10-30' ------ '1995-11-11' ------ '1995-11-23' ------ '1995-12-06' ------ '1995-12-19' ------ '1996-01-01' ------ '1996-01-13' ------ '1996-01-23' ------ '1996-02-03' ------ '1996-02-14' ------ '1996-02-24' ------ '1996-03-05' ------ '1996-03-17' ------ '1996-03-26' ------ '1996-04-09' ------ '1996-04-21' ------ '1996-05-03' ------ '1996-05-15' ------ '1996-05-28' ------ '1996-06-06' ------ '1996-06-16' ------ '1996-06-27' ------ '1996-07-11' ------ '1996-07-24' ------ '1996-08-07' ------ '1996-08-20' ------ '1996-09-04' ------ '1996-09-17' ------ '1996-10-05' ------ '1996-10-18' ------ '1996-10-29' ------ '1996-11-07' ------ '1996-11-20' ------ '1996-11-30' ------ '1996-12-15' ------ '1996-12-30' ------ '1997-01-13' ------ '1997-01-25' ------ '1997-02-05' ------ '1997-02-15' ------ '1997-02-24' ------ '1997-03-06' ------ '1997-03-18' ------ '1997-03-30' ------ '1997-04-09' ------ '1997-04-21' ------ '1997-05-01' ------ '1997-05-12' ------ '1997-05-24' ------ '1997-06-04' ------ '1997-06-15' ------ '1997-06-28' ------ '1997-07-10' ------ '1997-07-20' ------ '1997-07-30' ------ '1997-08-13' ------ '1997-08-24' ------ '1997-09-04' ------ '1997-09-16' ------ '1997-09-29' ------ '1997-10-15' ------ '1997-10-30' ------ '1997-11-13' ------ '1997-11-25' ------ '1997-12-06' ------ '1997-12-18' ------ '1997-12-30' ------ '1998-01-10' ------ '1998-01-23' ------ '1998-02-02' ------ '1998-02-15' ------ '1998-02-28' ------ '1998-03-11' ------ '1998-03-24' ------ '1998-04-03' ------ '1998-04-12' ------ '1998-04-24' ------ '1998-05-05' ------ '1998-05-18' ------ '1998-05-31' ------ '1998-06-11' ------ '1998-06-20' ------ '1998-06-30' ------ '1998-07-12' ------ '1998-07-23' ------ '1998-08-02'
│ │ │ │ │ │ histogram(18)= 0 1.5e+06
│ │ │ │ │ │ <----- 0 --
│ │ │ │ │ ├── key: (11)
@@ -106,18 +106,18 @@ top-k
│ │ │ ├── select
│ │ │ │ ├── save-table-name: q3_select_8
│ │ │ │ ├── columns: c_custkey:1(int!null) c_mktsegment:7(char!null)
- │ │ │ │ ├── stats: [rows=30165, distinct(1)=30139, null(1)=0, avgsize(1)=4, distinct(7)=1, null(7)=0, avgsize(7)=4]
- │ │ │ │ │ histogram(7)= 0 30165
+ │ │ │ │ ├── stats: [rows=30550, distinct(1)=30523.3, null(1)=0, avgsize(1)=4, distinct(7)=1, null(7)=0, avgsize(7)=11]
+ │ │ │ │ │ histogram(7)= 0 30550
│ │ │ │ │ <--- 'BUILDING'
│ │ │ │ ├── key: (1)
│ │ │ │ ├── fd: ()-->(7)
│ │ │ │ ├── scan customer
│ │ │ │ │ ├── save-table-name: q3_scan_9
│ │ │ │ │ ├── columns: c_custkey:1(int!null) c_mktsegment:7(char!null)
- │ │ │ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(7)=5, null(7)=0, avgsize(7)=4]
- │ │ │ │ │ │ histogram(1)= 0 5 769 5 765 5 732 5 744 5 731 5 754 5 772 5 757 5 713 5 741 5 808 5 744 5 739 5 687 5 820 5 761 5 782 5 632 5 711 5 692 5 648 5 770 5 765 5 702 5 751 5 807 5 794 5 735 5 807 5 719 5 773 5 781 5 684 5 748 5 682 5 703 5 794 5 718 5 807 5 674 5 747 5 677 5 813 5 666 5 766 5 822 5 703 5 676 5 765 5 693 5 723 5 780 5 793 5 770 5 696 5 775 5 764 5 884 5 696 5 688 5 637 5 789 5 702 5 732 5 697 5 769 5 739 5 744 5 861 5 791 5 726 5 793 5 730 5 763 5 789 5 797 5 775 5 862 5 780 5 746 5 783 5 743 5 822 5 806 5 775 5 727 5 724 5 799 5 707 5 757 5 614 5 747 5 704 5 740 5 749 5 735 5 741 5 807 5 827 5 816 5 702 5 699 5 803 5 793 5 672 5 831 5 694 5 746 5 731 5 686 5 685 5 695 5 828 5 756 5 722 5 749 5 790 5 758 5 750 5 782 5 733 5 778 5 762 5 758 5 731 5 778 5 663 5 696 5 684 5 796 5 770 5 656 5 690 5 747 5 782 5 785 5 751 5 697 5 663 5 766 5 695 5 866 5 813 5 765 5 901 5 747 5 683 5 706 5 689 5 734 5 715 5 752 5 855 5 771 5 717 5 794 5 760 5 827 5 747 5 757 5 767 5 726 5 690 5 787 5 783 5 744 5 761 5 746 5 793 5 696 5 749 5 745 5 755 5 800 5 778 5 814 5 826 5 700 5 740 5 773 5 713 5 824 5 792 5 702 5 734 5 751 5 716 5 718 5 722 5 784 5 778 5 700 5 714 5 739 5 748 5 697 5 751 5 663 5 740 5
- │ │ │ │ │ │ <--- 37 ----- 834 ----- 1623 ----- 2351 ----- 3101 ----- 3828 ----- 4598 ----- 5401 ----- 6176 ----- 6868 ----- 7613 ----- 8479 ----- 9230 ----- 9972 ----- 10613 ----- 11500 ----- 12282 ----- 13103 ----- 13624 ----- 14312 ----- 14962 ----- 15520 ----- 16319 ----- 17109 ----- 17780 ----- 18543 ----- 19408 ----- 20250 ----- 20984 ----- 21848 ----- 22551 ----- 23355 ----- 24174 ----- 24809 ----- 25567 ----- 26196 ----- 26868 ----- 27710 ----- 28412 ----- 29276 ----- 29889 ----- 30645 ----- 31264 ----- 32139 ----- 32736 ----- 33527 ----- 34418 ----- 35091 ----- 35709 ----- 36498 ----- 37150 ----- 37861 ----- 38677 ----- 39517 ----- 40316 ----- 40975 ----- 41782 ----- 42569 ----- 43565 ----- 44224 ----- 44867 ----- 45399 ----- 46231 ----- 46902 ----- 47630 ----- 48291 ----- 49087 ----- 49829 ----- 50580 ----- 51538 ----- 52375 ----- 53092 ----- 53932 ----- 54656 ----- 55442 ----- 56274 ----- 57121 ----- 57929 ----- 58888 ----- 59705 ----- 60460 ----- 61282 ----- 62031 ----- 62922 ----- 63785 ----- 64593 ----- 65311 ----- 66024 ----- 66875 ----- 67556 ----- 68331 ----- 68808 ----- 69564 ----- 70239 ----- 70983 ----- 71744 ----- 72478 ----- 73223 ----- 74088 ----- 74988 ----- 75868 ----- 76539 ----- 77203 ----- 78061 ----- 78901 ----- 79510 ----- 80417 ----- 81071 ----- 81826 ----- 82553 ----- 83191 ----- 83828 ----- 84485 ----- 85386 ----- 86159 ----- 86868 ----- 87628 ----- 88463 ----- 89240 ----- 90002 ----- 90822 ----- 91553 ----- 92367 ----- 93152 ----- 93929 ----- 94656 ----- 95470 ----- 96061 ----- 96720 ----- 97355 ----- 98200 ----- 98998 ----- 99573 ----- 100219 ----- 100975 ----- 101795 ----- 102620 ----- 103384 ----- 104044 ----- 104635 ----- 105426 ----- 106083 ----- 107049 ----- 107925 ----- 108715 ----- 109740 ----- 110496 ----- 111128 ----- 111807 ----- 112451 ----- 113184 ----- 113866 ----- 114619 ----- 115556 ----- 116344 ----- 117029 ----- 117859 ----- 118626 ----- 119515 ----- 120258 ----- 121021 ----- 121802 ----- 122505 ----- 123136 ----- 123953 ----- 124763 ----- 125501 ----- 126271 ----- 127012 ----- 127841 ----- 128483 ----- 129230 ----- 129970 ----- 130729 ----- 131569 ----- 132370 ----- 133235 ----- 134122 ----- 134773 ----- 135503 ----- 136294 ----- 136971 ----- 137854 ----- 138681 ----- 139336 ----- 140055 ----- 140806 ----- 141489 ----- 142177 ----- 142873 ----- 143685 ----- 144486 ----- 145138 ----- 145817 ----- 146545 ----- 147291 ----- 147936 ----- 148687 ----- 149260 ----- 149990
- │ │ │ │ │ │ histogram(7)= 0 28890 90495 30615
+ │ │ │ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(7)=5, null(7)=0, avgsize(7)=11]
+ │ │ │ │ │ │ histogram(1)= 0 0 0 5 745 5 746 5 711 5 780 5 738 5 835 5 697 5 757 5 704 5 696 5 753 5 678 5 813 5 873 5 736 5 840 5 703 5 745 5 710 5 763 5 742 5 673 5 702 5 793 5 732 5 752 5 707 5 751 5 722 5 814 5 789 5 671 5 643 5 706 5 723 5 757 5 713 5 760 5 766 5 711 5 858 5 702 5 695 5 697 5 823 5 857 5 712 5 808 5 754 5 739 5 694 5 782 5 792 5 751 5 758 5 749 5 798 5 685 5 692 5 792 5 710 5 771 5 724 5 853 5 713 5 823 5 772 5 656 5 763 5 672 5 735 5 810 5 786 5 709 5 731 5 702 5 708 5 669 5 733 5 744 5 758 5 800 5 682 5 716 5 716 5 729 5 778 5 721 5 766 5 820 5 757 5 739 5 799 5 780 5 710 5 749 5 754 5 750 5 699 5 821 5 759 5 818 5 763 5 854 5 779 5 810 5 783 5 686 5 703 5 776 5 675 5 812 5 745 5 759 5 793 5 751 5 761 5 798 5 794 5 729 5 696 5 699 5 831 5 709 5 747 5 722 5 768 5 729 5 702 5 729 5 698 5 767 5 792 5 726 5 737 5 671 5 721 5 842 5 701 5 704 5 708 5 726 5 695 5 665 5 688 5 653 5 690 5 734 5 789 5 659 5 785 5 733 5 740 5 826 5 745 5 929 5 899 5 743 5 790 5 825 5 779 5 677 5 697 5 756 5 693 5 862 5 772 5 783 5 757 5 799 5 778 5 752 5 715 5 709 5 790 5 789 5 865 5 808 5 772 5 743 5 751 5 742 5 676 5 684 5 744 5 709 5 679 5 817 5 755 5 754 5 797 5 709 5 748 5 679 5 751 5 775 5 736 5 790 5 714 5 0 0
+ │ │ │ │ │ │ <--- -9223372036854775808 --- 59 ----- 811 ----- 1565 ----- 2252 ----- 3068 ----- 3807 ----- 4720 ----- 5381 ----- 6155 ----- 6829 ----- 7487 ----- 8254 ----- 8876 ----- 9751 ----- 10728 ----- 11463 ----- 12385 ----- 13057 ----- 13810 ----- 14495 ----- 15281 ----- 16028 ----- 16640 ----- 17311 ----- 18151 ----- 18880 ----- 19645 ----- 20325 ----- 21088 ----- 21798 ----- 22674 ----- 23507 ----- 24115 ----- 24661 ----- 25340 ----- 26052 ----- 26827 ----- 27518 ----- 28298 ----- 29089 ----- 29777 ----- 30730 ----- 31401 ----- 32057 ----- 32718 ----- 33611 ----- 34562 ----- 35251 ----- 36117 ----- 36887 ----- 37629 ----- 38283 ----- 39104 ----- 39942 ----- 40705 ----- 41481 ----- 42241 ----- 43089 ----- 43725 ----- 44376 ----- 45214 ----- 45899 ----- 46700 ----- 47413 ----- 48356 ----- 49047 ----- 49939 ----- 50742 ----- 51316 ----- 52101 ----- 52710 ----- 53444 ----- 54313 ----- 55140 ----- 55823 ----- 56549 ----- 57219 ----- 57901 ----- 58503 ----- 59234 ----- 59984 ----- 60760 ----- 61613 ----- 62243 ----- 62941 ----- 63638 ----- 64360 ----- 65173 ----- 65880 ----- 66672 ----- 67560 ----- 68334 ----- 69075 ----- 69925 ----- 70742 ----- 71428 ----- 72189 ----- 72958 ----- 73720 ----- 74385 ----- 75274 ----- 76053 ----- 76936 ----- 77721 ----- 78666 ----- 79480 ----- 80349 ----- 81171 ----- 81810 ----- 82482 ----- 83292 ----- 83907 ----- 84780 ----- 85532 ----- 86310 ----- 87149 ----- 87912 ----- 88694 ----- 89543 ----- 90384 ----- 91106 ----- 91764 ----- 92428 ----- 93335 ----- 94018 ----- 94775 ----- 95484 ----- 96279 ----- 97001 ----- 97672 ----- 98394 ----- 99056 ----- 99850 ----- 100688 ----- 101405 ----- 102143 ----- 102751 ----- 103459 ----- 104384 ----- 105052 ----- 105727 ----- 106409 ----- 107125 ----- 107782 ----- 108377 ----- 109020 ----- 109588 ----- 110235 ----- 110967 ----- 111800 ----- 112382 ----- 113196 ----- 113913 ----- 114643 ----- 115529 ----- 116268 ----- 117329 ----- 118341 ----- 119076 ----- 119898 ----- 120782 ----- 121584 ----- 122186 ----- 122830 ----- 123591 ----- 124227 ----- 125175 ----- 125964 ----- 126773 ----- 127535 ----- 128374 ----- 129175 ----- 129928 ----- 130609 ----- 131279 ----- 132102 ----- 132923 ----- 133877 ----- 134732 ----- 135521 ----- 136257 ----- 137007 ----- 137740 ----- 138341 ----- 138958 ----- 139695 ----- 140364 ----- 140971 ----- 141841 ----- 142600 ----- 143356 ----- 144192 ----- 144861 ----- 145607 ----- 146214 ----- 146965 ----- 147761 ----- 148483 ----- 149306 ----- 149986 --- 9223372036854775807
+ │ │ │ │ │ │ histogram(7)= 0 29085 91650 29265
│ │ │ │ │ │ <--- 'AUTOMOBILE' ------- 'MACHINERY'
│ │ │ │ │ ├── key: (1)
│ │ │ │ │ └── fd: (1)-->(7)
@@ -158,10 +158,10 @@ column_names row_count distinct_count null_count
{sum} 11620 11601 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_orderkey} 364699.00 31.39 <== 364699.00 31.41 <== 0.00 1.00
-{o_orderdate} 364699.00 31.39 <== 364699.00 3039.16 <== 0.00 1.00
-{o_shippriority} 364699.00 31.39 <== 364699.00 364699.00 <== 0.00 1.00
-{sum} 364699.00 31.39 <== 364699.00 31.44 <== 0.00 1.00
+{l_orderkey} 358457.00 30.85 <== 358457.00 30.87 <== 0.00 1.00
+{o_orderdate} 358457.00 30.85 <== 358457.00 2987.14 <== 0.00 1.00
+{o_shippriority} 358457.00 30.85 <== 358457.00 358457.00 <== 0.00 1.00
+{sum} 358457.00 30.85 <== 358457.00 30.90 <== 0.00 1.00
----Stats for q3_project_3----
column_names row_count distinct_count null_count
@@ -171,10 +171,10 @@ column_names row_count distinct_count null_count
{o_shippriority} 30519 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column40} 501066.00 16.42 <== 415698.00 13.66 <== 0.00 1.00
-{l_orderkey} 501066.00 16.42 <== 364699.00 31.41 <== 0.00 1.00
-{o_orderdate} 501066.00 16.42 <== 1169.00 9.74 <== 0.00 1.00
-{o_shippriority} 501066.00 16.42 <== 1.00 1.00 0.00 1.00
+{column40} 493436.00 16.17 <== 408763.00 13.44 <== 0.00 1.00
+{l_orderkey} 493436.00 16.17 <== 358457.00 30.87 <== 0.00 1.00
+{o_orderdate} 493436.00 16.17 <== 1169.00 9.74 <== 0.00 1.00
+{o_shippriority} 493436.00 16.17 <== 1.00 1.00 0.00 1.00
----Stats for q3_lookup_join_4----
column_names row_count distinct_count null_count
@@ -190,16 +190,16 @@ column_names row_count distinct_count null_count
{o_shippriority} 30519 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 501066.00 16.42 <== 30139.00 3.49 <== 0.00 1.00
-{c_mktsegment} 501066.00 16.42 <== 1.00 1.00 0.00 1.00
-{l_discount} 501066.00 16.42 <== 11.00 1.00 0.00 1.00
-{l_extendedprice} 501066.00 16.42 <== 371185.00 12.36 <== 0.00 1.00
-{l_orderkey} 501066.00 16.42 <== 364699.00 31.41 <== 0.00 1.00
-{l_shipdate} 501066.00 16.42 <== 1354.00 11.28 <== 0.00 1.00
-{o_custkey} 501066.00 16.42 <== 30139.00 3.49 <== 0.00 1.00
-{o_orderdate} 501066.00 16.42 <== 1169.00 9.74 <== 0.00 1.00
-{o_orderkey} 501066.00 16.42 <== 364699.00 31.41 <== 0.00 1.00
-{o_shippriority} 501066.00 16.42 <== 1.00 1.00 0.00 1.00
+{c_custkey} 493436.00 16.17 <== 30523.00 3.53 <== 0.00 1.00
+{c_mktsegment} 493436.00 16.17 <== 1.00 1.00 0.00 1.00
+{l_discount} 493436.00 16.17 <== 11.00 1.00 0.00 1.00
+{l_extendedprice} 493436.00 16.17 <== 362999.00 12.08 <== 0.00 1.00
+{l_orderkey} 493436.00 16.17 <== 358457.00 30.87 <== 0.00 1.00
+{l_shipdate} 493436.00 16.17 <== 1355.00 11.29 <== 0.00 1.00
+{o_custkey} 493436.00 16.17 <== 30523.00 3.53 <== 0.00 1.00
+{o_orderdate} 493436.00 16.17 <== 1169.00 9.74 <== 0.00 1.00
+{o_orderkey} 493436.00 16.17 <== 358457.00 30.87 <== 0.00 1.00
+{o_shippriority} 493436.00 16.17 <== 1.00 1.00 0.00 1.00
----Stats for q3_inner_join_5----
column_names row_count distinct_count null_count
@@ -211,12 +211,12 @@ column_names row_count distinct_count null_count
{o_shippriority} 147126 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 224947.00 1.53 30139.00 1.50 0.00 1.00
-{c_mktsegment} 224947.00 1.53 1.00 1.00 0.00 1.00
-{o_custkey} 224947.00 1.53 30139.00 1.50 0.00 1.00
-{o_orderdate} 224947.00 1.53 1169.00 1.00 0.00 1.00
-{o_orderkey} 224947.00 1.53 194147.00 1.34 0.00 1.00
-{o_shippriority} 224947.00 1.53 1.00 1.00 0.00 1.00
+{c_custkey} 222935.00 1.52 30523.00 1.52 0.00 1.00
+{c_mktsegment} 222935.00 1.52 1.00 1.00 0.00 1.00
+{o_custkey} 222935.00 1.52 30523.00 1.52 0.00 1.00
+{o_orderdate} 222935.00 1.52 1169.00 1.00 0.00 1.00
+{o_orderkey} 222935.00 1.52 192056.00 1.32 0.00 1.00
+{o_shippriority} 222935.00 1.52 1.00 1.00 0.00 1.00
----Stats for q3_select_6----
column_names row_count distinct_count null_count
@@ -226,10 +226,10 @@ column_names row_count distinct_count null_count
{o_shippriority} 727305 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_custkey} 744600.00 1.02 99850.00 1.00 0.00 1.00
-{o_orderdate} 744600.00 1.02 1169.00 1.00 0.00 1.00
-{o_orderkey} 744600.00 1.02 744600.00 1.02 0.00 1.00
-{o_shippriority} 744600.00 1.02 1.00 1.00 0.00 1.00
+{o_custkey} 728580.00 1.00 99841.00 1.00 0.00 1.00
+{o_orderdate} 728580.00 1.00 1169.00 1.00 0.00 1.00
+{o_orderkey} 728580.00 1.00 728580.00 1.00 0.00 1.00
+{o_shippriority} 728580.00 1.00 1.00 1.00 0.00 1.00
----Stats for q3_scan_7----
column_names row_count distinct_count null_count
@@ -239,7 +239,7 @@ column_names row_count distinct_count null_count
{o_shippriority} 1500000 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_custkey} 1500000.00 1.00 99853.00 1.00 0.00 1.00
+{o_custkey} 1500000.00 1.00 99846.00 1.00 0.00 1.00
{o_orderdate} 1500000.00 1.00 2406.00 1.00 0.00 1.00
{o_orderkey} 1500000.00 1.00 1500000.00 1.00 0.00 1.00
{o_shippriority} 1500000.00 1.00 1.00 1.00 0.00 1.00
@@ -250,8 +250,8 @@ column_names row_count distinct_count null_count
{c_mktsegment} 30142 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 30165.00 1.00 30139.00 1.00 0.00 1.00
-{c_mktsegment} 30165.00 1.00 1.00 1.00 0.00 1.00
+{c_custkey} 30550.00 1.01 30523.00 1.01 0.00 1.00
+{c_mktsegment} 30550.00 1.01 1.00 1.00 0.00 1.00
----Stats for q3_scan_9----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q04 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q04
index 887b9c519f7b..333593941687 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q04
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q04
@@ -42,7 +42,7 @@ ORDER BY
sort
├── save-table-name: q4_sort_1
├── columns: o_orderpriority:6(char!null) order_count:30(int!null)
- ├── stats: [rows=4, distinct(6)=4, null(6)=0, avgsize(6)=4, distinct(30)=4, null(30)=0, avgsize(30)=4]
+ ├── stats: [rows=5, distinct(6)=5, null(6)=0, avgsize(6)=11, distinct(30)=5, null(30)=0, avgsize(30)=11]
├── key: (6)
├── fd: (6)-->(30)
├── ordering: +6
@@ -50,33 +50,33 @@ sort
├── save-table-name: q4_group_by_2
├── columns: o_orderpriority:6(char!null) count_rows:30(int!null)
├── grouping columns: o_orderpriority:6(char!null)
- ├── stats: [rows=4, distinct(6)=4, null(6)=0, avgsize(6)=4, distinct(30)=4, null(30)=0, avgsize(30)=4]
+ ├── stats: [rows=5, distinct(6)=5, null(6)=0, avgsize(6)=11, distinct(30)=5, null(30)=0, avgsize(30)=11]
├── key: (6)
├── fd: (6)-->(30)
├── semi-join (lookup lineitem)
│ ├── save-table-name: q4_lookup_join_3
│ ├── columns: o_orderkey:1(int!null) o_orderdate:5(date!null) o_orderpriority:6(char!null)
│ ├── key columns: [1] = [12]
- │ ├── stats: [rows=62887.5, distinct(1)=62887.5, null(1)=0, avgsize(1)=4, distinct(5)=92, null(5)=0, avgsize(5)=4, distinct(6)=4, null(6)=0, avgsize(6)=4]
+ │ ├── stats: [rows=51977.27, distinct(1)=51977.3, null(1)=0, avgsize(1)=4, distinct(5)=92, null(5)=0, avgsize(5)=4, distinct(6)=5, null(6)=0, avgsize(6)=11]
│ ├── key: (1)
│ ├── fd: (1)-->(5,6)
│ ├── index-join orders
│ │ ├── save-table-name: q4_index_join_4
│ │ ├── columns: o_orderkey:1(int!null) o_orderdate:5(date!null) o_orderpriority:6(char!null)
- │ │ ├── stats: [rows=62887.5, distinct(1)=62887.5, null(1)=0, avgsize(1)=4, distinct(5)=92, null(5)=0, avgsize(5)=4, distinct(6)=4, null(6)=0, avgsize(6)=4]
- │ │ │ histogram(5)= 0 0 7200 300 7200 600 6600 750 7200 900 6900 900 6900 450 6600 750 6750 1200 1125 562.5
- │ │ │ <--- '1993-06-30' ------ '1993-07-11' ------ '1993-07-22' ------ '1993-08-02' ------ '1993-08-14' ------ '1993-08-25' ------ '1993-09-05' ------ '1993-09-16' ------ '1993-09-27' ------ '1993-09-30'
+ │ │ ├── stats: [rows=51977.27, distinct(1)=51977.3, null(1)=0, avgsize(1)=4, distinct(5)=92, null(5)=0, avgsize(5)=4, distinct(6)=5, null(6)=0, avgsize(6)=11]
+ │ │ │ histogram(5)= 0 0 627.27 900 6300 1200 6750 600 7050 900 7050 450 6900 1200 6750 600 4112.5 587.5
+ │ │ │ <--- '1993-06-30' -------- '1993-07-02' ------ '1993-07-16' ------ '1993-07-29' ------ '1993-08-12' ------ '1993-08-25' ------ '1993-09-07' ------ '1993-09-22' -------- '1993-09-30'
│ │ ├── key: (1)
│ │ ├── fd: (1)-->(5,6)
│ │ └── scan orders@o_od
│ │ ├── save-table-name: q4_scan_5
│ │ ├── columns: o_orderkey:1(int!null) o_orderdate:5(date!null)
│ │ ├── constraint: /5/1: [/'1993-07-01' - /'1993-09-30']
- │ │ ├── stats: [rows=62887.5, distinct(1)=62887.5, null(1)=0, avgsize(1)=4, distinct(5)=92, null(5)=0, avgsize(5)=4]
- │ │ │ histogram(1)= 0 0 0 0.041924 312.84 0.041924 305.46 0.041924 316.32 0.041924 318.21 0.041924 302.82 0.041924 307.1 0.041924 314.73 0.041924 308.23 0.041924 326.09 0.041924 317.66 0.041924 324.16 0.041924 322.61 0.041924 318.08 0.041924 317.37 0.041924 325.25 0.041924 319.67 0.041924 314.73 0.041924 303.78 0.041924 327.89 0.041924 316.11 0.041924 312.59 0.041924 318.21 0.041924 324.54 0.041924 318.83 0.041924 323.28 0.041924 323.24 0.041924 323.19 0.041924 314.05 0.041924 315.61 0.041924 307.39 0.041924 306.55 0.041924 317.66 0.041924 316.36 0.041924 305.12 0.041924 309.95 0.041924 314.81 0.041924 319.59 0.041924 317.87 0.041924 326 0.041924 315.44 0.041924 317.32 0.041924 313.76 0.041924 321.27 0.041924 308.94 0.041924 313.22 0.041924 309.44 0.041924 320.64 0.041924 309.48 0.041924 320.13 0.041924 314.05 0.041924 312.21 0.041924 315.56 0.041924 312 0.041924 304.62 0.041924 333.76 0.041924 304.03 0.041924 315.06 0.041924 305.84 0.041924 314.56 0.041924 305.46 0.041924 306.93 0.041924 303.36 0.041924 312.42 0.041924 327.47 0.041924 309.36 0.041924 311.04 0.041924 321.22 0.041924 310.45 0.041924 311.62 0.041924 317.79 0.041924 328.56 0.041924 312.17 0.041924 308.39 0.041924 319.38 0.041924 298.12 0.041924 310.2 0.041924 319.59 0.041924 320.97 0.041924 311.66 0.041924 321.01 0.041924 310.45 0.041924 313.38 0.041924 317.49 0.041924 322.36 0.041924 316.95 0.041924 310.87 0.041924 315.44 0.041924 316.91 0.041924 307.35 0.041924 318.12 0.041924 309.78 0.041924 307.22 0.041924 321.64 0.041924 315.44 0.041924 322.31 0.041924 315.48 0.041924 319.25 0.041924 312.92 0.041924 318.41 0.041924 309.11 0.041924 321.6 0.041924 306.51 0.041924 304.83 0.041924 310.24 0.041924 322.36 0.041924 313.93 0.041924 316.82 0.041924 308.81 0.041924 315.35 0.041924 325.46 0.041924 309.69 0.041924 310.24 0.041924 317.07 0.041924 314.56 0.041924 301.94 0.041924 318.46 0.041924 315.52 0.041924 312.42 0.041924 305.25 0.041924 306.38 0.041924 309.69 0.041924 307.98 0.041924 309.57 0.041924 315.73 0.041924 323.11 0.041924 317.87 0.041924 314.98 0.041924 315.98 0.041924 302.32 0.041924 322.4 0.041924 321.1 0.041924 308.52 0.041924 320.59 0.041924 304.08 0.041924 307.22 0.041924 315.52 0.041924 317.16 0.041924 315.48 0.041924 311.87 0.041924 314.18 0.041924 311.08 0.041924 314.85 0.041924 318.46 0.041924 310.11 0.041924 309.36 0.041924 307.35 0.041924 309.74 0.041924 316.65 0.041924 307.35 0.041924 311.58 0.041924 325.92 0.041924 329.27 0.041924 317.07 0.041924 316.49 0.041924 329.02 0.041924 332.63 0.041924 325.71 0.041924 324.45 0.041924 313.64 0.041924 321.98 0.041924 321.31 0.041924 318.12 0.041924 315.61 0.041924 313.05 0.041924 312.13 0.041924 315.27 0.041924 328.31 0.041924 317.32 0.041924 321.64 0.041924 320.22 0.041924 312.88 0.041924 329.19 0.041924 313.76 0.041924 325.58 0.041924 312.42 0.041924 337.53 0.041924 320.51 0.041924 323.86 0.041924 313.26 0.041924 315.19 0.041924 328.31 0.041924 309.74 0.041924 324.91 0.041924 316.36 0.041924 323.61 0.041924 309.61 0.041924 312.96 0.041924 313.09 0.041924 327.43 0.041924 325.63 0.041924 314.93 0.041924 320.39 0.041924 323.32 0.041924 324.07 0.041924 319.97 0.041924 324.28 0.041924 332.54 0.041924 318.08 0.041924 333.93 0.041924 0 0
- │ │ │ <--- -9223372036854775808 ---- 1472 --------- 30469 --------- 54689 --------- 85922 --------- 118369 -------- 140867 ------- 166146 -------- 196357 -------- 222375 -------- 259877 -------- 291970 -------- 328227 -------- 363490 -------- 395873 -------- 427783 -------- 464741 -------- 498146 -------- 528358 -------- 551493 -------- 590144 -------- 621254 -------- 650083 -------- 682531 -------- 719041 -------- 751906 -------- 787617 -------- 823298 -------- 858944 -------- 888739 -------- 919527 -------- 944996 -------- 969922 -------- 1002020 -------- 1033280 -------- 1057284 -------- 1084416 -------- 1114693 -------- 1148034 -------- 1180262 ----- 1217697 -------- 1248386 -------- 1280261 -------- 1309862 -------- 1344263 -------- 1370759 -------- 1400003 -------- 1426822 -------- 1460837 -------- 1487680 -------- 1521376 -------- 1551174 -------- 1579779 -------- 1610532 ----- 1638983 -------- 1662660 -------- 1705024 -------- 1728321 -------- 1758757 -------- 1783239 -------- 1813344 -------- 1837573 -------- 1862757 -------- 1885607 -------- 1914340 -------- 1952706 -------- 1979458 -------- 2007302 -------- 2041697 -------- 2069157 -------- 2097383 -------- 2129571 -------- 2168643 -------- 2197223 -------- 2223363 -------- 2256577 -------- 2275975 ------- 2303264 -------- 2336608 -------- 2370823 -------- 2399074 -------- 2433315 -------- 2460771 -------- 2490114 -------- 2522119 -------- 2557218 -------- 2588866 -------- 2616610 -------- 2647296 -------- 2678913 -------- 2704354 -------- 2736743 -------- 2763779 -------- 2789157 -------- 2823812 -------- 2854502 -------- 2889572 -------- 2920263 -------- 2953378 -------- 2982439 -------- 3015013 -------- 3041603 ------- 3076227 -------- 3101125 -------- 3124930 -------- 3152260 -------- 3187366 -------- 3217059 -------- 3248611 -------- 3275008 -------- 3305634 -------- 3342721 -------- 3369702 -------- 3397031 -------- 3428771 -------- 3458885 -------- 3480806 -------- 3513408 -------- 3544129 -------- 3572866 -------- 3596965 -------- 3621794 -------- 3648771 -------- 3674624 -------- 3701510 -------- 3732387 -------- 3767974 -------- 3800224 -------- 3830599 -------- 3861635 -------- 3883808 ------- 3918949 ------- 3953249 -------- 3979456 -------- 4013443 -------- 4036775 -------- 4062148 -------- 4092867 -------- 4124641 -------- 4155333 -------- 4183718 -------- 4213574 -------- 4241445 -------- 4271751 -------- 4304354 -------- 4331590 -------- 4358338 -------- 4383782 -------- 4410791 -------- 4442244 -------- 4467687 -------- 4495876 -------- 4529761 -------- 4565792 -------- 4593991 -------- 4621829 -------- 4657703 -------- 4695878 -------- 4729632 -------- 4762593 -------- 4788581 -------- 4819943 -------- 4850885 -------- 4879777 -------- 4907042 -------- 4932640 -------- 4957638 -------- 4984675 -------- 5020100 -------- 5048481 -------- 5079622 -------- 5109862 -------- 5135363 -------- 5171364 -------- 5197414 -------- 5231104 -------- 5256289 -------- 5297604 -------- 5328038 -------- 5360608 -------- 5386337 -------- 5413315 -------- 5448743 -------- 5472197 -------- 5505440 -------- 5533184 -------- 5565603 -------- 5588963 -------- 5614503 -------- 5640135 -------- 5675008 -------- 5708709 -------- 5735522 -------- 5765862 -------- 5798085 -------- 5830787 -------- 5860867 -------- 5893703 -------- 5931844 -------- 5960706 -------- 5999719 --- 9223372036854775807
- │ │ │ histogram(5)= 0 0 7200 300 7200 600 6600 750 7200 900 6900 900 6900 450 6600 750 6750 1200 1125 562.5
- │ │ │ <--- '1993-06-30' ------ '1993-07-11' ------ '1993-07-22' ------ '1993-08-02' ------ '1993-08-14' ------ '1993-08-25' ------ '1993-09-05' ------ '1993-09-16' ------ '1993-09-27' ------ '1993-09-30'
+ │ │ ├── stats: [rows=51977.27, distinct(1)=51977.3, null(1)=0, avgsize(1)=4, distinct(5)=92, null(5)=0, avgsize(5)=4]
+ │ │ │ histogram(1)= 0 0 0 0.034651 256.66 0.034651 253.92 0.034651 268.51 0.034651 257.6 0.034651 278.25 0.034651 251.77 0.034651 257.8 0.034651 271.11 0.034651 260.82 0.034651 261.75 0.034651 257.35 0.034651 259.57 0.034651 263.21 0.034651 260.85 0.034651 264.77 0.034651 263.14 0.034651 255.9 0.034651 267.3 0.034651 256.76 0.034651 251.22 0.034651 260.54 0.034651 257.63 0.034651 262.52 0.034651 258.91 0.034651 253.06 0.034651 246.37 0.034651 264.98 0.034651 264.04 0.034651 262.65 0.034651 259.54 0.034651 256.76 0.034651 264.04 0.034651 270.49 0.034651 257.08 0.034651 258.32 0.034651 265.15 0.034651 256.69 0.034651 252.22 0.034651 256.52 0.034651 255.59 0.034651 255.59 0.034651 260.51 0.034651 264.28 0.034651 265.98 0.034651 258.88 0.034651 254.79 0.034651 263.28 0.034651 265.08 0.034651 260.23 0.034651 253.68 0.034651 252.54 0.034651 255.24 0.034651 255.79 0.034651 259.15 0.034651 260.82 0.034651 250.67 0.034651 266.02 0.034651 256.45 0.034651 268.2 0.034651 264.7 0.034651 260.44 0.034651 249.9 0.034651 250.6 0.034651 249.31 0.034651 249.07 0.034651 273.26 0.034651 255.03 0.034651 253.02 0.034651 259.67 0.034651 260.92 0.034651 261.93 0.034651 247.72 0.034651 257.73 0.034651 254.27 0.034651 252.95 0.034651 266.26 0.034651 257.49 0.034651 251.32 0.034651 257.84 0.034651 258.77 0.034651 266.64 0.034651 260.89 0.034651 257.87 0.034651 266.64 0.034651 268.13 0.034651 260.71 0.034651 256.45 0.034651 260.71 0.034651 266.85 0.034651 248 0.034651 254.79 0.034651 255.03 0.034651 254.16 0.034651 257.98 0.034651 269.13 0.034651 265.98 0.034651 260.3 0.034651 263.94 0.034651 253.26 0.034651 263.14 0.034651 252.85 0.034651 261.89 0.034651 257.01 0.034651 263.83 0.034651 257.18 0.034651 253.75 0.034651 262.83 0.034651 267.75 0.034651 259.74 0.034651 257.63 0.034651 254.27 0.034651 258.18 0.034651 262.55 0.034651 251.08 0.034651 264.25 0.034651 268.51 0.034651 257.04 0.034651 266.88 0.034651 257.73 0.034651 254.55 0.034651 260.51 0.034651 264.11 0.034651 255.03 0.034651 256.21 0.034651 264.49 0.034651 267.37 0.034651 261.93 0.034651 254.72 0.034651 261.89 0.034651 256.45 0.034651 252.88 0.034651 272.91 0.034651 255.2 0.034651 254.1 0.034651 258.46 0.034651 258.91 0.034651 262.13 0.034651 260.71 0.034651 251.95 0.034651 253.3 0.034651 257.08 0.034651 275.82 0.034651 255.83 0.034651 260.16 0.034651 260.75 0.034651 262.2 0.034651 267.02 0.034651 271.73 0.034651 259.33 0.034651 266.33 0.034651 263.56 0.034651 266.05 0.034651 265.01 0.034651 276.72 0.034651 272.36 0.034651 265.91 0.034651 267.96 0.034651 259.95 0.034651 259.85 0.034651 263.24 0.034651 262.41 0.034651 271.98 0.034651 262.24 0.034651 261.61 0.034651 259.67 0.034651 272.7 0.034651 260.19 0.034651 264.28 0.034651 269.41 0.034651 274.05 0.034651 259.95 0.034651 271.73 0.034651 261.37 0.034651 264.18 0.034651 260.71 0.034651 261.58 0.034651 276.45 0.034651 262.31 0.034651 274.33 0.034651 263.83 0.034651 273.19 0.034651 262.65 0.034651 279.88 0.034651 266.78 0.034651 264.59 0.034651 260.96 0.034651 260.44 0.034651 265.91 0.034651 269.65 0.034651 266.78 0.034651 259.29 0.034651 270.49 0.034651 269.41 0.034651 265.36 0.034651 265.29 0.034651 262.65 0.034651 260.12 0.034651 268.09 0.034651 262.83 0.034651 0 0
+ │ │ │ <--- -9223372036854775808 ---- 1505 --------- 29025 --------- 54400 --------- 91106 -------- 119366 -------- 163554 -------- 187236 ------- 215651 -------- 254373 -------- 285123 -------- 316614 -------- 344678 -------- 374465 -------- 407078 -------- 437861 -------- 471683 -------- 504230 ------- 531168 ------- 566951 -------- 594561 -------- 617825 -------- 648358 -------- 676640 -------- 708706 -------- 737986 -------- 762690 -------- 782081 -------- 816064 -------- 849318 -------- 881511 -------- 911271 -------- 938885 -------- 972135 -------- 1010370 -------- 1038212 -------- 1067041 -------- 1101158 -------- 1128704 -------- 1152742 -------- 1180165 -------- 1206852 -------- 1233537 -------- 1264064 -------- 1297504 -------- 1332260 -------- 1361504 -------- 1387553 -------- 1420224 -------- 1454275 -------- 1484580 -------- 1509766 -------- 1534050 -------- 1560452 -------- 1587299 -------- 1616771 -------- 1647526 -------- 1670343 -------- 1705121 -------- 1732486 ------- 1768967 ------- 1802725 -------- 1833189 ------- 1855398 ------- 1878146 -------- 1899877 -------- 1921414 -------- 1961765 -------- 1988000 -------- 2012672 -------- 2042529 -------- 2073381 -------- 2104999 -------- 2125477 -------- 2153825 -------- 2179462 -------- 2204065 -------- 2239044 -------- 2267205 -------- 2290530 -------- 2318977 -------- 2348134 -------- 2383399 -------- 2414215 -------- 2442695 -------- 2477955 -------- 2514372 -------- 2545062 -------- 2572418 -------- 2603108 -------- 2638534 ----- 2659232 -------- 2685286 -------- 2711527 -------- 2737088 -------- 2765639 -------- 2802818 -------- 2837570 ------- 2867911 -------- 2901088 -------- 2925954 -------- 2958501 -------- 2983042 -------- 3014626 -------- 3042406 -------- 3075489 -------- 3103425 -------- 3128673 -------- 3160994 -------- 3197125 -------- 3227043 -------- 3255328 -------- 3280965 -------- 3309669 -------- 3341767 -------- 3364898 -------- 3398305 -------- 3435008 -------- 3462818 -------- 3498272 -------- 3526631 -------- 3552485 -------- 3583014 -------- 3616322 -------- 3642566 -------- 3669732 -------- 3703330 -------- 3739170 -------- 3770791 -------- 3796804 -------- 3828387 -------- 3855751 -------- 3880321 -------- 3920422 ------- 3946818 ------- 3972322 -------- 4001250 -------- 4030533 -------- 4062306 -------- 4092992 -------- 4116803 ------- 4141697 -------- 4169536 -------- 4211878 -------- 4238753 -------- 4268994 -------- 4299686 ------- 4331525 -------- 4367079 -------- 4406277 -------- 4435878 -------- 4470914 -------- 4500294 -------- 4531617 -------- 4562114 -------- 4601666 -------- 4637856 -------- 4669060 -------- 4701861 -------- 4728416 -------- 4754881 -------- 4784001 -------- 4812482 -------- 4848389 -------- 4876741 -------- 4904612 -------- 4930945 ------- 4967397 -------- 4994146 -------- 5024099 -------- 5058023 -------- 5095527 -------- 5122081 -------- 5157798 -------- 5185472 -------- 5215332 -------- 5242497 -------- 5270338 -------- 5309699 -------- 5338112 -------- 5375843 -------- 5405441 -------- 5442277 -------- 5470945 -------- 5512930 -------- 5544807 -------- 5574980 -------- 5602340 -------- 5629280 -------- 5660482 -------- 5694599 -------- 5726466 -------- 5752519 -------- 5787268 -------- 5821185 -------- 5851973 -------- 5882689 -------- 5911363 -------- 5938052 -------- 5970949 -------- 5999748 --- 9223372036854775807
+ │ │ │ histogram(5)= 0 0 627.27 900 6300 1200 6750 600 7050 900 7050 450 6900 1200 6750 600 4112.5 587.5
+ │ │ │ <--- '1993-06-30' -------- '1993-07-02' ------ '1993-07-16' ------ '1993-07-29' ------ '1993-08-12' ------ '1993-08-25' ------ '1993-09-07' ------ '1993-09-22' -------- '1993-09-30'
│ │ ├── key: (1)
│ │ └── fd: (1)-->(5)
│ └── filters
@@ -90,8 +90,8 @@ column_names row_count distinct_count null_count
{order_count} 5 5 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_orderpriority} 4.00 1.25 4.00 1.25 0.00 1.00
-{order_count} 4.00 1.25 4.00 1.25 0.00 1.00
+{o_orderpriority} 5.00 1.00 5.00 1.00 0.00 1.00
+{order_count} 5.00 1.00 5.00 1.00 0.00 1.00
----Stats for q4_group_by_2----
column_names row_count distinct_count null_count
@@ -99,8 +99,8 @@ column_names row_count distinct_count null_count
{o_orderpriority} 5 5 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{count_rows} 4.00 1.25 4.00 1.25 0.00 1.00
-{o_orderpriority} 4.00 1.25 4.00 1.25 0.00 1.00
+{count_rows} 5.00 1.00 5.00 1.00 0.00 1.00
+{o_orderpriority} 5.00 1.00 5.00 1.00 0.00 1.00
----Stats for q4_lookup_join_3----
column_names row_count distinct_count null_count
@@ -109,9 +109,9 @@ column_names row_count distinct_count null_count
{o_orderpriority} 52523 5 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_orderdate} 62887.00 1.20 92.00 1.00 0.00 1.00
-{o_orderkey} 62887.00 1.20 62887.00 1.20 0.00 1.00
-{o_orderpriority} 62887.00 1.20 4.00 1.25 0.00 1.00
+{o_orderdate} 51977.00 1.01 92.00 1.00 0.00 1.00
+{o_orderkey} 51977.00 1.01 51977.00 1.01 0.00 1.00
+{o_orderpriority} 51977.00 1.01 5.00 1.00 0.00 1.00
----Stats for q4_index_join_4----
column_names row_count distinct_count null_count
@@ -120,9 +120,9 @@ column_names row_count distinct_count null_count
{o_orderpriority} 57218 5 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_orderdate} 62887.00 1.10 92.00 1.00 0.00 1.00
-{o_orderkey} 62887.00 1.10 62887.00 1.10 0.00 1.00
-{o_orderpriority} 62887.00 1.10 4.00 1.25 0.00 1.00
+{o_orderdate} 51977.00 1.10 92.00 1.00 0.00 1.00
+{o_orderkey} 51977.00 1.10 51977.00 1.10 0.00 1.00
+{o_orderpriority} 51977.00 1.10 5.00 1.00 0.00 1.00
----Stats for q4_scan_5----
column_names row_count distinct_count null_count
@@ -130,7 +130,7 @@ column_names row_count distinct_count null_count
{o_orderkey} 57218 57218 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_orderdate} 62887.00 1.10 92.00 1.00 0.00 1.00
-{o_orderkey} 62887.00 1.10 62887.00 1.10 0.00 1.00
+{o_orderdate} 51977.00 1.10 92.00 1.00 0.00 1.00
+{o_orderkey} 51977.00 1.10 51977.00 1.10 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q05 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q05
index 47fc20e421b5..53ac4608fb32 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q05
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q05
@@ -49,7 +49,7 @@ sort
├── save-table-name: q5_sort_1
├── columns: n_name:50(char!null) revenue:61(float!null)
├── immutable
- ├── stats: [rows=5, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(61)=5, null(61)=0, avgsize(61)=4]
+ ├── stats: [rows=5, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(61)=5, null(61)=0, avgsize(61)=10]
├── key: (50)
├── fd: (50)-->(61)
├── ordering: -61
@@ -58,70 +58,70 @@ sort
├── columns: n_name:50(char!null) sum:61(float!null)
├── grouping columns: n_name:50(char!null)
├── immutable
- ├── stats: [rows=5, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(61)=5, null(61)=0, avgsize(61)=4]
+ ├── stats: [rows=5, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(61)=5, null(61)=0, avgsize(61)=10]
├── key: (50)
├── fd: (50)-->(61)
├── project
│ ├── save-table-name: q5_project_3
│ ├── columns: column60:60(float!null) n_name:50(char!null)
│ ├── immutable
- │ ├── stats: [rows=13659.85, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(60)=13344.7, null(60)=0, avgsize(60)=8]
+ │ ├── stats: [rows=12896.98, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(60)=12601.8, null(60)=0, avgsize(60)=18]
│ ├── inner-join (hash)
│ │ ├── save-table-name: q5_inner_join_4
│ │ ├── columns: c_custkey:1(int!null) c_nationkey:4(int!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_suppkey:24(int!null) l_extendedprice:27(float!null) l_discount:28(float!null) s_suppkey:40(int!null) s_nationkey:43(int!null) n_nationkey:49(int!null) n_name:50(char!null) n_regionkey:51(int!null) r_regionkey:55(int!null) r_name:56(char!null)
│ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ ├── stats: [rows=13659.85, distinct(1)=13659.9, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=4, distinct(11)=13268.8, null(11)=0, avgsize(11)=4, distinct(12)=13659.9, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4, distinct(22)=13268.8, null(22)=0, avgsize(22)=4, distinct(24)=1843.68, null(24)=0, avgsize(24)=4, distinct(27)=13317.4, null(27)=0, avgsize(27)=4, distinct(28)=11, null(28)=0, avgsize(28)=4, distinct(40)=1843.68, null(40)=0, avgsize(40)=4, distinct(43)=5, null(43)=0, avgsize(43)=4, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(51)=1, null(51)=0, avgsize(51)=4, distinct(55)=1, null(55)=0, avgsize(55)=4, distinct(56)=0.996222, null(56)=0, avgsize(56)=4, distinct(27,28)=13344.7, null(27,28)=0, avgsize(27,28)=8]
+ │ │ ├── stats: [rows=12896.98, distinct(1)=12897, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=2, distinct(11)=12527.8, null(11)=0, avgsize(11)=4, distinct(12)=12897, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4, distinct(22)=12527.8, null(22)=0, avgsize(22)=4, distinct(24)=1843.11, null(24)=0, avgsize(24)=4, distinct(27)=12576, null(27)=0, avgsize(27)=9, distinct(28)=11, null(28)=0, avgsize(28)=9, distinct(40)=1843.11, null(40)=0, avgsize(40)=3, distinct(43)=5, null(43)=0, avgsize(43)=2, distinct(49)=5, null(49)=0, avgsize(49)=1, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(51)=1, null(51)=0, avgsize(51)=2, distinct(55)=1, null(55)=0, avgsize(55)=1, distinct(56)=0.996222, null(56)=0, avgsize(56)=9, distinct(27,28)=12601.8, null(27,28)=0, avgsize(27,28)=18]
│ │ ├── fd: ()-->(56), (1)-->(4), (11)-->(12,15), (40)-->(43), (49)-->(50,51), (51)==(55), (55)==(51), (43)==(4,49), (49)==(4,43), (24)==(40), (40)==(24), (11)==(22), (22)==(11), (1)==(12), (12)==(1), (4)==(43,49)
│ │ ├── inner-join (lookup lineitem)
│ │ │ ├── save-table-name: q5_lookup_join_5
│ │ │ ├── columns: c_custkey:1(int!null) c_nationkey:4(int!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_suppkey:24(int!null) l_extendedprice:27(float!null) l_discount:28(float!null) n_nationkey:49(int!null) n_name:50(char!null) n_regionkey:51(int!null) r_regionkey:55(int!null) r_name:56(char!null)
│ │ │ ├── key columns: [11] = [22]
- │ │ │ ├── stats: [rows=299743.7, distinct(1)=27671.8, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=4, distinct(11)=65086.6, null(11)=0, avgsize(11)=4, distinct(12)=27671.8, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4, distinct(22)=65086.6, null(22)=0, avgsize(22)=4, distinct(24)=9920, null(24)=0, avgsize(24)=4, distinct(27)=257902, null(27)=0, avgsize(27)=4, distinct(28)=11, null(28)=0, avgsize(28)=4, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(51)=1, null(51)=0, avgsize(51)=4, distinct(55)=1, null(55)=0, avgsize(55)=4, distinct(56)=0.996222, null(56)=0, avgsize(56)=4]
+ │ │ │ ├── stats: [rows=287046.1, distinct(1)=27671.5, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=2, distinct(11)=62202.5, null(11)=0, avgsize(11)=4, distinct(12)=27671.5, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4, distinct(22)=62202.5, null(22)=0, avgsize(22)=4, distinct(24)=9920, null(24)=0, avgsize(24)=4, distinct(27)=246816, null(27)=0, avgsize(27)=9, distinct(28)=11, null(28)=0, avgsize(28)=9, distinct(49)=5, null(49)=0, avgsize(49)=1, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(51)=1, null(51)=0, avgsize(51)=2, distinct(55)=1, null(55)=0, avgsize(55)=1, distinct(56)=0.996222, null(56)=0, avgsize(56)=9]
│ │ │ ├── fd: ()-->(56), (11)-->(12,15), (1)-->(4), (49)-->(50,51), (51)==(55), (55)==(51), (4)==(49), (49)==(4), (1)==(12), (12)==(1), (11)==(22), (22)==(11)
│ │ │ ├── inner-join (hash)
│ │ │ │ ├── save-table-name: q5_inner_join_6
│ │ │ │ ├── columns: c_custkey:1(int!null) c_nationkey:4(int!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) n_nationkey:49(int!null) n_name:50(char!null) n_regionkey:51(int!null) r_regionkey:55(int!null) r_name:56(char!null)
│ │ │ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ │ │ ├── stats: [rows=76269.11, distinct(1)=27672.3, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=4, distinct(11)=65086.6, null(11)=0, avgsize(11)=4, distinct(12)=27672.3, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(51)=1, null(51)=0, avgsize(51)=4, distinct(55)=1, null(55)=0, avgsize(55)=4, distinct(56)=0.996222, null(56)=0, avgsize(56)=4]
+ │ │ │ │ ├── stats: [rows=73051.37, distinct(1)=27672.3, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=2, distinct(11)=62202.5, null(11)=0, avgsize(11)=4, distinct(12)=27672.3, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4, distinct(49)=5, null(49)=0, avgsize(49)=1, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(51)=1, null(51)=0, avgsize(51)=2, distinct(55)=1, null(55)=0, avgsize(55)=1, distinct(56)=0.996222, null(56)=0, avgsize(56)=9]
│ │ │ │ ├── key: (11)
│ │ │ │ ├── fd: ()-->(56), (11)-->(12,15), (1)-->(4), (49)-->(50,51), (51)==(55), (55)==(51), (4)==(49), (49)==(4), (1)==(12), (12)==(1)
│ │ │ │ ├── index-join orders
│ │ │ │ │ ├── save-table-name: q5_index_join_7
│ │ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null)
- │ │ │ │ │ ├── stats: [rows=233988.5, distinct(11)=233988, null(11)=0, avgsize(11)=4, distinct(12)=92038, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4]
- │ │ │ │ │ │ histogram(15)= 0 0 3796.2 450 7050 900 7200 750 6450 1200 6900 1050 6600 900 7050 750 6750 900 6900 600 7200 450 6900 600 7050 900 6600 1050 6900 600 7050 1350 7200 450 6450 900 7050 1350 7200 150 7050 750 6900 1050 7050 900 6750 600 7050 1800 6600 750 6300 1350 7200 600 7200 450 6600 900 6900 450 4673.1 519.23
- │ │ │ │ │ │ <--- '1993-12-31' -------- '1994-01-08' ------ '1994-01-19' ------ '1994-01-30' ------ '1994-02-12' ------ '1994-02-25' ------ '1994-03-06' ------ '1994-03-19' ------ '1994-03-31' ------ '1994-04-12' ------ '1994-04-22' ------ '1994-05-05' ------ '1994-05-19' ------ '1994-05-30' ------ '1994-06-10' ------ '1994-06-23' ------ '1994-07-05' ------ '1994-07-16' ------ '1994-07-25' ------ '1994-08-06' ------ '1994-08-18' ------ '1994-08-31' ------ '1994-09-10' ------ '1994-09-25' ------ '1994-10-06' ------ '1994-10-21' ------ '1994-11-01' ------ '1994-11-12' ------ '1994-11-27' ------ '1994-12-08' ------ '1994-12-21' -------- '1994-12-31'
+ │ │ │ │ │ ├── stats: [rows=220934.3, distinct(11)=220934, null(11)=0, avgsize(11)=4, distinct(12)=90731.1, null(12)=0, avgsize(12)=4, distinct(15)=365, null(15)=0, avgsize(15)=4]
+ │ │ │ │ │ │ histogram(15)= 0 0 1061.5 450 7200 600 6600 900 6900 750 5700 1800 6900 750 6300 1050 7050 900 7200 300 7050 450 6600 750 6450 1200 6900 600 7050 1050 7050 450 6600 750 7050 600 6450 900 7050 600 7200 900 6750 900 7200 750 7200 1050 6750 600 6900 600 6900 1050 7050 450 7050 750 6000 1350 4909.1 613.64
+ │ │ │ │ │ │ <--- '1993-12-31' -------- '1994-01-03' ------ '1994-01-15' ------ '1994-01-23' ------ '1994-02-04' ------ '1994-02-15' ------ '1994-02-27' ------ '1994-03-09' ------ '1994-03-19' ------ '1994-04-05' ------ '1994-04-16' ------ '1994-04-29' ------ '1994-05-10' ------ '1994-05-24' ------ '1994-06-04' ------ '1994-06-16' ------ '1994-06-30' ------ '1994-07-16' ------ '1994-07-31' ------ '1994-08-13' ------ '1994-08-27' ------ '1994-09-08' ------ '1994-09-23' ------ '1994-10-06' ------ '1994-10-17' ------ '1994-10-28' ------ '1994-11-11' ------ '1994-11-25' ------ '1994-12-11' ------ '1994-12-22' -------- '1994-12-31'
│ │ │ │ │ ├── key: (11)
│ │ │ │ │ ├── fd: (11)-->(12,15)
│ │ │ │ │ └── scan orders@o_od
│ │ │ │ │ ├── save-table-name: q5_scan_8
│ │ │ │ │ ├── columns: o_orderkey:11(int!null) o_orderdate:15(date!null)
│ │ │ │ │ ├── constraint: /15/11: [/'1994-01-01' - /'1994-12-31']
- │ │ │ │ │ ├── stats: [rows=233988.5, distinct(11)=233988, null(11)=0, avgsize(11)=4, distinct(15)=365, null(15)=0, avgsize(15)=4]
- │ │ │ │ │ │ histogram(11)= 0 0 0 0.15599 1164 0.15599 1136.5 0.15599 1176.9 0.15599 1184 0.15599 1126.7 0.15599 1142.6 0.15599 1171 0.15599 1146.8 0.15599 1213.3 0.15599 1181.9 0.15599 1206.1 0.15599 1200.3 0.15599 1183.5 0.15599 1180.8 0.15599 1210.2 0.15599 1189.4 0.15599 1171 0.15599 1130.3 0.15599 1220 0.15599 1176.2 0.15599 1163.1 0.15599 1184 0.15599 1207.5 0.15599 1186.3 0.15599 1202.8 0.15599 1202.7 0.15599 1202.5 0.15599 1168.5 0.15599 1174.3 0.15599 1143.7 0.15599 1140.6 0.15599 1181.9 0.15599 1177.1 0.15599 1135.3 0.15599 1153.2 0.15599 1171.3 0.15599 1189.1 0.15599 1182.7 0.15599 1213 0.15599 1173.7 0.15599 1180.7 0.15599 1167.4 0.15599 1195.3 0.15599 1149.5 0.15599 1165.4 0.15599 1151.4 0.15599 1193 0.15599 1151.5 0.15599 1191.1 0.15599 1168.5 0.15599 1161.7 0.15599 1174.1 0.15599 1160.9 0.15599 1133.4 0.15599 1241.8 0.15599 1131.2 0.15599 1172.3 0.15599 1137.9 0.15599 1170.4 0.15599 1136.5 0.15599 1142 0.15599 1128.7 0.15599 1162.4 0.15599 1218.4 0.15599 1151 0.15599 1157.3 0.15599 1195.2 0.15599 1155.1 0.15599 1159.5 0.15599 1182.4 0.15599 1222.5 0.15599 1161.5 0.15599 1147.5 0.15599 1188.3 0.15599 1109.2 0.15599 1154.2 0.15599 1189.1 0.15599 1194.3 0.15599 1159.6 0.15599 1194.4 0.15599 1155.1 0.15599 1166 0.15599 1181.3 0.15599 1199.4 0.15599 1179.3 0.15599 1156.7 0.15599 1173.7 0.15599 1179.1 0.15599 1143.6 0.15599 1183.6 0.15599 1152.6 0.15599 1143.1 0.15599 1196.8 0.15599 1173.7 0.15599 1199.2 0.15599 1173.8 0.15599 1187.9 0.15599 1164.3 0.15599 1184.7 0.15599 1150.1 0.15599 1196.6 0.15599 1140.4 0.15599 1134.2 0.15599 1154.3 0.15599 1199.4 0.15599 1168 0.15599 1178.8 0.15599 1149 0.15599 1173.4 0.15599 1210.9 0.15599 1152.3 0.15599 1154.3 0.15599 1179.7 0.15599 1170.4 0.15599 1123.4 0.15599 1184.9 0.15599 1174 0.15599 1162.4 0.15599 1135.8 0.15599 1140 0.15599 1152.3 0.15599 1145.9 0.15599 1151.8 0.15599 1174.8 0.15599 1202.2 0.15599 1182.7 0.15599 1171.9 0.15599 1175.7 0.15599 1124.8 0.15599 1199.6 0.15599 1194.7 0.15599 1147.9 0.15599 1192.9 0.15599 1131.4 0.15599 1143.1 0.15599 1174 0.15599 1180.1 0.15599 1173.8 0.15599 1160.4 0.15599 1169 0.15599 1157.4 0.15599 1171.5 0.15599 1184.9 0.15599 1153.9 0.15599 1151 0.15599 1143.6 0.15599 1152.5 0.15599 1178.2 0.15599 1143.6 0.15599 1159.3 0.15599 1212.7 0.15599 1225.1 0.15599 1179.7 0.15599 1177.6 0.15599 1224.2 0.15599 1237.6 0.15599 1211.9 0.15599 1207.2 0.15599 1167 0.15599 1198 0.15599 1195.5 0.15599 1183.6 0.15599 1174.3 0.15599 1164.8 0.15599 1161.3 0.15599 1173 0.15599 1221.6 0.15599 1180.7 0.15599 1196.8 0.15599 1191.4 0.15599 1164.1 0.15599 1224.8 0.15599 1167.4 0.15599 1211.4 0.15599 1162.4 0.15599 1255.9 0.15599 1192.5 0.15599 1205 0.15599 1165.6 0.15599 1172.7 0.15599 1221.6 0.15599 1152.5 0.15599 1208.9 0.15599 1177.1 0.15599 1204.1 0.15599 1152 0.15599 1164.5 0.15599 1164.9 0.15599 1218.3 0.15599 1211.6 0.15599 1171.8 0.15599 1192.1 0.15599 1203 0.15599 1205.8 0.15599 1190.5 0.15599 1206.6 0.15599 1237.3 0.15599 1183.5 0.15599 1242.5 0.15599 0 0
- │ │ │ │ │ │ <--- -9223372036854775808 --- 1472 ------- 30469 -------- 54689 -------- 85922 ------ 118369 -------- 140867 -------- 166146 ------ 196357 -------- 222375 -------- 259877 -------- 291970 -------- 328227 -------- 363490 -------- 395873 -------- 427783 -------- 464741 -------- 498146 ------ 528358 -------- 551493 ------ 590144 -------- 621254 -------- 650083 ------ 682531 -------- 719041 -------- 751906 -------- 787617 -------- 823298 -------- 858944 -------- 888739 -------- 919527 -------- 944996 -------- 969922 -------- 1002020 -------- 1033280 -------- 1057284 -------- 1084416 -------- 1114693 -------- 1148034 -------- 1180262 ------ 1217697 -------- 1248386 -------- 1280261 -------- 1309862 -------- 1344263 -------- 1370759 -------- 1400003 -------- 1426822 ------ 1460837 -------- 1487680 -------- 1521376 -------- 1551174 -------- 1579779 -------- 1610532 -------- 1638983 -------- 1662660 -------- 1705024 -------- 1728321 -------- 1758757 -------- 1783239 -------- 1813344 -------- 1837573 ------ 1862757 -------- 1885607 -------- 1914340 -------- 1952706 ------ 1979458 -------- 2007302 -------- 2041697 -------- 2069157 -------- 2097383 -------- 2129571 -------- 2168643 -------- 2197223 -------- 2223363 -------- 2256577 -------- 2275975 -------- 2303264 -------- 2336608 -------- 2370823 -------- 2399074 -------- 2433315 -------- 2460771 ------ 2490114 -------- 2522119 -------- 2557218 -------- 2588866 -------- 2616610 -------- 2647296 -------- 2678913 -------- 2704354 -------- 2736743 -------- 2763779 -------- 2789157 -------- 2823812 -------- 2854502 -------- 2889572 -------- 2920263 -------- 2953378 -------- 2982439 -------- 3015013 -------- 3041603 -------- 3076227 -------- 3101125 -------- 3124930 -------- 3152260 -------- 3187366 ------ 3217059 -------- 3248611 ------ 3275008 -------- 3305634 -------- 3342721 -------- 3369702 -------- 3397031 -------- 3428771 -------- 3458885 -------- 3480806 -------- 3513408 ------ 3544129 -------- 3572866 -------- 3596965 ------ 3621794 -------- 3648771 -------- 3674624 -------- 3701510 -------- 3732387 -------- 3767974 -------- 3800224 -------- 3830599 -------- 3861635 -------- 3883808 -------- 3918949 -------- 3953249 -------- 3979456 -------- 4013443 -------- 4036775 -------- 4062148 ------ 4092867 -------- 4124641 -------- 4155333 -------- 4183718 ------ 4213574 -------- 4241445 -------- 4271751 -------- 4304354 -------- 4331590 ------ 4358338 -------- 4383782 -------- 4410791 -------- 4442244 -------- 4467687 -------- 4495876 -------- 4529761 -------- 4565792 -------- 4593991 -------- 4621829 -------- 4657703 -------- 4695878 -------- 4729632 -------- 4762593 ------ 4788581 ------ 4819943 -------- 4850885 -------- 4879777 -------- 4907042 -------- 4932640 -------- 4957638 ------ 4984675 -------- 5020100 -------- 5048481 -------- 5079622 -------- 5109862 -------- 5135363 -------- 5171364 -------- 5197414 -------- 5231104 -------- 5256289 -------- 5297604 -------- 5328038 ------ 5360608 -------- 5386337 -------- 5413315 -------- 5448743 -------- 5472197 -------- 5505440 -------- 5533184 -------- 5565603 ------ 5588963 -------- 5614503 -------- 5640135 -------- 5675008 -------- 5708709 -------- 5735522 -------- 5765862 ------ 5798085 -------- 5830787 -------- 5860867 -------- 5893703 -------- 5931844 -------- 5960706 -------- 5999719 --- 9223372036854775807
- │ │ │ │ │ │ histogram(15)= 0 0 3796.2 450 7050 900 7200 750 6450 1200 6900 1050 6600 900 7050 750 6750 900 6900 600 7200 450 6900 600 7050 900 6600 1050 6900 600 7050 1350 7200 450 6450 900 7050 1350 7200 150 7050 750 6900 1050 7050 900 6750 600 7050 1800 6600 750 6300 1350 7200 600 7200 450 6600 900 6900 450 4673.1 519.23
- │ │ │ │ │ │ <--- '1993-12-31' -------- '1994-01-08' ------ '1994-01-19' ------ '1994-01-30' ------ '1994-02-12' ------ '1994-02-25' ------ '1994-03-06' ------ '1994-03-19' ------ '1994-03-31' ------ '1994-04-12' ------ '1994-04-22' ------ '1994-05-05' ------ '1994-05-19' ------ '1994-05-30' ------ '1994-06-10' ------ '1994-06-23' ------ '1994-07-05' ------ '1994-07-16' ------ '1994-07-25' ------ '1994-08-06' ------ '1994-08-18' ------ '1994-08-31' ------ '1994-09-10' ------ '1994-09-25' ------ '1994-10-06' ------ '1994-10-21' ------ '1994-11-01' ------ '1994-11-12' ------ '1994-11-27' ------ '1994-12-08' ------ '1994-12-21' -------- '1994-12-31'
+ │ │ │ │ │ ├── stats: [rows=220934.3, distinct(11)=220934, null(11)=0, avgsize(11)=4, distinct(15)=365, null(15)=0, avgsize(15)=4]
+ │ │ │ │ │ │ histogram(11)= 0 0 0 0.14729 1091 0.14729 1079.3 0.14729 1141.3 0.14729 1094.9 0.14729 1182.7 0.14729 1070.2 0.14729 1095.8 0.14729 1152.4 0.14729 1108.6 0.14729 1112.6 0.14729 1093.9 0.14729 1103.3 0.14729 1118.8 0.14729 1108.8 0.14729 1125.4 0.14729 1118.5 0.14729 1087.7 0.14729 1136.2 0.14729 1091.4 0.14729 1067.8 0.14729 1107.5 0.14729 1095.1 0.14729 1115.8 0.14729 1100.5 0.14729 1075.6 0.14729 1047.2 0.14729 1126.3 0.14729 1122.3 0.14729 1116.4 0.14729 1103.2 0.14729 1091.4 0.14729 1122.3 0.14729 1149.7 0.14729 1092.7 0.14729 1098 0.14729 1127 0.14729 1091.1 0.14729 1072.1 0.14729 1090.4 0.14729 1086.4 0.14729 1086.4 0.14729 1107.3 0.14729 1123.4 0.14729 1130.6 0.14729 1100.4 0.14729 1083 0.14729 1119.1 0.14729 1126.7 0.14729 1106.1 0.14729 1078.3 0.14729 1073.4 0.14729 1084.9 0.14729 1087.3 0.14729 1101.6 0.14729 1108.6 0.14729 1065.5 0.14729 1130.7 0.14729 1090.1 0.14729 1140 0.14729 1125.1 0.14729 1107 0.14729 1062.2 0.14729 1065.2 0.14729 1059.7 0.14729 1058.7 0.14729 1161.5 0.14729 1084 0.14729 1075.5 0.14729 1103.8 0.14729 1109.1 0.14729 1113.3 0.14729 1053 0.14729 1095.5 0.14729 1080.8 0.14729 1075.2 0.14729 1131.8 0.14729 1094.5 0.14729 1068.3 0.14729 1096 0.14729 1099.9 0.14729 1133.4 0.14729 1108.9 0.14729 1096.1 0.14729 1133.4 0.14729 1139.7 0.14729 1108.2 0.14729 1090.1 0.14729 1108.2 0.14729 1134.3 0.14729 1054.1 0.14729 1083 0.14729 1084 0.14729 1080.4 0.14729 1096.6 0.14729 1144 0.14729 1130.6 0.14729 1106.4 0.14729 1121.9 0.14729 1076.5 0.14729 1118.5 0.14729 1074.8 0.14729 1113.2 0.14729 1092.4 0.14729 1121.4 0.14729 1093.2 0.14729 1078.6 0.14729 1117.2 0.14729 1138.1 0.14729 1104.1 0.14729 1095.1 0.14729 1080.8 0.14729 1097.4 0.14729 1116 0.14729 1067.2 0.14729 1123.2 0.14729 1141.3 0.14729 1092.6 0.14729 1134.4 0.14729 1095.5 0.14729 1082 0.14729 1107.3 0.14729 1122.6 0.14729 1084 0.14729 1089 0.14729 1124.2 0.14729 1136.5 0.14729 1113.3 0.14729 1082.7 0.14729 1113.2 0.14729 1090.1 0.14729 1074.9 0.14729 1160 0.14729 1084.8 0.14729 1080.1 0.14729 1098.6 0.14729 1100.5 0.14729 1114.2 0.14729 1108.2 0.14729 1070.9 0.14729 1076.7 0.14729 1092.7 0.14729 1172.4 0.14729 1087.4 0.14729 1105.8 0.14729 1108.3 0.14729 1114.5 0.14729 1135 0.14729 1155 0.14729 1102.3 0.14729 1132 0.14729 1120.3 0.14729 1130.9 0.14729 1126.5 0.14729 1176.2 0.14729 1157.7 0.14729 1130.3 0.14729 1139 0.14729 1104.9 0.14729 1104.5 0.14729 1118.9 0.14729 1115.4 0.14729 1156.1 0.14729 1114.7 0.14729 1112 0.14729 1103.8 0.14729 1159.2 0.14729 1106 0.14729 1123.4 0.14729 1145.2 0.14729 1164.9 0.14729 1104.9 0.14729 1155 0.14729 1111 0.14729 1122.9 0.14729 1108.2 0.14729 1111.9 0.14729 1175.1 0.14729 1115 0.14729 1166.1 0.14729 1121.4 0.14729 1161.2 0.14729 1116.4 0.14729 1189.6 0.14729 1134 0.14729 1124.7 0.14729 1109.2 0.14729 1107 0.14729 1130.3 0.14729 1146.2 0.14729 1134 0.14729 1102.2 0.14729 1149.7 0.14729 1145.2 0.14729 1127.9 0.14729 1127.6 0.14729 1116.4 0.14729 1105.7 0.14729 1139.6 0.14729 1117.2 0.14729 0 0
+ │ │ │ │ │ │ <--- -9223372036854775808 --- 1505 ------- 29025 -------- 54400 -------- 91106 -------- 119366 -------- 163554 -------- 187236 -------- 215651 -------- 254373 -------- 285123 -------- 316614 -------- 344678 -------- 374465 -------- 407078 -------- 437861 -------- 471683 -------- 504230 -------- 531168 -------- 566951 -------- 594561 -------- 617825 -------- 648358 -------- 676640 -------- 708706 -------- 737986 -------- 762690 -------- 782081 -------- 816064 -------- 849318 -------- 881511 -------- 911271 -------- 938885 -------- 972135 -------- 1010370 -------- 1038212 ------ 1067041 ------ 1101158 -------- 1128704 -------- 1152742 -------- 1180165 -------- 1206852 -------- 1233537 -------- 1264064 -------- 1297504 -------- 1332260 -------- 1361504 ------ 1387553 -------- 1420224 -------- 1454275 -------- 1484580 -------- 1509766 -------- 1534050 -------- 1560452 -------- 1587299 -------- 1616771 -------- 1647526 -------- 1670343 -------- 1705121 -------- 1732486 ------ 1768967 -------- 1802725 ------ 1833189 -------- 1855398 -------- 1878146 -------- 1899877 -------- 1921414 -------- 1961765 ------ 1988000 -------- 2012672 -------- 2042529 -------- 2073381 -------- 2104999 ------ 2125477 -------- 2153825 -------- 2179462 -------- 2204065 -------- 2239044 -------- 2267205 -------- 2290530 ------ 2318977 -------- 2348134 -------- 2383399 -------- 2414215 -------- 2442695 -------- 2477955 -------- 2514372 -------- 2545062 -------- 2572418 -------- 2603108 -------- 2638534 -------- 2659232 ------ 2685286 ------ 2711527 -------- 2737088 -------- 2765639 ------ 2802818 -------- 2837570 -------- 2867911 -------- 2901088 -------- 2925954 -------- 2958501 -------- 2983042 -------- 3014626 -------- 3042406 -------- 3075489 -------- 3103425 -------- 3128673 -------- 3160994 -------- 3197125 -------- 3227043 -------- 3255328 -------- 3280965 -------- 3309669 ------ 3341767 -------- 3364898 -------- 3398305 -------- 3435008 -------- 3462818 -------- 3498272 -------- 3526631 ------ 3552485 -------- 3583014 -------- 3616322 ------ 3642566 ------ 3669732 -------- 3703330 -------- 3739170 -------- 3770791 -------- 3796804 -------- 3828387 -------- 3855751 -------- 3880321 ------ 3920422 -------- 3946818 -------- 3972322 -------- 4001250 -------- 4030533 -------- 4062306 -------- 4092992 -------- 4116803 -------- 4141697 -------- 4169536 -------- 4211878 -------- 4238753 -------- 4268994 -------- 4299686 -------- 4331525 ------ 4367079 ------ 4406277 -------- 4435878 ------ 4470914 -------- 4500294 -------- 4531617 -------- 4562114 -------- 4601666 -------- 4637856 -------- 4669060 ------ 4701861 -------- 4728416 -------- 4754881 -------- 4784001 -------- 4812482 -------- 4848389 -------- 4876741 ------ 4904612 -------- 4930945 -------- 4967397 ------ 4994146 -------- 5024099 -------- 5058023 -------- 5095527 -------- 5122081 ------ 5157798 ------ 5185472 -------- 5215332 -------- 5242497 -------- 5270338 -------- 5309699 ------ 5338112 -------- 5375843 -------- 5405441 -------- 5442277 -------- 5470945 -------- 5512930 ------ 5544807 -------- 5574980 -------- 5602340 ------ 5629280 -------- 5660482 -------- 5694599 ------ 5726466 -------- 5752519 -------- 5787268 -------- 5821185 -------- 5851973 -------- 5882689 -------- 5911363 -------- 5938052 -------- 5970949 -------- 5999748 --- 9223372036854775807
+ │ │ │ │ │ │ histogram(15)= 0 0 1061.5 450 7200 600 6600 900 6900 750 5700 1800 6900 750 6300 1050 7050 900 7200 300 7050 450 6600 750 6450 1200 6900 600 7050 1050 7050 450 6600 750 7050 600 6450 900 7050 600 7200 900 6750 900 7200 750 7200 1050 6750 600 6900 600 6900 1050 7050 450 7050 750 6000 1350 4909.1 613.64
+ │ │ │ │ │ │ <--- '1993-12-31' -------- '1994-01-03' ------ '1994-01-15' ------ '1994-01-23' ------ '1994-02-04' ------ '1994-02-15' ------ '1994-02-27' ------ '1994-03-09' ------ '1994-03-19' ------ '1994-04-05' ------ '1994-04-16' ------ '1994-04-29' ------ '1994-05-10' ------ '1994-05-24' ------ '1994-06-04' ------ '1994-06-16' ------ '1994-06-30' ------ '1994-07-16' ------ '1994-07-31' ------ '1994-08-13' ------ '1994-08-27' ------ '1994-09-08' ------ '1994-09-23' ------ '1994-10-06' ------ '1994-10-17' ------ '1994-10-28' ------ '1994-11-11' ------ '1994-11-25' ------ '1994-12-11' ------ '1994-12-22' -------- '1994-12-31'
│ │ │ │ │ ├── key: (11)
│ │ │ │ │ └── fd: (11)-->(15)
│ │ │ │ ├── inner-join (lookup customer@c_nk)
│ │ │ │ │ ├── save-table-name: q5_lookup_join_9
│ │ │ │ │ ├── columns: c_custkey:1(int!null) c_nationkey:4(int!null) n_nationkey:49(int!null) n_name:50(char!null) n_regionkey:51(int!null) r_regionkey:55(int!null) r_name:56(char!null)
│ │ │ │ │ ├── key columns: [49] = [4]
- │ │ │ │ │ ├── stats: [rows=30000, distinct(1)=27672.3, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=4, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(51)=1, null(51)=0, avgsize(51)=4, distinct(55)=1, null(55)=0, avgsize(55)=4, distinct(56)=0.996222, null(56)=0, avgsize(56)=4, distinct(4,49)=25, null(4,49)=0, avgsize(4,49)=8]
+ │ │ │ │ │ ├── stats: [rows=30000, distinct(1)=27672.3, null(1)=0, avgsize(1)=4, distinct(4)=5, null(4)=0, avgsize(4)=2, distinct(49)=5, null(49)=0, avgsize(49)=1, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(51)=1, null(51)=0, avgsize(51)=2, distinct(55)=1, null(55)=0, avgsize(55)=1, distinct(56)=0.996222, null(56)=0, avgsize(56)=9, distinct(4,49)=25, null(4,49)=0, avgsize(4,49)=3]
│ │ │ │ │ ├── key: (1)
│ │ │ │ │ ├── fd: ()-->(56), (1)-->(4), (49)-->(50,51), (51)==(55), (55)==(51), (4)==(49), (49)==(4)
│ │ │ │ │ ├── inner-join (hash)
│ │ │ │ │ │ ├── save-table-name: q5_inner_join_10
│ │ │ │ │ │ ├── columns: n_nationkey:49(int!null) n_name:50(char!null) n_regionkey:51(int!null) r_regionkey:55(int!null) r_name:56(char!null)
│ │ │ │ │ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ │ │ │ │ ├── stats: [rows=5, distinct(49)=5, null(49)=0, avgsize(49)=4, distinct(50)=5, null(50)=0, avgsize(50)=4, distinct(51)=1, null(51)=0, avgsize(51)=4, distinct(55)=1, null(55)=0, avgsize(55)=4, distinct(56)=0.996222, null(56)=0, avgsize(56)=4]
+ │ │ │ │ │ │ ├── stats: [rows=5, distinct(49)=5, null(49)=0, avgsize(49)=1, distinct(50)=5, null(50)=0, avgsize(50)=10, distinct(51)=1, null(51)=0, avgsize(51)=2, distinct(55)=1, null(55)=0, avgsize(55)=1, distinct(56)=0.996222, null(56)=0, avgsize(56)=9]
│ │ │ │ │ │ ├── key: (49)
│ │ │ │ │ │ ├── fd: ()-->(56), (49)-->(50,51), (51)==(55), (55)==(51)
│ │ │ │ │ │ ├── scan nation
│ │ │ │ │ │ │ ├── save-table-name: q5_scan_11
│ │ │ │ │ │ │ ├── columns: n_nationkey:49(int!null) n_name:50(char!null) n_regionkey:51(int!null)
- │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(49)=25, null(49)=0, avgsize(49)=4, distinct(50)=25, null(50)=0, avgsize(50)=4, distinct(51)=5, null(51)=0, avgsize(51)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(49)=25, null(49)=0, avgsize(49)=1, distinct(50)=25, null(50)=0, avgsize(50)=10, distinct(51)=5, null(51)=0, avgsize(51)=2]
│ │ │ │ │ │ │ │ histogram(49)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ histogram(50)= 0 1 23 1
@@ -133,7 +133,7 @@ sort
│ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ ├── save-table-name: q5_select_12
│ │ │ │ │ │ │ ├── columns: r_regionkey:55(int!null) r_name:56(char!null)
- │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(55)=1, null(55)=0, avgsize(55)=4, distinct(56)=1, null(56)=0, avgsize(56)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(55)=1, null(55)=0, avgsize(55)=1, distinct(56)=1, null(56)=0, avgsize(56)=9]
│ │ │ │ │ │ │ │ histogram(56)= 0 1
│ │ │ │ │ │ │ │ <--- 'ASIA'
│ │ │ │ │ │ │ ├── key: (55)
@@ -141,7 +141,7 @@ sort
│ │ │ │ │ │ │ ├── scan region
│ │ │ │ │ │ │ │ ├── save-table-name: q5_scan_13
│ │ │ │ │ │ │ │ ├── columns: r_regionkey:55(int!null) r_name:56(char!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(55)=5, null(55)=0, avgsize(55)=4, distinct(56)=5, null(56)=0, avgsize(56)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(55)=5, null(55)=0, avgsize(55)=1, distinct(56)=5, null(56)=0, avgsize(56)=9]
│ │ │ │ │ │ │ │ │ histogram(55)= 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4
│ │ │ │ │ │ │ │ │ histogram(56)= 0 1 3 1
@@ -159,10 +159,10 @@ sort
│ │ ├── scan supplier@s_nk
│ │ │ ├── save-table-name: q5_scan_14
│ │ │ ├── columns: s_suppkey:40(int!null) s_nationkey:43(int!null)
- │ │ │ ├── stats: [rows=10000, distinct(40)=9920, null(40)=0, avgsize(40)=4, distinct(43)=25, null(43)=0, avgsize(43)=4]
+ │ │ │ ├── stats: [rows=10000, distinct(40)=9920, null(40)=0, avgsize(40)=3, distinct(43)=25, null(43)=0, avgsize(43)=2]
│ │ │ │ histogram(40)= 0 0 0 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 0 0
│ │ │ │ <--- -9223372036854775808 --- 1 ---- 51 ---- 101 ---- 151 ---- 201 ---- 251 ---- 301 ---- 351 ---- 401 ---- 451 ---- 501 ---- 551 ---- 601 ---- 651 ---- 701 ---- 751 ---- 801 ---- 851 ---- 901 ---- 951 ---- 1001 ---- 1051 ---- 1101 ---- 1151 ---- 1201 ---- 1251 ---- 1301 ---- 1351 ---- 1401 ---- 1451 ---- 1501 ---- 1551 ---- 1601 ---- 1651 ---- 1701 ---- 1751 ---- 1801 ---- 1851 ---- 1901 ---- 1951 ---- 2001 ---- 2051 ---- 2101 ---- 2151 ---- 2201 ---- 2251 ---- 2301 ---- 2351 ---- 2401 ---- 2451 ---- 2501 ---- 2551 ---- 2601 ---- 2651 ---- 2701 ---- 2751 ---- 2801 ---- 2851 ---- 2901 ---- 2951 ---- 3001 ---- 3051 ---- 3101 ---- 3151 ---- 3201 ---- 3251 ---- 3301 ---- 3351 ---- 3401 ---- 3451 ---- 3501 ---- 3551 ---- 3601 ---- 3651 ---- 3701 ---- 3751 ---- 3801 ---- 3851 ---- 3901 ---- 3951 ---- 4001 ---- 4051 ---- 4101 ---- 4151 ---- 4201 ---- 4251 ---- 4301 ---- 4351 ---- 4401 ---- 4451 ---- 4501 ---- 4551 ---- 4601 ---- 4651 ---- 4701 ---- 4751 ---- 4801 ---- 4851 ---- 4901 ---- 4951 ---- 5001 ---- 5051 ---- 5101 ---- 5151 ---- 5201 ---- 5251 ---- 5301 ---- 5351 ---- 5401 ---- 5451 ---- 5501 ---- 5551 ---- 5601 ---- 5651 ---- 5701 ---- 5751 ---- 5801 ---- 5851 ---- 5901 ---- 5951 ---- 6001 ---- 6051 ---- 6101 ---- 6151 ---- 6201 ---- 6251 ---- 6301 ---- 6351 ---- 6401 ---- 6451 ---- 6501 ---- 6551 ---- 6601 ---- 6651 ---- 6701 ---- 6751 ---- 6801 ---- 6851 ---- 6901 ---- 6951 ---- 7001 ---- 7051 ---- 7101 ---- 7151 ---- 7201 ---- 7251 ---- 7301 ---- 7351 ---- 7401 ---- 7451 ---- 7501 ---- 7552 ---- 7603 ---- 7654 ---- 7705 ---- 7756 ---- 7807 ---- 7858 ---- 7909 ---- 7960 ---- 8011 ---- 8062 ---- 8113 ---- 8164 ---- 8215 ---- 8266 ---- 8317 ---- 8368 ---- 8419 ---- 8470 ---- 8521 ---- 8572 ---- 8623 ---- 8674 ---- 8725 ---- 8776 ---- 8827 ---- 8878 ---- 8929 ---- 8980 ---- 9031 ---- 9082 ---- 9133 ---- 9184 ---- 9235 ---- 9286 ---- 9337 ---- 9388 ---- 9439 ---- 9490 ---- 9541 ---- 9592 ---- 9643 ---- 9694 ---- 9745 ---- 9796 ---- 9847 ---- 9898 ---- 9949 ---- 10000 --- 9223372036854775807
- │ │ │ │ histogram(43)= 0 403 0 384 0 391 0 396 0 406 0 396 0 393 0 399 0 406 0 393 0 383 0 398 0 394 0 414 0 422 0 387 0 435 0 403 0 441 0 357 0 394 0 390 0 421 0 411 0 383
+ │ │ │ │ histogram(43)= 0 420 0 413 0 397 0 412 0 415 0 380 0 402 0 396 0 415 0 405 0 393 0 438 0 377 0 362 0 376 0 373 0 406 0 421 0 407 0 398 0 411 0 399 0 401 0 390 0 393
│ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ ├── key: (40)
│ │ │ └── fd: (40)-->(43)
@@ -199,8 +199,8 @@ column_names row_count distinct_count null_count
{n_name} 7243 5 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column60} 13660.00 1.89 13345.00 1.84 0.00 1.00
-{n_name} 13660.00 1.89 5.00 1.00 0.00 1.00
+{column60} 12897.00 1.78 12602.00 1.74 0.00 1.00
+{n_name} 12897.00 1.78 5.00 1.00 0.00 1.00
----Stats for q5_inner_join_4----
column_names row_count distinct_count null_count
@@ -222,22 +222,22 @@ column_names row_count distinct_count null_count
{s_suppkey} 7243 1944 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 13660.00 1.89 13660.00 2.46 <== 0.00 1.00
-{c_nationkey} 13660.00 1.89 5.00 1.00 0.00 1.00
-{l_discount} 13660.00 1.89 11.00 1.00 0.00 1.00
-{l_extendedprice} 13660.00 1.89 13317.00 1.85 0.00 1.00
-{l_orderkey} 13660.00 1.89 13269.00 2.00 <== 0.00 1.00
-{l_suppkey} 13660.00 1.89 1844.00 1.05 0.00 1.00
-{n_name} 13660.00 1.89 5.00 1.00 0.00 1.00
-{n_nationkey} 13660.00 1.89 5.00 1.00 0.00 1.00
-{n_regionkey} 13660.00 1.89 1.00 1.00 0.00 1.00
-{o_custkey} 13660.00 1.89 13660.00 2.46 <== 0.00 1.00
-{o_orderdate} 13660.00 1.89 365.00 1.00 0.00 1.00
-{o_orderkey} 13660.00 1.89 13269.00 2.00 <== 0.00 1.00
-{r_name} 13660.00 1.89 1.00 1.00 0.00 1.00
-{r_regionkey} 13660.00 1.89 1.00 1.00 0.00 1.00
-{s_nationkey} 13660.00 1.89 5.00 1.00 0.00 1.00
-{s_suppkey} 13660.00 1.89 1844.00 1.05 0.00 1.00
+{c_custkey} 12897.00 1.78 12897.00 2.32 <== 0.00 1.00
+{c_nationkey} 12897.00 1.78 5.00 1.00 0.00 1.00
+{l_discount} 12897.00 1.78 11.00 1.00 0.00 1.00
+{l_extendedprice} 12897.00 1.78 12576.00 1.74 0.00 1.00
+{l_orderkey} 12897.00 1.78 12528.00 1.89 0.00 1.00
+{l_suppkey} 12897.00 1.78 1843.00 1.05 0.00 1.00
+{n_name} 12897.00 1.78 5.00 1.00 0.00 1.00
+{n_nationkey} 12897.00 1.78 5.00 1.00 0.00 1.00
+{n_regionkey} 12897.00 1.78 1.00 1.00 0.00 1.00
+{o_custkey} 12897.00 1.78 12897.00 2.32 <== 0.00 1.00
+{o_orderdate} 12897.00 1.78 365.00 1.00 0.00 1.00
+{o_orderkey} 12897.00 1.78 12528.00 1.89 0.00 1.00
+{r_name} 12897.00 1.78 1.00 1.00 0.00 1.00
+{r_regionkey} 12897.00 1.78 1.00 1.00 0.00 1.00
+{s_nationkey} 12897.00 1.78 5.00 1.00 0.00 1.00
+{s_suppkey} 12897.00 1.78 1843.00 1.05 0.00 1.00
----Stats for q5_lookup_join_5----
column_names row_count distinct_count null_count
@@ -257,20 +257,20 @@ column_names row_count distinct_count null_count
{r_regionkey} 184082 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 299744.00 1.63 27672.00 1.60 0.00 1.00
-{c_nationkey} 299744.00 1.63 5.00 1.00 0.00 1.00
-{l_discount} 299744.00 1.63 11.00 1.00 0.00 1.00
-{l_extendedprice} 299744.00 1.63 257902.00 1.56 0.00 1.00
-{l_orderkey} 299744.00 1.63 65087.00 1.42 0.00 1.00
-{l_suppkey} 299744.00 1.63 9920.00 1.00 0.00 1.00
-{n_name} 299744.00 1.63 5.00 1.00 0.00 1.00
-{n_nationkey} 299744.00 1.63 5.00 1.00 0.00 1.00
-{n_regionkey} 299744.00 1.63 1.00 1.00 0.00 1.00
-{o_custkey} 299744.00 1.63 27672.00 1.60 0.00 1.00
-{o_orderdate} 299744.00 1.63 365.00 1.00 0.00 1.00
-{o_orderkey} 299744.00 1.63 65087.00 1.42 0.00 1.00
-{r_name} 299744.00 1.63 1.00 1.00 0.00 1.00
-{r_regionkey} 299744.00 1.63 1.00 1.00 0.00 1.00
+{c_custkey} 287046.00 1.56 27671.00 1.60 0.00 1.00
+{c_nationkey} 287046.00 1.56 5.00 1.00 0.00 1.00
+{l_discount} 287046.00 1.56 11.00 1.00 0.00 1.00
+{l_extendedprice} 287046.00 1.56 246816.00 1.49 0.00 1.00
+{l_orderkey} 287046.00 1.56 62202.00 1.35 0.00 1.00
+{l_suppkey} 287046.00 1.56 9920.00 1.00 0.00 1.00
+{n_name} 287046.00 1.56 5.00 1.00 0.00 1.00
+{n_nationkey} 287046.00 1.56 5.00 1.00 0.00 1.00
+{n_regionkey} 287046.00 1.56 1.00 1.00 0.00 1.00
+{o_custkey} 287046.00 1.56 27671.00 1.60 0.00 1.00
+{o_orderdate} 287046.00 1.56 365.00 1.00 0.00 1.00
+{o_orderkey} 287046.00 1.56 62202.00 1.35 0.00 1.00
+{r_name} 287046.00 1.56 1.00 1.00 0.00 1.00
+{r_regionkey} 287046.00 1.56 1.00 1.00 0.00 1.00
----Stats for q5_inner_join_6----
column_names row_count distinct_count null_count
@@ -286,16 +286,16 @@ column_names row_count distinct_count null_count
{r_regionkey} 46008 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 76269.00 1.66 27672.00 1.60 0.00 1.00
-{c_nationkey} 76269.00 1.66 5.00 1.00 0.00 1.00
-{n_name} 76269.00 1.66 5.00 1.00 0.00 1.00
-{n_nationkey} 76269.00 1.66 5.00 1.00 0.00 1.00
-{n_regionkey} 76269.00 1.66 1.00 1.00 0.00 1.00
-{o_custkey} 76269.00 1.66 27672.00 1.60 0.00 1.00
-{o_orderdate} 76269.00 1.66 365.00 1.00 0.00 1.00
-{o_orderkey} 76269.00 1.66 65087.00 1.42 0.00 1.00
-{r_name} 76269.00 1.66 1.00 1.00 0.00 1.00
-{r_regionkey} 76269.00 1.66 1.00 1.00 0.00 1.00
+{c_custkey} 73051.00 1.59 27672.00 1.60 0.00 1.00
+{c_nationkey} 73051.00 1.59 5.00 1.00 0.00 1.00
+{n_name} 73051.00 1.59 5.00 1.00 0.00 1.00
+{n_nationkey} 73051.00 1.59 5.00 1.00 0.00 1.00
+{n_regionkey} 73051.00 1.59 1.00 1.00 0.00 1.00
+{o_custkey} 73051.00 1.59 27672.00 1.60 0.00 1.00
+{o_orderdate} 73051.00 1.59 365.00 1.00 0.00 1.00
+{o_orderkey} 73051.00 1.59 62202.00 1.35 0.00 1.00
+{r_name} 73051.00 1.59 1.00 1.00 0.00 1.00
+{r_regionkey} 73051.00 1.59 1.00 1.00 0.00 1.00
----Stats for q5_index_join_7----
column_names row_count distinct_count null_count
@@ -304,9 +304,9 @@ column_names row_count distinct_count null_count
{o_orderkey} 227597 227597 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_custkey} 233988.00 1.03 92038.00 1.06 0.00 1.00
-{o_orderdate} 233988.00 1.03 365.00 1.00 0.00 1.00
-{o_orderkey} 233988.00 1.03 233988.00 1.03 0.00 1.00
+{o_custkey} 220934.00 1.03 90731.00 1.05 0.00 1.00
+{o_orderdate} 220934.00 1.03 365.00 1.00 0.00 1.00
+{o_orderkey} 220934.00 1.03 220934.00 1.03 0.00 1.00
----Stats for q5_scan_8----
column_names row_count distinct_count null_count
@@ -314,8 +314,8 @@ column_names row_count distinct_count null_count
{o_orderkey} 227597 227597 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_orderdate} 233988.00 1.03 365.00 1.00 0.00 1.00
-{o_orderkey} 233988.00 1.03 233988.00 1.03 0.00 1.00
+{o_orderdate} 220934.00 1.03 365.00 1.00 0.00 1.00
+{o_orderkey} 220934.00 1.03 220934.00 1.03 0.00 1.00
----Stats for q5_lookup_join_9----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q06 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q06
index 6a7cafb84ad1..171e8f604eaf 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q06
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q06
@@ -43,32 +43,32 @@ scalar-group-by
│ ├── save-table-name: q6_project_2
│ ├── columns: column19:19(float!null)
│ ├── immutable
- │ ├── stats: [rows=72953.08, distinct(19)=72953.1, null(19)=0, avgsize(19)=8]
+ │ ├── stats: [rows=71117.89, distinct(19)=71117.9, null(19)=0, avgsize(19)=18]
│ ├── select
│ │ ├── save-table-name: q6_select_3
│ │ ├── columns: l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipdate:11(date!null)
- │ │ ├── stats: [rows=72953.08, distinct(5)=23.5306, null(5)=0, avgsize(5)=4, distinct(6)=70695, null(6)=0, avgsize(6)=4, distinct(7)=1.8, null(7)=0, avgsize(7)=4, distinct(11)=365, null(11)=0, avgsize(11)=4, distinct(6,7)=72953.1, null(6,7)=0, avgsize(6,7)=8, distinct(5,7,11)=15459.6, null(5,7,11)=0, avgsize(5,7,11)=12]
- │ │ │ histogram(5)= 0 2974 69979 0
- │ │ │ <--- 1.0 ------- 23.999999999999996
- │ │ │ histogram(7)= 0 0 72953 0
+ │ │ ├── stats: [rows=71117.89, distinct(5)=23.5306, null(5)=0, avgsize(5)=9, distinct(6)=68848.6, null(6)=0, avgsize(6)=9, distinct(7)=1.8, null(7)=0, avgsize(7)=9, distinct(11)=365, null(11)=0, avgsize(11)=4, distinct(6,7)=71117.9, null(6,7)=0, avgsize(6,7)=18, distinct(5,7,11)=15459.6, null(5,7,11)=0, avgsize(5,7,11)=22]
+ │ │ │ histogram(5)= 0 2860.5 68257 0
+ │ │ │ <--- 1.0 -------- 23.999999999999996
+ │ │ │ histogram(7)= 0 0 71118 0
│ │ │ <--- 0.049999999999999996 ------- 0.07
- │ │ │ histogram(11)= 0 324.17 2037.5 231.52 2083.8 231.52 2222.7 231.52 2176.4 370.46 2222.7 92.577 2222.7 231.52 2176.4 138.94 2130 231.52 2083.8 231.52 2176.4 231.52 2176.4 92.577 2130 277.81 2222.7 185.23 2130 277.81 2176.4 138.94 2222.7 92.577 2083.8 324.17 2083.8 277.81 2083.8 277.81 2037.5 277.81 2130 185.23 2176.4 324.17 2083.8 277.81 1991.2 277.81 2222.7 277.81 2222.7 185.23 2083.8 231.52 2176.4 185.23 2176.4 185.23 2176.4 185.23 1355.5 193.64
- │ │ │ <--- '1994-01-01' -------- '1994-01-11' -------- '1994-01-22' -------- '1994-02-05' -------- '1994-02-18' -------- '1994-03-01' -------- '1994-03-13' -------- '1994-03-26' ------ '1994-04-06' -------- '1994-04-17' -------- '1994-04-27' -------- '1994-05-10' ------ '1994-05-21' -------- '1994-06-03' ------ '1994-06-17' -------- '1994-06-27' -------- '1994-07-13' -------- '1994-07-27' -------- '1994-08-06' -------- '1994-08-19' -------- '1994-08-30' ------ '1994-09-11' -------- '1994-09-21' -------- '1994-10-03' -------- '1994-10-13' -------- '1994-10-26' -------- '1994-11-08' -------- '1994-11-19' -------- '1994-12-01' -------- '1994-12-13' -------- '1994-12-23' -------- '1994-12-31'
+ │ │ │ histogram(11)= 0 0 923.01 138.42 2123 323.06 2076.7 415.35 2215.2 230.78 2123 184.56 1846 415.35 1892.2 415.35 2169.1 276.92 2030.6 230.78 2076.7 184.56 2215.2 276.92 2169.1 138.42 2215.2 184.56 2215.2 138.42 2169.1 138.42 2123 276.92 2169.1 230.78 2030.6 230.78 2169.1 92.282 2169.1 184.56 2215.2 92.282 2123 230.78 1892.2 415.35 2215.2 138.42 1984.5 276.92 2076.7 184.56 2215.2 138.42 2215.2 46.141 2215.2 46.141 2123 276.92 2024.5 144.61
+ │ │ │ <--- '1993-12-31' -------- '1994-01-06' ------ '1994-01-20' -------- '1994-02-01' -------- '1994-02-14' ------ '1994-02-25' ------ '1994-03-11' -------- '1994-03-24' -------- '1994-04-07' -------- '1994-04-19' -------- '1994-05-03' -------- '1994-05-14' -------- '1994-05-24' -------- '1994-06-04' -------- '1994-06-14' -------- '1994-06-26' ------ '1994-07-06' -------- '1994-07-17' -------- '1994-08-01' -------- '1994-08-11' -------- '1994-08-25' -------- '1994-09-05' ------ '1994-09-16' -------- '1994-09-26' -------- '1994-10-07' -------- '1994-10-17' -------- '1994-10-27' -------- '1994-11-09' -------- '1994-11-22' -------- '1994-12-04' ------ '1994-12-16' -------- '1994-12-31'
│ │ ├── index-join lineitem
│ │ │ ├── save-table-name: q6_index_join_4
│ │ │ ├── columns: l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipdate:11(date!null)
- │ │ │ ├── stats: [rows=945631.6, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=634563, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(11)=365, null(11)=0, avgsize(11)=4]
+ │ │ │ ├── stats: [rows=924787.9, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=612961, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(11)=365, null(11)=0, avgsize(11)=4]
│ │ │ └── scan lineitem@l_sd
│ │ │ ├── save-table-name: q6_scan_5
│ │ │ ├── columns: l_orderkey:1(int!null) l_linenumber:4(int!null) l_shipdate:11(date!null)
│ │ │ ├── constraint: /11/1/4: [/'1994-01-01' - /'1994-12-31']
- │ │ │ ├── stats: [rows=945631.6, distinct(1)=748681, null(1)=0, avgsize(1)=4, distinct(4)=7, null(4)=0, avgsize(4)=4, distinct(11)=365, null(11)=0, avgsize(11)=4]
- │ │ │ │ histogram(1)= 0 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527
- │ │ │ │ <--- 576 --------- 38535 -------- 66885 -------- 93380 -------- 127425 -------- 157218 -------- 184483 -------- 215330 -------- 252869 -------- 283878 -------- 313798 -------- 337056 -------- 372549 -------- 399591 -------- 426245 -------- 460578 -------- 498439 -------- 526049 -------- 554468 -------- 577921 -------- 609187 -------- 639524 -------- 665345 -------- 686180 -------- 721539 -------- 755680 -------- 782756 -------- 814496 -------- 845446 -------- 872130 -------- 910912 -------- 933697 -------- 965184 -------- 1000353 -------- 1038658 -------- 1073667 -------- 1097891 -------- 1131330 -------- 1157732 -------- 1179943 -------- 1206401 -------- 1230150 -------- 1261824 -------- 1293217 -------- 1326754 -------- 1357573 -------- 1390145 -------- 1429312 -------- 1460418 -------- 1491104 -------- 1523937 -------- 1559812 -------- 1591653 -------- 1615174 -------- 1646759 -------- 1670465 -------- 1696321 -------- 1724192 -------- 1748033 -------- 1777570 -------- 1807428 -------- 1836962 -------- 1872481 -------- 1902817 -------- 1928324 -------- 1960775 -------- 1985989 -------- 2019107 -------- 2044613 -------- 2071490 -------- 2101959 -------- 2135555 -------- 2164486 -------- 2186337 -------- 2213989 -------- 2246309 -------- 2276992 -------- 2306403 -------- 2329921 -------- 2354977 -------- 2380711 -------- 2410529 -------- 2437920 -------- 2462017 -------- 2483714 -------- 2513920 -------- 2542855 -------- 2574112 -------- 2596035 -------- 2625031 -------- 2658051 -------- 2695046 -------- 2725222 -------- 2754245 -------- 2777702 -------- 2804896 -------- 2844579 -------- 2873860 -------- 2903459 -------- 2933249 -------- 2965479 -------- 2996160 -------- 3022976 -------- 3053152 -------- 3083623 -------- 3111136 -------- 3144033 -------- 3180134 -------- 3209799 -------- 3239394 -------- 3270886 -------- 3297664 -------- 3329444 -------- 3357574 -------- 3380838 -------- 3412196 -------- 3438917 -------- 3462467 -------- 3498629 -------- 3530208 -------- 3562148 -------- 3589889 -------- 3621063 -------- 3655456 -------- 3686724 -------- 3709029 -------- 3738215 -------- 3767687 -------- 3804547 -------- 3831142 -------- 3875111 -------- 3905605 -------- 3933795 -------- 3966593 -------- 3995558 -------- 4020134 -------- 4052513 -------- 4078949 -------- 4114208 -------- 4149762 -------- 4176135 -------- 4207782 -------- 4241376 -------- 4270502 -------- 4304167 -------- 4333669 -------- 4362818 -------- 4393537 -------- 4423076 -------- 4452064 -------- 4491143 -------- 4522723 -------- 4550883 -------- 4581382 -------- 4616002 -------- 4649410 -------- 4680485 -------- 4715584 -------- 4740036 -------- 4771554 -------- 4799461 -------- 4826690 -------- 4855525 -------- 4887974 -------- 4917479 -------- 4950885 -------- 4984195 -------- 5010113 -------- 5033571 -------- 5065472 -------- 5100512 -------- 5129413 -------- 5160069 -------- 5186596 -------- 5221538 -------- 5252964 -------- 5284069 -------- 5314051 -------- 5353026 -------- 5388961 -------- 5424644 -------- 5452676 -------- 5483553 -------- 5516612 -------- 5551041 -------- 5579878 -------- 5612576 -------- 5643427 -------- 5673666 -------- 5709218 -------- 5737221 -------- 5766119 -------- 5795044 -------- 5826560 -------- 5855943 -------- 5889604 -------- 5917607 -------- 5942535 -------- 5969639 -------- 5999557
- │ │ │ │ histogram(4)= 0 2.3953e+05 0 2.0057e+05 0 1.6757e+05 0 1.4232e+05 0 94563 0 68937 0 32151
- │ │ │ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 -------- 4 ----- 5 ----- 6 -
- │ │ │ │ histogram(11)= 0 4202 26410 3001 27010 3001 28811 3001 28211 4802 28811 1200 28811 3001 28211 1801 27610 3001 27010 3001 28211 3001 28211 1200 27610 3601 28811 2401 27610 3601 28211 1801 28811 1200 27010 4202 27010 3601 27010 3601 26410 3601 27610 2401 28211 4202 27010 3601 25810 3601 28811 3601 28811 2401 27010 3001 28211 2401 28211 2401 28211 2401 17570 2510
- │ │ │ │ <--- '1994-01-01' ------- '1994-01-11' ------- '1994-01-22' ------- '1994-02-05' ------- '1994-02-18' ------- '1994-03-01' ------- '1994-03-13' ------- '1994-03-26' ------- '1994-04-06' ------- '1994-04-17' ------- '1994-04-27' ------- '1994-05-10' ------- '1994-05-21' ------- '1994-06-03' ------- '1994-06-17' ------- '1994-06-27' ------- '1994-07-13' ------- '1994-07-27' ------- '1994-08-06' ------- '1994-08-19' ------- '1994-08-30' ------- '1994-09-11' ------- '1994-09-21' ------- '1994-10-03' ------- '1994-10-13' ------- '1994-10-26' ------- '1994-11-08' ------- '1994-11-19' ------- '1994-12-01' ------- '1994-12-13' ------- '1994-12-23' ------- '1994-12-31'
+ │ │ │ ├── stats: [rows=924787.9, distinct(1)=736000, null(1)=0, avgsize(1)=4, distinct(4)=7, null(4)=0, avgsize(4)=1, distinct(11)=365, null(11)=0, avgsize(11)=4]
+ │ │ │ │ histogram(1)= 0 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4439 184.92 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4439 184.92 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4439 184.92 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46
+ │ │ │ │ <--- 197 -------- 23686 -------- 53253 -------- 90435 -------- 121730 -------- 153280 -------- 175456 -------- 208548 -------- 242209 -------- 273057 ------ 296640 -------- 330307 -------- 360999 -------- 386307 -------- 420225 -------- 450050 -------- 477795 -------- 504711 -------- 533153 -------- 556672 -------- 582243 -------- 613729 -------- 646117 -------- 675840 -------- 706048 -------- 733063 -------- 769282 -------- 793922 -------- 820357 -------- 849536 -------- 875719 -------- 905028 -------- 940643 -------- 968355 -------- 998721 -------- 1023621 -------- 1059424 -------- 1084932 -------- 1115553 -------- 1139363 -------- 1167361 -------- 1194400 -------- 1225984 -------- 1253861 -------- 1281633 -------- 1304999 -------- 1336355 -------- 1370759 -------- 1400832 -------- 1434085 -------- 1458852 -------- 1491427 -------- 1525120 -------- 1555205 -------- 1591300 -------- 1619426 -------- 1651458 -------- 1682950 -------- 1711399 -------- 1747591 -------- 1787205 ------ 1822240 -------- 1856163 -------- 1886915 -------- 1910949 -------- 1947202 ------ 1974311 -------- 2009286 -------- 2044034 -------- 2079104 -------- 2103488 -------- 2134657 -------- 2164293 -------- 2204514 -------- 2230823 -------- 2265253 -------- 2289826 -------- 2329539 -------- 2364455 -------- 2393507 -------- 2414628 -------- 2440228 -------- 2465255 -------- 2489568 -------- 2520900 -------- 2554919 -------- 2583333 -------- 2612966 -------- 2644833 -------- 2667362 -------- 2702784 -------- 2727394 -------- 2759748 -------- 2794531 -------- 2822214 -------- 2846624 -------- 2883748 -------- 2919586 -------- 2951908 -------- 2980068 -------- 3014726 -------- 3050725 -------- 3081028 -------- 3113351 -------- 3150243 -------- 3185669 -------- 3214311 -------- 3241281 -------- 3275748 -------- 3303232 -------- 3339559 -------- 3370627 -------- 3393664 -------- 3435265 -------- 3464581 -------- 3489026 -------- 3516096 -------- 3548480 -------- 3587015 -------- 3611239 -------- 3638724 -------- 3668641 -------- 3695751 -------- 3729636 -------- 3751523 -------- 3784608 -------- 3815715 -------- 3848608 -------- 3881184 -------- 3908738 -------- 3940002 -------- 3966176 -------- 4001984 -------- 4035687 -------- 4065283 -------- 4092834 -------- 4133062 -------- 4160613 -------- 4196421 -------- 4223713 -------- 4254788 -------- 4291040 -------- 4313664 -------- 4342823 -------- 4369952 -------- 4391684 -------- 4419040 -------- 4449921 -------- 4471781 -------- 4506210 -------- 4538176 -------- 4571297 -------- 4601121 -------- 4630887 -------- 4657476 -------- 4684803 -------- 4714566 -------- 4744070 -------- 4776385 -------- 4807777 -------- 4839491 -------- 4873953 -------- 4902245 -------- 4936263 -------- 4970721 -------- 5003140 -------- 5029729 -------- 5059010 -------- 5087521 -------- 5121093 -------- 5150405 -------- 5178375 -------- 5203683 -------- 5234531 -------- 5268195 -------- 5300004 -------- 5331558 -------- 5362178 -------- 5385762 -------- 5418498 -------- 5445762 -------- 5483109 -------- 5514561 -------- 5542052 -------- 5569572 -------- 5596102 -------- 5622401 -------- 5652194 -------- 5671362 -------- 5699591 -------- 5727136 -------- 5753284 -------- 5780742 -------- 5809189 -------- 5836545 -------- 5864454 -------- 5894917 -------- 5933825 -------- 5968933 -------- 5999590
+ │ │ │ │ histogram(4)= 0 2.2925e+05 0 2.0632e+05 0 1.6221e+05 0 1.328e+05 0 98120 0 63995 0 32090
+ │ │ │ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ------- 5 ----- 6 ----- 7 -
+ │ │ │ │ histogram(11)= 0 0 12002 1800 27606 4201 27005 5401 28806 3001 27606 2400 24005 5401 24605 5401 28206 3601 26405 3001 27005 2400 28806 3601 28206 1800 28806 2400 28806 1800 28206 1800 27606 3601 28206 3001 26405 3001 28206 1200 28206 2400 28806 1200 27606 3001 24605 5401 28806 1800 25805 3601 27005 2400 28806 1800 28806 600 28806 600 27606 3601 26326 1880.4
+ │ │ │ │ <--- '1993-12-31' ------- '1994-01-06' ------- '1994-01-20' ------- '1994-02-01' ------- '1994-02-14' ------- '1994-02-25' ------- '1994-03-11' ------- '1994-03-24' ------- '1994-04-07' ------- '1994-04-19' ------- '1994-05-03' ------- '1994-05-14' ------- '1994-05-24' ------- '1994-06-04' ------- '1994-06-14' ------- '1994-06-26' ------- '1994-07-06' ------- '1994-07-17' ------- '1994-08-01' ------- '1994-08-11' ------- '1994-08-25' ------- '1994-09-05' ------- '1994-09-16' ------- '1994-09-26' ------- '1994-10-07' ------- '1994-10-17' ------- '1994-10-27' ------- '1994-11-09' ------- '1994-11-22' ------- '1994-12-04' ------- '1994-12-16' ------- '1994-12-31'
│ │ │ ├── key: (1,4)
│ │ │ └── fd: (1,4)-->(11)
│ │ └── filters
@@ -92,7 +92,7 @@ column_names row_count distinct_count null_count
{column19} 114160 108866 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column19} 72953.00 1.56 72953.00 1.49 0.00 1.00
+{column19} 71118.00 1.61 71118.00 1.53 0.00 1.00
----Stats for q6_select_3----
column_names row_count distinct_count null_count
@@ -102,10 +102,10 @@ column_names row_count distinct_count null_count
{l_shipdate} 114160 365 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 72953.00 1.56 2.00 1.50 0.00 1.00
-{l_extendedprice} 72953.00 1.56 70695.00 1.40 0.00 1.00
-{l_quantity} 72953.00 1.56 24.00 1.04 0.00 1.00
-{l_shipdate} 72953.00 1.56 365.00 1.00 0.00 1.00
+{l_discount} 71118.00 1.61 2.00 1.50 0.00 1.00
+{l_extendedprice} 71118.00 1.61 68849.00 1.43 0.00 1.00
+{l_quantity} 71118.00 1.61 24.00 1.04 0.00 1.00
+{l_shipdate} 71118.00 1.61 365.00 1.00 0.00 1.00
----Stats for q6_index_join_4----
column_names row_count distinct_count null_count
@@ -115,10 +115,10 @@ column_names row_count distinct_count null_count
{l_shipdate} 909455 365 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 945632.00 1.04 11.00 1.00 0.00 1.00
-{l_extendedprice} 945632.00 1.04 634563.00 1.12 0.00 1.00
-{l_quantity} 945632.00 1.04 50.00 1.00 0.00 1.00
-{l_shipdate} 945632.00 1.04 365.00 1.00 0.00 1.00
+{l_discount} 924788.00 1.02 11.00 1.00 0.00 1.00
+{l_extendedprice} 924788.00 1.02 612961.00 1.08 0.00 1.00
+{l_quantity} 924788.00 1.02 50.00 1.00 0.00 1.00
+{l_shipdate} 924788.00 1.02 365.00 1.00 0.00 1.00
----Stats for q6_scan_5----
column_names row_count distinct_count null_count
@@ -127,8 +127,8 @@ column_names row_count distinct_count null_count
{l_shipdate} 909455 365 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 945632.00 1.04 7.00 1.00 0.00 1.00
-{l_orderkey} 945632.00 1.04 748681.00 2.81 <== 0.00 1.00
-{l_shipdate} 945632.00 1.04 365.00 1.00 0.00 1.00
+{l_linenumber} 924788.00 1.02 7.00 1.00 0.00 1.00
+{l_orderkey} 924788.00 1.02 736000.00 2.77 <== 0.00 1.00
+{l_shipdate} 924788.00 1.02 365.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q07 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q07
index d0c02bcb117d..13660ffdfc36 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q07
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q07
@@ -61,7 +61,7 @@ sort
├── save-table-name: q7_sort_1
├── columns: supp_nation:50(char!null) cust_nation:56(char!null) l_year:61(float) revenue:63(float!null)
├── immutable
- ├── stats: [rows=974.2888, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4, distinct(61)=730.979, null(61)=0, avgsize(61)=4, distinct(63)=974.289, null(63)=0, avgsize(63)=12, distinct(50,56,61)=974.289, null(50,56,61)=0, avgsize(50,56,61)=12]
+ ├── stats: [rows=974.2682, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(56)=1.33333, null(56)=0, avgsize(56)=10, distinct(61)=730.978, null(61)=0, avgsize(61)=4, distinct(63)=974.268, null(63)=0, avgsize(63)=24, distinct(50,56,61)=974.268, null(50,56,61)=0, avgsize(50,56,61)=24]
├── key: (50,56,61)
├── fd: (50,56,61)-->(63)
├── ordering: +50,+56,+61
@@ -70,27 +70,27 @@ sort
├── columns: n1.n_name:50(char!null) n2.n_name:56(char!null) l_year:61(float) sum:63(float!null)
├── grouping columns: n1.n_name:50(char!null) n2.n_name:56(char!null) l_year:61(float)
├── immutable
- ├── stats: [rows=974.2888, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4, distinct(61)=730.979, null(61)=0, avgsize(61)=4, distinct(63)=974.289, null(63)=0, avgsize(63)=12, distinct(50,56,61)=974.289, null(50,56,61)=0, avgsize(50,56,61)=12]
+ ├── stats: [rows=974.2682, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(56)=1.33333, null(56)=0, avgsize(56)=10, distinct(61)=730.978, null(61)=0, avgsize(61)=4, distinct(63)=974.268, null(63)=0, avgsize(63)=24, distinct(50,56,61)=974.268, null(50,56,61)=0, avgsize(50,56,61)=24]
├── key: (50,56,61)
├── fd: (50,56,61)-->(63)
├── project
│ ├── save-table-name: q7_project_3
│ ├── columns: l_year:61(float) volume:62(float!null) n1.n_name:50(char!null) n2.n_name:56(char!null)
│ ├── immutable
- │ ├── stats: [rows=7656.189, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4, distinct(61)=730.979, null(61)=0, avgsize(61)=4, distinct(62)=7496.02, null(62)=0, avgsize(62)=8, distinct(50,56,61)=974.289, null(50,56,61)=0, avgsize(50,56,61)=12]
+ │ ├── stats: [rows=7604.442, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(56)=1.33333, null(56)=0, avgsize(56)=10, distinct(61)=730.978, null(61)=0, avgsize(61)=4, distinct(62)=7445.29, null(62)=0, avgsize(62)=18, distinct(50,56,61)=974.268, null(50,56,61)=0, avgsize(50,56,61)=24]
│ ├── inner-join (hash)
│ │ ├── save-table-name: q7_inner_join_4
│ │ ├── columns: s_suppkey:1(int!null) s_nationkey:4(int!null) l_orderkey:10(int!null) l_suppkey:12(int!null) l_extendedprice:15(float!null) l_discount:16(float!null) l_shipdate:20(date!null) o_orderkey:28(int!null) o_custkey:29(int!null) c_custkey:39(int!null) c_nationkey:42(int!null) n1.n_nationkey:49(int!null) n1.n_name:50(char!null) n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
│ │ ├── multiplicity: left-rows(zero-or-more), right-rows(zero-or-one)
- │ │ ├── stats: [rows=7656.189, distinct(1)=7656.19, null(1)=0, avgsize(1)=4, distinct(4)=1.29975, null(4)=0, avgsize(4)=4, distinct(10)=7407.94, null(10)=0, avgsize(10)=4, distinct(12)=7656.19, null(12)=0, avgsize(12)=4, distinct(15)=7486.94, null(15)=0, avgsize(15)=4, distinct(16)=11, null(16)=0, avgsize(16)=4, distinct(20)=730.979, null(20)=0, avgsize(20)=4, distinct(28)=7407.94, null(28)=0, avgsize(28)=4, distinct(29)=4913.87, null(29)=0, avgsize(29)=4, distinct(39)=4913.87, null(39)=0, avgsize(39)=4, distinct(42)=1.29975, null(42)=0, avgsize(42)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=4, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(55)=1.29975, null(55)=0, avgsize(55)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4, distinct(15,16)=7496.02, null(15,16)=0, avgsize(15,16)=8, distinct(20,50,56)=974.289, null(20,50,56)=0, avgsize(20,50,56)=12]
+ │ │ ├── stats: [rows=7604.442, distinct(1)=7604.44, null(1)=0, avgsize(1)=3, distinct(4)=1.29975, null(4)=0, avgsize(4)=2, distinct(10)=7359.52, null(10)=0, avgsize(10)=4, distinct(12)=7604.44, null(12)=0, avgsize(12)=4, distinct(15)=7435.74, null(15)=0, avgsize(15)=9, distinct(16)=11, null(16)=0, avgsize(16)=9, distinct(20)=730.978, null(20)=0, avgsize(20)=4, distinct(28)=7359.52, null(28)=0, avgsize(28)=4, distinct(29)=4894.07, null(29)=0, avgsize(29)=4, distinct(39)=4894.07, null(39)=0, avgsize(39)=4, distinct(42)=1.29975, null(42)=0, avgsize(42)=2, distinct(49)=1.29975, null(49)=0, avgsize(49)=1, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(55)=1.29975, null(55)=0, avgsize(55)=1, distinct(56)=1.33333, null(56)=0, avgsize(56)=10, distinct(15,16)=7445.29, null(15,16)=0, avgsize(15,16)=18, distinct(20,50,56)=974.268, null(20,50,56)=0, avgsize(20,50,56)=24]
│ │ ├── fd: (1)-->(4), (28)-->(29), (39)-->(42), (49)-->(50), (55)-->(56), (42)==(55), (55)==(42), (29)==(39), (39)==(29), (10)==(28), (28)==(10), (1)==(12), (12)==(1), (4)==(49), (49)==(4)
│ │ ├── scan customer@c_nk
│ │ │ ├── save-table-name: q7_scan_5
│ │ │ ├── columns: c_custkey:39(int!null) c_nationkey:42(int!null)
- │ │ │ ├── stats: [rows=150000, distinct(39)=148813, null(39)=0, avgsize(39)=4, distinct(42)=25, null(42)=0, avgsize(42)=4]
- │ │ │ │ histogram(39)= 0 5 769 5 765 5 732 5 744 5 731 5 754 5 772 5 757 5 713 5 741 5 808 5 744 5 739 5 687 5 820 5 761 5 782 5 632 5 711 5 692 5 648 5 770 5 765 5 702 5 751 5 807 5 794 5 735 5 807 5 719 5 773 5 781 5 684 5 748 5 682 5 703 5 794 5 718 5 807 5 674 5 747 5 677 5 813 5 666 5 766 5 822 5 703 5 676 5 765 5 693 5 723 5 780 5 793 5 770 5 696 5 775 5 764 5 884 5 696 5 688 5 637 5 789 5 702 5 732 5 697 5 769 5 739 5 744 5 861 5 791 5 726 5 793 5 730 5 763 5 789 5 797 5 775 5 862 5 780 5 746 5 783 5 743 5 822 5 806 5 775 5 727 5 724 5 799 5 707 5 757 5 614 5 747 5 704 5 740 5 749 5 735 5 741 5 807 5 827 5 816 5 702 5 699 5 803 5 793 5 672 5 831 5 694 5 746 5 731 5 686 5 685 5 695 5 828 5 756 5 722 5 749 5 790 5 758 5 750 5 782 5 733 5 778 5 762 5 758 5 731 5 778 5 663 5 696 5 684 5 796 5 770 5 656 5 690 5 747 5 782 5 785 5 751 5 697 5 663 5 766 5 695 5 866 5 813 5 765 5 901 5 747 5 683 5 706 5 689 5 734 5 715 5 752 5 855 5 771 5 717 5 794 5 760 5 827 5 747 5 757 5 767 5 726 5 690 5 787 5 783 5 744 5 761 5 746 5 793 5 696 5 749 5 745 5 755 5 800 5 778 5 814 5 826 5 700 5 740 5 773 5 713 5 824 5 792 5 702 5 734 5 751 5 716 5 718 5 722 5 784 5 778 5 700 5 714 5 739 5 748 5 697 5 751 5 663 5 740 5
- │ │ │ │ <--- 37 ----- 834 ----- 1623 ----- 2351 ----- 3101 ----- 3828 ----- 4598 ----- 5401 ----- 6176 ----- 6868 ----- 7613 ----- 8479 ----- 9230 ----- 9972 ----- 10613 ----- 11500 ----- 12282 ----- 13103 ----- 13624 ----- 14312 ----- 14962 ----- 15520 ----- 16319 ----- 17109 ----- 17780 ----- 18543 ----- 19408 ----- 20250 ----- 20984 ----- 21848 ----- 22551 ----- 23355 ----- 24174 ----- 24809 ----- 25567 ----- 26196 ----- 26868 ----- 27710 ----- 28412 ----- 29276 ----- 29889 ----- 30645 ----- 31264 ----- 32139 ----- 32736 ----- 33527 ----- 34418 ----- 35091 ----- 35709 ----- 36498 ----- 37150 ----- 37861 ----- 38677 ----- 39517 ----- 40316 ----- 40975 ----- 41782 ----- 42569 ----- 43565 ----- 44224 ----- 44867 ----- 45399 ----- 46231 ----- 46902 ----- 47630 ----- 48291 ----- 49087 ----- 49829 ----- 50580 ----- 51538 ----- 52375 ----- 53092 ----- 53932 ----- 54656 ----- 55442 ----- 56274 ----- 57121 ----- 57929 ----- 58888 ----- 59705 ----- 60460 ----- 61282 ----- 62031 ----- 62922 ----- 63785 ----- 64593 ----- 65311 ----- 66024 ----- 66875 ----- 67556 ----- 68331 ----- 68808 ----- 69564 ----- 70239 ----- 70983 ----- 71744 ----- 72478 ----- 73223 ----- 74088 ----- 74988 ----- 75868 ----- 76539 ----- 77203 ----- 78061 ----- 78901 ----- 79510 ----- 80417 ----- 81071 ----- 81826 ----- 82553 ----- 83191 ----- 83828 ----- 84485 ----- 85386 ----- 86159 ----- 86868 ----- 87628 ----- 88463 ----- 89240 ----- 90002 ----- 90822 ----- 91553 ----- 92367 ----- 93152 ----- 93929 ----- 94656 ----- 95470 ----- 96061 ----- 96720 ----- 97355 ----- 98200 ----- 98998 ----- 99573 ----- 100219 ----- 100975 ----- 101795 ----- 102620 ----- 103384 ----- 104044 ----- 104635 ----- 105426 ----- 106083 ----- 107049 ----- 107925 ----- 108715 ----- 109740 ----- 110496 ----- 111128 ----- 111807 ----- 112451 ----- 113184 ----- 113866 ----- 114619 ----- 115556 ----- 116344 ----- 117029 ----- 117859 ----- 118626 ----- 119515 ----- 120258 ----- 121021 ----- 121802 ----- 122505 ----- 123136 ----- 123953 ----- 124763 ----- 125501 ----- 126271 ----- 127012 ----- 127841 ----- 128483 ----- 129230 ----- 129970 ----- 130729 ----- 131569 ----- 132370 ----- 133235 ----- 134122 ----- 134773 ----- 135503 ----- 136294 ----- 136971 ----- 137854 ----- 138681 ----- 139336 ----- 140055 ----- 140806 ----- 141489 ----- 142177 ----- 142873 ----- 143685 ----- 144486 ----- 145138 ----- 145817 ----- 146545 ----- 147291 ----- 147936 ----- 148687 ----- 149260 ----- 149990
- │ │ │ │ histogram(42)= 0 5865 0 5790 0 5715 0 6645 0 5865 0 5955 0 5790 0 5865 0 5760 0 6060 0 5790 0 6435 0 6150 0 6075 0 5805 0 7050 0 5970 0 5970 0 5865 0 5895 0 5835 0 6180 0 5760 0 5775 0 6135
+ │ │ │ ├── stats: [rows=150000, distinct(39)=148813, null(39)=0, avgsize(39)=4, distinct(42)=25, null(42)=0, avgsize(42)=2]
+ │ │ │ │ histogram(39)= 0 0 0 5 745 5 746 5 711 5 780 5 738 5 835 5 697 5 757 5 704 5 696 5 753 5 678 5 813 5 873 5 736 5 840 5 703 5 745 5 710 5 763 5 742 5 673 5 702 5 793 5 732 5 752 5 707 5 751 5 722 5 814 5 789 5 671 5 643 5 706 5 723 5 757 5 713 5 760 5 766 5 711 5 858 5 702 5 695 5 697 5 823 5 857 5 712 5 808 5 754 5 739 5 694 5 782 5 792 5 751 5 758 5 749 5 798 5 685 5 692 5 792 5 710 5 771 5 724 5 853 5 713 5 823 5 772 5 656 5 763 5 672 5 735 5 810 5 786 5 709 5 731 5 702 5 708 5 669 5 733 5 744 5 758 5 800 5 682 5 716 5 716 5 729 5 778 5 721 5 766 5 820 5 757 5 739 5 799 5 780 5 710 5 749 5 754 5 750 5 699 5 821 5 759 5 818 5 763 5 854 5 779 5 810 5 783 5 686 5 703 5 776 5 675 5 812 5 745 5 759 5 793 5 751 5 761 5 798 5 794 5 729 5 696 5 699 5 831 5 709 5 747 5 722 5 768 5 729 5 702 5 729 5 698 5 767 5 792 5 726 5 737 5 671 5 721 5 842 5 701 5 704 5 708 5 726 5 695 5 665 5 688 5 653 5 690 5 734 5 789 5 659 5 785 5 733 5 740 5 826 5 745 5 929 5 899 5 743 5 790 5 825 5 779 5 677 5 697 5 756 5 693 5 862 5 772 5 783 5 757 5 799 5 778 5 752 5 715 5 709 5 790 5 789 5 865 5 808 5 772 5 743 5 751 5 742 5 676 5 684 5 744 5 709 5 679 5 817 5 755 5 754 5 797 5 709 5 748 5 679 5 751 5 775 5 736 5 790 5 714 5 0 0
+ │ │ │ │ <--- -9223372036854775808 --- 59 ----- 811 ----- 1565 ----- 2252 ----- 3068 ----- 3807 ----- 4720 ----- 5381 ----- 6155 ----- 6829 ----- 7487 ----- 8254 ----- 8876 ----- 9751 ----- 10728 ----- 11463 ----- 12385 ----- 13057 ----- 13810 ----- 14495 ----- 15281 ----- 16028 ----- 16640 ----- 17311 ----- 18151 ----- 18880 ----- 19645 ----- 20325 ----- 21088 ----- 21798 ----- 22674 ----- 23507 ----- 24115 ----- 24661 ----- 25340 ----- 26052 ----- 26827 ----- 27518 ----- 28298 ----- 29089 ----- 29777 ----- 30730 ----- 31401 ----- 32057 ----- 32718 ----- 33611 ----- 34562 ----- 35251 ----- 36117 ----- 36887 ----- 37629 ----- 38283 ----- 39104 ----- 39942 ----- 40705 ----- 41481 ----- 42241 ----- 43089 ----- 43725 ----- 44376 ----- 45214 ----- 45899 ----- 46700 ----- 47413 ----- 48356 ----- 49047 ----- 49939 ----- 50742 ----- 51316 ----- 52101 ----- 52710 ----- 53444 ----- 54313 ----- 55140 ----- 55823 ----- 56549 ----- 57219 ----- 57901 ----- 58503 ----- 59234 ----- 59984 ----- 60760 ----- 61613 ----- 62243 ----- 62941 ----- 63638 ----- 64360 ----- 65173 ----- 65880 ----- 66672 ----- 67560 ----- 68334 ----- 69075 ----- 69925 ----- 70742 ----- 71428 ----- 72189 ----- 72958 ----- 73720 ----- 74385 ----- 75274 ----- 76053 ----- 76936 ----- 77721 ----- 78666 ----- 79480 ----- 80349 ----- 81171 ----- 81810 ----- 82482 ----- 83292 ----- 83907 ----- 84780 ----- 85532 ----- 86310 ----- 87149 ----- 87912 ----- 88694 ----- 89543 ----- 90384 ----- 91106 ----- 91764 ----- 92428 ----- 93335 ----- 94018 ----- 94775 ----- 95484 ----- 96279 ----- 97001 ----- 97672 ----- 98394 ----- 99056 ----- 99850 ----- 100688 ----- 101405 ----- 102143 ----- 102751 ----- 103459 ----- 104384 ----- 105052 ----- 105727 ----- 106409 ----- 107125 ----- 107782 ----- 108377 ----- 109020 ----- 109588 ----- 110235 ----- 110967 ----- 111800 ----- 112382 ----- 113196 ----- 113913 ----- 114643 ----- 115529 ----- 116268 ----- 117329 ----- 118341 ----- 119076 ----- 119898 ----- 120782 ----- 121584 ----- 122186 ----- 122830 ----- 123591 ----- 124227 ----- 125175 ----- 125964 ----- 126773 ----- 127535 ----- 128374 ----- 129175 ----- 129928 ----- 130609 ----- 131279 ----- 132102 ----- 132923 ----- 133877 ----- 134732 ----- 135521 ----- 136257 ----- 137007 ----- 137740 ----- 138341 ----- 138958 ----- 139695 ----- 140364 ----- 140971 ----- 141841 ----- 142600 ----- 143356 ----- 144192 ----- 144861 ----- 145607 ----- 146214 ----- 146965 ----- 147761 ----- 148483 ----- 149306 ----- 149986 --- 9223372036854775807
+ │ │ │ │ histogram(42)= 0 5475 0 5910 0 5925 0 6075 0 5910 0 5895 0 6765 0 6090 0 6000 0 6735 0 5730 0 6015 0 5895 0 6180 0 5565 0 5760 0 6390 0 6135 0 5940 0 6105 0 6150 0 5700 0 6225 0 6075 0 5355
│ │ │ │ <--- 0 ---- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 ---- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ ├── key: (39)
│ │ │ └── fd: (39)-->(42)
@@ -99,39 +99,39 @@ sort
│ │ │ ├── columns: s_suppkey:1(int!null) s_nationkey:4(int!null) l_orderkey:10(int!null) l_suppkey:12(int!null) l_extendedprice:15(float!null) l_discount:16(float!null) l_shipdate:20(date!null) o_orderkey:28(int!null) o_custkey:29(int!null) n1.n_nationkey:49(int!null) n1.n_name:50(char!null) n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
│ │ │ ├── key columns: [10] = [28]
│ │ │ ├── lookup columns are key
- │ │ │ ├── stats: [rows=98990.74, distinct(1)=529.63, null(1)=0, avgsize(1)=4, distinct(4)=1.29975, null(4)=0, avgsize(4)=4, distinct(10)=94907.6, null(10)=0, avgsize(10)=4, distinct(12)=529.63, null(12)=0, avgsize(12)=4, distinct(15)=61085.9, null(15)=0, avgsize(15)=4, distinct(16)=11, null(16)=0, avgsize(16)=4, distinct(20)=731, null(20)=0, avgsize(20)=4, distinct(28)=94907.6, null(28)=0, avgsize(28)=4, distinct(29)=62800.6, null(29)=0, avgsize(29)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=4, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(55)=1.29975, null(55)=0, avgsize(55)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4]
+ │ │ │ ├── stats: [rows=97519.83, distinct(1)=529.63, null(1)=0, avgsize(1)=3, distinct(4)=1.29975, null(4)=0, avgsize(4)=2, distinct(10)=93524.1, null(10)=0, avgsize(10)=4, distinct(12)=529.63, null(12)=0, avgsize(12)=4, distinct(15)=60140.8, null(15)=0, avgsize(15)=9, distinct(16)=11, null(16)=0, avgsize(16)=9, distinct(20)=731, null(20)=0, avgsize(20)=4, distinct(28)=93524.1, null(28)=0, avgsize(28)=4, distinct(29)=62248.9, null(29)=0, avgsize(29)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=1, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(55)=1.29975, null(55)=0, avgsize(55)=1, distinct(56)=1.33333, null(56)=0, avgsize(56)=10]
│ │ │ ├── fd: (28)-->(29), (1)-->(4), (49)-->(50), (55)-->(56), (4)==(49), (49)==(4), (1)==(12), (12)==(1), (10)==(28), (28)==(10)
│ │ │ ├── inner-join (lookup lineitem)
│ │ │ │ ├── save-table-name: q7_lookup_join_7
│ │ │ │ ├── columns: s_suppkey:1(int!null) s_nationkey:4(int!null) l_orderkey:10(int!null) l_suppkey:12(int!null) l_extendedprice:15(float!null) l_discount:16(float!null) l_shipdate:20(date!null) n1.n_nationkey:49(int!null) n1.n_name:50(char!null) n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
│ │ │ │ ├── key columns: [10 13] = [10 13]
│ │ │ │ ├── lookup columns are key
- │ │ │ │ ├── stats: [rows=98990.74, distinct(1)=529.63, null(1)=0, avgsize(1)=4, distinct(4)=1.29975, null(4)=0, avgsize(4)=4, distinct(10)=94907.6, null(10)=0, avgsize(10)=4, distinct(12)=529.63, null(12)=0, avgsize(12)=4, distinct(15)=93572.9, null(15)=0, avgsize(15)=4, distinct(16)=11, null(16)=0, avgsize(16)=4, distinct(20)=731, null(20)=0, avgsize(20)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=4, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(55)=1.29975, null(55)=0, avgsize(55)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4]
+ │ │ │ │ ├── stats: [rows=97519.83, distinct(1)=529.63, null(1)=0, avgsize(1)=3, distinct(4)=1.29975, null(4)=0, avgsize(4)=2, distinct(10)=93524.1, null(10)=0, avgsize(10)=4, distinct(12)=529.63, null(12)=0, avgsize(12)=4, distinct(15)=92051.8, null(15)=0, avgsize(15)=9, distinct(16)=11, null(16)=0, avgsize(16)=9, distinct(20)=731, null(20)=0, avgsize(20)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=1, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(55)=1.29975, null(55)=0, avgsize(55)=1, distinct(56)=1.33333, null(56)=0, avgsize(56)=10]
│ │ │ │ ├── fd: (1)-->(4), (49)-->(50), (55)-->(56), (4)==(49), (49)==(4), (1)==(12), (12)==(1)
│ │ │ │ ├── inner-join (lookup lineitem@l_sk)
│ │ │ │ │ ├── save-table-name: q7_lookup_join_8
│ │ │ │ │ ├── columns: s_suppkey:1(int!null) s_nationkey:4(int!null) l_orderkey:10(int!null) l_suppkey:12(int!null) l_linenumber:13(int!null) n1.n_nationkey:49(int!null) n1.n_name:50(char!null) n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
│ │ │ │ │ ├── key columns: [1] = [12]
- │ │ │ │ │ ├── stats: [rows=322703.9, distinct(1)=529.63, null(1)=0, avgsize(1)=4, distinct(4)=1.29975, null(4)=0, avgsize(4)=4, distinct(10)=290904, null(10)=0, avgsize(10)=4, distinct(12)=529.63, null(12)=0, avgsize(12)=4, distinct(13)=7, null(13)=0, avgsize(13)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=4, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(55)=1.29975, null(55)=0, avgsize(55)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4]
+ │ │ │ │ │ ├── stats: [rows=322646, distinct(1)=529.63, null(1)=0, avgsize(1)=3, distinct(4)=1.29975, null(4)=0, avgsize(4)=2, distinct(10)=290857, null(10)=0, avgsize(10)=4, distinct(12)=529.63, null(12)=0, avgsize(12)=4, distinct(13)=7, null(13)=0, avgsize(13)=1, distinct(49)=1.29975, null(49)=0, avgsize(49)=1, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(55)=1.29975, null(55)=0, avgsize(55)=1, distinct(56)=1.33333, null(56)=0, avgsize(56)=10]
│ │ │ │ │ ├── key: (10,13,55)
│ │ │ │ │ ├── fd: (1)-->(4), (49)-->(50), (55)-->(56), (4)==(49), (49)==(4), (10,13)-->(12), (1)==(12), (12)==(1)
│ │ │ │ │ ├── inner-join (lookup supplier@s_nk)
│ │ │ │ │ │ ├── save-table-name: q7_lookup_join_9
│ │ │ │ │ │ ├── columns: s_suppkey:1(int!null) s_nationkey:4(int!null) n1.n_nationkey:49(int!null) n1.n_name:50(char!null) n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
│ │ │ │ │ │ ├── key columns: [49] = [4]
- │ │ │ │ │ │ ├── stats: [rows=533.3333, distinct(1)=529.63, null(1)=0, avgsize(1)=4, distinct(4)=1.29975, null(4)=0, avgsize(4)=4, distinct(49)=1.29975, null(49)=0, avgsize(49)=4, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(55)=1.29975, null(55)=0, avgsize(55)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4]
+ │ │ │ │ │ │ ├── stats: [rows=533.3333, distinct(1)=529.63, null(1)=0, avgsize(1)=3, distinct(4)=1.29975, null(4)=0, avgsize(4)=2, distinct(49)=1.29975, null(49)=0, avgsize(49)=1, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(55)=1.29975, null(55)=0, avgsize(55)=1, distinct(56)=1.33333, null(56)=0, avgsize(56)=10]
│ │ │ │ │ │ ├── key: (1,55)
│ │ │ │ │ │ ├── fd: (1)-->(4), (49)-->(50), (55)-->(56), (4)==(49), (49)==(4)
│ │ │ │ │ │ ├── inner-join (cross)
│ │ │ │ │ │ │ ├── save-table-name: q7_inner_join_10
│ │ │ │ │ │ │ ├── columns: n1.n_nationkey:49(int!null) n1.n_name:50(char!null) n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
- │ │ │ │ │ │ │ ├── stats: [rows=1.333333, distinct(49)=1.29975, null(49)=0, avgsize(49)=4, distinct(50)=1.33333, null(50)=0, avgsize(50)=4, distinct(55)=1.29975, null(55)=0, avgsize(55)=4, distinct(56)=1.33333, null(56)=0, avgsize(56)=4, distinct(50,56)=1.33333, null(50,56)=0, avgsize(50,56)=8]
+ │ │ │ │ │ │ │ ├── stats: [rows=1.333333, distinct(49)=1.29975, null(49)=0, avgsize(49)=1, distinct(50)=1.33333, null(50)=0, avgsize(50)=10, distinct(55)=1.29975, null(55)=0, avgsize(55)=1, distinct(56)=1.33333, null(56)=0, avgsize(56)=10, distinct(50,56)=1.33333, null(50,56)=0, avgsize(50,56)=20]
│ │ │ │ │ │ │ ├── key: (49,55)
│ │ │ │ │ │ │ ├── fd: (49)-->(50), (55)-->(56)
│ │ │ │ │ │ │ ├── scan nation [as=n1]
│ │ │ │ │ │ │ │ ├── save-table-name: q7_scan_11
│ │ │ │ │ │ │ │ ├── columns: n1.n_nationkey:49(int!null) n1.n_name:50(char!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(49)=25, null(49)=0, avgsize(49)=4, distinct(50)=25, null(50)=0, avgsize(50)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(49)=25, null(49)=0, avgsize(49)=1, distinct(50)=25, null(50)=0, avgsize(50)=10]
│ │ │ │ │ │ │ │ │ histogram(49)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ │ histogram(50)= 0 1 23 1
@@ -141,7 +141,7 @@ sort
│ │ │ │ │ │ │ ├── scan nation [as=n2]
│ │ │ │ │ │ │ │ ├── save-table-name: q7_scan_12
│ │ │ │ │ │ │ │ ├── columns: n2.n_nationkey:55(int!null) n2.n_name:56(char!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(55)=25, null(55)=0, avgsize(55)=4, distinct(56)=25, null(56)=0, avgsize(56)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(55)=25, null(55)=0, avgsize(55)=1, distinct(56)=25, null(56)=0, avgsize(56)=10]
│ │ │ │ │ │ │ │ │ histogram(55)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ │ histogram(56)= 0 1 23 1
@@ -199,10 +199,10 @@ column_names row_count distinct_count null_count
{volume} 5924 5904 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_year} 7656.00 1.29 731.00 365.50 <== 0.00 1.00
-{n_name} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{n_name_1} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{volume} 7656.00 1.29 7496.00 1.27 0.00 1.00
+{l_year} 7604.00 1.28 731.00 365.50 <== 0.00 1.00
+{n_name} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{n_name_1} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{volume} 7604.00 1.28 7445.00 1.26 0.00 1.00
----Stats for q7_inner_join_4----
column_names row_count distinct_count null_count
@@ -223,21 +223,21 @@ column_names row_count distinct_count null_count
{s_suppkey} 5924 796 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 7656.00 1.29 4914.00 1.26 0.00 1.00
-{c_nationkey} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{l_discount} 7656.00 1.29 11.00 1.00 0.00 1.00
-{l_extendedprice} 7656.00 1.29 7487.00 1.27 0.00 1.00
-{l_orderkey} 7656.00 1.29 7408.00 1.36 0.00 1.00
-{l_shipdate} 7656.00 1.29 731.00 1.00 0.00 1.00
-{l_suppkey} 7656.00 1.29 7656.00 9.62 <== 0.00 1.00
-{n_name} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{n_name_1} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{n_nationkey} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{n_nationkey_1} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{o_custkey} 7656.00 1.29 4914.00 1.26 0.00 1.00
-{o_orderkey} 7656.00 1.29 7408.00 1.36 0.00 1.00
-{s_nationkey} 7656.00 1.29 1.00 2.00 <== 0.00 1.00
-{s_suppkey} 7656.00 1.29 7656.00 9.62 <== 0.00 1.00
+{c_custkey} 7604.00 1.28 4894.00 1.25 0.00 1.00
+{c_nationkey} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{l_discount} 7604.00 1.28 11.00 1.00 0.00 1.00
+{l_extendedprice} 7604.00 1.28 7436.00 1.27 0.00 1.00
+{l_orderkey} 7604.00 1.28 7360.00 1.35 0.00 1.00
+{l_shipdate} 7604.00 1.28 731.00 1.00 0.00 1.00
+{l_suppkey} 7604.00 1.28 7604.00 9.55 <== 0.00 1.00
+{n_name} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{n_name_1} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{n_nationkey} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{n_nationkey_1} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{o_custkey} 7604.00 1.28 4894.00 1.25 0.00 1.00
+{o_orderkey} 7604.00 1.28 7360.00 1.35 0.00 1.00
+{s_nationkey} 7604.00 1.28 1.00 2.00 <== 0.00 1.00
+{s_suppkey} 7604.00 1.28 7604.00 9.55 <== 0.00 1.00
----Stats for q7_scan_5----
column_names row_count distinct_count null_count
@@ -265,19 +265,19 @@ column_names row_count distinct_count null_count
{s_suppkey} 145703 798 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 98991.00 1.47 11.00 1.00 0.00 1.00
-{l_extendedprice} 98991.00 1.47 61086.00 2.14 <== 0.00 1.00
-{l_orderkey} 98991.00 1.47 94908.00 1.33 0.00 1.00
-{l_shipdate} 98991.00 1.47 731.00 1.00 0.00 1.00
-{l_suppkey} 98991.00 1.47 530.00 1.51 0.00 1.00
-{n_name} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{n_name_1} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{n_nationkey} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{n_nationkey_1} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{o_custkey} 98991.00 1.47 62801.00 1.09 0.00 1.00
-{o_orderkey} 98991.00 1.47 94908.00 1.33 0.00 1.00
-{s_nationkey} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{s_suppkey} 98991.00 1.47 530.00 1.51 0.00 1.00
+{l_discount} 97520.00 1.49 11.00 1.00 0.00 1.00
+{l_extendedprice} 97520.00 1.49 60141.00 2.17 <== 0.00 1.00
+{l_orderkey} 97520.00 1.49 93524.00 1.35 0.00 1.00
+{l_shipdate} 97520.00 1.49 731.00 1.00 0.00 1.00
+{l_suppkey} 97520.00 1.49 530.00 1.51 0.00 1.00
+{n_name} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{n_name_1} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{n_nationkey} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{n_nationkey_1} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{o_custkey} 97520.00 1.49 62249.00 1.09 0.00 1.00
+{o_orderkey} 97520.00 1.49 93524.00 1.35 0.00 1.00
+{s_nationkey} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{s_suppkey} 97520.00 1.49 530.00 1.51 0.00 1.00
----Stats for q7_lookup_join_7----
column_names row_count distinct_count null_count
@@ -294,17 +294,17 @@ column_names row_count distinct_count null_count
{s_suppkey} 145703 798 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 98991.00 1.47 11.00 1.00 0.00 1.00
-{l_extendedprice} 98991.00 1.47 93573.00 1.39 0.00 1.00
-{l_orderkey} 98991.00 1.47 94908.00 1.33 0.00 1.00
-{l_shipdate} 98991.00 1.47 731.00 1.00 0.00 1.00
-{l_suppkey} 98991.00 1.47 530.00 1.51 0.00 1.00
-{n_name} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{n_name_1} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{n_nationkey} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{n_nationkey_1} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{s_nationkey} 98991.00 1.47 1.00 2.00 <== 0.00 1.00
-{s_suppkey} 98991.00 1.47 530.00 1.51 0.00 1.00
+{l_discount} 97520.00 1.49 11.00 1.00 0.00 1.00
+{l_extendedprice} 97520.00 1.49 92052.00 1.42 0.00 1.00
+{l_orderkey} 97520.00 1.49 93524.00 1.35 0.00 1.00
+{l_shipdate} 97520.00 1.49 731.00 1.00 0.00 1.00
+{l_suppkey} 97520.00 1.49 530.00 1.51 0.00 1.00
+{n_name} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{n_name_1} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{n_nationkey} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{n_nationkey_1} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{s_nationkey} 97520.00 1.49 1.00 2.00 <== 0.00 1.00
+{s_suppkey} 97520.00 1.49 530.00 1.51 0.00 1.00
----Stats for q7_lookup_join_8----
column_names row_count distinct_count null_count
@@ -319,15 +319,15 @@ column_names row_count distinct_count null_count
{s_suppkey} 478523 798 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 322704.00 1.48 7.00 1.00 0.00 1.00
-{l_orderkey} 322704.00 1.48 290904.00 1.42 0.00 1.00
-{l_suppkey} 322704.00 1.48 530.00 1.51 0.00 1.00
-{n_name} 322704.00 1.48 1.00 2.00 <== 0.00 1.00
-{n_name_1} 322704.00 1.48 1.00 2.00 <== 0.00 1.00
-{n_nationkey} 322704.00 1.48 1.00 2.00 <== 0.00 1.00
-{n_nationkey_1} 322704.00 1.48 1.00 2.00 <== 0.00 1.00
-{s_nationkey} 322704.00 1.48 1.00 2.00 <== 0.00 1.00
-{s_suppkey} 322704.00 1.48 530.00 1.51 0.00 1.00
+{l_linenumber} 322646.00 1.48 7.00 1.00 0.00 1.00
+{l_orderkey} 322646.00 1.48 290857.00 1.42 0.00 1.00
+{l_suppkey} 322646.00 1.48 530.00 1.51 0.00 1.00
+{n_name} 322646.00 1.48 1.00 2.00 <== 0.00 1.00
+{n_name_1} 322646.00 1.48 1.00 2.00 <== 0.00 1.00
+{n_nationkey} 322646.00 1.48 1.00 2.00 <== 0.00 1.00
+{n_nationkey_1} 322646.00 1.48 1.00 2.00 <== 0.00 1.00
+{s_nationkey} 322646.00 1.48 1.00 2.00 <== 0.00 1.00
+{s_suppkey} 322646.00 1.48 530.00 1.51 0.00 1.00
----Stats for q7_lookup_join_9----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q08 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q08
index 7245ef9d01a4..b99a99f39204 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q08
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q08
@@ -60,7 +60,7 @@ sort
├── save-table-name: q8_sort_1
├── columns: o_year:77(float) mkt_share:82(float!null)
├── immutable
- ├── stats: [rows=728.8625, distinct(77)=728.862, null(77)=0, avgsize(77)=4, distinct(82)=728.862, null(82)=0, avgsize(82)=4]
+ ├── stats: [rows=728.9954, distinct(77)=728.995, null(77)=0, avgsize(77)=4, distinct(82)=728.995, null(82)=0, avgsize(82)=4]
├── key: (77)
├── fd: (77)-->(82)
├── ordering: +77
@@ -68,7 +68,7 @@ sort
├── save-table-name: q8_project_2
├── columns: mkt_share:82(float!null) o_year:77(float)
├── immutable
- ├── stats: [rows=728.8625, distinct(77)=728.862, null(77)=0, avgsize(77)=4, distinct(82)=728.862, null(82)=0, avgsize(82)=4]
+ ├── stats: [rows=728.9954, distinct(77)=728.995, null(77)=0, avgsize(77)=4, distinct(82)=728.995, null(82)=0, avgsize(82)=4]
├── key: (77)
├── fd: (77)-->(82)
├── group-by (hash)
@@ -76,38 +76,38 @@ sort
│ ├── columns: o_year:77(float) sum:80(float!null) sum:81(float!null)
│ ├── grouping columns: o_year:77(float)
│ ├── immutable
- │ ├── stats: [rows=728.8625, distinct(77)=728.862, null(77)=0, avgsize(77)=4, distinct(80)=728.862, null(80)=0, avgsize(80)=4, distinct(81)=728.862, null(81)=0, avgsize(81)=4, distinct(80,81)=728.862, null(80,81)=0, avgsize(80,81)=4]
+ │ ├── stats: [rows=728.9954, distinct(77)=728.995, null(77)=0, avgsize(77)=4, distinct(80)=728.995, null(80)=0, avgsize(80)=4, distinct(81)=728.995, null(81)=0, avgsize(81)=4, distinct(80,81)=728.995, null(80,81)=0, avgsize(80,81)=4]
│ ├── key: (77)
│ ├── fd: (77)-->(80,81)
│ ├── project
│ │ ├── save-table-name: q8_project_4
│ │ ├── columns: column79:79(float!null) o_year:77(float) volume:78(float!null)
│ │ ├── immutable
- │ │ ├── stats: [rows=4265.205, distinct(77)=728.862, null(77)=0, avgsize(77)=4, distinct(78)=4231.33, null(78)=0, avgsize(78)=8, distinct(79)=4248.24, null(79)=0, avgsize(79)=12]
+ │ │ ├── stats: [rows=4312.133, distinct(77)=728.995, null(77)=0, avgsize(77)=4, distinct(78)=4278.28, null(78)=0, avgsize(78)=18, distinct(79)=4295.19, null(79)=0, avgsize(79)=28]
│ │ ├── project
│ │ │ ├── save-table-name: q8_project_5
│ │ │ ├── columns: o_year:77(float) volume:78(float!null) n2.n_name:67(char!null)
│ │ │ ├── immutable
- │ │ │ ├── stats: [rows=4265.205, distinct(67)=25, null(67)=0, avgsize(67)=4, distinct(77)=728.862, null(77)=0, avgsize(77)=4, distinct(78)=4231.33, null(78)=0, avgsize(78)=8, distinct(67,78)=4248.24, null(67,78)=0, avgsize(67,78)=12]
+ │ │ │ ├── stats: [rows=4312.133, distinct(67)=25, null(67)=0, avgsize(67)=10, distinct(77)=728.995, null(77)=0, avgsize(77)=4, distinct(78)=4278.28, null(78)=0, avgsize(78)=18, distinct(67,78)=4295.19, null(67,78)=0, avgsize(67,78)=28]
│ │ │ ├── inner-join (hash)
│ │ │ │ ├── save-table-name: q8_inner_join_6
│ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null) s_suppkey:12(int!null) s_nationkey:15(int!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_extendedprice:26(float!null) l_discount:27(float!null) o_orderkey:39(int!null) o_custkey:40(int!null) o_orderdate:43(date!null) c_custkey:50(int!null) c_nationkey:53(int!null) n1.n_nationkey:60(int!null) n1.n_regionkey:62(int!null) n2.n_nationkey:66(int!null) n2.n_name:67(char!null) r_regionkey:72(int!null) r_name:73(char!null)
│ │ │ │ ├── multiplicity: left-rows(exactly-one), right-rows(zero-or-more)
- │ │ │ │ ├── stats: [rows=4265.205, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4, distinct(12)=3466.7, null(12)=0, avgsize(12)=4, distinct(15)=25, null(15)=0, avgsize(15)=4, distinct(21)=4186.58, null(21)=0, avgsize(21)=4, distinct(22)=1334.44, null(22)=0, avgsize(22)=4, distinct(23)=3466.7, null(23)=0, avgsize(23)=4, distinct(26)=4229.08, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=4186.58, null(39)=0, avgsize(39)=4, distinct(40)=3952.77, null(40)=0, avgsize(40)=4, distinct(43)=728.862, null(43)=0, avgsize(43)=4, distinct(50)=3952.77, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=4, distinct(60)=5, null(60)=0, avgsize(60)=4, distinct(62)=1, null(62)=0, avgsize(62)=4, distinct(66)=25, null(66)=0, avgsize(66)=4, distinct(67)=25, null(67)=0, avgsize(67)=4, distinct(72)=1, null(72)=0, avgsize(72)=4, distinct(73)=0.996222, null(73)=0, avgsize(73)=4, distinct(26,27)=4231.33, null(26,27)=0, avgsize(26,27)=8, distinct(26,27,67)=4248.24, null(26,27,67)=0, avgsize(26,27,67)=12]
+ │ │ │ │ ├── stats: [rows=4312.133, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23, distinct(12)=3497.16, null(12)=0, avgsize(12)=3, distinct(15)=25, null(15)=0, avgsize(15)=2, distinct(21)=4233.58, null(21)=0, avgsize(21)=4, distinct(22)=1331.6, null(22)=0, avgsize(22)=4, distinct(23)=3497.16, null(23)=0, avgsize(23)=4, distinct(26)=4275.82, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=4233.58, null(39)=0, avgsize(39)=4, distinct(40)=3992.96, null(40)=0, avgsize(40)=4, distinct(43)=728.995, null(43)=0, avgsize(43)=4, distinct(50)=3992.96, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=2, distinct(60)=5, null(60)=0, avgsize(60)=1, distinct(62)=1, null(62)=0, avgsize(62)=2, distinct(66)=25, null(66)=0, avgsize(66)=1, distinct(67)=25, null(67)=0, avgsize(67)=10, distinct(72)=1, null(72)=0, avgsize(72)=1, distinct(73)=0.996222, null(73)=0, avgsize(73)=9, distinct(26,27)=4278.28, null(26,27)=0, avgsize(26,27)=18, distinct(26,27,67)=4295.19, null(26,27,67)=0, avgsize(26,27,67)=28]
│ │ │ │ ├── fd: ()-->(5,73), (12)-->(15), (39)-->(40,43), (50)-->(53), (60)-->(62), (62)==(72), (72)==(62), (53)==(60), (60)==(53), (40)==(50), (50)==(40), (21)==(39), (39)==(21), (12)==(23), (23)==(12), (66)-->(67), (15)==(66), (66)==(15), (1)==(22), (22)==(1)
│ │ │ │ ├── inner-join (hash)
│ │ │ │ │ ├── save-table-name: q8_inner_join_7
│ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null) s_suppkey:12(int!null) s_nationkey:15(int!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_extendedprice:26(float!null) l_discount:27(float!null) o_orderkey:39(int!null) o_custkey:40(int!null) o_orderdate:43(date!null) c_custkey:50(int!null) c_nationkey:53(int!null) n1.n_nationkey:60(int!null) n1.n_regionkey:62(int!null) r_regionkey:72(int!null) r_name:73(char!null)
│ │ │ │ │ ├── multiplicity: left-rows(zero-or-more), right-rows(exactly-one)
- │ │ │ │ │ ├── stats: [rows=4076.392, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4, distinct(12)=3342.69, null(12)=0, avgsize(12)=4, distinct(15)=25, null(15)=0, avgsize(15)=4, distinct(21)=4005.16, null(21)=0, avgsize(21)=4, distinct(22)=1334.44, null(22)=0, avgsize(22)=4, distinct(23)=3342.69, null(23)=0, avgsize(23)=4, distinct(26)=4048.66, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=4005.16, null(39)=0, avgsize(39)=4, distinct(40)=3790.37, null(40)=0, avgsize(40)=4, distinct(43)=728.233, null(43)=0, avgsize(43)=4, distinct(50)=3790.37, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=4, distinct(60)=5, null(60)=0, avgsize(60)=4, distinct(62)=1, null(62)=0, avgsize(62)=4, distinct(72)=1, null(72)=0, avgsize(72)=4, distinct(73)=0.996222, null(73)=0, avgsize(73)=4]
+ │ │ │ │ │ ├── stats: [rows=4130.162, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23, distinct(12)=3378.25, null(12)=0, avgsize(12)=3, distinct(15)=25, null(15)=0, avgsize(15)=2, distinct(21)=4058.69, null(21)=0, avgsize(21)=4, distinct(22)=1331.6, null(22)=0, avgsize(22)=4, distinct(23)=3378.25, null(23)=0, avgsize(23)=4, distinct(26)=4102.07, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=4058.69, null(39)=0, avgsize(39)=4, distinct(40)=3836.73, null(40)=0, avgsize(40)=4, distinct(43)=728.429, null(43)=0, avgsize(43)=4, distinct(50)=3836.73, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=2, distinct(60)=5, null(60)=0, avgsize(60)=1, distinct(62)=1, null(62)=0, avgsize(62)=2, distinct(72)=1, null(72)=0, avgsize(72)=1, distinct(73)=0.996222, null(73)=0, avgsize(73)=9]
│ │ │ │ │ ├── fd: ()-->(5,73), (12)-->(15), (39)-->(40,43), (50)-->(53), (60)-->(62), (62)==(72), (72)==(62), (53)==(60), (60)==(53), (40)==(50), (50)==(40), (21)==(39), (39)==(21), (12)==(23), (23)==(12), (1)==(22), (22)==(1)
│ │ │ │ │ ├── scan supplier@s_nk
│ │ │ │ │ │ ├── save-table-name: q8_scan_8
│ │ │ │ │ │ ├── columns: s_suppkey:12(int!null) s_nationkey:15(int!null)
- │ │ │ │ │ │ ├── stats: [rows=10000, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(15)=25, null(15)=0, avgsize(15)=4]
+ │ │ │ │ │ │ ├── stats: [rows=10000, distinct(12)=9920, null(12)=0, avgsize(12)=3, distinct(15)=25, null(15)=0, avgsize(15)=2]
│ │ │ │ │ │ │ histogram(12)= 0 0 0 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 0 0
│ │ │ │ │ │ │ <--- -9223372036854775808 --- 1 ---- 51 ---- 101 ---- 151 ---- 201 ---- 251 ---- 301 ---- 351 ---- 401 ---- 451 ---- 501 ---- 551 ---- 601 ---- 651 ---- 701 ---- 751 ---- 801 ---- 851 ---- 901 ---- 951 ---- 1001 ---- 1051 ---- 1101 ---- 1151 ---- 1201 ---- 1251 ---- 1301 ---- 1351 ---- 1401 ---- 1451 ---- 1501 ---- 1551 ---- 1601 ---- 1651 ---- 1701 ---- 1751 ---- 1801 ---- 1851 ---- 1901 ---- 1951 ---- 2001 ---- 2051 ---- 2101 ---- 2151 ---- 2201 ---- 2251 ---- 2301 ---- 2351 ---- 2401 ---- 2451 ---- 2501 ---- 2551 ---- 2601 ---- 2651 ---- 2701 ---- 2751 ---- 2801 ---- 2851 ---- 2901 ---- 2951 ---- 3001 ---- 3051 ---- 3101 ---- 3151 ---- 3201 ---- 3251 ---- 3301 ---- 3351 ---- 3401 ---- 3451 ---- 3501 ---- 3551 ---- 3601 ---- 3651 ---- 3701 ---- 3751 ---- 3801 ---- 3851 ---- 3901 ---- 3951 ---- 4001 ---- 4051 ---- 4101 ---- 4151 ---- 4201 ---- 4251 ---- 4301 ---- 4351 ---- 4401 ---- 4451 ---- 4501 ---- 4551 ---- 4601 ---- 4651 ---- 4701 ---- 4751 ---- 4801 ---- 4851 ---- 4901 ---- 4951 ---- 5001 ---- 5051 ---- 5101 ---- 5151 ---- 5201 ---- 5251 ---- 5301 ---- 5351 ---- 5401 ---- 5451 ---- 5501 ---- 5551 ---- 5601 ---- 5651 ---- 5701 ---- 5751 ---- 5801 ---- 5851 ---- 5901 ---- 5951 ---- 6001 ---- 6051 ---- 6101 ---- 6151 ---- 6201 ---- 6251 ---- 6301 ---- 6351 ---- 6401 ---- 6451 ---- 6501 ---- 6551 ---- 6601 ---- 6651 ---- 6701 ---- 6751 ---- 6801 ---- 6851 ---- 6901 ---- 6951 ---- 7001 ---- 7051 ---- 7101 ---- 7151 ---- 7201 ---- 7251 ---- 7301 ---- 7351 ---- 7401 ---- 7451 ---- 7501 ---- 7552 ---- 7603 ---- 7654 ---- 7705 ---- 7756 ---- 7807 ---- 7858 ---- 7909 ---- 7960 ---- 8011 ---- 8062 ---- 8113 ---- 8164 ---- 8215 ---- 8266 ---- 8317 ---- 8368 ---- 8419 ---- 8470 ---- 8521 ---- 8572 ---- 8623 ---- 8674 ---- 8725 ---- 8776 ---- 8827 ---- 8878 ---- 8929 ---- 8980 ---- 9031 ---- 9082 ---- 9133 ---- 9184 ---- 9235 ---- 9286 ---- 9337 ---- 9388 ---- 9439 ---- 9490 ---- 9541 ---- 9592 ---- 9643 ---- 9694 ---- 9745 ---- 9796 ---- 9847 ---- 9898 ---- 9949 ---- 10000 --- 9223372036854775807
- │ │ │ │ │ │ │ histogram(15)= 0 403 0 384 0 391 0 396 0 406 0 396 0 393 0 399 0 406 0 393 0 383 0 398 0 394 0 414 0 422 0 387 0 435 0 403 0 441 0 357 0 394 0 390 0 421 0 411 0 383
+ │ │ │ │ │ │ │ histogram(15)= 0 420 0 413 0 397 0 412 0 415 0 380 0 402 0 396 0 415 0 405 0 393 0 438 0 377 0 362 0 376 0 373 0 406 0 421 0 407 0 398 0 411 0 399 0 401 0 390 0 393
│ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ ├── key: (12)
│ │ │ │ │ │ └── fd: (12)-->(15)
@@ -115,26 +115,26 @@ sort
│ │ │ │ │ │ ├── save-table-name: q8_inner_join_9
│ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_extendedprice:26(float!null) l_discount:27(float!null) o_orderkey:39(int!null) o_custkey:40(int!null) o_orderdate:43(date!null) c_custkey:50(int!null) c_nationkey:53(int!null) n1.n_nationkey:60(int!null) n1.n_regionkey:62(int!null) r_regionkey:72(int!null) r_name:73(char!null)
│ │ │ │ │ │ ├── multiplicity: left-rows(zero-or-more), right-rows(zero-or-one)
- │ │ │ │ │ │ ├── stats: [rows=3817.709, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4, distinct(21)=3755.81, null(21)=0, avgsize(21)=4, distinct(22)=1334.44, null(22)=0, avgsize(22)=4, distinct(23)=3168.92, null(23)=0, avgsize(23)=4, distinct(26)=3799.94, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=3755.81, null(39)=0, avgsize(39)=4, distinct(40)=3566.07, null(40)=0, avgsize(40)=4, distinct(43)=727.058, null(43)=0, avgsize(43)=4, distinct(50)=3566.07, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=4, distinct(60)=5, null(60)=0, avgsize(60)=4, distinct(62)=1, null(62)=0, avgsize(62)=4, distinct(72)=1, null(72)=0, avgsize(72)=4, distinct(73)=0.996222, null(73)=0, avgsize(73)=4]
+ │ │ │ │ │ │ ├── stats: [rows=3879.949, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23, distinct(21)=3817.47, null(21)=0, avgsize(21)=4, distinct(22)=1331.6, null(22)=0, avgsize(22)=4, distinct(23)=3211.15, null(23)=0, avgsize(23)=4, distinct(26)=3861.68, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=3817.47, null(39)=0, avgsize(39)=4, distinct(40)=3620.23, null(40)=0, avgsize(40)=4, distinct(43)=727.379, null(43)=0, avgsize(43)=4, distinct(50)=3620.23, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=2, distinct(60)=5, null(60)=0, avgsize(60)=1, distinct(62)=1, null(62)=0, avgsize(62)=2, distinct(72)=1, null(72)=0, avgsize(72)=1, distinct(73)=0.996222, null(73)=0, avgsize(73)=9]
│ │ │ │ │ │ ├── fd: ()-->(5,73), (39)-->(40,43), (50)-->(53), (60)-->(62), (62)==(72), (72)==(62), (53)==(60), (60)==(53), (40)==(50), (50)==(40), (21)==(39), (39)==(21), (1)==(22), (22)==(1)
│ │ │ │ │ │ ├── inner-join (lookup customer@c_nk)
│ │ │ │ │ │ │ ├── save-table-name: q8_lookup_join_10
│ │ │ │ │ │ │ ├── columns: c_custkey:50(int!null) c_nationkey:53(int!null) n1.n_nationkey:60(int!null) n1.n_regionkey:62(int!null) r_regionkey:72(int!null) r_name:73(char!null)
│ │ │ │ │ │ │ ├── key columns: [60] = [53]
- │ │ │ │ │ │ │ ├── stats: [rows=30000, distinct(50)=27672.3, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=4, distinct(60)=5, null(60)=0, avgsize(60)=4, distinct(62)=1, null(62)=0, avgsize(62)=4, distinct(72)=1, null(72)=0, avgsize(72)=4, distinct(73)=0.996222, null(73)=0, avgsize(73)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=30000, distinct(50)=27672.3, null(50)=0, avgsize(50)=4, distinct(53)=5, null(53)=0, avgsize(53)=2, distinct(60)=5, null(60)=0, avgsize(60)=1, distinct(62)=1, null(62)=0, avgsize(62)=2, distinct(72)=1, null(72)=0, avgsize(72)=1, distinct(73)=0.996222, null(73)=0, avgsize(73)=9]
│ │ │ │ │ │ │ ├── key: (50)
│ │ │ │ │ │ │ ├── fd: ()-->(73), (50)-->(53), (60)-->(62), (62)==(72), (72)==(62), (53)==(60), (60)==(53)
│ │ │ │ │ │ │ ├── inner-join (lookup nation@n_rk [as=n1])
│ │ │ │ │ │ │ │ ├── save-table-name: q8_lookup_join_11
│ │ │ │ │ │ │ │ ├── columns: n1.n_nationkey:60(int!null) n1.n_regionkey:62(int!null) r_regionkey:72(int!null) r_name:73(char!null)
│ │ │ │ │ │ │ │ ├── key columns: [72] = [62]
- │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(60)=5, null(60)=0, avgsize(60)=4, distinct(62)=1, null(62)=0, avgsize(62)=4, distinct(72)=1, null(72)=0, avgsize(72)=4, distinct(73)=0.996222, null(73)=0, avgsize(73)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(60)=5, null(60)=0, avgsize(60)=1, distinct(62)=1, null(62)=0, avgsize(62)=2, distinct(72)=1, null(72)=0, avgsize(72)=1, distinct(73)=0.996222, null(73)=0, avgsize(73)=9]
│ │ │ │ │ │ │ │ ├── key: (60)
│ │ │ │ │ │ │ │ ├── fd: ()-->(73), (60)-->(62), (62)==(72), (72)==(62)
│ │ │ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ │ │ ├── save-table-name: q8_select_12
│ │ │ │ │ │ │ │ │ ├── columns: r_regionkey:72(int!null) r_name:73(char!null)
- │ │ │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(72)=1, null(72)=0, avgsize(72)=4, distinct(73)=1, null(73)=0, avgsize(73)=4]
+ │ │ │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(72)=1, null(72)=0, avgsize(72)=1, distinct(73)=1, null(73)=0, avgsize(73)=9]
│ │ │ │ │ │ │ │ │ │ histogram(73)= 0 1
│ │ │ │ │ │ │ │ │ │ <--- 'AMERICA'
│ │ │ │ │ │ │ │ │ ├── key: (72)
@@ -142,7 +142,7 @@ sort
│ │ │ │ │ │ │ │ │ ├── scan region
│ │ │ │ │ │ │ │ │ │ ├── save-table-name: q8_scan_13
│ │ │ │ │ │ │ │ │ │ ├── columns: r_regionkey:72(int!null) r_name:73(char!null)
- │ │ │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(72)=5, null(72)=0, avgsize(72)=4, distinct(73)=5, null(73)=0, avgsize(73)=4]
+ │ │ │ │ │ │ │ │ │ │ ├── stats: [rows=5, distinct(72)=5, null(72)=0, avgsize(72)=1, distinct(73)=5, null(73)=0, avgsize(73)=9]
│ │ │ │ │ │ │ │ │ │ │ histogram(72)= 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4
│ │ │ │ │ │ │ │ │ │ │ histogram(73)= 0 1 3 1
@@ -158,38 +158,38 @@ sort
│ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_extendedprice:26(float!null) l_discount:27(float!null) o_orderkey:39(int!null) o_custkey:40(int!null) o_orderdate:43(date!null)
│ │ │ │ │ │ │ ├── key columns: [21] = [39]
│ │ │ │ │ │ │ ├── lookup columns are key
- │ │ │ │ │ │ │ ├── stats: [rows=11762.47, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4, distinct(21)=11609, null(21)=0, avgsize(21)=4, distinct(22)=1334.44, null(22)=0, avgsize(22)=4, distinct(23)=6889.23, null(23)=0, avgsize(23)=4, distinct(26)=11677.7, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=11609, null(39)=0, avgsize(39)=4, distinct(40)=11092.9, null(40)=0, avgsize(40)=4, distinct(43)=731, null(43)=0, avgsize(43)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=12014.85, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23, distinct(21)=11858.5, null(21)=0, avgsize(21)=4, distinct(22)=1331.6, null(22)=0, avgsize(22)=4, distinct(23)=6965.36, null(23)=0, avgsize(23)=4, distinct(26)=11924.3, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=11858.5, null(39)=0, avgsize(39)=4, distinct(40)=11317.3, null(40)=0, avgsize(40)=4, distinct(43)=731, null(43)=0, avgsize(43)=4]
│ │ │ │ │ │ │ ├── fd: ()-->(5), (39)-->(40,43), (21)==(39), (39)==(21), (1)==(22), (22)==(1)
│ │ │ │ │ │ │ ├── inner-join (lookup lineitem)
│ │ │ │ │ │ │ │ ├── save-table-name: q8_lookup_join_15
│ │ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_extendedprice:26(float!null) l_discount:27(float!null)
│ │ │ │ │ │ │ │ ├── key columns: [21 24] = [21 24]
│ │ │ │ │ │ │ │ ├── lookup columns are key
- │ │ │ │ │ │ │ │ ├── stats: [rows=40201.65, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4, distinct(21)=39677.3, null(21)=0, avgsize(21)=4, distinct(22)=1334.44, null(22)=0, avgsize(22)=4, distinct(23)=9747.62, null(23)=0, avgsize(23)=4, distinct(26)=39381.1, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=40108.95, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23, distinct(21)=39587, null(21)=0, avgsize(21)=4, distinct(22)=1331.6, null(22)=0, avgsize(22)=4, distinct(23)=9746, null(23)=0, avgsize(23)=4, distinct(26)=39252.8, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9]
│ │ │ │ │ │ │ │ ├── fd: ()-->(5), (1)==(22), (22)==(1)
│ │ │ │ │ │ │ │ ├── inner-join (lookup lineitem@l_pk)
│ │ │ │ │ │ │ │ │ ├── save-table-name: q8_lookup_join_16
│ │ │ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_linenumber:24(int!null)
│ │ │ │ │ │ │ │ │ ├── key columns: [1] = [22]
- │ │ │ │ │ │ │ │ │ ├── stats: [rows=40201.65, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4, distinct(21)=39677.3, null(21)=0, avgsize(21)=4, distinct(22)=1334.44, null(22)=0, avgsize(22)=4, distinct(24)=7, null(24)=0, avgsize(24)=4]
+ │ │ │ │ │ │ │ │ │ ├── stats: [rows=40108.95, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23, distinct(21)=39587, null(21)=0, avgsize(21)=4, distinct(22)=1331.6, null(22)=0, avgsize(22)=4, distinct(24)=7, null(24)=0, avgsize(24)=1]
│ │ │ │ │ │ │ │ │ ├── key: (21,24)
│ │ │ │ │ │ │ │ │ ├── fd: ()-->(5), (21,24)-->(22), (1)==(22), (22)==(1)
│ │ │ │ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ │ │ │ ├── save-table-name: q8_select_17
│ │ │ │ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null)
- │ │ │ │ │ │ │ │ │ │ ├── stats: [rows=1334.459, distinct(1)=1334.44, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=4]
- │ │ │ │ │ │ │ │ │ │ │ histogram(5)= 0 1334.5
+ │ │ │ │ │ │ │ │ │ │ ├── stats: [rows=1331.622, distinct(1)=1331.6, null(1)=0, avgsize(1)=4, distinct(5)=1, null(5)=0, avgsize(5)=23]
+ │ │ │ │ │ │ │ │ │ │ │ histogram(5)= 0 1331.6
│ │ │ │ │ │ │ │ │ │ │ <--- 'ECONOMY ANODIZED STEEL'
│ │ │ │ │ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ │ │ │ │ ├── fd: ()-->(5)
│ │ │ │ │ │ │ │ │ │ ├── scan part
│ │ │ │ │ │ │ │ │ │ │ ├── save-table-name: q8_scan_18
│ │ │ │ │ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_type:5(varchar!null)
- │ │ │ │ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(1)=199241, null(1)=0, avgsize(1)=4, distinct(5)=150, null(5)=0, avgsize(5)=4]
- │ │ │ │ │ │ │ │ │ │ │ │ histogram(1)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ │ │ │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ │ │ │ │ │ │ │ histogram(5)= 0 1340 1.975e+05 1160
- │ │ │ │ │ │ │ │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ----------- 'STANDARD POLISHED TIN'
+ │ │ │ │ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(1)=199241, null(1)=0, avgsize(1)=4, distinct(5)=150, null(5)=0, avgsize(5)=23]
+ │ │ │ │ │ │ │ │ │ │ │ │ histogram(1)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ │ │ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ │ │ │ │ │ │ │ histogram(5)= 0 1360 1.9708e+05 1560
+ │ │ │ │ │ │ │ │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ------------ 'STANDARD POLISHED TIN'
│ │ │ │ │ │ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ │ │ │ │ │ └── fd: (1)-->(5)
│ │ │ │ │ │ │ │ │ │ └── filters
@@ -205,7 +205,7 @@ sort
│ │ │ │ ├── scan nation [as=n2]
│ │ │ │ │ ├── save-table-name: q8_scan_19
│ │ │ │ │ ├── columns: n2.n_nationkey:66(int!null) n2.n_name:67(char!null)
- │ │ │ │ │ ├── stats: [rows=25, distinct(66)=25, null(66)=0, avgsize(66)=4, distinct(67)=25, null(67)=0, avgsize(67)=4]
+ │ │ │ │ │ ├── stats: [rows=25, distinct(66)=25, null(66)=0, avgsize(66)=1, distinct(67)=25, null(67)=0, avgsize(67)=10]
│ │ │ │ │ │ histogram(66)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ histogram(67)= 0 1 23 1
@@ -263,9 +263,9 @@ column_names row_count distinct_count null_count
{volume} 2603 2599 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column79} 4265.00 1.64 4248.00 39.33 <== 0.00 1.00
-{o_year} 4265.00 1.64 729.00 364.50 <== 0.00 1.00
-{volume} 4265.00 1.64 4231.00 1.63 0.00 1.00
+{column79} 4312.00 1.66 4295.00 39.77 <== 0.00 1.00
+{o_year} 4312.00 1.66 729.00 364.50 <== 0.00 1.00
+{volume} 4312.00 1.66 4278.00 1.65 0.00 1.00
----Stats for q8_project_5----
column_names row_count distinct_count null_count
@@ -274,9 +274,9 @@ column_names row_count distinct_count null_count
{volume} 2603 2599 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{n_name} 4265.00 1.64 25.00 1.00 0.00 1.00
-{o_year} 4265.00 1.64 729.00 364.50 <== 0.00 1.00
-{volume} 4265.00 1.64 4231.00 1.63 0.00 1.00
+{n_name} 4312.00 1.66 25.00 1.00 0.00 1.00
+{o_year} 4312.00 1.66 729.00 364.50 <== 0.00 1.00
+{volume} 4312.00 1.66 4278.00 1.65 0.00 1.00
----Stats for q8_inner_join_6----
column_names row_count distinct_count null_count
@@ -302,26 +302,26 @@ column_names row_count distinct_count null_count
{s_suppkey} 2603 1895 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 4265.00 1.64 3953.00 1.66 0.00 1.00
-{c_nationkey} 4265.00 1.64 5.00 1.00 0.00 1.00
-{l_discount} 4265.00 1.64 11.00 1.00 0.00 1.00
-{l_extendedprice} 4265.00 1.64 4229.00 1.66 0.00 1.00
-{l_orderkey} 4265.00 1.64 4187.00 1.63 0.00 1.00
-{l_partkey} 4265.00 1.64 1334.00 1.09 0.00 1.00
-{l_suppkey} 4265.00 1.64 3467.00 1.83 0.00 1.00
-{n_name} 4265.00 1.64 25.00 1.00 0.00 1.00
-{n_nationkey} 4265.00 1.64 5.00 1.00 0.00 1.00
-{n_nationkey_1} 4265.00 1.64 25.00 1.00 0.00 1.00
-{n_regionkey} 4265.00 1.64 1.00 1.00 0.00 1.00
-{o_custkey} 4265.00 1.64 3953.00 1.66 0.00 1.00
-{o_orderdate} 4265.00 1.64 729.00 1.03 0.00 1.00
-{o_orderkey} 4265.00 1.64 4187.00 1.63 0.00 1.00
-{p_partkey} 4265.00 1.64 1334.00 1.09 0.00 1.00
-{p_type} 4265.00 1.64 1.00 1.00 0.00 1.00
-{r_name} 4265.00 1.64 1.00 1.00 0.00 1.00
-{r_regionkey} 4265.00 1.64 1.00 1.00 0.00 1.00
-{s_nationkey} 4265.00 1.64 25.00 1.00 0.00 1.00
-{s_suppkey} 4265.00 1.64 3467.00 1.83 0.00 1.00
+{c_custkey} 4312.00 1.66 3993.00 1.67 0.00 1.00
+{c_nationkey} 4312.00 1.66 5.00 1.00 0.00 1.00
+{l_discount} 4312.00 1.66 11.00 1.00 0.00 1.00
+{l_extendedprice} 4312.00 1.66 4276.00 1.68 0.00 1.00
+{l_orderkey} 4312.00 1.66 4234.00 1.65 0.00 1.00
+{l_partkey} 4312.00 1.66 1332.00 1.09 0.00 1.00
+{l_suppkey} 4312.00 1.66 3497.00 1.85 0.00 1.00
+{n_name} 4312.00 1.66 25.00 1.00 0.00 1.00
+{n_nationkey} 4312.00 1.66 5.00 1.00 0.00 1.00
+{n_nationkey_1} 4312.00 1.66 25.00 1.00 0.00 1.00
+{n_regionkey} 4312.00 1.66 1.00 1.00 0.00 1.00
+{o_custkey} 4312.00 1.66 3993.00 1.67 0.00 1.00
+{o_orderdate} 4312.00 1.66 729.00 1.03 0.00 1.00
+{o_orderkey} 4312.00 1.66 4234.00 1.65 0.00 1.00
+{p_partkey} 4312.00 1.66 1332.00 1.09 0.00 1.00
+{p_type} 4312.00 1.66 1.00 1.00 0.00 1.00
+{r_name} 4312.00 1.66 1.00 1.00 0.00 1.00
+{r_regionkey} 4312.00 1.66 1.00 1.00 0.00 1.00
+{s_nationkey} 4312.00 1.66 25.00 1.00 0.00 1.00
+{s_suppkey} 4312.00 1.66 3497.00 1.85 0.00 1.00
----Stats for q8_inner_join_7----
column_names row_count distinct_count null_count
@@ -345,24 +345,24 @@ column_names row_count distinct_count null_count
{s_suppkey} 2603 1895 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 4076.00 1.57 3790.00 1.59 0.00 1.00
-{c_nationkey} 4076.00 1.57 5.00 1.00 0.00 1.00
-{l_discount} 4076.00 1.57 11.00 1.00 0.00 1.00
-{l_extendedprice} 4076.00 1.57 4049.00 1.59 0.00 1.00
-{l_orderkey} 4076.00 1.57 4005.00 1.56 0.00 1.00
-{l_partkey} 4076.00 1.57 1334.00 1.09 0.00 1.00
-{l_suppkey} 4076.00 1.57 3343.00 1.76 0.00 1.00
-{n_nationkey} 4076.00 1.57 5.00 1.00 0.00 1.00
-{n_regionkey} 4076.00 1.57 1.00 1.00 0.00 1.00
-{o_custkey} 4076.00 1.57 3790.00 1.59 0.00 1.00
-{o_orderdate} 4076.00 1.57 728.00 1.03 0.00 1.00
-{o_orderkey} 4076.00 1.57 4005.00 1.56 0.00 1.00
-{p_partkey} 4076.00 1.57 1334.00 1.09 0.00 1.00
-{p_type} 4076.00 1.57 1.00 1.00 0.00 1.00
-{r_name} 4076.00 1.57 1.00 1.00 0.00 1.00
-{r_regionkey} 4076.00 1.57 1.00 1.00 0.00 1.00
-{s_nationkey} 4076.00 1.57 25.00 1.00 0.00 1.00
-{s_suppkey} 4076.00 1.57 3343.00 1.76 0.00 1.00
+{c_custkey} 4130.00 1.59 3837.00 1.61 0.00 1.00
+{c_nationkey} 4130.00 1.59 5.00 1.00 0.00 1.00
+{l_discount} 4130.00 1.59 11.00 1.00 0.00 1.00
+{l_extendedprice} 4130.00 1.59 4102.00 1.61 0.00 1.00
+{l_orderkey} 4130.00 1.59 4059.00 1.58 0.00 1.00
+{l_partkey} 4130.00 1.59 1332.00 1.09 0.00 1.00
+{l_suppkey} 4130.00 1.59 3378.00 1.78 0.00 1.00
+{n_nationkey} 4130.00 1.59 5.00 1.00 0.00 1.00
+{n_regionkey} 4130.00 1.59 1.00 1.00 0.00 1.00
+{o_custkey} 4130.00 1.59 3837.00 1.61 0.00 1.00
+{o_orderdate} 4130.00 1.59 728.00 1.03 0.00 1.00
+{o_orderkey} 4130.00 1.59 4059.00 1.58 0.00 1.00
+{p_partkey} 4130.00 1.59 1332.00 1.09 0.00 1.00
+{p_type} 4130.00 1.59 1.00 1.00 0.00 1.00
+{r_name} 4130.00 1.59 1.00 1.00 0.00 1.00
+{r_regionkey} 4130.00 1.59 1.00 1.00 0.00 1.00
+{s_nationkey} 4130.00 1.59 25.00 1.00 0.00 1.00
+{s_suppkey} 4130.00 1.59 3378.00 1.78 0.00 1.00
----Stats for q8_scan_8----
column_names row_count distinct_count null_count
@@ -393,22 +393,22 @@ column_names row_count distinct_count null_count
{r_regionkey} 2603 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 3818.00 1.47 3566.00 1.50 0.00 1.00
-{c_nationkey} 3818.00 1.47 5.00 1.00 0.00 1.00
-{l_discount} 3818.00 1.47 11.00 1.00 0.00 1.00
-{l_extendedprice} 3818.00 1.47 3800.00 1.50 0.00 1.00
-{l_orderkey} 3818.00 1.47 3756.00 1.46 0.00 1.00
-{l_partkey} 3818.00 1.47 1334.00 1.09 0.00 1.00
-{l_suppkey} 3818.00 1.47 3169.00 1.67 0.00 1.00
-{n_nationkey} 3818.00 1.47 5.00 1.00 0.00 1.00
-{n_regionkey} 3818.00 1.47 1.00 1.00 0.00 1.00
-{o_custkey} 3818.00 1.47 3566.00 1.50 0.00 1.00
-{o_orderdate} 3818.00 1.47 727.00 1.03 0.00 1.00
-{o_orderkey} 3818.00 1.47 3756.00 1.46 0.00 1.00
-{p_partkey} 3818.00 1.47 1334.00 1.09 0.00 1.00
-{p_type} 3818.00 1.47 1.00 1.00 0.00 1.00
-{r_name} 3818.00 1.47 1.00 1.00 0.00 1.00
-{r_regionkey} 3818.00 1.47 1.00 1.00 0.00 1.00
+{c_custkey} 3880.00 1.49 3620.00 1.52 0.00 1.00
+{c_nationkey} 3880.00 1.49 5.00 1.00 0.00 1.00
+{l_discount} 3880.00 1.49 11.00 1.00 0.00 1.00
+{l_extendedprice} 3880.00 1.49 3862.00 1.52 0.00 1.00
+{l_orderkey} 3880.00 1.49 3817.00 1.49 0.00 1.00
+{l_partkey} 3880.00 1.49 1332.00 1.09 0.00 1.00
+{l_suppkey} 3880.00 1.49 3211.00 1.69 0.00 1.00
+{n_nationkey} 3880.00 1.49 5.00 1.00 0.00 1.00
+{n_regionkey} 3880.00 1.49 1.00 1.00 0.00 1.00
+{o_custkey} 3880.00 1.49 3620.00 1.52 0.00 1.00
+{o_orderdate} 3880.00 1.49 727.00 1.03 0.00 1.00
+{o_orderkey} 3880.00 1.49 3817.00 1.49 0.00 1.00
+{p_partkey} 3880.00 1.49 1332.00 1.09 0.00 1.00
+{p_type} 3880.00 1.49 1.00 1.00 0.00 1.00
+{r_name} 3880.00 1.49 1.00 1.00 0.00 1.00
+{r_regionkey} 3880.00 1.49 1.00 1.00 0.00 1.00
----Stats for q8_lookup_join_10----
column_names row_count distinct_count null_count
@@ -472,16 +472,16 @@ column_names row_count distinct_count null_count
{p_type} 13389 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 11762.00 1.14 11.00 1.00 0.00 1.00
-{l_extendedprice} 11762.00 1.14 11678.00 1.03 0.00 1.00
-{l_orderkey} 11762.00 1.14 11609.00 1.15 0.00 1.00
-{l_partkey} 11762.00 1.14 1334.00 1.09 0.00 1.00
-{l_suppkey} 11762.00 1.14 6889.00 1.70 0.00 1.00
-{o_custkey} 11762.00 1.14 11093.00 1.11 0.00 1.00
-{o_orderdate} 11762.00 1.14 731.00 1.00 0.00 1.00
-{o_orderkey} 11762.00 1.14 11609.00 1.15 0.00 1.00
-{p_partkey} 11762.00 1.14 1334.00 1.09 0.00 1.00
-{p_type} 11762.00 1.14 1.00 1.00 0.00 1.00
+{l_discount} 12015.00 1.11 11.00 1.00 0.00 1.00
+{l_extendedprice} 12015.00 1.11 11924.00 1.01 0.00 1.00
+{l_orderkey} 12015.00 1.11 11858.00 1.13 0.00 1.00
+{l_partkey} 12015.00 1.11 1332.00 1.09 0.00 1.00
+{l_suppkey} 12015.00 1.11 6965.00 1.72 0.00 1.00
+{o_custkey} 12015.00 1.11 11317.00 1.08 0.00 1.00
+{o_orderdate} 12015.00 1.11 731.00 1.00 0.00 1.00
+{o_orderkey} 12015.00 1.11 11858.00 1.13 0.00 1.00
+{p_partkey} 12015.00 1.11 1332.00 1.09 0.00 1.00
+{p_type} 12015.00 1.11 1.00 1.00 0.00 1.00
----Stats for q8_lookup_join_15----
column_names row_count distinct_count null_count
@@ -494,13 +494,13 @@ column_names row_count distinct_count null_count
{p_type} 43693 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 40202.00 1.09 11.00 1.00 0.00 1.00
-{l_extendedprice} 40202.00 1.09 39381.00 1.22 0.00 1.00
-{l_orderkey} 40202.00 1.09 39677.00 1.09 0.00 1.00
-{l_partkey} 40202.00 1.09 1334.00 1.09 0.00 1.00
-{l_suppkey} 40202.00 1.09 9748.00 2.24 <== 0.00 1.00
-{p_partkey} 40202.00 1.09 1334.00 1.09 0.00 1.00
-{p_type} 40202.00 1.09 1.00 1.00 0.00 1.00
+{l_discount} 40109.00 1.09 11.00 1.00 0.00 1.00
+{l_extendedprice} 40109.00 1.09 39253.00 1.22 0.00 1.00
+{l_orderkey} 40109.00 1.09 39587.00 1.10 0.00 1.00
+{l_partkey} 40109.00 1.09 1332.00 1.09 0.00 1.00
+{l_suppkey} 40109.00 1.09 9746.00 2.24 <== 0.00 1.00
+{p_partkey} 40109.00 1.09 1332.00 1.09 0.00 1.00
+{p_type} 40109.00 1.09 1.00 1.00 0.00 1.00
----Stats for q8_lookup_join_16----
column_names row_count distinct_count null_count
@@ -511,11 +511,11 @@ column_names row_count distinct_count null_count
{p_type} 43693 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 40202.00 1.09 7.00 1.00 0.00 1.00
-{l_orderkey} 40202.00 1.09 39677.00 1.09 0.00 1.00
-{l_partkey} 40202.00 1.09 1334.00 1.09 0.00 1.00
-{p_partkey} 40202.00 1.09 1334.00 1.09 0.00 1.00
-{p_type} 40202.00 1.09 1.00 1.00 0.00 1.00
+{l_linenumber} 40109.00 1.09 7.00 1.00 0.00 1.00
+{l_orderkey} 40109.00 1.09 39587.00 1.10 0.00 1.00
+{l_partkey} 40109.00 1.09 1332.00 1.09 0.00 1.00
+{p_partkey} 40109.00 1.09 1332.00 1.09 0.00 1.00
+{p_type} 40109.00 1.09 1.00 1.00 0.00 1.00
----Stats for q8_select_17----
column_names row_count distinct_count null_count
@@ -523,8 +523,8 @@ column_names row_count distinct_count null_count
{p_type} 1451 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_partkey} 1334.00 1.09 1334.00 1.09 0.00 1.00
-{p_type} 1334.00 1.09 1.00 1.00 0.00 1.00
+{p_partkey} 1332.00 1.09 1332.00 1.09 0.00 1.00
+{p_type} 1332.00 1.09 1.00 1.00 0.00 1.00
----Stats for q8_scan_18----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q09 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q09
index a786e75df79b..7b05f58c49cf 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q09
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q09
@@ -58,7 +58,7 @@ sort
├── save-table-name: q9_sort_1
├── columns: nation:58(char!null) o_year:63(float) sum_profit:65(float!null)
├── immutable
- ├── stats: [rows=1548.777, distinct(58)=25, null(58)=0, avgsize(58)=4, distinct(63)=957.295, null(63)=0, avgsize(63)=4, distinct(65)=1548.78, null(65)=0, avgsize(65)=8, distinct(58,63)=1548.78, null(58,63)=0, avgsize(58,63)=8]
+ ├── stats: [rows=1548.499, distinct(58)=25, null(58)=0, avgsize(58)=10, distinct(63)=957.145, null(63)=0, avgsize(63)=4, distinct(65)=1548.5, null(65)=0, avgsize(65)=14, distinct(58,63)=1548.5, null(58,63)=0, avgsize(58,63)=14]
├── key: (58,63)
├── fd: (58,63)-->(65)
├── ordering: +58,-63
@@ -67,33 +67,33 @@ sort
├── columns: n_name:58(char!null) o_year:63(float) sum:65(float!null)
├── grouping columns: n_name:58(char!null) o_year:63(float)
├── immutable
- ├── stats: [rows=1548.777, distinct(58)=25, null(58)=0, avgsize(58)=4, distinct(63)=957.295, null(63)=0, avgsize(63)=4, distinct(65)=1548.78, null(65)=0, avgsize(65)=8, distinct(58,63)=1548.78, null(58,63)=0, avgsize(58,63)=8]
+ ├── stats: [rows=1548.499, distinct(58)=25, null(58)=0, avgsize(58)=10, distinct(63)=957.145, null(63)=0, avgsize(63)=4, distinct(65)=1548.5, null(65)=0, avgsize(65)=14, distinct(58,63)=1548.5, null(58,63)=0, avgsize(58,63)=14]
├── key: (58,63)
├── fd: (58,63)-->(65)
├── project
│ ├── save-table-name: q9_project_3
│ ├── columns: o_year:63(float) amount:64(float!null) n_name:58(char!null)
│ ├── immutable
- │ ├── stats: [rows=2450.856, distinct(58)=25, null(58)=0, avgsize(58)=4, distinct(63)=957.295, null(63)=0, avgsize(63)=4, distinct(64)=958.499, null(64)=0, avgsize(64)=16, distinct(58,63)=1548.78, null(58,63)=0, avgsize(58,63)=8]
+ │ ├── stats: [rows=2450.416, distinct(58)=25, null(58)=0, avgsize(58)=10, distinct(63)=957.145, null(63)=0, avgsize(63)=4, distinct(64)=958.326, null(64)=0, avgsize(64)=36, distinct(58,63)=1548.5, null(58,63)=0, avgsize(58,63)=14]
│ ├── inner-join (hash)
│ │ ├── save-table-name: q9_inner_join_4
│ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null) s_suppkey:12(int!null) s_nationkey:15(int!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_quantity:25(float!null) l_extendedprice:26(float!null) l_discount:27(float!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null) o_orderkey:46(int!null) o_orderdate:50(date!null) n_nationkey:57(int!null) n_name:58(char!null)
│ │ ├── multiplicity: left-rows(exactly-one), right-rows(zero-or-more)
- │ │ ├── stats: [rows=2450.856, distinct(1)=1065.2, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4, distinct(12)=1064.72, null(12)=0, avgsize(12)=4, distinct(15)=25, null(15)=0, avgsize(15)=4, distinct(21)=1066.62, null(21)=0, avgsize(21)=4, distinct(22)=1065.2, null(22)=0, avgsize(22)=4, distinct(23)=1064.72, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=4, distinct(26)=958.344, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=958.499, null(39)=0, avgsize(39)=4, distinct(40)=958.499, null(40)=0, avgsize(40)=4, distinct(42)=734.534, null(42)=0, avgsize(42)=4, distinct(46)=1066.62, null(46)=0, avgsize(46)=4, distinct(50)=957.295, null(50)=0, avgsize(50)=4, distinct(57)=25, null(57)=0, avgsize(57)=4, distinct(58)=25, null(58)=0, avgsize(58)=4, distinct(50,58)=1548.78, null(50,58)=0, avgsize(50,58)=8, distinct(25-27,42)=958.499, null(25-27,42)=0, avgsize(25-27,42)=16]
+ │ │ ├── stats: [rows=2450.416, distinct(1)=1065.01, null(1)=0, avgsize(1)=4, distinct(2)=2405.95, null(2)=0, avgsize(2)=35, distinct(12)=1064.52, null(12)=0, avgsize(12)=3, distinct(15)=25, null(15)=0, avgsize(15)=2, distinct(21)=1066.43, null(21)=0, avgsize(21)=4, distinct(22)=1065.01, null(22)=0, avgsize(22)=4, distinct(23)=1064.52, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=9, distinct(26)=958.165, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=958.326, null(39)=0, avgsize(39)=4, distinct(40)=958.326, null(40)=0, avgsize(40)=3, distinct(42)=956.829, null(42)=0, avgsize(42)=9, distinct(46)=1066.43, null(46)=0, avgsize(46)=4, distinct(50)=957.145, null(50)=0, avgsize(50)=4, distinct(57)=25, null(57)=0, avgsize(57)=1, distinct(58)=25, null(58)=0, avgsize(58)=10, distinct(50,58)=1548.5, null(50,58)=0, avgsize(50,58)=14, distinct(25-27,42)=958.326, null(25-27,42)=0, avgsize(25-27,42)=36]
│ │ ├── fd: (1)-->(2), (12)-->(15), (39,40)-->(42), (23)==(12,40), (40)==(12,23), (22)==(1,39), (39)==(1,22), (46)-->(50), (21)==(46), (46)==(21), (12)==(23,40), (57)-->(58), (15)==(57), (57)==(15), (1)==(22,39)
│ │ ├── inner-join (hash)
│ │ │ ├── save-table-name: q9_inner_join_5
│ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null) s_suppkey:12(int!null) s_nationkey:15(int!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_quantity:25(float!null) l_extendedprice:26(float!null) l_discount:27(float!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null) o_orderkey:46(int!null) o_orderdate:50(date!null)
│ │ │ ├── multiplicity: left-rows(zero-or-more), right-rows(exactly-one)
- │ │ │ ├── stats: [rows=2450.856, distinct(1)=1224.06, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4, distinct(12)=1224.4, null(12)=0, avgsize(12)=4, distinct(15)=25, null(15)=0, avgsize(15)=4, distinct(21)=1227.57, null(21)=0, avgsize(21)=4, distinct(22)=1224.06, null(22)=0, avgsize(22)=4, distinct(23)=1224.4, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=4, distinct(26)=1058.55, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=1058.78, null(39)=0, avgsize(39)=4, distinct(40)=1058.78, null(40)=0, avgsize(40)=4, distinct(42)=763.514, null(42)=0, avgsize(42)=4, distinct(46)=1227.57, null(46)=0, avgsize(46)=4, distinct(50)=1057.01, null(50)=0, avgsize(50)=4]
+ │ │ │ ├── stats: [rows=2450.416, distinct(1)=1223.85, null(1)=0, avgsize(1)=4, distinct(2)=2405.95, null(2)=0, avgsize(2)=35, distinct(12)=1224.18, null(12)=0, avgsize(12)=3, distinct(15)=25, null(15)=0, avgsize(15)=2, distinct(21)=1227.35, null(21)=0, avgsize(21)=4, distinct(22)=1223.85, null(22)=0, avgsize(22)=4, distinct(23)=1224.18, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=9, distinct(26)=1058.35, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=1058.59, null(39)=0, avgsize(39)=4, distinct(40)=1058.59, null(40)=0, avgsize(40)=3, distinct(42)=1056.39, null(42)=0, avgsize(42)=9, distinct(46)=1227.35, null(46)=0, avgsize(46)=4, distinct(50)=1056.85, null(50)=0, avgsize(50)=4]
│ │ │ ├── fd: (1)-->(2), (12)-->(15), (39,40)-->(42), (23)==(12,40), (40)==(12,23), (22)==(1,39), (39)==(1,22), (46)-->(50), (21)==(46), (46)==(21), (12)==(23,40), (1)==(22,39)
│ │ │ ├── scan supplier@s_nk
│ │ │ │ ├── save-table-name: q9_scan_6
│ │ │ │ ├── columns: s_suppkey:12(int!null) s_nationkey:15(int!null)
- │ │ │ │ ├── stats: [rows=10000, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(15)=25, null(15)=0, avgsize(15)=4]
+ │ │ │ │ ├── stats: [rows=10000, distinct(12)=9920, null(12)=0, avgsize(12)=3, distinct(15)=25, null(15)=0, avgsize(15)=2]
│ │ │ │ │ histogram(12)= 0 0 0 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 0 0
│ │ │ │ │ <--- -9223372036854775808 --- 1 ---- 51 ---- 101 ---- 151 ---- 201 ---- 251 ---- 301 ---- 351 ---- 401 ---- 451 ---- 501 ---- 551 ---- 601 ---- 651 ---- 701 ---- 751 ---- 801 ---- 851 ---- 901 ---- 951 ---- 1001 ---- 1051 ---- 1101 ---- 1151 ---- 1201 ---- 1251 ---- 1301 ---- 1351 ---- 1401 ---- 1451 ---- 1501 ---- 1551 ---- 1601 ---- 1651 ---- 1701 ---- 1751 ---- 1801 ---- 1851 ---- 1901 ---- 1951 ---- 2001 ---- 2051 ---- 2101 ---- 2151 ---- 2201 ---- 2251 ---- 2301 ---- 2351 ---- 2401 ---- 2451 ---- 2501 ---- 2551 ---- 2601 ---- 2651 ---- 2701 ---- 2751 ---- 2801 ---- 2851 ---- 2901 ---- 2951 ---- 3001 ---- 3051 ---- 3101 ---- 3151 ---- 3201 ---- 3251 ---- 3301 ---- 3351 ---- 3401 ---- 3451 ---- 3501 ---- 3551 ---- 3601 ---- 3651 ---- 3701 ---- 3751 ---- 3801 ---- 3851 ---- 3901 ---- 3951 ---- 4001 ---- 4051 ---- 4101 ---- 4151 ---- 4201 ---- 4251 ---- 4301 ---- 4351 ---- 4401 ---- 4451 ---- 4501 ---- 4551 ---- 4601 ---- 4651 ---- 4701 ---- 4751 ---- 4801 ---- 4851 ---- 4901 ---- 4951 ---- 5001 ---- 5051 ---- 5101 ---- 5151 ---- 5201 ---- 5251 ---- 5301 ---- 5351 ---- 5401 ---- 5451 ---- 5501 ---- 5551 ---- 5601 ---- 5651 ---- 5701 ---- 5751 ---- 5801 ---- 5851 ---- 5901 ---- 5951 ---- 6001 ---- 6051 ---- 6101 ---- 6151 ---- 6201 ---- 6251 ---- 6301 ---- 6351 ---- 6401 ---- 6451 ---- 6501 ---- 6551 ---- 6601 ---- 6651 ---- 6701 ---- 6751 ---- 6801 ---- 6851 ---- 6901 ---- 6951 ---- 7001 ---- 7051 ---- 7101 ---- 7151 ---- 7201 ---- 7251 ---- 7301 ---- 7351 ---- 7401 ---- 7451 ---- 7501 ---- 7552 ---- 7603 ---- 7654 ---- 7705 ---- 7756 ---- 7807 ---- 7858 ---- 7909 ---- 7960 ---- 8011 ---- 8062 ---- 8113 ---- 8164 ---- 8215 ---- 8266 ---- 8317 ---- 8368 ---- 8419 ---- 8470 ---- 8521 ---- 8572 ---- 8623 ---- 8674 ---- 8725 ---- 8776 ---- 8827 ---- 8878 ---- 8929 ---- 8980 ---- 9031 ---- 9082 ---- 9133 ---- 9184 ---- 9235 ---- 9286 ---- 9337 ---- 9388 ---- 9439 ---- 9490 ---- 9541 ---- 9592 ---- 9643 ---- 9694 ---- 9745 ---- 9796 ---- 9847 ---- 9898 ---- 9949 ---- 10000 --- 9223372036854775807
- │ │ │ │ │ histogram(15)= 0 403 0 384 0 391 0 396 0 406 0 396 0 393 0 399 0 406 0 393 0 383 0 398 0 394 0 414 0 422 0 387 0 435 0 403 0 441 0 357 0 394 0 390 0 421 0 411 0 383
+ │ │ │ │ │ histogram(15)= 0 420 0 413 0 397 0 412 0 415 0 380 0 402 0 396 0 415 0 405 0 393 0 438 0 377 0 362 0 376 0 373 0 406 0 421 0 407 0 398 0 411 0 399 0 401 0 390 0 393
│ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ ├── key: (12)
│ │ │ │ └── fd: (12)-->(15)
@@ -102,20 +102,20 @@ sort
│ │ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_quantity:25(float!null) l_extendedprice:26(float!null) l_discount:27(float!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null) o_orderkey:46(int!null) o_orderdate:50(date!null)
│ │ │ │ ├── key columns: [21] = [46]
│ │ │ │ ├── lookup columns are key
- │ │ │ │ ├── stats: [rows=2431.25, distinct(1)=1535.74, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4, distinct(21)=1535.88, null(21)=0, avgsize(21)=4, distinct(22)=1535.74, null(22)=0, avgsize(22)=4, distinct(23)=1220.4, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=4, distinct(26)=1220.02, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=1220.4, null(39)=0, avgsize(39)=4, distinct(40)=1220.4, null(40)=0, avgsize(40)=4, distinct(42)=800.087, null(42)=0, avgsize(42)=4, distinct(46)=1535.88, null(46)=0, avgsize(46)=4, distinct(50)=1217.46, null(50)=0, avgsize(50)=4]
+ │ │ │ │ ├── stats: [rows=2430.813, distinct(1)=1535.46, null(1)=0, avgsize(1)=4, distinct(2)=2387.05, null(2)=0, avgsize(2)=35, distinct(21)=1535.6, null(21)=0, avgsize(21)=4, distinct(22)=1535.46, null(22)=0, avgsize(22)=4, distinct(23)=1220.18, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=9, distinct(26)=1219.79, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=1220.18, null(39)=0, avgsize(39)=4, distinct(40)=1220.18, null(40)=0, avgsize(40)=3, distinct(42)=1216.52, null(42)=0, avgsize(42)=9, distinct(46)=1535.6, null(46)=0, avgsize(46)=4, distinct(50)=1217.29, null(50)=0, avgsize(50)=4]
│ │ │ │ ├── fd: (1)-->(2), (39,40)-->(42), (23)==(40), (40)==(23), (22)==(1,39), (39)==(1,22), (46)-->(50), (21)==(46), (46)==(21), (1)==(22,39)
│ │ │ │ ├── inner-join (lookup lineitem)
│ │ │ │ │ ├── save-table-name: q9_lookup_join_8
│ │ │ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_quantity:25(float!null) l_extendedprice:26(float!null) l_discount:27(float!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null)
│ │ │ │ │ ├── key columns: [21 24] = [21 24]
│ │ │ │ │ ├── lookup columns are key
- │ │ │ │ │ ├── stats: [rows=2431.25, distinct(1)=2429.5, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4, distinct(21)=1535.88, null(21)=0, avgsize(21)=4, distinct(22)=2429.5, null(22)=0, avgsize(22)=4, distinct(23)=1536.39, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=4, distinct(26)=1535.58, null(26)=0, avgsize(26)=4, distinct(27)=11, null(27)=0, avgsize(27)=4, distinct(39)=1536.39, null(39)=0, avgsize(39)=4, distinct(40)=1536.39, null(40)=0, avgsize(40)=4, distinct(42)=848.52, null(42)=0, avgsize(42)=4]
+ │ │ │ │ │ ├── stats: [rows=2430.813, distinct(1)=2429.06, null(1)=0, avgsize(1)=4, distinct(2)=2387.05, null(2)=0, avgsize(2)=35, distinct(21)=1535.6, null(21)=0, avgsize(21)=4, distinct(22)=2429.06, null(22)=0, avgsize(22)=4, distinct(23)=1536.11, null(23)=0, avgsize(23)=4, distinct(25)=50, null(25)=0, avgsize(25)=9, distinct(26)=1535.27, null(26)=0, avgsize(26)=9, distinct(27)=11, null(27)=0, avgsize(27)=9, distinct(39)=1536.11, null(39)=0, avgsize(39)=4, distinct(40)=1536.11, null(40)=0, avgsize(40)=3, distinct(42)=1528.33, null(42)=0, avgsize(42)=9]
│ │ │ │ │ ├── fd: (1)-->(2), (39,40)-->(42), (23)==(40), (40)==(23), (22)==(1,39), (39)==(1,22), (1)==(22,39)
│ │ │ │ │ ├── inner-join (lookup lineitem@l_pk_sk)
│ │ │ │ │ │ ├── save-table-name: q9_lookup_join_9
│ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null) l_orderkey:21(int!null) l_partkey:22(int!null) l_suppkey:23(int!null) l_linenumber:24(int!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null)
│ │ │ │ │ │ ├── key columns: [39 40] = [22 23]
- │ │ │ │ │ │ ├── stats: [rows=812.9182, distinct(1)=807.978, null(1)=0, avgsize(1)=4, distinct(2)=119.863, null(2)=0, avgsize(2)=4, distinct(21)=812.702, null(21)=0, avgsize(21)=4, distinct(22)=812.918, null(22)=0, avgsize(22)=4, distinct(23)=812.918, null(23)=0, avgsize(23)=4, distinct(24)=7, null(24)=0, avgsize(24)=4, distinct(39)=812.918, null(39)=0, avgsize(39)=4, distinct(40)=812.918, null(40)=0, avgsize(40)=4, distinct(42)=556.438, null(42)=0, avgsize(42)=4]
+ │ │ │ │ │ │ ├── stats: [rows=812.7722, distinct(1)=807.834, null(1)=0, avgsize(1)=4, distinct(2)=807.748, null(2)=0, avgsize(2)=35, distinct(21)=812.556, null(21)=0, avgsize(21)=4, distinct(22)=812.772, null(22)=0, avgsize(22)=4, distinct(23)=812.772, null(23)=0, avgsize(23)=4, distinct(24)=7, null(24)=0, avgsize(24)=1, distinct(39)=812.772, null(39)=0, avgsize(39)=4, distinct(40)=812.772, null(40)=0, avgsize(40)=3, distinct(42)=809.246, null(42)=0, avgsize(42)=9]
│ │ │ │ │ │ ├── key: (21,24)
│ │ │ │ │ │ ├── fd: (1)-->(2), (39,40)-->(42), (1)==(22,39), (39)==(1,22), (21,24)-->(22,23), (22)==(1,39), (23)==(40), (40)==(23)
│ │ │ │ │ │ ├── inner-join (merge)
@@ -123,37 +123,37 @@ sort
│ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null) ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null)
│ │ │ │ │ │ │ ├── left ordering: +39
│ │ │ │ │ │ │ ├── right ordering: +1
- │ │ │ │ │ │ │ ├── stats: [rows=267682.5, distinct(1)=66618.7, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4, distinct(39)=66618.7, null(39)=0, avgsize(39)=4, distinct(40)=9920, null(40)=0, avgsize(40)=4, distinct(42)=1000, null(42)=0, avgsize(42)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=267682.5, distinct(1)=66618.7, null(1)=0, avgsize(1)=4, distinct(2)=65464.1, null(2)=0, avgsize(2)=35, distinct(39)=66618.7, null(39)=0, avgsize(39)=4, distinct(40)=9920, null(40)=0, avgsize(40)=3, distinct(42)=93404.7, null(42)=0, avgsize(42)=9]
│ │ │ │ │ │ │ ├── key: (39,40)
│ │ │ │ │ │ │ ├── fd: (1)-->(2), (39,40)-->(42), (1)==(39), (39)==(1)
│ │ │ │ │ │ │ ├── scan partsupp
│ │ │ │ │ │ │ │ ├── save-table-name: q9_scan_11
│ │ │ │ │ │ │ │ ├── columns: ps_partkey:39(int!null) ps_suppkey:40(int!null) ps_supplycost:42(float!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=800000, distinct(39)=199241, null(39)=0, avgsize(39)=4, distinct(40)=9920, null(40)=0, avgsize(40)=4, distinct(42)=1000, null(42)=0, avgsize(42)=4]
- │ │ │ │ │ │ │ │ │ histogram(39)= 0 0 0 79.993 3911.6 79.993 3941.6 79.993 3926.6 79.993 3926.6 79.993 3926.6 79.993 3916.6 79.993 3908.6 79.993 3912.6 79.993 3934.6 79.993 3934.6 79.993 3929.6 79.993 3923.6 79.993 3932.6 158.99 3918.6 79.993 3915.6 79.993 3907.6 79.993 3912.6 79.993 3914.6 79.993 3922.6 79.993 3914.6 79.993 3921.6 79.993 3909.6 79.993 3927.6 79.993 3913.6 79.993 3913.6 79.993 3904.6 79.993 3913.6 79.993 3920.6 79.993 3913.6 79.993 3904.6 79.993 3904.6 79.993 3908.6 79.993 3908.6 79.993 3944.6 79.993 3916.6 79.993 3930.6 79.993 3904.6 79.993 3927.6 79.993 3923.6 79.993 3911.6 79.993 3911.6 79.993 3914.6 79.993 3913.6 79.993 3913.6 79.993 3922.6 79.993 3901.6 79.993 3922.6 79.993 3924.6 79.993 3920.6 79.993 3921.6 79.993 3930.6 79.993 3925.6 79.993 3913.6 79.993 3924.6 79.993 3939.6 79.993 3928.6 79.993 3924.6 79.993 3918.6 79.993 3928.6 79.993 3916.6 79.993 3911.6 79.993 3936.6 79.993 3933.6 79.993 3831.6 158.99 3903.6 79.993 3911.6 79.993 3913.6 79.993 3911.6 79.993 3909.6 79.993 3913.6 79.993 3920.6 79.993 3910.6 79.993 3906.6 79.993 3918.6 79.993 3910.6 79.993 3908.6 79.993 3910.6 79.993 3911.6 79.993 3903.6 79.993 3903.6 79.993 3904.6 79.993 3923.6 79.993 3933.6 79.993 3928.6 79.993 3834.6 158.99 3928.6 79.993 3904.6 79.993 3943.6 79.993 3909.6 79.993 3943.6 79.993 3918.6 79.993 3919.6 79.993 3923.6 79.993 3916.6 79.993 3942.6 79.993 3934.6 79.993 3922.6 79.993 3908.6 79.993 3919.6 79.993 3910.6 79.993 3943.6 79.993 3912.6 79.993 3916.6 79.993 3951.6 79.993 3919.6 79.993 3906.6 79.993 3920.6 79.993 3941.6 79.993 3913.6 79.993 3905.6 79.993 3909.6 79.993 3909.6 79.993 3905.6 79.993 3913.6 79.993 3918.6 79.993 3934.6 79.993 3902.6 79.993 3907.6 79.993 3923.6 79.993 3922.6 79.993 3926.6 79.993 3917.6 79.993 3827.6 158.99 3911.6 79.993 3911.6 79.993 3937.6 79.993 3904.6 79.993 3975.6 79.993 3905.6 158.99 3917.6 79.993 3918.6 79.993 3906.6 79.993 3930.6 79.993 3917.6 79.993 3909.6 79.993 3916.6 79.993 3912.6 79.993 3922.6 79.993 3912.6 79.993 3907.6 79.993 3905.6 79.993 3912.6 79.993 3931.6 79.993 3913.6 79.993 3918.6 79.993 3920.6 79.993 3911.6 79.993 3902.6 79.993 3917.6 79.993 3920.6 79.993 3915.6 79.993 3904.6 79.993 4056.6 79.993 4020.6 79.993 4006.6 79.993 4046.6 79.993 4006.6 79.993 3998.6 79.993 4012.6 79.993 3985.6 79.993 3991.6 79.993 4009.6 79.993 3989.6 79.993 4032.6 79.993 3989.6 79.993 3990.6 79.993 3985.6 79.993 4024.6 79.993 3993.6 79.993 4000.6 79.993 4039.6 79.993 3987.6 79.993 4016.6 79.993 4017.6 79.993 3990.6 79.993 3998.6 79.993 4002.6 79.993 4005.6 79.993 4003.6 79.993 4000.6 79.993 4026.6 79.993 3995.6 79.993 3997.6 79.993 4014.6 79.993 4008.6 79.993 4002.6 79.993 3989.6 79.993 4017.6 79.993 4003.6 79.993 3988.6 79.993 4028.6 79.993 3997.6 79.993 4000.6 79.993 3998.6 158.99 3904.6 79.993 3990.6 79.993 3989.6 79.993 3997.6 79.993 3988.6 79.993 0 0
- │ │ │ │ │ │ │ │ │ <--- -9223372036854775808 ---- 5 ---------- 925 --------- 2147 -------- 3243 -------- 4346 -------- 5444 -------- 6433 -------- 7290 -------- 8225 -------- 9393 -------- 10561 -------- 11687 -------- 12755 -------- 13905 -------- 14921 -------- 15897 -------- 16739 -------- 17675 -------- 18640 -------- 19705 -------- 20671 -------- 21719 -------- 22602 -------- 23714 -------- 24672 -------- 25620 -------- 26379 -------- 27327 -------- 28366 -------- 29320 -------- 30070 -------- 30837 -------- 31707 -------- 32567 -------- 33809 -------- 34795 -------- 35930 -------- 36688 -------- 37801 -------- 38874 -------- 39798 -------- 40717 -------- 41686 -------- 42635 -------- 43586 -------- 44647 -------- 45188 -------- 46250 -------- 47331 -------- 48366 -------- 49411 -------- 50547 -------- 51636 -------- 52588 -------- 53673 -------- 54877 -------- 55992 -------- 57071 -------- 58085 -------- 59202 -------- 60194 -------- 61109 -------- 62289 -------- 63452 -------- 64350 -------- 65061 -------- 65983 -------- 66930 -------- 67848 -------- 68740 -------- 69687 -------- 70729 -------- 71625 -------- 72441 -------- 73462 -------- 74357 -------- 75226 -------- 76123 -------- 77037 -------- 77774 -------- 78521 -------- 79269 -------- 80341 -------- 81504 -------- 82626 -------- 83571 -------- 84691 -------- 85448 -------- 86681 -------- 87565 -------- 88799 -------- 89810 -------- 90834 -------- 91901 -------- 92892 -------- 94119 -------- 95284 -------- 96346 -------- 97205 -------- 98231 -------- 99141 -------- 100372 -------- 101314 -------- 102304 -------- 103594 -------- 104620 -------- 105437 -------- 106475 -------- 107696 -------- 108646 -------- 109445 -------- 110330 -------- 111220 -------- 112020 -------- 112978 -------- 113996 -------- 115166 -------- 115838 -------- 116694 -------- 117766 -------- 118830 -------- 119934 -------- 120936 -------- 121757 -------- 122685 -------- 123602 -------- 124791 -------- 125549 -------- 126970 -------- 127770 -------- 128776 -------- 129788 -------- 130602 -------- 131740 -------- 132748 -------- 133632 -------- 134629 -------- 135564 -------- 136625 -------- 137559 -------- 138398 -------- 139204 -------- 140136 -------- 141281 -------- 142230 -------- 143246 -------- 144284 -------- 145212 -------- 145869 -------- 146873 -------- 147910 -------- 148889 -------- 149656 -------- 151106 -------- 152338 -------- 153457 -------- 154854 -------- 155973 -------- 157005 -------- 158178 -------- 159002 -------- 159939 -------- 161091 -------- 162000 -------- 163314 -------- 164230 -------- 165157 -------- 165980 -------- 167242 -------- 168207 -------- 169271 -------- 170628 -------- 171503 -------- 172711 -------- 173922 -------- 174853 -------- 175886 -------- 176965 -------- 178073 -------- 179166 -------- 180231 -------- 181505 -------- 182510 -------- 183541 -------- 184734 -------- 185872 -------- 186957 -------- 187866 -------- 189075 -------- 190166 -------- 191061 -------- 192354 -------- 193380 -------- 194445 -------- 195479 -------- 196243 -------- 197170 -------- 198076 -------- 199103 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ │ │ │ │ histogram(40)= 0 240 3920 160 3840 160 3840 160 3920 80 3760 240 3920 80 3920 160 3920 80 3920 80 3920 160 3760 320 3920 80 3920 80 3840 160 3920 80 3760 240 3840 240 3920 80 3920 80 3840 160 3920 80 3920 80 3920 80 3920 240 3920 320 3920 80 3920 80 3920 80 3920 80 3920 160 3920 160 3920 80 3920 160 3680 320 3920 160 3840 240 3920 80 3920 80 3840 160 3920 80 3920 80 3840 160 3920 80 3920 320 3920 80 3920 160 3920 80 3920 160 3920 160 3920 80 3920 80 3840 320 3920 80 3680 320 3920 160 3680 400 3840 240 3840 160 3920 240 3920 80 3920 320 3920 320 3920 160 3760 320 3760 240 3920 80 3920 80 3840 160 3840 320 3840 160 3920 160 3920 80 3920 80 3920 80 3920 80 3920 160 3920 80 3840 240 3920 80 3840 160 3840 160 3840 240 3840 160 3920 80 3920 160 3920 80 3840 160 3920 80 3920 240 3920 160 3920 160 3840 160 3920 160 3840 80 3840 240 3840 160 3760 160 3920 160 3840 80 3840 160 3920 80 3920 80 3920 80 3920 80 3840 160 3920 240 3760 160 3840 80 3840 320 3760 160 3680 240 3840 160 3760 320 3840 240 3840 160 3840 80 3840 160 3840 80 3920 80 3920 240 3760 160 3840 80 3920 160 3600 320 3920 160 3840 240 3840 80 3840 160 3840 160 3680 320 3760 240 3840 80 3840 160 3760 400 3840 160 3840 160 3680 320 3840 80 3840 80 3920 80 3840 160 3920 160 3840 80 3920 80 3840 160 3920 320 3760 160 3840 160 3840 80 3840 160 3840 80 3680 320 3920 80 3920 160 3840 80 3840 240 3840 80 3920 80 3920 80 3760 240 3920 160 3840 160 3840 240 3840 80 3680 240 3920 80 3920 80 3680 320 3920 80 3920 80 3920 160 3840 240 3840 160 3840 160 3680 240 3760 160 3920 80 3920 80 3760 240 3840 240 3840 80 3840 160 3760 240 3920 160 3840 240 3680 320 3840 160 3840 80 3760 160 3920 240 3840 80 3840 80 3840 160 3920 80 3680 320 3920 160 3760 160 3840 160 3920 80
- │ │ │ │ │ │ │ │ │ <--- 1 ------ 48 ------ 112 ------ 174 ------ 233 ------ 271 ------ 318 ------ 364 ------ 415 ------ 468 ------ 521 ------ 565 ------ 617 ------ 658 ------ 713 ------ 767 ------ 817 ------ 878 ------ 930 ------ 978 ------ 1034 ------ 1095 ------ 1150 ------ 1193 ------ 1243 ------ 1294 ------ 1348 ------ 1402 ------ 1468 ------ 1507 ------ 1552 ------ 1614 ------ 1673 ------ 1731 ------ 1780 ------ 1834 ------ 1881 ------ 1940 ------ 1994 ------ 2041 ------ 2096 ------ 2153 ------ 2199 ------ 2256 ------ 2304 ------ 2349 ------ 2401 ------ 2451 ------ 2498 ------ 2546 ------ 2599 ------ 2643 ------ 2683 ------ 2731 ------ 2772 ------ 2827 ------ 2869 ------ 2915 ------ 2973 ------ 3023 ------ 3078 ------ 3129 ------ 3184 ------ 3236 ------ 3296 ------ 3353 ------ 3413 ------ 3473 ------ 3521 ------ 3566 ------ 3607 ------ 3657 ------ 3718 ------ 3775 ------ 3813 ------ 3868 ------ 3924 ------ 3971 ------ 4008 ------ 4065 ------ 4123 ------ 4174 ------ 4231 ------ 4269 ------ 4332 ------ 4385 ------ 4436 ------ 4484 ------ 4537 ------ 4588 ------ 4633 ------ 4685 ------ 4733 ------ 4783 ------ 4834 ------ 4874 ------ 4918 ------ 4953 ------ 5008 ------ 5052 ------ 5096 ------ 5147 ------ 5197 ------ 5245 ------ 5292 ------ 5341 ------ 5396 ------ 5449 ------ 5498 ------ 5547 ------ 5602 ------ 5651 ------ 5703 ------ 5742 ------ 5786 ------ 5827 ------ 5865 ------ 5935 ------ 5980 ------ 6050 ------ 6096 ------ 6153 ------ 6208 ------ 6270 ------ 6309 ------ 6358 ------ 6412 ------ 6464 ------ 6518 ------ 6577 ------ 6640 ------ 6676 ------ 6735 ------ 6792 ------ 6835 ------ 6877 ------ 6916 ------ 6968 ------ 7025 ------ 7061 ------ 7107 ------ 7159 ------ 7221 ------ 7264 ------ 7300 ------ 7356 ------ 7390 ------ 7448 ------ 7495 ------ 7547 ------ 7605 ------ 7648 ------ 7707 ------ 7755 ------ 7818 ------ 7858 ------ 7904 ------ 7951 ------ 7992 ------ 8049 ------ 8098 ------ 8144 ------ 8194 ------ 8234 ------ 8282 ------ 8323 ------ 8376 ------ 8433 ------ 8474 ------ 8514 ------ 8564 ------ 8623 ------ 8676 ------ 8734 ------ 8784 ------ 8819 ------ 8857 ------ 8907 ------ 8955 ------ 9012 ------ 9060 ------ 9103 ------ 9157 ------ 9200 ------ 9249 ------ 9301 ------ 9339 ------ 9381 ------ 9430 ------ 9474 ------ 9529 ------ 9579 ------ 9631 ------ 9673 ------ 9732 ------ 9780 ------ 9832 ------ 9886 ------ 9941 ------ 9997
- │ │ │ │ │ │ │ │ │ histogram(42)= 0 1040 7.9808e+05 880
- │ │ │ │ │ │ │ │ │ <--- 0.009999999776482582 ------------ 10.0
+ │ │ │ │ │ │ │ │ ├── stats: [rows=800000, distinct(39)=199241, null(39)=0, avgsize(39)=4, distinct(40)=9920, null(40)=0, avgsize(40)=3, distinct(42)=100379, null(42)=0, avgsize(42)=9]
+ │ │ │ │ │ │ │ │ │ histogram(39)= 0 79.993 3912.7 79.993 3933.7 79.993 3920.7 79.993 3917.7 79.993 3929.7 79.993 3912.7 79.993 3932.7 79.993 3918.7 158.99 3914.7 79.993 3928.7 79.993 3910.7 79.993 3904.7 79.993 3924.7 79.993 3914.7 79.993 3909.7 79.993 3917.7 79.993 3926.7 79.993 3913.7 79.993 3905.7 79.993 3912.7 79.993 3931.7 79.993 3926.7 79.993 3926.7 79.993 3906.7 79.993 3923.7 79.993 3904.7 79.993 3904.7 79.993 3907.7 158.99 3979.6 79.993 3906.7 79.993 3914.7 79.993 3918.7 79.993 3917.7 79.993 3826.7 158.99 3936.7 79.993 3908.7 79.993 3926.7 79.993 3930.7 79.993 3967.6 79.993 3910.7 79.993 3922.7 79.993 3914.7 79.993 3913.7 79.993 3915.7 79.993 3919.7 79.993 3916.7 79.993 3920.7 79.993 3926.7 79.993 3908.7 79.993 3904.7 158.99 3926.7 79.993 3922.7 79.993 3918.7 79.993 3908.7 79.993 3919.7 79.993 3908.7 79.993 3907.7 79.993 3916.7 79.993 3917.7 79.993 3905.7 79.993 3918.7 79.993 3940.7 79.993 3916.7 79.993 3923.7 79.993 3909.7 79.993 3915.7 79.993 3911.7 79.993 3915.7 79.993 3914.7 79.993 3948.6 79.993 3924.7 79.993 3916.7 79.993 3943.7 79.993 3933.7 79.993 3915.7 79.993 3916.7 79.993 3914.7 79.993 3919.7 79.993 3916.7 79.993 3912.7 79.993 3904.7 79.993 3913.7 79.993 3909.7 79.993 3914.7 79.993 3910.7 79.993 3923.7 79.993 3913.7 79.993 3914.7 79.993 3921.7 79.993 3927.7 79.993 3921.7 79.993 3924.7 158.99 3910.7 79.993 3916.7 79.993 3949.6 79.993 3922.7 79.993 3915.7 79.993 3942.7 79.993 3915.7 79.993 3917.7 79.993 3842.7 158.99 3911.7 79.993 3923.7 79.993 3923.7 79.993 3906.7 79.993 3925.7 79.993 3951.6 79.993 3933.7 79.993 3916.7 79.993 3903.7 79.993 3923.7 79.993 3932.7 79.993 3928.7 79.993 3905.7 79.993 3921.7 79.993 3920.7 79.993 3910.7 79.993 3912.7 79.993 3916.7 79.993 3922.7 79.993 3911.7 79.993 3906.7 79.993 3921.7 79.993 3911.7 79.993 3911.7 79.993 3926.7 79.993 3912.7 79.993 3945.6 79.993 3910.7 79.993 3922.7 79.993 3918.7 79.993 3911.7 79.993 3917.7 79.993 3945.6 79.993 3926.7 79.993 3926.7 79.993 3917.7 79.993 3904.7 79.993 3925.7 79.993 3912.7 79.993 3912.7 79.993 3954.6 79.993 3915.7 79.993 3912.7 79.993 3910.7 79.993 3909.7 79.993 3911.7 79.993 3903.7 79.993 3915.7 79.993 3949.6 79.993 3923.7 79.993 3921.7 79.993 3909.7 79.993 3905.7 79.993 3988.6 79.993 3988.6 79.993 3999.6 79.993 4003.6 79.993 3998.6 79.993 4021.6 79.993 4027.6 79.993 4005.6 79.993 3999.6 79.993 3997.6 79.993 3988.6 79.993 3989.6 79.993 4004.6 79.993 3984.6 79.993 3999.6 79.993 3999.6 79.993 4019.6 79.993 4011.6 79.993 4020.6 79.993 4012.6 79.993 3996.6 79.993 4029.6 79.993 4004.6 158.99 3912.7 79.993 3995.6 79.993 3989.6 79.993 3991.6 79.993 3986.6 79.993 3986.6 79.993 4006.6 79.993 3988.6 79.993 3989.6 79.993 3989.6 79.993 3998.6 79.993 4012.6 79.993 4017.6 79.993 4017.6 79.993 3996.6 79.993 3994.6 79.993 4009.6 79.993 3995.6 79.993 3996.6 79.993 3991.6 79.993 4006.6 79.993 4020.6 79.993
+ │ │ │ │ │ │ │ │ │ <---- 13 --------- 942 --------- 2097 -------- 3127 -------- 4125 -------- 5247 -------- 6181 -------- 7326 -------- 8333 -------- 9292 -------- 10410 -------- 11308 -------- 12057 -------- 13131 -------- 14088 -------- 14972 -------- 15975 -------- 17072 -------- 18019 -------- 18798 -------- 19734 -------- 20877 -------- 21973 -------- 23067 -------- 23887 -------- 24957 -------- 25716 -------- 26450 -------- 27291 -------- 28733 -------- 29539 -------- 30499 -------- 31512 -------- 32509 -------- 33286 -------- 34464 -------- 35311 -------- 36406 -------- 37541 -------- 38918 -------- 39818 -------- 40879 -------- 41843 -------- 42789 -------- 43757 -------- 44778 -------- 45769 -------- 46806 -------- 47899 -------- 48763 -------- 49507 -------- 50607 -------- 51663 -------- 52669 -------- 53525 -------- 54549 -------- 55415 -------- 56261 -------- 57242 -------- 58242 -------- 59036 -------- 60050 -------- 61259 -------- 62240 -------- 63307 -------- 64178 -------- 65152 -------- 66063 -------- 67040 -------- 68005 -------- 69273 -------- 70354 -------- 71339 -------- 72569 -------- 73724 -------- 74695 -------- 75684 -------- 76646 -------- 77670 -------- 78657 -------- 79587 -------- 80331 -------- 81281 -------- 82150 -------- 83115 -------- 84014 -------- 85082 -------- 86031 -------- 86990 -------- 88034 -------- 89138 -------- 90187 -------- 91260 -------- 92150 -------- 93140 -------- 94413 -------- 95469 -------- 96443 -------- 97666 -------- 98637 -------- 99633 -------- 100664 -------- 101572 -------- 102643 -------- 103706 -------- 104522 -------- 105605 -------- 106892 -------- 108047 -------- 109036 -------- 109721 -------- 110790 -------- 111938 -------- 113052 -------- 113830 -------- 114873 -------- 115912 -------- 116814 -------- 117737 -------- 118721 -------- 119776 -------- 120692 -------- 121500 -------- 122545 -------- 123457 -------- 124366 -------- 125466 -------- 126391 -------- 127638 -------- 128533 -------- 129586 -------- 130602 -------- 131508 -------- 132509 -------- 133756 -------- 134848 -------- 135944 -------- 136945 -------- 137706 -------- 138791 -------- 139720 -------- 140657 -------- 141959 -------- 142929 -------- 143854 -------- 144743 -------- 145629 -------- 146548 -------- 147238 -------- 148209 -------- 149481 -------- 150548 -------- 151598 -------- 152481 -------- 153250 -------- 154137 -------- 155017 -------- 156060 -------- 157143 -------- 158169 -------- 159406 -------- 160686 -------- 161794 -------- 162837 -------- 163860 -------- 164730 -------- 165623 -------- 166716 -------- 167485 -------- 168526 -------- 169568 -------- 170793 -------- 171958 -------- 173192 -------- 174365 -------- 175367 -------- 176660 -------- 177754 -------- 178681 -------- 179672 -------- 180568 -------- 181502 -------- 182344 -------- 183171 -------- 184286 -------- 185174 -------- 186068 -------- 186966 -------- 187997 -------- 189168 -------- 190375 -------- 191583 -------- 192588 -------- 193575 -------- 194722 -------- 195713 -------- 196725 -------- 197653 -------- 198767 -------- 199999
+ │ │ │ │ │ │ │ │ │ histogram(40)= 0 160 3920 160 3920 80 3920 160 3920 160 3920 240 3760 240 3920 80 3840 240 3920 240 3840 320 3760 240 3920 80 3840 160 3920 240 3920 320 3920 80 3920 80 3920 80 3840 160 3920 240 3760 240 3920 80 3840 160 3920 80 3920 160 3920 80 3920 160 3920 80 3920 160 3920 80 3760 240 3840 240 3920 80 3920 80 3840 240 3760 240 3920 80 3840 160 3840 160 3920 80 3920 80 3920 160 3760 240 3920 240 3920 80 3920 160 3920 80 3840 160 3920 160 3920 80 3840 160 3840 240 3920 160 3840 160 3920 160 3920 80 3840 160 3920 160 3840 160 3840 160 3920 80 3920 160 3920 160 3920 80 3920 80 3840 160 3840 160 3840 160 3920 80 3920 80 3840 240 3840 160 3920 320 3840 160 3840 240 3920 80 3920 80 3760 240 3840 160 3920 160 3920 80 3840 240 3920 80 3920 80 3920 160 3920 80 3920 80 3920 80 3920 80 3840 160 3920 80 3920 160 3760 320 3920 80 3920 80 3840 160 3920 240 3920 80 3920 80 3920 80 3920 160 3840 160 3760 400 3760 240 3680 320 3840 240 3840 80 3840 160 3840 160 3920 80 3920 80 3920 80 3840 160 3920 80 3760 240 3920 80 3840 240 3840 80 3840 160 3920 240 3840 80 3840 80 3840 160 3920 80 3760 240 3920 80 3920 160 3840 160 3760 240 3760 240 3840 80 3920 160 3840 80 3920 80 3920 80 3840 400 3760 160 3840 80 3840 160 3760 160 3840 240 3840 160 3680 320 3760 160 3920 80 3920 80 3920 80 3920 80 3920 80 3840 160 3760 240 3840 160 3920 80 3840 160 3920 240 3840 160 3840 80 3840 160 3840 80 3920 80 3920 80 3920 160 3840 160 3840 160 3840 160 3760 160 3920 80 3920 80 3920 80 3920 80 3760 240 3920 80 3920 320 3760 160 3840 80 3840 80 3920 160 3840 80 3920 160 3760 160 3920 80 3920 80 3920 160 3840 160 3840 80 3840 160 3920 80 3920 80 3920 80 3840 160 3840 240 3840 160 3840 80 3920 80 3840 240 3840 80 3920 80 3920 80 3840 160
+ │ │ │ │ │ │ │ │ │ <--- 2 ------ 50 ------ 104 ------ 153 ------ 213 ------ 281 ------ 320 ------ 366 ------ 411 ------ 462 ------ 515 ------ 548 ------ 600 ------ 649 ------ 697 ------ 743 ------ 793 ------ 845 ------ 893 ------ 953 ------ 1006 ------ 1052 ------ 1103 ------ 1158 ------ 1199 ------ 1246 ------ 1302 ------ 1375 ------ 1418 ------ 1475 ------ 1524 ------ 1563 ------ 1628 ------ 1689 ------ 1740 ------ 1799 ------ 1850 ------ 1901 ------ 1948 ------ 2017 ------ 2055 ------ 2099 ------ 2157 ------ 2214 ------ 2267 ------ 2319 ------ 2373 ------ 2428 ------ 2478 ------ 2546 ------ 2602 ------ 2657 ------ 2707 ------ 2760 ------ 2808 ------ 2852 ------ 2913 ------ 2968 ------ 3030 ------ 3069 ------ 3115 ------ 3165 ------ 3210 ------ 3256 ------ 3306 ------ 3365 ------ 3419 ------ 3469 ------ 3523 ------ 3576 ------ 3641 ------ 3694 ------ 3738 ------ 3806 ------ 3851 ------ 3900 ------ 3957 ------ 4004 ------ 4050 ------ 4095 ------ 4145 ------ 4201 ------ 4251 ------ 4293 ------ 4335 ------ 4380 ------ 4432 ------ 4484 ------ 4541 ------ 4593 ------ 4650 ------ 4706 ------ 4744 ------ 4804 ------ 4845 ------ 4897 ------ 4945 ------ 4992 ------ 5044 ------ 5108 ------ 5160 ------ 5207 ------ 5261 ------ 5319 ------ 5358 ------ 5404 ------ 5450 ------ 5490 ------ 5538 ------ 5590 ------ 5639 ------ 5686 ------ 5742 ------ 5788 ------ 5837 ------ 5884 ------ 5940 ------ 5985 ------ 6037 ------ 6090 ------ 6135 ------ 6185 ------ 6228 ------ 6271 ------ 6323 ------ 6376 ------ 6434 ------ 6474 ------ 6527 ------ 6586 ------ 6633 ------ 6674 ------ 6711 ------ 6751 ------ 6797 ------ 6835 ------ 6880 ------ 6918 ------ 6982 ------ 7026 ------ 7069 ------ 7123 ------ 7179 ------ 7238 ------ 7287 ------ 7336 ------ 7388 ------ 7438 ------ 7480 ------ 7528 ------ 7574 ------ 7620 ------ 7664 ------ 7706 ------ 7755 ------ 7805 ------ 7847 ------ 7896 ------ 7954 ------ 8014 ------ 8064 ------ 8108 ------ 8159 ------ 8207 ------ 8250 ------ 8304 ------ 8361 ------ 8410 ------ 8462 ------ 8513 ------ 8562 ------ 8608 ------ 8644 ------ 8706 ------ 8752 ------ 8799 ------ 8840 ------ 8902 ------ 8954 ------ 8995 ------ 9063 ------ 9106 ------ 9152 ------ 9202 ------ 9256 ------ 9310 ------ 9362 ------ 9409 ------ 9462 ------ 9504 ------ 9551 ------ 9598 ------ 9644 ------ 9689 ------ 9741 ------ 9800 ------ 9855 ------ 9896 ------ 9945 ------ 10000
+ │ │ │ │ │ │ │ │ │ histogram(42)= 0 80 7.9984e+05 80
+ │ │ │ │ │ │ │ │ │ <--- 1.14 ------------ 999.93
│ │ │ │ │ │ │ │ ├── key: (39,40)
│ │ │ │ │ │ │ │ ├── fd: (39,40)-->(42)
│ │ │ │ │ │ │ │ └── ordering: +39
│ │ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ │ ├── save-table-name: q9_select_12
│ │ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=66666.67, distinct(1)=66618.7, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=66666.67, distinct(1)=66618.7, null(1)=0, avgsize(1)=4, distinct(2)=66666.7, null(2)=0, avgsize(2)=35]
│ │ │ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ │ │ ├── fd: (1)-->(2)
│ │ │ │ │ │ │ │ ├── ordering: +1
│ │ │ │ │ │ │ │ ├── scan part
│ │ │ │ │ │ │ │ │ ├── save-table-name: q9_scan_13
│ │ │ │ │ │ │ │ │ ├── columns: p_partkey:1(int!null) p_name:2(varchar!null)
- │ │ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(1)=199241, null(1)=0, avgsize(1)=4, distinct(2)=120, null(2)=0, avgsize(2)=4]
- │ │ │ │ │ │ │ │ │ │ histogram(1)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ │ │ │ │ │ histogram(2)= 0 1520 1.9714e+05 1340
- │ │ │ │ │ │ │ │ │ │ <--- 'almond antique aquamarine azure beige' ------------ 'beige azure aquamarine antique almond'
+ │ │ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(1)=199241, null(1)=0, avgsize(1)=4, distinct(2)=198131, null(2)=0, avgsize(2)=35]
+ │ │ │ │ │ │ │ │ │ │ histogram(1)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ │ │ │ │ │ histogram(2)= 0 20 1.9996e+05 20
+ │ │ │ │ │ │ │ │ │ │ <--- 'almond aquamarine blue puff tan' ------------ 'yellow wheat goldenrod orange blush'
│ │ │ │ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ │ │ │ ├── fd: (1)-->(2)
│ │ │ │ │ │ │ │ │ └── ordering: +1
@@ -168,7 +168,7 @@ sort
│ │ ├── scan nation
│ │ │ ├── save-table-name: q9_scan_14
│ │ │ ├── columns: n_nationkey:57(int!null) n_name:58(char!null)
- │ │ │ ├── stats: [rows=25, distinct(57)=25, null(57)=0, avgsize(57)=4, distinct(58)=25, null(58)=0, avgsize(58)=4]
+ │ │ │ ├── stats: [rows=25, distinct(57)=25, null(57)=0, avgsize(57)=1, distinct(58)=25, null(58)=0, avgsize(58)=10]
│ │ │ │ histogram(57)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ histogram(58)= 0 1 23 1
@@ -191,9 +191,9 @@ column_names row_count distinct_count null_count
{sum_profit} 175 175 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{nation} 1549.00 8.85 <== 25.00 1.00 0.00 1.00
-{o_year} 1549.00 8.85 <== 957.00 136.71 <== 0.00 1.00
-{sum_profit} 1549.00 8.85 <== 1549.00 8.85 <== 0.00 1.00
+{nation} 1548.00 8.85 <== 25.00 1.00 0.00 1.00
+{o_year} 1548.00 8.85 <== 957.00 136.71 <== 0.00 1.00
+{sum_profit} 1548.00 8.85 <== 1548.00 8.85 <== 0.00 1.00
----Stats for q9_group_by_2----
column_names row_count distinct_count null_count
@@ -202,9 +202,9 @@ column_names row_count distinct_count null_count
{sum} 175 175 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{n_name} 1549.00 8.85 <== 25.00 1.00 0.00 1.00
-{o_year} 1549.00 8.85 <== 957.00 136.71 <== 0.00 1.00
-{sum} 1549.00 8.85 <== 1549.00 8.85 <== 0.00 1.00
+{n_name} 1548.00 8.85 <== 25.00 1.00 0.00 1.00
+{o_year} 1548.00 8.85 <== 957.00 136.71 <== 0.00 1.00
+{sum} 1548.00 8.85 <== 1548.00 8.85 <== 0.00 1.00
----Stats for q9_project_3----
column_names row_count distinct_count null_count
@@ -213,9 +213,9 @@ column_names row_count distinct_count null_count
{o_year} 319404 7 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{amount} 2451.00 130.32 <== 958.00 329.05 <== 0.00 1.00
-{n_name} 2451.00 130.32 <== 25.00 1.00 0.00 1.00
-{o_year} 2451.00 130.32 <== 957.00 136.71 <== 0.00 1.00
+{amount} 2450.00 130.37 <== 958.00 329.05 <== 0.00 1.00
+{n_name} 2450.00 130.37 <== 25.00 1.00 0.00 1.00
+{o_year} 2450.00 130.37 <== 957.00 136.71 <== 0.00 1.00
----Stats for q9_inner_join_4----
column_names row_count distinct_count null_count
@@ -238,23 +238,23 @@ column_names row_count distinct_count null_count
{s_suppkey} 319404 9799 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 2451.00 130.32 <== 11.00 1.00 0.00 1.00
-{l_extendedprice} 2451.00 130.32 <== 958.00 221.90 <== 0.00 1.00
-{l_orderkey} 2451.00 130.32 <== 1067.00 270.45 <== 0.00 1.00
-{l_partkey} 2451.00 130.32 <== 1065.00 9.98 <== 0.00 1.00
-{l_quantity} 2451.00 130.32 <== 50.00 1.00 0.00 1.00
-{l_suppkey} 2451.00 130.32 <== 1065.00 9.20 <== 0.00 1.00
-{n_name} 2451.00 130.32 <== 25.00 1.00 0.00 1.00
-{n_nationkey} 2451.00 130.32 <== 25.00 1.00 0.00 1.00
-{o_orderdate} 2451.00 130.32 <== 957.00 2.51 <== 0.00 1.00
-{o_orderkey} 2451.00 130.32 <== 1067.00 270.45 <== 0.00 1.00
-{p_name} 2451.00 130.32 <== 120.00 89.00 <== 0.00 1.00
-{p_partkey} 2451.00 130.32 <== 1065.00 9.98 <== 0.00 1.00
-{ps_partkey} 2451.00 130.32 <== 958.00 11.10 <== 0.00 1.00
-{ps_suppkey} 2451.00 130.32 <== 958.00 10.23 <== 0.00 1.00
-{ps_supplycost} 2451.00 130.32 <== 735.00 47.40 <== 0.00 1.00
-{s_nationkey} 2451.00 130.32 <== 25.00 1.00 0.00 1.00
-{s_suppkey} 2451.00 130.32 <== 1065.00 9.20 <== 0.00 1.00
+{l_discount} 2450.00 130.37 <== 11.00 1.00 0.00 1.00
+{l_extendedprice} 2450.00 130.37 <== 958.00 221.90 <== 0.00 1.00
+{l_orderkey} 2450.00 130.37 <== 1066.00 270.71 <== 0.00 1.00
+{l_partkey} 2450.00 130.37 <== 1065.00 9.98 <== 0.00 1.00
+{l_quantity} 2450.00 130.37 <== 50.00 1.00 0.00 1.00
+{l_suppkey} 2450.00 130.37 <== 1065.00 9.20 <== 0.00 1.00
+{n_name} 2450.00 130.37 <== 25.00 1.00 0.00 1.00
+{n_nationkey} 2450.00 130.37 <== 25.00 1.00 0.00 1.00
+{o_orderdate} 2450.00 130.37 <== 957.00 2.51 <== 0.00 1.00
+{o_orderkey} 2450.00 130.37 <== 1066.00 270.71 <== 0.00 1.00
+{p_name} 2450.00 130.37 <== 2406.00 4.44 <== 0.00 1.00
+{p_partkey} 2450.00 130.37 <== 1065.00 9.98 <== 0.00 1.00
+{ps_partkey} 2450.00 130.37 <== 958.00 11.10 <== 0.00 1.00
+{ps_suppkey} 2450.00 130.37 <== 958.00 10.23 <== 0.00 1.00
+{ps_supplycost} 2450.00 130.37 <== 957.00 36.40 <== 0.00 1.00
+{s_nationkey} 2450.00 130.37 <== 25.00 1.00 0.00 1.00
+{s_suppkey} 2450.00 130.37 <== 1065.00 9.20 <== 0.00 1.00
----Stats for q9_inner_join_5----
column_names row_count distinct_count null_count
@@ -275,21 +275,21 @@ column_names row_count distinct_count null_count
{s_suppkey} 319404 9799 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 2451.00 130.32 <== 11.00 1.00 0.00 1.00
-{l_extendedprice} 2451.00 130.32 <== 1059.00 200.74 <== 0.00 1.00
-{l_orderkey} 2451.00 130.32 <== 1228.00 234.99 <== 0.00 1.00
-{l_partkey} 2451.00 130.32 <== 1224.00 8.69 <== 0.00 1.00
-{l_quantity} 2451.00 130.32 <== 50.00 1.00 0.00 1.00
-{l_suppkey} 2451.00 130.32 <== 1224.00 8.01 <== 0.00 1.00
-{o_orderdate} 2451.00 130.32 <== 1057.00 2.28 <== 0.00 1.00
-{o_orderkey} 2451.00 130.32 <== 1228.00 234.99 <== 0.00 1.00
-{p_name} 2451.00 130.32 <== 120.00 89.00 <== 0.00 1.00
-{p_partkey} 2451.00 130.32 <== 1224.00 8.69 <== 0.00 1.00
-{ps_partkey} 2451.00 130.32 <== 1059.00 10.04 <== 0.00 1.00
-{ps_suppkey} 2451.00 130.32 <== 1059.00 9.25 <== 0.00 1.00
-{ps_supplycost} 2451.00 130.32 <== 764.00 45.60 <== 0.00 1.00
-{s_nationkey} 2451.00 130.32 <== 25.00 1.00 0.00 1.00
-{s_suppkey} 2451.00 130.32 <== 1224.00 8.01 <== 0.00 1.00
+{l_discount} 2450.00 130.37 <== 11.00 1.00 0.00 1.00
+{l_extendedprice} 2450.00 130.37 <== 1058.00 200.93 <== 0.00 1.00
+{l_orderkey} 2450.00 130.37 <== 1227.00 235.19 <== 0.00 1.00
+{l_partkey} 2450.00 130.37 <== 1224.00 8.69 <== 0.00 1.00
+{l_quantity} 2450.00 130.37 <== 50.00 1.00 0.00 1.00
+{l_suppkey} 2450.00 130.37 <== 1224.00 8.01 <== 0.00 1.00
+{o_orderdate} 2450.00 130.37 <== 1057.00 2.28 <== 0.00 1.00
+{o_orderkey} 2450.00 130.37 <== 1227.00 235.19 <== 0.00 1.00
+{p_name} 2450.00 130.37 <== 2406.00 4.44 <== 0.00 1.00
+{p_partkey} 2450.00 130.37 <== 1224.00 8.69 <== 0.00 1.00
+{ps_partkey} 2450.00 130.37 <== 1059.00 10.04 <== 0.00 1.00
+{ps_suppkey} 2450.00 130.37 <== 1059.00 9.25 <== 0.00 1.00
+{ps_supplycost} 2450.00 130.37 <== 1056.00 32.99 <== 0.00 1.00
+{s_nationkey} 2450.00 130.37 <== 25.00 1.00 0.00 1.00
+{s_suppkey} 2450.00 130.37 <== 1224.00 8.01 <== 0.00 1.00
----Stats for q9_scan_6----
column_names row_count distinct_count null_count
@@ -320,16 +320,16 @@ column_names row_count_est row_count_err distinct_count_est distinct_co
{l_discount} 2431.00 131.39 <== 11.00 1.00 0.00 1.00
{l_extendedprice} 2431.00 131.39 <== 1220.00 174.25 <== 0.00 1.00
{l_orderkey} 2431.00 131.39 <== 1536.00 187.87 <== 0.00 1.00
-{l_partkey} 2431.00 131.39 <== 1536.00 6.92 <== 0.00 1.00
+{l_partkey} 2431.00 131.39 <== 1535.00 6.93 <== 0.00 1.00
{l_quantity} 2431.00 131.39 <== 50.00 1.00 0.00 1.00
{l_suppkey} 2431.00 131.39 <== 1220.00 8.03 <== 0.00 1.00
{o_orderdate} 2431.00 131.39 <== 1217.00 1.98 <== 0.00 1.00
{o_orderkey} 2431.00 131.39 <== 1536.00 187.87 <== 0.00 1.00
-{p_name} 2431.00 131.39 <== 120.00 89.00 <== 0.00 1.00
-{p_partkey} 2431.00 131.39 <== 1536.00 6.92 <== 0.00 1.00
+{p_name} 2431.00 131.39 <== 2387.00 4.47 <== 0.00 1.00
+{p_partkey} 2431.00 131.39 <== 1535.00 6.93 <== 0.00 1.00
{ps_partkey} 2431.00 131.39 <== 1220.00 8.71 <== 0.00 1.00
{ps_suppkey} 2431.00 131.39 <== 1220.00 8.03 <== 0.00 1.00
-{ps_supplycost} 2431.00 131.39 <== 800.00 43.55 <== 0.00 1.00
+{ps_supplycost} 2431.00 131.39 <== 1217.00 28.63 <== 0.00 1.00
----Stats for q9_lookup_join_8----
column_names row_count distinct_count null_count
@@ -347,16 +347,16 @@ column_names row_count distinct_count null_count
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{l_discount} 2431.00 131.39 <== 11.00 1.00 0.00 1.00
-{l_extendedprice} 2431.00 131.39 <== 1536.00 138.40 <== 0.00 1.00
+{l_extendedprice} 2431.00 131.39 <== 1535.00 138.49 <== 0.00 1.00
{l_orderkey} 2431.00 131.39 <== 1536.00 187.87 <== 0.00 1.00
{l_partkey} 2431.00 131.39 <== 2429.00 4.38 <== 0.00 1.00
{l_quantity} 2431.00 131.39 <== 50.00 1.00 0.00 1.00
{l_suppkey} 2431.00 131.39 <== 1536.00 6.38 <== 0.00 1.00
-{p_name} 2431.00 131.39 <== 120.00 89.00 <== 0.00 1.00
+{p_name} 2431.00 131.39 <== 2387.00 4.47 <== 0.00 1.00
{p_partkey} 2431.00 131.39 <== 2429.00 4.38 <== 0.00 1.00
{ps_partkey} 2431.00 131.39 <== 1536.00 6.92 <== 0.00 1.00
{ps_suppkey} 2431.00 131.39 <== 1536.00 6.38 <== 0.00 1.00
-{ps_supplycost} 2431.00 131.39 <== 849.00 41.04 <== 0.00 1.00
+{ps_supplycost} 2431.00 131.39 <== 1528.00 22.80 <== 0.00 1.00
----Stats for q9_lookup_join_9----
column_names row_count distinct_count null_count
@@ -375,11 +375,11 @@ column_names row_count_est row_count_err distinct_count_est distinct_coun
{l_orderkey} 813.00 392.87 <== 813.00 354.95 <== 0.00 1.00
{l_partkey} 813.00 392.87 <== 813.00 13.08 <== 0.00 1.00
{l_suppkey} 813.00 392.87 <== 813.00 12.05 <== 0.00 1.00
-{p_name} 813.00 392.87 <== 120.00 89.00 <== 0.00 1.00
+{p_name} 813.00 392.87 <== 808.00 13.22 <== 0.00 1.00
{p_partkey} 813.00 392.87 <== 808.00 13.16 <== 0.00 1.00
{ps_partkey} 813.00 392.87 <== 813.00 13.08 <== 0.00 1.00
{ps_suppkey} 813.00 392.87 <== 813.00 12.05 <== 0.00 1.00
-{ps_supplycost} 813.00 392.87 <== 556.00 62.66 <== 0.00 1.00
+{ps_supplycost} 813.00 392.87 <== 809.00 43.06 <== 0.00 1.00
----Stats for q9_merge_join_10----
column_names row_count distinct_count null_count
@@ -390,11 +390,11 @@ column_names row_count distinct_count null_count
{ps_supplycost} 42656 34850 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_name} 267683.00 6.28 <== 120.00 89.00 <== 0.00 1.00
+{p_name} 267683.00 6.28 <== 65464.00 6.13 <== 0.00 1.00
{p_partkey} 267683.00 6.28 <== 66619.00 6.27 <== 0.00 1.00
{ps_partkey} 267683.00 6.28 <== 66619.00 6.27 <== 0.00 1.00
{ps_suppkey} 267683.00 6.28 <== 9920.00 1.01 0.00 1.00
-{ps_supplycost} 267683.00 6.28 <== 1000.00 34.85 <== 0.00 1.00
+{ps_supplycost} 267683.00 6.28 <== 93405.00 2.68 <== 0.00 1.00
----Stats for q9_scan_11----
column_names row_count distinct_count null_count
@@ -405,7 +405,7 @@ column_names row_count distinct_count null_count
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{ps_partkey} 800000.00 1.00 199241.00 1.00 0.00 1.00
{ps_suppkey} 800000.00 1.00 9920.00 1.00 0.00 1.00
-{ps_supplycost} 800000.00 1.00 1000.00 100.38 <== 0.00 1.00
+{ps_supplycost} 800000.00 1.00 100379.00 1.00 0.00 1.00
----Stats for q9_select_12----
column_names row_count distinct_count null_count
@@ -413,7 +413,7 @@ column_names row_count distinct_count null_count
{p_partkey} 10664 10632 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_name} 66667.00 6.25 <== 120.00 88.87 <== 0.00 1.00
+{p_name} 66667.00 6.25 <== 66667.00 6.25 <== 0.00 1.00
{p_partkey} 66667.00 6.25 <== 66619.00 6.27 <== 0.00 1.00
----Stats for q9_scan_13----
@@ -422,7 +422,7 @@ column_names row_count distinct_count null_count
{p_partkey} 200000 199241 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_name} 200000.00 1.00 120.00 1651.09 <== 0.00 1.00
+{p_name} 200000.00 1.00 198131.00 1.00 0.00 1.00
{p_partkey} 200000.00 1.00 199241.00 1.00 0.00 1.00
----Stats for q9_scan_14----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q10 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q10
index a10b5d039e84..4deabbdad3b5 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q10
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q10
@@ -69,70 +69,70 @@ top-k
├── columns: c_custkey:1(int!null) c_name:2(varchar!null) c_address:3(varchar!null) c_phone:5(char!null) c_acctbal:6(float!null) c_comment:8(varchar!null) n_name:41(char!null) sum:47(float!null)
├── grouping columns: c_custkey:1(int!null)
├── immutable
- ├── stats: [rows=32486.14, distinct(1)=32486.1, null(1)=0, avgsize(1)=4, distinct(2)=32486.1, null(2)=0, avgsize(2)=4, distinct(3)=32486.1, null(3)=0, avgsize(3)=4, distinct(5)=32486.1, null(5)=0, avgsize(5)=4, distinct(6)=32486.1, null(6)=0, avgsize(6)=4, distinct(8)=32486.1, null(8)=0, avgsize(8)=4, distinct(41)=32486.1, null(41)=0, avgsize(41)=4, distinct(47)=32486.1, null(47)=0, avgsize(47)=4]
+ ├── stats: [rows=32163.1, distinct(1)=32163.1, null(1)=0, avgsize(1)=4, distinct(2)=32163.1, null(2)=0, avgsize(2)=4, distinct(3)=32163.1, null(3)=0, avgsize(3)=4, distinct(5)=32163.1, null(5)=0, avgsize(5)=4, distinct(6)=32163.1, null(6)=0, avgsize(6)=4, distinct(8)=32163.1, null(8)=0, avgsize(8)=4, distinct(41)=32163.1, null(41)=0, avgsize(41)=4, distinct(47)=32163.1, null(47)=0, avgsize(47)=4]
├── key: (1)
├── fd: (1)-->(2,3,5,6,8,41,47)
├── project
│ ├── save-table-name: q10_project_3
│ ├── columns: column46:46(float!null) c_custkey:1(int!null) c_name:2(varchar!null) c_address:3(varchar!null) c_phone:5(char!null) c_acctbal:6(float!null) c_comment:8(varchar!null) n_name:41(char!null)
│ ├── immutable
- │ ├── stats: [rows=79982.64, distinct(1)=32486.1, null(1)=0, avgsize(1)=4, distinct(2)=45377.8, null(2)=0, avgsize(2)=4, distinct(3)=45377.8, null(3)=0, avgsize(3)=4, distinct(5)=45377.8, null(5)=0, avgsize(5)=4, distinct(6)=44989, null(6)=0, avgsize(6)=4, distinct(8)=45377.8, null(8)=0, avgsize(8)=4, distinct(41)=25, null(41)=0, avgsize(41)=4, distinct(46)=40133.3, null(46)=0, avgsize(46)=8]
+ │ ├── stats: [rows=79341.61, distinct(1)=32163.1, null(1)=0, avgsize(1)=4, distinct(2)=45059.5, null(2)=0, avgsize(2)=20, distinct(3)=45057.1, null(3)=0, avgsize(3)=28, distinct(5)=45059.5, null(5)=0, avgsize(5)=17, distinct(6)=44685.4, null(6)=0, avgsize(6)=9, distinct(8)=45034, null(8)=0, avgsize(8)=75, distinct(41)=25, null(41)=0, avgsize(41)=10, distinct(46)=39820, null(46)=0, avgsize(46)=18]
│ ├── fd: (1)-->(2,3,5,6,8,41)
│ ├── inner-join (hash)
│ │ ├── save-table-name: q10_inner_join_4
│ │ ├── columns: c_custkey:1(int!null) c_name:2(varchar!null) c_address:3(varchar!null) c_nationkey:4(int!null) c_phone:5(char!null) c_acctbal:6(float!null) c_comment:8(varchar!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_extendedprice:27(float!null) l_discount:28(float!null) l_returnflag:30(char!null) n_nationkey:40(int!null) n_name:41(char!null)
│ │ ├── multiplicity: left-rows(exactly-one), right-rows(zero-or-more)
- │ │ ├── stats: [rows=79982.64, distinct(1)=32486.1, null(1)=0, avgsize(1)=4, distinct(2)=45377.8, null(2)=0, avgsize(2)=4, distinct(3)=45377.8, null(3)=0, avgsize(3)=4, distinct(4)=25, null(4)=0, avgsize(4)=4, distinct(5)=45377.8, null(5)=0, avgsize(5)=4, distinct(6)=44989, null(6)=0, avgsize(6)=4, distinct(8)=45377.8, null(8)=0, avgsize(8)=4, distinct(11)=36212, null(11)=0, avgsize(11)=4, distinct(12)=32486.1, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4, distinct(22)=36212, null(22)=0, avgsize(22)=4, distinct(27)=39899.5, null(27)=0, avgsize(27)=4, distinct(28)=11, null(28)=0, avgsize(28)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(40)=25, null(40)=0, avgsize(40)=4, distinct(41)=25, null(41)=0, avgsize(41)=4, distinct(27,28)=40133.3, null(27,28)=0, avgsize(27,28)=8]
+ │ │ ├── stats: [rows=79341.61, distinct(1)=32163.1, null(1)=0, avgsize(1)=4, distinct(2)=45059.5, null(2)=0, avgsize(2)=20, distinct(3)=45057.1, null(3)=0, avgsize(3)=28, distinct(4)=25, null(4)=0, avgsize(4)=2, distinct(5)=45059.5, null(5)=0, avgsize(5)=17, distinct(6)=44685.4, null(6)=0, avgsize(6)=9, distinct(8)=45034, null(8)=0, avgsize(8)=75, distinct(11)=35816.5, null(11)=0, avgsize(11)=4, distinct(12)=32163.1, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4, distinct(22)=35816.5, null(22)=0, avgsize(22)=4, distinct(27)=39572.9, null(27)=0, avgsize(27)=9, distinct(28)=11, null(28)=0, avgsize(28)=9, distinct(30)=1, null(30)=0, avgsize(30)=3, distinct(40)=25, null(40)=0, avgsize(40)=1, distinct(41)=25, null(41)=0, avgsize(41)=10, distinct(27,28)=39820, null(27,28)=0, avgsize(27,28)=18]
│ │ ├── fd: ()-->(30), (1)-->(2-6,8), (11)-->(12,15), (11)==(22), (22)==(11), (1)==(12), (12)==(1), (40)-->(41), (4)==(40), (40)==(4)
│ │ ├── inner-join (hash)
│ │ │ ├── save-table-name: q10_inner_join_5
│ │ │ ├── columns: c_custkey:1(int!null) c_name:2(varchar!null) c_address:3(varchar!null) c_nationkey:4(int!null) c_phone:5(char!null) c_acctbal:6(float!null) c_comment:8(varchar!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_extendedprice:27(float!null) l_discount:28(float!null) l_returnflag:30(char!null)
│ │ │ ├── multiplicity: left-rows(zero-or-more), right-rows(exactly-one)
- │ │ │ ├── stats: [rows=79982.64, distinct(1)=36326.3, null(1)=0, avgsize(1)=4, distinct(2)=61993, null(2)=0, avgsize(2)=4, distinct(3)=61993, null(3)=0, avgsize(3)=4, distinct(4)=25, null(4)=0, avgsize(4)=4, distinct(5)=61993, null(5)=0, avgsize(5)=4, distinct(6)=60977.6, null(6)=0, avgsize(6)=4, distinct(8)=61993, null(8)=0, avgsize(8)=4, distinct(11)=42393.4, null(11)=0, avgsize(11)=4, distinct(12)=36326.3, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4, distinct(22)=42393.4, null(22)=0, avgsize(22)=4, distinct(27)=49327.8, null(27)=0, avgsize(27)=4, distinct(28)=11, null(28)=0, avgsize(28)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(27,28)=49804.9, null(27,28)=0, avgsize(27,28)=8]
+ │ │ │ ├── stats: [rows=79341.61, distinct(1)=35939.8, null(1)=0, avgsize(1)=4, distinct(2)=61616.1, null(2)=0, avgsize(2)=20, distinct(3)=61609.9, null(3)=0, avgsize(3)=28, distinct(4)=25, null(4)=0, avgsize(4)=2, distinct(5)=61616.1, null(5)=0, avgsize(5)=17, distinct(6)=60636.4, null(6)=0, avgsize(6)=9, distinct(8)=61548.8, null(8)=0, avgsize(8)=75, distinct(11)=41870.4, null(11)=0, avgsize(11)=4, distinct(12)=35939.8, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4, distinct(22)=41870.4, null(22)=0, avgsize(22)=4, distinct(27)=48918.7, null(27)=0, avgsize(27)=9, distinct(28)=11, null(28)=0, avgsize(28)=9, distinct(30)=1, null(30)=0, avgsize(30)=3, distinct(27,28)=49422.8, null(27,28)=0, avgsize(27,28)=18]
│ │ │ ├── fd: ()-->(30), (1)-->(2-6,8), (11)-->(12,15), (11)==(22), (22)==(11), (1)==(12), (12)==(1)
│ │ │ ├── scan customer
│ │ │ │ ├── save-table-name: q10_scan_6
│ │ │ │ ├── columns: c_custkey:1(int!null) c_name:2(varchar!null) c_address:3(varchar!null) c_nationkey:4(int!null) c_phone:5(char!null) c_acctbal:6(float!null) c_comment:8(varchar!null)
- │ │ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(2)=150000, null(2)=0, avgsize(2)=4, distinct(3)=150000, null(3)=0, avgsize(3)=4, distinct(4)=25, null(4)=0, avgsize(4)=4, distinct(5)=150000, null(5)=0, avgsize(5)=4, distinct(6)=140426, null(6)=0, avgsize(6)=4, distinct(8)=150000, null(8)=0, avgsize(8)=4]
- │ │ │ │ │ histogram(1)= 0 5 769 5 765 5 732 5 744 5 731 5 754 5 772 5 757 5 713 5 741 5 808 5 744 5 739 5 687 5 820 5 761 5 782 5 632 5 711 5 692 5 648 5 770 5 765 5 702 5 751 5 807 5 794 5 735 5 807 5 719 5 773 5 781 5 684 5 748 5 682 5 703 5 794 5 718 5 807 5 674 5 747 5 677 5 813 5 666 5 766 5 822 5 703 5 676 5 765 5 693 5 723 5 780 5 793 5 770 5 696 5 775 5 764 5 884 5 696 5 688 5 637 5 789 5 702 5 732 5 697 5 769 5 739 5 744 5 861 5 791 5 726 5 793 5 730 5 763 5 789 5 797 5 775 5 862 5 780 5 746 5 783 5 743 5 822 5 806 5 775 5 727 5 724 5 799 5 707 5 757 5 614 5 747 5 704 5 740 5 749 5 735 5 741 5 807 5 827 5 816 5 702 5 699 5 803 5 793 5 672 5 831 5 694 5 746 5 731 5 686 5 685 5 695 5 828 5 756 5 722 5 749 5 790 5 758 5 750 5 782 5 733 5 778 5 762 5 758 5 731 5 778 5 663 5 696 5 684 5 796 5 770 5 656 5 690 5 747 5 782 5 785 5 751 5 697 5 663 5 766 5 695 5 866 5 813 5 765 5 901 5 747 5 683 5 706 5 689 5 734 5 715 5 752 5 855 5 771 5 717 5 794 5 760 5 827 5 747 5 757 5 767 5 726 5 690 5 787 5 783 5 744 5 761 5 746 5 793 5 696 5 749 5 745 5 755 5 800 5 778 5 814 5 826 5 700 5 740 5 773 5 713 5 824 5 792 5 702 5 734 5 751 5 716 5 718 5 722 5 784 5 778 5 700 5 714 5 739 5 748 5 697 5 751 5 663 5 740 5
- │ │ │ │ │ <--- 37 ----- 834 ----- 1623 ----- 2351 ----- 3101 ----- 3828 ----- 4598 ----- 5401 ----- 6176 ----- 6868 ----- 7613 ----- 8479 ----- 9230 ----- 9972 ----- 10613 ----- 11500 ----- 12282 ----- 13103 ----- 13624 ----- 14312 ----- 14962 ----- 15520 ----- 16319 ----- 17109 ----- 17780 ----- 18543 ----- 19408 ----- 20250 ----- 20984 ----- 21848 ----- 22551 ----- 23355 ----- 24174 ----- 24809 ----- 25567 ----- 26196 ----- 26868 ----- 27710 ----- 28412 ----- 29276 ----- 29889 ----- 30645 ----- 31264 ----- 32139 ----- 32736 ----- 33527 ----- 34418 ----- 35091 ----- 35709 ----- 36498 ----- 37150 ----- 37861 ----- 38677 ----- 39517 ----- 40316 ----- 40975 ----- 41782 ----- 42569 ----- 43565 ----- 44224 ----- 44867 ----- 45399 ----- 46231 ----- 46902 ----- 47630 ----- 48291 ----- 49087 ----- 49829 ----- 50580 ----- 51538 ----- 52375 ----- 53092 ----- 53932 ----- 54656 ----- 55442 ----- 56274 ----- 57121 ----- 57929 ----- 58888 ----- 59705 ----- 60460 ----- 61282 ----- 62031 ----- 62922 ----- 63785 ----- 64593 ----- 65311 ----- 66024 ----- 66875 ----- 67556 ----- 68331 ----- 68808 ----- 69564 ----- 70239 ----- 70983 ----- 71744 ----- 72478 ----- 73223 ----- 74088 ----- 74988 ----- 75868 ----- 76539 ----- 77203 ----- 78061 ----- 78901 ----- 79510 ----- 80417 ----- 81071 ----- 81826 ----- 82553 ----- 83191 ----- 83828 ----- 84485 ----- 85386 ----- 86159 ----- 86868 ----- 87628 ----- 88463 ----- 89240 ----- 90002 ----- 90822 ----- 91553 ----- 92367 ----- 93152 ----- 93929 ----- 94656 ----- 95470 ----- 96061 ----- 96720 ----- 97355 ----- 98200 ----- 98998 ----- 99573 ----- 100219 ----- 100975 ----- 101795 ----- 102620 ----- 103384 ----- 104044 ----- 104635 ----- 105426 ----- 106083 ----- 107049 ----- 107925 ----- 108715 ----- 109740 ----- 110496 ----- 111128 ----- 111807 ----- 112451 ----- 113184 ----- 113866 ----- 114619 ----- 115556 ----- 116344 ----- 117029 ----- 117859 ----- 118626 ----- 119515 ----- 120258 ----- 121021 ----- 121802 ----- 122505 ----- 123136 ----- 123953 ----- 124763 ----- 125501 ----- 126271 ----- 127012 ----- 127841 ----- 128483 ----- 129230 ----- 129970 ----- 130729 ----- 131569 ----- 132370 ----- 133235 ----- 134122 ----- 134773 ----- 135503 ----- 136294 ----- 136971 ----- 137854 ----- 138681 ----- 139336 ----- 140055 ----- 140806 ----- 141489 ----- 142177 ----- 142873 ----- 143685 ----- 144486 ----- 145138 ----- 145817 ----- 146545 ----- 147291 ----- 147936 ----- 148687 ----- 149260 ----- 149990
+ │ │ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(2)=150000, null(2)=0, avgsize(2)=20, distinct(3)=149937, null(3)=0, avgsize(3)=28, distinct(4)=25, null(4)=0, avgsize(4)=2, distinct(5)=150000, null(5)=0, avgsize(5)=17, distinct(6)=140628, null(6)=0, avgsize(6)=9, distinct(8)=149323, null(8)=0, avgsize(8)=75]
+ │ │ │ │ │ histogram(1)= 0 0 0 5 745 5 746 5 711 5 780 5 738 5 835 5 697 5 757 5 704 5 696 5 753 5 678 5 813 5 873 5 736 5 840 5 703 5 745 5 710 5 763 5 742 5 673 5 702 5 793 5 732 5 752 5 707 5 751 5 722 5 814 5 789 5 671 5 643 5 706 5 723 5 757 5 713 5 760 5 766 5 711 5 858 5 702 5 695 5 697 5 823 5 857 5 712 5 808 5 754 5 739 5 694 5 782 5 792 5 751 5 758 5 749 5 798 5 685 5 692 5 792 5 710 5 771 5 724 5 853 5 713 5 823 5 772 5 656 5 763 5 672 5 735 5 810 5 786 5 709 5 731 5 702 5 708 5 669 5 733 5 744 5 758 5 800 5 682 5 716 5 716 5 729 5 778 5 721 5 766 5 820 5 757 5 739 5 799 5 780 5 710 5 749 5 754 5 750 5 699 5 821 5 759 5 818 5 763 5 854 5 779 5 810 5 783 5 686 5 703 5 776 5 675 5 812 5 745 5 759 5 793 5 751 5 761 5 798 5 794 5 729 5 696 5 699 5 831 5 709 5 747 5 722 5 768 5 729 5 702 5 729 5 698 5 767 5 792 5 726 5 737 5 671 5 721 5 842 5 701 5 704 5 708 5 726 5 695 5 665 5 688 5 653 5 690 5 734 5 789 5 659 5 785 5 733 5 740 5 826 5 745 5 929 5 899 5 743 5 790 5 825 5 779 5 677 5 697 5 756 5 693 5 862 5 772 5 783 5 757 5 799 5 778 5 752 5 715 5 709 5 790 5 789 5 865 5 808 5 772 5 743 5 751 5 742 5 676 5 684 5 744 5 709 5 679 5 817 5 755 5 754 5 797 5 709 5 748 5 679 5 751 5 775 5 736 5 790 5 714 5 0 0
+ │ │ │ │ │ <--- -9223372036854775808 --- 59 ----- 811 ----- 1565 ----- 2252 ----- 3068 ----- 3807 ----- 4720 ----- 5381 ----- 6155 ----- 6829 ----- 7487 ----- 8254 ----- 8876 ----- 9751 ----- 10728 ----- 11463 ----- 12385 ----- 13057 ----- 13810 ----- 14495 ----- 15281 ----- 16028 ----- 16640 ----- 17311 ----- 18151 ----- 18880 ----- 19645 ----- 20325 ----- 21088 ----- 21798 ----- 22674 ----- 23507 ----- 24115 ----- 24661 ----- 25340 ----- 26052 ----- 26827 ----- 27518 ----- 28298 ----- 29089 ----- 29777 ----- 30730 ----- 31401 ----- 32057 ----- 32718 ----- 33611 ----- 34562 ----- 35251 ----- 36117 ----- 36887 ----- 37629 ----- 38283 ----- 39104 ----- 39942 ----- 40705 ----- 41481 ----- 42241 ----- 43089 ----- 43725 ----- 44376 ----- 45214 ----- 45899 ----- 46700 ----- 47413 ----- 48356 ----- 49047 ----- 49939 ----- 50742 ----- 51316 ----- 52101 ----- 52710 ----- 53444 ----- 54313 ----- 55140 ----- 55823 ----- 56549 ----- 57219 ----- 57901 ----- 58503 ----- 59234 ----- 59984 ----- 60760 ----- 61613 ----- 62243 ----- 62941 ----- 63638 ----- 64360 ----- 65173 ----- 65880 ----- 66672 ----- 67560 ----- 68334 ----- 69075 ----- 69925 ----- 70742 ----- 71428 ----- 72189 ----- 72958 ----- 73720 ----- 74385 ----- 75274 ----- 76053 ----- 76936 ----- 77721 ----- 78666 ----- 79480 ----- 80349 ----- 81171 ----- 81810 ----- 82482 ----- 83292 ----- 83907 ----- 84780 ----- 85532 ----- 86310 ----- 87149 ----- 87912 ----- 88694 ----- 89543 ----- 90384 ----- 91106 ----- 91764 ----- 92428 ----- 93335 ----- 94018 ----- 94775 ----- 95484 ----- 96279 ----- 97001 ----- 97672 ----- 98394 ----- 99056 ----- 99850 ----- 100688 ----- 101405 ----- 102143 ----- 102751 ----- 103459 ----- 104384 ----- 105052 ----- 105727 ----- 106409 ----- 107125 ----- 107782 ----- 108377 ----- 109020 ----- 109588 ----- 110235 ----- 110967 ----- 111800 ----- 112382 ----- 113196 ----- 113913 ----- 114643 ----- 115529 ----- 116268 ----- 117329 ----- 118341 ----- 119076 ----- 119898 ----- 120782 ----- 121584 ----- 122186 ----- 122830 ----- 123591 ----- 124227 ----- 125175 ----- 125964 ----- 126773 ----- 127535 ----- 128374 ----- 129175 ----- 129928 ----- 130609 ----- 131279 ----- 132102 ----- 132923 ----- 133877 ----- 134732 ----- 135521 ----- 136257 ----- 137007 ----- 137740 ----- 138341 ----- 138958 ----- 139695 ----- 140364 ----- 140971 ----- 141841 ----- 142600 ----- 143356 ----- 144192 ----- 144861 ----- 145607 ----- 146214 ----- 146965 ----- 147761 ----- 148483 ----- 149306 ----- 149986 --- 9223372036854775807
│ │ │ │ │ histogram(2)= 0 1 1.5e+05 1
- │ │ │ │ │ <--- 'Customer#000000037' --------- 'Customer#000149990'
- │ │ │ │ │ histogram(3)= 0 1 1.5e+05 1
- │ │ │ │ │ <--- ' P2khq0dbP' --------- 'zzUlzMPWHZ'
- │ │ │ │ │ histogram(4)= 0 5865 0 5790 0 5715 0 6645 0 5865 0 5955 0 5790 0 5865 0 5760 0 6060 0 5790 0 6435 0 6150 0 6075 0 5805 0 7050 0 5970 0 5970 0 5865 0 5895 0 5835 0 6180 0 5760 0 5775 0 6135
+ │ │ │ │ │ <--- 'Customer#000000059' --------- 'Customer#000149986'
+ │ │ │ │ │ histogram(3)= 0 15 1.4997e+05 15
+ │ │ │ │ │ <--- ' BAEZWaPhKP6 rBk,WBsgRMjmelv7' ------------ 'zzxGktzXTMKS1BxZlgQ9nqQ'
+ │ │ │ │ │ histogram(4)= 0 5475 0 5910 0 5925 0 6075 0 5910 0 5895 0 6765 0 6090 0 6000 0 6735 0 5730 0 6015 0 5895 0 6180 0 5565 0 5760 0 6390 0 6135 0 5940 0 6105 0 6150 0 5700 0 6225 0 6075 0 5355
│ │ │ │ │ <--- 0 ---- 1 ---- 2 ---- 3 ---- 4 ---- 5 ---- 6 ---- 7 ---- 8 ---- 9 ---- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ histogram(5)= 0 1 1.5e+05 1
- │ │ │ │ │ <--- '10-104-665-3850' --------- '34-996-464-1615'
- │ │ │ │ │ histogram(6)= 0 15 1.4997e+05 15
- │ │ │ │ │ <--- -997.5 ------------ 9999.6904296875
- │ │ │ │ │ histogram(8)= 0 1 1.5e+05 1
- │ │ │ │ │ <--- ' About and hold house dog key. Become news pla' --------- 'zine although of specific. Be ahead dog surface. Movement k'
+ │ │ │ │ │ <--- '10-100-106-1617' --------- '34-999-618-6881'
+ │ │ │ │ │ histogram(6)= 0 15 1.4997e+05 15
+ │ │ │ │ │ <--- -997.51 ------------ 9998.32
+ │ │ │ │ │ histogram(8)= 0 15 1.4997e+05 15
+ │ │ │ │ │ <--- ' Tiresias. carefully even accounts boost carefully quickly ironic requests. bold, ironic pin' ------------ 'zle carefully at the carefully final foxes. slyly ironic theodolites wake careful'
│ │ │ │ ├── key: (1)
│ │ │ │ └── fd: (1)-->(2-6,8)
│ │ │ ├── inner-join (lookup lineitem)
│ │ │ │ ├── save-table-name: q10_lookup_join_7
│ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_extendedprice:27(float!null) l_discount:28(float!null) l_returnflag:30(char!null)
│ │ │ │ ├── key columns: [11] = [22]
- │ │ │ │ ├── stats: [rows=79349.71, distinct(11)=55566.3, null(11)=0, avgsize(11)=4, distinct(12)=36326.3, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4, distinct(22)=55566.3, null(22)=0, avgsize(22)=4, distinct(27)=75505.3, null(27)=0, avgsize(27)=4, distinct(28)=11, null(28)=0, avgsize(28)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(27,28)=77198.6, null(27,28)=0, avgsize(27,28)=8]
+ │ │ │ │ ├── stats: [rows=78713.75, distinct(11)=54688.5, null(11)=0, avgsize(11)=4, distinct(12)=35939.8, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4, distinct(22)=54688.5, null(22)=0, avgsize(22)=4, distinct(27)=74852.1, null(27)=0, avgsize(27)=9, distinct(28)=11, null(28)=0, avgsize(28)=9, distinct(30)=1, null(30)=0, avgsize(30)=3, distinct(27,28)=76641.4, null(27,28)=0, avgsize(27,28)=18]
│ │ │ │ ├── fd: ()-->(30), (11)-->(12,15), (11)==(22), (22)==(11)
│ │ │ │ ├── index-join orders
│ │ │ │ │ ├── save-table-name: q10_index_join_8
│ │ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_orderdate:15(date!null)
- │ │ │ │ │ ├── stats: [rows=55566.35, distinct(11)=55566.3, null(11)=0, avgsize(11)=4, distinct(12)=43216.8, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4]
- │ │ │ │ │ │ histogram(15)= 0 0 5062.5 600 7200 150 6900 1350 6300 1050 7200 600 7050 600 7200 1050 2711.5 542.31
- │ │ │ │ │ │ <--- '1993-09-30' -------- '1993-10-10' ------ '1993-10-24' ------ '1993-11-04' ------ '1993-11-15' ------ '1993-11-27' ------ '1993-12-10' ------ '1993-12-25' -------- '1993-12-31'
+ │ │ │ │ │ ├── stats: [rows=54688.46, distinct(11)=54688.5, null(11)=0, avgsize(11)=4, distinct(12)=42696.7, null(12)=0, avgsize(12)=4, distinct(15)=92, null(15)=0, avgsize(15)=4]
+ │ │ │ │ │ │ histogram(15)= 0 0 2350 750 6750 1350 7050 600 7050 300 7200 450 7050 600 6900 450 5307.7 530.77
+ │ │ │ │ │ │ <--- '1993-09-30' ------ '1993-10-05' ------ '1993-10-18' ------ '1993-10-31' ------ '1993-11-14' ------ '1993-11-25' ------ '1993-12-06' ------ '1993-12-20' -------- '1993-12-31'
│ │ │ │ │ ├── key: (11)
│ │ │ │ │ ├── fd: (11)-->(12,15)
│ │ │ │ │ └── scan orders@o_od
│ │ │ │ │ ├── save-table-name: q10_scan_9
│ │ │ │ │ ├── columns: o_orderkey:11(int!null) o_orderdate:15(date!null)
│ │ │ │ │ ├── constraint: /15/11: [/'1993-10-01' - /'1993-12-31']
- │ │ │ │ │ ├── stats: [rows=55566.35, distinct(11)=55566.3, null(11)=0, avgsize(11)=4, distinct(15)=92, null(15)=0, avgsize(15)=4]
- │ │ │ │ │ │ histogram(11)= 0 0 0 0.037044 276.42 0.037044 269.9 0.037044 279.49 0.037044 281.16 0.037044 267.57 0.037044 271.34 0.037044 278.09 0.037044 272.34 0.037044 288.12 0.037044 280.68 0.037044 286.42 0.037044 285.05 0.037044 281.05 0.037044 280.42 0.037044 287.38 0.037044 282.46 0.037044 278.09 0.037044 268.42 0.037044 289.72 0.037044 279.31 0.037044 276.2 0.037044 281.16 0.037044 286.75 0.037044 281.72 0.037044 285.64 0.037044 285.61 0.037044 285.57 0.037044 277.49 0.037044 278.86 0.037044 271.6 0.037044 270.86 0.037044 280.68 0.037044 279.53 0.037044 269.6 0.037044 273.86 0.037044 278.16 0.037044 282.38 0.037044 280.86 0.037044 288.05 0.037044 278.72 0.037044 280.38 0.037044 277.23 0.037044 283.86 0.037044 272.97 0.037044 276.75 0.037044 273.42 0.037044 283.31 0.037044 273.46 0.037044 282.86 0.037044 277.49 0.037044 275.86 0.037044 278.83 0.037044 275.68 0.037044 269.16 0.037044 294.9 0.037044 268.64 0.037044 278.38 0.037044 270.23 0.037044 277.94 0.037044 269.9 0.037044 271.2 0.037044 268.05 0.037044 276.05 0.037044 289.35 0.037044 273.34 0.037044 274.83 0.037044 283.83 0.037044 274.31 0.037044 275.34 0.037044 280.79 0.037044 290.31 0.037044 275.83 0.037044 272.49 0.037044 282.2 0.037044 263.42 0.037044 274.09 0.037044 282.38 0.037044 283.61 0.037044 275.38 0.037044 283.64 0.037044 274.31 0.037044 276.9 0.037044 280.53 0.037044 284.83 0.037044 280.05 0.037044 274.68 0.037044 278.72 0.037044 280.01 0.037044 271.57 0.037044 281.09 0.037044 273.71 0.037044 271.46 0.037044 284.2 0.037044 278.72 0.037044 284.79 0.037044 278.75 0.037044 282.09 0.037044 276.49 0.037044 281.35 0.037044 273.12 0.037044 284.16 0.037044 270.83 0.037044 269.34 0.037044 274.12 0.037044 284.83 0.037044 277.38 0.037044 279.94 0.037044 272.86 0.037044 278.64 0.037044 287.57 0.037044 273.64 0.037044 274.12 0.037044 280.16 0.037044 277.94 0.037044 266.79 0.037044 281.38 0.037044 278.79 0.037044 276.05 0.037044 269.71 0.037044 270.71 0.037044 273.64 0.037044 272.12 0.037044 273.53 0.037044 278.98 0.037044 285.49 0.037044 280.86 0.037044 278.31 0.037044 279.2 0.037044 267.12 0.037044 284.87 0.037044 283.72 0.037044 272.6 0.037044 283.27 0.037044 268.68 0.037044 271.46 0.037044 278.79 0.037044 280.23 0.037044 278.75 0.037044 275.57 0.037044 277.6 0.037044 274.86 0.037044 278.2 0.037044 281.38 0.037044 274.01 0.037044 273.34 0.037044 271.57 0.037044 273.68 0.037044 279.79 0.037044 271.57 0.037044 275.31 0.037044 287.98 0.037044 290.94 0.037044 280.16 0.037044 279.64 0.037044 290.72 0.037044 293.9 0.037044 287.79 0.037044 286.68 0.037044 277.12 0.037044 284.49 0.037044 283.9 0.037044 281.09 0.037044 278.86 0.037044 276.6 0.037044 275.79 0.037044 278.57 0.037044 290.09 0.037044 280.38 0.037044 284.2 0.037044 282.94 0.037044 276.46 0.037044 290.87 0.037044 277.23 0.037044 287.68 0.037044 276.05 0.037044 298.24 0.037044 283.2 0.037044 286.16 0.037044 276.79 0.037044 278.49 0.037044 290.09 0.037044 273.68 0.037044 287.09 0.037044 279.53 0.037044 285.94 0.037044 273.57 0.037044 276.53 0.037044 276.64 0.037044 289.31 0.037044 287.72 0.037044 278.27 0.037044 283.09 0.037044 285.68 0.037044 286.35 0.037044 282.72 0.037044 286.53 0.037044 293.83 0.037044 281.05 0.037044 295.05 0.037044 0 0
- │ │ │ │ │ │ <--- -9223372036854775808 ---- 1472 --------- 30469 -------- 54689 --------- 85922 --------- 118369 -------- 140867 -------- 166146 -------- 196357 -------- 222375 -------- 259877 -------- 291970 -------- 328227 -------- 363490 -------- 395873 -------- 427783 -------- 464741 -------- 498146 -------- 528358 -------- 551493 -------- 590144 -------- 621254 ------- 650083 -------- 682531 -------- 719041 -------- 751906 -------- 787617 -------- 823298 -------- 858944 -------- 888739 -------- 919527 ------- 944996 -------- 969922 -------- 1002020 -------- 1033280 ------- 1057284 -------- 1084416 -------- 1114693 -------- 1148034 -------- 1180262 -------- 1217697 -------- 1248386 -------- 1280261 -------- 1309862 -------- 1344263 -------- 1370759 -------- 1400003 -------- 1426822 -------- 1460837 -------- 1487680 -------- 1521376 -------- 1551174 -------- 1579779 -------- 1610532 -------- 1638983 -------- 1662660 ------- 1705024 -------- 1728321 -------- 1758757 -------- 1783239 -------- 1813344 ------- 1837573 ------- 1862757 -------- 1885607 -------- 1914340 -------- 1952706 -------- 1979458 -------- 2007302 -------- 2041697 -------- 2069157 -------- 2097383 -------- 2129571 -------- 2168643 -------- 2197223 -------- 2223363 ------- 2256577 -------- 2275975 -------- 2303264 -------- 2336608 -------- 2370823 -------- 2399074 -------- 2433315 -------- 2460771 ------- 2490114 -------- 2522119 -------- 2557218 -------- 2588866 -------- 2616610 -------- 2647296 -------- 2678913 -------- 2704354 -------- 2736743 -------- 2763779 -------- 2789157 ------- 2823812 -------- 2854502 -------- 2889572 -------- 2920263 -------- 2953378 -------- 2982439 -------- 3015013 -------- 3041603 -------- 3076227 -------- 3101125 -------- 3124930 -------- 3152260 -------- 3187366 -------- 3217059 -------- 3248611 -------- 3275008 -------- 3305634 -------- 3342721 -------- 3369702 -------- 3397031 -------- 3428771 -------- 3458885 -------- 3480806 -------- 3513408 -------- 3544129 -------- 3572866 -------- 3596965 -------- 3621794 -------- 3648771 -------- 3674624 -------- 3701510 -------- 3732387 -------- 3767974 -------- 3800224 -------- 3830599 ------- 3861635 -------- 3883808 -------- 3918949 -------- 3953249 ------- 3979456 -------- 4013443 -------- 4036775 -------- 4062148 -------- 4092867 -------- 4124641 -------- 4155333 -------- 4183718 ------- 4213574 -------- 4241445 ------- 4271751 -------- 4304354 -------- 4331590 -------- 4358338 -------- 4383782 -------- 4410791 -------- 4442244 -------- 4467687 -------- 4495876 -------- 4529761 -------- 4565792 -------- 4593991 -------- 4621829 -------- 4657703 ------- 4695878 -------- 4729632 -------- 4762593 -------- 4788581 -------- 4819943 ------- 4850885 -------- 4879777 -------- 4907042 ------- 4932640 -------- 4957638 -------- 4984675 -------- 5020100 -------- 5048481 ------- 5079622 -------- 5109862 -------- 5135363 -------- 5171364 -------- 5197414 -------- 5231104 -------- 5256289 -------- 5297604 ------- 5328038 -------- 5360608 -------- 5386337 -------- 5413315 -------- 5448743 -------- 5472197 -------- 5505440 -------- 5533184 -------- 5565603 -------- 5588963 -------- 5614503 -------- 5640135 -------- 5675008 -------- 5708709 -------- 5735522 -------- 5765862 -------- 5798085 -------- 5830787 -------- 5860867 -------- 5893703 -------- 5931844 -------- 5960706 -------- 5999719 --- 9223372036854775807
- │ │ │ │ │ │ histogram(15)= 0 0 5062.5 600 7200 150 6900 1350 6300 1050 7200 600 7050 600 7200 1050 2711.5 542.31
- │ │ │ │ │ │ <--- '1993-09-30' -------- '1993-10-10' ------ '1993-10-24' ------ '1993-11-04' ------ '1993-11-15' ------ '1993-11-27' ------ '1993-12-10' ------ '1993-12-25' -------- '1993-12-31'
+ │ │ │ │ │ ├── stats: [rows=54688.46, distinct(11)=54688.5, null(11)=0, avgsize(11)=4, distinct(15)=92, null(15)=0, avgsize(15)=4]
+ │ │ │ │ │ │ histogram(11)= 0 0 0 0.036458 270.05 0.036458 267.17 0.036458 282.52 0.036458 271.03 0.036458 292.76 0.036458 264.91 0.036458 271.25 0.036458 285.25 0.036458 274.42 0.036458 275.41 0.036458 270.78 0.036458 273.11 0.036458 276.94 0.036458 274.46 0.036458 278.58 0.036458 276.87 0.036458 269.25 0.036458 281.24 0.036458 270.16 0.036458 264.32 0.036458 274.13 0.036458 271.07 0.036458 276.21 0.036458 272.42 0.036458 266.26 0.036458 259.22 0.036458 278.8 0.036458 277.81 0.036458 276.35 0.036458 273.07 0.036458 270.16 0.036458 277.81 0.036458 284.59 0.036458 270.48 0.036458 271.8 0.036458 278.98 0.036458 270.08 0.036458 265.38 0.036458 269.9 0.036458 268.92 0.036458 268.92 0.036458 274.09 0.036458 278.07 0.036458 279.85 0.036458 272.38 0.036458 268.08 0.036458 277.01 0.036458 278.91 0.036458 273.8 0.036458 266.91 0.036458 265.71 0.036458 268.55 0.036458 269.14 0.036458 272.67 0.036458 274.42 0.036458 263.74 0.036458 279.89 0.036458 269.83 0.036458 282.19 0.036458 278.51 0.036458 274.02 0.036458 262.94 0.036458 263.67 0.036458 262.32 0.036458 262.06 0.036458 287.51 0.036458 268.33 0.036458 266.22 0.036458 273.22 0.036458 274.53 0.036458 275.59 0.036458 260.64 0.036458 271.18 0.036458 267.53 0.036458 266.15 0.036458 280.15 0.036458 270.92 0.036458 264.43 0.036458 271.29 0.036458 272.27 0.036458 280.55 0.036458 274.5 0.036458 271.32 0.036458 280.55 0.036458 282.12 0.036458 274.31 0.036458 269.83 0.036458 274.31 0.036458 280.77 0.036458 260.93 0.036458 268.08 0.036458 268.33 0.036458 267.42 0.036458 271.43 0.036458 283.17 0.036458 279.85 0.036458 273.88 0.036458 277.7 0.036458 266.47 0.036458 276.87 0.036458 266.04 0.036458 275.55 0.036458 270.41 0.036458 277.59 0.036458 270.59 0.036458 266.98 0.036458 276.54 0.036458 281.71 0.036458 273.29 0.036458 271.07 0.036458 267.53 0.036458 271.65 0.036458 276.25 0.036458 264.18 0.036458 278.03 0.036458 282.52 0.036458 270.45 0.036458 280.8 0.036458 271.18 0.036458 267.82 0.036458 274.09 0.036458 277.89 0.036458 268.33 0.036458 269.57 0.036458 278.29 0.036458 281.31 0.036458 275.59 0.036458 268.01 0.036458 275.55 0.036458 269.83 0.036458 266.07 0.036458 287.15 0.036458 268.52 0.036458 267.35 0.036458 271.94 0.036458 272.42 0.036458 275.81 0.036458 274.31 0.036458 265.09 0.036458 266.51 0.036458 270.48 0.036458 290.21 0.036458 269.17 0.036458 273.73 0.036458 274.35 0.036458 275.88 0.036458 280.95 0.036458 285.91 0.036458 272.85 0.036458 280.22 0.036458 277.3 0.036458 279.93 0.036458 278.83 0.036458 291.16 0.036458 286.56 0.036458 279.78 0.036458 281.93 0.036458 273.51 0.036458 273.4 0.036458 276.97 0.036458 276.1 0.036458 286.16 0.036458 275.92 0.036458 275.26 0.036458 273.22 0.036458 286.93 0.036458 273.77 0.036458 278.07 0.036458 283.46 0.036458 288.35 0.036458 273.51 0.036458 285.91 0.036458 275.01 0.036458 277.96 0.036458 274.31 0.036458 275.22 0.036458 290.87 0.036458 275.99 0.036458 288.64 0.036458 277.59 0.036458 287.44 0.036458 276.35 0.036458 294.47 0.036458 280.69 0.036458 278.4 0.036458 274.57 0.036458 274.02 0.036458 279.78 0.036458 283.72 0.036458 280.69 0.036458 272.82 0.036458 284.59 0.036458 283.46 0.036458 279.2 0.036458 279.13 0.036458 276.35 0.036458 273.69 0.036458 282.08 0.036458 276.54 0.036458 0 0
+ │ │ │ │ │ │ <--- -9223372036854775808 ---- 1505 --------- 29025 --------- 54400 --------- 91106 --------- 119366 -------- 163554 -------- 187236 -------- 215651 -------- 254373 -------- 285123 -------- 316614 -------- 344678 -------- 374465 -------- 407078 -------- 437861 -------- 471683 -------- 504230 -------- 531168 -------- 566951 -------- 594561 -------- 617825 -------- 648358 -------- 676640 -------- 708706 -------- 737986 -------- 762690 -------- 782081 ------- 816064 -------- 849318 -------- 881511 -------- 911271 -------- 938885 -------- 972135 -------- 1010370 -------- 1038212 ------- 1067041 -------- 1101158 -------- 1128704 -------- 1152742 ------- 1180165 -------- 1206852 -------- 1233537 -------- 1264064 -------- 1297504 -------- 1332260 -------- 1361504 -------- 1387553 -------- 1420224 -------- 1454275 ------- 1484580 -------- 1509766 -------- 1534050 -------- 1560452 -------- 1587299 -------- 1616771 -------- 1647526 -------- 1670343 -------- 1705121 -------- 1732486 -------- 1768967 -------- 1802725 -------- 1833189 -------- 1855398 -------- 1878146 -------- 1899877 -------- 1921414 -------- 1961765 -------- 1988000 -------- 2012672 -------- 2042529 -------- 2073381 -------- 2104999 -------- 2125477 -------- 2153825 -------- 2179462 -------- 2204065 -------- 2239044 -------- 2267205 -------- 2290530 -------- 2318977 -------- 2348134 -------- 2383399 ------- 2414215 -------- 2442695 -------- 2477955 -------- 2514372 -------- 2545062 -------- 2572418 -------- 2603108 -------- 2638534 -------- 2659232 -------- 2685286 -------- 2711527 -------- 2737088 -------- 2765639 -------- 2802818 -------- 2837570 -------- 2867911 ------- 2901088 -------- 2925954 -------- 2958501 -------- 2983042 -------- 3014626 -------- 3042406 -------- 3075489 -------- 3103425 -------- 3128673 -------- 3160994 -------- 3197125 -------- 3227043 -------- 3255328 -------- 3280965 -------- 3309669 -------- 3341767 -------- 3364898 -------- 3398305 -------- 3435008 -------- 3462818 ------- 3498272 -------- 3526631 -------- 3552485 -------- 3583014 -------- 3616322 -------- 3642566 -------- 3669732 -------- 3703330 -------- 3739170 -------- 3770791 -------- 3796804 -------- 3828387 -------- 3855751 -------- 3880321 -------- 3920422 -------- 3946818 -------- 3972322 -------- 4001250 -------- 4030533 -------- 4062306 -------- 4092992 -------- 4116803 -------- 4141697 -------- 4169536 -------- 4211878 -------- 4238753 -------- 4268994 -------- 4299686 -------- 4331525 -------- 4367079 -------- 4406277 -------- 4435878 -------- 4470914 ------- 4500294 -------- 4531617 -------- 4562114 -------- 4601666 -------- 4637856 -------- 4669060 -------- 4701861 -------- 4728416 ------- 4754881 -------- 4784001 ------- 4812482 -------- 4848389 -------- 4876741 -------- 4904612 -------- 4930945 -------- 4967397 -------- 4994146 -------- 5024099 -------- 5058023 -------- 5095527 -------- 5122081 -------- 5157798 -------- 5185472 -------- 5215332 -------- 5242497 -------- 5270338 -------- 5309699 -------- 5338112 -------- 5375843 -------- 5405441 -------- 5442277 -------- 5470945 -------- 5512930 -------- 5544807 ------- 5574980 -------- 5602340 -------- 5629280 -------- 5660482 -------- 5694599 -------- 5726466 -------- 5752519 -------- 5787268 -------- 5821185 ------- 5851973 -------- 5882689 -------- 5911363 -------- 5938052 -------- 5970949 -------- 5999748 --- 9223372036854775807
+ │ │ │ │ │ │ histogram(15)= 0 0 2350 750 6750 1350 7050 600 7050 300 7200 450 7050 600 6900 450 5307.7 530.77
+ │ │ │ │ │ │ <--- '1993-09-30' ------ '1993-10-05' ------ '1993-10-18' ------ '1993-10-31' ------ '1993-11-14' ------ '1993-11-25' ------ '1993-12-06' ------ '1993-12-20' -------- '1993-12-31'
│ │ │ │ │ ├── key: (11)
│ │ │ │ │ └── fd: (11)-->(15)
│ │ │ │ └── filters
@@ -142,7 +142,7 @@ top-k
│ │ ├── scan nation
│ │ │ ├── save-table-name: q10_scan_10
│ │ │ ├── columns: n_nationkey:40(int!null) n_name:41(char!null)
- │ │ │ ├── stats: [rows=25, distinct(40)=25, null(40)=0, avgsize(40)=4, distinct(41)=25, null(41)=0, avgsize(41)=4]
+ │ │ │ ├── stats: [rows=25, distinct(40)=25, null(40)=0, avgsize(40)=1, distinct(41)=25, null(41)=0, avgsize(41)=10]
│ │ │ │ histogram(40)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ histogram(41)= 0 1 23 1
@@ -202,14 +202,14 @@ column_names row_count distinct_count null_count
{sum} 37967 37685 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 32486.00 1.17 32486.00 1.16 0.00 1.00
-{c_address} 32486.00 1.17 32486.00 1.17 0.00 1.00
-{c_comment} 32486.00 1.17 32486.00 1.17 0.00 1.00
-{c_custkey} 32486.00 1.17 32486.00 1.17 0.00 1.00
-{c_name} 32486.00 1.17 32486.00 1.17 0.00 1.00
-{c_phone} 32486.00 1.17 32486.00 1.17 0.00 1.00
-{n_name} 32486.00 1.17 32486.00 1299.44 <== 0.00 1.00
-{sum} 32486.00 1.17 32486.00 1.16 0.00 1.00
+{c_acctbal} 32163.00 1.18 32163.00 1.17 0.00 1.00
+{c_address} 32163.00 1.18 32163.00 1.18 0.00 1.00
+{c_comment} 32163.00 1.18 32163.00 1.18 0.00 1.00
+{c_custkey} 32163.00 1.18 32163.00 1.18 0.00 1.00
+{c_name} 32163.00 1.18 32163.00 1.18 0.00 1.00
+{c_phone} 32163.00 1.18 32163.00 1.18 0.00 1.00
+{n_name} 32163.00 1.18 32163.00 1286.52 <== 0.00 1.00
+{sum} 32163.00 1.18 32163.00 1.17 0.00 1.00
----Stats for q10_project_3----
column_names row_count distinct_count null_count
@@ -223,14 +223,14 @@ column_names row_count distinct_count null_count
{n_name} 114705 25 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 79983.00 1.43 44989.00 1.19 0.00 1.00
-{c_address} 79983.00 1.43 45378.00 1.19 0.00 1.00
-{c_comment} 79983.00 1.43 45378.00 1.19 0.00 1.00
-{c_custkey} 79983.00 1.43 32486.00 1.17 0.00 1.00
-{c_name} 79983.00 1.43 45378.00 1.20 0.00 1.00
-{c_phone} 79983.00 1.43 45378.00 1.19 0.00 1.00
-{column46} 79983.00 1.43 40133.00 2.86 <== 0.00 1.00
-{n_name} 79983.00 1.43 25.00 1.00 0.00 1.00
+{c_acctbal} 79342.00 1.45 44685.00 1.19 0.00 1.00
+{c_address} 79342.00 1.45 45057.00 1.18 0.00 1.00
+{c_comment} 79342.00 1.45 45034.00 1.18 0.00 1.00
+{c_custkey} 79342.00 1.45 32163.00 1.18 0.00 1.00
+{c_name} 79342.00 1.45 45060.00 1.19 0.00 1.00
+{c_phone} 79342.00 1.45 45060.00 1.18 0.00 1.00
+{column46} 79342.00 1.45 39820.00 2.88 <== 0.00 1.00
+{n_name} 79342.00 1.45 25.00 1.00 0.00 1.00
----Stats for q10_inner_join_4----
column_names row_count distinct_count null_count
@@ -252,22 +252,22 @@ column_names row_count distinct_count null_count
{o_orderkey} 114705 48516 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 79983.00 1.43 44989.00 1.19 0.00 1.00
-{c_address} 79983.00 1.43 45378.00 1.19 0.00 1.00
-{c_comment} 79983.00 1.43 45378.00 1.19 0.00 1.00
-{c_custkey} 79983.00 1.43 32486.00 1.17 0.00 1.00
-{c_name} 79983.00 1.43 45378.00 1.20 0.00 1.00
-{c_nationkey} 79983.00 1.43 25.00 1.00 0.00 1.00
-{c_phone} 79983.00 1.43 45378.00 1.19 0.00 1.00
-{l_discount} 79983.00 1.43 11.00 1.00 0.00 1.00
-{l_extendedprice} 79983.00 1.43 39899.00 2.66 <== 0.00 1.00
-{l_orderkey} 79983.00 1.43 36212.00 1.34 0.00 1.00
-{l_returnflag} 79983.00 1.43 1.00 1.00 0.00 1.00
-{n_name} 79983.00 1.43 25.00 1.00 0.00 1.00
-{n_nationkey} 79983.00 1.43 25.00 1.00 0.00 1.00
-{o_custkey} 79983.00 1.43 32486.00 1.17 0.00 1.00
-{o_orderdate} 79983.00 1.43 92.00 1.00 0.00 1.00
-{o_orderkey} 79983.00 1.43 36212.00 1.34 0.00 1.00
+{c_acctbal} 79342.00 1.45 44685.00 1.19 0.00 1.00
+{c_address} 79342.00 1.45 45057.00 1.18 0.00 1.00
+{c_comment} 79342.00 1.45 45034.00 1.18 0.00 1.00
+{c_custkey} 79342.00 1.45 32163.00 1.18 0.00 1.00
+{c_name} 79342.00 1.45 45060.00 1.19 0.00 1.00
+{c_nationkey} 79342.00 1.45 25.00 1.00 0.00 1.00
+{c_phone} 79342.00 1.45 45060.00 1.18 0.00 1.00
+{l_discount} 79342.00 1.45 11.00 1.00 0.00 1.00
+{l_extendedprice} 79342.00 1.45 39573.00 2.68 <== 0.00 1.00
+{l_orderkey} 79342.00 1.45 35816.00 1.35 0.00 1.00
+{l_returnflag} 79342.00 1.45 1.00 1.00 0.00 1.00
+{n_name} 79342.00 1.45 25.00 1.00 0.00 1.00
+{n_nationkey} 79342.00 1.45 25.00 1.00 0.00 1.00
+{o_custkey} 79342.00 1.45 32163.00 1.18 0.00 1.00
+{o_orderdate} 79342.00 1.45 92.00 1.00 0.00 1.00
+{o_orderkey} 79342.00 1.45 35816.00 1.35 0.00 1.00
----Stats for q10_inner_join_5----
column_names row_count distinct_count null_count
@@ -287,20 +287,20 @@ column_names row_count distinct_count null_count
{o_orderkey} 114705 48516 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 79983.00 1.43 60978.00 1.62 0.00 1.00
-{c_address} 79983.00 1.43 61993.00 1.63 0.00 1.00
-{c_comment} 79983.00 1.43 61993.00 1.63 0.00 1.00
-{c_custkey} 79983.00 1.43 36326.00 1.04 0.00 1.00
-{c_name} 79983.00 1.43 61993.00 1.64 0.00 1.00
-{c_nationkey} 79983.00 1.43 25.00 1.00 0.00 1.00
-{c_phone} 79983.00 1.43 61993.00 1.63 0.00 1.00
-{l_discount} 79983.00 1.43 11.00 1.00 0.00 1.00
-{l_extendedprice} 79983.00 1.43 49328.00 2.15 <== 0.00 1.00
-{l_orderkey} 79983.00 1.43 42393.00 1.14 0.00 1.00
-{l_returnflag} 79983.00 1.43 1.00 1.00 0.00 1.00
-{o_custkey} 79983.00 1.43 36326.00 1.04 0.00 1.00
-{o_orderdate} 79983.00 1.43 92.00 1.00 0.00 1.00
-{o_orderkey} 79983.00 1.43 42393.00 1.14 0.00 1.00
+{c_acctbal} 79342.00 1.45 60636.00 1.61 0.00 1.00
+{c_address} 79342.00 1.45 61610.00 1.62 0.00 1.00
+{c_comment} 79342.00 1.45 61549.00 1.62 0.00 1.00
+{c_custkey} 79342.00 1.45 35940.00 1.05 0.00 1.00
+{c_name} 79342.00 1.45 61616.00 1.63 0.00 1.00
+{c_nationkey} 79342.00 1.45 25.00 1.00 0.00 1.00
+{c_phone} 79342.00 1.45 61616.00 1.62 0.00 1.00
+{l_discount} 79342.00 1.45 11.00 1.00 0.00 1.00
+{l_extendedprice} 79342.00 1.45 48919.00 2.17 <== 0.00 1.00
+{l_orderkey} 79342.00 1.45 41870.00 1.16 0.00 1.00
+{l_returnflag} 79342.00 1.45 1.00 1.00 0.00 1.00
+{o_custkey} 79342.00 1.45 35940.00 1.05 0.00 1.00
+{o_orderdate} 79342.00 1.45 92.00 1.00 0.00 1.00
+{o_orderkey} 79342.00 1.45 41870.00 1.16 0.00 1.00
----Stats for q10_scan_6----
column_names row_count distinct_count null_count
@@ -313,9 +313,9 @@ column_names row_count distinct_count null_count
{c_phone} 150000 150000 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 150000.00 1.00 140426.00 1.00 0.00 1.00
-{c_address} 150000.00 1.00 150000.00 1.00 0.00 1.00
-{c_comment} 150000.00 1.00 150000.00 1.00 0.00 1.00
+{c_acctbal} 150000.00 1.00 140628.00 1.00 0.00 1.00
+{c_address} 150000.00 1.00 149937.00 1.00 0.00 1.00
+{c_comment} 150000.00 1.00 149323.00 1.00 0.00 1.00
{c_custkey} 150000.00 1.00 148813.00 1.00 0.00 1.00
{c_name} 150000.00 1.00 150000.00 1.00 0.00 1.00
{c_nationkey} 150000.00 1.00 25.00 1.00 0.00 1.00
@@ -332,13 +332,13 @@ column_names row_count distinct_count null_count
{o_orderkey} 114705 48516 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 79350.00 1.45 11.00 1.00 0.00 1.00
-{l_extendedprice} 79350.00 1.45 75505.00 1.41 0.00 1.00
-{l_orderkey} 79350.00 1.45 55566.00 1.15 0.00 1.00
-{l_returnflag} 79350.00 1.45 1.00 1.00 0.00 1.00
-{o_custkey} 79350.00 1.45 36326.00 1.04 0.00 1.00
-{o_orderdate} 79350.00 1.45 92.00 1.00 0.00 1.00
-{o_orderkey} 79350.00 1.45 55566.00 1.15 0.00 1.00
+{l_discount} 78714.00 1.46 11.00 1.00 0.00 1.00
+{l_extendedprice} 78714.00 1.46 74852.00 1.42 0.00 1.00
+{l_orderkey} 78714.00 1.46 54688.00 1.13 0.00 1.00
+{l_returnflag} 78714.00 1.46 1.00 1.00 0.00 1.00
+{o_custkey} 78714.00 1.46 35940.00 1.05 0.00 1.00
+{o_orderdate} 78714.00 1.46 92.00 1.00 0.00 1.00
+{o_orderkey} 78714.00 1.46 54688.00 1.13 0.00 1.00
----Stats for q10_index_join_8----
column_names row_count distinct_count null_count
@@ -347,9 +347,9 @@ column_names row_count distinct_count null_count
{o_orderkey} 57069 56240 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_custkey} 55566.00 1.03 43217.00 1.01 0.00 1.00
-{o_orderdate} 55566.00 1.03 92.00 1.00 0.00 1.00
-{o_orderkey} 55566.00 1.03 55566.00 1.01 0.00 1.00
+{o_custkey} 54688.00 1.04 42697.00 1.00 0.00 1.00
+{o_orderdate} 54688.00 1.04 92.00 1.00 0.00 1.00
+{o_orderkey} 54688.00 1.04 54688.00 1.03 0.00 1.00
----Stats for q10_scan_9----
column_names row_count distinct_count null_count
@@ -357,8 +357,8 @@ column_names row_count distinct_count null_count
{o_orderkey} 57069 56240 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_orderdate} 55566.00 1.03 92.00 1.00 0.00 1.00
-{o_orderkey} 55566.00 1.03 55566.00 1.01 0.00 1.00
+{o_orderdate} 54688.00 1.04 92.00 1.00 0.00 1.00
+{o_orderkey} 54688.00 1.04 54688.00 1.03 0.00 1.00
----Stats for q10_scan_10----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q11 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q11
index 892fea8dde90..3220ed326d16 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q11
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q11
@@ -71,33 +71,33 @@ sort
│ │ ├── save-table-name: q11_project_4
│ │ ├── columns: column23:23(float!null) ps_partkey:1(int!null)
│ │ ├── immutable
- │ │ ├── stats: [rows=32258.06, distinct(1)=29783.5, null(1)=0, avgsize(1)=4, distinct(23)=31617.9, null(23)=0, avgsize(23)=8]
+ │ │ ├── stats: [rows=32258.06, distinct(1)=29783.5, null(1)=0, avgsize(1)=4, distinct(23)=31617.9, null(23)=0, avgsize(23)=13]
│ │ ├── inner-join (lookup partsupp)
│ │ │ ├── save-table-name: q11_lookup_join_5
│ │ │ ├── columns: ps_partkey:1(int!null) ps_suppkey:2(int!null) ps_availqty:3(int!null) ps_supplycost:4(float!null) s_suppkey:8(int!null) s_nationkey:11(int!null) n_nationkey:17(int!null) n_name:18(char!null)
│ │ │ ├── key columns: [1 2] = [1 2]
│ │ │ ├── lookup columns are key
- │ │ │ ├── stats: [rows=32258.06, distinct(1)=29783.5, null(1)=0, avgsize(1)=4, distinct(2)=399.935, null(2)=0, avgsize(2)=4, distinct(3)=9536.12, null(3)=0, avgsize(3)=4, distinct(4)=1000, null(4)=0, avgsize(4)=4, distinct(8)=399.935, null(8)=0, avgsize(8)=4, distinct(11)=1, null(11)=0, avgsize(11)=4, distinct(17)=1, null(17)=0, avgsize(17)=4, distinct(18)=1, null(18)=0, avgsize(18)=4, distinct(3,4)=31617.9, null(3,4)=0, avgsize(3,4)=8]
+ │ │ │ ├── stats: [rows=32258.06, distinct(1)=29783.5, null(1)=0, avgsize(1)=4, distinct(2)=399.935, null(2)=0, avgsize(2)=3, distinct(3)=9536.12, null(3)=0, avgsize(3)=4, distinct(4)=27589.3, null(4)=0, avgsize(4)=9, distinct(8)=399.935, null(8)=0, avgsize(8)=3, distinct(11)=1, null(11)=0, avgsize(11)=2, distinct(17)=1, null(17)=0, avgsize(17)=1, distinct(18)=1, null(18)=0, avgsize(18)=10, distinct(3,4)=31617.9, null(3,4)=0, avgsize(3,4)=13]
│ │ │ ├── key: (1,8)
│ │ │ ├── fd: ()-->(18), (1,2)-->(3,4), (8)-->(11), (11)==(17), (17)==(11), (2)==(8), (8)==(2)
│ │ │ ├── inner-join (lookup partsupp@ps_sk)
│ │ │ │ ├── save-table-name: q11_lookup_join_6
│ │ │ │ ├── columns: ps_partkey:1(int!null) ps_suppkey:2(int!null) s_suppkey:8(int!null) s_nationkey:11(int!null) n_nationkey:17(int!null) n_name:18(char!null)
│ │ │ │ ├── key columns: [8] = [2]
- │ │ │ │ ├── stats: [rows=32258.06, distinct(1)=29783.5, null(1)=0, avgsize(1)=4, distinct(2)=399.935, null(2)=0, avgsize(2)=4, distinct(8)=399.935, null(8)=0, avgsize(8)=4, distinct(11)=1, null(11)=0, avgsize(11)=4, distinct(17)=1, null(17)=0, avgsize(17)=4, distinct(18)=1, null(18)=0, avgsize(18)=4]
+ │ │ │ │ ├── stats: [rows=32258.06, distinct(1)=29783.5, null(1)=0, avgsize(1)=4, distinct(2)=399.935, null(2)=0, avgsize(2)=3, distinct(8)=399.935, null(8)=0, avgsize(8)=3, distinct(11)=1, null(11)=0, avgsize(11)=2, distinct(17)=1, null(17)=0, avgsize(17)=1, distinct(18)=1, null(18)=0, avgsize(18)=10]
│ │ │ │ ├── key: (1,8)
│ │ │ │ ├── fd: ()-->(18), (8)-->(11), (11)==(17), (17)==(11), (2)==(8), (8)==(2)
│ │ │ │ ├── inner-join (lookup supplier@s_nk)
│ │ │ │ │ ├── save-table-name: q11_lookup_join_7
│ │ │ │ │ ├── columns: s_suppkey:8(int!null) s_nationkey:11(int!null) n_nationkey:17(int!null) n_name:18(char!null)
│ │ │ │ │ ├── key columns: [17] = [11]
- │ │ │ │ │ ├── stats: [rows=400, distinct(8)=399.935, null(8)=0, avgsize(8)=4, distinct(11)=1, null(11)=0, avgsize(11)=4, distinct(17)=1, null(17)=0, avgsize(17)=4, distinct(18)=1, null(18)=0, avgsize(18)=4]
+ │ │ │ │ │ ├── stats: [rows=400, distinct(8)=399.935, null(8)=0, avgsize(8)=3, distinct(11)=1, null(11)=0, avgsize(11)=2, distinct(17)=1, null(17)=0, avgsize(17)=1, distinct(18)=1, null(18)=0, avgsize(18)=10]
│ │ │ │ │ ├── key: (8)
│ │ │ │ │ ├── fd: ()-->(18), (8)-->(11), (11)==(17), (17)==(11)
│ │ │ │ │ ├── select
│ │ │ │ │ │ ├── save-table-name: q11_select_8
│ │ │ │ │ │ ├── columns: n_nationkey:17(int!null) n_name:18(char!null)
- │ │ │ │ │ │ ├── stats: [rows=1, distinct(17)=1, null(17)=0, avgsize(17)=4, distinct(18)=1, null(18)=0, avgsize(18)=4]
+ │ │ │ │ │ │ ├── stats: [rows=1, distinct(17)=1, null(17)=0, avgsize(17)=1, distinct(18)=1, null(18)=0, avgsize(18)=10]
│ │ │ │ │ │ │ histogram(18)= 0 1
│ │ │ │ │ │ │ <--- 'GERMANY'
│ │ │ │ │ │ ├── key: (17)
@@ -105,7 +105,7 @@ sort
│ │ │ │ │ │ ├── scan nation
│ │ │ │ │ │ │ ├── save-table-name: q11_scan_9
│ │ │ │ │ │ │ ├── columns: n_nationkey:17(int!null) n_name:18(char!null)
- │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(17)=25, null(17)=0, avgsize(17)=4, distinct(18)=25, null(18)=0, avgsize(18)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(17)=25, null(17)=0, avgsize(17)=1, distinct(18)=25, null(18)=0, avgsize(18)=10]
│ │ │ │ │ │ │ │ histogram(17)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ histogram(18)= 0 1 23 1
@@ -146,32 +146,32 @@ sort
│ │ ├── save-table-name: q11_project_12
│ │ ├── columns: column47:47(float!null)
│ │ ├── immutable
- │ │ ├── stats: [rows=32258.06, distinct(47)=31617.9, null(47)=0, avgsize(47)=8]
+ │ │ ├── stats: [rows=32258.06, distinct(47)=31617.9, null(47)=0, avgsize(47)=13]
│ │ ├── inner-join (lookup partsupp)
│ │ │ ├── save-table-name: q11_lookup_join_13
│ │ │ ├── columns: ps_suppkey:26(int!null) ps_availqty:27(int!null) ps_supplycost:28(float!null) s_suppkey:32(int!null) s_nationkey:35(int!null) n_nationkey:41(int!null) n_name:42(char!null)
│ │ │ ├── key columns: [25 26] = [25 26]
│ │ │ ├── lookup columns are key
- │ │ │ ├── stats: [rows=32258.06, distinct(26)=399.935, null(26)=0, avgsize(26)=4, distinct(27)=9536.12, null(27)=0, avgsize(27)=4, distinct(28)=1000, null(28)=0, avgsize(28)=4, distinct(32)=399.935, null(32)=0, avgsize(32)=4, distinct(35)=1, null(35)=0, avgsize(35)=4, distinct(41)=1, null(41)=0, avgsize(41)=4, distinct(42)=1, null(42)=0, avgsize(42)=4, distinct(27,28)=31617.9, null(27,28)=0, avgsize(27,28)=8]
+ │ │ │ ├── stats: [rows=32258.06, distinct(26)=399.935, null(26)=0, avgsize(26)=3, distinct(27)=9536.12, null(27)=0, avgsize(27)=4, distinct(28)=27589.3, null(28)=0, avgsize(28)=9, distinct(32)=399.935, null(32)=0, avgsize(32)=3, distinct(35)=1, null(35)=0, avgsize(35)=2, distinct(41)=1, null(41)=0, avgsize(41)=1, distinct(42)=1, null(42)=0, avgsize(42)=10, distinct(27,28)=31617.9, null(27,28)=0, avgsize(27,28)=13]
│ │ │ ├── fd: ()-->(42), (32)-->(35), (35)==(41), (41)==(35), (26)==(32), (32)==(26)
│ │ │ ├── inner-join (lookup partsupp@ps_sk)
│ │ │ │ ├── save-table-name: q11_lookup_join_14
│ │ │ │ ├── columns: ps_partkey:25(int!null) ps_suppkey:26(int!null) s_suppkey:32(int!null) s_nationkey:35(int!null) n_nationkey:41(int!null) n_name:42(char!null)
│ │ │ │ ├── key columns: [32] = [26]
- │ │ │ │ ├── stats: [rows=32258.06, distinct(25)=29783.5, null(25)=0, avgsize(25)=4, distinct(26)=399.935, null(26)=0, avgsize(26)=4, distinct(32)=399.935, null(32)=0, avgsize(32)=4, distinct(35)=1, null(35)=0, avgsize(35)=4, distinct(41)=1, null(41)=0, avgsize(41)=4, distinct(42)=1, null(42)=0, avgsize(42)=4]
+ │ │ │ │ ├── stats: [rows=32258.06, distinct(25)=29783.5, null(25)=0, avgsize(25)=4, distinct(26)=399.935, null(26)=0, avgsize(26)=3, distinct(32)=399.935, null(32)=0, avgsize(32)=3, distinct(35)=1, null(35)=0, avgsize(35)=2, distinct(41)=1, null(41)=0, avgsize(41)=1, distinct(42)=1, null(42)=0, avgsize(42)=10]
│ │ │ │ ├── key: (25,32)
│ │ │ │ ├── fd: ()-->(42), (32)-->(35), (35)==(41), (41)==(35), (26)==(32), (32)==(26)
│ │ │ │ ├── inner-join (lookup supplier@s_nk)
│ │ │ │ │ ├── save-table-name: q11_lookup_join_15
│ │ │ │ │ ├── columns: s_suppkey:32(int!null) s_nationkey:35(int!null) n_nationkey:41(int!null) n_name:42(char!null)
│ │ │ │ │ ├── key columns: [41] = [35]
- │ │ │ │ │ ├── stats: [rows=400, distinct(32)=399.935, null(32)=0, avgsize(32)=4, distinct(35)=1, null(35)=0, avgsize(35)=4, distinct(41)=1, null(41)=0, avgsize(41)=4, distinct(42)=1, null(42)=0, avgsize(42)=4]
+ │ │ │ │ │ ├── stats: [rows=400, distinct(32)=399.935, null(32)=0, avgsize(32)=3, distinct(35)=1, null(35)=0, avgsize(35)=2, distinct(41)=1, null(41)=0, avgsize(41)=1, distinct(42)=1, null(42)=0, avgsize(42)=10]
│ │ │ │ │ ├── key: (32)
│ │ │ │ │ ├── fd: ()-->(42), (32)-->(35), (35)==(41), (41)==(35)
│ │ │ │ │ ├── select
│ │ │ │ │ │ ├── save-table-name: q11_select_16
│ │ │ │ │ │ ├── columns: n_nationkey:41(int!null) n_name:42(char!null)
- │ │ │ │ │ │ ├── stats: [rows=1, distinct(41)=1, null(41)=0, avgsize(41)=4, distinct(42)=1, null(42)=0, avgsize(42)=4]
+ │ │ │ │ │ │ ├── stats: [rows=1, distinct(41)=1, null(41)=0, avgsize(41)=1, distinct(42)=1, null(42)=0, avgsize(42)=10]
│ │ │ │ │ │ │ histogram(42)= 0 1
│ │ │ │ │ │ │ <--- 'GERMANY'
│ │ │ │ │ │ ├── key: (41)
@@ -179,7 +179,7 @@ sort
│ │ │ │ │ │ ├── scan nation
│ │ │ │ │ │ │ ├── save-table-name: q11_scan_17
│ │ │ │ │ │ │ ├── columns: n_nationkey:41(int!null) n_name:42(char!null)
- │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(41)=25, null(41)=0, avgsize(41)=4, distinct(42)=25, null(42)=0, avgsize(42)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(41)=25, null(41)=0, avgsize(41)=1, distinct(42)=25, null(42)=0, avgsize(42)=10]
│ │ │ │ │ │ │ │ histogram(41)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ histogram(42)= 0 1 23 1
@@ -252,7 +252,7 @@ column_names row_count_est row_count_err distinct_count_est distinct_coun
{ps_availqty} 32258.00 1.02 9536.00 1.00 0.00 1.00
{ps_partkey} 32258.00 1.02 29783.00 1.00 0.00 1.00
{ps_suppkey} 32258.00 1.02 400.00 1.01 0.00 1.00
-{ps_supplycost} 32258.00 1.02 1000.00 27.35 <== 0.00 1.00
+{ps_supplycost} 32258.00 1.02 27589.00 1.01 0.00 1.00
{s_nationkey} 32258.00 1.02 1.00 1.00 0.00 1.00
{s_suppkey} 32258.00 1.02 400.00 1.01 0.00 1.00
@@ -340,7 +340,7 @@ column_names row_count_est row_count_err distinct_count_est distinct_coun
{n_nationkey} 32258.00 1.02 1.00 1.00 0.00 1.00
{ps_availqty} 32258.00 1.02 9536.00 1.00 0.00 1.00
{ps_suppkey} 32258.00 1.02 400.00 1.01 0.00 1.00
-{ps_supplycost} 32258.00 1.02 1000.00 27.35 <== 0.00 1.00
+{ps_supplycost} 32258.00 1.02 27589.00 1.01 0.00 1.00
{s_nationkey} 32258.00 1.02 1.00 1.00 0.00 1.00
{s_suppkey} 32258.00 1.02 400.00 1.01 0.00 1.00
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q12 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q12
index a5dc7799bf12..dad36f16711a 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q12
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q12
@@ -52,7 +52,7 @@ ORDER BY
sort
├── save-table-name: q12_sort_1
├── columns: l_shipmode:26(char!null) high_line_count:31(decimal!null) low_line_count:33(decimal!null)
- ├── stats: [rows=2, distinct(26)=2, null(26)=0, avgsize(26)=4, distinct(31)=2, null(31)=0, avgsize(31)=4, distinct(33)=2, null(33)=0, avgsize(33)=4]
+ ├── stats: [rows=2, distinct(26)=2, null(26)=0, avgsize(26)=7, distinct(31)=2, null(31)=0, avgsize(31)=7, distinct(33)=2, null(33)=0, avgsize(33)=7]
├── key: (26)
├── fd: (26)-->(31,33)
├── ordering: +26
@@ -60,43 +60,43 @@ sort
├── save-table-name: q12_group_by_2
├── columns: l_shipmode:26(char!null) sum:31(decimal!null) sum:33(decimal!null)
├── grouping columns: l_shipmode:26(char!null)
- ├── stats: [rows=2, distinct(26)=2, null(26)=0, avgsize(26)=4, distinct(31)=2, null(31)=0, avgsize(31)=4, distinct(33)=2, null(33)=0, avgsize(33)=4]
+ ├── stats: [rows=2, distinct(26)=2, null(26)=0, avgsize(26)=7, distinct(31)=2, null(31)=0, avgsize(31)=7, distinct(33)=2, null(33)=0, avgsize(33)=7]
├── key: (26)
├── fd: (26)-->(31,33)
├── project
│ ├── save-table-name: q12_project_3
│ ├── columns: column30:30(int!null) column32:32(int!null) l_shipmode:26(char!null)
- │ ├── stats: [rows=29858.68, distinct(26)=2, null(26)=0, avgsize(26)=4, distinct(30)=4, null(30)=0, avgsize(30)=4, distinct(32)=4, null(32)=0, avgsize(32)=4]
+ │ ├── stats: [rows=29610.71, distinct(26)=2, null(26)=0, avgsize(26)=7, distinct(30)=5, null(30)=0, avgsize(30)=11, distinct(32)=5, null(32)=0, avgsize(32)=11]
│ ├── inner-join (lookup orders)
│ │ ├── save-table-name: q12_lookup_join_4
│ │ ├── columns: o_orderkey:1(int!null) o_orderpriority:6(char!null) l_orderkey:12(int!null) l_shipdate:22(date!null) l_commitdate:23(date!null) l_receiptdate:24(date!null) l_shipmode:26(char!null)
│ │ ├── key columns: [12] = [1]
│ │ ├── lookup columns are key
- │ │ ├── stats: [rows=29858.68, distinct(1)=29641.8, null(1)=0, avgsize(1)=4, distinct(6)=4, null(6)=0, avgsize(6)=4, distinct(12)=29641.8, null(12)=0, avgsize(12)=4, distinct(22)=2525.98, null(22)=0, avgsize(22)=4, distinct(23)=2465.99, null(23)=0, avgsize(23)=4, distinct(24)=365, null(24)=0, avgsize(24)=4, distinct(26)=2, null(26)=0, avgsize(26)=4]
+ │ │ ├── stats: [rows=29610.71, distinct(1)=29397.4, null(1)=0, avgsize(1)=4, distinct(6)=5, null(6)=0, avgsize(6)=11, distinct(12)=29397.4, null(12)=0, avgsize(12)=4, distinct(22)=2525.98, null(22)=0, avgsize(22)=4, distinct(23)=2465.98, null(23)=0, avgsize(23)=4, distinct(24)=365, null(24)=0, avgsize(24)=4, distinct(26)=2, null(26)=0, avgsize(26)=7]
│ │ ├── fd: (1)-->(6), (1)==(12), (12)==(1)
│ │ ├── select
│ │ │ ├── save-table-name: q12_select_5
│ │ │ ├── columns: l_orderkey:12(int!null) l_shipdate:22(date!null) l_commitdate:23(date!null) l_receiptdate:24(date!null) l_shipmode:26(char!null)
- │ │ │ ├── stats: [rows=29858.68, distinct(12)=29641.8, null(12)=0, avgsize(12)=4, distinct(22)=2526, null(22)=0, avgsize(22)=4, distinct(23)=2466, null(23)=0, avgsize(23)=4, distinct(24)=365, null(24)=0, avgsize(24)=4, distinct(26)=2, null(26)=0, avgsize(26)=4, distinct(24,26)=730, null(24,26)=0, avgsize(24,26)=8]
- │ │ │ │ histogram(24)= 0 0 181.73 75.722 908.64 56.8 795.07 132.52 851.84 113.57 908.64 94.645 870.76 94.645 908.64 37.845 889.71 37.845 813.99 132.52 870.76 132.52 889.71 132.52 908.64 151.44 908.64 113.57 889.71 56.8 889.71 94.645 889.71 56.8 832.91 132.52 889.71 37.845 813.99 113.57 889.71 151.44 908.64 56.8 908.64 75.722 832.91 113.57 757.19 189.29 832.91 151.44 908.64 170.37 908.64 75.722 889.71 189.29 889.71 56.8 889.71 37.845 908.64 37.845 237.48 79.16
- │ │ │ │ <--- '1993-12-31' -------- '1994-01-03' -------- '1994-01-16' -------- '1994-01-25' -------- '1994-02-04' -------- '1994-02-15' -------- '1994-03-03' -------- '1994-03-15' -------- '1994-03-27' -------- '1994-04-08' -------- '1994-04-18' -------- '1994-04-28' -------- '1994-05-12' -------- '1994-05-24' -------- '1994-06-05' -------- '1994-06-18' -------- '1994-06-30' -------- '1994-07-15' -------- '1994-07-27' -------- '1994-08-08' -------- '1994-08-20' -------- '1994-09-02' -------- '1994-09-15' -------- '1994-09-26' -------- '1994-10-06' -------- '1994-10-16' -------- '1994-10-29' -------- '1994-11-10' -------- '1994-11-23' -------- '1994-12-05' -------- '1994-12-17' -------- '1994-12-27' -------- '1994-12-31'
- │ │ │ │ histogram(26)= 0 14929 0 14929
+ │ │ │ ├── stats: [rows=29610.71, distinct(12)=29397.4, null(12)=0, avgsize(12)=4, distinct(22)=2526, null(22)=0, avgsize(22)=4, distinct(23)=2466, null(23)=0, avgsize(23)=4, distinct(24)=365, null(24)=0, avgsize(24)=4, distinct(26)=2, null(26)=0, avgsize(26)=7, distinct(24,26)=730, null(24,26)=0, avgsize(24,26)=11]
+ │ │ │ │ histogram(24)= 0 94.925 797.26 132.88 816.24 132.88 835.22 151.86 835.22 94.925 854.2 132.88 911.17 37.957 835.22 113.9 835.22 132.88 873.18 94.925 854.2 94.925 873.18 151.86 911.17 37.957 911.17 37.957 854.2 75.915 911.17 18.979 835.22 132.88 911.17 75.915 911.17 37.957 854.2 75.915 892.19 56.936 854.2 94.925 911.17 37.957 816.24 113.9 911.17 151.86 835.22 113.9 892.19 37.957 873.18 94.925 892.19 94.925 873.18 132.88 854.2 94.925 622.63 77.828
+ │ │ │ │ <--- '1994-01-01' -------- '1994-01-13' -------- '1994-01-25' -------- '1994-02-06' -------- '1994-02-18' ------- '1994-03-02' -------- '1994-03-15' -------- '1994-03-28' -------- '1994-04-12' -------- '1994-04-23' ------- '1994-05-08' -------- '1994-05-18' -------- '1994-05-30' -------- '1994-06-11' ------- '1994-06-20' -------- '1994-06-30' -------- '1994-07-10' -------- '1994-07-23' -------- '1994-08-05' ------- '1994-08-15' -------- '1994-08-29' ------- '1994-09-09' -------- '1994-09-21' -------- '1994-09-30' -------- '1994-10-12' -------- '1994-10-22' -------- '1994-11-01' -------- '1994-11-12' -------- '1994-11-27' -------- '1994-12-11' ------- '1994-12-22' -------- '1994-12-31'
+ │ │ │ │ histogram(26)= 0 14805 0 14805
│ │ │ │ <--- 'MAIL' --- 'SHIP'
│ │ │ ├── index-join lineitem
│ │ │ │ ├── save-table-name: q12_index_join_6
│ │ │ │ ├── columns: l_orderkey:12(int!null) l_shipdate:22(date!null) l_commitdate:23(date!null) l_receiptdate:24(date!null) l_shipmode:26(char!null)
- │ │ │ │ ├── stats: [rows=946759.1, distinct(12)=749363, null(12)=0, avgsize(12)=4, distinct(22)=2526, null(22)=0, avgsize(22)=4, distinct(23)=2466, null(23)=0, avgsize(23)=4, distinct(24)=365, null(24)=0, avgsize(24)=4, distinct(26)=7, null(26)=0, avgsize(26)=4]
+ │ │ │ │ ├── stats: [rows=936126, distinct(12)=742921, null(12)=0, avgsize(12)=4, distinct(22)=2526, null(22)=0, avgsize(22)=4, distinct(23)=2466, null(23)=0, avgsize(23)=4, distinct(24)=365, null(24)=0, avgsize(24)=4, distinct(26)=7, null(26)=0, avgsize(26)=7]
│ │ │ │ └── scan lineitem@l_rd
│ │ │ │ ├── save-table-name: q12_scan_7
│ │ │ │ ├── columns: l_orderkey:12(int!null) l_linenumber:15(int!null) l_receiptdate:24(date!null)
│ │ │ │ ├── constraint: /24/12/15: [/'1994-01-01' - /'1994-12-31']
- │ │ │ │ ├── stats: [rows=946759.1, distinct(12)=749363, null(12)=0, avgsize(12)=4, distinct(15)=7, null(15)=0, avgsize(15)=4, distinct(24)=365, null(24)=0, avgsize(24)=4]
- │ │ │ │ │ histogram(12)= 0 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4639.1 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64 4733.7 94.64
- │ │ │ │ │ <--- 576 -------- 38535 -------- 66885 -------- 93380 -------- 127425 -------- 157218 -------- 184483 -------- 215330 -------- 252869 -------- 283878 -------- 313798 -------- 337056 -------- 372549 -------- 399591 -------- 426245 -------- 460578 -------- 498439 -------- 526049 -------- 554468 -------- 577921 -------- 609187 -------- 639524 -------- 665345 -------- 686180 -------- 721539 -------- 755680 -------- 782756 -------- 814496 -------- 845446 -------- 872130 -------- 910912 -------- 933697 -------- 965184 -------- 1000353 -------- 1038658 -------- 1073667 -------- 1097891 -------- 1131330 -------- 1157732 -------- 1179943 -------- 1206401 -------- 1230150 -------- 1261824 -------- 1293217 -------- 1326754 -------- 1357573 -------- 1390145 -------- 1429312 -------- 1460418 -------- 1491104 -------- 1523937 -------- 1559812 -------- 1591653 -------- 1615174 -------- 1646759 -------- 1670465 -------- 1696321 -------- 1724192 -------- 1748033 -------- 1777570 -------- 1807428 -------- 1836962 -------- 1872481 -------- 1902817 -------- 1928324 -------- 1960775 -------- 1985989 -------- 2019107 -------- 2044613 -------- 2071490 -------- 2101959 -------- 2135555 -------- 2164486 -------- 2186337 -------- 2213989 -------- 2246309 -------- 2276992 -------- 2306403 -------- 2329921 -------- 2354977 -------- 2380711 -------- 2410529 -------- 2437920 -------- 2462017 -------- 2483714 -------- 2513920 -------- 2542855 -------- 2574112 -------- 2596035 -------- 2625031 -------- 2658051 -------- 2695046 -------- 2725222 -------- 2754245 -------- 2777702 -------- 2804896 -------- 2844579 -------- 2873860 -------- 2903459 -------- 2933249 -------- 2965479 -------- 2996160 -------- 3022976 -------- 3053152 -------- 3083623 -------- 3111136 -------- 3144033 -------- 3180134 -------- 3209799 -------- 3239394 -------- 3270886 -------- 3297664 -------- 3329444 -------- 3357574 -------- 3380838 -------- 3412196 -------- 3438917 -------- 3462467 -------- 3498629 -------- 3530208 -------- 3562148 -------- 3589889 -------- 3621063 -------- 3655456 -------- 3686724 -------- 3709029 -------- 3738215 -------- 3767687 -------- 3804547 -------- 3831142 -------- 3875111 -------- 3905605 -------- 3933795 -------- 3966593 -------- 3995558 -------- 4020134 -------- 4052513 -------- 4078949 -------- 4114208 -------- 4149762 -------- 4176135 -------- 4207782 -------- 4241376 -------- 4270502 -------- 4304167 -------- 4333669 -------- 4362818 -------- 4393537 -------- 4423076 -------- 4452064 -------- 4491143 -------- 4522723 -------- 4550883 -------- 4581382 -------- 4616002 -------- 4649410 -------- 4680485 -------- 4715584 -------- 4740036 -------- 4771554 -------- 4799461 -------- 4826690 -------- 4855525 -------- 4887974 -------- 4917479 -------- 4950885 -------- 4984195 -------- 5010113 -------- 5033571 -------- 5065472 -------- 5100512 -------- 5129413 -------- 5160069 -------- 5186596 -------- 5221538 -------- 5252964 -------- 5284069 -------- 5314051 -------- 5353026 -------- 5388961 -------- 5424644 -------- 5452676 -------- 5483553 -------- 5516612 -------- 5551041 -------- 5579878 -------- 5612576 -------- 5643427 -------- 5673666 -------- 5709218 -------- 5737221 -------- 5766119 -------- 5795044 -------- 5826560 -------- 5855943 -------- 5889604 -------- 5917607 -------- 5942535 -------- 5969639 -------- 5999557
- │ │ │ │ │ histogram(15)= 0 2.3981e+05 0 2.0081e+05 0 1.6777e+05 0 1.4249e+05 0 94676 0 69019 0 32190
- │ │ │ │ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 -------- 4 ----- 5 ----- 6 -
- │ │ │ │ │ histogram(24)= 0 0 5762.2 2401 28811 1801 25210 4202 27010 3601 28811 3001 27610 3001 28811 1200 28211 1200 25810 4202 27610 4202 28211 4202 28811 4802 28811 3601 28211 1801 28211 3001 28211 1801 26410 4202 28211 1200 25810 3601 28211 4802 28811 1801 28811 2401 26410 3601 24009 6002 26410 4802 28811 5402 28811 2401 28211 6002 28211 1801 28211 1200 28811 1200 7530 2510
- │ │ │ │ │ <--- '1993-12-31' -------- '1994-01-03' ------- '1994-01-16' ------- '1994-01-25' ------- '1994-02-04' ------- '1994-02-15' ------- '1994-03-03' ------- '1994-03-15' ------- '1994-03-27' ------- '1994-04-08' ------- '1994-04-18' ------- '1994-04-28' ------- '1994-05-12' ------- '1994-05-24' ------- '1994-06-05' ------- '1994-06-18' ------- '1994-06-30' ------- '1994-07-15' ------- '1994-07-27' ------- '1994-08-08' ------- '1994-08-20' ------- '1994-09-02' ------- '1994-09-15' ------- '1994-09-26' ------- '1994-10-06' ------- '1994-10-16' ------- '1994-10-29' ------- '1994-11-10' ------- '1994-11-23' ------- '1994-12-05' ------- '1994-12-17' ------- '1994-12-27' ------ '1994-12-31'
+ │ │ │ │ ├── stats: [rows=936126, distinct(12)=742921, null(12)=0, avgsize(12)=4, distinct(15)=7, null(15)=0, avgsize(15)=1, distinct(24)=365, null(24)=0, avgsize(24)=4]
+ │ │ │ │ │ histogram(12)= 0 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4493.4 187.19 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4493.4 187.19 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4493.4 187.19 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4587 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594 4680.6 93.594
+ │ │ │ │ │ <--- 197 ------- 23686 ------ 53253 ------ 90435 ------ 121730 ------ 153280 ------ 175456 ------ 208548 ------ 242209 ------ 273057 -------- 296640 ------ 330307 ------ 360999 ------ 386307 ------ 420225 ------ 450050 ------ 477795 ------ 504711 ------ 533153 ------ 556672 ------ 582243 ------ 613729 ------ 646117 ------ 675840 ------ 706048 ------ 733063 ------ 769282 ------ 793922 ------ 820357 ------ 849536 ------ 875719 ------ 905028 ------ 940643 ------ 968355 ------ 998721 ------ 1023621 ------ 1059424 ------ 1084932 ------ 1115553 ------ 1139363 ------ 1167361 ------ 1194400 ------ 1225984 ------ 1253861 ------ 1281633 ------ 1304999 ------ 1336355 ------ 1370759 ------ 1400832 ------ 1434085 ------ 1458852 ------ 1491427 ------ 1525120 ------ 1555205 ------ 1591300 ------ 1619426 ------ 1651458 ------ 1682950 ------ 1711399 ------ 1747591 ------ 1787205 -------- 1822240 ------ 1856163 ------ 1886915 ------ 1910949 ------ 1947202 -------- 1974311 ------ 2009286 ------ 2044034 ------ 2079104 ------ 2103488 ------ 2134657 ------ 2164293 ------ 2204514 ------ 2230823 ------ 2265253 ------ 2289826 ------ 2329539 ------ 2364455 ------ 2393507 ------ 2414628 ------ 2440228 ------ 2465255 ------ 2489568 ------ 2520900 ------ 2554919 ------ 2583333 ------ 2612966 ------ 2644833 ------ 2667362 ------ 2702784 ------ 2727394 ------ 2759748 ------ 2794531 ------ 2822214 ------ 2846624 ------ 2883748 ------ 2919586 ------ 2951908 ------ 2980068 ------ 3014726 ------ 3050725 ------ 3081028 ------ 3113351 ------ 3150243 ------ 3185669 ------ 3214311 ------ 3241281 ------ 3275748 ------ 3303232 ------ 3339559 ------ 3370627 ------ 3393664 ------ 3435265 ------ 3464581 ------ 3489026 ------ 3516096 ------ 3548480 ------ 3587015 ------ 3611239 ------ 3638724 ------ 3668641 ------ 3695751 ------ 3729636 ------ 3751523 ------ 3784608 ------ 3815715 ------ 3848608 ------ 3881184 ------ 3908738 ------ 3940002 ------ 3966176 ------ 4001984 ------ 4035687 ------ 4065283 ------ 4092834 ------ 4133062 ------ 4160613 ------ 4196421 ------ 4223713 ------ 4254788 ------ 4291040 ------ 4313664 ------ 4342823 ------ 4369952 ------ 4391684 ------ 4419040 ------ 4449921 ------ 4471781 ------ 4506210 ------ 4538176 -------- 4571297 -------- 4601121 -------- 4630887 -------- 4657476 -------- 4684803 -------- 4714566 -------- 4744070 -------- 4776385 -------- 4807777 -------- 4839491 -------- 4873953 -------- 4902245 -------- 4936263 -------- 4970721 -------- 5003140 -------- 5029729 -------- 5059010 -------- 5087521 -------- 5121093 -------- 5150405 -------- 5178375 -------- 5203683 -------- 5234531 -------- 5268195 -------- 5300004 -------- 5331558 -------- 5362178 -------- 5385762 -------- 5418498 -------- 5445762 -------- 5483109 -------- 5514561 -------- 5542052 -------- 5569572 -------- 5596102 -------- 5622401 -------- 5652194 -------- 5671362 -------- 5699591 -------- 5727136 -------- 5753284 -------- 5780742 -------- 5809189 -------- 5836545 -------- 5864454 -------- 5894917 -------- 5933825 -------- 5968933 -------- 5999590
+ │ │ │ │ │ histogram(15)= 0 2.3207e+05 0 2.0885e+05 0 1.642e+05 0 1.3443e+05 0 99323 0 64780 0 32484
+ │ │ │ │ │ <------ 1 ---------- 2 ---------- 3 --------- 4 -------- 5 ----- 6 ----- 7 -
+ │ │ │ │ │ histogram(24)= 0 3001 25205 4201 25805 4201 26405 4801 26405 3001 27005 4201 28806 1200 26405 3601 26405 4201 27605 3001 27005 3001 27605 4801 28806 1200 28806 1200 27005 2400 28806 600 26405 4201 28806 2400 28806 1200 27005 2400 28206 1800 27005 3001 28806 1200 25805 3601 28806 4801 26405 3601 28206 1200 27605 3001 28206 3001 27605 4201 27005 3001 19684 2460.5
+ │ │ │ │ │ <--- '1994-01-01' ------- '1994-01-13' ------- '1994-01-25' ------- '1994-02-06' ------- '1994-02-18' ------- '1994-03-02' ------- '1994-03-15' ------- '1994-03-28' ------- '1994-04-12' ------- '1994-04-23' ------- '1994-05-08' ------- '1994-05-18' ------- '1994-05-30' ------- '1994-06-11' ------- '1994-06-20' ------- '1994-06-30' ------- '1994-07-10' ------- '1994-07-23' ------- '1994-08-05' ------- '1994-08-15' ------- '1994-08-29' ------- '1994-09-09' ------- '1994-09-21' ------- '1994-09-30' ------- '1994-10-12' ------- '1994-10-22' ------- '1994-11-01' ------- '1994-11-12' ------- '1994-11-27' ------- '1994-12-11' ------- '1994-12-22' ------- '1994-12-31'
│ │ │ │ ├── key: (12,15)
│ │ │ │ └── fd: (12,15)-->(24)
│ │ │ └── filters
@@ -142,9 +142,9 @@ column_names row_count distinct_count null_count
{l_shipmode} 30988 2 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column30} 29859.00 1.04 4.00 2.00 <== 0.00 1.00
-{column32} 29859.00 1.04 4.00 2.00 <== 0.00 1.00
-{l_shipmode} 29859.00 1.04 2.00 1.00 0.00 1.00
+{column30} 29611.00 1.05 5.00 2.50 <== 0.00 1.00
+{column32} 29611.00 1.05 5.00 2.50 <== 0.00 1.00
+{l_shipmode} 29611.00 1.05 2.00 1.00 0.00 1.00
----Stats for q12_lookup_join_4----
column_names row_count distinct_count null_count
@@ -157,13 +157,13 @@ column_names row_count distinct_count null_count
{o_orderpriority} 30988 5 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 29859.00 1.04 2466.00 6.29 <== 0.00 1.00
-{l_orderkey} 29859.00 1.04 29642.00 1.03 0.00 1.00
-{l_receiptdate} 29859.00 1.04 365.00 1.00 0.00 1.00
-{l_shipdate} 29859.00 1.04 2526.00 6.46 <== 0.00 1.00
-{l_shipmode} 29859.00 1.04 2.00 1.00 0.00 1.00
-{o_orderkey} 29859.00 1.04 29642.00 1.03 0.00 1.00
-{o_orderpriority} 29859.00 1.04 4.00 1.25 0.00 1.00
+{l_commitdate} 29611.00 1.05 2466.00 6.29 <== 0.00 1.00
+{l_orderkey} 29611.00 1.05 29397.00 1.02 0.00 1.00
+{l_receiptdate} 29611.00 1.05 365.00 1.00 0.00 1.00
+{l_shipdate} 29611.00 1.05 2526.00 6.46 <== 0.00 1.00
+{l_shipmode} 29611.00 1.05 2.00 1.00 0.00 1.00
+{o_orderkey} 29611.00 1.05 29397.00 1.02 0.00 1.00
+{o_orderpriority} 29611.00 1.05 5.00 1.00 0.00 1.00
----Stats for q12_select_5----
column_names row_count distinct_count null_count
@@ -174,11 +174,11 @@ column_names row_count distinct_count null_count
{l_shipmode} 30988 2 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 29859.00 1.04 2466.00 6.29 <== 0.00 1.00
-{l_orderkey} 29859.00 1.04 29642.00 1.03 0.00 1.00
-{l_receiptdate} 29859.00 1.04 365.00 1.00 0.00 1.00
-{l_shipdate} 29859.00 1.04 2526.00 6.46 <== 0.00 1.00
-{l_shipmode} 29859.00 1.04 2.00 1.00 0.00 1.00
+{l_commitdate} 29611.00 1.05 2466.00 6.29 <== 0.00 1.00
+{l_orderkey} 29611.00 1.05 29397.00 1.02 0.00 1.00
+{l_receiptdate} 29611.00 1.05 365.00 1.00 0.00 1.00
+{l_shipdate} 29611.00 1.05 2526.00 6.46 <== 0.00 1.00
+{l_shipmode} 29611.00 1.05 2.00 1.00 0.00 1.00
----Stats for q12_index_join_6----
column_names row_count distinct_count null_count
@@ -189,11 +189,11 @@ column_names row_count distinct_count null_count
{l_shipmode} 909844 7 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 946759.00 1.04 2466.00 4.40 <== 0.00 1.00
-{l_orderkey} 946759.00 1.04 749363.00 2.80 <== 0.00 1.00
-{l_receiptdate} 946759.00 1.04 365.00 1.00 0.00 1.00
-{l_shipdate} 946759.00 1.04 2526.00 6.41 <== 0.00 1.00
-{l_shipmode} 946759.00 1.04 7.00 1.00 0.00 1.00
+{l_commitdate} 936126.00 1.03 2466.00 4.40 <== 0.00 1.00
+{l_orderkey} 936126.00 1.03 742921.00 2.77 <== 0.00 1.00
+{l_receiptdate} 936126.00 1.03 365.00 1.00 0.00 1.00
+{l_shipdate} 936126.00 1.03 2526.00 6.41 <== 0.00 1.00
+{l_shipmode} 936126.00 1.03 7.00 1.00 0.00 1.00
----Stats for q12_scan_7----
column_names row_count distinct_count null_count
@@ -202,8 +202,8 @@ column_names row_count distinct_count null_count
{l_receiptdate} 909844 365 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 946759.00 1.04 7.00 1.00 0.00 1.00
-{l_orderkey} 946759.00 1.04 749363.00 2.80 <== 0.00 1.00
-{l_receiptdate} 946759.00 1.04 365.00 1.00 0.00 1.00
+{l_linenumber} 936126.00 1.03 7.00 1.00 0.00 1.00
+{l_orderkey} 936126.00 1.03 742921.00 2.77 <== 0.00 1.00
+{l_receiptdate} 936126.00 1.03 365.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q13 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q13
index 8369d354174b..d229a28d674d 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q13
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q13
@@ -60,25 +60,25 @@ sort
│ ├── right-join (hash)
│ │ ├── save-table-name: q13_right_join_4
│ │ ├── columns: c_custkey:1(int!null) o_orderkey:11(int) o_custkey:12(int) o_comment:19(varchar)
- │ │ ├── stats: [rows=503988.2, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(11)=317522, null(11)=0, avgsize(11)=4, distinct(12)=99627, null(12)=0, avgsize(12)=4, distinct(19)=317522, null(19)=0, avgsize(19)=4]
+ │ │ ├── stats: [rows=503988.2, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(11)=317522, null(11)=0, avgsize(11)=4, distinct(12)=99620.1, null(12)=0, avgsize(12)=4, distinct(19)=317522, null(19)=0, avgsize(19)=51]
│ │ ├── key: (1,11)
│ │ ├── fd: (11)-->(12,19)
│ │ ├── select
│ │ │ ├── save-table-name: q13_select_5
│ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_comment:19(varchar!null)
- │ │ │ ├── stats: [rows=500000, distinct(11)=500000, null(11)=0, avgsize(11)=4, distinct(12)=99627, null(12)=0, avgsize(12)=4, distinct(19)=500000, null(19)=0, avgsize(19)=4]
+ │ │ │ ├── stats: [rows=500000, distinct(11)=500000, null(11)=0, avgsize(11)=4, distinct(12)=99620.1, null(12)=0, avgsize(12)=4, distinct(19)=500000, null(19)=0, avgsize(19)=51]
│ │ │ ├── key: (11)
│ │ │ ├── fd: (11)-->(12,19)
│ │ │ ├── scan orders
│ │ │ │ ├── save-table-name: q13_scan_6
│ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_comment:19(varchar!null)
- │ │ │ │ ├── stats: [rows=1500000, distinct(11)=1.5e+06, null(11)=0, avgsize(11)=4, distinct(12)=99853, null(12)=0, avgsize(12)=4, distinct(19)=1.47385e+06, null(19)=0, avgsize(19)=4]
- │ │ │ │ │ histogram(11)= 0 0 0 0.99998 7461.9 0.99998 7285.9 0.99998 7544.9 0.99998 7589.9 0.99998 7222.9 0.99998 7324.9 0.99998 7506.9 0.99998 7351.9 0.99998 7777.9 0.99998 7576.9 0.99998 7731.9 0.99998 7694.9 0.99998 7586.9 0.99998 7569.9 0.99998 7757.9 0.99998 7624.9 0.99998 7506.9 0.99998 7245.9 0.99998 7820.9 0.99998 7539.9 0.99998 7455.9 0.99998 7589.9 0.99998 7740.9 0.99998 7604.9 0.99998 7710.9 0.99998 7709.9 0.99998 7708.9 0.99998 7490.9 0.99998 7527.9 0.99998 7331.9 0.99998 7311.9 0.99998 7576.9 0.99998 7545.9 0.99998 7277.9 0.99998 7392.9 0.99998 7508.9 0.99998 7622.9 0.99998 7581.9 0.99998 7775.9 0.99998 7523.9 0.99998 7568.9 0.99998 7483.9 0.99998 7662.9 0.99998 7368.9 0.99998 7470.9 0.99998 7380.9 0.99998 7647.9 0.99998 7381.9 0.99998 7635.9 0.99998 7490.9 0.99998 7446.9 0.99998 7526.9 0.99998 7441.9 0.99998 7265.9 0.99998 7960.9 0.99998 7251.9 0.99998 7514.9 0.99998 7294.9 0.99998 7502.9 0.99998 7285.9 0.99998 7320.9 0.99998 7235.9 0.99998 7451.9 0.99998 7810.9 0.99998 7378.9 0.99998 7418.9 0.99998 7661.9 0.99998 7404.9 0.99998 7432.9 0.99998 7579.9 0.99998 7836.9 0.99998 7445.9 0.99998 7355.9 0.99998 7617.9 0.99998 7110.9 0.99998 7398.9 0.99998 7622.9 0.99998 7655.9 0.99998 7433.9 0.99998 7656.9 0.99998 7404.9 0.99998 7474.9 0.99998 7572.9 0.99998 7688.9 0.99998 7559.9 0.99998 7414.9 0.99998 7523.9 0.99998 7558.9 0.99998 7330.9 0.99998 7587.9 0.99998 7388.9 0.99998 7327.9 0.99998 7671.9 0.99998 7523.9 0.99998 7687.9 0.99998 7524.9 0.99998 7614.9 0.99998 7463.9 0.99998 7594.9 0.99998 7372.9 0.99998 7670.9 0.99998 7310.9 0.99998 7270.9 0.99998 7399.9 0.99998 7688.9 0.99998 7487.9 0.99998 7556.9 0.99998 7365.9 0.99998 7521.9 0.99998 7762.9 0.99998 7386.9 0.99998 7399.9 0.99998 7562.9 0.99998 7502.9 0.99998 7201.9 0.99998 7595.9 0.99998 7525.9 0.99998 7451.9 0.99998 7280.9 0.99998 7307.9 0.99998 7386.9 0.99998 7345.9 0.99998 7383.9 0.99998 7530.9 0.99998 7706.9 0.99998 7581.9 0.99998 7512.9 0.99998 7536.9 0.99998 7210.9 0.99998 7689.9 0.99998 7658.9 0.99998 7358.9 0.99998 7646.9 0.99998 7252.9 0.99998 7327.9 0.99998 7525.9 0.99998 7564.9 0.99998 7524.9 0.99998 7438.9 0.99998 7493.9 0.99998 7419.9 0.99998 7509.9 0.99998 7595.9 0.99998 7396.9 0.99998 7378.9 0.99998 7330.9 0.99998 7387.9 0.99998 7552.9 0.99998 7330.9 0.99998 7431.9 0.99998 7773.9 0.99998 7853.9 0.99998 7562.9 0.99998 7548.9 0.99998 7847.9 0.99998 7933.9 0.99998 7768.9 0.99998 7738.9 0.99998 7480.9 0.99998 7679.9 0.99998 7663.9 0.99998 7587.9 0.99998 7527.9 0.99998 7466.9 0.99998 7444.9 0.99998 7519.9 0.99998 7830.9 0.99998 7568.9 0.99998 7671.9 0.99998 7637.9 0.99998 7462.9 0.99998 7851.9 0.99998 7483.9 0.99998 7765.9 0.99998 7451.9 0.99998 8050.9 0.99998 7644.9 0.99998 7724.9 0.99998 7471.9 0.99998 7517.9 0.99998 7830.9 0.99998 7387.9 0.99998 7749.9 0.99998 7545.9 0.99998 7718.9 0.99998 7384.9 0.99998 7464.9 0.99998 7467.9 0.99998 7809.9 0.99998 7766.9 0.99998 7511.9 0.99998 7641.9 0.99998 7711.9 0.99998 7729.9 0.99998 7631.9 0.99998 7734.9 0.99998 7931.9 0.99998 7586.9 0.99998 7964.9 0.99998 0 0
- │ │ │ │ │ <--- -9223372036854775808 --- 1472 --------- 30469 -------- 54689 -------- 85922 -------- 118369 -------- 140867 -------- 166146 -------- 196357 -------- 222375 -------- 259877 -------- 291970 -------- 328227 -------- 363490 -------- 395873 -------- 427783 -------- 464741 -------- 498146 -------- 528358 -------- 551493 -------- 590144 -------- 621254 -------- 650083 -------- 682531 -------- 719041 -------- 751906 -------- 787617 -------- 823298 -------- 858944 -------- 888739 -------- 919527 -------- 944996 -------- 969922 -------- 1002020 -------- 1033280 -------- 1057284 -------- 1084416 -------- 1114693 -------- 1148034 -------- 1180262 -------- 1217697 -------- 1248386 -------- 1280261 -------- 1309862 -------- 1344263 -------- 1370759 -------- 1400003 -------- 1426822 -------- 1460837 -------- 1487680 -------- 1521376 -------- 1551174 -------- 1579779 -------- 1610532 -------- 1638983 -------- 1662660 -------- 1705024 -------- 1728321 -------- 1758757 -------- 1783239 -------- 1813344 -------- 1837573 -------- 1862757 -------- 1885607 -------- 1914340 -------- 1952706 -------- 1979458 -------- 2007302 -------- 2041697 -------- 2069157 -------- 2097383 -------- 2129571 -------- 2168643 -------- 2197223 -------- 2223363 -------- 2256577 -------- 2275975 -------- 2303264 -------- 2336608 -------- 2370823 -------- 2399074 -------- 2433315 -------- 2460771 -------- 2490114 -------- 2522119 -------- 2557218 -------- 2588866 -------- 2616610 -------- 2647296 -------- 2678913 -------- 2704354 -------- 2736743 -------- 2763779 -------- 2789157 -------- 2823812 -------- 2854502 -------- 2889572 -------- 2920263 -------- 2953378 -------- 2982439 -------- 3015013 -------- 3041603 -------- 3076227 -------- 3101125 -------- 3124930 -------- 3152260 -------- 3187366 -------- 3217059 -------- 3248611 -------- 3275008 -------- 3305634 -------- 3342721 -------- 3369702 -------- 3397031 -------- 3428771 -------- 3458885 -------- 3480806 -------- 3513408 -------- 3544129 -------- 3572866 -------- 3596965 -------- 3621794 -------- 3648771 -------- 3674624 -------- 3701510 -------- 3732387 -------- 3767974 -------- 3800224 -------- 3830599 -------- 3861635 -------- 3883808 -------- 3918949 -------- 3953249 -------- 3979456 -------- 4013443 -------- 4036775 -------- 4062148 -------- 4092867 -------- 4124641 -------- 4155333 -------- 4183718 -------- 4213574 -------- 4241445 -------- 4271751 -------- 4304354 -------- 4331590 -------- 4358338 -------- 4383782 -------- 4410791 -------- 4442244 -------- 4467687 -------- 4495876 -------- 4529761 -------- 4565792 -------- 4593991 -------- 4621829 -------- 4657703 -------- 4695878 -------- 4729632 -------- 4762593 -------- 4788581 -------- 4819943 -------- 4850885 -------- 4879777 -------- 4907042 -------- 4932640 -------- 4957638 -------- 4984675 -------- 5020100 -------- 5048481 -------- 5079622 -------- 5109862 -------- 5135363 -------- 5171364 -------- 5197414 -------- 5231104 -------- 5256289 -------- 5297604 -------- 5328038 -------- 5360608 -------- 5386337 -------- 5413315 -------- 5448743 -------- 5472197 -------- 5505440 -------- 5533184 -------- 5565603 -------- 5588963 -------- 5614503 -------- 5640135 -------- 5675008 -------- 5708709 -------- 5735522 -------- 5765862 -------- 5798085 -------- 5830787 -------- 5860867 -------- 5893703 -------- 5931844 -------- 5960706 -------- 5999719 --- 9223372036854775807
- │ │ │ │ │ histogram(12)= 0 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7200 450 7350 150 7200 300 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7200 300 7350 150 7200 300 7350 300 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 450 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 300 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 150 7500 150 7350 300 7500 150 7500 150 7500 150 7500 150 7500 150
- │ │ │ │ │ <--- 25 ------ 758 ------ 1460 ------ 2207 ------ 2911 ------ 3766 ------ 4592 ------ 5371 ------ 6080 ------ 6773 ------ 7421 ------ 8009 ------ 8668 ------ 9583 ------ 10459 ------ 11120 ------ 11872 ------ 12722 ------ 13612 ------ 14390 ------ 15179 ------ 15862 ------ 16658 ------ 17234 ------ 18083 ------ 18862 ------ 19577 ------ 20138 ------ 20869 ------ 21644 ------ 22265 ------ 23105 ------ 23966 ------ 24782 ------ 25532 ------ 26317 ------ 27071 ------ 27664 ------ 28414 ------ 29291 ------ 30097 ------ 30917 ------ 31571 ------ 32357 ------ 33175 ------ 33820 ------ 34678 ------ 35311 ------ 35935 ------ 36689 ------ 37360 ------ 37969 ------ 38792 ------ 39442 ------ 40268 ------ 41044 ------ 41656 ------ 42370 ------ 43085 ------ 43909 ------ 44672 ------ 45326 ------ 46310 ------ 47150 ------ 47801 ------ 48563 ------ 49336 ------ 50111 ------ 50747 ------ 51631 ------ 52250 ------ 52873 ------ 53753 ------ 54632 ------ 55324 ------ 56141 ------ 56924 ------ 57524 ------ 58382 ------ 59069 ------ 59915 ------ 60779 ------ 61466 ------ 62306 ------ 63041 ------ 63799 ------ 64415 ------ 65452 ------ 66266 ------ 67055 ------ 67754 ------ 68510 ------ 69350 ------ 70127 ------ 70702 ------ 71462 ------ 72428 ------ 73267 ------ 74005 ------ 74719 ------ 75695 ------ 76400 ------ 77000 ------ 77953 ------ 78557 ------ 79315 ------ 79925 ------ 80530 ------ 81220 ------ 81902 ------ 82607 ------ 83179 ------ 84025 ------ 84970 ------ 85844 ------ 86657 ------ 87184 ------ 88037 ------ 88840 ------ 89531 ------ 90134 ------ 90893 ------ 91651 ------ 92528 ------ 93278 ------ 93944 ------ 94579 ------ 95708 ------ 96323 ------ 97174 ------ 97856 ------ 98602 ------ 99260 ------ 99967 ------ 100567 ------ 101209 ------ 101923 ------ 102734 ------ 103540 ------ 104402 ------ 105101 ------ 105854 ------ 106667 ------ 107584 ------ 108601 ------ 109366 ------ 110185 ------ 111109 ------ 112079 ------ 112712 ------ 113375 ------ 114088 ------ 114719 ------ 115409 ------ 116246 ------ 117028 ------ 117703 ------ 118441 ------ 119161 ------ 119911 ------ 120542 ------ 121391 ------ 122210 ------ 123049 ------ 123794 ------ 124418 ------ 125149 ------ 125963 ------ 126791 ------ 127537 ------ 128390 ------ 129067 ------ 129604 ------ 130400 ------ 131039 ------ 131752 ------ 132460 ------ 133154 ------ 133693 ------ 134515 ------ 135289 ------ 135959 ------ 136651 ------ 137456 ------ 138158 ------ 138947 ------ 139789 ------ 140599 ------ 141446 ------ 142318 ------ 143132 ------ 143698 ------ 144484 ------ 145376 ------ 146068 ------ 146774 ------ 147730 ------ 148436 ------ 149324 ------ 149992
- │ │ │ │ │ histogram(19)= 0 150 1.4997e+06 150
- │ │ │ │ │ <--- ' A factor person not up industry per' ------------ 'zine. Wonder population enter share directo'
+ │ │ │ │ ├── stats: [rows=1500000, distinct(11)=1.5e+06, null(11)=0, avgsize(11)=4, distinct(12)=99846, null(12)=0, avgsize(12)=4, distinct(19)=1.4694e+06, null(19)=0, avgsize(19)=51]
+ │ │ │ │ │ histogram(11)= 0 0 0 0.99998 7406.9 0.99998 7327.9 0.99998 7748.9 0.99998 7433.9 0.99998 8029.9 0.99998 7265.9 0.99998 7439.9 0.99998 7823.9 0.99998 7526.9 0.99998 7553.9 0.99998 7426.9 0.99998 7490.9 0.99998 7595.9 0.99998 7527.9 0.99998 7640.9 0.99998 7593.9 0.99998 7384.9 0.99998 7713.9 0.99998 7409.9 0.99998 7249.9 0.99998 7518.9 0.99998 7434.9 0.99998 7575.9 0.99998 7471.9 0.99998 7302.9 0.99998 7109.9 0.99998 7646.9 0.99998 7619.9 0.99998 7579.9 0.99998 7489.9 0.99998 7409.9 0.99998 7619.9 0.99998 7805.9 0.99998 7418.9 0.99998 7454.9 0.99998 7651.9 0.99998 7407.9 0.99998 7278.9 0.99998 7402.9 0.99998 7375.9 0.99998 7375.9 0.99998 7517.9 0.99998 7626.9 0.99998 7675.9 0.99998 7470.9 0.99998 7352.9 0.99998 7597.9 0.99998 7649.9 0.99998 7509.9 0.99998 7320.9 0.99998 7287.9 0.99998 7365.9 0.99998 7381.9 0.99998 7478.9 0.99998 7526.9 0.99998 7233.9 0.99998 7676.9 0.99998 7400.9 0.99998 7739.9 0.99998 7638.9 0.99998 7515.9 0.99998 7211.9 0.99998 7231.9 0.99998 7194.9 0.99998 7187.9 0.99998 7885.9 0.99998 7359.9 0.99998 7301.9 0.99998 7493.9 0.99998 7529.9 0.99998 7558.9 0.99998 7148.9 0.99998 7437.9 0.99998 7337.9 0.99998 7299.9 0.99998 7683.9 0.99998 7430.9 0.99998 7252.9 0.99998 7440.9 0.99998 7467.9 0.99998 7694.9 0.99998 7528.9 0.99998 7441.9 0.99998 7694.9 0.99998 7737.9 0.99998 7523.9 0.99998 7400.9 0.99998 7523.9 0.99998 7700.9 0.99998 7156.9 0.99998 7352.9 0.99998 7359.9 0.99998 7334.9 0.99998 7444.9 0.99998 7766.9 0.99998 7675.9 0.99998 7511.9 0.99998 7616.9 0.99998 7308.9 0.99998 7593.9 0.99998 7296.9 0.99998 7557.9 0.99998 7416.9 0.99998 7613.9 0.99998 7421.9 0.99998 7322.9 0.99998 7584.9 0.99998 7726.9 0.99998 7495.9 0.99998 7434.9 0.99998 7337.9 0.99998 7450.9 0.99998 7576.9 0.99998 7245.9 0.99998 7625.9 0.99998 7748.9 0.99998 7417.9 0.99998 7701.9 0.99998 7437.9 0.99998 7345.9 0.99998 7517.9 0.99998 7621.9 0.99998 7359.9 0.99998 7393.9 0.99998 7632.9 0.99998 7715.9 0.99998 7558.9 0.99998 7350.9 0.99998 7557.9 0.99998 7400.9 0.99998 7297.9 0.99998 7875.9 0.99998 7364.9 0.99998 7332.9 0.99998 7458.9 0.99998 7471.9 0.99998 7564.9 0.99998 7523.9 0.99998 7270.9 0.99998 7309.9 0.99998 7418.9 0.99998 7959.9 0.99998 7382.9 0.99998 7507.9 0.99998 7524.9 0.99998 7566.9 0.99998 7705.9 0.99998 7841.9 0.99998 7483.9 0.99998 7685.9 0.99998 7605.9 0.99998 7677.9 0.99998 7647.9 0.99998 7985.9 0.99998 7859.9 0.99998 7673.9 0.99998 7732.9 0.99998 7501.9 0.99998 7498.9 0.99998 7596.9 0.99998 7572.9 0.99998 7848.9 0.99998 7567.9 0.99998 7549.9 0.99998 7493.9 0.99998 7869.9 0.99998 7508.9 0.99998 7626.9 0.99998 7774.9 0.99998 7908.9 0.99998 7501.9 0.99998 7841.9 0.99998 7542.9 0.99998 7623.9 0.99998 7523.9 0.99998 7548.9 0.99998 7977.9 0.99998 7569.9 0.99998 7916.9 0.99998 7613.9 0.99998 7883.9 0.99998 7579.9 0.99998 8076.9 0.99998 7698.9 0.99998 7635.9 0.99998 7530.9 0.99998 7515.9 0.99998 7673.9 0.99998 7781.9 0.99998 7698.9 0.99998 7482.9 0.99998 7805.9 0.99998 7774.9 0.99998 7657.9 0.99998 7655.9 0.99998 7579.9 0.99998 7506.9 0.99998 7736.9 0.99998 7584.9 0.99998 0 0
+ │ │ │ │ │ <--- -9223372036854775808 --- 1505 --------- 29025 -------- 54400 -------- 91106 -------- 119366 -------- 163554 -------- 187236 -------- 215651 -------- 254373 -------- 285123 -------- 316614 -------- 344678 -------- 374465 -------- 407078 -------- 437861 -------- 471683 -------- 504230 -------- 531168 -------- 566951 -------- 594561 -------- 617825 -------- 648358 -------- 676640 -------- 708706 -------- 737986 -------- 762690 -------- 782081 -------- 816064 -------- 849318 -------- 881511 -------- 911271 -------- 938885 -------- 972135 -------- 1010370 -------- 1038212 -------- 1067041 -------- 1101158 -------- 1128704 -------- 1152742 -------- 1180165 -------- 1206852 -------- 1233537 -------- 1264064 -------- 1297504 -------- 1332260 -------- 1361504 -------- 1387553 -------- 1420224 -------- 1454275 -------- 1484580 -------- 1509766 -------- 1534050 -------- 1560452 -------- 1587299 -------- 1616771 -------- 1647526 -------- 1670343 -------- 1705121 -------- 1732486 -------- 1768967 -------- 1802725 -------- 1833189 -------- 1855398 -------- 1878146 -------- 1899877 -------- 1921414 -------- 1961765 -------- 1988000 -------- 2012672 -------- 2042529 -------- 2073381 -------- 2104999 -------- 2125477 -------- 2153825 -------- 2179462 -------- 2204065 -------- 2239044 -------- 2267205 -------- 2290530 -------- 2318977 -------- 2348134 -------- 2383399 -------- 2414215 -------- 2442695 -------- 2477955 -------- 2514372 -------- 2545062 -------- 2572418 -------- 2603108 -------- 2638534 -------- 2659232 -------- 2685286 -------- 2711527 -------- 2737088 -------- 2765639 -------- 2802818 -------- 2837570 -------- 2867911 -------- 2901088 -------- 2925954 -------- 2958501 -------- 2983042 -------- 3014626 -------- 3042406 -------- 3075489 -------- 3103425 -------- 3128673 -------- 3160994 -------- 3197125 -------- 3227043 -------- 3255328 -------- 3280965 -------- 3309669 -------- 3341767 -------- 3364898 -------- 3398305 -------- 3435008 -------- 3462818 -------- 3498272 -------- 3526631 -------- 3552485 -------- 3583014 -------- 3616322 -------- 3642566 -------- 3669732 -------- 3703330 -------- 3739170 -------- 3770791 -------- 3796804 -------- 3828387 -------- 3855751 -------- 3880321 -------- 3920422 -------- 3946818 -------- 3972322 -------- 4001250 -------- 4030533 -------- 4062306 -------- 4092992 -------- 4116803 -------- 4141697 -------- 4169536 -------- 4211878 -------- 4238753 -------- 4268994 -------- 4299686 -------- 4331525 -------- 4367079 -------- 4406277 -------- 4435878 -------- 4470914 -------- 4500294 -------- 4531617 -------- 4562114 -------- 4601666 -------- 4637856 -------- 4669060 -------- 4701861 -------- 4728416 -------- 4754881 -------- 4784001 -------- 4812482 -------- 4848389 -------- 4876741 -------- 4904612 -------- 4930945 -------- 4967397 -------- 4994146 -------- 5024099 -------- 5058023 -------- 5095527 -------- 5122081 -------- 5157798 -------- 5185472 -------- 5215332 -------- 5242497 -------- 5270338 -------- 5309699 -------- 5338112 -------- 5375843 -------- 5405441 -------- 5442277 -------- 5470945 -------- 5512930 -------- 5544807 -------- 5574980 -------- 5602340 -------- 5629280 -------- 5660482 -------- 5694599 -------- 5726466 -------- 5752519 -------- 5787268 -------- 5821185 -------- 5851973 -------- 5882689 -------- 5911363 -------- 5938052 -------- 5970949 -------- 5999748 --- 9223372036854775807
+ │ │ │ │ │ histogram(12)= 0 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7200 450 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 300 7350 300 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7500 150 7500 300 7350 150 7500 300 7350 150 7500 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 300 7350 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150
+ │ │ │ │ │ <--- 4 ------ 959 ------ 1858 ------ 2773 ------ 3466 ------ 4333 ------ 5026 ------ 5872 ------ 6571 ------ 7069 ------ 7897 ------ 8611 ------ 9514 ------ 10309 ------ 11038 ------ 11893 ------ 12632 ------ 13450 ------ 14104 ------ 14923 ------ 15719 ------ 16382 ------ 17119 ------ 17882 ------ 18701 ------ 19576 ------ 20314 ------ 20950 ------ 21727 ------ 22261 ------ 23059 ------ 23692 ------ 24488 ------ 25144 ------ 25895 ------ 26747 ------ 27650 ------ 28408 ------ 29140 ------ 29920 ------ 30511 ------ 31261 ------ 31999 ------ 32920 ------ 33688 ------ 34525 ------ 35197 ------ 35876 ------ 36580 ------ 37313 ------ 37924 ------ 38768 ------ 39440 ------ 40127 ------ 41005 ------ 41810 ------ 42422 ------ 43310 ------ 44095 ------ 44644 ------ 45347 ------ 45970 ------ 46634 ------ 47284 ------ 48055 ------ 48850 ------ 49712 ------ 50356 ------ 51268 ------ 52048 ------ 52571 ------ 53125 ------ 54088 ------ 54913 ------ 55771 ------ 56386 ------ 57085 ------ 57877 ------ 58729 ------ 59353 ------ 60133 ------ 60947 ------ 61672 ------ 62411 ------ 63296 ------ 64000 ------ 64586 ------ 65251 ------ 65914 ------ 66403 ------ 66991 ------ 67798 ------ 68494 ------ 69406 ------ 70106 ------ 70921 ------ 71770 ------ 72482 ------ 73256 ------ 74083 ------ 74681 ------ 75412 ------ 76201 ------ 76876 ------ 77684 ------ 78421 ------ 79058 ------ 79909 ------ 80591 ------ 81247 ------ 81964 ------ 82835 ------ 83731 ------ 84467 ------ 85012 ------ 85874 ------ 86647 ------ 87151 ------ 87853 ------ 88543 ------ 89425 ------ 90046 ------ 90640 ------ 91544 ------ 92257 ------ 93107 ------ 93835 ------ 94424 ------ 95383 ------ 96313 ------ 96938 ------ 97808 ------ 98689 ------ 99505 ------ 100144 ------ 100981 ------ 101797 ------ 102556 ------ 103504 ------ 104113 ------ 104980 ------ 105622 ------ 106241 ------ 106988 ------ 107578 ------ 108302 ------ 108905 ------ 109765 ------ 110663 ------ 111409 ------ 112093 ------ 113033 ------ 113683 ------ 114346 ------ 115006 ------ 115798 ------ 116261 ------ 116908 ------ 117610 ------ 118319 ------ 119203 ------ 120058 ------ 120922 ------ 121702 ------ 122486 ------ 123253 ------ 124142 ------ 124795 ------ 125689 ------ 126277 ------ 126904 ------ 127684 ------ 128251 ------ 129032 ------ 129916 ------ 130717 ------ 131554 ------ 132482 ------ 133408 ------ 134272 ------ 135073 ------ 135869 ------ 136963 ------ 137806 ------ 138412 ------ 139103 ------ 139982 ------ 140794 ------ 141455 ------ 142396 ------ 143047 ------ 143788 ------ 144620 ------ 145336 ------ 146170 ------ 147014 ------ 147769 ------ 148508 ------ 149234 ------ 149995
+ │ │ │ │ │ histogram(19)= 0 150 1.4997e+06 150
+ │ │ │ │ │ <--- ' about the blithely final pack' ------------ 'zzle about the thinly unusual asymptotes. quickly bold courts nag'
│ │ │ │ ├── key: (11)
│ │ │ │ └── fd: (11)-->(12,19)
│ │ │ └── filters
@@ -87,8 +87,8 @@ sort
│ │ │ ├── save-table-name: q13_scan_7
│ │ │ ├── columns: c_custkey:1(int!null)
│ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4]
- │ │ │ │ histogram(1)= 0 5 769 5 765 5 732 5 744 5 731 5 754 5 772 5 757 5 713 5 741 5 808 5 744 5 739 5 687 5 820 5 761 5 782 5 632 5 711 5 692 5 648 5 770 5 765 5 702 5 751 5 807 5 794 5 735 5 807 5 719 5 773 5 781 5 684 5 748 5 682 5 703 5 794 5 718 5 807 5 674 5 747 5 677 5 813 5 666 5 766 5 822 5 703 5 676 5 765 5 693 5 723 5 780 5 793 5 770 5 696 5 775 5 764 5 884 5 696 5 688 5 637 5 789 5 702 5 732 5 697 5 769 5 739 5 744 5 861 5 791 5 726 5 793 5 730 5 763 5 789 5 797 5 775 5 862 5 780 5 746 5 783 5 743 5 822 5 806 5 775 5 727 5 724 5 799 5 707 5 757 5 614 5 747 5 704 5 740 5 749 5 735 5 741 5 807 5 827 5 816 5 702 5 699 5 803 5 793 5 672 5 831 5 694 5 746 5 731 5 686 5 685 5 695 5 828 5 756 5 722 5 749 5 790 5 758 5 750 5 782 5 733 5 778 5 762 5 758 5 731 5 778 5 663 5 696 5 684 5 796 5 770 5 656 5 690 5 747 5 782 5 785 5 751 5 697 5 663 5 766 5 695 5 866 5 813 5 765 5 901 5 747 5 683 5 706 5 689 5 734 5 715 5 752 5 855 5 771 5 717 5 794 5 760 5 827 5 747 5 757 5 767 5 726 5 690 5 787 5 783 5 744 5 761 5 746 5 793 5 696 5 749 5 745 5 755 5 800 5 778 5 814 5 826 5 700 5 740 5 773 5 713 5 824 5 792 5 702 5 734 5 751 5 716 5 718 5 722 5 784 5 778 5 700 5 714 5 739 5 748 5 697 5 751 5 663 5 740 5
- │ │ │ │ <--- 37 ----- 834 ----- 1623 ----- 2351 ----- 3101 ----- 3828 ----- 4598 ----- 5401 ----- 6176 ----- 6868 ----- 7613 ----- 8479 ----- 9230 ----- 9972 ----- 10613 ----- 11500 ----- 12282 ----- 13103 ----- 13624 ----- 14312 ----- 14962 ----- 15520 ----- 16319 ----- 17109 ----- 17780 ----- 18543 ----- 19408 ----- 20250 ----- 20984 ----- 21848 ----- 22551 ----- 23355 ----- 24174 ----- 24809 ----- 25567 ----- 26196 ----- 26868 ----- 27710 ----- 28412 ----- 29276 ----- 29889 ----- 30645 ----- 31264 ----- 32139 ----- 32736 ----- 33527 ----- 34418 ----- 35091 ----- 35709 ----- 36498 ----- 37150 ----- 37861 ----- 38677 ----- 39517 ----- 40316 ----- 40975 ----- 41782 ----- 42569 ----- 43565 ----- 44224 ----- 44867 ----- 45399 ----- 46231 ----- 46902 ----- 47630 ----- 48291 ----- 49087 ----- 49829 ----- 50580 ----- 51538 ----- 52375 ----- 53092 ----- 53932 ----- 54656 ----- 55442 ----- 56274 ----- 57121 ----- 57929 ----- 58888 ----- 59705 ----- 60460 ----- 61282 ----- 62031 ----- 62922 ----- 63785 ----- 64593 ----- 65311 ----- 66024 ----- 66875 ----- 67556 ----- 68331 ----- 68808 ----- 69564 ----- 70239 ----- 70983 ----- 71744 ----- 72478 ----- 73223 ----- 74088 ----- 74988 ----- 75868 ----- 76539 ----- 77203 ----- 78061 ----- 78901 ----- 79510 ----- 80417 ----- 81071 ----- 81826 ----- 82553 ----- 83191 ----- 83828 ----- 84485 ----- 85386 ----- 86159 ----- 86868 ----- 87628 ----- 88463 ----- 89240 ----- 90002 ----- 90822 ----- 91553 ----- 92367 ----- 93152 ----- 93929 ----- 94656 ----- 95470 ----- 96061 ----- 96720 ----- 97355 ----- 98200 ----- 98998 ----- 99573 ----- 100219 ----- 100975 ----- 101795 ----- 102620 ----- 103384 ----- 104044 ----- 104635 ----- 105426 ----- 106083 ----- 107049 ----- 107925 ----- 108715 ----- 109740 ----- 110496 ----- 111128 ----- 111807 ----- 112451 ----- 113184 ----- 113866 ----- 114619 ----- 115556 ----- 116344 ----- 117029 ----- 117859 ----- 118626 ----- 119515 ----- 120258 ----- 121021 ----- 121802 ----- 122505 ----- 123136 ----- 123953 ----- 124763 ----- 125501 ----- 126271 ----- 127012 ----- 127841 ----- 128483 ----- 129230 ----- 129970 ----- 130729 ----- 131569 ----- 132370 ----- 133235 ----- 134122 ----- 134773 ----- 135503 ----- 136294 ----- 136971 ----- 137854 ----- 138681 ----- 139336 ----- 140055 ----- 140806 ----- 141489 ----- 142177 ----- 142873 ----- 143685 ----- 144486 ----- 145138 ----- 145817 ----- 146545 ----- 147291 ----- 147936 ----- 148687 ----- 149260 ----- 149990
+ │ │ │ │ histogram(1)= 0 0 0 5 745 5 746 5 711 5 780 5 738 5 835 5 697 5 757 5 704 5 696 5 753 5 678 5 813 5 873 5 736 5 840 5 703 5 745 5 710 5 763 5 742 5 673 5 702 5 793 5 732 5 752 5 707 5 751 5 722 5 814 5 789 5 671 5 643 5 706 5 723 5 757 5 713 5 760 5 766 5 711 5 858 5 702 5 695 5 697 5 823 5 857 5 712 5 808 5 754 5 739 5 694 5 782 5 792 5 751 5 758 5 749 5 798 5 685 5 692 5 792 5 710 5 771 5 724 5 853 5 713 5 823 5 772 5 656 5 763 5 672 5 735 5 810 5 786 5 709 5 731 5 702 5 708 5 669 5 733 5 744 5 758 5 800 5 682 5 716 5 716 5 729 5 778 5 721 5 766 5 820 5 757 5 739 5 799 5 780 5 710 5 749 5 754 5 750 5 699 5 821 5 759 5 818 5 763 5 854 5 779 5 810 5 783 5 686 5 703 5 776 5 675 5 812 5 745 5 759 5 793 5 751 5 761 5 798 5 794 5 729 5 696 5 699 5 831 5 709 5 747 5 722 5 768 5 729 5 702 5 729 5 698 5 767 5 792 5 726 5 737 5 671 5 721 5 842 5 701 5 704 5 708 5 726 5 695 5 665 5 688 5 653 5 690 5 734 5 789 5 659 5 785 5 733 5 740 5 826 5 745 5 929 5 899 5 743 5 790 5 825 5 779 5 677 5 697 5 756 5 693 5 862 5 772 5 783 5 757 5 799 5 778 5 752 5 715 5 709 5 790 5 789 5 865 5 808 5 772 5 743 5 751 5 742 5 676 5 684 5 744 5 709 5 679 5 817 5 755 5 754 5 797 5 709 5 748 5 679 5 751 5 775 5 736 5 790 5 714 5 0 0
+ │ │ │ │ <--- -9223372036854775808 --- 59 ----- 811 ----- 1565 ----- 2252 ----- 3068 ----- 3807 ----- 4720 ----- 5381 ----- 6155 ----- 6829 ----- 7487 ----- 8254 ----- 8876 ----- 9751 ----- 10728 ----- 11463 ----- 12385 ----- 13057 ----- 13810 ----- 14495 ----- 15281 ----- 16028 ----- 16640 ----- 17311 ----- 18151 ----- 18880 ----- 19645 ----- 20325 ----- 21088 ----- 21798 ----- 22674 ----- 23507 ----- 24115 ----- 24661 ----- 25340 ----- 26052 ----- 26827 ----- 27518 ----- 28298 ----- 29089 ----- 29777 ----- 30730 ----- 31401 ----- 32057 ----- 32718 ----- 33611 ----- 34562 ----- 35251 ----- 36117 ----- 36887 ----- 37629 ----- 38283 ----- 39104 ----- 39942 ----- 40705 ----- 41481 ----- 42241 ----- 43089 ----- 43725 ----- 44376 ----- 45214 ----- 45899 ----- 46700 ----- 47413 ----- 48356 ----- 49047 ----- 49939 ----- 50742 ----- 51316 ----- 52101 ----- 52710 ----- 53444 ----- 54313 ----- 55140 ----- 55823 ----- 56549 ----- 57219 ----- 57901 ----- 58503 ----- 59234 ----- 59984 ----- 60760 ----- 61613 ----- 62243 ----- 62941 ----- 63638 ----- 64360 ----- 65173 ----- 65880 ----- 66672 ----- 67560 ----- 68334 ----- 69075 ----- 69925 ----- 70742 ----- 71428 ----- 72189 ----- 72958 ----- 73720 ----- 74385 ----- 75274 ----- 76053 ----- 76936 ----- 77721 ----- 78666 ----- 79480 ----- 80349 ----- 81171 ----- 81810 ----- 82482 ----- 83292 ----- 83907 ----- 84780 ----- 85532 ----- 86310 ----- 87149 ----- 87912 ----- 88694 ----- 89543 ----- 90384 ----- 91106 ----- 91764 ----- 92428 ----- 93335 ----- 94018 ----- 94775 ----- 95484 ----- 96279 ----- 97001 ----- 97672 ----- 98394 ----- 99056 ----- 99850 ----- 100688 ----- 101405 ----- 102143 ----- 102751 ----- 103459 ----- 104384 ----- 105052 ----- 105727 ----- 106409 ----- 107125 ----- 107782 ----- 108377 ----- 109020 ----- 109588 ----- 110235 ----- 110967 ----- 111800 ----- 112382 ----- 113196 ----- 113913 ----- 114643 ----- 115529 ----- 116268 ----- 117329 ----- 118341 ----- 119076 ----- 119898 ----- 120782 ----- 121584 ----- 122186 ----- 122830 ----- 123591 ----- 124227 ----- 125175 ----- 125964 ----- 126773 ----- 127535 ----- 128374 ----- 129175 ----- 129928 ----- 130609 ----- 131279 ----- 132102 ----- 132923 ----- 133877 ----- 134732 ----- 135521 ----- 136257 ----- 137007 ----- 137740 ----- 138341 ----- 138958 ----- 139695 ----- 140364 ----- 140971 ----- 141841 ----- 142600 ----- 143356 ----- 144192 ----- 144861 ----- 145607 ----- 146214 ----- 146965 ----- 147761 ----- 148483 ----- 149306 ----- 149986 --- 9223372036854775807
│ │ │ └── key: (1)
│ │ └── filters
│ │ └── c_custkey:1 = o_custkey:12 [type=bool, outer=(1,12), constraints=(/1: (/NULL - ]; /12: (/NULL - ]), fd=(1)==(12), (12)==(1)]
@@ -135,7 +135,7 @@ column_names row_count distinct_count null_count
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{c_custkey} 503988.00 3.04 <== 148813.00 1.00 0.00 1.00
{o_comment} 503988.00 3.04 <== 317522.00 4.58 <== 0.00 +Inf <==
-{o_custkey} 503988.00 3.04 <== 99627.00 1.00 0.00 +Inf <==
+{o_custkey} 503988.00 3.04 <== 99620.00 1.00 0.00 +Inf <==
{o_orderkey} 503988.00 3.04 <== 317522.00 4.67 <== 0.00 +Inf <==
----Stats for q13_select_5----
@@ -146,7 +146,7 @@ column_names row_count distinct_count null_count
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{o_comment} 500000.00 2.97 <== 500000.00 2.91 <== 0.00 1.00
-{o_custkey} 500000.00 2.97 <== 99627.00 1.00 0.00 1.00
+{o_custkey} 500000.00 2.97 <== 99620.00 1.00 0.00 1.00
{o_orderkey} 500000.00 2.97 <== 500000.00 2.97 <== 0.00 1.00
----Stats for q13_scan_6----
@@ -156,8 +156,8 @@ column_names row_count distinct_count null_count
{o_orderkey} 1500000 1500000 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_comment} 1500000.00 1.00 1473851.00 1.00 0.00 1.00
-{o_custkey} 1500000.00 1.00 99853.00 1.00 0.00 1.00
+{o_comment} 1500000.00 1.00 1469402.00 1.00 0.00 1.00
+{o_custkey} 1500000.00 1.00 99846.00 1.00 0.00 1.00
{o_orderkey} 1500000.00 1.00 1500000.00 1.00 0.00 1.00
----Stats for q13_scan_7----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q14 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q14
index 76e63ebdbb2b..ad8304c42760 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q14
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q14
@@ -51,40 +51,40 @@ project
│ │ ├── save-table-name: q14_project_3
│ │ ├── columns: column30:30(float!null) column32:32(float!null)
│ │ ├── immutable
- │ │ ├── stats: [rows=85001.1, distinct(30)=85001.1, null(30)=0, avgsize(30)=12, distinct(32)=53645.6, null(32)=0, avgsize(32)=8]
+ │ │ ├── stats: [rows=76412.86, distinct(30)=76412.9, null(30)=0, avgsize(30)=41, distinct(32)=48225.4, null(32)=0, avgsize(32)=18]
│ │ ├── inner-join (hash)
│ │ │ ├── save-table-name: q14_inner_join_4
│ │ │ ├── columns: l_partkey:2(int!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipdate:11(date!null) p_partkey:19(int!null) p_type:23(varchar!null)
│ │ │ ├── multiplicity: left-rows(zero-or-more), right-rows(exactly-one)
- │ │ │ ├── stats: [rows=85001.1, distinct(2)=69377.6, null(2)=0, avgsize(2)=4, distinct(6)=52819, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(11)=30, null(11)=0, avgsize(11)=4, distinct(19)=69377.6, null(19)=0, avgsize(19)=4, distinct(23)=150, null(23)=0, avgsize(23)=4, distinct(6,7)=53645.6, null(6,7)=0, avgsize(6,7)=8, distinct(6,7,23)=85001.1, null(6,7,23)=0, avgsize(6,7,23)=12]
+ │ │ │ ├── stats: [rows=76412.86, distinct(2)=63600.6, null(2)=0, avgsize(2)=4, distinct(6)=47518.9, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(11)=30, null(11)=0, avgsize(11)=4, distinct(19)=63600.6, null(19)=0, avgsize(19)=4, distinct(23)=150, null(23)=0, avgsize(23)=23, distinct(6,7)=48225.4, null(6,7)=0, avgsize(6,7)=18, distinct(6,7,23)=76412.9, null(6,7,23)=0, avgsize(6,7,23)=41]
│ │ │ ├── fd: (19)-->(23), (2)==(19), (19)==(2)
│ │ │ ├── scan part
│ │ │ │ ├── save-table-name: q14_scan_5
│ │ │ │ ├── columns: p_partkey:19(int!null) p_type:23(varchar!null)
- │ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(23)=150, null(23)=0, avgsize(23)=4]
- │ │ │ │ │ histogram(19)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ histogram(23)= 0 1340 1.975e+05 1160
- │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ----------- 'STANDARD POLISHED TIN'
+ │ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(23)=150, null(23)=0, avgsize(23)=23]
+ │ │ │ │ │ histogram(19)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ histogram(23)= 0 1360 1.9708e+05 1560
+ │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ------------ 'STANDARD POLISHED TIN'
│ │ │ │ ├── key: (19)
│ │ │ │ └── fd: (19)-->(23)
│ │ │ ├── index-join lineitem
│ │ │ │ ├── save-table-name: q14_index_join_6
│ │ │ │ ├── columns: l_partkey:2(int!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipdate:11(date!null)
- │ │ │ │ ├── stats: [rows=84678.52, distinct(2)=69377.6, null(2)=0, avgsize(2)=4, distinct(6)=81644.5, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(11)=30, null(11)=0, avgsize(11)=4, distinct(6,7)=84678.5, null(6,7)=0, avgsize(6,7)=8]
- │ │ │ │ │ histogram(11)= 0 0 4247.7 2401 27010 2401 28811 5402 12005 2400.9
- │ │ │ │ │ <--- '1995-08-31' -------- '1995-09-03' ------- '1995-09-13' ------- '1995-09-24' ------- '1995-09-30'
+ │ │ │ │ ├── stats: [rows=76122.87, distinct(2)=63600.6, null(2)=0, avgsize(2)=4, distinct(6)=73526.2, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(11)=30, null(11)=0, avgsize(11)=4, distinct(6,7)=76122.9, null(6,7)=0, avgsize(6,7)=18]
+ │ │ │ │ │ histogram(11)= 0 0 26405 3001 28806 2400 13295 2215.8
+ │ │ │ │ │ <--- '1995-08-31' ------- '1995-09-11' ------- '1995-09-23' ------- '1995-09-30'
│ │ │ │ └── scan lineitem@l_sd
│ │ │ │ ├── save-table-name: q14_scan_7
│ │ │ │ ├── columns: l_orderkey:1(int!null) l_linenumber:4(int!null) l_shipdate:11(date!null)
│ │ │ │ ├── constraint: /11/1/4: [/'1995-09-01' - /'1995-09-30']
- │ │ │ │ ├── stats: [rows=84678.52, distinct(1)=82944.2, null(1)=0, avgsize(1)=4, distinct(4)=7, null(4)=0, avgsize(4)=4, distinct(11)=30, null(11)=0, avgsize(11)=4]
- │ │ │ │ │ histogram(1)= 0 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 414.92 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646 423.39 8.4646
- │ │ │ │ │ <--- 576 --------- 38535 -------- 66885 -------- 93380 -------- 127425 -------- 157218 -------- 184483 -------- 215330 -------- 252869 -------- 283878 -------- 313798 -------- 337056 -------- 372549 -------- 399591 -------- 426245 -------- 460578 -------- 498439 -------- 526049 -------- 554468 -------- 577921 -------- 609187 -------- 639524 -------- 665345 -------- 686180 -------- 721539 -------- 755680 -------- 782756 -------- 814496 -------- 845446 -------- 872130 -------- 910912 -------- 933697 -------- 965184 -------- 1000353 -------- 1038658 -------- 1073667 -------- 1097891 -------- 1131330 -------- 1157732 -------- 1179943 -------- 1206401 -------- 1230150 -------- 1261824 -------- 1293217 -------- 1326754 -------- 1357573 -------- 1390145 -------- 1429312 -------- 1460418 -------- 1491104 -------- 1523937 -------- 1559812 -------- 1591653 -------- 1615174 -------- 1646759 -------- 1670465 -------- 1696321 -------- 1724192 -------- 1748033 -------- 1777570 -------- 1807428 -------- 1836962 -------- 1872481 -------- 1902817 -------- 1928324 -------- 1960775 -------- 1985989 -------- 2019107 -------- 2044613 -------- 2071490 -------- 2101959 -------- 2135555 -------- 2164486 -------- 2186337 -------- 2213989 -------- 2246309 -------- 2276992 -------- 2306403 -------- 2329921 -------- 2354977 -------- 2380711 -------- 2410529 -------- 2437920 -------- 2462017 -------- 2483714 -------- 2513920 -------- 2542855 -------- 2574112 -------- 2596035 -------- 2625031 -------- 2658051 -------- 2695046 -------- 2725222 -------- 2754245 -------- 2777702 -------- 2804896 -------- 2844579 -------- 2873860 -------- 2903459 -------- 2933249 -------- 2965479 -------- 2996160 -------- 3022976 -------- 3053152 -------- 3083623 -------- 3111136 -------- 3144033 -------- 3180134 -------- 3209799 -------- 3239394 -------- 3270886 -------- 3297664 -------- 3329444 -------- 3357574 -------- 3380838 -------- 3412196 -------- 3438917 -------- 3462467 -------- 3498629 -------- 3530208 -------- 3562148 -------- 3589889 -------- 3621063 -------- 3655456 -------- 3686724 -------- 3709029 -------- 3738215 -------- 3767687 -------- 3804547 -------- 3831142 -------- 3875111 -------- 3905605 -------- 3933795 -------- 3966593 -------- 3995558 -------- 4020134 -------- 4052513 -------- 4078949 -------- 4114208 -------- 4149762 -------- 4176135 -------- 4207782 -------- 4241376 -------- 4270502 -------- 4304167 -------- 4333669 -------- 4362818 -------- 4393537 -------- 4423076 -------- 4452064 -------- 4491143 -------- 4522723 -------- 4550883 -------- 4581382 -------- 4616002 -------- 4649410 -------- 4680485 -------- 4715584 -------- 4740036 -------- 4771554 -------- 4799461 -------- 4826690 -------- 4855525 -------- 4887974 -------- 4917479 -------- 4950885 -------- 4984195 -------- 5010113 -------- 5033571 -------- 5065472 -------- 5100512 -------- 5129413 -------- 5160069 -------- 5186596 -------- 5221538 -------- 5252964 -------- 5284069 -------- 5314051 -------- 5353026 -------- 5388961 -------- 5424644 -------- 5452676 -------- 5483553 -------- 5516612 -------- 5551041 -------- 5579878 -------- 5612576 -------- 5643427 -------- 5673666 -------- 5709218 -------- 5737221 -------- 5766119 -------- 5795044 -------- 5826560 -------- 5855943 -------- 5889604 -------- 5917607 -------- 5942535 -------- 5969639 -------- 5999557
- │ │ │ │ │ histogram(4)= 0 21449 0 17960 0 15005 0 12744 0 8467.8 0 6173.1 0 2879.1
- │ │ │ │ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ------ 5 ------ 6 --
- │ │ │ │ │ histogram(11)= 0 0 4247.7 2401 27010 2401 28811 5402 12005 2400.9
- │ │ │ │ │ <--- '1995-08-31' -------- '1995-09-03' ------- '1995-09-13' ------- '1995-09-24' ------- '1995-09-30'
+ │ │ │ │ ├── stats: [rows=76122.87, distinct(1)=74720.1, null(1)=0, avgsize(1)=4, distinct(4)=7, null(4)=0, avgsize(4)=1, distinct(11)=30, null(11)=0, avgsize(11)=4]
+ │ │ │ │ │ histogram(1)= 0 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 365.39 15.221 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 365.39 15.221 373 7.6107 373 7.6107 373 7.6107 373 7.6107 365.39 15.221 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 373 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107 380.61 7.6107
+ │ │ │ │ │ <--- 197 ------ 23686 ----- 53253 ----- 90435 ----- 121730 ----- 153280 ----- 175456 ----- 208548 ----- 242209 ----- 273057 -------- 296640 ----- 330307 ----- 360999 ----- 386307 ----- 420225 ----- 450050 ----- 477795 ----- 504711 ----- 533153 ----- 556672 ----- 582243 ----- 613729 ----- 646117 ----- 675840 ----- 706048 ----- 733063 ----- 769282 ----- 793922 ----- 820357 ----- 849536 ----- 875719 ----- 905028 ----- 940643 ----- 968355 ----- 998721 ----- 1023621 ----- 1059424 ----- 1084932 ----- 1115553 ----- 1139363 ----- 1167361 ----- 1194400 ----- 1225984 ----- 1253861 ----- 1281633 ----- 1304999 ----- 1336355 ----- 1370759 ----- 1400832 ----- 1434085 ----- 1458852 ----- 1491427 ----- 1525120 ----- 1555205 ----- 1591300 ----- 1619426 ----- 1651458 ----- 1682950 ----- 1711399 ----- 1747591 ----- 1787205 -------- 1822240 ----- 1856163 ----- 1886915 ----- 1910949 ----- 1947202 -------- 1974311 ----- 2009286 ----- 2044034 ----- 2079104 ----- 2103488 ----- 2134657 ----- 2164293 ----- 2204514 ----- 2230823 ----- 2265253 ----- 2289826 ----- 2329539 ----- 2364455 ----- 2393507 ----- 2414628 ----- 2440228 ----- 2465255 ----- 2489568 ----- 2520900 ----- 2554919 ----- 2583333 ----- 2612966 ----- 2644833 ----- 2667362 ----- 2702784 ----- 2727394 ----- 2759748 ----- 2794531 ----- 2822214 ----- 2846624 ----- 2883748 ----- 2919586 ----- 2951908 ----- 2980068 ----- 3014726 ----- 3050725 ----- 3081028 ----- 3113351 ----- 3150243 ----- 3185669 ----- 3214311 ----- 3241281 ----- 3275748 ----- 3303232 ----- 3339559 ----- 3370627 ----- 3393664 ----- 3435265 ----- 3464581 ----- 3489026 ----- 3516096 ----- 3548480 ----- 3587015 ----- 3611239 ----- 3638724 ----- 3668641 ----- 3695751 ----- 3729636 ----- 3751523 ----- 3784608 ----- 3815715 ----- 3848608 ----- 3881184 ----- 3908738 ----- 3940002 ----- 3966176 ----- 4001984 ----- 4035687 ----- 4065283 ----- 4092834 ----- 4133062 ----- 4160613 ----- 4196421 ----- 4223713 ----- 4254788 ----- 4291040 ----- 4313664 ----- 4342823 ----- 4369952 ----- 4391684 ----- 4419040 ----- 4449921 ----- 4471781 ----- 4506210 ----- 4538176 -------- 4571297 -------- 4601121 -------- 4630887 -------- 4657476 -------- 4684803 -------- 4714566 -------- 4744070 -------- 4776385 -------- 4807777 -------- 4839491 -------- 4873953 -------- 4902245 -------- 4936263 -------- 4970721 -------- 5003140 -------- 5029729 -------- 5059010 -------- 5087521 -------- 5121093 -------- 5150405 -------- 5178375 -------- 5203683 -------- 5234531 -------- 5268195 -------- 5300004 -------- 5331558 -------- 5362178 -------- 5385762 -------- 5418498 -------- 5445762 -------- 5483109 -------- 5514561 -------- 5542052 -------- 5569572 -------- 5596102 -------- 5622401 -------- 5652194 -------- 5671362 -------- 5699591 -------- 5727136 -------- 5753284 -------- 5780742 -------- 5809189 -------- 5836545 -------- 5864454 -------- 5894917 -------- 5933825 -------- 5968933 -------- 5999590
+ │ │ │ │ │ histogram(4)= 0 18871 0 16983 0 13352 0 10931 0 8076.6 0 5267.7 0 2641.5
+ │ │ │ │ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ------ 6 ------ 7 --
+ │ │ │ │ │ histogram(11)= 0 0 26405 3001 28806 2400 13295 2215.8
+ │ │ │ │ │ <--- '1995-08-31' ------- '1995-09-11' ------- '1995-09-23' ------- '1995-09-30'
│ │ │ │ ├── key: (1,4)
│ │ │ │ └── fd: (1,4)-->(11)
│ │ │ └── filters
@@ -122,8 +122,8 @@ column_names row_count distinct_count null_count
{column32} 75983 75983 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column30} 85001.00 1.12 85001.00 6.73 <== 0.00 1.00
-{column32} 85001.00 1.12 53646.00 1.42 0.00 1.00
+{column30} 76413.00 1.01 76413.00 6.05 <== 0.00 1.00
+{column32} 76413.00 1.01 48225.00 1.58 0.00 1.00
----Stats for q14_inner_join_4----
column_names row_count distinct_count null_count
@@ -135,12 +135,12 @@ column_names row_count distinct_count null_count
{p_type} 75983 150 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 85001.00 1.12 11.00 1.00 0.00 1.00
-{l_extendedprice} 85001.00 1.12 52819.00 1.38 0.00 1.00
-{l_partkey} 85001.00 1.12 69378.00 1.10 0.00 1.00
-{l_shipdate} 85001.00 1.12 30.00 1.00 0.00 1.00
-{p_partkey} 85001.00 1.12 69378.00 1.10 0.00 1.00
-{p_type} 85001.00 1.12 150.00 1.00 0.00 1.00
+{l_discount} 76413.00 1.01 11.00 1.00 0.00 1.00
+{l_extendedprice} 76413.00 1.01 47519.00 1.53 0.00 1.00
+{l_partkey} 76413.00 1.01 63601.00 1.01 0.00 1.00
+{l_shipdate} 76413.00 1.01 30.00 1.00 0.00 1.00
+{p_partkey} 76413.00 1.01 63601.00 1.01 0.00 1.00
+{p_type} 76413.00 1.01 150.00 1.00 0.00 1.00
----Stats for q14_scan_5----
column_names row_count distinct_count null_count
@@ -159,10 +159,10 @@ column_names row_count distinct_count null_count
{l_shipdate} 75983 30 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 84679.00 1.11 11.00 1.00 0.00 1.00
-{l_extendedprice} 84679.00 1.11 81644.00 1.12 0.00 1.00
-{l_partkey} 84679.00 1.11 69378.00 1.10 0.00 1.00
-{l_shipdate} 84679.00 1.11 30.00 1.00 0.00 1.00
+{l_discount} 76123.00 1.00 11.00 1.00 0.00 1.00
+{l_extendedprice} 76123.00 1.00 73526.00 1.01 0.00 1.00
+{l_partkey} 76123.00 1.00 63601.00 1.01 0.00 1.00
+{l_shipdate} 76123.00 1.00 30.00 1.00 0.00 1.00
----Stats for q14_scan_7----
column_names row_count distinct_count null_count
@@ -171,8 +171,8 @@ column_names row_count distinct_count null_count
{l_shipdate} 75983 30 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 84679.00 1.11 7.00 1.00 0.00 1.00
-{l_orderkey} 84679.00 1.11 82944.00 1.67 0.00 1.00
-{l_shipdate} 84679.00 1.11 30.00 1.00 0.00 1.00
+{l_linenumber} 76123.00 1.00 7.00 1.00 0.00 1.00
+{l_orderkey} 76123.00 1.00 74720.00 1.51 0.00 1.00
+{l_shipdate} 76123.00 1.00 30.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q15 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q15
index aad9487b00e4..62c44bbdce73 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q15
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q15
@@ -55,7 +55,7 @@ project
├── save-table-name: q15_project_1
├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_address:3(varchar!null) s_phone:5(char!null) total_revenue:29(float!null)
├── immutable
- ├── stats: [rows=3333.333, distinct(1)=3306.67, null(1)=0, avgsize(1)=4, distinct(2)=2834.36, null(2)=0, avgsize(2)=4, distinct(3)=2834.81, null(3)=0, avgsize(3)=4, distinct(5)=2827.56, null(5)=0, avgsize(5)=4, distinct(29)=2100.04, null(29)=0, avgsize(29)=4]
+ ├── stats: [rows=3333.333, distinct(1)=3306.67, null(1)=0, avgsize(1)=3, distinct(2)=2834.36, null(2)=0, avgsize(2)=20, distinct(3)=2834.81, null(3)=0, avgsize(3)=27, distinct(5)=2834.81, null(5)=0, avgsize(5)=17, distinct(29)=2100.04, null(29)=0, avgsize(29)=4]
├── key: (1)
├── fd: (1)-->(2,3,5,29)
├── ordering: +1
@@ -65,22 +65,22 @@ project
├── left ordering: +1
├── right ordering: +12
├── immutable
- ├── stats: [rows=3333.333, distinct(1)=3306.67, null(1)=0, avgsize(1)=4, distinct(2)=2834.36, null(2)=0, avgsize(2)=4, distinct(3)=2834.81, null(3)=0, avgsize(3)=4, distinct(5)=2827.56, null(5)=0, avgsize(5)=4, distinct(12)=3306.67, null(12)=0, avgsize(12)=4, distinct(29)=2100.04, null(29)=0, avgsize(29)=4]
+ ├── stats: [rows=3333.333, distinct(1)=3306.67, null(1)=0, avgsize(1)=3, distinct(2)=2834.36, null(2)=0, avgsize(2)=20, distinct(3)=2834.81, null(3)=0, avgsize(3)=27, distinct(5)=2834.81, null(5)=0, avgsize(5)=17, distinct(12)=3306.67, null(12)=0, avgsize(12)=4, distinct(29)=2100.04, null(29)=0, avgsize(29)=4]
├── key: (12)
├── fd: (1)-->(2,3,5), (12)-->(29), (1)==(12), (12)==(1)
├── ordering: +(1|12) [actual: +1]
├── scan supplier
│ ├── save-table-name: q15_scan_3
│ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_address:3(varchar!null) s_phone:5(char!null)
- │ ├── stats: [rows=10000, distinct(1)=9920, null(1)=0, avgsize(1)=4, distinct(2)=9990, null(2)=0, avgsize(2)=4, distinct(3)=10000, null(3)=0, avgsize(3)=4, distinct(5)=9840, null(5)=0, avgsize(5)=4]
+ │ ├── stats: [rows=10000, distinct(1)=9920, null(1)=0, avgsize(1)=3, distinct(2)=9990, null(2)=0, avgsize(2)=20, distinct(3)=10000, null(3)=0, avgsize(3)=27, distinct(5)=10000, null(5)=0, avgsize(5)=17]
│ │ histogram(1)= 0 0 0 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 0 0
│ │ <--- -9223372036854775808 --- 1 ---- 51 ---- 101 ---- 151 ---- 201 ---- 251 ---- 301 ---- 351 ---- 401 ---- 451 ---- 501 ---- 551 ---- 601 ---- 651 ---- 701 ---- 751 ---- 801 ---- 851 ---- 901 ---- 951 ---- 1001 ---- 1051 ---- 1101 ---- 1151 ---- 1201 ---- 1251 ---- 1301 ---- 1351 ---- 1401 ---- 1451 ---- 1501 ---- 1551 ---- 1601 ---- 1651 ---- 1701 ---- 1751 ---- 1801 ---- 1851 ---- 1901 ---- 1951 ---- 2001 ---- 2051 ---- 2101 ---- 2151 ---- 2201 ---- 2251 ---- 2301 ---- 2351 ---- 2401 ---- 2451 ---- 2501 ---- 2551 ---- 2601 ---- 2651 ---- 2701 ---- 2751 ---- 2801 ---- 2851 ---- 2901 ---- 2951 ---- 3001 ---- 3051 ---- 3101 ---- 3151 ---- 3201 ---- 3251 ---- 3301 ---- 3351 ---- 3401 ---- 3451 ---- 3501 ---- 3551 ---- 3601 ---- 3651 ---- 3701 ---- 3751 ---- 3801 ---- 3851 ---- 3901 ---- 3951 ---- 4001 ---- 4051 ---- 4101 ---- 4151 ---- 4201 ---- 4251 ---- 4301 ---- 4351 ---- 4401 ---- 4451 ---- 4501 ---- 4551 ---- 4601 ---- 4651 ---- 4701 ---- 4751 ---- 4801 ---- 4851 ---- 4901 ---- 4951 ---- 5001 ---- 5051 ---- 5101 ---- 5151 ---- 5201 ---- 5251 ---- 5301 ---- 5351 ---- 5401 ---- 5451 ---- 5501 ---- 5551 ---- 5601 ---- 5651 ---- 5701 ---- 5751 ---- 5801 ---- 5851 ---- 5901 ---- 5951 ---- 6001 ---- 6051 ---- 6101 ---- 6151 ---- 6201 ---- 6251 ---- 6301 ---- 6351 ---- 6401 ---- 6451 ---- 6501 ---- 6551 ---- 6601 ---- 6651 ---- 6701 ---- 6751 ---- 6801 ---- 6851 ---- 6901 ---- 6951 ---- 7001 ---- 7051 ---- 7101 ---- 7151 ---- 7201 ---- 7251 ---- 7301 ---- 7351 ---- 7401 ---- 7451 ---- 7501 ---- 7552 ---- 7603 ---- 7654 ---- 7705 ---- 7756 ---- 7807 ---- 7858 ---- 7909 ---- 7960 ---- 8011 ---- 8062 ---- 8113 ---- 8164 ---- 8215 ---- 8266 ---- 8317 ---- 8368 ---- 8419 ---- 8470 ---- 8521 ---- 8572 ---- 8623 ---- 8674 ---- 8725 ---- 8776 ---- 8827 ---- 8878 ---- 8929 ---- 8980 ---- 9031 ---- 9082 ---- 9133 ---- 9184 ---- 9235 ---- 9286 ---- 9337 ---- 9388 ---- 9439 ---- 9490 ---- 9541 ---- 9592 ---- 9643 ---- 9694 ---- 9745 ---- 9796 ---- 9847 ---- 9898 ---- 9949 ---- 10000 --- 9223372036854775807
│ │ histogram(2)= 0 1 9998 1
│ │ <--- 'Supplier#000000001' ------ 'Supplier#000010000'
- │ │ histogram(3)= 0 1 9998 1
- │ │ <--- ' 7thzdOKLdVP yR7ZbOMnubI6,PrkxBX ZYw1' ------ 'zzvmS9DyfR'
+ │ │ histogram(3)= 0 1 9998 1
+ │ │ <--- ' 9aW1wwnBJJPnCx,nox0MA48Y0zpI1IeVfYZ' ------ 'zzfDhdtZcvmVzA8rNFU,Yctj1zBN'
│ │ histogram(5)= 0 1 9998 1
- │ │ <--- '10-101-276-5805' ------ '34-997-188-3418'
+ │ │ <--- '10-102-116-6785' ------ '34-998-900-4911'
│ ├── key: (1)
│ ├── fd: (1)-->(2,3,5)
│ └── ordering: +1
@@ -111,24 +111,24 @@ project
│ │ │ ├── save-table-name: q15_project_7
│ │ │ ├── columns: column28:28(float!null) l_suppkey:12(int!null)
│ │ │ ├── immutable
- │ │ │ ├── stats: [rows=227324.7, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(28)=227325, null(28)=0, avgsize(28)=8]
+ │ │ │ ├── stats: [rows=238668.4, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(28)=238668, null(28)=0, avgsize(28)=18]
│ │ │ ├── index-join lineitem
│ │ │ │ ├── save-table-name: q15_index_join_8
│ │ │ │ ├── columns: l_suppkey:12(int!null) l_extendedprice:15(float!null) l_discount:16(float!null) l_shipdate:20(date!null)
- │ │ │ │ ├── stats: [rows=227324.7, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(15)=206167, null(15)=0, avgsize(15)=4, distinct(16)=11, null(16)=0, avgsize(16)=4, distinct(20)=91, null(20)=0, avgsize(20)=4, distinct(15,16)=227325, null(15,16)=0, avgsize(15,16)=8]
- │ │ │ │ │ histogram(20)= 0 0 14405 3001 24609 4802 27010 4802 26410 6603 25810 4202 28211 3001 24609 4202 23082 2564.6
- │ │ │ │ │ <--- '1995-12-31' ------- '1996-01-07' ------- '1996-01-21' ------- '1996-02-01' ------- '1996-02-14' ------- '1996-02-23' ------- '1996-03-07' ------- '1996-03-21' ------- '1996-03-31'
+ │ │ │ │ ├── stats: [rows=238668.4, distinct(12)=9920, null(12)=0, avgsize(12)=4, distinct(15)=214148, null(15)=0, avgsize(15)=9, distinct(16)=11, null(16)=0, avgsize(16)=9, distinct(20)=91, null(20)=0, avgsize(20)=4, distinct(15,16)=238668, null(15,16)=0, avgsize(15,16)=18]
+ │ │ │ │ │ histogram(20)= 0 0 2820.6 1200 28206 600 27606 3601 25805 3001 25805 3001 27606 2400 26405 3001 25805 4801 24004 3000.6
+ │ │ │ │ │ <--- '1995-12-31' -------- '1996-01-02' ------- '1996-01-14' ------- '1996-01-25' ------- '1996-02-07' ------- '1996-02-18' ------- '1996-02-28' ------- '1996-03-12' ------- '1996-03-22' ------- '1996-03-31'
│ │ │ │ └── scan lineitem@l_sd
│ │ │ │ ├── save-table-name: q15_scan_9
│ │ │ │ ├── columns: l_orderkey:10(int!null) l_linenumber:13(int!null) l_shipdate:20(date!null)
│ │ │ │ ├── constraint: /20/10/13: [/'1996-01-01' - /'1996-03-31']
- │ │ │ │ ├── stats: [rows=227324.7, distinct(10)=215016, null(10)=0, avgsize(10)=4, distinct(13)=7, null(13)=0, avgsize(13)=4, distinct(20)=91, null(20)=0, avgsize(20)=4]
- │ │ │ │ │ histogram(10)= 0 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724
- │ │ │ │ │ <--- 576 --------- 38535 -------- 66885 -------- 93380 -------- 127425 -------- 157218 -------- 184483 -------- 215330 -------- 252869 -------- 283878 -------- 313798 -------- 337056 -------- 372549 -------- 399591 -------- 426245 -------- 460578 -------- 498439 -------- 526049 -------- 554468 -------- 577921 -------- 609187 -------- 639524 -------- 665345 -------- 686180 -------- 721539 -------- 755680 -------- 782756 -------- 814496 -------- 845446 -------- 872130 -------- 910912 -------- 933697 -------- 965184 -------- 1000353 -------- 1038658 -------- 1073667 -------- 1097891 -------- 1131330 -------- 1157732 -------- 1179943 -------- 1206401 -------- 1230150 -------- 1261824 -------- 1293217 -------- 1326754 -------- 1357573 -------- 1390145 -------- 1429312 -------- 1460418 -------- 1491104 -------- 1523937 -------- 1559812 -------- 1591653 -------- 1615174 -------- 1646759 -------- 1670465 -------- 1696321 -------- 1724192 -------- 1748033 -------- 1777570 -------- 1807428 -------- 1836962 -------- 1872481 -------- 1902817 -------- 1928324 -------- 1960775 -------- 1985989 -------- 2019107 -------- 2044613 -------- 2071490 -------- 2101959 -------- 2135555 -------- 2164486 -------- 2186337 -------- 2213989 -------- 2246309 -------- 2276992 -------- 2306403 -------- 2329921 -------- 2354977 -------- 2380711 -------- 2410529 -------- 2437920 -------- 2462017 -------- 2483714 -------- 2513920 -------- 2542855 -------- 2574112 -------- 2596035 -------- 2625031 -------- 2658051 -------- 2695046 -------- 2725222 -------- 2754245 -------- 2777702 -------- 2804896 -------- 2844579 -------- 2873860 -------- 2903459 -------- 2933249 -------- 2965479 -------- 2996160 -------- 3022976 -------- 3053152 -------- 3083623 -------- 3111136 -------- 3144033 -------- 3180134 -------- 3209799 -------- 3239394 -------- 3270886 -------- 3297664 -------- 3329444 -------- 3357574 -------- 3380838 -------- 3412196 -------- 3438917 -------- 3462467 -------- 3498629 -------- 3530208 -------- 3562148 -------- 3589889 -------- 3621063 -------- 3655456 -------- 3686724 -------- 3709029 -------- 3738215 -------- 3767687 -------- 3804547 -------- 3831142 -------- 3875111 -------- 3905605 -------- 3933795 -------- 3966593 -------- 3995558 -------- 4020134 -------- 4052513 -------- 4078949 -------- 4114208 -------- 4149762 -------- 4176135 -------- 4207782 -------- 4241376 -------- 4270502 -------- 4304167 -------- 4333669 -------- 4362818 -------- 4393537 -------- 4423076 -------- 4452064 -------- 4491143 -------- 4522723 -------- 4550883 -------- 4581382 -------- 4616002 -------- 4649410 -------- 4680485 -------- 4715584 -------- 4740036 -------- 4771554 -------- 4799461 -------- 4826690 -------- 4855525 -------- 4887974 -------- 4917479 -------- 4950885 -------- 4984195 -------- 5010113 -------- 5033571 -------- 5065472 -------- 5100512 -------- 5129413 -------- 5160069 -------- 5186596 -------- 5221538 -------- 5252964 -------- 5284069 -------- 5314051 -------- 5353026 -------- 5388961 -------- 5424644 -------- 5452676 -------- 5483553 -------- 5516612 -------- 5551041 -------- 5579878 -------- 5612576 -------- 5643427 -------- 5673666 -------- 5709218 -------- 5737221 -------- 5766119 -------- 5795044 -------- 5826560 -------- 5855943 -------- 5889604 -------- 5917607 -------- 5942535 -------- 5969639 -------- 5999557
- │ │ │ │ │ histogram(13)= 0 57581 0 48216 0 40282 0 34212 0 22732 0 16572 0 7729
- │ │ │ │ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ---- 6 -
- │ │ │ │ │ histogram(20)= 0 0 14405 3001 24609 4802 27010 4802 26410 6603 25810 4202 28211 3001 24609 4202 23082 2564.6
- │ │ │ │ │ <--- '1995-12-31' ------- '1996-01-07' ------- '1996-01-21' ------- '1996-02-01' ------- '1996-02-14' ------- '1996-02-23' ------- '1996-03-07' ------- '1996-03-21' ------- '1996-03-31'
+ │ │ │ │ ├── stats: [rows=238668.4, distinct(10)=225118, null(10)=0, avgsize(10)=4, distinct(13)=7, null(13)=0, avgsize(13)=1, distinct(20)=91, null(20)=0, avgsize(20)=4]
+ │ │ │ │ │ histogram(10)= 0 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1145.6 47.724 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1145.6 47.724 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1145.6 47.724 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862
+ │ │ │ │ │ <--- 197 --------- 23686 -------- 53253 -------- 90435 -------- 121730 -------- 153280 -------- 175456 -------- 208548 -------- 242209 -------- 273057 -------- 296640 -------- 330307 -------- 360999 -------- 386307 -------- 420225 -------- 450050 -------- 477795 -------- 504711 -------- 533153 -------- 556672 -------- 582243 -------- 613729 -------- 646117 -------- 675840 -------- 706048 -------- 733063 -------- 769282 -------- 793922 -------- 820357 -------- 849536 -------- 875719 -------- 905028 -------- 940643 -------- 968355 -------- 998721 -------- 1023621 -------- 1059424 -------- 1084932 -------- 1115553 -------- 1139363 -------- 1167361 -------- 1194400 -------- 1225984 -------- 1253861 -------- 1281633 -------- 1304999 -------- 1336355 -------- 1370759 -------- 1400832 -------- 1434085 -------- 1458852 -------- 1491427 -------- 1525120 -------- 1555205 -------- 1591300 -------- 1619426 -------- 1651458 -------- 1682950 -------- 1711399 -------- 1747591 -------- 1787205 -------- 1822240 -------- 1856163 -------- 1886915 -------- 1910949 -------- 1947202 -------- 1974311 -------- 2009286 -------- 2044034 -------- 2079104 -------- 2103488 -------- 2134657 -------- 2164293 -------- 2204514 -------- 2230823 -------- 2265253 -------- 2289826 -------- 2329539 -------- 2364455 -------- 2393507 -------- 2414628 -------- 2440228 -------- 2465255 -------- 2489568 -------- 2520900 -------- 2554919 -------- 2583333 -------- 2612966 -------- 2644833 -------- 2667362 -------- 2702784 -------- 2727394 -------- 2759748 -------- 2794531 -------- 2822214 -------- 2846624 -------- 2883748 -------- 2919586 -------- 2951908 -------- 2980068 -------- 3014726 -------- 3050725 -------- 3081028 -------- 3113351 -------- 3150243 -------- 3185669 -------- 3214311 -------- 3241281 -------- 3275748 -------- 3303232 -------- 3339559 -------- 3370627 -------- 3393664 -------- 3435265 -------- 3464581 -------- 3489026 -------- 3516096 -------- 3548480 -------- 3587015 -------- 3611239 -------- 3638724 -------- 3668641 -------- 3695751 -------- 3729636 -------- 3751523 -------- 3784608 -------- 3815715 -------- 3848608 -------- 3881184 -------- 3908738 -------- 3940002 -------- 3966176 -------- 4001984 -------- 4035687 -------- 4065283 -------- 4092834 -------- 4133062 -------- 4160613 -------- 4196421 -------- 4223713 -------- 4254788 -------- 4291040 -------- 4313664 -------- 4342823 -------- 4369952 -------- 4391684 -------- 4419040 -------- 4449921 -------- 4471781 -------- 4506210 -------- 4538176 -------- 4571297 -------- 4601121 -------- 4630887 -------- 4657476 -------- 4684803 -------- 4714566 -------- 4744070 -------- 4776385 -------- 4807777 -------- 4839491 -------- 4873953 -------- 4902245 -------- 4936263 -------- 4970721 -------- 5003140 -------- 5029729 -------- 5059010 -------- 5087521 -------- 5121093 -------- 5150405 -------- 5178375 -------- 5203683 -------- 5234531 -------- 5268195 -------- 5300004 -------- 5331558 -------- 5362178 -------- 5385762 -------- 5418498 -------- 5445762 -------- 5483109 -------- 5514561 -------- 5542052 -------- 5569572 -------- 5596102 -------- 5622401 -------- 5652194 -------- 5671362 -------- 5699591 -------- 5727136 -------- 5753284 -------- 5780742 -------- 5809189 -------- 5836545 -------- 5864454 -------- 5894917 -------- 5933825 -------- 5968933 -------- 5999590
+ │ │ │ │ │ histogram(13)= 0 59166 0 53247 0 41862 0 34273 0 25323 0 16516 0 8281.8
+ │ │ │ │ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 --
+ │ │ │ │ │ histogram(20)= 0 0 2820.6 1200 28206 600 27606 3601 25805 3001 25805 3001 27606 2400 26405 3001 25805 4801 24004 3000.6
+ │ │ │ │ │ <--- '1995-12-31' -------- '1996-01-02' ------- '1996-01-14' ------- '1996-01-25' ------- '1996-02-07' ------- '1996-02-18' ------- '1996-02-28' ------- '1996-03-12' ------- '1996-03-22' ------- '1996-03-31'
│ │ │ │ ├── key: (10,13)
│ │ │ │ └── fd: (10,13)-->(20)
│ │ │ └── projections
@@ -160,24 +160,24 @@ project
│ │ │ ├── save-table-name: q15_project_12
│ │ │ ├── columns: column48:48(float!null) l_suppkey:32(int!null)
│ │ │ ├── immutable
- │ │ │ ├── stats: [rows=227324.7, distinct(32)=9920, null(32)=0, avgsize(32)=4, distinct(48)=227325, null(48)=0, avgsize(48)=8]
+ │ │ │ ├── stats: [rows=238668.4, distinct(32)=9920, null(32)=0, avgsize(32)=4, distinct(48)=238668, null(48)=0, avgsize(48)=18]
│ │ │ ├── index-join lineitem
│ │ │ │ ├── save-table-name: q15_index_join_13
│ │ │ │ ├── columns: l_suppkey:32(int!null) l_extendedprice:35(float!null) l_discount:36(float!null) l_shipdate:40(date!null)
- │ │ │ │ ├── stats: [rows=227324.7, distinct(32)=9920, null(32)=0, avgsize(32)=4, distinct(35)=206167, null(35)=0, avgsize(35)=4, distinct(36)=11, null(36)=0, avgsize(36)=4, distinct(40)=91, null(40)=0, avgsize(40)=4, distinct(35,36)=227325, null(35,36)=0, avgsize(35,36)=8]
- │ │ │ │ │ histogram(40)= 0 0 14405 3001 24609 4802 27010 4802 26410 6603 25810 4202 28211 3001 24609 4202 23082 2564.6
- │ │ │ │ │ <--- '1995-12-31' ------- '1996-01-07' ------- '1996-01-21' ------- '1996-02-01' ------- '1996-02-14' ------- '1996-02-23' ------- '1996-03-07' ------- '1996-03-21' ------- '1996-03-31'
+ │ │ │ │ ├── stats: [rows=238668.4, distinct(32)=9920, null(32)=0, avgsize(32)=4, distinct(35)=214148, null(35)=0, avgsize(35)=9, distinct(36)=11, null(36)=0, avgsize(36)=9, distinct(40)=91, null(40)=0, avgsize(40)=4, distinct(35,36)=238668, null(35,36)=0, avgsize(35,36)=18]
+ │ │ │ │ │ histogram(40)= 0 0 2820.6 1200 28206 600 27606 3601 25805 3001 25805 3001 27606 2400 26405 3001 25805 4801 24004 3000.6
+ │ │ │ │ │ <--- '1995-12-31' -------- '1996-01-02' ------- '1996-01-14' ------- '1996-01-25' ------- '1996-02-07' ------- '1996-02-18' ------- '1996-02-28' ------- '1996-03-12' ------- '1996-03-22' ------- '1996-03-31'
│ │ │ │ └── scan lineitem@l_sd
│ │ │ │ ├── save-table-name: q15_scan_14
│ │ │ │ ├── columns: l_orderkey:30(int!null) l_linenumber:33(int!null) l_shipdate:40(date!null)
│ │ │ │ ├── constraint: /40/30/33: [/'1996-01-01' - /'1996-03-31']
- │ │ │ │ ├── stats: [rows=227324.7, distinct(30)=215016, null(30)=0, avgsize(30)=4, distinct(33)=7, null(33)=0, avgsize(33)=4, distinct(40)=91, null(40)=0, avgsize(40)=4]
- │ │ │ │ │ histogram(30)= 0 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1113.9 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724 1136.6 22.724
- │ │ │ │ │ <--- 576 --------- 38535 -------- 66885 -------- 93380 -------- 127425 -------- 157218 -------- 184483 -------- 215330 -------- 252869 -------- 283878 -------- 313798 -------- 337056 -------- 372549 -------- 399591 -------- 426245 -------- 460578 -------- 498439 -------- 526049 -------- 554468 -------- 577921 -------- 609187 -------- 639524 -------- 665345 -------- 686180 -------- 721539 -------- 755680 -------- 782756 -------- 814496 -------- 845446 -------- 872130 -------- 910912 -------- 933697 -------- 965184 -------- 1000353 -------- 1038658 -------- 1073667 -------- 1097891 -------- 1131330 -------- 1157732 -------- 1179943 -------- 1206401 -------- 1230150 -------- 1261824 -------- 1293217 -------- 1326754 -------- 1357573 -------- 1390145 -------- 1429312 -------- 1460418 -------- 1491104 -------- 1523937 -------- 1559812 -------- 1591653 -------- 1615174 -------- 1646759 -------- 1670465 -------- 1696321 -------- 1724192 -------- 1748033 -------- 1777570 -------- 1807428 -------- 1836962 -------- 1872481 -------- 1902817 -------- 1928324 -------- 1960775 -------- 1985989 -------- 2019107 -------- 2044613 -------- 2071490 -------- 2101959 -------- 2135555 -------- 2164486 -------- 2186337 -------- 2213989 -------- 2246309 -------- 2276992 -------- 2306403 -------- 2329921 -------- 2354977 -------- 2380711 -------- 2410529 -------- 2437920 -------- 2462017 -------- 2483714 -------- 2513920 -------- 2542855 -------- 2574112 -------- 2596035 -------- 2625031 -------- 2658051 -------- 2695046 -------- 2725222 -------- 2754245 -------- 2777702 -------- 2804896 -------- 2844579 -------- 2873860 -------- 2903459 -------- 2933249 -------- 2965479 -------- 2996160 -------- 3022976 -------- 3053152 -------- 3083623 -------- 3111136 -------- 3144033 -------- 3180134 -------- 3209799 -------- 3239394 -------- 3270886 -------- 3297664 -------- 3329444 -------- 3357574 -------- 3380838 -------- 3412196 -------- 3438917 -------- 3462467 -------- 3498629 -------- 3530208 -------- 3562148 -------- 3589889 -------- 3621063 -------- 3655456 -------- 3686724 -------- 3709029 -------- 3738215 -------- 3767687 -------- 3804547 -------- 3831142 -------- 3875111 -------- 3905605 -------- 3933795 -------- 3966593 -------- 3995558 -------- 4020134 -------- 4052513 -------- 4078949 -------- 4114208 -------- 4149762 -------- 4176135 -------- 4207782 -------- 4241376 -------- 4270502 -------- 4304167 -------- 4333669 -------- 4362818 -------- 4393537 -------- 4423076 -------- 4452064 -------- 4491143 -------- 4522723 -------- 4550883 -------- 4581382 -------- 4616002 -------- 4649410 -------- 4680485 -------- 4715584 -------- 4740036 -------- 4771554 -------- 4799461 -------- 4826690 -------- 4855525 -------- 4887974 -------- 4917479 -------- 4950885 -------- 4984195 -------- 5010113 -------- 5033571 -------- 5065472 -------- 5100512 -------- 5129413 -------- 5160069 -------- 5186596 -------- 5221538 -------- 5252964 -------- 5284069 -------- 5314051 -------- 5353026 -------- 5388961 -------- 5424644 -------- 5452676 -------- 5483553 -------- 5516612 -------- 5551041 -------- 5579878 -------- 5612576 -------- 5643427 -------- 5673666 -------- 5709218 -------- 5737221 -------- 5766119 -------- 5795044 -------- 5826560 -------- 5855943 -------- 5889604 -------- 5917607 -------- 5942535 -------- 5969639 -------- 5999557
- │ │ │ │ │ histogram(33)= 0 57581 0 48216 0 40282 0 34212 0 22732 0 16572 0 7729
- │ │ │ │ │ <---- 0 ----- 1 ----- 2 ----- 3 ----- 4 ----- 5 ---- 6 -
- │ │ │ │ │ histogram(40)= 0 0 14405 3001 24609 4802 27010 4802 26410 6603 25810 4202 28211 3001 24609 4202 23082 2564.6
- │ │ │ │ │ <--- '1995-12-31' ------- '1996-01-07' ------- '1996-01-21' ------- '1996-02-01' ------- '1996-02-14' ------- '1996-02-23' ------- '1996-03-07' ------- '1996-03-21' ------- '1996-03-31'
+ │ │ │ │ ├── stats: [rows=238668.4, distinct(30)=225118, null(30)=0, avgsize(30)=4, distinct(33)=7, null(33)=0, avgsize(33)=1, distinct(40)=91, null(40)=0, avgsize(40)=4]
+ │ │ │ │ │ histogram(30)= 0 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1145.6 47.724 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1145.6 47.724 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1145.6 47.724 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1169.5 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862 1193.3 23.862
+ │ │ │ │ │ <--- 197 --------- 23686 -------- 53253 -------- 90435 -------- 121730 -------- 153280 -------- 175456 -------- 208548 -------- 242209 -------- 273057 -------- 296640 -------- 330307 -------- 360999 -------- 386307 -------- 420225 -------- 450050 -------- 477795 -------- 504711 -------- 533153 -------- 556672 -------- 582243 -------- 613729 -------- 646117 -------- 675840 -------- 706048 -------- 733063 -------- 769282 -------- 793922 -------- 820357 -------- 849536 -------- 875719 -------- 905028 -------- 940643 -------- 968355 -------- 998721 -------- 1023621 -------- 1059424 -------- 1084932 -------- 1115553 -------- 1139363 -------- 1167361 -------- 1194400 -------- 1225984 -------- 1253861 -------- 1281633 -------- 1304999 -------- 1336355 -------- 1370759 -------- 1400832 -------- 1434085 -------- 1458852 -------- 1491427 -------- 1525120 -------- 1555205 -------- 1591300 -------- 1619426 -------- 1651458 -------- 1682950 -------- 1711399 -------- 1747591 -------- 1787205 -------- 1822240 -------- 1856163 -------- 1886915 -------- 1910949 -------- 1947202 -------- 1974311 -------- 2009286 -------- 2044034 -------- 2079104 -------- 2103488 -------- 2134657 -------- 2164293 -------- 2204514 -------- 2230823 -------- 2265253 -------- 2289826 -------- 2329539 -------- 2364455 -------- 2393507 -------- 2414628 -------- 2440228 -------- 2465255 -------- 2489568 -------- 2520900 -------- 2554919 -------- 2583333 -------- 2612966 -------- 2644833 -------- 2667362 -------- 2702784 -------- 2727394 -------- 2759748 -------- 2794531 -------- 2822214 -------- 2846624 -------- 2883748 -------- 2919586 -------- 2951908 -------- 2980068 -------- 3014726 -------- 3050725 -------- 3081028 -------- 3113351 -------- 3150243 -------- 3185669 -------- 3214311 -------- 3241281 -------- 3275748 -------- 3303232 -------- 3339559 -------- 3370627 -------- 3393664 -------- 3435265 -------- 3464581 -------- 3489026 -------- 3516096 -------- 3548480 -------- 3587015 -------- 3611239 -------- 3638724 -------- 3668641 -------- 3695751 -------- 3729636 -------- 3751523 -------- 3784608 -------- 3815715 -------- 3848608 -------- 3881184 -------- 3908738 -------- 3940002 -------- 3966176 -------- 4001984 -------- 4035687 -------- 4065283 -------- 4092834 -------- 4133062 -------- 4160613 -------- 4196421 -------- 4223713 -------- 4254788 -------- 4291040 -------- 4313664 -------- 4342823 -------- 4369952 -------- 4391684 -------- 4419040 -------- 4449921 -------- 4471781 -------- 4506210 -------- 4538176 -------- 4571297 -------- 4601121 -------- 4630887 -------- 4657476 -------- 4684803 -------- 4714566 -------- 4744070 -------- 4776385 -------- 4807777 -------- 4839491 -------- 4873953 -------- 4902245 -------- 4936263 -------- 4970721 -------- 5003140 -------- 5029729 -------- 5059010 -------- 5087521 -------- 5121093 -------- 5150405 -------- 5178375 -------- 5203683 -------- 5234531 -------- 5268195 -------- 5300004 -------- 5331558 -------- 5362178 -------- 5385762 -------- 5418498 -------- 5445762 -------- 5483109 -------- 5514561 -------- 5542052 -------- 5569572 -------- 5596102 -------- 5622401 -------- 5652194 -------- 5671362 -------- 5699591 -------- 5727136 -------- 5753284 -------- 5780742 -------- 5809189 -------- 5836545 -------- 5864454 -------- 5894917 -------- 5933825 -------- 5968933 -------- 5999590
+ │ │ │ │ │ histogram(33)= 0 59166 0 53247 0 41862 0 34273 0 25323 0 16516 0 8281.8
+ │ │ │ │ │ <---- 1 ----- 2 ----- 3 ----- 4 ----- 5 ----- 6 ----- 7 --
+ │ │ │ │ │ histogram(40)= 0 0 2820.6 1200 28206 600 27606 3601 25805 3001 25805 3001 27606 2400 26405 3001 25805 4801 24004 3000.6
+ │ │ │ │ │ <--- '1995-12-31' -------- '1996-01-02' ------- '1996-01-14' ------- '1996-01-25' ------- '1996-02-07' ------- '1996-02-18' ------- '1996-02-28' ------- '1996-03-12' ------- '1996-03-22' ------- '1996-03-31'
│ │ │ │ ├── key: (30,33)
│ │ │ │ └── fd: (30,33)-->(40)
│ │ │ └── projections
@@ -201,7 +201,7 @@ column_names row_count distinct_count null_count
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{s_address} 3333.00 3333.00 <== 2835.00 2835.00 <== 0.00 1.00
{s_name} 3333.00 3333.00 <== 2834.00 2834.00 <== 0.00 1.00
-{s_phone} 3333.00 3333.00 <== 2828.00 2828.00 <== 0.00 1.00
+{s_phone} 3333.00 3333.00 <== 2835.00 2835.00 <== 0.00 1.00
{s_suppkey} 3333.00 3333.00 <== 3307.00 3307.00 <== 0.00 1.00
{total_revenue} 3333.00 3333.00 <== 2100.00 2100.00 <== 0.00 1.00
@@ -218,7 +218,7 @@ column_names row_count_est row_count_err distinct_count_est distinct_count_e
{l_suppkey} 3333.00 3333.00 <== 3307.00 3307.00 <== 0.00 1.00
{s_address} 3333.00 3333.00 <== 2835.00 2835.00 <== 0.00 1.00
{s_name} 3333.00 3333.00 <== 2834.00 2834.00 <== 0.00 1.00
-{s_phone} 3333.00 3333.00 <== 2828.00 2828.00 <== 0.00 1.00
+{s_phone} 3333.00 3333.00 <== 2835.00 2835.00 <== 0.00 1.00
{s_suppkey} 3333.00 3333.00 <== 3307.00 3307.00 <== 0.00 1.00
{sum} 3333.00 3333.00 <== 2100.00 2100.00 <== 0.00 1.00
@@ -232,7 +232,7 @@ column_names row_count distinct_count null_count
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{s_address} 10000.00 1.09 10000.00 1.09 0.00 1.00
{s_name} 10000.00 1.09 9990.00 1.09 0.00 1.00
-{s_phone} 10000.00 1.09 9840.00 1.07 0.00 1.00
+{s_phone} 10000.00 1.09 10000.00 1.09 0.00 1.00
{s_suppkey} 10000.00 1.09 9920.00 1.09 0.00 1.00
----Stats for q15_sort_4----
@@ -268,8 +268,8 @@ column_names row_count distinct_count null_count
{l_suppkey} 225954 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column28} 227325.00 1.01 227325.00 1.03 0.00 1.00
-{l_suppkey} 227325.00 1.01 9920.00 1.00 0.00 1.00
+{column28} 238668.00 1.06 238668.00 1.08 0.00 1.00
+{l_suppkey} 238668.00 1.06 9920.00 1.00 0.00 1.00
----Stats for q15_index_join_8----
column_names row_count distinct_count null_count
@@ -279,10 +279,10 @@ column_names row_count distinct_count null_count
{l_suppkey} 225954 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 227325.00 1.01 11.00 1.00 0.00 1.00
-{l_extendedprice} 227325.00 1.01 206167.00 1.05 0.00 1.00
-{l_shipdate} 227325.00 1.01 91.00 1.00 0.00 1.00
-{l_suppkey} 227325.00 1.01 9920.00 1.00 0.00 1.00
+{l_discount} 238668.00 1.06 11.00 1.00 0.00 1.00
+{l_extendedprice} 238668.00 1.06 214148.00 1.09 0.00 1.00
+{l_shipdate} 238668.00 1.06 91.00 1.00 0.00 1.00
+{l_suppkey} 238668.00 1.06 9920.00 1.00 0.00 1.00
----Stats for q15_scan_9----
column_names row_count distinct_count null_count
@@ -291,9 +291,9 @@ column_names row_count distinct_count null_count
{l_shipdate} 225954 91 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 227325.00 1.01 7.00 1.00 0.00 1.00
-{l_orderkey} 227325.00 1.01 215016.00 2.26 <== 0.00 1.00
-{l_shipdate} 227325.00 1.01 91.00 1.00 0.00 1.00
+{l_linenumber} 238668.00 1.06 7.00 1.00 0.00 1.00
+{l_orderkey} 238668.00 1.06 225118.00 2.36 <== 0.00 1.00
+{l_shipdate} 238668.00 1.06 91.00 1.00 0.00 1.00
----Stats for q15_scalar_group_by_10----
column_names row_count distinct_count null_count
@@ -317,8 +317,8 @@ column_names row_count distinct_count null_count
{l_suppkey} 225954 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column48} 227325.00 1.01 227325.00 1.03 0.00 1.00
-{l_suppkey} 227325.00 1.01 9920.00 1.00 0.00 1.00
+{column48} 238668.00 1.06 238668.00 1.08 0.00 1.00
+{l_suppkey} 238668.00 1.06 9920.00 1.00 0.00 1.00
----Stats for q15_index_join_13----
column_names row_count distinct_count null_count
@@ -328,10 +328,10 @@ column_names row_count distinct_count null_count
{l_suppkey} 225954 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 227325.00 1.01 11.00 1.00 0.00 1.00
-{l_extendedprice} 227325.00 1.01 206167.00 1.05 0.00 1.00
-{l_shipdate} 227325.00 1.01 91.00 1.00 0.00 1.00
-{l_suppkey} 227325.00 1.01 9920.00 1.00 0.00 1.00
+{l_discount} 238668.00 1.06 11.00 1.00 0.00 1.00
+{l_extendedprice} 238668.00 1.06 214148.00 1.09 0.00 1.00
+{l_shipdate} 238668.00 1.06 91.00 1.00 0.00 1.00
+{l_suppkey} 238668.00 1.06 9920.00 1.00 0.00 1.00
----Stats for q15_scan_14----
column_names row_count distinct_count null_count
@@ -340,8 +340,8 @@ column_names row_count distinct_count null_count
{l_shipdate} 225954 91 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 227325.00 1.01 7.00 1.00 0.00 1.00
-{l_orderkey} 227325.00 1.01 215016.00 2.26 <== 0.00 1.00
-{l_shipdate} 227325.00 1.01 91.00 1.00 0.00 1.00
+{l_linenumber} 238668.00 1.06 7.00 1.00 0.00 1.00
+{l_orderkey} 238668.00 1.06 225118.00 2.36 <== 0.00 1.00
+{l_shipdate} 238668.00 1.06 91.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q16 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q16
index 0c38a3e913e4..a6f7db54965a 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q16
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q16
@@ -54,7 +54,7 @@ ORDER BY
sort
├── save-table-name: q16_sort_1
├── columns: p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null) supplier_cnt:28(int!null)
- ├── stats: [rows=9970.637, distinct(11)=24.9999, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=8, null(13)=0, avgsize(13)=4, distinct(28)=9970.64, null(28)=0, avgsize(28)=12, distinct(11-13)=9970.64, null(11-13)=0, avgsize(11-13)=12]
+ ├── stats: [rows=9929.297, distinct(11)=24.9999, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=8, null(13)=0, avgsize(13)=2, distinct(28)=9929.3, null(28)=0, avgsize(28)=35, distinct(11-13)=9929.3, null(11-13)=0, avgsize(11-13)=35]
├── key: (11-13)
├── fd: (11-13)-->(28)
├── ordering: -28,+11,+12,+13
@@ -62,49 +62,49 @@ sort
├── save-table-name: q16_group_by_2
├── columns: p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null) count:28(int!null)
├── grouping columns: p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
- ├── stats: [rows=9970.637, distinct(11)=24.9999, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=8, null(13)=0, avgsize(13)=4, distinct(28)=9970.64, null(28)=0, avgsize(28)=12, distinct(11-13)=9970.64, null(11-13)=0, avgsize(11-13)=12]
+ ├── stats: [rows=9929.297, distinct(11)=24.9999, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=8, null(13)=0, avgsize(13)=2, distinct(28)=9929.3, null(28)=0, avgsize(28)=35, distinct(11-13)=9929.3, null(11-13)=0, avgsize(11-13)=35]
├── key: (11-13)
├── fd: (11-13)-->(28)
├── distinct-on
│ ├── save-table-name: q16_distinct_on_3
│ ├── columns: ps_suppkey:2(int!null) p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
│ ├── grouping columns: ps_suppkey:2(int!null) p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
- │ ├── stats: [rows=28917.7, distinct(2)=9382.35, null(2)=0, avgsize(2)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=8, null(13)=0, avgsize(13)=4, distinct(11-13)=9970.64, null(11-13)=0, avgsize(11-13)=12, distinct(2,11-13)=28917.7, null(2,11-13)=0, avgsize(2,11-13)=16]
+ │ ├── stats: [rows=28797.62, distinct(2)=9375.8, null(2)=0, avgsize(2)=3, distinct(11)=24.9999, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=8, null(13)=0, avgsize(13)=2, distinct(11-13)=9929.3, null(11-13)=0, avgsize(11-13)=35, distinct(2,11-13)=28797.6, null(2,11-13)=0, avgsize(2,11-13)=38]
│ ├── key: (2,11-13)
│ └── anti-join (hash)
│ ├── save-table-name: q16_anti_join_4
│ ├── columns: ps_partkey:1(int!null) ps_suppkey:2(int!null) p_partkey:8(int!null) p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
- │ ├── stats: [rows=28917.7, distinct(1)=10702.2, null(1)=0, avgsize(1)=4, distinct(2)=9382.35, null(2)=0, avgsize(2)=4, distinct(8)=10702.2, null(8)=0, avgsize(8)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=8, null(13)=0, avgsize(13)=4, distinct(11-13)=9970.64, null(11-13)=0, avgsize(11-13)=12, distinct(2,11-13)=28917.7, null(2,11-13)=0, avgsize(2,11-13)=16]
+ │ ├── stats: [rows=28797.62, distinct(1)=10657.8, null(1)=0, avgsize(1)=4, distinct(2)=9375.8, null(2)=0, avgsize(2)=3, distinct(8)=10657.8, null(8)=0, avgsize(8)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=8, null(13)=0, avgsize(13)=2, distinct(11-13)=9929.3, null(11-13)=0, avgsize(11-13)=35, distinct(2,11-13)=28797.6, null(2,11-13)=0, avgsize(2,11-13)=38]
│ ├── key: (2,8)
│ ├── fd: (8)-->(11-13), (1)==(8), (8)==(1)
│ ├── inner-join (lookup partsupp)
│ │ ├── save-table-name: q16_lookup_join_5
│ │ ├── columns: ps_partkey:1(int!null) ps_suppkey:2(int!null) p_partkey:8(int!null) p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
│ │ ├── key columns: [8] = [1]
- │ │ ├── stats: [rows=42976.28, distinct(1)=10702.2, null(1)=0, avgsize(1)=4, distinct(2)=9789.68, null(2)=0, avgsize(2)=4, distinct(8)=10702.2, null(8)=0, avgsize(8)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=8, null(13)=0, avgsize(13)=4]
+ │ │ ├── stats: [rows=42797.83, distinct(1)=10657.8, null(1)=0, avgsize(1)=4, distinct(2)=9787.31, null(2)=0, avgsize(2)=3, distinct(8)=10657.8, null(8)=0, avgsize(8)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=8, null(13)=0, avgsize(13)=2]
│ │ ├── key: (2,8)
│ │ ├── fd: (8)-->(11-13), (1)==(8), (8)==(1)
│ │ ├── select
│ │ │ ├── save-table-name: q16_select_6
│ │ │ ├── columns: p_partkey:8(int!null) p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
- │ │ │ ├── stats: [rows=10703.3, distinct(8)=10702.2, null(8)=0, avgsize(8)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=8, null(13)=0, avgsize(13)=4, distinct(11,13)=199.999, null(11,13)=0, avgsize(11,13)=8, distinct(11-13)=10683.9, null(11-13)=0, avgsize(11-13)=12]
- │ │ │ │ histogram(11)= 0 473.09 7339.4 0 0 0 2433.8 457.03
- │ │ │ │ <--- 'Brand#11' -------- 'Brand#45' --- e'Brand#45\x00' -------- 'Brand#55'
- │ │ │ │ histogram(13)= 0 1337.9 0 1337.9 0 1337.9 0 1337.9 0 1337.9 0 1337.9 0 1337.9 0 1337.9
+ │ │ │ ├── stats: [rows=10658.85, distinct(8)=10657.8, null(8)=0, avgsize(8)=4, distinct(11)=24.9999, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=8, null(13)=0, avgsize(13)=2, distinct(11,13)=199.999, null(11,13)=0, avgsize(11,13)=12, distinct(11-13)=10639.6, null(11-13)=0, avgsize(11-13)=35]
+ │ │ │ │ histogram(11)= 0 407.17 7376.2 0 0 0 2446 429.55
+ │ │ │ │ <--- 'Brand#11' -------- 'Brand#45' --- e'Brand#45\x00' ------ 'Brand#55'
+ │ │ │ │ histogram(13)= 0 1332.4 0 1332.4 0 1332.4 0 1332.4 0 1332.4 0 1332.4 0 1332.4 0 1332.4
│ │ │ │ <---- 3 ------ 9 ------ 14 ----- 19 ----- 23 ----- 36 ----- 45 ----- 49 -
│ │ │ ├── key: (8)
│ │ │ ├── fd: (8)-->(11-13)
│ │ │ ├── scan part
│ │ │ │ ├── save-table-name: q16_scan_7
│ │ │ │ ├── columns: p_partkey:8(int!null) p_brand:11(char!null) p_type:12(varchar!null) p_size:13(int!null)
- │ │ │ │ ├── stats: [rows=200000, distinct(8)=199241, null(8)=0, avgsize(8)=4, distinct(11)=25, null(11)=0, avgsize(11)=4, distinct(12)=150, null(12)=0, avgsize(12)=4, distinct(13)=50, null(13)=0, avgsize(13)=4, distinct(11,13)=1250, null(11,13)=0, avgsize(11,13)=8, distinct(11-13)=187500, null(11-13)=0, avgsize(11-13)=12]
- │ │ │ │ │ histogram(8)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ histogram(11)= 0 8840 1.8262e+05 8540
- │ │ │ │ │ <--- 'Brand#11' ------------ 'Brand#55'
- │ │ │ │ │ histogram(12)= 0 1340 1.975e+05 1160
- │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ----------- 'STANDARD POLISHED TIN'
- │ │ │ │ │ histogram(13)= 0 3740 1.9266e+05 3600
+ │ │ │ │ ├── stats: [rows=200000, distinct(8)=199241, null(8)=0, avgsize(8)=4, distinct(11)=25, null(11)=0, avgsize(11)=10, distinct(12)=150, null(12)=0, avgsize(12)=23, distinct(13)=50, null(13)=0, avgsize(13)=2, distinct(11,13)=1250, null(11,13)=0, avgsize(11,13)=12, distinct(11-13)=187500, null(11-13)=0, avgsize(11-13)=35]
+ │ │ │ │ │ histogram(8)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ histogram(11)= 0 7640 1.843e+05 8060
+ │ │ │ │ │ <--- 'Brand#11' ----------- 'Brand#55'
+ │ │ │ │ │ histogram(12)= 0 1360 1.9708e+05 1560
+ │ │ │ │ │ <--- 'ECONOMY ANODIZED BRASS' ------------ 'STANDARD POLISHED TIN'
+ │ │ │ │ │ histogram(13)= 0 4240 1.9186e+05 3900
│ │ │ │ │ <--- 1 ------------- 50
│ │ │ │ ├── key: (8)
│ │ │ │ └── fd: (8)-->(11-13)
@@ -116,17 +116,17 @@ sort
│ ├── select
│ │ ├── save-table-name: q16_select_8
│ │ ├── columns: s_suppkey:19(int!null) s_comment:25(varchar!null)
- │ │ ├── stats: [rows=3333.333, distinct(19)=3328.26, null(19)=0, avgsize(19)=4, distinct(25)=3333.33, null(25)=0, avgsize(25)=4]
+ │ │ ├── stats: [rows=3333.333, distinct(19)=3328.26, null(19)=0, avgsize(19)=3, distinct(25)=3333.33, null(25)=0, avgsize(25)=65]
│ │ ├── key: (19)
│ │ ├── fd: (19)-->(25)
│ │ ├── scan supplier
│ │ │ ├── save-table-name: q16_scan_9
│ │ │ ├── columns: s_suppkey:19(int!null) s_comment:25(varchar!null)
- │ │ │ ├── stats: [rows=10000, distinct(19)=9920, null(19)=0, avgsize(19)=4, distinct(25)=9903, null(25)=0, avgsize(25)=4]
+ │ │ │ ├── stats: [rows=10000, distinct(19)=9920, null(19)=0, avgsize(19)=3, distinct(25)=9934, null(25)=0, avgsize(25)=65]
│ │ │ │ histogram(19)= 0 0 0 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 49 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 50 1 0 0
│ │ │ │ <--- -9223372036854775808 --- 1 ---- 51 ---- 101 ---- 151 ---- 201 ---- 251 ---- 301 ---- 351 ---- 401 ---- 451 ---- 501 ---- 551 ---- 601 ---- 651 ---- 701 ---- 751 ---- 801 ---- 851 ---- 901 ---- 951 ---- 1001 ---- 1051 ---- 1101 ---- 1151 ---- 1201 ---- 1251 ---- 1301 ---- 1351 ---- 1401 ---- 1451 ---- 1501 ---- 1551 ---- 1601 ---- 1651 ---- 1701 ---- 1751 ---- 1801 ---- 1851 ---- 1901 ---- 1951 ---- 2001 ---- 2051 ---- 2101 ---- 2151 ---- 2201 ---- 2251 ---- 2301 ---- 2351 ---- 2401 ---- 2451 ---- 2501 ---- 2551 ---- 2601 ---- 2651 ---- 2701 ---- 2751 ---- 2801 ---- 2851 ---- 2901 ---- 2951 ---- 3001 ---- 3051 ---- 3101 ---- 3151 ---- 3201 ---- 3251 ---- 3301 ---- 3351 ---- 3401 ---- 3451 ---- 3501 ---- 3551 ---- 3601 ---- 3651 ---- 3701 ---- 3751 ---- 3801 ---- 3851 ---- 3901 ---- 3951 ---- 4001 ---- 4051 ---- 4101 ---- 4151 ---- 4201 ---- 4251 ---- 4301 ---- 4351 ---- 4401 ---- 4451 ---- 4501 ---- 4551 ---- 4601 ---- 4651 ---- 4701 ---- 4751 ---- 4801 ---- 4851 ---- 4901 ---- 4951 ---- 5001 ---- 5051 ---- 5101 ---- 5151 ---- 5201 ---- 5251 ---- 5301 ---- 5351 ---- 5401 ---- 5451 ---- 5501 ---- 5551 ---- 5601 ---- 5651 ---- 5701 ---- 5751 ---- 5801 ---- 5851 ---- 5901 ---- 5951 ---- 6001 ---- 6051 ---- 6101 ---- 6151 ---- 6201 ---- 6251 ---- 6301 ---- 6351 ---- 6401 ---- 6451 ---- 6501 ---- 6551 ---- 6601 ---- 6651 ---- 6701 ---- 6751 ---- 6801 ---- 6851 ---- 6901 ---- 6951 ---- 7001 ---- 7051 ---- 7101 ---- 7151 ---- 7201 ---- 7251 ---- 7301 ---- 7351 ---- 7401 ---- 7451 ---- 7501 ---- 7552 ---- 7603 ---- 7654 ---- 7705 ---- 7756 ---- 7807 ---- 7858 ---- 7909 ---- 7960 ---- 8011 ---- 8062 ---- 8113 ---- 8164 ---- 8215 ---- 8266 ---- 8317 ---- 8368 ---- 8419 ---- 8470 ---- 8521 ---- 8572 ---- 8623 ---- 8674 ---- 8725 ---- 8776 ---- 8827 ---- 8878 ---- 8929 ---- 8980 ---- 9031 ---- 9082 ---- 9133 ---- 9184 ---- 9235 ---- 9286 ---- 9337 ---- 9388 ---- 9439 ---- 9490 ---- 9541 ---- 9592 ---- 9643 ---- 9694 ---- 9745 ---- 9796 ---- 9847 ---- 9898 ---- 9949 ---- 10000 --- 9223372036854775807
- │ │ │ │ histogram(25)= 0 1 9998 1
- │ │ │ │ <--- ' A ability south main close despite clearly. Who hold sense everyone. Cou' ------ 'zine know whatever discuss. Realize brother co'
+ │ │ │ │ histogram(25)= 0 1 9998 1
+ │ │ │ │ <--- ' about the blithely express foxes. bli' ------ 'zzle furiously. bold accounts haggle furiously ironic excuses. fur'
│ │ │ ├── key: (19)
│ │ │ └── fd: (19)-->(25)
│ │ └── filters
@@ -144,10 +144,10 @@ column_names row_count distinct_count null_count
{supplier_cnt} 18314 15 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_brand} 9971.00 1.84 25.00 1.04 0.00 1.00
-{p_size} 9971.00 1.84 8.00 1.00 0.00 1.00
-{p_type} 9971.00 1.84 150.00 1.03 0.00 1.00
-{supplier_cnt} 9971.00 1.84 9971.00 664.73 <== 0.00 1.00
+{p_brand} 9929.00 1.84 25.00 1.04 0.00 1.00
+{p_size} 9929.00 1.84 8.00 1.00 0.00 1.00
+{p_type} 9929.00 1.84 150.00 1.03 0.00 1.00
+{supplier_cnt} 9929.00 1.84 9929.00 661.93 <== 0.00 1.00
----Stats for q16_group_by_2----
column_names row_count distinct_count null_count
@@ -157,10 +157,10 @@ column_names row_count distinct_count null_count
{p_type} 18314 145 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{count} 9971.00 1.84 9971.00 664.73 <== 0.00 1.00
-{p_brand} 9971.00 1.84 25.00 1.04 0.00 1.00
-{p_size} 9971.00 1.84 8.00 1.00 0.00 1.00
-{p_type} 9971.00 1.84 150.00 1.03 0.00 1.00
+{count} 9929.00 1.84 9929.00 661.93 <== 0.00 1.00
+{p_brand} 9929.00 1.84 25.00 1.04 0.00 1.00
+{p_size} 9929.00 1.84 8.00 1.00 0.00 1.00
+{p_type} 9929.00 1.84 150.00 1.03 0.00 1.00
----Stats for q16_distinct_on_3----
column_names row_count distinct_count null_count
@@ -170,10 +170,10 @@ column_names row_count distinct_count null_count
{ps_suppkey} 118250 9916 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_brand} 28918.00 4.09 <== 25.00 1.04 0.00 1.00
-{p_size} 28918.00 4.09 <== 8.00 1.00 0.00 1.00
-{p_type} 28918.00 4.09 <== 150.00 1.03 0.00 1.00
-{ps_suppkey} 28918.00 4.09 <== 9382.00 1.06 0.00 1.00
+{p_brand} 28798.00 4.11 <== 25.00 1.04 0.00 1.00
+{p_size} 28798.00 4.11 <== 8.00 1.00 0.00 1.00
+{p_type} 28798.00 4.11 <== 150.00 1.03 0.00 1.00
+{ps_suppkey} 28798.00 4.11 <== 9376.00 1.06 0.00 1.00
----Stats for q16_anti_join_4----
column_names row_count distinct_count null_count
@@ -185,12 +185,12 @@ column_names row_count distinct_count null_count
{ps_suppkey} 118274 9916 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_brand} 28918.00 4.09 <== 25.00 1.04 0.00 1.00
-{p_partkey} 28918.00 4.09 <== 10702.00 2.75 <== 0.00 1.00
-{p_size} 28918.00 4.09 <== 8.00 1.00 0.00 1.00
-{p_type} 28918.00 4.09 <== 150.00 1.03 0.00 1.00
-{ps_partkey} 28918.00 4.09 <== 10702.00 2.75 <== 0.00 1.00
-{ps_suppkey} 28918.00 4.09 <== 9382.00 1.06 0.00 1.00
+{p_brand} 28798.00 4.11 <== 25.00 1.04 0.00 1.00
+{p_partkey} 28798.00 4.11 <== 10658.00 2.76 <== 0.00 1.00
+{p_size} 28798.00 4.11 <== 8.00 1.00 0.00 1.00
+{p_type} 28798.00 4.11 <== 150.00 1.03 0.00 1.00
+{ps_partkey} 28798.00 4.11 <== 10658.00 2.76 <== 0.00 1.00
+{ps_suppkey} 28798.00 4.11 <== 9376.00 1.06 0.00 1.00
----Stats for q16_lookup_join_5----
column_names row_count distinct_count null_count
@@ -202,12 +202,12 @@ column_names row_count distinct_count null_count
{ps_suppkey} 118324 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_brand} 42976.00 2.75 <== 25.00 1.04 0.00 1.00
-{p_partkey} 42976.00 2.75 <== 10702.00 2.75 <== 0.00 1.00
-{p_size} 42976.00 2.75 <== 8.00 1.00 0.00 1.00
-{p_type} 42976.00 2.75 <== 150.00 1.03 0.00 1.00
-{ps_partkey} 42976.00 2.75 <== 10702.00 2.75 <== 0.00 1.00
-{ps_suppkey} 42976.00 2.75 <== 9790.00 1.01 0.00 1.00
+{p_brand} 42798.00 2.76 <== 25.00 1.04 0.00 1.00
+{p_partkey} 42798.00 2.76 <== 10658.00 2.76 <== 0.00 1.00
+{p_size} 42798.00 2.76 <== 8.00 1.00 0.00 1.00
+{p_type} 42798.00 2.76 <== 150.00 1.03 0.00 1.00
+{ps_partkey} 42798.00 2.76 <== 10658.00 2.76 <== 0.00 1.00
+{ps_suppkey} 42798.00 2.76 <== 9787.00 1.01 0.00 1.00
----Stats for q16_select_6----
column_names row_count distinct_count null_count
@@ -217,10 +217,10 @@ column_names row_count distinct_count null_count
{p_type} 29581 145 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_brand} 10703.00 2.76 <== 25.00 1.04 0.00 1.00
-{p_partkey} 10703.00 2.76 <== 10702.00 2.75 <== 0.00 1.00
-{p_size} 10703.00 2.76 <== 8.00 1.00 0.00 1.00
-{p_type} 10703.00 2.76 <== 150.00 1.03 0.00 1.00
+{p_brand} 10659.00 2.78 <== 25.00 1.04 0.00 1.00
+{p_partkey} 10659.00 2.78 <== 10658.00 2.76 <== 0.00 1.00
+{p_size} 10659.00 2.78 <== 8.00 1.00 0.00 1.00
+{p_type} 10659.00 2.78 <== 150.00 1.03 0.00 1.00
----Stats for q16_scan_7----
column_names row_count distinct_count null_count
@@ -250,7 +250,7 @@ column_names row_count distinct_count null_count
{s_suppkey} 10000 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{s_comment} 10000.00 1.00 9903.00 1.00 0.00 1.00
+{s_comment} 10000.00 1.00 9934.00 1.00 0.00 1.00
{s_suppkey} 10000.00 1.00 9920.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q17 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q17
index fc9d3f0a4765..9d0951d4ab99 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q17
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q17
@@ -62,21 +62,21 @@ project
│ │ ├── key columns: [1 4] = [1 4]
│ │ ├── lookup columns are key
│ │ ├── immutable
- │ │ ├── stats: [rows=2852.285, distinct(2)=284.037, null(2)=0, avgsize(2)=4, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=2848.1, null(6)=0, avgsize(6)=4, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(49)=284.037, null(49)=0, avgsize(49)=4]
+ │ │ ├── stats: [rows=2008.967, distinct(2)=200.094, null(2)=0, avgsize(2)=4, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=2006.79, null(6)=0, avgsize(6)=9, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(49)=200.094, null(49)=0, avgsize(49)=4]
│ │ ├── fd: (19)-->(49), (2)==(19), (19)==(2)
│ │ ├── inner-join (lookup lineitem@l_pk)
│ │ │ ├── save-table-name: q17_lookup_join_4
│ │ │ ├── columns: l_orderkey:1(int!null) l_partkey:2(int!null) l_linenumber:4(int!null) p_partkey:19(int!null) "?column?":49(float!null)
│ │ │ ├── key columns: [19] = [2]
│ │ │ ├── immutable
- │ │ │ ├── stats: [rows=8556.854, distinct(1)=8532.95, null(1)=0, avgsize(1)=4, distinct(2)=284.037, null(2)=0, avgsize(2)=4, distinct(4)=7, null(4)=0, avgsize(4)=4, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(49)=284.037, null(49)=0, avgsize(49)=4]
+ │ │ │ ├── stats: [rows=6026.9, distinct(1)=6015.04, null(1)=0, avgsize(1)=4, distinct(2)=200.094, null(2)=0, avgsize(2)=4, distinct(4)=7, null(4)=0, avgsize(4)=1, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(49)=200.094, null(49)=0, avgsize(49)=4]
│ │ │ ├── key: (1,4)
│ │ │ ├── fd: (19)-->(49), (1,4)-->(2), (2)==(19), (19)==(2)
│ │ │ ├── project
│ │ │ │ ├── save-table-name: q17_project_5
│ │ │ │ ├── columns: "?column?":49(float!null) p_partkey:19(int!null)
│ │ │ │ ├── immutable
- │ │ │ │ ├── stats: [rows=284.0375, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(49)=284.037, null(49)=0, avgsize(49)=4]
+ │ │ │ │ ├── stats: [rows=200.0937, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(49)=200.094, null(49)=0, avgsize(49)=4]
│ │ │ │ ├── key: (19)
│ │ │ │ ├── fd: (19)-->(49)
│ │ │ │ ├── group-by (streaming)
@@ -84,7 +84,7 @@ project
│ │ │ │ │ ├── columns: p_partkey:19(int!null) avg:48(float!null)
│ │ │ │ │ ├── grouping columns: p_partkey:19(int!null)
│ │ │ │ │ ├── internal-ordering: +(19|31) opt(22,25)
- │ │ │ │ │ ├── stats: [rows=284.0375, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(48)=284.037, null(48)=0, avgsize(48)=4]
+ │ │ │ │ │ ├── stats: [rows=200.0937, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(48)=200.094, null(48)=0, avgsize(48)=4]
│ │ │ │ │ ├── key: (19)
│ │ │ │ │ ├── fd: (19)-->(48)
│ │ │ │ │ ├── inner-join (lookup lineitem)
@@ -92,24 +92,24 @@ project
│ │ │ │ │ │ ├── columns: p_partkey:19(int!null) p_brand:22(char!null) p_container:25(char!null) l_partkey:31(int!null) l_quantity:34(float!null)
│ │ │ │ │ │ ├── key columns: [30 33] = [30 33]
│ │ │ │ │ │ ├── lookup columns are key
- │ │ │ │ │ │ ├── stats: [rows=8556.877, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(22)=1, null(22)=0, avgsize(22)=4, distinct(25)=1, null(25)=0, avgsize(25)=4, distinct(31)=284.037, null(31)=0, avgsize(31)=4, distinct(34)=50, null(34)=0, avgsize(34)=4]
+ │ │ │ │ │ │ ├── stats: [rows=6026.912, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(22)=1, null(22)=0, avgsize(22)=10, distinct(25)=1, null(25)=0, avgsize(25)=10, distinct(31)=200.094, null(31)=0, avgsize(31)=4, distinct(34)=50, null(34)=0, avgsize(34)=9]
│ │ │ │ │ │ ├── fd: ()-->(22,25), (19)==(31), (31)==(19)
│ │ │ │ │ │ ├── ordering: +(19|31) opt(22,25) [actual: +19]
│ │ │ │ │ │ ├── inner-join (lookup lineitem@l_pk)
│ │ │ │ │ │ │ ├── save-table-name: q17_lookup_join_8
│ │ │ │ │ │ │ ├── columns: p_partkey:19(int!null) p_brand:22(char!null) p_container:25(char!null) l_orderkey:30(int!null) l_partkey:31(int!null) l_linenumber:33(int!null)
│ │ │ │ │ │ │ ├── key columns: [19] = [31]
- │ │ │ │ │ │ │ ├── stats: [rows=8556.877, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(22)=1, null(22)=0, avgsize(22)=4, distinct(25)=1, null(25)=0, avgsize(25)=4, distinct(30)=8532.97, null(30)=0, avgsize(30)=4, distinct(31)=284.037, null(31)=0, avgsize(31)=4, distinct(33)=7, null(33)=0, avgsize(33)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=6026.912, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(22)=1, null(22)=0, avgsize(22)=10, distinct(25)=1, null(25)=0, avgsize(25)=10, distinct(30)=6015.05, null(30)=0, avgsize(30)=4, distinct(31)=200.094, null(31)=0, avgsize(31)=4, distinct(33)=7, null(33)=0, avgsize(33)=1]
│ │ │ │ │ │ │ ├── key: (30,33)
│ │ │ │ │ │ │ ├── fd: ()-->(22,25), (30,33)-->(31), (19)==(31), (31)==(19)
│ │ │ │ │ │ │ ├── ordering: +(19|31) opt(22,25) [actual: +19]
│ │ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ │ ├── save-table-name: q17_select_9
│ │ │ │ │ │ │ │ ├── columns: p_partkey:19(int!null) p_brand:22(char!null) p_container:25(char!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=284.0382, distinct(19)=284.037, null(19)=0, avgsize(19)=4, distinct(22)=1, null(22)=0, avgsize(22)=4, distinct(25)=1, null(25)=0, avgsize(25)=4, distinct(22,25)=1, null(22,25)=0, avgsize(22,25)=8]
- │ │ │ │ │ │ │ │ │ histogram(22)= 0 284.04
+ │ │ │ │ │ │ │ │ ├── stats: [rows=200.0941, distinct(19)=200.094, null(19)=0, avgsize(19)=4, distinct(22)=1, null(22)=0, avgsize(22)=10, distinct(25)=1, null(25)=0, avgsize(25)=10, distinct(22,25)=1, null(22,25)=0, avgsize(22,25)=20]
+ │ │ │ │ │ │ │ │ │ histogram(22)= 0 200.09
│ │ │ │ │ │ │ │ │ <--- 'Brand#23'
- │ │ │ │ │ │ │ │ │ histogram(25)= 0 284.04
+ │ │ │ │ │ │ │ │ │ histogram(25)= 0 200.09
│ │ │ │ │ │ │ │ │ <--- 'MED BOX'
│ │ │ │ │ │ │ │ ├── key: (19)
│ │ │ │ │ │ │ │ ├── fd: ()-->(22,25)
@@ -117,12 +117,12 @@ project
│ │ │ │ │ │ │ │ ├── scan part
│ │ │ │ │ │ │ │ │ ├── save-table-name: q17_scan_10
│ │ │ │ │ │ │ │ │ ├── columns: p_partkey:19(int!null) p_brand:22(char!null) p_container:25(char!null)
- │ │ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(22)=25, null(22)=0, avgsize(22)=4, distinct(25)=28, null(25)=0, avgsize(25)=4, distinct(22,25)=700, null(22,25)=0, avgsize(22,25)=8]
- │ │ │ │ │ │ │ │ │ │ histogram(19)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ │ │ │ │ │ histogram(22)= 0 8840 1.8262e+05 8540
- │ │ │ │ │ │ │ │ │ │ <--- 'Brand#11' ------------ 'Brand#55'
- │ │ │ │ │ │ │ │ │ │ histogram(25)= 0 6480 1.8602e+05 7500
+ │ │ │ │ │ │ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(22)=25, null(22)=0, avgsize(22)=10, distinct(25)=40, null(25)=0, avgsize(25)=10, distinct(22,25)=1000, null(22,25)=0, avgsize(22,25)=20]
+ │ │ │ │ │ │ │ │ │ │ histogram(19)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ │ │ │ │ │ histogram(22)= 0 7640 1.843e+05 8060
+ │ │ │ │ │ │ │ │ │ │ <--- 'Brand#11' ----------- 'Brand#55'
+ │ │ │ │ │ │ │ │ │ │ histogram(25)= 0 5460 1.8978e+05 4760
│ │ │ │ │ │ │ │ │ │ <--- 'JUMBO BAG' ------------ 'WRAP PKG'
│ │ │ │ │ │ │ │ │ ├── key: (19)
│ │ │ │ │ │ │ │ │ ├── fd: (19)-->(22,25)
@@ -169,11 +169,11 @@ column_names row_count distinct_count null_count
{p_partkey} 587 195 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{?column?} 2852.00 4.86 <== 284.00 1.54 0.00 1.00
-{l_extendedprice} 2852.00 4.86 <== 2848.00 6.62 <== 0.00 1.00
-{l_partkey} 2852.00 4.86 <== 284.00 1.46 0.00 1.00
-{l_quantity} 2852.00 4.86 <== 50.00 8.33 <== 0.00 1.00
-{p_partkey} 2852.00 4.86 <== 284.00 1.46 0.00 1.00
+{?column?} 2009.00 3.42 <== 200.00 1.08 0.00 1.00
+{l_extendedprice} 2009.00 3.42 <== 2007.00 4.67 <== 0.00 1.00
+{l_partkey} 2009.00 3.42 <== 200.00 1.03 0.00 1.00
+{l_quantity} 2009.00 3.42 <== 50.00 8.33 <== 0.00 1.00
+{p_partkey} 2009.00 3.42 <== 200.00 1.03 0.00 1.00
----Stats for q17_lookup_join_4----
column_names row_count distinct_count null_count
@@ -184,11 +184,11 @@ column_names row_count distinct_count null_count
{p_partkey} 6088 204 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{?column?} 8557.00 1.41 284.00 1.46 0.00 1.00
-{l_linenumber} 8557.00 1.41 7.00 1.00 0.00 1.00
-{l_orderkey} 8557.00 1.41 8533.00 1.40 0.00 1.00
-{l_partkey} 8557.00 1.41 284.00 1.39 0.00 1.00
-{p_partkey} 8557.00 1.41 284.00 1.39 0.00 1.00
+{?column?} 6027.00 1.01 200.00 1.03 0.00 1.00
+{l_linenumber} 6027.00 1.01 7.00 1.00 0.00 1.00
+{l_orderkey} 6027.00 1.01 6015.00 1.01 0.00 1.00
+{l_partkey} 6027.00 1.01 200.00 1.02 0.00 1.00
+{p_partkey} 6027.00 1.01 200.00 1.02 0.00 1.00
----Stats for q17_project_5----
column_names row_count distinct_count null_count
@@ -196,8 +196,8 @@ column_names row_count distinct_count null_count
{p_partkey} 204 204 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{?column?} 284.00 1.39 284.00 1.46 0.00 1.00
-{p_partkey} 284.00 1.39 284.00 1.39 0.00 1.00
+{?column?} 200.00 1.02 200.00 1.03 0.00 1.00
+{p_partkey} 200.00 1.02 200.00 1.02 0.00 1.00
----Stats for q17_group_by_6----
column_names row_count distinct_count null_count
@@ -205,8 +205,8 @@ column_names row_count distinct_count null_count
{p_partkey} 204 204 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{avg} 284.00 1.39 284.00 1.46 0.00 1.00
-{p_partkey} 284.00 1.39 284.00 1.39 0.00 1.00
+{avg} 200.00 1.02 200.00 1.03 0.00 1.00
+{p_partkey} 200.00 1.02 200.00 1.02 0.00 1.00
----Stats for q17_lookup_join_7----
column_names row_count distinct_count null_count
@@ -217,11 +217,11 @@ column_names row_count distinct_count null_count
{p_partkey} 6088 204 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_partkey} 8557.00 1.41 284.00 1.39 0.00 1.00
-{l_quantity} 8557.00 1.41 50.00 1.00 0.00 1.00
-{p_brand} 8557.00 1.41 1.00 1.00 0.00 1.00
-{p_container} 8557.00 1.41 1.00 1.00 0.00 1.00
-{p_partkey} 8557.00 1.41 284.00 1.39 0.00 1.00
+{l_partkey} 6027.00 1.01 200.00 1.02 0.00 1.00
+{l_quantity} 6027.00 1.01 50.00 1.00 0.00 1.00
+{p_brand} 6027.00 1.01 1.00 1.00 0.00 1.00
+{p_container} 6027.00 1.01 1.00 1.00 0.00 1.00
+{p_partkey} 6027.00 1.01 200.00 1.02 0.00 1.00
----Stats for q17_lookup_join_8----
column_names row_count distinct_count null_count
@@ -233,12 +233,12 @@ column_names row_count distinct_count null_count
{p_partkey} 6088 204 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 8557.00 1.41 7.00 1.00 0.00 1.00
-{l_orderkey} 8557.00 1.41 8533.00 1.40 0.00 1.00
-{l_partkey} 8557.00 1.41 284.00 1.39 0.00 1.00
-{p_brand} 8557.00 1.41 1.00 1.00 0.00 1.00
-{p_container} 8557.00 1.41 1.00 1.00 0.00 1.00
-{p_partkey} 8557.00 1.41 284.00 1.39 0.00 1.00
+{l_linenumber} 6027.00 1.01 7.00 1.00 0.00 1.00
+{l_orderkey} 6027.00 1.01 6015.00 1.01 0.00 1.00
+{l_partkey} 6027.00 1.01 200.00 1.02 0.00 1.00
+{p_brand} 6027.00 1.01 1.00 1.00 0.00 1.00
+{p_container} 6027.00 1.01 1.00 1.00 0.00 1.00
+{p_partkey} 6027.00 1.01 200.00 1.02 0.00 1.00
----Stats for q17_select_9----
column_names row_count distinct_count null_count
@@ -247,9 +247,9 @@ column_names row_count distinct_count null_count
{p_partkey} 204 204 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{p_brand} 284.00 1.39 1.00 1.00 0.00 1.00
-{p_container} 284.00 1.39 1.00 1.00 0.00 1.00
-{p_partkey} 284.00 1.39 284.00 1.39 0.00 1.00
+{p_brand} 200.00 1.02 1.00 1.00 0.00 1.00
+{p_container} 200.00 1.02 1.00 1.00 0.00 1.00
+{p_partkey} 200.00 1.02 200.00 1.02 0.00 1.00
----Stats for q17_scan_10----
column_names row_count distinct_count null_count
@@ -259,7 +259,7 @@ column_names row_count distinct_count null_count
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{p_brand} 200000.00 1.00 25.00 1.00 0.00 1.00
-{p_container} 200000.00 1.00 28.00 1.43 0.00 1.00
+{p_container} 200000.00 1.00 40.00 1.00 0.00 1.00
{p_partkey} 200000.00 1.00 199241.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q18 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q18
index 80960b73c630..a53a5c51e409 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q18
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q18
@@ -65,52 +65,52 @@ top-k
├── save-table-name: q18_group_by_2
├── columns: c_custkey:1(int!null) c_name:2(varchar!null) o_orderkey:11(int!null) o_totalprice:14(float!null) o_orderdate:15(date!null) sum:59(float!null)
├── grouping columns: o_orderkey:11(int!null)
- ├── stats: [rows=499399.1, distinct(1)=499399, null(1)=0, avgsize(1)=4, distinct(2)=499399, null(2)=0, avgsize(2)=4, distinct(11)=499399, null(11)=0, avgsize(11)=4, distinct(14)=499399, null(14)=0, avgsize(14)=4, distinct(15)=499399, null(15)=0, avgsize(15)=4, distinct(59)=499399, null(59)=0, avgsize(59)=4]
+ ├── stats: [rows=499392.2, distinct(1)=499392, null(1)=0, avgsize(1)=4, distinct(2)=499392, null(2)=0, avgsize(2)=4, distinct(11)=499392, null(11)=0, avgsize(11)=4, distinct(14)=499392, null(14)=0, avgsize(14)=4, distinct(15)=499392, null(15)=0, avgsize(15)=4, distinct(59)=499392, null(59)=0, avgsize(59)=4]
├── key: (11)
├── fd: (1)-->(2), (11)-->(1,2,14,15,59)
├── inner-join (hash)
│ ├── save-table-name: q18_inner_join_3
│ ├── columns: c_custkey:1(int!null) c_name:2(varchar!null) o_orderkey:11(int!null) o_custkey:12(int!null) o_totalprice:14(float!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_quantity:26(float!null)
│ ├── multiplicity: left-rows(exactly-one), right-rows(zero-or-more)
- │ ├── stats: [rows=2016723, distinct(1)=99656, null(1)=0, avgsize(1)=4, distinct(2)=150000, null(2)=0, avgsize(2)=4, distinct(11)=499399, null(11)=0, avgsize(11)=4, distinct(12)=99656, null(12)=0, avgsize(12)=4, distinct(14)=488633, null(14)=0, avgsize(14)=4, distinct(15)=2406, null(15)=0, avgsize(15)=4, distinct(22)=499399, null(22)=0, avgsize(22)=4, distinct(26)=50, null(26)=0, avgsize(26)=4]
+ │ ├── stats: [rows=2016361, distinct(1)=99649.1, null(1)=0, avgsize(1)=4, distinct(2)=150000, null(2)=0, avgsize(2)=20, distinct(11)=499392, null(11)=0, avgsize(11)=4, distinct(12)=99649.1, null(12)=0, avgsize(12)=4, distinct(14)=488044, null(14)=0, avgsize(14)=9, distinct(15)=2406, null(15)=0, avgsize(15)=4, distinct(22)=499392, null(22)=0, avgsize(22)=4, distinct(26)=50, null(26)=0, avgsize(26)=9]
│ ├── fd: (1)-->(2), (11)-->(12,14,15), (11)==(22), (22)==(11), (1)==(12), (12)==(1)
│ ├── inner-join (merge)
│ │ ├── save-table-name: q18_merge_join_4
│ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_totalprice:14(float!null) o_orderdate:15(date!null) l_orderkey:22(int!null) l_quantity:26(float!null)
│ │ ├── left ordering: +22
│ │ ├── right ordering: +11
- │ │ ├── stats: [rows=2000764, distinct(11)=509090, null(11)=0, avgsize(11)=4, distinct(12)=99656, null(12)=0, avgsize(12)=4, distinct(14)=497246, null(14)=0, avgsize(14)=4, distinct(15)=2406, null(15)=0, avgsize(15)=4, distinct(22)=509090, null(22)=0, avgsize(22)=4, distinct(26)=50, null(26)=0, avgsize(26)=4]
+ │ │ ├── stats: [rows=2000405, distinct(11)=509090, null(11)=0, avgsize(11)=4, distinct(12)=99649.1, null(12)=0, avgsize(12)=4, distinct(14)=496607, null(14)=0, avgsize(14)=9, distinct(15)=2406, null(15)=0, avgsize(15)=4, distinct(22)=509090, null(22)=0, avgsize(22)=4, distinct(26)=50, null(26)=0, avgsize(26)=9]
│ │ ├── fd: (11)-->(12,14,15), (11)==(22), (22)==(11)
│ │ ├── scan lineitem
│ │ │ ├── save-table-name: q18_scan_5
│ │ │ ├── columns: l_orderkey:22(int!null) l_quantity:26(float!null)
- │ │ │ ├── stats: [rows=6002293, distinct(22)=1.52727e+06, null(22)=0, avgsize(22)=4, distinct(26)=50, null(26)=0, avgsize(26)=4]
- │ │ │ │ histogram(22)= 0 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600
- │ │ │ │ <--- 576 ------- 38535 ------- 66885 ------- 93380 ------- 127425 ------- 157218 ------- 184483 ------- 215330 ------- 252869 ------- 283878 ------- 313798 ------- 337056 ------- 372549 ------- 399591 ------- 426245 ------- 460578 ------- 498439 ------- 526049 ------- 554468 ------- 577921 ------- 609187 ------- 639524 ------- 665345 ------- 686180 ------- 721539 ------- 755680 ------- 782756 ------- 814496 ------- 845446 ------- 872130 ------- 910912 ------- 933697 ------- 965184 ------- 1000353 ------- 1038658 ------- 1073667 ------- 1097891 ------- 1131330 ------- 1157732 ------- 1179943 ------- 1206401 ------- 1230150 ------- 1261824 ------- 1293217 ------- 1326754 ------- 1357573 ------- 1390145 ------- 1429312 ------- 1460418 ------- 1491104 ------- 1523937 ------- 1559812 ------- 1591653 ------- 1615174 ------- 1646759 ------- 1670465 ------- 1696321 ------- 1724192 ------- 1748033 ------- 1777570 ------- 1807428 ------- 1836962 ------- 1872481 ------- 1902817 ------- 1928324 ------- 1960775 ------- 1985989 ------- 2019107 ------- 2044613 ------- 2071490 ------- 2101959 ------- 2135555 ------- 2164486 ------- 2186337 ------- 2213989 ------- 2246309 ------- 2276992 ------- 2306403 ------- 2329921 ------- 2354977 ------- 2380711 ------- 2410529 ------- 2437920 ------- 2462017 ------- 2483714 ------- 2513920 ------- 2542855 ------- 2574112 ------- 2596035 ------- 2625031 ------- 2658051 ------- 2695046 ------- 2725222 ------- 2754245 ------- 2777702 ------- 2804896 ------- 2844579 ------- 2873860 ------- 2903459 ------- 2933249 ------- 2965479 ------- 2996160 ------- 3022976 ------- 3053152 ------- 3083623 ------- 3111136 ------- 3144033 ------- 3180134 ------- 3209799 ------- 3239394 ------- 3270886 ------- 3297664 ------- 3329444 ------- 3357574 ------- 3380838 ------- 3412196 ------- 3438917 ------- 3462467 ------- 3498629 ------- 3530208 ------- 3562148 ------- 3589889 ------- 3621063 ------- 3655456 ------- 3686724 ------- 3709029 ------- 3738215 ------- 3767687 ------- 3804547 ------- 3831142 ------- 3875111 ------- 3905605 ------- 3933795 ------- 3966593 ------- 3995558 ------- 4020134 ------- 4052513 ------- 4078949 ------- 4114208 ------- 4149762 ------- 4176135 ------- 4207782 ------- 4241376 ------- 4270502 ------- 4304167 ------- 4333669 ------- 4362818 ------- 4393537 ------- 4423076 ------- 4452064 ------- 4491143 ------- 4522723 ------- 4550883 ------- 4581382 ------- 4616002 ------- 4649410 ------- 4680485 ------- 4715584 ------- 4740036 ------- 4771554 ------- 4799461 ------- 4826690 ------- 4855525 ------- 4887974 ------- 4917479 ------- 4950885 ------- 4984195 ------- 5010113 ------- 5033571 ------- 5065472 ------- 5100512 ------- 5129413 ------- 5160069 ------- 5186596 ------- 5221538 ------- 5252964 ------- 5284069 ------- 5314051 ------- 5353026 ------- 5388961 ------- 5424644 ------- 5452676 ------- 5483553 ------- 5516612 ------- 5551041 ------- 5579878 ------- 5612576 ------- 5643427 ------- 5673666 ------- 5709218 ------- 5737221 ------- 5766119 ------- 5795044 ------- 5826560 ------- 5855943 ------- 5889604 ------- 5917607 ------- 5942535 ------- 5969639 ------- 5999557
- │ │ │ │ histogram(26)= 0 1.1524e+05 5.7772e+06 1.0984e+05
- │ │ │ │ <----- 1.0 ----------------- 50.0 --
+ │ │ │ ├── stats: [rows=6001215, distinct(22)=1.52727e+06, null(22)=0, avgsize(22)=4, distinct(26)=50, null(26)=0, avgsize(26)=9]
+ │ │ │ │ histogram(22)= 0 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600
+ │ │ │ │ <--- 197 ------- 23686 ------- 53253 ------- 90435 ------- 121730 ------- 153280 ------- 175456 ------- 208548 ------- 242209 ------- 273057 ------- 296640 ------- 330307 ------- 360999 ------- 386307 ------- 420225 ------- 450050 ------- 477795 ------- 504711 ------- 533153 ------- 556672 ------- 582243 ------- 613729 ------- 646117 ------- 675840 ------- 706048 ------- 733063 ------- 769282 ------- 793922 ------- 820357 ------- 849536 ------- 875719 ------- 905028 ------- 940643 ------- 968355 ------- 998721 ------- 1023621 ------- 1059424 ------- 1084932 ------- 1115553 ------- 1139363 ------- 1167361 ------- 1194400 ------- 1225984 ------- 1253861 ------- 1281633 ------- 1304999 ------- 1336355 ------- 1370759 ------- 1400832 ------- 1434085 ------- 1458852 ------- 1491427 ------- 1525120 ------- 1555205 ------- 1591300 ------- 1619426 ------- 1651458 ------- 1682950 ------- 1711399 ------- 1747591 ------- 1787205 ------- 1822240 ------- 1856163 ------- 1886915 ------- 1910949 ------- 1947202 ------- 1974311 ------- 2009286 ------- 2044034 ------- 2079104 ------- 2103488 ------- 2134657 ------- 2164293 ------- 2204514 ------- 2230823 ------- 2265253 ------- 2289826 ------- 2329539 ------- 2364455 ------- 2393507 ------- 2414628 ------- 2440228 ------- 2465255 ------- 2489568 ------- 2520900 ------- 2554919 ------- 2583333 ------- 2612966 ------- 2644833 ------- 2667362 ------- 2702784 ------- 2727394 ------- 2759748 ------- 2794531 ------- 2822214 ------- 2846624 ------- 2883748 ------- 2919586 ------- 2951908 ------- 2980068 ------- 3014726 ------- 3050725 ------- 3081028 ------- 3113351 ------- 3150243 ------- 3185669 ------- 3214311 ------- 3241281 ------- 3275748 ------- 3303232 ------- 3339559 ------- 3370627 ------- 3393664 ------- 3435265 ------- 3464581 ------- 3489026 ------- 3516096 ------- 3548480 ------- 3587015 ------- 3611239 ------- 3638724 ------- 3668641 ------- 3695751 ------- 3729636 ------- 3751523 ------- 3784608 ------- 3815715 ------- 3848608 ------- 3881184 ------- 3908738 ------- 3940002 ------- 3966176 ------- 4001984 ------- 4035687 ------- 4065283 ------- 4092834 ------- 4133062 ------- 4160613 ------- 4196421 ------- 4223713 ------- 4254788 ------- 4291040 ------- 4313664 ------- 4342823 ------- 4369952 ------- 4391684 ------- 4419040 ------- 4449921 ------- 4471781 ------- 4506210 ------- 4538176 ------- 4571297 ------- 4601121 ------- 4630887 ------- 4657476 ------- 4684803 ------- 4714566 ------- 4744070 ------- 4776385 ------- 4807777 ------- 4839491 ------- 4873953 ------- 4902245 ------- 4936263 ------- 4970721 ------- 5003140 ------- 5029729 ------- 5059010 ------- 5087521 ------- 5121093 ------- 5150405 ------- 5178375 ------- 5203683 ------- 5234531 ------- 5268195 ------- 5300004 ------- 5331558 ------- 5362178 ------- 5385762 ------- 5418498 ------- 5445762 ------- 5483109 ------- 5514561 ------- 5542052 ------- 5569572 ------- 5596102 ------- 5622401 ------- 5652194 ------- 5671362 ------- 5699591 ------- 5727136 ------- 5753284 ------- 5780742 ------- 5809189 ------- 5836545 ------- 5864454 ------- 5894917 ------- 5933825 ------- 5968933 ------- 5999590
+ │ │ │ │ histogram(26)= 0 1.1342e+05 5.766e+06 1.2182e+05
+ │ │ │ │ <----- 1.0 ---------------- 50.0 --
│ │ │ └── ordering: +22
│ │ ├── semi-join (merge)
│ │ │ ├── save-table-name: q18_merge_join_6
│ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_totalprice:14(float!null) o_orderdate:15(date!null)
│ │ │ ├── left ordering: +11
│ │ │ ├── right ordering: +40
- │ │ │ ├── stats: [rows=509090, distinct(11)=509090, null(11)=0, avgsize(11)=4, distinct(12)=99656, null(12)=0, avgsize(12)=4, distinct(14)=507049, null(14)=0, avgsize(14)=4, distinct(15)=2406, null(15)=0, avgsize(15)=4]
+ │ │ │ ├── stats: [rows=509090, distinct(11)=509090, null(11)=0, avgsize(11)=4, distinct(12)=99649.1, null(12)=0, avgsize(12)=4, distinct(14)=506350, null(14)=0, avgsize(14)=9, distinct(15)=2406, null(15)=0, avgsize(15)=4]
│ │ │ ├── key: (11)
│ │ │ ├── fd: (11)-->(12,14,15)
│ │ │ ├── ordering: +11
│ │ │ ├── scan orders
│ │ │ │ ├── save-table-name: q18_scan_7
│ │ │ │ ├── columns: o_orderkey:11(int!null) o_custkey:12(int!null) o_totalprice:14(float!null) o_orderdate:15(date!null)
- │ │ │ │ ├── stats: [rows=1500000, distinct(11)=1.5e+06, null(11)=0, avgsize(11)=4, distinct(12)=99853, null(12)=0, avgsize(12)=4, distinct(14)=1.4694e+06, null(14)=0, avgsize(14)=4, distinct(15)=2406, null(15)=0, avgsize(15)=4]
- │ │ │ │ │ histogram(11)= 0 0 0 0.99998 7461.9 0.99998 7285.9 0.99998 7544.9 0.99998 7589.9 0.99998 7222.9 0.99998 7324.9 0.99998 7506.9 0.99998 7351.9 0.99998 7777.9 0.99998 7576.9 0.99998 7731.9 0.99998 7694.9 0.99998 7586.9 0.99998 7569.9 0.99998 7757.9 0.99998 7624.9 0.99998 7506.9 0.99998 7245.9 0.99998 7820.9 0.99998 7539.9 0.99998 7455.9 0.99998 7589.9 0.99998 7740.9 0.99998 7604.9 0.99998 7710.9 0.99998 7709.9 0.99998 7708.9 0.99998 7490.9 0.99998 7527.9 0.99998 7331.9 0.99998 7311.9 0.99998 7576.9 0.99998 7545.9 0.99998 7277.9 0.99998 7392.9 0.99998 7508.9 0.99998 7622.9 0.99998 7581.9 0.99998 7775.9 0.99998 7523.9 0.99998 7568.9 0.99998 7483.9 0.99998 7662.9 0.99998 7368.9 0.99998 7470.9 0.99998 7380.9 0.99998 7647.9 0.99998 7381.9 0.99998 7635.9 0.99998 7490.9 0.99998 7446.9 0.99998 7526.9 0.99998 7441.9 0.99998 7265.9 0.99998 7960.9 0.99998 7251.9 0.99998 7514.9 0.99998 7294.9 0.99998 7502.9 0.99998 7285.9 0.99998 7320.9 0.99998 7235.9 0.99998 7451.9 0.99998 7810.9 0.99998 7378.9 0.99998 7418.9 0.99998 7661.9 0.99998 7404.9 0.99998 7432.9 0.99998 7579.9 0.99998 7836.9 0.99998 7445.9 0.99998 7355.9 0.99998 7617.9 0.99998 7110.9 0.99998 7398.9 0.99998 7622.9 0.99998 7655.9 0.99998 7433.9 0.99998 7656.9 0.99998 7404.9 0.99998 7474.9 0.99998 7572.9 0.99998 7688.9 0.99998 7559.9 0.99998 7414.9 0.99998 7523.9 0.99998 7558.9 0.99998 7330.9 0.99998 7587.9 0.99998 7388.9 0.99998 7327.9 0.99998 7671.9 0.99998 7523.9 0.99998 7687.9 0.99998 7524.9 0.99998 7614.9 0.99998 7463.9 0.99998 7594.9 0.99998 7372.9 0.99998 7670.9 0.99998 7310.9 0.99998 7270.9 0.99998 7399.9 0.99998 7688.9 0.99998 7487.9 0.99998 7556.9 0.99998 7365.9 0.99998 7521.9 0.99998 7762.9 0.99998 7386.9 0.99998 7399.9 0.99998 7562.9 0.99998 7502.9 0.99998 7201.9 0.99998 7595.9 0.99998 7525.9 0.99998 7451.9 0.99998 7280.9 0.99998 7307.9 0.99998 7386.9 0.99998 7345.9 0.99998 7383.9 0.99998 7530.9 0.99998 7706.9 0.99998 7581.9 0.99998 7512.9 0.99998 7536.9 0.99998 7210.9 0.99998 7689.9 0.99998 7658.9 0.99998 7358.9 0.99998 7646.9 0.99998 7252.9 0.99998 7327.9 0.99998 7525.9 0.99998 7564.9 0.99998 7524.9 0.99998 7438.9 0.99998 7493.9 0.99998 7419.9 0.99998 7509.9 0.99998 7595.9 0.99998 7396.9 0.99998 7378.9 0.99998 7330.9 0.99998 7387.9 0.99998 7552.9 0.99998 7330.9 0.99998 7431.9 0.99998 7773.9 0.99998 7853.9 0.99998 7562.9 0.99998 7548.9 0.99998 7847.9 0.99998 7933.9 0.99998 7768.9 0.99998 7738.9 0.99998 7480.9 0.99998 7679.9 0.99998 7663.9 0.99998 7587.9 0.99998 7527.9 0.99998 7466.9 0.99998 7444.9 0.99998 7519.9 0.99998 7830.9 0.99998 7568.9 0.99998 7671.9 0.99998 7637.9 0.99998 7462.9 0.99998 7851.9 0.99998 7483.9 0.99998 7765.9 0.99998 7451.9 0.99998 8050.9 0.99998 7644.9 0.99998 7724.9 0.99998 7471.9 0.99998 7517.9 0.99998 7830.9 0.99998 7387.9 0.99998 7749.9 0.99998 7545.9 0.99998 7718.9 0.99998 7384.9 0.99998 7464.9 0.99998 7467.9 0.99998 7809.9 0.99998 7766.9 0.99998 7511.9 0.99998 7641.9 0.99998 7711.9 0.99998 7729.9 0.99998 7631.9 0.99998 7734.9 0.99998 7931.9 0.99998 7586.9 0.99998 7964.9 0.99998 0 0
- │ │ │ │ │ <--- -9223372036854775808 --- 1472 --------- 30469 -------- 54689 -------- 85922 -------- 118369 -------- 140867 -------- 166146 -------- 196357 -------- 222375 -------- 259877 -------- 291970 -------- 328227 -------- 363490 -------- 395873 -------- 427783 -------- 464741 -------- 498146 -------- 528358 -------- 551493 -------- 590144 -------- 621254 -------- 650083 -------- 682531 -------- 719041 -------- 751906 -------- 787617 -------- 823298 -------- 858944 -------- 888739 -------- 919527 -------- 944996 -------- 969922 -------- 1002020 -------- 1033280 -------- 1057284 -------- 1084416 -------- 1114693 -------- 1148034 -------- 1180262 -------- 1217697 -------- 1248386 -------- 1280261 -------- 1309862 -------- 1344263 -------- 1370759 -------- 1400003 -------- 1426822 -------- 1460837 -------- 1487680 -------- 1521376 -------- 1551174 -------- 1579779 -------- 1610532 -------- 1638983 -------- 1662660 -------- 1705024 -------- 1728321 -------- 1758757 -------- 1783239 -------- 1813344 -------- 1837573 -------- 1862757 -------- 1885607 -------- 1914340 -------- 1952706 -------- 1979458 -------- 2007302 -------- 2041697 -------- 2069157 -------- 2097383 -------- 2129571 -------- 2168643 -------- 2197223 -------- 2223363 -------- 2256577 -------- 2275975 -------- 2303264 -------- 2336608 -------- 2370823 -------- 2399074 -------- 2433315 -------- 2460771 -------- 2490114 -------- 2522119 -------- 2557218 -------- 2588866 -------- 2616610 -------- 2647296 -------- 2678913 -------- 2704354 -------- 2736743 -------- 2763779 -------- 2789157 -------- 2823812 -------- 2854502 -------- 2889572 -------- 2920263 -------- 2953378 -------- 2982439 -------- 3015013 -------- 3041603 -------- 3076227 -------- 3101125 -------- 3124930 -------- 3152260 -------- 3187366 -------- 3217059 -------- 3248611 -------- 3275008 -------- 3305634 -------- 3342721 -------- 3369702 -------- 3397031 -------- 3428771 -------- 3458885 -------- 3480806 -------- 3513408 -------- 3544129 -------- 3572866 -------- 3596965 -------- 3621794 -------- 3648771 -------- 3674624 -------- 3701510 -------- 3732387 -------- 3767974 -------- 3800224 -------- 3830599 -------- 3861635 -------- 3883808 -------- 3918949 -------- 3953249 -------- 3979456 -------- 4013443 -------- 4036775 -------- 4062148 -------- 4092867 -------- 4124641 -------- 4155333 -------- 4183718 -------- 4213574 -------- 4241445 -------- 4271751 -------- 4304354 -------- 4331590 -------- 4358338 -------- 4383782 -------- 4410791 -------- 4442244 -------- 4467687 -------- 4495876 -------- 4529761 -------- 4565792 -------- 4593991 -------- 4621829 -------- 4657703 -------- 4695878 -------- 4729632 -------- 4762593 -------- 4788581 -------- 4819943 -------- 4850885 -------- 4879777 -------- 4907042 -------- 4932640 -------- 4957638 -------- 4984675 -------- 5020100 -------- 5048481 -------- 5079622 -------- 5109862 -------- 5135363 -------- 5171364 -------- 5197414 -------- 5231104 -------- 5256289 -------- 5297604 -------- 5328038 -------- 5360608 -------- 5386337 -------- 5413315 -------- 5448743 -------- 5472197 -------- 5505440 -------- 5533184 -------- 5565603 -------- 5588963 -------- 5614503 -------- 5640135 -------- 5675008 -------- 5708709 -------- 5735522 -------- 5765862 -------- 5798085 -------- 5830787 -------- 5860867 -------- 5893703 -------- 5931844 -------- 5960706 -------- 5999719 --- 9223372036854775807
- │ │ │ │ │ histogram(12)= 0 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7200 450 7350 150 7200 300 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7200 300 7350 150 7200 300 7350 300 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 450 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 300 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 150 7500 150 7350 300 7500 150 7500 150 7500 150 7500 150 7500 150
- │ │ │ │ │ <--- 25 ------ 758 ------ 1460 ------ 2207 ------ 2911 ------ 3766 ------ 4592 ------ 5371 ------ 6080 ------ 6773 ------ 7421 ------ 8009 ------ 8668 ------ 9583 ------ 10459 ------ 11120 ------ 11872 ------ 12722 ------ 13612 ------ 14390 ------ 15179 ------ 15862 ------ 16658 ------ 17234 ------ 18083 ------ 18862 ------ 19577 ------ 20138 ------ 20869 ------ 21644 ------ 22265 ------ 23105 ------ 23966 ------ 24782 ------ 25532 ------ 26317 ------ 27071 ------ 27664 ------ 28414 ------ 29291 ------ 30097 ------ 30917 ------ 31571 ------ 32357 ------ 33175 ------ 33820 ------ 34678 ------ 35311 ------ 35935 ------ 36689 ------ 37360 ------ 37969 ------ 38792 ------ 39442 ------ 40268 ------ 41044 ------ 41656 ------ 42370 ------ 43085 ------ 43909 ------ 44672 ------ 45326 ------ 46310 ------ 47150 ------ 47801 ------ 48563 ------ 49336 ------ 50111 ------ 50747 ------ 51631 ------ 52250 ------ 52873 ------ 53753 ------ 54632 ------ 55324 ------ 56141 ------ 56924 ------ 57524 ------ 58382 ------ 59069 ------ 59915 ------ 60779 ------ 61466 ------ 62306 ------ 63041 ------ 63799 ------ 64415 ------ 65452 ------ 66266 ------ 67055 ------ 67754 ------ 68510 ------ 69350 ------ 70127 ------ 70702 ------ 71462 ------ 72428 ------ 73267 ------ 74005 ------ 74719 ------ 75695 ------ 76400 ------ 77000 ------ 77953 ------ 78557 ------ 79315 ------ 79925 ------ 80530 ------ 81220 ------ 81902 ------ 82607 ------ 83179 ------ 84025 ------ 84970 ------ 85844 ------ 86657 ------ 87184 ------ 88037 ------ 88840 ------ 89531 ------ 90134 ------ 90893 ------ 91651 ------ 92528 ------ 93278 ------ 93944 ------ 94579 ------ 95708 ------ 96323 ------ 97174 ------ 97856 ------ 98602 ------ 99260 ------ 99967 ------ 100567 ------ 101209 ------ 101923 ------ 102734 ------ 103540 ------ 104402 ------ 105101 ------ 105854 ------ 106667 ------ 107584 ------ 108601 ------ 109366 ------ 110185 ------ 111109 ------ 112079 ------ 112712 ------ 113375 ------ 114088 ------ 114719 ------ 115409 ------ 116246 ------ 117028 ------ 117703 ------ 118441 ------ 119161 ------ 119911 ------ 120542 ------ 121391 ------ 122210 ------ 123049 ------ 123794 ------ 124418 ------ 125149 ------ 125963 ------ 126791 ------ 127537 ------ 128390 ------ 129067 ------ 129604 ------ 130400 ------ 131039 ------ 131752 ------ 132460 ------ 133154 ------ 133693 ------ 134515 ------ 135289 ------ 135959 ------ 136651 ------ 137456 ------ 138158 ------ 138947 ------ 139789 ------ 140599 ------ 141446 ------ 142318 ------ 143132 ------ 143698 ------ 144484 ------ 145376 ------ 146068 ------ 146774 ------ 147730 ------ 148436 ------ 149324 ------ 149992
- │ │ │ │ │ histogram(14)= 0 150 1.4997e+06 150
- │ │ │ │ │ <--- 929.1190185546875 ------------ 465073.34375
- │ │ │ │ │ histogram(15)= 0 750 7350 450 6600 900 7200 750 7350 450 6750 750 7350 750 7200 300 6600 1050 7350 600 7350 600 7200 900 7350 750 6900 750 6900 900 6600 900 7350 1200 6600 1350 6900 900 7200 300 7050 600 7350 750 7200 300 6300 1050 6900 600 7050 900 6450 900 6150 1200 6750 750 7050 750 6750 750 6900 1050 6450 900 6450 900 6300 1200 7200 900 6600 750 6900 1200 7050 1200 7200 600 6750 1200 6900 750 6900 450 6900 600 6750 1650 5850 1500 7200 300 7200 600 6600 750 7200 900 6900 900 6900 450 6600 750 6750 1200 6750 600 7200 150 6900 1350 6300 1050 7200 600 7050 600 7200 1050 7050 450 7050 900 7200 750 6450 1200 6900 1050 6600 900 7050 750 6750 900 6900 600 7200 450 6900 600 7050 900 6600 1050 6900 600 7050 1350 7200 450 6450 900 7050 1350 7200 150 7050 750 6900 1050 7050 900 6750 600 7050 1800 6600 750 6300 1350 7200 600 7200 450 6600 900 6900 450 6750 600 6600 900 7050 300 7050 450 7050 750 6900 600 6900 750 7050 300 7050 450 7200 600 7200 750 7200 150 7050 750 6750 1050 7050 750 7050 450 6600 600 6750 600 7050 300 6750 900 6900 450 6900 450 6600 1050 7050 450 6300 1200 6750 600 6900 750 6600 750 6750 450 6750 600 7050 900 6750 600 6600 750 6900 600 6750 750 6750 750 6900 600 6600 600 6300 1050 7050 450 6750 1050 6750 750 6750 900 6900 450 6450 750 6900 300 6450 750 6900 1050 7050 600 6900 750 7050 750 6600 1200 6600 1050 6750 1050 6600 750 6900 600 7050 150 7050 450 6450 1200 6750 750 7050 600 6600 450 6750 750 6450 750 6750 750 6600 600 5700 1350 6300 900 6900 600 6750 750 6300 900 6450 600 6600 450 6000 1050 6750 450 6300 900 6900 900 6450 600 6900 750 6450 750 6600 1200 6750 450 6300 900 6600 600 6600 1200 6750 1200 6600 1050 6300 1050 6450 900 6600 450 6750 600 6300 600 6300 600 6000 1200 6450 1050 6150 750 6300 600 6600 600 6450 600 6600 900 5550 1200 6450 900 5550 1050 6000 900 5850 900 6300 300 6450 600 6450 450 5850 450
- │ │ │ │ │ <--- '1992-01-01' ------ '1992-01-14' ------ '1992-01-25' ------ '1992-02-09' ------ '1992-02-23' ------ '1992-03-06' ------ '1992-03-19' ------ '1992-03-30' ------ '1992-04-12' ------ '1992-04-24' ------ '1992-05-07' ------ '1992-05-20' ------ '1992-05-31' ------ '1992-06-13' ------ '1992-06-27' ------ '1992-07-09' ------ '1992-07-21' ------ '1992-08-03' ------ '1992-08-17' ------ '1992-09-01' ------ '1992-09-13' ------ '1992-09-23' ------ '1992-10-06' ------ '1992-10-16' ------ '1992-10-29' ------ '1992-11-09' ------ '1992-11-20' ------ '1992-12-03' ------ '1992-12-14' ------ '1992-12-27' ------ '1993-01-09' ------ '1993-01-21' ------ '1993-02-01' ------ '1993-02-13' ------ '1993-02-23' ------ '1993-03-07' ------ '1993-03-17' ------ '1993-03-30' ------ '1993-04-12' ------ '1993-04-24' ------ '1993-05-08' ------ '1993-05-19' ------ '1993-06-01' ------ '1993-06-12' ------ '1993-06-20' ------ '1993-06-30' ------ '1993-07-11' ------ '1993-07-22' ------ '1993-08-02' ------ '1993-08-14' ------ '1993-08-25' ------ '1993-09-05' ------ '1993-09-16' ------ '1993-09-27' ------ '1993-10-10' ------ '1993-10-24' ------ '1993-11-04' ------ '1993-11-15' ------ '1993-11-27' ------ '1993-12-10' ------ '1993-12-25' ------ '1994-01-08' ------ '1994-01-19' ------ '1994-01-30' ------ '1994-02-12' ------ '1994-02-25' ------ '1994-03-06' ------ '1994-03-19' ------ '1994-03-31' ------ '1994-04-12' ------ '1994-04-22' ------ '1994-05-05' ------ '1994-05-19' ------ '1994-05-30' ------ '1994-06-10' ------ '1994-06-23' ------ '1994-07-05' ------ '1994-07-16' ------ '1994-07-25' ------ '1994-08-06' ------ '1994-08-18' ------ '1994-08-31' ------ '1994-09-10' ------ '1994-09-25' ------ '1994-10-06' ------ '1994-10-21' ------ '1994-11-01' ------ '1994-11-12' ------ '1994-11-27' ------ '1994-12-08' ------ '1994-12-21' ------ '1995-01-04' ------ '1995-01-17' ------ '1995-02-01' ------ '1995-02-11' ------ '1995-02-23' ------ '1995-03-08' ------ '1995-03-21' ------ '1995-04-05' ------ '1995-04-18' ------ '1995-04-30' ------ '1995-05-13' ------ '1995-05-25' ------ '1995-06-08' ------ '1995-06-22' ------ '1995-07-07' ------ '1995-07-19' ------ '1995-07-29' ------ '1995-08-13' ------ '1995-08-24' ------ '1995-09-05' ------ '1995-09-20' ------ '1995-10-05' ------ '1995-10-14' ------ '1995-10-25' ------ '1995-11-06' ------ '1995-11-16' ------ '1995-11-26' ------ '1995-12-09' ------ '1995-12-21' ------ '1995-12-31' ------ '1996-01-11' ------ '1996-01-23' ------ '1996-02-03' ------ '1996-02-21' ------ '1996-03-02' ------ '1996-03-16' ------ '1996-03-27' ------ '1996-04-08' ------ '1996-04-20' ------ '1996-05-03' ------ '1996-05-13' ------ '1996-05-24' ------ '1996-06-06' ------ '1996-06-19' ------ '1996-06-30' ------ '1996-07-14' ------ '1996-07-25' ------ '1996-08-04' ------ '1996-08-19' ------ '1996-09-03' ------ '1996-09-14' ------ '1996-09-25' ------ '1996-10-09' ------ '1996-10-19' ------ '1996-11-01' ------ '1996-11-11' ------ '1996-11-23' ------ '1996-12-05' ------ '1996-12-19' ------ '1996-12-29' ------ '1997-01-12' ------ '1997-01-22' ------ '1997-02-06' ------ '1997-02-24' ------ '1997-03-08' ------ '1997-03-19' ------ '1997-04-01' ------ '1997-04-12' ------ '1997-04-23' ------ '1997-05-05' ------ '1997-05-15' ------ '1997-05-25' ------ '1997-06-07' ------ '1997-06-18' ------ '1997-07-02' ------ '1997-07-11' ------ '1997-07-24' ------ '1997-08-04' ------ '1997-08-17' ------ '1997-08-26' ------ '1997-09-09' ------ '1997-09-19' ------ '1997-09-28' ------ '1997-10-09' ------ '1997-10-19' ------ '1997-11-01' ------ '1997-11-13' ------ '1997-11-24' ------ '1997-12-05' ------ '1997-12-20' ------ '1997-12-30' ------ '1998-01-12' ------ '1998-01-23' ------ '1998-02-05' ------ '1998-02-17' ------ '1998-02-26' ------ '1998-03-12' ------ '1998-03-23' ------ '1998-04-03' ------ '1998-04-13' ------ '1998-04-24' ------ '1998-05-07' ------ '1998-05-19' ------ '1998-06-01' ------ '1998-06-13' ------ '1998-06-27' ------ '1998-07-12' ------ '1998-07-26' ------ '1998-08-02'
+ │ │ │ │ ├── stats: [rows=1500000, distinct(11)=1.5e+06, null(11)=0, avgsize(11)=4, distinct(12)=99846, null(12)=0, avgsize(12)=4, distinct(14)=1.45917e+06, null(14)=0, avgsize(14)=9, distinct(15)=2406, null(15)=0, avgsize(15)=4]
+ │ │ │ │ │ histogram(11)= 0 0 0 0.99998 7406.9 0.99998 7327.9 0.99998 7748.9 0.99998 7433.9 0.99998 8029.9 0.99998 7265.9 0.99998 7439.9 0.99998 7823.9 0.99998 7526.9 0.99998 7553.9 0.99998 7426.9 0.99998 7490.9 0.99998 7595.9 0.99998 7527.9 0.99998 7640.9 0.99998 7593.9 0.99998 7384.9 0.99998 7713.9 0.99998 7409.9 0.99998 7249.9 0.99998 7518.9 0.99998 7434.9 0.99998 7575.9 0.99998 7471.9 0.99998 7302.9 0.99998 7109.9 0.99998 7646.9 0.99998 7619.9 0.99998 7579.9 0.99998 7489.9 0.99998 7409.9 0.99998 7619.9 0.99998 7805.9 0.99998 7418.9 0.99998 7454.9 0.99998 7651.9 0.99998 7407.9 0.99998 7278.9 0.99998 7402.9 0.99998 7375.9 0.99998 7375.9 0.99998 7517.9 0.99998 7626.9 0.99998 7675.9 0.99998 7470.9 0.99998 7352.9 0.99998 7597.9 0.99998 7649.9 0.99998 7509.9 0.99998 7320.9 0.99998 7287.9 0.99998 7365.9 0.99998 7381.9 0.99998 7478.9 0.99998 7526.9 0.99998 7233.9 0.99998 7676.9 0.99998 7400.9 0.99998 7739.9 0.99998 7638.9 0.99998 7515.9 0.99998 7211.9 0.99998 7231.9 0.99998 7194.9 0.99998 7187.9 0.99998 7885.9 0.99998 7359.9 0.99998 7301.9 0.99998 7493.9 0.99998 7529.9 0.99998 7558.9 0.99998 7148.9 0.99998 7437.9 0.99998 7337.9 0.99998 7299.9 0.99998 7683.9 0.99998 7430.9 0.99998 7252.9 0.99998 7440.9 0.99998 7467.9 0.99998 7694.9 0.99998 7528.9 0.99998 7441.9 0.99998 7694.9 0.99998 7737.9 0.99998 7523.9 0.99998 7400.9 0.99998 7523.9 0.99998 7700.9 0.99998 7156.9 0.99998 7352.9 0.99998 7359.9 0.99998 7334.9 0.99998 7444.9 0.99998 7766.9 0.99998 7675.9 0.99998 7511.9 0.99998 7616.9 0.99998 7308.9 0.99998 7593.9 0.99998 7296.9 0.99998 7557.9 0.99998 7416.9 0.99998 7613.9 0.99998 7421.9 0.99998 7322.9 0.99998 7584.9 0.99998 7726.9 0.99998 7495.9 0.99998 7434.9 0.99998 7337.9 0.99998 7450.9 0.99998 7576.9 0.99998 7245.9 0.99998 7625.9 0.99998 7748.9 0.99998 7417.9 0.99998 7701.9 0.99998 7437.9 0.99998 7345.9 0.99998 7517.9 0.99998 7621.9 0.99998 7359.9 0.99998 7393.9 0.99998 7632.9 0.99998 7715.9 0.99998 7558.9 0.99998 7350.9 0.99998 7557.9 0.99998 7400.9 0.99998 7297.9 0.99998 7875.9 0.99998 7364.9 0.99998 7332.9 0.99998 7458.9 0.99998 7471.9 0.99998 7564.9 0.99998 7523.9 0.99998 7270.9 0.99998 7309.9 0.99998 7418.9 0.99998 7959.9 0.99998 7382.9 0.99998 7507.9 0.99998 7524.9 0.99998 7566.9 0.99998 7705.9 0.99998 7841.9 0.99998 7483.9 0.99998 7685.9 0.99998 7605.9 0.99998 7677.9 0.99998 7647.9 0.99998 7985.9 0.99998 7859.9 0.99998 7673.9 0.99998 7732.9 0.99998 7501.9 0.99998 7498.9 0.99998 7596.9 0.99998 7572.9 0.99998 7848.9 0.99998 7567.9 0.99998 7549.9 0.99998 7493.9 0.99998 7869.9 0.99998 7508.9 0.99998 7626.9 0.99998 7774.9 0.99998 7908.9 0.99998 7501.9 0.99998 7841.9 0.99998 7542.9 0.99998 7623.9 0.99998 7523.9 0.99998 7548.9 0.99998 7977.9 0.99998 7569.9 0.99998 7916.9 0.99998 7613.9 0.99998 7883.9 0.99998 7579.9 0.99998 8076.9 0.99998 7698.9 0.99998 7635.9 0.99998 7530.9 0.99998 7515.9 0.99998 7673.9 0.99998 7781.9 0.99998 7698.9 0.99998 7482.9 0.99998 7805.9 0.99998 7774.9 0.99998 7657.9 0.99998 7655.9 0.99998 7579.9 0.99998 7506.9 0.99998 7736.9 0.99998 7584.9 0.99998 0 0
+ │ │ │ │ │ <--- -9223372036854775808 --- 1505 --------- 29025 -------- 54400 -------- 91106 -------- 119366 -------- 163554 -------- 187236 -------- 215651 -------- 254373 -------- 285123 -------- 316614 -------- 344678 -------- 374465 -------- 407078 -------- 437861 -------- 471683 -------- 504230 -------- 531168 -------- 566951 -------- 594561 -------- 617825 -------- 648358 -------- 676640 -------- 708706 -------- 737986 -------- 762690 -------- 782081 -------- 816064 -------- 849318 -------- 881511 -------- 911271 -------- 938885 -------- 972135 -------- 1010370 -------- 1038212 -------- 1067041 -------- 1101158 -------- 1128704 -------- 1152742 -------- 1180165 -------- 1206852 -------- 1233537 -------- 1264064 -------- 1297504 -------- 1332260 -------- 1361504 -------- 1387553 -------- 1420224 -------- 1454275 -------- 1484580 -------- 1509766 -------- 1534050 -------- 1560452 -------- 1587299 -------- 1616771 -------- 1647526 -------- 1670343 -------- 1705121 -------- 1732486 -------- 1768967 -------- 1802725 -------- 1833189 -------- 1855398 -------- 1878146 -------- 1899877 -------- 1921414 -------- 1961765 -------- 1988000 -------- 2012672 -------- 2042529 -------- 2073381 -------- 2104999 -------- 2125477 -------- 2153825 -------- 2179462 -------- 2204065 -------- 2239044 -------- 2267205 -------- 2290530 -------- 2318977 -------- 2348134 -------- 2383399 -------- 2414215 -------- 2442695 -------- 2477955 -------- 2514372 -------- 2545062 -------- 2572418 -------- 2603108 -------- 2638534 -------- 2659232 -------- 2685286 -------- 2711527 -------- 2737088 -------- 2765639 -------- 2802818 -------- 2837570 -------- 2867911 -------- 2901088 -------- 2925954 -------- 2958501 -------- 2983042 -------- 3014626 -------- 3042406 -------- 3075489 -------- 3103425 -------- 3128673 -------- 3160994 -------- 3197125 -------- 3227043 -------- 3255328 -------- 3280965 -------- 3309669 -------- 3341767 -------- 3364898 -------- 3398305 -------- 3435008 -------- 3462818 -------- 3498272 -------- 3526631 -------- 3552485 -------- 3583014 -------- 3616322 -------- 3642566 -------- 3669732 -------- 3703330 -------- 3739170 -------- 3770791 -------- 3796804 -------- 3828387 -------- 3855751 -------- 3880321 -------- 3920422 -------- 3946818 -------- 3972322 -------- 4001250 -------- 4030533 -------- 4062306 -------- 4092992 -------- 4116803 -------- 4141697 -------- 4169536 -------- 4211878 -------- 4238753 -------- 4268994 -------- 4299686 -------- 4331525 -------- 4367079 -------- 4406277 -------- 4435878 -------- 4470914 -------- 4500294 -------- 4531617 -------- 4562114 -------- 4601666 -------- 4637856 -------- 4669060 -------- 4701861 -------- 4728416 -------- 4754881 -------- 4784001 -------- 4812482 -------- 4848389 -------- 4876741 -------- 4904612 -------- 4930945 -------- 4967397 -------- 4994146 -------- 5024099 -------- 5058023 -------- 5095527 -------- 5122081 -------- 5157798 -------- 5185472 -------- 5215332 -------- 5242497 -------- 5270338 -------- 5309699 -------- 5338112 -------- 5375843 -------- 5405441 -------- 5442277 -------- 5470945 -------- 5512930 -------- 5544807 -------- 5574980 -------- 5602340 -------- 5629280 -------- 5660482 -------- 5694599 -------- 5726466 -------- 5752519 -------- 5787268 -------- 5821185 -------- 5851973 -------- 5882689 -------- 5911363 -------- 5938052 -------- 5970949 -------- 5999748 --- 9223372036854775807
+ │ │ │ │ │ histogram(12)= 0 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7200 450 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 300 7350 300 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7200 300 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7350 150 7500 150 7500 300 7350 150 7500 300 7350 150 7500 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 300 7350 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 300 7350 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7500 150 7350 300 7500 150 7500 150
+ │ │ │ │ │ <--- 4 ------ 959 ------ 1858 ------ 2773 ------ 3466 ------ 4333 ------ 5026 ------ 5872 ------ 6571 ------ 7069 ------ 7897 ------ 8611 ------ 9514 ------ 10309 ------ 11038 ------ 11893 ------ 12632 ------ 13450 ------ 14104 ------ 14923 ------ 15719 ------ 16382 ------ 17119 ------ 17882 ------ 18701 ------ 19576 ------ 20314 ------ 20950 ------ 21727 ------ 22261 ------ 23059 ------ 23692 ------ 24488 ------ 25144 ------ 25895 ------ 26747 ------ 27650 ------ 28408 ------ 29140 ------ 29920 ------ 30511 ------ 31261 ------ 31999 ------ 32920 ------ 33688 ------ 34525 ------ 35197 ------ 35876 ------ 36580 ------ 37313 ------ 37924 ------ 38768 ------ 39440 ------ 40127 ------ 41005 ------ 41810 ------ 42422 ------ 43310 ------ 44095 ------ 44644 ------ 45347 ------ 45970 ------ 46634 ------ 47284 ------ 48055 ------ 48850 ------ 49712 ------ 50356 ------ 51268 ------ 52048 ------ 52571 ------ 53125 ------ 54088 ------ 54913 ------ 55771 ------ 56386 ------ 57085 ------ 57877 ------ 58729 ------ 59353 ------ 60133 ------ 60947 ------ 61672 ------ 62411 ------ 63296 ------ 64000 ------ 64586 ------ 65251 ------ 65914 ------ 66403 ------ 66991 ------ 67798 ------ 68494 ------ 69406 ------ 70106 ------ 70921 ------ 71770 ------ 72482 ------ 73256 ------ 74083 ------ 74681 ------ 75412 ------ 76201 ------ 76876 ------ 77684 ------ 78421 ------ 79058 ------ 79909 ------ 80591 ------ 81247 ------ 81964 ------ 82835 ------ 83731 ------ 84467 ------ 85012 ------ 85874 ------ 86647 ------ 87151 ------ 87853 ------ 88543 ------ 89425 ------ 90046 ------ 90640 ------ 91544 ------ 92257 ------ 93107 ------ 93835 ------ 94424 ------ 95383 ------ 96313 ------ 96938 ------ 97808 ------ 98689 ------ 99505 ------ 100144 ------ 100981 ------ 101797 ------ 102556 ------ 103504 ------ 104113 ------ 104980 ------ 105622 ------ 106241 ------ 106988 ------ 107578 ------ 108302 ------ 108905 ------ 109765 ------ 110663 ------ 111409 ------ 112093 ------ 113033 ------ 113683 ------ 114346 ------ 115006 ------ 115798 ------ 116261 ------ 116908 ------ 117610 ------ 118319 ------ 119203 ------ 120058 ------ 120922 ------ 121702 ------ 122486 ------ 123253 ------ 124142 ------ 124795 ------ 125689 ------ 126277 ------ 126904 ------ 127684 ------ 128251 ------ 129032 ------ 129916 ------ 130717 ------ 131554 ------ 132482 ------ 133408 ------ 134272 ------ 135073 ------ 135869 ------ 136963 ------ 137806 ------ 138412 ------ 139103 ------ 139982 ------ 140794 ------ 141455 ------ 142396 ------ 143047 ------ 143788 ------ 144620 ------ 145336 ------ 146170 ------ 147014 ------ 147769 ------ 148508 ------ 149234 ------ 149995
+ │ │ │ │ │ histogram(14)= 0 150 1.4997e+06 150
+ │ │ │ │ │ <--- 1094.65 ------------ 477728.86
+ │ │ │ │ │ histogram(15)= 0 450 6900 600 7350 600 6750 900 7050 1350 7350 1350 6750 900 6600 900 7350 600 7200 600 7350 1050 6900 750 6900 750 7350 450 7350 600 7200 750 7350 450 7200 750 7350 750 6150 1200 7050 300 7200 600 7200 300 6600 1350 7050 450 6750 600 7200 750 7050 450 6750 600 7200 900 7050 900 7050 750 7050 600 7200 750 6150 1200 7200 1200 6000 1350 6300 1200 7200 750 6750 1200 6600 900 7050 750 7050 450 7050 900 7200 450 7200 1050 6900 900 6300 1200 6750 600 7050 900 7050 450 6900 1200 6750 600 7050 750 6750 1350 7050 600 7050 300 7200 450 7050 600 6900 450 6900 450 7200 600 6600 900 6900 750 5700 1800 6900 750 6300 1050 7050 900 7200 300 7050 450 6600 750 6450 1200 6900 600 7050 1050 7050 450 6600 750 7050 600 6450 900 7050 600 7200 900 6750 900 7200 750 7200 1050 6750 600 6900 600 6900 1050 7050 450 7050 750 6000 1350 6750 900 6900 900 6900 900 7050 1050 6750 600 7050 900 6450 900 7050 300 6600 750 7050 1350 7200 450 7200 750 7200 600 6300 900 7050 750 6450 900 6900 900 6600 600 6600 600 6900 750 7050 600 6150 1050 6750 600 6600 600 7050 900 7050 1650 6750 600 6750 600 6750 450 7050 1050 6900 1350 6600 600 6300 900 6600 600 6300 1050 6750 900 6300 900 7050 1200 6600 1200 6750 750 6900 900 6750 600 6750 600 6150 1200 6450 1050 7050 750 6300 1050 7050 450 6750 600 6750 600 7050 600 7050 900 6900 600 6900 900 6900 600 6450 1200 6600 450 6900 450 6750 600 6750 750 6750 1350 6750 450 6600 750 6600 450 6450 750 6450 600 6750 600 6900 900 6300 750 6450 1200 6000 1500 6900 900 6000 1200 6300 750 6450 600 6900 1050 6600 600 6900 1650 5850 1050 6600 750 6600 450 6300 900 6600 300 6600 600 6750 900 6750 450 6600 750 6600 300 6150 900 6750 600 5850 1050 6750 450 6750 750 6600 900 6150 600 6600 450 6150 750 6600 1350 6600 450 6000 1200 5550 1350 6150 450 6300 450 6450 900 6450 750 6000 1650 5850 750 6000 450 5250 900 5400 1050 5400 600
+ │ │ │ │ │ <--- '1992-01-01' ------ '1992-01-13' ------ '1992-01-25' ------ '1992-02-05' ------ '1992-02-18' ------ '1992-02-29' ------ '1992-03-12' ------ '1992-03-23' ------ '1992-04-05' ------ '1992-04-17' ------ '1992-04-30' ------ '1992-05-16' ------ '1992-05-28' ------ '1992-06-09' ------ '1992-06-22' ------ '1992-07-04' ------ '1992-07-15' ------ '1992-07-26' ------ '1992-08-09' ------ '1992-08-19' ------ '1992-09-01' ------ '1992-09-12' ------ '1992-09-23' ------ '1992-10-04' ------ '1992-10-17' ------ '1992-10-27' ------ '1992-11-06' ------ '1992-11-19' ------ '1992-11-30' ------ '1992-12-12' ------ '1992-12-23' ------ '1993-01-06' ------ '1993-01-18' ------ '1993-01-31' ------ '1993-02-08' ------ '1993-02-21' ------ '1993-03-01' ------ '1993-03-16' ------ '1993-03-27' ------ '1993-04-07' ------ '1993-04-21' ------ '1993-05-02' ------ '1993-05-14' ------ '1993-05-28' ------ '1993-06-08' ------ '1993-06-20' ------ '1993-07-02' ------ '1993-07-16' ------ '1993-07-29' ------ '1993-08-12' ------ '1993-08-25' ------ '1993-09-07' ------ '1993-09-22' ------ '1993-10-05' ------ '1993-10-18' ------ '1993-10-31' ------ '1993-11-14' ------ '1993-11-25' ------ '1993-12-06' ------ '1993-12-20' ------ '1994-01-03' ------ '1994-01-15' ------ '1994-01-23' ------ '1994-02-04' ------ '1994-02-15' ------ '1994-02-27' ------ '1994-03-09' ------ '1994-03-19' ------ '1994-04-05' ------ '1994-04-16' ------ '1994-04-29' ------ '1994-05-10' ------ '1994-05-24' ------ '1994-06-04' ------ '1994-06-16' ------ '1994-06-30' ------ '1994-07-16' ------ '1994-07-31' ------ '1994-08-13' ------ '1994-08-27' ------ '1994-09-08' ------ '1994-09-23' ------ '1994-10-06' ------ '1994-10-17' ------ '1994-10-28' ------ '1994-11-11' ------ '1994-11-25' ------ '1994-12-11' ------ '1994-12-22' ------ '1995-01-03' ------ '1995-01-17' ------ '1995-01-30' ------ '1995-02-09' ------ '1995-02-23' ------ '1995-03-10' ------ '1995-03-21' ------ '1995-04-04' ------ '1995-04-15' ------ '1995-04-27' ------ '1995-05-12' ------ '1995-05-26' ------ '1995-06-04' ------ '1995-06-13' ------ '1995-06-26' ------ '1995-07-08' ------ '1995-07-19' ------ '1995-07-31' ------ '1995-08-12' ------ '1995-08-21' ------ '1995-09-04' ------ '1995-09-13' ------ '1995-09-25' ------ '1995-10-06' ------ '1995-10-22' ------ '1995-10-30' ------ '1995-11-11' ------ '1995-11-23' ------ '1995-12-06' ------ '1995-12-19' ------ '1996-01-01' ------ '1996-01-13' ------ '1996-01-23' ------ '1996-02-03' ------ '1996-02-14' ------ '1996-02-24' ------ '1996-03-05' ------ '1996-03-17' ------ '1996-03-26' ------ '1996-04-09' ------ '1996-04-21' ------ '1996-05-03' ------ '1996-05-15' ------ '1996-05-28' ------ '1996-06-06' ------ '1996-06-16' ------ '1996-06-27' ------ '1996-07-11' ------ '1996-07-24' ------ '1996-08-07' ------ '1996-08-20' ------ '1996-09-04' ------ '1996-09-17' ------ '1996-10-05' ------ '1996-10-18' ------ '1996-10-29' ------ '1996-11-07' ------ '1996-11-20' ------ '1996-11-30' ------ '1996-12-15' ------ '1996-12-30' ------ '1997-01-13' ------ '1997-01-25' ------ '1997-02-05' ------ '1997-02-15' ------ '1997-02-24' ------ '1997-03-06' ------ '1997-03-18' ------ '1997-03-30' ------ '1997-04-09' ------ '1997-04-21' ------ '1997-05-01' ------ '1997-05-12' ------ '1997-05-24' ------ '1997-06-04' ------ '1997-06-15' ------ '1997-06-28' ------ '1997-07-10' ------ '1997-07-20' ------ '1997-07-30' ------ '1997-08-13' ------ '1997-08-24' ------ '1997-09-04' ------ '1997-09-16' ------ '1997-09-29' ------ '1997-10-15' ------ '1997-10-30' ------ '1997-11-13' ------ '1997-11-25' ------ '1997-12-06' ------ '1997-12-18' ------ '1997-12-30' ------ '1998-01-10' ------ '1998-01-23' ------ '1998-02-02' ------ '1998-02-15' ------ '1998-02-28' ------ '1998-03-11' ------ '1998-03-24' ------ '1998-04-03' ------ '1998-04-12' ------ '1998-04-24' ------ '1998-05-05' ------ '1998-05-18' ------ '1998-05-31' ------ '1998-06-11' ------ '1998-06-20' ------ '1998-06-30' ------ '1998-07-12' ------ '1998-07-23' ------ '1998-08-02'
│ │ │ │ ├── key: (11)
│ │ │ │ ├── fd: (11)-->(12,14,15)
│ │ │ │ └── ordering: +11
@@ -132,11 +132,11 @@ top-k
│ │ │ │ │ ├── scan lineitem
│ │ │ │ │ │ ├── save-table-name: q18_scan_10
│ │ │ │ │ │ ├── columns: l_orderkey:40(int!null) l_quantity:44(float!null)
- │ │ │ │ │ │ ├── stats: [rows=6002293, distinct(40)=1.52727e+06, null(40)=0, avgsize(40)=4, distinct(44)=50, null(44)=0, avgsize(44)=4]
- │ │ │ │ │ │ │ histogram(40)= 0 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600
- │ │ │ │ │ │ │ <--- 576 ------- 38535 ------- 66885 ------- 93380 ------- 127425 ------- 157218 ------- 184483 ------- 215330 ------- 252869 ------- 283878 ------- 313798 ------- 337056 ------- 372549 ------- 399591 ------- 426245 ------- 460578 ------- 498439 ------- 526049 ------- 554468 ------- 577921 ------- 609187 ------- 639524 ------- 665345 ------- 686180 ------- 721539 ------- 755680 ------- 782756 ------- 814496 ------- 845446 ------- 872130 ------- 910912 ------- 933697 ------- 965184 ------- 1000353 ------- 1038658 ------- 1073667 ------- 1097891 ------- 1131330 ------- 1157732 ------- 1179943 ------- 1206401 ------- 1230150 ------- 1261824 ------- 1293217 ------- 1326754 ------- 1357573 ------- 1390145 ------- 1429312 ------- 1460418 ------- 1491104 ------- 1523937 ------- 1559812 ------- 1591653 ------- 1615174 ------- 1646759 ------- 1670465 ------- 1696321 ------- 1724192 ------- 1748033 ------- 1777570 ------- 1807428 ------- 1836962 ------- 1872481 ------- 1902817 ------- 1928324 ------- 1960775 ------- 1985989 ------- 2019107 ------- 2044613 ------- 2071490 ------- 2101959 ------- 2135555 ------- 2164486 ------- 2186337 ------- 2213989 ------- 2246309 ------- 2276992 ------- 2306403 ------- 2329921 ------- 2354977 ------- 2380711 ------- 2410529 ------- 2437920 ------- 2462017 ------- 2483714 ------- 2513920 ------- 2542855 ------- 2574112 ------- 2596035 ------- 2625031 ------- 2658051 ------- 2695046 ------- 2725222 ------- 2754245 ------- 2777702 ------- 2804896 ------- 2844579 ------- 2873860 ------- 2903459 ------- 2933249 ------- 2965479 ------- 2996160 ------- 3022976 ------- 3053152 ------- 3083623 ------- 3111136 ------- 3144033 ------- 3180134 ------- 3209799 ------- 3239394 ------- 3270886 ------- 3297664 ------- 3329444 ------- 3357574 ------- 3380838 ------- 3412196 ------- 3438917 ------- 3462467 ------- 3498629 ------- 3530208 ------- 3562148 ------- 3589889 ------- 3621063 ------- 3655456 ------- 3686724 ------- 3709029 ------- 3738215 ------- 3767687 ------- 3804547 ------- 3831142 ------- 3875111 ------- 3905605 ------- 3933795 ------- 3966593 ------- 3995558 ------- 4020134 ------- 4052513 ------- 4078949 ------- 4114208 ------- 4149762 ------- 4176135 ------- 4207782 ------- 4241376 ------- 4270502 ------- 4304167 ------- 4333669 ------- 4362818 ------- 4393537 ------- 4423076 ------- 4452064 ------- 4491143 ------- 4522723 ------- 4550883 ------- 4581382 ------- 4616002 ------- 4649410 ------- 4680485 ------- 4715584 ------- 4740036 ------- 4771554 ------- 4799461 ------- 4826690 ------- 4855525 ------- 4887974 ------- 4917479 ------- 4950885 ------- 4984195 ------- 5010113 ------- 5033571 ------- 5065472 ------- 5100512 ------- 5129413 ------- 5160069 ------- 5186596 ------- 5221538 ------- 5252964 ------- 5284069 ------- 5314051 ------- 5353026 ------- 5388961 ------- 5424644 ------- 5452676 ------- 5483553 ------- 5516612 ------- 5551041 ------- 5579878 ------- 5612576 ------- 5643427 ------- 5673666 ------- 5709218 ------- 5737221 ------- 5766119 ------- 5795044 ------- 5826560 ------- 5855943 ------- 5889604 ------- 5917607 ------- 5942535 ------- 5969639 ------- 5999557
- │ │ │ │ │ │ │ histogram(44)= 0 1.1524e+05 5.7772e+06 1.0984e+05
- │ │ │ │ │ │ │ <----- 1.0 ----------------- 50.0 --
+ │ │ │ │ │ │ ├── stats: [rows=6001215, distinct(40)=1.52727e+06, null(40)=0, avgsize(40)=4, distinct(44)=50, null(44)=0, avgsize(44)=9]
+ │ │ │ │ │ │ │ histogram(40)= 0 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600
+ │ │ │ │ │ │ │ <--- 197 ------- 23686 ------- 53253 ------- 90435 ------- 121730 ------- 153280 ------- 175456 ------- 208548 ------- 242209 ------- 273057 ------- 296640 ------- 330307 ------- 360999 ------- 386307 ------- 420225 ------- 450050 ------- 477795 ------- 504711 ------- 533153 ------- 556672 ------- 582243 ------- 613729 ------- 646117 ------- 675840 ------- 706048 ------- 733063 ------- 769282 ------- 793922 ------- 820357 ------- 849536 ------- 875719 ------- 905028 ------- 940643 ------- 968355 ------- 998721 ------- 1023621 ------- 1059424 ------- 1084932 ------- 1115553 ------- 1139363 ------- 1167361 ------- 1194400 ------- 1225984 ------- 1253861 ------- 1281633 ------- 1304999 ------- 1336355 ------- 1370759 ------- 1400832 ------- 1434085 ------- 1458852 ------- 1491427 ------- 1525120 ------- 1555205 ------- 1591300 ------- 1619426 ------- 1651458 ------- 1682950 ------- 1711399 ------- 1747591 ------- 1787205 ------- 1822240 ------- 1856163 ------- 1886915 ------- 1910949 ------- 1947202 ------- 1974311 ------- 2009286 ------- 2044034 ------- 2079104 ------- 2103488 ------- 2134657 ------- 2164293 ------- 2204514 ------- 2230823 ------- 2265253 ------- 2289826 ------- 2329539 ------- 2364455 ------- 2393507 ------- 2414628 ------- 2440228 ------- 2465255 ------- 2489568 ------- 2520900 ------- 2554919 ------- 2583333 ------- 2612966 ------- 2644833 ------- 2667362 ------- 2702784 ------- 2727394 ------- 2759748 ------- 2794531 ------- 2822214 ------- 2846624 ------- 2883748 ------- 2919586 ------- 2951908 ------- 2980068 ------- 3014726 ------- 3050725 ------- 3081028 ------- 3113351 ------- 3150243 ------- 3185669 ------- 3214311 ------- 3241281 ------- 3275748 ------- 3303232 ------- 3339559 ------- 3370627 ------- 3393664 ------- 3435265 ------- 3464581 ------- 3489026 ------- 3516096 ------- 3548480 ------- 3587015 ------- 3611239 ------- 3638724 ------- 3668641 ------- 3695751 ------- 3729636 ------- 3751523 ------- 3784608 ------- 3815715 ------- 3848608 ------- 3881184 ------- 3908738 ------- 3940002 ------- 3966176 ------- 4001984 ------- 4035687 ------- 4065283 ------- 4092834 ------- 4133062 ------- 4160613 ------- 4196421 ------- 4223713 ------- 4254788 ------- 4291040 ------- 4313664 ------- 4342823 ------- 4369952 ------- 4391684 ------- 4419040 ------- 4449921 ------- 4471781 ------- 4506210 ------- 4538176 ------- 4571297 ------- 4601121 ------- 4630887 ------- 4657476 ------- 4684803 ------- 4714566 ------- 4744070 ------- 4776385 ------- 4807777 ------- 4839491 ------- 4873953 ------- 4902245 ------- 4936263 ------- 4970721 ------- 5003140 ------- 5029729 ------- 5059010 ------- 5087521 ------- 5121093 ------- 5150405 ------- 5178375 ------- 5203683 ------- 5234531 ------- 5268195 ------- 5300004 ------- 5331558 ------- 5362178 ------- 5385762 ------- 5418498 ------- 5445762 ------- 5483109 ------- 5514561 ------- 5542052 ------- 5569572 ------- 5596102 ------- 5622401 ------- 5652194 ------- 5671362 ------- 5699591 ------- 5727136 ------- 5753284 ------- 5780742 ------- 5809189 ------- 5836545 ------- 5864454 ------- 5894917 ------- 5933825 ------- 5968933 ------- 5999590
+ │ │ │ │ │ │ │ histogram(44)= 0 1.1342e+05 5.766e+06 1.2182e+05
+ │ │ │ │ │ │ │ <----- 1.0 ---------------- 50.0 --
│ │ │ │ │ │ └── ordering: +40
│ │ │ │ │ └── aggregations
│ │ │ │ │ └── sum [as=sum:58, type=float, outer=(44)]
@@ -148,11 +148,11 @@ top-k
│ ├── scan customer
│ │ ├── save-table-name: q18_scan_11
│ │ ├── columns: c_custkey:1(int!null) c_name:2(varchar!null)
- │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(2)=150000, null(2)=0, avgsize(2)=4]
- │ │ │ histogram(1)= 0 5 769 5 765 5 732 5 744 5 731 5 754 5 772 5 757 5 713 5 741 5 808 5 744 5 739 5 687 5 820 5 761 5 782 5 632 5 711 5 692 5 648 5 770 5 765 5 702 5 751 5 807 5 794 5 735 5 807 5 719 5 773 5 781 5 684 5 748 5 682 5 703 5 794 5 718 5 807 5 674 5 747 5 677 5 813 5 666 5 766 5 822 5 703 5 676 5 765 5 693 5 723 5 780 5 793 5 770 5 696 5 775 5 764 5 884 5 696 5 688 5 637 5 789 5 702 5 732 5 697 5 769 5 739 5 744 5 861 5 791 5 726 5 793 5 730 5 763 5 789 5 797 5 775 5 862 5 780 5 746 5 783 5 743 5 822 5 806 5 775 5 727 5 724 5 799 5 707 5 757 5 614 5 747 5 704 5 740 5 749 5 735 5 741 5 807 5 827 5 816 5 702 5 699 5 803 5 793 5 672 5 831 5 694 5 746 5 731 5 686 5 685 5 695 5 828 5 756 5 722 5 749 5 790 5 758 5 750 5 782 5 733 5 778 5 762 5 758 5 731 5 778 5 663 5 696 5 684 5 796 5 770 5 656 5 690 5 747 5 782 5 785 5 751 5 697 5 663 5 766 5 695 5 866 5 813 5 765 5 901 5 747 5 683 5 706 5 689 5 734 5 715 5 752 5 855 5 771 5 717 5 794 5 760 5 827 5 747 5 757 5 767 5 726 5 690 5 787 5 783 5 744 5 761 5 746 5 793 5 696 5 749 5 745 5 755 5 800 5 778 5 814 5 826 5 700 5 740 5 773 5 713 5 824 5 792 5 702 5 734 5 751 5 716 5 718 5 722 5 784 5 778 5 700 5 714 5 739 5 748 5 697 5 751 5 663 5 740 5
- │ │ │ <--- 37 ----- 834 ----- 1623 ----- 2351 ----- 3101 ----- 3828 ----- 4598 ----- 5401 ----- 6176 ----- 6868 ----- 7613 ----- 8479 ----- 9230 ----- 9972 ----- 10613 ----- 11500 ----- 12282 ----- 13103 ----- 13624 ----- 14312 ----- 14962 ----- 15520 ----- 16319 ----- 17109 ----- 17780 ----- 18543 ----- 19408 ----- 20250 ----- 20984 ----- 21848 ----- 22551 ----- 23355 ----- 24174 ----- 24809 ----- 25567 ----- 26196 ----- 26868 ----- 27710 ----- 28412 ----- 29276 ----- 29889 ----- 30645 ----- 31264 ----- 32139 ----- 32736 ----- 33527 ----- 34418 ----- 35091 ----- 35709 ----- 36498 ----- 37150 ----- 37861 ----- 38677 ----- 39517 ----- 40316 ----- 40975 ----- 41782 ----- 42569 ----- 43565 ----- 44224 ----- 44867 ----- 45399 ----- 46231 ----- 46902 ----- 47630 ----- 48291 ----- 49087 ----- 49829 ----- 50580 ----- 51538 ----- 52375 ----- 53092 ----- 53932 ----- 54656 ----- 55442 ----- 56274 ----- 57121 ----- 57929 ----- 58888 ----- 59705 ----- 60460 ----- 61282 ----- 62031 ----- 62922 ----- 63785 ----- 64593 ----- 65311 ----- 66024 ----- 66875 ----- 67556 ----- 68331 ----- 68808 ----- 69564 ----- 70239 ----- 70983 ----- 71744 ----- 72478 ----- 73223 ----- 74088 ----- 74988 ----- 75868 ----- 76539 ----- 77203 ----- 78061 ----- 78901 ----- 79510 ----- 80417 ----- 81071 ----- 81826 ----- 82553 ----- 83191 ----- 83828 ----- 84485 ----- 85386 ----- 86159 ----- 86868 ----- 87628 ----- 88463 ----- 89240 ----- 90002 ----- 90822 ----- 91553 ----- 92367 ----- 93152 ----- 93929 ----- 94656 ----- 95470 ----- 96061 ----- 96720 ----- 97355 ----- 98200 ----- 98998 ----- 99573 ----- 100219 ----- 100975 ----- 101795 ----- 102620 ----- 103384 ----- 104044 ----- 104635 ----- 105426 ----- 106083 ----- 107049 ----- 107925 ----- 108715 ----- 109740 ----- 110496 ----- 111128 ----- 111807 ----- 112451 ----- 113184 ----- 113866 ----- 114619 ----- 115556 ----- 116344 ----- 117029 ----- 117859 ----- 118626 ----- 119515 ----- 120258 ----- 121021 ----- 121802 ----- 122505 ----- 123136 ----- 123953 ----- 124763 ----- 125501 ----- 126271 ----- 127012 ----- 127841 ----- 128483 ----- 129230 ----- 129970 ----- 130729 ----- 131569 ----- 132370 ----- 133235 ----- 134122 ----- 134773 ----- 135503 ----- 136294 ----- 136971 ----- 137854 ----- 138681 ----- 139336 ----- 140055 ----- 140806 ----- 141489 ----- 142177 ----- 142873 ----- 143685 ----- 144486 ----- 145138 ----- 145817 ----- 146545 ----- 147291 ----- 147936 ----- 148687 ----- 149260 ----- 149990
+ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(2)=150000, null(2)=0, avgsize(2)=20]
+ │ │ │ histogram(1)= 0 0 0 5 745 5 746 5 711 5 780 5 738 5 835 5 697 5 757 5 704 5 696 5 753 5 678 5 813 5 873 5 736 5 840 5 703 5 745 5 710 5 763 5 742 5 673 5 702 5 793 5 732 5 752 5 707 5 751 5 722 5 814 5 789 5 671 5 643 5 706 5 723 5 757 5 713 5 760 5 766 5 711 5 858 5 702 5 695 5 697 5 823 5 857 5 712 5 808 5 754 5 739 5 694 5 782 5 792 5 751 5 758 5 749 5 798 5 685 5 692 5 792 5 710 5 771 5 724 5 853 5 713 5 823 5 772 5 656 5 763 5 672 5 735 5 810 5 786 5 709 5 731 5 702 5 708 5 669 5 733 5 744 5 758 5 800 5 682 5 716 5 716 5 729 5 778 5 721 5 766 5 820 5 757 5 739 5 799 5 780 5 710 5 749 5 754 5 750 5 699 5 821 5 759 5 818 5 763 5 854 5 779 5 810 5 783 5 686 5 703 5 776 5 675 5 812 5 745 5 759 5 793 5 751 5 761 5 798 5 794 5 729 5 696 5 699 5 831 5 709 5 747 5 722 5 768 5 729 5 702 5 729 5 698 5 767 5 792 5 726 5 737 5 671 5 721 5 842 5 701 5 704 5 708 5 726 5 695 5 665 5 688 5 653 5 690 5 734 5 789 5 659 5 785 5 733 5 740 5 826 5 745 5 929 5 899 5 743 5 790 5 825 5 779 5 677 5 697 5 756 5 693 5 862 5 772 5 783 5 757 5 799 5 778 5 752 5 715 5 709 5 790 5 789 5 865 5 808 5 772 5 743 5 751 5 742 5 676 5 684 5 744 5 709 5 679 5 817 5 755 5 754 5 797 5 709 5 748 5 679 5 751 5 775 5 736 5 790 5 714 5 0 0
+ │ │ │ <--- -9223372036854775808 --- 59 ----- 811 ----- 1565 ----- 2252 ----- 3068 ----- 3807 ----- 4720 ----- 5381 ----- 6155 ----- 6829 ----- 7487 ----- 8254 ----- 8876 ----- 9751 ----- 10728 ----- 11463 ----- 12385 ----- 13057 ----- 13810 ----- 14495 ----- 15281 ----- 16028 ----- 16640 ----- 17311 ----- 18151 ----- 18880 ----- 19645 ----- 20325 ----- 21088 ----- 21798 ----- 22674 ----- 23507 ----- 24115 ----- 24661 ----- 25340 ----- 26052 ----- 26827 ----- 27518 ----- 28298 ----- 29089 ----- 29777 ----- 30730 ----- 31401 ----- 32057 ----- 32718 ----- 33611 ----- 34562 ----- 35251 ----- 36117 ----- 36887 ----- 37629 ----- 38283 ----- 39104 ----- 39942 ----- 40705 ----- 41481 ----- 42241 ----- 43089 ----- 43725 ----- 44376 ----- 45214 ----- 45899 ----- 46700 ----- 47413 ----- 48356 ----- 49047 ----- 49939 ----- 50742 ----- 51316 ----- 52101 ----- 52710 ----- 53444 ----- 54313 ----- 55140 ----- 55823 ----- 56549 ----- 57219 ----- 57901 ----- 58503 ----- 59234 ----- 59984 ----- 60760 ----- 61613 ----- 62243 ----- 62941 ----- 63638 ----- 64360 ----- 65173 ----- 65880 ----- 66672 ----- 67560 ----- 68334 ----- 69075 ----- 69925 ----- 70742 ----- 71428 ----- 72189 ----- 72958 ----- 73720 ----- 74385 ----- 75274 ----- 76053 ----- 76936 ----- 77721 ----- 78666 ----- 79480 ----- 80349 ----- 81171 ----- 81810 ----- 82482 ----- 83292 ----- 83907 ----- 84780 ----- 85532 ----- 86310 ----- 87149 ----- 87912 ----- 88694 ----- 89543 ----- 90384 ----- 91106 ----- 91764 ----- 92428 ----- 93335 ----- 94018 ----- 94775 ----- 95484 ----- 96279 ----- 97001 ----- 97672 ----- 98394 ----- 99056 ----- 99850 ----- 100688 ----- 101405 ----- 102143 ----- 102751 ----- 103459 ----- 104384 ----- 105052 ----- 105727 ----- 106409 ----- 107125 ----- 107782 ----- 108377 ----- 109020 ----- 109588 ----- 110235 ----- 110967 ----- 111800 ----- 112382 ----- 113196 ----- 113913 ----- 114643 ----- 115529 ----- 116268 ----- 117329 ----- 118341 ----- 119076 ----- 119898 ----- 120782 ----- 121584 ----- 122186 ----- 122830 ----- 123591 ----- 124227 ----- 125175 ----- 125964 ----- 126773 ----- 127535 ----- 128374 ----- 129175 ----- 129928 ----- 130609 ----- 131279 ----- 132102 ----- 132923 ----- 133877 ----- 134732 ----- 135521 ----- 136257 ----- 137007 ----- 137740 ----- 138341 ----- 138958 ----- 139695 ----- 140364 ----- 140971 ----- 141841 ----- 142600 ----- 143356 ----- 144192 ----- 144861 ----- 145607 ----- 146214 ----- 146965 ----- 147761 ----- 148483 ----- 149306 ----- 149986 --- 9223372036854775807
│ │ │ histogram(2)= 0 1 1.5e+05 1
- │ │ │ <--- 'Customer#000000037' --------- 'Customer#000149990'
+ │ │ │ <--- 'Customer#000000059' --------- 'Customer#000149986'
│ │ ├── key: (1)
│ │ └── fd: (1)-->(2)
│ └── filters
@@ -196,12 +196,12 @@ column_names row_count distinct_count null_count
{sum} 57 18 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 499399.00 8761.39 <== 499399.00 8761.39 <== 0.00 1.00
-{c_name} 499399.00 8761.39 <== 499399.00 8761.39 <== 0.00 1.00
-{o_orderdate} 499399.00 8761.39 <== 499399.00 8761.39 <== 0.00 1.00
-{o_orderkey} 499399.00 8761.39 <== 499399.00 8761.39 <== 0.00 1.00
-{o_totalprice} 499399.00 8761.39 <== 499399.00 8761.39 <== 0.00 1.00
-{sum} 499399.00 8761.39 <== 499399.00 27744.39 <== 0.00 1.00
+{c_custkey} 499392.00 8761.26 <== 499392.00 8761.26 <== 0.00 1.00
+{c_name} 499392.00 8761.26 <== 499392.00 8761.26 <== 0.00 1.00
+{o_orderdate} 499392.00 8761.26 <== 499392.00 8761.26 <== 0.00 1.00
+{o_orderkey} 499392.00 8761.26 <== 499392.00 8761.26 <== 0.00 1.00
+{o_totalprice} 499392.00 8761.26 <== 499392.00 8761.26 <== 0.00 1.00
+{sum} 499392.00 8761.26 <== 499392.00 27744.00 <== 0.00 1.00
----Stats for q18_inner_join_3----
column_names row_count distinct_count null_count
@@ -215,14 +215,14 @@ column_names row_count distinct_count null_count
{o_totalprice} 399 57 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_custkey} 2016723.00 5054.44 <== 99656.00 1748.35 <== 0.00 1.00
-{c_name} 2016723.00 5054.44 <== 150000.00 2631.58 <== 0.00 1.00
-{l_orderkey} 2016723.00 5054.44 <== 499399.00 8761.39 <== 0.00 1.00
-{l_quantity} 2016723.00 5054.44 <== 50.00 1.85 0.00 1.00
-{o_custkey} 2016723.00 5054.44 <== 99656.00 1748.35 <== 0.00 1.00
-{o_orderdate} 2016723.00 5054.44 <== 2406.00 42.21 <== 0.00 1.00
-{o_orderkey} 2016723.00 5054.44 <== 499399.00 8761.39 <== 0.00 1.00
-{o_totalprice} 2016723.00 5054.44 <== 488633.00 8572.51 <== 0.00 1.00
+{c_custkey} 2016361.00 5053.54 <== 99649.00 1748.23 <== 0.00 1.00
+{c_name} 2016361.00 5053.54 <== 150000.00 2631.58 <== 0.00 1.00
+{l_orderkey} 2016361.00 5053.54 <== 499392.00 8761.26 <== 0.00 1.00
+{l_quantity} 2016361.00 5053.54 <== 50.00 1.85 0.00 1.00
+{o_custkey} 2016361.00 5053.54 <== 99649.00 1748.23 <== 0.00 1.00
+{o_orderdate} 2016361.00 5053.54 <== 2406.00 42.21 <== 0.00 1.00
+{o_orderkey} 2016361.00 5053.54 <== 499392.00 8761.26 <== 0.00 1.00
+{o_totalprice} 2016361.00 5053.54 <== 488044.00 8562.18 <== 0.00 1.00
----Stats for q18_merge_join_4----
column_names row_count distinct_count null_count
@@ -234,12 +234,12 @@ column_names row_count distinct_count null_count
{o_totalprice} 399 57 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_orderkey} 2000764.00 5014.45 <== 509090.00 8931.40 <== 0.00 1.00
-{l_quantity} 2000764.00 5014.45 <== 50.00 1.85 0.00 1.00
-{o_custkey} 2000764.00 5014.45 <== 99656.00 1748.35 <== 0.00 1.00
-{o_orderdate} 2000764.00 5014.45 <== 2406.00 42.21 <== 0.00 1.00
-{o_orderkey} 2000764.00 5014.45 <== 509090.00 8931.40 <== 0.00 1.00
-{o_totalprice} 2000764.00 5014.45 <== 497246.00 8723.61 <== 0.00 1.00
+{l_orderkey} 2000405.00 5013.55 <== 509090.00 8931.40 <== 0.00 1.00
+{l_quantity} 2000405.00 5013.55 <== 50.00 1.85 0.00 1.00
+{o_custkey} 2000405.00 5013.55 <== 99649.00 1748.23 <== 0.00 1.00
+{o_orderdate} 2000405.00 5013.55 <== 2406.00 42.21 <== 0.00 1.00
+{o_orderkey} 2000405.00 5013.55 <== 509090.00 8931.40 <== 0.00 1.00
+{o_totalprice} 2000405.00 5013.55 <== 496607.00 8712.40 <== 0.00 1.00
----Stats for q18_scan_5----
column_names row_count distinct_count null_count
@@ -247,8 +247,8 @@ column_names row_count distinct_count null_count
{l_quantity} 5986300 50 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_orderkey} 6002293.00 1.00 1527270.00 1.00 0.00 1.00
-{l_quantity} 6002293.00 1.00 50.00 1.00 0.00 1.00
+{l_orderkey} 6001215.00 1.00 1527270.00 1.00 0.00 1.00
+{l_quantity} 6001215.00 1.00 50.00 1.00 0.00 1.00
----Stats for q18_merge_join_6----
column_names row_count distinct_count null_count
@@ -258,10 +258,10 @@ column_names row_count distinct_count null_count
{o_totalprice} 57 57 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_custkey} 509090.00 8931.40 <== 99656.00 1748.35 <== 0.00 1.00
+{o_custkey} 509090.00 8931.40 <== 99649.00 1748.23 <== 0.00 1.00
{o_orderdate} 509090.00 8931.40 <== 2406.00 42.21 <== 0.00 1.00
{o_orderkey} 509090.00 8931.40 <== 509090.00 8931.40 <== 0.00 1.00
-{o_totalprice} 509090.00 8931.40 <== 507049.00 8895.60 <== 0.00 1.00
+{o_totalprice} 509090.00 8931.40 <== 506350.00 8883.33 <== 0.00 1.00
----Stats for q18_scan_7----
column_names row_count distinct_count null_count
@@ -271,10 +271,10 @@ column_names row_count distinct_count null_count
{o_totalprice} 1497000 1456760 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{o_custkey} 1500000.00 1.00 99853.00 1.00 0.00 1.00
+{o_custkey} 1500000.00 1.00 99846.00 1.00 0.00 1.00
{o_orderdate} 1500000.00 1.00 2406.00 1.00 0.00 1.00
{o_orderkey} 1500000.00 1.00 1500000.00 1.00 0.00 1.00
-{o_totalprice} 1500000.00 1.00 1469395.00 1.01 0.00 1.00
+{o_totalprice} 1500000.00 1.00 1459167.00 1.00 0.00 1.00
----Stats for q18_select_8----
column_names row_count distinct_count null_count
@@ -300,8 +300,8 @@ column_names row_count distinct_count null_count
{l_quantity} 6001215 50 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_orderkey} 6002293.00 1.00 1527270.00 1.00 0.00 1.00
-{l_quantity} 6002293.00 1.00 50.00 1.00 0.00 1.00
+{l_orderkey} 6001215.00 1.00 1527270.00 1.00 0.00 1.00
+{l_quantity} 6001215.00 1.00 50.00 1.00 0.00 1.00
----Stats for q18_scan_11----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q19 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q19
index bddbe61d5e3a..e723b9bf1aa1 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q19
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q19
@@ -66,37 +66,37 @@ scalar-group-by
│ ├── save-table-name: q19_project_2
│ ├── columns: column30:30(float!null)
│ ├── immutable
- │ ├── stats: [rows=269.4049, distinct(30)=269.319, null(30)=0, avgsize(30)=8]
+ │ ├── stats: [rows=185.5999, distinct(30)=185.559, null(30)=0, avgsize(30)=18]
│ ├── inner-join (hash)
│ │ ├── save-table-name: q19_inner_join_3
│ │ ├── columns: l_partkey:2(int!null) l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipinstruct:14(char!null) l_shipmode:15(char!null) p_partkey:19(int!null) p_brand:22(char!null) p_size:24(int!null) p_container:25(char!null)
│ │ ├── multiplicity: left-rows(zero-or-one), right-rows(zero-or-more)
- │ │ ├── stats: [rows=269.4049, distinct(2)=269.405, null(2)=0, avgsize(2)=4, distinct(5)=5.55556, null(5)=0, avgsize(5)=4, distinct(6)=269.302, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(14)=1, null(14)=0, avgsize(14)=4, distinct(15)=2, null(15)=0, avgsize(15)=4, distinct(19)=269.405, null(19)=0, avgsize(19)=4, distinct(22)=3, null(22)=0, avgsize(22)=4, distinct(24)=16.6667, null(24)=0, avgsize(24)=4, distinct(25)=12, null(25)=0, avgsize(25)=4, distinct(6,7)=269.319, null(6,7)=0, avgsize(6,7)=8, distinct(22,24,25)=269.405, null(22,24,25)=0, avgsize(22,24,25)=12]
+ │ │ ├── stats: [rows=185.5999, distinct(2)=185.6, null(2)=0, avgsize(2)=4, distinct(5)=5.55556, null(5)=0, avgsize(5)=9, distinct(6)=185.55, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(14)=1, null(14)=0, avgsize(14)=14, distinct(15)=2, null(15)=0, avgsize(15)=7, distinct(19)=185.6, null(19)=0, avgsize(19)=4, distinct(22)=3, null(22)=0, avgsize(22)=10, distinct(24)=16.6667, null(24)=0, avgsize(24)=2, distinct(25)=12, null(25)=0, avgsize(25)=10, distinct(6,7)=185.559, null(6,7)=0, avgsize(6,7)=18, distinct(22,24,25)=185.6, null(22,24,25)=0, avgsize(22,24,25)=22]
│ │ ├── fd: ()-->(14), (19)-->(22,24,25), (2)==(19), (19)==(2)
│ │ ├── select
│ │ │ ├── save-table-name: q19_select_4
│ │ │ ├── columns: l_partkey:2(int!null) l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipinstruct:14(char!null) l_shipmode:15(char!null)
- │ │ │ ├── stats: [rows=422702.4, distinct(2)=177164, null(2)=0, avgsize(2)=4, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=352755, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(14)=1, null(14)=0, avgsize(14)=4, distinct(15)=2, null(15)=0, avgsize(15)=4, distinct(6,7)=422702, null(6,7)=0, avgsize(6,7)=8, distinct(14,15)=2, null(14,15)=0, avgsize(14,15)=8]
- │ │ │ │ histogram(14)= 0 4.227e+05
+ │ │ │ ├── stats: [rows=416015.1, distinct(2)=176353, null(2)=0, avgsize(2)=4, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=344687, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(14)=1, null(14)=0, avgsize(14)=14, distinct(15)=2, null(15)=0, avgsize(15)=7, distinct(6,7)=416015, null(6,7)=0, avgsize(6,7)=18, distinct(14,15)=2, null(14,15)=0, avgsize(14,15)=21]
+ │ │ │ │ histogram(14)= 0 4.1602e+05
│ │ │ │ <--- 'DELIVER IN PERSON'
- │ │ │ │ histogram(15)= 0 2.1259e+05 0 2.1011e+05
+ │ │ │ │ histogram(15)= 0 2.0613e+05 0 2.0988e+05
│ │ │ │ <---- 'AIR' ----- 'AIR REG'
│ │ │ ├── fd: ()-->(14)
│ │ │ ├── scan lineitem
│ │ │ │ ├── save-table-name: q19_scan_5
│ │ │ │ ├── columns: l_partkey:2(int!null) l_quantity:5(float!null) l_extendedprice:6(float!null) l_discount:7(float!null) l_shipinstruct:14(char!null) l_shipmode:15(char!null)
- │ │ │ │ └── stats: [rows=6002293, distinct(2)=199241, null(2)=0, avgsize(2)=4, distinct(5)=50, null(5)=0, avgsize(5)=4, distinct(6)=971211, null(6)=0, avgsize(6)=4, distinct(7)=11, null(7)=0, avgsize(7)=4, distinct(14)=4, null(14)=0, avgsize(14)=4, distinct(15)=7, null(15)=0, avgsize(15)=4, distinct(6,7)=6.00229e+06, null(6,7)=0, avgsize(6,7)=8, distinct(14,15)=28, null(14,15)=0, avgsize(14,15)=8]
- │ │ │ │ histogram(2)= 0 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 28811 1200 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 1200 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 28811 1200 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 1200 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 1200 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 29411 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 29411 1200 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 29411 1200 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 600 30011 1200 29411 600 30011 600 30011 600 30011 600 30011 600
- │ │ │ │ <--- 36 ------- 1013 ------- 2065 ------- 3053 ------- 4168 ------- 5170 ------- 6301 ------- 7300 ------- 8351 ------- 9461 ------- 10582 ------- 11609 ------- 12692 ------- 13691 ------- 14777 ------- 15768 ------- 16756 ------- 17931 ------- 18965 ------- 19900 ------- 20853 ------- 21840 ------- 22742 ------- 23650 ------- 24666 ------- 25737 ------- 26843 ------- 27775 ------- 28588 ------- 29772 ------- 30781 ------- 31621 ------- 32841 ------- 33819 ------- 34990 ------- 36003 ------- 36949 ------- 37895 ------- 38980 ------- 40110 ------- 41045 ------- 41966 ------- 42956 ------- 44116 ------- 45202 ------- 45994 ------- 47035 ------- 47975 ------- 49068 ------- 49949 ------- 50863 ------- 51898 ------- 52841 ------- 53846 ------- 54862 ------- 55795 ------- 56777 ------- 57941 ------- 58797 ------- 59668 ------- 60440 ------- 61304 ------- 62198 ------- 63188 ------- 64430 ------- 65613 ------- 66627 ------- 67564 ------- 68391 ------- 69351 ------- 70423 ------- 71530 ------- 72392 ------- 73498 ------- 74561 ------- 75704 ------- 76680 ------- 77724 ------- 78786 ------- 79977 ------- 80998 ------- 82034 ------- 83077 ------- 84210 ------- 85306 ------- 86049 ------- 87167 ------- 88277 ------- 89189 ------- 90069 ------- 90967 ------- 91913 ------- 92893 ------- 93887 ------- 95083 ------- 96200 ------- 97199 ------- 98087 ------- 99058 ------- 100326 ------- 101430 ------- 102262 ------- 103278 ------- 104003 ------- 104933 ------- 105966 ------- 106826 ------- 108018 ------- 109204 ------- 110263 ------- 111212 ------- 112135 ------- 113157 ------- 114253 ------- 115075 ------- 115779 ------- 117050 ------- 118355 ------- 119422 ------- 120371 ------- 121344 ------- 122269 ------- 123210 ------- 124101 ------- 124987 ------- 125971 ------- 126883 ------- 127821 ------- 128845 ------- 129809 ------- 130642 ------- 131647 ------- 132550 ------- 133443 ------- 134599 ------- 135562 ------- 136525 ------- 137714 ------- 138491 ------- 139404 ------- 140691 ------- 141671 ------- 142456 ------- 143417 ------- 144521 ------- 145166 ------- 146211 ------- 147346 ------- 148327 ------- 149424 ------- 150333 ------- 151471 ------- 152571 ------- 153594 ------- 154570 ------- 155580 ------- 156402 ------- 157294 ------- 158395 ------- 159425 ------- 160524 ------- 161350 ------- 162405 ------- 163119 ------- 164177 ------- 164962 ------- 166161 ------- 167141 ------- 168485 ------- 169347 ------- 170368 ------- 171518 ------- 172771 ------- 173719 ------- 174797 ------- 175725 ------- 176954 ------- 177965 ------- 178807 ------- 179921 ------- 180997 ------- 181648 ------- 182761 ------- 183750 ------- 184921 ------- 185654 ------- 186640 ------- 187905 ------- 188745 ------- 189644 ------- 190659 ------- 191850 ------- 192962 ------- 194022 ------- 195210 ------- 196346 ------- 197213 ------- 198032 ------- 198936 ------- 199984
- │ │ │ │ histogram(5)= 0 1.1524e+05 5.7772e+06 1.0984e+05
- │ │ │ │ <----- 1.0 ----------------- 50.0 --
- │ │ │ │ histogram(6)= 0 600 6.0011e+06 600
- │ │ │ │ <--- 926.010009765625 ------------ 102066.5078125
- │ │ │ │ histogram(7)= 0 5.318e+05 4.9159e+06 5.5461e+05
- │ │ │ │ <----- 0.0 -------------- 0.10000000149011612
- │ │ │ │ histogram(14)= 0 1.5276e+06 2.9609e+06 1.5138e+06
- │ │ │ │ <--- 'COLLECT COD' ------------ 'TAKE BACK RETURN'
- │ │ │ │ histogram(15)= 0 8.6193e+05 4.2592e+06 8.8114e+05
+ │ │ │ │ └── stats: [rows=6001215, distinct(2)=199241, null(2)=0, avgsize(2)=4, distinct(5)=50, null(5)=0, avgsize(5)=9, distinct(6)=925955, null(6)=0, avgsize(6)=9, distinct(7)=11, null(7)=0, avgsize(7)=9, distinct(14)=4, null(14)=0, avgsize(14)=14, distinct(15)=7, null(15)=0, avgsize(15)=7, distinct(6,7)=6.00122e+06, null(6,7)=0, avgsize(6,7)=18, distinct(14,15)=28, null(14,15)=0, avgsize(14,15)=21]
+ │ │ │ │ histogram(2)= 0 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 1200 29406 600 29406 600 29406 600 29406 600 28806 1200 28806 1200 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 28806 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 1200 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 29406 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 29406 1200 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600 30006 600
+ │ │ │ │ <--- 1 ------- 1010 ------- 2021 ------- 2991 ------- 3884 ------- 5037 ------- 6245 ------- 7212 ------- 8245 ------- 9154 ------- 10259 ------- 11255 ------- 12046 ------- 13289 ------- 14181 ------- 15137 ------- 16032 ------- 17172 ------- 18410 ------- 19491 ------- 20333 ------- 21223 ------- 22309 ------- 23246 ------- 24374 ------- 25350 ------- 26537 ------- 27310 ------- 28392 ------- 29739 ------- 30950 ------- 31941 ------- 33097 ------- 33985 ------- 34802 ------- 35684 ------- 36612 ------- 37384 ------- 38411 ------- 39549 ------- 40551 ------- 41405 ------- 42339 ------- 43330 ------- 44225 ------- 45263 ------- 46110 ------- 47040 ------- 48028 ------- 48915 ------- 49799 ------- 50642 ------- 51505 ------- 52630 ------- 53961 ------- 54897 ------- 55868 ------- 56689 ------- 57415 ------- 58518 ------- 59669 ------- 60830 ------- 61995 ------- 63158 ------- 63865 ------- 64886 ------- 65607 ------- 66597 ------- 67661 ------- 68633 ------- 69805 ------- 70863 ------- 71876 ------- 73029 ------- 74162 ------- 74986 ------- 76076 ------- 76985 ------- 77776 ------- 78508 ------- 79548 ------- 80396 ------- 81456 ------- 82333 ------- 83231 ------- 84386 ------- 85300 ------- 86272 ------- 87463 ------- 88529 ------- 89522 ------- 90306 ------- 91426 ------- 92473 ------- 93517 ------- 94593 ------- 95575 ------- 96574 ------- 97504 ------- 98485 ------- 99367 ------- 100491 ------- 101417 ------- 102577 ------- 103708 ------- 104704 ------- 105507 ------- 106609 ------- 107562 ------- 108737 ------- 109864 ------- 110773 ------- 111601 ------- 112703 ------- 113643 ------- 114751 ------- 115554 ------- 116375 ------- 117312 ------- 118175 ------- 119101 ------- 120011 ------- 120960 ------- 121864 ------- 122791 ------- 123795 ------- 124770 ------- 125769 ------- 126755 ------- 127543 ------- 128685 ------- 129867 ------- 130997 ------- 131919 ------- 133103 ------- 134064 ------- 134881 ------- 135973 ------- 136848 ------- 137915 ------- 139143 ------- 140073 ------- 141060 ------- 141836 ------- 142825 ------- 143705 ------- 144771 ------- 146062 ------- 147034 ------- 147999 ------- 148876 ------- 149779 ------- 151087 ------- 152065 ------- 153127 ------- 154130 ------- 155112 ------- 156203 ------- 157156 ------- 158209 ------- 159141 ------- 160322 ------- 161399 ------- 162398 ------- 163341 ------- 164401 ------- 165792 ------- 166940 ------- 167888 ------- 168873 ------- 169587 ------- 170828 ------- 172084 ------- 172929 ------- 174080 ------- 175179 ------- 176285 ------- 177380 ------- 178290 ------- 179162 ------- 180295 ------- 181480 ------- 182534 ------- 183776 ------- 184856 ------- 185893 ------- 186994 ------- 187717 ------- 188760 ------- 189696 ------- 190738 ------- 191579 ------- 192799 ------- 193728 ------- 194863 ------- 195849 ------- 196821 ------- 197744 ------- 198749 ------- 199990
+ │ │ │ │ histogram(5)= 0 1.1342e+05 5.766e+06 1.2182e+05
+ │ │ │ │ <----- 1.0 ---------------- 50.0 --
+ │ │ │ │ histogram(6)= 0 600 6e+06 600
+ │ │ │ │ <--- 929.02 ------- 104249.0
+ │ │ │ │ histogram(7)= 0 5.4971e+05 4.9108e+06 5.4071e+05
+ │ │ │ │ <----- 0.0 ----------------- 0.1 ---
+ │ │ │ │ histogram(14)= 0 1.5093e+06 2.949e+06 1.5429e+06
+ │ │ │ │ <--- 'COLLECT COD' ----------- 'TAKE BACK RETURN'
+ │ │ │ │ histogram(15)= 0 8.3897e+05 4.2711e+06 8.9118e+05
│ │ │ │ <---- 'AIR' -------------- 'TRUCK' -
│ │ │ └── filters
│ │ │ ├── l_shipmode:15 IN ('AIR', 'AIR REG') [type=bool, outer=(15), constraints=(/15: [/'AIR' - /'AIR'] [/'AIR REG' - /'AIR REG']; tight)]
@@ -104,22 +104,22 @@ scalar-group-by
│ │ ├── select
│ │ │ ├── save-table-name: q19_select_6
│ │ │ ├── columns: p_partkey:19(int!null) p_brand:22(char!null) p_size:24(int!null) p_container:25(char!null)
- │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(22)=25, null(22)=0, avgsize(22)=4, distinct(24)=50, null(24)=0, avgsize(24)=4, distinct(25)=28, null(25)=0, avgsize(25)=4, distinct(22,24,25)=35000, null(22,24,25)=0, avgsize(22,24,25)=12]
- │ │ │ │ histogram(24)= 0 3740 1.9266e+05 3600
+ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(22)=25, null(22)=0, avgsize(22)=10, distinct(24)=50, null(24)=0, avgsize(24)=2, distinct(25)=40, null(25)=0, avgsize(25)=10, distinct(22,24,25)=50000, null(22,24,25)=0, avgsize(22,24,25)=22]
+ │ │ │ │ histogram(24)= 0 4240 1.9186e+05 3900
│ │ │ │ <--- 1 ------------- 50
│ │ │ ├── key: (19)
│ │ │ ├── fd: (19)-->(22,24,25)
│ │ │ ├── scan part
│ │ │ │ ├── save-table-name: q19_scan_7
│ │ │ │ ├── columns: p_partkey:19(int!null) p_brand:22(char!null) p_size:24(int!null) p_container:25(char!null)
- │ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(22)=25, null(22)=0, avgsize(22)=4, distinct(24)=50, null(24)=0, avgsize(24)=4, distinct(25)=28, null(25)=0, avgsize(25)=4, distinct(22,24,25)=35000, null(22,24,25)=0, avgsize(22,24,25)=12]
- │ │ │ │ │ histogram(19)= 0 0 0 3.9981 1014.5 3.9981 1043.5 3.9981 946.55 3.9981 1105.5 3.9981 1017.5 3.9981 1020.5 3.9981 880.58 3.9981 954.55 3.9981 883.58 3.9981 933.56 3.9981 891.58 3.9981 1085.5 3.9981 1045.5 3.9981 1134.5 3.9981 1008.5 3.9981 1099.5 3.9981 941.55 3.9981 988.53 3.9981 1003.5 3.9981 894.58 3.9981 975.54 3.9981 1141.5 3.9981 990.53 3.9981 1008.5 3.9981 1074.5 3.9981 966.54 3.9981 994.53 3.9981 906.57 3.9981 1089.5 3.9981 922.56 3.9981 1010.5 3.9981 882.58 3.9981 971.54 3.9981 862.59 3.9981 972.54 3.9981 925.56 3.9981 1156.5 3.9981 1097.5 3.9981 972.54 3.9981 983.53 3.9981 1005.5 3.9981 1048.5 3.9981 1084.5 3.9981 898.57 3.9981 900.57 3.9981 1289.4 3.9981 864.59 3.9981 940.55 3.9981 968.54 3.9981 949.55 3.9981 1023.5 3.9981 865.59 3.9981 1019.5 3.9981 1051.5 3.9981 945.55 3.9981 930.56 3.9981 1086.5 3.9981 1108.5 3.9981 1102.5 3.9981 981.53 3.9981 967.54 3.9981 968.54 3.9981 1045.5 3.9981 829.61 3.9981 1082.5 3.9981 1100.5 3.9981 1007.5 3.9981 1041.5 3.9981 1044.5 3.9981 874.58 3.9981 1075.5 3.9981 1091.5 3.9981 923.56 3.9981 1049.5 3.9981 1064.5 3.9981 1056.5 3.9981 864.59 3.9981 1094.5 3.9981 921.56 3.9981 941.55 3.9981 1055.5 3.9981 1044.5 3.9981 939.55 3.9981 918.56 3.9981 1042.5 3.9981 901.57 3.9981 1003.5 3.9981 1177.4 3.9981 928.56 3.9981 1067.5 3.9981 987.53 3.9981 874.58 3.9981 912.57 3.9981 832.6 3.9981 953.55 3.9981 1078.5 3.9981 886.58 3.9981 894.58 3.9981 938.55 3.9981 987.53 3.9981 985.53 3.9981 1002.5 3.9981 1042.5 3.9981 1274.4 3.9981 1056.5 3.9981 953.55 3.9981 970.54 3.9981 1032.5 3.9981 967.54 3.9981 968.54 3.9981 937.55 3.9981 1130.5 3.9981 918.56 3.9981 904.57 3.9981 957.55 3.9981 1235.4 3.9981 1105.5 3.9981 1009.5 3.9981 1047.5 3.9981 950.55 3.9981 1022.5 3.9981 1069.5 3.9981 1005.5 3.9981 1118.5 3.9981 828.61 3.9981 1119.5 3.9981 842.6 3.9981 995.53 3.9981 983.53 3.9981 921.56 3.9981 1135.5 3.9981 1136.5 3.9981 972.54 3.9981 1125.5 3.9981 887.58 3.9981 1000.5 3.9981 1009.5 3.9981 987.53 3.9981 1066.5 3.9981 947.55 3.9981 991.53 3.9981 1025.5 3.9981 1119.5 3.9981 1020.5 3.9981 1034.5 3.9981 980.53 3.9981 895.57 3.9981 921.56 3.9981 964.54 3.9981 1014.5 3.9981 946.55 3.9981 1039.5 3.9981 1014.5 3.9981 953.55 3.9981 961.54 3.9981 936.56 3.9981 925.56 3.9981 951.55 3.9981 1036.5 3.9981 1020.5 3.9981 1033.5 3.9981 1004.5 3.9981 1053.5 3.9981 1009.5 3.9981 1094.5 3.9981 976.54 3.9981 1012.5 3.9981 1021.5 3.9981 1015.5 3.9981 919.56 3.9981 1078.5 3.9981 1038.5 3.9981 991.53 3.9981 930.56 3.9981 1064.5 3.9981 960.54 3.9981 1011.5 3.9981 970.54 3.9981 1103.5 3.9981 999.53 3.9981 1038.5 3.9981 1108.5 3.9981 1007.5 3.9981 1263.4 3.9981 861.59 3.9981 1009.5 3.9981 917.56 3.9981 1099.5 3.9981 1027.5 3.9981 1008.5 3.9981 983.53 3.9981 1010.5 3.9981 1067.5 3.9981 931.56 3.9981 984.53 3.9981 874.58 3.9981 1002.5 3.9981 954.55 3.9981 1040.5 3.9981 0 0
- │ │ │ │ │ <--- -9223372036854775808 ---- 28 --------- 1067 -------- 2159 -------- 3071 -------- 4270 -------- 5315 -------- 6366 -------- 7145 -------- 8073 -------- 8858 -------- 9745 -------- 10547 -------- 11712 -------- 12807 -------- 14056 -------- 15084 -------- 16273 -------- 17176 -------- 18168 -------- 19188 -------- 19996 -------- 20964 -------- 22225 -------- 23220 -------- 24249 -------- 25395 -------- 26346 -------- 27348 -------- 28181 -------- 29353 -------- 30217 -------- 31249 -------- 32031 -------- 32991 -------- 33729 -------- 34691 -------- 35561 -------- 36846 -------- 38031 -------- 38993 -------- 39976 -------- 40999 -------- 42099 -------- 43263 -------- 44078 -------- 44899 -------- 46401 -------- 47145 -------- 48046 -------- 49001 -------- 49918 -------- 50973 -------- 51718 -------- 52766 -------- 53872 -------- 54782 -------- 55662 -------- 56828 -------- 58033 -------- 59228 -------- 60207 -------- 61159 -------- 62113 -------- 63208 -------- 63870 -------- 65030 -------- 66220 -------- 67247 -------- 68334 -------- 69427 -------- 70192 -------- 71340 -------- 72515 -------- 73382 -------- 74484 -------- 75612 -------- 76726 -------- 77468 -------- 78648 -------- 79510 -------- 80412 -------- 81524 -------- 82617 -------- 83516 -------- 84373 -------- 85462 -------- 86284 -------- 87304 -------- 88625 -------- 89501 -------- 90635 -------- 91625 -------- 92391 -------- 93235 ------- 93905 -------- 94831 -------- 95983 -------- 96773 -------- 97580 -------- 98477 -------- 99466 -------- 100452 -------- 101470 -------- 102560 -------- 104039 -------- 105153 -------- 106078 -------- 107035 -------- 108107 -------- 109059 -------- 110014 -------- 110909 -------- 112151 -------- 113007 -------- 113835 -------- 114769 -------- 116184 -------- 117384 -------- 118415 -------- 119514 -------- 120434 -------- 121488 -------- 122626 -------- 123649 -------- 124870 -------- 125529 -------- 126753 ------- 127446 -------- 128450 -------- 129432 -------- 130295 -------- 131545 -------- 132797 -------- 133758 -------- 134991 -------- 135784 -------- 136797 -------- 137828 -------- 138817 -------- 139949 -------- 140862 -------- 141860 -------- 142919 -------- 144143 -------- 145194 -------- 146269 -------- 147245 -------- 148054 -------- 148917 -------- 149863 -------- 150902 -------- 151794 -------- 152862 -------- 153885 -------- 154792 -------- 155714 -------- 156586 -------- 157436 -------- 158338 -------- 159401 -------- 160434 -------- 161492 -------- 162496 -------- 163589 -------- 164603 -------- 165768 -------- 166719 -------- 167738 -------- 168773 -------- 169798 -------- 170636 -------- 171773 -------- 172839 -------- 173818 -------- 174678 -------- 175791 -------- 176712 -------- 177729 -------- 178668 -------- 179849 -------- 180844 -------- 181911 -------- 183101 -------- 184110 -------- 185558 -------- 186269 -------- 187282 -------- 188116 -------- 189290 -------- 190336 -------- 191348 -------- 192312 -------- 193328 -------- 194446 -------- 195308 -------- 196274 -------- 197016 -------- 198016 -------- 198924 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ histogram(22)= 0 8840 1.8262e+05 8540
- │ │ │ │ │ <--- 'Brand#11' ------------ 'Brand#55'
- │ │ │ │ │ histogram(24)= 0 3740 1.9266e+05 3600
+ │ │ │ │ ├── stats: [rows=200000, distinct(19)=199241, null(19)=0, avgsize(19)=4, distinct(22)=25, null(22)=0, avgsize(22)=10, distinct(24)=50, null(24)=0, avgsize(24)=2, distinct(25)=40, null(25)=0, avgsize(25)=10, distinct(22,24,25)=50000, null(22,24,25)=0, avgsize(22,24,25)=22]
+ │ │ │ │ │ histogram(19)= 0 3.9982 929.57 3.9982 1135.5 3.9982 923.58 3.9982 1036.5 3.9982 964.56 3.9982 953.56 3.9982 899.59 3.9982 1152.5 3.9982 1118.5 3.9982 1137.5 3.9982 1129.5 3.9982 1136.5 3.9982 983.55 3.9982 983.55 3.9982 1028.5 3.9982 1007.5 3.9982 1036.5 3.9982 884.59 3.9982 985.55 3.9982 970.55 3.9982 1036.5 3.9982 943.57 3.9982 1020.5 3.9982 1001.5 3.9982 1001.5 3.9982 954.56 3.9982 1036.5 3.9982 990.54 3.9982 928.57 3.9982 1010.5 3.9982 892.59 3.9982 960.56 3.9982 1059.5 3.9982 947.56 3.9982 906.58 3.9982 935.57 3.9982 860.6 3.9982 971.55 3.9982 1067.5 3.9982 994.54 3.9982 961.56 3.9982 943.57 3.9982 901.59 3.9982 972.55 3.9982 956.56 3.9982 1106.5 3.9982 1152.5 3.9982 967.55 3.9982 943.57 3.9982 916.58 3.9982 1076.5 3.9982 933.57 3.9982 1108.5 3.9982 1081.5 3.9982 975.55 3.9982 1021.5 3.9982 1034.5 3.9982 905.58 3.9982 902.58 3.9982 966.56 3.9982 1080.5 3.9982 927.57 3.9982 936.57 3.9982 1008.5 3.9982 1033.5 3.9982 903.58 3.9982 944.57 3.9982 908.58 3.9982 1008.5 3.9982 1059.5 3.9982 1079.5 3.9982 911.58 3.9982 1107.5 3.9982 992.54 3.9982 975.55 3.9982 1156.5 3.9982 1042.5 3.9982 1072.5 3.9982 916.58 3.9982 1022.5 3.9982 999.54 3.9982 966.56 3.9982 936.57 3.9982 934.57 3.9982 969.55 3.9982 1136.5 3.9982 997.54 3.9982 991.54 3.9982 1002.5 3.9982 1047.5 3.9982 1059.5 3.9982 972.55 3.9982 918.58 3.9982 959.56 3.9982 1083.5 3.9982 934.57 3.9982 900.59 3.9982 970.55 3.9982 952.56 3.9982 1063.5 3.9982 870.6 3.9982 958.56 3.9982 1029.5 3.9982 943.57 3.9982 872.6 3.9982 972.55 3.9982 1009.5 3.9982 875.6 3.9982 1127.5 3.9982 987.55 3.9982 1156.5 3.9982 971.55 3.9982 1155.5 3.9982 930.57 3.9982 1051.5 3.9982 1044.5 3.9982 867.6 3.9982 898.59 3.9982 926.57 3.9982 965.56 3.9982 1027.5 3.9982 993.54 3.9982 927.57 3.9982 973.55 3.9982 934.57 3.9982 951.56 3.9982 1007.5 3.9982 1124.5 3.9982 936.57 3.9982 1050.5 3.9982 1075.5 3.9982 1028.5 3.9982 872.6 3.9982 960.56 3.9982 1014.5 3.9982 1017.5 3.9982 860.6 3.9982 1039.5 3.9982 1059.5 3.9982 921.58 3.9982 936.57 3.9982 1024.5 3.9982 970.55 3.9982 1047.5 3.9982 917.58 3.9982 948.56 3.9982 978.55 3.9982 993.54 3.9982 1121.5 3.9982 944.57 3.9982 1005.5 3.9982 1037.5 3.9982 1261.4 3.9982 1062.5 3.9982 925.57 3.9982 976.55 3.9982 892.59 3.9982 972.55 3.9982 1135.5 3.9982 1044.5 3.9982 959.56 3.9982 990.54 3.9982 993.54 3.9982 1130.5 3.9982 919.58 3.9982 1025.5 3.9982 1001.5 3.9982 974.55 3.9982 1061.5 3.9982 1166.5 3.9982 1017.5 3.9982 1063.5 3.9982 1188.5 3.9982 964.56 3.9982 1047.5 3.9982 1210.4 3.9982 1087.5 3.9982 1151.5 3.9982 1096.5 3.9982 957.56 3.9982 1073.5 3.9982 925.57 3.9982 1051.5 3.9982 930.57 3.9982 1005.5 3.9982 977.55 3.9982 963.56 3.9982 1005.5 3.9982 954.56 3.9982 1025.5 3.9982 1039.5 3.9982 985.55 3.9982 923.58 3.9982 1087.5 3.9982 958.56 3.9982 1066.5 3.9982 1110.5 3.9982 934.57 3.9982 946.56 3.9982
+ │ │ │ │ │ <---- 23 --------- 901 --------- 2150 -------- 3016 -------- 4093 -------- 5038 -------- 5962 -------- 6778 -------- 8056 -------- 9277 -------- 10530 -------- 11769 -------- 13020 -------- 14001 -------- 14982 -------- 16046 -------- 17072 -------- 18149 -------- 18935 -------- 19920 -------- 20876 -------- 21953 -------- 22859 -------- 23908 -------- 24923 -------- 25938 -------- 26865 -------- 27943 -------- 28938 -------- 29813 -------- 30844 -------- 31647 -------- 32585 -------- 33704 -------- 34617 -------- 35448 -------- 36338 ------- 37071 -------- 38029 -------- 39162 -------- 40163 -------- 41103 -------- 42008 -------- 42828 -------- 43789 -------- 44720 -------- 45920 -------- 47197 -------- 48149 -------- 49054 -------- 49906 -------- 51054 -------- 51940 -------- 53144 -------- 54301 -------- 55267 -------- 56318 -------- 57393 -------- 58223 -------- 59046 -------- 59995 -------- 61150 -------- 62024 -------- 62915 -------- 63943 -------- 65015 -------- 65840 -------- 66748 -------- 67584 -------- 68611 -------- 69729 -------- 70883 -------- 71725 -------- 72926 -------- 73924 -------- 74891 -------- 76176 -------- 77264 -------- 78405 -------- 79257 -------- 80310 -------- 81321 -------- 82270 -------- 83162 -------- 84049 -------- 85004 -------- 86255 -------- 87262 -------- 88259 -------- 89276 -------- 90374 -------- 91493 -------- 92454 -------- 93310 -------- 94246 -------- 95407 -------- 96295 -------- 97113 -------- 98069 -------- 98991 -------- 100116 ------- 100871 -------- 101805 -------- 102871 -------- 103776 ------- 104536 -------- 105497 -------- 106526 ------- 107293 -------- 108529 -------- 109518 -------- 110802 -------- 111761 -------- 113044 -------- 113923 -------- 115027 -------- 116119 ------- 116867 -------- 117681 -------- 118553 -------- 119501 -------- 120563 -------- 121563 -------- 122437 -------- 123400 -------- 124288 -------- 125209 -------- 126234 -------- 127465 -------- 128356 -------- 129458 -------- 130604 -------- 131668 ------- 132428 -------- 133365 -------- 134403 -------- 135446 ------- 136179 -------- 137262 -------- 138380 -------- 139242 -------- 140134 -------- 141190 -------- 142146 -------- 143244 -------- 144097 -------- 145011 -------- 145982 -------- 146981 -------- 148207 -------- 149115 -------- 150119 -------- 151183 -------- 152627 -------- 153735 -------- 154585 -------- 155535 -------- 156315 -------- 157258 -------- 158494 -------- 159570 -------- 160487 -------- 161464 -------- 162446 -------- 163673 -------- 164509 -------- 165550 -------- 166548 -------- 167495 -------- 168601 -------- 169889 -------- 170916 -------- 172026 -------- 173351 -------- 174278 -------- 175359 -------- 176720 -------- 177872 -------- 179135 -------- 180304 -------- 181217 -------- 182345 -------- 183194 -------- 184282 -------- 185142 -------- 186147 -------- 187099 -------- 188024 -------- 189029 -------- 189936 -------- 190977 -------- 192044 -------- 193012 -------- 193858 -------- 195011 -------- 195927 -------- 197043 -------- 198236 -------- 199104 -------- 199995
+ │ │ │ │ │ histogram(22)= 0 7640 1.843e+05 8060
+ │ │ │ │ │ <--- 'Brand#11' ----------- 'Brand#55'
+ │ │ │ │ │ histogram(24)= 0 4240 1.9186e+05 3900
│ │ │ │ │ <--- 1 ------------- 50
- │ │ │ │ │ histogram(25)= 0 6480 1.8602e+05 7500
+ │ │ │ │ │ histogram(25)= 0 5460 1.8978e+05 4760
│ │ │ │ │ <--- 'JUMBO BAG' ------------ 'WRAP PKG'
│ │ │ │ ├── key: (19)
│ │ │ │ └── fd: (19)-->(22,24,25)
@@ -146,7 +146,7 @@ column_names row_count distinct_count null_count
{column30} 121 121 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{column30} 269.00 2.22 <== 269.00 2.22 <== 0.00 1.00
+{column30} 186.00 1.54 186.00 1.54 0.00 1.00
----Stats for q19_inner_join_3----
column_names row_count distinct_count null_count
@@ -162,16 +162,16 @@ column_names row_count distinct_count null_count
{p_size} 121 14 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 269.00 2.22 <== 11.00 1.00 0.00 1.00
-{l_extendedprice} 269.00 2.22 <== 269.00 2.28 <== 0.00 1.00
-{l_partkey} 269.00 2.22 <== 269.00 2.61 <== 0.00 1.00
-{l_quantity} 269.00 2.22 <== 6.00 4.83 <== 0.00 1.00
-{l_shipinstruct} 269.00 2.22 <== 1.00 1.00 0.00 1.00
-{l_shipmode} 269.00 2.22 <== 2.00 2.00 <== 0.00 1.00
-{p_brand} 269.00 2.22 <== 3.00 1.00 0.00 1.00
-{p_container} 269.00 2.22 <== 12.00 1.00 0.00 1.00
-{p_partkey} 269.00 2.22 <== 269.00 2.61 <== 0.00 1.00
-{p_size} 269.00 2.22 <== 17.00 1.21 0.00 1.00
+{l_discount} 186.00 1.54 11.00 1.00 0.00 1.00
+{l_extendedprice} 186.00 1.54 186.00 1.58 0.00 1.00
+{l_partkey} 186.00 1.54 186.00 1.81 0.00 1.00
+{l_quantity} 186.00 1.54 6.00 4.83 <== 0.00 1.00
+{l_shipinstruct} 186.00 1.54 1.00 1.00 0.00 1.00
+{l_shipmode} 186.00 1.54 2.00 2.00 <== 0.00 1.00
+{p_brand} 186.00 1.54 3.00 1.00 0.00 1.00
+{p_container} 186.00 1.54 12.00 1.00 0.00 1.00
+{p_partkey} 186.00 1.54 186.00 1.81 0.00 1.00
+{p_size} 186.00 1.54 17.00 1.21 0.00 1.00
----Stats for q19_select_4----
column_names row_count distinct_count null_count
@@ -183,12 +183,12 @@ column_names row_count distinct_count null_count
{l_shipmode} 214377 1 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 422702.00 1.97 <== 11.00 1.00 0.00 1.00
-{l_extendedprice} 422702.00 1.97 <== 352755.00 1.87 0.00 1.00
-{l_partkey} 422702.00 1.97 <== 177164.00 1.35 0.00 1.00
-{l_quantity} 422702.00 1.97 <== 50.00 1.00 0.00 1.00
-{l_shipinstruct} 422702.00 1.97 <== 1.00 1.00 0.00 1.00
-{l_shipmode} 422702.00 1.97 <== 2.00 2.00 <== 0.00 1.00
+{l_discount} 416015.00 1.94 <== 11.00 1.00 0.00 1.00
+{l_extendedprice} 416015.00 1.94 <== 344687.00 1.82 0.00 1.00
+{l_partkey} 416015.00 1.94 <== 176353.00 1.34 0.00 1.00
+{l_quantity} 416015.00 1.94 <== 50.00 1.00 0.00 1.00
+{l_shipinstruct} 416015.00 1.94 <== 1.00 1.00 0.00 1.00
+{l_shipmode} 416015.00 1.94 <== 2.00 2.00 <== 0.00 1.00
----Stats for q19_scan_5----
column_names row_count distinct_count null_count
@@ -200,12 +200,12 @@ column_names row_count distinct_count null_count
{l_shipmode} 6001215 7 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_discount} 6002293.00 1.00 11.00 1.00 0.00 1.00
-{l_extendedprice} 6002293.00 1.00 971211.00 1.05 0.00 1.00
-{l_partkey} 6002293.00 1.00 199241.00 1.00 0.00 1.00
-{l_quantity} 6002293.00 1.00 50.00 1.00 0.00 1.00
-{l_shipinstruct} 6002293.00 1.00 4.00 1.00 0.00 1.00
-{l_shipmode} 6002293.00 1.00 7.00 1.00 0.00 1.00
+{l_discount} 6001215.00 1.00 11.00 1.00 0.00 1.00
+{l_extendedprice} 6001215.00 1.00 925955.00 1.00 0.00 1.00
+{l_partkey} 6001215.00 1.00 199241.00 1.00 0.00 1.00
+{l_quantity} 6001215.00 1.00 50.00 1.00 0.00 1.00
+{l_shipinstruct} 6001215.00 1.00 4.00 1.00 0.00 1.00
+{l_shipmode} 6001215.00 1.00 7.00 1.00 0.00 1.00
----Stats for q19_select_6----
column_names row_count distinct_count null_count
@@ -216,7 +216,7 @@ column_names row_count distinct_count null_count
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{p_brand} 200000.00 1.00 25.00 1.00 0.00 1.00
-{p_container} 200000.00 1.00 28.00 1.43 0.00 1.00
+{p_container} 200000.00 1.00 40.00 1.00 0.00 1.00
{p_partkey} 200000.00 1.00 199241.00 1.00 0.00 1.00
{p_size} 200000.00 1.00 50.00 1.00 0.00 1.00
@@ -229,7 +229,7 @@ column_names row_count distinct_count null_count
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
{p_brand} 200000.00 1.00 25.00 1.00 0.00 1.00
-{p_container} 200000.00 1.00 28.00 1.43 0.00 1.00
+{p_container} 200000.00 1.00 40.00 1.00 0.00 1.00
{p_partkey} 200000.00 1.00 199241.00 1.00 0.00 1.00
{p_size} 200000.00 1.00 50.00 1.00 0.00 1.00
----
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q20 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q20
index 2b8ce3bf150d..88a258048fc2 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q20
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q20
@@ -62,27 +62,27 @@ sort
├── save-table-name: q20_sort_1
├── columns: s_name:2(char!null) s_address:3(varchar!null)
├── immutable
- ├── stats: [rows=2.016129e-05, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=4, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=4]
+ ├── stats: [rows=2.016129e-05, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=20, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=27]
├── ordering: +2
└── project
├── save-table-name: q20_project_2
├── columns: s_name:2(char!null) s_address:3(varchar!null)
├── immutable
- ├── stats: [rows=2.016129e-05, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=4, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=4]
+ ├── stats: [rows=2.016129e-05, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=20, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=27]
└── inner-join (lookup nation)
├── save-table-name: q20_lookup_join_3
├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_address:3(varchar!null) s_nationkey:4(int!null) n_nationkey:10(int!null) n_name:11(char!null)
├── key columns: [4] = [10]
├── lookup columns are key
├── immutable
- ├── stats: [rows=2.016129e-05, distinct(1)=2e-05, null(1)=0, avgsize(1)=4, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=4, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=4, distinct(4)=2.01613e-05, null(4)=0, avgsize(4)=4, distinct(10)=2.01613e-05, null(10)=0, avgsize(10)=4, distinct(11)=2.01613e-05, null(11)=0, avgsize(11)=4]
+ ├── stats: [rows=2.016129e-05, distinct(1)=2e-05, null(1)=0, avgsize(1)=3, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=20, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=27, distinct(4)=2.01613e-05, null(4)=0, avgsize(4)=2, distinct(10)=2.01613e-05, null(10)=0, avgsize(10)=1, distinct(11)=2.01613e-05, null(11)=0, avgsize(11)=10]
├── key: (1)
├── fd: ()-->(11), (1)-->(2-4), (4)==(10), (10)==(4)
├── project
│ ├── save-table-name: q20_project_4
│ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_address:3(varchar!null) s_nationkey:4(int!null)
│ ├── immutable
- │ ├── stats: [rows=2.016129e-05, distinct(1)=2e-05, null(1)=0, avgsize(1)=4, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=4, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=4, distinct(4)=2.01613e-05, null(4)=0, avgsize(4)=4]
+ │ ├── stats: [rows=2.016129e-05, distinct(1)=2e-05, null(1)=0, avgsize(1)=3, distinct(2)=2.01613e-05, null(2)=0, avgsize(2)=20, distinct(3)=2.01613e-05, null(3)=0, avgsize(3)=27, distinct(4)=2.01613e-05, null(4)=0, avgsize(4)=2]
│ ├── key: (1)
│ ├── fd: (1)-->(2-4)
│ └── inner-join (lookup supplier)
@@ -91,7 +91,7 @@ sort
│ ├── key columns: [17] = [1]
│ ├── lookup columns are key
│ ├── immutable
- │ ├── stats: [rows=0.2, distinct(1)=2e-05, null(1)=0, avgsize(1)=4, distinct(2)=0.2, null(2)=0, avgsize(2)=4, distinct(3)=0.2, null(3)=0, avgsize(3)=4, distinct(4)=0.2, null(4)=0, avgsize(4)=4, distinct(17)=2e-05, null(17)=0, avgsize(17)=4]
+ │ ├── stats: [rows=0.2, distinct(1)=2e-05, null(1)=0, avgsize(1)=3, distinct(2)=0.2, null(2)=0, avgsize(2)=20, distinct(3)=0.2, null(3)=0, avgsize(3)=27, distinct(4)=0.2, null(4)=0, avgsize(4)=2, distinct(17)=2e-05, null(17)=0, avgsize(17)=3]
│ ├── key: (17)
│ ├── fd: (1)-->(2-4), (1)==(17), (17)==(1)
│ ├── distinct-on
@@ -99,7 +99,7 @@ sort
│ │ ├── columns: ps_suppkey:17(int!null)
│ │ ├── grouping columns: ps_suppkey:17(int!null)
│ │ ├── immutable
- │ │ ├── stats: [rows=2e-05, distinct(17)=2e-05, null(17)=0, avgsize(17)=4]
+ │ │ ├── stats: [rows=2e-05, distinct(17)=2e-05, null(17)=0, avgsize(17)=3]
│ │ ├── key: (17)
│ │ └── inner-join (lookup part)
│ │ ├── save-table-name: q20_lookup_join_7
@@ -107,58 +107,58 @@ sort
│ │ ├── key columns: [16] = [23]
│ │ ├── lookup columns are key
│ │ ├── immutable
- │ │ ├── stats: [rows=0.002551704, distinct(16)=2e-05, null(16)=0, avgsize(16)=4, distinct(17)=0.0025517, null(17)=0, avgsize(17)=4, distinct(18)=0.0025517, null(18)=0, avgsize(18)=8, distinct(23)=2e-05, null(23)=0, avgsize(23)=4, distinct(24)=2e-05, null(24)=0, avgsize(24)=4, distinct(52)=0.0025517, null(52)=0, avgsize(52)=8]
+ │ │ ├── stats: [rows=0.002495459, distinct(16)=2e-05, null(16)=0, avgsize(16)=4, distinct(17)=0.00249546, null(17)=0, avgsize(17)=3, distinct(18)=0.00249546, null(18)=0, avgsize(18)=7, distinct(23)=2e-05, null(23)=0, avgsize(23)=4, distinct(24)=7.51679e-09, null(24)=0, avgsize(24)=35, distinct(52)=0.00249546, null(52)=0, avgsize(52)=7]
│ │ ├── key: (17,23)
│ │ ├── fd: (16,17)-->(18,52), (23)-->(24), (16)==(23), (23)==(16)
│ │ ├── select
│ │ │ ├── save-table-name: q20_select_8
│ │ │ ├── columns: ps_partkey:16(int!null) ps_suppkey:17(int!null) ps_availqty:18(int!null) sum:52(float!null)
│ │ │ ├── immutable
- │ │ │ ├── stats: [rows=127.5852, distinct(16)=127.585, null(16)=0, avgsize(16)=4, distinct(17)=127.585, null(17)=0, avgsize(17)=4, distinct(18)=127.585, null(18)=0, avgsize(18)=8, distinct(52)=127.585, null(52)=0, avgsize(52)=8]
+ │ │ │ ├── stats: [rows=124.773, distinct(16)=124.773, null(16)=0, avgsize(16)=4, distinct(17)=124.773, null(17)=0, avgsize(17)=3, distinct(18)=124.773, null(18)=0, avgsize(18)=7, distinct(52)=124.773, null(52)=0, avgsize(52)=7]
│ │ │ ├── key: (16,17)
│ │ │ ├── fd: (16,17)-->(18,52)
│ │ │ ├── group-by (hash)
│ │ │ │ ├── save-table-name: q20_group_by_9
│ │ │ │ ├── columns: ps_partkey:16(int!null) ps_suppkey:17(int!null) ps_availqty:18(int!null) sum:52(float!null)
│ │ │ │ ├── grouping columns: ps_partkey:16(int!null) ps_suppkey:17(int!null)
- │ │ │ │ ├── stats: [rows=382.7556, distinct(16)=382.756, null(16)=0, avgsize(16)=4, distinct(17)=382.756, null(17)=0, avgsize(17)=4, distinct(18)=382.756, null(18)=0, avgsize(18)=8, distinct(52)=382.756, null(52)=0, avgsize(52)=8, distinct(16,17)=382.756, null(16,17)=0, avgsize(16,17)=8]
+ │ │ │ │ ├── stats: [rows=374.3189, distinct(16)=374.319, null(16)=0, avgsize(16)=4, distinct(17)=374.319, null(17)=0, avgsize(17)=3, distinct(18)=374.319, null(18)=0, avgsize(18)=7, distinct(52)=374.319, null(52)=0, avgsize(52)=7, distinct(16,17)=374.319, null(16,17)=0, avgsize(16,17)=7]
│ │ │ │ ├── key: (16,17)
│ │ │ │ ├── fd: (16,17)-->(18,52)
│ │ │ │ ├── inner-join (hash)
│ │ │ │ │ ├── save-table-name: q20_inner_join_10
│ │ │ │ │ ├── columns: ps_partkey:16(int!null) ps_suppkey:17(int!null) ps_availqty:18(int!null) l_partkey:35(int!null) l_suppkey:36(int!null) l_quantity:38(float!null) l_shipdate:44(date!null)
│ │ │ │ │ ├── multiplicity: left-rows(exactly-one), right-rows(zero-or-more)
- │ │ │ │ │ ├── stats: [rows=382.7556, distinct(16)=382.756, null(16)=0, avgsize(16)=4, distinct(17)=382.756, null(17)=0, avgsize(17)=4, distinct(18)=375.466, null(18)=0, avgsize(18)=4, distinct(35)=382.756, null(35)=0, avgsize(35)=4, distinct(36)=382.756, null(36)=0, avgsize(36)=4, distinct(38)=49.9763, null(38)=0, avgsize(38)=4, distinct(44)=237.1, null(44)=0, avgsize(44)=4, distinct(16,17)=382.756, null(16,17)=0, avgsize(16,17)=8]
+ │ │ │ │ │ ├── stats: [rows=374.3189, distinct(16)=374.319, null(16)=0, avgsize(16)=4, distinct(17)=374.319, null(17)=0, avgsize(17)=3, distinct(18)=367.345, null(18)=0, avgsize(18)=4, distinct(35)=374.319, null(35)=0, avgsize(35)=4, distinct(36)=374.319, null(36)=0, avgsize(36)=4, distinct(38)=49.972, null(38)=0, avgsize(38)=9, distinct(44)=234.109, null(44)=0, avgsize(44)=4, distinct(16,17)=374.319, null(16,17)=0, avgsize(16,17)=7]
│ │ │ │ │ ├── fd: (16,17)-->(18), (16)==(35), (35)==(16), (17)==(36), (36)==(17)
│ │ │ │ │ ├── index-join lineitem
│ │ │ │ │ │ ├── save-table-name: q20_index_join_11
│ │ │ │ │ │ ├── columns: l_partkey:35(int!null) l_suppkey:36(int!null) l_quantity:38(float!null) l_shipdate:44(date!null)
- │ │ │ │ │ │ ├── stats: [rows=945631.6, distinct(35)=198102, null(35)=0, avgsize(35)=4, distinct(36)=9920, null(36)=0, avgsize(36)=4, distinct(38)=50, null(38)=0, avgsize(38)=4, distinct(44)=365, null(44)=0, avgsize(44)=4]
- │ │ │ │ │ │ │ histogram(44)= 0 4202 26410 3001 27010 3001 28811 3001 28211 4802 28811 1200 28811 3001 28211 1801 27610 3001 27010 3001 28211 3001 28211 1200 27610 3601 28811 2401 27610 3601 28211 1801 28811 1200 27010 4202 27010 3601 27010 3601 26410 3601 27610 2401 28211 4202 27010 3601 25810 3601 28811 3601 28811 2401 27010 3001 28211 2401 28211 2401 28211 2401 17570 2510
- │ │ │ │ │ │ │ <--- '1994-01-01' ------- '1994-01-11' ------- '1994-01-22' ------- '1994-02-05' ------- '1994-02-18' ------- '1994-03-01' ------- '1994-03-13' ------- '1994-03-26' ------- '1994-04-06' ------- '1994-04-17' ------- '1994-04-27' ------- '1994-05-10' ------- '1994-05-21' ------- '1994-06-03' ------- '1994-06-17' ------- '1994-06-27' ------- '1994-07-13' ------- '1994-07-27' ------- '1994-08-06' ------- '1994-08-19' ------- '1994-08-30' ------- '1994-09-11' ------- '1994-09-21' ------- '1994-10-03' ------- '1994-10-13' ------- '1994-10-26' ------- '1994-11-08' ------- '1994-11-19' ------- '1994-12-01' ------- '1994-12-13' ------- '1994-12-23' ------- '1994-12-31'
+ │ │ │ │ │ │ ├── stats: [rows=924787.9, distinct(35)=197952, null(35)=0, avgsize(35)=4, distinct(36)=9920, null(36)=0, avgsize(36)=4, distinct(38)=50, null(38)=0, avgsize(38)=9, distinct(44)=365, null(44)=0, avgsize(44)=4]
+ │ │ │ │ │ │ │ histogram(44)= 0 0 12002 1800 27606 4201 27005 5401 28806 3001 27606 2400 24005 5401 24605 5401 28206 3601 26405 3001 27005 2400 28806 3601 28206 1800 28806 2400 28806 1800 28206 1800 27606 3601 28206 3001 26405 3001 28206 1200 28206 2400 28806 1200 27606 3001 24605 5401 28806 1800 25805 3601 27005 2400 28806 1800 28806 600 28806 600 27606 3601 26326 1880.4
+ │ │ │ │ │ │ │ <--- '1993-12-31' ------- '1994-01-06' ------- '1994-01-20' ------- '1994-02-01' ------- '1994-02-14' ------- '1994-02-25' ------- '1994-03-11' ------- '1994-03-24' ------- '1994-04-07' ------- '1994-04-19' ------- '1994-05-03' ------- '1994-05-14' ------- '1994-05-24' ------- '1994-06-04' ------- '1994-06-14' ------- '1994-06-26' ------- '1994-07-06' ------- '1994-07-17' ------- '1994-08-01' ------- '1994-08-11' ------- '1994-08-25' ------- '1994-09-05' ------- '1994-09-16' ------- '1994-09-26' ------- '1994-10-07' ------- '1994-10-17' ------- '1994-10-27' ------- '1994-11-09' ------- '1994-11-22' ------- '1994-12-04' ------- '1994-12-16' ------- '1994-12-31'
│ │ │ │ │ │ └── scan lineitem@l_sd
│ │ │ │ │ │ ├── save-table-name: q20_scan_12
│ │ │ │ │ │ ├── columns: l_orderkey:34(int!null) l_linenumber:37(int!null) l_shipdate:44(date!null)
│ │ │ │ │ │ ├── constraint: /44/34/37: [/'1994-01-01' - /'1994-12-31']
- │ │ │ │ │ │ ├── stats: [rows=945631.6, distinct(34)=748681, null(34)=0, avgsize(34)=4, distinct(37)=7, null(37)=0, avgsize(37)=4, distinct(44)=365, null(44)=0, avgsize(44)=4]
- │ │ │ │ │ │ │ histogram(34)= 0 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4633.6 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527 4728.1 94.527
- │ │ │ │ │ │ │ <--- 576 --------- 38535 -------- 66885 -------- 93380 -------- 127425 -------- 157218 -------- 184483 -------- 215330 -------- 252869 -------- 283878 -------- 313798 -------- 337056 -------- 372549 -------- 399591 -------- 426245 -------- 460578 -------- 498439 -------- 526049 -------- 554468 -------- 577921 -------- 609187 -------- 639524 -------- 665345 -------- 686180 -------- 721539 -------- 755680 -------- 782756 -------- 814496 -------- 845446 -------- 872130 -------- 910912 -------- 933697 -------- 965184 -------- 1000353 -------- 1038658 -------- 1073667 -------- 1097891 -------- 1131330 -------- 1157732 -------- 1179943 -------- 1206401 -------- 1230150 -------- 1261824 -------- 1293217 -------- 1326754 -------- 1357573 -------- 1390145 -------- 1429312 -------- 1460418 -------- 1491104 -------- 1523937 -------- 1559812 -------- 1591653 -------- 1615174 -------- 1646759 -------- 1670465 -------- 1696321 -------- 1724192 -------- 1748033 -------- 1777570 -------- 1807428 -------- 1836962 -------- 1872481 -------- 1902817 -------- 1928324 -------- 1960775 -------- 1985989 -------- 2019107 -------- 2044613 -------- 2071490 -------- 2101959 -------- 2135555 -------- 2164486 -------- 2186337 -------- 2213989 -------- 2246309 -------- 2276992 -------- 2306403 -------- 2329921 -------- 2354977 -------- 2380711 -------- 2410529 -------- 2437920 -------- 2462017 -------- 2483714 -------- 2513920 -------- 2542855 -------- 2574112 -------- 2596035 -------- 2625031 -------- 2658051 -------- 2695046 -------- 2725222 -------- 2754245 -------- 2777702 -------- 2804896 -------- 2844579 -------- 2873860 -------- 2903459 -------- 2933249 -------- 2965479 -------- 2996160 -------- 3022976 -------- 3053152 -------- 3083623 -------- 3111136 -------- 3144033 -------- 3180134 -------- 3209799 -------- 3239394 -------- 3270886 -------- 3297664 -------- 3329444 -------- 3357574 -------- 3380838 -------- 3412196 -------- 3438917 -------- 3462467 -------- 3498629 -------- 3530208 -------- 3562148 -------- 3589889 -------- 3621063 -------- 3655456 -------- 3686724 -------- 3709029 -------- 3738215 -------- 3767687 -------- 3804547 -------- 3831142 -------- 3875111 -------- 3905605 -------- 3933795 -------- 3966593 -------- 3995558 -------- 4020134 -------- 4052513 -------- 4078949 -------- 4114208 -------- 4149762 -------- 4176135 -------- 4207782 -------- 4241376 -------- 4270502 -------- 4304167 -------- 4333669 -------- 4362818 -------- 4393537 -------- 4423076 -------- 4452064 -------- 4491143 -------- 4522723 -------- 4550883 -------- 4581382 -------- 4616002 -------- 4649410 -------- 4680485 -------- 4715584 -------- 4740036 -------- 4771554 -------- 4799461 -------- 4826690 -------- 4855525 -------- 4887974 -------- 4917479 -------- 4950885 -------- 4984195 -------- 5010113 -------- 5033571 -------- 5065472 -------- 5100512 -------- 5129413 -------- 5160069 -------- 5186596 -------- 5221538 -------- 5252964 -------- 5284069 -------- 5314051 -------- 5353026 -------- 5388961 -------- 5424644 -------- 5452676 -------- 5483553 -------- 5516612 -------- 5551041 -------- 5579878 -------- 5612576 -------- 5643427 -------- 5673666 -------- 5709218 -------- 5737221 -------- 5766119 -------- 5795044 -------- 5826560 -------- 5855943 -------- 5889604 -------- 5917607 -------- 5942535 -------- 5969639 -------- 5999557
- │ │ │ │ │ │ │ histogram(37)= 0 2.3953e+05 0 2.0057e+05 0 1.6757e+05 0 1.4232e+05 0 94563 0 68937 0 32151
- │ │ │ │ │ │ │ <------ 0 ---------- 1 ---------- 2 ---------- 3 -------- 4 ----- 5 ----- 6 -
- │ │ │ │ │ │ │ histogram(44)= 0 4202 26410 3001 27010 3001 28811 3001 28211 4802 28811 1200 28811 3001 28211 1801 27610 3001 27010 3001 28211 3001 28211 1200 27610 3601 28811 2401 27610 3601 28211 1801 28811 1200 27010 4202 27010 3601 27010 3601 26410 3601 27610 2401 28211 4202 27010 3601 25810 3601 28811 3601 28811 2401 27010 3001 28211 2401 28211 2401 28211 2401 17570 2510
- │ │ │ │ │ │ │ <--- '1994-01-01' ------- '1994-01-11' ------- '1994-01-22' ------- '1994-02-05' ------- '1994-02-18' ------- '1994-03-01' ------- '1994-03-13' ------- '1994-03-26' ------- '1994-04-06' ------- '1994-04-17' ------- '1994-04-27' ------- '1994-05-10' ------- '1994-05-21' ------- '1994-06-03' ------- '1994-06-17' ------- '1994-06-27' ------- '1994-07-13' ------- '1994-07-27' ------- '1994-08-06' ------- '1994-08-19' ------- '1994-08-30' ------- '1994-09-11' ------- '1994-09-21' ------- '1994-10-03' ------- '1994-10-13' ------- '1994-10-26' ------- '1994-11-08' ------- '1994-11-19' ------- '1994-12-01' ------- '1994-12-13' ------- '1994-12-23' ------- '1994-12-31'
+ │ │ │ │ │ │ ├── stats: [rows=924787.9, distinct(34)=736000, null(34)=0, avgsize(34)=4, distinct(37)=7, null(37)=0, avgsize(37)=1, distinct(44)=365, null(44)=0, avgsize(44)=4]
+ │ │ │ │ │ │ │ histogram(34)= 0 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4439 184.92 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4439 184.92 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4439 184.92 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4531.5 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46 4623.9 92.46
+ │ │ │ │ │ │ │ <--- 197 -------- 23686 -------- 53253 -------- 90435 -------- 121730 -------- 153280 -------- 175456 -------- 208548 -------- 242209 -------- 273057 ------ 296640 -------- 330307 -------- 360999 -------- 386307 -------- 420225 -------- 450050 -------- 477795 -------- 504711 -------- 533153 -------- 556672 -------- 582243 -------- 613729 -------- 646117 -------- 675840 -------- 706048 -------- 733063 -------- 769282 -------- 793922 -------- 820357 -------- 849536 -------- 875719 -------- 905028 -------- 940643 -------- 968355 -------- 998721 -------- 1023621 -------- 1059424 -------- 1084932 -------- 1115553 -------- 1139363 -------- 1167361 -------- 1194400 -------- 1225984 -------- 1253861 -------- 1281633 -------- 1304999 -------- 1336355 -------- 1370759 -------- 1400832 -------- 1434085 -------- 1458852 -------- 1491427 -------- 1525120 -------- 1555205 -------- 1591300 -------- 1619426 -------- 1651458 -------- 1682950 -------- 1711399 -------- 1747591 -------- 1787205 ------ 1822240 -------- 1856163 -------- 1886915 -------- 1910949 -------- 1947202 ------ 1974311 -------- 2009286 -------- 2044034 -------- 2079104 -------- 2103488 -------- 2134657 -------- 2164293 -------- 2204514 -------- 2230823 -------- 2265253 -------- 2289826 -------- 2329539 -------- 2364455 -------- 2393507 -------- 2414628 -------- 2440228 -------- 2465255 -------- 2489568 -------- 2520900 -------- 2554919 -------- 2583333 -------- 2612966 -------- 2644833 -------- 2667362 -------- 2702784 -------- 2727394 -------- 2759748 -------- 2794531 -------- 2822214 -------- 2846624 -------- 2883748 -------- 2919586 -------- 2951908 -------- 2980068 -------- 3014726 -------- 3050725 -------- 3081028 -------- 3113351 -------- 3150243 -------- 3185669 -------- 3214311 -------- 3241281 -------- 3275748 -------- 3303232 -------- 3339559 -------- 3370627 -------- 3393664 -------- 3435265 -------- 3464581 -------- 3489026 -------- 3516096 -------- 3548480 -------- 3587015 -------- 3611239 -------- 3638724 -------- 3668641 -------- 3695751 -------- 3729636 -------- 3751523 -------- 3784608 -------- 3815715 -------- 3848608 -------- 3881184 -------- 3908738 -------- 3940002 -------- 3966176 -------- 4001984 -------- 4035687 -------- 4065283 -------- 4092834 -------- 4133062 -------- 4160613 -------- 4196421 -------- 4223713 -------- 4254788 -------- 4291040 -------- 4313664 -------- 4342823 -------- 4369952 -------- 4391684 -------- 4419040 -------- 4449921 -------- 4471781 -------- 4506210 -------- 4538176 -------- 4571297 -------- 4601121 -------- 4630887 -------- 4657476 -------- 4684803 -------- 4714566 -------- 4744070 -------- 4776385 -------- 4807777 -------- 4839491 -------- 4873953 -------- 4902245 -------- 4936263 -------- 4970721 -------- 5003140 -------- 5029729 -------- 5059010 -------- 5087521 -------- 5121093 -------- 5150405 -------- 5178375 -------- 5203683 -------- 5234531 -------- 5268195 -------- 5300004 -------- 5331558 -------- 5362178 -------- 5385762 -------- 5418498 -------- 5445762 -------- 5483109 -------- 5514561 -------- 5542052 -------- 5569572 -------- 5596102 -------- 5622401 -------- 5652194 -------- 5671362 -------- 5699591 -------- 5727136 -------- 5753284 -------- 5780742 -------- 5809189 -------- 5836545 -------- 5864454 -------- 5894917 -------- 5933825 -------- 5968933 -------- 5999590
+ │ │ │ │ │ │ │ histogram(37)= 0 2.2925e+05 0 2.0632e+05 0 1.6221e+05 0 1.328e+05 0 98120 0 63995 0 32090
+ │ │ │ │ │ │ │ <------ 1 ---------- 2 ---------- 3 ---------- 4 ------- 5 ----- 6 ----- 7 -
+ │ │ │ │ │ │ │ histogram(44)= 0 0 12002 1800 27606 4201 27005 5401 28806 3001 27606 2400 24005 5401 24605 5401 28206 3601 26405 3001 27005 2400 28806 3601 28206 1800 28806 2400 28806 1800 28206 1800 27606 3601 28206 3001 26405 3001 28206 1200 28206 2400 28806 1200 27606 3001 24605 5401 28806 1800 25805 3601 27005 2400 28806 1800 28806 600 28806 600 27606 3601 26326 1880.4
+ │ │ │ │ │ │ │ <--- '1993-12-31' ------- '1994-01-06' ------- '1994-01-20' ------- '1994-02-01' ------- '1994-02-14' ------- '1994-02-25' ------- '1994-03-11' ------- '1994-03-24' ------- '1994-04-07' ------- '1994-04-19' ------- '1994-05-03' ------- '1994-05-14' ------- '1994-05-24' ------- '1994-06-04' ------- '1994-06-14' ------- '1994-06-26' ------- '1994-07-06' ------- '1994-07-17' ------- '1994-08-01' ------- '1994-08-11' ------- '1994-08-25' ------- '1994-09-05' ------- '1994-09-16' ------- '1994-09-26' ------- '1994-10-07' ------- '1994-10-17' ------- '1994-10-27' ------- '1994-11-09' ------- '1994-11-22' ------- '1994-12-04' ------- '1994-12-16' ------- '1994-12-31'
│ │ │ │ │ │ ├── key: (34,37)
│ │ │ │ │ │ └── fd: (34,37)-->(44)
│ │ │ │ │ ├── scan partsupp
│ │ │ │ │ │ ├── save-table-name: q20_scan_13
│ │ │ │ │ │ ├── columns: ps_partkey:16(int!null) ps_suppkey:17(int!null) ps_availqty:18(int!null)
- │ │ │ │ │ │ ├── stats: [rows=800000, distinct(16)=199241, null(16)=0, avgsize(16)=4, distinct(17)=9920, null(17)=0, avgsize(17)=4, distinct(18)=9920, null(18)=0, avgsize(18)=4, distinct(16,17)=798302, null(16,17)=0, avgsize(16,17)=8]
- │ │ │ │ │ │ │ histogram(16)= 0 0 0 79.993 3911.6 79.993 3941.6 79.993 3926.6 79.993 3926.6 79.993 3926.6 79.993 3916.6 79.993 3908.6 79.993 3912.6 79.993 3934.6 79.993 3934.6 79.993 3929.6 79.993 3923.6 79.993 3932.6 158.99 3918.6 79.993 3915.6 79.993 3907.6 79.993 3912.6 79.993 3914.6 79.993 3922.6 79.993 3914.6 79.993 3921.6 79.993 3909.6 79.993 3927.6 79.993 3913.6 79.993 3913.6 79.993 3904.6 79.993 3913.6 79.993 3920.6 79.993 3913.6 79.993 3904.6 79.993 3904.6 79.993 3908.6 79.993 3908.6 79.993 3944.6 79.993 3916.6 79.993 3930.6 79.993 3904.6 79.993 3927.6 79.993 3923.6 79.993 3911.6 79.993 3911.6 79.993 3914.6 79.993 3913.6 79.993 3913.6 79.993 3922.6 79.993 3901.6 79.993 3922.6 79.993 3924.6 79.993 3920.6 79.993 3921.6 79.993 3930.6 79.993 3925.6 79.993 3913.6 79.993 3924.6 79.993 3939.6 79.993 3928.6 79.993 3924.6 79.993 3918.6 79.993 3928.6 79.993 3916.6 79.993 3911.6 79.993 3936.6 79.993 3933.6 79.993 3831.6 158.99 3903.6 79.993 3911.6 79.993 3913.6 79.993 3911.6 79.993 3909.6 79.993 3913.6 79.993 3920.6 79.993 3910.6 79.993 3906.6 79.993 3918.6 79.993 3910.6 79.993 3908.6 79.993 3910.6 79.993 3911.6 79.993 3903.6 79.993 3903.6 79.993 3904.6 79.993 3923.6 79.993 3933.6 79.993 3928.6 79.993 3834.6 158.99 3928.6 79.993 3904.6 79.993 3943.6 79.993 3909.6 79.993 3943.6 79.993 3918.6 79.993 3919.6 79.993 3923.6 79.993 3916.6 79.993 3942.6 79.993 3934.6 79.993 3922.6 79.993 3908.6 79.993 3919.6 79.993 3910.6 79.993 3943.6 79.993 3912.6 79.993 3916.6 79.993 3951.6 79.993 3919.6 79.993 3906.6 79.993 3920.6 79.993 3941.6 79.993 3913.6 79.993 3905.6 79.993 3909.6 79.993 3909.6 79.993 3905.6 79.993 3913.6 79.993 3918.6 79.993 3934.6 79.993 3902.6 79.993 3907.6 79.993 3923.6 79.993 3922.6 79.993 3926.6 79.993 3917.6 79.993 3827.6 158.99 3911.6 79.993 3911.6 79.993 3937.6 79.993 3904.6 79.993 3975.6 79.993 3905.6 158.99 3917.6 79.993 3918.6 79.993 3906.6 79.993 3930.6 79.993 3917.6 79.993 3909.6 79.993 3916.6 79.993 3912.6 79.993 3922.6 79.993 3912.6 79.993 3907.6 79.993 3905.6 79.993 3912.6 79.993 3931.6 79.993 3913.6 79.993 3918.6 79.993 3920.6 79.993 3911.6 79.993 3902.6 79.993 3917.6 79.993 3920.6 79.993 3915.6 79.993 3904.6 79.993 4056.6 79.993 4020.6 79.993 4006.6 79.993 4046.6 79.993 4006.6 79.993 3998.6 79.993 4012.6 79.993 3985.6 79.993 3991.6 79.993 4009.6 79.993 3989.6 79.993 4032.6 79.993 3989.6 79.993 3990.6 79.993 3985.6 79.993 4024.6 79.993 3993.6 79.993 4000.6 79.993 4039.6 79.993 3987.6 79.993 4016.6 79.993 4017.6 79.993 3990.6 79.993 3998.6 79.993 4002.6 79.993 4005.6 79.993 4003.6 79.993 4000.6 79.993 4026.6 79.993 3995.6 79.993 3997.6 79.993 4014.6 79.993 4008.6 79.993 4002.6 79.993 3989.6 79.993 4017.6 79.993 4003.6 79.993 3988.6 79.993 4028.6 79.993 3997.6 79.993 4000.6 79.993 3998.6 158.99 3904.6 79.993 3990.6 79.993 3989.6 79.993 3997.6 79.993 3988.6 79.993 0 0
- │ │ │ │ │ │ │ <--- -9223372036854775808 ---- 5 ---------- 925 --------- 2147 -------- 3243 -------- 4346 -------- 5444 -------- 6433 -------- 7290 -------- 8225 -------- 9393 -------- 10561 -------- 11687 -------- 12755 -------- 13905 -------- 14921 -------- 15897 -------- 16739 -------- 17675 -------- 18640 -------- 19705 -------- 20671 -------- 21719 -------- 22602 -------- 23714 -------- 24672 -------- 25620 -------- 26379 -------- 27327 -------- 28366 -------- 29320 -------- 30070 -------- 30837 -------- 31707 -------- 32567 -------- 33809 -------- 34795 -------- 35930 -------- 36688 -------- 37801 -------- 38874 -------- 39798 -------- 40717 -------- 41686 -------- 42635 -------- 43586 -------- 44647 -------- 45188 -------- 46250 -------- 47331 -------- 48366 -------- 49411 -------- 50547 -------- 51636 -------- 52588 -------- 53673 -------- 54877 -------- 55992 -------- 57071 -------- 58085 -------- 59202 -------- 60194 -------- 61109 -------- 62289 -------- 63452 -------- 64350 -------- 65061 -------- 65983 -------- 66930 -------- 67848 -------- 68740 -------- 69687 -------- 70729 -------- 71625 -------- 72441 -------- 73462 -------- 74357 -------- 75226 -------- 76123 -------- 77037 -------- 77774 -------- 78521 -------- 79269 -------- 80341 -------- 81504 -------- 82626 -------- 83571 -------- 84691 -------- 85448 -------- 86681 -------- 87565 -------- 88799 -------- 89810 -------- 90834 -------- 91901 -------- 92892 -------- 94119 -------- 95284 -------- 96346 -------- 97205 -------- 98231 -------- 99141 -------- 100372 -------- 101314 -------- 102304 -------- 103594 -------- 104620 -------- 105437 -------- 106475 -------- 107696 -------- 108646 -------- 109445 -------- 110330 -------- 111220 -------- 112020 -------- 112978 -------- 113996 -------- 115166 -------- 115838 -------- 116694 -------- 117766 -------- 118830 -------- 119934 -------- 120936 -------- 121757 -------- 122685 -------- 123602 -------- 124791 -------- 125549 -------- 126970 -------- 127770 -------- 128776 -------- 129788 -------- 130602 -------- 131740 -------- 132748 -------- 133632 -------- 134629 -------- 135564 -------- 136625 -------- 137559 -------- 138398 -------- 139204 -------- 140136 -------- 141281 -------- 142230 -------- 143246 -------- 144284 -------- 145212 -------- 145869 -------- 146873 -------- 147910 -------- 148889 -------- 149656 -------- 151106 -------- 152338 -------- 153457 -------- 154854 -------- 155973 -------- 157005 -------- 158178 -------- 159002 -------- 159939 -------- 161091 -------- 162000 -------- 163314 -------- 164230 -------- 165157 -------- 165980 -------- 167242 -------- 168207 -------- 169271 -------- 170628 -------- 171503 -------- 172711 -------- 173922 -------- 174853 -------- 175886 -------- 176965 -------- 178073 -------- 179166 -------- 180231 -------- 181505 -------- 182510 -------- 183541 -------- 184734 -------- 185872 -------- 186957 -------- 187866 -------- 189075 -------- 190166 -------- 191061 -------- 192354 -------- 193380 -------- 194445 -------- 195479 -------- 196243 -------- 197170 -------- 198076 -------- 199103 -------- 199994 --- 9223372036854775807
- │ │ │ │ │ │ │ histogram(17)= 0 240 3920 160 3840 160 3840 160 3920 80 3760 240 3920 80 3920 160 3920 80 3920 80 3920 160 3760 320 3920 80 3920 80 3840 160 3920 80 3760 240 3840 240 3920 80 3920 80 3840 160 3920 80 3920 80 3920 80 3920 240 3920 320 3920 80 3920 80 3920 80 3920 80 3920 160 3920 160 3920 80 3920 160 3680 320 3920 160 3840 240 3920 80 3920 80 3840 160 3920 80 3920 80 3840 160 3920 80 3920 320 3920 80 3920 160 3920 80 3920 160 3920 160 3920 80 3920 80 3840 320 3920 80 3680 320 3920 160 3680 400 3840 240 3840 160 3920 240 3920 80 3920 320 3920 320 3920 160 3760 320 3760 240 3920 80 3920 80 3840 160 3840 320 3840 160 3920 160 3920 80 3920 80 3920 80 3920 80 3920 160 3920 80 3840 240 3920 80 3840 160 3840 160 3840 240 3840 160 3920 80 3920 160 3920 80 3840 160 3920 80 3920 240 3920 160 3920 160 3840 160 3920 160 3840 80 3840 240 3840 160 3760 160 3920 160 3840 80 3840 160 3920 80 3920 80 3920 80 3920 80 3840 160 3920 240 3760 160 3840 80 3840 320 3760 160 3680 240 3840 160 3760 320 3840 240 3840 160 3840 80 3840 160 3840 80 3920 80 3920 240 3760 160 3840 80 3920 160 3600 320 3920 160 3840 240 3840 80 3840 160 3840 160 3680 320 3760 240 3840 80 3840 160 3760 400 3840 160 3840 160 3680 320 3840 80 3840 80 3920 80 3840 160 3920 160 3840 80 3920 80 3840 160 3920 320 3760 160 3840 160 3840 80 3840 160 3840 80 3680 320 3920 80 3920 160 3840 80 3840 240 3840 80 3920 80 3920 80 3760 240 3920 160 3840 160 3840 240 3840 80 3680 240 3920 80 3920 80 3680 320 3920 80 3920 80 3920 160 3840 240 3840 160 3840 160 3680 240 3760 160 3920 80 3920 80 3760 240 3840 240 3840 80 3840 160 3760 240 3920 160 3840 240 3680 320 3840 160 3840 80 3760 160 3920 240 3840 80 3840 80 3840 160 3920 80 3680 320 3920 160 3760 160 3840 160 3920 80
- │ │ │ │ │ │ │ <--- 1 ------ 48 ------ 112 ------ 174 ------ 233 ------ 271 ------ 318 ------ 364 ------ 415 ------ 468 ------ 521 ------ 565 ------ 617 ------ 658 ------ 713 ------ 767 ------ 817 ------ 878 ------ 930 ------ 978 ------ 1034 ------ 1095 ------ 1150 ------ 1193 ------ 1243 ------ 1294 ------ 1348 ------ 1402 ------ 1468 ------ 1507 ------ 1552 ------ 1614 ------ 1673 ------ 1731 ------ 1780 ------ 1834 ------ 1881 ------ 1940 ------ 1994 ------ 2041 ------ 2096 ------ 2153 ------ 2199 ------ 2256 ------ 2304 ------ 2349 ------ 2401 ------ 2451 ------ 2498 ------ 2546 ------ 2599 ------ 2643 ------ 2683 ------ 2731 ------ 2772 ------ 2827 ------ 2869 ------ 2915 ------ 2973 ------ 3023 ------ 3078 ------ 3129 ------ 3184 ------ 3236 ------ 3296 ------ 3353 ------ 3413 ------ 3473 ------ 3521 ------ 3566 ------ 3607 ------ 3657 ------ 3718 ------ 3775 ------ 3813 ------ 3868 ------ 3924 ------ 3971 ------ 4008 ------ 4065 ------ 4123 ------ 4174 ------ 4231 ------ 4269 ------ 4332 ------ 4385 ------ 4436 ------ 4484 ------ 4537 ------ 4588 ------ 4633 ------ 4685 ------ 4733 ------ 4783 ------ 4834 ------ 4874 ------ 4918 ------ 4953 ------ 5008 ------ 5052 ------ 5096 ------ 5147 ------ 5197 ------ 5245 ------ 5292 ------ 5341 ------ 5396 ------ 5449 ------ 5498 ------ 5547 ------ 5602 ------ 5651 ------ 5703 ------ 5742 ------ 5786 ------ 5827 ------ 5865 ------ 5935 ------ 5980 ------ 6050 ------ 6096 ------ 6153 ------ 6208 ------ 6270 ------ 6309 ------ 6358 ------ 6412 ------ 6464 ------ 6518 ------ 6577 ------ 6640 ------ 6676 ------ 6735 ------ 6792 ------ 6835 ------ 6877 ------ 6916 ------ 6968 ------ 7025 ------ 7061 ------ 7107 ------ 7159 ------ 7221 ------ 7264 ------ 7300 ------ 7356 ------ 7390 ------ 7448 ------ 7495 ------ 7547 ------ 7605 ------ 7648 ------ 7707 ------ 7755 ------ 7818 ------ 7858 ------ 7904 ------ 7951 ------ 7992 ------ 8049 ------ 8098 ------ 8144 ------ 8194 ------ 8234 ------ 8282 ------ 8323 ------ 8376 ------ 8433 ------ 8474 ------ 8514 ------ 8564 ------ 8623 ------ 8676 ------ 8734 ------ 8784 ------ 8819 ------ 8857 ------ 8907 ------ 8955 ------ 9012 ------ 9060 ------ 9103 ------ 9157 ------ 9200 ------ 9249 ------ 9301 ------ 9339 ------ 9381 ------ 9430 ------ 9474 ------ 9529 ------ 9579 ------ 9631 ------ 9673 ------ 9732 ------ 9780 ------ 9832 ------ 9886 ------ 9941 ------ 9997
+ │ │ │ │ │ │ ├── stats: [rows=800000, distinct(16)=199241, null(16)=0, avgsize(16)=4, distinct(17)=9920, null(17)=0, avgsize(17)=3, distinct(18)=9920, null(18)=0, avgsize(18)=4, distinct(16,17)=798302, null(16,17)=0, avgsize(16,17)=7]
+ │ │ │ │ │ │ │ histogram(16)= 0 79.993 3912.7 79.993 3933.7 79.993 3920.7 79.993 3917.7 79.993 3929.7 79.993 3912.7 79.993 3932.7 79.993 3918.7 158.99 3914.7 79.993 3928.7 79.993 3910.7 79.993 3904.7 79.993 3924.7 79.993 3914.7 79.993 3909.7 79.993 3917.7 79.993 3926.7 79.993 3913.7 79.993 3905.7 79.993 3912.7 79.993 3931.7 79.993 3926.7 79.993 3926.7 79.993 3906.7 79.993 3923.7 79.993 3904.7 79.993 3904.7 79.993 3907.7 158.99 3979.6 79.993 3906.7 79.993 3914.7 79.993 3918.7 79.993 3917.7 79.993 3826.7 158.99 3936.7 79.993 3908.7 79.993 3926.7 79.993 3930.7 79.993 3967.6 79.993 3910.7 79.993 3922.7 79.993 3914.7 79.993 3913.7 79.993 3915.7 79.993 3919.7 79.993 3916.7 79.993 3920.7 79.993 3926.7 79.993 3908.7 79.993 3904.7 158.99 3926.7 79.993 3922.7 79.993 3918.7 79.993 3908.7 79.993 3919.7 79.993 3908.7 79.993 3907.7 79.993 3916.7 79.993 3917.7 79.993 3905.7 79.993 3918.7 79.993 3940.7 79.993 3916.7 79.993 3923.7 79.993 3909.7 79.993 3915.7 79.993 3911.7 79.993 3915.7 79.993 3914.7 79.993 3948.6 79.993 3924.7 79.993 3916.7 79.993 3943.7 79.993 3933.7 79.993 3915.7 79.993 3916.7 79.993 3914.7 79.993 3919.7 79.993 3916.7 79.993 3912.7 79.993 3904.7 79.993 3913.7 79.993 3909.7 79.993 3914.7 79.993 3910.7 79.993 3923.7 79.993 3913.7 79.993 3914.7 79.993 3921.7 79.993 3927.7 79.993 3921.7 79.993 3924.7 158.99 3910.7 79.993 3916.7 79.993 3949.6 79.993 3922.7 79.993 3915.7 79.993 3942.7 79.993 3915.7 79.993 3917.7 79.993 3842.7 158.99 3911.7 79.993 3923.7 79.993 3923.7 79.993 3906.7 79.993 3925.7 79.993 3951.6 79.993 3933.7 79.993 3916.7 79.993 3903.7 79.993 3923.7 79.993 3932.7 79.993 3928.7 79.993 3905.7 79.993 3921.7 79.993 3920.7 79.993 3910.7 79.993 3912.7 79.993 3916.7 79.993 3922.7 79.993 3911.7 79.993 3906.7 79.993 3921.7 79.993 3911.7 79.993 3911.7 79.993 3926.7 79.993 3912.7 79.993 3945.6 79.993 3910.7 79.993 3922.7 79.993 3918.7 79.993 3911.7 79.993 3917.7 79.993 3945.6 79.993 3926.7 79.993 3926.7 79.993 3917.7 79.993 3904.7 79.993 3925.7 79.993 3912.7 79.993 3912.7 79.993 3954.6 79.993 3915.7 79.993 3912.7 79.993 3910.7 79.993 3909.7 79.993 3911.7 79.993 3903.7 79.993 3915.7 79.993 3949.6 79.993 3923.7 79.993 3921.7 79.993 3909.7 79.993 3905.7 79.993 3988.6 79.993 3988.6 79.993 3999.6 79.993 4003.6 79.993 3998.6 79.993 4021.6 79.993 4027.6 79.993 4005.6 79.993 3999.6 79.993 3997.6 79.993 3988.6 79.993 3989.6 79.993 4004.6 79.993 3984.6 79.993 3999.6 79.993 3999.6 79.993 4019.6 79.993 4011.6 79.993 4020.6 79.993 4012.6 79.993 3996.6 79.993 4029.6 79.993 4004.6 158.99 3912.7 79.993 3995.6 79.993 3989.6 79.993 3991.6 79.993 3986.6 79.993 3986.6 79.993 4006.6 79.993 3988.6 79.993 3989.6 79.993 3989.6 79.993 3998.6 79.993 4012.6 79.993 4017.6 79.993 4017.6 79.993 3996.6 79.993 3994.6 79.993 4009.6 79.993 3995.6 79.993 3996.6 79.993 3991.6 79.993 4006.6 79.993 4020.6 79.993
+ │ │ │ │ │ │ │ <---- 13 --------- 942 --------- 2097 -------- 3127 -------- 4125 -------- 5247 -------- 6181 -------- 7326 -------- 8333 -------- 9292 -------- 10410 -------- 11308 -------- 12057 -------- 13131 -------- 14088 -------- 14972 -------- 15975 -------- 17072 -------- 18019 -------- 18798 -------- 19734 -------- 20877 -------- 21973 -------- 23067 -------- 23887 -------- 24957 -------- 25716 -------- 26450 -------- 27291 -------- 28733 -------- 29539 -------- 30499 -------- 31512 -------- 32509 -------- 33286 -------- 34464 -------- 35311 -------- 36406 -------- 37541 -------- 38918 -------- 39818 -------- 40879 -------- 41843 -------- 42789 -------- 43757 -------- 44778 -------- 45769 -------- 46806 -------- 47899 -------- 48763 -------- 49507 -------- 50607 -------- 51663 -------- 52669 -------- 53525 -------- 54549 -------- 55415 -------- 56261 -------- 57242 -------- 58242 -------- 59036 -------- 60050 -------- 61259 -------- 62240 -------- 63307 -------- 64178 -------- 65152 -------- 66063 -------- 67040 -------- 68005 -------- 69273 -------- 70354 -------- 71339 -------- 72569 -------- 73724 -------- 74695 -------- 75684 -------- 76646 -------- 77670 -------- 78657 -------- 79587 -------- 80331 -------- 81281 -------- 82150 -------- 83115 -------- 84014 -------- 85082 -------- 86031 -------- 86990 -------- 88034 -------- 89138 -------- 90187 -------- 91260 -------- 92150 -------- 93140 -------- 94413 -------- 95469 -------- 96443 -------- 97666 -------- 98637 -------- 99633 -------- 100664 -------- 101572 -------- 102643 -------- 103706 -------- 104522 -------- 105605 -------- 106892 -------- 108047 -------- 109036 -------- 109721 -------- 110790 -------- 111938 -------- 113052 -------- 113830 -------- 114873 -------- 115912 -------- 116814 -------- 117737 -------- 118721 -------- 119776 -------- 120692 -------- 121500 -------- 122545 -------- 123457 -------- 124366 -------- 125466 -------- 126391 -------- 127638 -------- 128533 -------- 129586 -------- 130602 -------- 131508 -------- 132509 -------- 133756 -------- 134848 -------- 135944 -------- 136945 -------- 137706 -------- 138791 -------- 139720 -------- 140657 -------- 141959 -------- 142929 -------- 143854 -------- 144743 -------- 145629 -------- 146548 -------- 147238 -------- 148209 -------- 149481 -------- 150548 -------- 151598 -------- 152481 -------- 153250 -------- 154137 -------- 155017 -------- 156060 -------- 157143 -------- 158169 -------- 159406 -------- 160686 -------- 161794 -------- 162837 -------- 163860 -------- 164730 -------- 165623 -------- 166716 -------- 167485 -------- 168526 -------- 169568 -------- 170793 -------- 171958 -------- 173192 -------- 174365 -------- 175367 -------- 176660 -------- 177754 -------- 178681 -------- 179672 -------- 180568 -------- 181502 -------- 182344 -------- 183171 -------- 184286 -------- 185174 -------- 186068 -------- 186966 -------- 187997 -------- 189168 -------- 190375 -------- 191583 -------- 192588 -------- 193575 -------- 194722 -------- 195713 -------- 196725 -------- 197653 -------- 198767 -------- 199999
+ │ │ │ │ │ │ │ histogram(17)= 0 160 3920 160 3920 80 3920 160 3920 160 3920 240 3760 240 3920 80 3840 240 3920 240 3840 320 3760 240 3920 80 3840 160 3920 240 3920 320 3920 80 3920 80 3920 80 3840 160 3920 240 3760 240 3920 80 3840 160 3920 80 3920 160 3920 80 3920 160 3920 80 3920 160 3920 80 3760 240 3840 240 3920 80 3920 80 3840 240 3760 240 3920 80 3840 160 3840 160 3920 80 3920 80 3920 160 3760 240 3920 240 3920 80 3920 160 3920 80 3840 160 3920 160 3920 80 3840 160 3840 240 3920 160 3840 160 3920 160 3920 80 3840 160 3920 160 3840 160 3840 160 3920 80 3920 160 3920 160 3920 80 3920 80 3840 160 3840 160 3840 160 3920 80 3920 80 3840 240 3840 160 3920 320 3840 160 3840 240 3920 80 3920 80 3760 240 3840 160 3920 160 3920 80 3840 240 3920 80 3920 80 3920 160 3920 80 3920 80 3920 80 3920 80 3840 160 3920 80 3920 160 3760 320 3920 80 3920 80 3840 160 3920 240 3920 80 3920 80 3920 80 3920 160 3840 160 3760 400 3760 240 3680 320 3840 240 3840 80 3840 160 3840 160 3920 80 3920 80 3920 80 3840 160 3920 80 3760 240 3920 80 3840 240 3840 80 3840 160 3920 240 3840 80 3840 80 3840 160 3920 80 3760 240 3920 80 3920 160 3840 160 3760 240 3760 240 3840 80 3920 160 3840 80 3920 80 3920 80 3840 400 3760 160 3840 80 3840 160 3760 160 3840 240 3840 160 3680 320 3760 160 3920 80 3920 80 3920 80 3920 80 3920 80 3840 160 3760 240 3840 160 3920 80 3840 160 3920 240 3840 160 3840 80 3840 160 3840 80 3920 80 3920 80 3920 160 3840 160 3840 160 3840 160 3760 160 3920 80 3920 80 3920 80 3920 80 3760 240 3920 80 3920 320 3760 160 3840 80 3840 80 3920 160 3840 80 3920 160 3760 160 3920 80 3920 80 3920 160 3840 160 3840 80 3840 160 3920 80 3920 80 3920 80 3840 160 3840 240 3840 160 3840 80 3920 80 3840 240 3840 80 3920 80 3920 80 3840 160
+ │ │ │ │ │ │ │ <--- 2 ------ 50 ------ 104 ------ 153 ------ 213 ------ 281 ------ 320 ------ 366 ------ 411 ------ 462 ------ 515 ------ 548 ------ 600 ------ 649 ------ 697 ------ 743 ------ 793 ------ 845 ------ 893 ------ 953 ------ 1006 ------ 1052 ------ 1103 ------ 1158 ------ 1199 ------ 1246 ------ 1302 ------ 1375 ------ 1418 ------ 1475 ------ 1524 ------ 1563 ------ 1628 ------ 1689 ------ 1740 ------ 1799 ------ 1850 ------ 1901 ------ 1948 ------ 2017 ------ 2055 ------ 2099 ------ 2157 ------ 2214 ------ 2267 ------ 2319 ------ 2373 ------ 2428 ------ 2478 ------ 2546 ------ 2602 ------ 2657 ------ 2707 ------ 2760 ------ 2808 ------ 2852 ------ 2913 ------ 2968 ------ 3030 ------ 3069 ------ 3115 ------ 3165 ------ 3210 ------ 3256 ------ 3306 ------ 3365 ------ 3419 ------ 3469 ------ 3523 ------ 3576 ------ 3641 ------ 3694 ------ 3738 ------ 3806 ------ 3851 ------ 3900 ------ 3957 ------ 4004 ------ 4050 ------ 4095 ------ 4145 ------ 4201 ------ 4251 ------ 4293 ------ 4335 ------ 4380 ------ 4432 ------ 4484 ------ 4541 ------ 4593 ------ 4650 ------ 4706 ------ 4744 ------ 4804 ------ 4845 ------ 4897 ------ 4945 ------ 4992 ------ 5044 ------ 5108 ------ 5160 ------ 5207 ------ 5261 ------ 5319 ------ 5358 ------ 5404 ------ 5450 ------ 5490 ------ 5538 ------ 5590 ------ 5639 ------ 5686 ------ 5742 ------ 5788 ------ 5837 ------ 5884 ------ 5940 ------ 5985 ------ 6037 ------ 6090 ------ 6135 ------ 6185 ------ 6228 ------ 6271 ------ 6323 ------ 6376 ------ 6434 ------ 6474 ------ 6527 ------ 6586 ------ 6633 ------ 6674 ------ 6711 ------ 6751 ------ 6797 ------ 6835 ------ 6880 ------ 6918 ------ 6982 ------ 7026 ------ 7069 ------ 7123 ------ 7179 ------ 7238 ------ 7287 ------ 7336 ------ 7388 ------ 7438 ------ 7480 ------ 7528 ------ 7574 ------ 7620 ------ 7664 ------ 7706 ------ 7755 ------ 7805 ------ 7847 ------ 7896 ------ 7954 ------ 8014 ------ 8064 ------ 8108 ------ 8159 ------ 8207 ------ 8250 ------ 8304 ------ 8361 ------ 8410 ------ 8462 ------ 8513 ------ 8562 ------ 8608 ------ 8644 ------ 8706 ------ 8752 ------ 8799 ------ 8840 ------ 8902 ------ 8954 ------ 8995 ------ 9063 ------ 9106 ------ 9152 ------ 9202 ------ 9256 ------ 9310 ------ 9362 ------ 9409 ------ 9462 ------ 9504 ------ 9551 ------ 9598 ------ 9644 ------ 9689 ------ 9741 ------ 9800 ------ 9855 ------ 9896 ------ 9945 ------ 10000
│ │ │ │ │ │ │ histogram(18)= 0 80 7.9984e+05 80
- │ │ │ │ │ │ │ <--- 1 ------------ 9998
+ │ │ │ │ │ │ │ <--- 2 ------------ 9998
│ │ │ │ │ │ ├── key: (16,17)
│ │ │ │ │ │ └── fd: (16,17)-->(18)
│ │ │ │ │ └── filters
@@ -272,10 +272,10 @@ column_names row_count distinct_count null_count
{sum} 542095 246 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{ps_availqty} 128.00 4235.12 <== 128.00 77.50 <== 0.00 1.00
-{ps_partkey} 128.00 4235.12 <== 128.00 1540.60 <== 0.00 1.00
-{ps_suppkey} 128.00 4235.12 <== 128.00 77.50 <== 0.00 1.00
-{sum} 128.00 4235.12 <== 128.00 1.92 <== 0.00 1.00
+{ps_availqty} 125.00 4336.76 <== 125.00 79.36 <== 0.00 1.00
+{ps_partkey} 125.00 4336.76 <== 125.00 1577.58 <== 0.00 1.00
+{ps_suppkey} 125.00 4336.76 <== 125.00 79.36 <== 0.00 1.00
+{sum} 125.00 4336.76 <== 125.00 1.97 <== 0.00 1.00
----Stats for q20_group_by_9----
column_names row_count distinct_count null_count
@@ -285,10 +285,10 @@ column_names row_count distinct_count null_count
{sum} 543210 246 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{ps_availqty} 383.00 1418.30 <== 383.00 25.90 <== 0.00 1.00
-{ps_partkey} 383.00 1418.30 <== 383.00 515.02 <== 0.00 1.00
-{ps_suppkey} 383.00 1418.30 <== 383.00 25.90 <== 0.00 1.00
-{sum} 383.00 1418.30 <== 383.00 1.56 0.00 1.00
+{ps_availqty} 374.00 1452.43 <== 374.00 26.52 <== 0.00 1.00
+{ps_partkey} 374.00 1452.43 <== 374.00 527.41 <== 0.00 1.00
+{ps_suppkey} 374.00 1452.43 <== 374.00 26.52 <== 0.00 1.00
+{sum} 374.00 1452.43 <== 374.00 1.52 0.00 1.00
----Stats for q20_inner_join_10----
column_names row_count distinct_count null_count
@@ -301,13 +301,13 @@ column_names row_count distinct_count null_count
{ps_suppkey} 909455 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_partkey} 383.00 2374.56 <== 383.00 515.02 <== 0.00 1.00
-{l_quantity} 383.00 2374.56 <== 50.00 1.00 0.00 1.00
-{l_shipdate} 383.00 2374.56 <== 237.00 1.54 0.00 1.00
-{l_suppkey} 383.00 2374.56 <== 383.00 25.90 <== 0.00 1.00
-{ps_availqty} 383.00 2374.56 <== 375.00 26.45 <== 0.00 1.00
-{ps_partkey} 383.00 2374.56 <== 383.00 515.02 <== 0.00 1.00
-{ps_suppkey} 383.00 2374.56 <== 383.00 25.90 <== 0.00 1.00
+{l_partkey} 374.00 2431.70 <== 374.00 527.41 <== 0.00 1.00
+{l_quantity} 374.00 2431.70 <== 50.00 1.00 0.00 1.00
+{l_shipdate} 374.00 2431.70 <== 234.00 1.56 0.00 1.00
+{l_suppkey} 374.00 2431.70 <== 374.00 26.52 <== 0.00 1.00
+{ps_availqty} 374.00 2431.70 <== 367.00 27.03 <== 0.00 1.00
+{ps_partkey} 374.00 2431.70 <== 374.00 527.41 <== 0.00 1.00
+{ps_suppkey} 374.00 2431.70 <== 374.00 26.52 <== 0.00 1.00
----Stats for q20_index_join_11----
column_names row_count distinct_count null_count
@@ -317,10 +317,10 @@ column_names row_count distinct_count null_count
{l_suppkey} 909455 9920 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_partkey} 945632.00 1.04 198102.00 1.00 0.00 1.00
-{l_quantity} 945632.00 1.04 50.00 1.00 0.00 1.00
-{l_shipdate} 945632.00 1.04 365.00 1.00 0.00 1.00
-{l_suppkey} 945632.00 1.04 9920.00 1.00 0.00 1.00
+{l_partkey} 924788.00 1.02 197952.00 1.00 0.00 1.00
+{l_quantity} 924788.00 1.02 50.00 1.00 0.00 1.00
+{l_shipdate} 924788.00 1.02 365.00 1.00 0.00 1.00
+{l_suppkey} 924788.00 1.02 9920.00 1.00 0.00 1.00
----Stats for q20_scan_12----
column_names row_count distinct_count null_count
@@ -329,9 +329,9 @@ column_names row_count distinct_count null_count
{l_shipdate} 909455 365 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 945632.00 1.04 7.00 1.00 0.00 1.00
-{l_orderkey} 945632.00 1.04 748681.00 2.81 <== 0.00 1.00
-{l_shipdate} 945632.00 1.04 365.00 1.00 0.00 1.00
+{l_linenumber} 924788.00 1.02 7.00 1.00 0.00 1.00
+{l_orderkey} 924788.00 1.02 736000.00 2.77 <== 0.00 1.00
+{l_shipdate} 924788.00 1.02 365.00 1.00 0.00 1.00
----Stats for q20_scan_13----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q21 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q21
index d50d0ba23cf9..cacf0bce02e0 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q21
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q21
@@ -63,7 +63,7 @@ top-k
├── internal-ordering: -81,+2
├── k: 100
├── cardinality: [0 - 100]
- ├── stats: [rows=100, distinct(2)=100, null(2)=0, avgsize(2)=4, distinct(81)=100, null(81)=0, avgsize(81)=4]
+ ├── stats: [rows=100, distinct(2)=100, null(2)=0, avgsize(2)=20, distinct(81)=100, null(81)=0, avgsize(81)=20]
├── key: (2)
├── fd: (2)-->(81)
├── ordering: -81,+2
@@ -71,7 +71,7 @@ top-k
├── save-table-name: q21_group_by_2
├── columns: s_name:2(char!null) count_rows:81(int!null)
├── grouping columns: s_name:2(char!null)
- ├── stats: [rows=8389.827, distinct(2)=8389.83, null(2)=0, avgsize(2)=4, distinct(81)=8389.83, null(81)=0, avgsize(81)=4]
+ ├── stats: [rows=8389.301, distinct(2)=8389.3, null(2)=0, avgsize(2)=20, distinct(81)=8389.3, null(81)=0, avgsize(81)=20]
├── key: (2)
├── fd: (2)-->(81)
├── inner-join (lookup orders)
@@ -79,32 +79,32 @@ top-k
│ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_nationkey:4(int!null) l1.l_orderkey:10(int!null) l1.l_suppkey:12(int!null) l1.l_commitdate:21(date!null) l1.l_receiptdate:22(date!null) o_orderkey:28(int!null) o_orderstatus:30(char!null) n_nationkey:39(int!null) n_name:40(char!null)
│ ├── key columns: [10] = [28]
│ ├── lookup columns are key
- │ ├── stats: [rows=17928, distinct(1)=8351.44, null(1)=0, avgsize(1)=4, distinct(2)=8389.83, null(2)=0, avgsize(2)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(10)=17716.2, null(10)=0, avgsize(10)=4, distinct(12)=8351.44, null(12)=0, avgsize(12)=4, distinct(21)=2464.52, null(21)=0, avgsize(21)=4, distinct(22)=2551.03, null(22)=0, avgsize(22)=4, distinct(28)=17716.2, null(28)=0, avgsize(28)=4, distinct(30)=1, null(30)=0, avgsize(30)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ ├── stats: [rows=17924.78, distinct(1)=8350.92, null(1)=0, avgsize(1)=3, distinct(2)=8389.3, null(2)=0, avgsize(2)=20, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(10)=17713.1, null(10)=0, avgsize(10)=4, distinct(12)=8350.92, null(12)=0, avgsize(12)=4, distinct(21)=2464.52, null(21)=0, avgsize(21)=4, distinct(22)=2552.02, null(22)=0, avgsize(22)=4, distinct(28)=17713.1, null(28)=0, avgsize(28)=4, distinct(30)=1, null(30)=0, avgsize(30)=3, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ ├── fd: ()-->(30,40), (1)-->(2,4), (10)==(28), (28)==(10), (1)==(12), (12)==(1), (4)==(39), (39)==(4)
│ ├── anti-join (lookup lineitem [as=l3])
│ │ ├── save-table-name: q21_lookup_join_4
│ │ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_nationkey:4(int!null) l1.l_orderkey:10(int!null) l1.l_suppkey:12(int!null) l1.l_commitdate:21(date!null) l1.l_receiptdate:22(date!null) n_nationkey:39(int!null) n_name:40(char!null)
│ │ ├── key columns: [10] = [63]
- │ │ ├── stats: [rows=17928, distinct(1)=399.935, null(1)=0, avgsize(1)=4, distinct(2)=399.992, null(2)=0, avgsize(2)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(10)=17928, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(21)=2465.98, null(21)=0, avgsize(21)=4, distinct(22)=2552.97, null(22)=0, avgsize(22)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ ├── stats: [rows=17924.78, distinct(1)=399.935, null(1)=0, avgsize(1)=3, distinct(2)=399.992, null(2)=0, avgsize(2)=20, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(10)=17924.8, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(21)=2465.98, null(21)=0, avgsize(21)=4, distinct(22)=2553.97, null(22)=0, avgsize(22)=4, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ ├── fd: ()-->(40), (1)-->(2,4), (4)==(39), (39)==(4), (1)==(12), (12)==(1)
│ │ ├── semi-join (lookup lineitem [as=l2])
│ │ │ ├── save-table-name: q21_lookup_join_5
│ │ │ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_nationkey:4(int!null) l1.l_orderkey:10(int!null) l1.l_suppkey:12(int!null) l1.l_commitdate:21(date!null) l1.l_receiptdate:22(date!null) n_nationkey:39(int!null) n_name:40(char!null)
│ │ │ ├── key columns: [10] = [45]
- │ │ │ ├── stats: [rows=26891.99, distinct(1)=399.935, null(1)=0, avgsize(1)=4, distinct(2)=399.992, null(2)=0, avgsize(2)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(10)=26892, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(21)=2466, null(21)=0, avgsize(21)=4, distinct(22)=2552.99, null(22)=0, avgsize(22)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ │ ├── stats: [rows=26887.16, distinct(1)=399.935, null(1)=0, avgsize(1)=3, distinct(2)=399.992, null(2)=0, avgsize(2)=20, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(10)=26887.2, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(21)=2466, null(21)=0, avgsize(21)=4, distinct(22)=2553.99, null(22)=0, avgsize(22)=4, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ │ ├── fd: ()-->(40), (1)-->(2,4), (4)==(39), (39)==(4), (1)==(12), (12)==(1)
│ │ │ ├── inner-join (lookup lineitem [as=l1])
│ │ │ │ ├── save-table-name: q21_lookup_join_6
│ │ │ │ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_nationkey:4(int!null) l1.l_orderkey:10(int!null) l1.l_suppkey:12(int!null) l1.l_commitdate:21(date!null) l1.l_receiptdate:22(date!null) n_nationkey:39(int!null) n_name:40(char!null)
│ │ │ │ ├── key columns: [10 13] = [10 13]
│ │ │ │ ├── lookup columns are key
- │ │ │ │ ├── stats: [rows=80675.98, distinct(1)=399.935, null(1)=0, avgsize(1)=4, distinct(2)=399.992, null(2)=0, avgsize(2)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(10)=78063.7, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(21)=2466, null(21)=0, avgsize(21)=4, distinct(22)=2553, null(22)=0, avgsize(22)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ │ │ ├── stats: [rows=80661.49, distinct(1)=399.935, null(1)=0, avgsize(1)=3, distinct(2)=399.992, null(2)=0, avgsize(2)=20, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(10)=78049.9, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(21)=2466, null(21)=0, avgsize(21)=4, distinct(22)=2554, null(22)=0, avgsize(22)=4, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ │ │ ├── fd: ()-->(40), (1)-->(2,4), (4)==(39), (39)==(4), (1)==(12), (12)==(1)
│ │ │ │ ├── inner-join (lookup lineitem@l_sk [as=l1])
│ │ │ │ │ ├── save-table-name: q21_lookup_join_7
│ │ │ │ │ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_nationkey:4(int!null) l1.l_orderkey:10(int!null) l1.l_suppkey:12(int!null) l1.l_linenumber:13(int!null) n_nationkey:39(int!null) n_name:40(char!null)
│ │ │ │ │ ├── key columns: [1] = [12]
- │ │ │ │ │ ├── stats: [rows=242027.9, distinct(1)=399.935, null(1)=0, avgsize(1)=4, distinct(2)=399.992, null(2)=0, avgsize(2)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(10)=223835, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(13)=7, null(13)=0, avgsize(13)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ │ │ │ ├── stats: [rows=241984.5, distinct(1)=399.935, null(1)=0, avgsize(1)=3, distinct(2)=399.992, null(2)=0, avgsize(2)=20, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(10)=223798, null(10)=0, avgsize(10)=4, distinct(12)=399.935, null(12)=0, avgsize(12)=4, distinct(13)=7, null(13)=0, avgsize(13)=1, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ │ │ │ ├── key: (10,13)
│ │ │ │ │ ├── fd: ()-->(40), (1)-->(2,4), (4)==(39), (39)==(4), (10,13)-->(12), (1)==(12), (12)==(1)
│ │ │ │ │ ├── inner-join (lookup supplier)
@@ -112,20 +112,20 @@ top-k
│ │ │ │ │ │ ├── columns: s_suppkey:1(int!null) s_name:2(char!null) s_nationkey:4(int!null) n_nationkey:39(int!null) n_name:40(char!null)
│ │ │ │ │ │ ├── key columns: [1] = [1]
│ │ │ │ │ │ ├── lookup columns are key
- │ │ │ │ │ │ ├── stats: [rows=400, distinct(1)=399.935, null(1)=0, avgsize(1)=4, distinct(2)=399.992, null(2)=0, avgsize(2)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ │ │ │ │ ├── stats: [rows=400, distinct(1)=399.935, null(1)=0, avgsize(1)=3, distinct(2)=399.992, null(2)=0, avgsize(2)=20, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ ├── fd: ()-->(40), (1)-->(2,4), (4)==(39), (39)==(4)
│ │ │ │ │ │ ├── inner-join (lookup supplier@s_nk)
│ │ │ │ │ │ │ ├── save-table-name: q21_lookup_join_9
│ │ │ │ │ │ │ ├── columns: s_suppkey:1(int!null) s_nationkey:4(int!null) n_nationkey:39(int!null) n_name:40(char!null)
│ │ │ │ │ │ │ ├── key columns: [39] = [4]
- │ │ │ │ │ │ │ ├── stats: [rows=400, distinct(1)=399.935, null(1)=0, avgsize(1)=4, distinct(4)=1, null(4)=0, avgsize(4)=4, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ │ │ │ │ │ ├── stats: [rows=400, distinct(1)=399.935, null(1)=0, avgsize(1)=3, distinct(4)=1, null(4)=0, avgsize(4)=2, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ │ │ │ │ │ ├── key: (1)
│ │ │ │ │ │ │ ├── fd: ()-->(40), (1)-->(4), (4)==(39), (39)==(4)
│ │ │ │ │ │ │ ├── select
│ │ │ │ │ │ │ │ ├── save-table-name: q21_select_10
│ │ │ │ │ │ │ │ ├── columns: n_nationkey:39(int!null) n_name:40(char!null)
- │ │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(39)=1, null(39)=0, avgsize(39)=4, distinct(40)=1, null(40)=0, avgsize(40)=4]
+ │ │ │ │ │ │ │ │ ├── stats: [rows=1, distinct(39)=1, null(39)=0, avgsize(39)=1, distinct(40)=1, null(40)=0, avgsize(40)=10]
│ │ │ │ │ │ │ │ │ histogram(40)= 0 1
│ │ │ │ │ │ │ │ │ <--- 'SAUDI ARABIA'
│ │ │ │ │ │ │ │ ├── key: (39)
@@ -133,7 +133,7 @@ top-k
│ │ │ │ │ │ │ │ ├── scan nation
│ │ │ │ │ │ │ │ │ ├── save-table-name: q21_scan_11
│ │ │ │ │ │ │ │ │ ├── columns: n_nationkey:39(int!null) n_name:40(char!null)
- │ │ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(39)=25, null(39)=0, avgsize(39)=4, distinct(40)=25, null(40)=0, avgsize(40)=4]
+ │ │ │ │ │ │ │ │ │ ├── stats: [rows=25, distinct(39)=25, null(39)=0, avgsize(39)=1, distinct(40)=25, null(40)=0, avgsize(40)=10]
│ │ │ │ │ │ │ │ │ │ histogram(39)= 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1 0 1
│ │ │ │ │ │ │ │ │ │ <--- 0 --- 1 --- 2 --- 3 --- 4 --- 5 --- 6 --- 7 --- 8 --- 9 --- 10 --- 11 --- 12 --- 13 --- 14 --- 15 --- 16 --- 17 --- 18 --- 19 --- 20 --- 21 --- 22 --- 23 --- 24
│ │ │ │ │ │ │ │ │ │ histogram(40)= 0 1 23 1
@@ -172,8 +172,8 @@ column_names row_count distinct_count null_count
{s_name} 411 411 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{count_rows} 8390.00 20.41 <== 8390.00 493.53 <== 0.00 1.00
-{s_name} 8390.00 20.41 <== 8390.00 20.41 <== 0.00 1.00
+{count_rows} 8389.00 20.41 <== 8389.00 493.47 <== 0.00 1.00
+{s_name} 8389.00 20.41 <== 8389.00 20.41 <== 0.00 1.00
----Stats for q21_lookup_join_3----
column_names row_count distinct_count null_count
@@ -190,17 +190,17 @@ column_names row_count distinct_count null_count
{s_suppkey} 4141 411 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 17928.00 4.33 <== 2465.00 2.07 <== 0.00 1.00
-{l_orderkey} 17928.00 4.33 <== 17716.00 4.29 <== 0.00 1.00
-{l_receiptdate} 17928.00 4.33 <== 2551.00 2.17 <== 0.00 1.00
-{l_suppkey} 17928.00 4.33 <== 8351.00 20.32 <== 0.00 1.00
-{n_name} 17928.00 4.33 <== 1.00 1.00 0.00 1.00
-{n_nationkey} 17928.00 4.33 <== 1.00 1.00 0.00 1.00
-{o_orderkey} 17928.00 4.33 <== 17716.00 4.29 <== 0.00 1.00
-{o_orderstatus} 17928.00 4.33 <== 1.00 1.00 0.00 1.00
-{s_name} 17928.00 4.33 <== 8390.00 20.41 <== 0.00 1.00
-{s_nationkey} 17928.00 4.33 <== 1.00 1.00 0.00 1.00
-{s_suppkey} 17928.00 4.33 <== 8351.00 20.32 <== 0.00 1.00
+{l_commitdate} 17925.00 4.33 <== 2465.00 2.07 <== 0.00 1.00
+{l_orderkey} 17925.00 4.33 <== 17713.00 4.29 <== 0.00 1.00
+{l_receiptdate} 17925.00 4.33 <== 2552.00 2.17 <== 0.00 1.00
+{l_suppkey} 17925.00 4.33 <== 8351.00 20.32 <== 0.00 1.00
+{n_name} 17925.00 4.33 <== 1.00 1.00 0.00 1.00
+{n_nationkey} 17925.00 4.33 <== 1.00 1.00 0.00 1.00
+{o_orderkey} 17925.00 4.33 <== 17713.00 4.29 <== 0.00 1.00
+{o_orderstatus} 17925.00 4.33 <== 1.00 1.00 0.00 1.00
+{s_name} 17925.00 4.33 <== 8389.00 20.41 <== 0.00 1.00
+{s_nationkey} 17925.00 4.33 <== 1.00 1.00 0.00 1.00
+{s_suppkey} 17925.00 4.33 <== 8351.00 20.32 <== 0.00 1.00
----Stats for q21_lookup_join_4----
column_names row_count distinct_count null_count
@@ -215,15 +215,15 @@ column_names row_count distinct_count null_count
{s_suppkey} 8357 411 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 17928.00 2.15 <== 2466.00 1.05 0.00 1.00
-{l_orderkey} 17928.00 2.15 <== 17928.00 2.15 <== 0.00 1.00
-{l_receiptdate} 17928.00 2.15 <== 2553.00 1.07 0.00 1.00
-{l_suppkey} 17928.00 2.15 <== 400.00 1.03 0.00 1.00
-{n_name} 17928.00 2.15 <== 1.00 1.00 0.00 1.00
-{n_nationkey} 17928.00 2.15 <== 1.00 1.00 0.00 1.00
-{s_name} 17928.00 2.15 <== 400.00 1.03 0.00 1.00
-{s_nationkey} 17928.00 2.15 <== 1.00 1.00 0.00 1.00
-{s_suppkey} 17928.00 2.15 <== 400.00 1.03 0.00 1.00
+{l_commitdate} 17925.00 2.14 <== 2466.00 1.05 0.00 1.00
+{l_orderkey} 17925.00 2.14 <== 17925.00 2.15 <== 0.00 1.00
+{l_receiptdate} 17925.00 2.14 <== 2554.00 1.07 0.00 1.00
+{l_suppkey} 17925.00 2.14 <== 400.00 1.03 0.00 1.00
+{n_name} 17925.00 2.14 <== 1.00 1.00 0.00 1.00
+{n_nationkey} 17925.00 2.14 <== 1.00 1.00 0.00 1.00
+{s_name} 17925.00 2.14 <== 400.00 1.03 0.00 1.00
+{s_nationkey} 17925.00 2.14 <== 1.00 1.00 0.00 1.00
+{s_suppkey} 17925.00 2.14 <== 400.00 1.03 0.00 1.00
----Stats for q21_lookup_join_5----
column_names row_count distinct_count null_count
@@ -238,15 +238,15 @@ column_names row_count distinct_count null_count
{s_suppkey} 151237 411 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 26892.00 5.62 <== 2466.00 1.00 0.00 1.00
-{l_orderkey} 26892.00 5.62 <== 26892.00 5.38 <== 0.00 1.00
-{l_receiptdate} 26892.00 5.62 <== 2553.00 1.02 0.00 1.00
-{l_suppkey} 26892.00 5.62 <== 400.00 1.03 0.00 1.00
-{n_name} 26892.00 5.62 <== 1.00 1.00 0.00 1.00
-{n_nationkey} 26892.00 5.62 <== 1.00 1.00 0.00 1.00
-{s_name} 26892.00 5.62 <== 400.00 1.03 0.00 1.00
-{s_nationkey} 26892.00 5.62 <== 1.00 1.00 0.00 1.00
-{s_suppkey} 26892.00 5.62 <== 400.00 1.03 0.00 1.00
+{l_commitdate} 26887.00 5.62 <== 2466.00 1.00 0.00 1.00
+{l_orderkey} 26887.00 5.62 <== 26887.00 5.38 <== 0.00 1.00
+{l_receiptdate} 26887.00 5.62 <== 2554.00 1.02 0.00 1.00
+{l_suppkey} 26887.00 5.62 <== 400.00 1.03 0.00 1.00
+{n_name} 26887.00 5.62 <== 1.00 1.00 0.00 1.00
+{n_nationkey} 26887.00 5.62 <== 1.00 1.00 0.00 1.00
+{s_name} 26887.00 5.62 <== 400.00 1.03 0.00 1.00
+{s_nationkey} 26887.00 5.62 <== 1.00 1.00 0.00 1.00
+{s_suppkey} 26887.00 5.62 <== 400.00 1.03 0.00 1.00
----Stats for q21_lookup_join_6----
column_names row_count distinct_count null_count
@@ -261,15 +261,15 @@ column_names row_count distinct_count null_count
{s_suppkey} 156739 411 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_commitdate} 80676.00 1.94 <== 2466.00 1.00 0.00 1.00
-{l_orderkey} 80676.00 1.94 <== 78064.00 1.92 <== 0.00 1.00
-{l_receiptdate} 80676.00 1.94 <== 2553.00 1.02 0.00 1.00
-{l_suppkey} 80676.00 1.94 <== 400.00 1.03 0.00 1.00
-{n_name} 80676.00 1.94 <== 1.00 1.00 0.00 1.00
-{n_nationkey} 80676.00 1.94 <== 1.00 1.00 0.00 1.00
-{s_name} 80676.00 1.94 <== 400.00 1.03 0.00 1.00
-{s_nationkey} 80676.00 1.94 <== 1.00 1.00 0.00 1.00
-{s_suppkey} 80676.00 1.94 <== 400.00 1.03 0.00 1.00
+{l_commitdate} 80661.00 1.94 <== 2466.00 1.00 0.00 1.00
+{l_orderkey} 80661.00 1.94 <== 78050.00 1.92 <== 0.00 1.00
+{l_receiptdate} 80661.00 1.94 <== 2554.00 1.02 0.00 1.00
+{l_suppkey} 80661.00 1.94 <== 400.00 1.03 0.00 1.00
+{n_name} 80661.00 1.94 <== 1.00 1.00 0.00 1.00
+{n_nationkey} 80661.00 1.94 <== 1.00 1.00 0.00 1.00
+{s_name} 80661.00 1.94 <== 400.00 1.03 0.00 1.00
+{s_nationkey} 80661.00 1.94 <== 1.00 1.00 0.00 1.00
+{s_suppkey} 80661.00 1.94 <== 400.00 1.03 0.00 1.00
----Stats for q21_lookup_join_7----
column_names row_count distinct_count null_count
@@ -283,14 +283,14 @@ column_names row_count distinct_count null_count
{s_suppkey} 247140 411 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{l_linenumber} 242028.00 1.02 7.00 1.00 0.00 1.00
-{l_orderkey} 242028.00 1.02 223835.00 1.02 0.00 1.00
-{l_suppkey} 242028.00 1.02 400.00 1.03 0.00 1.00
-{n_name} 242028.00 1.02 1.00 1.00 0.00 1.00
-{n_nationkey} 242028.00 1.02 1.00 1.00 0.00 1.00
-{s_name} 242028.00 1.02 400.00 1.03 0.00 1.00
-{s_nationkey} 242028.00 1.02 1.00 1.00 0.00 1.00
-{s_suppkey} 242028.00 1.02 400.00 1.03 0.00 1.00
+{l_linenumber} 241984.00 1.02 7.00 1.00 0.00 1.00
+{l_orderkey} 241984.00 1.02 223798.00 1.02 0.00 1.00
+{l_suppkey} 241984.00 1.02 400.00 1.03 0.00 1.00
+{n_name} 241984.00 1.02 1.00 1.00 0.00 1.00
+{n_nationkey} 241984.00 1.02 1.00 1.00 0.00 1.00
+{s_name} 241984.00 1.02 400.00 1.03 0.00 1.00
+{s_nationkey} 241984.00 1.02 1.00 1.00 0.00 1.00
+{s_suppkey} 241984.00 1.02 400.00 1.03 0.00 1.00
----Stats for q21_lookup_join_8----
column_names row_count distinct_count null_count
diff --git a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q22 b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q22
index 021c6ec7c7fb..ab53585ea0d8 100644
--- a/pkg/sql/opt/memo/testdata/stats_quality/tpch/q22
+++ b/pkg/sql/opt/memo/testdata/stats_quality/tpch/q22
@@ -58,7 +58,7 @@ sort
├── save-table-name: q22_sort_1
├── columns: cntrycode:33(string) numcust:34(int!null) totacctbal:35(float!null)
├── immutable
- ├── stats: [rows=1e-10, distinct(33)=1e-10, null(33)=0, avgsize(33)=4, distinct(34)=1e-10, null(34)=0, avgsize(34)=4, distinct(35)=1e-10, null(35)=0, avgsize(35)=4]
+ ├── stats: [rows=1e-10, distinct(33)=1e-10, null(33)=0, avgsize(33)=17, distinct(34)=1e-10, null(34)=0, avgsize(34)=17, distinct(35)=1e-10, null(35)=0, avgsize(35)=17]
├── key: (33)
├── fd: (33)-->(34,35)
├── ordering: +33
@@ -67,39 +67,39 @@ sort
├── columns: cntrycode:33(string) count_rows:34(int!null) sum:35(float!null)
├── grouping columns: cntrycode:33(string)
├── immutable
- ├── stats: [rows=1e-10, distinct(33)=1e-10, null(33)=0, avgsize(33)=4, distinct(34)=1e-10, null(34)=0, avgsize(34)=4, distinct(35)=1e-10, null(35)=0, avgsize(35)=4]
+ ├── stats: [rows=1e-10, distinct(33)=1e-10, null(33)=0, avgsize(33)=17, distinct(34)=1e-10, null(34)=0, avgsize(34)=17, distinct(35)=1e-10, null(35)=0, avgsize(35)=17]
├── key: (33)
├── fd: (33)-->(34,35)
├── project
│ ├── save-table-name: q22_project_3
│ ├── columns: cntrycode:33(string) c_acctbal:6(float!null)
│ ├── immutable
- │ ├── stats: [rows=1e-10, distinct(6)=1e-10, null(6)=0, avgsize(6)=4, distinct(33)=1e-10, null(33)=0, avgsize(33)=4]
+ │ ├── stats: [rows=1e-10, distinct(6)=1e-10, null(6)=0, avgsize(6)=9, distinct(33)=1e-10, null(33)=0, avgsize(33)=17]
│ ├── anti-join (lookup orders@o_ck)
│ │ ├── save-table-name: q22_lookup_join_4
│ │ ├── columns: c_custkey:1(int!null) c_phone:5(char!null) c_acctbal:6(float!null)
│ │ ├── key columns: [1] = [23]
│ │ ├── immutable
- │ │ ├── stats: [rows=1e-10, distinct(1)=1e-10, null(1)=0, avgsize(1)=4, distinct(5)=1e-10, null(5)=0, avgsize(5)=4, distinct(6)=1e-10, null(6)=0, avgsize(6)=4]
+ │ │ ├── stats: [rows=1e-10, distinct(1)=1e-10, null(1)=0, avgsize(1)=4, distinct(5)=1e-10, null(5)=0, avgsize(5)=17, distinct(6)=1e-10, null(6)=0, avgsize(6)=9]
│ │ ├── key: (1)
│ │ ├── fd: (1)-->(5,6)
│ │ ├── select
│ │ │ ├── save-table-name: q22_select_5
│ │ │ ├── columns: c_custkey:1(int!null) c_phone:5(char!null) c_acctbal:6(float!null)
│ │ │ ├── immutable
- │ │ │ ├── stats: [rows=16666.67, distinct(1)=16659, null(1)=0, avgsize(1)=4, distinct(5)=16666.7, null(5)=0, avgsize(5)=4, distinct(6)=16666.7, null(6)=0, avgsize(6)=4]
+ │ │ │ ├── stats: [rows=16666.67, distinct(1)=16659, null(1)=0, avgsize(1)=4, distinct(5)=16666.7, null(5)=0, avgsize(5)=17, distinct(6)=16666.7, null(6)=0, avgsize(6)=9]
│ │ │ ├── key: (1)
│ │ │ ├── fd: (1)-->(5,6)
│ │ │ ├── scan customer
│ │ │ │ ├── save-table-name: q22_scan_6
│ │ │ │ ├── columns: c_custkey:1(int!null) c_phone:5(char!null) c_acctbal:6(float!null)
- │ │ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(5)=150000, null(5)=0, avgsize(5)=4, distinct(6)=140426, null(6)=0, avgsize(6)=4]
- │ │ │ │ │ histogram(1)= 0 5 769 5 765 5 732 5 744 5 731 5 754 5 772 5 757 5 713 5 741 5 808 5 744 5 739 5 687 5 820 5 761 5 782 5 632 5 711 5 692 5 648 5 770 5 765 5 702 5 751 5 807 5 794 5 735 5 807 5 719 5 773 5 781 5 684 5 748 5 682 5 703 5 794 5 718 5 807 5 674 5 747 5 677 5 813 5 666 5 766 5 822 5 703 5 676 5 765 5 693 5 723 5 780 5 793 5 770 5 696 5 775 5 764 5 884 5 696 5 688 5 637 5 789 5 702 5 732 5 697 5 769 5 739 5 744 5 861 5 791 5 726 5 793 5 730 5 763 5 789 5 797 5 775 5 862 5 780 5 746 5 783 5 743 5 822 5 806 5 775 5 727 5 724 5 799 5 707 5 757 5 614 5 747 5 704 5 740 5 749 5 735 5 741 5 807 5 827 5 816 5 702 5 699 5 803 5 793 5 672 5 831 5 694 5 746 5 731 5 686 5 685 5 695 5 828 5 756 5 722 5 749 5 790 5 758 5 750 5 782 5 733 5 778 5 762 5 758 5 731 5 778 5 663 5 696 5 684 5 796 5 770 5 656 5 690 5 747 5 782 5 785 5 751 5 697 5 663 5 766 5 695 5 866 5 813 5 765 5 901 5 747 5 683 5 706 5 689 5 734 5 715 5 752 5 855 5 771 5 717 5 794 5 760 5 827 5 747 5 757 5 767 5 726 5 690 5 787 5 783 5 744 5 761 5 746 5 793 5 696 5 749 5 745 5 755 5 800 5 778 5 814 5 826 5 700 5 740 5 773 5 713 5 824 5 792 5 702 5 734 5 751 5 716 5 718 5 722 5 784 5 778 5 700 5 714 5 739 5 748 5 697 5 751 5 663 5 740 5
- │ │ │ │ │ <--- 37 ----- 834 ----- 1623 ----- 2351 ----- 3101 ----- 3828 ----- 4598 ----- 5401 ----- 6176 ----- 6868 ----- 7613 ----- 8479 ----- 9230 ----- 9972 ----- 10613 ----- 11500 ----- 12282 ----- 13103 ----- 13624 ----- 14312 ----- 14962 ----- 15520 ----- 16319 ----- 17109 ----- 17780 ----- 18543 ----- 19408 ----- 20250 ----- 20984 ----- 21848 ----- 22551 ----- 23355 ----- 24174 ----- 24809 ----- 25567 ----- 26196 ----- 26868 ----- 27710 ----- 28412 ----- 29276 ----- 29889 ----- 30645 ----- 31264 ----- 32139 ----- 32736 ----- 33527 ----- 34418 ----- 35091 ----- 35709 ----- 36498 ----- 37150 ----- 37861 ----- 38677 ----- 39517 ----- 40316 ----- 40975 ----- 41782 ----- 42569 ----- 43565 ----- 44224 ----- 44867 ----- 45399 ----- 46231 ----- 46902 ----- 47630 ----- 48291 ----- 49087 ----- 49829 ----- 50580 ----- 51538 ----- 52375 ----- 53092 ----- 53932 ----- 54656 ----- 55442 ----- 56274 ----- 57121 ----- 57929 ----- 58888 ----- 59705 ----- 60460 ----- 61282 ----- 62031 ----- 62922 ----- 63785 ----- 64593 ----- 65311 ----- 66024 ----- 66875 ----- 67556 ----- 68331 ----- 68808 ----- 69564 ----- 70239 ----- 70983 ----- 71744 ----- 72478 ----- 73223 ----- 74088 ----- 74988 ----- 75868 ----- 76539 ----- 77203 ----- 78061 ----- 78901 ----- 79510 ----- 80417 ----- 81071 ----- 81826 ----- 82553 ----- 83191 ----- 83828 ----- 84485 ----- 85386 ----- 86159 ----- 86868 ----- 87628 ----- 88463 ----- 89240 ----- 90002 ----- 90822 ----- 91553 ----- 92367 ----- 93152 ----- 93929 ----- 94656 ----- 95470 ----- 96061 ----- 96720 ----- 97355 ----- 98200 ----- 98998 ----- 99573 ----- 100219 ----- 100975 ----- 101795 ----- 102620 ----- 103384 ----- 104044 ----- 104635 ----- 105426 ----- 106083 ----- 107049 ----- 107925 ----- 108715 ----- 109740 ----- 110496 ----- 111128 ----- 111807 ----- 112451 ----- 113184 ----- 113866 ----- 114619 ----- 115556 ----- 116344 ----- 117029 ----- 117859 ----- 118626 ----- 119515 ----- 120258 ----- 121021 ----- 121802 ----- 122505 ----- 123136 ----- 123953 ----- 124763 ----- 125501 ----- 126271 ----- 127012 ----- 127841 ----- 128483 ----- 129230 ----- 129970 ----- 130729 ----- 131569 ----- 132370 ----- 133235 ----- 134122 ----- 134773 ----- 135503 ----- 136294 ----- 136971 ----- 137854 ----- 138681 ----- 139336 ----- 140055 ----- 140806 ----- 141489 ----- 142177 ----- 142873 ----- 143685 ----- 144486 ----- 145138 ----- 145817 ----- 146545 ----- 147291 ----- 147936 ----- 148687 ----- 149260 ----- 149990
+ │ │ │ │ ├── stats: [rows=150000, distinct(1)=148813, null(1)=0, avgsize(1)=4, distinct(5)=150000, null(5)=0, avgsize(5)=17, distinct(6)=140628, null(6)=0, avgsize(6)=9]
+ │ │ │ │ │ histogram(1)= 0 0 0 5 745 5 746 5 711 5 780 5 738 5 835 5 697 5 757 5 704 5 696 5 753 5 678 5 813 5 873 5 736 5 840 5 703 5 745 5 710 5 763 5 742 5 673 5 702 5 793 5 732 5 752 5 707 5 751 5 722 5 814 5 789 5 671 5 643 5 706 5 723 5 757 5 713 5 760 5 766 5 711 5 858 5 702 5 695 5 697 5 823 5 857 5 712 5 808 5 754 5 739 5 694 5 782 5 792 5 751 5 758 5 749 5 798 5 685 5 692 5 792 5 710 5 771 5 724 5 853 5 713 5 823 5 772 5 656 5 763 5 672 5 735 5 810 5 786 5 709 5 731 5 702 5 708 5 669 5 733 5 744 5 758 5 800 5 682 5 716 5 716 5 729 5 778 5 721 5 766 5 820 5 757 5 739 5 799 5 780 5 710 5 749 5 754 5 750 5 699 5 821 5 759 5 818 5 763 5 854 5 779 5 810 5 783 5 686 5 703 5 776 5 675 5 812 5 745 5 759 5 793 5 751 5 761 5 798 5 794 5 729 5 696 5 699 5 831 5 709 5 747 5 722 5 768 5 729 5 702 5 729 5 698 5 767 5 792 5 726 5 737 5 671 5 721 5 842 5 701 5 704 5 708 5 726 5 695 5 665 5 688 5 653 5 690 5 734 5 789 5 659 5 785 5 733 5 740 5 826 5 745 5 929 5 899 5 743 5 790 5 825 5 779 5 677 5 697 5 756 5 693 5 862 5 772 5 783 5 757 5 799 5 778 5 752 5 715 5 709 5 790 5 789 5 865 5 808 5 772 5 743 5 751 5 742 5 676 5 684 5 744 5 709 5 679 5 817 5 755 5 754 5 797 5 709 5 748 5 679 5 751 5 775 5 736 5 790 5 714 5 0 0
+ │ │ │ │ │ <--- -9223372036854775808 --- 59 ----- 811 ----- 1565 ----- 2252 ----- 3068 ----- 3807 ----- 4720 ----- 5381 ----- 6155 ----- 6829 ----- 7487 ----- 8254 ----- 8876 ----- 9751 ----- 10728 ----- 11463 ----- 12385 ----- 13057 ----- 13810 ----- 14495 ----- 15281 ----- 16028 ----- 16640 ----- 17311 ----- 18151 ----- 18880 ----- 19645 ----- 20325 ----- 21088 ----- 21798 ----- 22674 ----- 23507 ----- 24115 ----- 24661 ----- 25340 ----- 26052 ----- 26827 ----- 27518 ----- 28298 ----- 29089 ----- 29777 ----- 30730 ----- 31401 ----- 32057 ----- 32718 ----- 33611 ----- 34562 ----- 35251 ----- 36117 ----- 36887 ----- 37629 ----- 38283 ----- 39104 ----- 39942 ----- 40705 ----- 41481 ----- 42241 ----- 43089 ----- 43725 ----- 44376 ----- 45214 ----- 45899 ----- 46700 ----- 47413 ----- 48356 ----- 49047 ----- 49939 ----- 50742 ----- 51316 ----- 52101 ----- 52710 ----- 53444 ----- 54313 ----- 55140 ----- 55823 ----- 56549 ----- 57219 ----- 57901 ----- 58503 ----- 59234 ----- 59984 ----- 60760 ----- 61613 ----- 62243 ----- 62941 ----- 63638 ----- 64360 ----- 65173 ----- 65880 ----- 66672 ----- 67560 ----- 68334 ----- 69075 ----- 69925 ----- 70742 ----- 71428 ----- 72189 ----- 72958 ----- 73720 ----- 74385 ----- 75274 ----- 76053 ----- 76936 ----- 77721 ----- 78666 ----- 79480 ----- 80349 ----- 81171 ----- 81810 ----- 82482 ----- 83292 ----- 83907 ----- 84780 ----- 85532 ----- 86310 ----- 87149 ----- 87912 ----- 88694 ----- 89543 ----- 90384 ----- 91106 ----- 91764 ----- 92428 ----- 93335 ----- 94018 ----- 94775 ----- 95484 ----- 96279 ----- 97001 ----- 97672 ----- 98394 ----- 99056 ----- 99850 ----- 100688 ----- 101405 ----- 102143 ----- 102751 ----- 103459 ----- 104384 ----- 105052 ----- 105727 ----- 106409 ----- 107125 ----- 107782 ----- 108377 ----- 109020 ----- 109588 ----- 110235 ----- 110967 ----- 111800 ----- 112382 ----- 113196 ----- 113913 ----- 114643 ----- 115529 ----- 116268 ----- 117329 ----- 118341 ----- 119076 ----- 119898 ----- 120782 ----- 121584 ----- 122186 ----- 122830 ----- 123591 ----- 124227 ----- 125175 ----- 125964 ----- 126773 ----- 127535 ----- 128374 ----- 129175 ----- 129928 ----- 130609 ----- 131279 ----- 132102 ----- 132923 ----- 133877 ----- 134732 ----- 135521 ----- 136257 ----- 137007 ----- 137740 ----- 138341 ----- 138958 ----- 139695 ----- 140364 ----- 140971 ----- 141841 ----- 142600 ----- 143356 ----- 144192 ----- 144861 ----- 145607 ----- 146214 ----- 146965 ----- 147761 ----- 148483 ----- 149306 ----- 149986 --- 9223372036854775807
│ │ │ │ │ histogram(5)= 0 1 1.5e+05 1
- │ │ │ │ │ <--- '10-104-665-3850' --------- '34-996-464-1615'
- │ │ │ │ │ histogram(6)= 0 15 1.4997e+05 15
- │ │ │ │ │ <--- -997.5 ------------ 9999.6904296875
+ │ │ │ │ │ <--- '10-100-106-1617' --------- '34-999-618-6881'
+ │ │ │ │ │ histogram(6)= 0 15 1.4997e+05 15
+ │ │ │ │ │ <--- -997.51 ------------ 9998.32
│ │ │ │ ├── key: (1)
│ │ │ │ └── fd: (1)-->(5,6)
│ │ │ └── filters
@@ -119,17 +119,17 @@ sort
│ │ │ │ ├── save-table-name: q22_select_8
│ │ │ │ ├── columns: c_phone:15(char!null) c_acctbal:16(float!null)
│ │ │ │ ├── immutable
- │ │ │ │ ├── stats: [rows=45460.66, distinct(15)=45460.7, null(15)=0, avgsize(15)=4, distinct(16)=45460.7, null(16)=0, avgsize(16)=4]
- │ │ │ │ │ histogram(16)= 0 0 45456 5
- │ │ │ │ │ <--- 0.0 ------- 9999.6904296875
+ │ │ │ │ ├── stats: [rows=45460.05, distinct(15)=45460.1, null(15)=0, avgsize(15)=17, distinct(16)=45460.1, null(16)=0, avgsize(16)=9]
+ │ │ │ │ │ histogram(16)= 0 0 45455 5
+ │ │ │ │ │ <--- 0.0 ------- 9998.32
│ │ │ │ ├── scan customer
│ │ │ │ │ ├── save-table-name: q22_scan_9
│ │ │ │ │ ├── columns: c_phone:15(char!null) c_acctbal:16(float!null)
- │ │ │ │ │ └── stats: [rows=150000, distinct(15)=150000, null(15)=0, avgsize(15)=4, distinct(16)=140426, null(16)=0, avgsize(16)=4]
+ │ │ │ │ │ └── stats: [rows=150000, distinct(15)=150000, null(15)=0, avgsize(15)=17, distinct(16)=140628, null(16)=0, avgsize(16)=9]
│ │ │ │ │ histogram(15)= 0 1 1.5e+05 1
- │ │ │ │ │ <--- '10-104-665-3850' --------- '34-996-464-1615'
- │ │ │ │ │ histogram(16)= 0 15 1.4997e+05 15
- │ │ │ │ │ <--- -997.5 ------------ 9999.6904296875
+ │ │ │ │ │ <--- '10-100-106-1617' --------- '34-999-618-6881'
+ │ │ │ │ │ histogram(16)= 0 15 1.4997e+05 15
+ │ │ │ │ │ <--- -997.51 ------------ 9998.32
│ │ │ │ └── filters
│ │ │ │ ├── c_acctbal:16 > 0.0 [type=bool, outer=(16), constraints=(/16: [/5e-324 - ]; tight)]
│ │ │ │ └── substring(c_phone:15, 1, 2) IN ('13', '17', '18', '23', '29', '30', '31') [type=bool, outer=(15), immutable]
@@ -204,7 +204,7 @@ column_names row_count distinct_count null_count
{c_phone} 150000 150000 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 150000.00 1.00 140426.00 1.00 0.00 1.00
+{c_acctbal} 150000.00 1.00 140628.00 1.00 0.00 1.00
{c_custkey} 150000.00 1.00 148813.00 1.00 0.00 1.00
{c_phone} 150000.00 1.00 150000.00 1.00 0.00 1.00
@@ -221,8 +221,8 @@ column_names row_count distinct_count null_count
{c_phone} 38120 38046 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 45461.00 1.19 45461.00 1.22 0.00 1.00
-{c_phone} 45461.00 1.19 45461.00 1.19 0.00 1.00
+{c_acctbal} 45460.00 1.19 45460.00 1.22 0.00 1.00
+{c_phone} 45460.00 1.19 45460.00 1.19 0.00 1.00
----Stats for q22_scan_9----
column_names row_count distinct_count null_count
@@ -230,7 +230,7 @@ column_names row_count distinct_count null_count
{c_phone} 150000 150000 0
~~~~
column_names row_count_est row_count_err distinct_count_est distinct_count_err null_count_est null_count_err
-{c_acctbal} 150000.00 1.00 140426.00 1.00 0.00 1.00
+{c_acctbal} 150000.00 1.00 140628.00 1.00 0.00 1.00
{c_phone} 150000.00 1.00 150000.00 1.00 0.00 1.00
----
----
diff --git a/pkg/sql/opt/testutils/opttester/testfixtures/tpcc_stats_w10 b/pkg/sql/opt/testutils/opttester/testfixtures/tpcc_stats_w10
index bf4954cd9948..0f764a1b5817 100644
--- a/pkg/sql/opt/testutils/opttester/testfixtures/tpcc_stats_w10
+++ b/pkg/sql/opt/testutils/opttester/testfixtures/tpcc_stats_w10
@@ -1,72 +1,72 @@
-# Stats for TPC-C with 10 warehouses, collected soon after the initial data
-# import.
+# Statistics for tpcc
exec-ddl
ALTER TABLE "customer" INJECT STATISTICS '[
{
+ "avg_size": 1,
"columns": [
"c_w_id"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 29700,
+ "num_eq": 29730,
"num_range": 0,
"upper_bound": "0"
},
{
"distinct_range": 0,
- "num_eq": 30360,
+ "num_eq": 28620,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 29250,
+ "num_eq": 29430,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 30390,
+ "num_eq": 29850,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 30570,
+ "num_eq": 29340,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 29250,
+ "num_eq": 30600,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 30150,
+ "num_eq": 30270,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 31110,
+ "num_eq": 31170,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 30330,
+ "num_eq": 29880,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 28890,
+ "num_eq": 31110,
"num_range": 0,
"upper_bound": "9"
}
@@ -78,69 +78,70 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 1,
"columns": [
"c_d_id"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 29910,
+ "num_eq": 30510,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 29730,
+ "num_eq": 30150,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 31980,
+ "num_eq": 29610,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 29850,
+ "num_eq": 31320,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 30180,
+ "num_eq": 29040,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 29040,
+ "num_eq": 29730,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 30630,
+ "num_eq": 30330,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 30150,
+ "num_eq": 29940,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 29430,
+ "num_eq": 29250,
"num_range": 0,
"upper_bound": "9"
},
{
"distinct_range": 0,
- "num_eq": 29100,
+ "num_eq": 30120,
"num_range": 0,
"upper_bound": "10"
}
@@ -152,11 +153,12 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
"c_w_id",
"c_d_id"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 100,
"histo_col_type": "",
"name": "__auto__",
@@ -164,15 +166,16 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 3,
"columns": [
"c_id"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 2999,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 90,
+ "num_eq": 120,
"num_range": 0,
"upper_bound": "1"
},
@@ -182,1192 +185,1192 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"num_range": 1440,
"upper_bound": "14"
},
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "30"
- },
{
"distinct_range": 12.995357142857143,
- "num_eq": 90,
+ "num_eq": 120,
"num_range": 1470,
- "upper_bound": "44"
+ "upper_bound": "28"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 17.99357142857143,
"num_eq": 120,
- "num_range": 1380,
- "upper_bound": "59"
+ "num_range": 1470,
+ "upper_bound": "47"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "74"
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "62"
},
{
- "distinct_range": 18.993214285714288,
+ "distinct_range": 11.995714285714286,
"num_eq": 90,
- "num_range": 1410,
- "upper_bound": "94"
+ "num_range": 1470,
+ "upper_bound": "75"
},
{
- "distinct_range": 17.99357142857143,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "90"
+ },
+ {
+ "distinct_range": 15.994285714285715,
"num_eq": 90,
"num_range": 1440,
- "upper_bound": "113"
+ "upper_bound": "107"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 11.995714285714286,
"num_eq": 150,
"num_range": 1470,
- "upper_bound": "130"
+ "upper_bound": "120"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 180,
+ "distinct_range": 11.995714285714286,
+ "num_eq": 240,
"num_range": 1410,
+ "upper_bound": "133"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1440,
"upper_bound": "148"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1470,
- "upper_bound": "164"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "163"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 15.994285714285715,
"num_eq": 60,
"num_range": 1470,
- "upper_bound": "178"
+ "upper_bound": "180"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 300,
- "num_range": 1260,
- "upper_bound": "189"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "194"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "207"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1470,
+ "upper_bound": "210"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 12.995357142857143,
"num_eq": 150,
- "num_range": 1440,
- "upper_bound": "222"
+ "num_range": 1470,
+ "upper_bound": "224"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
+ "distinct_range": 19.992857142857144,
+ "num_eq": 150,
"num_range": 1440,
- "upper_bound": "240"
+ "upper_bound": "245"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 14.994642857142857,
"num_eq": 210,
- "num_range": 1350,
- "upper_bound": "257"
+ "num_range": 1470,
+ "upper_bound": "261"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "270"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "279"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
"num_range": 1440,
- "upper_bound": "283"
- },
- {
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1470,
"upper_bound": "296"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "312"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "311"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 13.995000000000001,
"num_eq": 180,
- "num_range": 1320,
+ "num_range": 1410,
"upper_bound": "326"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
"num_range": 1410,
- "upper_bound": "341"
+ "upper_bound": "342"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1380,
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1440,
"upper_bound": "355"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1290,
- "upper_bound": "368"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "373"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 16.993928571428572,
"num_eq": 60,
- "num_range": 1470,
- "upper_bound": "382"
+ "num_range": 1410,
+ "upper_bound": "391"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "400"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "402"
},
{
"distinct_range": 12.995357142857143,
"num_eq": 90,
- "num_range": 1470,
- "upper_bound": "414"
+ "num_range": 1410,
+ "upper_bound": "416"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 90,
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
"num_range": 1410,
- "upper_bound": "433"
+ "upper_bound": "434"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1470,
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
"upper_bound": "448"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "460"
- },
- {
- "distinct_range": 10.99607142857143,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "472"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "465"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 180,
+ "num_eq": 120,
"num_range": 1380,
- "upper_bound": "486"
+ "upper_bound": "479"
},
{
"distinct_range": 15.994285714285715,
"num_eq": 90,
- "num_range": 1380,
- "upper_bound": "503"
+ "num_range": 1440,
+ "upper_bound": "496"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1440,
- "upper_bound": "520"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "512"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 16.993928571428572,
"num_eq": 180,
- "num_range": 1320,
- "upper_bound": "533"
+ "num_range": 1410,
+ "upper_bound": "530"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1440,
+ "distinct_range": 16.993928571428572,
+ "num_eq": 240,
+ "num_range": 1380,
"upper_bound": "548"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 30,
+ "num_eq": 240,
"num_range": 1440,
"upper_bound": "563"
},
- {
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "577"
- },
{
"distinct_range": 11.995714285714286,
"num_eq": 120,
- "num_range": 1440,
- "upper_bound": "590"
+ "num_range": 1380,
+ "upper_bound": "576"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 15.994285714285715,
"num_eq": 90,
- "num_range": 1410,
- "upper_bound": "605"
+ "num_range": 1440,
+ "upper_bound": "593"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "620"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "609"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
"num_range": 1380,
- "upper_bound": "633"
+ "upper_bound": "625"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 9.996428571428572,
"num_eq": 120,
- "num_range": 1410,
- "upper_bound": "648"
- },
- {
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "662"
+ "num_range": 1440,
+ "upper_bound": "636"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 14.994642857142857,
"num_eq": 60,
- "num_range": 1410,
- "upper_bound": "676"
+ "num_range": 1440,
+ "upper_bound": "652"
},
{
"distinct_range": 15.994285714285715,
"num_eq": 90,
"num_range": 1410,
- "upper_bound": "693"
+ "upper_bound": "669"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 30,
- "num_range": 1440,
- "upper_bound": "710"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "685"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "722"
- },
- {
- "distinct_range": 14.994642857142857,
+ "distinct_range": 12.995357142857143,
"num_eq": 180,
- "num_range": 1320,
- "upper_bound": "738"
+ "num_range": 1410,
+ "upper_bound": "699"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "752"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "717"
},
{
"distinct_range": 13.995000000000001,
"num_eq": 120,
- "num_range": 1350,
- "upper_bound": "767"
+ "num_range": 1380,
+ "upper_bound": "732"
},
{
"distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "749"
+ },
+ {
+ "distinct_range": 14.994642857142857,
"num_eq": 150,
- "num_range": 1410,
- "upper_bound": "784"
+ "num_range": 1440,
+ "upper_bound": "765"
},
{
"distinct_range": 14.994642857142857,
"num_eq": 120,
- "num_range": 1440,
- "upper_bound": "800"
+ "num_range": 1380,
+ "upper_bound": "781"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "815"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "793"
},
{
- "distinct_range": 8.996785714285714,
- "num_eq": 120,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
"num_range": 1410,
- "upper_bound": "825"
+ "upper_bound": "810"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 14.994642857142857,
"num_eq": 240,
- "num_range": 1350,
- "upper_bound": "839"
+ "num_range": 1290,
+ "upper_bound": "826"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "837"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
"num_range": 1410,
- "upper_bound": "853"
+ "upper_bound": "852"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 240,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "869"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
"num_range": 1260,
- "upper_bound": "867"
+ "upper_bound": "884"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
"num_range": 1380,
- "upper_bound": "881"
+ "upper_bound": "902"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1440,
- "upper_bound": "895"
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "916"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 210,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
"num_range": 1440,
- "upper_bound": "915"
+ "upper_bound": "931"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 16.993928571428572,
"num_eq": 120,
"num_range": 1410,
- "upper_bound": "928"
- },
- {
- "distinct_range": 12.995357142857143,
- "num_eq": 240,
- "num_range": 1380,
- "upper_bound": "942"
+ "upper_bound": "949"
},
{
"distinct_range": 14.994642857142857,
"num_eq": 120,
"num_range": 1410,
- "upper_bound": "958"
+ "upper_bound": "965"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 11.995714285714286,
"num_eq": 90,
"num_range": 1440,
- "upper_bound": "975"
+ "upper_bound": "978"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1440,
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
"upper_bound": "991"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "1008"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1006"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1023"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1024"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1260,
- "upper_bound": "1036"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1039"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 10.99607142857143,
"num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1053"
+ "num_range": 1350,
+ "upper_bound": "1051"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 210,
- "num_range": 1320,
- "upper_bound": "1067"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1063"
},
{
- "distinct_range": 14.994642857142857,
+ "distinct_range": 12.995357142857143,
"num_eq": 150,
- "num_range": 1410,
- "upper_bound": "1083"
+ "num_range": 1350,
+ "upper_bound": "1077"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1440,
- "upper_bound": "1099"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1091"
},
{
"distinct_range": 15.994285714285715,
"num_eq": 90,
"num_range": 1440,
- "upper_bound": "1116"
+ "upper_bound": "1108"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1134"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "1119"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1146"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1132"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1165"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1147"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1162"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1178"
},
{
"distinct_range": 17.99357142857143,
- "num_eq": 270,
- "num_range": 1230,
- "upper_bound": "1184"
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1197"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1200"
+ "num_eq": 240,
+ "num_range": 1290,
+ "upper_bound": "1213"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 14.994642857142857,
"num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1217"
+ "num_range": 1380,
+ "upper_bound": "1229"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 15.994285714285715,
"num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1230"
+ "num_range": 1350,
+ "upper_bound": "1246"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "1247"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1261"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 60,
+ "num_eq": 30,
"num_range": 1440,
- "upper_bound": "1260"
+ "upper_bound": "1274"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
"num_range": 1410,
- "upper_bound": "1276"
+ "upper_bound": "1289"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 180,
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
"num_range": 1410,
- "upper_bound": "1288"
- },
- {
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "1301"
+ "upper_bound": "1303"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1440,
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1380,
"upper_bound": "1315"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1440,
- "upper_bound": "1328"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1327"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1410,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 240,
+ "num_range": 1440,
"upper_bound": "1344"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1380,
+ "num_eq": 60,
+ "num_range": 1440,
"upper_bound": "1361"
},
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1377"
- },
{
"distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1391"
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1375"
},
{
"distinct_range": 17.99357142857143,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1394"
+ },
+ {
+ "distinct_range": 14.994642857142857,
"num_eq": 120,
- "num_range": 1440,
+ "num_range": 1410,
"upper_bound": "1410"
},
{
"distinct_range": 12.995357142857143,
"num_eq": 90,
- "num_range": 1410,
+ "num_range": 1380,
"upper_bound": "1424"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1440"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1436"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 14.994642857142857,
"num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1455"
+ "num_range": 1410,
+ "upper_bound": "1452"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "1465"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
"num_range": 1410,
- "upper_bound": "1470"
+ "upper_bound": "1480"
},
{
- "distinct_range": 14.994642857142857,
+ "distinct_range": 10.99607142857143,
"num_eq": 150,
"num_range": 1440,
- "upper_bound": "1486"
- },
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1502"
+ "upper_bound": "1492"
},
{
- "distinct_range": 10.99607142857143,
+ "distinct_range": 12.995357142857143,
"num_eq": 180,
"num_range": 1440,
- "upper_bound": "1514"
+ "upper_bound": "1506"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1528"
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1520"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 240,
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
"num_range": 1380,
- "upper_bound": "1541"
+ "upper_bound": "1534"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
"num_range": 1440,
- "upper_bound": "1558"
+ "upper_bound": "1552"
},
{
- "distinct_range": 14.994642857142857,
+ "distinct_range": 18.993214285714288,
"num_eq": 60,
"num_range": 1440,
- "upper_bound": "1574"
+ "upper_bound": "1572"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 16.993928571428572,
"num_eq": 90,
"num_range": 1380,
- "upper_bound": "1587"
+ "upper_bound": "1590"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "1602"
- },
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
"num_range": 1410,
- "upper_bound": "1618"
- },
- {
- "distinct_range": 12.995357142857143,
- "num_eq": 210,
- "num_range": 1380,
- "upper_bound": "1632"
+ "upper_bound": "1607"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 11.995714285714286,
"num_eq": 120,
"num_range": 1380,
- "upper_bound": "1646"
+ "upper_bound": "1620"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1657"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1632"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 14.994642857142857,
"num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1670"
+ "num_range": 1410,
+ "upper_bound": "1648"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 14.994642857142857,
"num_eq": 150,
- "num_range": 1320,
- "upper_bound": "1687"
+ "num_range": 1440,
+ "upper_bound": "1664"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1702"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "1677"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
+ "distinct_range": 9.996428571428572,
+ "num_eq": 60,
"num_range": 1410,
- "upper_bound": "1719"
+ "upper_bound": "1688"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 60,
+ "num_eq": 90,
"num_range": 1440,
- "upper_bound": "1735"
+ "upper_bound": "1704"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
"num_range": 1440,
- "upper_bound": "1750"
- },
- {
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1765"
+ "upper_bound": "1720"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "1781"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1737"
},
{
- "distinct_range": 16.993928571428572,
+ "distinct_range": 13.995000000000001,
"num_eq": 90,
"num_range": 1380,
- "upper_bound": "1799"
+ "upper_bound": "1752"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 12.995357142857143,
"num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1816"
- },
- {
- "distinct_range": 17.99357142857143,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1835"
+ "num_range": 1440,
+ "upper_bound": "1766"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1851"
- },
- {
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
+ "num_eq": 120,
"num_range": 1440,
- "upper_bound": "1868"
+ "upper_bound": "1782"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "1881"
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1795"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "1897"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1810"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
"num_range": 1440,
- "upper_bound": "1910"
+ "upper_bound": "1828"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 180,
+ "num_eq": 30,
"num_range": 1440,
- "upper_bound": "1923"
- },
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1939"
+ "upper_bound": "1841"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1290,
- "upper_bound": "1954"
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1856"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 270,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
"num_range": 1410,
- "upper_bound": "1965"
- },
- {
- "distinct_range": 12.995357142857143,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "1979"
+ "upper_bound": "1871"
},
{
"distinct_range": 12.995357142857143,
"num_eq": 180,
- "num_range": 1260,
- "upper_bound": "1993"
- },
- {
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
"num_range": 1380,
- "upper_bound": "2008"
+ "upper_bound": "1885"
},
{
- "distinct_range": 10.99607142857143,
+ "distinct_range": 14.994642857142857,
"num_eq": 120,
- "num_range": 1350,
- "upper_bound": "2020"
+ "num_range": 1410,
+ "upper_bound": "1901"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 13.995000000000001,
"num_eq": 120,
- "num_range": 1410,
- "upper_bound": "2034"
+ "num_range": 1350,
+ "upper_bound": "1916"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 30,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
"num_range": 1410,
- "upper_bound": "2048"
- },
- {
- "distinct_range": 16.993928571428572,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2066"
+ "upper_bound": "1931"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 15.994285714285715,
"num_eq": 90,
"num_range": 1350,
- "upper_bound": "2081"
+ "upper_bound": "1948"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
"num_range": 1410,
- "upper_bound": "2097"
- },
- {
- "distinct_range": 11.995714285714286,
- "num_eq": 240,
- "num_range": 1320,
- "upper_bound": "2110"
+ "upper_bound": "1963"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 120,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
"num_range": 1410,
- "upper_bound": "2130"
- },
- {
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2144"
+ "upper_bound": "1978"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2159"
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "1993"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "2175"
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2009"
},
{
- "distinct_range": 14.994642857142857,
+ "distinct_range": 17.99357142857143,
"num_eq": 90,
"num_range": 1350,
- "upper_bound": "2191"
+ "upper_bound": "2028"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 30,
+ "num_eq": 90,
"num_range": 1410,
- "upper_bound": "2208"
+ "upper_bound": "2045"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2224"
- },
- {
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2243"
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2061"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2258"
- },
- {
- "distinct_range": 11.995714285714286,
"num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2271"
+ "num_range": 1350,
+ "upper_bound": "2076"
},
{
- "distinct_range": 9.996428571428572,
+ "distinct_range": 15.994285714285715,
"num_eq": 90,
"num_range": 1410,
- "upper_bound": "2282"
+ "upper_bound": "2093"
},
{
"distinct_range": 11.995714285714286,
"num_eq": 90,
"num_range": 1380,
- "upper_bound": "2295"
+ "upper_bound": "2106"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 14.994642857142857,
"num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2308"
+ "num_range": 1410,
+ "upper_bound": "2122"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "2322"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2134"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 60,
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
"num_range": 1380,
- "upper_bound": "2336"
+ "upper_bound": "2147"
},
{
- "distinct_range": 12.995357142857143,
+ "distinct_range": 8.996785714285714,
"num_eq": 150,
- "num_range": 1290,
- "upper_bound": "2350"
+ "num_range": 1380,
+ "upper_bound": "2157"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2366"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2176"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2382"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2191"
},
{
"distinct_range": 16.993928571428572,
"num_eq": 180,
- "num_range": 1320,
- "upper_bound": "2400"
- },
- {
- "distinct_range": 10.99607142857143,
- "num_eq": 210,
- "num_range": 1230,
- "upper_bound": "2412"
+ "num_range": 1410,
+ "upper_bound": "2209"
},
{
- "distinct_range": 14.994642857142857,
+ "distinct_range": 16.993928571428572,
"num_eq": 60,
"num_range": 1380,
- "upper_bound": "2428"
+ "upper_bound": "2227"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 210,
- "num_range": 1230,
- "upper_bound": "2444"
+ "distinct_range": 8.996785714285714,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2237"
},
{
- "distinct_range": 10.99607142857143,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2254"
+ },
+ {
+ "distinct_range": 12.995357142857143,
"num_eq": 150,
"num_range": 1320,
- "upper_bound": "2456"
+ "upper_bound": "2268"
},
{
- "distinct_range": 8.996785714285714,
+ "distinct_range": 14.994642857142857,
"num_eq": 90,
"num_range": 1350,
- "upper_bound": "2466"
- },
- {
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "2481"
+ "upper_bound": "2284"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 11.995714285714286,
"num_eq": 90,
"num_range": 1410,
- "upper_bound": "2496"
+ "upper_bound": "2297"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 12.995357142857143,
"num_eq": 60,
- "num_range": 1410,
- "upper_bound": "2511"
+ "num_range": 1380,
+ "upper_bound": "2311"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2524"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2325"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 60,
+ "num_eq": 90,
"num_range": 1410,
- "upper_bound": "2537"
- },
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "2553"
+ "upper_bound": "2338"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 12.995357142857143,
"num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2566"
+ "num_range": 1350,
+ "upper_bound": "2352"
},
{
- "distinct_range": 14.994642857142857,
+ "distinct_range": 11.995714285714286,
"num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2582"
+ "num_range": 1290,
+ "upper_bound": "2365"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
"num_range": 1410,
- "upper_bound": "2597"
+ "upper_bound": "2383"
},
{
"distinct_range": 10.99607142857143,
- "num_eq": 180,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2395"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 120,
"num_range": 1350,
- "upper_bound": "2609"
+ "upper_bound": "2414"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "2625"
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2430"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "2644"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2448"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2659"
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2463"
},
{
"distinct_range": 14.994642857142857,
"num_eq": 90,
"num_range": 1380,
- "upper_bound": "2675"
- },
- {
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2690"
+ "upper_bound": "2479"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2706"
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2495"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
"num_range": 1320,
- "upper_bound": "2723"
+ "upper_bound": "2507"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1290,
- "upper_bound": "2739"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2527"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 13.995000000000001,
"num_eq": 120,
"num_range": 1380,
- "upper_bound": "2752"
+ "upper_bound": "2542"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 210,
- "num_range": 1320,
- "upper_bound": "2768"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2557"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2782"
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2571"
},
{
- "distinct_range": 13.995000000000001,
+ "distinct_range": 9.996428571428572,
"num_eq": 150,
- "num_range": 1260,
- "upper_bound": "2797"
+ "num_range": 1290,
+ "upper_bound": "2582"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
+ "distinct_range": 12.995357142857143,
+ "num_eq": 240,
"num_range": 1350,
- "upper_bound": "2813"
+ "upper_bound": "2596"
},
{
"distinct_range": 14.994642857142857,
"num_eq": 150,
- "num_range": 1260,
- "upper_bound": "2829"
+ "num_range": 1380,
+ "upper_bound": "2612"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
+ "distinct_range": 9.996428571428572,
+ "num_eq": 150,
"num_range": 1380,
- "upper_bound": "2845"
+ "upper_bound": "2623"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1320,
- "upper_bound": "2858"
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2636"
},
{
- "distinct_range": 15.994285714285715,
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "2648"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2663"
+ },
+ {
+ "distinct_range": 10.99607142857143,
"num_eq": 60,
"num_range": 1350,
- "upper_bound": "2875"
+ "upper_bound": "2675"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "2689"
},
{
"distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1290,
- "upper_bound": "2894"
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2708"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 120,
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
"num_range": 1350,
- "upper_bound": "2905"
+ "upper_bound": "2724"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 210,
- "num_range": 1320,
- "upper_bound": "2922"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "2739"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
- "num_range": 1290,
- "upper_bound": "2935"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1350,
+ "upper_bound": "2755"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
"num_range": 1350,
- "upper_bound": "2954"
+ "upper_bound": "2772"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1230,
- "upper_bound": "2969"
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "2787"
},
{
- "distinct_range": 16.993928571428572,
+ "distinct_range": 12.995357142857143,
"num_eq": 120,
"num_range": 1260,
- "upper_bound": "2987"
+ "upper_bound": "2801"
},
{
- "distinct_range": 11.995714285714286,
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2816"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2827"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 240,
+ "num_range": 1290,
+ "upper_bound": "2843"
+ },
+ {
+ "distinct_range": 14.994642857142857,
"num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2859"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2870"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1320,
+ "upper_bound": "2883"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2899"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1260,
+ "upper_bound": "2911"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1230,
+ "upper_bound": "2926"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1260,
+ "upper_bound": "2941"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1290,
+ "upper_bound": "2957"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
"num_range": 1230,
+ "upper_bound": "2973"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1200,
+ "upper_bound": "2988"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1260,
"upper_bound": "3000"
}
],
@@ -1378,12 +1381,13 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 5,
"columns": [
"c_w_id",
"c_d_id",
"c_id"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 295745,
"histo_col_type": "",
"name": "__auto__",
@@ -1391,1191 +1395,1186 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 14,
"columns": [
"c_last"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1000,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 750,
+ "num_eq": 720,
"num_range": 0,
"upper_bound": "ABLEABLEABLE"
},
{
- "distinct_range": 6.432377049180328,
- "num_eq": 240,
- "num_range": 1290,
+ "distinct_range": 5.586317477284874,
+ "num_eq": 360,
+ "num_range": 1170,
"upper_bound": "ABLEABLEBAR"
},
{
- "distinct_range": 6.731557377049181,
- "num_eq": 240,
+ "distinct_range": 6.445750935328701,
+ "num_eq": 180,
"num_range": 1350,
- "upper_bound": "ABLEABLEPRES"
+ "upper_bound": "ABLEABLEOUGHT"
},
{
- "distinct_range": 7.030737704918033,
+ "distinct_range": 7.018706574024586,
"num_eq": 90,
- "num_range": 1410,
+ "num_range": 1470,
"upper_bound": "ABLEANTICALLY"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 600,
- "num_range": 1140,
- "upper_bound": "ABLEATIONANTI"
+ "distinct_range": 6.875467664350614,
+ "num_eq": 330,
+ "num_range": 1440,
+ "upper_bound": "ABLEATIONATION"
},
{
- "distinct_range": 7.180327868852459,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "ABLEATIONOUGHT"
+ "distinct_range": 5.729556386958845,
+ "num_eq": 300,
+ "num_range": 1200,
+ "upper_bound": "ABLEBARABLE"
},
{
- "distinct_range": 6.731557377049181,
- "num_eq": 180,
+ "distinct_range": 6.445750935328701,
+ "num_eq": 150,
"num_range": 1350,
- "upper_bound": "ABLEBARATION"
+ "upper_bound": "ABLEBARPRI"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 660,
- "num_range": 1200,
- "upper_bound": "ABLECALLYATION"
+ "distinct_range": 6.445750935328701,
+ "num_eq": 300,
+ "num_range": 1350,
+ "upper_bound": "ABLECALLYCALLY"
},
{
- "distinct_range": 6.282786885245902,
- "num_eq": 270,
- "num_range": 1260,
- "upper_bound": "ABLECALLYPRI"
+ "distinct_range": 6.732228754676643,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "ABLEEINGATION"
},
{
- "distinct_range": 6.581967213114754,
- "num_eq": 210,
- "num_range": 1320,
- "upper_bound": "ABLEEINGEING"
+ "distinct_range": 5.156600748262961,
+ "num_eq": 480,
+ "num_range": 1080,
+ "upper_bound": "ABLEEINGOUGHT"
},
{
- "distinct_range": 2.3934426229508197,
- "num_eq": 1650,
- "num_range": 480,
+ "distinct_range": 0,
+ "num_eq": 2010,
+ "num_range": 0,
"upper_bound": "ABLEEINGPRES"
},
{
- "distinct_range": 7.030737704918033,
- "num_eq": 60,
- "num_range": 1410,
+ "distinct_range": 6.159273115980759,
+ "num_eq": 240,
+ "num_range": 1290,
"upper_bound": "ABLEESEBAR"
},
{
- "distinct_range": 6.881147540983607,
- "num_eq": 420,
- "num_range": 1380,
- "upper_bound": "ABLEOUGHTATION"
+ "distinct_range": 6.445750935328701,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "ABLEOUGHTANTI"
},
{
- "distinct_range": 4.487704918032787,
- "num_eq": 990,
- "num_range": 900,
+ "distinct_range": 6.732228754676643,
+ "num_eq": 630,
+ "num_range": 1410,
"upper_bound": "ABLEOUGHTPRES"
},
{
- "distinct_range": 7.180327868852459,
- "num_eq": 210,
+ "distinct_range": 6.875467664350614,
+ "num_eq": 90,
"num_range": 1440,
"upper_bound": "ABLEPRESPRI"
},
{
- "distinct_range": 1.944672131147541,
- "num_eq": 1740,
- "num_range": 390,
+ "distinct_range": 1.4323890967397113,
+ "num_eq": 1860,
+ "num_range": 300,
"upper_bound": "ABLEPRIBAR"
},
{
- "distinct_range": 7.180327868852459,
- "num_eq": 30,
- "num_range": 1440,
- "upper_bound": "ANTIABLEESE"
+ "distinct_range": 6.30251202565473,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "ANTIABLEEING"
},
{
- "distinct_range": 6.881147540983607,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "ANTIANTIEING"
+ "distinct_range": 6.732228754676643,
+ "num_eq": 240,
+ "num_range": 1410,
+ "upper_bound": "ANTIANTIOUGHT"
},
{
- "distinct_range": 7.030737704918033,
- "num_eq": 240,
+ "distinct_range": 6.732228754676643,
+ "num_eq": 480,
"num_range": 1410,
- "upper_bound": "ANTIATIONESE"
+ "upper_bound": "ANTIBARABLE"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 1950,
- "num_range": 990,
+ "distinct_range": 0,
+ "num_eq": 2010,
+ "num_range": 0,
"upper_bound": "ANTIBARANTI"
},
{
- "distinct_range": 6.731557377049181,
- "num_eq": 210,
- "num_range": 1350,
+ "distinct_range": 6.016034206306788,
+ "num_eq": 270,
+ "num_range": 1260,
"upper_bound": "ANTIBARCALLY"
},
{
- "distinct_range": 6.881147540983607,
+ "distinct_range": 6.588989845002672,
"num_eq": 420,
"num_range": 1380,
"upper_bound": "ANTIBAROUGHT"
},
{
- "distinct_range": 6.731557377049181,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "ANTICALLYABLE"
+ "distinct_range": 6.588989845002672,
+ "num_eq": 300,
+ "num_range": 1380,
+ "upper_bound": "ANTICALLYANTI"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 390,
- "num_range": 1200,
+ "distinct_range": 5.872795296632817,
+ "num_eq": 480,
+ "num_range": 1230,
"upper_bound": "ANTICALLYCALLY"
},
{
- "distinct_range": 7.030737704918033,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "ANTIEINGCALLY"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 300,
+ "num_range": 1230,
+ "upper_bound": "ANTIEINGATION"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 270,
- "num_range": 1200,
- "upper_bound": "ANTIESECALLY"
+ "distinct_range": 6.30251202565473,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "ANTIESEATION"
},
{
- "distinct_range": 2.9918032786885247,
- "num_eq": 1920,
- "num_range": 600,
+ "distinct_range": 3.5809727418492785,
+ "num_eq": 2070,
+ "num_range": 750,
"upper_bound": "ANTIOUGHTABLE"
},
{
- "distinct_range": 0.8975409836065574,
- "num_eq": 1650,
+ "distinct_range": 0.8594334580438268,
+ "num_eq": 1770,
"num_range": 180,
"upper_bound": "ANTIOUGHTBAR"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 4470,
- "num_range": 1140,
+ "distinct_range": 5.872795296632817,
+ "num_eq": 5490,
+ "num_range": 1230,
"upper_bound": "ANTIOUGHTPRES"
},
{
"distinct_range": 0,
- "num_eq": 1890,
+ "num_eq": 2160,
"num_range": 0,
"upper_bound": "ANTIOUGHTPRI"
},
{
- "distinct_range": 6.581967213114754,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "ANTIPRIABLE"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "ANTIPRESPRI"
},
{
- "distinct_range": 5.8340163934426235,
- "num_eq": 630,
- "num_range": 1170,
- "upper_bound": "ATIONABLEABLE"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "ANTIPRIPRI"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 420,
- "num_range": 1140,
- "upper_bound": "ATIONABLEEING"
+ "distinct_range": 5.01336183858899,
+ "num_eq": 360,
+ "num_range": 1050,
+ "upper_bound": "ATIONABLEATION"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 2160,
- "num_range": 990,
+ "distinct_range": 5.872795296632817,
+ "num_eq": 240,
+ "num_range": 1230,
+ "upper_bound": "ATIONABLEPRES"
+ },
+ {
+ "distinct_range": 0.5729556386958845,
+ "num_eq": 1800,
+ "num_range": 120,
"upper_bound": "ATIONANTIABLE"
},
{
"distinct_range": 0,
- "num_eq": 2370,
+ "num_eq": 2010,
"num_range": 0,
"upper_bound": "ATIONANTIANTI"
},
{
"distinct_range": 0,
- "num_eq": 1950,
+ "num_eq": 2070,
"num_range": 0,
"upper_bound": "ATIONANTIATION"
},
{
- "distinct_range": 3.889344262295082,
- "num_eq": 720,
- "num_range": 780,
- "upper_bound": "ATIONANTICALLY"
- },
- {
- "distinct_range": 0,
- "num_eq": 1560,
- "num_range": 0,
+ "distinct_range": 6.445750935328701,
+ "num_eq": 1770,
+ "num_range": 1350,
"upper_bound": "ATIONANTIEING"
},
{
- "distinct_range": 4.338114754098361,
- "num_eq": 900,
- "num_range": 870,
- "upper_bound": "ATIONANTIOUGHT"
+ "distinct_range": 6.588989845002672,
+ "num_eq": 810,
+ "num_range": 1380,
+ "upper_bound": "ATIONANTIPRES"
},
{
- "distinct_range": 6.731557377049181,
+ "distinct_range": 5.586317477284874,
"num_eq": 210,
- "num_range": 1350,
- "upper_bound": "ATIONATIONBAR"
+ "num_range": 1170,
+ "upper_bound": "ATIONATIONPRI"
},
{
- "distinct_range": 5.8340163934426235,
- "num_eq": 1590,
- "num_range": 1170,
+ "distinct_range": 3.294494922501336,
+ "num_eq": 1860,
+ "num_range": 690,
"upper_bound": "ATIONBARANTI"
},
{
- "distinct_range": 2.8422131147540983,
- "num_eq": 900,
- "num_range": 570,
- "upper_bound": "ATIONBARESE"
+ "distinct_range": 5.729556386958845,
+ "num_eq": 180,
+ "num_range": 1200,
+ "upper_bound": "ATIONBAROUGHT"
},
{
- "distinct_range": 6.133196721311475,
- "num_eq": 4830,
- "num_range": 1230,
+ "distinct_range": 6.445750935328701,
+ "num_eq": 4920,
+ "num_range": 1350,
"upper_bound": "ATIONCALLYBAR"
},
{
- "distinct_range": 6.282786885245902,
- "num_eq": 180,
- "num_range": 1260,
- "upper_bound": "ATIONEINGEING"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 120,
+ "num_range": 1230,
+ "upper_bound": "ATIONEINGBAR"
},
{
- "distinct_range": 6.432377049180328,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "ATIONESEANTI"
+ "distinct_range": 4.726884019241047,
+ "num_eq": 540,
+ "num_range": 990,
+ "upper_bound": "ATIONESEATION"
},
{
- "distinct_range": 3.141393442622951,
- "num_eq": 810,
- "num_range": 630,
- "upper_bound": "ATIONESEBAR"
+ "distinct_range": 6.30251202565473,
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "ATIONESEESE"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 1560,
- "num_range": 840,
+ "distinct_range": 1.4323890967397113,
+ "num_eq": 1620,
+ "num_range": 300,
"upper_bound": "ATIONESEPRES"
},
{
- "distinct_range": 5.385245901639345,
- "num_eq": 360,
- "num_range": 1080,
- "upper_bound": "ATIONOUGHTATION"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 300,
+ "num_range": 1290,
+ "upper_bound": "ATIONOUGHTEING"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 900,
- "num_range": 1110,
+ "distinct_range": 4.870122928915019,
+ "num_eq": 780,
+ "num_range": 1020,
"upper_bound": "ATIONPRESANTI"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 420,
- "num_range": 1140,
- "upper_bound": "ATIONPRESPRES"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "ATIONPRESOUGHT"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 2100,
- "num_range": 990,
+ "distinct_range": 3.7242116515232495,
+ "num_eq": 750,
+ "num_range": 780,
+ "upper_bound": "ATIONPRIANTI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1770,
+ "num_range": 0,
"upper_bound": "ATIONPRIATION"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 900,
- "num_range": 840,
+ "distinct_range": 3.437733832175307,
+ "num_eq": 750,
+ "num_range": 720,
"upper_bound": "ATIONPRICALLY"
},
{
- "distinct_range": 3.141393442622951,
- "num_eq": 930,
- "num_range": 630,
- "upper_bound": "ATIONPRIPRES"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 300,
+ "num_range": 1230,
+ "upper_bound": "ATIONPRIPRI"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 150,
- "num_range": 1200,
- "upper_bound": "BARABLECALLY"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 270,
+ "num_range": 1230,
+ "upper_bound": "BARABLEEING"
},
{
- "distinct_range": 4.038934426229508,
- "num_eq": 1770,
- "num_range": 810,
+ "distinct_range": 2.291822554783538,
+ "num_eq": 1470,
+ "num_range": 480,
"upper_bound": "BARANTIABLE"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 120,
- "num_range": 1200,
- "upper_bound": "BARANTICALLY"
+ "distinct_range": 5.443078567610903,
+ "num_eq": 210,
+ "num_range": 1140,
+ "upper_bound": "BARANTIEING"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 180,
+ "distinct_range": 5.443078567610903,
+ "num_eq": 630,
"num_range": 1140,
- "upper_bound": "BARATIONABLE"
+ "upper_bound": "BARATIONANTI"
},
{
- "distinct_range": 6.133196721311475,
- "num_eq": 120,
+ "distinct_range": 5.872795296632817,
+ "num_eq": 180,
"num_range": 1230,
- "upper_bound": "BARATIONCALLY"
+ "upper_bound": "BARATIONOUGHT"
},
{
- "distinct_range": 5.8340163934426235,
- "num_eq": 210,
- "num_range": 1170,
- "upper_bound": "BARBARANTI"
+ "distinct_range": 6.016034206306788,
+ "num_eq": 60,
+ "num_range": 1260,
+ "upper_bound": "BARBAREING"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 360,
- "num_range": 1110,
- "upper_bound": "BARCALLYANTI"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 480,
+ "num_range": 1290,
+ "upper_bound": "BARCALLYATION"
+ },
+ {
+ "distinct_range": 5.01336183858899,
+ "num_eq": 390,
+ "num_range": 1050,
+ "upper_bound": "BARCALLYPRES"
},
{
- "distinct_range": 6.432377049180328,
+ "distinct_range": 5.872795296632817,
"num_eq": 240,
- "num_range": 1290,
- "upper_bound": "BARCALLYOUGHT"
+ "num_range": 1230,
+ "upper_bound": "BAREINGATION"
},
{
- "distinct_range": 6.432377049180328,
- "num_eq": 750,
- "num_range": 1290,
- "upper_bound": "BAREINGBAR"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 240,
+ "num_range": 1230,
+ "upper_bound": "BAREINGOUGHT"
},
{
- "distinct_range": 2.8422131147540983,
+ "distinct_range": 0,
"num_eq": 1950,
- "num_range": 570,
+ "num_range": 0,
"upper_bound": "BAREINGPRES"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 690,
- "num_range": 990,
+ "distinct_range": 5.01336183858899,
+ "num_eq": 810,
+ "num_range": 1050,
"upper_bound": "BARESEATION"
},
{
- "distinct_range": 5.8340163934426235,
- "num_eq": 660,
- "num_range": 1170,
- "upper_bound": "BARESEPRES"
+ "distinct_range": 5.299839657936932,
+ "num_eq": 270,
+ "num_range": 1110,
+ "upper_bound": "BARESEOUGHT"
},
{
- "distinct_range": 6.133196721311475,
- "num_eq": 120,
- "num_range": 1230,
- "upper_bound": "BAROUGHTESE"
+ "distinct_range": 6.016034206306788,
+ "num_eq": 240,
+ "num_range": 1260,
+ "upper_bound": "BAROUGHTABLE"
},
{
- "distinct_range": 4.487704918032787,
- "num_eq": 750,
- "num_range": 900,
- "upper_bound": "BARPRESANTI"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 300,
+ "num_range": 1230,
+ "upper_bound": "BAROUGHTPRES"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 240,
- "num_range": 1200,
- "upper_bound": "BARPRESOUGHT"
+ "distinct_range": 6.016034206306788,
+ "num_eq": 120,
+ "num_range": 1260,
+ "upper_bound": "BARPRESCALLY"
},
{
- "distinct_range": 3.5901639344262297,
- "num_eq": 750,
- "num_range": 720,
- "upper_bound": "BARPRIBAR"
+ "distinct_range": 6.016034206306788,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "BARPRIABLE"
},
{
- "distinct_range": 5.086065573770492,
- "num_eq": 540,
- "num_range": 1020,
- "upper_bound": "CALLYABLEANTI"
+ "distinct_range": 5.729556386958845,
+ "num_eq": 180,
+ "num_range": 1200,
+ "upper_bound": "BARPRICALLY"
},
{
- "distinct_range": 5.534836065573771,
+ "distinct_range": 6.159273115980759,
"num_eq": 180,
- "num_range": 1110,
- "upper_bound": "CALLYABLEPRES"
+ "num_range": 1290,
+ "upper_bound": "CALLYABLEATION"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 150,
+ "distinct_range": 5.443078567610903,
+ "num_eq": 210,
"num_range": 1140,
- "upper_bound": "CALLYANTIESE"
+ "upper_bound": "CALLYABLEPRI"
},
{
- "distinct_range": 6.133196721311475,
- "num_eq": 210,
+ "distinct_range": 5.872795296632817,
+ "num_eq": 240,
"num_range": 1230,
- "upper_bound": "CALLYATIONCALLY"
+ "upper_bound": "CALLYANTIPRES"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 240,
- "num_range": 1110,
- "upper_bound": "CALLYBARANTI"
+ "distinct_range": 4.440406199893105,
+ "num_eq": 510,
+ "num_range": 930,
+ "upper_bound": "CALLYATIONCALLY"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 360,
- "num_range": 1140,
- "upper_bound": "CALLYCALLYABLE"
+ "distinct_range": 5.156600748262961,
+ "num_eq": 330,
+ "num_range": 1080,
+ "upper_bound": "CALLYBARABLE"
},
{
- "distinct_range": 4.038934426229508,
- "num_eq": 960,
- "num_range": 810,
- "upper_bound": "CALLYCALLYPRES"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "CALLYBAROUGHT"
},
{
- "distinct_range": 4.038934426229508,
- "num_eq": 660,
- "num_range": 810,
- "upper_bound": "CALLYEINGATION"
+ "distinct_range": 6.159273115980759,
+ "num_eq": 270,
+ "num_range": 1290,
+ "upper_bound": "CALLYCALLYOUGHT"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 150,
- "num_range": 1200,
- "upper_bound": "CALLYEINGEING"
+ "distinct_range": 4.870122928915019,
+ "num_eq": 330,
+ "num_range": 1020,
+ "upper_bound": "CALLYEINGANTI"
},
{
- "distinct_range": 5.8340163934426235,
- "num_eq": 150,
- "num_range": 1170,
- "upper_bound": "CALLYESEBAR"
+ "distinct_range": 6.016034206306788,
+ "num_eq": 300,
+ "num_range": 1260,
+ "upper_bound": "CALLYEINGCALLY"
},
{
- "distinct_range": 6.133196721311475,
- "num_eq": 150,
- "num_range": 1230,
- "upper_bound": "CALLYOUGHTABLE"
+ "distinct_range": 6.016034206306788,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "CALLYESEBAR"
},
{
- "distinct_range": 2.543032786885246,
- "num_eq": 840,
- "num_range": 510,
+ "distinct_range": 5.586317477284874,
+ "num_eq": 570,
+ "num_range": 1170,
"upper_bound": "CALLYOUGHTBAR"
},
{
- "distinct_range": 4.786885245901639,
- "num_eq": 1890,
- "num_range": 960,
+ "distinct_range": 3.151256012827365,
+ "num_eq": 1530,
+ "num_range": 660,
"upper_bound": "CALLYPRESABLE"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 750,
- "num_range": 1140,
+ "distinct_range": 5.586317477284874,
+ "num_eq": 810,
+ "num_range": 1170,
"upper_bound": "CALLYPRESOUGHT"
},
{
- "distinct_range": 3.889344262295082,
- "num_eq": 750,
- "num_range": 780,
+ "distinct_range": 4.153928380545163,
+ "num_eq": 600,
+ "num_range": 870,
"upper_bound": "CALLYPRIATION"
},
{
- "distinct_range": 5.385245901639345,
- "num_eq": 180,
- "num_range": 1080,
- "upper_bound": "CALLYPRIOUGHT"
+ "distinct_range": 4.870122928915019,
+ "num_eq": 420,
+ "num_range": 1020,
+ "upper_bound": "CALLYPRIPRES"
},
{
- "distinct_range": 5.684426229508197,
+ "distinct_range": 5.729556386958845,
"num_eq": 180,
- "num_range": 1140,
- "upper_bound": "EINGABLEATION"
+ "num_range": 1200,
+ "upper_bound": "EINGABLEESE"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 210,
- "num_range": 1110,
- "upper_bound": "EINGABLEPRI"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 450,
+ "num_range": 960,
+ "upper_bound": "EINGANTIANTI"
},
{
- "distinct_range": 5.235655737704918,
- "num_eq": 300,
- "num_range": 1050,
- "upper_bound": "EINGANTIESE"
+ "distinct_range": 5.156600748262961,
+ "num_eq": 330,
+ "num_range": 1080,
+ "upper_bound": "EINGANTIPRES"
},
{
- "distinct_range": 3.4405737704918034,
- "num_eq": 750,
- "num_range": 690,
- "upper_bound": "EINGATIONABLE"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 360,
+ "num_range": 1230,
+ "upper_bound": "EINGATIONBAR"
},
{
- "distinct_range": 6.133196721311475,
- "num_eq": 210,
- "num_range": 1230,
- "upper_bound": "EINGATIONESE"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 390,
+ "num_range": 960,
+ "upper_bound": "EINGATIONPRES"
},
{
- "distinct_range": 5.534836065573771,
+ "distinct_range": 5.729556386958845,
"num_eq": 150,
- "num_range": 1110,
- "upper_bound": "EINGBARCALLY"
+ "num_range": 1200,
+ "upper_bound": "EINGBARESE"
},
{
- "distinct_range": 5.385245901639345,
- "num_eq": 270,
- "num_range": 1080,
+ "distinct_range": 5.443078567610903,
+ "num_eq": 180,
+ "num_range": 1140,
"upper_bound": "EINGCALLYBAR"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 510,
- "num_range": 1140,
- "upper_bound": "EINGEINGANTI"
+ "distinct_range": 5.299839657936932,
+ "num_eq": 180,
+ "num_range": 1110,
+ "upper_bound": "EINGEINGABLE"
},
{
- "distinct_range": 0,
- "num_eq": 1740,
- "num_range": 0,
+ "distinct_range": 3.5809727418492785,
+ "num_eq": 1650,
+ "num_range": 750,
"upper_bound": "EINGEINGATION"
},
{
- "distinct_range": 3.141393442622951,
- "num_eq": 960,
- "num_range": 630,
- "upper_bound": "EINGEINGCALLY"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 90,
+ "num_range": 1230,
+ "upper_bound": "EINGEINGEING"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 450,
+ "distinct_range": 5.729556386958845,
+ "num_eq": 90,
"num_range": 1200,
- "upper_bound": "EINGEINGPRI"
+ "upper_bound": "EINGESEABLE"
},
{
- "distinct_range": 5.385245901639345,
- "num_eq": 150,
- "num_range": 1080,
- "upper_bound": "EINGESEESE"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 120,
+ "num_range": 1230,
+ "upper_bound": "EINGESEPRES"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 120,
- "num_range": 1110,
+ "distinct_range": 5.872795296632817,
+ "num_eq": 60,
+ "num_range": 1230,
"upper_bound": "EINGOUGHTEING"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 240,
- "num_range": 990,
- "upper_bound": "EINGPRESBAR"
+ "distinct_range": 4.870122928915019,
+ "num_eq": 270,
+ "num_range": 1020,
+ "upper_bound": "EINGPRESATION"
},
{
- "distinct_range": 5.983606557377049,
- "num_eq": 210,
- "num_range": 1200,
- "upper_bound": "EINGPRIATION"
+ "distinct_range": 5.872795296632817,
+ "num_eq": 270,
+ "num_range": 1230,
+ "upper_bound": "EINGPRIBAR"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 630,
- "num_range": 840,
- "upper_bound": "EINGPRIPRES"
+ "distinct_range": 5.443078567610903,
+ "num_eq": 120,
+ "num_range": 1140,
+ "upper_bound": "ESEABLEABLE"
},
{
- "distinct_range": 5.385245901639345,
- "num_eq": 180,
- "num_range": 1080,
- "upper_bound": "ESEABLEBAR"
+ "distinct_range": 4.726884019241047,
+ "num_eq": 420,
+ "num_range": 990,
+ "upper_bound": "ESEANTIABLE"
},
{
- "distinct_range": 5.8340163934426235,
- "num_eq": 570,
- "num_range": 1170,
- "upper_bound": "ESEANTIANTI"
+ "distinct_range": 5.729556386958845,
+ "num_eq": 210,
+ "num_range": 1200,
+ "upper_bound": "ESEANTIEING"
},
{
- "distinct_range": 5.086065573770492,
- "num_eq": 240,
- "num_range": 1020,
- "upper_bound": "ESEANTIPRES"
+ "distinct_range": 5.156600748262961,
+ "num_eq": 2040,
+ "num_range": 1080,
+ "upper_bound": "ESEATIONABLE"
},
{
- "distinct_range": 0.7479508196721312,
- "num_eq": 2070,
- "num_range": 150,
- "upper_bound": "ESEATIONABLE"
+ "distinct_range": 4.010689470871192,
+ "num_eq": 750,
+ "num_range": 840,
+ "upper_bound": "ESEATIONBAR"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 180,
- "num_range": 1110,
- "upper_bound": "ESEATIONEING"
+ "distinct_range": 3.437733832175307,
+ "num_eq": 630,
+ "num_range": 720,
+ "upper_bound": "ESEATIONOUGHT"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 270,
+ "distinct_range": 5.299839657936932,
+ "num_eq": 180,
"num_range": 1110,
- "upper_bound": "ESEBARABLE"
+ "upper_bound": "ESEBARBAR"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 270,
- "num_range": 1140,
- "upper_bound": "ESECALLYABLE"
+ "distinct_range": 5.586317477284874,
+ "num_eq": 630,
+ "num_range": 1170,
+ "upper_bound": "ESECALLYATION"
},
{
- "distinct_range": 4.338114754098361,
- "num_eq": 390,
+ "distinct_range": 4.153928380545163,
+ "num_eq": 780,
"num_range": 870,
- "upper_bound": "ESECALLYBAR"
+ "upper_bound": "ESECALLYPRES"
},
{
- "distinct_range": 4.487704918032787,
- "num_eq": 690,
- "num_range": 900,
- "upper_bound": "ESECALLYPRES"
+ "distinct_range": 3.7242116515232495,
+ "num_eq": 630,
+ "num_range": 780,
+ "upper_bound": "ESEEINGANTI"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 1860,
- "num_range": 990,
+ "distinct_range": 0,
+ "num_eq": 1410,
+ "num_range": 0,
"upper_bound": "ESEEINGATION"
},
{
- "distinct_range": 5.534836065573771,
- "num_eq": 270,
+ "distinct_range": 5.299839657936932,
+ "num_eq": 180,
"num_range": 1110,
- "upper_bound": "ESEEINGESE"
+ "upper_bound": "ESEEINGOUGHT"
},
{
- "distinct_range": 5.385245901639345,
- "num_eq": 360,
- "num_range": 1080,
+ "distinct_range": 5.586317477284874,
+ "num_eq": 480,
+ "num_range": 1170,
"upper_bound": "ESEESEATION"
},
{
"distinct_range": 0,
- "num_eq": 1650,
+ "num_eq": 1920,
"num_range": 0,
"upper_bound": "ESEESEBAR"
},
{
- "distinct_range": 5.235655737704918,
- "num_eq": 150,
- "num_range": 1050,
+ "distinct_range": 5.299839657936932,
+ "num_eq": 480,
+ "num_range": 1110,
"upper_bound": "ESEOUGHTANTI"
},
{
- "distinct_range": 5.684426229508197,
- "num_eq": 120,
- "num_range": 1140,
- "upper_bound": "ESEOUGHTESE"
+ "distinct_range": 4.726884019241047,
+ "num_eq": 300,
+ "num_range": 990,
+ "upper_bound": "ESEOUGHTCALLY"
},
{
- "distinct_range": 5.385245901639345,
+ "distinct_range": 3.5809727418492785,
"num_eq": 660,
- "num_range": 1080,
- "upper_bound": "ESEPRESANTI"
+ "num_range": 750,
+ "upper_bound": "ESEPRESABLE"
},
{
- "distinct_range": 4.338114754098361,
- "num_eq": 420,
- "num_range": 870,
- "upper_bound": "ESEPRESCALLY"
+ "distinct_range": 5.443078567610903,
+ "num_eq": 390,
+ "num_range": 1140,
+ "upper_bound": "ESEPRESBAR"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 270,
- "num_range": 930,
- "upper_bound": "ESEPRESOUGHT"
+ "distinct_range": 4.297167290219134,
+ "num_eq": 300,
+ "num_range": 900,
+ "upper_bound": "ESEPRESESE"
},
{
- "distinct_range": 4.786885245901639,
- "num_eq": 360,
- "num_range": 960,
- "upper_bound": "ESEPRIATION"
+ "distinct_range": 5.586317477284874,
+ "num_eq": 210,
+ "num_range": 1170,
+ "upper_bound": "ESEPRIBAR"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 900,
- "num_range": 930,
- "upper_bound": "ESEPRIPRES"
+ "distinct_range": 5.01336183858899,
+ "num_eq": 330,
+ "num_range": 1050,
+ "upper_bound": "ESEPRIPRI"
},
{
- "distinct_range": 1.0471311475409837,
- "num_eq": 1260,
- "num_range": 210,
+ "distinct_range": 0,
+ "num_eq": 1470,
+ "num_range": 0,
"upper_bound": "OUGHTABLEABLE"
},
{
"distinct_range": 0,
- "num_eq": 3870,
+ "num_eq": 4020,
"num_range": 0,
"upper_bound": "OUGHTABLEANTI"
},
{
- "distinct_range": 4.338114754098361,
- "num_eq": 1350,
- "num_range": 870,
+ "distinct_range": 3.8674505611972205,
+ "num_eq": 1140,
+ "num_range": 810,
"upper_bound": "OUGHTABLEESE"
},
{
- "distinct_range": 2.0942622950819674,
- "num_eq": 1560,
- "num_range": 420,
+ "distinct_range": 3.294494922501336,
+ "num_eq": 1290,
+ "num_range": 690,
"upper_bound": "OUGHTABLEPRES"
},
{
- "distinct_range": 4.038934426229508,
- "num_eq": 720,
- "num_range": 810,
+ "distinct_range": 4.297167290219134,
+ "num_eq": 660,
+ "num_range": 900,
"upper_bound": "OUGHTANTIANTI"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 300,
- "num_range": 930,
- "upper_bound": "OUGHTANTIPRES"
- },
- {
- "distinct_range": 3.889344262295082,
- "num_eq": 330,
- "num_range": 780,
- "upper_bound": "OUGHTATIONATION"
+ "distinct_range": 4.870122928915019,
+ "num_eq": 240,
+ "num_range": 1020,
+ "upper_bound": "OUGHTANTIPRI"
},
{
- "distinct_range": 5.235655737704918,
- "num_eq": 60,
- "num_range": 1050,
- "upper_bound": "OUGHTATIONPRI"
+ "distinct_range": 5.156600748262961,
+ "num_eq": 180,
+ "num_range": 1080,
+ "upper_bound": "OUGHTATIONOUGHT"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 570,
- "num_range": 990,
- "upper_bound": "OUGHTBARATION"
+ "distinct_range": 3.7242116515232495,
+ "num_eq": 480,
+ "num_range": 780,
+ "upper_bound": "OUGHTBARANTI"
},
{
- "distinct_range": 2.6926229508196724,
- "num_eq": 630,
- "num_range": 540,
+ "distinct_range": 5.156600748262961,
+ "num_eq": 690,
+ "num_range": 1080,
"upper_bound": "OUGHTBAREING"
},
{
- "distinct_range": 4.038934426229508,
- "num_eq": 270,
- "num_range": 810,
- "upper_bound": "OUGHTBARPRI"
+ "distinct_range": 5.01336183858899,
+ "num_eq": 180,
+ "num_range": 1050,
+ "upper_bound": "OUGHTCALLYATION"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 210,
- "num_range": 990,
- "upper_bound": "OUGHTCALLYESE"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 360,
+ "num_range": 960,
+ "upper_bound": "OUGHTEINGABLE"
},
{
- "distinct_range": 4.338114754098361,
- "num_eq": 870,
- "num_range": 870,
- "upper_bound": "OUGHTEINGATION"
+ "distinct_range": 3.5809727418492785,
+ "num_eq": 360,
+ "num_range": 750,
+ "upper_bound": "OUGHTEINGBAR"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 240,
- "num_range": 930,
- "upper_bound": "OUGHTEINGPRES"
+ "distinct_range": 5.156600748262961,
+ "num_eq": 210,
+ "num_range": 1080,
+ "upper_bound": "OUGHTEINGPRI"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 150,
- "num_range": 990,
- "upper_bound": "OUGHTESEEING"
+ "distinct_range": 4.870122928915019,
+ "num_eq": 120,
+ "num_range": 1020,
+ "upper_bound": "OUGHTESECALLY"
},
{
- "distinct_range": 3.5901639344262297,
- "num_eq": 600,
- "num_range": 720,
- "upper_bound": "OUGHTOUGHTANTI"
+ "distinct_range": 4.010689470871192,
+ "num_eq": 270,
+ "num_range": 840,
+ "upper_bound": "OUGHTOUGHTABLE"
},
{
- "distinct_range": 0,
- "num_eq": 1500,
- "num_range": 0,
+ "distinct_range": 3.294494922501336,
+ "num_eq": 1860,
+ "num_range": 690,
"upper_bound": "OUGHTOUGHTATION"
},
{
"distinct_range": 0,
- "num_eq": 1530,
+ "num_eq": 1230,
"num_range": 0,
"upper_bound": "OUGHTOUGHTBAR"
},
{
- "distinct_range": 4.786885245901639,
- "num_eq": 240,
- "num_range": 960,
+ "distinct_range": 4.726884019241047,
+ "num_eq": 150,
+ "num_range": 990,
"upper_bound": "OUGHTOUGHTOUGHT"
},
{
- "distinct_range": 5.086065573770492,
+ "distinct_range": 5.01336183858899,
"num_eq": 150,
- "num_range": 1020,
- "upper_bound": "OUGHTPRESATION"
+ "num_range": 1050,
+ "upper_bound": "OUGHTPRESBAR"
},
{
- "distinct_range": 4.487704918032787,
- "num_eq": 150,
- "num_range": 900,
+ "distinct_range": 4.726884019241047,
+ "num_eq": 210,
+ "num_range": 990,
"upper_bound": "OUGHTPRIATION"
},
{
- "distinct_range": 5.086065573770492,
- "num_eq": 720,
- "num_range": 1020,
- "upper_bound": "PRESABLEABLE"
+ "distinct_range": 3.437733832175307,
+ "num_eq": 390,
+ "num_range": 720,
+ "upper_bound": "OUGHTPRIPRES"
},
{
- "distinct_range": 3.7397540983606556,
- "num_eq": 330,
- "num_range": 750,
- "upper_bound": "PRESABLEOUGHT"
+ "distinct_range": 4.870122928915019,
+ "num_eq": 240,
+ "num_range": 1020,
+ "upper_bound": "PRESABLEBAR"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 150,
- "num_range": 990,
- "upper_bound": "PRESANTIBAR"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 360,
+ "num_range": 960,
+ "upper_bound": "PRESANTIANTI"
},
{
- "distinct_range": 5.086065573770492,
- "num_eq": 570,
- "num_range": 1020,
- "upper_bound": "PRESATIONABLE"
+ "distinct_range": 4.297167290219134,
+ "num_eq": 150,
+ "num_range": 900,
+ "upper_bound": "PRESANTIOUGHT"
},
{
- "distinct_range": 0,
- "num_eq": 1710,
- "num_range": 0,
+ "distinct_range": 4.583645109567076,
+ "num_eq": 1920,
+ "num_range": 960,
"upper_bound": "PRESATIONANTI"
},
{
- "distinct_range": 3.290983606557377,
- "num_eq": 840,
- "num_range": 660,
- "upper_bound": "PRESATIONESE"
- },
- {
- "distinct_range": 1.944672131147541,
+ "distinct_range": 1.8621058257616248,
"num_eq": 750,
"num_range": 390,
- "upper_bound": "PRESATIONPRES"
+ "upper_bound": "PRESATIONESE"
},
{
- "distinct_range": 4.936475409836066,
- "num_eq": 180,
- "num_range": 990,
- "upper_bound": "PRESBARBAR"
+ "distinct_range": 3.7242116515232495,
+ "num_eq": 270,
+ "num_range": 780,
+ "upper_bound": "PRESATIONPRI"
},
{
- "distinct_range": 4.936475409836066,
+ "distinct_range": 4.440406199893105,
"num_eq": 240,
- "num_range": 990,
+ "num_range": 930,
+ "upper_bound": "PRESBARCALLY"
+ },
+ {
+ "distinct_range": 4.010689470871192,
+ "num_eq": 390,
+ "num_range": 840,
"upper_bound": "PRESCALLYANTI"
},
{
- "distinct_range": 2.9918032786885247,
- "num_eq": 720,
- "num_range": 600,
+ "distinct_range": 3.437733832175307,
+ "num_eq": 630,
+ "num_range": 720,
"upper_bound": "PRESCALLYBAR"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 150,
- "num_range": 930,
+ "distinct_range": 4.010689470871192,
+ "num_eq": 240,
+ "num_range": 840,
"upper_bound": "PRESCALLYPRES"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 180,
- "num_range": 840,
- "upper_bound": "PRESEINGESE"
+ "distinct_range": 4.440406199893105,
+ "num_eq": 120,
+ "num_range": 930,
+ "upper_bound": "PRESEINGOUGHT"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 210,
- "num_range": 930,
- "upper_bound": "PRESESEBAR"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 90,
+ "num_range": 960,
+ "upper_bound": "PRESESECALLY"
},
{
- "distinct_range": 2.543032786885246,
- "num_eq": 1020,
- "num_range": 510,
- "upper_bound": "PRESESEPRES"
+ "distinct_range": 4.440406199893105,
+ "num_eq": 150,
+ "num_range": 930,
+ "upper_bound": "PRESESEPRI"
},
{
- "distinct_range": 4.338114754098361,
+ "distinct_range": 3.7242116515232495,
"num_eq": 210,
- "num_range": 870,
- "upper_bound": "PRESOUGHTBAR"
+ "num_range": 780,
+ "upper_bound": "PRESOUGHTEING"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 180,
- "num_range": 840,
- "upper_bound": "PRESOUGHTPRI"
+ "distinct_range": 3.294494922501336,
+ "num_eq": 510,
+ "num_range": 690,
+ "upper_bound": "PRESPRESANTI"
},
{
- "distinct_range": 4.487704918032787,
- "num_eq": 210,
- "num_range": 900,
- "upper_bound": "PRESPRESCALLY"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 150,
+ "num_range": 960,
+ "upper_bound": "PRESPRESPRI"
},
{
- "distinct_range": 3.889344262295082,
- "num_eq": 210,
- "num_range": 780,
- "upper_bound": "PRESPRIATION"
+ "distinct_range": 4.583645109567076,
+ "num_eq": 90,
+ "num_range": 960,
+ "upper_bound": "PRESPRIESE"
},
{
- "distinct_range": 3.889344262295082,
- "num_eq": 210,
- "num_range": 780,
- "upper_bound": "PRESPRIPRI"
+ "distinct_range": 1.8621058257616248,
+ "num_eq": 630,
+ "num_range": 390,
+ "upper_bound": "PRIABLEABLE"
},
{
- "distinct_range": 2.3934426229508197,
- "num_eq": 1260,
- "num_range": 480,
+ "distinct_range": 0,
+ "num_eq": 1680,
+ "num_range": 0,
"upper_bound": "PRIABLEANTI"
},
{
- "distinct_range": 2.0942622950819674,
- "num_eq": 600,
- "num_range": 420,
+ "distinct_range": 3.008017103153394,
+ "num_eq": 1110,
+ "num_range": 630,
"upper_bound": "PRIABLEESE"
},
{
- "distinct_range": 4.637295081967213,
- "num_eq": 390,
- "num_range": 930,
- "upper_bound": "PRIABLEPRI"
+ "distinct_range": 1.8621058257616248,
+ "num_eq": 600,
+ "num_range": 390,
+ "upper_bound": "PRIABLEPRES"
},
{
- "distinct_range": 4.338114754098361,
- "num_eq": 150,
- "num_range": 870,
- "upper_bound": "PRIANTIOUGHT"
+ "distinct_range": 4.297167290219134,
+ "num_eq": 90,
+ "num_range": 900,
+ "upper_bound": "PRIANTIESE"
},
{
- "distinct_range": 4.338114754098361,
+ "distinct_range": 4.010689470871192,
"num_eq": 150,
- "num_range": 870,
- "upper_bound": "PRIATIONESE"
+ "num_range": 840,
+ "upper_bound": "PRIATIONCALLY"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 300,
- "num_range": 840,
- "upper_bound": "PRIBARATION"
+ "distinct_range": 3.8674505611972205,
+ "num_eq": 360,
+ "num_range": 810,
+ "upper_bound": "PRIBARANTI"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 150,
- "num_range": 840,
- "upper_bound": "PRIBARPRES"
+ "distinct_range": 3.8674505611972205,
+ "num_eq": 360,
+ "num_range": 810,
+ "upper_bound": "PRIBAREING"
},
{
- "distinct_range": 4.188524590163935,
- "num_eq": 150,
- "num_range": 840,
- "upper_bound": "PRICALLYESE"
+ "distinct_range": 3.008017103153394,
+ "num_eq": 300,
+ "num_range": 630,
+ "upper_bound": "PRICALLYBAR"
},
{
- "distinct_range": 3.889344262295082,
- "num_eq": 210,
- "num_range": 780,
- "upper_bound": "PRIEINGATION"
+ "distinct_range": 3.5809727418492785,
+ "num_eq": 240,
+ "num_range": 750,
+ "upper_bound": "PRIEINGABLE"
},
{
- "distinct_range": 4.487704918032787,
- "num_eq": 630,
- "num_range": 900,
- "upper_bound": "PRIESEABLE"
+ "distinct_range": 4.153928380545163,
+ "num_eq": 180,
+ "num_range": 870,
+ "upper_bound": "PRIEINGPRES"
},
{
- "distinct_range": 0,
- "num_eq": 1830,
- "num_range": 0,
+ "distinct_range": 3.5809727418492785,
+ "num_eq": 1530,
+ "num_range": 750,
"upper_bound": "PRIESEANTI"
},
{
"distinct_range": 0,
- "num_eq": 4980,
+ "num_eq": 4950,
"num_range": 0,
"upper_bound": "PRIESEATION"
},
{
"distinct_range": 0,
- "num_eq": 1590,
+ "num_eq": 1860,
"num_range": 0,
"upper_bound": "PRIESEBAR"
},
{
"distinct_range": 0,
- "num_eq": 1680,
+ "num_eq": 1830,
"num_range": 0,
"upper_bound": "PRIESECALLY"
},
{
- "distinct_range": 0.14959016393442623,
- "num_eq": 720,
- "num_range": 30,
- "upper_bound": "PRIESEESE"
+ "distinct_range": 2.7215392838054515,
+ "num_eq": 420,
+ "num_range": 570,
+ "upper_bound": "PRIESEOUGHT"
},
{
- "distinct_range": 1.7950819672131149,
- "num_eq": 1650,
- "num_range": 360,
+ "distinct_range": 0,
+ "num_eq": 1590,
+ "num_range": 0,
"upper_bound": "PRIESEPRES"
},
{
- "distinct_range": 0,
- "num_eq": 900,
- "num_range": 0,
- "upper_bound": "PRIESEPRI"
+ "distinct_range": 2.5783003741314805,
+ "num_eq": 90,
+ "num_range": 540,
+ "upper_bound": "PRIOUGHTABLE"
},
{
- "distinct_range": 1.944672131147541,
+ "distinct_range": 1.5756280064136825,
"num_eq": 690,
- "num_range": 390,
+ "num_range": 330,
"upper_bound": "PRIOUGHTATION"
},
{
"distinct_range": 0,
- "num_eq": 720,
+ "num_eq": 810,
"num_range": 0,
"upper_bound": "PRIOUGHTBAR"
},
{
- "distinct_range": 1.944672131147541,
- "num_eq": 210,
- "num_range": 390,
- "upper_bound": "PRIOUGHTESE"
- },
- {
- "distinct_range": 0.8975409836065574,
- "num_eq": 390,
- "num_range": 180,
+ "distinct_range": 2.4350614644575095,
+ "num_eq": 300,
+ "num_range": 510,
"upper_bound": "PRIOUGHTPRES"
},
{
- "distinct_range": 0.8975409836065574,
- "num_eq": 2160,
- "num_range": 180,
+ "distinct_range": 0.7161945483698556,
+ "num_eq": 2100,
+ "num_range": 150,
"upper_bound": "PRIPRESABLE"
},
{
"distinct_range": 0,
- "num_eq": 690,
+ "num_eq": 450,
"num_range": 0,
"upper_bound": "PRIPRESANTI"
},
{
"distinct_range": 0,
- "num_eq": 720,
+ "num_eq": 690,
"num_range": 0,
"upper_bound": "PRIPRESATION"
},
{
"distinct_range": 0,
- "num_eq": 600,
+ "num_eq": 540,
"num_range": 0,
"upper_bound": "PRIPRESBAR"
},
{
- "distinct_range": 1.0471311475409837,
- "num_eq": 600,
- "num_range": 210,
+ "distinct_range": 1.2891501870657402,
+ "num_eq": 570,
+ "num_range": 270,
"upper_bound": "PRIPRESEING"
},
{
- "distinct_range": 0.7479508196721312,
- "num_eq": 660,
- "num_range": 150,
+ "distinct_range": 1.145911277391769,
+ "num_eq": 690,
+ "num_range": 240,
"upper_bound": "PRIPRESOUGHT"
},
{
- "distinct_range": 0,
- "num_eq": 360,
- "num_range": 0,
- "upper_bound": "PRIPRESPRES"
- },
- {
- "distinct_range": 1.0471311475409837,
- "num_eq": 210,
- "num_range": 210,
- "upper_bound": "PRIPRIABLE"
+ "distinct_range": 1.2891501870657402,
+ "num_eq": 180,
+ "num_range": 270,
+ "upper_bound": "PRIPRESPRI"
},
{
- "distinct_range": 1.3463114754098362,
- "num_eq": 750,
- "num_range": 270,
- "upper_bound": "PRIPRIATION"
+ "distinct_range": 0.4297167290219134,
+ "num_eq": 360,
+ "num_range": 90,
+ "upper_bound": "PRIPRIANTI"
},
{
"distinct_range": 0,
- "num_eq": 270,
+ "num_eq": 1050,
"num_range": 0,
- "upper_bound": "PRIPRIBAR"
+ "upper_bound": "PRIPRIATION"
},
{
- "distinct_range": 0,
- "num_eq": 270,
- "num_range": 0,
+ "distinct_range": 0.5729556386958845,
+ "num_eq": 300,
+ "num_range": 120,
"upper_bound": "PRIPRICALLY"
},
{
"distinct_range": 0,
- "num_eq": 330,
+ "num_eq": 480,
"num_range": 0,
"upper_bound": "PRIPRIEING"
},
{
- "distinct_range": 0.8975409836065574,
- "num_eq": 150,
- "num_range": 180,
+ "distinct_range": 0.4297167290219134,
+ "num_eq": 120,
+ "num_range": 90,
"upper_bound": "PRIPRIOUGHT"
},
{
"distinct_range": 0,
- "num_eq": 720,
+ "num_eq": 780,
"num_range": 0,
"upper_bound": "PRIPRIPRES"
},
{
"distinct_range": 0,
- "num_eq": 480,
+ "num_eq": 330,
"num_range": 0,
"upper_bound": "PRIPRIPRI"
}
@@ -2587,12 +2586,13 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 16,
"columns": [
"c_w_id",
"c_d_id",
"c_last"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 99837,
"histo_col_type": "",
"name": "__auto__",
@@ -2600,1204 +2600,1205 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 14,
"columns": [
"c_first"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 558,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 480,
+ "num_eq": 450,
"num_range": 0,
"upper_bound": "1U5yraPx"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 480,
- "num_range": 1020,
- "upper_bound": "1U5yraPxxELo"
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 750,
+ "num_range": 900,
+ "upper_bound": "1U5yraPxxEL"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 540,
- "num_range": 990,
- "upper_bound": "1U5yraPxxELo5B1"
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 450,
+ "num_range": 1140,
+ "upper_bound": "1U5yraPxxELo5B"
},
{
- "distinct_range": 2.7031400192246076,
- "num_eq": 510,
- "num_range": 1410,
- "upper_bound": "1fcW8RsaCX"
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 480,
+ "num_range": 1020,
+ "upper_bound": "1fcW8Rsa"
},
{
- "distinct_range": 2.7031400192246076,
- "num_eq": 510,
- "num_range": 1410,
- "upper_bound": "1fcW8RsaCXoEz"
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 630,
+ "num_range": 1050,
+ "upper_bound": "1fcW8RsaCXo"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 750,
- "num_range": 1140,
- "upper_bound": "1fcW8RsaCXoEzmss"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 720,
+ "num_range": 1230,
+ "upper_bound": "1fcW8RsaCXoEzm"
},
{
- "distinct_range": 2.588112784363986,
- "num_eq": 240,
- "num_range": 1350,
+ "distinct_range": 2.480237789203085,
+ "num_eq": 660,
+ "num_range": 1290,
+ "upper_bound": "3v1U5yra"
+ },
+ {
+ "distinct_range": 2.134158097686375,
+ "num_eq": 630,
+ "num_range": 1110,
"upper_bound": "3v1U5yraPxx"
},
{
- "distinct_range": 2.4155719320730533,
+ "distinct_range": 1.8457583547557839,
"num_eq": 600,
- "num_range": 1260,
+ "num_range": 960,
"upper_bound": "3v1U5yraPxxELo"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 480,
- "num_range": 1200,
- "upper_bound": "5B1fcW8Rs"
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 540,
+ "num_range": 1050,
+ "upper_bound": "5B1fcW8R"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 510,
- "num_range": 960,
- "upper_bound": "5B1fcW8RsaCX"
+ "distinct_range": 1.6150385604113109,
+ "num_eq": 690,
+ "num_range": 840,
+ "upper_bound": "5B1fcW8RsaC"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 630,
- "num_range": 1200,
- "upper_bound": "5B1fcW8RsaCXoEz"
+ "distinct_range": 1.6150385604113109,
+ "num_eq": 750,
+ "num_range": 840,
+ "upper_bound": "5B1fcW8RsaCXoE"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 750,
- "num_range": 870,
- "upper_bound": "5yraPxxEL"
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 540,
+ "num_range": 1050,
+ "upper_bound": "5yraPxxE"
},
{
- "distinct_range": 2.530599166933675,
- "num_eq": 330,
- "num_range": 1320,
- "upper_bound": "5yraPxxELo5B1"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 540,
+ "num_range": 1230,
+ "upper_bound": "5yraPxxELo5"
},
{
- "distinct_range": 1.7829221403396347,
- "num_eq": 690,
- "num_range": 930,
- "upper_bound": "5yraPxxELo5B1fcW"
+ "distinct_range": 2.595597686375321,
+ "num_eq": 540,
+ "num_range": 1350,
+ "upper_bound": "5yraPxxELo5B1f"
+ },
+ {
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 480,
+ "num_range": 1140,
+ "upper_bound": "6NHnwiwK"
},
{
- "distinct_range": 2.7031400192246076,
+ "distinct_range": 2.537917737789203,
"num_eq": 450,
- "num_range": 1410,
- "upper_bound": "6NHnwiwKdcg"
+ "num_range": 1320,
+ "upper_bound": "6NHnwiwKdcgp"
},
{
- "distinct_range": 2.588112784363986,
- "num_eq": 510,
- "num_range": 1350,
- "upper_bound": "6NHnwiwKdcgphy3"
+ "distinct_range": 1.4996786632390744,
+ "num_eq": 720,
+ "num_range": 780,
+ "upper_bound": "6NHnwiwKdcgphy"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 600,
- "num_range": 1110,
- "upper_bound": "6rumMmp6N"
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 690,
+ "num_range": 1140,
+ "upper_bound": "6rumMmp6"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 570,
- "num_range": 960,
- "upper_bound": "6rumMmp6NHnw"
+ "distinct_range": 2.537917737789203,
+ "num_eq": 510,
+ "num_range": 1320,
+ "upper_bound": "6rumMmp6NHn"
},
{
- "distinct_range": 2.3580583146427427,
+ "distinct_range": 1.9034383033419022,
"num_eq": 510,
- "num_range": 1230,
- "upper_bound": "6rumMmp6NHnwiwK"
+ "num_range": 990,
+ "upper_bound": "6rumMmp6NHnwiw"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 630,
- "num_range": 900,
+ "distinct_range": 2.4225578406169666,
+ "num_eq": 750,
+ "num_range": 1260,
"upper_bound": "8RsaCXoE"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 570,
- "num_range": 1050,
- "upper_bound": "8RsaCXoEzmss"
+ "distinct_range": 2.134158097686375,
+ "num_eq": 660,
+ "num_range": 1110,
+ "upper_bound": "8RsaCXoEzms"
},
{
- "distinct_range": 2.530599166933675,
- "num_eq": 420,
- "num_range": 1320,
- "upper_bound": "8RsaCXoEzmssaF9"
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 630,
+ "num_range": 1050,
+ "upper_bound": "8RsaCXoEzmssaF"
},
{
- "distinct_range": 2.6456264017942965,
- "num_eq": 600,
- "num_range": 1380,
- "upper_bound": "9cdLXe0Yhg"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 480,
+ "num_range": 1230,
+ "upper_bound": "9cdLXe0Y"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 360,
- "num_range": 1110,
- "upper_bound": "9cdLXe0YhgLRr"
+ "distinct_range": 2.537917737789203,
+ "num_eq": 660,
+ "num_range": 1320,
+ "upper_bound": "9cdLXe0YhgL"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 540,
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 510,
"num_range": 1020,
- "upper_bound": "9cdLXe0YhgLRrwsm"
+ "upper_bound": "9cdLXe0YhgLRrw"
},
{
- "distinct_range": 1.8404357577699455,
+ "distinct_range": 2.30719794344473,
"num_eq": 540,
- "num_range": 960,
- "upper_bound": "9m9cdLXe0Y"
+ "num_range": 1200,
+ "upper_bound": "9m9cdLXe0"
},
{
- "distinct_range": 2.6456264017942965,
- "num_eq": 480,
- "num_range": 1380,
- "upper_bound": "9m9cdLXe0YhgLR"
+ "distinct_range": 1.9034383033419022,
+ "num_eq": 690,
+ "num_range": 990,
+ "upper_bound": "9m9cdLXe0Yhg"
},
{
- "distinct_range": 2.6456264017942965,
- "num_eq": 480,
- "num_range": 1380,
- "upper_bound": "B1fcW8Rsa"
+ "distinct_range": 2.480237789203085,
+ "num_eq": 750,
+ "num_range": 1290,
+ "upper_bound": "9m9cdLXe0YhgLRrw"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 720,
- "num_range": 1170,
- "upper_bound": "B1fcW8RsaCXo"
+ "distinct_range": 1.8457583547557839,
+ "num_eq": 480,
+ "num_range": 960,
+ "upper_bound": "B1fcW8RsaC"
},
{
- "distinct_range": 2.3580583146427427,
- "num_eq": 570,
- "num_range": 1230,
- "upper_bound": "B1fcW8RsaCXoEzm"
+ "distinct_range": 2.537917737789203,
+ "num_eq": 420,
+ "num_range": 1320,
+ "upper_bound": "B1fcW8RsaCXoEz"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 540,
- "num_range": 1200,
+ "distinct_range": 2.6532776349614395,
+ "num_eq": 330,
+ "num_range": 1380,
"upper_bound": "CXoEzmssaF"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 600,
- "num_range": 1020,
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 570,
+ "num_range": 900,
"upper_bound": "CXoEzmssaF9m9"
},
{
- "distinct_range": 1.7829221403396347,
- "num_eq": 720,
- "num_range": 930,
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 540,
+ "num_range": 900,
"upper_bound": "CXoEzmssaF9m9cdL"
},
{
- "distinct_range": 2.4730855495033643,
- "num_eq": 570,
- "num_range": 1290,
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 480,
+ "num_range": 1050,
"upper_bound": "ELo5B1fcW8"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 750,
- "num_range": 1020,
+ "distinct_range": 2.30719794344473,
+ "num_eq": 540,
+ "num_range": 1200,
"upper_bound": "ELo5B1fcW8Rsa"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 510,
- "num_range": 1020,
+ "distinct_range": 2.30719794344473,
+ "num_eq": 540,
+ "num_range": 1200,
"upper_bound": "ELo5B1fcW8RsaCXo"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 720,
- "num_range": 1170,
- "upper_bound": "EzmssaF9m9c"
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 570,
+ "num_range": 1140,
+ "upper_bound": "EzmssaF9m9"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 630,
- "num_range": 1170,
- "upper_bound": "EzmssaF9m9cdLX"
+ "distinct_range": 2.30719794344473,
+ "num_eq": 900,
+ "num_range": 1200,
+ "upper_bound": "EzmssaF9m9cdL"
},
{
- "distinct_range": 2.4730855495033643,
- "num_eq": 480,
- "num_range": 1290,
- "upper_bound": "F9m9cdLXe"
+ "distinct_range": 2.249517994858612,
+ "num_eq": 510,
+ "num_range": 1170,
+ "upper_bound": "EzmssaF9m9cdLXe0"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 690,
- "num_range": 960,
- "upper_bound": "F9m9cdLXe0Yh"
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 630,
+ "num_range": 900,
+ "upper_bound": "F9m9cdLXe0"
},
{
- "distinct_range": 2.588112784363986,
- "num_eq": 510,
- "num_range": 1350,
- "upper_bound": "F9m9cdLXe0YhgLR"
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 570,
+ "num_range": 1020,
+ "upper_bound": "F9m9cdLXe0Yhg"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 450,
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 600,
"num_range": 1050,
- "upper_bound": "HnwiwKdcg"
+ "upper_bound": "F9m9cdLXe0YhgLRr"
},
{
- "distinct_range": 2.4155719320730533,
- "num_eq": 510,
- "num_range": 1260,
- "upper_bound": "HnwiwKdcgphy"
+ "distinct_range": 2.595597686375321,
+ "num_eq": 480,
+ "num_range": 1350,
+ "upper_bound": "HnwiwKdcgph"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 570,
- "num_range": 960,
- "upper_bound": "HnwiwKdcgphy3v1"
+ "distinct_range": 2.537917737789203,
+ "num_eq": 660,
+ "num_range": 1320,
+ "upper_bound": "HnwiwKdcgphy3v"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 600,
- "num_range": 1170,
- "upper_bound": "Kdcgphy3v"
+ "distinct_range": 2.134158097686375,
+ "num_eq": 690,
+ "num_range": 1110,
+ "upper_bound": "Kdcgphy3"
},
{
- "distinct_range": 2.530599166933675,
- "num_eq": 570,
- "num_range": 1320,
- "upper_bound": "Kdcgphy3v1U5"
+ "distinct_range": 1.8457583547557839,
+ "num_eq": 750,
+ "num_range": 960,
+ "upper_bound": "Kdcgphy3v1U"
},
{
- "distinct_range": 1.6103812880487023,
- "num_eq": 660,
- "num_range": 840,
- "upper_bound": "Kdcgphy3v1U5yr"
+ "distinct_range": 2.6532776349614395,
+ "num_eq": 300,
+ "num_range": 1380,
+ "upper_bound": "Kdcgphy3v1U5yra"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 840,
- "num_range": 1110,
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 570,
+ "num_range": 1020,
"upper_bound": "LXe0YhgLR"
},
{
- "distinct_range": 1.5528676706183915,
- "num_eq": 720,
- "num_range": 810,
+ "distinct_range": 2.30719794344473,
+ "num_eq": 510,
+ "num_range": 1200,
"upper_bound": "LXe0YhgLRrws"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 450,
- "num_range": 1020,
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 480,
+ "num_range": 930,
"upper_bound": "LXe0YhgLRrwsmd6"
},
{
- "distinct_range": 2.4730855495033643,
- "num_eq": 510,
- "num_range": 1290,
+ "distinct_range": 2.076478149100257,
+ "num_eq": 360,
+ "num_range": 1080,
"upper_bound": "Lo5B1fcW8"
},
{
- "distinct_range": 2.3580583146427427,
- "num_eq": 720,
- "num_range": 1230,
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 450,
+ "num_range": 1020,
"upper_bound": "Lo5B1fcW8Rsa"
},
{
- "distinct_range": 2.4730855495033643,
- "num_eq": 630,
- "num_range": 1290,
- "upper_bound": "Lo5B1fcW8RsaCXo"
+ "distinct_range": 2.30719794344473,
+ "num_eq": 570,
+ "num_range": 1200,
+ "upper_bound": "Lo5B1fcW8RsaCXoE"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 540,
- "num_range": 990,
- "upper_bound": "Mmp6NHnwi"
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 600,
+ "num_range": 1140,
+ "upper_bound": "Mmp6NHnwiw"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 540,
- "num_range": 900,
- "upper_bound": "Mmp6NHnwiwKd"
+ "distinct_range": 2.249517994858612,
+ "num_eq": 270,
+ "num_range": 1170,
+ "upper_bound": "Mmp6NHnwiwKdc"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 600,
- "num_range": 990,
- "upper_bound": "Mmp6NHnwiwKdcgp"
+ "distinct_range": 2.480237789203085,
+ "num_eq": 630,
+ "num_range": 1290,
+ "upper_bound": "NHnwiwKd"
},
{
- "distinct_range": 2.588112784363986,
- "num_eq": 450,
+ "distinct_range": 2.595597686375321,
+ "num_eq": 660,
"num_range": 1350,
- "upper_bound": "NHnwiwKdcg"
+ "upper_bound": "NHnwiwKdcgph"
},
{
- "distinct_range": 2.4155719320730533,
- "num_eq": 510,
- "num_range": 1260,
- "upper_bound": "NHnwiwKdcgphy"
+ "distinct_range": 2.249517994858612,
+ "num_eq": 270,
+ "num_range": 1170,
+ "upper_bound": "NHnwiwKdcgphy3v"
},
{
- "distinct_range": 2.6456264017942965,
- "num_eq": 540,
+ "distinct_range": 2.6532776349614395,
+ "num_eq": 750,
"num_range": 1380,
- "upper_bound": "PxxELo5B"
+ "upper_bound": "PxxELo5B1f"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 330,
- "num_range": 1140,
- "upper_bound": "PxxELo5B1fc"
+ "distinct_range": 1.6150385604113109,
+ "num_eq": 630,
+ "num_range": 840,
+ "upper_bound": "PxxELo5B1fcW"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 390,
- "num_range": 1140,
+ "distinct_range": 2.249517994858612,
+ "num_eq": 300,
+ "num_range": 1170,
"upper_bound": "PxxELo5B1fcW8Rs"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 630,
- "num_range": 1110,
+ "distinct_range": 1.6150385604113109,
+ "num_eq": 660,
+ "num_range": 840,
"upper_bound": "RsaCXoEzm"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 630,
- "num_range": 900,
- "upper_bound": "RsaCXoEzmssa"
+ "distinct_range": 2.249517994858612,
+ "num_eq": 240,
+ "num_range": 1170,
+ "upper_bound": "RsaCXoEzmssaF"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 480,
- "num_range": 960,
- "upper_bound": "RsaCXoEzmssaF9m"
+ "distinct_range": 2.076478149100257,
+ "num_eq": 450,
+ "num_range": 1080,
+ "upper_bound": "RsaCXoEzmssaF9m9"
},
{
- "distinct_range": 2.18551746235181,
+ "distinct_range": 2.0187982005141385,
"num_eq": 600,
- "num_range": 1140,
- "upper_bound": "U5yraPxxE"
- },
- {
- "distinct_range": 2.1280038449214995,
- "num_eq": 540,
- "num_range": 1110,
- "upper_bound": "U5yraPxxELo5"
+ "num_range": 1050,
+ "upper_bound": "U5yraPxxEL"
},
{
- "distinct_range": 2.243031079782121,
+ "distinct_range": 2.537917737789203,
"num_eq": 660,
- "num_range": 1170,
- "upper_bound": "U5yraPxxELo5B1f"
- },
- {
- "distinct_range": 2.3005446972124317,
- "num_eq": 600,
- "num_range": 1200,
- "upper_bound": "W8RsaCXoE"
+ "num_range": 1320,
+ "upper_bound": "U5yraPxxELo5B1"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 570,
- "num_range": 1170,
- "upper_bound": "W8RsaCXoEzms"
+ "distinct_range": 1.8457583547557839,
+ "num_eq": 540,
+ "num_range": 960,
+ "upper_bound": "W8RsaCXo"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 510,
- "num_range": 960,
- "upper_bound": "W8RsaCXoEzmssaF"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 420,
+ "num_range": 1230,
+ "upper_bound": "W8RsaCXoEzm"
},
{
- "distinct_range": 1.7829221403396347,
+ "distinct_range": 1.7880784061696657,
"num_eq": 570,
"num_range": 930,
- "upper_bound": "Xe0YhgLRr"
+ "upper_bound": "W8RsaCXoEzmssa"
},
{
- "distinct_range": 1.6103812880487023,
- "num_eq": 660,
- "num_range": 840,
- "upper_bound": "Xe0YhgLRrwsm"
+ "distinct_range": 1.9034383033419022,
+ "num_eq": 420,
+ "num_range": 990,
+ "upper_bound": "Xe0YhgLR"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 660,
- "num_range": 1170,
- "upper_bound": "Xe0YhgLRrwsmd68"
+ "distinct_range": 2.537917737789203,
+ "num_eq": 630,
+ "num_range": 1320,
+ "upper_bound": "Xe0YhgLRrwsm"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 690,
- "num_range": 870,
- "upper_bound": "XoEzmssa"
+ "distinct_range": 2.134158097686375,
+ "num_eq": 630,
+ "num_range": 1110,
+ "upper_bound": "Xe0YhgLRrwsmd68P"
},
{
- "distinct_range": 2.588112784363986,
- "num_eq": 540,
- "num_range": 1350,
- "upper_bound": "XoEzmssaF9m"
+ "distinct_range": 2.076478149100257,
+ "num_eq": 360,
+ "num_range": 1080,
+ "upper_bound": "XoEzmssaF9"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 570,
+ "distinct_range": 1.9034383033419022,
+ "num_eq": 630,
"num_range": 990,
- "upper_bound": "XoEzmssaF9m9cd"
+ "upper_bound": "XoEzmssaF9m9c"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 480,
- "num_range": 1050,
- "upper_bound": "aCXoEzms"
+ "distinct_range": 2.595597686375321,
+ "num_eq": 660,
+ "num_range": 1350,
+ "upper_bound": "XoEzmssaF9m9cdLX"
},
{
- "distinct_range": 2.3005446972124317,
+ "distinct_range": 2.4225578406169666,
"num_eq": 510,
- "num_range": 1200,
- "upper_bound": "aCXoEzmssaF9"
+ "num_range": 1260,
+ "upper_bound": "aCXoEzmssa"
},
{
- "distinct_range": 1.8404357577699455,
- "num_eq": 450,
- "num_range": 960,
- "upper_bound": "aCXoEzmssaF9m9c"
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 480,
+ "num_range": 1020,
+ "upper_bound": "aCXoEzmssaF9m"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 690,
- "num_range": 1200,
- "upper_bound": "aF9m9cdLX"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 450,
+ "num_range": 1230,
+ "upper_bound": "aCXoEzmssaF9m9cd"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 660,
- "num_range": 1110,
- "upper_bound": "aF9m9cdLXe0Y"
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 570,
+ "num_range": 930,
+ "upper_bound": "aF9m9cdLXe"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 480,
- "num_range": 1200,
- "upper_bound": "aF9m9cdLXe0YhgLR"
+ "distinct_range": 2.595597686375321,
+ "num_eq": 510,
+ "num_range": 1350,
+ "upper_bound": "aF9m9cdLXe0Yhg"
},
{
- "distinct_range": 2.3580583146427427,
- "num_eq": 600,
+ "distinct_range": 2.364877892030848,
+ "num_eq": 510,
"num_range": 1230,
- "upper_bound": "aPxxELo5B1f"
+ "upper_bound": "aPxxELo5B"
},
{
- "distinct_range": 2.4730855495033643,
- "num_eq": 270,
- "num_range": 1290,
- "upper_bound": "aPxxELo5B1fcW8R"
+ "distinct_range": 2.595597686375321,
+ "num_eq": 570,
+ "num_range": 1350,
+ "upper_bound": "aPxxELo5B1fcW"
},
{
- "distinct_range": 2.3580583146427427,
+ "distinct_range": 1.7880784061696657,
"num_eq": 690,
- "num_range": 1230,
- "upper_bound": "cW8RsaCXo"
+ "num_range": 930,
+ "upper_bound": "aPxxELo5B1fcW8Rs"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 540,
- "num_range": 990,
- "upper_bound": "cW8RsaCXoEzm"
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 450,
+ "num_range": 1140,
+ "upper_bound": "cW8RsaCXoE"
},
{
- "distinct_range": 1.5528676706183915,
- "num_eq": 540,
- "num_range": 810,
- "upper_bound": "cW8RsaCXoEzmss"
+ "distinct_range": 2.480237789203085,
+ "num_eq": 600,
+ "num_range": 1290,
+ "upper_bound": "cW8RsaCXoEzms"
},
{
- "distinct_range": 1.5528676706183915,
+ "distinct_range": 2.480237789203085,
"num_eq": 600,
- "num_range": 810,
- "upper_bound": "cdLXe0Yh"
+ "num_range": 1290,
+ "upper_bound": "cW8RsaCXoEzmssaF"
},
{
- "distinct_range": 2.0704902274911885,
- "num_eq": 570,
- "num_range": 1080,
- "upper_bound": "cdLXe0YhgLR"
+ "distinct_range": 2.537917737789203,
+ "num_eq": 780,
+ "num_range": 1320,
+ "upper_bound": "cdLXe0YhgL"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 690,
- "num_range": 1170,
- "upper_bound": "cdLXe0YhgLRrws"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 300,
+ "num_range": 1230,
+ "upper_bound": "cdLXe0YhgLRrw"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 360,
- "num_range": 1050,
- "upper_bound": "cgphy3v1"
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 540,
+ "num_range": 1020,
+ "upper_bound": "cdLXe0YhgLRrwsmd"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 540,
- "num_range": 990,
- "upper_bound": "cgphy3v1U5y"
+ "distinct_range": 2.076478149100257,
+ "num_eq": 600,
+ "num_range": 1080,
+ "upper_bound": "cgphy3v1U5"
},
{
- "distinct_range": 2.4155719320730533,
- "num_eq": 480,
- "num_range": 1260,
+ "distinct_range": 2.480237789203085,
+ "num_eq": 420,
+ "num_range": 1290,
"upper_bound": "cgphy3v1U5yraP"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 570,
- "num_range": 1140,
- "upper_bound": "dLXe0Yhg"
+ "distinct_range": 1.3266388174807198,
+ "num_eq": 630,
+ "num_range": 690,
+ "upper_bound": "cgphy3v1U5yraPxx"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 600,
- "num_range": 1200,
- "upper_bound": "dLXe0YhgLRr"
+ "distinct_range": 2.076478149100257,
+ "num_eq": 510,
+ "num_range": 1080,
+ "upper_bound": "dLXe0YhgLR"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 570,
- "num_range": 870,
- "upper_bound": "dLXe0YhgLRrws"
+ "distinct_range": 1.384318766066838,
+ "num_eq": 630,
+ "num_range": 720,
+ "upper_bound": "dLXe0YhgLRrw"
},
{
- "distinct_range": 2.3580583146427427,
- "num_eq": 420,
- "num_range": 1230,
- "upper_bound": "dLXe0YhgLRrwsmd6"
+ "distinct_range": 1.9034383033419022,
+ "num_eq": 750,
+ "num_range": 990,
+ "upper_bound": "dLXe0YhgLRrwsmd"
},
{
- "distinct_range": 2.3580583146427427,
- "num_eq": 720,
- "num_range": 1230,
- "upper_bound": "dcgphy3v1U"
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 480,
+ "num_range": 1050,
+ "upper_bound": "dcgphy3v1"
},
{
- "distinct_range": 0.9202178788849728,
- "num_eq": 900,
- "num_range": 480,
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 330,
+ "num_range": 1140,
"upper_bound": "dcgphy3v1U5y"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 450,
- "num_range": 900,
+ "distinct_range": 2.076478149100257,
+ "num_eq": 630,
+ "num_range": 1080,
"upper_bound": "dcgphy3v1U5yraP"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 750,
- "num_range": 1050,
+ "distinct_range": 2.480237789203085,
+ "num_eq": 510,
+ "num_range": 1290,
"upper_bound": "fcW8RsaCX"
},
{
- "distinct_range": 2.4730855495033643,
- "num_eq": 480,
+ "distinct_range": 2.480237789203085,
+ "num_eq": 540,
"num_range": 1290,
"upper_bound": "fcW8RsaCXoEz"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 690,
- "num_range": 990,
+ "distinct_range": 2.076478149100257,
+ "num_eq": 570,
+ "num_range": 1080,
"upper_bound": "fcW8RsaCXoEzmss"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 480,
- "num_range": 900,
+ "distinct_range": 2.134158097686375,
+ "num_eq": 660,
+ "num_range": 1110,
"upper_bound": "gphy3v1U5"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 420,
- "num_range": 1140,
- "upper_bound": "gphy3v1U5yra"
+ "distinct_range": 1.2112789203084833,
+ "num_eq": 810,
+ "num_range": 630,
+ "upper_bound": "gphy3v1U5yr"
},
{
- "distinct_range": 2.4155719320730533,
- "num_eq": 630,
+ "distinct_range": 2.4225578406169666,
+ "num_eq": 360,
"num_range": 1260,
"upper_bound": "gphy3v1U5yraPxx"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 480,
- "num_range": 1170,
+ "distinct_range": 2.076478149100257,
+ "num_eq": 600,
+ "num_range": 1080,
"upper_bound": "hy3v1U5yr"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 510,
- "num_range": 1200,
- "upper_bound": "hy3v1U5yraPx"
+ "distinct_range": 1.3266388174807198,
+ "num_eq": 630,
+ "num_range": 690,
+ "upper_bound": "hy3v1U5yraP"
},
{
- "distinct_range": 2.3005446972124317,
- "num_eq": 420,
- "num_range": 1200,
- "upper_bound": "hy3v1U5yraPxxEL"
+ "distinct_range": 2.364877892030848,
+ "num_eq": 720,
+ "num_range": 1230,
+ "upper_bound": "hy3v1U5yraPxxE"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 690,
- "num_range": 600,
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 570,
+ "num_range": 1020,
"upper_bound": "iwKdcgph"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 510,
- "num_range": 870,
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 540,
+ "num_range": 930,
"upper_bound": "iwKdcgphy3v"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 750,
- "num_range": 1020,
+ "distinct_range": 2.30719794344473,
+ "num_eq": 540,
+ "num_range": 1200,
"upper_bound": "iwKdcgphy3v1U5"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 450,
- "num_range": 900,
- "upper_bound": "m9cdLXe0"
+ "distinct_range": 1.2689588688946014,
+ "num_eq": 630,
+ "num_range": 660,
+ "upper_bound": "iwKdcgphy3v1U5yr"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 540,
- "num_range": 1020,
- "upper_bound": "m9cdLXe0Yhg"
+ "distinct_range": 1.9034383033419022,
+ "num_eq": 660,
+ "num_range": 990,
+ "upper_bound": "m9cdLXe0Y"
},
{
- "distinct_range": 0.9202178788849728,
- "num_eq": 900,
- "num_range": 480,
- "upper_bound": "m9cdLXe0YhgLR"
+ "distinct_range": 1.6727185089974292,
+ "num_eq": 510,
+ "num_range": 870,
+ "upper_bound": "m9cdLXe0YhgL"
},
{
- "distinct_range": 1.092758731175905,
- "num_eq": 750,
- "num_range": 570,
+ "distinct_range": 1.8457583547557839,
+ "num_eq": 660,
+ "num_range": 960,
"upper_bound": "m9cdLXe0YhgLRrw"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 660,
- "num_range": 900,
- "upper_bound": "mMmp6NHnw"
+ "distinct_range": 1.2112789203084833,
+ "num_eq": 750,
+ "num_range": 630,
+ "upper_bound": "mMmp6NHn"
},
{
- "distinct_range": 1.955462992630567,
- "num_eq": 360,
- "num_range": 1020,
- "upper_bound": "mMmp6NHnwiwK"
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 510,
+ "num_range": 1140,
+ "upper_bound": "mMmp6NHnwiw"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 510,
+ "distinct_range": 1.6727185089974292,
+ "num_eq": 540,
"num_range": 870,
- "upper_bound": "mMmp6NHnwiwKdcg"
+ "upper_bound": "mMmp6NHnwiwKd"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 510,
- "num_range": 1140,
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 570,
+ "num_range": 930,
+ "upper_bound": "mMmp6NHnwiwKdcgp"
+ },
+ {
+ "distinct_range": 1.0959190231362468,
+ "num_eq": 810,
+ "num_range": 570,
"upper_bound": "mp6NHnwiw"
},
{
- "distinct_range": 2.0704902274911885,
- "num_eq": 540,
- "num_range": 1080,
- "upper_bound": "mp6NHnwiwKdc"
+ "distinct_range": 0.9228791773778919,
+ "num_eq": 780,
+ "num_range": 480,
+ "upper_bound": "mp6NHnwiwKd"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 420,
- "num_range": 870,
- "upper_bound": "mp6NHnwiwKdcgph"
+ "distinct_range": 1.4996786632390744,
+ "num_eq": 750,
+ "num_range": 780,
+ "upper_bound": "mp6NHnwiwKdcgp"
},
{
- "distinct_range": 1.3228132008971483,
- "num_eq": 660,
- "num_range": 690,
- "upper_bound": "mssaF9m9c"
+ "distinct_range": 2.0187982005141385,
+ "num_eq": 480,
+ "num_range": 1050,
+ "upper_bound": "mssaF9m9"
},
{
- "distinct_range": 1.0352451137455942,
- "num_eq": 810,
- "num_range": 540,
+ "distinct_range": 1.6150385604113109,
+ "num_eq": 540,
+ "num_range": 840,
"upper_bound": "mssaF9m9cdL"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 600,
- "num_range": 1110,
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 540,
+ "num_range": 930,
"upper_bound": "mssaF9m9cdLXe0"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 510,
- "num_range": 1110,
- "upper_bound": "nwiwKdcg"
+ "distinct_range": 1.6150385604113109,
+ "num_eq": 450,
+ "num_range": 840,
+ "upper_bound": "mssaF9m9cdLXe0Yh"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 690,
- "num_range": 990,
- "upper_bound": "nwiwKdcgphy"
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 480,
+ "num_range": 930,
+ "upper_bound": "nwiwKdcgph"
},
{
- "distinct_range": 1.4378404357577699,
- "num_eq": 480,
- "num_range": 750,
+ "distinct_range": 2.076478149100257,
+ "num_eq": 420,
+ "num_range": 1080,
"upper_bound": "nwiwKdcgphy3v"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 420,
- "num_range": 1050,
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 690,
+ "num_range": 1020,
"upper_bound": "nwiwKdcgphy3v1U5"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 570,
- "num_range": 1050,
+ "distinct_range": 2.076478149100257,
+ "num_eq": 630,
+ "num_range": 1080,
"upper_bound": "o5B1fcW8Rs"
},
{
- "distinct_range": 2.18551746235181,
- "num_eq": 540,
+ "distinct_range": 2.30719794344473,
+ "num_eq": 510,
+ "num_range": 1200,
+ "upper_bound": "o5B1fcW8RsaCXo"
+ },
+ {
+ "distinct_range": 2.1918380462724936,
+ "num_eq": 780,
"num_range": 1140,
- "upper_bound": "o5B1fcW8RsaCX"
+ "upper_bound": "oEzmssaF"
},
{
- "distinct_range": 2.243031079782121,
+ "distinct_range": 1.6727185089974292,
"num_eq": 540,
- "num_range": 1170,
- "upper_bound": "o5B1fcW8RsaCXoEz"
+ "num_range": 870,
+ "upper_bound": "oEzmssaF9m9"
},
{
- "distinct_range": 2.1280038449214995,
- "num_eq": 630,
- "num_range": 1110,
- "upper_bound": "oEzmssaF9m"
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 390,
+ "num_range": 930,
+ "upper_bound": "oEzmssaF9m9cdL"
},
{
- "distinct_range": 1.667894905479013,
+ "distinct_range": 2.076478149100257,
"num_eq": 540,
- "num_range": 870,
- "upper_bound": "oEzmssaF9m9cd"
- },
- {
- "distinct_range": 2.0704902274911885,
- "num_eq": 450,
"num_range": 1080,
- "upper_bound": "oEzmssaF9m9cdLXe"
+ "upper_bound": "p6NHnwiw"
},
{
- "distinct_range": 2.243031079782121,
- "num_eq": 690,
- "num_range": 1170,
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 540,
+ "num_range": 930,
"upper_bound": "p6NHnwiwKd"
},
{
- "distinct_range": 1.2077859660365267,
- "num_eq": 660,
- "num_range": 630,
- "upper_bound": "p6NHnwiwKdcg"
- },
- {
- "distinct_range": 0.9777314963152836,
- "num_eq": 750,
- "num_range": 510,
- "upper_bound": "p6NHnwiwKdcgph"
+ "distinct_range": 1.5573586118251928,
+ "num_eq": 450,
+ "num_range": 810,
+ "upper_bound": "p6NHnwiwKdcgp"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 660,
- "num_range": 600,
+ "distinct_range": 1.6727185089974292,
+ "num_eq": 510,
+ "num_range": 870,
"upper_bound": "p6NHnwiwKdcgphy3"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 600,
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 570,
"num_range": 900,
"upper_bound": "phy3v1U5yr"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 630,
- "num_range": 990,
+ "distinct_range": 2.134158097686375,
+ "num_eq": 480,
+ "num_range": 1110,
"upper_bound": "phy3v1U5yraPx"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 390,
- "num_range": 990,
- "upper_bound": "phy3v1U5yraPxxEL"
+ "distinct_range": 1.153598971722365,
+ "num_eq": 600,
+ "num_range": 600,
+ "upper_bound": "phy3v1U5yraPxxE"
},
{
- "distinct_range": 1.2652995834668375,
+ "distinct_range": 1.5573586118251928,
"num_eq": 600,
- "num_range": 660,
+ "num_range": 810,
"upper_bound": "raPxxELo5"
},
{
- "distinct_range": 1.380326818327459,
- "num_eq": 450,
- "num_range": 720,
- "upper_bound": "raPxxELo5B1"
- },
- {
- "distinct_range": 1.7829221403396347,
- "num_eq": 780,
+ "distinct_range": 1.7880784061696657,
+ "num_eq": 540,
"num_range": 930,
- "upper_bound": "raPxxELo5B1fcW"
+ "upper_bound": "raPxxELo5B1f"
},
{
- "distinct_range": 1.2077859660365267,
+ "distinct_range": 1.2689588688946014,
"num_eq": 570,
- "num_range": 630,
- "upper_bound": "raPxxELo5B1fcW8R"
- },
- {
- "distinct_range": 1.7829221403396347,
- "num_eq": 540,
- "num_range": 930,
- "upper_bound": "rumMmp6NHn"
+ "num_range": 660,
+ "upper_bound": "raPxxELo5B1fcW8"
},
{
- "distinct_range": 1.7829221403396347,
- "num_eq": 360,
- "num_range": 930,
- "upper_bound": "rumMmp6NHnwiw"
+ "distinct_range": 1.9611182519280204,
+ "num_eq": 450,
+ "num_range": 1020,
+ "upper_bound": "rumMmp6NH"
},
{
- "distinct_range": 2.0704902274911885,
+ "distinct_range": 1.3266388174807198,
"num_eq": 660,
- "num_range": 1080,
- "upper_bound": "rumMmp6NHnwiwKdc"
+ "num_range": 690,
+ "upper_bound": "rumMmp6NHnw"
},
{
- "distinct_range": 1.380326818327459,
- "num_eq": 810,
- "num_range": 720,
- "upper_bound": "saCXoEzms"
+ "distinct_range": 2.076478149100257,
+ "num_eq": 720,
+ "num_range": 1080,
+ "upper_bound": "rumMmp6NHnwiwK"
},
{
- "distinct_range": 2.012976610060878,
- "num_eq": 540,
- "num_range": 1050,
- "upper_bound": "saCXoEzmssaF"
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 600,
+ "num_range": 900,
+ "upper_bound": "saCXoEzm"
},
{
- "distinct_range": 1.725408522909324,
- "num_eq": 420,
- "num_range": 900,
- "upper_bound": "saCXoEzmssaF9m9"
+ "distinct_range": 1.3266388174807198,
+ "num_eq": 450,
+ "num_range": 690,
+ "upper_bound": "saCXoEzmss"
},
{
- "distinct_range": 1.725408522909324,
+ "distinct_range": 1.8457583547557839,
"num_eq": 480,
- "num_range": 900,
- "upper_bound": "saF9m9cdL"
+ "num_range": 960,
+ "upper_bound": "saCXoEzmssaF9"
},
{
- "distinct_range": 1.0352451137455942,
+ "distinct_range": 1.6727185089974292,
"num_eq": 690,
- "num_range": 540,
- "upper_bound": "saF9m9cdLXe"
+ "num_range": 870,
+ "upper_bound": "saCXoEzmssaF9m9c"
},
{
- "distinct_range": 0.9777314963152836,
- "num_eq": 690,
- "num_range": 510,
- "upper_bound": "saF9m9cdLXe0Y"
+ "distinct_range": 1.4419987146529563,
+ "num_eq": 600,
+ "num_range": 750,
+ "upper_bound": "saF9m9cdL"
},
{
- "distinct_range": 1.667894905479013,
- "num_eq": 390,
+ "distinct_range": 1.6727185089974292,
+ "num_eq": 780,
"num_range": 870,
- "upper_bound": "saF9m9cdLXe0YhgL"
+ "upper_bound": "saF9m9cdLXe0"
},
{
- "distinct_range": 1.2077859660365267,
- "num_eq": 510,
- "num_range": 630,
+ "distinct_range": 1.9034383033419022,
+ "num_eq": 630,
+ "num_range": 990,
+ "upper_bound": "saF9m9cdLXe0Yhg"
+ },
+ {
+ "distinct_range": 2.076478149100257,
+ "num_eq": 570,
+ "num_range": 1080,
"upper_bound": "ssaF9m9cd"
},
{
- "distinct_range": 0.9202178788849728,
- "num_eq": 660,
- "num_range": 480,
+ "distinct_range": 1.2112789203084833,
+ "num_eq": 690,
+ "num_range": 630,
"upper_bound": "ssaF9m9cdLX"
},
{
- "distinct_range": 1.4378404357577699,
- "num_eq": 720,
- "num_range": 750,
+ "distinct_range": 1.0382390745501284,
+ "num_eq": 540,
+ "num_range": 540,
"upper_bound": "ssaF9m9cdLXe0"
},
{
- "distinct_range": 1.3228132008971483,
- "num_eq": 450,
- "num_range": 690,
- "upper_bound": "ssaF9m9cdLXe0Yhg"
+ "distinct_range": 1.384318766066838,
+ "num_eq": 510,
+ "num_range": 720,
+ "upper_bound": "ssaF9m9cdLXe0Yh"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 510,
- "num_range": 600,
+ "distinct_range": 1.6727185089974292,
+ "num_eq": 390,
+ "num_range": 870,
"upper_bound": "umMmp6NHn"
},
{
- "distinct_range": 2.012976610060878,
+ "distinct_range": 0.9805591259640102,
"num_eq": 600,
- "num_range": 1050,
- "upper_bound": "umMmp6NHnwiw"
+ "num_range": 510,
+ "upper_bound": "umMmp6NHnwi"
},
{
- "distinct_range": 1.4953540531880807,
- "num_eq": 300,
- "num_range": 780,
- "upper_bound": "umMmp6NHnwiwKd"
+ "distinct_range": 0.9805591259640102,
+ "num_eq": 690,
+ "num_range": 510,
+ "upper_bound": "umMmp6NHnwiwK"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 510,
- "num_range": 600,
- "upper_bound": "umMmp6NHnwiwKdcg"
+ "distinct_range": 1.4996786632390744,
+ "num_eq": 570,
+ "num_range": 780,
+ "upper_bound": "umMmp6NHnwiwKdc"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 480,
- "num_range": 990,
- "upper_bound": "v1U5yraPxx"
+ "distinct_range": 1.0382390745501284,
+ "num_eq": 570,
+ "num_range": 540,
+ "upper_bound": "v1U5yraP"
},
{
- "distinct_range": 1.092758731175905,
- "num_eq": 570,
- "num_range": 570,
- "upper_bound": "v1U5yraPxxEL"
+ "distinct_range": 0.8075192802056554,
+ "num_eq": 750,
+ "num_range": 420,
+ "upper_bound": "v1U5yraPxx"
},
{
- "distinct_range": 1.8404357577699455,
+ "distinct_range": 1.2689588688946014,
"num_eq": 600,
- "num_range": 960,
- "upper_bound": "v1U5yraPxxELo5B"
+ "num_range": 660,
+ "upper_bound": "v1U5yraPxxEL"
},
{
- "distinct_range": 1.8979493752002563,
- "num_eq": 840,
- "num_range": 990,
- "upper_bound": "wKdcgphy3"
+ "distinct_range": 1.2689588688946014,
+ "num_eq": 720,
+ "num_range": 660,
+ "upper_bound": "v1U5yraPxxELo5"
},
{
- "distinct_range": 1.2077859660365267,
- "num_eq": 720,
+ "distinct_range": 1.2112789203084833,
+ "num_eq": 420,
"num_range": 630,
- "upper_bound": "wKdcgphy3v1"
+ "upper_bound": "v1U5yraPxxELo5B1"
},
{
- "distinct_range": 1.092758731175905,
- "num_eq": 660,
- "num_range": 570,
- "upper_bound": "wKdcgphy3v1U5"
+ "distinct_range": 0.7498393316195372,
+ "num_eq": 780,
+ "num_range": 390,
+ "upper_bound": "wKdcgphy3"
},
{
- "distinct_range": 1.2077859660365267,
- "num_eq": 570,
- "num_range": 630,
- "upper_bound": "wKdcgphy3v1U5yr"
+ "distinct_range": 1.6727185089974292,
+ "num_eq": 420,
+ "num_range": 870,
+ "upper_bound": "wKdcgphy3v1U"
},
{
- "distinct_range": 1.380326818327459,
+ "distinct_range": 1.4419987146529563,
"num_eq": 390,
- "num_range": 720,
- "upper_bound": "wiwKdcgp"
+ "num_range": 750,
+ "upper_bound": "wKdcgphy3v1U5y"
},
{
- "distinct_range": 1.0352451137455942,
+ "distinct_range": 0.8075192802056554,
"num_eq": 720,
- "num_range": 540,
+ "num_range": 420,
+ "upper_bound": "wKdcgphy3v1U5yra"
+ },
+ {
+ "distinct_range": 1.7303984575835474,
+ "num_eq": 450,
+ "num_range": 900,
"upper_bound": "wiwKdcgphy"
},
{
- "distinct_range": 1.1502723486062159,
+ "distinct_range": 1.0959190231362468,
"num_eq": 540,
- "num_range": 600,
+ "num_range": 570,
"upper_bound": "wiwKdcgphy3v"
},
{
- "distinct_range": 1.8979493752002563,
+ "distinct_range": 1.0382390745501284,
"num_eq": 570,
- "num_range": 990,
- "upper_bound": "wiwKdcgphy3v1U5"
+ "num_range": 540,
+ "upper_bound": "wiwKdcgphy3v1U"
},
{
- "distinct_range": 1.3228132008971483,
- "num_eq": 540,
- "num_range": 690,
- "upper_bound": "xELo5B1f"
+ "distinct_range": 1.384318766066838,
+ "num_eq": 450,
+ "num_range": 720,
+ "upper_bound": "wiwKdcgphy3v1U5y"
},
{
- "distinct_range": 1.092758731175905,
- "num_eq": 660,
+ "distinct_range": 1.0959190231362468,
+ "num_eq": 450,
"num_range": 570,
- "upper_bound": "xELo5B1fcW"
+ "upper_bound": "xELo5B1fc"
},
{
- "distinct_range": 1.0352451137455942,
- "num_eq": 510,
- "num_range": 540,
- "upper_bound": "xELo5B1fcW8R"
+ "distinct_range": 1.3266388174807198,
+ "num_eq": 600,
+ "num_range": 690,
+ "upper_bound": "xELo5B1fcW8"
},
{
- "distinct_range": 0.9777314963152836,
- "num_eq": 570,
- "num_range": 510,
+ "distinct_range": 1.4419987146529563,
+ "num_eq": 750,
+ "num_range": 750,
"upper_bound": "xELo5B1fcW8Rsa"
},
{
- "distinct_range": 1.2652995834668375,
- "num_eq": 600,
- "num_range": 660,
+ "distinct_range": 1.2112789203084833,
+ "num_eq": 480,
+ "num_range": 630,
"upper_bound": "xELo5B1fcW8RsaCX"
},
{
- "distinct_range": 1.4378404357577699,
- "num_eq": 720,
- "num_range": 750,
- "upper_bound": "xxELo5B1f"
+ "distinct_range": 1.2112789203084833,
+ "num_eq": 660,
+ "num_range": 630,
+ "upper_bound": "xxELo5B1f"
},
{
- "distinct_range": 0.9777314963152836,
- "num_eq": 480,
- "num_range": 510,
+ "distinct_range": 1.0959190231362468,
+ "num_eq": 540,
+ "num_range": 570,
"upper_bound": "xxELo5B1fcW"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 510,
- "num_range": 600,
- "upper_bound": "xxELo5B1fcW8R"
+ "distinct_range": 1.4996786632390744,
+ "num_eq": 390,
+ "num_range": 780,
+ "upper_bound": "xxELo5B1fcW8Rs"
},
{
- "distinct_range": 1.2652995834668375,
- "num_eq": 540,
- "num_range": 660,
- "upper_bound": "xxELo5B1fcW8Rsa"
+ "distinct_range": 0.8075192802056554,
+ "num_eq": 570,
+ "num_range": 420,
+ "upper_bound": "xxELo5B1fcW8RsaC"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 450,
- "num_range": 600,
- "upper_bound": "y3v1U5yr"
+ "distinct_range": 1.2689588688946014,
+ "num_eq": 570,
+ "num_range": 660,
+ "upper_bound": "y3v1U5yra"
},
{
- "distinct_range": 1.3228132008971483,
- "num_eq": 750,
- "num_range": 690,
+ "distinct_range": 0.8075192802056554,
+ "num_eq": 720,
+ "num_range": 420,
"upper_bound": "y3v1U5yraPx"
},
{
- "distinct_range": 1.4953540531880807,
- "num_eq": 450,
- "num_range": 780,
- "upper_bound": "y3v1U5yraPxxEL"
- },
- {
- "distinct_range": 0.6901634091637295,
- "num_eq": 600,
- "num_range": 360,
- "upper_bound": "y3v1U5yraPxxELo5"
+ "distinct_range": 0.7498393316195372,
+ "num_eq": 540,
+ "num_range": 390,
+ "upper_bound": "y3v1U5yraPxxE"
},
{
- "distinct_range": 0.862704261454662,
- "num_eq": 510,
- "num_range": 450,
- "upper_bound": "yraPxxELo"
+ "distinct_range": 1.153598971722365,
+ "num_eq": 630,
+ "num_range": 600,
+ "upper_bound": "y3v1U5yraPxxELo"
},
{
- "distinct_range": 1.1502723486062159,
- "num_eq": 600,
- "num_range": 600,
- "upper_bound": "yraPxxELo5B"
+ "distinct_range": 0.9805591259640102,
+ "num_eq": 720,
+ "num_range": 510,
+ "upper_bound": "yraPxxEL"
},
{
- "distinct_range": 0.8051906440243511,
- "num_eq": 360,
- "num_range": 420,
- "upper_bound": "yraPxxELo5B1f"
+ "distinct_range": 1.0959190231362468,
+ "num_eq": 630,
+ "num_range": 570,
+ "upper_bound": "yraPxxELo5"
},
{
- "distinct_range": 0.9777314963152836,
+ "distinct_range": 0.9228791773778919,
"num_eq": 570,
- "num_range": 510,
- "upper_bound": "yraPxxELo5B1fcW"
+ "num_range": 480,
+ "upper_bound": "yraPxxELo5B1"
},
{
- "distinct_range": 1.092758731175905,
- "num_eq": 390,
+ "distinct_range": 1.0959190231362468,
+ "num_eq": 420,
"num_range": 570,
- "upper_bound": "zmssaF9m"
+ "upper_bound": "yraPxxELo5B1fc"
},
{
- "distinct_range": 1.2077859660365267,
- "num_eq": 480,
- "num_range": 630,
- "upper_bound": "zmssaF9m9c"
+ "distinct_range": 1.0382390745501284,
+ "num_eq": 390,
+ "num_range": 540,
+ "upper_bound": "yraPxxELo5B1fcW8"
},
{
"distinct_range": 0,
- "num_eq": 750,
+ "num_eq": 780,
"num_range": 0,
- "upper_bound": "zmssaF9m9cd"
+ "upper_bound": "zmssaF9m"
},
{
- "distinct_range": 1.0352451137455942,
- "num_eq": 540,
- "num_range": 540,
- "upper_bound": "zmssaF9m9cdLX"
+ "distinct_range": 0.692159383033419,
+ "num_eq": 630,
+ "num_range": 360,
+ "upper_bound": "zmssaF9m9c"
+ },
+ {
+ "distinct_range": 0.7498393316195372,
+ "num_eq": 390,
+ "num_range": 390,
+ "upper_bound": "zmssaF9m9cdL"
},
{
"distinct_range": 0,
- "num_eq": 690,
+ "num_eq": 840,
"num_range": 0,
- "upper_bound": "zmssaF9m9cdLXe"
+ "upper_bound": "zmssaF9m9cdLX"
},
{
"distinct_range": 0,
"num_eq": 630,
"num_range": 0,
- "upper_bound": "zmssaF9m9cdLXe0"
+ "upper_bound": "zmssaF9m9cdLXe"
},
{
- "distinct_range": 0,
- "num_eq": 480,
- "num_range": 0,
+ "distinct_range": 1.0382390745501284,
+ "num_eq": 690,
+ "num_range": 540,
"upper_bound": "zmssaF9m9cdLXe0Y"
}
],
@@ -3808,13 +3809,14 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 30,
"columns": [
"c_w_id",
"c_d_id",
"c_last",
"c_first"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 296493,
"histo_col_type": "",
"name": "__auto__",
@@ -3822,10 +3824,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 4,
"columns": [
"c_middle"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -3842,22 +3845,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 17,
"columns": [
"c_street_1"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 770,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 570,
+ "num_eq": 360,
"num_range": 0,
"upper_bound": "0YhgLRrwsm"
},
{
- "distinct_range": 768,
- "num_eq": 390,
- "num_range": 299040,
+ "distinct_range": 767.9999999999999,
+ "num_eq": 750,
+ "num_range": 298890,
"upper_bound": "zmssaF9m9cdLXe0YhgLR"
}
],
@@ -3868,22 +3872,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 17,
"columns": [
"c_street_2"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 880,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 60,
+ "num_eq": 30,
"num_range": 0,
- "upper_bound": "0ObpVWo1Ba"
+ "upper_bound": "0ObpVWo1BahdejZr"
},
{
"distinct_range": 878,
- "num_eq": 540,
- "num_range": 299400,
+ "num_eq": 450,
+ "num_range": 299520,
"upper_bound": "zmssaF9m9cdLXe0YhgLR"
}
],
@@ -3894,10 +3899,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 18,
"columns": [
"c_city"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 965,
"histo_buckets": [
{
@@ -3908,8 +3914,8 @@ ALTER TABLE "customer" INJECT STATISTICS '[
},
{
"distinct_range": 963.0000000000001,
- "num_eq": 540,
- "num_range": 298980,
+ "num_eq": 420,
+ "num_range": 299100,
"upper_bound": "zmssaF9m9cdLXe0YhgLR"
}
],
@@ -3920,22 +3926,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 4,
"columns": [
"c_state"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 26,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 10680,
+ "num_eq": 11310,
"num_range": 0,
"upper_bound": "AK"
},
{
"distinct_range": 24,
- "num_eq": 11940,
- "num_range": 277380,
+ "num_eq": 11610,
+ "num_range": 277080,
"upper_bound": "ZT"
}
],
@@ -3946,22 +3953,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 11,
"columns": [
"c_zip"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 28770,
+ "num_eq": 28650,
"num_range": 0,
"upper_bound": "022311111"
},
{
"distinct_range": 8,
- "num_eq": 31110,
- "num_range": 240120,
+ "num_eq": 29940,
+ "num_range": 241410,
"upper_bound": "902211111"
}
],
@@ -3972,22 +3980,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 18,
"columns": [
"c_phone"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 31140,
+ "num_eq": 30480,
"num_range": 0,
"upper_bound": "0223082947329423"
},
{
"distinct_range": 8,
- "num_eq": 30150,
- "num_range": 238710,
+ "num_eq": 31530,
+ "num_range": 237990,
"upper_bound": "9473294232201446"
}
],
@@ -3998,10 +4007,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 7,
"columns": [
"c_since"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -4018,21 +4028,22 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 4,
"columns": [
"c_credit"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 2,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 33570,
+ "num_eq": 34410,
"num_range": 0,
"upper_bound": "BC"
},
{
"distinct_range": 0,
- "num_eq": 266430,
+ "num_eq": 265590,
"num_range": 0,
"upper_bound": "GC"
}
@@ -4044,10 +4055,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 7,
"columns": [
"c_credit_lim"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -4064,22 +4076,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 6,
"columns": [
"c_discount"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 5000,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 90,
"num_range": 0,
- "upper_bound": "0.0001"
+ "upper_bound": "0"
},
{
"distinct_range": 4998,
- "num_eq": 30,
- "num_range": 299880,
+ "num_eq": 90,
+ "num_range": 299820,
"upper_bound": "0.5"
}
],
@@ -4090,10 +4103,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 6,
"columns": [
"c_balance"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -4110,10 +4124,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 6,
"columns": [
"c_ytd_payment"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -4130,10 +4145,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
"c_payment_cnt"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -4150,10 +4166,11 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
"c_delivery_cnt"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 1,
"histo_buckets": [
{
@@ -4170,22 +4187,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 403,
"columns": [
"c_data"
],
- "created_at": "2021-09-08 20:48:24.719584",
+ "created_at": "2022-02-25 01:08:05.836313",
"distinct_count": 16976,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 30,
"num_range": 0,
- "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk13xWSP8P9fwb2ZjtZAs3NbYdihFxFime6B6Adnt5jrXvRR7OGYhlpdljbDvShaRF4E9zNHsJ7ZvyiJ3n2X1f4fJoMgn5buTDyUmQupcYMoPylHqYo89SqHqQ4HFVNpmnIWHyIowzQN2r4uSQJ8PYVLLLZk9Epp6cNEnaVrN3JXcrBCOuRRSlC0zvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ1Ol7SuF7jPf275wNDlEbdC58hrunlPfhoY1dORoIgb0VnxqkqbEWTXujHUO"
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk13xWSP8P9fwb2ZjtZAs3NbYdihFxFime6B6Adnt5jrXvRR7OGYhlpdljbDvShaRF4E9zNHsJ7ZvyiJ3n2X1f4fJoMgn5buTDyUmQupcYMoPylHqYo89SqHqQ4HFVNpmnIWHyIowzQN2r4uSQJ8PYVLLLZk9Epp6cNEnaVrN3JXcrBCOuRRSlC0zvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ1Ol7SuF7jPf275wNDlEbdC58hrunlPfhoY1dORoIgb0VnxqkqbEWTXujHUOvCRfqCd"
},
{
"distinct_range": 16974,
- "num_eq": 390,
- "num_range": 299580,
+ "num_eq": 240,
+ "num_range": 299730,
"upper_bound": "zmssaF9m9cdLXe0YhgLRrwsmd68P2bElAgrnp8ueWNXJpBB0ObpVWo1BahdejZrKB2O3Hzk13xWSP8P9fwb2ZjtZAs3NbYdihFxFime6B6Adnt5jrXvRR7OGYhlpdljbDvShaRF4E9zNHsJ7ZvyiJ3n2X1f4fJoMgn5buTDyUmQupcYMoPylHqYo89SqHqQ4HFVNpmnIWHyIowzQN2r4uSQJ8PYVLLLZk9Epp6cNEnaVrN3JXcrBCOuRRSlC0zvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ1Ol7SuF7jPf275wNDlEbdC58hrunlPfhoY1dORoIgb0VnxqkqbEWTXujHUOvCRfqCdVyc8gRGMfAd4nWB1rXYANQ0fa6ZQJJI2uTeFFazaVwxnN"
}
],
@@ -4194,76 +4212,72 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"name": "__auto__",
"null_count": 0,
"row_count": 300000
- }
-]';
-----
-
-exec-ddl
-ALTER TABLE "district" INJECT STATISTICS '[
+ },
{
+ "avg_size": 1,
"columns": [
- "d_w_id"
+ "c_w_id"
],
- "created_at": "2021-09-08 20:49:16.527128",
+ "created_at": "2022-02-25 01:09:16.735123",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29520,
"num_range": 0,
"upper_bound": "0"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 32190,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29730,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29040,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 30060,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 30510,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29700,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 30150,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29250,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29850,
"num_range": 0,
"upper_bound": "9"
}
@@ -4272,72 +4286,73 @@ ALTER TABLE "district" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 100
+ "row_count": 300000
},
{
+ "avg_size": 1,
"columns": [
- "d_id"
+ "c_d_id"
],
- "created_at": "2021-09-08 20:49:16.527128",
+ "created_at": "2022-02-25 01:09:16.735123",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29640,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 30540,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29280,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 30000,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 32070,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 28470,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29250,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 30450,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 29280,
"num_range": 0,
"upper_bound": "9"
},
{
"distinct_range": 0,
- "num_eq": 10,
+ "num_eq": 31020,
"num_range": 0,
"upper_bound": "10"
}
@@ -4346,313 +4361,14690 @@ ALTER TABLE "district" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 100
+ "row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
- "d_w_id",
- "d_id"
+ "c_w_id",
+ "c_d_id"
],
- "created_at": "2021-09-08 20:49:16.527128",
+ "created_at": "2022-02-25 01:09:16.735123",
"distinct_count": 100,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 100
+ "row_count": 300000
},
{
+ "avg_size": 3,
"columns": [
- "d_name"
+ "c_id"
],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 78,
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 2999,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1,
+ "num_eq": 150,
"num_range": 0,
- "upper_bound": "1U5yraPx"
+ "upper_bound": "1"
},
{
- "distinct_range": 76,
- "num_eq": 1,
- "num_range": 98,
- "upper_bound": "zmssaF9m"
- }
- ],
- "histo_col_type": "VARCHAR(10)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_street_1"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 91,
- "histo_buckets": [
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "17"
+ },
{
- "distinct_range": 0,
- "num_eq": 1,
- "num_range": 0,
- "upper_bound": "0YhgLRrwsmd68P2bEl"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 210,
+ "num_range": 1470,
+ "upper_bound": "37"
},
{
- "distinct_range": 89,
- "num_eq": 1,
- "num_range": 98,
- "upper_bound": "zmssaF9m9cdL"
- }
- ],
- "histo_col_type": "VARCHAR(20)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_street_2"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 95,
- "histo_buckets": [
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "55"
+ },
{
- "distinct_range": 0,
- "num_eq": 1,
- "num_range": 0,
- "upper_bound": "0YhgLRrwsmd68"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "70"
},
{
- "distinct_range": 93,
- "num_eq": 1,
- "num_range": 98,
- "upper_bound": "zmssaF9m9cdLXe0YhgLR"
- }
- ],
- "histo_col_type": "VARCHAR(20)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_city"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 94,
- "histo_buckets": [
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "85"
+ },
{
- "distinct_range": 0,
- "num_eq": 1,
- "num_range": 0,
- "upper_bound": "0YhgLRrwsmd"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "101"
},
{
- "distinct_range": 92,
- "num_eq": 1,
- "num_range": 98,
- "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "115"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "127"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "144"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "159"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "173"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 240,
+ "num_range": 1410,
+ "upper_bound": "191"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "206"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "222"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "236"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "254"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "272"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "286"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "303"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "317"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "333"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "348"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "361"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "377"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "390"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "408"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "421"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "433"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "450"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "466"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "479"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "491"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "507"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "518"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "533"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "544"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "559"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "570"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "585"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "602"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 270,
+ "num_range": 1350,
+ "upper_bound": "615"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "630"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "646"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "664"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "679"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "694"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "711"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "725"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "737"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "752"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "767"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "782"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "794"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "806"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "824"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "838"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "854"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "869"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "885"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "902"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "916"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "930"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "945"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "961"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "974"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "986"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1001"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1018"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1032"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1048"
+ },
+ {
+ "distinct_range": 19.992857142857144,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1069"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1082"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1095"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1109"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1123"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1143"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1160"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1176"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1193"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 270,
+ "num_range": 1320,
+ "upper_bound": "1207"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1220"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1236"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1249"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1266"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "1280"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1292"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1308"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1326"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1341"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1352"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1366"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1381"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1397"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1412"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "1427"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1441"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1454"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1471"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1486"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1499"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1516"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1535"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1551"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1565"
+ },
+ {
+ "distinct_range": 20.9925,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1587"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1602"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1621"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1635"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 270,
+ "num_range": 1320,
+ "upper_bound": "1649"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 300,
+ "num_range": 1290,
+ "upper_bound": "1664"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "1678"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1694"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1711"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "1729"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1741"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1755"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "1771"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1786"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1801"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1818"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1834"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1849"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1864"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1883"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "1898"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1915"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1931"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1944"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1959"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1974"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 240,
+ "num_range": 1380,
+ "upper_bound": "1992"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2007"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2024"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "2036"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2054"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2070"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2086"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 270,
+ "num_range": 1230,
+ "upper_bound": "2101"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "2119"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2137"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2148"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2161"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2180"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2198"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2213"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2227"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2240"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2255"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2274"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "2289"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2303"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2321"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2335"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2350"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2366"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2380"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2391"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2407"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2420"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "2434"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2450"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2469"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2489"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2504"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2518"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2530"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2543"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2557"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2572"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2584"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2598"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2614"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2625"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2638"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1230,
+ "upper_bound": "2650"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2663"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2677"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2691"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1230,
+ "upper_bound": "2705"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2720"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2735"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2746"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2761"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2776"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2789"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2804"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2821"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2837"
+ },
+ {
+ "distinct_range": 19.992857142857144,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2858"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2872"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 60,
+ "num_range": 1320,
+ "upper_bound": "2892"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2905"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2919"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2934"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2946"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1260,
+ "upper_bound": "2959"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 240,
+ "num_range": 1170,
+ "upper_bound": "2974"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 210,
+ "num_range": 1200,
+ "upper_bound": "2986"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1140,
+ "upper_bound": "3000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "c_w_id",
+ "c_d_id",
+ "c_id"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 295745,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 14,
+ "columns": [
+ "c_last"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1000,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 690,
+ "num_range": 0,
+ "upper_bound": "ABLEABLEABLE"
+ },
+ {
+ "distinct_range": 6.6628137980856055,
+ "num_eq": 360,
+ "num_range": 1380,
+ "upper_bound": "ABLEABLEBAR"
+ },
+ {
+ "distinct_range": 6.6628137980856055,
+ "num_eq": 240,
+ "num_range": 1380,
+ "upper_bound": "ABLEABLEOUGHT"
+ },
+ {
+ "distinct_range": 7.097345132743363,
+ "num_eq": 180,
+ "num_range": 1470,
+ "upper_bound": "ABLEANTIBAR"
+ },
+ {
+ "distinct_range": 5.648907350550839,
+ "num_eq": 600,
+ "num_range": 1170,
+ "upper_bound": "ABLEATIONANTI"
+ },
+ {
+ "distinct_range": 6.95250135452411,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "ABLEATIONPRI"
+ },
+ {
+ "distinct_range": 6.807657576304858,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "ABLEBARESE"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 720,
+ "num_range": 900,
+ "upper_bound": "ABLECALLYATION"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 780,
+ "num_range": 1200,
+ "upper_bound": "ABLEEINGABLE"
+ },
+ {
+ "distinct_range": 6.807657576304858,
+ "num_eq": 270,
+ "num_range": 1410,
+ "upper_bound": "ABLEEINGOUGHT"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1710,
+ "num_range": 0,
+ "upper_bound": "ABLEEINGPRES"
+ },
+ {
+ "distinct_range": 6.95250135452411,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "ABLEESEEING"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 390,
+ "num_range": 1200,
+ "upper_bound": "ABLEOUGHTBAR"
+ },
+ {
+ "distinct_range": 6.807657576304858,
+ "num_eq": 240,
+ "num_range": 1410,
+ "upper_bound": "ABLEPRESABLE"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 1800,
+ "num_range": 1200,
+ "upper_bound": "ABLEPRIBAR"
+ },
+ {
+ "distinct_range": 6.807657576304858,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "ANTIABLEOUGHT"
+ },
+ {
+ "distinct_range": 6.95250135452411,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "ANTIANTIOUGHT"
+ },
+ {
+ "distinct_range": 6.807657576304858,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "ANTIATIONPRI"
+ },
+ {
+ "distinct_range": 3.910782011919812,
+ "num_eq": 1440,
+ "num_range": 810,
+ "upper_bound": "ANTIBARANTI"
+ },
+ {
+ "distinct_range": 4.779844681235326,
+ "num_eq": 690,
+ "num_range": 990,
+ "upper_bound": "ANTIBAREING"
+ },
+ {
+ "distinct_range": 3.910782011919812,
+ "num_eq": 960,
+ "num_range": 810,
+ "upper_bound": "ANTIBARPRES"
+ },
+ {
+ "distinct_range": 3.910782011919812,
+ "num_eq": 840,
+ "num_range": 810,
+ "upper_bound": "ANTICALLYATION"
+ },
+ {
+ "distinct_range": 6.807657576304858,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "ANTIEINGANTI"
+ },
+ {
+ "distinct_range": 6.517970019866353,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "ANTIESEABLE"
+ },
+ {
+ "distinct_range": 4.200469568358317,
+ "num_eq": 1560,
+ "num_range": 870,
+ "upper_bound": "ANTIOUGHTABLE"
+ },
+ {
+ "distinct_range": 1.013906447534766,
+ "num_eq": 1980,
+ "num_range": 210,
+ "upper_bound": "ANTIOUGHTBAR"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 5160,
+ "num_range": 1020,
+ "upper_bound": "ANTIOUGHTPRES"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1920,
+ "num_range": 0,
+ "upper_bound": "ANTIOUGHTPRI"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "ANTIPRESPRI"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 660,
+ "num_range": 930,
+ "upper_bound": "ATIONABLEABLE"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 270,
+ "num_range": 1200,
+ "upper_bound": "ATIONABLEESE"
+ },
+ {
+ "distinct_range": 2.896875564385046,
+ "num_eq": 1800,
+ "num_range": 600,
+ "upper_bound": "ATIONANTIABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1710,
+ "num_range": 0,
+ "upper_bound": "ATIONANTIANTI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1860,
+ "num_range": 0,
+ "upper_bound": "ATIONANTIATION"
+ },
+ {
+ "distinct_range": 6.517970019866353,
+ "num_eq": 1350,
+ "num_range": 1350,
+ "upper_bound": "ATIONANTIEING"
+ },
+ {
+ "distinct_range": 3.1865631208235508,
+ "num_eq": 810,
+ "num_range": 660,
+ "upper_bound": "ATIONANTIOUGHT"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "ATIONATIONANTI"
+ },
+ {
+ "distinct_range": 3.3314068990428027,
+ "num_eq": 810,
+ "num_range": 690,
+ "upper_bound": "ATIONBARABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1770,
+ "num_range": 0,
+ "upper_bound": "ATIONBARANTI"
+ },
+ {
+ "distinct_range": 6.6628137980856055,
+ "num_eq": 450,
+ "num_range": 1380,
+ "upper_bound": "ATIONBAROUGHT"
+ },
+ {
+ "distinct_range": 6.6628137980856055,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "ATIONCALLYATION"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 5640,
+ "num_range": 0,
+ "upper_bound": "ATIONCALLYBAR"
+ },
+ {
+ "distinct_range": 6.517970019866353,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "ATIONEINGESE"
+ },
+ {
+ "distinct_range": 5.648907350550839,
+ "num_eq": 270,
+ "num_range": 1170,
+ "upper_bound": "ATIONESEANTI"
+ },
+ {
+ "distinct_range": 3.6210944554813076,
+ "num_eq": 660,
+ "num_range": 750,
+ "upper_bound": "ATIONESEBAR"
+ },
+ {
+ "distinct_range": 5.648907350550839,
+ "num_eq": 1740,
+ "num_range": 1170,
+ "upper_bound": "ATIONESEPRES"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 120,
+ "num_range": 1230,
+ "upper_bound": "ATIONOUGHTBAR"
+ },
+ {
+ "distinct_range": 4.635000903016073,
+ "num_eq": 750,
+ "num_range": 960,
+ "upper_bound": "ATIONPRESANTI"
+ },
+ {
+ "distinct_range": 6.3731262416471015,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "ATIONPRESPRI"
+ },
+ {
+ "distinct_range": 5.0695322376738305,
+ "num_eq": 1680,
+ "num_range": 1050,
+ "upper_bound": "ATIONPRIATION"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 300,
+ "num_range": 1260,
+ "upper_bound": "ATIONPRIESE"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 330,
+ "num_range": 1140,
+ "upper_bound": "BARABLEABLE"
+ },
+ {
+ "distinct_range": 6.3731262416471015,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "BARABLEPRI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 2130,
+ "num_range": 0,
+ "upper_bound": "BARANTIABLE"
+ },
+ {
+ "distinct_range": 6.3731262416471015,
+ "num_eq": 630,
+ "num_range": 1320,
+ "upper_bound": "BARANTIOUGHT"
+ },
+ {
+ "distinct_range": 6.228282463427849,
+ "num_eq": 60,
+ "num_range": 1290,
+ "upper_bound": "BARATIONCALLY"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 180,
+ "num_range": 1200,
+ "upper_bound": "BARBARANTI"
+ },
+ {
+ "distinct_range": 4.635000903016073,
+ "num_eq": 360,
+ "num_range": 960,
+ "upper_bound": "BARCALLYANTI"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "BARCALLYOUGHT"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 240,
+ "num_range": 1200,
+ "upper_bound": "BAREINGATION"
+ },
+ {
+ "distinct_range": 6.228282463427849,
+ "num_eq": 270,
+ "num_range": 1290,
+ "upper_bound": "BAREINGOUGHT"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 2070,
+ "num_range": 0,
+ "upper_bound": "BAREINGPRES"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 300,
+ "num_range": 1020,
+ "upper_bound": "BARESEABLE"
+ },
+ {
+ "distinct_range": 5.214376015893083,
+ "num_eq": 270,
+ "num_range": 1080,
+ "upper_bound": "BARESECALLY"
+ },
+ {
+ "distinct_range": 2.462344229727289,
+ "num_eq": 1050,
+ "num_range": 510,
+ "upper_bound": "BARESEPRES"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 90,
+ "num_range": 1230,
+ "upper_bound": "BAROUGHTOUGHT"
+ },
+ {
+ "distinct_range": 3.1865631208235508,
+ "num_eq": 720,
+ "num_range": 660,
+ "upper_bound": "BARPRESANTI"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "BARPRIABLE"
+ },
+ {
+ "distinct_range": 6.228282463427849,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "BARPRICALLY"
+ },
+ {
+ "distinct_range": 3.0417193426042983,
+ "num_eq": 870,
+ "num_range": 630,
+ "upper_bound": "CALLYABLEANTI"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 330,
+ "num_range": 1140,
+ "upper_bound": "CALLYABLEPRES"
+ },
+ {
+ "distinct_range": 6.228282463427849,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "CALLYANTIOUGHT"
+ },
+ {
+ "distinct_range": 5.0695322376738305,
+ "num_eq": 300,
+ "num_range": 1050,
+ "upper_bound": "CALLYATIONATION"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 420,
+ "num_range": 1140,
+ "upper_bound": "CALLYATIONPRES"
+ },
+ {
+ "distinct_range": 6.228282463427849,
+ "num_eq": 90,
+ "num_range": 1290,
+ "upper_bound": "CALLYBARESE"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 90,
+ "num_range": 1260,
+ "upper_bound": "CALLYCALLYCALLY"
+ },
+ {
+ "distinct_range": 4.779844681235326,
+ "num_eq": 330,
+ "num_range": 990,
+ "upper_bound": "CALLYCALLYPRI"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 780,
+ "num_range": 1230,
+ "upper_bound": "CALLYEINGBAR"
+ },
+ {
+ "distinct_range": 6.228282463427849,
+ "num_eq": 60,
+ "num_range": 1290,
+ "upper_bound": "CALLYESEABLE"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 270,
+ "num_range": 1260,
+ "upper_bound": "CALLYESEPRES"
+ },
+ {
+ "distinct_range": 2.896875564385046,
+ "num_eq": 900,
+ "num_range": 600,
+ "upper_bound": "CALLYOUGHTBAR"
+ },
+ {
+ "distinct_range": 3.7659382337005596,
+ "num_eq": 1440,
+ "num_range": 780,
+ "upper_bound": "CALLYPRESABLE"
+ },
+ {
+ "distinct_range": 5.0695322376738305,
+ "num_eq": 840,
+ "num_range": 1050,
+ "upper_bound": "CALLYPRESOUGHT"
+ },
+ {
+ "distinct_range": 3.6210944554813076,
+ "num_eq": 720,
+ "num_range": 750,
+ "upper_bound": "CALLYPRIATION"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 510,
+ "num_range": 1230,
+ "upper_bound": "CALLYPRIPRES"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 420,
+ "num_range": 930,
+ "upper_bound": "EINGABLEANTI"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 210,
+ "num_range": 1200,
+ "upper_bound": "EINGANTIABLE"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 180,
+ "num_range": 1200,
+ "upper_bound": "EINGANTIEING"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 270,
+ "num_range": 1020,
+ "upper_bound": "EINGANTIPRI"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 240,
+ "num_range": 1200,
+ "upper_bound": "EINGATIONBAR"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 180,
+ "num_range": 1200,
+ "upper_bound": "EINGATIONPRI"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 90,
+ "num_range": 1230,
+ "upper_bound": "EINGBARPRES"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 270,
+ "num_range": 1020,
+ "upper_bound": "EINGCALLYCALLY"
+ },
+ {
+ "distinct_range": 6.083438685208597,
+ "num_eq": 660,
+ "num_range": 1260,
+ "upper_bound": "EINGEINGANTI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 2070,
+ "num_range": 0,
+ "upper_bound": "EINGEINGATION"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 120,
+ "num_range": 1200,
+ "upper_bound": "EINGEINGEING"
+ },
+ {
+ "distinct_range": 5.648907350550839,
+ "num_eq": 270,
+ "num_range": 1170,
+ "upper_bound": "EINGEINGPRI"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 150,
+ "num_range": 1200,
+ "upper_bound": "EINGESEPRES"
+ },
+ {
+ "distinct_range": 5.648907350550839,
+ "num_eq": 210,
+ "num_range": 1170,
+ "upper_bound": "EINGOUGHTESE"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 180,
+ "num_range": 1140,
+ "upper_bound": "EINGPRESEING"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 180,
+ "num_range": 1230,
+ "upper_bound": "EINGPRIBAR"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 330,
+ "num_range": 1020,
+ "upper_bound": "EINGPRIPRI"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 270,
+ "num_range": 1140,
+ "upper_bound": "ESEABLEPRES"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 120,
+ "num_range": 1140,
+ "upper_bound": "ESEANTIATION"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 270,
+ "num_range": 1140,
+ "upper_bound": "ESEANTIOUGHT"
+ },
+ {
+ "distinct_range": 2.1726566732887846,
+ "num_eq": 1650,
+ "num_range": 450,
+ "upper_bound": "ESEATIONABLE"
+ },
+ {
+ "distinct_range": 5.648907350550839,
+ "num_eq": 300,
+ "num_range": 1170,
+ "upper_bound": "ESEATIONEING"
+ },
+ {
+ "distinct_range": 5.359219794112335,
+ "num_eq": 390,
+ "num_range": 1110,
+ "upper_bound": "ESEBARABLE"
+ },
+ {
+ "distinct_range": 5.938594906989344,
+ "num_eq": 90,
+ "num_range": 1230,
+ "upper_bound": "ESEBARPRES"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 330,
+ "num_range": 1020,
+ "upper_bound": "ESECALLYATION"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 210,
+ "num_range": 1140,
+ "upper_bound": "ESECALLYESE"
+ },
+ {
+ "distinct_range": 3.910782011919812,
+ "num_eq": 450,
+ "num_range": 810,
+ "upper_bound": "ESEEINGABLE"
+ },
+ {
+ "distinct_range": 2.027812895069532,
+ "num_eq": 2010,
+ "num_range": 420,
+ "upper_bound": "ESEEINGATION"
+ },
+ {
+ "distinct_range": 2.1726566732887846,
+ "num_eq": 780,
+ "num_range": 450,
+ "upper_bound": "ESEEINGCALLY"
+ },
+ {
+ "distinct_range": 3.0417193426042983,
+ "num_eq": 840,
+ "num_range": 630,
+ "upper_bound": "ESEEINGPRES"
+ },
+ {
+ "distinct_range": 4.200469568358317,
+ "num_eq": 1770,
+ "num_range": 870,
+ "upper_bound": "ESEESEBAR"
+ },
+ {
+ "distinct_range": 4.055625790139064,
+ "num_eq": 450,
+ "num_range": 840,
+ "upper_bound": "ESEOUGHTANTI"
+ },
+ {
+ "distinct_range": 5.793751128770092,
+ "num_eq": 60,
+ "num_range": 1200,
+ "upper_bound": "ESEOUGHTEING"
+ },
+ {
+ "distinct_range": 3.910782011919812,
+ "num_eq": 840,
+ "num_range": 810,
+ "upper_bound": "ESEPRESABLE"
+ },
+ {
+ "distinct_range": 1.8829691168502798,
+ "num_eq": 930,
+ "num_range": 390,
+ "upper_bound": "ESEPRESATION"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 480,
+ "num_range": 1140,
+ "upper_bound": "ESEPRESOUGHT"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 330,
+ "num_range": 1140,
+ "upper_bound": "ESEPRIATION"
+ },
+ {
+ "distinct_range": 5.504063572331587,
+ "num_eq": 690,
+ "num_range": 1140,
+ "upper_bound": "ESEPRIPRES"
+ },
+ {
+ "distinct_range": 1.448437782192523,
+ "num_eq": 1320,
+ "num_range": 300,
+ "upper_bound": "OUGHTABLEABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 3450,
+ "num_range": 0,
+ "upper_bound": "OUGHTABLEANTI"
+ },
+ {
+ "distinct_range": 5.359219794112335,
+ "num_eq": 1020,
+ "num_range": 1110,
+ "upper_bound": "OUGHTABLEESE"
+ },
+ {
+ "distinct_range": 2.462344229727289,
+ "num_eq": 1320,
+ "num_range": 510,
+ "upper_bound": "OUGHTABLEPRES"
+ },
+ {
+ "distinct_range": 3.476250677262055,
+ "num_eq": 450,
+ "num_range": 720,
+ "upper_bound": "OUGHTANTIABLE"
+ },
+ {
+ "distinct_range": 4.779844681235326,
+ "num_eq": 150,
+ "num_range": 990,
+ "upper_bound": "OUGHTANTIEING"
+ },
+ {
+ "distinct_range": 5.359219794112335,
+ "num_eq": 300,
+ "num_range": 1110,
+ "upper_bound": "OUGHTATIONABLE"
+ },
+ {
+ "distinct_range": 5.0695322376738305,
+ "num_eq": 150,
+ "num_range": 1050,
+ "upper_bound": "OUGHTATIONOUGHT"
+ },
+ {
+ "distinct_range": 3.6210944554813076,
+ "num_eq": 450,
+ "num_range": 750,
+ "upper_bound": "OUGHTBARANTI"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 300,
+ "num_range": 1020,
+ "upper_bound": "OUGHTBARCALLY"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 330,
+ "num_range": 900,
+ "upper_bound": "OUGHTBAROUGHT"
+ },
+ {
+ "distinct_range": 4.635000903016073,
+ "num_eq": 300,
+ "num_range": 960,
+ "upper_bound": "OUGHTCALLYPRES"
+ },
+ {
+ "distinct_range": 2.462344229727289,
+ "num_eq": 720,
+ "num_range": 510,
+ "upper_bound": "OUGHTEINGATION"
+ },
+ {
+ "distinct_range": 4.779844681235326,
+ "num_eq": 240,
+ "num_range": 990,
+ "upper_bound": "OUGHTEINGPRES"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 90,
+ "num_range": 1020,
+ "upper_bound": "OUGHTESECALLY"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 450,
+ "num_range": 900,
+ "upper_bound": "OUGHTOUGHTANTI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1650,
+ "num_range": 0,
+ "upper_bound": "OUGHTOUGHTATION"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1290,
+ "num_range": 0,
+ "upper_bound": "OUGHTOUGHTBAR"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 330,
+ "num_range": 930,
+ "upper_bound": "OUGHTOUGHTESE"
+ },
+ {
+ "distinct_range": 4.055625790139064,
+ "num_eq": 270,
+ "num_range": 840,
+ "upper_bound": "OUGHTOUGHTPRI"
+ },
+ {
+ "distinct_range": 4.924688459454578,
+ "num_eq": 120,
+ "num_range": 1020,
+ "upper_bound": "OUGHTPRESESE"
+ },
+ {
+ "distinct_range": 5.0695322376738305,
+ "num_eq": 60,
+ "num_range": 1050,
+ "upper_bound": "OUGHTPRIOUGHT"
+ },
+ {
+ "distinct_range": 5.214376015893083,
+ "num_eq": 330,
+ "num_range": 1080,
+ "upper_bound": "PRESABLEBAR"
+ },
+ {
+ "distinct_range": 5.0695322376738305,
+ "num_eq": 480,
+ "num_range": 1050,
+ "upper_bound": "PRESANTIABLE"
+ },
+ {
+ "distinct_range": 4.635000903016073,
+ "num_eq": 120,
+ "num_range": 960,
+ "upper_bound": "PRESANTIESE"
+ },
+ {
+ "distinct_range": 2.1726566732887846,
+ "num_eq": 630,
+ "num_range": 450,
+ "upper_bound": "PRESATIONABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1650,
+ "num_range": 0,
+ "upper_bound": "PRESATIONANTI"
+ },
+ {
+ "distinct_range": 3.3314068990428027,
+ "num_eq": 750,
+ "num_range": 690,
+ "upper_bound": "PRESATIONESE"
+ },
+ {
+ "distinct_range": 1.7381253386310276,
+ "num_eq": 750,
+ "num_range": 360,
+ "upper_bound": "PRESATIONPRES"
+ },
+ {
+ "distinct_range": 4.635000903016073,
+ "num_eq": 150,
+ "num_range": 960,
+ "upper_bound": "PRESBARESE"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 270,
+ "num_range": 930,
+ "upper_bound": "PRESCALLYANTI"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 600,
+ "num_range": 900,
+ "upper_bound": "PRESCALLYBAR"
+ },
+ {
+ "distinct_range": 4.200469568358317,
+ "num_eq": 330,
+ "num_range": 870,
+ "upper_bound": "PRESCALLYPRES"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 150,
+ "num_range": 900,
+ "upper_bound": "PRESEINGPRES"
+ },
+ {
+ "distinct_range": 4.055625790139064,
+ "num_eq": 210,
+ "num_range": 840,
+ "upper_bound": "PRESESEEING"
+ },
+ {
+ "distinct_range": 4.779844681235326,
+ "num_eq": 270,
+ "num_range": 990,
+ "upper_bound": "PRESESEPRI"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 180,
+ "num_range": 930,
+ "upper_bound": "PRESOUGHTEING"
+ },
+ {
+ "distinct_range": 4.200469568358317,
+ "num_eq": 240,
+ "num_range": 870,
+ "upper_bound": "PRESPRESANTI"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 180,
+ "num_range": 930,
+ "upper_bound": "PRESPRESPRI"
+ },
+ {
+ "distinct_range": 4.055625790139064,
+ "num_eq": 270,
+ "num_range": 840,
+ "upper_bound": "PRESPRIESE"
+ },
+ {
+ "distinct_range": 1.8829691168502798,
+ "num_eq": 780,
+ "num_range": 390,
+ "upper_bound": "PRIABLEABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1560,
+ "num_range": 0,
+ "upper_bound": "PRIABLEANTI"
+ },
+ {
+ "distinct_range": 3.7659382337005596,
+ "num_eq": 750,
+ "num_range": 780,
+ "upper_bound": "PRIABLEESE"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 510,
+ "num_range": 900,
+ "upper_bound": "PRIABLEPRI"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 150,
+ "num_range": 930,
+ "upper_bound": "PRIANTIOUGHT"
+ },
+ {
+ "distinct_range": 4.635000903016073,
+ "num_eq": 120,
+ "num_range": 960,
+ "upper_bound": "PRIATIONBAR"
+ },
+ {
+ "distinct_range": 3.7659382337005596,
+ "num_eq": 360,
+ "num_range": 780,
+ "upper_bound": "PRIBARABLE"
+ },
+ {
+ "distinct_range": 4.200469568358317,
+ "num_eq": 150,
+ "num_range": 870,
+ "upper_bound": "PRIBARCALLY"
+ },
+ {
+ "distinct_range": 4.345313346577569,
+ "num_eq": 120,
+ "num_range": 900,
+ "upper_bound": "PRICALLYANTI"
+ },
+ {
+ "distinct_range": 4.490157124796821,
+ "num_eq": 210,
+ "num_range": 930,
+ "upper_bound": "PRIEINGBAR"
+ },
+ {
+ "distinct_range": 2.6071880079465415,
+ "num_eq": 810,
+ "num_range": 540,
+ "upper_bound": "PRIESEABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1410,
+ "num_range": 0,
+ "upper_bound": "PRIESEANTI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 5040,
+ "num_range": 0,
+ "upper_bound": "PRIESEATION"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 1590,
+ "num_range": 0,
+ "upper_bound": "PRIESEBAR"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 2010,
+ "num_range": 0,
+ "upper_bound": "PRIESECALLY"
+ },
+ {
+ "distinct_range": 0.7242188910962615,
+ "num_eq": 600,
+ "num_range": 150,
+ "upper_bound": "PRIESEESE"
+ },
+ {
+ "distinct_range": 1.448437782192523,
+ "num_eq": 1650,
+ "num_range": 300,
+ "upper_bound": "PRIESEPRES"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 720,
+ "num_range": 0,
+ "upper_bound": "PRIESEPRI"
+ },
+ {
+ "distinct_range": 2.027812895069532,
+ "num_eq": 540,
+ "num_range": 420,
+ "upper_bound": "PRIOUGHTATION"
+ },
+ {
+ "distinct_range": 2.6071880079465415,
+ "num_eq": 480,
+ "num_range": 540,
+ "upper_bound": "PRIOUGHTCALLY"
+ },
+ {
+ "distinct_range": 2.6071880079465415,
+ "num_eq": 360,
+ "num_range": 540,
+ "upper_bound": "PRIOUGHTPRES"
+ },
+ {
+ "distinct_range": 0.7242188910962615,
+ "num_eq": 1530,
+ "num_range": 150,
+ "upper_bound": "PRIPRESABLE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 600,
+ "num_range": 0,
+ "upper_bound": "PRIPRESANTI"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 690,
+ "num_range": 0,
+ "upper_bound": "PRIPRESATION"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 660,
+ "num_range": 0,
+ "upper_bound": "PRIPRESBAR"
+ },
+ {
+ "distinct_range": 2.027812895069532,
+ "num_eq": 540,
+ "num_range": 420,
+ "upper_bound": "PRIPRESEING"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 480,
+ "num_range": 0,
+ "upper_bound": "PRIPRESESE"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 750,
+ "num_range": 0,
+ "upper_bound": "PRIPRESOUGHT"
+ },
+ {
+ "distinct_range": 1.7381253386310276,
+ "num_eq": 270,
+ "num_range": 360,
+ "upper_bound": "PRIPRIABLE"
+ },
+ {
+ "distinct_range": 1.5932815604117754,
+ "num_eq": 450,
+ "num_range": 330,
+ "upper_bound": "PRIPRIATION"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 360,
+ "num_range": 0,
+ "upper_bound": "PRIPRIBAR"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 420,
+ "num_range": 0,
+ "upper_bound": "PRIPRICALLY"
+ },
+ {
+ "distinct_range": 1.1587502257540183,
+ "num_eq": 180,
+ "num_range": 240,
+ "upper_bound": "PRIPRIESE"
+ },
+ {
+ "distinct_range": 0.7242188910962615,
+ "num_eq": 690,
+ "num_range": 150,
+ "upper_bound": "PRIPRIPRES"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 270,
+ "num_range": 0,
+ "upper_bound": "PRIPRIPRI"
+ }
+ ],
+ "histo_col_type": "VARCHAR(16)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 16,
+ "columns": [
+ "c_w_id",
+ "c_d_id",
+ "c_last"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 99837,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 14,
+ "columns": [
+ "c_first"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 558,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 390,
+ "num_range": 0,
+ "upper_bound": "1U5yraPx"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 480,
+ "num_range": 1050,
+ "upper_bound": "1U5yraPxxEL"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 540,
+ "num_range": 1230,
+ "upper_bound": "1U5yraPxxELo5B"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 390,
+ "num_range": 1320,
+ "upper_bound": "1fcW8Rsa"
+ },
+ {
+ "distinct_range": 2.601449275362319,
+ "num_eq": 630,
+ "num_range": 1380,
+ "upper_bound": "1fcW8RsaCXoE"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 570,
+ "num_range": 1050,
+ "upper_bound": "1fcW8RsaCXoEzms"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 630,
+ "num_range": 1110,
+ "upper_bound": "3v1U5yraP"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 330,
+ "num_range": 1230,
+ "upper_bound": "3v1U5yraPxxE"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 570,
+ "num_range": 990,
+ "upper_bound": "3v1U5yraPxxELo5"
+ },
+ {
+ "distinct_range": 2.601449275362319,
+ "num_eq": 300,
+ "num_range": 1380,
+ "upper_bound": "5B1fcW8Rsa"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 420,
+ "num_range": 1200,
+ "upper_bound": "5B1fcW8RsaCXo"
+ },
+ {
+ "distinct_range": 1.526937618147448,
+ "num_eq": 690,
+ "num_range": 810,
+ "upper_bound": "5B1fcW8RsaCXoEz"
+ },
+ {
+ "distinct_range": 2.3752362948960304,
+ "num_eq": 420,
+ "num_range": 1260,
+ "upper_bound": "5yraPxxEL"
+ },
+ {
+ "distinct_range": 1.4703843730308759,
+ "num_eq": 690,
+ "num_range": 780,
+ "upper_bound": "5yraPxxELo5B"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 690,
+ "num_range": 1050,
+ "upper_bound": "5yraPxxELo5B1fc"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 540,
+ "num_range": 1320,
+ "upper_bound": "6NHnwiwKd"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 630,
+ "num_range": 1170,
+ "upper_bound": "6NHnwiwKdcgp"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 690,
+ "num_range": 1110,
+ "upper_bound": "6NHnwiwKdcgphy3"
+ },
+ {
+ "distinct_range": 2.601449275362319,
+ "num_eq": 510,
+ "num_range": 1380,
+ "upper_bound": "6rumMmp6NH"
+ },
+ {
+ "distinct_range": 2.7145557655954633,
+ "num_eq": 420,
+ "num_range": 1440,
+ "upper_bound": "6rumMmp6NHnwiw"
+ },
+ {
+ "distinct_range": 1.8097038437303088,
+ "num_eq": 510,
+ "num_range": 960,
+ "upper_bound": "8RsaCXoE"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 330,
+ "num_range": 1170,
+ "upper_bound": "8RsaCXoEzms"
+ },
+ {
+ "distinct_range": 2.7145557655954633,
+ "num_eq": 690,
+ "num_range": 1440,
+ "upper_bound": "8RsaCXoEzmssaF9"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 540,
+ "num_range": 930,
+ "upper_bound": "9cdLXe0Yh"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 570,
+ "num_range": 930,
+ "upper_bound": "9cdLXe0YhgLR"
+ },
+ {
+ "distinct_range": 2.4317895400126024,
+ "num_eq": 540,
+ "num_range": 1290,
+ "upper_bound": "9cdLXe0YhgLRrws"
+ },
+ {
+ "distinct_range": 2.7145557655954633,
+ "num_eq": 510,
+ "num_range": 1440,
+ "upper_bound": "9m9cdLXe0"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 330,
+ "num_range": 1200,
+ "upper_bound": "9m9cdLXe0YhgL"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 780,
+ "num_range": 1230,
+ "upper_bound": "9m9cdLXe0YhgLRrw"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 480,
+ "num_range": 1320,
+ "upper_bound": "B1fcW8RsaC"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 570,
+ "num_range": 1050,
+ "upper_bound": "B1fcW8RsaCXoE"
+ },
+ {
+ "distinct_range": 2.149023314429742,
+ "num_eq": 630,
+ "num_range": 1140,
+ "upper_bound": "B1fcW8RsaCXoEzms"
+ },
+ {
+ "distinct_range": 2.601449275362319,
+ "num_eq": 420,
+ "num_range": 1380,
+ "upper_bound": "CXoEzmssaF"
+ },
+ {
+ "distinct_range": 2.3752362948960304,
+ "num_eq": 450,
+ "num_range": 1260,
+ "upper_bound": "CXoEzmssaF9m9"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 570,
+ "num_range": 900,
+ "upper_bound": "CXoEzmssaF9m9cdL"
+ },
+ {
+ "distinct_range": 2.4317895400126024,
+ "num_eq": 330,
+ "num_range": 1290,
+ "upper_bound": "ELo5B1fcW8R"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 570,
+ "num_range": 990,
+ "upper_bound": "ELo5B1fcW8RsaC"
+ },
+ {
+ "distinct_range": 2.3752362948960304,
+ "num_eq": 510,
+ "num_range": 1260,
+ "upper_bound": "EzmssaF9m"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 390,
+ "num_range": 1320,
+ "upper_bound": "EzmssaF9m9cdL"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 810,
+ "num_range": 1230,
+ "upper_bound": "EzmssaF9m9cdLXe0"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 420,
+ "num_range": 1050,
+ "upper_bound": "F9m9cdLXe0"
+ },
+ {
+ "distinct_range": 2.6580025204788913,
+ "num_eq": 570,
+ "num_range": 1410,
+ "upper_bound": "F9m9cdLXe0YhgL"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 540,
+ "num_range": 990,
+ "upper_bound": "HnwiwKdc"
+ },
+ {
+ "distinct_range": 2.6580025204788913,
+ "num_eq": 480,
+ "num_range": 1410,
+ "upper_bound": "HnwiwKdcgphy"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 900,
+ "num_range": 990,
+ "upper_bound": "HnwiwKdcgphy3v1"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 420,
+ "num_range": 1320,
+ "upper_bound": "Kdcgphy3v1"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 540,
+ "num_range": 900,
+ "upper_bound": "Kdcgphy3v1U5y"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 360,
+ "num_range": 1080,
+ "upper_bound": "Kdcgphy3v1U5yraP"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 510,
+ "num_range": 1170,
+ "upper_bound": "LXe0YhgLRr"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 570,
+ "num_range": 1080,
+ "upper_bound": "LXe0YhgLRrwsm"
+ },
+ {
+ "distinct_range": 2.3752362948960304,
+ "num_eq": 420,
+ "num_range": 1260,
+ "upper_bound": "Lo5B1fcW"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 630,
+ "num_range": 900,
+ "upper_bound": "Lo5B1fcW8Rs"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 480,
+ "num_range": 1230,
+ "upper_bound": "Lo5B1fcW8RsaCX"
+ },
+ {
+ "distinct_range": 1.4138311279143039,
+ "num_eq": 690,
+ "num_range": 750,
+ "upper_bound": "Lo5B1fcW8RsaCXoE"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 510,
+ "num_range": 990,
+ "upper_bound": "Mmp6NHnwiw"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 450,
+ "num_range": 1080,
+ "upper_bound": "Mmp6NHnwiwKdc"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 510,
+ "num_range": 1200,
+ "upper_bound": "Mmp6NHnwiwKdcgph"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 510,
+ "num_range": 1020,
+ "upper_bound": "NHnwiwKdcg"
+ },
+ {
+ "distinct_range": 1.8097038437303088,
+ "num_eq": 570,
+ "num_range": 960,
+ "upper_bound": "NHnwiwKdcgphy"
+ },
+ {
+ "distinct_range": 2.149023314429742,
+ "num_eq": 570,
+ "num_range": 1140,
+ "upper_bound": "NHnwiwKdcgphy3v1"
+ },
+ {
+ "distinct_range": 1.6400441083805923,
+ "num_eq": 600,
+ "num_range": 870,
+ "upper_bound": "PxxELo5B1f"
+ },
+ {
+ "distinct_range": 2.544896030245747,
+ "num_eq": 450,
+ "num_range": 1350,
+ "upper_bound": "PxxELo5B1fcW8R"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 660,
+ "num_range": 1200,
+ "upper_bound": "RsaCXoEzm"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 690,
+ "num_range": 1230,
+ "upper_bound": "RsaCXoEzmssa"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 510,
+ "num_range": 930,
+ "upper_bound": "RsaCXoEzmssaF9m"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 600,
+ "num_range": 1110,
+ "upper_bound": "U5yraPxxE"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 510,
+ "num_range": 900,
+ "upper_bound": "U5yraPxxELo5"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 600,
+ "num_range": 1110,
+ "upper_bound": "U5yraPxxELo5B1f"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 510,
+ "num_range": 930,
+ "upper_bound": "W8RsaCXoE"
+ },
+ {
+ "distinct_range": 2.544896030245747,
+ "num_eq": 450,
+ "num_range": 1350,
+ "upper_bound": "W8RsaCXoEzms"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 750,
+ "num_range": 1020,
+ "upper_bound": "W8RsaCXoEzmssaF"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 480,
+ "num_range": 1080,
+ "upper_bound": "Xe0YhgLRr"
+ },
+ {
+ "distinct_range": 1.074511657214871,
+ "num_eq": 870,
+ "num_range": 570,
+ "upper_bound": "Xe0YhgLRrws"
+ },
+ {
+ "distinct_range": 1.6400441083805923,
+ "num_eq": 540,
+ "num_range": 870,
+ "upper_bound": "Xe0YhgLRrwsmd6"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 570,
+ "num_range": 1020,
+ "upper_bound": "XoEzmssa"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 570,
+ "num_range": 1320,
+ "upper_bound": "XoEzmssaF9m"
+ },
+ {
+ "distinct_range": 1.1876181474480152,
+ "num_eq": 780,
+ "num_range": 630,
+ "upper_bound": "XoEzmssaF9m9c"
+ },
+ {
+ "distinct_range": 1.131064902331443,
+ "num_eq": 780,
+ "num_range": 600,
+ "upper_bound": "XoEzmssaF9m9cdL"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 630,
+ "num_range": 900,
+ "upper_bound": "aCXoEzms"
+ },
+ {
+ "distinct_range": 2.149023314429742,
+ "num_eq": 630,
+ "num_range": 1140,
+ "upper_bound": "aCXoEzmssaF"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 570,
+ "num_range": 1170,
+ "upper_bound": "aCXoEzmssaF9m9c"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 810,
+ "num_range": 1020,
+ "upper_bound": "aF9m9cdLX"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 600,
+ "num_range": 1080,
+ "upper_bound": "aF9m9cdLXe0Y"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 420,
+ "num_range": 1230,
+ "upper_bound": "aF9m9cdLXe0YhgL"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 480,
+ "num_range": 900,
+ "upper_bound": "aPxxELo5B"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 630,
+ "num_range": 1230,
+ "upper_bound": "aPxxELo5B1fc"
+ },
+ {
+ "distinct_range": 2.488342785129175,
+ "num_eq": 600,
+ "num_range": 1320,
+ "upper_bound": "aPxxELo5B1fcW8R"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 720,
+ "num_range": 1170,
+ "upper_bound": "cW8RsaCXo"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 600,
+ "num_range": 990,
+ "upper_bound": "cW8RsaCXoEzm"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 570,
+ "num_range": 1170,
+ "upper_bound": "cW8RsaCXoEzmssa"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 300,
+ "num_range": 1050,
+ "upper_bound": "cdLXe0Yhg"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 450,
+ "num_range": 1080,
+ "upper_bound": "cdLXe0YhgLRr"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 450,
+ "num_range": 1170,
+ "upper_bound": "cdLXe0YhgLRrwsm"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 360,
+ "num_range": 1020,
+ "upper_bound": "cgphy3v1U"
+ },
+ {
+ "distinct_range": 1.6400441083805923,
+ "num_eq": 510,
+ "num_range": 870,
+ "upper_bound": "cgphy3v1U5yr"
+ },
+ {
+ "distinct_range": 1.8097038437303088,
+ "num_eq": 450,
+ "num_range": 960,
+ "upper_bound": "cgphy3v1U5yraPx"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 720,
+ "num_range": 1170,
+ "upper_bound": "dLXe0YhgL"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 540,
+ "num_range": 1170,
+ "upper_bound": "dLXe0YhgLRrws"
+ },
+ {
+ "distinct_range": 1.8097038437303088,
+ "num_eq": 480,
+ "num_range": 960,
+ "upper_bound": "dLXe0YhgLRrwsmd6"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 510,
+ "num_range": 1080,
+ "upper_bound": "dcgphy3v1U"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 840,
+ "num_range": 1020,
+ "upper_bound": "dcgphy3v1U5yr"
+ },
+ {
+ "distinct_range": 2.4317895400126024,
+ "num_eq": 630,
+ "num_range": 1290,
+ "upper_bound": "dcgphy3v1U5yraPx"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 510,
+ "num_range": 1080,
+ "upper_bound": "fcW8RsaCXo"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 570,
+ "num_range": 1170,
+ "upper_bound": "fcW8RsaCXoEzms"
+ },
+ {
+ "distinct_range": 2.3752362948960304,
+ "num_eq": 540,
+ "num_range": 1260,
+ "upper_bound": "gphy3v1U"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 450,
+ "num_range": 900,
+ "upper_bound": "gphy3v1U5yr"
+ },
+ {
+ "distinct_range": 2.3186830497794584,
+ "num_eq": 660,
+ "num_range": 1230,
+ "upper_bound": "gphy3v1U5yraPx"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 330,
+ "num_range": 990,
+ "upper_bound": "hy3v1U5y"
+ },
+ {
+ "distinct_range": 2.149023314429742,
+ "num_eq": 330,
+ "num_range": 1140,
+ "upper_bound": "hy3v1U5yraP"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 600,
+ "num_range": 930,
+ "upper_bound": "hy3v1U5yraPxxE"
+ },
+ {
+ "distinct_range": 1.8097038437303088,
+ "num_eq": 600,
+ "num_range": 960,
+ "upper_bound": "iwKdcgph"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 540,
+ "num_range": 1170,
+ "upper_bound": "iwKdcgphy3v"
+ },
+ {
+ "distinct_range": 1.2441713925645874,
+ "num_eq": 660,
+ "num_range": 660,
+ "upper_bound": "iwKdcgphy3v1U"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 570,
+ "num_range": 990,
+ "upper_bound": "iwKdcgphy3v1U5yr"
+ },
+ {
+ "distinct_range": 1.526937618147448,
+ "num_eq": 600,
+ "num_range": 810,
+ "upper_bound": "m9cdLXe0Y"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 690,
+ "num_range": 930,
+ "upper_bound": "m9cdLXe0YhgL"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 720,
+ "num_range": 1200,
+ "upper_bound": "m9cdLXe0YhgLRrw"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 750,
+ "num_range": 1200,
+ "upper_bound": "mMmp6NHnw"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 660,
+ "num_range": 1050,
+ "upper_bound": "mMmp6NHnwiwK"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 360,
+ "num_range": 1050,
+ "upper_bound": "mMmp6NHnwiwKdcg"
+ },
+ {
+ "distinct_range": 1.526937618147448,
+ "num_eq": 660,
+ "num_range": 810,
+ "upper_bound": "mp6NHnwiw"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 330,
+ "num_range": 1050,
+ "upper_bound": "mp6NHnwiwKdc"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 480,
+ "num_range": 1110,
+ "upper_bound": "mp6NHnwiwKdcgph"
+ },
+ {
+ "distinct_range": 2.149023314429742,
+ "num_eq": 510,
+ "num_range": 1140,
+ "upper_bound": "mssaF9m9c"
+ },
+ {
+ "distinct_range": 2.262129804662886,
+ "num_eq": 660,
+ "num_range": 1200,
+ "upper_bound": "mssaF9m9cdLX"
+ },
+ {
+ "distinct_range": 1.4138311279143039,
+ "num_eq": 630,
+ "num_range": 750,
+ "upper_bound": "mssaF9m9cdLXe0"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 510,
+ "num_range": 1080,
+ "upper_bound": "nwiwKdcg"
+ },
+ {
+ "distinct_range": 2.149023314429742,
+ "num_eq": 510,
+ "num_range": 1140,
+ "upper_bound": "nwiwKdcgphy"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 540,
+ "num_range": 1020,
+ "upper_bound": "nwiwKdcgphy3v1"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 390,
+ "num_range": 900,
+ "upper_bound": "o5B1fcW8"
+ },
+ {
+ "distinct_range": 1.4138311279143039,
+ "num_eq": 690,
+ "num_range": 750,
+ "upper_bound": "o5B1fcW8Rs"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 690,
+ "num_range": 1050,
+ "upper_bound": "o5B1fcW8RsaCX"
+ },
+ {
+ "distinct_range": 1.58349086326402,
+ "num_eq": 540,
+ "num_range": 840,
+ "upper_bound": "o5B1fcW8RsaCXoEz"
+ },
+ {
+ "distinct_range": 1.526937618147448,
+ "num_eq": 450,
+ "num_range": 810,
+ "upper_bound": "oEzmssaF9m"
+ },
+ {
+ "distinct_range": 2.205576559546314,
+ "num_eq": 540,
+ "num_range": 1170,
+ "upper_bound": "oEzmssaF9m9cd"
+ },
+ {
+ "distinct_range": 1.7531505986137366,
+ "num_eq": 630,
+ "num_range": 930,
+ "upper_bound": "oEzmssaF9m9cdLXe"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 570,
+ "num_range": 1110,
+ "upper_bound": "p6NHnwiwKd"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 390,
+ "num_range": 990,
+ "upper_bound": "p6NHnwiwKdcgp"
+ },
+ {
+ "distinct_range": 1.1876181474480152,
+ "num_eq": 690,
+ "num_range": 630,
+ "upper_bound": "p6NHnwiwKdcgphy"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 480,
+ "num_range": 1080,
+ "upper_bound": "phy3v1U5y"
+ },
+ {
+ "distinct_range": 1.6400441083805923,
+ "num_eq": 780,
+ "num_range": 870,
+ "upper_bound": "phy3v1U5yra"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 570,
+ "num_range": 990,
+ "upper_bound": "phy3v1U5yraPxx"
+ },
+ {
+ "distinct_range": 2.0924700693131695,
+ "num_eq": 510,
+ "num_range": 1110,
+ "upper_bound": "raPxxELo"
+ },
+ {
+ "distinct_range": 1.4138311279143039,
+ "num_eq": 600,
+ "num_range": 750,
+ "upper_bound": "raPxxELo5B"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 510,
+ "num_range": 1050,
+ "upper_bound": "raPxxELo5B1fc"
+ },
+ {
+ "distinct_range": 1.58349086326402,
+ "num_eq": 600,
+ "num_range": 840,
+ "upper_bound": "raPxxELo5B1fcW8R"
+ },
+ {
+ "distinct_range": 1.3007246376811594,
+ "num_eq": 630,
+ "num_range": 690,
+ "upper_bound": "rumMmp6NH"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 450,
+ "num_range": 1050,
+ "upper_bound": "rumMmp6NHnwi"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 450,
+ "num_range": 990,
+ "upper_bound": "rumMmp6NHnwiwKd"
+ },
+ {
+ "distinct_range": 2.0359168241965975,
+ "num_eq": 450,
+ "num_range": 1080,
+ "upper_bound": "saCXoEzms"
+ },
+ {
+ "distinct_range": 1.3007246376811594,
+ "num_eq": 450,
+ "num_range": 690,
+ "upper_bound": "saCXoEzmssa"
+ },
+ {
+ "distinct_range": 1.074511657214871,
+ "num_eq": 570,
+ "num_range": 570,
+ "upper_bound": "saCXoEzmssaF9"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 360,
+ "num_range": 1050,
+ "upper_bound": "saCXoEzmssaF9m9c"
+ },
+ {
+ "distinct_range": 0.9048519218651544,
+ "num_eq": 870,
+ "num_range": 480,
+ "upper_bound": "saF9m9cdL"
+ },
+ {
+ "distinct_range": 1.3572778827977316,
+ "num_eq": 630,
+ "num_range": 720,
+ "upper_bound": "saF9m9cdLXe"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 360,
+ "num_range": 1020,
+ "upper_bound": "saF9m9cdLXe0Yh"
+ },
+ {
+ "distinct_range": 1.9793635790800252,
+ "num_eq": 690,
+ "num_range": 1050,
+ "upper_bound": "ssaF9m9c"
+ },
+ {
+ "distinct_range": 1.866257088846881,
+ "num_eq": 600,
+ "num_range": 990,
+ "upper_bound": "ssaF9m9cdLX"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 600,
+ "num_range": 1020,
+ "upper_bound": "ssaF9m9cdLXe0Y"
+ },
+ {
+ "distinct_range": 0.9048519218651544,
+ "num_eq": 690,
+ "num_range": 480,
+ "upper_bound": "ssaF9m9cdLXe0Yhg"
+ },
+ {
+ "distinct_range": 1.3007246376811594,
+ "num_eq": 420,
+ "num_range": 690,
+ "upper_bound": "umMmp6NHn"
+ },
+ {
+ "distinct_range": 1.922810333963453,
+ "num_eq": 480,
+ "num_range": 1020,
+ "upper_bound": "umMmp6NHnwiw"
+ },
+ {
+ "distinct_range": 1.1876181474480152,
+ "num_eq": 600,
+ "num_range": 630,
+ "upper_bound": "umMmp6NHnwiwKd"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 540,
+ "num_range": 900,
+ "upper_bound": "v1U5yraP"
+ },
+ {
+ "distinct_range": 0.9048519218651544,
+ "num_eq": 600,
+ "num_range": 480,
+ "upper_bound": "v1U5yraPxx"
+ },
+ {
+ "distinct_range": 1.0179584120982987,
+ "num_eq": 510,
+ "num_range": 540,
+ "upper_bound": "v1U5yraPxxEL"
+ },
+ {
+ "distinct_range": 1.074511657214871,
+ "num_eq": 660,
+ "num_range": 570,
+ "upper_bound": "v1U5yraPxxELo5"
+ },
+ {
+ "distinct_range": 1.3572778827977316,
+ "num_eq": 420,
+ "num_range": 720,
+ "upper_bound": "v1U5yraPxxELo5B1"
+ },
+ {
+ "distinct_range": 1.131064902331443,
+ "num_eq": 450,
+ "num_range": 600,
+ "upper_bound": "wKdcgphy3"
+ },
+ {
+ "distinct_range": 1.6400441083805923,
+ "num_eq": 480,
+ "num_range": 870,
+ "upper_bound": "wKdcgphy3v1U"
+ },
+ {
+ "distinct_range": 1.6965973534971646,
+ "num_eq": 480,
+ "num_range": 900,
+ "upper_bound": "wKdcgphy3v1U5yr"
+ },
+ {
+ "distinct_range": 0.8482986767485823,
+ "num_eq": 600,
+ "num_range": 450,
+ "upper_bound": "wiwKdcgp"
+ },
+ {
+ "distinct_range": 1.8097038437303088,
+ "num_eq": 630,
+ "num_range": 960,
+ "upper_bound": "wiwKdcgphy3"
+ },
+ {
+ "distinct_range": 1.4703843730308759,
+ "num_eq": 480,
+ "num_range": 780,
+ "upper_bound": "wiwKdcgphy3v1"
+ },
+ {
+ "distinct_range": 1.074511657214871,
+ "num_eq": 840,
+ "num_range": 570,
+ "upper_bound": "wiwKdcgphy3v1U5"
+ },
+ {
+ "distinct_range": 1.3572778827977316,
+ "num_eq": 510,
+ "num_range": 720,
+ "upper_bound": "xELo5B1f"
+ },
+ {
+ "distinct_range": 1.131064902331443,
+ "num_eq": 450,
+ "num_range": 600,
+ "upper_bound": "xELo5B1fcW"
+ },
+ {
+ "distinct_range": 0.9048519218651544,
+ "num_eq": 510,
+ "num_range": 480,
+ "upper_bound": "xELo5B1fcW8R"
+ },
+ {
+ "distinct_range": 1.074511657214871,
+ "num_eq": 450,
+ "num_range": 570,
+ "upper_bound": "xELo5B1fcW8Rsa"
+ },
+ {
+ "distinct_range": 1.131064902331443,
+ "num_eq": 570,
+ "num_range": 600,
+ "upper_bound": "xELo5B1fcW8RsaCX"
+ },
+ {
+ "distinct_range": 1.1876181474480152,
+ "num_eq": 840,
+ "num_range": 630,
+ "upper_bound": "xxELo5B1f"
+ },
+ {
+ "distinct_range": 1.6400441083805923,
+ "num_eq": 600,
+ "num_range": 870,
+ "upper_bound": "xxELo5B1fcW8"
+ },
+ {
+ "distinct_range": 1.1876181474480152,
+ "num_eq": 510,
+ "num_range": 630,
+ "upper_bound": "xxELo5B1fcW8Rs"
+ },
+ {
+ "distinct_range": 1.3007246376811594,
+ "num_eq": 450,
+ "num_range": 690,
+ "upper_bound": "xxELo5B1fcW8RsaC"
+ },
+ {
+ "distinct_range": 0.9614051669817265,
+ "num_eq": 630,
+ "num_range": 510,
+ "upper_bound": "y3v1U5yra"
+ },
+ {
+ "distinct_range": 0.7351921865154379,
+ "num_eq": 510,
+ "num_range": 390,
+ "upper_bound": "y3v1U5yraPx"
+ },
+ {
+ "distinct_range": 0.9614051669817265,
+ "num_eq": 480,
+ "num_range": 510,
+ "upper_bound": "y3v1U5yraPxxE"
+ },
+ {
+ "distinct_range": 0.9048519218651544,
+ "num_eq": 510,
+ "num_range": 480,
+ "upper_bound": "y3v1U5yraPxxELo"
+ },
+ {
+ "distinct_range": 0.9048519218651544,
+ "num_eq": 510,
+ "num_range": 480,
+ "upper_bound": "yraPxxEL"
+ },
+ {
+ "distinct_range": 1.2441713925645874,
+ "num_eq": 690,
+ "num_range": 660,
+ "upper_bound": "yraPxxELo5"
+ },
+ {
+ "distinct_range": 0.79174543163201,
+ "num_eq": 480,
+ "num_range": 420,
+ "upper_bound": "yraPxxELo5B1"
+ },
+ {
+ "distinct_range": 0.7351921865154379,
+ "num_eq": 540,
+ "num_range": 390,
+ "upper_bound": "yraPxxELo5B1fc"
+ },
+ {
+ "distinct_range": 1.0179584120982987,
+ "num_eq": 600,
+ "num_range": 540,
+ "upper_bound": "yraPxxELo5B1fcW8"
+ },
+ {
+ "distinct_range": 0.9614051669817265,
+ "num_eq": 330,
+ "num_range": 510,
+ "upper_bound": "zmssaF9m9"
+ },
+ {
+ "distinct_range": 1.131064902331443,
+ "num_eq": 360,
+ "num_range": 600,
+ "upper_bound": "zmssaF9m9cd"
+ },
+ {
+ "distinct_range": 1.0179584120982987,
+ "num_eq": 600,
+ "num_range": 540,
+ "upper_bound": "zmssaF9m9cdLX"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 690,
+ "num_range": 0,
+ "upper_bound": "zmssaF9m9cdLXe"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 450,
+ "num_range": 0,
+ "upper_bound": "zmssaF9m9cdLXe0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 570,
+ "num_range": 0,
+ "upper_bound": "zmssaF9m9cdLXe0Y"
+ }
+ ],
+ "histo_col_type": "VARCHAR(16)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 30,
+ "columns": [
+ "c_w_id",
+ "c_d_id",
+ "c_last",
+ "c_first"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 296493,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "c_middle"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "OE"
+ }
+ ],
+ "histo_col_type": "CHAR(2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 17,
+ "columns": [
+ "c_street_1"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 770,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 540,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsm"
+ },
+ {
+ "distinct_range": 767.9999999999999,
+ "num_eq": 570,
+ "num_range": 298890,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 17,
+ "columns": [
+ "c_street_2"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 880,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 30,
+ "num_range": 0,
+ "upper_bound": "0ObpVWo1Bahde"
+ },
+ {
+ "distinct_range": 878,
+ "num_eq": 270,
+ "num_range": 299700,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 18,
+ "columns": [
+ "c_city"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 965,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 360,
+ "num_range": 0,
+ "upper_bound": "0ObpVWo1Ba"
+ },
+ {
+ "distinct_range": 963,
+ "num_eq": 330,
+ "num_range": 299310,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "c_state"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 26,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10890,
+ "num_range": 0,
+ "upper_bound": "AK"
+ },
+ {
+ "distinct_range": 24,
+ "num_eq": 11460,
+ "num_range": 277650,
+ "upper_bound": "ZT"
+ }
+ ],
+ "histo_col_type": "CHAR(2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 11,
+ "columns": [
+ "c_zip"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 29700,
+ "num_range": 0,
+ "upper_bound": "022311111"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 30390,
+ "num_range": 239910,
+ "upper_bound": "902211111"
+ }
+ ],
+ "histo_col_type": "CHAR(9)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 18,
+ "columns": [
+ "c_phone"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 29130,
+ "num_range": 0,
+ "upper_bound": "0223082947329423"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 30750,
+ "num_range": 240120,
+ "upper_bound": "9473294232201446"
+ }
+ ],
+ "histo_col_type": "CHAR(16)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "c_since"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "2006-01-02 15:04:05"
+ }
+ ],
+ "histo_col_type": "TIMESTAMP",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "c_credit"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 2,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 33570,
+ "num_range": 0,
+ "upper_bound": "BC"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 266430,
+ "num_range": 0,
+ "upper_bound": "GC"
+ }
+ ],
+ "histo_col_type": "CHAR(2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "c_credit_lim"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "5E+4"
+ }
+ ],
+ "histo_col_type": "DECIMAL(12,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "c_discount"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 5000,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 60,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 4998,
+ "num_eq": 30,
+ "num_range": 299910,
+ "upper_bound": "0.5"
+ }
+ ],
+ "histo_col_type": "DECIMAL(4,4)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "c_balance"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "-1E+1"
+ }
+ ],
+ "histo_col_type": "DECIMAL(12,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "c_ytd_payment"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "1E+1"
+ }
+ ],
+ "histo_col_type": "DECIMAL(12,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "c_payment_cnt"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "1"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "c_delivery_cnt"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "0"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 403,
+ "columns": [
+ "c_data"
+ ],
+ "created_at": "2022-02-25 01:09:16.735123",
+ "distinct_count": 16976,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 60,
+ "num_range": 0,
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk13xWSP8P9fwb2ZjtZAs3NbYdihFxFime6B6Adnt5jrXvRR7OGYhlpdljbDvShaRF4E9zNHsJ7ZvyiJ3n2X1f4fJoMgn5buTDyUmQupcYMoPylHqYo89SqHqQ4HFVNpmnIWHyIowzQN2r4uSQJ8PYVLLLZk9Epp6cNEnaVrN3JXcrBCOuRRSlC0zvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ1Ol7SuF7jPf275wNDlEbdC58hrunlPfhoY1dORoIgb0VnxqkqbEWTXujHUOvCRf"
+ },
+ {
+ "distinct_range": 16974,
+ "num_eq": 270,
+ "num_range": 299670,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsmd68P2bElAgrnp8ueWNXJpBB0ObpVWo1BahdejZrKB2O3Hzk13xWSP8P9fwb2ZjtZAs3NbYdihFxFime6B6Adnt5jrXvRR7OGYhlpdljbDvShaRF4E9zNHsJ7ZvyiJ3n2X1f4fJoMgn5buTDyUmQupcYMoPylHqYo89SqHqQ4HFVNpmnIWHyIowzQN2r4uSQJ8PYVLLLZk9Epp6cNEnaVrN3JXcrBCOuRRSlC0zvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ1Ol7SuF7jPf275wNDlEbdC58hrunlPfhoY1dORoIgb0VnxqkqbEWTXujHUOvCRfqCdVyc8gRGMfAd4nWB1rXYANQ0fa6ZQJJI2uTeFFazaVwxnN"
+ }
+ ],
+ "histo_col_type": "VARCHAR(500)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ }
+]';
+----
+
+exec-ddl
+ALTER TABLE "district" INJECT STATISTICS '[
+ {
+ "avg_size": 1,
+ "columns": [
+ "d_w_id"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "d_id"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "9"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "d_w_id",
+ "d_id"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 100,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 10,
+ "columns": [
+ "d_name"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 78,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "1U5yraPx"
+ },
+ {
+ "distinct_range": 76,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m"
+ }
+ ],
+ "histo_col_type": "VARCHAR(10)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 17,
+ "columns": [
+ "d_street_1"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 91,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsmd68P2bEl"
+ },
+ {
+ "distinct_range": 89,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m9cdL"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 17,
+ "columns": [
+ "d_street_2"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 95,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsmd68"
+ },
+ {
+ "distinct_range": 93,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 18,
+ "columns": [
+ "d_city"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 94,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsmd"
+ },
+ {
+ "distinct_range": 92,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "d_state"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 25,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "AK"
+ },
+ {
+ "distinct_range": 23,
+ "num_eq": 4,
+ "num_range": 95,
+ "upper_bound": "ZT"
+ }
+ ],
+ "histo_col_type": "CHAR(2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 11,
+ "columns": [
+ "d_zip"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 15,
+ "num_range": 0,
+ "upper_bound": "022311111"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 8,
+ "num_range": 77,
+ "upper_bound": "902211111"
+ }
+ ],
+ "histo_col_type": "CHAR(9)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "d_tax"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 98,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0.0021"
+ },
+ {
+ "distinct_range": 96,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "0.1962"
+ }
+ ],
+ "histo_col_type": "DECIMAL(4,4)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "d_ytd"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 100,
+ "num_range": 0,
+ "upper_bound": "3E+4"
+ }
+ ],
+ "histo_col_type": "DECIMAL(12,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "d_next_o_id"
+ ],
+ "created_at": "2022-02-25 01:07:38.472284",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 100,
+ "num_range": 0,
+ "upper_bound": "3001"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "d_w_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "d_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "9"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "d_w_id",
+ "d_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 100,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 10,
+ "columns": [
+ "d_name"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 78,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "1U5yraPx"
+ },
+ {
+ "distinct_range": 76,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m"
+ }
+ ],
+ "histo_col_type": "VARCHAR(10)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 17,
+ "columns": [
+ "d_street_1"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 91,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsmd68P2bEl"
+ },
+ {
+ "distinct_range": 89,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m9cdL"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 17,
+ "columns": [
+ "d_street_2"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 95,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsmd68"
+ },
+ {
+ "distinct_range": 93,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 18,
+ "columns": [
+ "d_city"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 94,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0YhgLRrwsmd"
+ },
+ {
+ "distinct_range": 92,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLR"
+ }
+ ],
+ "histo_col_type": "VARCHAR(20)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "d_state"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 25,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "AK"
+ },
+ {
+ "distinct_range": 23,
+ "num_eq": 4,
+ "num_range": 95,
+ "upper_bound": "ZT"
+ }
+ ],
+ "histo_col_type": "CHAR(2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 11,
+ "columns": [
+ "d_zip"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 15,
+ "num_range": 0,
+ "upper_bound": "022311111"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 8,
+ "num_range": 77,
+ "upper_bound": "902211111"
+ }
+ ],
+ "histo_col_type": "CHAR(9)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "d_tax"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 98,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "0.0021"
+ },
+ {
+ "distinct_range": 96,
+ "num_eq": 1,
+ "num_range": 98,
+ "upper_bound": "0.1962"
+ }
+ ],
+ "histo_col_type": "DECIMAL(4,4)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "d_ytd"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 100,
+ "num_range": 0,
+ "upper_bound": "3E+4"
+ }
+ ],
+ "histo_col_type": "DECIMAL(12,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "d_next_o_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.105068",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 100,
+ "num_range": 0,
+ "upper_bound": "3001"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100
+ }
+]';
+----
+
+exec-ddl
+ALTER TABLE "history" INJECT STATISTICS '[
+ {
+ "avg_size": 1,
+ "columns": [
+ "h_w_id"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 26908,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 23875,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 27679,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 26677,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 24235,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29735,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 24441,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 26599,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 22744,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 24107,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 25,
+ "columns": [
+ "rowid"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 257000,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "00000000-0000-0000-0000-000000000000"
+ },
+ {
+ "distinct_range": 9.604264050722122E-10,
+ "num_eq": 1,
+ "num_range": 0,
+ "upper_bound": "000037ec-8ec2-4e6d-8000-000000000001"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0121e338-0187-47e0-8000-00000000052f"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "02043489-bc1d-49c0-8000-00000000093b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0321f133-2538-4f80-8000-000000000e57"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "044ef88b-9778-4740-8000-0000000013b9"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "057d875b-f109-43c0-8000-000000001922"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0684fbc4-78b2-4a00-8000-000000001dd8"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "07baf7ff-c813-4140-8000-000000002363"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "091c3531-81c9-4100-8000-0000000029b4"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0a1a7cca-9d8f-4900-8000-000000002e40"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0b65a9a8-0496-4780-8000-00000000342c"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0c4bb1af-3a14-4f00-8000-000000003849"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "0d971679-2fde-4b80-8000-000000003e36"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "10fd9fd3-6f7e-4d00-8000-000000004dc7"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "120cb993-7bb9-4c00-8000-0000000052a0"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "132f0ca4-9ac6-4100-8000-0000000057d1"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "14638168-02d7-4300-8000-000000005d55"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "1578f0f4-3b17-4500-8000-00000000624b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "168a0205-4c28-4600-8000-00000000672d"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "178f7f1c-cefc-4a00-8000-000000006bda"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "1886c924-1275-4500-8000-000000007046"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "19a415f4-5e0b-4e00-8000-000000007560"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "1a877ee4-e26d-4800-8000-000000007971"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "1b8a5ce5-b424-4f00-8000-000000007e12"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "1c67a7f6-9b44-4500-8000-000000008207"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "20c2dc41-6d41-4400-8000-0000000095f8"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "21b3d07c-84b5-4c00-8000-000000009a47"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "22bd0449-8271-4600-8000-000000009f05"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "23e345fc-ab28-4e00-8000-00000000a448"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "25028a1d-fb93-4a00-8000-00000000a96b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "262664a7-01f0-4400-8000-00000000aea3"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "270307f2-3cc8-4e00-8000-00000000b295"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "282bb0cf-87d9-4600-8000-00000000b7e3"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "295ca6ca-03c4-4000-8000-00000000bd57"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "2a5d8d79-d0a6-4600-8000-00000000c1ef"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "2b900aec-33e1-4600-8000-00000000c76a"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "2cb7643e-2664-4800-8000-00000000ccb2"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "3057619f-0fb3-4a00-8000-00000000dd4a"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "315cdeb6-9287-4000-8000-00000000e1f7"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "329ab835-f53d-4e00-8000-00000000e7a6"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "339628cb-d124-4a00-8000-00000000ec25"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "34912988-8f86-4a00-8000-00000000f0a2"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "35a69914-c7c6-4c00-8000-00000000f598"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "36dc9550-1727-4400-8000-00000000fb23"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "380037ec-8ec2-4e00-8000-00000001005a"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "38f2eb8c-1c4a-4a00-8000-0000000104b1"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "3a64531f-1a2f-4600-8000-000000010b4c"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "3bb6b57a-e845-4000-8000-000000011159"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "3cc9bddc-fe2b-4200-8000-000000011644"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "4041514a-bd04-4800-8000-000000012623"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "415b573e-ab36-4c00-8000-000000012b2e"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "42497476-82cc-4800-8000-000000012f70"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "43606b7a-a25d-4c00-8000-00000001346d"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "449f9485-5da2-4400-8000-000000013a22"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "45a1cac0-8312-4000-8000-000000013ec0"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "466ac4e1-8d95-4800-8000-000000014258"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "4763ce4d-4722-4400-8000-0000000146cc"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "48a6ae0d-7d4f-4000-8000-000000014c92"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "49b0f979-44d7-4000-8000-000000015155"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "4ac3c9ee-cbfb-4400-8000-00000001563f"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "4bd35387-f5bb-4000-8000-000000015b1a"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "4cc6e6d9-be4c-4800-8000-000000015f75"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "505db76b-3bb8-4c00-8000-000000016fe3"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "516bb98c-7e28-4400-8000-0000000174b7"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "5263ab59-6de8-4c00-8000-000000017926"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "532b8ddb-aea0-4c00-8000-000000017cb9"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "5424276e-4aa8-4c00-8000-00000001812b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "55a9003e-ea20-4c00-8000-00000001881f"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "56db45c4-be99-4c00-8000-000000018d99"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "57baf7ff-c813-4000-8000-000000019199"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "58dc3372-1d53-4c00-8000-0000000196c5"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "59ed7c6f-bd27-4c00-8000-000000019ba8"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "5b325380-f829-4800-8000-00000001a177"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "5c104657-8b90-4c00-8000-00000001a56f"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "5d083824-7b51-4000-8000-00000001a9de"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "5e10c42b-ccc5-4000-8000-00000001ae99"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "60b7105b-5041-4800-8000-00000001baba"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "61c46ab6-e669-4400-8000-00000001bf8b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "62a8b359-a5d5-4800-8000-00000001c3a0"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "63c4b09e-98dc-4c00-8000-00000001c8b4"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "64b6848b-eb5b-4c00-8000-00000001cd07"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "65ab9f55-9b3d-4800-8000-00000001d169"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "66a5f84c-ad57-4c00-8000-00000001d5e3"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "67c81371-3da1-4400-8000-00000001db13"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "68cd9088-c075-4800-8000-00000001dfc0"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "69ea6d7f-ee86-4400-8000-00000001e4d8"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "6b07128a-8dd4-4000-8000-00000001e9ef"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "6be8f403-2ae6-4800-8000-00000001edf9"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "6d296c99-3eb9-4000-8000-00000001f3b4"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "7079adb2-9ce7-4400-8000-0000000202df"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "7191f442-1506-4000-8000-0000000207e2"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "72f2c19a-b138-4400-8000-000000020e31"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "740f66a5-5087-4000-8000-000000021348"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "751b7175-8e21-4800-8000-000000021813"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "764a701f-0537-4000-8000-000000021d7e"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "7782d384-76f2-4400-8000-000000022314"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "78616e20-b6a0-4400-8000-00000002270f"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "79c2038c-c40f-4800-8000-000000022d5d"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "7acd2eaa-c6a0-4400-8000-000000023224"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "7ba84a7e-1a28-4800-8000-00000002360f"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "7cb02ebf-bf56-4c00-8000-000000023ac7"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "80510bd2-e3ae-4800-8000-000000024b63"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "818ffcf1-1031-4000-8000-000000025117"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "82a763ce-4d47-4000-8000-000000025616"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "83c08a10-006f-4800-8000-000000025b1d"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "84cb0d68-56b9-4800-8000-000000025fe1"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "85c725c3-dee7-4000-8000-000000026463"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "86a0ba1f-4b1e-4000-8000-000000026847"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "876a93f2-90ab-4800-8000-000000026be3"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "888dfea2-7983-4000-8000-000000027119"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "898a16fe-01b1-4800-8000-00000002759b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "8ace4649-906c-4800-8000-000000027b67"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "8bccfdbb-c9b6-4000-8000-000000027ff5"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "8ca6ca03-c4b0-4000-8000-0000000283da"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "8dfc733b-f029-4000-8000-0000000289f6"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "90857998-b9e7-4000-8000-000000029591"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "91af3a14-cec4-4000-8000-000000029ae4"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "92cb6f46-508e-4000-8000-000000029ff9"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "93fc9d2d-5b3b-4800-8000-00000002a56e"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "94bd1244-a622-4000-8000-00000002a8df"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "95c0601e-955e-4000-8000-00000002ad82"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "96d7fee8-6136-4800-8000-00000002b282"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "97be3edc-2576-4800-8000-00000002b6a0"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "989f08b5-f8bc-4800-8000-00000002baa5"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "99bcc55f-61d7-4000-8000-00000002bfc1"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "9ae3aed8-36d4-4000-8000-00000002c507"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "9c330244-3649-4000-8000-00000002cb06"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "9d51d68c-692f-4000-8000-00000002d027"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a0b5f8bc-8675-4000-8000-00000002dfad"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a1cdcf72-e10f-4000-8000-00000002e4ae"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a2e6f5b4-9438-4800-8000-00000002e9b5"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a3c787a1-d8bb-4800-8000-00000002edb9"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a52dcb14-65e8-4000-8000-00000002f421"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a64f0686-bb28-4000-8000-00000002f94d"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a75ad96a-6a01-4800-8000-00000002fe17"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a8b0f27b-b2fe-4800-8000-000000030435"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "a99fef65-c59e-4800-8000-00000003087b"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "aabc2497-4768-4000-8000-000000030d90"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "abd31b9b-66f9-4000-8000-00000003128d"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "acf4fed3-6880-4800-8000-0000000317bc"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b01b1695-2625-4000-8000-000000032626"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b12870f0-bc4e-4800-8000-000000032af7"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b22e5de1-5ca6-4800-8000-000000032fa6"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b35387f5-bb91-4800-8000-0000000334e4"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b4ac401d-b5ab-4800-8000-000000033b0e"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b5e353f7-ced9-4800-8000-00000003409e"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b715997d-a352-4800-8000-000000034618"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b86a6303-93c1-4000-8000-000000034c30"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "b9704ff4-3419-4000-8000-0000000350df"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "ba96c993-eb93-4800-8000-000000035623"
+ },
+ {
+ "distinct_range": 1284.1241206030165,
+ "num_eq": 1,
+ "num_range": 1284,
+ "upper_bound": "bb97e830-4737-4000-8000-000000035abc"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "bcb33daf-8df7-4800-8000-000000035fcd"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "bda5119c-e075-4800-8000-000000036420"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c1129888-f861-4800-8000-0000000373d1"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c2846ff5-13cc-4000-8000-000000037a6e"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c397087e-0c2d-4800-8000-000000037f57"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c49f5c98-cee0-4800-8000-000000038411"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c607975c-60e2-4000-8000-000000038a82"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c6f2dd90-f899-4000-8000-000000038eb7"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c80f4aaf-0925-4000-8000-0000000393cd"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "c9550172-7f31-4800-8000-0000000399a0"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "ca5e353f-7ced-4000-8000-000000039e5e"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "cb900aec-33e1-4800-8000-00000003a3d6"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "cc8e8a71-de69-4000-8000-00000003a863"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d01f3d23-be92-4000-8000-00000003b8b5"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d13b3a68-b19a-4000-8000-00000003bdc9"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d22e95cd-eb69-4800-8000-00000003c223"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d3ad88ab-7c61-4000-8000-00000003c8fc"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d4d63188-c772-4800-8000-00000003ce4a"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d5f495f7-dcd4-4800-8000-00000003d369"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d70cdc87-54f3-4800-8000-00000003d86c"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d85729b2-80f1-4000-8000-00000003de54"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "d9930be0-ded2-4800-8000-00000003e3fa"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "dac3c9ee-cbfb-4800-8000-00000003e96d"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "db97406a-9af0-4000-8000-00000003ed35"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "dc9976a5-c060-4000-8000-00000003f1d3"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e0ffcf11-0315-4000-8000-0000000405f7"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e2721656-3c05-4000-8000-000000040c96"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e37de939-eadd-4800-8000-000000041160"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e4891457-ed6e-4800-8000-000000041627"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e5aeae45-69de-4000-8000-000000041b67"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e6d9be4c-d749-4800-8000-0000000420c0"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e7db4cc2-5072-4800-8000-00000004255b"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "e90a8358-564a-4000-8000-000000042ac7"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "ea199d18-6285-4000-8000-000000042fa0"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "eb4baab1-a83c-4000-8000-000000043519"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "ec7373dc-b843-4000-8000-000000043a63"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "eda8c852-5b5e-4000-8000-000000043feb"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f04c0592-1038-4000-8000-000000044bfe"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f11fb3fa-6def-4800-8000-000000044fc7"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f237c29d-574c-4800-8000-0000000454c9"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f3a61b40-8691-4800-8000-000000045b56"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f4ace7e3-61f2-4000-8000-000000046009"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f5f99c38-b04a-4800-8000-0000000465fc"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f73af480-ff27-4800-8000-000000046bbb"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f8c8525b-5e3c-4000-8000-0000000472d6"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "f9b637a6-a70f-4800-8000-000000047717"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "fb25dfd5-2ee2-4000-8000-000000047daa"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "fc41a52d-9327-4800-8000-0000000482bd"
+ },
+ {
+ "distinct_range": 1309.8241206030166,
+ "num_eq": 1,
+ "num_range": 1310,
+ "upper_bound": "fd9e4bf7-96ec-4800-8000-0000000488f9"
+ },
+ {
+ "distinct_range": 9.604264050722122E-10,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "ffffffff-ffff-ffff-ffff-ffffffffffff"
+ }
+ ],
+ "histo_col_type": "UUID",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "h_w_id",
+ "rowid"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 257000,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "h_c_id"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 2999,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 77,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 2997,
+ "num_eq": 206,
+ "num_range": 256717,
+ "upper_bound": "3000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "h_c_d_id"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 26137,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 25829,
+ "num_range": 205035,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "h_c_w_id"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 26908,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 24107,
+ "num_range": 205986,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "h_d_id"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 26137,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 25829,
+ "num_range": 205035,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "h_date"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 257000,
+ "num_range": 0,
+ "upper_bound": "2006-01-02 15:04:05"
+ }
+ ],
+ "histo_col_type": "TIMESTAMP",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "h_amount"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 257000,
+ "num_range": 0,
+ "upper_bound": "1E+1"
+ }
+ ],
+ "histo_col_type": "DECIMAL(6,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 21,
+ "columns": [
+ "h_data"
+ ],
+ "created_at": "2022-02-25 01:07:49.495079",
+ "distinct_count": 806,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 283,
+ "num_range": 0,
+ "upper_bound": "1U5yraPxxELo"
+ },
+ {
+ "distinct_range": 804,
+ "num_eq": 334,
+ "num_range": 256383,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "VARCHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 257000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "h_w_id"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 31200,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29460,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30030,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 31080,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 28680,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29880,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30300,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29760,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30390,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29220,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 25,
+ "columns": [
+ "rowid"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 299387,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "00000000-0000-0000-0000-000000000000"
+ },
+ {
+ "distinct_range": 1.1641532182693481E-10,
+ "num_eq": 4,
+ "num_range": 0,
+ "upper_bound": "000cab98-5809-44bc-8000-00000000003a"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "01343cd6-d94e-43c0-8000-000000000583"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "028e448a-2bf6-4740-8000-000000000bb3"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "03bc6381-6802-4700-8000-00000000111a"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "04e5b424-5f5a-4980-8000-00000000166b"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "0644523f-67f4-4bc0-8000-000000001cb0"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "074e2dd2-11f7-40c0-8000-000000002171"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "08c463b9-5491-4980-8000-000000002822"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "0a209aaa-3ad1-4d00-8000-000000002e5c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "0b51c891-457e-4700-8000-0000000033d1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "0cce5444-b41d-4200-8000-000000003a9f"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "0de04508-0037-4c80-8000-000000003f85"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "0f072e80-d535-4080-8000-0000000044cb"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "1032069b-b3de-4800-8000-000000004a23"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "115a3f9f-e16a-4200-8000-000000004f6f"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "12aca1fb-af7f-4d00-8000-00000000557c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "1413c520-77b6-4200-8000-000000005be8"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "150cce8c-3142-4000-8000-00000000605c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "161e8762-ee9b-4c00-8000-000000006541"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "176ddace-ee0f-4d00-8000-000000006b40"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "18d3767b-cef5-4d00-8000-0000000071a5"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "19f47a01-9573-4b00-8000-0000000076d0"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "1b2298f8-d17f-4b00-8000-000000007c37"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "1c71b478-4230-4d00-8000-000000008235"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "1d9d6c45-5be3-4e00-8000-000000008791"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "1ef0068d-b8ba-4700-8000-000000008d9f"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2006c5a5-4989-4000-8000-00000000929b"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "212a3055-3261-4c00-8000-0000000097d1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "22b0c88a-47ec-4e00-8000-000000009ecd"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "23eab367-a0f9-4a00-8000-00000000a46a"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "25226f07-666d-4400-8000-00000000a9fd"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "26392e1e-f73c-4c00-8000-00000000aef9"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2782d384-76f2-4600-8000-00000000b4de"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "28fa58f7-121a-4400-8000-00000000bb95"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2a3b0979-b4b0-4e00-8000-00000000c151"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2b78e2f9-1766-4e00-8000-00000000c700"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2cdc4f68-64b4-4e00-8000-00000000cd5b"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2e384e6c-bc32-4200-8000-00000000d394"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "2f905ecf-0a05-4400-8000-00000000d9bb"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "30b74847-df03-4800-8000-00000000df01"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "328208ca-f172-4000-8000-00000000e735"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "33fe5c91-d14e-4c00-8000-00000000ee02"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "35143bf7-2713-4a00-8000-00000000f2fa"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "36880ab4-4753-4400-8000-00000000f9a0"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "38092ccf-6be3-4e00-8000-000000010083"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "3957a089-304e-4400-8000-00000001067e"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "3a6c3063-2d85-4c00-8000-000000010b70"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "3b80c03d-2abc-4400-8000-000000011062"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "3caf4f0d-844d-4200-8000-0000000115cb"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "3e0fe479-91bc-4600-8000-000000011c19"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "3f48b7b8-20fc-4800-8000-0000000121b1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "40ab4475-3341-4000-8000-000000012808"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "41eb4d32-298f-4c00-8000-000000012dc1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "4333a30c-50b7-4000-8000-0000000133a0"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "446aeed2-f8a7-4c00-8000-000000013931"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "457df735-0e8d-4000-8000-000000013e1c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "46f88b97-7857-4800-8000-0000000144e1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "485729b2-80f1-4c00-8000-000000014b26"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "49d5e4a3-8327-4800-8000-0000000151fe"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "4afa9ede-c48d-4c00-8000-00000001573a"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "4c107e44-1a52-4800-8000-000000015c32"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "4dbe30e1-01c6-4400-8000-0000000163e1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "4f326f77-3f8a-4800-8000-000000016a89"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "5049667b-5f1b-4000-8000-000000016f86"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "51c5f22e-cdba-4c00-8000-000000017654"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "52f10236-3b25-4000-8000-000000017bad"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "544a9a10-7048-4800-8000-0000000181db"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "55aeae45-69de-4000-8000-000000018839"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "56fbd273-d5ba-4400-8000-000000018e2e"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "583e425a-ee63-4000-8000-0000000193f2"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "593c5207-7b66-4800-8000-00000001987d"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "5a2d4642-92da-4000-8000-000000019ccc"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "5b2d852c-b375-4c00-8000-00000001a161"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "5c9dd520-e78f-4000-8000-00000001a7f7"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "5df266ba-493c-4800-8000-00000001ae0e"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "5f3abc94-7064-4c00-8000-00000001b3ed"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "605faebc-408d-4000-8000-00000001b92a"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6191f442-1506-4000-8000-00000001bea4"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "62a3ad18-d25e-4c00-8000-00000001c389"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "63aca8f9-4158-4800-8000-00000001c846"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "64f0d844-d013-4800-8000-00000001ce12"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "661f6715-29a4-4400-8000-00000001d37b"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "67f0ed3d-859c-4c00-8000-00000001dbce"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6953e9d3-b565-4000-8000-00000001e227"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6abad50b-eed9-4800-8000-00000001e892"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6be0370c-dc87-4400-8000-00000001edd1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6d25b5e3-c3d0-4c00-8000-00000001f3a3"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6e8a71de-69ad-4400-8000-00000001fa04"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "6fc3451c-f8ed-4400-8000-00000001ff9c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "70d95c6e-dd75-4400-8000-000000020495"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "71f63966-0b86-4000-8000-0000000209ad"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "734cfa3d-00ca-4800-8000-000000020fce"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "74abd044-9827-4c00-8000-000000021614"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "76167232-4c83-4800-8000-000000021c90"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "778bc867-5413-4400-8000-00000002233d"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "78ccb0d6-856b-4c00-8000-0000000228fa"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "7a14cec4-1dd1-4400-8000-000000022ed8"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "7bac0133-9511-4c00-8000-000000023620"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "7cfb8c8c-2347-4c00-8000-000000023c20"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "7e3ce4d4-7224-4000-8000-0000000241df"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "7f694467-381d-4c00-8000-00000002473e"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "8114c7c6-8bf9-4800-8000-000000024ee3"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "822c6690-57d1-4800-8000-0000000253e3"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "83721d53-cddd-4000-8000-0000000259b6"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "846b9698-a4ee-4800-8000-000000025e2c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "85dc1e79-67ca-4800-8000-0000000264c3"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "8736cdf2-66ba-4800-8000-000000026af6"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "887f23cc-8de2-4000-8000-0000000270d5"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "89b4e81b-4e81-4800-8000-00000002765f"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "8b15459a-cd2e-4800-8000-000000027cac"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "8c39ffd6-0e94-4000-8000-0000000281e8"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "8d864452-3f67-4800-8000-0000000287d9"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "8ee9b0c1-8cb6-4800-8000-000000028e34"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "903eea20-9aaa-4800-8000-00000002944e"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "91789d11-64f3-4800-8000-0000000299ea"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "92d4d402-4b33-4800-8000-00000002a024"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "943adf88-499e-4800-8000-00000002a68b"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "959f2ba9-d1f6-4000-8000-00000002acea"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "970616e2-0b6a-4800-8000-00000002b355"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "9832ae61-6025-4000-8000-00000002b8b5"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "994b9cb6-848b-4800-8000-00000002bdbb"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "9a98191f-4421-4000-8000-00000002c3ad"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "9bc55864-4523-4800-8000-00000002c910"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "9cdf9644-c218-4800-8000-00000002ce1c"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "9e0b85fe-6a8c-4800-8000-00000002d379"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "9f10cb29-5e9e-4800-8000-00000002d825"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a05bc01a-36e2-4800-8000-00000002de10"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a1c58255-b035-4000-8000-00000002e488"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a31e0291-1b8d-4800-8000-00000002eab1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a424cf33-f6ef-4800-8000-00000002ef64"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a5c1afa9-edec-4800-8000-00000002f6c6"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a743b177-4d86-4000-8000-00000002fdad"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a8510bd2-e3ae-4800-8000-00000003027e"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "a9abbb4b-e29e-4800-8000-0000000308b1"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "aaf8df7a-4e7a-4800-8000-000000030ea6"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "ac562e09-fe86-4000-8000-0000000314e5"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "ad9be4cd-7492-4800-8000-000000031ab8"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "aee711aa-db99-4800-8000-0000000320a4"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b010d226-f076-4800-8000-0000000325f7"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b15c6edd-7502-4000-8000-000000032be5"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b2b9bd6d-250e-4000-8000-000000033224"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b3f3e037-0cdc-4800-8000-0000000337c2"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b549896f-3855-4800-8000-000000033dde"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b66e43aa-79bb-4000-8000-00000003431a"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b7ba184d-8d09-4800-8000-000000034909"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "b8e5982e-17f9-4800-8000-000000034e64"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "ba942a7d-3a76-4000-8000-000000035617"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "bbb336b1-fc1f-4800-8000-000000035b39"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "bd1b3988-ff5f-4800-8000-0000000361a9"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "beb3f370-5def-4800-8000-0000000368f8"
+ },
+ {
+ "distinct_range": 1496.0653266331658,
+ "num_eq": 4,
+ "num_range": 1496,
+ "upper_bound": "bfe08aef-b2aa-4000-8000-000000036e58"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c13b3a68-b19a-4000-8000-00000003748b"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c28278a4-0ef6-4000-8000-000000037a65"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c392aa02-e4fe-4000-8000-000000037f43"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c4cbb52e-0300-4800-8000-0000000384dc"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c5c8ad3b-c638-4800-8000-000000038962"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c714b9cb-6848-4000-8000-000000038f52"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c89ae227-604f-4800-8000-00000003964c"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "c9d883ba-3443-4800-8000-000000039bfa"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "cba29c77-9a6b-4000-8000-00000003a42b"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "cca88968-3ac3-4000-8000-00000003a8da"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "ce7f15d1-6a32-4800-8000-00000003b144"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "cfabad50-beed-4000-8000-00000003b6a4"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d0e60807-357e-4800-8000-00000003bc43"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d1fb7793-6dbe-4800-8000-00000003c139"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d3596de8-ca11-4000-8000-00000003c77b"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d4c71ec6-4d0f-4800-8000-00000003ce05"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d633103f-59f9-4800-8000-00000003d487"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d751ac9a-fe1d-4800-8000-00000003d9a7"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "d8b6d86e-c17e-4800-8000-00000003e00a"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "da352386-a630-4800-8000-00000003e6e0"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "db75d409-48c5-4000-8000-00000003ec9c"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "dce11dbc-a969-4800-8000-00000003f31b"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "dddb76b3-bb83-4000-8000-00000003f795"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "df00d8b4-a931-4000-8000-00000003fcd4"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e04577d9-5571-4800-8000-0000000402a2"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e1b13165-d399-4000-8000-000000040923"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e2fb46a4-70d4-4800-8000-000000040f0a"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e3e68cd9-088c-4800-8000-00000004133f"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e572633b-8050-4800-8000-000000041a53"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e67aef42-d1c5-4000-8000-000000041f0e"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e79b82ef-7abe-4000-8000-000000042437"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "e8f74a07-4379-4800-8000-000000042a6f"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "ea602c90-81c2-4000-8000-0000000430e3"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "eba423ef-81bb-4800-8000-0000000436ae"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "ecfed368-80ab-4800-8000-000000043ce1"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "ee6cbc32-926b-4800-8000-00000004436c"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "efa39820-1cd5-4800-8000-0000000448fb"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f10694b6-4c9f-4000-8000-000000044f54"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f236aafe-8d80-4000-8000-0000000454c4"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f37bf1e8-e608-4800-8000-000000045a95"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f49320d9-945b-4000-8000-000000045f93"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f60300f4-aaf0-4000-8000-000000046627"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f7414a4d-2b2c-4000-8000-000000046bd8"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "f88ff5f3-7e59-4000-8000-0000000471d4"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "fa0b6a08-232b-4800-8000-00000004789d"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "fb89ed0c-969f-4000-8000-000000047f74"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "fd379fa9-7e13-4800-8000-000000048723"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "fe9914c7-c68b-4800-8000-000000048d75"
+ },
+ {
+ "distinct_range": 1526.0653266331658,
+ "num_eq": 4,
+ "num_range": 1526,
+ "upper_bound": "fff4a3f3-0084-4000-8000-0000000493ac"
+ },
+ {
+ "distinct_range": 1.1641532182693481E-10,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "ffffffff-ffff-ffff-ffff-ffffffffffff"
+ }
+ ],
+ "histo_col_type": "UUID",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "h_w_id",
+ "rowid"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 300000,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "h_c_id"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 2999,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 120,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 2997,
+ "num_eq": 150,
+ "num_range": 299730,
+ "upper_bound": "3000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "h_c_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 28860,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 29400,
+ "num_range": 241740,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "h_c_w_id"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 31200,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 29220,
+ "num_range": 239580,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "h_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 28860,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 29400,
+ "num_range": 241740,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "h_date"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "2006-01-02 15:04:05"
+ }
+ ],
+ "histo_col_type": "TIMESTAMP",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "h_amount"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "1E+1"
+ }
+ ],
+ "histo_col_type": "DECIMAL(6,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 21,
+ "columns": [
+ "h_data"
+ ],
+ "created_at": "2022-02-25 01:09:18.469724",
+ "distinct_count": 806,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 180,
+ "num_range": 0,
+ "upper_bound": "1U5yraPxxELo"
+ },
+ {
+ "distinct_range": 804,
+ "num_eq": 390,
+ "num_range": 299430,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "VARCHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ }
+]';
+----
+
+exec-ddl
+ALTER TABLE "item" INJECT STATISTICS '[
+ {
+ "avg_size": 4,
+ "columns": [
+ "i_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.750968",
+ "distinct_count": 99658,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "-9223372036854775808"
+ },
+ {
+ "distinct_range": 2.1827872842550278E-11,
+ "num_eq": 2,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 466.6317773119472,
+ "num_eq": 2,
+ "num_range": 480,
+ "upper_bound": "477"
+ },
+ {
+ "distinct_range": 335.34963633773646,
+ "num_eq": 2,
+ "num_range": 418,
+ "upper_bound": "814"
+ },
+ {
+ "distinct_range": 500.42429303550284,
+ "num_eq": 2,
+ "num_range": 499,
+ "upper_bound": "1317"
+ },
+ {
+ "distinct_range": 477.56546633759496,
+ "num_eq": 2,
+ "num_range": 486,
+ "upper_bound": "1797"
+ },
+ {
+ "distinct_range": 572.9565750803921,
+ "num_eq": 2,
+ "num_range": 539,
+ "upper_bound": "2373"
+ },
+ {
+ "distinct_range": 447.74433562752836,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "2823"
+ },
+ {
+ "distinct_range": 577.9235817481649,
+ "num_eq": 2,
+ "num_range": 542,
+ "upper_bound": "3404"
+ },
+ {
+ "distinct_range": 537.1906759176618,
+ "num_eq": 2,
+ "num_range": 519,
+ "upper_bound": "3944"
+ },
+ {
+ "distinct_range": 490.48607852135035,
+ "num_eq": 2,
+ "num_range": 493,
+ "upper_bound": "4437"
+ },
+ {
+ "distinct_range": 434.8198149226815,
+ "num_eq": 2,
+ "num_range": 464,
+ "upper_bound": "4874"
+ },
+ {
+ "distinct_range": 545.1391995097557,
+ "num_eq": 2,
+ "num_range": 523,
+ "upper_bound": "5422"
+ },
+ {
+ "distinct_range": 647.4509550297842,
+ "num_eq": 2,
+ "num_range": 584,
+ "upper_bound": "6073"
+ },
+ {
+ "distinct_range": 585.8705638445534,
+ "num_eq": 2,
+ "num_range": 547,
+ "upper_bound": "6662"
+ },
+ {
+ "distinct_range": 631.5606266893237,
+ "num_eq": 2,
+ "num_range": 574,
+ "upper_bound": "7297"
+ },
+ {
+ "distinct_range": 562.0287618625746,
+ "num_eq": 2,
+ "num_range": 533,
+ "upper_bound": "7862"
+ },
+ {
+ "distinct_range": 471.6017366533132,
+ "num_eq": 2,
+ "num_range": 483,
+ "upper_bound": "8336"
+ },
+ {
+ "distinct_range": 526.2609150423492,
+ "num_eq": 2,
+ "num_range": 513,
+ "upper_bound": "8865"
+ },
+ {
+ "distinct_range": 491.4799275321452,
+ "num_eq": 2,
+ "num_range": 494,
+ "upper_bound": "9359"
+ },
+ {
+ "distinct_range": 432.831311030429,
+ "num_eq": 2,
+ "num_range": 463,
+ "upper_bound": "9794"
+ },
+ {
+ "distinct_range": 493.46760700652356,
+ "num_eq": 2,
+ "num_range": 495,
+ "upper_bound": "10290"
+ },
+ {
+ "distinct_range": 478.55939817704234,
+ "num_eq": 2,
+ "num_range": 487,
+ "upper_bound": "10771"
+ },
+ {
+ "distinct_range": 563.0222225009626,
+ "num_eq": 2,
+ "num_range": 534,
+ "upper_bound": "11337"
+ },
+ {
+ "distinct_range": 467.6257827930011,
+ "num_eq": 2,
+ "num_range": 481,
+ "upper_bound": "11807"
+ },
+ {
+ "distinct_range": 380.12349035295836,
+ "num_eq": 2,
+ "num_range": 437,
+ "upper_bound": "12189"
+ },
+ {
+ "distinct_range": 640.4990474195706,
+ "num_eq": 2,
+ "num_range": 579,
+ "upper_bound": "12833"
+ },
+ {
+ "distinct_range": 454.7031678680387,
+ "num_eq": 2,
+ "num_range": 474,
+ "upper_bound": "13290"
+ },
+ {
+ "distinct_range": 393.05418831588617,
+ "num_eq": 2,
+ "num_range": 443,
+ "upper_bound": "13685"
+ },
+ {
+ "distinct_range": 478.55939817704234,
+ "num_eq": 2,
+ "num_range": 487,
+ "upper_bound": "14166"
+ },
+ {
+ "distinct_range": 602.757000468728,
+ "num_eq": 2,
+ "num_range": 557,
+ "upper_bound": "14772"
+ },
+ {
+ "distinct_range": 581.8971075707373,
+ "num_eq": 2,
+ "num_range": 545,
+ "upper_bound": "15357"
+ },
+ {
+ "distinct_range": 531.2290672310313,
+ "num_eq": 2,
+ "num_range": 516,
+ "upper_bound": "15891"
+ },
+ {
+ "distinct_range": 561.035296539617,
+ "num_eq": 2,
+ "num_range": 533,
+ "upper_bound": "16455"
+ },
+ {
+ "distinct_range": 552.0938948680937,
+ "num_eq": 2,
+ "num_range": 527,
+ "upper_bound": "17010"
+ },
+ {
+ "distinct_range": 445.7560313918622,
+ "num_eq": 2,
+ "num_range": 469,
+ "upper_bound": "17458"
+ },
+ {
+ "distinct_range": 409.9611655130185,
+ "num_eq": 2,
+ "num_range": 452,
+ "upper_bound": "17870"
+ },
+ {
+ "distinct_range": 468.61978143928786,
+ "num_eq": 2,
+ "num_range": 481,
+ "upper_bound": "18341"
+ },
+ {
+ "distinct_range": 547.1262800331258,
+ "num_eq": 2,
+ "num_range": 525,
+ "upper_bound": "18891"
+ },
+ {
+ "distinct_range": 535.2034938597805,
+ "num_eq": 2,
+ "num_range": 518,
+ "upper_bound": "19429"
+ },
+ {
+ "distinct_range": 424.8769755103909,
+ "num_eq": 2,
+ "num_range": 459,
+ "upper_bound": "19856"
+ },
+ {
+ "distinct_range": 566.0025764850405,
+ "num_eq": 2,
+ "num_range": 535,
+ "upper_bound": "20425"
+ },
+ {
+ "distinct_range": 697.102776414988,
+ "num_eq": 2,
+ "num_range": 614,
+ "upper_bound": "21126"
+ },
+ {
+ "distinct_range": 395.04338232049963,
+ "num_eq": 2,
+ "num_range": 444,
+ "upper_bound": "21523"
+ },
+ {
+ "distinct_range": 498.43669866528876,
+ "num_eq": 2,
+ "num_range": 497,
+ "upper_bound": "22024"
+ },
+ {
+ "distinct_range": 635.5332938693055,
+ "num_eq": 2,
+ "num_range": 576,
+ "upper_bound": "22663"
+ },
+ {
+ "distinct_range": 396.0379652494675,
+ "num_eq": 2,
+ "num_range": 445,
+ "upper_bound": "23061"
+ },
+ {
+ "distinct_range": 448.738476575724,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "23512"
+ },
+ {
+ "distinct_range": 579.9103534175954,
+ "num_eq": 2,
+ "num_range": 543,
+ "upper_bound": "24095"
+ },
+ {
+ "distinct_range": 548.1198128448667,
+ "num_eq": 2,
+ "num_range": 525,
+ "upper_bound": "24646"
+ },
+ {
+ "distinct_range": 513.3430829380552,
+ "num_eq": 2,
+ "num_range": 506,
+ "upper_bound": "25162"
+ },
+ {
+ "distinct_range": 436.80828736883205,
+ "num_eq": 2,
+ "num_range": 465,
+ "upper_bound": "25601"
+ },
+ {
+ "distinct_range": 437.802511883951,
+ "num_eq": 2,
+ "num_range": 465,
+ "upper_bound": "26041"
+ },
+ {
+ "distinct_range": 538.1842592031558,
+ "num_eq": 2,
+ "num_range": 520,
+ "upper_bound": "26582"
+ },
+ {
+ "distinct_range": 451.72085512000285,
+ "num_eq": 2,
+ "num_range": 473,
+ "upper_bound": "27036"
+ },
+ {
+ "distinct_range": 549.1133407153599,
+ "num_eq": 2,
+ "num_range": 526,
+ "upper_bound": "27588"
+ },
+ {
+ "distinct_range": 483.5289599637081,
+ "num_eq": 2,
+ "num_range": 489,
+ "upper_bound": "28074"
+ },
+ {
+ "distinct_range": 548.1198128448667,
+ "num_eq": 2,
+ "num_range": 525,
+ "upper_bound": "28625"
+ },
+ {
+ "distinct_range": 569.9763172758185,
+ "num_eq": 2,
+ "num_range": 538,
+ "upper_bound": "29198"
+ },
+ {
+ "distinct_range": 548.1198128448667,
+ "num_eq": 2,
+ "num_range": 525,
+ "upper_bound": "29749"
+ },
+ {
+ "distinct_range": 469.6137732792577,
+ "num_eq": 2,
+ "num_range": 482,
+ "upper_bound": "30221"
+ },
+ {
+ "distinct_range": 487.50449409077686,
+ "num_eq": 2,
+ "num_range": 491,
+ "upper_bound": "30711"
+ },
+ {
+ "distinct_range": 589.8439515902517,
+ "num_eq": 2,
+ "num_range": 549,
+ "upper_bound": "31304"
+ },
+ {
+ "distinct_range": 465.6377649675292,
+ "num_eq": 2,
+ "num_range": 480,
+ "upper_bound": "31772"
+ },
+ {
+ "distinct_range": 596.7972182511465,
+ "num_eq": 2,
+ "num_range": 553,
+ "upper_bound": "32372"
+ },
+ {
+ "distinct_range": 475.5775829612445,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "32850"
+ },
+ {
+ "distinct_range": 493.46760700652356,
+ "num_eq": 2,
+ "num_range": 495,
+ "upper_bound": "33346"
+ },
+ {
+ "distinct_range": 503.40563988343365,
+ "num_eq": 2,
+ "num_range": 500,
+ "upper_bound": "33852"
+ },
+ {
+ "distinct_range": 487.50449409077686,
+ "num_eq": 2,
+ "num_range": 491,
+ "upper_bound": "34342"
+ },
+ {
+ "distinct_range": 533.216291018419,
+ "num_eq": 2,
+ "num_range": 517,
+ "upper_bound": "34878"
+ },
+ {
+ "distinct_range": 430.8427754197312,
+ "num_eq": 2,
+ "num_range": 462,
+ "upper_bound": "35311"
+ },
+ {
+ "distinct_range": 504.39941033985656,
+ "num_eq": 2,
+ "num_range": 501,
+ "upper_bound": "35818"
+ },
+ {
+ "distinct_range": 594.81059142862,
+ "num_eq": 2,
+ "num_range": 552,
+ "upper_bound": "36416"
+ },
+ {
+ "distinct_range": 443.7676971581611,
+ "num_eq": 2,
+ "num_range": 468,
+ "upper_bound": "36862"
+ },
+ {
+ "distinct_range": 461.6616463790667,
+ "num_eq": 2,
+ "num_range": 478,
+ "upper_bound": "37326"
+ },
+ {
+ "distinct_range": 447.74433562752836,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "37776"
+ },
+ {
+ "distinct_range": 490.48607852135035,
+ "num_eq": 2,
+ "num_range": 493,
+ "upper_bound": "38269"
+ },
+ {
+ "distinct_range": 587.8572662203806,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "38860"
+ },
+ {
+ "distinct_range": 458.6794839489045,
+ "num_eq": 2,
+ "num_range": 476,
+ "upper_bound": "39321"
+ },
+ {
+ "distinct_range": 434.8198149226815,
+ "num_eq": 2,
+ "num_range": 464,
+ "upper_bound": "39758"
+ },
+ {
+ "distinct_range": 447.74433562752836,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "40208"
+ },
+ {
+ "distinct_range": 605.7368370431215,
+ "num_eq": 2,
+ "num_range": 559,
+ "upper_bound": "40817"
+ },
+ {
+ "distinct_range": 417.91650152903696,
+ "num_eq": 2,
+ "num_range": 455,
+ "upper_bound": "41237"
+ },
+ {
+ "distinct_range": 532.2226817532005,
+ "num_eq": 2,
+ "num_range": 516,
+ "upper_bound": "41772"
+ },
+ {
+ "distinct_range": 521.2926283003677,
+ "num_eq": 2,
+ "num_range": 510,
+ "upper_bound": "42296"
+ },
+ {
+ "distinct_range": 412.9444812144581,
+ "num_eq": 2,
+ "num_range": 453,
+ "upper_bound": "42711"
+ },
+ {
+ "distinct_range": 754.6898561726498,
+ "num_eq": 2,
+ "num_range": 650,
+ "upper_bound": "43470"
+ },
+ {
+ "distinct_range": 416.922114542295,
+ "num_eq": 2,
+ "num_range": 455,
+ "upper_bound": "43889"
+ },
+ {
+ "distinct_range": 611.6964030782365,
+ "num_eq": 2,
+ "num_range": 562,
+ "upper_bound": "44504"
+ },
+ {
+ "distinct_range": 573.9499853366112,
+ "num_eq": 2,
+ "num_range": 540,
+ "upper_bound": "45081"
+ },
+ {
+ "distinct_range": 601.7637135802656,
+ "num_eq": 2,
+ "num_range": 556,
+ "upper_bound": "45686"
+ },
+ {
+ "distinct_range": 457.6854156501106,
+ "num_eq": 2,
+ "num_range": 476,
+ "upper_bound": "46146"
+ },
+ {
+ "distinct_range": 397.03253885179663,
+ "num_eq": 2,
+ "num_range": 445,
+ "upper_bound": "46545"
+ },
+ {
+ "distinct_range": 512.3493645059226,
+ "num_eq": 2,
+ "num_range": 505,
+ "upper_bound": "47060"
+ },
+ {
+ "distinct_range": 440.7851389980674,
+ "num_eq": 2,
+ "num_range": 467,
+ "upper_bound": "47503"
+ },
+ {
+ "distinct_range": 522.2862965405085,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "48028"
+ },
+ {
+ "distinct_range": 468.61978143928786,
+ "num_eq": 2,
+ "num_range": 481,
+ "upper_bound": "48499"
+ },
+ {
+ "distinct_range": 407.9722446126234,
+ "num_eq": 2,
+ "num_range": 451,
+ "upper_bound": "48909"
+ },
+ {
+ "distinct_range": 515.3305028272479,
+ "num_eq": 2,
+ "num_range": 507,
+ "upper_bound": "49427"
+ },
+ {
+ "distinct_range": 437.802511883951,
+ "num_eq": 2,
+ "num_range": 465,
+ "upper_bound": "49867"
+ },
+ {
+ "distinct_range": 521.2926283003677,
+ "num_eq": 2,
+ "num_range": 510,
+ "upper_bound": "50391"
+ },
+ {
+ "distinct_range": 476.57152794138244,
+ "num_eq": 2,
+ "num_range": 486,
+ "upper_bound": "50870"
+ },
+ {
+ "distinct_range": 425.87129581161105,
+ "num_eq": 2,
+ "num_range": 459,
+ "upper_bound": "51298"
+ },
+ {
+ "distinct_range": 516.3242043292017,
+ "num_eq": 2,
+ "num_range": 507,
+ "upper_bound": "51817"
+ },
+ {
+ "distinct_range": 551.1003817081914,
+ "num_eq": 2,
+ "num_range": 527,
+ "upper_bound": "52371"
+ },
+ {
+ "distinct_range": 600.7704226523323,
+ "num_eq": 2,
+ "num_range": 556,
+ "upper_bound": "52975"
+ },
+ {
+ "distinct_range": 537.1906759176618,
+ "num_eq": 2,
+ "num_range": 519,
+ "upper_bound": "53515"
+ },
+ {
+ "distinct_range": 489.49222329448594,
+ "num_eq": 2,
+ "num_range": 493,
+ "upper_bound": "54007"
+ },
+ {
+ "distinct_range": 528.2481919165974,
+ "num_eq": 2,
+ "num_range": 514,
+ "upper_bound": "54538"
+ },
+ {
+ "distinct_range": 470.6077583412136,
+ "num_eq": 2,
+ "num_range": 482,
+ "upper_bound": "55011"
+ },
+ {
+ "distinct_range": 527.2545561598902,
+ "num_eq": 2,
+ "num_range": 513,
+ "upper_bound": "55541"
+ },
+ {
+ "distinct_range": 464.6437457310018,
+ "num_eq": 2,
+ "num_range": 479,
+ "upper_bound": "56008"
+ },
+ {
+ "distinct_range": 439.7909376654041,
+ "num_eq": 2,
+ "num_range": 466,
+ "upper_bound": "56450"
+ },
+ {
+ "distinct_range": 521.2926283003677,
+ "num_eq": 2,
+ "num_range": 510,
+ "upper_bound": "56974"
+ },
+ {
+ "distinct_range": 630.5674508533554,
+ "num_eq": 2,
+ "num_range": 573,
+ "upper_bound": "57608"
+ },
+ {
+ "distinct_range": 441.7793326692868,
+ "num_eq": 2,
+ "num_range": 467,
+ "upper_bound": "58052"
+ },
+ {
+ "distinct_range": 599.7771276702426,
+ "num_eq": 2,
+ "num_range": 555,
+ "upper_bound": "58655"
+ },
+ {
+ "distinct_range": 352.2668689166162,
+ "num_eq": 2,
+ "num_range": 425,
+ "upper_bound": "59009"
+ },
+ {
+ "distinct_range": 471.6017366533132,
+ "num_eq": 2,
+ "num_range": 483,
+ "upper_bound": "59483"
+ },
+ {
+ "distinct_range": 601.7637135802656,
+ "num_eq": 2,
+ "num_range": 556,
+ "upper_bound": "60088"
+ },
+ {
+ "distinct_range": 523.2799593133182,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "60614"
+ },
+ {
+ "distinct_range": 521.2926283003677,
+ "num_eq": 2,
+ "num_range": 510,
+ "upper_bound": "61138"
+ },
+ {
+ "distinct_range": 613.6828937690491,
+ "num_eq": 2,
+ "num_range": 563,
+ "upper_bound": "61755"
+ },
+ {
+ "distinct_range": 474.58363136988066,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "62232"
+ },
+ {
+ "distinct_range": 620.6354900510664,
+ "num_eq": 2,
+ "num_range": 568,
+ "upper_bound": "62856"
+ },
+ {
+ "distinct_range": 625.6015167875023,
+ "num_eq": 2,
+ "num_range": 571,
+ "upper_bound": "63485"
+ },
+ {
+ "distinct_range": 459.67354515014966,
+ "num_eq": 2,
+ "num_range": 477,
+ "upper_bound": "63947"
+ },
+ {
+ "distinct_range": 468.61978143928786,
+ "num_eq": 2,
+ "num_range": 481,
+ "upper_bound": "64418"
+ },
+ {
+ "distinct_range": 431.8370472070187,
+ "num_eq": 2,
+ "num_range": 462,
+ "upper_bound": "64852"
+ },
+ {
+ "distinct_range": 456.69134022380615,
+ "num_eq": 2,
+ "num_range": 475,
+ "upper_bound": "65311"
+ },
+ {
+ "distinct_range": 447.74433562752836,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "65761"
+ },
+ {
+ "distinct_range": 465.6377649675292,
+ "num_eq": 2,
+ "num_range": 480,
+ "upper_bound": "66229"
+ },
+ {
+ "distinct_range": 425.87129581161105,
+ "num_eq": 2,
+ "num_range": 459,
+ "upper_bound": "66657"
+ },
+ {
+ "distinct_range": 364.20644920265676,
+ "num_eq": 2,
+ "num_range": 430,
+ "upper_bound": "67023"
+ },
+ {
+ "distinct_range": 511.3556403853147,
+ "num_eq": 2,
+ "num_range": 505,
+ "upper_bound": "67537"
+ },
+ {
+ "distinct_range": 424.8769755103909,
+ "num_eq": 2,
+ "num_range": 459,
+ "upper_bound": "67964"
+ },
+ {
+ "distinct_range": 423.8826470000256,
+ "num_eq": 2,
+ "num_range": 458,
+ "upper_bound": "68390"
+ },
+ {
+ "distinct_range": 542.158541186978,
+ "num_eq": 2,
+ "num_range": 522,
+ "upper_bound": "68935"
+ },
+ {
+ "distinct_range": 495.45526191833284,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "69433"
+ },
+ {
+ "distinct_range": 422.88831024473757,
+ "num_eq": 2,
+ "num_range": 458,
+ "upper_bound": "69858"
+ },
+ {
+ "distinct_range": 377.13924620933744,
+ "num_eq": 2,
+ "num_range": 436,
+ "upper_bound": "70237"
+ },
+ {
+ "distinct_range": 512.3493645059226,
+ "num_eq": 2,
+ "num_range": 505,
+ "upper_bound": "70752"
+ },
+ {
+ "distinct_range": 448.738476575724,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "71203"
+ },
+ {
+ "distinct_range": 443.7676971581611,
+ "num_eq": 2,
+ "num_range": 468,
+ "upper_bound": "71649"
+ },
+ {
+ "distinct_range": 571.9631603294307,
+ "num_eq": 2,
+ "num_range": 539,
+ "upper_bound": "72224"
+ },
+ {
+ "distinct_range": 444.7618680407743,
+ "num_eq": 2,
+ "num_range": 469,
+ "upper_bound": "72671"
+ },
+ {
+ "distinct_range": 428.8542078153812,
+ "num_eq": 2,
+ "num_range": 461,
+ "upper_bound": "73102"
+ },
+ {
+ "distinct_range": 441.7793326692868,
+ "num_eq": 2,
+ "num_range": 467,
+ "upper_bound": "73546"
+ },
+ {
+ "distinct_range": 509.368174987636,
+ "num_eq": 2,
+ "num_range": 503,
+ "upper_bound": "74058"
+ },
+ {
+ "distinct_range": 452.7149666387738,
+ "num_eq": 2,
+ "num_range": 473,
+ "upper_bound": "74513"
+ },
+ {
+ "distinct_range": 500.42429303550284,
+ "num_eq": 2,
+ "num_range": 499,
+ "upper_bound": "75016"
+ },
+ {
+ "distinct_range": 469.6137732792577,
+ "num_eq": 2,
+ "num_range": 482,
+ "upper_bound": "75488"
+ },
+ {
+ "distinct_range": 491.51048072385817,
+ "num_eq": 2,
+ "num_range": 498,
+ "upper_bound": "75982"
+ },
+ {
+ "distinct_range": 472.62505496508845,
+ "num_eq": 2,
+ "num_range": 488,
+ "upper_bound": "76457"
+ },
+ {
+ "distinct_range": 468.64886821379025,
+ "num_eq": 2,
+ "num_range": 486,
+ "upper_bound": "76928"
+ },
+ {
+ "distinct_range": 533.2493523335585,
+ "num_eq": 2,
+ "num_range": 521,
+ "upper_bound": "77464"
+ },
+ {
+ "distinct_range": 480.5771026542069,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "77947"
+ },
+ {
+ "distinct_range": 509.39982918467797,
+ "num_eq": 2,
+ "num_range": 508,
+ "upper_bound": "78459"
+ },
+ {
+ "distinct_range": 487.5347971248698,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "78949"
+ },
+ {
+ "distinct_range": 579.945981653491,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "79532"
+ },
+ {
+ "distinct_range": 492.50438576774684,
+ "num_eq": 2,
+ "num_range": 499,
+ "upper_bound": "80027"
+ },
+ {
+ "distinct_range": 551.1344546662883,
+ "num_eq": 2,
+ "num_range": 531,
+ "upper_bound": "80581"
+ },
+ {
+ "distinct_range": 596.8337175293038,
+ "num_eq": 2,
+ "num_range": 558,
+ "upper_bound": "81181"
+ },
+ {
+ "distinct_range": 527.2872720506152,
+ "num_eq": 2,
+ "num_range": 518,
+ "upper_bound": "81711"
+ },
+ {
+ "distinct_range": 472.62505496508845,
+ "num_eq": 2,
+ "num_range": 488,
+ "upper_bound": "82186"
+ },
+ {
+ "distinct_range": 509.39982918467797,
+ "num_eq": 2,
+ "num_range": 508,
+ "upper_bound": "82698"
+ },
+ {
+ "distinct_range": 423.90866102664086,
+ "num_eq": 2,
+ "num_range": 463,
+ "upper_bound": "83124"
+ },
+ {
+ "distinct_range": 469.64292523729137,
+ "num_eq": 2,
+ "num_range": 487,
+ "upper_bound": "83596"
+ },
+ {
+ "distinct_range": 548.1537197204088,
+ "num_eq": 2,
+ "num_range": 530,
+ "upper_bound": "84147"
+ },
+ {
+ "distinct_range": 507.41222039387765,
+ "num_eq": 2,
+ "num_range": 507,
+ "upper_bound": "84657"
+ },
+ {
+ "distinct_range": 485.5469169106776,
+ "num_eq": 2,
+ "num_range": 495,
+ "upper_bound": "85145"
+ },
+ {
+ "distinct_range": 459.7020393242,
+ "num_eq": 2,
+ "num_range": 482,
+ "upper_bound": "85607"
+ },
+ {
+ "distinct_range": 454.731328153132,
+ "num_eq": 2,
+ "num_range": 479,
+ "upper_bound": "86064"
+ },
+ {
+ "distinct_range": 486.5408602406276,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "86553"
+ },
+ {
+ "distinct_range": 524.3061582476953,
+ "num_eq": 2,
+ "num_range": 516,
+ "upper_bound": "87080"
+ },
+ {
+ "distinct_range": 378.1565844417248,
+ "num_eq": 2,
+ "num_range": 442,
+ "upper_bound": "87460"
+ },
+ {
+ "distinct_range": 617.6933648066774,
+ "num_eq": 2,
+ "num_range": 570,
+ "upper_bound": "88081"
+ },
+ {
+ "distinct_range": 600.8071226868135,
+ "num_eq": 2,
+ "num_range": 560,
+ "upper_bound": "88685"
+ },
+ {
+ "distinct_range": 500.4554017381483,
+ "num_eq": 2,
+ "num_range": 503,
+ "upper_bound": "89188"
+ },
+ {
+ "distinct_range": 424.903060851002,
+ "num_eq": 2,
+ "num_range": 464,
+ "upper_bound": "89615"
+ },
+ {
+ "distinct_range": 482.56504798407383,
+ "num_eq": 2,
+ "num_range": 494,
+ "upper_bound": "90100"
+ },
+ {
+ "distinct_range": 495.4860632523615,
+ "num_eq": 2,
+ "num_range": 500,
+ "upper_bound": "90598"
+ },
+ {
+ "distinct_range": 497.4738171207672,
+ "num_eq": 2,
+ "num_range": 502,
+ "upper_bound": "91098"
+ },
+ {
+ "distinct_range": 444.7893504173858,
+ "num_eq": 2,
+ "num_range": 474,
+ "upper_bound": "91545"
+ },
+ {
+ "distinct_range": 476.60113251982193,
+ "num_eq": 2,
+ "num_range": 490,
+ "upper_bound": "92024"
+ },
+ {
+ "distinct_range": 445.7835821715488,
+ "num_eq": 2,
+ "num_range": 474,
+ "upper_bound": "92472"
+ },
+ {
+ "distinct_range": 506.4184071224961,
+ "num_eq": 2,
+ "num_range": 506,
+ "upper_bound": "92981"
+ },
+ {
+ "distinct_range": 580.9394129613788,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "93565"
+ },
+ {
+ "distinct_range": 425.89745232593316,
+ "num_eq": 2,
+ "num_range": 464,
+ "upper_bound": "93993"
+ },
+ {
+ "distinct_range": 421.919836185745,
+ "num_eq": 2,
+ "num_range": 462,
+ "upper_bound": "94417"
+ },
+ {
+ "distinct_range": 487.5347971248698,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "94907"
+ },
+ {
+ "distinct_range": 480.5771026542069,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "95390"
+ },
+ {
+ "distinct_range": 446.7778062896516,
+ "num_eq": 2,
+ "num_range": 475,
+ "upper_bound": "95839"
+ },
+ {
+ "distinct_range": 496.47994328205584,
+ "num_eq": 2,
+ "num_range": 501,
+ "upper_bound": "96338"
+ },
+ {
+ "distinct_range": 475.6071232705648,
+ "num_eq": 2,
+ "num_range": 490,
+ "upper_bound": "96816"
+ },
+ {
+ "distinct_range": 628.6191505868078,
+ "num_eq": 2,
+ "num_range": 576,
+ "upper_bound": "97448"
+ },
+ {
+ "distinct_range": 443.7951109949059,
+ "num_eq": 2,
+ "num_range": 473,
+ "upper_bound": "97894"
+ },
+ {
+ "distinct_range": 536.2303199468959,
+ "num_eq": 2,
+ "num_range": 523,
+ "upper_bound": "98433"
+ },
+ {
+ "distinct_range": 600.8071226868135,
+ "num_eq": 2,
+ "num_range": 560,
+ "upper_bound": "99037"
+ },
+ {
+ "distinct_range": 493.4982845202958,
+ "num_eq": 2,
+ "num_range": 499,
+ "upper_bound": "99533"
+ },
+ {
+ "distinct_range": 443.7951109949059,
+ "num_eq": 2,
+ "num_range": 473,
+ "upper_bound": "99979"
+ },
+ {
+ "distinct_range": 2.1827872842550278E-11,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "9223372036854775807"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "i_im_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.750968",
+ "distinct_count": 9918,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 9916,
+ "num_eq": 10,
+ "num_range": 99980,
+ "upper_bound": "10000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 22,
+ "columns": [
+ "i_name"
+ ],
+ "created_at": "2022-02-25 01:08:06.750968",
+ "distinct_count": 682,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 150,
+ "num_range": 0,
+ "upper_bound": "1U5yraPxxELo5B"
+ },
+ {
+ "distinct_range": 680,
+ "num_eq": 150,
+ "num_range": 99700,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "VARCHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "i_price"
+ ],
+ "created_at": "2022-02-25 01:08:06.750968",
+ "distinct_count": 9857,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 9855,
+ "num_eq": 20,
+ "num_range": 99970,
+ "upper_bound": "1E+2"
+ }
+ ],
+ "histo_col_type": "DECIMAL(5,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 41,
+ "columns": [
+ "i_data"
+ ],
+ "created_at": "2022-02-25 01:08:06.750968",
+ "distinct_count": 11682,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "0ORIGINALYhgLRrwsmd68P2bElAgrnp8ueWNXJpBB0ObpVW"
+ },
+ {
+ "distinct_range": 11680,
+ "num_eq": 10,
+ "num_range": 99980,
+ "upper_bound": "zmssaF9mORIGINAL9cdLXe0YhgLRrwsmd"
+ }
+ ],
+ "histo_col_type": "VARCHAR(50)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "i_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.845057",
+ "distinct_count": 99658,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 2,
+ "num_range": 0,
+ "upper_bound": "10"
+ },
+ {
+ "distinct_range": 424.87946032494574,
+ "num_eq": 2,
+ "num_range": 459,
+ "upper_bound": "437"
+ },
+ {
+ "distinct_range": 474.58676524044154,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "914"
+ },
+ {
+ "distinct_range": 396.04009385661055,
+ "num_eq": 2,
+ "num_range": 445,
+ "upper_bound": "1312"
+ },
+ {
+ "distinct_range": 392.0616579447497,
+ "num_eq": 2,
+ "num_range": 443,
+ "upper_bound": "1706"
+ },
+ {
+ "distinct_range": 512.3530167175514,
+ "num_eq": 2,
+ "num_range": 505,
+ "upper_bound": "2221"
+ },
+ {
+ "distinct_range": 482.5383018444409,
+ "num_eq": 2,
+ "num_range": 489,
+ "upper_bound": "2706"
+ },
+ {
+ "distinct_range": 542.1626156160783,
+ "num_eq": 2,
+ "num_range": 522,
+ "upper_bound": "3251"
+ },
+ {
+ "distinct_range": 446.7529525909505,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "3700"
+ },
+ {
+ "distinct_range": 457.6883243118151,
+ "num_eq": 2,
+ "num_range": 476,
+ "upper_bound": "4160"
+ },
+ {
+ "distinct_range": 671.2908220089689,
+ "num_eq": 2,
+ "num_range": 598,
+ "upper_bound": "4835"
+ },
+ {
+ "distinct_range": 523.2837650915294,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "5361"
+ },
+ {
+ "distinct_range": 505.39673019900124,
+ "num_eq": 2,
+ "num_range": 501,
+ "upper_bound": "5869"
+ },
+ {
+ "distinct_range": 517.321622062246,
+ "num_eq": 2,
+ "num_range": 508,
+ "upper_bound": "6389"
+ },
+ {
+ "distinct_range": 576.9347689866894,
+ "num_eq": 2,
+ "num_range": 542,
+ "upper_bound": "6969"
+ },
+ {
+ "distinct_range": 473.5927936423335,
+ "num_eq": 2,
+ "num_range": 484,
+ "upper_bound": "7445"
+ },
+ {
+ "distinct_range": 503.4091675796326,
+ "num_eq": 2,
+ "num_range": 500,
+ "upper_bound": "7951"
+ },
+ {
+ "distinct_range": 567.0004525892498,
+ "num_eq": 2,
+ "num_range": 536,
+ "upper_bound": "8521"
+ },
+ {
+ "distinct_range": 460.6705473660175,
+ "num_eq": 2,
+ "num_range": 477,
+ "upper_bound": "8984"
+ },
+ {
+ "distinct_range": 448.7412678343252,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "9435"
+ },
+ {
+ "distinct_range": 414.9356751866655,
+ "num_eq": 2,
+ "num_range": 454,
+ "upper_bound": "9852"
+ },
+ {
+ "distinct_range": 422.89076997995255,
+ "num_eq": 2,
+ "num_range": 458,
+ "upper_bound": "10277"
+ },
+ {
+ "distinct_range": 377.1411507212755,
+ "num_eq": 2,
+ "num_range": 436,
+ "upper_bound": "10656"
+ },
+ {
+ "distinct_range": 439.79361284810454,
+ "num_eq": 2,
+ "num_range": 467,
+ "upper_bound": "11098"
+ },
+ {
+ "distinct_range": 474.58676524044154,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "11575"
+ },
+ {
+ "distinct_range": 559.0526700041055,
+ "num_eq": 2,
+ "num_range": 532,
+ "upper_bound": "12137"
+ },
+ {
+ "distinct_range": 487.50780306122624,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "12627"
+ },
+ {
+ "distinct_range": 448.7412678343252,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "13078"
+ },
+ {
+ "distinct_range": 456.6942357767432,
+ "num_eq": 2,
+ "num_range": 475,
+ "upper_bound": "13537"
+ },
+ {
+ "distinct_range": 573.9545212183488,
+ "num_eq": 2,
+ "num_range": 540,
+ "upper_bound": "14114"
+ },
+ {
+ "distinct_range": 446.7529525909505,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "14563"
+ },
+ {
+ "distinct_range": 569.9807948952596,
+ "num_eq": 2,
+ "num_range": 538,
+ "upper_bound": "15136"
+ },
+ {
+ "distinct_range": 466.63480465434355,
+ "num_eq": 2,
+ "num_range": 480,
+ "upper_bound": "15605"
+ },
+ {
+ "distinct_range": 532.2266142642802,
+ "num_eq": 2,
+ "num_range": 516,
+ "upper_bound": "16140"
+ },
+ {
+ "distinct_range": 493.4709975936828,
+ "num_eq": 2,
+ "num_range": 495,
+ "upper_bound": "16636"
+ },
+ {
+ "distinct_range": 625.6068236940312,
+ "num_eq": 2,
+ "num_range": 571,
+ "upper_bound": "17265"
+ },
+ {
+ "distinct_range": 381.1201693399544,
+ "num_eq": 2,
+ "num_range": 438,
+ "upper_bound": "17648"
+ },
+ {
+ "distinct_range": 486.51391547878643,
+ "num_eq": 2,
+ "num_range": 491,
+ "upper_bound": "18137"
+ },
+ {
+ "distinct_range": 546.1368737731705,
+ "num_eq": 2,
+ "num_range": 524,
+ "upper_bound": "18686"
+ },
+ {
+ "distinct_range": 471.6048304639536,
+ "num_eq": 2,
+ "num_range": 483,
+ "upper_bound": "19160"
+ },
+ {
+ "distinct_range": 559.0526700041055,
+ "num_eq": 2,
+ "num_range": 532,
+ "upper_bound": "19722"
+ },
+ {
+ "distinct_range": 503.4091675796326,
+ "num_eq": 2,
+ "num_range": 500,
+ "upper_bound": "20228"
+ },
+ {
+ "distinct_range": 432.83389688264197,
+ "num_eq": 2,
+ "num_range": 463,
+ "upper_bound": "20663"
+ },
+ {
+ "distinct_range": 550.1110524348004,
+ "num_eq": 2,
+ "num_range": 526,
+ "upper_bound": "21216"
+ },
+ {
+ "distinct_range": 397.0346794654382,
+ "num_eq": 2,
+ "num_range": 445,
+ "upper_bound": "21615"
+ },
+ {
+ "distinct_range": 456.6942357767432,
+ "num_eq": 2,
+ "num_range": 475,
+ "upper_bound": "22074"
+ },
+ {
+ "distinct_range": 447.7471139223363,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "22524"
+ },
+ {
+ "distinct_range": 397.0346794654382,
+ "num_eq": 2,
+ "num_range": 445,
+ "upper_bound": "22923"
+ },
+ {
+ "distinct_range": 516.3279122104744,
+ "num_eq": 2,
+ "num_range": 507,
+ "upper_bound": "23442"
+ },
+ {
+ "distinct_range": 552.0981123342475,
+ "num_eq": 2,
+ "num_range": 528,
+ "upper_bound": "23997"
+ },
+ {
+ "distinct_range": 459.6764800766341,
+ "num_eq": 2,
+ "num_range": 477,
+ "upper_bound": "24459"
+ },
+ {
+ "distinct_range": 466.63480465434355,
+ "num_eq": 2,
+ "num_range": 480,
+ "upper_bound": "24928"
+ },
+ {
+ "distinct_range": 489.49555941541473,
+ "num_eq": 2,
+ "num_range": 493,
+ "upper_bound": "25420"
+ },
+ {
+ "distinct_range": 442.77623243583787,
+ "num_eq": 2,
+ "num_range": 468,
+ "upper_bound": "25865"
+ },
+ {
+ "distinct_range": 547.1304258435587,
+ "num_eq": 2,
+ "num_range": 525,
+ "upper_bound": "26415"
+ },
+ {
+ "distinct_range": 411.9523744755335,
+ "num_eq": 2,
+ "num_range": 453,
+ "upper_bound": "26829"
+ },
+ {
+ "distinct_range": 518.3153263498374,
+ "num_eq": 2,
+ "num_range": 509,
+ "upper_bound": "27350"
+ },
+ {
+ "distinct_range": 476.57468859210314,
+ "num_eq": 2,
+ "num_range": 486,
+ "upper_bound": "27829"
+ },
+ {
+ "distinct_range": 513.3467490483403,
+ "num_eq": 2,
+ "num_range": 506,
+ "upper_bound": "28345"
+ },
+ {
+ "distinct_range": 485.52002159183223,
+ "num_eq": 2,
+ "num_range": 491,
+ "upper_bound": "28833"
+ },
+ {
+ "distinct_range": 558.05917609317,
+ "num_eq": 2,
+ "num_range": 531,
+ "upper_bound": "29394"
+ },
+ {
+ "distinct_range": 484.5261213744859,
+ "num_eq": 2,
+ "num_range": 490,
+ "upper_bound": "29881"
+ },
+ {
+ "distinct_range": 464.64674659196146,
+ "num_eq": 2,
+ "num_range": 479,
+ "upper_bound": "30348"
+ },
+ {
+ "distinct_range": 514.3404757258068,
+ "num_eq": 2,
+ "num_range": 506,
+ "upper_bound": "30865"
+ },
+ {
+ "distinct_range": 438.79939100793035,
+ "num_eq": 2,
+ "num_range": 466,
+ "upper_bound": "31306"
+ },
+ {
+ "distinct_range": 439.79361284810454,
+ "num_eq": 2,
+ "num_range": 467,
+ "upper_bound": "31748"
+ },
+ {
+ "distinct_range": 394.0508946794037,
+ "num_eq": 2,
+ "num_range": 444,
+ "upper_bound": "32144"
+ },
+ {
+ "distinct_range": 620.6407217880326,
+ "num_eq": 2,
+ "num_range": 568,
+ "upper_bound": "32768"
+ },
+ {
+ "distinct_range": 509.371785579016,
+ "num_eq": 2,
+ "num_range": 504,
+ "upper_bound": "33280"
+ },
+ {
+ "distinct_range": 577.9281760507307,
+ "num_eq": 2,
+ "num_range": 542,
+ "upper_bound": "33861"
+ },
+ {
+ "distinct_range": 523.2837650915294,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "34387"
+ },
+ {
+ "distinct_range": 587.8620072533073,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "34978"
+ },
+ {
+ "distinct_range": 495.45867982035037,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "35476"
+ },
+ {
+ "distinct_range": 473.5927936423335,
+ "num_eq": 2,
+ "num_range": 484,
+ "upper_bound": "35952"
+ },
+ {
+ "distinct_range": 479.5565244168138,
+ "num_eq": 2,
+ "num_range": 487,
+ "upper_bound": "36434"
+ },
+ {
+ "distinct_range": 519.3090250952564,
+ "num_eq": 2,
+ "num_range": 509,
+ "upper_bound": "36956"
+ },
+ {
+ "distinct_range": 586.8686434830263,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "37546"
+ },
+ {
+ "distinct_range": 485.52002159183223,
+ "num_eq": 2,
+ "num_range": 491,
+ "upper_bound": "38034"
+ },
+ {
+ "distinct_range": 526.2647629580936,
+ "num_eq": 2,
+ "num_range": 513,
+ "upper_bound": "38563"
+ },
+ {
+ "distinct_range": 470.6108388282106,
+ "num_eq": 2,
+ "num_range": 483,
+ "upper_bound": "39036"
+ },
+ {
+ "distinct_range": 457.6883243118151,
+ "num_eq": 2,
+ "num_range": 476,
+ "upper_bound": "39496"
+ },
+ {
+ "distinct_range": 592.828762784178,
+ "num_eq": 2,
+ "num_range": 551,
+ "upper_bound": "40092"
+ },
+ {
+ "distinct_range": 579.9149769892899,
+ "num_eq": 2,
+ "num_range": 544,
+ "upper_bound": "40675"
+ },
+ {
+ "distinct_range": 572.9610963816006,
+ "num_eq": 2,
+ "num_range": 540,
+ "upper_bound": "41251"
+ },
+ {
+ "distinct_range": 344.30777888262907,
+ "num_eq": 2,
+ "num_range": 421,
+ "upper_bound": "41597"
+ },
+ {
+ "distinct_range": 387.08839957595893,
+ "num_eq": 2,
+ "num_range": 441,
+ "upper_bound": "41986"
+ },
+ {
+ "distinct_range": 537.1946792451545,
+ "num_eq": 2,
+ "num_range": 519,
+ "upper_bound": "42526"
+ },
+ {
+ "distinct_range": 694.1302478225931,
+ "num_eq": 2,
+ "num_range": 612,
+ "upper_bound": "43224"
+ },
+ {
+ "distinct_range": 580.9083708963964,
+ "num_eq": 2,
+ "num_range": 544,
+ "upper_bound": "43808"
+ },
+ {
+ "distinct_range": 399.0238229301833,
+ "num_eq": 2,
+ "num_range": 446,
+ "upper_bound": "44209"
+ },
+ {
+ "distinct_range": 564.0200690009435,
+ "num_eq": 2,
+ "num_range": 534,
+ "upper_bound": "44776"
+ },
+ {
+ "distinct_range": 590.8420731739986,
+ "num_eq": 2,
+ "num_range": 550,
+ "upper_bound": "45370"
+ },
+ {
+ "distinct_range": 566.0069960031082,
+ "num_eq": 2,
+ "num_range": 536,
+ "upper_bound": "45939"
+ },
+ {
+ "distinct_range": 436.8109241634154,
+ "num_eq": 2,
+ "num_range": 465,
+ "upper_bound": "46378"
+ },
+ {
+ "distinct_range": 484.5261213744859,
+ "num_eq": 2,
+ "num_range": 490,
+ "upper_bound": "46865"
+ },
+ {
+ "distinct_range": 434.82242621129063,
+ "num_eq": 2,
+ "num_range": 464,
+ "upper_bound": "47302"
+ },
+ {
+ "distinct_range": 457.6883243118151,
+ "num_eq": 2,
+ "num_range": 476,
+ "upper_bound": "47762"
+ },
+ {
+ "distinct_range": 415.9300915937831,
+ "num_eq": 2,
+ "num_range": 455,
+ "upper_bound": "48180"
+ },
+ {
+ "distinct_range": 488.5016843648975,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "48671"
+ },
+ {
+ "distinct_range": 533.2202376696987,
+ "num_eq": 2,
+ "num_range": 517,
+ "upper_bound": "49207"
+ },
+ {
+ "distinct_range": 495.45867982035037,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "49705"
+ },
+ {
+ "distinct_range": 456.6942357767432,
+ "num_eq": 2,
+ "num_range": 475,
+ "upper_bound": "50164"
+ },
+ {
+ "distinct_range": 386.09371901137945,
+ "num_eq": 2,
+ "num_range": 440,
+ "upper_bound": "50552"
+ },
+ {
+ "distinct_range": 486.51391547878643,
+ "num_eq": 2,
+ "num_range": 491,
+ "upper_bound": "51041"
+ },
+ {
+ "distinct_range": 657.387753560431,
+ "num_eq": 2,
+ "num_range": 590,
+ "upper_bound": "51702"
+ },
+ {
+ "distinct_range": 599.7820460184796,
+ "num_eq": 2,
+ "num_range": 555,
+ "upper_bound": "52305"
+ },
+ {
+ "distinct_range": 523.2837650915294,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "52831"
+ },
+ {
+ "distinct_range": 438.79939100793035,
+ "num_eq": 2,
+ "num_range": 466,
+ "upper_bound": "53272"
+ },
+ {
+ "distinct_range": 505.39673019900124,
+ "num_eq": 2,
+ "num_range": 501,
+ "upper_bound": "53780"
+ },
+ {
+ "distinct_range": 493.4709975936828,
+ "num_eq": 2,
+ "num_range": 495,
+ "upper_bound": "54276"
+ },
+ {
+ "distinct_range": 557.0656774366242,
+ "num_eq": 2,
+ "num_range": 530,
+ "upper_bound": "54836"
+ },
+ {
+ "distinct_range": 550.1110524348004,
+ "num_eq": 2,
+ "num_range": 526,
+ "upper_bound": "55389"
+ },
+ {
+ "distinct_range": 467.6288233989265,
+ "num_eq": 2,
+ "num_range": 481,
+ "upper_bound": "55859"
+ },
+ {
+ "distinct_range": 444.76460754319976,
+ "num_eq": 2,
+ "num_range": 469,
+ "upper_bound": "56306"
+ },
+ {
+ "distinct_range": 416.9244994818031,
+ "num_eq": 2,
+ "num_range": 455,
+ "upper_bound": "56725"
+ },
+ {
+ "distinct_range": 539.1818690872329,
+ "num_eq": 2,
+ "num_range": 520,
+ "upper_bound": "57267"
+ },
+ {
+ "distinct_range": 381.1201693399544,
+ "num_eq": 2,
+ "num_range": 438,
+ "upper_bound": "57650"
+ },
+ {
+ "distinct_range": 391.06702538829563,
+ "num_eq": 2,
+ "num_range": 443,
+ "upper_bound": "58043"
+ },
+ {
+ "distinct_range": 484.5261213744859,
+ "num_eq": 2,
+ "num_range": 490,
+ "upper_bound": "58530"
+ },
+ {
+ "distinct_range": 568.9873520181503,
+ "num_eq": 2,
+ "num_range": 537,
+ "upper_bound": "59102"
+ },
+ {
+ "distinct_range": 446.7529525909505,
+ "num_eq": 2,
+ "num_range": 470,
+ "upper_bound": "59551"
+ },
+ {
+ "distinct_range": 477.5686404002772,
+ "num_eq": 2,
+ "num_range": 486,
+ "upper_bound": "60031"
+ },
+ {
+ "distinct_range": 492.4771473022347,
+ "num_eq": 2,
+ "num_range": 494,
+ "upper_bound": "60526"
+ },
+ {
+ "distinct_range": 402.0074693585198,
+ "num_eq": 2,
+ "num_range": 448,
+ "upper_bound": "60930"
+ },
+ {
+ "distinct_range": 472.59881539272556,
+ "num_eq": 2,
+ "num_range": 484,
+ "upper_bound": "61405"
+ },
+ {
+ "distinct_range": 443.77042376302654,
+ "num_eq": 2,
+ "num_range": 469,
+ "upper_bound": "61851"
+ },
+ {
+ "distinct_range": 488.5016843648975,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "62342"
+ },
+ {
+ "distinct_range": 592.828762784178,
+ "num_eq": 2,
+ "num_range": 551,
+ "upper_bound": "62938"
+ },
+ {
+ "distinct_range": 523.2837650915294,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "63464"
+ },
+ {
+ "distinct_range": 476.57468859210314,
+ "num_eq": 2,
+ "num_range": 486,
+ "upper_bound": "63943"
+ },
+ {
+ "distinct_range": 567.9939045885251,
+ "num_eq": 2,
+ "num_range": 537,
+ "upper_bound": "64514"
+ },
+ {
+ "distinct_range": 561.0396436609839,
+ "num_eq": 2,
+ "num_range": 533,
+ "upper_bound": "65078"
+ },
+ {
+ "distinct_range": 570.9742332369044,
+ "num_eq": 2,
+ "num_range": 538,
+ "upper_bound": "65652"
+ },
+ {
+ "distinct_range": 523.2837650915294,
+ "num_eq": 2,
+ "num_range": 511,
+ "upper_bound": "66178"
+ },
+ {
+ "distinct_range": 671.2908220089689,
+ "num_eq": 2,
+ "num_range": 598,
+ "upper_bound": "66853"
+ },
+ {
+ "distinct_range": 378.1359204623677,
+ "num_eq": 2,
+ "num_range": 437,
+ "upper_bound": "67233"
+ },
+ {
+ "distinct_range": 487.50780306122624,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "67723"
+ },
+ {
+ "distinct_range": 499.4339715399705,
+ "num_eq": 2,
+ "num_range": 498,
+ "upper_bound": "68225"
+ },
+ {
+ "distinct_range": 426.86811790582664,
+ "num_eq": 2,
+ "num_range": 460,
+ "upper_bound": "68654"
+ },
+ {
+ "distinct_range": 471.6048304639536,
+ "num_eq": 2,
+ "num_range": 483,
+ "upper_bound": "69128"
+ },
+ {
+ "distinct_range": 537.1946792451545,
+ "num_eq": 2,
+ "num_range": 519,
+ "upper_bound": "69668"
+ },
+ {
+ "distinct_range": 587.8620072533073,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "70259"
+ },
+ {
+ "distinct_range": 586.8686434830263,
+ "num_eq": 2,
+ "num_range": 548,
+ "upper_bound": "70849"
+ },
+ {
+ "distinct_range": 516.3279122104744,
+ "num_eq": 2,
+ "num_range": 507,
+ "upper_bound": "71368"
+ },
+ {
+ "distinct_range": 496.45251180512935,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "71867"
+ },
+ {
+ "distinct_range": 506.3905027413245,
+ "num_eq": 2,
+ "num_range": 502,
+ "upper_bound": "72376"
+ },
+ {
+ "distinct_range": 458.6824057351469,
+ "num_eq": 2,
+ "num_range": 476,
+ "upper_bound": "72837"
+ },
+ {
+ "distinct_range": 483.53221480073677,
+ "num_eq": 2,
+ "num_range": 489,
+ "upper_bound": "73323"
+ },
+ {
+ "distinct_range": 613.6880206201027,
+ "num_eq": 2,
+ "num_range": 564,
+ "upper_bound": "73940"
+ },
+ {
+ "distinct_range": 503.4091675796326,
+ "num_eq": 2,
+ "num_range": 500,
+ "upper_bound": "74446"
+ },
+ {
+ "distinct_range": 504.4029518196022,
+ "num_eq": 2,
+ "num_range": 501,
+ "upper_bound": "74953"
+ },
+ {
+ "distinct_range": 499.46495032130446,
+ "num_eq": 2,
+ "num_range": 503,
+ "upper_bound": "75455"
+ },
+ {
+ "distinct_range": 412.9719811366543,
+ "num_eq": 2,
+ "num_range": 458,
+ "upper_bound": "75870"
+ },
+ {
+ "distinct_range": 524.3099060578977,
+ "num_eq": 2,
+ "num_range": 516,
+ "upper_bound": "76397"
+ },
+ {
+ "distinct_range": 516.3599129142872,
+ "num_eq": 2,
+ "num_range": 512,
+ "upper_bound": "76916"
+ },
+ {
+ "distinct_range": 426.89428742240557,
+ "num_eq": 2,
+ "num_range": 465,
+ "upper_bound": "77345"
+ },
+ {
+ "distinct_range": 465.6696055718568,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "77813"
+ },
+ {
+ "distinct_range": 534.2469010535539,
+ "num_eq": 2,
+ "num_range": 522,
+ "upper_bound": "78350"
+ },
+ {
+ "distinct_range": 464.6755075363981,
+ "num_eq": 2,
+ "num_range": 484,
+ "upper_bound": "78817"
+ },
+ {
+ "distinct_range": 504.43423481911987,
+ "num_eq": 2,
+ "num_range": 505,
+ "upper_bound": "79324"
+ },
+ {
+ "distinct_range": 433.8548272354576,
+ "num_eq": 2,
+ "num_range": 469,
+ "upper_bound": "79760"
+ },
+ {
+ "distinct_range": 596.8385106662861,
+ "num_eq": 2,
+ "num_range": 558,
+ "upper_bound": "80360"
+ },
+ {
+ "distinct_range": 575.9766981396383,
+ "num_eq": 2,
+ "num_range": 546,
+ "upper_bound": "80939"
+ },
+ {
+ "distinct_range": 479.5862550972897,
+ "num_eq": 2,
+ "num_range": 492,
+ "upper_bound": "81421"
+ },
+ {
+ "distinct_range": 587.8979692788479,
+ "num_eq": 2,
+ "num_range": 552,
+ "upper_bound": "82012"
+ },
+ {
+ "distinct_range": 520.3349544207463,
+ "num_eq": 2,
+ "num_range": 514,
+ "upper_bound": "82535"
+ },
+ {
+ "distinct_range": 472.6280971814127,
+ "num_eq": 2,
+ "num_range": 488,
+ "upper_bound": "83010"
+ },
+ {
+ "distinct_range": 440.814974206058,
+ "num_eq": 2,
+ "num_range": 472,
+ "upper_bound": "83453"
+ },
+ {
+ "distinct_range": 583.9242830922204,
+ "num_eq": 2,
+ "num_range": 550,
+ "upper_bound": "84040"
+ },
+ {
+ "distinct_range": 534.2469010535539,
+ "num_eq": 2,
+ "num_range": 522,
+ "upper_bound": "84577"
+ },
+ {
+ "distinct_range": 574.9832297712766,
+ "num_eq": 2,
+ "num_range": 545,
+ "upper_bound": "85155"
+ },
+ {
+ "distinct_range": 604.7853723828268,
+ "num_eq": 2,
+ "num_range": 562,
+ "upper_bound": "85763"
+ },
+ {
+ "distinct_range": 489.5259204551515,
+ "num_eq": 2,
+ "num_range": 497,
+ "upper_bound": "86255"
+ },
+ {
+ "distinct_range": 486.54408874699163,
+ "num_eq": 2,
+ "num_range": 496,
+ "upper_bound": "86744"
+ },
+ {
+ "distinct_range": 491.51377644822685,
+ "num_eq": 2,
+ "num_range": 498,
+ "upper_bound": "87238"
+ },
+ {
+ "distinct_range": 394.0746507655383,
+ "num_eq": 2,
+ "num_range": 449,
+ "upper_bound": "87634"
+ },
+ {
+ "distinct_range": 519.3412025244354,
+ "num_eq": 2,
+ "num_range": 514,
+ "upper_bound": "88156"
+ },
+ {
+ "distinct_range": 576.9701619693724,
+ "num_eq": 2,
+ "num_range": 546,
+ "upper_bound": "88736"
+ },
+ {
+ "distinct_range": 566.0418074160382,
+ "num_eq": 2,
+ "num_range": 540,
+ "upper_bound": "89305"
+ },
+ {
+ "distinct_range": 460.6990447227398,
+ "num_eq": 2,
+ "num_range": 482,
+ "upper_bound": "89768"
+ },
+ {
+ "distinct_range": 473.62213994753523,
+ "num_eq": 2,
+ "num_range": 489,
+ "upper_bound": "90244"
+ },
+ {
+ "distinct_range": 492.5076949778728,
+ "num_eq": 2,
+ "num_range": 499,
+ "upper_bound": "90739"
+ },
+ {
+ "distinct_range": 466.6636965984758,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "91208"
+ },
+ {
+ "distinct_range": 562.0677202043842,
+ "num_eq": 2,
+ "num_range": 538,
+ "upper_bound": "91773"
+ },
+ {
+ "distinct_range": 563.0612491349586,
+ "num_eq": 2,
+ "num_range": 538,
+ "upper_bound": "92339"
+ },
+ {
+ "distinct_range": 539.2151977772662,
+ "num_eq": 2,
+ "num_range": 525,
+ "upper_bound": "92881"
+ },
+ {
+ "distinct_range": 558.0935564866534,
+ "num_eq": 2,
+ "num_range": 535,
+ "upper_bound": "93442"
+ },
+ {
+ "distinct_range": 466.6636965984758,
+ "num_eq": 2,
+ "num_range": 485,
+ "upper_bound": "93911"
+ },
+ {
+ "distinct_range": 453.7399581447198,
+ "num_eq": 2,
+ "num_range": 479,
+ "upper_bound": "94367"
+ },
+ {
+ "distinct_range": 489.5259204551515,
+ "num_eq": 2,
+ "num_range": 497,
+ "upper_bound": "94859"
+ },
+ {
+ "distinct_range": 546.1705945951596,
+ "num_eq": 2,
+ "num_range": 529,
+ "upper_bound": "95408"
+ },
+ {
+ "distinct_range": 437.8321014316712,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "95848"
+ },
+ {
+ "distinct_range": 548.1578048175314,
+ "num_eq": 2,
+ "num_range": 530,
+ "upper_bound": "96399"
+ },
+ {
+ "distinct_range": 438.8264001933669,
+ "num_eq": 2,
+ "num_range": 471,
+ "upper_bound": "96840"
+ },
+ {
+ "distinct_range": 559.0871046515288,
+ "num_eq": 2,
+ "num_range": 536,
+ "upper_bound": "97402"
+ },
+ {
+ "distinct_range": 499.46495032130446,
+ "num_eq": 2,
+ "num_range": 503,
+ "upper_bound": "97904"
+ },
+ {
+ "distinct_range": 583.9242830922204,
+ "num_eq": 2,
+ "num_range": 550,
+ "upper_bound": "98491"
+ },
+ {
+ "distinct_range": 545.1769818739565,
+ "num_eq": 2,
+ "num_range": 528,
+ "upper_bound": "99039"
+ },
+ {
+ "distinct_range": 496.48330657385566,
+ "num_eq": 2,
+ "num_range": 501,
+ "upper_bound": "99538"
+ },
+ {
+ "distinct_range": 439.82069110709904,
+ "num_eq": 2,
+ "num_range": 472,
+ "upper_bound": "99980"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "i_im_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.845057",
+ "distinct_count": 9918,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 9916,
+ "num_eq": 10,
+ "num_range": 99980,
+ "upper_bound": "10000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 22,
+ "columns": [
+ "i_name"
+ ],
+ "created_at": "2022-02-25 01:09:26.845057",
+ "distinct_count": 682,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 170,
+ "num_range": 0,
+ "upper_bound": "1U5yraPxxELo5B"
+ },
+ {
+ "distinct_range": 680,
+ "num_eq": 120,
+ "num_range": 99710,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "VARCHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "i_price"
+ ],
+ "created_at": "2022-02-25 01:09:26.845057",
+ "distinct_count": 9857,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "1.01"
+ },
+ {
+ "distinct_range": 9855,
+ "num_eq": 10,
+ "num_range": 99980,
+ "upper_bound": "1E+2"
+ }
+ ],
+ "histo_col_type": "DECIMAL(5,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ },
+ {
+ "avg_size": 41,
+ "columns": [
+ "i_data"
+ ],
+ "created_at": "2022-02-25 01:09:26.845057",
+ "distinct_count": 11682,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 10,
+ "num_range": 0,
+ "upper_bound": "0YhORIGINALgLRrwsmd68P2bElAgrnp8ueWN"
+ },
+ {
+ "distinct_range": 11680,
+ "num_eq": 10,
+ "num_range": 99980,
+ "upper_bound": "zmssaORIGINALF9m9cdLXe0YhgLRrwsmd68P2bElAgrnp8u"
+ }
+ ],
+ "histo_col_type": "VARCHAR(50)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 100000
+ }
+]';
+----
+
+exec-ddl
+ALTER TABLE "new_order" INJECT STATISTICS '[
+ {
+ "avg_size": 1,
+ "columns": [
+ "no_w_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.297265",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 8874,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9018,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9234,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8676,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9135,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9072,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9225,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9162,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8604,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9000,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "no_d_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.297265",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 9216,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8919,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8964,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8703,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9099,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9054,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9000,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8865,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9135,
+ "num_range": 0,
+ "upper_bound": "9"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9045,
+ "num_range": 0,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "no_w_id",
+ "no_d_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.297265",
+ "distinct_count": 100,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "no_o_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.297265",
+ "distinct_count": 900,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 126,
+ "num_range": 0,
+ "upper_bound": "2101"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 405,
+ "upper_bound": "2106"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 378,
+ "upper_bound": "2111"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 342,
+ "upper_bound": "2115"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 405,
+ "upper_bound": "2120"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 333,
+ "upper_bound": "2125"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 441,
+ "upper_bound": "2131"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 432,
+ "upper_bound": "2135"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 306,
+ "upper_bound": "2140"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 369,
+ "upper_bound": "2145"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 414,
+ "upper_bound": "2150"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 414,
+ "upper_bound": "2155"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 369,
+ "upper_bound": "2160"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 360,
+ "upper_bound": "2165"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 414,
+ "upper_bound": "2170"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 369,
+ "upper_bound": "2175"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 342,
+ "upper_bound": "2179"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 387,
+ "upper_bound": "2183"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 324,
+ "upper_bound": "2188"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 333,
+ "upper_bound": "2193"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 63,
+ "num_range": 396,
+ "upper_bound": "2199"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 108,
+ "num_range": 414,
+ "upper_bound": "2205"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 369,
+ "upper_bound": "2209"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 378,
+ "upper_bound": "2214"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 432,
+ "upper_bound": "2219"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 423,
+ "upper_bound": "2224"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 414,
+ "upper_bound": "2229"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 342,
+ "upper_bound": "2233"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 432,
+ "upper_bound": "2238"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 99,
+ "num_range": 414,
+ "upper_bound": "2244"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 90,
+ "num_range": 414,
+ "upper_bound": "2250"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 432,
+ "upper_bound": "2255"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 342,
+ "upper_bound": "2260"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 369,
+ "upper_bound": "2264"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 432,
+ "upper_bound": "2269"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 153,
+ "num_range": 432,
+ "upper_bound": "2275"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 342,
+ "upper_bound": "2280"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 423,
+ "upper_bound": "2285"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 54,
+ "num_range": 405,
+ "upper_bound": "2291"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 432,
+ "upper_bound": "2296"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 378,
+ "upper_bound": "2301"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 405,
+ "upper_bound": "2307"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 342,
+ "upper_bound": "2311"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 369,
+ "upper_bound": "2316"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 405,
+ "upper_bound": "2321"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 162,
+ "num_range": 378,
+ "upper_bound": "2325"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 396,
+ "upper_bound": "2330"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 369,
+ "upper_bound": "2334"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 144,
+ "num_range": 297,
+ "upper_bound": "2337"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 360,
+ "upper_bound": "2341"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2346"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 360,
+ "upper_bound": "2350"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 387,
+ "upper_bound": "2355"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 414,
+ "upper_bound": "2360"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 342,
+ "upper_bound": "2364"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 315,
+ "upper_bound": "2368"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 126,
+ "num_range": 414,
+ "upper_bound": "2374"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 72,
+ "num_range": 396,
+ "upper_bound": "2378"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 126,
+ "num_range": 414,
+ "upper_bound": "2384"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 405,
+ "upper_bound": "2389"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 126,
+ "num_range": 423,
+ "upper_bound": "2395"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 387,
+ "upper_bound": "2400"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 351,
+ "upper_bound": "2405"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 378,
+ "upper_bound": "2410"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 162,
+ "num_range": 405,
+ "upper_bound": "2415"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 414,
+ "upper_bound": "2420"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 351,
+ "upper_bound": "2424"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 414,
+ "upper_bound": "2429"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 45,
+ "num_range": 387,
+ "upper_bound": "2434"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 315,
+ "upper_bound": "2438"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 369,
+ "upper_bound": "2443"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 351,
+ "upper_bound": "2447"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 63,
+ "num_range": 387,
+ "upper_bound": "2453"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 162,
+ "num_range": 414,
+ "upper_bound": "2458"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 360,
+ "upper_bound": "2462"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 387,
+ "upper_bound": "2468"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 396,
+ "upper_bound": "2473"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 369,
+ "upper_bound": "2478"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 378,
+ "upper_bound": "2483"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 414,
+ "upper_bound": "2489"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 378,
+ "upper_bound": "2493"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 306,
+ "upper_bound": "2497"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 324,
+ "upper_bound": "2501"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 369,
+ "upper_bound": "2505"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 306,
+ "upper_bound": "2509"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 306,
+ "upper_bound": "2513"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 306,
+ "upper_bound": "2517"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 396,
+ "upper_bound": "2522"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 369,
+ "upper_bound": "2527"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 378,
+ "upper_bound": "2532"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 315,
+ "upper_bound": "2536"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 387,
+ "upper_bound": "2541"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 360,
+ "upper_bound": "2545"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 378,
+ "upper_bound": "2550"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 387,
+ "upper_bound": "2555"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 333,
+ "upper_bound": "2560"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 387,
+ "upper_bound": "2565"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 324,
+ "upper_bound": "2569"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 369,
+ "upper_bound": "2574"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 351,
+ "upper_bound": "2578"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 342,
+ "upper_bound": "2582"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 342,
+ "upper_bound": "2586"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 342,
+ "upper_bound": "2590"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 360,
+ "upper_bound": "2595"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 378,
+ "upper_bound": "2600"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 387,
+ "upper_bound": "2604"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 54,
+ "num_range": 396,
+ "upper_bound": "2610"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 324,
+ "upper_bound": "2614"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 342,
+ "upper_bound": "2619"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 387,
+ "upper_bound": "2624"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 81,
+ "num_range": 333,
+ "upper_bound": "2630"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 189,
+ "num_range": 342,
+ "upper_bound": "2634"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 396,
+ "upper_bound": "2638"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 360,
+ "upper_bound": "2643"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 378,
+ "upper_bound": "2648"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 351,
+ "upper_bound": "2653"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 396,
+ "upper_bound": "2658"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 279,
+ "upper_bound": "2662"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 342,
+ "upper_bound": "2668"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 135,
+ "num_range": 369,
+ "upper_bound": "2674"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 342,
+ "upper_bound": "2679"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 342,
+ "upper_bound": "2684"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 360,
+ "upper_bound": "2688"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 360,
+ "upper_bound": "2693"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 342,
+ "upper_bound": "2697"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 360,
+ "upper_bound": "2702"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 306,
+ "upper_bound": "2706"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 378,
+ "upper_bound": "2711"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 279,
+ "upper_bound": "2715"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 369,
+ "upper_bound": "2719"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 360,
+ "upper_bound": "2724"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 333,
+ "upper_bound": "2728"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 108,
+ "num_range": 360,
+ "upper_bound": "2734"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 351,
+ "upper_bound": "2739"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 63,
+ "num_range": 360,
+ "upper_bound": "2743"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 162,
+ "num_range": 270,
+ "upper_bound": "2748"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 351,
+ "upper_bound": "2752"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 315,
+ "upper_bound": "2756"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 342,
+ "upper_bound": "2761"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 378,
+ "upper_bound": "2766"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 288,
+ "upper_bound": "2770"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 333,
+ "upper_bound": "2775"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 324,
+ "upper_bound": "2780"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 297,
+ "upper_bound": "2784"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 351,
+ "upper_bound": "2789"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 324,
+ "upper_bound": "2794"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 369,
+ "upper_bound": "2799"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 306,
+ "upper_bound": "2803"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 324,
+ "upper_bound": "2807"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 369,
+ "upper_bound": "2812"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 306,
+ "upper_bound": "2816"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 261,
+ "upper_bound": "2820"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 297,
+ "upper_bound": "2825"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 288,
+ "upper_bound": "2829"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 306,
+ "upper_bound": "2833"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 360,
+ "upper_bound": "2837"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 297,
+ "upper_bound": "2841"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 306,
+ "upper_bound": "2845"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 297,
+ "upper_bound": "2849"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 63,
+ "num_range": 351,
+ "upper_bound": "2853"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 279,
+ "upper_bound": "2857"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 333,
+ "upper_bound": "2862"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 234,
+ "upper_bound": "2866"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 270,
+ "upper_bound": "2871"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 306,
+ "upper_bound": "2875"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 342,
+ "upper_bound": "2880"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 270,
+ "upper_bound": "2884"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 315,
+ "upper_bound": "2888"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 297,
+ "upper_bound": "2892"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 261,
+ "upper_bound": "2896"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 315,
+ "upper_bound": "2900"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 315,
+ "upper_bound": "2904"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 279,
+ "upper_bound": "2908"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 162,
+ "num_range": 306,
+ "upper_bound": "2912"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 315,
+ "upper_bound": "2916"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 216,
+ "upper_bound": "2920"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 162,
+ "num_range": 297,
+ "upper_bound": "2924"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 261,
+ "upper_bound": "2928"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 270,
+ "upper_bound": "2931"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 297,
+ "upper_bound": "2935"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 315,
+ "upper_bound": "2939"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 54,
+ "num_range": 306,
+ "upper_bound": "2943"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 207,
+ "upper_bound": "2947"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 315,
+ "upper_bound": "2951"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 162,
+ "num_range": 180,
+ "upper_bound": "2954"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 117,
+ "num_range": 234,
+ "upper_bound": "2957"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 90,
+ "num_range": 252,
+ "upper_bound": "2960"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 180,
+ "num_range": 252,
+ "upper_bound": "2964"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 180,
+ "num_range": 270,
+ "upper_bound": "2967"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 207,
+ "upper_bound": "2970"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 216,
+ "upper_bound": "2973"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 117,
+ "num_range": 225,
+ "upper_bound": "2976"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 135,
+ "num_range": 198,
+ "upper_bound": "2979"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 81,
+ "num_range": 225,
+ "upper_bound": "2982"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 270,
+ "upper_bound": "2986"
+ },
+ {
+ "distinct_range": 1,
+ "num_eq": 126,
+ "num_range": 153,
+ "upper_bound": "2988"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 207,
+ "upper_bound": "2991"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 252,
+ "upper_bound": "2995"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 180,
+ "upper_bound": "2998"
+ },
+ {
+ "distinct_range": 1,
+ "num_eq": 126,
+ "num_range": 108,
+ "upper_bound": "3000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "no_w_id",
+ "no_d_id",
+ "no_o_id"
+ ],
+ "created_at": "2022-02-25 01:08:06.297265",
+ "distinct_count": 90000,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "no_w_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.394826",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 9171,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9198,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8919,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8586,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8712,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9414,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8694,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9495,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9378,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8433,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "no_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.394826",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 8622,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8928,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8883,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9279,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8946,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9315,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9171,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9063,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 8613,
+ "num_range": 0,
+ "upper_bound": "9"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 9180,
+ "num_range": 0,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "no_w_id",
+ "no_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.394826",
+ "distinct_count": 100,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "no_o_id"
+ ],
+ "created_at": "2022-02-25 01:09:26.394826",
+ "distinct_count": 900,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 90,
+ "num_range": 0,
+ "upper_bound": "2101"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 351,
+ "upper_bound": "2106"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 324,
+ "upper_bound": "2110"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 351,
+ "upper_bound": "2115"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2121"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 63,
+ "num_range": 432,
+ "upper_bound": "2127"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 387,
+ "upper_bound": "2132"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2137"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 333,
+ "upper_bound": "2142"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 387,
+ "upper_bound": "2146"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 369,
+ "upper_bound": "2150"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 414,
+ "upper_bound": "2155"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 396,
+ "upper_bound": "2160"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 369,
+ "upper_bound": "2164"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 90,
+ "num_range": 423,
+ "upper_bound": "2170"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 342,
+ "upper_bound": "2175"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 378,
+ "upper_bound": "2179"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 432,
+ "upper_bound": "2184"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 378,
+ "upper_bound": "2189"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 369,
+ "upper_bound": "2194"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 144,
+ "num_range": 432,
+ "upper_bound": "2200"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 414,
+ "upper_bound": "2205"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 72,
+ "num_range": 423,
+ "upper_bound": "2211"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 387,
+ "upper_bound": "2216"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 423,
+ "upper_bound": "2221"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 378,
+ "upper_bound": "2226"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 432,
+ "upper_bound": "2231"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 405,
+ "upper_bound": "2236"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 423,
+ "upper_bound": "2242"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 189,
+ "num_range": 270,
+ "upper_bound": "2246"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 45,
+ "num_range": 405,
+ "upper_bound": "2251"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 99,
+ "num_range": 432,
+ "upper_bound": "2257"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 324,
+ "upper_bound": "2262"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 405,
+ "upper_bound": "2266"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 378,
+ "upper_bound": "2271"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 396,
+ "upper_bound": "2276"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 369,
+ "upper_bound": "2280"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 360,
+ "upper_bound": "2284"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 378,
+ "upper_bound": "2289"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 351,
+ "upper_bound": "2293"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 423,
+ "upper_bound": "2298"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 351,
+ "upper_bound": "2302"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 369,
+ "upper_bound": "2307"
+ },
+ {
+ "distinct_range": 6,
+ "num_eq": 108,
+ "num_range": 396,
+ "upper_bound": "2314"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 360,
+ "upper_bound": "2318"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 396,
+ "upper_bound": "2323"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2328"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 333,
+ "upper_bound": "2332"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 414,
+ "upper_bound": "2337"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 396,
+ "upper_bound": "2342"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 423,
+ "upper_bound": "2347"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 414,
+ "upper_bound": "2352"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 162,
+ "num_range": 333,
+ "upper_bound": "2357"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 342,
+ "upper_bound": "2361"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 315,
+ "upper_bound": "2365"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 396,
+ "upper_bound": "2370"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 144,
+ "num_range": 378,
+ "upper_bound": "2376"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 63,
+ "num_range": 414,
+ "upper_bound": "2382"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 378,
+ "upper_bound": "2387"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 396,
+ "upper_bound": "2392"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 324,
+ "upper_bound": "2397"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 297,
+ "upper_bound": "2401"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 360,
+ "upper_bound": "2406"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 162,
+ "num_range": 333,
+ "upper_bound": "2411"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 369,
+ "upper_bound": "2416"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 423,
+ "upper_bound": "2421"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 99,
+ "num_range": 414,
+ "upper_bound": "2427"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 315,
+ "upper_bound": "2431"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 414,
+ "upper_bound": "2436"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 315,
+ "upper_bound": "2441"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2446"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 279,
+ "upper_bound": "2450"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 378,
+ "upper_bound": "2455"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 360,
+ "upper_bound": "2460"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 423,
+ "upper_bound": "2465"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 396,
+ "upper_bound": "2470"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 360,
+ "upper_bound": "2475"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 351,
+ "upper_bound": "2480"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 270,
+ "upper_bound": "2484"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 414,
+ "upper_bound": "2489"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 360,
+ "upper_bound": "2493"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 306,
+ "upper_bound": "2497"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 297,
+ "upper_bound": "2501"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 369,
+ "upper_bound": "2506"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 72,
+ "num_range": 360,
+ "upper_bound": "2510"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 351,
+ "upper_bound": "2515"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 288,
+ "upper_bound": "2519"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 315,
+ "upper_bound": "2524"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 405,
+ "upper_bound": "2529"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 342,
+ "upper_bound": "2533"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 396,
+ "upper_bound": "2538"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 396,
+ "upper_bound": "2543"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 342,
+ "upper_bound": "2547"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 351,
+ "upper_bound": "2551"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 99,
+ "num_range": 405,
+ "upper_bound": "2557"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 414,
+ "upper_bound": "2561"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 369,
+ "upper_bound": "2565"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 414,
+ "upper_bound": "2569"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 396,
+ "upper_bound": "2574"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 333,
+ "upper_bound": "2578"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 297,
+ "upper_bound": "2582"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 333,
+ "upper_bound": "2586"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 378,
+ "upper_bound": "2591"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2595"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 333,
+ "upper_bound": "2600"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 333,
+ "upper_bound": "2605"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 297,
+ "upper_bound": "2609"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 342,
+ "upper_bound": "2613"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 342,
+ "upper_bound": "2618"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 342,
+ "upper_bound": "2622"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 351,
+ "upper_bound": "2627"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 405,
+ "upper_bound": "2632"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 396,
+ "upper_bound": "2637"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 153,
+ "num_range": 369,
+ "upper_bound": "2642"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 315,
+ "upper_bound": "2646"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 144,
+ "num_range": 279,
+ "upper_bound": "2649"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 306,
+ "upper_bound": "2653"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 333,
+ "upper_bound": "2657"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 171,
+ "num_range": 252,
+ "upper_bound": "2661"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 279,
+ "upper_bound": "2665"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 306,
+ "upper_bound": "2669"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 297,
+ "upper_bound": "2673"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 45,
+ "num_range": 387,
+ "upper_bound": "2677"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 279,
+ "upper_bound": "2681"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 369,
+ "upper_bound": "2686"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 387,
+ "upper_bound": "2690"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 342,
+ "upper_bound": "2694"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 315,
+ "upper_bound": "2698"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 369,
+ "upper_bound": "2703"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 360,
+ "upper_bound": "2708"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 387,
+ "upper_bound": "2714"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 342,
+ "upper_bound": "2718"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 81,
+ "num_range": 351,
+ "upper_bound": "2723"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 360,
+ "upper_bound": "2728"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 99,
+ "num_range": 351,
+ "upper_bound": "2733"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 369,
+ "upper_bound": "2737"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 306,
+ "upper_bound": "2741"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 378,
+ "upper_bound": "2746"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 324,
+ "upper_bound": "2750"
+ },
+ {
+ "distinct_range": 5,
+ "num_eq": 117,
+ "num_range": 387,
+ "upper_bound": "2756"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 369,
+ "upper_bound": "2761"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 342,
+ "upper_bound": "2766"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 90,
+ "num_range": 324,
+ "upper_bound": "2770"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 369,
+ "upper_bound": "2775"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 306,
+ "upper_bound": "2779"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 351,
+ "upper_bound": "2784"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 324,
+ "upper_bound": "2788"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 306,
+ "upper_bound": "2792"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 90,
+ "num_range": 360,
+ "upper_bound": "2797"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 117,
+ "num_range": 333,
+ "upper_bound": "2802"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 315,
+ "upper_bound": "2807"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 288,
+ "upper_bound": "2811"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 279,
+ "upper_bound": "2815"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 333,
+ "upper_bound": "2820"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 288,
+ "upper_bound": "2823"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 117,
+ "num_range": 279,
+ "upper_bound": "2827"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 63,
+ "num_range": 369,
+ "upper_bound": "2831"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 279,
+ "upper_bound": "2835"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 72,
+ "num_range": 342,
+ "upper_bound": "2840"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 135,
+ "num_range": 333,
+ "upper_bound": "2845"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 180,
+ "num_range": 252,
+ "upper_bound": "2849"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 171,
+ "num_range": 315,
+ "upper_bound": "2854"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 45,
+ "num_range": 333,
+ "upper_bound": "2858"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 153,
+ "num_range": 270,
+ "upper_bound": "2861"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 288,
+ "upper_bound": "2866"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 54,
+ "num_range": 342,
+ "upper_bound": "2871"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 72,
+ "num_range": 342,
+ "upper_bound": "2875"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 342,
+ "upper_bound": "2879"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 126,
+ "num_range": 243,
+ "upper_bound": "2883"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 351,
+ "upper_bound": "2887"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 81,
+ "num_range": 297,
+ "upper_bound": "2890"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 126,
+ "num_range": 270,
+ "upper_bound": "2893"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 324,
+ "upper_bound": "2897"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 144,
+ "num_range": 270,
+ "upper_bound": "2901"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 270,
+ "upper_bound": "2905"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 144,
+ "num_range": 360,
+ "upper_bound": "2910"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 54,
+ "num_range": 324,
+ "upper_bound": "2914"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 333,
+ "upper_bound": "2919"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 306,
+ "upper_bound": "2923"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 342,
+ "upper_bound": "2927"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 81,
+ "num_range": 315,
+ "upper_bound": "2931"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 108,
+ "num_range": 315,
+ "upper_bound": "2936"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 126,
+ "num_range": 234,
+ "upper_bound": "2939"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 117,
+ "num_range": 297,
+ "upper_bound": "2942"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 54,
+ "num_range": 279,
+ "upper_bound": "2946"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 126,
+ "num_range": 270,
+ "upper_bound": "2951"
+ },
+ {
+ "distinct_range": 4,
+ "num_eq": 63,
+ "num_range": 306,
+ "upper_bound": "2956"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 171,
+ "num_range": 189,
+ "upper_bound": "2959"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 288,
+ "upper_bound": "2963"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 99,
+ "num_range": 279,
+ "upper_bound": "2967"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 108,
+ "num_range": 243,
+ "upper_bound": "2971"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 288,
+ "upper_bound": "2974"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 108,
+ "num_range": 225,
+ "upper_bound": "2977"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 54,
+ "num_range": 261,
+ "upper_bound": "2981"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 153,
+ "num_range": 297,
+ "upper_bound": "2985"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 99,
+ "num_range": 234,
+ "upper_bound": "2988"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 180,
+ "num_range": 216,
+ "upper_bound": "2992"
+ },
+ {
+ "distinct_range": 3,
+ "num_eq": 135,
+ "num_range": 171,
+ "upper_bound": "2996"
+ },
+ {
+ "distinct_range": 2,
+ "num_eq": 90,
+ "num_range": 144,
+ "upper_bound": "2999"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 126,
+ "num_range": 0,
+ "upper_bound": "3000"
}
],
- "histo_col_type": "VARCHAR(20)",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 100
+ "row_count": 90000
},
{
+ "avg_size": 5,
"columns": [
- "d_state"
+ "no_w_id",
+ "no_d_id",
+ "no_o_id"
],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 25,
+ "created_at": "2022-02-25 01:09:26.394826",
+ "distinct_count": 90000,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 90000
+ }
+]';
+----
+
+exec-ddl
+ALTER TABLE "order" INJECT STATISTICS '[
+ {
+ "avg_size": 1,
+ "columns": [
+ "o_w_id"
+ ],
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 28920,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29880,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29910,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29820,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30270,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30510,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30060,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29220,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 31680,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29730,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "o_d_id"
+ ],
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 29700,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29820,
+ "num_range": 0,
+ "upper_bound": "2"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29430,
+ "num_range": 0,
+ "upper_bound": "3"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30390,
+ "num_range": 0,
+ "upper_bound": "4"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 31410,
+ "num_range": 0,
+ "upper_bound": "5"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29460,
+ "num_range": 0,
+ "upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30180,
+ "num_range": 0,
+ "upper_bound": "7"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29250,
+ "num_range": 0,
+ "upper_bound": "8"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 29880,
+ "num_range": 0,
+ "upper_bound": "9"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 30480,
+ "num_range": 0,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "o_w_id",
+ "o_d_id"
+ ],
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 100,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "o_id"
+ ],
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 2999,
"histo_buckets": [
{
- "distinct_range": 0,
- "num_eq": 1,
- "num_range": 0,
- "upper_bound": "AK"
+ "distinct_range": 0,
+ "num_eq": 150,
+ "num_range": 0,
+ "upper_bound": "1"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "18"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "31"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "44"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "57"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 240,
+ "num_range": 1440,
+ "upper_bound": "72"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "89"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "102"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "121"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "134"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1470,
+ "upper_bound": "149"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "164"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "181"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "199"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 30,
+ "num_range": 1470,
+ "upper_bound": "217"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "234"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "250"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "267"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "283"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "299"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "315"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "332"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "347"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "366"
+ },
+ {
+ "distinct_range": 19.992857142857144,
+ "num_eq": 210,
+ "num_range": 1470,
+ "upper_bound": "387"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "404"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "419"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "433"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "445"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "459"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "472"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "487"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "503"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "519"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "535"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "550"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "564"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "583"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "599"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "611"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "627"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "640"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "654"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "670"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "681"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "695"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "712"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "725"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "737"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "750"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 240,
+ "num_range": 1380,
+ "upper_bound": "765"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "778"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "792"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "809"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "825"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "840"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "860"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "873"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "887"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "902"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "915"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "928"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "948"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "962"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "976"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "991"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1008"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1024"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1041"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1056"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1069"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1085"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1101"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1116"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1129"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1143"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1158"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1174"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1187"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1203"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1216"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1228"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1245"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1259"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1273"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1289"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1306"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1323"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1339"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1354"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1370"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1386"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1401"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1417"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "1430"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1447"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1463"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1477"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "1493"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1506"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1518"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1532"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1548"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1566"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1579"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1594"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1607"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1622"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1634"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1649"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1662"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1677"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1694"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1707"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1724"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1741"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1755"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1773"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1788"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1808"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1822"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1838"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1852"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1869"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1885"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1902"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1918"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1931"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1945"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1958"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1973"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1989"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2002"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2015"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "2031"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2048"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2063"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2081"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2094"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2112"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2127"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "2144"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2159"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "2178"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "2193"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2207"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2222"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2239"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2255"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2268"
},
{
- "distinct_range": 23,
- "num_eq": 4,
- "num_range": 95,
- "upper_bound": "ZT"
- }
- ],
- "histo_col_type": "CHAR(2)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_zip"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 10,
- "histo_buckets": [
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "2285"
+ },
{
- "distinct_range": 0,
- "num_eq": 15,
- "num_range": 0,
- "upper_bound": "022311111"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2303"
},
{
- "distinct_range": 8,
- "num_eq": 8,
- "num_range": 77,
- "upper_bound": "902211111"
- }
- ],
- "histo_col_type": "CHAR(9)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_tax"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 98,
- "histo_buckets": [
+ "distinct_range": 16.993928571428572,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "2321"
+ },
{
- "distinct_range": 0,
- "num_eq": 1,
- "num_range": 0,
- "upper_bound": "0.0021"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2337"
},
{
- "distinct_range": 96,
- "num_eq": 1,
- "num_range": 98,
- "upper_bound": "0.1962"
- }
- ],
- "histo_col_type": "DECIMAL(4,4)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_ytd"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 1,
- "histo_buckets": [
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2354"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2369"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2385"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2399"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2415"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2430"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2445"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2463"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2476"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2487"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2500"
+ },
+ {
+ "distinct_range": 8.996785714285714,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2510"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "2524"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "2536"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2552"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1350,
+ "upper_bound": "2566"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2579"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "2595"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2610"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2626"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2639"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2650"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2668"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2684"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2697"
+ },
+ {
+ "distinct_range": 9.996428571428572,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2708"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 270,
+ "num_range": 1320,
+ "upper_bound": "2721"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2739"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 30,
+ "num_range": 1380,
+ "upper_bound": "2756"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2773"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "2789"
+ },
{
- "distinct_range": 0,
- "num_eq": 100,
- "num_range": 0,
- "upper_bound": "3E+4"
- }
- ],
- "histo_col_type": "DECIMAL(12,2)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- },
- {
- "columns": [
- "d_next_o_id"
- ],
- "created_at": "2021-09-08 20:49:16.527128",
- "distinct_count": 1,
- "histo_buckets": [
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2805"
+ },
{
- "distinct_range": 0,
- "num_eq": 100,
- "num_range": 0,
- "upper_bound": "3001"
- }
- ],
- "histo_col_type": "INT8",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100
- }
-]';
-----
-
-exec-ddl
-ALTER TABLE "history" INJECT STATISTICS '[
- {
- "columns": [
- "h_w_id"
- ],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 10,
- "histo_buckets": [
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2820"
+ },
{
- "distinct_range": 0,
- "num_eq": 29580,
- "num_range": 0,
- "upper_bound": "0"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2832"
},
{
- "distinct_range": 0,
- "num_eq": 29010,
- "num_range": 0,
- "upper_bound": "1"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2849"
},
{
- "distinct_range": 0,
- "num_eq": 29820,
- "num_range": 0,
- "upper_bound": "2"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1350,
+ "upper_bound": "2862"
},
{
- "distinct_range": 0,
- "num_eq": 28770,
- "num_range": 0,
- "upper_bound": "3"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1200,
+ "upper_bound": "2875"
},
{
- "distinct_range": 0,
- "num_eq": 29610,
- "num_range": 0,
- "upper_bound": "4"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2890"
},
{
- "distinct_range": 0,
- "num_eq": 29760,
- "num_range": 0,
- "upper_bound": "5"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2906"
},
{
- "distinct_range": 0,
- "num_eq": 30330,
- "num_range": 0,
- "upper_bound": "6"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2921"
},
{
- "distinct_range": 0,
- "num_eq": 30750,
- "num_range": 0,
- "upper_bound": "7"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1260,
+ "upper_bound": "2936"
},
{
- "distinct_range": 0,
- "num_eq": 30360,
- "num_range": 0,
- "upper_bound": "8"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2947"
},
{
- "distinct_range": 0,
- "num_eq": 32010,
- "num_range": 0,
- "upper_bound": "9"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2960"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1200,
+ "upper_bound": "2974"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1140,
+ "upper_bound": "2987"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1230,
+ "upper_bound": "3000"
}
],
"histo_col_type": "INT8",
@@ -4662,4197 +19054,4161 @@ ALTER TABLE "history" INJECT STATISTICS '[
"row_count": 300000
},
{
+ "avg_size": 5,
"columns": [
- "rowid"
+ "o_w_id",
+ "o_d_id",
+ "o_id"
],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 299387,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 295745,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "o_c_id"
+ ],
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 2999,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 0,
- "num_range": 0,
- "upper_bound": "00000000-0000-0000-0000-000000000000"
- },
- {
- "distinct_range": 1.1641532182693481E-10,
- "num_eq": 4,
+ "num_eq": 150,
"num_range": 0,
- "upper_bound": "00006fd9-1d84-4cda-8000-000000000002"
- },
- {
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "016cd12b-47f3-4c30-8000-000000000686"
+ "upper_bound": "1"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "02c9e7ce-693d-49a0-8000-000000000cc4"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "15"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "041a1aec-a3bb-4400-8000-0000000012c7"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "33"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "054c6072-7834-45c0-8000-000000001841"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "49"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "068d80ce-384e-4cc0-8000-000000001dff"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "67"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "07f5f37e-5913-4880-8000-000000002471"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "81"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "09488dc6-b5ea-4180-8000-000000002a7f"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1470,
+ "upper_bound": "97"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "0a98c0e4-f068-4b80-8000-000000003082"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 30,
+ "num_range": 1470,
+ "upper_bound": "112"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "0bd15c36-f0e6-4000-8000-000000003619"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "125"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "0ceea907-3c7b-4900-8000-000000003b33"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "140"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "0e2f219d-504f-4480-8000-0000000040ee"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "155"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "0fb8c8c2-347b-4100-8000-0000000047f8"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "171"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "112aa02e-4fe6-4900-8000-000000004e95"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "186"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1298c0e4-f068-4c00-8000-000000005521"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 30,
+ "num_range": 1470,
+ "upper_bound": "204"
},
- {
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "13cbae30-7128-4900-8000-000000005a9e"
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "220"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "14d5c1af-a9ed-4c00-8000-000000005f60"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "236"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "16501e25-84f4-4700-8000-000000006624"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1470,
+ "upper_bound": "250"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1765c59e-4bf7-4700-8000-000000006b1b"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "264"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "18b5f8bc-8675-4100-8000-00000000711e"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1470,
+ "upper_bound": "280"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1a027525-460a-4600-8000-000000007710"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "300"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1b8c8c23-47bc-4000-8000-000000007e1c"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1470,
+ "upper_bound": "315"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1cd1d30d-a043-4900-8000-0000000083ed"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 180,
+ "num_range": 1470,
+ "upper_bound": "334"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1e2f9176-6dd3-4100-8000-000000008a2e"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1470,
+ "upper_bound": "351"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "1f63ce4d-4722-4500-8000-000000008fb1"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "366"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "20aad49c-15bc-4200-8000-00000000958a"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "382"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "21d7a407-f93a-4a00-8000-000000009aeb"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "398"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "23287eeb-dfff-4000-8000-00000000a0f1"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "410"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "24c83665-16db-4e00-8000-00000000a860"
+ "distinct_range": 19.992857142857144,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "431"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "26d5cfaa-cd9e-4400-8000-00000000b1c6"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "446"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2835bd51-2ec6-4c00-8000-00000000b811"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "463"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2988ff5f-37e5-4200-8000-00000000be22"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "479"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2adc7959-cfc6-4400-8000-00000000c434"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "493"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2bb256ff-c115-4000-8000-00000000c807"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "510"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2cd63188-c772-4a00-8000-00000000cd3f"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "525"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2e37de93-9ead-4600-8000-00000000d392"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "537"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "2f785729-b280-4200-8000-00000000d94d"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "552"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "307d2c7b-890d-4a00-8000-00000000ddf7"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "570"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "31dd1a21-ea35-4400-8000-00000000e442"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "586"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "33280f12-c27a-4400-8000-00000000ea2d"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "599"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "34832e64-deee-4000-8000-00000000f062"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "611"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "35ad26cd-828d-4c00-8000-00000000f5b6"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "626"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "373f8ae8-b519-4a00-8000-00000000fce8"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "643"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "38bf5d78-811b-4e00-8000-0000000103c5"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "658"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "39ecd4aa-10e0-4200-8000-000000010929"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "670"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "3b1d22de-e083-4200-8000-000000010e9a"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "685"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "3c5b6c37-60bf-4e00-8000-00000001144b"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "702"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "3d7928e0-c9d9-4400-8000-000000011967"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "719"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "3ed75722-b4ef-4800-8000-000000011faa"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "735"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "400e6afc-ce1c-4800-8000-00000001253a"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "748"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "41a02752-5460-4c00-8000-000000012c69"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1350,
+ "upper_bound": "764"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "42d005ae-067f-4c00-8000-0000000131d8"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "780"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "44392023-d38b-4400-8000-00000001384d"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "795"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "45306a2b-1705-4000-8000-000000013cb9"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "811"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "466d2c0b-afef-4400-8000-000000014263"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "829"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "47fd60e9-4ee3-4400-8000-00000001498b"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 300,
+ "num_range": 1410,
+ "upper_bound": "847"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "4902a614-42f4-4800-8000-000000014e37"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "861"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "4a26809d-4951-4400-8000-00000001536f"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "875"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "4b915a77-8c70-4c00-8000-0000000159ec"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "892"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "4ce3150d-ae3e-4c00-8000-000000015ff6"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "906"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "4e7aef42-d1c5-4400-8000-000000016741"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "923"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "4ffe08ae-fb2a-4000-8000-000000016e2d"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "937"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "5145b6c3-760b-4400-8000-000000017409"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "950"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "525dfd52-ee2b-4400-8000-00000001790c"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "970"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "53ba6c30-632d-4400-8000-000000017f47"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "985"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "553149dd-520e-4800-8000-0000000185fb"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "999"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "56944673-81d7-4c00-8000-000000018c54"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1017"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "57b8c8c2-347b-4000-8000-00000001918f"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 240,
+ "num_range": 1230,
+ "upper_bound": "1032"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "590d9248-24eb-4c00-8000-0000000197a7"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1045"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "5abc2497-4768-4c00-8000-000000019f5a"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "1061"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "5bf9fe16-aa1e-4c00-8000-00000001a509"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 270,
+ "num_range": 1320,
+ "upper_bound": "1074"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "5d7e670e-2c12-4c00-8000-00000001abfb"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1088"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "5ebf8769-ec2c-4400-8000-00000001b1b9"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1101"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "6018af6b-03cb-4000-8000-00000001b7e5"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1120"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "6155a938-2b78-4400-8000-00000001bd90"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 270,
+ "num_range": 1380,
+ "upper_bound": "1135"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "629968aa-9caf-4800-8000-00000001c35a"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1148"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "63a5e353-f7ce-4800-8000-00000001c827"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1162"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "64ed218f-552b-4400-8000-00000001ce01"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1178"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "664b87bd-cf03-4800-8000-00000001d445"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1192"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "67528c4d-3927-4000-8000-00000001d8f9"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1206"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "68c1fc8f-3237-4c00-8000-00000001df8b"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1225"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "69ea3593-5fc3-4400-8000-00000001e4d7"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1241"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "6b15ed60-7975-4800-8000-00000001ea33"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1256"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "6c56d5cf-aacd-4000-8000-00000001eff0"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1269"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "6d9c54a6-9217-4400-8000-00000001f5c2"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1286"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "6f21d53c-ddd6-4000-8000-00000001fcb9"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1302"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "70b04ab6-06b7-4c00-8000-0000000203d9"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1320"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "71fa97e1-32b5-4000-8000-0000000209c1"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1334"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "734acaff-6d33-4800-8000-000000020fc4"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1350"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "7495f7dc-d43a-4800-8000-0000000215b0"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1364"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "75d7bffe-409b-4800-8000-000000021b71"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "1379"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "77136a40-0fba-4800-8000-000000022116"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1393"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "789bc1d9-9b59-4000-8000-00000002281a"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1411"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "79eecbfb-15b5-4400-8000-000000022e2a"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1425"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "7b43cd6d-94e7-4c00-8000-000000023443"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1439"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "7c813713-da19-4c00-8000-0000000239f0"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1455"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "7da202ad-11d4-4c00-8000-000000023f1a"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1469"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "7f18e05a-00b5-4000-8000-0000000245ce"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "1486"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "803eea20-9aaa-4800-8000-000000024b10"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1499"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "81704ff4-3419-4000-8000-000000025086"
+ "distinct_range": 8.996785714285714,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1509"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "82c471b4-7842-4000-8000-00000002569b"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1523"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8419e300-14f8-4800-8000-000000025cb6"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1539"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8582fd75-e204-4000-8000-00000002632b"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1553"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "86b65a9a-8049-4800-8000-0000000268aa"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1569"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "87c733bf-0298-4800-8000-000000026d8b"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1587"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "89088c07-5174-4000-8000-00000002734a"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1600"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8a6ecf79-dea1-4800-8000-0000000279b2"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1613"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8b96d091-7d6b-4800-8000-000000027efd"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1631"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8c9d6547-ca0a-4000-8000-0000000283af"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1646"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8e21ce3f-4bfe-4800-8000-000000028aa1"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1659"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "8f70b1d2-2dee-4800-8000-00000002909e"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "1672"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "90c9320d-9945-4800-8000-0000000296c7"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1687"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "92835856-4a00-4800-8000-000000029eaf"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1703"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "9382ef7a-be53-4800-8000-00000002a341"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1721"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "94cfa3d0-0cab-4800-8000-00000002a934"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1733"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "960b85fe-6a8c-4800-8000-00000002aeda"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1747"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "973f8ae8-b519-4800-8000-00000002b45c"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1764"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "98811b1d-92b8-4000-8000-00000002ba1c"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 240,
+ "num_range": 1410,
+ "upper_bound": "1777"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "99e2903b-db30-4000-8000-00000002c06e"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1792"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "9b1156f8-c384-4800-8000-00000002c5d8"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1809"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "9c57ed6e-7499-4800-8000-00000002cbaf"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1824"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "9d76f9a3-3642-4000-8000-00000002d0d1"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1838"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "9ee2b32f-b46a-4800-8000-00000002d752"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1852"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a02363b2-56ff-4000-8000-00000002dd0e"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "1866"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a18201cd-5f99-4000-8000-00000002e353"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "1880"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a317e4b1-7e4b-4800-8000-00000002ea95"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1896"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a45d2b9b-d6d2-4000-8000-00000002f066"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1911"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a5b06da9-dff1-4800-8000-00000002f677"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1924"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a6c8b439-5810-4000-8000-00000002fb7a"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1350,
+ "upper_bound": "1941"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a81aa6bc-08a1-4000-8000-000000030185"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1961"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "a939eadd-590c-4800-8000-0000000306a8"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "1976"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "aa4dd2f1-a9fb-4800-8000-000000030b97"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1994"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "abe06ef9-6b49-4000-8000-0000000312ca"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2009"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "ad56dccd-3ca5-4800-8000-00000003197c"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "2025"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "aead2dcb-1465-4800-8000-000000031f9b"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2042"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "afc4cc94-e03e-4800-8000-00000003249b"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2060"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b0c692f6-e829-4800-8000-000000032937"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2078"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b228afda-dce9-4000-8000-000000032f8c"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2095"
},
- {
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b349b360-a367-4000-8000-0000000334b7"
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2108"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b478e9f6-a93f-4800-8000-000000033a23"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2123"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b5ab2f7c-7db8-4800-8000-000000033f9d"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2140"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b6d10156-88ea-4800-8000-0000000344de"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 270,
+ "num_range": 1320,
+ "upper_bound": "2155"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b8224c13-8d33-4800-8000-000000034ae6"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2170"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "b942dfc0-362d-4800-8000-00000003500f"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2188"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "bacf95d4-e8fb-4000-8000-000000035727"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2200"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "bc36f0e6-3ff3-4800-8000-000000035d94"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2216"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "bda9382b-78e2-4800-8000-000000036433"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2227"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "bf24ac40-1db5-4800-8000-000000036afc"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2246"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "c0208caf-1720-4800-8000-000000036f7d"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2264"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "c12023d3-8b74-4800-8000-00000003740f"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2277"
},
{
- "distinct_range": 1496.0653266331658,
- "num_eq": 4,
- "num_range": 1496,
- "upper_bound": "c28cf4fe-d368-4000-8000-000000037a95"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2292"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "c3e53d4d-affd-4000-8000-0000000380bd"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2308"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "c55a23a9-9a09-4000-8000-000000038768"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2322"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "c6ab367a-0f90-4800-8000-000000038d6f"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2336"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "c7e55943-f75f-4000-8000-00000003930d"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2351"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "c93be22e-5de1-4000-8000-00000003992d"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2365"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "ca5d558d-41e4-4800-8000-000000039e5a"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2379"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "cb3c6002-9f16-4000-8000-00000003a257"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2396"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "cc7faf9b-f2c8-4800-8000-00000003a81f"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "2407"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "ce1e1789-d116-4000-8000-00000003af88"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2420"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "cf7d257d-f735-4000-8000-00000003b5cf"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2433"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d09cd978-6524-4800-8000-00000003baf4"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2445"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d1a794bd-4a31-4800-8000-00000003bfb9"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2457"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d30a5966-eb38-4800-8000-00000003c611"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2469"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d46231dc-aa48-4000-8000-00000003cc37"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2483"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d5b035bd-512e-4800-8000-00000003d230"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2500"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d6e9b0c1-8cb6-4800-8000-00000003d7cb"
+ "distinct_range": 8.996785714285714,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2510"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d801bf64-7612-4000-8000-00000003dccd"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "2524"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "d97c53c6-dfdc-4000-8000-00000003e392"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2538"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "daadb99a-794b-4800-8000-00000003e908"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "2550"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "dbb80506-40d3-4800-8000-00000003edcb"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2564"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "dd028a1d-fb93-4800-8000-00000003f3b4"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "2582"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "de58db1b-d353-4800-8000-00000003f9d3"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2597"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "dfce693d-69a6-4800-8000-000000040081"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2613"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e0dca34b-3ad8-4800-8000-000000040556"
+ "distinct_range": 8.996785714285714,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2623"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e28e0c9d-9d34-4800-8000-000000040d16"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 240,
+ "num_range": 1290,
+ "upper_bound": "2636"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e3a5e353-f7ce-4800-8000-000000041217"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2649"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e4f1efe3-99df-4000-8000-000000041807"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2663"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e651a59d-6c45-4800-8000-000000041e51"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1380,
+ "upper_bound": "2679"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e7829b97-e830-4800-8000-0000000423c5"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2693"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e89b5200-7dd4-4000-8000-0000000428ca"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2709"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "e9dcaa48-ccb0-4800-8000-000000042e89"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2725"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "eb1ff9e2-2062-4000-8000-000000043451"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2740"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "ec3fe5c9-1d14-4000-8000-000000043977"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 240,
+ "num_range": 1200,
+ "upper_bound": "2755"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "ed7ab058-b12a-4800-8000-000000043f18"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2767"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "eeea209a-aa3a-4000-8000-0000000445aa"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2782"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f057d178-2d38-4800-8000-000000044c34"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 30,
+ "num_range": 1380,
+ "upper_bound": "2800"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f1be84c3-d7e9-4000-8000-00000004529e"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2815"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f2ed1394-317a-4000-8000-000000045807"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2831"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f46c764a-dff8-4000-8000-000000045ee2"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "2843"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f5821dc3-a6fa-4000-8000-0000000463d9"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "2856"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f68ed059-90dc-4000-8000-0000000468a7"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2871"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f74fb549-f948-4800-8000-000000046c1a"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1170,
+ "upper_bound": "2884"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f8cb295e-9e1b-4800-8000-0000000472e3"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2899"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "f9bebcb0-66ac-4000-8000-00000004773e"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2918"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "fad0e560-4189-4800-8000-000000047c25"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2933"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "fbebcb06-6ac4-4000-8000-000000048134"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1140,
+ "upper_bound": "2947"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "fd535e04-5080-4000-8000-0000000487a2"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1260,
+ "upper_bound": "2960"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "fe9b7bf1-e8e6-4800-8000-000000048d80"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2972"
},
{
- "distinct_range": 1526.0653266331658,
- "num_eq": 4,
- "num_range": 1526,
- "upper_bound": "fffd60e9-4ee3-4000-8000-0000000493d4"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "2988"
},
{
- "distinct_range": 1.1641532182693481E-10,
- "num_eq": 0,
- "num_range": 0,
- "upper_bound": "ffffffff-ffff-ffff-ffff-ffffffffffff"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1080,
+ "upper_bound": "3000"
}
],
- "histo_col_type": "UUID",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
"row_count": 300000
},
{
+ "avg_size": 5,
"columns": [
- "h_w_id",
- "rowid"
+ "o_w_id",
+ "o_d_id",
+ "o_c_id"
],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 300000,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 295745,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
"row_count": 300000
},
{
+ "avg_size": 8,
"columns": [
- "h_c_id"
- ],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 2999,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 90,
- "num_range": 0,
- "upper_bound": "1"
- },
- {
- "distinct_range": 2997,
- "num_eq": 90,
- "num_range": 299820,
- "upper_bound": "3000"
- }
- ],
- "histo_col_type": "INT8",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 300000
- },
- {
- "columns": [
- "h_c_d_id"
- ],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 10,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 29250,
- "num_range": 0,
- "upper_bound": "1"
- },
- {
- "distinct_range": 8,
- "num_eq": 29970,
- "num_range": 240780,
- "upper_bound": "10"
- }
+ "o_w_id",
+ "o_d_id",
+ "o_c_id",
+ "o_id"
],
- "histo_col_type": "INT8",
- "histo_version": 1,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 298416,
+ "histo_col_type": "",
"name": "__auto__",
"null_count": 0,
"row_count": 300000
},
{
+ "avg_size": 7,
"columns": [
- "h_c_w_id"
+ "o_entry_d"
],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 10,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 1,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 29580,
+ "num_eq": 300000,
"num_range": 0,
- "upper_bound": "0"
- },
- {
- "distinct_range": 8,
- "num_eq": 32010,
- "num_range": 238410,
- "upper_bound": "9"
+ "upper_bound": "2006-01-02 15:04:05"
}
],
- "histo_col_type": "INT8",
+ "histo_col_type": "TIMESTAMP",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
"row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
- "h_d_id"
+ "o_carrier_id"
],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 10,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 11,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 29250,
+ "num_eq": 21916,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 8,
- "num_eq": 29970,
- "num_range": 240780,
+ "num_eq": 20629,
+ "num_range": 167455,
"upper_bound": "10"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
- "null_count": 0,
+ "null_count": 90000,
"row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
- "h_date"
+ "o_ol_cnt"
],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 1,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 11,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 300000,
+ "num_eq": 26550,
"num_range": 0,
- "upper_bound": "2006-01-02 15:04:05"
- }
- ],
- "histo_col_type": "TIMESTAMP",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 300000
- },
- {
- "columns": [
- "h_amount"
- ],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 1,
- "histo_buckets": [
+ "upper_bound": "5"
+ },
{
- "distinct_range": 0,
- "num_eq": 300000,
- "num_range": 0,
- "upper_bound": "1E+1"
+ "distinct_range": 9,
+ "num_eq": 27120,
+ "num_range": 246330,
+ "upper_bound": "15"
}
],
- "histo_col_type": "DECIMAL(6,2)",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
"row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
- "h_data"
+ "o_all_local"
],
- "created_at": "2021-09-08 20:49:18.138991",
- "distinct_count": 806,
+ "created_at": "2022-02-25 01:07:53.523333",
+ "distinct_count": 1,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 480,
+ "num_eq": 300000,
"num_range": 0,
- "upper_bound": "1U5yraPxxELo"
- },
- {
- "distinct_range": 804.0000000000001,
- "num_eq": 330,
- "num_range": 299190,
- "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ "upper_bound": "1"
}
],
- "histo_col_type": "VARCHAR(24)",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
"row_count": 300000
- }
-]';
-----
-
-exec-ddl
-ALTER TABLE "item" INJECT STATISTICS '[
+ },
{
+ "avg_size": 1,
"columns": [
- "i_id"
+ "o_w_id"
],
- "created_at": "2021-09-08 20:49:18.666715",
- "distinct_count": 99658,
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 2,
+ "num_eq": 29970,
"num_range": 0,
- "upper_bound": "6"
- },
- {
- "distinct_range": 459.58920791954773,
- "num_eq": 2,
- "num_range": 477,
- "upper_bound": "468"
- },
- {
- "distinct_range": 498.3373025153326,
- "num_eq": 2,
- "num_range": 497,
- "upper_bound": "969"
- },
- {
- "distinct_range": 368.13420294769486,
- "num_eq": 2,
- "num_range": 432,
- "upper_bound": "1339"
- },
- {
- "distinct_range": 582.7563527598943,
- "num_eq": 2,
- "num_range": 545,
- "upper_bound": "1925"
- },
- {
- "distinct_range": 543.0346077306694,
- "num_eq": 2,
- "num_range": 522,
- "upper_bound": "2471"
+ "upper_bound": "0"
},
{
- "distinct_range": 503.3042689872976,
- "num_eq": 2,
- "num_range": 500,
- "upper_bound": "2977"
+ "distinct_range": 0,
+ "num_eq": 30090,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 464.55751382566984,
- "num_eq": 2,
- "num_range": 479,
- "upper_bound": "3444"
+ "distinct_range": 0,
+ "num_eq": 29760,
+ "num_range": 0,
+ "upper_bound": "2"
},
{
- "distinct_range": 489.39635745199354,
- "num_eq": 2,
- "num_range": 493,
- "upper_bound": "3936"
+ "distinct_range": 0,
+ "num_eq": 29040,
+ "num_range": 0,
+ "upper_bound": "3"
},
{
- "distinct_range": 559.9173240264843,
- "num_eq": 2,
- "num_range": 532,
- "upper_bound": "4499"
+ "distinct_range": 0,
+ "num_eq": 29820,
+ "num_range": 0,
+ "upper_bound": "4"
},
{
- "distinct_range": 535.0892703318236,
- "num_eq": 2,
- "num_range": 518,
- "upper_bound": "5037"
+ "distinct_range": 0,
+ "num_eq": 29580,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 377.08451868435407,
- "num_eq": 2,
- "num_range": 436,
- "upper_bound": "5416"
+ "distinct_range": 0,
+ "num_eq": 30660,
+ "num_range": 0,
+ "upper_bound": "6"
},
{
- "distinct_range": 495.35704603723616,
- "num_eq": 2,
- "num_range": 496,
- "upper_bound": "5914"
+ "distinct_range": 0,
+ "num_eq": 29280,
+ "num_range": 0,
+ "upper_bound": "7"
},
{
- "distinct_range": 474.493577337669,
- "num_eq": 2,
- "num_range": 485,
- "upper_bound": "6391"
+ "distinct_range": 0,
+ "num_eq": 31080,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 515.2243546473355,
- "num_eq": 2,
- "num_range": 507,
- "upper_bound": "6909"
- },
+ "distinct_range": 0,
+ "num_eq": 30720,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "o_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 10,
+ "histo_buckets": [
{
- "distinct_range": 473.5000032489809,
- "num_eq": 2,
- "num_range": 484,
- "upper_bound": "7385"
+ "distinct_range": 0,
+ "num_eq": 30990,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 480.45487461012755,
- "num_eq": 2,
- "num_range": 488,
- "upper_bound": "7868"
+ "distinct_range": 0,
+ "num_eq": 30780,
+ "num_range": 0,
+ "upper_bound": "2"
},
{
- "distinct_range": 465.55115279970425,
- "num_eq": 2,
- "num_range": 480,
- "upper_bound": "8336"
+ "distinct_range": 0,
+ "num_eq": 28650,
+ "num_range": 0,
+ "upper_bound": "3"
},
{
- "distinct_range": 471.51283377182796,
- "num_eq": 2,
- "num_range": 483,
- "upper_bound": "8810"
+ "distinct_range": 0,
+ "num_eq": 30570,
+ "num_range": 0,
+ "upper_bound": "4"
},
{
- "distinct_range": 471.51283377182796,
- "num_eq": 2,
- "num_range": 483,
- "upper_bound": "9284"
+ "distinct_range": 0,
+ "num_eq": 30060,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 510.257759305977,
- "num_eq": 2,
- "num_range": 504,
- "upper_bound": "9797"
+ "distinct_range": 0,
+ "num_eq": 30060,
+ "num_range": 0,
+ "upper_bound": "6"
},
{
- "distinct_range": 560.9103788699192,
- "num_eq": 2,
- "num_range": 533,
- "upper_bound": "10361"
+ "distinct_range": 0,
+ "num_eq": 30690,
+ "num_range": 0,
+ "upper_bound": "7"
},
{
- "distinct_range": 487.40940843690265,
- "num_eq": 2,
- "num_range": 491,
- "upper_bound": "10851"
+ "distinct_range": 0,
+ "num_eq": 28020,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 417.8476116905229,
- "num_eq": 2,
- "num_range": 455,
- "upper_bound": "11271"
+ "distinct_range": 0,
+ "num_eq": 30180,
+ "num_range": 0,
+ "upper_bound": "9"
},
{
- "distinct_range": 608.5714594952894,
- "num_eq": 2,
- "num_range": 560,
- "upper_bound": "11883"
- },
+ "distinct_range": 0,
+ "num_eq": 30000,
+ "num_range": 0,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "o_w_id",
+ "o_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 100,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 3,
+ "columns": [
+ "o_id"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 2999,
+ "histo_buckets": [
{
- "distinct_range": 385.03961917725087,
- "num_eq": 2,
- "num_range": 440,
- "upper_bound": "12270"
+ "distinct_range": 0,
+ "num_eq": 60,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 632.3982671593972,
- "num_eq": 2,
- "num_range": 575,
- "upper_bound": "12906"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "17"
},
{
- "distinct_range": 610.5571161608441,
- "num_eq": 2,
- "num_range": 562,
- "upper_bound": "13520"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "31"
},
{
- "distinct_range": 505.291011492804,
- "num_eq": 2,
- "num_range": 501,
- "upper_bound": "14028"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "46"
},
{
- "distinct_range": 521.1840720228802,
- "num_eq": 2,
- "num_range": 510,
- "upper_bound": "14552"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "62"
},
{
- "distinct_range": 414.8654942089104,
- "num_eq": 2,
- "num_range": 454,
- "upper_bound": "14969"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1470,
+ "upper_bound": "77"
},
{
- "distinct_range": 441.70172150734624,
- "num_eq": 2,
- "num_range": 467,
- "upper_bound": "15413"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 240,
+ "num_range": 1410,
+ "upper_bound": "90"
},
{
- "distinct_range": 490.3898219884782,
- "num_eq": 2,
- "num_range": 493,
- "upper_bound": "15906"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "107"
},
{
- "distinct_range": 490.3898219884782,
- "num_eq": 2,
- "num_range": 493,
- "upper_bound": "16399"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1350,
+ "upper_bound": "120"
},
{
- "distinct_range": 506.2843734000812,
- "num_eq": 2,
- "num_range": 502,
- "upper_bound": "16908"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "135"
},
{
- "distinct_range": 479.46134245119157,
- "num_eq": 2,
- "num_range": 487,
- "upper_bound": "17390"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "151"
},
{
- "distinct_range": 489.39635745199354,
- "num_eq": 2,
- "num_range": 493,
- "upper_bound": "17882"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "163"
},
{
- "distinct_range": 531.1164696817564,
- "num_eq": 2,
- "num_range": 516,
- "upper_bound": "18416"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "178"
},
{
- "distinct_range": 554.9519741220522,
- "num_eq": 2,
- "num_range": 529,
- "upper_bound": "18974"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "189"
},
{
- "distinct_range": 465.55115279970425,
- "num_eq": 2,
- "num_range": 480,
- "upper_bound": "19442"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "204"
},
{
- "distinct_range": 522.1773376838518,
- "num_eq": 2,
- "num_range": 511,
- "upper_bound": "19967"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 180,
+ "num_range": 1470,
+ "upper_bound": "222"
},
{
- "distinct_range": 446.6707229883164,
- "num_eq": 2,
- "num_range": 470,
- "upper_bound": "20416"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "239"
},
{
- "distinct_range": 603.6072442583638,
- "num_eq": 2,
- "num_range": 557,
- "upper_bound": "21023"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "254"
},
{
- "distinct_range": 529.1300357654311,
- "num_eq": 2,
- "num_range": 514,
- "upper_bound": "21555"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "268"
},
{
- "distinct_range": 416.853581584374,
- "num_eq": 2,
- "num_range": 455,
- "upper_bound": "21974"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "285"
},
{
- "distinct_range": 454.6207140773367,
- "num_eq": 2,
- "num_range": 474,
- "upper_bound": "22431"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "298"
},
{
- "distinct_range": 454.6207140773367,
- "num_eq": 2,
- "num_range": 474,
- "upper_bound": "22888"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "310"
},
{
- "distinct_range": 488.40288627718985,
- "num_eq": 2,
- "num_range": 492,
- "upper_bound": "23379"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "324"
},
{
- "distinct_range": 542.0414595263582,
- "num_eq": 2,
- "num_range": 522,
- "upper_bound": "23924"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "338"
},
{
- "distinct_range": 433.7508953791799,
- "num_eq": 2,
- "num_range": 463,
- "upper_bound": "24360"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "354"
},
{
- "distinct_range": 483.4354298727446,
- "num_eq": 2,
- "num_range": 489,
- "upper_bound": "24846"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "368"
},
{
- "distinct_range": 459.58920791954773,
- "num_eq": 2,
- "num_range": 477,
- "upper_bound": "25308"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "386"
},
{
- "distinct_range": 655.2302082860572,
- "num_eq": 2,
- "num_range": 588,
- "upper_bound": "25967"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "398"
},
{
- "distinct_range": 464.55751382566984,
- "num_eq": 2,
- "num_range": 479,
- "upper_bound": "26434"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "412"
},
{
- "distinct_range": 432.75700470093744,
- "num_eq": 2,
- "num_range": 463,
- "upper_bound": "26869"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "426"
},
{
- "distinct_range": 399.9536534563343,
- "num_eq": 2,
- "num_range": 447,
- "upper_bound": "27271"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "443"
},
{
- "distinct_range": 475.48714436559754,
- "num_eq": 2,
- "num_range": 485,
- "upper_bound": "27749"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "459"
},
{
- "distinct_range": 566.8686035610245,
- "num_eq": 2,
- "num_range": 536,
- "upper_bound": "28319"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "478"
},
{
- "distinct_range": 637.3619001809409,
- "num_eq": 2,
- "num_range": 578,
- "upper_bound": "28960"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "494"
},
{
- "distinct_range": 412.87737035031455,
- "num_eq": 2,
- "num_range": 453,
- "upper_bound": "29375"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "510"
},
{
- "distinct_range": 521.1840720228802,
- "num_eq": 2,
- "num_range": 510,
- "upper_bound": "29899"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "524"
},
{
- "distinct_range": 475.48714436559754,
- "num_eq": 2,
- "num_range": 485,
- "upper_bound": "30377"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "539"
},
{
- "distinct_range": 457.60183315691467,
- "num_eq": 2,
- "num_range": 476,
- "upper_bound": "30837"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "555"
},
{
- "distinct_range": 422.81762797819994,
- "num_eq": 2,
- "num_range": 458,
- "upper_bound": "31262"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "570"
},
{
- "distinct_range": 422.81762797819994,
- "num_eq": 2,
- "num_range": 458,
- "upper_bound": "31687"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 270,
+ "num_range": 1230,
+ "upper_bound": "584"
},
{
- "distinct_range": 532.1096782093178,
- "num_eq": 2,
- "num_range": 516,
- "upper_bound": "32222"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "601"
},
{
- "distinct_range": 659.2007846140752,
- "num_eq": 2,
- "num_range": 591,
- "upper_bound": "32885"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "612"
},
{
- "distinct_range": 404.9245036010886,
- "num_eq": 2,
- "num_range": 449,
- "upper_bound": "33292"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "626"
},
{
- "distinct_range": 409.8951154520642,
- "num_eq": 2,
- "num_range": 452,
- "upper_bound": "33704"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "641"
},
{
- "distinct_range": 521.1840720228802,
- "num_eq": 2,
- "num_range": 510,
- "upper_bound": "34228"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "656"
},
{
- "distinct_range": 389.0169178326498,
- "num_eq": 2,
- "num_range": 442,
- "upper_bound": "34619"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "670"
},
{
- "distinct_range": 568.8546391456573,
- "num_eq": 2,
- "num_range": 537,
- "upper_bound": "35191"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "686"
},
{
- "distinct_range": 478.4678033759362,
- "num_eq": 2,
- "num_range": 487,
- "upper_bound": "35672"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 240,
+ "num_range": 1260,
+ "upper_bound": "698"
},
{
- "distinct_range": 516.2176556849371,
- "num_eq": 2,
- "num_range": 507,
- "upper_bound": "36191"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "709"
},
{
- "distinct_range": 414.8654942089104,
- "num_eq": 2,
- "num_range": 454,
- "upper_bound": "36608"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "720"
},
{
- "distinct_range": 470.51923832423455,
- "num_eq": 2,
- "num_range": 482,
- "upper_bound": "37081"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "738"
},
{
- "distinct_range": 392.99405273108425,
- "num_eq": 2,
- "num_range": 443,
- "upper_bound": "37476"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "758"
},
{
- "distinct_range": 392.99405273108425,
- "num_eq": 2,
- "num_range": 443,
- "upper_bound": "37871"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "773"
},
{
- "distinct_range": 519.1975231639967,
- "num_eq": 2,
- "num_range": 509,
- "upper_bound": "38393"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "786"
},
{
- "distinct_range": 545.0208880873447,
- "num_eq": 2,
- "num_range": 523,
- "upper_bound": "38941"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "799"
},
{
- "distinct_range": 539.061982560539,
- "num_eq": 2,
- "num_range": 520,
- "upper_bound": "39483"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "813"
},
{
- "distinct_range": 528.1368103325829,
- "num_eq": 2,
- "num_range": 514,
- "upper_bound": "40014"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "833"
},
{
- "distinct_range": 539.061982560539,
- "num_eq": 2,
- "num_range": 520,
- "upper_bound": "40556"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "847"
},
{
- "distinct_range": 431.76310558895915,
- "num_eq": 2,
- "num_range": 462,
- "upper_bound": "40990"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "863"
},
{
- "distinct_range": 496.3504713065711,
- "num_eq": 2,
- "num_range": 496,
- "upper_bound": "41489"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "878"
},
{
- "distinct_range": 560.9103788699192,
- "num_eq": 2,
- "num_range": 533,
- "upper_bound": "42053"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "893"
},
{
- "distinct_range": 499.3307085067872,
- "num_eq": 2,
- "num_range": 498,
- "upper_bound": "42555"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "910"
},
{
- "distinct_range": 494.3636142896923,
- "num_eq": 2,
- "num_range": 495,
- "upper_bound": "43052"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "925"
},
{
- "distinct_range": 450.64578100213,
- "num_eq": 2,
- "num_range": 472,
- "upper_bound": "43505"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "938"
},
{
- "distinct_range": 564.8825484190158,
- "num_eq": 2,
- "num_range": 535,
- "upper_bound": "44073"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "955"
},
{
- "distinct_range": 418.84163279498273,
- "num_eq": 2,
- "num_range": 456,
- "upper_bound": "44494"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "971"
},
{
- "distinct_range": 563.8895134678388,
- "num_eq": 2,
- "num_range": 534,
- "upper_bound": "45061"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "983"
},
{
- "distinct_range": 591.6926888896921,
- "num_eq": 2,
- "num_range": 550,
- "upper_bound": "45656"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "999"
},
{
- "distinct_range": 601.6215284139222,
- "num_eq": 2,
- "num_range": 556,
- "upper_bound": "46261"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1017"
},
{
- "distinct_range": 471.51283377182796,
- "num_eq": 2,
- "num_range": 483,
- "upper_bound": "46735"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "1030"
},
{
- "distinct_range": 574.8126300129396,
- "num_eq": 2,
- "num_range": 541,
- "upper_bound": "47313"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1044"
},
{
- "distinct_range": 441.70172150734624,
- "num_eq": 2,
- "num_range": 467,
- "upper_bound": "47757"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1063"
},
{
- "distinct_range": 445.6769387130742,
- "num_eq": 2,
- "num_range": 469,
- "upper_bound": "48205"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1077"
},
{
- "distinct_range": 492.3767312544575,
- "num_eq": 2,
- "num_range": 494,
- "upper_bound": "48700"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1092"
},
{
- "distinct_range": 532.1096782093178,
- "num_eq": 2,
- "num_range": 516,
- "upper_bound": "49235"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 270,
+ "num_range": 1350,
+ "upper_bound": "1108"
},
{
- "distinct_range": 510.257759305977,
- "num_eq": 2,
- "num_range": 504,
- "upper_bound": "49748"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1126"
},
{
- "distinct_range": 495.35704603723616,
- "num_eq": 2,
- "num_range": 496,
- "upper_bound": "50246"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1139"
},
{
- "distinct_range": 468.5320258620446,
- "num_eq": 2,
- "num_range": 481,
- "upper_bound": "50717"
+ "distinct_range": 19.992857142857144,
+ "num_eq": 180,
+ "num_range": 1440,
+ "upper_bound": "1160"
},
{
- "distinct_range": 560.9103788699192,
- "num_eq": 2,
- "num_range": 533,
- "upper_bound": "51281"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1176"
},
{
- "distinct_range": 477.47425735576945,
- "num_eq": 2,
- "num_range": 486,
- "upper_bound": "51761"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1192"
},
{
- "distinct_range": 506.2843734000812,
- "num_eq": 2,
- "num_range": 502,
- "upper_bound": "52270"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1208"
},
{
- "distinct_range": 490.3898219884782,
- "num_eq": 2,
- "num_range": 493,
- "upper_bound": "52763"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1226"
},
{
- "distinct_range": 423.81160465913234,
- "num_eq": 2,
- "num_range": 458,
- "upper_bound": "53189"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1239"
},
{
- "distinct_range": 399.9536534563343,
- "num_eq": 2,
- "num_range": 447,
- "upper_bound": "53591"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1252"
},
{
- "distinct_range": 500.3241081240897,
- "num_eq": 2,
- "num_range": 498,
- "upper_bound": "54094"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "1266"
},
{
- "distinct_range": 505.291011492804,
- "num_eq": 2,
- "num_range": 501,
- "upper_bound": "54602"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1280"
},
{
- "distinct_range": 453.6269924060113,
- "num_eq": 2,
- "num_range": 474,
- "upper_bound": "55058"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1294"
},
{
- "distinct_range": 586.7281030366964,
- "num_eq": 2,
- "num_range": 548,
- "upper_bound": "55648"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1310"
},
{
- "distinct_range": 495.35704603723616,
- "num_eq": 2,
- "num_range": 496,
- "upper_bound": "56146"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1326"
},
{
- "distinct_range": 466.54478444342243,
- "num_eq": 2,
- "num_range": 480,
- "upper_bound": "56615"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "1342"
},
{
- "distinct_range": 506.2843734000812,
- "num_eq": 2,
- "num_range": 502,
- "upper_bound": "57124"
+ "distinct_range": 8.996785714285714,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1352"
},
{
- "distinct_range": 423.81160465913234,
- "num_eq": 2,
- "num_range": 458,
- "upper_bound": "57550"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "1365"
},
{
- "distinct_range": 555.9450542586189,
- "num_eq": 2,
- "num_range": 530,
- "upper_bound": "58109"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1378"
},
{
- "distinct_range": 512.2444155690481,
- "num_eq": 2,
- "num_range": 505,
- "upper_bound": "58624"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "1393"
},
{
- "distinct_range": 534.0960785126343,
- "num_eq": 2,
- "num_range": 517,
- "upper_bound": "59161"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1409"
},
{
- "distinct_range": 586.7281030366964,
- "num_eq": 2,
- "num_range": 548,
- "upper_bound": "59751"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1423"
},
{
- "distinct_range": 453.6269924060113,
- "num_eq": 2,
- "num_range": 474,
- "upper_bound": "60207"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1439"
},
{
- "distinct_range": 501.31750139292654,
- "num_eq": 2,
- "num_range": 499,
- "upper_bound": "60711"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1457"
},
{
- "distinct_range": 493.370176037593,
- "num_eq": 2,
- "num_range": 495,
- "upper_bound": "61207"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1470"
},
{
- "distinct_range": 551.9727029345129,
- "num_eq": 2,
- "num_range": 527,
- "upper_bound": "61762"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1489"
},
{
- "distinct_range": 561.9034287120447,
- "num_eq": 2,
- "num_range": 533,
- "upper_bound": "62327"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "1507"
},
{
- "distinct_range": 407.9068989711059,
- "num_eq": 2,
- "num_range": 451,
- "upper_bound": "62737"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1522"
},
{
- "distinct_range": 446.6707229883164,
- "num_eq": 2,
- "num_range": 470,
- "upper_bound": "63186"
+ "distinct_range": 8.996785714285714,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1532"
},
{
- "distinct_range": 707.8360171548218,
- "num_eq": 2,
- "num_range": 621,
- "upper_bound": "63898"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1545"
},
{
- "distinct_range": 556.9381292980383,
- "num_eq": 2,
- "num_range": 530,
- "upper_bound": "64458"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1558"
},
{
- "distinct_range": 420.82964815569784,
- "num_eq": 2,
- "num_range": 457,
- "upper_bound": "64881"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1571"
},
{
- "distinct_range": 548.9933851667984,
- "num_eq": 2,
- "num_range": 526,
- "upper_bound": "65433"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1583"
},
{
- "distinct_range": 529.1300357654311,
- "num_eq": 2,
- "num_range": 514,
- "upper_bound": "65965"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1600"
},
{
- "distinct_range": 457.60183315691467,
- "num_eq": 2,
- "num_range": 476,
- "upper_bound": "66425"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1614"
},
{
- "distinct_range": 389.0169178326498,
- "num_eq": 2,
- "num_range": 442,
- "upper_bound": "66816"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1626"
},
{
- "distinct_range": 615.5211853026703,
- "num_eq": 2,
- "num_range": 565,
- "upper_bound": "67435"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1641"
},
{
- "distinct_range": 569.8476496497824,
- "num_eq": 2,
- "num_range": 538,
- "upper_bound": "68008"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1660"
},
{
- "distinct_range": 517.2109507678831,
- "num_eq": 2,
- "num_range": 508,
- "upper_bound": "68528"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1673"
},
{
- "distinct_range": 387.02828915827473,
- "num_eq": 2,
- "num_range": 441,
- "upper_bound": "68917"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1688"
},
{
- "distinct_range": 435.73865157947534,
- "num_eq": 2,
- "num_range": 464,
- "upper_bound": "69355"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1701"
},
{
- "distinct_range": 384.0452685805843,
- "num_eq": 2,
- "num_range": 439,
- "upper_bound": "69741"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1718"
},
{
- "distinct_range": 470.51923832423455,
- "num_eq": 2,
- "num_range": 482,
- "upper_bound": "70214"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1731"
},
{
- "distinct_range": 413.87143686002673,
- "num_eq": 2,
- "num_range": 453,
- "upper_bound": "70630"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1745"
},
{
- "distinct_range": 549.9864962979962,
- "num_eq": 2,
- "num_range": 526,
- "upper_bound": "71183"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1762"
},
{
- "distinct_range": 607.5786248865586,
- "num_eq": 2,
- "num_range": 560,
- "upper_bound": "71794"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1781"
},
{
- "distinct_range": 600.6286640550184,
- "num_eq": 2,
- "num_range": 556,
- "upper_bound": "72398"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "1797"
},
{
- "distinct_range": 559.9173240264843,
- "num_eq": 2,
- "num_range": 532,
- "upper_bound": "72961"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1809"
},
{
- "distinct_range": 544.0277505774577,
- "num_eq": 2,
- "num_range": 523,
- "upper_bound": "73508"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 270,
+ "num_range": 1350,
+ "upper_bound": "1825"
},
{
- "distinct_range": 590.6997806964812,
- "num_eq": 2,
- "num_range": 550,
- "upper_bound": "74102"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "1839"
},
{
- "distinct_range": 479.46134245119157,
- "num_eq": 2,
- "num_range": 487,
- "upper_bound": "74584"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1852"
},
{
- "distinct_range": 527.1435792203715,
- "num_eq": 2,
- "num_range": 513,
- "upper_bound": "75114"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1869"
},
{
- "distinct_range": 471.5439774755069,
- "num_eq": 2,
- "num_range": 488,
- "upper_bound": "75588"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1882"
},
{
- "distinct_range": 505.3244217389053,
- "num_eq": 2,
- "num_range": 506,
- "upper_bound": "76096"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1898"
},
{
- "distinct_range": 484.46096341444314,
- "num_eq": 2,
- "num_range": 495,
- "upper_bound": "76583"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1916"
},
{
- "distinct_range": 466.5755815060514,
- "num_eq": 2,
- "num_range": 485,
- "upper_bound": "77052"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1930"
},
{
- "distinct_range": 467.5692754581191,
- "num_eq": 2,
- "num_range": 486,
- "upper_bound": "77522"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 270,
+ "num_range": 1200,
+ "upper_bound": "1945"
},
{
- "distinct_range": 575.8432827564067,
- "num_eq": 2,
- "num_range": 545,
- "upper_bound": "78101"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 240,
+ "num_range": 1410,
+ "upper_bound": "1958"
},
{
- "distinct_range": 458.6257594343349,
- "num_eq": 2,
- "num_range": 481,
- "upper_bound": "78562"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1974"
},
{
- "distinct_range": 520.2251622545814,
- "num_eq": 2,
- "num_range": 514,
- "upper_bound": "79085"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1989"
},
{
- "distinct_range": 477.50581243827816,
- "num_eq": 2,
- "num_range": 491,
- "upper_bound": "79565"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "2006"
},
{
- "distinct_range": 493.40280405616653,
- "num_eq": 2,
- "num_range": 499,
- "upper_bound": "80061"
+ "distinct_range": 20.9925,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2028"
},
{
- "distinct_range": 440.73683427373476,
- "num_eq": 2,
- "num_range": 472,
- "upper_bound": "80504"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2044"
},
{
- "distinct_range": 607.6180280074511,
- "num_eq": 2,
- "num_range": 564,
- "upper_bound": "81115"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "2060"
},
{
- "distinct_range": 574.8502450801502,
- "num_eq": 2,
- "num_range": 545,
- "upper_bound": "81693"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "2080"
},
{
- "distinct_range": 555.981585666294,
- "num_eq": 2,
- "num_range": 534,
- "upper_bound": "82252"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2094"
},
{
- "distinct_range": 685.0514000428337,
- "num_eq": 2,
- "num_range": 611,
- "upper_bound": "82941"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2112"
},
{
- "distinct_range": 390.03621629926704,
- "num_eq": 2,
- "num_range": 447,
- "upper_bound": "83333"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2123"
},
{
- "distinct_range": 495.3898057486728,
- "num_eq": 2,
- "num_range": 500,
- "upper_bound": "83831"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2138"
},
{
- "distinct_range": 423.83927268170675,
- "num_eq": 2,
- "num_range": 463,
- "upper_bound": "84257"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "2153"
},
{
- "distinct_range": 505.3244217389053,
- "num_eq": 2,
- "num_range": 506,
- "upper_bound": "84765"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2168"
},
{
- "distinct_range": 538.1042788895529,
- "num_eq": 2,
- "num_range": 524,
- "upper_bound": "85306"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2181"
},
{
- "distinct_range": 426.8213773588239,
- "num_eq": 2,
- "num_range": 465,
- "upper_bound": "85735"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1290,
+ "upper_bound": "2196"
},
{
- "distinct_range": 431.7913762286128,
- "num_eq": 2,
- "num_range": 467,
- "upper_bound": "86169"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "2213"
},
{
- "distinct_range": 450.6754450721156,
- "num_eq": 2,
- "num_range": 477,
- "upper_bound": "86622"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2228"
},
{
- "distinct_range": 515.2584024127976,
- "num_eq": 2,
- "num_range": 511,
- "upper_bound": "87140"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "2244"
},
{
- "distinct_range": 513.2716559028574,
- "num_eq": 2,
- "num_range": 510,
- "upper_bound": "87656"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2260"
},
{
- "distinct_range": 512.2782734289233,
- "num_eq": 2,
- "num_range": 510,
- "upper_bound": "88171"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "2275"
},
{
- "distinct_range": 663.2134919617272,
- "num_eq": 2,
- "num_range": 597,
- "upper_bound": "88838"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "2288"
},
{
- "distinct_range": 536.1178020464585,
- "num_eq": 2,
- "num_range": 523,
- "upper_bound": "89377"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2301"
},
{
- "distinct_range": 473.5312846329919,
- "num_eq": 2,
- "num_range": 489,
- "upper_bound": "89853"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2316"
},
{
- "distinct_range": 407.93333301327374,
- "num_eq": 2,
- "num_range": 456,
- "upper_bound": "90263"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2330"
},
{
- "distinct_range": 647.3303062790867,
- "num_eq": 2,
- "num_range": 588,
- "upper_bound": "90914"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2347"
},
{
- "distinct_range": 516.2517664971061,
- "num_eq": 2,
- "num_range": 512,
- "upper_bound": "91433"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2363"
},
{
- "distinct_range": 401.96798378144877,
- "num_eq": 2,
- "num_range": 453,
- "upper_bound": "91837"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2378"
},
{
- "distinct_range": 488.4351827239231,
- "num_eq": 2,
- "num_range": 497,
- "upper_bound": "92328"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2393"
},
{
- "distinct_range": 530.1582357864629,
- "num_eq": 2,
- "num_range": 519,
- "upper_bound": "92861"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2411"
},
{
- "distinct_range": 500.35719474692524,
- "num_eq": 2,
- "num_range": 503,
- "upper_bound": "93364"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2429"
},
{
- "distinct_range": 506.31784797927054,
- "num_eq": 2,
- "num_range": 506,
- "upper_bound": "93873"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2443"
},
{
- "distinct_range": 409.9217058517884,
- "num_eq": 2,
- "num_range": 457,
- "upper_bound": "94285"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "2459"
},
{
- "distinct_range": 617.5467068000098,
- "num_eq": 2,
- "num_range": 570,
- "upper_bound": "94906"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2478"
},
{
- "distinct_range": 583.7874114903319,
- "num_eq": 2,
- "num_range": 550,
- "upper_bound": "95493"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2493"
},
{
- "distinct_range": 521.218496167402,
- "num_eq": 2,
- "num_range": 515,
- "upper_bound": "96017"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2509"
},
{
- "distinct_range": 559.9540869913342,
- "num_eq": 2,
- "num_range": 536,
- "upper_bound": "96580"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 270,
+ "num_range": 1290,
+ "upper_bound": "2524"
},
{
- "distinct_range": 532.1447806700204,
- "num_eq": 2,
- "num_range": 521,
- "upper_bound": "97115"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2541"
},
{
- "distinct_range": 524.1984622168176,
- "num_eq": 2,
- "num_range": 516,
- "upper_bound": "97642"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2557"
},
{
- "distinct_range": 484.46096341444314,
- "num_eq": 2,
- "num_range": 495,
- "upper_bound": "98129"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2575"
},
{
- "distinct_range": 572.8641551421317,
- "num_eq": 2,
- "num_range": 544,
- "upper_bound": "98705"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "2588"
},
{
- "distinct_range": 358.21066477162026,
- "num_eq": 2,
- "num_range": 433,
- "upper_bound": "99065"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2603"
},
{
- "distinct_range": 459.61951377963317,
- "num_eq": 2,
- "num_range": 482,
- "upper_bound": "99527"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "2617"
},
{
- "distinct_range": 467.5692754581191,
- "num_eq": 2,
- "num_range": 486,
- "upper_bound": "99997"
- }
- ],
- "histo_col_type": "INT8",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100000
- },
- {
- "columns": [
- "i_im_id"
- ],
- "created_at": "2021-09-08 20:49:18.666715",
- "distinct_count": 9918,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 10,
- "num_range": 0,
- "upper_bound": "2"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2628"
},
{
- "distinct_range": 9916,
- "num_eq": 40,
- "num_range": 99950,
- "upper_bound": "9998"
- }
- ],
- "histo_col_type": "INT8",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100000
- },
- {
- "columns": [
- "i_name"
- ],
- "created_at": "2021-09-08 20:49:18.666715",
- "distinct_count": 682,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 180,
- "num_range": 0,
- "upper_bound": "1U5yraPxxELo5B"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2640"
},
{
- "distinct_range": 680,
- "num_eq": 140,
- "num_range": 99680,
- "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
- }
- ],
- "histo_col_type": "VARCHAR(24)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100000
- },
- {
- "columns": [
- "i_price"
- ],
- "created_at": "2021-09-08 20:49:18.666715",
- "distinct_count": 9857,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 30,
- "num_range": 0,
- "upper_bound": "1"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2656"
},
{
- "distinct_range": 9855,
- "num_eq": 10,
- "num_range": 99960,
- "upper_bound": "1E+2"
- }
- ],
- "histo_col_type": "DECIMAL(5,2)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100000
- },
- {
- "columns": [
- "i_data"
- ],
- "created_at": "2021-09-08 20:49:18.666715",
- "distinct_count": 11682,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 10,
- "num_range": 0,
- "upper_bound": "0YhORIGINALgLRrwsmd68P2bElAg"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2671"
},
{
- "distinct_range": 11680,
- "num_eq": 10,
- "num_range": 99980,
- "upper_bound": "zmssaORIGINALF9m9cdLXe0YhgLRrwsmd68P2bElAgrnp8u"
- }
- ],
- "histo_col_type": "VARCHAR(50)",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 100000
- }
-]';
-----
-
-exec-ddl
-ALTER TABLE "new_order" INJECT STATISTICS '[
- {
- "columns": [
- "no_w_id"
- ],
- "created_at": "2021-09-08 20:48:10.067968",
- "distinct_count": 10,
- "histo_buckets": [
- {
- "distinct_range": 0,
- "num_eq": 8838,
- "num_range": 0,
- "upper_bound": "0"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "2684"
},
{
- "distinct_range": 0,
- "num_eq": 8802,
- "num_range": 0,
- "upper_bound": "1"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2697"
},
{
- "distinct_range": 0,
- "num_eq": 9531,
- "num_range": 0,
- "upper_bound": "2"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2714"
},
{
- "distinct_range": 0,
- "num_eq": 8595,
- "num_range": 0,
- "upper_bound": "3"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2727"
},
{
- "distinct_range": 0,
- "num_eq": 8820,
- "num_range": 0,
- "upper_bound": "4"
+ "distinct_range": 19.992857142857144,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2748"
},
{
- "distinct_range": 0,
- "num_eq": 9369,
- "num_range": 0,
- "upper_bound": "5"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "2766"
},
{
- "distinct_range": 0,
- "num_eq": 8748,
- "num_range": 0,
- "upper_bound": "6"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2780"
},
{
- "distinct_range": 0,
- "num_eq": 9342,
- "num_range": 0,
- "upper_bound": "7"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2797"
},
{
- "distinct_range": 0,
- "num_eq": 8784,
- "num_range": 0,
- "upper_bound": "8"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2811"
},
{
- "distinct_range": 0,
- "num_eq": 9171,
- "num_range": 0,
- "upper_bound": "9"
- }
- ],
- "histo_col_type": "INT8",
- "histo_version": 1,
- "name": "__auto__",
- "null_count": 0,
- "row_count": 90000
- },
- {
- "columns": [
- "no_d_id"
- ],
- "created_at": "2021-09-08 20:48:10.067968",
- "distinct_count": 10,
- "histo_buckets": [
+ "distinct_range": 15.994285714285715,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2828"
+ },
{
- "distinct_range": 0,
- "num_eq": 9117,
- "num_range": 0,
- "upper_bound": "1"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2839"
},
{
- "distinct_range": 0,
- "num_eq": 9054,
- "num_range": 0,
- "upper_bound": "2"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "2856"
},
{
- "distinct_range": 0,
- "num_eq": 8748,
- "num_range": 0,
- "upper_bound": "3"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2873"
},
{
- "distinct_range": 0,
- "num_eq": 8748,
- "num_range": 0,
- "upper_bound": "4"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2887"
},
{
- "distinct_range": 0,
- "num_eq": 8946,
- "num_range": 0,
- "upper_bound": "5"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2904"
},
{
- "distinct_range": 0,
- "num_eq": 8973,
- "num_range": 0,
- "upper_bound": "6"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2919"
},
{
- "distinct_range": 0,
- "num_eq": 9189,
- "num_range": 0,
- "upper_bound": "7"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2931"
},
{
- "distinct_range": 0,
- "num_eq": 8910,
- "num_range": 0,
- "upper_bound": "8"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2947"
},
{
- "distinct_range": 0,
- "num_eq": 9297,
- "num_range": 0,
- "upper_bound": "9"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 120,
+ "num_range": 1260,
+ "upper_bound": "2960"
},
{
- "distinct_range": 0,
- "num_eq": 9018,
- "num_range": 0,
- "upper_bound": "10"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 240,
+ "num_range": 1200,
+ "upper_bound": "2971"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 210,
+ "num_range": 1230,
+ "upper_bound": "2984"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 30,
+ "num_range": 1290,
+ "upper_bound": "3000"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 90000
+ "row_count": 300000
},
{
+ "avg_size": 5,
"columns": [
- "no_w_id",
- "no_d_id"
+ "o_w_id",
+ "o_d_id",
+ "o_id"
],
- "created_at": "2021-09-08 20:48:10.067968",
- "distinct_count": 100,
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 295745,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 90000
+ "row_count": 300000
},
{
+ "avg_size": 3,
"columns": [
- "no_o_id"
+ "o_c_id"
],
- "created_at": "2021-09-08 20:48:10.067968",
- "distinct_count": 900,
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 2999,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 117,
+ "num_eq": 60,
"num_range": 0,
- "upper_bound": "2101"
+ "upper_bound": "1"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 405,
- "upper_bound": "2106"
+ "distinct_range": 15,
+ "num_eq": 120,
+ "num_range": 1470,
+ "upper_bound": "17"
},
{
- "distinct_range": 4,
- "num_eq": 63,
- "num_range": 423,
- "upper_bound": "2111"
+ "distinct_range": 12,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "30"
},
{
- "distinct_range": 5,
- "num_eq": 99,
- "num_range": 441,
- "upper_bound": "2117"
+ "distinct_range": 15,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "46"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 360,
- "upper_bound": "2121"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "61"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 423,
- "upper_bound": "2126"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "75"
},
{
- "distinct_range": 5,
- "num_eq": 198,
- "num_range": 351,
- "upper_bound": "2132"
+ "distinct_range": 11,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "87"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 351,
- "upper_bound": "2136"
+ "distinct_range": 13,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "101"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 414,
- "upper_bound": "2141"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1470,
+ "upper_bound": "117"
},
{
- "distinct_range": 5,
- "num_eq": 99,
- "num_range": 423,
- "upper_bound": "2147"
+ "distinct_range": 16,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "134"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 387,
- "upper_bound": "2152"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "149"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 405,
- "upper_bound": "2156"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "164"
},
{
- "distinct_range": 5,
- "num_eq": 36,
- "num_range": 414,
- "upper_bound": "2162"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1470,
+ "upper_bound": "179"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 414,
- "upper_bound": "2167"
+ "distinct_range": 15,
+ "num_eq": 30,
+ "num_range": 1470,
+ "upper_bound": "195"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 432,
- "upper_bound": "2172"
+ "distinct_range": 15,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "211"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 333,
- "upper_bound": "2177"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "226"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 396,
- "upper_bound": "2181"
+ "distinct_range": 11,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "238"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 360,
- "upper_bound": "2186"
+ "distinct_range": 11,
+ "num_eq": 240,
+ "num_range": 1290,
+ "upper_bound": "250"
},
{
- "distinct_range": 3,
- "num_eq": 81,
- "num_range": 405,
- "upper_bound": "2190"
+ "distinct_range": 12,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "263"
},
{
- "distinct_range": 5,
- "num_eq": 126,
- "num_range": 414,
- "upper_bound": "2196"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "278"
},
{
- "distinct_range": 4,
- "num_eq": 72,
- "num_range": 378,
- "upper_bound": "2201"
+ "distinct_range": 16,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "295"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 432,
- "upper_bound": "2205"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "308"
},
{
- "distinct_range": 4,
- "num_eq": 117,
- "num_range": 351,
- "upper_bound": "2210"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "322"
},
{
- "distinct_range": 6,
- "num_eq": 126,
- "num_range": 369,
- "upper_bound": "2217"
+ "distinct_range": 14,
+ "num_eq": 180,
+ "num_range": 1320,
+ "upper_bound": "337"
},
{
- "distinct_range": 4,
- "num_eq": 117,
- "num_range": 369,
- "upper_bound": "2222"
+ "distinct_range": 17,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "355"
+ },
+ {
+ "distinct_range": 18,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "374"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 150,
+ "num_range": 1470,
+ "upper_bound": "388"
+ },
+ {
+ "distinct_range": 19,
+ "num_eq": 60,
+ "num_range": 1470,
+ "upper_bound": "408"
+ },
+ {
+ "distinct_range": 20,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "429"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 423,
- "upper_bound": "2227"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1470,
+ "upper_bound": "444"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 342,
- "upper_bound": "2232"
+ "distinct_range": 17,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "462"
},
{
- "distinct_range": 4,
- "num_eq": 144,
- "num_range": 360,
- "upper_bound": "2237"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "475"
},
{
- "distinct_range": 4,
- "num_eq": 117,
- "num_range": 360,
- "upper_bound": "2242"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "490"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 360,
- "upper_bound": "2247"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "506"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 396,
- "upper_bound": "2252"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "521"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 405,
- "upper_bound": "2257"
+ "distinct_range": 15,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "537"
},
{
- "distinct_range": 5,
- "num_eq": 81,
- "num_range": 432,
- "upper_bound": "2263"
+ "distinct_range": 19,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "557"
},
{
- "distinct_range": 4,
- "num_eq": 72,
- "num_range": 396,
- "upper_bound": "2268"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "574"
},
{
- "distinct_range": 4,
- "num_eq": 54,
- "num_range": 396,
- "upper_bound": "2273"
+ "distinct_range": 11,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "586"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 342,
- "upper_bound": "2278"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "601"
},
{
- "distinct_range": 5,
- "num_eq": 81,
- "num_range": 414,
- "upper_bound": "2284"
+ "distinct_range": 13,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "615"
},
{
- "distinct_range": 5,
- "num_eq": 72,
- "num_range": 414,
- "upper_bound": "2290"
+ "distinct_range": 16,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "632"
},
{
- "distinct_range": 3,
+ "distinct_range": 12,
"num_eq": 90,
- "num_range": 351,
- "upper_bound": "2294"
+ "num_range": 1380,
+ "upper_bound": "645"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 405,
- "upper_bound": "2299"
+ "distinct_range": 19,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "665"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 333,
- "upper_bound": "2303"
+ "distinct_range": 16,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "682"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 333,
- "upper_bound": "2308"
+ "distinct_range": 17,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "700"
},
{
- "distinct_range": 4,
- "num_eq": 54,
- "num_range": 432,
- "upper_bound": "2313"
+ "distinct_range": 16,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "717"
},
{
- "distinct_range": 4,
- "num_eq": 135,
- "num_range": 360,
- "upper_bound": "2318"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "733"
},
{
- "distinct_range": 2,
- "num_eq": 117,
- "num_range": 315,
- "upper_bound": "2321"
+ "distinct_range": 15,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "749"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 333,
- "upper_bound": "2325"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "764"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 369,
- "upper_bound": "2330"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "779"
},
{
- "distinct_range": 4,
- "num_eq": 63,
- "num_range": 405,
- "upper_bound": "2335"
+ "distinct_range": 17,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "797"
},
{
- "distinct_range": 4,
- "num_eq": 171,
- "num_range": 378,
- "upper_bound": "2340"
+ "distinct_range": 14,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "812"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 396,
- "upper_bound": "2345"
+ "distinct_range": 11,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "824"
},
{
- "distinct_range": 4,
- "num_eq": 135,
- "num_range": 360,
- "upper_bound": "2350"
+ "distinct_range": 12,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "837"
},
{
- "distinct_range": 4,
- "num_eq": 63,
- "num_range": 423,
- "upper_bound": "2355"
+ "distinct_range": 10,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "848"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 315,
- "upper_bound": "2359"
+ "distinct_range": 12,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "861"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 324,
- "upper_bound": "2363"
+ "distinct_range": 17,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "879"
},
{
- "distinct_range": 3,
- "num_eq": 153,
- "num_range": 279,
- "upper_bound": "2367"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "894"
},
{
- "distinct_range": 4,
- "num_eq": 90,
- "num_range": 342,
- "upper_bound": "2372"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "911"
},
{
- "distinct_range": 4,
- "num_eq": 63,
- "num_range": 387,
- "upper_bound": "2377"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "924"
},
{
- "distinct_range": 2,
- "num_eq": 153,
- "num_range": 288,
- "upper_bound": "2380"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "937"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 351,
- "upper_bound": "2385"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "952"
},
{
- "distinct_range": 4,
- "num_eq": 180,
- "num_range": 396,
- "upper_bound": "2390"
+ "distinct_range": 15,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "968"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 297,
- "upper_bound": "2394"
+ "distinct_range": 14,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "983"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 387,
- "upper_bound": "2399"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1000"
},
{
- "distinct_range": 4,
- "num_eq": 153,
- "num_range": 360,
- "upper_bound": "2404"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1015"
},
{
- "distinct_range": 4,
- "num_eq": 144,
- "num_range": 414,
- "upper_bound": "2409"
+ "distinct_range": 14,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1030"
},
{
- "distinct_range": 4,
- "num_eq": 54,
- "num_range": 414,
- "upper_bound": "2414"
+ "distinct_range": 15,
+ "num_eq": 180,
+ "num_range": 1290,
+ "upper_bound": "1046"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 333,
- "upper_bound": "2418"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1061"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 333,
- "upper_bound": "2422"
+ "distinct_range": 16,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1078"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 387,
- "upper_bound": "2426"
+ "distinct_range": 17,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1096"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 423,
- "upper_bound": "2431"
+ "distinct_range": 17,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1114"
},
{
- "distinct_range": 4,
- "num_eq": 72,
- "num_range": 387,
- "upper_bound": "2436"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1129"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 342,
- "upper_bound": "2440"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1146"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 315,
- "upper_bound": "2444"
+ "distinct_range": 13,
+ "num_eq": 210,
+ "num_range": 1260,
+ "upper_bound": "1160"
},
{
- "distinct_range": 4,
- "num_eq": 45,
- "num_range": 396,
- "upper_bound": "2449"
+ "distinct_range": 18,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1179"
},
{
- "distinct_range": 4,
- "num_eq": 117,
- "num_range": 405,
- "upper_bound": "2454"
+ "distinct_range": 12,
+ "num_eq": 120,
+ "num_range": 1440,
+ "upper_bound": "1192"
},
{
- "distinct_range": 5,
- "num_eq": 72,
- "num_range": 405,
- "upper_bound": "2460"
+ "distinct_range": 14,
+ "num_eq": 180,
+ "num_range": 1350,
+ "upper_bound": "1207"
},
{
- "distinct_range": 4,
- "num_eq": 135,
- "num_range": 378,
- "upper_bound": "2465"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1222"
},
{
- "distinct_range": 5,
- "num_eq": 63,
- "num_range": 396,
- "upper_bound": "2471"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1236"
},
{
- "distinct_range": 4,
- "num_eq": 117,
- "num_range": 351,
- "upper_bound": "2476"
+ "distinct_range": 15,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1252"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 297,
- "upper_bound": "2480"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1268"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 360,
- "upper_bound": "2484"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1283"
},
{
- "distinct_range": 3,
- "num_eq": 54,
- "num_range": 378,
- "upper_bound": "2488"
+ "distinct_range": 16,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1300"
},
{
- "distinct_range": 4,
- "num_eq": 189,
- "num_range": 396,
- "upper_bound": "2493"
+ "distinct_range": 13,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "1314"
},
{
- "distinct_range": 4,
- "num_eq": 90,
- "num_range": 342,
- "upper_bound": "2498"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1329"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 378,
- "upper_bound": "2503"
+ "distinct_range": 10,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1340"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 342,
- "upper_bound": "2507"
+ "distinct_range": 11,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1352"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 396,
- "upper_bound": "2511"
+ "distinct_range": 17,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "1370"
},
{
- "distinct_range": 4,
+ "distinct_range": 14,
"num_eq": 90,
- "num_range": 378,
- "upper_bound": "2516"
+ "num_range": 1410,
+ "upper_bound": "1385"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 315,
- "upper_bound": "2520"
+ "distinct_range": 15,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1401"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 297,
- "upper_bound": "2524"
+ "distinct_range": 15,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1417"
},
{
- "distinct_range": 5,
- "num_eq": 117,
- "num_range": 396,
- "upper_bound": "2530"
+ "distinct_range": 11,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1429"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 351,
- "upper_bound": "2535"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1444"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 405,
- "upper_bound": "2540"
+ "distinct_range": 12,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1457"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 405,
- "upper_bound": "2545"
+ "distinct_range": 13,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1471"
},
{
- "distinct_range": 3,
- "num_eq": 99,
- "num_range": 360,
- "upper_bound": "2549"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1487"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 342,
- "upper_bound": "2554"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1502"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 369,
- "upper_bound": "2559"
+ "distinct_range": 13,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1516"
},
{
- "distinct_range": 5,
- "num_eq": 99,
- "num_range": 414,
- "upper_bound": "2565"
+ "distinct_range": 11,
+ "num_eq": 60,
+ "num_range": 1440,
+ "upper_bound": "1528"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 306,
- "upper_bound": "2569"
+ "distinct_range": 15,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1544"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 306,
- "upper_bound": "2573"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1560"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 333,
- "upper_bound": "2578"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1380,
+ "upper_bound": "1576"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 387,
- "upper_bound": "2582"
+ "distinct_range": 13,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1590"
},
{
- "distinct_range": 3,
- "num_eq": 54,
- "num_range": 360,
- "upper_bound": "2586"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1607"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 360,
- "upper_bound": "2590"
+ "distinct_range": 11,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1619"
},
{
- "distinct_range": 3,
- "num_eq": 81,
- "num_range": 351,
- "upper_bound": "2594"
+ "distinct_range": 12,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "1632"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 342,
- "upper_bound": "2599"
+ "distinct_range": 17,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "1650"
},
{
- "distinct_range": 4,
- "num_eq": 135,
- "num_range": 405,
- "upper_bound": "2604"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1663"
},
{
- "distinct_range": 4,
- "num_eq": 54,
- "num_range": 369,
- "upper_bound": "2609"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1677"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 333,
- "upper_bound": "2614"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "1692"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 324,
- "upper_bound": "2618"
+ "distinct_range": 13,
+ "num_eq": 210,
+ "num_range": 1440,
+ "upper_bound": "1706"
},
{
- "distinct_range": 4,
- "num_eq": 72,
- "num_range": 396,
- "upper_bound": "2623"
+ "distinct_range": 11,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "1718"
},
{
- "distinct_range": 5,
+ "distinct_range": 11,
"num_eq": 90,
- "num_range": 342,
- "upper_bound": "2629"
+ "num_range": 1380,
+ "upper_bound": "1730"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 351,
- "upper_bound": "2634"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "1746"
},
{
- "distinct_range": 5,
- "num_eq": 45,
- "num_range": 396,
- "upper_bound": "2640"
+ "distinct_range": 16,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1763"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 387,
- "upper_bound": "2645"
+ "distinct_range": 17,
+ "num_eq": 90,
+ "num_range": 1410,
+ "upper_bound": "1781"
},
{
- "distinct_range": 2,
- "num_eq": 126,
- "num_range": 351,
- "upper_bound": "2648"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "1795"
},
{
- "distinct_range": 4,
- "num_eq": 153,
- "num_range": 342,
- "upper_bound": "2653"
+ "distinct_range": 16,
+ "num_eq": 240,
+ "num_range": 1440,
+ "upper_bound": "1812"
},
{
- "distinct_range": 3,
- "num_eq": 171,
- "num_range": 405,
- "upper_bound": "2657"
+ "distinct_range": 13,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "1826"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 315,
- "upper_bound": "2662"
+ "distinct_range": 16,
+ "num_eq": 30,
+ "num_range": 1440,
+ "upper_bound": "1843"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 369,
- "upper_bound": "2666"
+ "distinct_range": 12,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "1856"
},
{
- "distinct_range": 4,
- "num_eq": 63,
- "num_range": 351,
- "upper_bound": "2671"
+ "distinct_range": 13,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1870"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 297,
- "upper_bound": "2675"
+ "distinct_range": 15,
+ "num_eq": 240,
+ "num_range": 1380,
+ "upper_bound": "1886"
},
{
- "distinct_range": 3,
- "num_eq": 162,
- "num_range": 333,
- "upper_bound": "2679"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1903"
},
{
- "distinct_range": 3,
- "num_eq": 153,
- "num_range": 270,
- "upper_bound": "2683"
+ "distinct_range": 12,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1916"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 324,
- "upper_bound": "2688"
+ "distinct_range": 19,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "1936"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 306,
- "upper_bound": "2692"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1951"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 396,
- "upper_bound": "2697"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1440,
+ "upper_bound": "1964"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 306,
- "upper_bound": "2701"
+ "distinct_range": 16,
+ "num_eq": 150,
+ "num_range": 1440,
+ "upper_bound": "1981"
},
{
- "distinct_range": 5,
- "num_eq": 135,
- "num_range": 351,
- "upper_bound": "2707"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "1997"
},
{
- "distinct_range": 3,
- "num_eq": 54,
- "num_range": 351,
- "upper_bound": "2711"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2011"
},
{
- "distinct_range": 4,
- "num_eq": 135,
- "num_range": 351,
- "upper_bound": "2716"
+ "distinct_range": 13,
+ "num_eq": 210,
+ "num_range": 1410,
+ "upper_bound": "2025"
},
{
- "distinct_range": 3,
- "num_eq": 72,
- "num_range": 342,
- "upper_bound": "2720"
+ "distinct_range": 14,
+ "num_eq": 210,
+ "num_range": 1380,
+ "upper_bound": "2040"
},
{
- "distinct_range": 3,
- "num_eq": 153,
- "num_range": 396,
- "upper_bound": "2724"
+ "distinct_range": 15,
+ "num_eq": 210,
+ "num_range": 1320,
+ "upper_bound": "2056"
},
{
- "distinct_range": 4,
- "num_eq": 135,
- "num_range": 369,
- "upper_bound": "2729"
+ "distinct_range": 10,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2067"
},
{
- "distinct_range": 4,
- "num_eq": 126,
- "num_range": 378,
- "upper_bound": "2734"
+ "distinct_range": 11,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2079"
},
{
- "distinct_range": 4,
- "num_eq": 117,
- "num_range": 297,
- "upper_bound": "2739"
+ "distinct_range": 14,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2094"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 360,
- "upper_bound": "2743"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2109"
},
{
- "distinct_range": 4,
+ "distinct_range": 16,
"num_eq": 90,
- "num_range": 333,
- "upper_bound": "2748"
+ "num_range": 1350,
+ "upper_bound": "2126"
},
{
- "distinct_range": 5,
- "num_eq": 117,
- "num_range": 351,
- "upper_bound": "2754"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2140"
},
{
- "distinct_range": 4,
+ "distinct_range": 12,
"num_eq": 90,
- "num_range": 360,
- "upper_bound": "2759"
- },
- {
- "distinct_range": 4,
- "num_eq": 153,
- "num_range": 387,
- "upper_bound": "2764"
+ "num_range": 1410,
+ "upper_bound": "2153"
},
{
- "distinct_range": 3,
- "num_eq": 81,
- "num_range": 369,
- "upper_bound": "2768"
+ "distinct_range": 13,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2167"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 315,
- "upper_bound": "2772"
+ "distinct_range": 15,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2183"
},
{
- "distinct_range": 3,
- "num_eq": 63,
- "num_range": 324,
- "upper_bound": "2776"
+ "distinct_range": 17,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2201"
},
{
- "distinct_range": 4,
- "num_eq": 90,
- "num_range": 315,
- "upper_bound": "2781"
+ "distinct_range": 21,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2223"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 297,
- "upper_bound": "2785"
+ "distinct_range": 14,
+ "num_eq": 180,
+ "num_range": 1410,
+ "upper_bound": "2238"
},
{
- "distinct_range": 4,
+ "distinct_range": 15,
"num_eq": 90,
- "num_range": 315,
- "upper_bound": "2790"
+ "num_range": 1410,
+ "upper_bound": "2254"
},
{
- "distinct_range": 3,
- "num_eq": 81,
- "num_range": 306,
- "upper_bound": "2794"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2269"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 315,
- "upper_bound": "2798"
+ "distinct_range": 13,
+ "num_eq": 240,
+ "num_range": 1290,
+ "upper_bound": "2283"
},
{
- "distinct_range": 4,
- "num_eq": 108,
- "num_range": 378,
- "upper_bound": "2803"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1380,
+ "upper_bound": "2296"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 342,
- "upper_bound": "2807"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1410,
+ "upper_bound": "2311"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 306,
- "upper_bound": "2811"
+ "distinct_range": 13,
+ "num_eq": 30,
+ "num_range": 1410,
+ "upper_bound": "2325"
},
{
- "distinct_range": 3,
- "num_eq": 90,
- "num_range": 324,
- "upper_bound": "2815"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2340"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 360,
- "upper_bound": "2819"
+ "distinct_range": 12,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2353"
},
{
- "distinct_range": 2,
- "num_eq": 180,
- "num_range": 252,
- "upper_bound": "2822"
+ "distinct_range": 13,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2367"
},
{
- "distinct_range": 3,
- "num_eq": 144,
- "num_range": 333,
- "upper_bound": "2826"
+ "distinct_range": 18,
+ "num_eq": 150,
+ "num_range": 1410,
+ "upper_bound": "2386"
},
{
- "distinct_range": 4,
- "num_eq": 99,
- "num_range": 360,
- "upper_bound": "2831"
+ "distinct_range": 17,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2404"
},
{
- "distinct_range": 5,
- "num_eq": 135,
- "num_range": 369,
- "upper_bound": "2837"
+ "distinct_range": 15,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2420"
},
{
- "distinct_range": 3,
- "num_eq": 126,
- "num_range": 279,
- "upper_bound": "2841"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2435"
},
{
- "distinct_range": 3,
- "num_eq": 117,
- "num_range": 315,
- "upper_bound": "2845"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2449"
},
{
- "distinct_range": 3,
- "num_eq": 90,
- "num_range": 297,
- "upper_bound": "2849"
+ "distinct_range": 13,
+ "num_eq": 240,
+ "num_range": 1230,
+ "upper_bound": "2463"
},
{
- "distinct_range": 3,
- "num_eq": 81,
- "num_range": 351,
- "upper_bound": "2853"
+ "distinct_range": 14,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2478"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 306,
- "upper_bound": "2858"
+ "distinct_range": 12,
+ "num_eq": 240,
+ "num_range": 1350,
+ "upper_bound": "2491"
},
{
- "distinct_range": 2,
- "num_eq": 126,
- "num_range": 279,
- "upper_bound": "2861"
+ "distinct_range": 17,
+ "num_eq": 120,
+ "num_range": 1410,
+ "upper_bound": "2509"
},
{
- "distinct_range": 2,
- "num_eq": 135,
- "num_range": 252,
- "upper_bound": "2864"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2523"
},
{
- "distinct_range": 3,
- "num_eq": 90,
- "num_range": 315,
- "upper_bound": "2868"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2538"
},
{
- "distinct_range": 3,
- "num_eq": 99,
- "num_range": 279,
- "upper_bound": "2872"
+ "distinct_range": 11,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2550"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 288,
- "upper_bound": "2877"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1380,
+ "upper_bound": "2567"
},
{
- "distinct_range": 4,
- "num_eq": 90,
- "num_range": 351,
- "upper_bound": "2882"
+ "distinct_range": 16,
+ "num_eq": 60,
+ "num_range": 1350,
+ "upper_bound": "2584"
},
{
- "distinct_range": 3,
- "num_eq": 99,
- "num_range": 324,
- "upper_bound": "2886"
+ "distinct_range": 18,
+ "num_eq": 240,
+ "num_range": 1320,
+ "upper_bound": "2603"
},
{
- "distinct_range": 3,
- "num_eq": 153,
- "num_range": 207,
- "upper_bound": "2890"
+ "distinct_range": 14,
+ "num_eq": 270,
+ "num_range": 1230,
+ "upper_bound": "2618"
},
{
- "distinct_range": 3,
- "num_eq": 153,
- "num_range": 261,
- "upper_bound": "2894"
+ "distinct_range": 17,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2636"
},
{
- "distinct_range": 4,
- "num_eq": 81,
- "num_range": 306,
- "upper_bound": "2899"
+ "distinct_range": 13,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2650"
},
{
- "distinct_range": 3,
- "num_eq": 135,
- "num_range": 243,
- "upper_bound": "2903"
+ "distinct_range": 17,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2668"
},
{
- "distinct_range": 4,
- "num_eq": 72,
- "num_range": 351,
- "upper_bound": "2908"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1290,
+ "upper_bound": "2683"
},
{
- "distinct_range": 3,
- "num_eq": 54,
- "num_range": 351,
- "upper_bound": "2912"
+ "distinct_range": 16,
+ "num_eq": 120,
+ "num_range": 1290,
+ "upper_bound": "2700"
},
{
- "distinct_range": 3,
+ "distinct_range": 14,
"num_eq": 90,
- "num_range": 288,
- "upper_bound": "2916"
+ "num_range": 1380,
+ "upper_bound": "2715"
},
{
- "distinct_range": 3,
- "num_eq": 81,
- "num_range": 342,
- "upper_bound": "2920"
+ "distinct_range": 12,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2728"
},
{
- "distinct_range": 3,
- "num_eq": 108,
- "num_range": 288,
- "upper_bound": "2924"
+ "distinct_range": 10,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2739"
},
{
- "distinct_range": 3,
- "num_eq": 90,
- "num_range": 333,
- "upper_bound": "2928"
+ "distinct_range": 14,
+ "num_eq": 150,
+ "num_range": 1260,
+ "upper_bound": "2754"
},
{
- "distinct_range": 3,
- "num_eq": 99,
- "num_range": 324,
- "upper_bound": "2932"
+ "distinct_range": 16,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2771"
},
{
- "distinct_range": 4,
- "num_eq": 54,
- "num_range": 333,
- "upper_bound": "2937"
+ "distinct_range": 12,
+ "num_eq": 180,
+ "num_range": 1380,
+ "upper_bound": "2784"
},
{
- "distinct_range": 2,
- "num_eq": 144,
- "num_range": 234,
- "upper_bound": "2940"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2797"
},
{
- "distinct_range": 3,
- "num_eq": 72,
- "num_range": 297,
- "upper_bound": "2944"
+ "distinct_range": 12,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "2810"
},
{
- "distinct_range": 3,
- "num_eq": 99,
- "num_range": 297,
- "upper_bound": "2948"
+ "distinct_range": 14,
+ "num_eq": 60,
+ "num_range": 1380,
+ "upper_bound": "2825"
},
{
- "distinct_range": 3,
- "num_eq": 162,
- "num_range": 252,
- "upper_bound": "2952"
+ "distinct_range": 15,
+ "num_eq": 150,
+ "num_range": 1320,
+ "upper_bound": "2841"
},
{
- "distinct_range": 2,
- "num_eq": 108,
- "num_range": 252,
- "upper_bound": "2955"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2854"
},
{
- "distinct_range": 4,
+ "distinct_range": 12,
"num_eq": 90,
- "num_range": 279,
- "upper_bound": "2960"
+ "num_range": 1350,
+ "upper_bound": "2867"
},
{
- "distinct_range": 2,
- "num_eq": 126,
- "num_range": 207,
- "upper_bound": "2963"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1350,
+ "upper_bound": "2880"
},
{
- "distinct_range": 2,
- "num_eq": 108,
- "num_range": 252,
- "upper_bound": "2966"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1350,
+ "upper_bound": "2894"
},
{
- "distinct_range": 3,
- "num_eq": 72,
- "num_range": 261,
- "upper_bound": "2970"
+ "distinct_range": 12,
+ "num_eq": 150,
+ "num_range": 1350,
+ "upper_bound": "2907"
},
{
- "distinct_range": 3,
- "num_eq": 99,
- "num_range": 270,
- "upper_bound": "2974"
+ "distinct_range": 14,
+ "num_eq": 90,
+ "num_range": 1320,
+ "upper_bound": "2922"
},
{
- "distinct_range": 2,
- "num_eq": 189,
- "num_range": 198,
- "upper_bound": "2977"
+ "distinct_range": 13,
+ "num_eq": 120,
+ "num_range": 1260,
+ "upper_bound": "2936"
},
{
- "distinct_range": 2,
- "num_eq": 81,
- "num_range": 270,
- "upper_bound": "2980"
+ "distinct_range": 12,
+ "num_eq": 90,
+ "num_range": 1290,
+ "upper_bound": "2949"
},
{
- "distinct_range": 2,
+ "distinct_range": 15,
+ "num_eq": 120,
+ "num_range": 1320,
+ "upper_bound": "2965"
+ },
+ {
+ "distinct_range": 11,
"num_eq": 90,
- "num_range": 234,
- "upper_bound": "2983"
+ "num_range": 1230,
+ "upper_bound": "2977"
},
{
- "distinct_range": 2,
- "num_eq": 99,
- "num_range": 234,
- "upper_bound": "2986"
+ "distinct_range": 10,
+ "num_eq": 180,
+ "num_range": 1260,
+ "upper_bound": "2988"
},
{
- "distinct_range": 2,
- "num_eq": 126,
- "num_range": 180,
- "upper_bound": "2989"
- },
+ "distinct_range": 10,
+ "num_eq": 210,
+ "num_range": 990,
+ "upper_bound": "2999"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "o_w_id",
+ "o_d_id",
+ "o_c_id"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 295745,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 8,
+ "columns": [
+ "o_w_id",
+ "o_d_id",
+ "o_c_id",
+ "o_id"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 298416,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 7,
+ "columns": [
+ "o_entry_d"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "2006-01-02 15:04:05"
+ }
+ ],
+ "histo_col_type": "TIMESTAMP",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "o_carrier_id"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 11,
+ "histo_buckets": [
{
- "distinct_range": 2,
- "num_eq": 117,
- "num_range": 261,
- "upper_bound": "2992"
+ "distinct_range": 0,
+ "num_eq": 21169,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 2,
- "num_eq": 99,
- "num_range": 216,
- "upper_bound": "2995"
- },
+ "distinct_range": 8,
+ "num_eq": 21318,
+ "num_range": 167513,
+ "upper_bound": "10"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 90000,
+ "row_count": 300000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "o_ol_cnt"
+ ],
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 11,
+ "histo_buckets": [
{
- "distinct_range": 2,
- "num_eq": 99,
- "num_range": 171,
- "upper_bound": "2998"
+ "distinct_range": 0,
+ "num_eq": 26550,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 1,
- "num_eq": 108,
- "num_range": 117,
- "upper_bound": "3000"
+ "distinct_range": 9,
+ "num_eq": 26490,
+ "num_range": 246960,
+ "upper_bound": "15"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 90000
+ "row_count": 300000
},
{
+ "avg_size": 2,
"columns": [
- "no_w_id",
- "no_d_id",
- "no_o_id"
+ "o_all_local"
],
- "created_at": "2021-09-08 20:48:10.067968",
- "distinct_count": 90000,
- "histo_col_type": "",
+ "created_at": "2022-02-25 01:09:20.242426",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 300000,
+ "num_range": 0,
+ "upper_bound": "1"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 90000
+ "row_count": 300000
}
]';
----
exec-ddl
-ALTER TABLE "order" INJECT STATISTICS '[
+ALTER TABLE "order_line" INJECT STATISTICS '[
{
+ "avg_size": 1,
"columns": [
- "o_w_id"
+ "ol_w_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
+ "created_at": "2022-02-25 01:08:12.56776",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 31260,
+ "num_eq": 197231,
"num_range": 0,
"upper_bound": "0"
},
{
"distinct_range": 0,
- "num_eq": 29820,
+ "num_eq": 135266,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 29520,
+ "num_eq": 167258,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 30000,
+ "num_eq": 162910,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 29670,
+ "num_eq": 127812,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 29340,
+ "num_eq": 189311,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 28530,
+ "num_eq": 135577,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 29760,
+ "num_eq": 153436,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 30810,
+ "num_eq": 170675,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 31290,
+ "num_eq": 113524,
"num_range": 0,
"upper_bound": "9"
}
@@ -8861,72 +23217,73 @@ ALTER TABLE "order" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 1553000
},
{
+ "avg_size": 1,
"columns": [
- "o_d_id"
+ "ol_d_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
+ "created_at": "2022-02-25 01:08:12.56776",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 30450,
+ "num_eq": 158717,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 29880,
+ "num_eq": 168345,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 31230,
+ "num_eq": 146137,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 29850,
+ "num_eq": 145516,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 28410,
+ "num_eq": 144740,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 29250,
+ "num_eq": 170985,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 29580,
+ "num_eq": 174713,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 30840,
+ "num_eq": 150796,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 30450,
+ "num_eq": 147224,
"num_range": 0,
"upper_bound": "9"
},
{
"distinct_range": 0,
- "num_eq": 30060,
+ "num_eq": 145827,
"num_range": 0,
"upper_bound": "10"
}
@@ -8935,4303 +23292,4942 @@ ALTER TABLE "order" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 1553000
},
{
+ "avg_size": 2,
"columns": [
- "o_w_id",
- "o_d_id"
+ "ol_w_id",
+ "ol_d_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 100,
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 67,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 1553000
},
{
+ "avg_size": 3,
"columns": [
- "o_id"
+ "ol_o_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
+ "created_at": "2022-02-25 01:08:12.56776",
"distinct_count": 2999,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 60,
+ "num_eq": 155,
"num_range": 0,
"upper_bound": "1"
},
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 932,
+ "num_range": 7299,
+ "upper_bound": "15"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "31"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "48"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "65"
+ },
{
"distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "14"
+ "num_eq": 311,
+ "num_range": 7610,
+ "upper_bound": "78"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "93"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "30"
+ "num_eq": 311,
+ "num_range": 7610,
+ "upper_bound": "109"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "127"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "143"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "158"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 932,
+ "num_range": 6988,
+ "upper_bound": "175"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "192"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1470,
- "upper_bound": "44"
+ "num_eq": 311,
+ "num_range": 7610,
+ "upper_bound": "206"
},
{
- "distinct_range": 8.996785714285714,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "54"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "221"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 7610,
+ "upper_bound": "236"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "253"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "68"
+ "num_eq": 311,
+ "num_range": 7610,
+ "upper_bound": "267"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "81"
+ "num_eq": 932,
+ "num_range": 6833,
+ "upper_bound": "280"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "98"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "296"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 1087,
+ "num_range": 6833,
+ "upper_bound": "308"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "111"
+ "num_eq": 1242,
+ "num_range": 7144,
+ "upper_bound": "321"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "125"
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "335"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "138"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "347"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "157"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7610,
+ "upper_bound": "364"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 776,
+ "num_range": 7454,
+ "upper_bound": "379"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 1087,
+ "num_range": 7144,
+ "upper_bound": "394"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 311,
+ "num_range": 7610,
+ "upper_bound": "409"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 1242,
+ "num_range": 6678,
+ "upper_bound": "426"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "444"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "173"
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "460"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "188"
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "475"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 1398,
+ "num_range": 7454,
+ "upper_bound": "492"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "203"
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "507"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 311,
+ "num_range": 7610,
+ "upper_bound": "527"
+ },
+ {
+ "distinct_range": 17.99357142857143,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "546"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "558"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "219"
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "574"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "589"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "601"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "613"
},
{
- "distinct_range": 19.992857142857144,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "240"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "631"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 240,
- "num_range": 1320,
- "upper_bound": "255"
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "646"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "272"
- },
- {
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "287"
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "663"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1470,
- "upper_bound": "303"
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "679"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "320"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "697"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "333"
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "710"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "349"
+ "distinct_range": 18.993214285714288,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "730"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "360"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 776,
+ "num_range": 6833,
+ "upper_bound": "747"
+ },
+ {
+ "distinct_range": 10.99607142857143,
+ "num_eq": 776,
+ "num_range": 7454,
+ "upper_bound": "759"
},
{
"distinct_range": 17.99357142857143,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "379"
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "778"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 270,
- "num_range": 1320,
- "upper_bound": "393"
+ "num_eq": 776,
+ "num_range": 7144,
+ "upper_bound": "792"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "408"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "804"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1470,
- "upper_bound": "424"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 776,
+ "num_range": 7144,
+ "upper_bound": "822"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "439"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "841"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "458"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 776,
+ "num_range": 7144,
+ "upper_bound": "855"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "474"
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "871"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "489"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 776,
+ "num_range": 7454,
+ "upper_bound": "889"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "506"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "904"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "519"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "918"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "532"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "932"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "549"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "947"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 240,
- "num_range": 1230,
- "upper_bound": "563"
+ "num_eq": 776,
+ "num_range": 7144,
+ "upper_bound": "961"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "577"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "976"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "593"
- },
- {
- "distinct_range": 18.993214285714288,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "613"
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "992"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 240,
- "num_range": 1230,
- "upper_bound": "627"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 1398,
+ "num_range": 7144,
+ "upper_bound": "1003"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1410,
- "upper_bound": "642"
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "1018"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "658"
+ "num_eq": 776,
+ "num_range": 6833,
+ "upper_bound": "1034"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 240,
- "num_range": 1380,
- "upper_bound": "676"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "1047"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 300,
- "num_range": 1320,
- "upper_bound": "691"
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1062"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "705"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "1075"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "720"
+ "num_eq": 155,
+ "num_range": 7454,
+ "upper_bound": "1090"
+ },
+ {
+ "distinct_range": 16.993928571428572,
+ "num_eq": 155,
+ "num_range": 7454,
+ "upper_bound": "1108"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 210,
- "num_range": 1290,
- "upper_bound": "736"
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1124"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 240,
- "num_range": 1440,
- "upper_bound": "749"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 932,
+ "num_range": 7454,
+ "upper_bound": "1138"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "767"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "1155"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "782"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "1168"
},
{
"distinct_range": 10.99607142857143,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "794"
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "1180"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "808"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "1197"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "825"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 1242,
+ "num_range": 6833,
+ "upper_bound": "1212"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "839"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 932,
+ "num_range": 7144,
+ "upper_bound": "1225"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "856"
+ "num_eq": 932,
+ "num_range": 7454,
+ "upper_bound": "1242"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 300,
- "num_range": 1230,
- "upper_bound": "868"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 776,
+ "num_range": 7144,
+ "upper_bound": "1261"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "885"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "1279"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "899"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "1295"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "914"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 932,
+ "num_range": 6988,
+ "upper_bound": "1311"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "930"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "1323"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1337"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "946"
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "1353"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 30,
- "num_range": 1440,
- "upper_bound": "963"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "1371"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "982"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "1389"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "998"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1402"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1440,
- "upper_bound": "1014"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "1417"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 1242,
+ "num_range": 7454,
+ "upper_bound": "1430"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 240,
- "num_range": 1290,
- "upper_bound": "1029"
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "1445"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 1087,
+ "num_range": 6833,
+ "upper_bound": "1458"
},
{
"distinct_range": 16.993928571428572,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1047"
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "1476"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1064"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "1490"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1080"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 932,
+ "num_range": 7299,
+ "upper_bound": "1503"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1095"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "1519"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1110"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "1538"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 240,
- "num_range": 1350,
- "upper_bound": "1126"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "1550"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1143"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "1569"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1161"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "1582"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1176"
+ "num_eq": 776,
+ "num_range": 7454,
+ "upper_bound": "1597"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1190"
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "1611"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1204"
+ "num_eq": 155,
+ "num_range": 7454,
+ "upper_bound": "1625"
},
{
- "distinct_range": 19.992857142857144,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1225"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "1640"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1410,
- "upper_bound": "1240"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "1657"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "1255"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 1242,
+ "num_range": 6678,
+ "upper_bound": "1674"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 330,
- "num_range": 1170,
- "upper_bound": "1271"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 1087,
+ "num_range": 6988,
+ "upper_bound": "1686"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "1285"
+ "num_eq": 932,
+ "num_range": 6988,
+ "upper_bound": "1700"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 270,
- "num_range": 1290,
- "upper_bound": "1302"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "1719"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "1735"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 300,
- "num_range": 1200,
- "upper_bound": "1317"
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "1750"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1333"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 1242,
+ "num_range": 6523,
+ "upper_bound": "1763"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1348"
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "1778"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1364"
+ "num_eq": 776,
+ "num_range": 7454,
+ "upper_bound": "1794"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1379"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 1087,
+ "num_range": 7144,
+ "upper_bound": "1806"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1396"
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1823"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1412"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "1837"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "1427"
- },
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "1443"
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "1852"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "1456"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1866"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1474"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 1087,
+ "num_range": 7454,
+ "upper_bound": "1880"
},
{
- "distinct_range": 8.996785714285714,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "1484"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "1894"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "1500"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 1087,
+ "num_range": 6833,
+ "upper_bound": "1909"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1512"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7454,
+ "upper_bound": "1926"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1528"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "1943"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1543"
+ "num_eq": 155,
+ "num_range": 7454,
+ "upper_bound": "1958"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1559"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 776,
+ "num_range": 6833,
+ "upper_bound": "1977"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1576"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "1992"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "1592"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 466,
+ "num_range": 7454,
+ "upper_bound": "2007"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1606"
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "2021"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "1619"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 311,
+ "num_range": 7454,
+ "upper_bound": "2033"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "1636"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 155,
+ "num_range": 7299,
+ "upper_bound": "2048"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 180,
- "num_range": 1440,
- "upper_bound": "1655"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "2060"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1669"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 932,
+ "num_range": 7299,
+ "upper_bound": "2075"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1686"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 1087,
+ "num_range": 6833,
+ "upper_bound": "2088"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "1705"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "2102"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1721"
+ "num_eq": 932,
+ "num_range": 6678,
+ "upper_bound": "2118"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1734"
+ "num_eq": 932,
+ "num_range": 6678,
+ "upper_bound": "2131"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1746"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "2146"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1761"
+ "num_eq": 1242,
+ "num_range": 6988,
+ "upper_bound": "2161"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1777"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "2173"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1789"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "2188"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1803"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 621,
+ "num_range": 6833,
+ "upper_bound": "2200"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "1816"
+ "distinct_range": 17.99357142857143,
+ "num_eq": 155,
+ "num_range": 7299,
+ "upper_bound": "2219"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "1831"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "2235"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "1847"
+ "num_eq": 1087,
+ "num_range": 6833,
+ "upper_bound": "2251"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1861"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "2264"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1875"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "2279"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1893"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 1242,
+ "num_range": 6833,
+ "upper_bound": "2294"
+ },
+ {
+ "distinct_range": 12.995357142857143,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "2308"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1910"
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "2325"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1926"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "2338"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1941"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 1087,
+ "num_range": 6678,
+ "upper_bound": "2355"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1955"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 1087,
+ "num_range": 6523,
+ "upper_bound": "2367"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1966"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 776,
+ "num_range": 7299,
+ "upper_bound": "2380"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "1981"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 932,
+ "num_range": 6523,
+ "upper_bound": "2397"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1996"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "2415"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1290,
- "upper_bound": "2011"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "2432"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "2024"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 466,
+ "num_range": 7144,
+ "upper_bound": "2449"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "2039"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 1553,
+ "num_range": 6833,
+ "upper_bound": "2462"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "2053"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 466,
+ "num_range": 7299,
+ "upper_bound": "2479"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "2067"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 6988,
+ "upper_bound": "2495"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1260,
- "upper_bound": "2083"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 776,
+ "num_range": 6833,
+ "upper_bound": "2507"
},
{
"distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2099"
+ "num_eq": 311,
+ "num_range": 7299,
+ "upper_bound": "2523"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 240,
- "num_range": 1320,
- "upper_bound": "2116"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 621,
+ "num_range": 7299,
+ "upper_bound": "2536"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "2130"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 932,
+ "num_range": 6678,
+ "upper_bound": "2549"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2148"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 1242,
+ "num_range": 6212,
+ "upper_bound": "2560"
},
{
"distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2165"
+ "num_eq": 776,
+ "num_range": 6833,
+ "upper_bound": "2577"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "2182"
+ "distinct_range": 16.993928571428572,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "2595"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2198"
+ "distinct_range": 9.996428571428572,
+ "num_eq": 311,
+ "num_range": 7144,
+ "upper_bound": "2606"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2209"
+ "distinct_range": 12.995357142857143,
+ "num_eq": 466,
+ "num_range": 6833,
+ "upper_bound": "2620"
},
{
"distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "2224"
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "2635"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "2237"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 776,
+ "num_range": 6988,
+ "upper_bound": "2650"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "2251"
+ "num_eq": 776,
+ "num_range": 7144,
+ "upper_bound": "2664"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 270,
- "num_range": 1410,
- "upper_bound": "2270"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 621,
+ "num_range": 7144,
+ "upper_bound": "2677"
+ },
+ {
+ "distinct_range": 11.995714285714286,
+ "num_eq": 932,
+ "num_range": 6678,
+ "upper_bound": "2690"
+ },
+ {
+ "distinct_range": 18.993214285714288,
+ "num_eq": 466,
+ "num_range": 6988,
+ "upper_bound": "2710"
},
{
"distinct_range": 10.99607142857143,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2282"
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "2722"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2293"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 1242,
+ "num_range": 6833,
+ "upper_bound": "2737"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2307"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 932,
+ "num_range": 6523,
+ "upper_bound": "2752"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "2324"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 621,
+ "num_range": 6678,
+ "upper_bound": "2765"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 466,
+ "num_range": 6988,
+ "upper_bound": "2781"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2338"
+ "num_eq": 932,
+ "num_range": 6678,
+ "upper_bound": "2795"
+ },
+ {
+ "distinct_range": 14.994642857142857,
+ "num_eq": 621,
+ "num_range": 6833,
+ "upper_bound": "2811"
+ },
+ {
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 6988,
+ "upper_bound": "2826"
},
{
"distinct_range": 11.995714285714286,
- "num_eq": 300,
- "num_range": 1260,
- "upper_bound": "2351"
+ "num_eq": 776,
+ "num_range": 6833,
+ "upper_bound": "2839"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "2365"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 932,
+ "num_range": 6212,
+ "upper_bound": "2851"
},
{
"distinct_range": 16.993928571428572,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2383"
+ "num_eq": 466,
+ "num_range": 6678,
+ "upper_bound": "2869"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2397"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 621,
+ "num_range": 6523,
+ "upper_bound": "2884"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "2413"
+ "distinct_range": 13.995000000000001,
+ "num_eq": 466,
+ "num_range": 6833,
+ "upper_bound": "2899"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2427"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 621,
+ "num_range": 6833,
+ "upper_bound": "2911"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "2440"
+ "distinct_range": 14.994642857142857,
+ "num_eq": 1242,
+ "num_range": 6212,
+ "upper_bound": "2927"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2453"
+ "distinct_range": 15.994285714285715,
+ "num_eq": 466,
+ "num_range": 6523,
+ "upper_bound": "2944"
+ },
+ {
+ "distinct_range": 15.994285714285715,
+ "num_eq": 776,
+ "num_range": 6678,
+ "upper_bound": "2961"
},
{
"distinct_range": 12.995357142857143,
- "num_eq": 300,
- "num_range": 1230,
- "upper_bound": "2467"
+ "num_eq": 621,
+ "num_range": 6678,
+ "upper_bound": "2975"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2480"
+ "distinct_range": 10.99607142857143,
+ "num_eq": 776,
+ "num_range": 5746,
+ "upper_bound": "2987"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "2494"
+ "distinct_range": 11.995714285714286,
+ "num_eq": 1087,
+ "num_range": 5591,
+ "upper_bound": "3000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "ol_w_id",
+ "ol_d_id",
+ "ol_o_id"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 155952,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "ol_number"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 15,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 155145,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2508"
+ "distinct_range": 0,
+ "num_eq": 160580,
+ "num_range": 0,
+ "upper_bound": "2"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "2523"
+ "distinct_range": 0,
+ "num_eq": 145361,
+ "num_range": 0,
+ "upper_bound": "3"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "2538"
+ "distinct_range": 0,
+ "num_eq": 159027,
+ "num_range": 0,
+ "upper_bound": "4"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1380,
- "upper_bound": "2553"
+ "distinct_range": 0,
+ "num_eq": 152194,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2568"
+ "distinct_range": 0,
+ "num_eq": 138217,
+ "num_range": 0,
+ "upper_bound": "6"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1290,
- "upper_bound": "2586"
+ "distinct_range": 0,
+ "num_eq": 126725,
+ "num_range": 0,
+ "upper_bound": "7"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "2601"
+ "distinct_range": 0,
+ "num_eq": 108865,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2616"
+ "distinct_range": 0,
+ "num_eq": 100634,
+ "num_range": 0,
+ "upper_bound": "9"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1320,
- "upper_bound": "2629"
+ "distinct_range": 0,
+ "num_eq": 84794,
+ "num_range": 0,
+ "upper_bound": "10"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 270,
- "num_range": 1170,
- "upper_bound": "2641"
+ "distinct_range": 0,
+ "num_eq": 70040,
+ "num_range": 0,
+ "upper_bound": "11"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1290,
- "upper_bound": "2655"
+ "distinct_range": 0,
+ "num_eq": 59946,
+ "num_range": 0,
+ "upper_bound": "12"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2669"
+ "distinct_range": 0,
+ "num_eq": 48143,
+ "num_range": 0,
+ "upper_bound": "13"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2684"
+ "distinct_range": 0,
+ "num_eq": 29196,
+ "num_range": 0,
+ "upper_bound": "14"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2701"
+ "distinct_range": 0,
+ "num_eq": 14132,
+ "num_range": 0,
+ "upper_bound": "15"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 6,
+ "columns": [
+ "ol_w_id",
+ "ol_d_id",
+ "ol_o_id",
+ "ol_number"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 1545580,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 4,
+ "columns": [
+ "ol_i_id"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 99658,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 155,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1230,
- "upper_bound": "2717"
+ "distinct_range": 99656,
+ "num_eq": 155,
+ "num_range": 1552689,
+ "upper_bound": "100000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "ol_supply_w_id"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 197231,
+ "num_range": 0,
+ "upper_bound": "0"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 150,
- "num_range": 1290,
- "upper_bound": "2735"
+ "distinct_range": 8,
+ "num_eq": 113524,
+ "num_range": 1242245,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "ol_delivery_d"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 2,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1086039,
+ "num_range": 0,
+ "upper_bound": "2006-01-02 15:04:05"
+ }
+ ],
+ "histo_col_type": "TIMESTAMP",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 466961,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 2,
+ "columns": [
+ "ol_quantity"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 1,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1553000,
+ "num_range": 0,
+ "upper_bound": "5"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "ol_amount"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 373873,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 1088964,
+ "num_range": 0,
+ "upper_bound": "0"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 90,
- "num_range": 1320,
- "upper_bound": "2747"
+ "distinct_range": 373871,
+ "num_eq": 155,
+ "num_range": 463881,
+ "upper_bound": "9997.27"
+ }
+ ],
+ "histo_col_type": "DECIMAL(6,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "ol_dist_info"
+ ],
+ "created_at": "2022-02-25 01:08:12.56776",
+ "distinct_count": 398,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 7920,
+ "num_range": 0,
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1350,
- "upper_bound": "2760"
+ "distinct_range": 396,
+ "num_eq": 1708,
+ "num_range": 1543371,
+ "upper_bound": "zvh9lctkhRvAvE5H6TtiDNPE"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 1553000
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "ol_w_id"
+ ],
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 290818,
+ "num_range": 0,
+ "upper_bound": "0"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "2774"
+ "distinct_range": 0,
+ "num_eq": 286317,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2789"
+ "distinct_range": 0,
+ "num_eq": 310927,
+ "num_range": 0,
+ "upper_bound": "2"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1350,
- "upper_bound": "2806"
+ "distinct_range": 0,
+ "num_eq": 310927,
+ "num_range": 0,
+ "upper_bound": "3"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2821"
+ "distinct_range": 0,
+ "num_eq": 307325,
+ "num_range": 0,
+ "upper_bound": "4"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2835"
+ "distinct_range": 0,
+ "num_eq": 317829,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "2848"
+ "distinct_range": 0,
+ "num_eq": 289018,
+ "num_range": 0,
+ "upper_bound": "6"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 210,
- "num_range": 1320,
- "upper_bound": "2862"
+ "distinct_range": 0,
+ "num_eq": 303424,
+ "num_range": 0,
+ "upper_bound": "7"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2877"
+ "distinct_range": 0,
+ "num_eq": 289318,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1320,
- "upper_bound": "2892"
+ "distinct_range": 0,
+ "num_eq": 295320,
+ "num_range": 0,
+ "upper_bound": "9"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 3001222
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "ol_d_id"
+ ],
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 10,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 287217,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "2907"
+ "distinct_range": 0,
+ "num_eq": 308225,
+ "num_range": 0,
+ "upper_bound": "2"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 180,
- "num_range": 1230,
- "upper_bound": "2918"
+ "distinct_range": 0,
+ "num_eq": 301623,
+ "num_range": 0,
+ "upper_bound": "3"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
- "num_range": 1260,
- "upper_bound": "2935"
+ "distinct_range": 0,
+ "num_eq": 296821,
+ "num_range": 0,
+ "upper_bound": "4"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1260,
- "upper_bound": "2951"
+ "distinct_range": 0,
+ "num_eq": 310626,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 90,
- "num_range": 1230,
- "upper_bound": "2963"
+ "distinct_range": 0,
+ "num_eq": 302523,
+ "num_range": 0,
+ "upper_bound": "6"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 210,
- "num_range": 1170,
- "upper_bound": "2974"
+ "distinct_range": 0,
+ "num_eq": 303123,
+ "num_range": 0,
+ "upper_bound": "7"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1290,
- "upper_bound": "2988"
+ "distinct_range": 0,
+ "num_eq": 304324,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 90,
- "num_range": 1200,
- "upper_bound": "3000"
+ "distinct_range": 0,
+ "num_eq": 293219,
+ "num_range": 0,
+ "upper_bound": "9"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 293520,
+ "num_range": 0,
+ "upper_bound": "10"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 3001222
},
{
+ "avg_size": 2,
"columns": [
- "o_w_id",
- "o_d_id",
- "o_id"
+ "ol_w_id",
+ "ol_d_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 295745,
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 100,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 3001222
},
{
+ "avg_size": 3,
"columns": [
- "o_c_id"
+ "ol_o_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
+ "created_at": "2022-02-25 01:09:36.891466",
"distinct_count": 2999,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 90,
+ "num_eq": 300,
"num_range": 0,
- "upper_bound": "1"
+ "upper_bound": "2"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 210,
- "num_range": 1410,
- "upper_bound": "17"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "14"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "32"
+ "distinct_range": 19,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "34"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "46"
+ "distinct_range": 17,
+ "num_eq": 1501,
+ "num_range": 13806,
+ "upper_bound": "52"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "63"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 14706,
+ "upper_bound": "67"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "82"
+ "distinct_range": 17,
+ "num_eq": 1501,
+ "num_range": 14406,
+ "upper_bound": "85"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 90,
- "num_range": 1410,
+ "distinct_range": 15,
+ "num_eq": 1501,
+ "num_range": 14706,
"upper_bound": "101"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "118"
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "114"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "134"
+ "distinct_range": 18,
+ "num_eq": 1200,
+ "num_range": 14706,
+ "upper_bound": "133"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "151"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "148"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "165"
+ "distinct_range": 11,
+ "num_eq": 1801,
+ "num_range": 13505,
+ "upper_bound": "160"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "184"
+ "distinct_range": 16,
+ "num_eq": 300,
+ "num_range": 14706,
+ "upper_bound": "177"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "197"
+ "distinct_range": 12,
+ "num_eq": 1801,
+ "num_range": 13205,
+ "upper_bound": "190"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "215"
+ "distinct_range": 22,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "213"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1470,
- "upper_bound": "229"
+ "distinct_range": 18,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "232"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1470,
- "upper_bound": "243"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 14706,
+ "upper_bound": "247"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "262"
+ "distinct_range": 13,
+ "num_eq": 1801,
+ "num_range": 13806,
+ "upper_bound": "261"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 240,
- "num_range": 1350,
- "upper_bound": "275"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 13806,
+ "upper_bound": "276"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "290"
+ "distinct_range": 17,
+ "num_eq": 1200,
+ "num_range": 14106,
+ "upper_bound": "294"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "304"
+ "distinct_range": 13,
+ "num_eq": 900,
+ "num_range": 14706,
+ "upper_bound": "308"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1470,
- "upper_bound": "320"
+ "distinct_range": 19,
+ "num_eq": 1801,
+ "num_range": 13205,
+ "upper_bound": "328"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "336"
+ "distinct_range": 15,
+ "num_eq": 600,
+ "num_range": 14706,
+ "upper_bound": "344"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 150,
- "num_range": 1470,
- "upper_bound": "348"
+ "distinct_range": 15,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "360"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "361"
+ "distinct_range": 17,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "378"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1470,
- "upper_bound": "375"
+ "distinct_range": 15,
+ "num_eq": 900,
+ "num_range": 14706,
+ "upper_bound": "394"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "409"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 900,
+ "num_range": 14406,
+ "upper_bound": "423"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "435"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 14706,
+ "upper_bound": "450"
+ },
+ {
+ "distinct_range": 15,
+ "num_eq": 900,
+ "num_range": 14406,
+ "upper_bound": "466"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 3001,
+ "num_range": 14106,
+ "upper_bound": "480"
+ },
+ {
+ "distinct_range": 16,
+ "num_eq": 900,
+ "num_range": 14706,
+ "upper_bound": "497"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 1801,
+ "num_range": 13806,
+ "upper_bound": "510"
+ },
+ {
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "526"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 14106,
+ "upper_bound": "540"
+ },
+ {
+ "distinct_range": 15,
+ "num_eq": 1801,
+ "num_range": 14706,
+ "upper_bound": "556"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "569"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "584"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 240,
- "num_range": 1410,
- "upper_bound": "392"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 14406,
+ "upper_bound": "597"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "405"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "612"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "422"
+ "distinct_range": 16,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "629"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "438"
+ "distinct_range": 12,
+ "num_eq": 1801,
+ "num_range": 12905,
+ "upper_bound": "642"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "456"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "659"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "470"
+ "distinct_range": 14,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "674"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "481"
+ "distinct_range": 16,
+ "num_eq": 900,
+ "num_range": 14406,
+ "upper_bound": "691"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "495"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "708"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "508"
+ "distinct_range": 16,
+ "num_eq": 2701,
+ "num_range": 12905,
+ "upper_bound": "725"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "519"
+ "distinct_range": 12,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "738"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "533"
+ "distinct_range": 15,
+ "num_eq": 1801,
+ "num_range": 13806,
+ "upper_bound": "754"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "551"
+ "distinct_range": 13,
+ "num_eq": 2101,
+ "num_range": 12605,
+ "upper_bound": "768"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "564"
+ "distinct_range": 17,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "786"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "581"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 14406,
+ "upper_bound": "803"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "597"
+ "distinct_range": 14,
+ "num_eq": 1801,
+ "num_range": 12905,
+ "upper_bound": "818"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "613"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "834"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1410,
- "upper_bound": "628"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "850"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "643"
+ "distinct_range": 11,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "862"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "661"
+ "distinct_range": 11,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "874"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 210,
- "num_range": 1320,
- "upper_bound": "672"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "888"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "687"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "900"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "703"
+ "distinct_range": 15,
+ "num_eq": 2701,
+ "num_range": 13205,
+ "upper_bound": "916"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 240,
- "num_range": 1350,
- "upper_bound": "721"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "931"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "735"
+ "distinct_range": 17,
+ "num_eq": 1801,
+ "num_range": 13505,
+ "upper_bound": "949"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "751"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "963"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "764"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "978"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1410,
- "upper_bound": "779"
+ "distinct_range": 14,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "993"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "792"
+ "distinct_range": 11,
+ "num_eq": 1801,
+ "num_range": 13205,
+ "upper_bound": "1005"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1440,
- "upper_bound": "807"
+ "distinct_range": 13,
+ "num_eq": 2101,
+ "num_range": 13806,
+ "upper_bound": "1019"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "824"
+ "distinct_range": 17,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1037"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "840"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 13806,
+ "upper_bound": "1052"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "854"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1065"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "868"
+ "distinct_range": 16,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "1082"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "886"
+ "distinct_range": 15,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "1098"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "902"
+ "distinct_range": 17,
+ "num_eq": 1501,
+ "num_range": 14406,
+ "upper_bound": "1116"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "919"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 14406,
+ "upper_bound": "1131"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 270,
- "num_range": 1440,
- "upper_bound": "934"
+ "distinct_range": 19,
+ "num_eq": 1200,
+ "num_range": 14106,
+ "upper_bound": "1151"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "948"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "1166"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "966"
+ "distinct_range": 13,
+ "num_eq": 2101,
+ "num_range": 12905,
+ "upper_bound": "1180"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 90,
- "num_range": 1440,
- "upper_bound": "984"
+ "distinct_range": 15,
+ "num_eq": 1801,
+ "num_range": 14406,
+ "upper_bound": "1196"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "997"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1210"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "1013"
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "1227"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1030"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "1243"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "1044"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 12005,
+ "upper_bound": "1256"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 300,
- "num_range": 1170,
- "upper_bound": "1061"
+ "distinct_range": 15,
+ "num_eq": 1801,
+ "num_range": 14106,
+ "upper_bound": "1272"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1080"
+ "distinct_range": 12,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "1285"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1097"
+ "distinct_range": 14,
+ "num_eq": 2401,
+ "num_range": 13806,
+ "upper_bound": "1300"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1115"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 14406,
+ "upper_bound": "1315"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1129"
+ "distinct_range": 13,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "1329"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1147"
+ "distinct_range": 15,
+ "num_eq": 1501,
+ "num_range": 13806,
+ "upper_bound": "1345"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1160"
+ "distinct_range": 15,
+ "num_eq": 2101,
+ "num_range": 13505,
+ "upper_bound": "1361"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 210,
- "num_range": 1380,
- "upper_bound": "1176"
+ "distinct_range": 16,
+ "num_eq": 600,
+ "num_range": 14406,
+ "upper_bound": "1378"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1191"
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "1393"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1206"
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "1408"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "1219"
+ "distinct_range": 16,
+ "num_eq": 2101,
+ "num_range": 14406,
+ "upper_bound": "1425"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1234"
+ "distinct_range": 15,
+ "num_eq": 900,
+ "num_range": 14406,
+ "upper_bound": "1441"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1247"
+ "distinct_range": 17,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "1459"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1263"
+ "distinct_range": 16,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "1476"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1278"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 14106,
+ "upper_bound": "1492"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "1294"
+ "distinct_range": 14,
+ "num_eq": 2101,
+ "num_range": 13205,
+ "upper_bound": "1507"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "1312"
+ "distinct_range": 10,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "1518"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1440,
- "upper_bound": "1329"
+ "distinct_range": 13,
+ "num_eq": 300,
+ "num_range": 14406,
+ "upper_bound": "1532"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1340"
+ "distinct_range": 13,
+ "num_eq": 1501,
+ "num_range": 14406,
+ "upper_bound": "1546"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1440,
- "upper_bound": "1356"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "1561"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "1370"
+ "distinct_range": 17,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "1579"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1440,
- "upper_bound": "1386"
+ "distinct_range": 14,
+ "num_eq": 1801,
+ "num_range": 14406,
+ "upper_bound": "1594"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 270,
- "num_range": 1410,
- "upper_bound": "1403"
+ "distinct_range": 11,
+ "num_eq": 2101,
+ "num_range": 12905,
+ "upper_bound": "1606"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 210,
- "num_range": 1410,
- "upper_bound": "1418"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 14106,
+ "upper_bound": "1622"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1435"
+ "distinct_range": 12,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "1635"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 270,
- "num_range": 1230,
- "upper_bound": "1451"
+ "distinct_range": 10,
+ "num_eq": 900,
+ "num_range": 14406,
+ "upper_bound": "1646"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1467"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1662"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 210,
- "num_range": 1380,
- "upper_bound": "1483"
+ "distinct_range": 15,
+ "num_eq": 1801,
+ "num_range": 14406,
+ "upper_bound": "1678"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1499"
+ "distinct_range": 14,
+ "num_eq": 2701,
+ "num_range": 14106,
+ "upper_bound": "1693"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1514"
+ "distinct_range": 11,
+ "num_eq": 2401,
+ "num_range": 12305,
+ "upper_bound": "1705"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1529"
+ "distinct_range": 11,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "1717"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 270,
- "num_range": 1380,
- "upper_bound": "1541"
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1734"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 30,
- "num_range": 1440,
- "upper_bound": "1556"
+ "distinct_range": 15,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "1750"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1440,
- "upper_bound": "1572"
+ "distinct_range": 13,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "1764"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1585"
+ "distinct_range": 14,
+ "num_eq": 1801,
+ "num_range": 13505,
+ "upper_bound": "1779"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1598"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "1791"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1612"
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "1804"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1628"
+ "distinct_range": 16,
+ "num_eq": 2101,
+ "num_range": 12605,
+ "upper_bound": "1821"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "1643"
+ "distinct_range": 10,
+ "num_eq": 2101,
+ "num_range": 12905,
+ "upper_bound": "1832"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "1659"
+ "distinct_range": 10,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "1843"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "1675"
+ "distinct_range": 14,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "1858"
},
{
- "distinct_range": 8.996785714285714,
- "num_eq": 240,
- "num_range": 1230,
- "upper_bound": "1685"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "1875"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 210,
- "num_range": 1440,
- "upper_bound": "1702"
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "1888"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "1717"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1902"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1290,
- "upper_bound": "1730"
+ "distinct_range": 17,
+ "num_eq": 2701,
+ "num_range": 12605,
+ "upper_bound": "1920"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "1745"
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 13205,
+ "upper_bound": "1935"
+ },
+ {
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 14406,
+ "upper_bound": "1952"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "1761"
+ "distinct_range": 18,
+ "num_eq": 300,
+ "num_range": 14106,
+ "upper_bound": "1971"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1774"
+ "distinct_range": 13,
+ "num_eq": 2101,
+ "num_range": 12605,
+ "upper_bound": "1985"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "1790"
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "2002"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "1806"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 13205,
+ "upper_bound": "2014"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 210,
- "num_range": 1350,
- "upper_bound": "1820"
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "2028"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "1835"
+ "distinct_range": 10,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "2039"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1849"
+ "distinct_range": 12,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "2052"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "1866"
+ "distinct_range": 12,
+ "num_eq": 2101,
+ "num_range": 12905,
+ "upper_bound": "2065"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "1879"
+ "distinct_range": 12,
+ "num_eq": 300,
+ "num_range": 14106,
+ "upper_bound": "2078"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "1893"
+ "distinct_range": 11,
+ "num_eq": 1801,
+ "num_range": 13205,
+ "upper_bound": "2090"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 180,
- "num_range": 1260,
- "upper_bound": "1907"
+ "distinct_range": 17,
+ "num_eq": 1801,
+ "num_range": 12605,
+ "upper_bound": "2108"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "1919"
+ "distinct_range": 17,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "2126"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "1936"
+ "distinct_range": 12,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "2139"
},
{
- "distinct_range": 19.992857142857144,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "1957"
+ "distinct_range": 16,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "2156"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "1971"
+ "distinct_range": 15,
+ "num_eq": 2101,
+ "num_range": 12605,
+ "upper_bound": "2172"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "1989"
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "2187"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 180,
- "num_range": 1410,
- "upper_bound": "2007"
+ "distinct_range": 13,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "2201"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2023"
+ "distinct_range": 12,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "2214"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2036"
+ "distinct_range": 12,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "2227"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 60,
- "num_range": 1410,
- "upper_bound": "2051"
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "2241"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "2063"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "2258"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "2080"
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 13806,
+ "upper_bound": "2272"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1410,
- "upper_bound": "2096"
+ "distinct_range": 13,
+ "num_eq": 1801,
+ "num_range": 13205,
+ "upper_bound": "2286"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2110"
+ "distinct_range": 17,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "2304"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2124"
+ "distinct_range": 13,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "2318"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1230,
- "upper_bound": "2137"
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 13806,
+ "upper_bound": "2333"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2152"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 13205,
+ "upper_bound": "2347"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1350,
- "upper_bound": "2167"
+ "distinct_range": 12,
+ "num_eq": 300,
+ "num_range": 14106,
+ "upper_bound": "2360"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "2183"
+ "distinct_range": 11,
+ "num_eq": 1801,
+ "num_range": 12605,
+ "upper_bound": "2372"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2198"
+ "distinct_range": 15,
+ "num_eq": 1501,
+ "num_range": 14106,
+ "upper_bound": "2388"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2213"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 12905,
+ "upper_bound": "2405"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1410,
- "upper_bound": "2230"
+ "distinct_range": 16,
+ "num_eq": 2101,
+ "num_range": 13205,
+ "upper_bound": "2422"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 150,
- "num_range": 1290,
- "upper_bound": "2241"
+ "distinct_range": 14,
+ "num_eq": 600,
+ "num_range": 13806,
+ "upper_bound": "2437"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 150,
- "num_range": 1290,
- "upper_bound": "2255"
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 13205,
+ "upper_bound": "2452"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "2270"
+ "distinct_range": 16,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "2469"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 210,
- "num_range": 1260,
- "upper_bound": "2284"
+ "distinct_range": 15,
+ "num_eq": 1200,
+ "num_range": 13205,
+ "upper_bound": "2485"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 150,
- "num_range": 1350,
- "upper_bound": "2296"
+ "distinct_range": 12,
+ "num_eq": 900,
+ "num_range": 13505,
+ "upper_bound": "2498"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 150,
- "num_range": 1380,
- "upper_bound": "2309"
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "2512"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2323"
+ "distinct_range": 13,
+ "num_eq": 2101,
+ "num_range": 14106,
+ "upper_bound": "2526"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2339"
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 14106,
+ "upper_bound": "2540"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "2355"
+ "distinct_range": 12,
+ "num_eq": 1801,
+ "num_range": 13806,
+ "upper_bound": "2553"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "2367"
+ "distinct_range": 9,
+ "num_eq": 1801,
+ "num_range": 12605,
+ "upper_bound": "2563"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2380"
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 14106,
+ "upper_bound": "2580"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2396"
+ "distinct_range": 14,
+ "num_eq": 2101,
+ "num_range": 12305,
+ "upper_bound": "2595"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2409"
+ "distinct_range": 13,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "2609"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2426"
+ "distinct_range": 16,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "2626"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 30,
- "num_range": 1410,
- "upper_bound": "2442"
+ "distinct_range": 14,
+ "num_eq": 900,
+ "num_range": 14106,
+ "upper_bound": "2641"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 300,
- "num_range": 1380,
- "upper_bound": "2454"
+ "distinct_range": 15,
+ "num_eq": 2401,
+ "num_range": 12305,
+ "upper_bound": "2657"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2470"
+ "distinct_range": 16,
+ "num_eq": 1801,
+ "num_range": 12905,
+ "upper_bound": "2674"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "2486"
+ "distinct_range": 13,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "2688"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2502"
+ "distinct_range": 12,
+ "num_eq": 900,
+ "num_range": 13505,
+ "upper_bound": "2701"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2518"
+ "distinct_range": 13,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "2715"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 150,
- "num_range": 1410,
- "upper_bound": "2536"
+ "distinct_range": 12,
+ "num_eq": 900,
+ "num_range": 13806,
+ "upper_bound": "2728"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2549"
+ "distinct_range": 16,
+ "num_eq": 2101,
+ "num_range": 13806,
+ "upper_bound": "2745"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2568"
+ "distinct_range": 12,
+ "num_eq": 2101,
+ "num_range": 12605,
+ "upper_bound": "2758"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2584"
+ "distinct_range": 14,
+ "num_eq": 600,
+ "num_range": 13806,
+ "upper_bound": "2773"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "2600"
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "2790"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "2617"
+ "distinct_range": 11,
+ "num_eq": 300,
+ "num_range": 13806,
+ "upper_bound": "2802"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 90,
- "num_range": 1380,
- "upper_bound": "2634"
+ "distinct_range": 12,
+ "num_eq": 2401,
+ "num_range": 12305,
+ "upper_bound": "2815"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2647"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 13505,
+ "upper_bound": "2832"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 180,
- "num_range": 1290,
- "upper_bound": "2659"
+ "distinct_range": 17,
+ "num_eq": 600,
+ "num_range": 13505,
+ "upper_bound": "2850"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 150,
- "num_range": 1320,
- "upper_bound": "2676"
+ "distinct_range": 14,
+ "num_eq": 1801,
+ "num_range": 12305,
+ "upper_bound": "2865"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 180,
- "num_range": 1230,
- "upper_bound": "2694"
+ "distinct_range": 17,
+ "num_eq": 1200,
+ "num_range": 13505,
+ "upper_bound": "2883"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 120,
- "num_range": 1380,
- "upper_bound": "2710"
+ "distinct_range": 15,
+ "num_eq": 900,
+ "num_range": 13505,
+ "upper_bound": "2899"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "2724"
+ "distinct_range": 15,
+ "num_eq": 1501,
+ "num_range": 12605,
+ "upper_bound": "2915"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 120,
- "num_range": 1290,
- "upper_bound": "2735"
+ "distinct_range": 16,
+ "num_eq": 1501,
+ "num_range": 13205,
+ "upper_bound": "2932"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1320,
- "upper_bound": "2750"
+ "distinct_range": 13,
+ "num_eq": 2401,
+ "num_range": 12905,
+ "upper_bound": "2946"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2763"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 12305,
+ "upper_bound": "2958"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2774"
+ "distinct_range": 14,
+ "num_eq": 1501,
+ "num_range": 12605,
+ "upper_bound": "2973"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2788"
+ "distinct_range": 10,
+ "num_eq": 900,
+ "num_range": 11705,
+ "upper_bound": "2984"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 120,
- "num_range": 1350,
- "upper_bound": "2805"
- },
+ "distinct_range": 15,
+ "num_eq": 600,
+ "num_range": 11705,
+ "upper_bound": "3000"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 3001222
+ },
+ {
+ "avg_size": 5,
+ "columns": [
+ "ol_w_id",
+ "ol_d_id",
+ "ol_o_id"
+ ],
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 295745,
+ "histo_col_type": "",
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 3001222
+ },
+ {
+ "avg_size": 1,
+ "columns": [
+ "ol_number"
+ ],
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 15,
+ "histo_buckets": [
{
- "distinct_range": 10.99607142857143,
- "num_eq": 180,
- "num_range": 1380,
- "upper_bound": "2817"
+ "distinct_range": 0,
+ "num_eq": 309126,
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1290,
- "upper_bound": "2831"
+ "distinct_range": 0,
+ "num_eq": 301323,
+ "num_range": 0,
+ "upper_bound": "2"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 60,
- "num_range": 1380,
- "upper_bound": "2845"
+ "distinct_range": 0,
+ "num_eq": 307925,
+ "num_range": 0,
+ "upper_bound": "3"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 90,
- "num_range": 1320,
- "upper_bound": "2859"
+ "distinct_range": 0,
+ "num_eq": 291719,
+ "num_range": 0,
+ "upper_bound": "4"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 210,
- "num_range": 1230,
- "upper_bound": "2872"
+ "distinct_range": 0,
+ "num_eq": 313027,
+ "num_range": 0,
+ "upper_bound": "5"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 120,
- "num_range": 1320,
- "upper_bound": "2886"
+ "distinct_range": 0,
+ "num_eq": 262307,
+ "num_range": 0,
+ "upper_bound": "6"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 180,
- "num_range": 1320,
- "upper_bound": "2904"
+ "distinct_range": 0,
+ "num_eq": 243699,
+ "num_range": 0,
+ "upper_bound": "7"
},
{
- "distinct_range": 8.996785714285714,
- "num_eq": 150,
- "num_range": 1230,
- "upper_bound": "2914"
+ "distinct_range": 0,
+ "num_eq": 212487,
+ "num_range": 0,
+ "upper_bound": "8"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 90,
- "num_range": 1290,
- "upper_bound": "2926"
+ "distinct_range": 0,
+ "num_eq": 189077,
+ "num_range": 0,
+ "upper_bound": "9"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 90,
- "num_range": 1350,
- "upper_bound": "2941"
+ "distinct_range": 0,
+ "num_eq": 160265,
+ "num_range": 0,
+ "upper_bound": "10"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 180,
- "num_range": 1260,
- "upper_bound": "2956"
+ "distinct_range": 0,
+ "num_eq": 135355,
+ "num_range": 0,
+ "upper_bound": "11"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 30,
- "num_range": 1320,
- "upper_bound": "2970"
+ "distinct_range": 0,
+ "num_eq": 113446,
+ "num_range": 0,
+ "upper_bound": "12"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 90,
- "num_range": 1260,
- "upper_bound": "2983"
+ "distinct_range": 0,
+ "num_eq": 80133,
+ "num_range": 0,
+ "upper_bound": "13"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 210,
- "num_range": 1140,
- "upper_bound": "3000"
+ "distinct_range": 0,
+ "num_eq": 56723,
+ "num_range": 0,
+ "upper_bound": "14"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 24610,
+ "num_range": 0,
+ "upper_bound": "15"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
- },
- {
- "columns": [
- "o_w_id",
- "o_d_id",
- "o_c_id"
- ],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 295745,
- "histo_col_type": "",
- "name": "__auto__",
- "null_count": 0,
- "row_count": 300000
+ "row_count": 3001222
},
{
+ "avg_size": 6,
"columns": [
- "o_w_id",
- "o_d_id",
- "o_c_id",
- "o_id"
+ "ol_w_id",
+ "ol_d_id",
+ "ol_o_id",
+ "ol_number"
],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 298416,
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 2986292,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 3001222
},
{
+ "avg_size": 4,
"columns": [
- "o_entry_d"
+ "ol_i_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 1,
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 99658,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 300000,
+ "num_eq": 300,
"num_range": 0,
- "upper_bound": "2006-01-02 15:04:05"
+ "upper_bound": "25"
+ },
+ {
+ "distinct_range": 99656,
+ "num_eq": 300,
+ "num_range": 3000622,
+ "upper_bound": "99993"
}
],
- "histo_col_type": "TIMESTAMP",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
+ "row_count": 3001222
},
{
+ "avg_size": 2,
"columns": [
- "o_carrier_id"
+ "ol_supply_w_id"
],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 11,
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 20768,
+ "num_eq": 290818,
"num_range": 0,
- "upper_bound": "1"
+ "upper_bound": "0"
},
{
"distinct_range": 8,
- "num_eq": 21913,
- "num_range": 167319,
- "upper_bound": "10"
+ "num_eq": 295320,
+ "num_range": 2415083,
+ "upper_bound": "9"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
- "null_count": 90000,
- "row_count": 300000
+ "null_count": 0,
+ "row_count": 3001222
},
{
+ "avg_size": 5,
"columns": [
- "o_ol_cnt"
+ "ol_delivery_d"
],
- "created_at": "2021-09-08 20:48:20.464516",
- "distinct_count": 11,
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 2,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 26280,
+ "num_eq": 2102088,
"num_range": 0,
- "upper_bound": "5"
- },
- {
- "distinct_range": 9,
- "num_eq": 27960,
- "num_range": 245760,
- "upper_bound": "15"
+ "upper_bound": "2006-01-02 15:04:05"
}
],
- "histo_col_type": "INT8",
+ "histo_col_type": "TIMESTAMP",
"histo_version": 1,
"name": "__auto__",
- "null_count": 0,
- "row_count": 300000
+ "null_count": 899134,
+ "row_count": 3001222
},
{
+ "avg_size": 2,
"columns": [
- "o_all_local"
+ "ol_quantity"
],
- "created_at": "2021-09-08 20:48:20.464516",
+ "created_at": "2022-02-25 01:09:36.891466",
"distinct_count": 1,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 300000,
+ "num_eq": 3001222,
"num_range": 0,
- "upper_bound": "1"
+ "upper_bound": "5"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 300000
- }
-]';
-----
-
-exec-ddl
-ALTER TABLE "order_line" INJECT STATISTICS '[
+ "row_count": 3001222
+ },
{
+ "avg_size": 5,
"columns": [
- "ol_w_id"
+ "ol_amount"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 10,
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 588894,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 307625,
+ "num_eq": 2111960,
"num_range": 0,
"upper_bound": "0"
},
{
- "distinct_range": 0,
- "num_eq": 293520,
- "num_range": 0,
- "upper_bound": "1"
- },
- {
- "distinct_range": 0,
- "num_eq": 295320,
- "num_range": 0,
- "upper_bound": "2"
- },
- {
- "distinct_range": 0,
- "num_eq": 283315,
- "num_range": 0,
- "upper_bound": "3"
- },
- {
- "distinct_range": 0,
- "num_eq": 291419,
- "num_range": 0,
- "upper_bound": "4"
- },
- {
- "distinct_range": 0,
- "num_eq": 298622,
- "num_range": 0,
- "upper_bound": "5"
- },
- {
- "distinct_range": 0,
- "num_eq": 313928,
- "num_range": 0,
- "upper_bound": "6"
- },
- {
- "distinct_range": 0,
- "num_eq": 294420,
- "num_range": 0,
- "upper_bound": "7"
- },
+ "distinct_range": 588892,
+ "num_eq": 300,
+ "num_range": 888962,
+ "upper_bound": "9998.04"
+ }
+ ],
+ "histo_col_type": "DECIMAL(6,2)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 3001222
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "ol_dist_info"
+ ],
+ "created_at": "2022-02-25 01:09:36.891466",
+ "distinct_count": 398,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 313027,
+ "num_eq": 13806,
"num_range": 0,
- "upper_bound": "8"
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
- "distinct_range": 0,
- "num_eq": 310026,
- "num_range": 0,
- "upper_bound": "9"
+ "distinct_range": 396,
+ "num_eq": 3301,
+ "num_range": 2984115,
+ "upper_bound": "zvh9lctkhRvAvE5H6TtiDNPE"
}
],
- "histo_col_type": "INT8",
+ "histo_col_type": "CHAR(24)",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
"row_count": 3001222
- },
+ }
+]';
+----
+
+exec-ddl
+ALTER TABLE "stock" INJECT STATISTICS '[
{
+ "avg_size": 1,
"columns": [
- "ol_d_id"
+ "s_w_id"
],
- "created_at": "2021-09-08 20:48:18.578707",
+ "created_at": "2022-02-25 01:08:01.518632",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 292919,
+ "num_eq": 92670,
+ "num_range": 0,
+ "upper_bound": "0"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 79584,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 305825,
+ "num_eq": 90201,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 303123,
+ "num_eq": 83205,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 297121,
+ "num_eq": 75387,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 299222,
+ "num_eq": 84111,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 310326,
+ "num_eq": 77362,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 301323,
+ "num_eq": 87403,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 298321,
+ "num_eq": 74893,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 294420,
+ "num_eq": 78185,
"num_range": 0,
"upper_bound": "9"
- },
- {
- "distinct_range": 0,
- "num_eq": 298622,
- "num_range": 0,
- "upper_bound": "10"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
- },
- {
- "columns": [
- "ol_w_id",
- "ol_d_id"
- ],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 100,
- "histo_col_type": "",
- "name": "__auto__",
- "null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 4,
"columns": [
- "ol_o_id"
+ "s_i_id"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 2999,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 99658,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 900,
+ "num_eq": 82,
"num_range": 0,
- "upper_bound": "1"
- },
- {
- "distinct_range": 14.994642857142857,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "17"
+ "upper_bound": "4"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 1801,
- "num_range": 13205,
- "upper_bound": "28"
+ "distinct_range": 464.6957203521976,
+ "num_eq": 165,
+ "num_range": 3950,
+ "upper_bound": "471"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14706,
- "upper_bound": "43"
+ "distinct_range": 367.03942268834277,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "840"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1801,
- "num_range": 14106,
- "upper_bound": "55"
+ "distinct_range": 358.0643940090939,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "1200"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "70"
+ "distinct_range": 394.9583769825712,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "1597"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "82"
+ "distinct_range": 586.8517889559417,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "2187"
},
- {
- "distinct_range": 15.994285714285715,
- "num_eq": 600,
- "num_range": 14706,
- "upper_bound": "99"
+ {
+ "distinct_range": 489.59513115096144,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "2679"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1801,
- "num_range": 14406,
- "upper_bound": "116"
+ "distinct_range": 435.82442379985184,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "3117"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "131"
+ "distinct_range": 492.57976028025183,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "3612"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "146"
+ "distinct_range": 462.7197220908085,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "4077"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1501,
- "num_range": 14706,
- "upper_bound": "161"
+ "distinct_range": 556.1512114511012,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "4636"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1501,
- "num_range": 14706,
- "upper_bound": "175"
+ "distinct_range": 399.94319982294195,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "5038"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 2101,
- "num_range": 14106,
- "upper_bound": "193"
+ "distinct_range": 451.76441436315787,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "5492"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "206"
+ "distinct_range": 622.4013622497582,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "6118"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "226"
+ "distinct_range": 588.8298672667211,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "6710"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 1200,
- "num_range": 14706,
- "upper_bound": "245"
+ "distinct_range": 503.52037848861295,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "7216"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "261"
+ "distinct_range": 380.00252431227597,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "7598"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "273"
+ "distinct_range": 465.7069815613108,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "8066"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "289"
+ "distinct_range": 423.86617558506083,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "8492"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 900,
- "num_range": 14706,
- "upper_bound": "308"
+ "distinct_range": 520.3792381328273,
+ "num_eq": 165,
+ "num_range": 3950,
+ "upper_bound": "9015"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "324"
+ "distinct_range": 445.78756065431133,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "9463"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "341"
+ "distinct_range": 583.8840416995638,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "10050"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "356"
+ "distinct_range": 518.4309638287956,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "10571"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "372"
+ "distinct_range": 459.7322183060962,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "11033"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1501,
- "num_range": 14406,
- "upper_bound": "386"
+ "distinct_range": 437.8172118386093,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "11473"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 2101,
- "num_range": 13806,
- "upper_bound": "401"
+ "distinct_range": 582.8946268680955,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "12059"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "417"
+ "distinct_range": 499.5425403325984,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "12561"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "434"
+ "distinct_range": 328.1453219406186,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "12891"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "449"
+ "distinct_range": 485.61510983125737,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "13379"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "461"
+ "distinct_range": 340.11328998606064,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "13721"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 900,
- "num_range": 14706,
- "upper_bound": "480"
+ "distinct_range": 381.9967450172589,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "14105"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 2701,
- "num_range": 12605,
- "upper_bound": "493"
+ "distinct_range": 499.5425403325984,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "14607"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1801,
- "num_range": 13505,
- "upper_bound": "508"
+ "distinct_range": 380.9996384166452,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "14990"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 900,
- "num_range": 14706,
- "upper_bound": "525"
+ "distinct_range": 639.1431964434787,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "15633"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "538"
+ "distinct_range": 449.77222099080757,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "16085"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "551"
+ "distinct_range": 512.4679754184438,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "16600"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1801,
- "num_range": 13205,
- "upper_bound": "566"
+ "distinct_range": 502.52598192818584,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "17105"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "586"
+ "distinct_range": 418.88287187736614,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "17526"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 600,
- "num_range": 14706,
- "upper_bound": "602"
+ "distinct_range": 495.56404593025917,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "18024"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "617"
+ "distinct_range": 412.9024246379581,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "18439"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1501,
- "num_range": 13806,
- "upper_bound": "635"
+ "distinct_range": 603.6542767373869,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "19046"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "650"
+ "distinct_range": 507.49753362222737,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "19556"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "662"
+ "distinct_range": 457.74041779842906,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "20016"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "680"
+ "distinct_range": 445.78756065431133,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "20464"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "695"
+ "distinct_range": 526.3788401746828,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "20993"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "710"
+ "distinct_range": 621.4155797944403,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "21618"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "728"
+ "distinct_range": 494.5693228794432,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "22115"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 300,
- "num_range": 14406,
- "upper_bound": "744"
+ "distinct_range": 532.3375378723852,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "22650"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1801,
- "num_range": 14106,
- "upper_bound": "761"
+ "distinct_range": 517.4372529166983,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "23170"
},
{
- "distinct_range": 19.992857142857144,
- "num_eq": 1501,
- "num_range": 14406,
- "upper_bound": "782"
+ "distinct_range": 467.69834765644197,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "23640"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 300,
- "num_range": 14406,
- "upper_bound": "798"
+ "distinct_range": 572.0057739615617,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "24215"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1801,
- "num_range": 13505,
- "upper_bound": "813"
+ "distinct_range": 498.5479772205636,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "24716"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "826"
+ "distinct_range": 528.3652893855785,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "25247"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "841"
+ "distinct_range": 387.9792185055543,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "25637"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 2101,
- "num_range": 12605,
- "upper_bound": "854"
+ "distinct_range": 428.849081955579,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "26068"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "872"
+ "distinct_range": 422.86954565982956,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "26493"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "888"
+ "distinct_range": 389.97330927131134,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "26885"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "904"
+ "distinct_range": 486.6101692528161,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "27374"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1801,
- "num_range": 12905,
- "upper_bound": "918"
+ "distinct_range": 569.0344604037082,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "27946"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "931"
+ "distinct_range": 685.2484616978863,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "28636"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 14406,
- "upper_bound": "947"
+ "distinct_range": 481.6345218140302,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "29120"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 2101,
- "num_range": 13205,
- "upper_bound": "961"
+ "distinct_range": 398.9462559262274,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "29521"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 2401,
- "num_range": 13806,
- "upper_bound": "972"
+ "distinct_range": 532.3375378723852,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "30056"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "986"
+ "distinct_range": 550.2011726647835,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "30609"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "1002"
+ "distinct_range": 475.662630365966,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "31087"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 2101,
- "num_range": 13205,
- "upper_bound": "1017"
+ "distinct_range": 699.8997309818469,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "31792"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "1029"
+ "distinct_range": 596.7387257787875,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "32392"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1501,
- "num_range": 14406,
- "upper_bound": "1047"
+ "distinct_range": 467.69834765644197,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "32862"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "1062"
+ "distinct_range": 396.95233675763086,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "33261"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1801,
- "num_range": 13205,
- "upper_bound": "1078"
+ "distinct_range": 628.3138414948381,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "33893"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 300,
- "num_range": 14406,
- "upper_bound": "1091"
+ "distinct_range": 411.90563540630154,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "34307"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "1104"
+ "distinct_range": 534.3233295838882,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "34844"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "1117"
+ "distinct_range": 635.206810381658,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "35483"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "1135"
+ "distinct_range": 529.3584334550893,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "36015"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "1152"
+ "distinct_range": 549.2092705718397,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "36567"
},
{
- "distinct_range": 19.992857142857144,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "1173"
+ "distinct_range": 565.0716696240008,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "37135"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 2701,
- "num_range": 13205,
- "upper_bound": "1185"
+ "distinct_range": 497.5533735089951,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "37635"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 2101,
- "num_range": 12605,
- "upper_bound": "1202"
+ "distinct_range": 320.16649830880715,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "37957"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "1217"
+ "distinct_range": 441.80255142077334,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "38401"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 2101,
- "num_range": 14106,
- "upper_bound": "1233"
+ "distinct_range": 440.8062467839895,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "38844"
+ },
+ {
+ "distinct_range": 525.38553596845,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "39372"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "1245"
+ "distinct_range": 447.7799356172793,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "39822"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1801,
- "num_range": 13505,
- "upper_bound": "1257"
+ "distinct_range": 483.6248851243135,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "40308"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "1274"
+ "distinct_range": 539.286808287404,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "40850"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 2101,
- "num_range": 13806,
- "upper_bound": "1288"
+ "distinct_range": 667.6248911777516,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "41522"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 2401,
- "num_range": 13806,
- "upper_bound": "1305"
+ "distinct_range": 582.8946268680955,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "42108"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1200,
- "num_range": 14406,
- "upper_bound": "1318"
+ "distinct_range": 497.5533735089951,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "42608"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "1330"
+ "distinct_range": 507.49753362222737,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "43118"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1501,
- "num_range": 14406,
- "upper_bound": "1347"
+ "distinct_range": 468.6939876131913,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "43589"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 13505,
- "upper_bound": "1362"
+ "distinct_range": 478.64872358101616,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "44070"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1200,
- "num_range": 13505,
- "upper_bound": "1374"
+ "distinct_range": 515.4496851649019,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "44588"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "1392"
+ "distinct_range": 573.986270486108,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "45165"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "1408"
+ "distinct_range": 696.9721315204227,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "45867"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1200,
- "num_range": 14406,
- "upper_bound": "1425"
+ "distinct_range": 572.0057739615617,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "46442"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "1441"
+ "distinct_range": 451.76441436315787,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "46896"
},
{
- "distinct_range": 8.996785714285714,
- "num_eq": 2101,
- "num_range": 13806,
- "upper_bound": "1451"
+ "distinct_range": 582.8946268680955,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "47482"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "1465"
+ "distinct_range": 451.76441436315787,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "47936"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "1478"
+ "distinct_range": 563.0898383015552,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "48502"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "1495"
+ "distinct_range": 567.053211729608,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "49072"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "1513"
+ "distinct_range": 485.61510983125737,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "49560"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "1530"
+ "distinct_range": 567.053211729608,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "50130"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "1543"
+ "distinct_range": 362.0533463129665,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "50494"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "1559"
+ "distinct_range": 285.2581480791127,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "50781"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "1572"
+ "distinct_range": 542.2641900365329,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "51326"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 300,
- "num_range": 14406,
- "upper_bound": "1587"
+ "distinct_range": 446.78375918519566,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "51775"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "1604"
+ "distinct_range": 630.2838099877521,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "52409"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "1620"
+ "distinct_range": 548.2173044102469,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "52960"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "1636"
+ "distinct_range": 397.9493015092255,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "53360"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "1648"
+ "distinct_range": 572.9960604980764,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "53936"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "1664"
+ "distinct_range": 552.1847826270377,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "54491"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "1678"
+ "distinct_range": 543.2565301092958,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "55037"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "1693"
+ "distinct_range": 531.3445581712768,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "55571"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "1708"
+ "distinct_range": 546.2331818898541,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "56120"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1200,
- "num_range": 13505,
- "upper_bound": "1722"
+ "distinct_range": 508.49171249661833,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "56631"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "1737"
+ "distinct_range": 484.62001499379465,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "57118"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "1752"
+ "distinct_range": 406.9214964731659,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "57527"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "1767"
+ "distinct_range": 443.79509847640367,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "57973"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 1801,
- "num_range": 12905,
- "upper_bound": "1778"
+ "distinct_range": 633.2379424268166,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "58610"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "1793"
+ "distinct_range": 455.74851527152487,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "59068"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "1808"
+ "distinct_range": 367.03942268834277,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "59437"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1200,
- "num_range": 14406,
- "upper_bound": "1826"
+ "distinct_range": 557.1426508681166,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "59997"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "1841"
+ "distinct_range": 516.443493212547,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "60516"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "1854"
+ "distinct_range": 424.85584885190053,
+ "num_eq": 165,
+ "num_range": 3950,
+ "upper_bound": "60943"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "1872"
+ "distinct_range": 562.098815495475,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "61508"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "1885"
+ "distinct_range": 573.986270486108,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "62085"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "1898"
+ "distinct_range": 456.74447912651505,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "62544"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 14406,
- "upper_bound": "1914"
+ "distinct_range": 345.0998247718894,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "62891"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 2101,
- "num_range": 12905,
- "upper_bound": "1926"
+ "distinct_range": 364.0477927476618,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "63257"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "1938"
+ "distinct_range": 390.9703413473656,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "63650"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "1952"
+ "distinct_range": 443.79509847640367,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "64096"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1200,
- "num_range": 14406,
- "upper_bound": "1965"
+ "distinct_range": 452.76047578505415,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "64551"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1501,
- "num_range": 13806,
- "upper_bound": "1982"
+ "distinct_range": 509.4858465476931,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "65063"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 13505,
- "upper_bound": "1998"
+ "distinct_range": 443.79509847640367,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "65509"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "2013"
+ "distinct_range": 480.6392891301696,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "65992"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 300,
- "num_range": 14406,
- "upper_bound": "2027"
+ "distinct_range": 549.2092705718397,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "66544"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "2039"
+ "distinct_range": 580.8286506836513,
+ "num_eq": 165,
+ "num_range": 3950,
+ "upper_bound": "67128"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "2056"
+ "distinct_range": 625.3580800974621,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "67757"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "2069"
+ "distinct_range": 703.8010803310364,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "68466"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1501,
- "num_range": 13505,
- "upper_bound": "2083"
+ "distinct_range": 525.38553596845,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "68994"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "2099"
+ "distinct_range": 595.7504265901973,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "69593"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 2101,
- "num_range": 13806,
- "upper_bound": "2115"
+ "distinct_range": 469.6895983817722,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "70065"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "2129"
+ "distinct_range": 435.82442379985184,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "70503"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 900,
- "num_range": 14406,
- "upper_bound": "2141"
+ "distinct_range": 405.9246316022448,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "70911"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 600,
- "num_range": 14406,
- "upper_bound": "2160"
+ "distinct_range": 603.6542767373869,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "71518"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "2174"
+ "distinct_range": 595.7504265901973,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "72117"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "2189"
+ "distinct_range": 502.52598192818584,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "72622"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "2203"
+ "distinct_range": 555.1597044064586,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "73180"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "2219"
+ "distinct_range": 463.715502839468,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "73646"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "2235"
+ "distinct_range": 472.67625206182606,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "74121"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1501,
- "num_range": 12905,
- "upper_bound": "2251"
+ "distinct_range": 395.9553618549625,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "74519"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "2269"
+ "distinct_range": 465.7069815613108,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "74987"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 13505,
- "upper_bound": "2285"
+ "distinct_range": 457.74041779842906,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "75447"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "2297"
+ "distinct_range": 356.06988988548125,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "75805"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "2316"
+ "distinct_range": 573.986270486108,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "76382"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 13806,
- "upper_bound": "2332"
+ "distinct_range": 340.11328998606064,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "76724"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 300,
- "num_range": 14106,
- "upper_bound": "2348"
+ "distinct_range": 512.4679754184438,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "77239"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "2368"
+ "distinct_range": 510.4799353421653,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "77752"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "2388"
+ "distinct_range": 527.3720914692922,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "78282"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 300,
- "num_range": 14106,
- "upper_bound": "2402"
+ "distinct_range": 439.809921787321,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "78724"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1801,
- "num_range": 13205,
- "upper_bound": "2417"
+ "distinct_range": 495.56404593025917,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "79222"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 13505,
- "upper_bound": "2433"
+ "distinct_range": 345.10044862482255,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "79569"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1501,
- "num_range": 14106,
- "upper_bound": "2448"
+ "distinct_range": 526.4152395247933,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "80098"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "2464"
+ "distinct_range": 596.8296825565375,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "80698"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 1501,
- "num_range": 13806,
- "upper_bound": "2475"
+ "distinct_range": 550.2521055100816,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "81251"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 300,
- "num_range": 14106,
- "upper_bound": "2490"
+ "distinct_range": 477.669902193559,
+ "num_eq": 165,
+ "num_range": 4115,
+ "upper_bound": "81731"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "2502"
+ "distinct_range": 334.12935141846253,
+ "num_eq": 82,
+ "num_range": 4033,
+ "upper_bound": "82067"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1801,
- "num_range": 12605,
- "upper_bound": "2514"
+ "distinct_range": 540.323768837952,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "82610"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "2529"
+ "distinct_range": 485.63410062291223,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "83098"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "2544"
+ "distinct_range": 420.8814626460258,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "83521"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 600,
- "num_range": 13806,
- "upper_bound": "2561"
+ "distinct_range": 639.2867182486692,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "84164"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "2579"
+ "distinct_range": 497.57660360645895,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "84664"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1200,
- "num_range": 13505,
- "upper_bound": "2593"
+ "distinct_range": 566.0624770918475,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "85233"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1801,
- "num_range": 13505,
- "upper_bound": "2606"
+ "distinct_range": 542.2641900365329,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "85778"
},
{
- "distinct_range": 16.993928571428572,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "2624"
+ "distinct_range": 567.116729353482,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "86348"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1501,
- "num_range": 12905,
- "upper_bound": "2637"
+ "distinct_range": 629.4286753767507,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "86981"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 14106,
- "upper_bound": "2652"
+ "distinct_range": 530.3900999848892,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "87514"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "2664"
+ "distinct_range": 364.0489458711796,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "87880"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 14106,
- "upper_bound": "2679"
+ "distinct_range": 382.993843964226,
+ "num_eq": 165,
+ "num_range": 4033,
+ "upper_bound": "88265"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 900,
- "num_range": 13505,
- "upper_bound": "2693"
+ "distinct_range": 519.4574353314387,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "88787"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 600,
- "num_range": 14106,
- "upper_bound": "2707"
+ "distinct_range": 578.0191033178784,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "89368"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 600,
- "num_range": 13806,
- "upper_bound": "2721"
+ "distinct_range": 542.3098772570808,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "89913"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 1801,
- "num_range": 13505,
- "upper_bound": "2738"
+ "distinct_range": 643.2270318420115,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "90560"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 2401,
- "num_range": 12905,
- "upper_bound": "2753"
+ "distinct_range": 686.4495121525648,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "91251"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 1501,
- "num_range": 12605,
- "upper_bound": "2764"
+ "distinct_range": 479.66112899856745,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "91733"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 600,
- "num_range": 13806,
- "upper_bound": "2776"
+ "distinct_range": 508.51942310334385,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "92244"
},
{
- "distinct_range": 17.99357142857143,
- "num_eq": 1200,
- "num_range": 13205,
- "upper_bound": "2795"
+ "distinct_range": 482.64775026167297,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "92729"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 1501,
- "num_range": 13205,
- "upper_bound": "2808"
+ "distinct_range": 502.551175037577,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "93234"
},
{
- "distinct_range": 14.994642857142857,
- "num_eq": 1200,
- "num_range": 13806,
- "upper_bound": "2824"
+ "distinct_range": 564.141938980803,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "93801"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 1801,
- "num_range": 13806,
- "upper_bound": "2836"
+ "distinct_range": 532.3772387613316,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "94336"
},
{
- "distinct_range": 18.993214285714288,
- "num_eq": 900,
- "num_range": 13205,
- "upper_bound": "2856"
+ "distinct_range": 607.7068134677887,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "94947"
},
{
- "distinct_range": 12.995357142857143,
- "num_eq": 1801,
- "num_range": 13505,
- "upper_bound": "2870"
+ "distinct_range": 456.7556507489267,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "95406"
},
{
- "distinct_range": 10.99607142857143,
- "num_eq": 600,
- "num_range": 13205,
- "upper_bound": "2882"
+ "distinct_range": 519.4574353314387,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "95928"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 600,
- "num_range": 13505,
- "upper_bound": "2899"
+ "distinct_range": 472.6913437633377,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "96403"
},
{
- "distinct_range": 11.995714285714286,
- "num_eq": 600,
- "num_range": 13205,
- "upper_bound": "2912"
+ "distinct_range": 457.7518084132223,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "96863"
},
{
- "distinct_range": 9.996428571428572,
- "num_eq": 2401,
- "num_range": 12005,
- "upper_bound": "2923"
+ "distinct_range": 400.9433612752566,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "97266"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 1200,
- "num_range": 12905,
- "upper_bound": "2938"
+ "distinct_range": 652.086420585875,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "97922"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 13205,
- "upper_bound": "2953"
+ "distinct_range": 522.4396248701322,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "98447"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 600,
- "num_range": 13505,
- "upper_bound": "2968"
+ "distinct_range": 474.682849732382,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "98924"
},
{
- "distinct_range": 13.995000000000001,
- "num_eq": 900,
- "num_range": 13205,
- "upper_bound": "2983"
+ "distinct_range": 599.7971793875903,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "99527"
},
{
- "distinct_range": 15.994285714285715,
- "num_eq": 900,
- "num_range": 12605,
- "upper_bound": "3000"
+ "distinct_range": 451.7745395441404,
+ "num_eq": 82,
+ "num_range": 4115,
+ "upper_bound": "99981"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 5,
"columns": [
- "ol_w_id",
- "ol_d_id",
- "ol_o_id"
+ "s_w_id",
+ "s_i_id"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 295745,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 821345,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 3,
"columns": [
- "ol_number"
+ "s_quantity"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 15,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 91,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 300122,
+ "num_eq": 9300,
"num_range": 0,
- "upper_bound": "1"
+ "upper_bound": "10"
},
{
- "distinct_range": 0,
- "num_eq": 301023,
- "num_range": 0,
- "upper_bound": "2"
- },
+ "distinct_range": 89,
+ "num_eq": 9218,
+ "num_range": 804483,
+ "upper_bound": "100"
+ }
+ ],
+ "histo_col_type": "INT8",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_01"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 293520,
+ "num_eq": 13662,
"num_range": 0,
- "upper_bound": "3"
+ "upper_bound": "1U5yraPxxELo5B1fcW8RsaCX"
},
{
- "distinct_range": 0,
- "num_eq": 297721,
- "num_range": 0,
- "upper_bound": "4"
- },
+ "distinct_range": 60.00000000000001,
+ "num_eq": 13580,
+ "num_range": 795759,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_02"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 305524,
+ "num_eq": 13497,
"num_range": 0,
- "upper_bound": "5"
+ "upper_bound": "0YhgLRrwsmd68P2bElAgrnp8"
},
{
- "distinct_range": 0,
- "num_eq": 263807,
- "num_range": 0,
- "upper_bound": "6"
- },
+ "distinct_range": 60,
+ "num_eq": 12510,
+ "num_range": 796993,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_03"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 264108,
+ "num_eq": 13250,
"num_range": 0,
- "upper_bound": "7"
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
+ {
+ "distinct_range": 59.99999999999999,
+ "num_eq": 14485,
+ "num_range": 795265,
+ "upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_04"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 210986,
+ "num_eq": 13826,
"num_range": 0,
- "upper_bound": "8"
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
- "distinct_range": 0,
- "num_eq": 197781,
- "num_range": 0,
- "upper_bound": "9"
- },
+ "distinct_range": 59.99999999999999,
+ "num_eq": 12674,
+ "num_range": 796499,
+ "upper_bound": "zk13xWSP8P9fwb2ZjtZAs3Nb"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_05"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 169869,
+ "num_eq": 12345,
"num_range": 0,
- "upper_bound": "10"
+ "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
- "distinct_range": 0,
- "num_eq": 137156,
- "num_range": 0,
- "upper_bound": "11"
- },
+ "distinct_range": 60,
+ "num_eq": 12839,
+ "num_range": 797816,
+ "upper_bound": "zk13xWSP8P9fwb2ZjtZAs3Nb"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_06"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 104743,
+ "num_eq": 12345,
"num_range": 0,
- "upper_bound": "12"
+ "upper_bound": "13xWSP8P9fwb2ZjtZAs3NbYd"
},
{
- "distinct_range": 0,
- "num_eq": 75631,
- "num_range": 0,
- "upper_bound": "13"
- },
+ "distinct_range": 60,
+ "num_eq": 12592,
+ "num_range": 798063,
+ "upper_bound": "xWSP8P9fwb2ZjtZAs3NbYdih"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
+ "name": "__auto__",
+ "null_count": 0,
+ "row_count": 823000
+ },
+ {
+ "avg_size": 26,
+ "columns": [
+ "s_dist_07"
+ ],
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 54022,
+ "num_eq": 14485,
"num_range": 0,
- "upper_bound": "14"
+ "upper_bound": "1f4fJoMgn5buTDyUmQupcYMo"
},
{
- "distinct_range": 0,
- "num_eq": 25210,
- "num_range": 0,
- "upper_bound": "15"
+ "distinct_range": 60,
+ "num_eq": 10699,
+ "num_range": 797816,
+ "upper_bound": "zNHsJ7ZvyiJ3n2X1f4fJoMgn"
}
],
- "histo_col_type": "INT8",
+ "histo_col_type": "CHAR(24)",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 26,
"columns": [
- "ol_w_id",
- "ol_d_id",
- "ol_o_id",
- "ol_number"
+ "s_dist_08"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 2986292,
- "histo_col_type": "",
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
+ "histo_buckets": [
+ {
+ "distinct_range": 0,
+ "num_eq": 14320,
+ "num_range": 0,
+ "upper_bound": "1f4fJoMgn5buTDyUmQupcYMo"
+ },
+ {
+ "distinct_range": 60,
+ "num_eq": 14567,
+ "num_range": 794113,
+ "upper_bound": "zNHsJ7ZvyiJ3n2X1f4fJoMgn"
+ }
+ ],
+ "histo_col_type": "CHAR(24)",
+ "histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 26,
"columns": [
- "ol_i_id"
+ "s_dist_09"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 99658,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 300,
+ "num_eq": 13909,
"num_range": 0,
- "upper_bound": "12"
+ "upper_bound": "1f4fJoMgn5buTDyUmQupcYMo"
},
{
- "distinct_range": 99656,
- "num_eq": 300,
- "num_range": 3000622,
- "upper_bound": "99985"
+ "distinct_range": 60.00000000000001,
+ "num_eq": 13662,
+ "num_range": 795430,
+ "upper_bound": "ylHqYo89SqHqQ4HFVNpmnIWH"
}
],
- "histo_col_type": "INT8",
+ "histo_col_type": "CHAR(24)",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 26,
"columns": [
- "ol_supply_w_id"
+ "s_dist_10"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 10,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 307625,
+ "num_eq": 14567,
"num_range": 0,
- "upper_bound": "0"
+ "upper_bound": "2r4uSQJ8PYVLLLZk9Epp6cNE"
},
{
- "distinct_range": 8,
- "num_eq": 310026,
- "num_range": 2383571,
- "upper_bound": "9"
+ "distinct_range": 60,
+ "num_eq": 13497,
+ "num_range": 794936,
+ "upper_bound": "zQN2r4uSQJ8PYVLLLZk9Epp6"
}
],
- "histo_col_type": "INT8",
+ "histo_col_type": "CHAR(24)",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 2,
"columns": [
- "ol_delivery_d"
+ "s_ytd"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 2,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 1,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 2102088,
+ "num_eq": 823000,
"num_range": 0,
- "upper_bound": "2006-01-02 15:04:05"
+ "upper_bound": "0"
}
],
- "histo_col_type": "TIMESTAMP",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
- "null_count": 899134,
- "row_count": 3001222
+ "null_count": 0,
+ "row_count": 823000
},
{
+ "avg_size": 2,
"columns": [
- "ol_quantity"
+ "s_order_cnt"
],
- "created_at": "2021-09-08 20:48:18.578707",
+ "created_at": "2022-02-25 01:08:01.518632",
"distinct_count": 1,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 3001222,
+ "num_eq": 823000,
"num_range": 0,
- "upper_bound": "5"
+ "upper_bound": "0"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 2,
"columns": [
- "ol_amount"
+ "s_remote_cnt"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 588894,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 1,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 2116762,
+ "num_eq": 823000,
"num_range": 0,
"upper_bound": "0"
- },
- {
- "distinct_range": 588892,
- "num_eq": 300,
- "num_range": 884160,
- "upper_bound": "9999.5"
}
],
- "histo_col_type": "DECIMAL(6,2)",
+ "histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
+ "row_count": 823000
},
{
+ "avg_size": 40,
"columns": [
- "ol_dist_info"
+ "s_data"
],
- "created_at": "2021-09-08 20:48:18.578707",
- "distinct_count": 398,
+ "created_at": "2022-02-25 01:08:01.518632",
+ "distinct_count": 41770,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 12905,
+ "num_eq": 82,
"num_range": 0,
- "upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
+ "upper_bound": "0zORIGINALvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ"
},
{
- "distinct_range": 395.99999999999994,
- "num_eq": 3301,
- "num_range": 2985015,
- "upper_bound": "zvh9lctkhRvAvE5H6TtiDNPE"
+ "distinct_range": 41768,
+ "num_eq": 82,
+ "num_range": 822835,
+ "upper_bound": "zQNORIGINAL2r4uSQJ8PYVLLLZk9Epp6cNEnaVrN3JXcrB"
}
],
- "histo_col_type": "CHAR(24)",
+ "histo_col_type": "VARCHAR(50)",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 3001222
- }
-]';
-----
-
-exec-ddl
-ALTER TABLE "stock" INJECT STATISTICS '[
+ "row_count": 823000
+ },
{
+ "avg_size": 1,
"columns": [
"s_w_id"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 10,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 97200,
+ "num_eq": 97600,
"num_range": 0,
"upper_bound": "0"
},
{
"distinct_range": 0,
- "num_eq": 99200,
+ "num_eq": 98400,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 102500,
+ "num_eq": 100300,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 101900,
+ "num_eq": 101000,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 97100,
+ "num_eq": 98700,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 102100,
+ "num_eq": 104700,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 104700,
+ "num_eq": 99500,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 97200,
+ "num_eq": 100900,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 95100,
+ "num_eq": 101300,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 103000,
+ "num_eq": 97600,
"num_range": 0,
"upper_bound": "9"
}
@@ -13243,1211 +28239,1212 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 4,
"columns": [
"s_i_id"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 99658,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 100,
"num_range": 0,
- "upper_bound": "14"
- },
- {
- "distinct_range": 457.58648108232626,
- "num_eq": 100,
- "num_range": 4900,
- "upper_bound": "474"
+ "upper_bound": "3"
},
{
- "distinct_range": 527.3333486068815,
+ "distinct_range": 409.7220261564885,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "1004"
+ "upper_bound": "415"
},
{
- "distinct_range": 552.2275644093144,
+ "distinct_range": 443.6119733963904,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "1559"
+ "upper_bound": "861"
},
{
- "distinct_range": 490.46791940765115,
+ "distinct_range": 490.44523587356076,
"num_eq": 200,
"num_range": 4800,
- "upper_bound": "2052"
+ "upper_bound": "1354"
},
{
- "distinct_range": 502.429550340756,
+ "distinct_range": 586.0355922484378,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "2557"
+ "upper_bound": "1943"
},
{
- "distinct_range": 652.6317778257574,
+ "distinct_range": 577.0824239345709,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "3213"
+ "upper_bound": "2523"
},
{
- "distinct_range": 510.39964117382164,
+ "distinct_range": 447.59874245522644,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "3726"
+ "upper_bound": "2973"
},
{
- "distinct_range": 465.55970578509795,
+ "distinct_range": 430.65450765815723,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "4194"
+ "upper_bound": "3406"
},
{
- "distinct_range": 520.3611308166184,
+ "distinct_range": 591.0085997271028,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "4717"
+ "upper_bound": "4000"
},
{
- "distinct_range": 396.78163876349856,
+ "distinct_range": 420.6868159826078,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "5116"
+ "upper_bound": "4423"
},
{
- "distinct_range": 470.54276405780445,
+ "distinct_range": 570.1173867484075,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "5589"
+ "upper_bound": "4996"
},
{
- "distinct_range": 488.48021921434446,
+ "distinct_range": 423.6771562832484,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "6080"
+ "upper_bound": "5422"
},
{
- "distinct_range": 440.6422287456068,
- "num_eq": 100,
+ "distinct_range": 469.5244500584027,
+ "num_eq": 200,
"num_range": 4900,
- "upper_bound": "6523"
+ "upper_bound": "5894"
},
{
- "distinct_range": 514.3843946151677,
+ "distinct_range": 507.38747847995336,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "7040"
+ "upper_bound": "6404"
},
{
- "distinct_range": 542.2712139760526,
- "num_eq": 100,
- "num_range": 4900,
- "upper_bound": "7585"
+ "distinct_range": 401.7468719494286,
+ "num_eq": 200,
+ "num_range": 4800,
+ "upper_bound": "6808"
},
{
- "distinct_range": 462.5697922806961,
+ "distinct_range": 412.71245348551565,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "8050"
+ "upper_bound": "7223"
},
{
- "distinct_range": 550.236449180621,
+ "distinct_range": 447.59874245522644,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "8603"
+ "upper_bound": "7673"
},
{
- "distinct_range": 437.6519287130503,
+ "distinct_range": 416.69965580430585,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "9043"
+ "upper_bound": "8092"
},
{
- "distinct_range": 459.5798232693726,
+ "distinct_range": 574.0975587455788,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "9505"
+ "upper_bound": "8669"
},
{
- "distinct_range": 562.1818939609661,
+ "distinct_range": 471.51754700802024,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "10070"
+ "upper_bound": "9143"
},
{
- "distinct_range": 446.62271289841703,
+ "distinct_range": 446.60205715084885,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "10519"
+ "upper_bound": "9592"
},
{
- "distinct_range": 547.2496285575419,
+ "distinct_range": 444.608672539067,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "11069"
+ "upper_bound": "10039"
},
{
- "distinct_range": 579.0989874080228,
+ "distinct_range": 459.5585682714902,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "11651"
+ "upper_bound": "10501"
},
{
- "distinct_range": 703.1640863605786,
+ "distinct_range": 556.1838267627639,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "12358"
+ "upper_bound": "11060"
},
{
- "distinct_range": 580.0938843353171,
+ "distinct_range": 447.59874245522644,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "12941"
+ "upper_bound": "11510"
},
{
- "distinct_range": 539.2839460706884,
+ "distinct_range": 403.7411115652614,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "13483"
+ "upper_bound": "11916"
},
{
- "distinct_range": 401.76603817701897,
- "num_eq": 200,
+ "distinct_range": 532.2884309172878,
+ "num_eq": 100,
"num_range": 4900,
- "upper_bound": "13887"
+ "upper_bound": "12451"
},
{
- "distinct_range": 473.53251577315274,
+ "distinct_range": 559.1699580130061,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "14363"
+ "upper_bound": "13013"
},
{
- "distinct_range": 426.6872029791018,
+ "distinct_range": 570.1173867484075,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "14792"
+ "upper_bound": "13586"
},
{
- "distinct_range": 504.4221429241194,
+ "distinct_range": 540.2547325659039,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "15299"
+ "upper_bound": "14129"
},
{
- "distinct_range": 354.9114154130126,
+ "distinct_range": 505.395047153346,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "15656"
+ "upper_bound": "14637"
},
{
- "distinct_range": 386.81271780594653,
+ "distinct_range": 568.1271543088037,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "16045"
+ "upper_bound": "15208"
},
{
- "distinct_range": 437.6519287130503,
+ "distinct_range": 508.38367636966336,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "16485"
+ "upper_bound": "15719"
},
{
- "distinct_range": 475.525647050781,
- "num_eq": 100,
+ "distinct_range": 554.1929669198681,
+ "num_eq": 200,
"num_range": 4900,
- "upper_bound": "16963"
+ "upper_bound": "16276"
},
{
- "distinct_range": 474.5290851408118,
+ "distinct_range": 472.514084859569,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "17440"
+ "upper_bound": "16751"
},
{
- "distinct_range": 445.62597680092665,
+ "distinct_range": 435.6382266400343,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "17888"
+ "upper_bound": "17189"
},
{
- "distinct_range": 466.5563308097095,
+ "distinct_range": 523.3251075595124,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "18357"
+ "upper_bound": "17715"
},
{
- "distinct_range": 551.232016787613,
+ "distinct_range": 494.43587797667595,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "18911"
+ "upper_bound": "18212"
},
{
- "distinct_range": 542.2712139760526,
+ "distinct_range": 607.9111108363904,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "19456"
+ "upper_bound": "18823"
},
{
- "distinct_range": 521.3572054093271,
+ "distinct_range": 345.9230440582955,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "19980"
+ "upper_bound": "19171"
},
{
- "distinct_range": 602.96863310966,
+ "distinct_range": 560.1652919448854,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "20586"
+ "upper_bound": "19734"
},
{
- "distinct_range": 518.3689397171237,
+ "distinct_range": 396.7632881039076,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "21107"
+ "upper_bound": "20133"
},
{
- "distinct_range": 466.5563308097095,
+ "distinct_range": 459.5585682714902,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "21576"
+ "upper_bound": "20595"
},
{
- "distinct_range": 537.2923461458093,
- "num_eq": 100,
- "num_range": 4900,
- "upper_bound": "22116"
+ "distinct_range": 438.6267999312981,
+ "num_eq": 200,
+ "num_range": 4800,
+ "upper_bound": "21036"
},
{
- "distinct_range": 521.3572054093271,
+ "distinct_range": 640.6924206893921,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "22640"
+ "upper_bound": "21680"
},
{
- "distinct_range": 566.1630110957145,
+ "distinct_range": 610.8929222714861,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "23209"
+ "upper_bound": "22294"
},
{
- "distinct_range": 610.9211766196056,
+ "distinct_range": 514.3606049737068,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "23823"
+ "upper_bound": "22811"
},
{
- "distinct_range": 544.2626356072897,
+ "distinct_range": 425.67070138652053,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "24370"
+ "upper_bound": "23239"
},
{
- "distinct_range": 562.1818939609661,
+ "distinct_range": 496.42854964522894,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "24935"
+ "upper_bound": "23738"
},
{
- "distinct_range": 430.6744258171913,
+ "distinct_range": 481.4825863646294,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "25368"
+ "upper_bound": "24222"
},
{
- "distinct_range": 398.77540388399325,
+ "distinct_range": 459.5559015952013,
+ "num_eq": 200,
+ "num_range": 4800,
+ "upper_bound": "24684"
+ },
+ {
+ "distinct_range": 497.4248701459015,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "25769"
+ "upper_bound": "25184"
},
{
- "distinct_range": 383.8220140497127,
+ "distinct_range": 568.1271543088037,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "26155"
+ "upper_bound": "25755"
},
{
- "distinct_range": 554.2185988439613,
+ "distinct_range": 566.1368267573415,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "26712"
+ "upper_bound": "26324"
},
{
- "distinct_range": 563.1772074104114,
+ "distinct_range": 540.2547325659039,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "27278"
+ "upper_bound": "26867"
},
{
- "distinct_range": 377.840574104908,
+ "distinct_range": 363.8669135079081,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "27658"
+ "upper_bound": "27233"
},
{
- "distinct_range": 461.57314197709786,
+ "distinct_range": 502.40631359604305,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "28122"
+ "upper_bound": "27738"
},
{
- "distinct_range": 553.2230918328262,
+ "distinct_range": 498.4211802352742,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "28678"
+ "upper_bound": "28239"
},
{
- "distinct_range": 508.40718957279074,
+ "distinct_range": 460.5551845146941,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "29189"
+ "upper_bound": "28702"
},
{
- "distinct_range": 507.41094560803066,
+ "distinct_range": 461.5517947906929,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "29699"
+ "upper_bound": "29166"
},
{
- "distinct_range": 421.70310226802167,
+ "distinct_range": 647.6402443607728,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "30123"
+ "upper_bound": "29817"
},
{
- "distinct_range": 522.3532658008762,
+ "distinct_range": 521.3330932839989,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "30648"
+ "upper_bound": "30341"
},
{
- "distinct_range": 648.6626080143001,
+ "distinct_range": 463.54499704380294,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "31300"
+ "upper_bound": "30807"
},
{
- "distinct_range": 472.5359390617676,
+ "distinct_range": 658.5536307514488,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "31775"
+ "upper_bound": "31469"
},
{
- "distinct_range": 520.3611308166184,
+ "distinct_range": 440.6218495880271,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "32298"
+ "upper_bound": "31912"
},
{
- "distinct_range": 388.80651372647293,
+ "distinct_range": 423.6771562832484,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "32689"
+ "upper_bound": "32338"
},
{
- "distinct_range": 464.5630742865474,
+ "distinct_range": 510.3760358222743,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "33156"
+ "upper_bound": "32851"
},
{
- "distinct_range": 436.65515396301714,
+ "distinct_range": 508.38367636966336,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "33595"
+ "upper_bound": "33362"
},
{
- "distinct_range": 631.7855699967592,
+ "distinct_range": 513.3644818068979,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "34230"
+ "upper_bound": "33878"
},
{
- "distinct_range": 475.525647050781,
+ "distinct_range": 480.48611774790385,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "34708"
+ "upper_bound": "34361"
},
{
- "distinct_range": 456.5898014254165,
- "num_eq": 100,
+ "distinct_range": 598.9638645133884,
+ "num_eq": 200,
"num_range": 4900,
- "upper_bound": "35167"
+ "upper_bound": "34963"
},
{
- "distinct_range": 523.3493118172958,
+ "distinct_range": 630.7632439064313,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "35693"
+ "upper_bound": "35597"
},
{
- "distinct_range": 555.2140852272454,
+ "distinct_range": 376.8262350370624,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "36251"
+ "upper_bound": "35976"
},
{
- "distinct_range": 430.6744258171913,
+ "distinct_range": 506.39126868963206,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "36684"
+ "upper_bound": "36485"
},
{
- "distinct_range": 514.3843946151677,
+ "distinct_range": 559.1699580130061,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "37201"
+ "upper_bound": "37047"
},
{
- "distinct_range": 510.39964117382164,
+ "distinct_range": 524.3210929603135,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "37714"
+ "upper_bound": "37574"
},
{
- "distinct_range": 521.3572054093271,
+ "distinct_range": 436.6349592027102,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "38238"
+ "upper_bound": "38013"
},
{
- "distinct_range": 473.53251577315274,
+ "distinct_range": 466.53475315699,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "38714"
+ "upper_bound": "38482"
},
{
- "distinct_range": 469.5461659872978,
+ "distinct_range": 512.3683457847128,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "39186"
+ "upper_bound": "38997"
+ },
+ {
+ "distinct_range": 523.3154727704546,
+ "num_eq": 200,
+ "num_range": 4800,
+ "upper_bound": "39523"
},
{
- "distinct_range": 494.4587460815595,
+ "distinct_range": 498.4211802352742,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "39683"
+ "upper_bound": "40024"
},
{
- "distinct_range": 570.143755191267,
+ "distinct_range": 589.019483370819,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "40256"
+ "upper_bound": "40616"
},
{
- "distinct_range": 608.9332448813273,
+ "distinct_range": 509.3798622028381,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "40868"
+ "upper_bound": "41128"
},
{
- "distinct_range": 516.3766938682504,
+ "distinct_range": 575.092539335663,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "41387"
+ "upper_bound": "41706"
},
{
- "distinct_range": 388.80651372647293,
- "num_eq": 100,
+ "distinct_range": 496.42854964522894,
+ "num_eq": 200,
"num_range": 4900,
- "upper_bound": "41778"
+ "upper_bound": "42205"
},
{
- "distinct_range": 401.76603817701897,
+ "distinct_range": 395.7664490929626,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "42182"
+ "upper_bound": "42603"
},
{
- "distinct_range": 650.6472873759583,
+ "distinct_range": 489.454026393414,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "42836"
+ "upper_bound": "43095"
},
{
- "distinct_range": 454.59642545790604,
+ "distinct_range": 587.0302511557226,
"num_eq": 200,
"num_range": 4900,
- "upper_bound": "43293"
+ "upper_bound": "43685"
},
{
- "distinct_range": 523.3493118172958,
+ "distinct_range": 447.59874245522644,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "43819"
+ "upper_bound": "44135"
},
{
- "distinct_range": 457.58648108232626,
- "num_eq": 100,
+ "distinct_range": 462.5483990004484,
+ "num_eq": 200,
"num_range": 4900,
- "upper_bound": "44279"
+ "upper_bound": "44600"
},
{
- "distinct_range": 435.65837530056206,
+ "distinct_range": 372.8387673963003,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "44717"
+ "upper_bound": "44975"
},
{
- "distinct_range": 384.81891657508874,
+ "distinct_range": 504.39881402446616,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "45104"
+ "upper_bound": "45482"
},
{
- "distinct_range": 552.2275644093144,
+ "distinct_range": 502.40631359604305,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "45659"
+ "upper_bound": "45987"
},
{
- "distinct_range": 468.5495610172161,
+ "distinct_range": 444.608672539067,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "46130"
+ "upper_bound": "46434"
},
{
- "distinct_range": 495.45513306179066,
+ "distinct_range": 489.454026393414,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "46628"
+ "upper_bound": "46926"
},
{
- "distinct_range": 446.62271289841703,
+ "distinct_range": 476.50016282602155,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "47077"
+ "upper_bound": "47405"
},
{
- "distinct_range": 370.8621798528944,
+ "distinct_range": 608.9050824725896,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "47450"
+ "upper_bound": "48017"
},
{
- "distinct_range": 490.4730996412264,
+ "distinct_range": 480.48611774790385,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "47943"
+ "upper_bound": "48500"
},
{
- "distinct_range": 638.7364681193998,
+ "distinct_range": 378.8199628006704,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "48585"
+ "upper_bound": "48881"
},
{
- "distinct_range": 436.65515396301714,
+ "distinct_range": 431.6512587089478,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "49024"
+ "upper_bound": "49315"
},
{
- "distinct_range": 446.62271289841703,
+ "distinct_range": 517.348895699202,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "49473"
+ "upper_bound": "49835"
},
{
- "distinct_range": 556.2095507659187,
+ "distinct_range": 462.5483990004484,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "50032"
+ "upper_bound": "50300"
},
{
- "distinct_range": 452.60302790351375,
+ "distinct_range": 443.6119733963904,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "50487"
- },
- {
- "distinct_range": 357.90206332355575,
- "num_eq": 200,
- "num_range": 4800,
- "upper_bound": "50847"
+ "upper_bound": "50746"
},
{
- "distinct_range": 390.80030406732834,
- "num_eq": 200,
+ "distinct_range": 482.47904669307144,
+ "num_eq": 100,
"num_range": 4900,
- "upper_bound": "51240"
+ "upper_bound": "51231"
},
{
- "distinct_range": 425.6903890400238,
+ "distinct_range": 378.8199628006704,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "51668"
+ "upper_bound": "51612"
},
{
- "distinct_range": 488.48021921434446,
+ "distinct_range": 656.5698145572527,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "52159"
+ "upper_bound": "52272"
},
{
- "distinct_range": 423.69675173349424,
+ "distinct_range": 565.1416278971499,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "52585"
+ "upper_bound": "52840"
},
{
- "distinct_range": 489.4766640831728,
+ "distinct_range": 503.40256945509,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "53077"
+ "upper_bound": "53346"
},
{
- "distinct_range": 525.3413600223823,
+ "distinct_range": 383.80426275672124,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "53605"
+ "upper_bound": "53732"
},
{
- "distinct_range": 509.4034214804579,
- "num_eq": 200,
+ "distinct_range": 495.43221887524277,
+ "num_eq": 100,
"num_range": 4900,
- "upper_bound": "54117"
+ "upper_bound": "54230"
},
{
- "distinct_range": 336.96663733647694,
+ "distinct_range": 529.3007954935766,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "54456"
+ "upper_bound": "54762"
},
{
- "distinct_range": 479.51181779314214,
+ "distinct_range": 570.1173867484075,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "54938"
+ "upper_bound": "55335"
},
{
- "distinct_range": 515.3805508339694,
- "num_eq": 100,
- "num_range": 4900,
- "upper_bound": "55456"
+ "distinct_range": 492.4377751032096,
+ "num_eq": 200,
+ "num_range": 4800,
+ "upper_bound": "55830"
},
{
- "distinct_range": 613.9028112587962,
+ "distinct_range": 467.53132551060423,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "56073"
+ "upper_bound": "56300"
},
{
- "distinct_range": 448.61617092291755,
+ "distinct_range": 510.3760358222743,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "56524"
+ "upper_bound": "56813"
},
{
- "distinct_range": 485.4908300575196,
+ "distinct_range": 475.50365457828906,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "57012"
+ "upper_bound": "57291"
},
{
- "distinct_range": 518.3689397171237,
+ "distinct_range": 542.2461346037192,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "57533"
+ "upper_bound": "57836"
},
{
- "distinct_range": 391.7971970584179,
+ "distinct_range": 445.60536715116905,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "57927"
+ "upper_bound": "58284"
},
{
- "distinct_range": 598.9915671318375,
+ "distinct_range": 433.64475006829946,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "58529"
+ "upper_bound": "58720"
},
{
- "distinct_range": 473.52887761288406,
- "num_eq": 300,
- "num_range": 4800,
- "upper_bound": "59005"
+ "distinct_range": 406.7315784161205,
+ "num_eq": 100,
+ "num_range": 4900,
+ "upper_bound": "59129"
},
{
- "distinct_range": 497.4478764943662,
+ "distinct_range": 466.53475315699,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "59505"
+ "upper_bound": "59598"
},
{
- "distinct_range": 493.4623491117685,
+ "distinct_range": 476.50016282602155,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "60001"
+ "upper_bound": "60077"
},
{
- "distinct_range": 526.3373618566234,
+ "distinct_range": 401.7474569951257,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "60530"
+ "upper_bound": "60481"
},
{
- "distinct_range": 594.0195251206801,
+ "distinct_range": 548.2198991915841,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "61127"
+ "upper_bound": "61032"
},
{
- "distinct_range": 407.74725432163615,
+ "distinct_range": 484.4719419898975,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "61537"
+ "upper_bound": "61519"
},
{
- "distinct_range": 460.5764856069758,
+ "distinct_range": 479.4896409651882,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "62000"
+ "upper_bound": "62001"
},
{
- "distinct_range": 459.5798232693726,
+ "distinct_range": 420.6868159826078,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "62462"
+ "upper_bound": "62424"
},
{
- "distinct_range": 442.6357411590213,
+ "distinct_range": 475.50365457828906,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "62907"
+ "upper_bound": "62902"
},
{
- "distinct_range": 563.1772074104114,
+ "distinct_range": 557.1792252007077,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "63473"
+ "upper_bound": "63462"
},
{
- "distinct_range": 441.63898709799673,
+ "distinct_range": 512.3683457847128,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "63917"
+ "upper_bound": "63977"
},
{
- "distinct_range": 352.91755839608703,
+ "distinct_range": 561.1606039301379,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "64272"
+ "upper_bound": "64541"
+ },
+ {
+ "distinct_range": 348.9136064921576,
+ "num_eq": 200,
+ "num_range": 4800,
+ "upper_bound": "64892"
},
{
- "distinct_range": 427.68401369114173,
+ "distinct_range": 462.5483990004484,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "64702"
+ "upper_bound": "65357"
},
{
- "distinct_range": 709.0987521488764,
+ "distinct_range": 398.7569610152337,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "65415"
+ "upper_bound": "65758"
},
{
- "distinct_range": 463.56643641760814,
+ "distinct_range": 560.1652919448854,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "65881"
+ "upper_bound": "66321"
},
{
- "distinct_range": 407.74725432163615,
+ "distinct_range": 475.50365457828906,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "66291"
+ "upper_bound": "66799"
},
{
- "distinct_range": 564.1724982350687,
+ "distinct_range": 587.0302511557226,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "66858"
+ "upper_bound": "67389"
},
{
- "distinct_range": 481.5048553681039,
+ "distinct_range": 507.38747847995336,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "67342"
+ "upper_bound": "67899"
},
{
- "distinct_range": 452.60302790351375,
+ "distinct_range": 565.1416278971499,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "67797"
+ "upper_bound": "68467"
},
{
- "distinct_range": 551.232016787613,
+ "distinct_range": 526.3130194052248,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "68351"
+ "upper_bound": "68996"
},
{
- "distinct_range": 457.58648108232626,
+ "distinct_range": 594.98647649119,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "68811"
+ "upper_bound": "69594"
},
{
- "distinct_range": 578.1040640527923,
+ "distinct_range": 506.39126868963206,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "69392"
+ "upper_bound": "70103"
},
{
- "distinct_range": 541.2754758687737,
+ "distinct_range": 464.5415888194746,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "69936"
+ "upper_bound": "70570"
},
{
- "distinct_range": 404.7566553887987,
+ "distinct_range": 525.3170636348357,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "70343"
+ "upper_bound": "71098"
},
{
- "distinct_range": 528.3293200926973,
+ "distinct_range": 567.1320023052422,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "70874"
+ "upper_bound": "71668"
},
{
- "distinct_range": 506.41468974210886,
+ "distinct_range": 539.2590048557973,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "71383"
+ "upper_bound": "72210"
},
{
- "distinct_range": 489.4766640831728,
+ "distinct_range": 470.52100203748233,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "71875"
+ "upper_bound": "72683"
},
{
- "distinct_range": 484.49434925376335,
+ "distinct_range": 540.2547325659039,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "72362"
+ "upper_bound": "73226"
},
{
- "distinct_range": 596.0084346367337,
+ "distinct_range": 414.70605969379824,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "72961"
+ "upper_bound": "73643"
},
{
- "distinct_range": 542.2712139760526,
+ "distinct_range": 446.60205715084885,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "73506"
+ "upper_bound": "74092"
},
{
- "distinct_range": 628.8059894604305,
+ "distinct_range": 405.734758193467,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "74138"
+ "upper_bound": "74500"
},
{
- "distinct_range": 690.2976374173721,
+ "distinct_range": 353.8981190648231,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "74832"
+ "upper_bound": "74856"
},
{
- "distinct_range": 459.5798232693726,
+ "distinct_range": 573.1025529515988,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "75294"
+ "upper_bound": "75432"
},
{
- "distinct_range": 508.40718957279074,
+ "distinct_range": 517.348895699202,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "75805"
+ "upper_bound": "75952"
},
{
- "distinct_range": 581.0887545863915,
+ "distinct_range": 513.3644818068979,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "76389"
+ "upper_bound": "76468"
},
{
- "distinct_range": 581.0887545863915,
+ "distinct_range": 685.3145202391885,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "76973"
+ "upper_bound": "77157"
},
{
- "distinct_range": 372.85601152525055,
+ "distinct_range": 430.65450765815723,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "77348"
+ "upper_bound": "77590"
},
{
- "distinct_range": 570.1610532558182,
+ "distinct_range": 517.3560345998696,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "77921"
+ "upper_bound": "78110"
},
{
- "distinct_range": 502.4349229568236,
+ "distinct_range": 407.72894315200665,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "78426"
+ "upper_bound": "78520"
},
{
- "distinct_range": 552.2406176314579,
- "num_eq": 100,
- "num_range": 5000,
- "upper_bound": "78981"
+ "distinct_range": 528.3048855156964,
+ "num_eq": 200,
+ "num_range": 4900,
+ "upper_bound": "79051"
},
{
- "distinct_range": 717.110500497448,
+ "distinct_range": 401.74791333717013,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "79702"
+ "upper_bound": "79455"
},
{
- "distinct_range": 646.7261000083905,
+ "distinct_range": 480.4895467696362,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "80352"
+ "upper_bound": "79938"
},
{
- "distinct_range": 535.3105109367282,
+ "distinct_range": 585.0624897789861,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "80890"
+ "upper_bound": "80526"
},
{
- "distinct_range": 506.42049502625014,
+ "distinct_range": 463.5473512421134,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "81399"
+ "upper_bound": "80992"
},
{
- "distinct_range": 434.66275110282976,
+ "distinct_range": 606.9463880215284,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "81836"
+ "upper_bound": "81602"
},
{
- "distinct_range": 473.53546260280774,
+ "distinct_range": 490.45464224414474,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "82312"
+ "upper_bound": "82095"
},
{
- "distinct_range": 347.9329750013475,
+ "distinct_range": 556.1977440055806,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "82662"
+ "upper_bound": "82654"
},
{
- "distinct_range": 546.2658181963656,
+ "distinct_range": 538.2736098654717,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "83211"
+ "upper_bound": "83195"
},
{
- "distinct_range": 456.5918016713959,
+ "distinct_range": 470.5237595755367,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "83670"
+ "upper_bound": "83668"
},
{
- "distinct_range": 474.5320973056053,
+ "distinct_range": 491.4511095512588,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "84147"
+ "upper_bound": "84162"
},
{
- "distinct_range": 546.2658181963656,
+ "distinct_range": 548.2321294772946,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "84696"
+ "upper_bound": "84713"
},
{
- "distinct_range": 432.66911571881275,
+ "distinct_range": 559.1845523376152,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "85131"
+ "upper_bound": "85275"
},
{
- "distinct_range": 539.2944739329499,
+ "distinct_range": 567.1485270634722,
"num_eq": 200,
"num_range": 5000,
- "upper_bound": "85673"
+ "upper_bound": "85845"
},
{
- "distinct_range": 654.6160767455973,
- "num_eq": 200,
- "num_range": 4900,
- "upper_bound": "86331"
- },
- {
- "distinct_range": 485.4908300575196,
+ "distinct_range": 591.0085997271028,
"num_eq": 100,
"num_range": 4900,
- "upper_bound": "86819"
+ "upper_bound": "86439"
},
{
- "distinct_range": 438.64998395704157,
+ "distinct_range": 342.93243893904133,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "87260"
+ "upper_bound": "86784"
},
{
- "distinct_range": 450.6113419701202,
+ "distinct_range": 584.0674659579379,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "87713"
+ "upper_bound": "87371"
},
{
- "distinct_range": 650.6979607322263,
+ "distinct_range": 524.3291995253243,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "88367"
+ "upper_bound": "87898"
},
{
- "distinct_range": 600.0125218593771,
+ "distinct_range": 480.4895467696362,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "88970"
+ "upper_bound": "88381"
},
{
- "distinct_range": 490.4773262132882,
+ "distinct_range": 450.59050175339524,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "89463"
+ "upper_bound": "88834"
},
{
- "distinct_range": 490.4773262132882,
+ "distinct_range": 521.3407732350707,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "89956"
+ "upper_bound": "89358"
},
{
- "distinct_range": 653.6764143469743,
+ "distinct_range": 494.440462153635,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "90613"
+ "upper_bound": "89855"
},
{
- "distinct_range": 389.8037224125475,
+ "distinct_range": 566.1531000111246,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "91005"
+ "upper_bound": "90424"
},
{
- "distinct_range": 410.73843084121705,
+ "distinct_range": 419.69080241324065,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "91418"
+ "upper_bound": "90846"
},
{
- "distinct_range": 479.51517441719415,
+ "distinct_range": 658.609176425544,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "91900"
+ "upper_bound": "91508"
},
{
- "distinct_range": 611.9463809839864,
+ "distinct_range": 550.2236376803685,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "92515"
+ "upper_bound": "92061"
},
{
- "distinct_range": 479.51517441719415,
+ "distinct_range": 547.2363500843136,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "92997"
+ "upper_bound": "92611"
},
{
- "distinct_range": 555.2277829047082,
+ "distinct_range": 518.3522370426683,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "93555"
+ "upper_bound": "93132"
},
{
- "distinct_range": 569.1656424815044,
+ "distinct_range": 471.52036647256875,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "94127"
+ "upper_bound": "93606"
},
{
- "distinct_range": 481.50835836259085,
+ "distinct_range": 489.45816691420634,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "94611"
+ "upper_bound": "94098"
},
{
- "distinct_range": 513.3948541179697,
+ "distinct_range": 449.5937894108858,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "95127"
+ "upper_bound": "94550"
},
{
- "distinct_range": 474.5320973056053,
+ "distinct_range": 512.3748512365673,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "95604"
+ "upper_bound": "95065"
},
{
- "distinct_range": 482.50493986608274,
+ "distinct_range": 505.40074149836386,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "96089"
+ "upper_bound": "95573"
},
{
- "distinct_range": 523.357274522812,
+ "distinct_range": 590.0372363283949,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "96615"
+ "upper_bound": "96166"
},
{
- "distinct_range": 482.50493986608274,
+ "distinct_range": 628.8157982655306,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "97100"
+ "upper_bound": "96798"
},
{
- "distinct_range": 434.66275110282976,
+ "distinct_range": 509.3860095222127,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "97537"
+ "upper_bound": "97310"
},
{
- "distinct_range": 503.4313305701196,
+ "distinct_range": 445.60689949065335,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "98043"
+ "upper_bound": "97758"
},
{
- "distinct_range": 564.188278067591,
+ "distinct_range": 712.1300888918871,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "98610"
+ "upper_bound": "98474"
},
{
- "distinct_range": 478.5185721871542,
+ "distinct_range": 549.2278920716593,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "99091"
+ "upper_bound": "99026"
},
{
- "distinct_range": 360.8930858955724,
+ "distinct_range": 502.4116859636338,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "99454"
+ "upper_bound": "99531"
},
{
- "distinct_range": 532.3223860489248,
+ "distinct_range": 447.6003524147458,
"num_eq": 100,
"num_range": 5000,
- "upper_bound": "99989"
+ "upper_bound": "99981"
}
],
"histo_col_type": "INT8",
@@ -14457,11 +29454,12 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 5,
"columns": [
"s_w_id",
"s_i_id"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 1000000,
"histo_col_type": "",
"name": "__auto__",
@@ -14469,10 +29467,11 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 3,
"columns": [
"s_quantity"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 91,
"histo_buckets": [
{
@@ -14483,8 +29482,8 @@ ALTER TABLE "stock" INJECT STATISTICS '[
},
{
"distinct_range": 89,
- "num_eq": 12400,
- "num_range": 976700,
+ "num_eq": 10100,
+ "num_range": 979000,
"upper_bound": "100"
}
],
@@ -14495,22 +29494,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_01"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 15900,
+ "num_eq": 17300,
"num_range": 0,
"upper_bound": "1U5yraPxxELo5B1fcW8RsaCX"
},
{
"distinct_range": 60,
- "num_eq": 16600,
- "num_range": 967500,
+ "num_eq": 16100,
+ "num_range": 966600,
"upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
}
],
@@ -14521,22 +29521,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_02"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 16800,
+ "num_eq": 16900,
"num_range": 0,
"upper_bound": "0YhgLRrwsmd68P2bElAgrnp8"
},
{
"distinct_range": 60,
- "num_eq": 17000,
- "num_range": 966200,
+ "num_eq": 16500,
+ "num_range": 966600,
"upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
}
],
@@ -14547,22 +29548,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_03"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 16800,
+ "num_eq": 16000,
"num_range": 0,
"upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
- "distinct_range": 59.99999999999999,
- "num_eq": 16700,
- "num_range": 966500,
+ "distinct_range": 60,
+ "num_eq": 17000,
+ "num_range": 967000,
"upper_bound": "zmssaF9m9cdLXe0YhgLRrwsm"
}
],
@@ -14573,22 +29575,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_04"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 15600,
+ "num_eq": 16200,
"num_range": 0,
"upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
- "distinct_range": 59.99999999999999,
- "num_eq": 17700,
- "num_range": 966700,
+ "distinct_range": 60.00000000000001,
+ "num_eq": 17000,
+ "num_range": 966800,
"upper_bound": "zk13xWSP8P9fwb2ZjtZAs3Nb"
}
],
@@ -14599,22 +29602,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_05"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 15100,
+ "num_eq": 15500,
"num_range": 0,
"upper_bound": "0ObpVWo1BahdejZrKB2O3Hzk"
},
{
"distinct_range": 59.99999999999999,
- "num_eq": 17200,
- "num_range": 967700,
+ "num_eq": 16600,
+ "num_range": 967900,
"upper_bound": "zk13xWSP8P9fwb2ZjtZAs3Nb"
}
],
@@ -14625,22 +29629,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_06"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 15100,
+ "num_eq": 15500,
"num_range": 0,
"upper_bound": "13xWSP8P9fwb2ZjtZAs3NbYd"
},
{
- "distinct_range": 59.99999999999999,
- "num_eq": 15700,
- "num_range": 969200,
+ "distinct_range": 60.00000000000001,
+ "num_eq": 15900,
+ "num_range": 968600,
"upper_bound": "xWSP8P9fwb2ZjtZAs3NbYdih"
}
],
@@ -14651,22 +29656,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_07"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 14300,
+ "num_eq": 16200,
"num_range": 0,
"upper_bound": "1f4fJoMgn5buTDyUmQupcYMo"
},
{
"distinct_range": 60,
- "num_eq": 14700,
- "num_range": 971000,
+ "num_eq": 15400,
+ "num_range": 968400,
"upper_bound": "zNHsJ7ZvyiJ3n2X1f4fJoMgn"
}
],
@@ -14677,22 +29683,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_08"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 16700,
+ "num_eq": 15900,
"num_range": 0,
"upper_bound": "1f4fJoMgn5buTDyUmQupcYMo"
},
{
- "distinct_range": 60,
- "num_eq": 17100,
- "num_range": 966200,
+ "distinct_range": 59.99999999999999,
+ "num_eq": 16000,
+ "num_range": 968100,
"upper_bound": "zNHsJ7ZvyiJ3n2X1f4fJoMgn"
}
],
@@ -14703,22 +29710,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_09"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 15100,
+ "num_eq": 16400,
"num_range": 0,
"upper_bound": "1f4fJoMgn5buTDyUmQupcYMo"
},
{
"distinct_range": 60,
- "num_eq": 15400,
- "num_range": 969500,
+ "num_eq": 16400,
+ "num_range": 967200,
"upper_bound": "ylHqYo89SqHqQ4HFVNpmnIWH"
}
],
@@ -14729,22 +29737,23 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 26,
"columns": [
"s_dist_10"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 62,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 15500,
+ "num_eq": 17600,
"num_range": 0,
"upper_bound": "2r4uSQJ8PYVLLLZk9Epp6cNE"
},
{
- "distinct_range": 59.99999999999999,
- "num_eq": 16800,
- "num_range": 967700,
+ "distinct_range": 60.00000000000001,
+ "num_eq": 16900,
+ "num_range": 965500,
"upper_bound": "zQN2r4uSQJ8PYVLLLZk9Epp6"
}
],
@@ -14755,10 +29764,11 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 2,
"columns": [
"s_ytd"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 1,
"histo_buckets": [
{
@@ -14775,10 +29785,11 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 2,
"columns": [
"s_order_cnt"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 1,
"histo_buckets": [
{
@@ -14795,10 +29806,11 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 2,
"columns": [
"s_remote_cnt"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 1,
"histo_buckets": [
{
@@ -14815,23 +29827,24 @@ ALTER TABLE "stock" INJECT STATISTICS '[
"row_count": 1000000
},
{
+ "avg_size": 40,
"columns": [
"s_data"
],
- "created_at": "2021-09-08 20:49:31.825993",
+ "created_at": "2022-02-25 01:09:25.921359",
"distinct_count": 44179,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 100,
"num_range": 0,
- "upper_bound": "0ORIGINALzvh9lctkhRvAvE5H6TtiDNPEJrcjA"
+ "upper_bound": "0ORIGINALzvh9lctkhRvAvE5H6TtiDNPEJrcjAUOegvQ1Ol7S"
},
{
"distinct_range": 44177,
"num_eq": 100,
"num_range": 999800,
- "upper_bound": "zQNORIGINAL2r4uSQJ8PYVLLLZ"
+ "upper_bound": "zQNORIGINAL2r4uSQJ8PYVLLLZk9Ep"
}
],
"histo_col_type": "VARCHAR(50)",
@@ -14846,10 +29859,11 @@ ALTER TABLE "stock" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "warehouse" INJECT STATISTICS '[
{
+ "avg_size": 1,
"columns": [
"w_id"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 10,
"histo_buckets": [
{
@@ -14920,10 +29934,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 4,
"columns": [
"w_name"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 5,
"histo_buckets": [
{
@@ -14946,10 +29961,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 4,
"columns": [
"w_street_1"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 7,
"histo_buckets": [
{
@@ -14972,10 +29988,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 4,
"columns": [
"w_street_2"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 6,
"histo_buckets": [
{
@@ -14998,10 +30015,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 4,
"columns": [
"w_city"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 8,
"histo_buckets": [
{
@@ -15024,10 +30042,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 4,
"columns": [
"w_state"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 9,
"histo_buckets": [
{
@@ -15050,10 +30069,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 11,
"columns": [
"w_zip"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 6,
"histo_buckets": [
{
@@ -15076,10 +30096,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 6,
"columns": [
"w_tax"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 10,
"histo_buckets": [
{
@@ -15102,10 +30123,11 @@ ALTER TABLE "warehouse" INJECT STATISTICS '[
"row_count": 10
},
{
+ "avg_size": 8,
"columns": [
"w_ytd"
],
- "created_at": "2021-09-08 20:49:16.342153",
+ "created_at": "2022-02-25 01:08:01.697807",
"distinct_count": 1,
"histo_buckets": [
{
diff --git a/pkg/sql/opt/testutils/opttester/testfixtures/tpch_stats b/pkg/sql/opt/testutils/opttester/testfixtures/tpch_stats
index 402443e495c1..d43f531d2294 100644
--- a/pkg/sql/opt/testutils/opttester/testfixtures/tpch_stats
+++ b/pkg/sql/opt/testutils/opttester/testfixtures/tpch_stats
@@ -1,1213 +1,1226 @@
-# Stats for TPC-H with SF1.
+# Statistics for tpch
exec-ddl
ALTER TABLE "customer" INJECT STATISTICS '[
{
+ "avg_size": 4,
"columns": [
"c_custkey"
],
- "created_at": "2021-09-08 20:49:19.847293",
+ "created_at": "2022-02-25 00:55:38.309222",
"distinct_count": 148813,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 5,
+ "num_eq": 0,
"num_range": 0,
- "upper_bound": "37"
+ "upper_bound": "-9223372036854775808"
},
{
- "distinct_range": 789.6184001250035,
+ "distinct_range": 7.275957614183426E-11,
"num_eq": 5,
- "num_range": 769,
- "upper_bound": "834"
+ "num_range": 0,
+ "upper_bound": "59"
},
{
- "distinct_range": 781.7415559495385,
+ "distinct_range": 745.4315660077249,
"num_eq": 5,
- "num_range": 765,
- "upper_bound": "1623"
+ "num_range": 745,
+ "upper_bound": "811"
},
{
- "distinct_range": 721.6612403244771,
+ "distinct_range": 747.4021849213348,
"num_eq": 5,
- "num_range": 732,
- "upper_bound": "2351"
+ "num_range": 746,
+ "upper_bound": "1565"
},
{
- "distinct_range": 743.3336686592722,
+ "distinct_range": 681.3645984433297,
"num_eq": 5,
- "num_range": 744,
- "upper_bound": "3101"
+ "num_range": 711,
+ "upper_bound": "2252"
},
{
- "distinct_range": 720.6760132827105,
+ "distinct_range": 808.4736400552299,
"num_eq": 5,
- "num_range": 731,
- "upper_bound": "3828"
+ "num_range": 780,
+ "upper_bound": "3068"
},
{
- "distinct_range": 763.0317770769237,
+ "distinct_range": 732.6216105991184,
"num_eq": 5,
- "num_range": 754,
- "upper_bound": "4598"
+ "num_range": 738,
+ "upper_bound": "3807"
},
{
- "distinct_range": 795.525671535944,
+ "distinct_range": 903.9607786572609,
"num_eq": 5,
- "num_range": 772,
- "upper_bound": "5401"
+ "num_range": 835,
+ "upper_bound": "4720"
},
{
- "distinct_range": 767.9557194228196,
+ "distinct_range": 655.7248704185072,
"num_eq": 5,
- "num_range": 757,
- "upper_bound": "6176"
+ "num_range": 697,
+ "upper_bound": "5381"
},
{
- "distinct_range": 686.1863263124364,
+ "distinct_range": 767.1063348887449,
"num_eq": 5,
- "num_range": 713,
- "upper_bound": "6868"
+ "num_range": 757,
+ "upper_bound": "6155"
},
{
- "distinct_range": 738.4085409215376,
+ "distinct_range": 668.5457273377186,
"num_eq": 5,
- "num_range": 741,
- "upper_bound": "7613"
+ "num_range": 704,
+ "upper_bound": "6829"
},
{
- "distinct_range": 857.5344884742542,
+ "distinct_range": 652.7659212783636,
"num_eq": 5,
- "num_range": 808,
- "upper_bound": "8479"
+ "num_range": 696,
+ "upper_bound": "7487"
},
{
- "distinct_range": 744.3186648840046,
+ "distinct_range": 760.2102985224018,
"num_eq": 5,
- "num_range": 744,
- "upper_bound": "9230"
+ "num_range": 753,
+ "upper_bound": "8254"
},
{
- "distinct_range": 735.4533460323819,
+ "distinct_range": 617.2496180854929,
"num_eq": 5,
- "num_range": 739,
- "upper_bound": "9972"
+ "num_range": 678,
+ "upper_bound": "8876"
},
{
- "distinct_range": 635.9044562485401,
+ "distinct_range": 866.5613210691779,
"num_eq": 5,
- "num_range": 687,
- "upper_bound": "10613"
+ "num_range": 813,
+ "upper_bound": "9751"
},
{
- "distinct_range": 878.1974991385584,
+ "distinct_range": 966.9292203895345,
"num_eq": 5,
- "num_range": 820,
- "upper_bound": "11500"
+ "num_range": 873,
+ "upper_bound": "10728"
},
{
- "distinct_range": 774.8488567797552,
+ "distinct_range": 728.6797550650009,
"num_eq": 5,
- "num_range": 761,
- "upper_bound": "12282"
+ "num_range": 736,
+ "upper_bound": "11463"
},
{
- "distinct_range": 813.2456762776069,
+ "distinct_range": 912.8171841334274,
"num_eq": 5,
- "num_range": 782,
- "upper_bound": "13103"
+ "num_range": 840,
+ "upper_bound": "12385"
},
{
- "distinct_range": 517.448265307649,
+ "distinct_range": 666.5734189023556,
"num_eq": 5,
- "num_range": 632,
- "upper_bound": "13624"
+ "num_range": 703,
+ "upper_bound": "13057"
},
{
- "distinct_range": 682.2437818022587,
+ "distinct_range": 746.4168801864117,
"num_eq": 5,
- "num_range": 711,
- "upper_bound": "14312"
+ "num_range": 745,
+ "upper_bound": "13810"
},
{
- "distinct_range": 644.7800860915876,
+ "distinct_range": 679.3925907756585,
"num_eq": 5,
- "num_range": 692,
- "upper_bound": "14962"
+ "num_range": 710,
+ "upper_bound": "14495"
},
{
- "distinct_range": 553.9971040598941,
+ "distinct_range": 778.9270980938309,
"num_eq": 5,
- "num_range": 648,
- "upper_bound": "15520"
+ "num_range": 763,
+ "upper_bound": "15281"
},
{
- "distinct_range": 791.5875247456524,
+ "distinct_range": 740.5048525636946,
"num_eq": 5,
- "num_range": 770,
- "upper_bound": "16319"
+ "num_range": 742,
+ "upper_bound": "16028"
},
{
- "distinct_range": 782.7261919578056,
+ "distinct_range": 607.3809160362447,
"num_eq": 5,
- "num_range": 765,
- "upper_bound": "17109"
+ "num_range": 673,
+ "upper_bound": "16640"
},
{
- "distinct_range": 665.4858799525288,
+ "distinct_range": 665.5872469779547,
"num_eq": 5,
"num_range": 702,
- "upper_bound": "17780"
- },
- {
- "distinct_range": 756.1378693877812,
- "num_eq": 5,
- "num_range": 751,
- "upper_bound": "18543"
+ "upper_bound": "17311"
},
{
- "distinct_range": 856.5504575603213,
+ "distinct_range": 832.1056601285927,
"num_eq": 5,
- "num_range": 807,
- "upper_bound": "19408"
+ "num_range": 793,
+ "upper_bound": "18151"
},
{
- "distinct_range": 833.9157143017296,
+ "distinct_range": 722.7666737517802,
"num_eq": 5,
- "num_range": 794,
- "upper_bound": "20250"
+ "num_range": 732,
+ "upper_bound": "18880"
},
{
- "distinct_range": 727.5723864399822,
+ "distinct_range": 758.2399209134203,
"num_eq": 5,
- "num_range": 735,
- "upper_bound": "20984"
+ "num_range": 752,
+ "upper_bound": "19645"
},
{
- "distinct_range": 855.5664194176215,
+ "distinct_range": 674.4623717339998,
"num_eq": 5,
- "num_range": 807,
- "upper_bound": "21848"
+ "num_range": 707,
+ "upper_bound": "20325"
},
{
- "distinct_range": 697.0273873586599,
+ "distinct_range": 756.2695067249741,
"num_eq": 5,
- "num_range": 719,
- "upper_bound": "22551"
+ "num_range": 751,
+ "upper_bound": "21088"
},
{
- "distinct_range": 796.5101870188635,
+ "distinct_range": 704.0394935152963,
"num_eq": 5,
- "num_range": 773,
- "upper_bound": "23355"
+ "num_range": 722,
+ "upper_bound": "21798"
},
{
- "distinct_range": 811.2769183750996,
+ "distinct_range": 867.5456408699638,
"num_eq": 5,
- "num_range": 781,
- "upper_bound": "24174"
+ "num_range": 814,
+ "upper_bound": "22674"
},
{
- "distinct_range": 629.9867768845187,
+ "distinct_range": 825.2134472666266,
"num_eq": 5,
- "num_range": 684,
- "upper_bound": "24809"
+ "num_range": 789,
+ "upper_bound": "23507"
},
{
- "distinct_range": 751.2133679538433,
+ "distinct_range": 603.4330439595428,
"num_eq": 5,
- "num_range": 748,
- "upper_bound": "25567"
+ "num_range": 671,
+ "upper_bound": "24115"
},
{
- "distinct_range": 624.0686135638291,
+ "distinct_range": 542.210175709961,
"num_eq": 5,
- "num_range": 682,
- "upper_bound": "26196"
+ "num_range": 643,
+ "upper_bound": "24661"
},
{
- "distinct_range": 666.4717342269539,
+ "distinct_range": 673.4762934031434,
"num_eq": 5,
- "num_range": 703,
- "upper_bound": "26868"
+ "num_range": 706,
+ "upper_bound": "25340"
},
{
- "distinct_range": 833.9157143017296,
+ "distinct_range": 706.0109527509259,
"num_eq": 5,
- "num_range": 794,
- "upper_bound": "27710"
+ "num_range": 723,
+ "upper_bound": "26052"
},
{
- "distinct_range": 696.0418923667495,
+ "distinct_range": 768.09144703673,
"num_eq": 5,
- "num_range": 718,
- "upper_bound": "28412"
+ "num_range": 757,
+ "upper_bound": "26827"
},
{
- "distinct_range": 855.5664194176215,
+ "distinct_range": 685.3084781312451,
"num_eq": 5,
- "num_range": 807,
- "upper_bound": "29276"
+ "num_range": 713,
+ "upper_bound": "27518"
},
{
- "distinct_range": 608.2844132891397,
+ "distinct_range": 773.0168746748601,
"num_eq": 5,
- "num_range": 674,
- "upper_bound": "29889"
+ "num_range": 760,
+ "upper_bound": "28298"
},
{
- "distinct_range": 749.2435008358334,
+ "distinct_range": 783.8520461916528,
"num_eq": 5,
- "num_range": 747,
- "upper_bound": "30645"
+ "num_range": 766,
+ "upper_bound": "29089"
},
{
- "distinct_range": 614.2039093328347,
+ "distinct_range": 682.3505852735691,
"num_eq": 5,
- "num_range": 677,
- "upper_bound": "31264"
+ "num_range": 711,
+ "upper_bound": "29777"
},
{
- "distinct_range": 866.3904443505969,
+ "distinct_range": 943.3188336386497,
"num_eq": 5,
- "num_range": 813,
- "upper_bound": "32139"
+ "num_range": 858,
+ "upper_bound": "30730"
},
{
- "distinct_range": 592.4965422165264,
+ "distinct_range": 665.5872469779547,
"num_eq": 5,
- "num_range": 666,
- "upper_bound": "32736"
+ "num_range": 702,
+ "upper_bound": "31401"
},
{
- "distinct_range": 783.710819210017,
+ "distinct_range": 650.7932270909681,
"num_eq": 5,
- "num_range": 766,
- "upper_bound": "33527"
+ "num_range": 695,
+ "upper_bound": "32057"
},
{
- "distinct_range": 882.1329635346208,
+ "distinct_range": 655.7248704185072,
"num_eq": 5,
- "num_range": 822,
- "upper_bound": "34418"
+ "num_range": 697,
+ "upper_bound": "32718"
},
{
- "distinct_range": 667.4575764143096,
+ "distinct_range": 884.2780390844284,
"num_eq": 5,
- "num_range": 703,
- "upper_bound": "35091"
+ "num_range": 823,
+ "upper_bound": "33611"
},
{
- "distinct_range": 613.2173621148775,
+ "distinct_range": 941.3511553552399,
"num_eq": 5,
- "num_range": 676,
- "upper_bound": "35709"
+ "num_range": 857,
+ "upper_bound": "34562"
},
{
- "distinct_range": 781.7415559495385,
+ "distinct_range": 683.3365608105223,
"num_eq": 5,
- "num_range": 765,
- "upper_bound": "36498"
+ "num_range": 712,
+ "upper_bound": "35251"
},
{
- "distinct_range": 646.7523057270853,
+ "distinct_range": 857.7021306035484,
"num_eq": 5,
- "num_range": 693,
- "upper_bound": "37150"
+ "num_range": 808,
+ "upper_bound": "36117"
},
{
- "distinct_range": 704.9109510617941,
+ "distinct_range": 763.1657967747672,
"num_eq": 5,
- "num_range": 723,
- "upper_bound": "37861"
+ "num_range": 754,
+ "upper_bound": "36887"
},
{
- "distinct_range": 808.3237205625335,
+ "distinct_range": 735.5778991696161,
"num_eq": 5,
- "num_range": 780,
- "upper_bound": "38677"
+ "num_range": 739,
+ "upper_bound": "37629"
},
{
- "distinct_range": 831.94728762926,
+ "distinct_range": 648.8204834319898,
"num_eq": 5,
- "num_range": 793,
- "upper_bound": "39517"
+ "num_range": 694,
+ "upper_bound": "38283"
},
{
- "distinct_range": 791.5875247456524,
+ "distinct_range": 813.3973482972481,
"num_eq": 5,
- "num_range": 770,
- "upper_bound": "40316"
+ "num_range": 782,
+ "upper_bound": "39104"
},
{
- "distinct_range": 653.654673228252,
+ "distinct_range": 830.1364943627041,
"num_eq": 5,
- "num_range": 696,
- "upper_bound": "40975"
+ "num_range": 792,
+ "upper_bound": "39942"
},
{
- "distinct_range": 799.463682904209,
+ "distinct_range": 756.2695067249741,
"num_eq": 5,
- "num_range": 775,
- "upper_bound": "41782"
+ "num_range": 751,
+ "upper_bound": "40705"
},
{
- "distinct_range": 779.7722575727291,
+ "distinct_range": 769.0765502799195,
"num_eq": 5,
- "num_range": 764,
- "upper_bound": "42569"
+ "num_range": 758,
+ "upper_bound": "41481"
},
{
- "distinct_range": 985.4030553034249,
+ "distinct_range": 753.3138164268312,
"num_eq": 5,
- "num_range": 884,
- "upper_bound": "43565"
+ "num_range": 749,
+ "upper_bound": "42241"
},
{
- "distinct_range": 653.654673228252,
+ "distinct_range": 839.9820237356929,
"num_eq": 5,
- "num_range": 696,
- "upper_bound": "44224"
+ "num_range": 798,
+ "upper_bound": "43089"
},
{
- "distinct_range": 637.8769099386531,
+ "distinct_range": 631.063516613744,
"num_eq": 5,
- "num_range": 688,
- "upper_bound": "44867"
+ "num_range": 685,
+ "upper_bound": "43725"
},
{
- "distinct_range": 528.3167112473104,
+ "distinct_range": 645.8612745606256,
"num_eq": 5,
- "num_range": 637,
- "upper_bound": "45399"
+ "num_range": 692,
+ "upper_bound": "44376"
},
{
- "distinct_range": 824.0732714842204,
+ "distinct_range": 830.1364943627041,
"num_eq": 5,
- "num_range": 789,
- "upper_bound": "46231"
+ "num_range": 792,
+ "upper_bound": "45214"
},
{
- "distinct_range": 665.4858799525288,
+ "distinct_range": 679.3925907756585,
"num_eq": 5,
- "num_range": 702,
- "upper_bound": "46902"
+ "num_range": 710,
+ "upper_bound": "45899"
},
{
- "distinct_range": 721.6612403244771,
+ "distinct_range": 793.7013048743872,
"num_eq": 5,
- "num_range": 732,
- "upper_bound": "47630"
+ "num_range": 771,
+ "upper_bound": "46700"
},
{
- "distinct_range": 655.6266647933971,
+ "distinct_range": 706.9966665111269,
"num_eq": 5,
- "num_range": 697,
- "upper_bound": "48291"
+ "num_range": 724,
+ "upper_bound": "47413"
},
{
- "distinct_range": 788.6338249302052,
+ "distinct_range": 933.4802115111881,
"num_eq": 5,
- "num_range": 769,
- "upper_bound": "49087"
+ "num_range": 853,
+ "upper_bound": "48356"
},
{
- "distinct_range": 735.4533460323819,
+ "distinct_range": 685.3084781312451,
"num_eq": 5,
- "num_range": 739,
- "upper_bound": "49829"
+ "num_range": 713,
+ "upper_bound": "49047"
},
{
- "distinct_range": 744.3186648840046,
+ "distinct_range": 883.2938339104758,
"num_eq": 5,
- "num_range": 744,
- "upper_bound": "50580"
+ "num_range": 823,
+ "upper_bound": "49939"
},
{
- "distinct_range": 948.0366527415014,
+ "distinct_range": 795.6710561094887,
"num_eq": 5,
- "num_range": 861,
- "upper_bound": "51538"
+ "num_range": 772,
+ "upper_bound": "50742"
},
{
- "distinct_range": 828.9945898432208,
+ "distinct_range": 569.8666646174739,
"num_eq": 5,
- "num_range": 791,
- "upper_bound": "52375"
+ "num_range": 656,
+ "upper_bound": "51316"
},
{
- "distinct_range": 710.8231679291555,
+ "distinct_range": 777.94208261536,
"num_eq": 5,
- "num_range": 726,
- "upper_bound": "53092"
+ "num_range": 763,
+ "upper_bound": "52101"
},
{
- "distinct_range": 831.94728762926,
+ "distinct_range": 604.4200332071216,
"num_eq": 5,
- "num_range": 793,
- "upper_bound": "53932"
+ "num_range": 672,
+ "upper_bound": "52710"
},
{
- "distinct_range": 717.7202698388794,
+ "distinct_range": 727.6942664599982,
"num_eq": 5,
- "num_range": 730,
- "upper_bound": "54656"
+ "num_range": 735,
+ "upper_bound": "53444"
},
{
- "distinct_range": 778.7875951579412,
+ "distinct_range": 860.6552569056258,
"num_eq": 5,
- "num_range": 763,
- "upper_bound": "55442"
+ "num_range": 810,
+ "upper_bound": "54313"
},
{
- "distinct_range": 824.0732714842204,
+ "distinct_range": 819.3055377775595,
"num_eq": 5,
- "num_range": 789,
- "upper_bound": "56274"
+ "num_range": 786,
+ "upper_bound": "55140"
},
{
- "distinct_range": 838.8366473010096,
+ "distinct_range": 677.4205375517361,
"num_eq": 5,
- "num_range": 797,
- "upper_bound": "57121"
+ "num_range": 709,
+ "upper_bound": "55823"
},
{
- "distinct_range": 800.4481647509274,
+ "distinct_range": 719.8099973942815,
"num_eq": 5,
- "num_range": 775,
- "upper_bound": "57929"
+ "num_range": 731,
+ "upper_bound": "56549"
},
{
- "distinct_range": 949.0200828503057,
+ "distinct_range": 664.6010632042853,
"num_eq": 5,
- "num_range": 862,
- "upper_bound": "58888"
+ "num_range": 702,
+ "upper_bound": "57219"
},
{
- "distinct_range": 809.3081279891328,
+ "distinct_range": 676.434493775766,
"num_eq": 5,
- "num_range": 780,
- "upper_bound": "59705"
+ "num_range": 708,
+ "upper_bound": "57901"
},
{
- "distinct_range": 748.2585529150406,
+ "distinct_range": 597.5108083373603,
"num_eq": 5,
- "num_range": 746,
- "upper_bound": "60460"
+ "num_range": 669,
+ "upper_bound": "58503"
},
{
- "distinct_range": 814.2300430996262,
+ "distinct_range": 724.7377408807972,
"num_eq": 5,
- "num_range": 783,
- "upper_bound": "61282"
+ "num_range": 733,
+ "upper_bound": "59234"
},
{
- "distinct_range": 742.3486626954385,
+ "distinct_range": 743.4609092171322,
"num_eq": 5,
- "num_range": 743,
- "upper_bound": "62031"
+ "num_range": 744,
+ "upper_bound": "59984"
},
{
- "distinct_range": 882.1329635346208,
+ "distinct_range": 769.0765502799195,
"num_eq": 5,
- "num_range": 822,
- "upper_bound": "62922"
+ "num_range": 758,
+ "upper_bound": "60760"
},
{
- "distinct_range": 854.5823740281329,
+ "distinct_range": 844.9045107319889,
"num_eq": 5,
- "num_range": 806,
- "upper_bound": "63785"
+ "num_range": 800,
+ "upper_bound": "61613"
},
{
- "distinct_range": 800.4481647509274,
+ "distinct_range": 625.1435950280666,
"num_eq": 5,
- "num_range": 775,
- "upper_bound": "64593"
+ "num_range": 682,
+ "upper_bound": "62243"
},
{
- "distinct_range": 711.8084999373816,
+ "distinct_range": 692.2098376391266,
"num_eq": 5,
- "num_range": 727,
- "upper_bound": "65311"
+ "num_range": 716,
+ "upper_bound": "62941"
},
{
- "distinct_range": 706.8817330375227,
+ "distinct_range": 691.22396232848,
"num_eq": 5,
- "num_range": 724,
- "upper_bound": "66024"
+ "num_range": 716,
+ "upper_bound": "63638"
},
{
- "distinct_range": 842.7732574653293,
+ "distinct_range": 715.8676198453843,
"num_eq": 5,
- "num_range": 799,
- "upper_bound": "66875"
+ "num_range": 729,
+ "upper_bound": "64360"
},
{
- "distinct_range": 675.3438828666475,
+ "distinct_range": 805.5193192735195,
"num_eq": 5,
- "num_range": 707,
- "upper_bound": "67556"
+ "num_range": 778,
+ "upper_bound": "65173"
},
{
- "distinct_range": 767.9557194228196,
+ "distinct_range": 701.0822249330786,
"num_eq": 5,
- "num_range": 757,
- "upper_bound": "68331"
+ "num_range": 721,
+ "upper_bound": "65880"
},
{
- "distinct_range": 473.9508134111793,
+ "distinct_range": 784.8370101102762,
"num_eq": 5,
- "num_range": 614,
- "upper_bound": "68808"
+ "num_range": 766,
+ "upper_bound": "66672"
},
{
- "distinct_range": 749.2435008358334,
+ "distinct_range": 879.3569469397013,
"num_eq": 5,
- "num_range": 747,
- "upper_bound": "69564"
+ "num_range": 820,
+ "upper_bound": "67560"
},
{
- "distinct_range": 669.4292246647884,
+ "distinct_range": 767.1063348887449,
"num_eq": 5,
- "num_range": 704,
- "upper_bound": "70239"
+ "num_range": 757,
+ "upper_bound": "68334"
},
{
- "distinct_range": 737.4234858657474,
+ "distinct_range": 734.5924794100079,
"num_eq": 5,
- "num_range": 740,
- "upper_bound": "70983"
+ "num_range": 739,
+ "upper_bound": "69075"
},
{
- "distinct_range": 754.1680972060622,
+ "distinct_range": 841.9510405259888,
"num_eq": 5,
- "num_range": 749,
- "upper_bound": "71744"
+ "num_range": 799,
+ "upper_bound": "69925"
},
{
- "distinct_range": 727.5723864399822,
+ "distinct_range": 809.4583976215613,
"num_eq": 5,
- "num_range": 735,
- "upper_bound": "72478"
+ "num_range": 780,
+ "upper_bound": "70742"
},
{
- "distinct_range": 738.4085409215376,
+ "distinct_range": 680.3786002879983,
"num_eq": 5,
- "num_range": 741,
- "upper_bound": "73223"
+ "num_range": 710,
+ "upper_bound": "71428"
},
{
- "distinct_range": 856.5504575603213,
+ "distinct_range": 754.2990557611244,
"num_eq": 5,
- "num_range": 807,
- "upper_bound": "74088"
+ "num_range": 749,
+ "upper_bound": "72189"
},
{
- "distinct_range": 890.9873634131902,
+ "distinct_range": 762.1806397465457,
"num_eq": 5,
- "num_range": 827,
- "upper_bound": "74988"
+ "num_range": 754,
+ "upper_bound": "72958"
},
{
- "distinct_range": 871.3101722060628,
+ "distinct_range": 755.2842858522722,
"num_eq": 5,
- "num_range": 816,
- "upper_bound": "75868"
+ "num_range": 750,
+ "upper_bound": "73720"
},
{
- "distinct_range": 665.4858799525288,
+ "distinct_range": 659.6699654119745,
"num_eq": 5,
- "num_range": 702,
- "upper_bound": "76539"
+ "num_range": 699,
+ "upper_bound": "74385"
},
{
- "distinct_range": 658.5845586894598,
+ "distinct_range": 880.3411786560907,
"num_eq": 5,
- "num_range": 699,
- "upper_bound": "77203"
+ "num_range": 821,
+ "upper_bound": "75274"
},
{
- "distinct_range": 849.6620377440299,
+ "distinct_range": 772.0318068159797,
"num_eq": 5,
- "num_range": 803,
- "upper_bound": "78061"
+ "num_range": 759,
+ "upper_bound": "76053"
},
{
- "distinct_range": 831.94728762926,
+ "distinct_range": 874.4356878848909,
"num_eq": 5,
- "num_range": 793,
- "upper_bound": "78901"
+ "num_range": 818,
+ "upper_bound": "76936"
},
{
- "distinct_range": 604.3377964304191,
+ "distinct_range": 777.94208261536,
"num_eq": 5,
- "num_range": 672,
- "upper_bound": "79510"
+ "num_range": 763,
+ "upper_bound": "77721"
},
{
- "distinct_range": 897.8737468288753,
+ "distinct_range": 935.4479822961132,
"num_eq": 5,
- "num_range": 831,
- "upper_bound": "80417"
+ "num_range": 854,
+ "upper_bound": "78666"
},
{
- "distinct_range": 648.7244741697218,
+ "distinct_range": 806.5041009018855,
"num_eq": 5,
- "num_range": 694,
- "upper_bound": "81071"
+ "num_range": 779,
+ "upper_bound": "79480"
},
{
- "distinct_range": 748.2585529150406,
+ "distinct_range": 860.6552569056258,
"num_eq": 5,
- "num_range": 746,
- "upper_bound": "81826"
+ "num_range": 810,
+ "upper_bound": "80349"
},
{
- "distinct_range": 720.6760132827105,
+ "distinct_range": 814.3820661707975,
"num_eq": 5,
- "num_range": 731,
- "upper_bound": "82553"
+ "num_range": 783,
+ "upper_bound": "81171"
},
{
- "distinct_range": 632.9456765352121,
+ "distinct_range": 634.0233000003948,
"num_eq": 5,
"num_range": 686,
- "upper_bound": "83191"
+ "upper_bound": "81810"
},
{
- "distinct_range": 631.9593900296002,
+ "distinct_range": 666.5734189023556,
"num_eq": 5,
- "num_range": 685,
- "upper_bound": "83828"
+ "num_range": 703,
+ "upper_bound": "82482"
},
{
- "distinct_range": 651.6826314884102,
+ "distinct_range": 802.564925932101,
"num_eq": 5,
- "num_range": 695,
- "upper_bound": "84485"
+ "num_range": 776,
+ "upper_bound": "83292"
},
{
- "distinct_range": 891.9711522423338,
+ "distinct_range": 610.3416723667392,
"num_eq": 5,
- "num_range": 828,
- "upper_bound": "85386"
+ "num_range": 675,
+ "upper_bound": "83907"
},
{
- "distinct_range": 765.9861699823155,
+ "distinct_range": 864.5926607705935,
"num_eq": 5,
- "num_range": 756,
- "upper_bound": "86159"
+ "num_range": 812,
+ "upper_bound": "84780"
},
{
- "distinct_range": 702.9401257477299,
+ "distinct_range": 745.4315660077249,
"num_eq": 5,
- "num_range": 722,
- "upper_bound": "86868"
+ "num_range": 745,
+ "upper_bound": "85532"
},
{
- "distinct_range": 753.1831969446264,
+ "distinct_range": 771.0467301460965,
"num_eq": 5,
- "num_range": 749,
- "upper_bound": "87628"
+ "num_range": 759,
+ "upper_bound": "86310"
},
{
- "distinct_range": 827.0260859057215,
+ "distinct_range": 831.1210810173288,
"num_eq": 5,
- "num_range": 790,
- "upper_bound": "88463"
+ "num_range": 793,
+ "upper_bound": "87149"
},
{
- "distinct_range": 769.9252324258391,
+ "distinct_range": 756.2695067249741,
"num_eq": 5,
- "num_range": 758,
- "upper_bound": "89240"
+ "num_range": 751,
+ "upper_bound": "87912"
},
{
- "distinct_range": 755.1529880120247,
+ "distinct_range": 774.9869840525455,
"num_eq": 5,
- "num_range": 750,
- "upper_bound": "90002"
+ "num_range": 761,
+ "upper_bound": "88694"
},
{
- "distinct_range": 812.261301376356,
+ "distinct_range": 840.9665358084405,
"num_eq": 5,
- "num_range": 782,
- "upper_bound": "90822"
+ "num_range": 798,
+ "upper_bound": "89543"
},
{
- "distinct_range": 724.616859528211,
+ "distinct_range": 833.0902317155856,
"num_eq": 5,
- "num_range": 733,
- "upper_bound": "91553"
+ "num_range": 794,
+ "upper_bound": "90384"
},
{
- "distinct_range": 806.3548811368652,
+ "distinct_range": 715.8676198453843,
"num_eq": 5,
- "num_range": 778,
- "upper_bound": "92367"
+ "num_range": 729,
+ "upper_bound": "91106"
},
{
- "distinct_range": 777.8029238946048,
+ "distinct_range": 652.7659212783636,
"num_eq": 5,
- "num_range": 762,
- "upper_bound": "93152"
+ "num_range": 696,
+ "upper_bound": "91764"
},
{
- "distinct_range": 769.9252324258391,
+ "distinct_range": 658.6837098300775,
"num_eq": 5,
- "num_range": 758,
- "upper_bound": "93929"
+ "num_range": 699,
+ "upper_bound": "92428"
},
{
- "distinct_range": 720.6760132827105,
+ "distinct_range": 898.0562262718568,
"num_eq": 5,
- "num_range": 731,
- "upper_bound": "94656"
+ "num_range": 831,
+ "upper_bound": "93335"
},
{
- "distinct_range": 806.3548811368652,
+ "distinct_range": 677.4205375517361,
"num_eq": 5,
- "num_range": 778,
- "upper_bound": "95470"
+ "num_range": 709,
+ "upper_bound": "94018"
},
{
- "distinct_range": 586.5751082397829,
+ "distinct_range": 750.3580427168374,
"num_eq": 5,
- "num_range": 663,
- "upper_bound": "96061"
+ "num_range": 747,
+ "upper_bound": "94775"
},
{
- "distinct_range": 653.654673228252,
+ "distinct_range": 703.0537479812078,
"num_eq": 5,
- "num_range": 696,
- "upper_bound": "96720"
+ "num_range": 722,
+ "upper_bound": "95484"
},
{
- "distinct_range": 629.9867768845187,
+ "distinct_range": 787.7918508671038,
"num_eq": 5,
- "num_range": 684,
- "upper_bound": "97355"
+ "num_range": 768,
+ "upper_bound": "96279"
},
{
- "distinct_range": 836.8682969218004,
+ "distinct_range": 715.8676198453843,
"num_eq": 5,
- "num_range": 796,
- "upper_bound": "98200"
+ "num_range": 729,
+ "upper_bound": "97001"
},
{
- "distinct_range": 790.6029667226838,
+ "distinct_range": 665.5872469779547,
"num_eq": 5,
- "num_range": 770,
- "upper_bound": "98998"
+ "num_range": 702,
+ "upper_bound": "97672"
},
{
- "distinct_range": 570.7818976432161,
+ "distinct_range": 715.8676198453843,
"num_eq": 5,
- "num_range": 656,
- "upper_bound": "99573"
+ "num_range": 729,
+ "upper_bound": "98394"
},
{
- "distinct_range": 640.8354920579599,
+ "distinct_range": 656.7111623679733,
"num_eq": 5,
- "num_range": 690,
- "upper_bound": "100219"
+ "num_range": 698,
+ "upper_bound": "99056"
},
{
- "distinct_range": 749.2435008358334,
+ "distinct_range": 786.80691242577,
"num_eq": 5,
- "num_range": 747,
- "upper_bound": "100975"
+ "num_range": 767,
+ "upper_bound": "99850"
},
{
- "distinct_range": 812.261301376356,
+ "distinct_range": 830.1364943627041,
"num_eq": 5,
- "num_range": 782,
- "upper_bound": "101795"
+ "num_range": 792,
+ "upper_bound": "100688"
},
{
- "distinct_range": 817.1830952970179,
+ "distinct_range": 710.9394165141803,
"num_eq": 5,
- "num_range": 785,
- "upper_bound": "102620"
+ "num_range": 726,
+ "upper_bound": "101405"
},
{
- "distinct_range": 757.122741358512,
+ "distinct_range": 731.6361614947125,
"num_eq": 5,
- "num_range": 751,
- "upper_bound": "103384"
+ "num_range": 737,
+ "upper_bound": "102143"
},
{
- "distinct_range": 654.6406752647165,
+ "distinct_range": 603.4330439595428,
"num_eq": 5,
- "num_range": 697,
- "upper_bound": "104044"
+ "num_range": 671,
+ "upper_bound": "102751"
},
{
- "distinct_range": 586.5751082397829,
+ "distinct_range": 702.0679917969968,
"num_eq": 5,
- "num_range": 663,
- "upper_bound": "104635"
+ "num_range": 721,
+ "upper_bound": "103459"
},
{
- "distinct_range": 783.710819210017,
+ "distinct_range": 915.7692080796647,
"num_eq": 5,
- "num_range": 766,
- "upper_bound": "105426"
+ "num_range": 842,
+ "upper_bound": "104384"
},
{
- "distinct_range": 651.6826314884102,
+ "distinct_range": 662.6286599740733,
"num_eq": 5,
- "num_range": 695,
- "upper_bound": "106083"
+ "num_range": 701,
+ "upper_bound": "105052"
},
{
- "distinct_range": 955.9039329771783,
+ "distinct_range": 669.5318639155721,
"num_eq": 5,
- "num_range": 866,
- "upper_bound": "107049"
+ "num_range": 704,
+ "upper_bound": "105727"
},
{
- "distinct_range": 867.374403955572,
+ "distinct_range": 676.434493775766,
"num_eq": 5,
- "num_range": 813,
- "upper_bound": "107925"
+ "num_range": 708,
+ "upper_bound": "106409"
},
{
- "distinct_range": 782.7261919578056,
+ "distinct_range": 709.9537447111205,
"num_eq": 5,
- "num_range": 765,
- "upper_bound": "108715"
+ "num_range": 726,
+ "upper_bound": "107125"
},
{
- "distinct_range": 1013.9143397950231,
+ "distinct_range": 651.7795803508873,
"num_eq": 5,
- "num_range": 901,
- "upper_bound": "109740"
+ "num_range": 695,
+ "upper_bound": "107782"
},
{
- "distinct_range": 749.2435008358334,
+ "distinct_range": 590.6008741003892,
"num_eq": 5,
- "num_range": 747,
- "upper_bound": "110496"
+ "num_range": 665,
+ "upper_bound": "108377"
},
{
- "distinct_range": 627.027756247418,
+ "distinct_range": 637.9694961726668,
"num_eq": 5,
- "num_range": 683,
- "upper_bound": "111128"
+ "num_range": 688,
+ "upper_bound": "109020"
},
{
- "distinct_range": 673.3723776210155,
+ "distinct_range": 563.9413488985941,
"num_eq": 5,
- "num_range": 706,
- "upper_bound": "111807"
+ "num_range": 653,
+ "upper_bound": "109588"
},
{
- "distinct_range": 638.8631170626214,
+ "distinct_range": 641.9154869061507,
"num_eq": 5,
- "num_range": 689,
- "upper_bound": "112451"
+ "num_range": 690,
+ "upper_bound": "110235"
},
{
- "distinct_range": 726.5872210107702,
+ "distinct_range": 725.7232593950988,
"num_eq": 5,
"num_range": 734,
- "upper_bound": "113184"
+ "upper_bound": "110967"
},
{
- "distinct_range": 676.4314389322568,
+ "distinct_range": 825.2134472666266,
"num_eq": 5,
- "num_range": 715,
- "upper_bound": "113866"
+ "num_range": 789,
+ "upper_bound": "111800"
},
{
- "distinct_range": 746.401497487265,
+ "distinct_range": 577.7662060934822,
"num_eq": 5,
- "num_range": 752,
- "upper_bound": "114619"
+ "num_range": 659,
+ "upper_bound": "112382"
},
{
- "distinct_range": 927.5203255929753,
+ "distinct_range": 806.6229249952753,
"num_eq": 5,
- "num_range": 855,
- "upper_bound": "115556"
+ "num_range": 785,
+ "upper_bound": "113196"
},
{
- "distinct_range": 780.8748501211991,
+ "distinct_range": 711.0444040844268,
"num_eq": 5,
- "num_range": 771,
- "upper_bound": "116344"
+ "num_range": 733,
+ "upper_bound": "113913"
},
{
- "distinct_range": 679.3890618125884,
+ "distinct_range": 723.8591608129574,
"num_eq": 5,
- "num_range": 717,
- "upper_bound": "117029"
+ "num_range": 740,
+ "upper_bound": "114643"
},
{
- "distinct_range": 822.2284056495587,
+ "distinct_range": 877.5164571240693,
"num_eq": 5,
- "num_range": 794,
- "upper_bound": "117859"
+ "num_range": 826,
+ "upper_bound": "115529"
},
{
- "distinct_range": 760.1922269399929,
+ "distinct_range": 732.729896639699,
"num_eq": 5,
- "num_range": 760,
- "upper_bound": "118626"
+ "num_range": 745,
+ "upper_bound": "116268"
},
{
- "distinct_range": 880.2965506204616,
+ "distinct_range": 1049.6891316591516,
"num_eq": 5,
- "num_range": 827,
- "upper_bound": "119515"
+ "num_range": 929,
+ "upper_bound": "117329"
},
{
- "distinct_range": 736.549797256818,
+ "distinct_range": 1001.4976057875397,
"num_eq": 5,
- "num_range": 747,
- "upper_bound": "120258"
+ "num_range": 899,
+ "upper_bound": "118341"
},
{
- "distinct_range": 756.2522115936692,
+ "distinct_range": 728.7874486323096,
"num_eq": 5,
- "num_range": 757,
- "upper_bound": "121021"
+ "num_range": 743,
+ "upper_bound": "119076"
},
{
- "distinct_range": 773.9810939178112,
+ "distinct_range": 814.501952982374,
"num_eq": 5,
- "num_range": 767,
- "upper_bound": "121802"
+ "num_range": 790,
+ "upper_bound": "119898"
},
{
- "distinct_range": 697.1325867808343,
+ "distinct_range": 875.547703709589,
"num_eq": 5,
- "num_range": 726,
- "upper_bound": "122505"
+ "num_range": 825,
+ "upper_bound": "120782"
},
{
- "distinct_range": 626.1346015274789,
+ "distinct_range": 794.8033931757922,
"num_eq": 5,
- "num_range": 690,
- "upper_bound": "123136"
+ "num_range": 779,
+ "upper_bound": "121584"
},
{
- "distinct_range": 809.4300906725737,
+ "distinct_range": 597.5968859676663,
"num_eq": 5,
- "num_range": 787,
- "upper_bound": "123953"
+ "num_range": 677,
+ "upper_bound": "122186"
},
{
- "distinct_range": 802.5381091068551,
+ "distinct_range": 639.0493316285276,
"num_eq": 5,
- "num_range": 783,
- "upper_bound": "124763"
+ "num_range": 697,
+ "upper_bound": "122830"
},
{
- "distinct_range": 731.6235690291636,
+ "distinct_range": 754.4105439273462,
"num_eq": 5,
- "num_range": 744,
- "upper_bound": "125501"
+ "num_range": 756,
+ "upper_bound": "123591"
},
{
- "distinct_range": 763.1471385998129,
+ "distinct_range": 631.1554863101879,
"num_eq": 5,
- "num_range": 761,
- "upper_bound": "126271"
+ "num_range": 693,
+ "upper_bound": "124227"
},
{
- "distinct_range": 734.5793365399803,
+ "distinct_range": 938.5348185421147,
"num_eq": 5,
- "num_range": 746,
- "upper_bound": "127012"
+ "num_range": 862,
+ "upper_bound": "125175"
},
{
- "distinct_range": 821.2439689011601,
+ "distinct_range": 781.9975214921509,
"num_eq": 5,
- "num_range": 793,
- "upper_bound": "127841"
+ "num_range": 772,
+ "upper_bound": "125964"
},
{
- "distinct_range": 636.9858083261129,
+ "distinct_range": 801.6982660276508,
"num_eq": 5,
- "num_range": 696,
- "upper_bound": "128483"
+ "num_range": 783,
+ "upper_bound": "126773"
},
{
- "distinct_range": 740.4905973741699,
+ "distinct_range": 755.3959173265044,
"num_eq": 5,
- "num_range": 749,
- "upper_bound": "129230"
+ "num_range": 757,
+ "upper_bound": "127535"
},
{
- "distinct_range": 733.5940909218475,
+ "distinct_range": 831.2431887843684,
"num_eq": 5,
- "num_range": 745,
- "upper_bound": "129970"
+ "num_range": 799,
+ "upper_bound": "128374"
},
{
- "distinct_range": 752.312042612521,
+ "distinct_range": 793.8183776048637,
"num_eq": 5,
- "num_range": 755,
- "upper_bound": "130729"
+ "num_range": 778,
+ "upper_bound": "129175"
},
{
- "distinct_range": 832.072332430479,
+ "distinct_range": 746.5272149118323,
"num_eq": 5,
- "num_range": 800,
- "upper_bound": "131569"
+ "num_range": 752,
+ "upper_bound": "129928"
},
{
- "distinct_range": 793.676377209335,
+ "distinct_range": 675.5478136120616,
"num_eq": 5,
- "num_range": 778,
- "upper_bound": "132370"
+ "num_range": 715,
+ "upper_bound": "130609"
},
{
- "distinct_range": 856.6787473000596,
+ "distinct_range": 664.6986687168576,
"num_eq": 5,
- "num_range": 814,
- "upper_bound": "133235"
+ "num_range": 709,
+ "upper_bound": "131279"
},
{
- "distinct_range": 878.3285570894932,
+ "distinct_range": 815.4867950212617,
"num_eq": 5,
- "num_range": 826,
- "upper_bound": "134122"
+ "num_range": 790,
+ "upper_bound": "132102"
},
{
- "distinct_range": 645.8628601459966,
+ "distinct_range": 813.5171028894756,
"num_eq": 5,
- "num_range": 700,
- "upper_bound": "134773"
+ "num_range": 789,
+ "upper_bound": "132923"
},
{
- "distinct_range": 723.7410686437424,
+ "distinct_range": 944.4385573006232,
"num_eq": 5,
- "num_range": 740,
- "upper_bound": "135503"
+ "num_range": 865,
+ "upper_bound": "133877"
},
{
- "distinct_range": 783.8291817110759,
+ "distinct_range": 846.9976071231381,
"num_eq": 5,
- "num_range": 773,
- "upper_bound": "136294"
+ "num_range": 808,
+ "upper_bound": "134732"
},
{
- "distinct_range": 671.5018276623507,
+ "distinct_range": 781.9975214921509,
"num_eq": 5,
- "num_range": 713,
- "upper_bound": "136971"
+ "num_range": 772,
+ "upper_bound": "135521"
},
{
- "distinct_range": 874.3924857805889,
+ "distinct_range": 729.7730757396539,
"num_eq": 5,
- "num_range": 824,
- "upper_bound": "137854"
+ "num_range": 743,
+ "upper_bound": "136257"
},
{
- "distinct_range": 819.275071101838,
+ "distinct_range": 743.5708081867305,
"num_eq": 5,
- "num_range": 792,
- "upper_bound": "138681"
+ "num_range": 751,
+ "upper_bound": "137007"
},
{
- "distinct_range": 649.8078753375713,
+ "distinct_range": 726.8161640433515,
"num_eq": 5,
- "num_range": 702,
- "upper_bound": "139336"
+ "num_range": 742,
+ "upper_bound": "137740"
},
{
- "distinct_range": 712.9015314951571,
+ "distinct_range": 596.6096190532006,
"num_eq": 5,
- "num_range": 734,
- "upper_bound": "140055"
+ "num_range": 676,
+ "upper_bound": "138341"
},
{
- "distinct_range": 744.4312371734234,
+ "distinct_range": 612.4041491922645,
"num_eq": 5,
- "num_range": 751,
- "upper_bound": "140806"
+ "num_range": 684,
+ "upper_bound": "138958"
},
{
- "distinct_range": 677.4173251489971,
+ "distinct_range": 730.7586927585861,
"num_eq": 5,
- "num_range": 716,
- "upper_bound": "141489"
+ "num_range": 744,
+ "upper_bound": "139695"
},
{
- "distinct_range": 682.3465778798568,
+ "distinct_range": 663.712310898426,
"num_eq": 5,
- "num_range": 718,
- "upper_bound": "142177"
+ "num_range": 709,
+ "upper_bound": "140364"
},
{
- "distinct_range": 690.2327719187579,
+ "distinct_range": 602.5330008681908,
"num_eq": 5,
- "num_range": 722,
- "upper_bound": "142873"
+ "num_range": 679,
+ "upper_bound": "140971"
},
{
- "distinct_range": 804.5072888492075,
+ "distinct_range": 861.7656491640009,
"num_eq": 5,
- "num_range": 784,
- "upper_bound": "143685"
+ "num_range": 817,
+ "upper_bound": "141841"
},
{
- "distinct_range": 793.676377209335,
+ "distinct_range": 752.439768795045,
"num_eq": 5,
- "num_range": 778,
- "upper_bound": "144486"
+ "num_range": 755,
+ "upper_bound": "142600"
},
{
- "distinct_range": 646.8491334407053,
+ "distinct_range": 749.48353488457,
"num_eq": 5,
- "num_range": 700,
- "upper_bound": "145138"
+ "num_range": 754,
+ "upper_bound": "143356"
},
{
- "distinct_range": 673.4737083419136,
+ "distinct_range": 828.2890178266346,
"num_eq": 5,
- "num_range": 714,
- "upper_bound": "145817"
+ "num_range": 797,
+ "upper_bound": "144192"
},
{
- "distinct_range": 721.7703392236174,
+ "distinct_range": 663.712310898426,
"num_eq": 5,
- "num_range": 739,
- "upper_bound": "146545"
+ "num_range": 709,
+ "upper_bound": "144861"
},
{
- "distinct_range": 739.5054124417314,
+ "distinct_range": 739.6287963993725,
"num_eq": 5,
"num_range": 748,
- "upper_bound": "147291"
+ "upper_bound": "145607"
},
{
- "distinct_range": 639.9449448217953,
+ "distinct_range": 602.5330008681908,
"num_eq": 5,
- "num_range": 697,
- "upper_bound": "147936"
+ "num_range": 679,
+ "upper_bound": "146214"
},
{
- "distinct_range": 744.4312371734234,
+ "distinct_range": 744.5562867771326,
"num_eq": 5,
"num_range": 751,
- "upper_bound": "148687"
+ "upper_bound": "146965"
+ },
+ {
+ "distinct_range": 788.8931718235921,
+ "num_eq": 5,
+ "num_range": 775,
+ "upper_bound": "147761"
},
{
- "distinct_range": 568.8901650084352,
+ "distinct_range": 715.9733656732451,
"num_eq": 5,
- "num_range": 663,
- "upper_bound": "149260"
+ "num_range": 736,
+ "upper_bound": "148483"
},
{
- "distinct_range": 723.7410686437424,
+ "distinct_range": 815.4867950212617,
"num_eq": 5,
- "num_range": 740,
- "upper_bound": "149990"
+ "num_range": 790,
+ "upper_bound": "149306"
+ },
+ {
+ "distinct_range": 674.5615870320078,
+ "num_eq": 5,
+ "num_range": 714,
+ "upper_bound": "149986"
+ },
+ {
+ "distinct_range": 7.275957614183426E-11,
+ "num_eq": 0,
+ "num_range": 0,
+ "upper_bound": "9223372036854775807"
}
],
"histo_col_type": "INT8",
@@ -1217,159 +1230,160 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 2,
"columns": [
"c_nationkey"
],
- "created_at": "2021-09-08 20:49:19.847293",
+ "created_at": "2022-02-25 00:55:38.309222",
"distinct_count": 25,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 5865,
+ "num_eq": 5475,
"num_range": 0,
"upper_bound": "0"
},
{
"distinct_range": 0,
- "num_eq": 5790,
+ "num_eq": 5910,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 5715,
+ "num_eq": 5925,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 6645,
+ "num_eq": 6075,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 5865,
+ "num_eq": 5910,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 5955,
+ "num_eq": 5895,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 5790,
+ "num_eq": 6765,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 5865,
+ "num_eq": 6090,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 5760,
+ "num_eq": 6000,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 6060,
+ "num_eq": 6735,
"num_range": 0,
"upper_bound": "9"
},
{
"distinct_range": 0,
- "num_eq": 5790,
+ "num_eq": 5730,
"num_range": 0,
"upper_bound": "10"
},
{
"distinct_range": 0,
- "num_eq": 6435,
+ "num_eq": 6015,
"num_range": 0,
"upper_bound": "11"
},
{
"distinct_range": 0,
- "num_eq": 6150,
+ "num_eq": 5895,
"num_range": 0,
"upper_bound": "12"
},
{
"distinct_range": 0,
- "num_eq": 6075,
+ "num_eq": 6180,
"num_range": 0,
"upper_bound": "13"
},
{
"distinct_range": 0,
- "num_eq": 5805,
+ "num_eq": 5565,
"num_range": 0,
"upper_bound": "14"
},
{
"distinct_range": 0,
- "num_eq": 7050,
+ "num_eq": 5760,
"num_range": 0,
"upper_bound": "15"
},
{
"distinct_range": 0,
- "num_eq": 5970,
+ "num_eq": 6390,
"num_range": 0,
"upper_bound": "16"
},
{
"distinct_range": 0,
- "num_eq": 5970,
+ "num_eq": 6135,
"num_range": 0,
"upper_bound": "17"
},
{
"distinct_range": 0,
- "num_eq": 5865,
+ "num_eq": 5940,
"num_range": 0,
"upper_bound": "18"
},
{
"distinct_range": 0,
- "num_eq": 5895,
+ "num_eq": 6105,
"num_range": 0,
"upper_bound": "19"
},
{
"distinct_range": 0,
- "num_eq": 5835,
+ "num_eq": 6150,
"num_range": 0,
"upper_bound": "20"
},
{
"distinct_range": 0,
- "num_eq": 6180,
+ "num_eq": 5700,
"num_range": 0,
"upper_bound": "21"
},
{
"distinct_range": 0,
- "num_eq": 5760,
+ "num_eq": 6225,
"num_range": 0,
"upper_bound": "22"
},
{
"distinct_range": 0,
- "num_eq": 5775,
+ "num_eq": 6075,
"num_range": 0,
"upper_bound": "23"
},
{
"distinct_range": 0,
- "num_eq": 6135,
+ "num_eq": 5355,
"num_range": 0,
"upper_bound": "24"
}
@@ -1381,23 +1395,24 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 20,
"columns": [
"c_name"
],
- "created_at": "2021-09-08 20:49:19.847293",
+ "created_at": "2022-02-25 00:55:38.309222",
"distinct_count": 150000,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": "Customer#000000037"
+ "upper_bound": "Customer#000000059"
},
{
"distinct_range": 149998,
"num_eq": 1,
"num_range": 149998,
- "upper_bound": "Customer#000149990"
+ "upper_bound": "Customer#000149986"
}
],
"histo_col_type": "VARCHAR(25)",
@@ -1407,23 +1422,24 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 28,
"columns": [
"c_address"
],
- "created_at": "2021-09-08 20:49:19.847293",
- "distinct_count": 150000,
+ "created_at": "2022-02-25 00:55:38.309222",
+ "distinct_count": 149937,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1,
+ "num_eq": 15,
"num_range": 0,
- "upper_bound": " P2khq0dbP"
+ "upper_bound": " BAEZWaPhKP6 rBk,WBsgRMjmelv7"
},
{
- "distinct_range": 149998,
- "num_eq": 1,
- "num_range": 149998,
- "upper_bound": "zzUlzMPWHZ"
+ "distinct_range": 149935,
+ "num_eq": 15,
+ "num_range": 149970,
+ "upper_bound": "zzxGktzXTMKS1BxZlgQ9nqQ"
}
],
"histo_col_type": "VARCHAR(40)",
@@ -1433,23 +1449,24 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 17,
"columns": [
"c_phone"
],
- "created_at": "2021-09-08 20:49:19.847293",
+ "created_at": "2022-02-25 00:55:38.309222",
"distinct_count": 150000,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": "10-104-665-3850"
+ "upper_bound": "10-100-106-1617"
},
{
"distinct_range": 149998,
"num_eq": 1,
"num_range": 149998,
- "upper_bound": "34-996-464-1615"
+ "upper_bound": "34-999-618-6881"
}
],
"histo_col_type": "CHAR(15)",
@@ -1459,23 +1476,24 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 9,
"columns": [
"c_acctbal"
],
- "created_at": "2021-09-08 20:49:19.847293",
- "distinct_count": 140426,
+ "created_at": "2022-02-25 00:55:38.309222",
+ "distinct_count": 140628,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 15,
"num_range": 0,
- "upper_bound": "-997.5"
+ "upper_bound": "-997.51"
},
{
- "distinct_range": 140424,
+ "distinct_range": 140626,
"num_eq": 15,
"num_range": 149970,
- "upper_bound": "9999.6904296875"
+ "upper_bound": "9998.32"
}
],
"histo_col_type": "FLOAT8",
@@ -1485,22 +1503,23 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 11,
"columns": [
"c_mktsegment"
],
- "created_at": "2021-09-08 20:49:19.847293",
+ "created_at": "2022-02-25 00:55:38.309222",
"distinct_count": 5,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 28890,
+ "num_eq": 29085,
"num_range": 0,
"upper_bound": "AUTOMOBILE"
},
{
"distinct_range": 3,
- "num_eq": 30615,
- "num_range": 90495,
+ "num_eq": 29265,
+ "num_range": 91650,
"upper_bound": "MACHINERY"
}
],
@@ -1511,23 +1530,24 @@ ALTER TABLE "customer" INJECT STATISTICS '[
"row_count": 150000
},
{
+ "avg_size": 75,
"columns": [
"c_comment"
],
- "created_at": "2021-09-08 20:49:19.847293",
- "distinct_count": 150000,
+ "created_at": "2022-02-25 00:55:38.309222",
+ "distinct_count": 149323,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1,
+ "num_eq": 15,
"num_range": 0,
- "upper_bound": " About and hold house dog key. Become news pla"
+ "upper_bound": " Tiresias. carefully even accounts boost carefully quickly ironic requests. bold, ironic pin"
},
{
- "distinct_range": 149998,
- "num_eq": 1,
- "num_range": 149998,
- "upper_bound": "zine although of specific. Be ahead dog surface. Movement k"
+ "distinct_range": 149321,
+ "num_eq": 15,
+ "num_range": 149970,
+ "upper_bound": "zle carefully at the carefully final foxes. slyly ironic theodolites wake careful"
}
],
"histo_col_type": "VARCHAR(117)",
@@ -1542,3720 +1562,3726 @@ ALTER TABLE "customer" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "lineitem" INJECT STATISTICS '[
{
+ "avg_size": 4,
"columns": [
"l_orderkey"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 1527270,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 600,
"num_range": 0,
- "upper_bound": "576"
+ "upper_bound": "197"
},
{
- "distinct_range": 8382.243103409697,
+ "distinct_range": 6875.089899424659,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "38535"
+ "num_range": 29406,
+ "upper_bound": "23686"
},
{
- "distinct_range": 7495.933560226399,
+ "distinct_range": 7636.927017679607,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "66885"
+ "num_range": 29406,
+ "upper_bound": "53253"
},
{
- "distinct_range": 7274.823155048839,
+ "distinct_range": 8330.222399538987,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "93380"
+ "num_range": 29406,
+ "upper_bound": "90435"
},
{
- "distinct_range": 8065.458164758223,
+ "distinct_range": 7815.399734151204,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "127425"
+ "num_range": 29406,
+ "upper_bound": "121730"
},
{
- "distinct_range": 7654.680638850278,
+ "distinct_range": 7840.555811244131,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "157218"
+ "num_range": 29406,
+ "upper_bound": "153280"
},
{
- "distinct_range": 7369.0704470940445,
+ "distinct_range": 6676.478858540478,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "184483"
+ "num_range": 29406,
+ "upper_bound": "175456"
},
{
- "distinct_range": 7764.001140494762,
+ "distinct_range": 7986.685904568448,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "215330"
+ "num_range": 29406,
+ "upper_bound": "208548"
},
{
- "distinct_range": 8350.640244918379,
+ "distinct_range": 8038.140227620831,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "252869"
+ "num_range": 29406,
+ "upper_bound": "242209"
},
{
- "distinct_range": 7780.336281965635,
+ "distinct_range": 7770.59046637861,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "283878"
+ "num_range": 29406,
+ "upper_bound": "273057"
},
{
- "distinct_range": 7668.139244249834,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "313798"
+ "distinct_range": 6817.174265720615,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "296640"
},
{
- "distinct_range": 6835.328449009817,
+ "distinct_range": 8038.676030844988,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "337056"
+ "num_range": 29406,
+ "upper_bound": "330307"
},
{
- "distinct_range": 8188.713723819864,
+ "distinct_range": 7754.734778688364,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "372549"
+ "num_range": 29406,
+ "upper_bound": "360999"
},
{
- "distinct_range": 7342.146567272742,
+ "distinct_range": 7128.208062650416,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "399591"
+ "num_range": 29406,
+ "upper_bound": "386307"
},
{
- "distinct_range": 7294.582899669164,
+ "distinct_range": 8060.966014009839,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "426245"
+ "num_range": 29406,
+ "upper_bound": "420225"
},
{
- "distinct_range": 8090.582952876495,
+ "distinct_range": 7664.494318698277,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "460578"
+ "num_range": 29406,
+ "upper_bound": "450050"
},
{
- "distinct_range": 8374.91667623081,
+ "distinct_range": 7432.280017650198,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "498439"
+ "num_range": 29406,
+ "upper_bound": "477795"
},
{
- "distinct_range": 7410.143264361364,
+ "distinct_range": 7332.9857028733795,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "526049"
+ "num_range": 29406,
+ "upper_bound": "504711"
},
{
- "distinct_range": 7503.77672288382,
+ "distinct_range": 7512.695024124555,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "554468"
+ "num_range": 29406,
+ "upper_bound": "533153"
},
{
- "distinct_range": 6863.974485906984,
+ "distinct_range": 6879.4651154107805,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "577921"
+ "num_range": 29406,
+ "upper_bound": "556672"
},
{
- "distinct_range": 7806.003395662586,
+ "distinct_range": 7162.858236131782,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "609187"
+ "num_range": 29406,
+ "upper_bound": "582243"
},
{
- "distinct_range": 7711.772336447446,
+ "distinct_range": 7834.269484269057,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "639524"
+ "num_range": 29406,
+ "upper_bound": "613729"
},
{
- "distinct_range": 7189.277662053646,
+ "distinct_range": 7921.215580350321,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "665345"
+ "num_range": 29406,
+ "upper_bound": "646117"
},
{
- "distinct_range": 6452.689663523358,
+ "distinct_range": 7653.635602662411,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "686180"
+ "num_range": 29406,
+ "upper_bound": "675840"
},
{
- "distinct_range": 8177.622178439619,
+ "distinct_range": 7704.807637128517,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "721539"
+ "num_range": 29406,
+ "upper_bound": "706048"
},
{
- "distinct_range": 8073.867693149887,
+ "distinct_range": 7345.059093937757,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "755680"
+ "num_range": 29406,
+ "upper_bound": "733063"
},
{
- "distinct_range": 7346.270836498706,
+ "distinct_range": 8254.557037772967,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "782756"
+ "num_range": 29406,
+ "upper_bound": "769282"
},
{
- "distinct_range": 7852.562507273589,
+ "distinct_range": 7038.050294271103,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "814496"
+ "num_range": 29406,
+ "upper_bound": "793922"
},
{
- "distinct_range": 7774.401116045534,
+ "distinct_range": 7273.467889436378,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "845446"
+ "num_range": 29406,
+ "upper_bound": "820357"
},
{
- "distinct_range": 7298.293503974827,
+ "distinct_range": 7594.831561114871,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "872130"
+ "num_range": 29406,
+ "upper_bound": "849536"
},
{
- "distinct_range": 8442.654741683109,
+ "distinct_range": 7241.706431357769,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "910912"
+ "num_range": 29406,
+ "upper_bound": "875719"
},
{
- "distinct_range": 6764.578460993752,
+ "distinct_range": 7609.022036324515,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "933697"
+ "num_range": 29406,
+ "upper_bound": "905028"
},
{
- "distinct_range": 7827.835925013022,
+ "distinct_range": 8205.542422975315,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "965184"
+ "num_range": 29406,
+ "upper_bound": "940643"
},
{
- "distinct_range": 8161.787869030823,
+ "distinct_range": 7428.404490659601,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1000353"
+ "num_range": 29406,
+ "upper_bound": "968355"
},
{
- "distinct_range": 8407.881719579962,
+ "distinct_range": 7721.229507515679,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1038658"
+ "num_range": 29406,
+ "upper_bound": "998721"
},
{
- "distinct_range": 8148.354956783243,
+ "distinct_range": 7073.514195557043,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1073667"
+ "num_range": 29406,
+ "upper_bound": "1023621"
},
{
- "distinct_range": 6974.359140645211,
+ "distinct_range": 8220.930870339553,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1097891"
+ "num_range": 29406,
+ "upper_bound": "1059424"
},
{
- "distinct_range": 8011.5593485027275,
+ "distinct_range": 7154.600632902273,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1131330"
+ "num_range": 29406,
+ "upper_bound": "1084932"
},
{
- "distinct_range": 7263.1921272073505,
+ "distinct_range": 7747.480575244559,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1157732"
+ "num_range": 29406,
+ "upper_bound": "1115553"
},
{
- "distinct_range": 6676.239162820828,
+ "distinct_range": 6921.542536261946,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1179943"
+ "num_range": 29406,
+ "upper_bound": "1139363"
},
{
- "distinct_range": 7270.202280192784,
+ "distinct_range": 7461.785380230954,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1206401"
+ "num_range": 29406,
+ "upper_bound": "1167361"
},
{
- "distinct_range": 6906.889629414249,
+ "distinct_range": 7347.977024719279,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1230150"
+ "num_range": 29406,
+ "upper_bound": "1194400"
},
{
- "distinct_range": 7846.139351314362,
+ "distinct_range": 7843.888013066973,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1261824"
+ "num_range": 29406,
+ "upper_bound": "1225984"
},
{
- "distinct_range": 7818.576494156013,
+ "distinct_range": 7447.719639290542,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1293217"
+ "num_range": 29406,
+ "upper_bound": "1253861"
},
{
- "distinct_range": 8020.372093288114,
+ "distinct_range": 7435.446244259924,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1326754"
+ "num_range": 29406,
+ "upper_bound": "1281633"
},
{
- "distinct_range": 7761.165445212706,
+ "distinct_range": 6857.077741895097,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1357573"
+ "num_range": 29406,
+ "upper_bound": "1304999"
},
{
- "distinct_range": 7931.921490434037,
+ "distinct_range": 7821.444020276747,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1390145"
+ "num_range": 29406,
+ "upper_bound": "1336355"
},
{
- "distinct_range": 8470.248050357917,
+ "distinct_range": 8103.444729587297,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1429312"
+ "num_range": 29406,
+ "upper_bound": "1370759"
},
{
- "distinct_range": 7790.059305722735,
+ "distinct_range": 7690.68025807451,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1460418"
+ "num_range": 29406,
+ "upper_bound": "1400832"
},
{
- "distinct_range": 7747.645878344537,
+ "distinct_range": 8001.375129687013,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1491104"
+ "num_range": 29406,
+ "upper_bound": "1434085"
},
{
- "distinct_range": 7956.21636842137,
+ "distinct_range": 7055.43315154421,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1523937"
+ "num_range": 29406,
+ "upper_bound": "1458852"
},
{
- "distinct_range": 8219.993640367049,
+ "distinct_range": 7938.805733696983,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1559812"
+ "num_range": 29406,
+ "upper_bound": "1491427"
},
{
- "distinct_range": 7862.354918623604,
+ "distinct_range": 8040.996232028883,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1591653"
+ "num_range": 29406,
+ "upper_bound": "1525120"
},
{
- "distinct_range": 6873.893575299823,
+ "distinct_range": 7691.939631215262,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1615174"
+ "num_range": 29406,
+ "upper_bound": "1555205"
},
{
- "distinct_range": 7837.447422347778,
+ "distinct_range": 8244.594484942309,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1646759"
+ "num_range": 29406,
+ "upper_bound": "1591300"
},
{
- "distinct_range": 6900.6973871080045,
+ "distinct_range": 7476.574808721368,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1670465"
+ "num_range": 29406,
+ "upper_bound": "1619426"
},
{
- "distinct_range": 7193.792369238889,
+ "distinct_range": 7887.3201656428055,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1696321"
+ "num_range": 29406,
+ "upper_bound": "1651458"
},
{
- "distinct_range": 7440.756036516703,
+ "distinct_range": 7834.859602833694,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1724192"
+ "num_range": 29406,
+ "upper_bound": "1682950"
},
{
- "distinct_range": 6920.090598185453,
+ "distinct_range": 7513.488916933386,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1748033"
+ "num_range": 29406,
+ "upper_bound": "1711399"
},
{
- "distinct_range": 7627.30603535448,
+ "distinct_range": 8252.392123491787,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1777570"
+ "num_range": 29406,
+ "upper_bound": "1747591"
},
{
- "distinct_range": 7661.578917035723,
+ "distinct_range": 8508.755916624199,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1807428"
+ "num_range": 29406,
+ "upper_bound": "1787205"
},
{
- "distinct_range": 7626.98327713249,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1836962"
+ "distinct_range": 8050.110858743258,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1822240"
},
{
- "distinct_range": 8190.85860265415,
+ "distinct_range": 8061.407581655896,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1872481"
+ "num_range": 29406,
+ "upper_bound": "1856163"
},
{
- "distinct_range": 7711.6687112053205,
+ "distinct_range": 7760.846601802964,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1902817"
+ "num_range": 29406,
+ "upper_bound": "1886915"
},
{
- "distinct_range": 7148.410875723133,
+ "distinct_range": 6953.4907365577355,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1928324"
+ "num_range": 29406,
+ "upper_bound": "1910949"
},
{
- "distinct_range": 7920.5625876965305,
+ "distinct_range": 8257.279791305933,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1960775"
+ "num_range": 29406,
+ "upper_bound": "1947202"
},
{
- "distinct_range": 7109.67820965394,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1985989"
+ "distinct_range": 7272.397826454881,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1974311"
},
{
- "distinct_range": 7982.427438791078,
+ "distinct_range": 8152.2371849874,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2019107"
+ "num_range": 29406,
+ "upper_bound": "2009286"
},
{
- "distinct_range": 7148.279673277619,
+ "distinct_range": 8132.981707373495,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2044613"
+ "num_range": 29406,
+ "upper_bound": "2044034"
},
{
- "distinct_range": 7322.032295523189,
+ "distinct_range": 8160.240827507013,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2071490"
+ "num_range": 29406,
+ "upper_bound": "2079104"
},
{
- "distinct_range": 7725.4087467181735,
+ "distinct_range": 7002.657507508177,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2101959"
+ "num_range": 29406,
+ "upper_bound": "2103488"
},
{
- "distinct_range": 8025.659612489616,
+ "distinct_range": 7802.8614939595145,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2135555"
+ "num_range": 29406,
+ "upper_bound": "2134657"
},
{
- "distinct_range": 7561.167888011236,
+ "distinct_range": 7644.332502354085,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2164486"
+ "num_range": 29406,
+ "upper_bound": "2164293"
},
{
- "distinct_range": 6619.396239729852,
+ "distinct_range": 8550.72112560846,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2186337"
+ "num_range": 29406,
+ "upper_bound": "2204514"
},
{
- "distinct_range": 7415.095950018986,
+ "distinct_range": 7257.637695239717,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2213989"
+ "num_range": 29406,
+ "upper_bound": "2230823"
},
{
- "distinct_range": 7908.195783329753,
+ "distinct_range": 8105.692367400778,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2246309"
+ "num_range": 29406,
+ "upper_bound": "2265253"
},
{
- "distinct_range": 7747.339969258757,
+ "distinct_range": 7028.833187438837,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2276992"
+ "num_range": 29406,
+ "upper_bound": "2289826"
},
{
- "distinct_range": 7613.71071540515,
+ "distinct_range": 8515.66767469415,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2306403"
+ "num_range": 29406,
+ "upper_bound": "2329539"
},
{
- "distinct_range": 6873.456729980368,
+ "distinct_range": 8147.250275984157,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2329921"
+ "num_range": 29406,
+ "upper_bound": "2364455"
},
{
- "distinct_range": 7088.547177311981,
+ "distinct_range": 7580.883561974042,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2354977"
+ "num_range": 29406,
+ "upper_bound": "2393507"
},
{
- "distinct_range": 7178.020383555324,
+ "distinct_range": 6506.174396432412,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2380711"
+ "num_range": 29406,
+ "upper_bound": "2414628"
},
{
- "distinct_range": 7657.336313733522,
+ "distinct_range": 7166.6503921614,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2410529"
+ "num_range": 29406,
+ "upper_bound": "2440228"
},
{
- "distinct_range": 7384.1520591662575,
+ "distinct_range": 7090.6631570813715,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2437920"
+ "num_range": 29406,
+ "upper_bound": "2465255"
},
{
- "distinct_range": 6956.485930652769,
+ "distinct_range": 6992.756939700355,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2462017"
+ "num_range": 29406,
+ "upper_bound": "2489568"
},
{
- "distinct_range": 6594.7320833310905,
+ "distinct_range": 7819.067942871871,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2483714"
+ "num_range": 29406,
+ "upper_bound": "2520900"
},
{
- "distinct_range": 7698.156327372192,
+ "distinct_range": 8069.867214176132,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2513920"
+ "num_range": 29406,
+ "upper_bound": "2554919"
},
{
- "distinct_range": 7561.61072930563,
+ "distinct_range": 7509.516766825206,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2542855"
+ "num_range": 29406,
+ "upper_bound": "2583333"
},
{
- "distinct_range": 7805.109626655791,
+ "distinct_range": 7644.011025437796,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2574112"
+ "num_range": 29406,
+ "upper_bound": "2612966"
},
{
- "distinct_range": 6630.855472671934,
+ "distinct_range": 7871.425851806159,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2596035"
+ "num_range": 29406,
+ "upper_bound": "2644833"
},
{
- "distinct_range": 7568.353580821891,
+ "distinct_range": 6731.278378154743,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2625031"
+ "num_range": 29406,
+ "upper_bound": "2667362"
},
{
- "distinct_range": 7973.451581650685,
+ "distinct_range": 8189.618345057969,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2658051"
+ "num_range": 29406,
+ "upper_bound": "2702784"
},
{
- "distinct_range": 8308.902797037756,
+ "distinct_range": 7033.92722830134,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2695046"
+ "num_range": 29406,
+ "upper_bound": "2727394"
},
{
- "distinct_range": 7695.0264585692075,
+ "distinct_range": 7918.001610720123,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2725222"
+ "num_range": 29406,
+ "upper_bound": "2759748"
},
{
- "distinct_range": 7571.33185584875,
+ "distinct_range": 8135.962727235735,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2754245"
+ "num_range": 29406,
+ "upper_bound": "2794531"
},
{
- "distinct_range": 6864.558963062782,
+ "distinct_range": 7424.993542723013,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2777702"
+ "num_range": 29406,
+ "upper_bound": "2822214"
},
{
- "distinct_range": 7360.530564783786,
+ "distinct_range": 7006.27382588086,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2804896"
+ "num_range": 29406,
+ "upper_bound": "2846624"
},
{
- "distinct_range": 8506.584971578337,
+ "distinct_range": 8325.748951121162,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2844579"
+ "num_range": 29406,
+ "upper_bound": "2883748"
},
{
- "distinct_range": 7599.598543222536,
+ "distinct_range": 8223.782441357189,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2873860"
+ "num_range": 29406,
+ "upper_bound": "2919586"
},
{
- "distinct_range": 7633.9661506630055,
+ "distinct_range": 7914.972244252987,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2903459"
+ "num_range": 29406,
+ "upper_bound": "2951908"
},
{
- "distinct_range": 7654.361748291993,
+ "distinct_range": 7480.487793354559,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2933249"
+ "num_range": 29406,
+ "upper_bound": "2980068"
},
{
- "distinct_range": 7899.6575346438785,
+ "distinct_range": 8125.295815122036,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2965479"
+ "num_range": 29406,
+ "upper_bound": "3014726"
},
{
- "distinct_range": 7747.136006368954,
+ "distinct_range": 8236.846314674922,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2996160"
+ "num_range": 29406,
+ "upper_bound": "3050725"
},
{
- "distinct_range": 7314.5541043322955,
+ "distinct_range": 7714.69600271095,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3022976"
+ "num_range": 29406,
+ "upper_bound": "3081028"
},
{
- "distinct_range": 7695.0264585692075,
+ "distinct_range": 7915.066977424217,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3053152"
+ "num_range": 29406,
+ "upper_bound": "3113351"
},
{
- "distinct_range": 7725.614717914753,
+ "distinct_range": 8307.749235571266,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3083623"
+ "num_range": 29406,
+ "upper_bound": "3150243"
},
{
- "distinct_range": 7398.665759084221,
+ "distinct_range": 8189.949686922741,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3111136"
+ "num_range": 29406,
+ "upper_bound": "3185669"
},
{
- "distinct_range": 7962.131050704161,
+ "distinct_range": 7535.27243115524,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3144033"
+ "num_range": 29406,
+ "upper_bound": "3214311"
},
{
- "distinct_range": 8238.266592801167,
+ "distinct_range": 7339.578569856314,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3180134"
+ "num_range": 29406,
+ "upper_bound": "3241281"
},
{
- "distinct_range": 7641.034587735795,
+ "distinct_range": 8108.886620892505,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3209799"
+ "num_range": 29406,
+ "upper_bound": "3275748"
},
{
- "distinct_range": 7633.537053423228,
+ "distinct_range": 7401.455822139463,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3239394"
+ "num_range": 29406,
+ "upper_bound": "3303232"
},
{
- "distinct_range": 7828.327342043511,
+ "distinct_range": 8263.192584352262,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3270886"
+ "num_range": 29406,
+ "upper_bound": "3339559"
},
{
- "distinct_range": 7309.8840244968005,
+ "distinct_range": 7792.758786073704,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3297664"
+ "num_range": 29406,
+ "upper_bound": "3370627"
},
{
- "distinct_range": 7856.446024860991,
+ "distinct_range": 6808.308897221847,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3329444"
+ "num_range": 29406,
+ "upper_bound": "3393664"
},
{
- "distinct_range": 7470.750602957668,
+ "distinct_range": 8642.582998813776,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3357574"
+ "num_range": 29406,
+ "upper_bound": "3435265"
},
{
- "distinct_range": 6836.214351557144,
+ "distinct_range": 7609.783656437061,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3380838"
+ "num_range": 29406,
+ "upper_bound": "3464581"
},
{
- "distinct_range": 7815.118717037054,
+ "distinct_range": 7011.134148535667,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3412196"
+ "num_range": 29406,
+ "upper_bound": "3489026"
},
{
- "distinct_range": 7302.86224068423,
+ "distinct_range": 7351.740867024675,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3438917"
+ "num_range": 29406,
+ "upper_bound": "3516096"
},
{
- "distinct_range": 6878.112797866152,
+ "distinct_range": 7920.837718991231,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3462467"
+ "num_range": 29406,
+ "upper_bound": "3548480"
},
{
- "distinct_range": 8243.169390841636,
+ "distinct_range": 8431.66690437035,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3498629"
+ "num_range": 29406,
+ "upper_bound": "3587015"
},
{
- "distinct_range": 7836.860189053916,
+ "distinct_range": 6980.293948652763,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3530208"
+ "num_range": 29406,
+ "upper_bound": "3611239"
},
{
- "distinct_range": 7871.910279880611,
+ "distinct_range": 7401.574679304762,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3562148"
+ "num_range": 29406,
+ "upper_bound": "3638724"
},
{
- "distinct_range": 7425.55724431279,
+ "distinct_range": 7674.243957961486,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3589889"
+ "num_range": 29406,
+ "upper_bound": "3668641"
},
{
- "distinct_range": 7796.849776167331,
+ "distinct_range": 7356.588875902608,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3621063"
+ "num_range": 29406,
+ "upper_bound": "3695751"
},
{
- "distinct_range": 8095.778294735811,
+ "distinct_range": 8058.049272417989,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3655456"
+ "num_range": 29406,
+ "upper_bound": "3729636"
},
{
- "distinct_range": 7806.201961203801,
+ "distinct_range": 6630.815191531017,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3686724"
+ "num_range": 29406,
+ "upper_bound": "3751523"
},
{
- "distinct_range": 6690.896705865561,
+ "distinct_range": 7986.044885003762,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3709029"
+ "num_range": 29406,
+ "upper_bound": "3784608"
},
{
- "distinct_range": 7589.230607005903,
+ "distinct_range": 7796.665361220936,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3738215"
+ "num_range": 29406,
+ "upper_bound": "3815715"
},
{
- "distinct_range": 7620.302690036506,
+ "distinct_range": 7968.385447768586,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3767687"
+ "num_range": 29406,
+ "upper_bound": "3848608"
},
{
- "distinct_range": 8298.40150450631,
+ "distinct_range": 7938.899406243908,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3804547"
+ "num_range": 29406,
+ "upper_bound": "3881184"
},
{
- "distinct_range": 7287.2690715364,
+ "distinct_range": 7409.761702499322,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3831142"
+ "num_range": 29406,
+ "upper_bound": "3908738"
},
{
- "distinct_range": 8782.443958229196,
+ "distinct_range": 7812.321607080408,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3875111"
+ "num_range": 29406,
+ "upper_bound": "3940002"
},
{
- "distinct_range": 7727.982015864079,
+ "distinct_range": 7240.564592328248,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3905605"
+ "num_range": 29406,
+ "upper_bound": "3966176"
},
{
- "distinct_range": 7477.64536288239,
+ "distinct_range": 8221.338492225503,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3933795"
+ "num_range": 29406,
+ "upper_bound": "4001984"
},
{
- "distinct_range": 7952.9747005850995,
+ "distinct_range": 8041.887919888985,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3966593"
+ "num_range": 29406,
+ "upper_bound": "4035687"
},
{
- "distinct_range": 7564.929341555261,
+ "distinct_range": 7640.042403504249,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3995558"
+ "num_range": 29406,
+ "upper_bound": "4065283"
},
{
- "distinct_range": 7023.276921430404,
+ "distinct_range": 7409.406322985524,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4020134"
+ "num_range": 29406,
+ "upper_bound": "4092834"
},
{
- "distinct_range": 7913.77450061275,
+ "distinct_range": 8551.19937354898,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4052513"
+ "num_range": 29406,
+ "upper_bound": "4133062"
},
{
- "distinct_range": 7267.450649768439,
+ "distinct_range": 7409.406322985524,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4078949"
+ "num_range": 29406,
+ "upper_bound": "4160613"
},
{
- "distinct_range": 8169.304121795843,
+ "distinct_range": 8221.338492225503,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4114208"
+ "num_range": 29406,
+ "upper_bound": "4196421"
},
{
- "distinct_range": 8193.742252832135,
+ "distinct_range": 7378.526231996631,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4149762"
+ "num_range": 29406,
+ "upper_bound": "4223713"
},
{
- "distinct_range": 7259.554086247538,
+ "distinct_range": 7793.460479542122,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4176135"
+ "num_range": 29406,
+ "upper_bound": "4254788"
},
{
- "distinct_range": 7843.506170534498,
+ "distinct_range": 8257.19976491071,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4207782"
+ "num_range": 29406,
+ "upper_bound": "4291040"
},
{
- "distinct_range": 8025.480596727383,
+ "distinct_range": 6745.8461055063035,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4241376"
+ "num_range": 29406,
+ "upper_bound": "4313664"
},
{
- "distinct_range": 7582.658266084832,
+ "distinct_range": 7592.640617704185,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4270502"
+ "num_range": 29406,
+ "upper_bound": "4342823"
},
{
- "distinct_range": 8031.826133470091,
+ "distinct_range": 7358.88830776508,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4304167"
+ "num_range": 29406,
+ "upper_bound": "4369952"
},
{
- "distinct_range": 7623.537675945348,
+ "distinct_range": 6606.021751875536,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4333669"
+ "num_range": 29406,
+ "upper_bound": "4391684"
},
{
- "distinct_range": 7585.179881827864,
+ "distinct_range": 7386.193601067368,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4362818"
+ "num_range": 29406,
+ "upper_bound": "4419040"
},
{
- "distinct_range": 7751.008087022627,
+ "distinct_range": 7773.929997624159,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4393537"
+ "num_range": 29406,
+ "upper_bound": "4449921"
},
{
- "distinct_range": 7627.52118210715,
+ "distinct_range": 6626.511648779603,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4423076"
+ "num_range": 29406,
+ "upper_bound": "4471781"
},
{
- "distinct_range": 7567.47039144653,
+ "distinct_range": 8105.605966041354,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4452064"
+ "num_range": 29406,
+ "upper_bound": "4506210"
},
{
- "distinct_range": 8463.977703926828,
+ "distinct_range": 7880.976581241297,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4491143"
+ "num_range": 29406,
+ "upper_bound": "4538176"
},
{
- "distinct_range": 7932.898417114886,
+ "distinct_range": 8089.665576696958,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4522723"
+ "num_range": 30006,
+ "upper_bound": "4571297"
},
{
- "distinct_range": 7559.781074284765,
+ "distinct_range": 7755.243687822352,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4550883"
+ "num_range": 30006,
+ "upper_bound": "4601121"
},
{
- "distinct_range": 7821.289989645345,
+ "distinct_range": 7748.899045577278,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4581382"
+ "num_range": 30006,
+ "upper_bound": "4630887"
},
{
- "distinct_range": 8219.51720130609,
+ "distinct_range": 7373.165634770877,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4616002"
+ "num_range": 30006,
+ "upper_bound": "4657476"
},
{
- "distinct_range": 8109.772687000854,
+ "distinct_range": 7465.673572722783,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4649410"
+ "num_range": 30006,
+ "upper_bound": "4684803"
},
{
- "distinct_range": 7881.441202474398,
+ "distinct_range": 7748.570407675422,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4680485"
+ "num_range": 30006,
+ "upper_bound": "4714566"
},
{
- "distinct_range": 8261.35320987189,
+ "distinct_range": 7720.023686754499,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4715584"
+ "num_range": 30006,
+ "upper_bound": "4744070"
},
{
- "distinct_range": 7079.074073286803,
+ "distinct_range": 8012.415607208201,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4740036"
+ "num_range": 30006,
+ "upper_bound": "4776385"
},
{
- "distinct_range": 7926.643855820927,
+ "distinct_range": 7920.4936059390375,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4771554"
+ "num_range": 30006,
+ "upper_bound": "4807777"
},
{
- "distinct_range": 7529.713711361781,
+ "distinct_range": 7952.993870285381,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4799461"
+ "num_range": 30006,
+ "upper_bound": "4839491"
},
{
- "distinct_range": 7447.292229993624,
+ "distinct_range": 8212.344760994207,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4826690"
+ "num_range": 30006,
+ "upper_bound": "4873953"
},
{
- "distinct_range": 7638.23497356234,
+ "distinct_range": 7581.703118167632,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4855525"
+ "num_range": 30006,
+ "upper_bound": "4902245"
},
{
- "distinct_range": 8018.76278771411,
+ "distinct_range": 8172.506451192901,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4887974"
+ "num_range": 30006,
+ "upper_bound": "4936263"
},
{
- "distinct_range": 7713.658474253254,
+ "distinct_range": 8211.989210762455,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4917479"
+ "num_range": 30006,
+ "upper_bound": "4970721"
},
{
- "distinct_range": 8109.586820350738,
+ "distinct_range": 8022.538093255714,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4950885"
+ "num_range": 30006,
+ "upper_bound": "5003140"
},
{
- "distinct_range": 8100.6462287274635,
+ "distinct_range": 7373.165634770877,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "4984195"
+ "num_range": 30006,
+ "upper_bound": "5029729"
},
{
- "distinct_range": 7279.885256639894,
+ "distinct_range": 7695.1657196336155,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5010113"
+ "num_range": 30006,
+ "upper_bound": "5059010"
},
{
- "distinct_range": 6933.971440153181,
+ "distinct_range": 7607.290783717943,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5033571"
+ "num_range": 30006,
+ "upper_bound": "5087521"
},
{
- "distinct_range": 7965.004091345067,
+ "distinct_range": 8131.718330873102,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5065472"
+ "num_range": 30006,
+ "upper_bound": "5121093"
},
{
- "distinct_range": 8256.245579500352,
+ "distinct_range": 7698.63692502793,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5100512"
+ "num_range": 30006,
+ "upper_bound": "5150405"
},
{
- "distinct_range": 7645.771282836877,
+ "distinct_range": 7543.588333085502,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5129413"
+ "num_range": 30006,
+ "upper_bound": "5178375"
},
{
- "distinct_range": 7837.842694091258,
+ "distinct_range": 7204.268295120602,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5160069"
+ "num_range": 30006,
+ "upper_bound": "5203683"
},
{
- "distinct_range": 7359.011047262375,
+ "distinct_range": 7864.500427932829,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5186596"
+ "num_range": 30006,
+ "upper_bound": "5234531"
},
{
- "distinct_range": 8247.733685689165,
+ "distinct_range": 8140.196284177085,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5221538"
+ "num_range": 30006,
+ "upper_bound": "5268195"
},
{
- "distinct_range": 7917.330664963832,
+ "distinct_range": 7962.493032736518,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5252964"
+ "num_range": 30006,
+ "upper_bound": "5300004"
},
{
- "distinct_range": 7884.531025377066,
+ "distinct_range": 7936.9035041517745,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5284069"
+ "num_range": 30006,
+ "upper_bound": "5331558"
},
{
- "distinct_range": 7765.92838648099,
+ "distinct_range": 7840.617193821004,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5314051"
+ "num_range": 30006,
+ "upper_bound": "5362178"
},
{
- "distinct_range": 8571.230605376375,
+ "distinct_range": 6958.726414325381,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5353026"
+ "num_range": 30006,
+ "upper_bound": "5385762"
},
{
- "distinct_range": 8332.389609902037,
+ "distinct_range": 8053.107023830726,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5388961"
+ "num_range": 30006,
+ "upper_bound": "5418498"
},
{
- "distinct_range": 8311.23612180143,
+ "distinct_range": 7457.907243981737,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5424644"
+ "num_range": 30006,
+ "upper_bound": "5445762"
},
{
- "distinct_range": 7544.615051679806,
+ "distinct_range": 8453.934247889267,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5452676"
+ "num_range": 30006,
+ "upper_bound": "5483109"
},
{
- "distinct_range": 7860.942348835946,
+ "distinct_range": 7926.5853162136755,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5483553"
+ "num_range": 30006,
+ "upper_bound": "5514561"
},
{
- "distinct_range": 8077.093183659318,
+ "distinct_range": 7485.7786533935105,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5516612"
+ "num_range": 30006,
+ "upper_bound": "5542052"
},
{
- "distinct_range": 8202.597539029506,
+ "distinct_range": 7489.317076851359,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5551041"
+ "num_range": 30006,
+ "upper_bound": "5569572"
},
{
- "distinct_range": 7638.463693815,
+ "distinct_range": 7365.623000624057,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5579878"
+ "num_range": 30006,
+ "upper_bound": "5596102"
},
{
- "distinct_range": 8042.762028893113,
+ "distinct_range": 7335.87714206336,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5612576"
+ "num_range": 30006,
+ "upper_bound": "5622401"
},
{
- "distinct_range": 7858.236826149772,
+ "distinct_range": 7751.854719301441,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5643427"
+ "num_range": 30006,
+ "upper_bound": "5652194"
},
{
- "distinct_range": 7793.6137716593275,
+ "distinct_range": 6214.999779723028,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5673666"
+ "num_range": 30006,
+ "upper_bound": "5671362"
},
{
- "distinct_range": 8300.152040670631,
+ "distinct_range": 7574.292328714376,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5709218"
+ "num_range": 30006,
+ "upper_bound": "5699591"
},
{
- "distinct_range": 7541.165960275857,
+ "distinct_range": 7492.363423782302,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5737221"
+ "num_range": 30006,
+ "upper_bound": "5727136"
},
{
- "distinct_range": 7645.429235347879,
+ "distinct_range": 7316.24623116937,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5766119"
+ "num_range": 30006,
+ "upper_bound": "5753284"
},
{
- "distinct_range": 7648.505910828408,
+ "distinct_range": 7481.746069532256,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5795044"
+ "num_range": 30006,
+ "upper_bound": "5780742"
},
{
- "distinct_range": 7926.441805185882,
+ "distinct_range": 7599.840864133289,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5826560"
+ "num_range": 30006,
+ "upper_bound": "5809189"
},
{
- "distinct_range": 7700.101376783535,
+ "distinct_range": 7469.240495582983,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5855943"
+ "num_range": 30006,
+ "upper_bound": "5836545"
},
{
- "distinct_range": 8133.155531923736,
+ "distinct_range": 7536.30083074794,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5889604"
+ "num_range": 30006,
+ "upper_bound": "5864454"
},
{
- "distinct_range": 7541.165960275857,
+ "distinct_range": 7824.025667231353,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5917607"
+ "num_range": 30006,
+ "upper_bound": "5894917"
},
{
- "distinct_range": 7145.939334798537,
+ "distinct_range": 8573.329605862818,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5942535"
+ "num_range": 30006,
+ "upper_bound": "5933825"
},
{
- "distinct_range": 7431.795787074028,
+ "distinct_range": 8268.983790533859,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5969639"
+ "num_range": 30006,
+ "upper_bound": "5968933"
},
{
- "distinct_range": 7758.982520602352,
+ "distinct_range": 7844.509934013906,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "5999557"
+ "num_range": 30006,
+ "upper_bound": "5999590"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 1,
"columns": [
"l_linenumber"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 7,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1520381,
- "num_range": 0,
- "upper_bound": "0"
- },
- {
- "distinct_range": 0,
- "num_eq": 1273086,
+ "num_eq": 1487701,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 1063606,
+ "num_eq": 1338871,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 903345,
+ "num_eq": 1052613,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 600229,
+ "num_eq": 861774,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 437567,
+ "num_eq": 636729,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 204078,
+ "num_eq": 415284,
"num_range": 0,
"upper_bound": "6"
+ },
+ {
+ "distinct_range": 0,
+ "num_eq": 208242,
+ "num_range": 0,
+ "upper_bound": "7"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 5,
"columns": [
"l_orderkey",
"l_linenumber"
],
- "created_at": "2021-09-08 20:49:14.314079",
- "distinct_count": 6002293,
+ "created_at": "2022-02-25 00:55:34.245977",
+ "distinct_count": 5986645,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 4,
"columns": [
"l_partkey"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 199241,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 600,
"num_range": 0,
- "upper_bound": "36"
+ "upper_bound": "1"
},
{
- "distinct_range": 972.5406184832756,
+ "distinct_range": 1004.221072138225,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1013"
+ "num_range": 29406,
+ "upper_bound": "1010"
},
{
- "distinct_range": 1047.2747848619842,
+ "distinct_range": 1006.2135742654708,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2065"
+ "num_range": 29406,
+ "upper_bound": "2021"
},
{
- "distinct_range": 983.5016295522155,
+ "distinct_range": 965.3672806568273,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3053"
+ "num_range": 29406,
+ "upper_bound": "2991"
},
{
- "distinct_range": 1110.051484617618,
+ "distinct_range": 888.655948757422,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4168"
+ "num_range": 29406,
+ "upper_bound": "3884"
},
{
- "distinct_range": 997.4520072763021,
+ "distinct_range": 1147.6812252917553,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "5170"
+ "num_range": 29406,
+ "upper_bound": "5037"
},
{
- "distinct_range": 1125.9947734434334,
+ "distinct_range": 1202.475033769424,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6301"
+ "num_range": 29406,
+ "upper_bound": "6245"
},
{
- "distinct_range": 994.4626406211427,
+ "distinct_range": 962.3785274659449,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "7300"
+ "num_range": 29406,
+ "upper_bound": "7212"
},
{
- "distinct_range": 1046.278329310279,
+ "distinct_range": 1028.1310976651146,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "8351"
+ "num_range": 29406,
+ "upper_bound": "8245"
},
{
- "distinct_range": 1105.0692068594306,
+ "distinct_range": 904.595965775489,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "9461"
+ "num_range": 29406,
+ "upper_bound": "9154"
},
{
- "distinct_range": 1116.0302179273726,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "10582"
+ "distinct_range": 1099.8611742439198,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "10259"
},
{
- "distinct_range": 1022.3633960692332,
+ "distinct_range": 991.2698083111118,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "11609"
+ "num_range": 29406,
+ "upper_bound": "11255"
},
{
- "distinct_range": 1078.1649069645096,
+ "distinct_range": 787.0383402672272,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "12692"
+ "num_range": 29406,
+ "upper_bound": "12046"
},
{
- "distinct_range": 994.4626406211427,
+ "distinct_range": 1237.3438209637632,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "13691"
+ "num_range": 29406,
+ "upper_bound": "13289"
},
{
- "distinct_range": 1081.1542736195486,
+ "distinct_range": 887.6596976937927,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "14777"
+ "num_range": 29406,
+ "upper_bound": "14181"
},
{
- "distinct_range": 986.4909962073788,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "15768"
+ "distinct_range": 951.4197657660042,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "15137"
},
{
- "distinct_range": 983.5016295522155,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "16756"
+ "distinct_range": 890.6484508846761,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "16032"
},
{
- "distinct_range": 1169.8388177095972,
+ "distinct_range": 1134.7299614670076,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "17931"
+ "num_range": 29406,
+ "upper_bound": "17172"
},
{
- "distinct_range": 1029.3385849312267,
+ "distinct_range": 1232.362565651691,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "18965"
+ "num_range": 29406,
+ "upper_bound": "18410"
},
{
- "distinct_range": 930.6894853108953,
+ "distinct_range": 1075.9511487181635,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "19900"
+ "num_range": 29406,
+ "upper_bound": "19491"
},
{
- "distinct_range": 948.6256852419244,
+ "distinct_range": 837.8471445123262,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "20853"
+ "num_range": 29406,
+ "upper_bound": "20333"
},
{
- "distinct_range": 982.5051740004941,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "21840"
+ "distinct_range": 885.6671955665307,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "21223"
},
{
- "distinct_range": 897.806452103992,
+ "distinct_range": 1080.9324040360893,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "22742"
+ "num_range": 29406,
+ "upper_bound": "22309"
},
{
- "distinct_range": 903.785185414339,
+ "distinct_range": 932.490995557099,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "23650"
+ "num_range": 29406,
+ "upper_bound": "23246"
},
{
- "distinct_range": 1011.4023850003596,
+ "distinct_range": 1122.7749487051651,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "24666"
+ "num_range": 29406,
+ "upper_bound": "24374"
},
{
- "distinct_range": 1066.2074403442648,
+ "distinct_range": 971.3447870385904,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "25737"
+ "num_range": 29406,
+ "upper_bound": "25350"
},
{
- "distinct_range": 1101.083384652846,
+ "distinct_range": 1181.5537614445216,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "26843"
+ "num_range": 29406,
+ "upper_bound": "26537"
},
{
- "distinct_range": 927.7001186557229,
+ "distinct_range": 769.1058211218981,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "27775"
+ "num_range": 29406,
+ "upper_bound": "27310"
},
{
- "distinct_range": 809.1219080004952,
+ "distinct_range": 1076.9473997817508,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "28588"
+ "num_range": 29406,
+ "upper_bound": "28392"
},
{
- "distinct_range": 1178.8069176717718,
+ "distinct_range": 1340.9539312127692,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "29772"
+ "num_range": 29406,
+ "upper_bound": "29739"
},
{
- "distinct_range": 1004.4271961383353,
+ "distinct_range": 1205.4637869582812,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "30781"
+ "num_range": 29406,
+ "upper_bound": "30950"
},
{
- "distinct_range": 836.026207897063,
+ "distinct_range": 986.2885529929853,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "31621"
+ "num_range": 29406,
+ "upper_bound": "31941"
},
{
- "distinct_range": 1214.6793175124928,
+ "distinct_range": 1150.6699784819784,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "32841"
+ "num_range": 29406,
+ "upper_bound": "33097"
},
{
- "distinct_range": 973.5370740349979,
+ "distinct_range": 883.6746934392759,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "33819"
+ "num_range": 29406,
+ "upper_bound": "33985"
},
{
- "distinct_range": 1165.852995503999,
+ "distinct_range": 812.9408679215915,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "34990"
+ "num_range": 29406,
+ "upper_bound": "34802"
},
{
- "distinct_range": 1008.4130183452074,
+ "distinct_range": 877.6971870575002,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "36003"
+ "num_range": 29406,
+ "upper_bound": "35684"
},
{
- "distinct_range": 941.6504963798586,
+ "distinct_range": 923.5247359844401,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "36949"
+ "num_range": 29406,
+ "upper_bound": "36612"
},
{
- "distinct_range": 941.6504963798336,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "37895"
+ "distinct_range": 768.1095700582687,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "37384"
},
{
- "distinct_range": 1080.15781806787,
+ "distinct_range": 1022.1535912834062,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "38980"
+ "num_range": 29406,
+ "upper_bound": "38411"
},
{
- "distinct_range": 1124.9983178918396,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "40110"
+ "distinct_range": 1132.7374593400662,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "39549"
},
{
- "distinct_range": 930.6894853108953,
+ "distinct_range": 997.2473146928595,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "41045"
+ "num_range": 29406,
+ "upper_bound": "40551"
},
{
- "distinct_range": 916.7391075867564,
+ "distinct_range": 849.8021572758788,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "41966"
+ "num_range": 29406,
+ "upper_bound": "41405"
},
{
- "distinct_range": 985.4945406556577,
+ "distinct_range": 929.502242366213,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "42956"
+ "num_range": 29406,
+ "upper_bound": "42339"
},
{
- "distinct_range": 1154.8919844380948,
+ "distinct_range": 986.2885529929853,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "44116"
+ "num_range": 29406,
+ "upper_bound": "43330"
},
{
- "distinct_range": 1081.1542736195486,
+ "distinct_range": 890.6484508846805,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "45202"
+ "num_range": 29406,
+ "upper_bound": "44225"
},
{
- "distinct_range": 788.1963414142756,
+ "distinct_range": 1033.1123529831964,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "45994"
+ "num_range": 29406,
+ "upper_bound": "45263"
},
{
- "distinct_range": 1036.3137737932036,
+ "distinct_range": 842.8283998304731,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "47035"
+ "num_range": 29406,
+ "upper_bound": "46110"
},
{
- "distinct_range": 935.6717630695154,
+ "distinct_range": 925.5172381116978,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "47975"
+ "num_range": 29406,
+ "upper_bound": "47040"
},
{
- "distinct_range": 1088.1294624812656,
+ "distinct_range": 983.2997998021079,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "49068"
+ "num_range": 29406,
+ "upper_bound": "48028"
},
{
- "distinct_range": 876.8808855177756,
+ "distinct_range": 882.6784423756466,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "49949"
+ "num_range": 29406,
+ "upper_bound": "48915"
},
{
- "distinct_range": 909.7639187246858,
+ "distinct_range": 879.6896891847587,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "50863"
+ "num_range": 29406,
+ "upper_bound": "49799"
},
{
- "distinct_range": 1030.3350404829387,
+ "distinct_range": 838.8433955759556,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "51898"
+ "num_range": 29406,
+ "upper_bound": "50642"
},
{
- "distinct_range": 938.6611297246873,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "52841"
+ "distinct_range": 858.7684168485429,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "51505"
},
{
- "distinct_range": 1000.44137393146,
+ "distinct_range": 1119.7861955146377,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "53846"
+ "num_range": 29406,
+ "upper_bound": "52630"
},
{
- "distinct_range": 1011.4023850003596,
+ "distinct_range": 1325.013914298653,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "54862"
+ "num_range": 29406,
+ "upper_bound": "53961"
},
{
- "distinct_range": 928.6965742074472,
+ "distinct_range": 931.4947444934705,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "55795"
+ "num_range": 29406,
+ "upper_bound": "54897"
},
{
- "distinct_range": 977.522896241886,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "56777"
+ "distinct_range": 966.3635317204547,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "55868"
},
{
- "distinct_range": 1158.8778066439588,
+ "distinct_range": 816.9258721761091,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "57941"
+ "num_range": 29406,
+ "upper_bound": "56689"
},
{
- "distinct_range": 851.9694967246586,
+ "distinct_range": 722.2820211313161,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "58797"
+ "num_range": 29406,
+ "upper_bound": "57415"
},
{
- "distinct_range": 866.916330000529,
+ "distinct_range": 1097.8686721168049,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "59668"
+ "num_range": 29406,
+ "upper_bound": "58518"
},
{
- "distinct_range": 768.2672303797807,
+ "distinct_range": 1145.6887231649168,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "60440"
+ "num_range": 29406,
+ "upper_bound": "59669"
},
{
- "distinct_range": 859.9411411384561,
+ "distinct_range": 1155.6512337989184,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "61304"
+ "num_range": 29406,
+ "upper_bound": "60830"
},
{
- "distinct_range": 889.8348076901956,
+ "distinct_range": 1159.636238052375,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "62198"
+ "num_range": 29406,
+ "upper_bound": "61995"
},
{
- "distinct_range": 985.4945406556577,
+ "distinct_range": 1157.6437359256577,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "63188"
+ "num_range": 29406,
+ "upper_bound": "63158"
},
{
- "distinct_range": 1236.601339627972,
+ "distinct_range": 703.3532509223576,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "64430"
+ "num_range": 29406,
+ "upper_bound": "63865"
},
{
- "distinct_range": 1177.81046212045,
+ "distinct_range": 1016.1760849016873,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "65613"
+ "num_range": 29406,
+ "upper_bound": "64886"
},
{
- "distinct_range": 1009.409473896925,
+ "distinct_range": 717.3007658131692,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "66627"
+ "num_range": 29406,
+ "upper_bound": "65607"
},
{
- "distinct_range": 932.6823964143434,
+ "distinct_range": 985.2923019293596,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "67564"
+ "num_range": 29406,
+ "upper_bound": "66597"
},
{
- "distinct_range": 823.0722857246416,
+ "distinct_range": 1059.0148806370419,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "68391"
+ "num_range": 29406,
+ "upper_bound": "67661"
},
{
- "distinct_range": 955.6008741039882,
+ "distinct_range": 967.3597827840819,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "69351"
+ "num_range": 29406,
+ "upper_bound": "68633"
},
{
- "distinct_range": 1067.203895895957,
+ "distinct_range": 1166.6099954956962,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "70423"
+ "num_range": 29406,
+ "upper_bound": "69805"
},
{
- "distinct_range": 1102.079840204495,
+ "distinct_range": 1053.0373742554175,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "71530"
+ "num_range": 29406,
+ "upper_bound": "70863"
},
{
- "distinct_range": 857.9482300350068,
+ "distinct_range": 1008.2060763927157,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "72392"
+ "num_range": 29406,
+ "upper_bound": "71876"
},
{
- "distinct_range": 1101.083384652846,
+ "distinct_range": 1147.6812252917553,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "73498"
+ "num_range": 29406,
+ "upper_bound": "73029"
},
{
- "distinct_range": 1058.2357959307017,
+ "distinct_range": 1127.756204022654,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "74561"
+ "num_range": 29406,
+ "upper_bound": "74162"
},
{
- "distinct_range": 1137.9522400623114,
+ "distinct_range": 819.9146253669974,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "75704"
+ "num_range": 29406,
+ "upper_bound": "74986"
},
{
- "distinct_range": 971.5441629315535,
+ "distinct_range": 1084.9174082904099,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "76680"
+ "num_range": 29406,
+ "upper_bound": "76076"
},
{
- "distinct_range": 1039.303140448331,
+ "distinct_range": 904.595965775489,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "77724"
+ "num_range": 29406,
+ "upper_bound": "76985"
},
{
- "distinct_range": 1057.2393403790034,
+ "distinct_range": 787.0383402672272,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "78786"
+ "num_range": 29406,
+ "upper_bound": "77776"
},
{
- "distinct_range": 1185.7821065307849,
+ "distinct_range": 728.2595275130926,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "79977"
+ "num_range": 29406,
+ "upper_bound": "78508"
},
{
- "distinct_range": 1016.3846627589421,
+ "distinct_range": 1035.1048551104263,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "80998"
+ "num_range": 29406,
+ "upper_bound": "79548"
},
{
- "distinct_range": 1031.3314960346504,
+ "distinct_range": 843.8246508941025,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "82034"
+ "num_range": 29406,
+ "upper_bound": "80396"
},
{
- "distinct_range": 1038.3066848966223,
+ "distinct_range": 1055.029876382628,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "83077"
+ "num_range": 29406,
+ "upper_bound": "81456"
},
{
- "distinct_range": 1127.9876845466122,
+ "distinct_range": 872.7159317393536,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "84210"
+ "num_range": 29406,
+ "upper_bound": "82333"
},
{
- "distinct_range": 1091.1188291362678,
+ "distinct_range": 893.6372040755682,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "85306"
+ "num_range": 29406,
+ "upper_bound": "83231"
},
{
- "distinct_range": 739.370019379763,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "86049"
+ "distinct_range": 1149.6737274119184,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "84386"
},
{
- "distinct_range": 1113.0408512725053,
+ "distinct_range": 909.5772210936345,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "87167"
+ "num_range": 29406,
+ "upper_bound": "85300"
},
{
- "distinct_range": 1105.0692068594306,
+ "distinct_range": 967.3597827840819,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "88277"
+ "num_range": 29406,
+ "upper_bound": "86272"
},
{
- "distinct_range": 907.7710076212369,
+ "distinct_range": 1185.5387656972305,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "89189"
+ "num_range": 29406,
+ "upper_bound": "87463"
},
{
- "distinct_range": 875.884429966051,
+ "distinct_range": 1061.0073827642445,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "90069"
+ "num_range": 29406,
+ "upper_bound": "88529"
},
{
- "distinct_range": 893.8206298970938,
+ "distinct_range": 988.2810551202363,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "90967"
+ "num_range": 29406,
+ "upper_bound": "89522"
},
{
- "distinct_range": 941.6504963798586,
+ "distinct_range": 780.0645828218214,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "91913"
+ "num_range": 29406,
+ "upper_bound": "90306"
},
{
- "distinct_range": 975.529985138442,
+ "distinct_range": 1114.8049401970409,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "92893"
+ "num_range": 29406,
+ "upper_bound": "91426"
},
{
- "distinct_range": 989.4803628625411,
+ "distinct_range": 1042.0786125557192,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "93887"
+ "num_range": 29406,
+ "upper_bound": "92473"
},
{
- "distinct_range": 1190.7643842869452,
+ "distinct_range": 1039.089859364882,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "95083"
+ "num_range": 29406,
+ "upper_bound": "93517"
},
{
- "distinct_range": 1112.0443957208786,
+ "distinct_range": 1070.9698934002122,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "96200"
+ "num_range": 29406,
+ "upper_bound": "94593"
},
{
- "distinct_range": 994.4626406211427,
+ "distinct_range": 977.3222934203507,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "97199"
+ "num_range": 29406,
+ "upper_bound": "95575"
},
{
- "distinct_range": 883.8560743798481,
+ "distinct_range": 994.2585615019863,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "98087"
+ "num_range": 29406,
+ "upper_bound": "96574"
},
{
- "distinct_range": 966.561885172941,
+ "distinct_range": 925.5172381116978,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "99058"
+ "num_range": 29406,
+ "upper_bound": "97504"
},
{
- "distinct_range": 1262.5091839315385,
+ "distinct_range": 976.3260423567241,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "100326"
+ "num_range": 29406,
+ "upper_bound": "98485"
},
{
- "distinct_range": 1099.0904735474783,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "101430"
+ "distinct_range": 877.6971870575002,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "99367"
},
{
- "distinct_range": 828.0545634832653,
+ "distinct_range": 1118.7899444511233,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "102262"
+ "num_range": 29406,
+ "upper_bound": "100491"
},
{
- "distinct_range": 1011.4023850003596,
+ "distinct_range": 921.5322338571824,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "103278"
+ "num_range": 29406,
+ "upper_bound": "101417"
},
{
- "distinct_range": 721.4338194487175,
+ "distinct_range": 1154.6549827355407,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "104003"
+ "num_range": 29406,
+ "upper_bound": "102577"
},
{
- "distinct_range": 925.7072075522747,
+ "distinct_range": 1125.763701895667,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "104933"
+ "num_range": 29406,
+ "upper_bound": "103708"
},
{
- "distinct_range": 1028.3421293795143,
+ "distinct_range": 991.2698083111118,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "105966"
+ "num_range": 29406,
+ "upper_bound": "104704"
},
{
- "distinct_range": 855.9553189315574,
+ "distinct_range": 798.99335303078,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "106826"
+ "num_range": 29406,
+ "upper_bound": "105507"
},
{
- "distinct_range": 1186.7785620820362,
+ "distinct_range": 1096.8724210532448,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "108018"
+ "num_range": 29406,
+ "upper_bound": "106609"
},
{
- "distinct_range": 1180.7998287743903,
+ "distinct_range": 948.4310125751545,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "109204"
+ "num_range": 29406,
+ "upper_bound": "107562"
},
{
- "distinct_range": 1054.2499737239036,
+ "distinct_range": 1169.5987486855947,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "110263"
+ "num_range": 29406,
+ "upper_bound": "108737"
},
{
- "distinct_range": 944.6398630350299,
+ "distinct_range": 1121.7786976416585,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "111212"
+ "num_range": 29406,
+ "upper_bound": "109864"
},
{
- "distinct_range": 918.732018690205,
+ "distinct_range": 904.595965775489,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "112135"
+ "num_range": 29406,
+ "upper_bound": "110773"
},
{
- "distinct_range": 1017.3811183106579,
+ "distinct_range": 823.8996296215149,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "113157"
+ "num_range": 29406,
+ "upper_bound": "111601"
},
{
- "distinct_range": 1091.1188291362678,
+ "distinct_range": 1096.8724210532448,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "114253"
+ "num_range": 29406,
+ "upper_bound": "112703"
},
{
- "distinct_range": 818.0900079660179,
+ "distinct_range": 935.479748747985,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "115075"
+ "num_range": 29406,
+ "upper_bound": "113643"
},
{
- "distinct_range": 700.5082528624978,
+ "distinct_range": 1102.849927434579,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "115779"
+ "num_range": 29406,
+ "upper_bound": "114751"
},
{
- "distinct_range": 1265.4985505806023,
+ "distinct_range": 798.99335303078,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "117050"
+ "num_range": 29406,
+ "upper_bound": "115554"
},
{
- "distinct_range": 1299.3780392427107,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "118355"
+ "distinct_range": 816.9258721761091,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "116375"
},
{
- "distinct_range": 1062.2216181374893,
+ "distinct_range": 932.490995557099,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "119422"
+ "num_range": 29406,
+ "upper_bound": "117312"
},
{
- "distinct_range": 944.6398630350299,
+ "distinct_range": 858.7684168485429,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "120371"
+ "num_range": 29406,
+ "upper_bound": "118175"
},
{
- "distinct_range": 968.5547962763861,
+ "distinct_range": 921.5322338571824,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "121344"
+ "num_range": 29406,
+ "upper_bound": "119101"
},
{
- "distinct_range": 920.7249297936536,
+ "distinct_range": 905.5922168391181,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "122269"
+ "num_range": 29406,
+ "upper_bound": "120011"
},
{
- "distinct_range": 936.6682186212394,
+ "distinct_range": 944.4460083206413,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "123210"
+ "num_range": 29406,
+ "upper_bound": "120960"
},
{
- "distinct_range": 886.8454410350218,
+ "distinct_range": 899.6147104573433,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "124101"
+ "num_range": 29406,
+ "upper_bound": "121864"
},
{
- "distinct_range": 881.8631632763987,
+ "distinct_range": 922.5284849208113,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "124987"
+ "num_range": 29406,
+ "upper_bound": "122791"
},
{
- "distinct_range": 979.5158073453294,
+ "distinct_range": 999.2398168201076,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "125971"
+ "num_range": 29406,
+ "upper_bound": "123795"
},
{
- "distinct_range": 907.7710076212369,
+ "distinct_range": 970.3485359749633,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "126883"
+ "num_range": 29406,
+ "upper_bound": "124770"
},
{
- "distinct_range": 933.6788519660674,
+ "distinct_range": 994.2585615019863,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "127821"
+ "num_range": 29406,
+ "upper_bound": "125769"
},
{
- "distinct_range": 1019.3740294140889,
+ "distinct_range": 981.3072976748559,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "128845"
+ "num_range": 29406,
+ "upper_bound": "126755"
},
{
- "distinct_range": 959.5866963108808,
+ "distinct_range": 784.049587076339,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "129809"
+ "num_range": 29406,
+ "upper_bound": "127543"
},
{
- "distinct_range": 829.05101903499,
+ "distinct_range": 1136.7224635939351,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "130642"
+ "num_range": 29406,
+ "upper_bound": "128685"
},
{
- "distinct_range": 1000.44137393146,
+ "distinct_range": 1176.5725061284397,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "131647"
+ "num_range": 29406,
+ "upper_bound": "129867"
},
{
- "distinct_range": 898.8029076557166,
+ "distinct_range": 1124.7674508321693,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "132550"
+ "num_range": 29406,
+ "upper_bound": "130997"
},
{
- "distinct_range": 888.838352138471,
+ "distinct_range": 917.5472296026667,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "133443"
+ "num_range": 29406,
+ "upper_bound": "131919"
},
{
- "distinct_range": 1150.906162232147,
+ "distinct_range": 1178.5650082548975,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "134599"
+ "num_range": 29406,
+ "upper_bound": "133103"
},
{
- "distinct_range": 958.5902407591577,
+ "distinct_range": 956.4010210841788,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "135562"
+ "num_range": 29406,
+ "upper_bound": "134064"
},
{
- "distinct_range": 958.5902407591577,
+ "distinct_range": 812.9408679215915,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "136525"
+ "num_range": 29406,
+ "upper_bound": "134881"
},
{
- "distinct_range": 1183.789195428254,
+ "distinct_range": 1086.9099104175627,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "137714"
+ "num_range": 29406,
+ "upper_bound": "135973"
},
{
- "distinct_range": 773.2495081384044,
+ "distinct_range": 870.7234296120948,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "138491"
+ "num_range": 29406,
+ "upper_bound": "136848"
},
{
- "distinct_range": 908.7674631729615,
+ "distinct_range": 1062.0036338278449,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "139404"
+ "num_range": 29406,
+ "upper_bound": "137915"
},
{
- "distinct_range": 1281.4418393696442,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "140691"
+ "distinct_range": 1222.4000550259843,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "139143"
},
{
- "distinct_range": 975.529985138442,
+ "distinct_range": 925.5172381116978,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "141671"
+ "num_range": 29406,
+ "upper_bound": "140073"
},
{
- "distinct_range": 781.2211525522024,
+ "distinct_range": 982.303548738482,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "142456"
+ "num_range": 29406,
+ "upper_bound": "141060"
},
{
- "distinct_range": 956.5973296557114,
+ "distinct_range": 772.0945743127862,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "143417"
+ "num_range": 29406,
+ "upper_bound": "141836"
},
{
- "distinct_range": 1099.0904735495433,
+ "distinct_range": 984.2960508657338,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "144521"
+ "num_range": 29406,
+ "upper_bound": "142825"
},
{
- "distinct_range": 641.7173753107377,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "145166"
+ "distinct_range": 875.7046849302416,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "143705"
},
{
- "distinct_range": 1040.2995960000392,
+ "distinct_range": 1061.0073827642445,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "146211"
+ "num_range": 29406,
+ "upper_bound": "144771"
},
{
- "distinct_range": 1129.9805956497785,
+ "distinct_range": 1285.1638719215146,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "147346"
+ "num_range": 29406,
+ "upper_bound": "146062"
},
{
- "distinct_range": 976.526440690164,
+ "distinct_range": 967.3597827840819,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "148327"
+ "num_range": 29406,
+ "upper_bound": "147034"
},
{
- "distinct_range": 1092.1152846879327,
+ "distinct_range": 960.3860253386897,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "149424"
+ "num_range": 29406,
+ "upper_bound": "147999"
},
{
- "distinct_range": 904.7816409660636,
+ "distinct_range": 872.7159317393536,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "150333"
+ "num_range": 29406,
+ "upper_bound": "148876"
},
{
- "distinct_range": 1132.969962304504,
+ "distinct_range": 898.6184593937141,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "151471"
+ "num_range": 29406,
+ "upper_bound": "149779"
},
{
- "distinct_range": 1095.1046513429178,
+ "distinct_range": 1302.1001399449563,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "152571"
+ "num_range": 29406,
+ "upper_bound": "151087"
},
{
- "distinct_range": 1018.3775738623737,
+ "distinct_range": 973.3372891658441,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "153594"
+ "num_range": 29406,
+ "upper_bound": "152065"
},
{
- "distinct_range": 971.5441629315883,
+ "distinct_range": 1057.022378509836,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "154570"
+ "num_range": 29406,
+ "upper_bound": "153127"
},
{
- "distinct_range": 1005.423651690151,
+ "distinct_range": 998.2435657565634,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "155580"
+ "num_range": 30006,
+ "upper_bound": "154130"
},
{
- "distinct_range": 818.090007966018,
+ "distinct_range": 977.322293420393,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "156402"
+ "num_range": 30006,
+ "upper_bound": "155112"
},
{
- "distinct_range": 887.8418965867484,
+ "distinct_range": 1085.9136593548596,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "157294"
+ "num_range": 30006,
+ "upper_bound": "156203"
},
{
- "distinct_range": 1096.1011068956898,
+ "distinct_range": 948.4310125751713,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "158395"
+ "num_range": 30006,
+ "upper_bound": "157156"
},
{
- "distinct_range": 1025.3527627245478,
+ "distinct_range": 1048.0561189377067,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "159425"
+ "num_range": 30006,
+ "upper_bound": "158209"
},
{
- "distinct_range": 1094.1081957912575,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "160524"
+ "distinct_range": 927.5097402389638,
+ "num_eq": 600,
+ "num_range": 30006,
+ "upper_bound": "159141"
},
{
- "distinct_range": 822.075830172917,
+ "distinct_range": 1175.5762550721756,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "161350"
+ "num_range": 30006,
+ "upper_bound": "160322"
},
{
- "distinct_range": 1050.2641515174382,
+ "distinct_range": 1071.9661444644169,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "162405"
+ "num_range": 30006,
+ "upper_bound": "161399"
},
{
- "distinct_range": 710.4728083797453,
+ "distinct_range": 994.2585615020571,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "163119"
+ "num_range": 30006,
+ "upper_bound": "162398"
},
{
- "distinct_range": 1053.2535181725734,
+ "distinct_range": 938.4685019388827,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "164177"
+ "num_range": 30006,
+ "upper_bound": "163341"
},
{
- "distinct_range": 781.2211525522024,
+ "distinct_range": 1055.029876383021,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "164962"
+ "num_range": 30006,
+ "upper_bound": "164401"
},
{
- "distinct_range": 1193.7537509506622,
+ "distinct_range": 1384.7889778656406,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "166161"
+ "num_range": 30006,
+ "upper_bound": "165792"
},
{
- "distinct_range": 975.5299851384816,
+ "distinct_range": 1142.6999699780074,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "167141"
+ "num_range": 30006,
+ "upper_bound": "166940"
},
{
- "distinct_range": 1338.2398057045664,
+ "distinct_range": 943.4497572570273,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "168485"
+ "num_range": 30006,
+ "upper_bound": "167888"
},
{
- "distinct_range": 857.9482300350074,
+ "distinct_range": 980.3110466112762,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "169347"
+ "num_range": 30006,
+ "upper_bound": "168873"
},
{
- "distinct_range": 1016.3846627589421,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "170368"
+ "distinct_range": 710.3270083677634,
+ "num_eq": 600,
+ "num_range": 30006,
+ "upper_bound": "169587"
},
{
- "distinct_range": 1144.927428926604,
+ "distinct_range": 1235.3513188625877,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "171518"
+ "num_range": 30006,
+ "upper_bound": "170828"
},
{
- "distinct_range": 1247.562350711355,
+ "distinct_range": 1250.2950848037037,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "172771"
+ "num_range": 30006,
+ "upper_bound": "172084"
},
{
- "distinct_range": 943.6434074833204,
+ "distinct_range": 840.8358977032148,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "173719"
+ "num_range": 30006,
+ "upper_bound": "172929"
},
{
- "distinct_range": 1073.182629206716,
+ "distinct_range": 1145.6887231685344,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "174797"
+ "num_range": 30006,
+ "upper_bound": "174080"
},
{
- "distinct_range": 923.7142964488335,
+ "distinct_range": 1093.88366786362,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "175725"
+ "num_range": 30006,
+ "upper_bound": "175179"
},
{
- "distinct_range": 1223.6474174885138,
+ "distinct_range": 1100.8574253087381,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "176954"
+ "num_range": 30006,
+ "upper_bound": "176285"
},
{
- "distinct_range": 1006.420107241872,
+ "distinct_range": 1089.8986636092466,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "177965"
+ "num_range": 30006,
+ "upper_bound": "177380"
},
{
- "distinct_range": 838.0191190005128,
+ "distinct_range": 905.592216839122,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "178807"
+ "num_range": 30006,
+ "upper_bound": "178290"
},
{
- "distinct_range": 1109.0550290675108,
+ "distinct_range": 867.7346764212078,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "179921"
+ "num_range": 30006,
+ "upper_bound": "179162"
},
{
- "distinct_range": 1071.1897181033103,
+ "distinct_range": 1127.7562040250532,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "180997"
+ "num_range": 30006,
+ "upper_bound": "180295"
},
{
- "distinct_range": 647.6961086210862,
+ "distinct_range": 1179.56125932571,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "181648"
+ "num_range": 30006,
+ "upper_bound": "181480"
},
{
- "distinct_range": 1108.058573515839,
+ "distinct_range": 1049.052370001324,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "182761"
+ "num_range": 30006,
+ "upper_bound": "182534"
},
{
- "distinct_range": 984.4980851039887,
+ "distinct_range": 1236.3475699254398,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "183750"
+ "num_range": 30006,
+ "upper_bound": "183776"
},
{
- "distinct_range": 1165.8529955096017,
+ "distinct_range": 1074.9548976552364,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "184921"
+ "num_range": 30006,
+ "upper_bound": "184856"
},
{
- "distinct_range": 729.4054638625155,
+ "distinct_range": 1032.1161019197914,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "185654"
+ "num_range": 30006,
+ "upper_bound": "185893"
},
{
- "distinct_range": 981.5087184488202,
+ "distinct_range": 1095.8761699908016,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "186640"
+ "num_range": 30006,
+ "upper_bound": "186994"
},
{
- "distinct_range": 1259.519817319189,
+ "distinct_range": 719.293267940428,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "187905"
+ "num_range": 30006,
+ "upper_bound": "187717"
},
{
- "distinct_range": 836.0262078970633,
+ "distinct_range": 1038.0936083015174,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "188745"
+ "num_range": 30006,
+ "upper_bound": "188760"
},
{
- "distinct_range": 894.817085448821,
+ "distinct_range": 931.49474449348,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "189644"
+ "num_range": 30006,
+ "upper_bound": "189696"
},
{
- "distinct_range": 1010.405929448755,
+ "distinct_range": 1037.097357237897,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "190659"
+ "num_range": 30006,
+ "upper_bound": "190738"
},
{
- "distinct_range": 1185.7821065393698,
+ "distinct_range": 836.8508934486971,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "191850"
+ "num_range": 30006,
+ "upper_bound": "191579"
},
{
- "distinct_range": 1107.0621179641662,
- "num_eq": 600,
- "num_range": 30011,
- "upper_bound": "192962"
+ "distinct_range": 1214.4300465241001,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "192799"
},
{
- "distinct_range": 1055.2464292759953,
+ "distinct_range": 924.5209870480766,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "194022"
+ "num_range": 30006,
+ "upper_bound": "193728"
},
{
- "distinct_range": 1182.7927398850347,
- "num_eq": 1200,
- "num_range": 30011,
- "upper_bound": "195210"
+ "distinct_range": 1129.7487061521413,
+ "num_eq": 600,
+ "num_range": 30006,
+ "upper_bound": "194863"
},
{
- "distinct_range": 1130.977051201357,
+ "distinct_range": 981.3072976749038,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "196346"
+ "num_range": 30006,
+ "upper_bound": "195849"
},
{
- "distinct_range": 862.9305077936309,
+ "distinct_range": 967.3597827841128,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "197213"
+ "num_range": 30006,
+ "upper_bound": "196821"
},
{
- "distinct_range": 815.1006413108437,
+ "distinct_range": 918.5434806663017,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "198032"
+ "num_range": 30006,
+ "upper_bound": "197744"
},
{
- "distinct_range": 899.7993632074441,
+ "distinct_range": 1000.236067883816,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "198936"
+ "num_range": 30006,
+ "upper_bound": "198749"
},
{
- "distinct_range": 1043.2889626554447,
+ "distinct_range": 1235.3513188625877,
"num_eq": 600,
- "num_range": 30011,
- "upper_bound": "199984"
+ "num_range": 30006,
+ "upper_bound": "199990"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 4,
"columns": [
"l_suppkey"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 9920,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1200,
- "num_range": 0,
- "upper_bound": "4"
- },
- {
- "distinct_range": 43.654179850974785,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "49"
- },
- {
- "distinct_range": 51.59130346024293,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "102"
+ "num_range": 0,
+ "upper_bound": "1"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "147"
+ "distinct_range": 48.60992039191672,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "51"
},
{
- "distinct_range": 61.51270797182811,
+ "distinct_range": 41.665646050214335,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "210"
+ "num_range": 28806,
+ "upper_bound": "94"
},
{
- "distinct_range": 43.654179850974785,
+ "distinct_range": 54.56215554194734,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "255"
- },
- {
- "distinct_range": 45.638460753291824,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "302"
+ "num_range": 28806,
+ "upper_bound": "150"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 49.60195958358849,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "348"
+ "num_range": 29406,
+ "upper_bound": "201"
},
{
- "distinct_range": 52.583443911401446,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "402"
+ "distinct_range": 53.57011635027557,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "256"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "451"
+ "distinct_range": 52.5780771586038,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "310"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 46.62584200857318,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "509"
+ "num_range": 28806,
+ "upper_bound": "358"
},
{
- "distinct_range": 37.70133714402368,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "548"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "402"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 61.50642988364973,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "605"
+ "num_range": 29406,
+ "upper_bound": "465"
},
{
- "distinct_range": 39.685618046340714,
+ "distinct_range": 41.665646050214335,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "646"
+ "num_range": 29406,
+ "upper_bound": "508"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 53.57011635027557,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "698"
+ "num_range": 29406,
+ "upper_bound": "563"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "745"
+ "distinct_range": 49.60195958358849,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "614"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 52.5780771586038,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "795"
+ "num_range": 29406,
+ "upper_bound": "668"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 39.68156766687079,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "849"
+ "num_range": 28806,
+ "upper_bound": "709"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 44.64176362522964,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "897"
+ "num_range": 29406,
+ "upper_bound": "755"
},
{
- "distinct_range": 40.677758497499234,
+ "distinct_range": 58.530312308634414,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "939"
+ "num_range": 29406,
+ "upper_bound": "815"
},
{
- "distinct_range": 57.544146167194036,
+ "distinct_range": 41.665646050214335,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "998"
+ "num_range": 29406,
+ "upper_bound": "858"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1044"
+ "distinct_range": 38.68952847519902,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "898"
},
{
- "distinct_range": 52.583443911401446,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1098"
+ "distinct_range": 44.64176362522964,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "944"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 45.63380281690141,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1150"
+ "num_range": 29406,
+ "upper_bound": "991"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1195"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1043"
},
{
- "distinct_range": 41.66989894865775,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1238"
+ "distinct_range": 33.729332516840174,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1078"
},
{
- "distinct_range": 40.677758497499234,
+ "distinct_range": 54.56215554194734,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1280"
+ "num_range": 29406,
+ "upper_bound": "1134"
+ },
+ {
+ "distinct_range": 54.56215554194734,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1190"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 46.62584200857318,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1337"
+ "num_range": 29406,
+ "upper_bound": "1238"
},
{
- "distinct_range": 59.528427069511075,
+ "distinct_range": 40.67360685854256,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1398"
+ "num_range": 28806,
+ "upper_bound": "1280"
},
{
- "distinct_range": 60.520567520669594,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1460"
+ "distinct_range": 46.62584200857318,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1328"
},
{
- "distinct_range": 43.654179850974785,
+ "distinct_range": 47.61788120024495,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1505"
+ "num_range": 29406,
+ "upper_bound": "1377"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 43.64972443355787,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1554"
+ "num_range": 29406,
+ "upper_bound": "1422"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 42.6576852418861,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1603"
+ "num_range": 28806,
+ "upper_bound": "1466"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 50.59399877526026,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1654"
+ "num_range": 29406,
+ "upper_bound": "1518"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1707"
+ "distinct_range": 39.68156766687079,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1559"
},
{
- "distinct_range": 52.583443911401446,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1761"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1611"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 49.60195958358849,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1817"
+ "num_range": 28806,
+ "upper_bound": "1662"
},
{
- "distinct_range": 50.599163009084414,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1869"
+ "distinct_range": 51.58603796693203,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1715"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 50.59399877526026,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1918"
+ "num_range": 29406,
+ "upper_bound": "1767"
},
{
- "distinct_range": 41.66989894865775,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1961"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1819"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 52.5780771586038,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2011"
+ "num_range": 29406,
+ "upper_bound": "1873"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 59.522351500306186,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "2063"
+ "num_range": 28806,
+ "upper_bound": "1934"
},
{
- "distinct_range": 60.520567520669594,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "2125"
+ "distinct_range": 49.60195958358849,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1985"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "2173"
+ "distinct_range": 76.38701775872627,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "2063"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 58.530312308634414,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2219"
+ "num_range": 29406,
+ "upper_bound": "2123"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "2270"
+ "distinct_range": 61.50642988364973,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "2186"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2325"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "2230"
},
{
- "distinct_range": 64.48912932530367,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "2391"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "2282"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 54.56215554194734,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "2447"
+ "num_range": 28806,
+ "upper_bound": "2338"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "2493"
+ "distinct_range": 56.54623392529088,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "2396"
},
{
- "distinct_range": 35.71705624170664,
+ "distinct_range": 41.665646050214335,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2530"
+ "num_range": 29406,
+ "upper_bound": "2439"
},
{
- "distinct_range": 59.528427069511075,
+ "distinct_range": 56.54623392529088,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "2591"
+ "num_range": 29406,
+ "upper_bound": "2497"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 56.54623392529088,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2644"
+ "num_range": 29406,
+ "upper_bound": "2555"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 43.64972443355787,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2690"
+ "num_range": 29406,
+ "upper_bound": "2600"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 48.60992039191672,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "2739"
+ "num_range": 29406,
+ "upper_bound": "2650"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "2794"
+ "distinct_range": 49.60195958358849,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "2701"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 54.56215554194734,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "2845"
+ "num_range": 28806,
+ "upper_bound": "2757"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "2887"
+ "distinct_range": 38.68952847519902,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "2797"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 51.58603796693203,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "2925"
+ "num_range": 28806,
+ "upper_bound": "2850"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 45.63380281690141,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "2983"
+ "num_range": 29406,
+ "upper_bound": "2897"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3028"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "2949"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 50.59399877526026,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "3078"
+ "num_range": 28806,
+ "upper_bound": "3001"
+ },
+ {
+ "distinct_range": 33.729332516840174,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "3036"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 56.54623392529088,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3116"
+ "num_range": 29406,
+ "upper_bound": "3094"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 46.62584200857318,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "3163"
+ "num_range": 29406,
+ "upper_bound": "3142"
},
{
- "distinct_range": 66.4734102276207,
+ "distinct_range": 60.51439069197796,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3231"
+ "num_range": 29406,
+ "upper_bound": "3204"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3276"
+ "distinct_range": 40.67360685854256,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "3246"
},
{
- "distinct_range": 40.677758497499234,
+ "distinct_range": 51.58603796693203,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "3318"
+ "num_range": 29406,
+ "upper_bound": "3299"
},
{
- "distinct_range": 41.66989894865775,
+ "distinct_range": 52.5780771586038,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "3361"
+ "num_range": 28806,
+ "upper_bound": "3353"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "3403"
+ "distinct_range": 52.5780771586038,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "3407"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3449"
+ "distinct_range": 43.64972443355787,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "3452"
+ },
+ {
+ "distinct_range": 58.530312308634414,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "3512"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 63.49050826699327,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3500"
+ "num_range": 29406,
+ "upper_bound": "3577"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "3549"
+ "distinct_range": 58.530312308634414,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "3637"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "3606"
+ "distinct_range": 58.530312308634414,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "3697"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "3654"
+ "distinct_range": 55.554194733619106,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "3754"
},
{
- "distinct_range": 57.544146167194036,
+ "distinct_range": 53.57011635027557,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3713"
+ "num_range": 29406,
+ "upper_bound": "3809"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 48.60992039191672,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3761"
+ "num_range": 29406,
+ "upper_bound": "3859"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 54.56215554194734,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "3816"
+ "num_range": 29406,
+ "upper_bound": "3915"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 37.697489283527254,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "3865"
+ "num_range": 28806,
+ "upper_bound": "3954"
},
{
- "distinct_range": 48.614882106767375,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "3915"
+ "distinct_range": 59.522351500306186,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "4015"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 46.62584200857318,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "3959"
+ "num_range": 29406,
+ "upper_bound": "4063"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4014"
+ "distinct_range": 43.64972443355787,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "4108"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4071"
+ "distinct_range": 45.63380281690141,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "4155"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 59.522351500306186,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "4117"
+ "num_range": 29406,
+ "upper_bound": "4216"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 47.61788120024495,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "4167"
+ "num_range": 29406,
+ "upper_bound": "4265"
},
{
- "distinct_range": 61.51270797182811,
+ "distinct_range": 56.54623392529088,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4230"
+ "num_range": 29406,
+ "upper_bound": "4323"
},
{
- "distinct_range": 65.48126977646218,
+ "distinct_range": 44.64176362522964,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4297"
+ "num_range": 29406,
+ "upper_bound": "4369"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 55.554194733619106,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "4343"
+ "num_range": 29406,
+ "upper_bound": "4426"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "4390"
+ "distinct_range": 49.60195958358849,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "4477"
+ },
+ {
+ "distinct_range": 45.63380281690141,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "4524"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 42.6576852418861,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "4437"
+ "num_range": 29406,
+ "upper_bound": "4568"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 44.64176362522964,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4490"
+ "num_range": 29406,
+ "upper_bound": "4614"
+ },
+ {
+ "distinct_range": 48.60992039191672,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "4664"
},
{
- "distinct_range": 63.496988874145146,
+ "distinct_range": 49.60195958358849,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4555"
+ "num_range": 29406,
+ "upper_bound": "4715"
},
{
- "distinct_range": 57.544146167194036,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "4614"
+ "distinct_range": 40.67360685854256,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "4757"
},
{
- "distinct_range": 39.685618046340714,
+ "distinct_range": 45.63380281690141,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "4655"
+ "num_range": 29406,
+ "upper_bound": "4804"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 55.554194733619106,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "4707"
+ "num_range": 28806,
+ "upper_bound": "4861"
},
{
- "distinct_range": 38.693477595182195,
+ "distinct_range": 49.60195958358849,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "4747"
+ "num_range": 29406,
+ "upper_bound": "4912"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4800"
+ "distinct_range": 48.60992039191672,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "4962"
},
{
- "distinct_range": 61.51270797182811,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "4863"
+ "distinct_range": 33.729332516840174,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "4997"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "4910"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "5041"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 49.60195958358849,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "4966"
+ "num_range": 29406,
+ "upper_bound": "5092"
},
{
- "distinct_range": 63.496988874145146,
+ "distinct_range": 42.6576852418861,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "5031"
+ "num_range": 28806,
+ "upper_bound": "5136"
},
{
- "distinct_range": 38.693477595182195,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "5071"
+ "distinct_range": 48.60992039191672,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "5186"
+ },
+ {
+ "distinct_range": 56.54623392529088,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "5244"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 40.67360685854256,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "5125"
+ "num_range": 28806,
+ "upper_bound": "5286"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "5170"
+ "distinct_range": 47.61788120024495,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "5335"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 47.61788120024495,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "5220"
+ "num_range": 29406,
+ "upper_bound": "5384"
},
{
- "distinct_range": 43.654179850974785,
+ "distinct_range": 50.59399877526026,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "5265"
+ "num_range": 29406,
+ "upper_bound": "5436"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "5316"
+ "distinct_range": 55.554194733619106,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "5493"
},
{
- "distinct_range": 58.536286618352555,
+ "distinct_range": 56.54623392529088,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "5376"
+ "num_range": 29406,
+ "upper_bound": "5551"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "5427"
+ "distinct_range": 43.64972443355787,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "5596"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "5474"
+ "distinct_range": 54.56215554194734,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "5652"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "5529"
+ "distinct_range": 44.64176362522964,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "5698"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "5574"
+ "distinct_range": 56.54623392529088,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "5756"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 38.68952847519902,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "5623"
+ "num_range": 29406,
+ "upper_bound": "5796"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "5680"
+ "distinct_range": 53.57011635027557,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "5851"
},
{
- "distinct_range": 33.73277533938961,
+ "distinct_range": 42.6576852418861,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "5715"
+ "num_range": 28806,
+ "upper_bound": "5895"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 47.61788120024495,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "5766"
+ "num_range": 28806,
+ "upper_bound": "5944"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 53.57011635027557,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "5817"
+ "num_range": 29406,
+ "upper_bound": "5999"
},
{
- "distinct_range": 37.70133714402368,
+ "distinct_range": 41.665646050214335,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "5856"
+ "num_range": 28806,
+ "upper_bound": "6042"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "5902"
+ "distinct_range": 40.67360685854256,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "6084"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "5948"
+ "distinct_range": 46.62584200857318,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "6132"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6005"
+ "distinct_range": 39.68156766687079,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "6173"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6046"
+ "distinct_range": 40.67360685854256,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "6215"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6101"
+ "distinct_range": 53.57011635027557,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "6270"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6143"
+ "distinct_range": 43.64972443355787,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "6315"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "6188"
+ "distinct_range": 41.665646050214335,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "6358"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 49.60195958358849,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "6234"
+ "num_range": 29406,
+ "upper_bound": "6409"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 54.56215554194734,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "6292"
+ "num_range": 28806,
+ "upper_bound": "6465"
},
{
- "distinct_range": 50.599163009084414,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6344"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "6509"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "6391"
+ "distinct_range": 55.554194733619106,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "6566"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "6440"
+ "distinct_range": 43.64972443355787,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "6611"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 65.4745866503368,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "6492"
+ "num_range": 29406,
+ "upper_bound": "6678"
},
{
- "distinct_range": 62.504848422986626,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "6556"
+ "distinct_range": 40.67360685854256,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "6720"
},
{
- "distinct_range": 42.66203939981627,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "6600"
+ "distinct_range": 52.5780771586038,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "6774"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "6646"
+ "distinct_range": 61.50642988364973,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "6837"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 40.67360685854256,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "6695"
+ "num_range": 29406,
+ "upper_bound": "6879"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "6750"
+ "distinct_range": 46.62584200857318,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "6927"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 53.57011635027557,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "6808"
- },
- {
- "distinct_range": 52.583443911401446,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "6862"
+ "num_range": 28206,
+ "upper_bound": "6982"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "6908"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "7026"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "6959"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "7070"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "7005"
+ "distinct_range": 44.64176362522964,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "7116"
},
{
- "distinct_range": 42.66203939981627,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "7049"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "7160"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "7102"
+ "distinct_range": 38.68952847519902,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "7200"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 33.729332516840174,
"num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "7154"
+ "num_range": 28806,
+ "upper_bound": "7235"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 51.58603796693203,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "7204"
+ "num_range": 29406,
+ "upper_bound": "7288"
},
{
- "distinct_range": 58.536286618352555,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "7264"
+ "distinct_range": 47.61788120024495,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "7337"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "7306"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "7381"
},
{
- "distinct_range": 58.536286618352555,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "7366"
+ "distinct_range": 65.4745866503368,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "7448"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 50.59399877526026,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "7421"
+ "num_range": 28806,
+ "upper_bound": "7500"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 51.58603796693203,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "7477"
+ "num_range": 28806,
+ "upper_bound": "7553"
},
{
- "distinct_range": 37.70133714402368,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "7516"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "7605"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "7561"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "7649"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "7618"
+ "distinct_range": 46.62584200857318,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "7697"
},
{
- "distinct_range": 58.536286618352555,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "7678"
+ "distinct_range": 52.5780771586038,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "7751"
},
{
- "distinct_range": 50.599163009084414,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "7730"
+ "distinct_range": 56.54623392529088,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "7809"
},
{
- "distinct_range": 30.756353985914053,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "7762"
+ "distinct_range": 46.62584200857318,
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "7857"
},
{
- "distinct_range": 62.504848422986626,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "7826"
+ "distinct_range": 43.64972443355787,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "7902"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 48.60992039191672,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "7882"
+ "num_range": 28806,
+ "upper_bound": "7952"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 52.5780771586038,
"num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "7935"
+ "num_range": 28806,
+ "upper_bound": "8006"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 49.60195958358849,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "7991"
+ "num_range": 28206,
+ "upper_bound": "8057"
},
{
- "distinct_range": 43.654179850974785,
+ "distinct_range": 42.6576852418861,
"num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "8036"
- },
- {
- "distinct_range": 39.685618046340714,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "8077"
+ "num_range": 29406,
+ "upper_bound": "8101"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "8124"
+ "distinct_range": 44.64176362522964,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "8147"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 2401,
- "num_range": 29411,
- "upper_bound": "8177"
+ "distinct_range": 48.60992039191672,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "8197"
},
{
- "distinct_range": 41.66989894865775,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "8220"
+ "distinct_range": 64.48254745866504,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "8263"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 40.67360685854256,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "8271"
+ "num_range": 28806,
+ "upper_bound": "8305"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "8318"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "8349"
},
{
- "distinct_range": 40.677758497499234,
+ "distinct_range": 51.58603796693203,
"num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "8360"
+ "num_range": 29406,
+ "upper_bound": "8402"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 53.57011635027557,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "8413"
+ "num_range": 28806,
+ "upper_bound": "8457"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 32.7372933251684,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "8466"
+ "num_range": 28806,
+ "upper_bound": "8491"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "8523"
+ "distinct_range": 45.63380281690141,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "8538"
},
{
- "distinct_range": 61.51270797182811,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "8586"
+ "distinct_range": 35.71341090018371,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "8575"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 51.58603796693203,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "8633"
+ "num_range": 29406,
+ "upper_bound": "8628"
},
{
- "distinct_range": 31.748494437072573,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "8666"
+ "distinct_range": 59.522351500306186,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "8689"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 51.58603796693203,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "8718"
+ "num_range": 29406,
+ "upper_bound": "8742"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "8769"
+ "distinct_range": 52.5780771586038,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "8796"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "8816"
+ "distinct_range": 34.721371708511946,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "8832"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "8869"
+ "distinct_range": 46.62584200857318,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "8880"
},
{
- "distinct_range": 37.70133714402368,
+ "distinct_range": 61.50642988364973,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "8908"
+ "num_range": 29406,
+ "upper_bound": "8943"
+ },
+ {
+ "distinct_range": 47.61788120024495,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "8992"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "8949"
+ "distinct_range": 51.58603796693203,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "9045"
},
{
- "distinct_range": 61.51270797182811,
+ "distinct_range": 49.60195958358849,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "9012"
+ "num_range": 29406,
+ "upper_bound": "9096"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "9058"
+ "distinct_range": 51.58603796693203,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "9149"
},
{
- "distinct_range": 66.4734102276207,
+ "distinct_range": 51.58603796693203,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "9126"
+ "num_range": 28206,
+ "upper_bound": "9202"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 61.50642988364973,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "9179"
+ "num_range": 28806,
+ "upper_bound": "9265"
},
{
- "distinct_range": 43.654179850974785,
+ "distinct_range": 61.50642988364973,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "9224"
+ "num_range": 29406,
+ "upper_bound": "9328"
},
{
- "distinct_range": 56.552005716035524,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "9282"
+ "distinct_range": 42.6576852418861,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "9372"
},
{
- "distinct_range": 39.685618046340714,
+ "distinct_range": 54.56215554194734,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "9323"
+ "num_range": 29406,
+ "upper_bound": "9428"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "9372"
+ "distinct_range": 48.60992039191672,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "9478"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 43.64972443355787,
"num_eq": 600,
- "num_range": 28811,
- "upper_bound": "9421"
- },
- {
- "distinct_range": 43.654179850974785,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "9466"
+ "num_range": 28806,
+ "upper_bound": "9523"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "9517"
+ "distinct_range": 44.64176362522964,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "9569"
},
{
- "distinct_range": 63.496988874145146,
+ "distinct_range": 47.61788120024495,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "9582"
+ "num_range": 28806,
+ "upper_bound": "9618"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 63.49050826699327,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "9628"
- },
- {
- "distinct_range": 53.575584362559965,
- "num_eq": 1801,
- "num_range": 28211,
+ "num_range": 29406,
"upper_bound": "9683"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 40.67360685854256,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "9730"
+ "num_range": 28806,
+ "upper_bound": "9725"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "9771"
+ "distinct_range": 50.59399877526026,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "9777"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "9819"
+ "distinct_range": 38.68952847519902,
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "9817"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "9866"
+ "distinct_range": 36.70545009185548,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "9855"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "9911"
+ "distinct_range": 45.63380281690141,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "9902"
},
{
- "distinct_range": 37.70133714402368,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "9950"
+ "distinct_range": 44.64176362522964,
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "9948"
},
{
- "distinct_range": 48.614882106767375,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "10000"
+ "distinct_range": 48.60992039191672,
+ "num_eq": 600,
+ "num_range": 27606,
+ "upper_bound": "9998"
}
],
"histo_col_type": "INT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 4,
"columns": [
"l_shipdate"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 2526,
"histo_buckets": [
{
@@ -5265,1209 +5291,1209 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"upper_bound": "-infinity"
},
{
- "distinct_range": 7.5,
+ "distinct_range": 4,
"num_eq": 600,
- "num_range": 7,
- "upper_bound": "1992-01-07"
+ "num_range": 4,
+ "upper_bound": "1992-01-04"
},
{
- "distinct_range": 45,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1992-02-22"
+ "distinct_range": 52,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1992-02-26"
},
{
- "distinct_range": 18,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1992-03-12"
+ "distinct_range": 23,
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "1992-03-21"
},
{
- "distinct_range": 20,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1992-04-02"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1992-04-04"
},
{
- "distinct_range": 14,
- "num_eq": 6002,
- "num_range": 27610,
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28206,
"upper_bound": "1992-04-17"
},
{
- "distinct_range": 12,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1992-04-30"
+ "distinct_range": 16,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1992-05-04"
},
{
"distinct_range": 12,
- "num_eq": 5402,
- "num_range": 27610,
- "upper_bound": "1992-05-13"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1992-05-17"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 29411,
- "upper_bound": "1992-05-25"
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1992-05-29"
},
{
- "distinct_range": 12,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1992-06-07"
+ "distinct_range": 10,
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1992-06-09"
},
{
"distinct_range": 12,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1992-06-20"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1992-06-22"
},
{
- "distinct_range": 15,
- "num_eq": 1801,
- "num_range": 28811,
+ "distinct_range": 13,
+ "num_eq": 3001,
+ "num_range": 28806,
"upper_bound": "1992-07-06"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1992-07-18"
- },
- {
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1992-07-30"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1992-07-19"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 29411,
- "upper_bound": "1992-08-12"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1992-08-01"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1992-08-24"
- },
- {
- "distinct_range": 16,
- "num_eq": 4802,
- "num_range": 29411,
- "upper_bound": "1992-09-10"
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-08-13"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1992-09-23"
- },
- {
- "distinct_range": 10,
"num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1992-10-04"
+ "num_range": 29406,
+ "upper_bound": "1992-08-26"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1992-10-16"
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1992-09-07"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1992-10-29"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 27606,
+ "upper_bound": "1992-09-19"
},
{
- "distinct_range": 15,
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 29411,
- "upper_bound": "1992-11-14"
+ "num_range": 27005,
+ "upper_bound": "1992-10-01"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1992-11-28"
+ "distinct_range": 12,
+ "num_eq": 4801,
+ "num_range": 25205,
+ "upper_bound": "1992-10-14"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1992-12-12"
+ "distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 25805,
+ "upper_bound": "1992-10-26"
},
{
- "distinct_range": 14,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1992-12-27"
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1992-11-06"
},
{
- "distinct_range": 10,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1993-01-07"
+ "distinct_range": 14,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1992-11-21"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1993-01-20"
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1992-12-04"
},
{
- "distinct_range": 11,
+ "distinct_range": 10,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1993-02-01"
+ "num_range": 26405,
+ "upper_bound": "1992-12-15"
},
{
- "distinct_range": 10,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "1993-02-12"
+ "distinct_range": 8,
+ "num_eq": 7201,
+ "num_range": 23405,
+ "upper_bound": "1992-12-24"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1993-02-25"
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1993-01-06"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1993-03-11"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1993-01-18"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1993-03-22"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1993-01-31"
},
{
"distinct_range": 12,
"num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1993-04-04"
- },
- {
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1993-04-15"
+ "num_range": 27005,
+ "upper_bound": "1993-02-13"
},
{
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1993-04-28"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1993-02-25"
},
{
- "distinct_range": 14,
- "num_eq": 4202,
- "num_range": 27610,
- "upper_bound": "1993-05-13"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1993-03-09"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1993-05-26"
+ "distinct_range": 9,
+ "num_eq": 4801,
+ "num_range": 25805,
+ "upper_bound": "1993-03-19"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1993-06-07"
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1993-03-31"
},
{
"distinct_range": 10,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1993-06-18"
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1993-04-11"
},
{
- "distinct_range": 9,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1993-06-28"
+ "distinct_range": 15,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1993-04-27"
},
{
- "distinct_range": 15,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1993-07-14"
+ "distinct_range": 8,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1993-05-06"
},
{
"distinct_range": 11,
- "num_eq": 6002,
- "num_range": 25810,
- "upper_bound": "1993-07-26"
+ "num_eq": 4201,
+ "num_range": 29406,
+ "upper_bound": "1993-05-18"
},
{
- "distinct_range": 12,
- "num_eq": 5402,
- "num_range": 28811,
- "upper_bound": "1993-08-08"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1993-06-01"
},
{
"distinct_range": 11,
- "num_eq": 6002,
- "num_range": 28811,
- "upper_bound": "1993-08-20"
- },
- {
- "distinct_range": 13,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1993-09-03"
+ "num_range": 28206,
+ "upper_bound": "1993-06-13"
},
{
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1993-09-14"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1993-06-25"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1993-09-26"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1993-07-08"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1993-10-09"
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1993-07-21"
},
{
- "distinct_range": 10,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1993-10-20"
+ "distinct_range": 12,
+ "num_eq": 4801,
+ "num_range": 24605,
+ "upper_bound": "1993-08-03"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1993-11-02"
+ "num_eq": 5401,
+ "num_range": 27005,
+ "upper_bound": "1993-08-16"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1993-11-15"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1993-08-29"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1993-11-29"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1993-09-10"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1993-09-19"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1993-10-02"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1993-12-10"
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1993-10-13"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1993-12-22"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1993-10-25"
},
{
- "distinct_range": 9,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1994-01-01"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1993-11-06"
},
{
- "distinct_range": 9,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1994-01-11"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1993-11-18"
},
{
"distinct_range": 10,
"num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1994-01-22"
- },
- {
- "distinct_range": 13,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1994-02-05"
+ "num_range": 28806,
+ "upper_bound": "1993-11-29"
},
{
"distinct_range": 12,
- "num_eq": 4802,
- "num_range": 28211,
- "upper_bound": "1994-02-18"
- },
- {
- "distinct_range": 10,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1994-03-01"
+ "num_range": 28206,
+ "upper_bound": "1993-12-12"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1994-03-13"
+ "num_eq": 6001,
+ "num_range": 25805,
+ "upper_bound": "1993-12-24"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-03-26"
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-01-06"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1994-04-06"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 27606,
+ "upper_bound": "1994-01-20"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1994-04-17"
+ "distinct_range": 11,
+ "num_eq": 5401,
+ "num_range": 27005,
+ "upper_bound": "1994-02-01"
},
{
- "distinct_range": 9,
+ "distinct_range": 12,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1994-04-27"
+ "num_range": 28806,
+ "upper_bound": "1994-02-14"
},
{
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1994-05-10"
+ "distinct_range": 10,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1994-02-25"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1994-05-21"
+ "distinct_range": 13,
+ "num_eq": 5401,
+ "num_range": 24005,
+ "upper_bound": "1994-03-11"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1994-06-03"
+ "num_eq": 5401,
+ "num_range": 24605,
+ "upper_bound": "1994-03-24"
},
{
"distinct_range": 13,
"num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1994-06-17"
+ "num_range": 28206,
+ "upper_bound": "1994-04-07"
},
{
- "distinct_range": 9,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-06-27"
- },
- {
- "distinct_range": 15,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1994-07-13"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1994-04-19"
},
{
"distinct_range": 13,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1994-07-27"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-05-03"
},
{
- "distinct_range": 9,
+ "distinct_range": 10,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1994-08-06"
+ "num_range": 28806,
+ "upper_bound": "1994-05-14"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1994-08-19"
+ "distinct_range": 9,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1994-05-24"
},
{
"distinct_range": 10,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1994-08-30"
- },
- {
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1994-09-11"
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "1994-06-04"
},
{
"distinct_range": 9,
- "num_eq": 4202,
- "num_range": 28211,
- "upper_bound": "1994-09-21"
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-06-14"
},
{
"distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1994-10-03"
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1994-06-26"
},
{
"distinct_range": 9,
"num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1994-10-13"
- },
- {
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1994-10-26"
- },
- {
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1994-11-08"
+ "num_range": 27606,
+ "upper_bound": "1994-07-06"
},
{
"distinct_range": 10,
"num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1994-11-19"
- },
- {
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1994-12-01"
+ "num_range": 28206,
+ "upper_bound": "1994-07-17"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1994-12-13"
+ "distinct_range": 14,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1994-08-01"
},
{
"distinct_range": 9,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1994-12-23"
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1994-08-11"
},
{
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1995-01-04"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1994-08-25"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1995-01-15"
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1994-09-05"
},
{
- "distinct_range": 12,
+ "distinct_range": 10,
"num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1995-01-28"
+ "num_range": 27606,
+ "upper_bound": "1994-09-16"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1995-02-10"
+ "distinct_range": 9,
+ "num_eq": 5401,
+ "num_range": 24605,
+ "upper_bound": "1994-09-26"
},
{
"distinct_range": 10,
- "num_eq": 3601,
- "num_range": 28211,
- "upper_bound": "1995-02-21"
- },
- {
- "distinct_range": 15,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-03-09"
- },
- {
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1995-03-21"
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-10-07"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1995-04-02"
+ "distinct_range": 9,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1994-10-17"
},
{
- "distinct_range": 8,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1995-04-11"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-10-27"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1995-04-22"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-11-09"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1995-05-03"
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "1994-11-22"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1995-05-15"
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "1994-12-04"
},
{
- "distinct_range": 12,
- "num_eq": 4802,
- "num_range": 27010,
- "upper_bound": "1995-05-28"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1994-12-16"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1995-06-11"
+ "distinct_range": 15,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1995-01-01"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1995-06-24"
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1995-01-14"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-07-04"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1995-01-26"
},
{
"distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1995-07-15"
- },
- {
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1995-07-25"
+ "num_eq": 5401,
+ "num_range": 26405,
+ "upper_bound": "1995-02-06"
},
{
- "distinct_range": 15,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1995-08-10"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1995-02-19"
},
{
- "distinct_range": 9,
- "num_eq": 6002,
- "num_range": 28211,
- "upper_bound": "1995-08-20"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1995-03-03"
},
{
"distinct_range": 13,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1995-09-03"
+ "num_eq": 6601,
+ "num_range": 26405,
+ "upper_bound": "1995-03-17"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-09-13"
+ "distinct_range": 14,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1995-04-01"
},
{
- "distinct_range": 10,
- "num_eq": 5402,
- "num_range": 28811,
- "upper_bound": "1995-09-24"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1995-04-13"
},
{
"distinct_range": 12,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1995-10-07"
+ "num_range": 28806,
+ "upper_bound": "1995-04-26"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1995-10-18"
+ "distinct_range": 15,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1995-05-12"
},
{
"distinct_range": 12,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1995-10-31"
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1995-05-25"
},
{
- "distinct_range": 12,
- "num_eq": 4802,
- "num_range": 26410,
- "upper_bound": "1995-11-13"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1995-06-06"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1995-11-24"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1995-06-19"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1995-12-04"
+ "distinct_range": 12,
+ "num_eq": 4801,
+ "num_range": 28206,
+ "upper_bound": "1995-07-02"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1995-12-16"
+ "distinct_range": 9,
+ "num_eq": 5401,
+ "num_range": 25205,
+ "upper_bound": "1995-07-12"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1995-12-26"
+ "distinct_range": 14,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1995-07-27"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-01-07"
+ "num_eq": 5401,
+ "num_range": 24605,
+ "upper_bound": "1995-08-08"
},
{
- "distinct_range": 13,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1996-01-21"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 28806,
+ "upper_bound": "1995-08-20"
},
{
"distinct_range": 10,
- "num_eq": 4802,
- "num_range": 27010,
- "upper_bound": "1996-02-01"
+ "num_eq": 6001,
+ "num_range": 24605,
+ "upper_bound": "1995-08-31"
},
{
- "distinct_range": 12,
- "num_eq": 6603,
- "num_range": 26410,
- "upper_bound": "1996-02-14"
- },
- {
- "distinct_range": 8,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1996-02-23"
- },
- {
- "distinct_range": 12,
+ "distinct_range": 10,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1996-03-07"
+ "num_range": 26405,
+ "upper_bound": "1995-09-11"
},
{
- "distinct_range": 13,
- "num_eq": 4202,
- "num_range": 24609,
- "upper_bound": "1996-03-21"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "1995-09-23"
},
{
- "distinct_range": 11,
- "num_eq": 4802,
- "num_range": 28211,
- "upper_bound": "1996-04-02"
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1995-10-07"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1996-04-14"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1995-10-18"
},
{
"distinct_range": 13,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1996-04-28"
+ "num_eq": 4201,
+ "num_range": 28806,
+ "upper_bound": "1995-11-01"
},
{
- "distinct_range": 13,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1996-05-12"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1995-11-13"
},
{
- "distinct_range": 13,
+ "distinct_range": 12,
"num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1996-05-26"
+ "num_range": 28806,
+ "upper_bound": "1995-11-26"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1996-06-06"
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1995-12-09"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1996-06-19"
+ "num_range": 28206,
+ "upper_bound": "1995-12-22"
},
{
- "distinct_range": 12,
+ "distinct_range": 10,
"num_eq": 1200,
- "num_range": 27610,
- "upper_bound": "1996-07-02"
+ "num_range": 28206,
+ "upper_bound": "1996-01-02"
},
{
- "distinct_range": 7,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-07-10"
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 28206,
+ "upper_bound": "1996-01-14"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1996-01-25"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-07-23"
+ "num_range": 25805,
+ "upper_bound": "1996-02-07"
},
{
"distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1996-08-03"
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1996-02-18"
},
{
- "distinct_range": 12,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1996-08-16"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1996-02-28"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1996-08-29"
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1996-03-12"
},
{
"distinct_range": 9,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1996-09-08"
+ "num_eq": 4801,
+ "num_range": 25805,
+ "upper_bound": "1996-03-22"
},
{
"distinct_range": 9,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1996-09-18"
- },
- {
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 27610,
- "upper_bound": "1996-10-01"
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1996-04-01"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-10-13"
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1996-04-13"
},
{
- "distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1996-10-25"
+ "distinct_range": 9,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1996-04-23"
},
{
- "distinct_range": 12,
+ "distinct_range": 10,
"num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1996-11-07"
+ "num_range": 25805,
+ "upper_bound": "1996-05-04"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1996-11-20"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1996-05-18"
},
{
"distinct_range": 11,
"num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1996-12-02"
+ "num_range": 28206,
+ "upper_bound": "1996-05-30"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1996-12-15"
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1996-06-12"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1996-12-27"
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1996-06-24"
},
{
- "distinct_range": 11,
- "num_eq": 4202,
- "num_range": 26410,
- "upper_bound": "1997-01-08"
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 24605,
+ "upper_bound": "1996-07-05"
},
{
- "distinct_range": 10,
- "num_eq": 1200,
- "num_range": 27610,
- "upper_bound": "1997-01-19"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 24605,
+ "upper_bound": "1996-07-19"
},
{
- "distinct_range": 10,
- "num_eq": 5402,
- "num_range": 25810,
- "upper_bound": "1997-01-30"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1996-07-31"
},
{
"distinct_range": 9,
- "num_eq": 3601,
- "num_range": 25210,
- "upper_bound": "1997-02-09"
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1996-08-10"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1997-02-21"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1996-08-24"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1996-09-07"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1997-03-06"
+ "num_range": 27005,
+ "upper_bound": "1996-09-20"
},
{
"distinct_range": 11,
- "num_eq": 1200,
- "num_range": 27010,
- "upper_bound": "1997-03-18"
- },
- {
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1997-03-29"
+ "num_eq": 3601,
+ "num_range": 25205,
+ "upper_bound": "1996-10-02"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 25210,
- "upper_bound": "1997-04-10"
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1996-10-14"
},
{
- "distinct_range": 10,
+ "distinct_range": 9,
"num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1997-04-21"
+ "num_range": 27005,
+ "upper_bound": "1996-10-24"
},
{
"distinct_range": 11,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1997-05-03"
+ "num_range": 25805,
+ "upper_bound": "1996-11-05"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 1200,
+ "num_range": 27606,
+ "upper_bound": "1996-11-20"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1997-05-14"
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1996-12-01"
},
{
- "distinct_range": 14,
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1997-05-29"
+ "num_range": 27005,
+ "upper_bound": "1996-12-13"
},
{
"distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1997-06-10"
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1996-12-25"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 27610,
- "upper_bound": "1997-06-24"
+ "distinct_range": 12,
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1997-01-07"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 26410,
- "upper_bound": "1997-07-06"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1997-01-19"
},
{
"distinct_range": 13,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1997-07-20"
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1997-02-02"
},
{
- "distinct_range": 11,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1997-08-01"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "1997-02-13"
},
{
- "distinct_range": 8,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1997-08-10"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1997-02-24"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 24605,
+ "upper_bound": "1997-03-08"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1997-08-23"
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1997-03-21"
},
{
- "distinct_range": 9,
+ "distinct_range": 10,
"num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1997-09-02"
+ "num_range": 28206,
+ "upper_bound": "1997-04-01"
},
{
"distinct_range": 12,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1997-09-15"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1997-04-14"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1997-04-26"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-05-09"
},
{
"distinct_range": 8,
- "num_eq": 1200,
- "num_range": 27610,
- "upper_bound": "1997-09-24"
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1997-05-18"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1997-05-31"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 25205,
+ "upper_bound": "1997-06-13"
},
{
"distinct_range": 13,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1997-10-08"
+ "num_eq": 3601,
+ "num_range": 25205,
+ "upper_bound": "1997-06-27"
},
{
- "distinct_range": 16,
- "num_eq": 1200,
- "num_range": 27010,
- "upper_bound": "1997-10-25"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1997-07-09"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1997-11-07"
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1997-07-22"
},
{
- "distinct_range": 9,
+ "distinct_range": 8,
+ "num_eq": 3001,
+ "num_range": 25205,
+ "upper_bound": "1997-07-31"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1997-08-11"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 3001,
+ "num_range": 25205,
+ "upper_bound": "1997-08-25"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1997-09-05"
+ },
+ {
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 25210,
- "upper_bound": "1997-11-17"
+ "num_range": 25805,
+ "upper_bound": "1997-09-17"
},
{
"distinct_range": 11,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1997-11-29"
+ "num_eq": 3601,
+ "num_range": 25205,
+ "upper_bound": "1997-09-29"
},
{
- "distinct_range": 12,
- "num_eq": 4802,
- "num_range": 27010,
- "upper_bound": "1997-12-12"
+ "distinct_range": 10,
+ "num_eq": 5401,
+ "num_range": 23405,
+ "upper_bound": "1997-10-10"
+ },
+ {
+ "distinct_range": 15,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1997-10-26"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1997-12-24"
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1997-11-07"
},
{
- "distinct_range": 8,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1998-01-02"
+ "distinct_range": 10,
+ "num_eq": 2400,
+ "num_range": 25805,
+ "upper_bound": "1997-11-18"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1998-01-16"
+ "distinct_range": 14,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-12-03"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1998-01-29"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 25205,
+ "upper_bound": "1997-12-15"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 5401,
+ "num_range": 27606,
+ "upper_bound": "1997-12-27"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 4201,
+ "num_range": 24005,
+ "upper_bound": "1998-01-11"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1998-02-11"
+ "num_range": 26405,
+ "upper_bound": "1998-01-24"
},
{
- "distinct_range": 13,
- "num_eq": 5402,
- "num_range": 25810,
- "upper_bound": "1998-02-25"
+ "distinct_range": 8,
+ "num_eq": 4201,
+ "num_range": 24005,
+ "upper_bound": "1998-02-02"
},
{
- "distinct_range": 13,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1998-03-11"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1998-02-14"
},
{
- "distinct_range": 8,
+ "distinct_range": 14,
"num_eq": 1200,
- "num_range": 27010,
+ "num_range": 26405,
+ "upper_bound": "1998-03-01"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1998-03-10"
+ },
+ {
+ "distinct_range": 9,
+ "num_eq": 3601,
+ "num_range": 26405,
"upper_bound": "1998-03-20"
},
{
- "distinct_range": 10,
- "num_eq": 5402,
- "num_range": 25210,
- "upper_bound": "1998-03-31"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1998-04-02"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 25210,
- "upper_bound": "1998-04-12"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1998-04-14"
},
{
"distinct_range": 11,
- "num_eq": 4802,
- "num_range": 22208,
- "upper_bound": "1998-04-24"
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1998-04-26"
},
{
- "distinct_range": 9,
+ "distinct_range": 12,
"num_eq": 3001,
- "num_range": 25210,
- "upper_bound": "1998-05-04"
+ "num_range": 24605,
+ "upper_bound": "1998-05-09"
},
{
- "distinct_range": 9,
- "num_eq": 1801,
- "num_range": 25210,
- "upper_bound": "1998-05-14"
+ "distinct_range": 8,
+ "num_eq": 3601,
+ "num_range": 24005,
+ "upper_bound": "1998-05-18"
},
{
"distinct_range": 8,
- "num_eq": 3001,
- "num_range": 24009,
- "upper_bound": "1998-05-23"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1998-05-27"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1998-06-03"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1998-06-06"
},
{
- "distinct_range": 9,
- "num_eq": 1200,
- "num_range": 25810,
- "upper_bound": "1998-06-13"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 25205,
+ "upper_bound": "1998-06-18"
},
{
"distinct_range": 10,
- "num_eq": 1200,
- "num_range": 26410,
- "upper_bound": "1998-06-24"
+ "num_eq": 1800,
+ "num_range": 25805,
+ "upper_bound": "1998-06-29"
},
{
"distinct_range": 10,
- "num_eq": 4802,
- "num_range": 24009,
- "upper_bound": "1998-07-05"
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1998-07-10"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1998-07-15"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 24605,
+ "upper_bound": "1998-07-22"
},
{
- "distinct_range": 14,
- "num_eq": 3601,
- "num_range": 24609,
- "upper_bound": "1998-07-30"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 24605,
+ "upper_bound": "1998-08-01"
},
{
"distinct_range": 8,
- "num_eq": 4202,
- "num_range": 22208,
- "upper_bound": "1998-08-08"
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1998-08-10"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 25210,
- "upper_bound": "1998-08-20"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 25805,
+ "upper_bound": "1998-08-21"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1998-09-03"
+ "distinct_range": 14,
+ "num_eq": 3001,
+ "num_range": 24605,
+ "upper_bound": "1998-09-05"
},
{
- "distinct_range": 16,
- "num_eq": 2401,
- "num_range": 24009,
- "upper_bound": "1998-09-20"
+ "distinct_range": 15,
+ "num_eq": 3601,
+ "num_range": 22805,
+ "upper_bound": "1998-09-21"
},
{
- "distinct_range": 21,
- "num_eq": 1200,
- "num_range": 25810,
- "upper_bound": "1998-10-12"
+ "distinct_range": 22,
+ "num_eq": 1800,
+ "num_range": 25205,
+ "upper_bound": "1998-10-14"
},
{
- "distinct_range": 39,
- "num_eq": 1200,
- "num_range": 24609,
- "upper_bound": "1998-11-21"
+ "distinct_range": 41,
+ "num_eq": 600,
+ "num_range": 25205,
+ "upper_bound": "1998-11-25"
},
{
- "distinct_range": 7.5,
+ "distinct_range": 4,
"num_eq": 0,
- "num_range": 7,
+ "num_range": 4,
"upper_bound": "infinity"
}
],
@@ -6475,13 +6501,14 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 4,
"columns": [
"l_commitdate"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 2466,
"histo_buckets": [
{
@@ -6491,1209 +6518,1209 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"upper_bound": "-infinity"
},
{
- "distinct_range": 1,
- "num_eq": 600,
- "num_range": 1,
- "upper_bound": "1992-01-31"
+ "distinct_range": 7,
+ "num_eq": 1800,
+ "num_range": 7,
+ "upper_bound": "1992-02-11"
},
{
- "distinct_range": 39,
+ "distinct_range": 31,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1992-03-11"
- },
- {
- "distinct_range": 14,
- "num_eq": 4802,
- "num_range": 28211,
- "upper_bound": "1992-03-26"
+ "num_range": 28806,
+ "upper_bound": "1992-03-14"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1992-04-08"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1992-03-27"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1992-04-19"
+ "distinct_range": 14,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1992-04-11"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1992-05-02"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1992-04-23"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1992-05-13"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1992-05-03"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1992-05-25"
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "1992-05-15"
},
{
"distinct_range": 13,
"num_eq": 3601,
- "num_range": 29411,
- "upper_bound": "1992-06-08"
+ "num_range": 28806,
+ "upper_bound": "1992-05-29"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1992-06-18"
- },
- {
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1992-06-28"
+ "distinct_range": 14,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-06-13"
},
{
- "distinct_range": 14,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1992-07-13"
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1992-06-25"
},
{
- "distinct_range": 15,
+ "distinct_range": 10,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1992-07-29"
+ "num_range": 27606,
+ "upper_bound": "1992-07-06"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1992-08-08"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-07-18"
},
{
- "distinct_range": 15,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1992-08-24"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-07-29"
},
{
"distinct_range": 14,
- "num_eq": 5402,
- "num_range": 25810,
- "upper_bound": "1992-09-08"
+ "num_eq": 3601,
+ "num_range": 28806,
+ "upper_bound": "1992-08-13"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1992-09-20"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1992-08-27"
},
{
- "distinct_range": 15,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1992-10-06"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1992-09-07"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1992-10-20"
+ "distinct_range": 9,
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1992-09-17"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1992-11-01"
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1992-09-29"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1992-11-13"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-10-12"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1992-11-25"
+ "num_eq": 4201,
+ "num_range": 28806,
+ "upper_bound": "1992-10-24"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1992-12-07"
+ "num_eq": 1200,
+ "num_range": 29406,
+ "upper_bound": "1992-11-05"
},
{
"distinct_range": 9,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1992-12-17"
- },
- {
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1992-12-28"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1992-11-15"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1993-01-10"
+ "distinct_range": 15,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1992-12-01"
},
{
"distinct_range": 13,
- "num_eq": 2401,
- "num_range": 29411,
- "upper_bound": "1993-01-24"
- },
- {
- "distinct_range": 14,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1993-02-08"
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-12-15"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1993-02-20"
+ "num_eq": 5401,
+ "num_range": 27606,
+ "upper_bound": "1992-12-27"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 29411,
- "upper_bound": "1993-03-02"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1993-01-09"
},
{
- "distinct_range": 14,
- "num_eq": 4802,
- "num_range": 29411,
- "upper_bound": "1993-03-17"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1993-01-23"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1993-03-31"
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1993-02-04"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1993-04-12"
+ "num_eq": 600,
+ "num_range": 29406,
+ "upper_bound": "1993-02-16"
},
{
- "distinct_range": 15,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1993-04-28"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1993-03-01"
},
{
"distinct_range": 10,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1993-05-09"
+ "num_eq": 4201,
+ "num_range": 28806,
+ "upper_bound": "1993-03-12"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1993-05-22"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1993-03-24"
+ },
+ {
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1993-04-03"
},
{
"distinct_range": 10,
"num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1993-06-02"
+ "num_range": 25805,
+ "upper_bound": "1993-04-14"
},
{
- "distinct_range": 14,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1993-06-17"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1993-04-26"
},
{
- "distinct_range": 10,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1993-06-28"
+ "distinct_range": 9,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1993-05-06"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1993-07-10"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "1993-05-19"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1993-07-23"
+ "num_range": 28206,
+ "upper_bound": "1993-06-01"
},
{
"distinct_range": 9,
- "num_eq": 5402,
- "num_range": 27611,
- "upper_bound": "1993-08-02"
- },
- {
- "distinct_range": 14,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1993-08-17"
- },
- {
- "distinct_range": 8,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1993-08-26"
- },
- {
- "distinct_range": 12,
- "num_eq": 5402,
- "num_range": 25210,
- "upper_bound": "1993-09-08"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1993-06-11"
},
{
"distinct_range": 15,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1993-09-24"
- },
- {
- "distinct_range": 9,
- "num_eq": 5402,
- "num_range": 24009,
- "upper_bound": "1993-10-04"
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1993-06-27"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1993-10-16"
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1993-07-09"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1993-10-26"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1993-07-22"
},
{
"distinct_range": 9,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1993-11-05"
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1993-08-01"
},
{
"distinct_range": 9,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1993-11-15"
- },
- {
- "distinct_range": 14,
- "num_eq": 3601,
- "num_range": 28211,
- "upper_bound": "1993-11-30"
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1993-08-11"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1993-12-12"
- },
- {
- "distinct_range": 12,
"num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1993-12-25"
- },
- {
- "distinct_range": 8,
- "num_eq": 4802,
- "num_range": 25810,
- "upper_bound": "1994-01-03"
+ "num_range": 25805,
+ "upper_bound": "1993-08-23"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-01-15"
- },
- {
- "distinct_range": 9,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-01-25"
+ "num_eq": 4801,
+ "num_range": 28206,
+ "upper_bound": "1993-09-04"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1994-02-06"
+ "distinct_range": 13,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1993-09-18"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1994-02-19"
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1993-10-01"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1994-03-04"
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1993-10-14"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1994-03-15"
- },
- {
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1994-03-27"
- },
- {
- "distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1994-04-08"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1993-10-25"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1994-04-21"
- },
- {
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1994-05-03"
- },
- {
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1994-05-13"
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1993-11-07"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1994-05-25"
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1993-11-19"
},
{
"distinct_range": 11,
- "num_eq": 4802,
- "num_range": 27010,
- "upper_bound": "1994-06-06"
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1993-12-01"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1994-06-17"
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1993-12-12"
},
{
- "distinct_range": 14,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1994-07-02"
+ "distinct_range": 9,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1993-12-22"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-07-15"
+ "distinct_range": 13,
+ "num_eq": 4801,
+ "num_range": 28206,
+ "upper_bound": "1994-01-05"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1994-07-25"
+ "distinct_range": 15,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-01-21"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-08-06"
+ "num_eq": 4801,
+ "num_range": 27606,
+ "upper_bound": "1994-02-02"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1994-08-19"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-02-14"
},
{
"distinct_range": 12,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1994-09-01"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-02-27"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 27611,
- "upper_bound": "1994-09-13"
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1994-03-11"
},
{
- "distinct_range": 16,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1994-09-30"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1994-03-23"
},
{
- "distinct_range": 9,
+ "distinct_range": 12,
"num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1994-10-10"
+ "num_range": 27005,
+ "upper_bound": "1994-04-05"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1994-10-21"
- },
- {
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-11-02"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-04-16"
},
{
"distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1994-11-12"
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1994-04-26"
},
{
- "distinct_range": 8,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1994-11-21"
+ "distinct_range": 16,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1994-05-13"
},
{
"distinct_range": 8,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1994-11-30"
+ "num_eq": 4201,
+ "num_range": 25805,
+ "upper_bound": "1994-05-22"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1994-12-12"
+ "distinct_range": 9,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-06-01"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1994-12-23"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 27606,
+ "upper_bound": "1994-06-15"
},
{
- "distinct_range": 12,
- "num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1995-01-05"
+ "distinct_range": 14,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1994-06-30"
},
{
- "distinct_range": 8,
+ "distinct_range": 10,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1995-01-14"
+ "num_range": 28806,
+ "upper_bound": "1994-07-11"
},
{
"distinct_range": 10,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1995-01-25"
+ "num_range": 26405,
+ "upper_bound": "1994-07-22"
},
{
- "distinct_range": 11,
+ "distinct_range": 6,
"num_eq": 3601,
- "num_range": 28211,
- "upper_bound": "1995-02-06"
- },
- {
- "distinct_range": 15,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1995-02-22"
+ "num_range": 28206,
+ "upper_bound": "1994-07-29"
},
{
"distinct_range": 12,
- "num_eq": 4202,
- "num_range": 27611,
- "upper_bound": "1995-03-07"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1994-08-11"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-03-18"
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1994-08-22"
},
{
- "distinct_range": 10,
+ "distinct_range": 9,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1995-03-29"
+ "num_range": 27005,
+ "upper_bound": "1994-09-01"
},
{
- "distinct_range": 10,
+ "distinct_range": 11,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1995-04-09"
+ "num_range": 28806,
+ "upper_bound": "1994-09-13"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1994-09-27"
},
{
"distinct_range": 10,
"num_eq": 3601,
- "num_range": 27611,
- "upper_bound": "1995-04-20"
+ "num_range": 25805,
+ "upper_bound": "1994-10-08"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1995-05-04"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-10-20"
},
{
- "distinct_range": 9,
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1995-05-14"
+ "num_range": 28206,
+ "upper_bound": "1994-11-01"
},
{
- "distinct_range": 12,
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1995-05-27"
+ "num_range": 27606,
+ "upper_bound": "1994-11-13"
},
{
- "distinct_range": 10,
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "1994-11-27"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1994-12-11"
+ },
+ {
+ "distinct_range": 13,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1995-06-07"
+ "num_range": 27606,
+ "upper_bound": "1994-12-25"
},
{
- "distinct_range": 9,
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1995-06-17"
+ "num_range": 27005,
+ "upper_bound": "1995-01-06"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "1995-01-19"
},
{
"distinct_range": 10,
- "num_eq": 4802,
- "num_range": 25210,
- "upper_bound": "1995-06-28"
+ "num_eq": 4201,
+ "num_range": 28806,
+ "upper_bound": "1995-01-30"
},
{
- "distinct_range": 12,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "1995-07-11"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1995-02-13"
},
{
- "distinct_range": 14,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1995-07-26"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1995-02-25"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-08-06"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1995-03-08"
},
{
- "distinct_range": 9,
+ "distinct_range": 12,
"num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1995-08-16"
+ "num_range": 27005,
+ "upper_bound": "1995-03-21"
},
{
- "distinct_range": 15,
- "num_eq": 4202,
- "num_range": 26410,
- "upper_bound": "1995-09-01"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 27606,
+ "upper_bound": "1995-04-02"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-09-14"
+ "num_eq": 6001,
+ "num_range": 27005,
+ "upper_bound": "1995-04-15"
},
{
- "distinct_range": 10,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1995-09-25"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1995-04-28"
},
{
- "distinct_range": 11,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1995-10-07"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 27606,
+ "upper_bound": "1995-05-12"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1995-10-19"
+ "distinct_range": 13,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1995-05-26"
},
{
- "distinct_range": 8,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1995-10-28"
+ "distinct_range": 10,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1995-06-06"
},
{
"distinct_range": 9,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1995-11-07"
+ "num_range": 26405,
+ "upper_bound": "1995-06-16"
},
{
- "distinct_range": 8,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1995-11-16"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1995-06-27"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1995-11-29"
+ "num_range": 28806,
+ "upper_bound": "1995-07-10"
},
{
"distinct_range": 10,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1995-12-10"
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1995-07-21"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1995-08-01"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1995-12-22"
+ "num_eq": 4201,
+ "num_range": 25205,
+ "upper_bound": "1995-08-13"
},
{
"distinct_range": 13,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1996-01-05"
+ "num_range": 27005,
+ "upper_bound": "1995-08-27"
},
{
"distinct_range": 11,
- "num_eq": 4802,
- "num_range": 25810,
- "upper_bound": "1996-01-17"
+ "num_eq": 5401,
+ "num_range": 28806,
+ "upper_bound": "1995-09-08"
},
{
- "distinct_range": 12,
- "num_eq": 4802,
- "num_range": 28211,
- "upper_bound": "1996-01-30"
+ "distinct_range": 13,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1995-09-22"
},
{
- "distinct_range": 13,
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1995-10-04"
+ },
+ {
+ "distinct_range": 11,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1996-02-13"
+ "num_range": 28206,
+ "upper_bound": "1995-10-16"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1996-02-27"
+ "distinct_range": 14,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1995-10-31"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1995-11-11"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1995-11-23"
},
{
"distinct_range": 11,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1996-03-10"
+ "num_range": 25805,
+ "upper_bound": "1995-12-05"
},
{
- "distinct_range": 9,
- "num_eq": 5402,
- "num_range": 24609,
- "upper_bound": "1996-03-20"
+ "distinct_range": 11,
+ "num_eq": 6001,
+ "num_range": 24005,
+ "upper_bound": "1995-12-17"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1996-04-03"
+ "distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 27005,
+ "upper_bound": "1995-12-29"
},
{
"distinct_range": 11,
"num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1996-04-15"
+ "num_range": 27005,
+ "upper_bound": "1996-01-10"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1996-04-27"
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "1996-01-22"
},
{
- "distinct_range": 12,
- "num_eq": 4802,
- "num_range": 25210,
- "upper_bound": "1996-05-10"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1996-02-01"
},
{
- "distinct_range": 12,
+ "distinct_range": 13,
"num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1996-05-23"
+ "num_range": 27005,
+ "upper_bound": "1996-02-15"
},
{
- "distinct_range": 10,
- "num_eq": 4202,
- "num_range": 27611,
- "upper_bound": "1996-06-03"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1996-02-27"
},
{
"distinct_range": 9,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1996-06-13"
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1996-03-08"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1996-06-25"
- },
- {
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1996-07-09"
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1996-03-20"
},
{
- "distinct_range": 10,
+ "distinct_range": 9,
"num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1996-07-20"
- },
- {
- "distinct_range": 13,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1996-08-03"
+ "num_range": 27005,
+ "upper_bound": "1996-03-30"
},
{
"distinct_range": 10,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-08-14"
+ "num_range": 26405,
+ "upper_bound": "1996-04-10"
},
{
- "distinct_range": 11,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1996-08-26"
+ "distinct_range": 9,
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1996-04-20"
},
{
"distinct_range": 12,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1996-09-08"
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1996-05-03"
},
{
- "distinct_range": 9,
- "num_eq": 4802,
- "num_range": 25810,
- "upper_bound": "1996-09-18"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 27606,
+ "upper_bound": "1996-05-16"
},
{
"distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1996-09-30"
+ "num_eq": 5401,
+ "num_range": 27606,
+ "upper_bound": "1996-05-28"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1996-10-11"
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1996-06-08"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1996-10-23"
- },
- {
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1996-11-05"
- },
- {
- "distinct_range": 13,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1996-11-19"
+ "num_range": 28206,
+ "upper_bound": "1996-06-20"
},
{
"distinct_range": 14,
- "num_eq": 4202,
- "num_range": 28811,
- "upper_bound": "1996-12-04"
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1996-07-05"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1996-07-17"
+ },
+ {
+ "distinct_range": 9,
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1996-07-27"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1996-08-08"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1996-12-15"
+ "num_eq": 3601,
+ "num_range": 27606,
+ "upper_bound": "1996-08-19"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1996-12-29"
+ "distinct_range": 15,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1996-09-04"
},
{
- "distinct_range": 8,
- "num_eq": 3001,
- "num_range": 27611,
- "upper_bound": "1997-01-07"
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 24605,
+ "upper_bound": "1996-09-15"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1997-01-18"
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1996-09-26"
},
{
- "distinct_range": 9,
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1996-10-07"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "1996-10-21"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1996-11-05"
+ },
+ {
+ "distinct_range": 12,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1997-01-28"
+ "num_range": 25205,
+ "upper_bound": "1996-11-18"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1996-11-29"
},
{
"distinct_range": 12,
"num_eq": 3601,
- "num_range": 28211,
+ "num_range": 26405,
+ "upper_bound": "1996-12-12"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1996-12-25"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1997-01-06"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 27606,
+ "upper_bound": "1997-01-17"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-01-30"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 6601,
+ "num_range": 22805,
"upper_bound": "1997-02-10"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1997-02-24"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1997-02-21"
},
{
"distinct_range": 13,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1997-03-10"
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1997-03-07"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 25810,
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 25805,
"upper_bound": "1997-03-20"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 26410,
+ "num_eq": 7201,
+ "num_range": 27606,
"upper_bound": "1997-03-31"
},
{
"distinct_range": 12,
- "num_eq": 1200,
- "num_range": 27611,
+ "num_eq": 3601,
+ "num_range": 27606,
"upper_bound": "1997-04-13"
},
{
- "distinct_range": 13,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1997-04-27"
+ "distinct_range": 9,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1997-04-23"
},
{
"distinct_range": 10,
+ "num_eq": 5401,
+ "num_range": 27005,
+ "upper_bound": "1997-05-04"
+ },
+ {
+ "distinct_range": 13,
"num_eq": 3601,
- "num_range": 25210,
- "upper_bound": "1997-05-08"
+ "num_range": 27606,
+ "upper_bound": "1997-05-18"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1997-05-21"
- },
- {
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1997-06-02"
+ "num_range": 27005,
+ "upper_bound": "1997-05-31"
},
{
"distinct_range": 10,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1997-06-13"
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1997-06-11"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1997-06-23"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 27005,
+ "upper_bound": "1997-06-24"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 26405,
"upper_bound": "1997-07-05"
},
- {
- "distinct_range": 9,
- "num_eq": 4802,
- "num_range": 24009,
- "upper_bound": "1997-07-15"
- },
{
"distinct_range": 14,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1997-07-30"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-07-20"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1997-08-12"
+ "num_eq": 4801,
+ "num_range": 27606,
+ "upper_bound": "1997-08-02"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27611,
- "upper_bound": "1997-08-25"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1997-08-13"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1997-09-08"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1997-08-24"
},
{
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1997-09-20"
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 25205,
+ "upper_bound": "1997-09-04"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1997-10-03"
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1997-09-17"
},
{
- "distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27611,
- "upper_bound": "1997-10-15"
+ "distinct_range": 14,
+ "num_eq": 2400,
+ "num_range": 27606,
+ "upper_bound": "1997-10-02"
+ },
+ {
+ "distinct_range": 15,
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1997-10-18"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1997-10-28"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-10-31"
},
{
- "distinct_range": 10,
- "num_eq": 1200,
- "num_range": 27611,
- "upper_bound": "1997-11-08"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 24605,
+ "upper_bound": "1997-11-12"
},
{
"distinct_range": 10,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1997-11-19"
+ "num_eq": 2400,
+ "num_range": 25805,
+ "upper_bound": "1997-11-23"
},
{
- "distinct_range": 14,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1997-12-04"
+ "distinct_range": 15,
+ "num_eq": 3001,
+ "num_range": 27606,
+ "upper_bound": "1997-12-09"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1997-12-14"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-12-22"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1997-12-28"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 25805,
+ "upper_bound": "1998-01-04"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1998-01-10"
+ "num_eq": 4201,
+ "num_range": 25805,
+ "upper_bound": "1998-01-17"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1998-01-22"
- },
- {
- "distinct_range": 10,
"num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1998-02-02"
+ "num_range": 27005,
+ "upper_bound": "1998-01-29"
},
{
"distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1998-02-14"
+ "num_eq": 4201,
+ "num_range": 23405,
+ "upper_bound": "1998-02-10"
},
{
"distinct_range": 10,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1998-02-25"
+ "num_eq": 5401,
+ "num_range": 25205,
+ "upper_bound": "1998-02-21"
},
{
- "distinct_range": 16,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1998-03-14"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1998-03-06"
},
{
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 25210,
- "upper_bound": "1998-03-26"
+ "distinct_range": 9,
+ "num_eq": 5401,
+ "num_range": 27005,
+ "upper_bound": "1998-03-16"
+ },
+ {
+ "distinct_range": 7,
+ "num_eq": 4801,
+ "num_range": 22204,
+ "upper_bound": "1998-03-24"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 25810,
- "upper_bound": "1998-04-06"
+ "num_eq": 2400,
+ "num_range": 25205,
+ "upper_bound": "1998-04-04"
},
{
"distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 24005,
+ "upper_bound": "1998-04-16"
+ },
+ {
+ "distinct_range": 8,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1998-04-18"
+ "num_range": 25205,
+ "upper_bound": "1998-04-25"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1998-05-01"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1998-05-07"
},
{
"distinct_range": 9,
- "num_eq": 1801,
- "num_range": 27611,
- "upper_bound": "1998-05-11"
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1998-05-17"
},
{
"distinct_range": 11,
- "num_eq": 3601,
- "num_range": 24609,
- "upper_bound": "1998-05-23"
+ "num_eq": 2400,
+ "num_range": 25805,
+ "upper_bound": "1998-05-29"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1998-06-03"
+ "num_eq": 4201,
+ "num_range": 24605,
+ "upper_bound": "1998-06-09"
},
{
- "distinct_range": 7,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1998-06-11"
+ "distinct_range": 6,
+ "num_eq": 5401,
+ "num_range": 21604,
+ "upper_bound": "1998-06-16"
},
{
"distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1998-06-22"
+ "num_eq": 3601,
+ "num_range": 25205,
+ "upper_bound": "1998-06-27"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 25210,
- "upper_bound": "1998-07-04"
+ "distinct_range": 9,
+ "num_eq": 1800,
+ "num_range": 25805,
+ "upper_bound": "1998-07-07"
},
{
- "distinct_range": 7,
- "num_eq": 5402,
- "num_range": 26410,
- "upper_bound": "1998-07-12"
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 22805,
+ "upper_bound": "1998-07-20"
},
{
- "distinct_range": 11,
- "num_eq": 5402,
- "num_range": 24609,
- "upper_bound": "1998-07-24"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 24005,
+ "upper_bound": "1998-07-30"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 26410,
- "upper_bound": "1998-08-07"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 24005,
+ "upper_bound": "1998-08-10"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 25810,
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 25205,
"upper_bound": "1998-08-20"
},
{
- "distinct_range": 14,
- "num_eq": 2401,
- "num_range": 23409,
- "upper_bound": "1998-09-04"
+ "distinct_range": 9,
+ "num_eq": 1200,
+ "num_range": 25205,
+ "upper_bound": "1998-08-30"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 24009,
- "upper_bound": "1998-09-15"
+ "distinct_range": 9,
+ "num_eq": 1200,
+ "num_range": 25205,
+ "upper_bound": "1998-09-09"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1998-09-26"
+ "distinct_range": 18,
+ "num_eq": 3601,
+ "num_range": 25205,
+ "upper_bound": "1998-09-28"
},
{
- "distinct_range": 32,
+ "distinct_range": 29,
"num_eq": 600,
- "num_range": 23409,
- "upper_bound": "1998-10-29"
+ "num_range": 24605,
+ "upper_bound": "1998-10-28"
},
{
- "distinct_range": 1,
+ "distinct_range": 7,
"num_eq": 0,
- "num_range": 1,
+ "num_range": 7,
"upper_bound": "infinity"
}
],
@@ -7701,14 +7728,15 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 4,
"columns": [
"l_receiptdate"
],
- "created_at": "2021-09-08 20:49:14.314079",
- "distinct_count": 2553,
+ "created_at": "2022-02-25 00:55:34.245977",
+ "distinct_count": 2554,
"histo_buckets": [
{
"distinct_range": 0,
@@ -7717,1209 +7745,1209 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"upper_bound": "-infinity"
},
{
- "distinct_range": 8,
+ "distinct_range": 14,
"num_eq": 600,
- "num_range": 8,
- "upper_bound": "1992-01-11"
+ "num_range": 14,
+ "upper_bound": "1992-01-19"
},
{
"distinct_range": 56,
"num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1992-03-08"
+ "num_range": 29406,
+ "upper_bound": "1992-03-16"
},
{
- "distinct_range": 20,
+ "distinct_range": 18,
"num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1992-03-29"
- },
- {
- "distinct_range": 20,
- "num_eq": 4802,
- "num_range": 28811,
- "upper_bound": "1992-04-19"
- },
- {
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1992-05-03"
- },
- {
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1992-05-15"
- },
- {
- "distinct_range": 11,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1992-05-27"
+ "num_range": 27605,
+ "upper_bound": "1992-04-04"
},
{
"distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1992-06-10"
+ "num_eq": 3001,
+ "num_range": 29406,
+ "upper_bound": "1992-04-18"
},
{
- "distinct_range": 11,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1992-06-22"
+ "distinct_range": 15,
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1992-05-04"
},
{
- "distinct_range": 13,
+ "distinct_range": 17,
"num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1992-07-06"
+ "num_range": 28806,
+ "upper_bound": "1992-05-22"
},
{
- "distinct_range": 13,
- "num_eq": 4202,
- "num_range": 27610,
- "upper_bound": "1992-07-20"
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1992-06-04"
},
{
- "distinct_range": 11,
- "num_eq": 4202,
- "num_range": 28811,
- "upper_bound": "1992-08-01"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 29406,
+ "upper_bound": "1992-06-15"
},
{
- "distinct_range": 12,
- "num_eq": 5402,
- "num_range": 25210,
- "upper_bound": "1992-08-14"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 29406,
+ "upper_bound": "1992-06-27"
},
{
"distinct_range": 12,
- "num_eq": 1801,
- "num_range": 29411,
- "upper_bound": "1992-08-27"
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1992-07-10"
},
{
"distinct_range": 12,
- "num_eq": 4802,
- "num_range": 25810,
- "upper_bound": "1992-09-09"
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1992-07-23"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1992-09-22"
+ "num_range": 28206,
+ "upper_bound": "1992-08-05"
},
{
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 29411,
- "upper_bound": "1992-10-05"
+ "distinct_range": 14,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1992-08-20"
},
{
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1992-10-18"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1992-09-01"
},
{
"distinct_range": 9,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1992-10-28"
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1992-09-11"
},
{
"distinct_range": 13,
- "num_eq": 600,
- "num_range": 29411,
- "upper_bound": "1992-11-11"
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1992-09-25"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1992-11-25"
+ "distinct_range": 14,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1992-10-10"
},
{
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1992-12-07"
+ "distinct_range": 9,
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1992-10-20"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1992-12-21"
+ "distinct_range": 10,
+ "num_eq": 2400,
+ "num_range": 27605,
+ "upper_bound": "1992-10-31"
},
{
- "distinct_range": 12,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1993-01-03"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1992-11-12"
},
{
- "distinct_range": 13,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1993-01-17"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1992-11-25"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1993-01-31"
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 25805,
+ "upper_bound": "1992-12-08"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 28211,
- "upper_bound": "1993-02-11"
+ "distinct_range": 16,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1992-12-25"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1993-02-24"
+ "distinct_range": 8,
+ "num_eq": 6001,
+ "num_range": 25205,
+ "upper_bound": "1993-01-03"
},
{
- "distinct_range": 12,
- "num_eq": 5402,
- "num_range": 28811,
- "upper_bound": "1993-03-09"
+ "distinct_range": 8,
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1993-01-12"
},
{
"distinct_range": 14,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1993-03-24"
+ "num_eq": 2400,
+ "num_range": 29406,
+ "upper_bound": "1993-01-27"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1993-04-05"
+ "num_eq": 4801,
+ "num_range": 25205,
+ "upper_bound": "1993-02-08"
},
{
- "distinct_range": 9,
- "num_eq": 5402,
- "num_range": 27610,
- "upper_bound": "1993-04-15"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1993-02-21"
},
{
- "distinct_range": 13,
- "num_eq": 4802,
- "num_range": 27610,
- "upper_bound": "1993-04-29"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 25805,
+ "upper_bound": "1993-03-05"
},
{
- "distinct_range": 15,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1993-05-15"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1993-03-18"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1993-05-28"
+ "distinct_range": 9,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1993-03-28"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1993-06-08"
+ "distinct_range": 11,
+ "num_eq": 5401,
+ "num_range": 24605,
+ "upper_bound": "1993-04-09"
+ },
+ {
+ "distinct_range": 7,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1993-04-17"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1993-06-21"
+ "num_eq": 3001,
+ "num_range": 29406,
+ "upper_bound": "1993-04-30"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1993-07-02"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1993-05-11"
},
{
- "distinct_range": 13,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1993-07-16"
+ "distinct_range": 14,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1993-05-26"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1993-07-28"
+ "num_eq": 3001,
+ "num_range": 27605,
+ "upper_bound": "1993-06-07"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1993-08-10"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1993-06-18"
},
{
"distinct_range": 9,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1993-08-20"
+ "num_eq": 5401,
+ "num_range": 27605,
+ "upper_bound": "1993-06-28"
},
{
- "distinct_range": 12,
+ "distinct_range": 13,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1993-09-02"
- },
- {
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27010,
- "upper_bound": "1993-09-13"
+ "num_range": 28806,
+ "upper_bound": "1993-07-12"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1993-09-24"
+ "distinct_range": 14,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1993-07-27"
},
{
"distinct_range": 14,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1993-10-09"
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1993-08-11"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1993-10-21"
+ "num_eq": 4201,
+ "num_range": 25805,
+ "upper_bound": "1993-08-23"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1993-11-03"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1993-09-04"
},
{
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1993-11-14"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1993-09-16"
},
{
- "distinct_range": 13,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1993-11-28"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1993-09-28"
},
{
"distinct_range": 10,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1993-12-09"
+ "num_eq": 1200,
+ "num_range": 28206,
+ "upper_bound": "1993-10-09"
},
{
- "distinct_range": 13,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1993-12-23"
+ "distinct_range": 10,
+ "num_eq": 3601,
+ "num_range": 28806,
+ "upper_bound": "1993-10-20"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1994-01-03"
+ "distinct_range": 9,
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1993-10-30"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1994-01-16"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1993-11-11"
},
{
- "distinct_range": 8,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1994-01-25"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1993-11-24"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1994-02-04"
+ "distinct_range": 11,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1993-12-06"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1994-02-15"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1993-12-19"
},
{
- "distinct_range": 15,
+ "distinct_range": 12,
"num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1994-03-03"
+ "num_range": 27005,
+ "upper_bound": "1994-01-01"
},
{
"distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1994-03-15"
+ "num_eq": 4201,
+ "num_range": 25205,
+ "upper_bound": "1994-01-13"
},
{
"distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1994-03-27"
+ "num_eq": 4201,
+ "num_range": 25805,
+ "upper_bound": "1994-01-25"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1994-04-08"
+ "num_eq": 4801,
+ "num_range": 26405,
+ "upper_bound": "1994-02-06"
},
{
- "distinct_range": 9,
- "num_eq": 4202,
- "num_range": 27610,
- "upper_bound": "1994-04-18"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1994-02-18"
},
{
- "distinct_range": 9,
- "num_eq": 4202,
- "num_range": 28211,
- "upper_bound": "1994-04-28"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1994-03-02"
},
{
- "distinct_range": 13,
- "num_eq": 4802,
- "num_range": 28811,
- "upper_bound": "1994-05-12"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1994-03-15"
},
{
- "distinct_range": 11,
+ "distinct_range": 12,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1994-05-24"
+ "num_range": 26405,
+ "upper_bound": "1994-03-28"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-06-05"
+ "distinct_range": 14,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1994-04-12"
},
{
- "distinct_range": 12,
+ "distinct_range": 10,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1994-06-18"
+ "num_range": 27605,
+ "upper_bound": "1994-04-23"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-06-30"
+ "distinct_range": 14,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1994-05-08"
},
{
- "distinct_range": 14,
- "num_eq": 4202,
- "num_range": 26410,
- "upper_bound": "1994-07-15"
+ "distinct_range": 9,
+ "num_eq": 4801,
+ "num_range": 27605,
+ "upper_bound": "1994-05-18"
},
{
"distinct_range": 11,
"num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1994-07-27"
+ "num_range": 28806,
+ "upper_bound": "1994-05-30"
},
{
"distinct_range": 11,
- "num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1994-08-08"
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1994-06-11"
},
{
- "distinct_range": 11,
- "num_eq": 4802,
- "num_range": 28211,
- "upper_bound": "1994-08-20"
+ "distinct_range": 8,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-06-20"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 28811,
- "upper_bound": "1994-09-02"
+ "distinct_range": 9,
+ "num_eq": 600,
+ "num_range": 28806,
+ "upper_bound": "1994-06-30"
+ },
+ {
+ "distinct_range": 9,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1994-07-10"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1994-09-15"
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "1994-07-23"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1994-09-26"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1994-08-05"
},
{
"distinct_range": 9,
- "num_eq": 6002,
- "num_range": 24009,
- "upper_bound": "1994-10-06"
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1994-08-15"
},
{
- "distinct_range": 9,
- "num_eq": 4802,
- "num_range": 26410,
- "upper_bound": "1994-10-16"
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1994-08-29"
},
{
- "distinct_range": 12,
- "num_eq": 5402,
- "num_range": 28811,
- "upper_bound": "1994-10-29"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1994-09-09"
},
{
"distinct_range": 11,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1994-11-10"
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1994-09-21"
},
{
- "distinct_range": 12,
- "num_eq": 6002,
- "num_range": 28211,
- "upper_bound": "1994-11-23"
+ "distinct_range": 8,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1994-09-30"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1994-12-05"
+ "num_eq": 4801,
+ "num_range": 28806,
+ "upper_bound": "1994-10-12"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1994-12-17"
+ "distinct_range": 9,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1994-10-22"
},
{
"distinct_range": 9,
"num_eq": 1200,
- "num_range": 28811,
- "upper_bound": "1994-12-27"
+ "num_range": 28206,
+ "upper_bound": "1994-11-01"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1995-01-08"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 27605,
+ "upper_bound": "1994-11-12"
},
{
- "distinct_range": 11,
- "num_eq": 4202,
- "num_range": 26410,
- "upper_bound": "1995-01-20"
+ "distinct_range": 14,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1994-11-27"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1995-02-01"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 27605,
+ "upper_bound": "1994-12-11"
},
{
- "distinct_range": 12,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "1995-02-14"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1994-12-22"
},
{
"distinct_range": 10,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1995-02-25"
+ "num_eq": 4801,
+ "num_range": 24605,
+ "upper_bound": "1995-01-02"
},
{
"distinct_range": 14,
- "num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1995-03-12"
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1995-01-17"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1995-03-24"
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1995-01-30"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1995-04-07"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 27605,
+ "upper_bound": "1995-02-12"
},
{
"distinct_range": 10,
- "num_eq": 5402,
- "num_range": 28811,
- "upper_bound": "1995-04-18"
+ "num_eq": 1800,
+ "num_range": 27605,
+ "upper_bound": "1995-02-23"
},
{
- "distinct_range": 8,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1995-04-27"
+ "distinct_range": 10,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1995-03-06"
},
{
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1995-05-09"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 28806,
+ "upper_bound": "1995-03-19"
},
{
- "distinct_range": 11,
- "num_eq": 3001,
- "num_range": 28811,
- "upper_bound": "1995-05-21"
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 27605,
+ "upper_bound": "1995-04-02"
},
{
- "distinct_range": 11,
+ "distinct_range": 13,
"num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1995-06-02"
+ "num_range": 28806,
+ "upper_bound": "1995-04-16"
},
{
- "distinct_range": 13,
- "num_eq": 600,
- "num_range": 28811,
- "upper_bound": "1995-06-16"
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1995-04-29"
},
{
- "distinct_range": 14,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1995-07-01"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1995-05-12"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 28811,
- "upper_bound": "1995-07-12"
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1995-05-26"
},
{
- "distinct_range": 10,
- "num_eq": 1200,
- "num_range": 28211,
- "upper_bound": "1995-07-23"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1995-06-09"
},
{
- "distinct_range": 10,
- "num_eq": 4202,
- "num_range": 28811,
- "upper_bound": "1995-08-03"
+ "distinct_range": 12,
+ "num_eq": 4201,
+ "num_range": 26405,
+ "upper_bound": "1995-06-22"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1995-08-15"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 28806,
+ "upper_bound": "1995-07-06"
},
{
- "distinct_range": 11,
- "num_eq": 4802,
- "num_range": 24609,
- "upper_bound": "1995-08-27"
+ "distinct_range": 8,
+ "num_eq": 4201,
+ "num_range": 27005,
+ "upper_bound": "1995-07-15"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1995-09-08"
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1995-07-27"
},
{
- "distinct_range": 10,
+ "distinct_range": 11,
"num_eq": 3601,
- "num_range": 28811,
- "upper_bound": "1995-09-19"
+ "num_range": 26405,
+ "upper_bound": "1995-08-08"
},
{
- "distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1995-10-01"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1995-08-21"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1995-10-12"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1995-09-03"
},
{
"distinct_range": 10,
- "num_eq": 4202,
- "num_range": 26410,
- "upper_bound": "1995-10-23"
+ "num_eq": 4801,
+ "num_range": 25805,
+ "upper_bound": "1995-09-14"
},
{
"distinct_range": 11,
- "num_eq": 6002,
- "num_range": 25810,
- "upper_bound": "1995-11-04"
- },
- {
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-11-17"
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1995-09-26"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1995-11-27"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1995-10-07"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1995-10-20"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 28211,
- "upper_bound": "1995-12-09"
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1995-11-01"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1995-11-13"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 27605,
+ "upper_bound": "1995-11-26"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27610,
+ "num_eq": 5401,
+ "num_range": 24605,
+ "upper_bound": "1995-12-07"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 27605,
"upper_bound": "1995-12-20"
},
{
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1995-12-31"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1996-01-01"
},
{
"distinct_range": 11,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1996-01-12"
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1996-01-13"
},
{
- "distinct_range": 9,
- "num_eq": 4202,
- "num_range": 25210,
- "upper_bound": "1996-01-22"
+ "distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 24605,
+ "upper_bound": "1996-01-25"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 27010,
+ "distinct_range": 10,
+ "num_eq": 4801,
+ "num_range": 25805,
"upper_bound": "1996-02-05"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1996-02-16"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 28806,
+ "upper_bound": "1996-02-18"
},
{
- "distinct_range": 9,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1996-02-26"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1996-03-03"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 1800,
+ "num_range": 27605,
+ "upper_bound": "1996-03-12"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 28211,
- "upper_bound": "1996-03-09"
+ "num_eq": 2400,
+ "num_range": 27605,
+ "upper_bound": "1996-03-24"
},
{
- "distinct_range": 8,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-03-18"
+ "distinct_range": 9,
+ "num_eq": 4801,
+ "num_range": 25805,
+ "upper_bound": "1996-04-03"
},
{
- "distinct_range": 14,
- "num_eq": 1200,
- "num_range": 27610,
- "upper_bound": "1996-04-02"
+ "distinct_range": 9,
+ "num_eq": 1800,
+ "num_range": 28806,
+ "upper_bound": "1996-04-13"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1996-04-15"
+ "distinct_range": 8,
+ "num_eq": 3601,
+ "num_range": 25805,
+ "upper_bound": "1996-04-22"
},
{
"distinct_range": 12,
"num_eq": 3601,
- "num_range": 28211,
- "upper_bound": "1996-04-28"
+ "num_range": 27605,
+ "upper_bound": "1996-05-05"
},
{
- "distinct_range": 12,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1996-05-11"
+ "distinct_range": 10,
+ "num_eq": 4801,
+ "num_range": 24605,
+ "upper_bound": "1996-05-16"
},
{
"distinct_range": 12,
"num_eq": 600,
- "num_range": 28211,
- "upper_bound": "1996-05-24"
+ "num_range": 28206,
+ "upper_bound": "1996-05-29"
},
{
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1996-06-06"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 26405,
+ "upper_bound": "1996-06-10"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1996-06-17"
+ "distinct_range": 9,
+ "num_eq": 5401,
+ "num_range": 24005,
+ "upper_bound": "1996-06-20"
},
{
"distinct_range": 12,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-06-30"
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1996-07-03"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1996-07-12"
+ "num_eq": 3601,
+ "num_range": 27605,
+ "upper_bound": "1996-07-15"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1996-07-23"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 28206,
+ "upper_bound": "1996-07-28"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 25210,
- "upper_bound": "1996-08-03"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 27005,
+ "upper_bound": "1996-08-09"
},
{
- "distinct_range": 10,
- "num_eq": 4202,
- "num_range": 24609,
- "upper_bound": "1996-08-14"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1996-08-22"
},
{
- "distinct_range": 11,
+ "distinct_range": 9,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1996-08-26"
+ "num_range": 27005,
+ "upper_bound": "1996-09-01"
},
{
- "distinct_range": 13,
- "num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1996-09-09"
+ "distinct_range": 14,
+ "num_eq": 6601,
+ "num_range": 22805,
+ "upper_bound": "1996-09-16"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 28211,
- "upper_bound": "1996-09-20"
+ "distinct_range": 12,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1996-09-29"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1996-10-02"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 27605,
+ "upper_bound": "1996-10-12"
},
{
- "distinct_range": 12,
+ "distinct_range": 11,
"num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1996-10-15"
+ "num_range": 25805,
+ "upper_bound": "1996-10-24"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1996-10-27"
+ "num_eq": 1800,
+ "num_range": 27605,
+ "upper_bound": "1996-11-05"
},
{
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1996-11-07"
+ "distinct_range": 9,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1996-11-15"
},
{
- "distinct_range": 12,
+ "distinct_range": 13,
"num_eq": 3601,
- "num_range": 28211,
- "upper_bound": "1996-11-20"
- },
- {
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1996-12-01"
+ "num_range": 28206,
+ "upper_bound": "1996-11-29"
},
{
- "distinct_range": 13,
- "num_eq": 2401,
- "num_range": 26410,
- "upper_bound": "1996-12-15"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 27605,
+ "upper_bound": "1996-12-11"
},
{
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 28211,
+ "distinct_range": 14,
+ "num_eq": 1800,
+ "num_range": 28206,
"upper_bound": "1996-12-26"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 24609,
+ "num_eq": 2400,
+ "num_range": 26405,
"upper_bound": "1997-01-07"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 27010,
+ "num_eq": 3001,
+ "num_range": 26405,
"upper_bound": "1997-01-19"
},
{
"distinct_range": 11,
"num_eq": 3601,
- "num_range": 28211,
+ "num_range": 26405,
"upper_bound": "1997-01-31"
},
- {
- "distinct_range": 12,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1997-02-13"
- },
{
"distinct_range": 9,
- "num_eq": 4802,
- "num_range": 24009,
- "upper_bound": "1997-02-23"
+ "num_eq": 6001,
+ "num_range": 22805,
+ "upper_bound": "1997-02-10"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1997-03-06"
+ "num_eq": 4201,
+ "num_range": 27605,
+ "upper_bound": "1997-02-21"
},
{
- "distinct_range": 14,
+ "distinct_range": 11,
"num_eq": 3001,
- "num_range": 28211,
- "upper_bound": "1997-03-21"
+ "num_range": 27005,
+ "upper_bound": "1997-03-05"
},
{
- "distinct_range": 12,
- "num_eq": 5402,
- "num_range": 28211,
- "upper_bound": "1997-04-03"
+ "distinct_range": 13,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1997-03-19"
},
{
"distinct_range": 10,
- "num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1997-04-14"
+ "num_eq": 4801,
+ "num_range": 25805,
+ "upper_bound": "1997-03-30"
},
{
- "distinct_range": 10,
- "num_eq": 3601,
- "num_range": 27010,
- "upper_bound": "1997-04-25"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 27005,
+ "upper_bound": "1997-04-11"
},
{
- "distinct_range": 14,
- "num_eq": 4202,
- "num_range": 27010,
- "upper_bound": "1997-05-10"
+ "distinct_range": 11,
+ "num_eq": 4201,
+ "num_range": 25205,
+ "upper_bound": "1997-04-23"
},
{
- "distinct_range": 9,
+ "distinct_range": 12,
"num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1997-05-20"
- },
- {
- "distinct_range": 10,
- "num_eq": 4202,
- "num_range": 26410,
- "upper_bound": "1997-05-31"
+ "num_range": 25805,
+ "upper_bound": "1997-05-06"
},
{
"distinct_range": 12,
"num_eq": 3001,
- "num_range": 25210,
- "upper_bound": "1997-06-13"
+ "num_range": 26405,
+ "upper_bound": "1997-05-19"
},
{
- "distinct_range": 14,
- "num_eq": 4802,
- "num_range": 27010,
- "upper_bound": "1997-06-28"
+ "distinct_range": 9,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-05-29"
},
{
- "distinct_range": 8,
- "num_eq": 1801,
- "num_range": 26410,
- "upper_bound": "1997-07-07"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 28206,
+ "upper_bound": "1997-06-10"
},
{
- "distinct_range": 18,
- "num_eq": 2401,
- "num_range": 27610,
- "upper_bound": "1997-07-26"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 28206,
+ "upper_bound": "1997-06-22"
},
{
- "distinct_range": 12,
- "num_eq": 1801,
- "num_range": 27610,
- "upper_bound": "1997-08-08"
+ "distinct_range": 13,
+ "num_eq": 4201,
+ "num_range": 28206,
+ "upper_bound": "1997-07-06"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 28206,
+ "upper_bound": "1997-07-20"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 5401,
+ "num_range": 27005,
+ "upper_bound": "1997-08-01"
},
{
"distinct_range": 10,
"num_eq": 3601,
- "num_range": 26410,
- "upper_bound": "1997-08-19"
+ "num_range": 25805,
+ "upper_bound": "1997-08-12"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1997-08-30"
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1997-08-23"
},
{
- "distinct_range": 10,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1997-09-10"
+ "distinct_range": 13,
+ "num_eq": 2400,
+ "num_range": 27005,
+ "upper_bound": "1997-09-06"
},
{
- "distinct_range": 9,
- "num_eq": 3601,
- "num_range": 24609,
+ "distinct_range": 13,
+ "num_eq": 3001,
+ "num_range": 26405,
"upper_bound": "1997-09-20"
},
{
- "distinct_range": 11,
+ "distinct_range": 12,
"num_eq": 3601,
- "num_range": 25810,
- "upper_bound": "1997-10-02"
+ "num_range": 27605,
+ "upper_bound": "1997-10-03"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 27610,
- "upper_bound": "1997-10-13"
+ "num_eq": 2400,
+ "num_range": 25805,
+ "upper_bound": "1997-10-14"
},
{
- "distinct_range": 14,
- "num_eq": 3601,
- "num_range": 27610,
- "upper_bound": "1997-10-28"
+ "distinct_range": 8,
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1997-10-23"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 27010,
- "upper_bound": "1997-11-11"
+ "distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 26405,
+ "upper_bound": "1997-11-04"
},
{
- "distinct_range": 15,
- "num_eq": 4202,
- "num_range": 25810,
- "upper_bound": "1997-11-27"
+ "distinct_range": 16,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1997-11-21"
},
{
- "distinct_range": 9,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1997-12-07"
+ "distinct_range": 12,
+ "num_eq": 3601,
+ "num_range": 26405,
+ "upper_bound": "1997-12-04"
},
{
- "distinct_range": 10,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1997-12-18"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 27605,
+ "upper_bound": "1997-12-17"
},
{
- "distinct_range": 12,
- "num_eq": 4802,
- "num_range": 26410,
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 27605,
"upper_bound": "1997-12-31"
},
{
"distinct_range": 10,
- "num_eq": 2401,
- "num_range": 25210,
+ "num_eq": 4201,
+ "num_range": 25205,
"upper_bound": "1998-01-11"
},
- {
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 27010,
- "upper_bound": "1998-01-22"
- },
{
"distinct_range": 13,
- "num_eq": 2401,
- "num_range": 27010,
- "upper_bound": "1998-02-05"
+ "num_eq": 2400,
+ "num_range": 27605,
+ "upper_bound": "1998-01-25"
},
{
"distinct_range": 11,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1998-02-17"
+ "num_eq": 2400,
+ "num_range": 27605,
+ "upper_bound": "1998-02-06"
},
{
"distinct_range": 12,
- "num_eq": 2401,
- "num_range": 26410,
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1998-02-19"
+ },
+ {
+ "distinct_range": 10,
+ "num_eq": 4201,
+ "num_range": 27005,
"upper_bound": "1998-03-02"
},
{
- "distinct_range": 14,
- "num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1998-03-17"
+ "distinct_range": 11,
+ "num_eq": 2400,
+ "num_range": 25805,
+ "upper_bound": "1998-03-14"
},
{
"distinct_range": 10,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1998-03-28"
+ "num_eq": 1200,
+ "num_range": 26405,
+ "upper_bound": "1998-03-25"
},
{
- "distinct_range": 9,
- "num_eq": 5402,
- "num_range": 23409,
- "upper_bound": "1998-04-07"
+ "distinct_range": 8,
+ "num_eq": 4801,
+ "num_range": 26405,
+ "upper_bound": "1998-04-03"
},
{
- "distinct_range": 10,
- "num_eq": 1801,
- "num_range": 26410,
- "upper_bound": "1998-04-18"
+ "distinct_range": 11,
+ "num_eq": 3601,
+ "num_range": 27005,
+ "upper_bound": "1998-04-15"
},
{
- "distinct_range": 9,
- "num_eq": 1801,
- "num_range": 25210,
- "upper_bound": "1998-04-28"
+ "distinct_range": 14,
+ "num_eq": 4801,
+ "num_range": 26405,
+ "upper_bound": "1998-04-30"
},
{
- "distinct_range": 12,
- "num_eq": 3601,
- "num_range": 23409,
- "upper_bound": "1998-05-11"
+ "distinct_range": 11,
+ "num_eq": 1800,
+ "num_range": 26405,
+ "upper_bound": "1998-05-12"
},
{
- "distinct_range": 10,
- "num_eq": 4802,
- "num_range": 25810,
- "upper_bound": "1998-05-22"
+ "distinct_range": 11,
+ "num_eq": 3001,
+ "num_range": 25205,
+ "upper_bound": "1998-05-24"
},
{
"distinct_range": 8,
"num_eq": 3001,
- "num_range": 24609,
- "upper_bound": "1998-05-31"
+ "num_range": 25205,
+ "upper_bound": "1998-06-02"
},
{
- "distinct_range": 7,
+ "distinct_range": 8,
"num_eq": 3001,
- "num_range": 26410,
- "upper_bound": "1998-06-08"
+ "num_range": 24005,
+ "upper_bound": "1998-06-11"
},
{
"distinct_range": 11,
- "num_eq": 4202,
- "num_range": 22809,
- "upper_bound": "1998-06-20"
+ "num_eq": 2400,
+ "num_range": 26405,
+ "upper_bound": "1998-06-23"
},
{
"distinct_range": 9,
- "num_eq": 3001,
- "num_range": 25810,
- "upper_bound": "1998-06-30"
+ "num_eq": 5401,
+ "num_range": 24605,
+ "upper_bound": "1998-07-03"
},
{
- "distinct_range": 11,
- "num_eq": 3601,
- "num_range": 25210,
- "upper_bound": "1998-07-12"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 25805,
+ "upper_bound": "1998-07-14"
},
{
"distinct_range": 10,
- "num_eq": 3601,
- "num_range": 25210,
- "upper_bound": "1998-07-23"
+ "num_eq": 3001,
+ "num_range": 24005,
+ "upper_bound": "1998-07-25"
},
{
- "distinct_range": 11,
- "num_eq": 4202,
- "num_range": 21608,
- "upper_bound": "1998-08-04"
+ "distinct_range": 12,
+ "num_eq": 3001,
+ "num_range": 25805,
+ "upper_bound": "1998-08-07"
},
{
- "distinct_range": 11,
- "num_eq": 2401,
- "num_range": 24609,
- "upper_bound": "1998-08-16"
+ "distinct_range": 10,
+ "num_eq": 3601,
+ "num_range": 24005,
+ "upper_bound": "1998-08-18"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 25210,
+ "distinct_range": 9,
+ "num_eq": 4801,
+ "num_range": 23405,
"upper_bound": "1998-08-28"
},
{
- "distinct_range": 12,
- "num_eq": 3001,
- "num_range": 25210,
- "upper_bound": "1998-09-10"
+ "distinct_range": 11,
+ "num_eq": 4801,
+ "num_range": 22204,
+ "upper_bound": "1998-09-09"
},
{
"distinct_range": 12,
- "num_eq": 1200,
- "num_range": 24009,
- "upper_bound": "1998-09-23"
+ "num_eq": 3001,
+ "num_range": 23405,
+ "upper_bound": "1998-09-22"
},
{
"distinct_range": 15,
- "num_eq": 1801,
- "num_range": 23409,
- "upper_bound": "1998-10-09"
+ "num_eq": 1800,
+ "num_range": 25205,
+ "upper_bound": "1998-10-08"
},
{
- "distinct_range": 15,
- "num_eq": 600,
- "num_range": 24609,
- "upper_bound": "1998-10-25"
+ "distinct_range": 23,
+ "num_eq": 1800,
+ "num_range": 24005,
+ "upper_bound": "1998-11-01"
},
{
- "distinct_range": 56,
+ "distinct_range": 46,
"num_eq": 600,
- "num_range": 25210,
- "upper_bound": "1998-12-21"
+ "num_range": 25805,
+ "upper_bound": "1998-12-18"
},
{
- "distinct_range": 8,
+ "distinct_range": 14,
"num_eq": 0,
- "num_range": 8,
+ "num_range": 14,
"upper_bound": "infinity"
}
],
@@ -8927,37 +8955,39 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 8,
"columns": [
"l_partkey",
"l_suppkey"
],
- "created_at": "2021-09-08 20:49:14.314079",
- "distinct_count": 797656,
+ "created_at": "2022-02-25 00:55:34.245977",
+ "distinct_count": 797888,
"histo_col_type": "",
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 9,
"columns": [
"l_quantity"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 50,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 115244,
+ "num_eq": 113423,
"num_range": 0,
"upper_bound": "1.0"
},
{
- "distinct_range": 48,
- "num_eq": 109842,
- "num_range": 5777207,
+ "distinct_range": 47.99999999999999,
+ "num_eq": 121825,
+ "num_range": 5765967,
"upper_bound": "50.0"
}
],
@@ -8965,103 +8995,107 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 9,
"columns": [
"l_extendedprice"
],
- "created_at": "2021-09-08 20:49:14.314079",
- "distinct_count": 971211,
+ "created_at": "2022-02-25 00:55:34.245977",
+ "distinct_count": 925955,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 600,
"num_range": 0,
- "upper_bound": "926.010009765625"
+ "upper_bound": "929.02"
},
{
- "distinct_range": 971209.0000000001,
+ "distinct_range": 925953.0000000001,
"num_eq": 600,
- "num_range": 6001093,
- "upper_bound": "102066.5078125"
+ "num_range": 6000015,
+ "upper_bound": "104249.0"
}
],
"histo_col_type": "FLOAT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 9,
"columns": [
"l_discount"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 11,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 531803,
+ "num_eq": 549711,
"num_range": 0,
"upper_bound": "0.0"
},
{
"distinct_range": 9,
- "num_eq": 554612,
- "num_range": 4915878,
- "upper_bound": "0.10000000149011612"
+ "num_eq": 540709,
+ "num_range": 4910794,
+ "upper_bound": "0.1"
}
],
"histo_col_type": "FLOAT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 9,
"columns": [
"l_tax"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 9,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 678259,
+ "num_eq": 658333,
"num_range": 0,
"upper_bound": "0.0"
},
{
"distinct_range": 7,
- "num_eq": 656651,
- "num_range": 4667383,
- "upper_bound": "0.07999999821186066"
+ "num_eq": 661334,
+ "num_range": 4681548,
+ "upper_bound": "0.08"
}
],
"histo_col_type": "FLOAT8",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 3,
"columns": [
"l_returnflag"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 3,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1526383,
+ "num_eq": 1495503,
"num_range": 0,
"upper_bound": "A"
},
{
"distinct_range": 1,
- "num_eq": 1436949,
- "num_range": 3038961,
+ "num_eq": 1468497,
+ "num_range": 3037215,
"upper_bound": "R"
}
],
@@ -9069,24 +9103,25 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 3,
"columns": [
"l_linestatus"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 2,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 3002947,
+ "num_eq": 3009009,
"num_range": 0,
"upper_bound": "F"
},
{
"distinct_range": 0,
- "num_eq": 2999346,
+ "num_eq": 2992206,
"num_range": 0,
"upper_bound": "O"
}
@@ -9095,25 +9130,26 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 14,
"columns": [
"l_shipinstruct"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 4,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1527584,
+ "num_eq": 1509306,
"num_range": 0,
"upper_bound": "COLLECT COD"
},
{
"distinct_range": 2,
- "num_eq": 1513778,
- "num_range": 2960931,
+ "num_eq": 1542912,
+ "num_range": 2948997,
"upper_bound": "TAKE BACK RETURN"
}
],
@@ -9121,25 +9157,26 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 7,
"columns": [
"l_shipmode"
],
- "created_at": "2021-09-08 20:49:14.314079",
+ "created_at": "2022-02-25 00:55:34.245977",
"distinct_count": 7,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 861929,
+ "num_eq": 838970,
"num_range": 0,
"upper_bound": "AIR"
},
{
"distinct_range": 5,
- "num_eq": 881137,
- "num_range": 4259227,
+ "num_eq": 891180,
+ "num_range": 4271065,
"upper_bound": "TRUCK"
}
],
@@ -9147,33 +9184,34 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
},
{
+ "avg_size": 29,
"columns": [
"l_comment"
],
- "created_at": "2021-09-08 20:49:14.314079",
- "distinct_count": 5403256,
+ "created_at": "2022-02-25 00:55:34.245977",
+ "distinct_count": 4643303,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 600,
"num_range": 0,
- "upper_bound": " About over business popular animal ru"
+ "upper_bound": " about the blithely regular requests. clo"
},
{
- "distinct_range": 5403254,
+ "distinct_range": 4643301,
"num_eq": 600,
- "num_range": 6001093,
- "upper_bound": "zine chair with by fa"
+ "num_range": 6000015,
+ "upper_bound": "zle idly against the d"
}
],
"histo_col_type": "VARCHAR(44)",
"histo_version": 1,
"name": "__auto__",
"null_count": 0,
- "row_count": 6002293
+ "row_count": 6001215
}
]';
----
@@ -9181,10 +9219,11 @@ ALTER TABLE "lineitem" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "nation" INJECT STATISTICS '[
{
+ "avg_size": 1,
"columns": [
"n_nationkey"
],
- "created_at": "2021-09-08 20:48:18.792016",
+ "created_at": "2022-02-25 00:55:34.538185",
"distinct_count": 25,
"histo_buckets": [
{
@@ -9345,10 +9384,11 @@ ALTER TABLE "nation" INJECT STATISTICS '[
"row_count": 25
},
{
+ "avg_size": 2,
"columns": [
"n_regionkey"
],
- "created_at": "2021-09-08 20:48:18.792016",
+ "created_at": "2022-02-25 00:55:34.538185",
"distinct_count": 5,
"histo_buckets": [
{
@@ -9389,10 +9429,11 @@ ALTER TABLE "nation" INJECT STATISTICS '[
"row_count": 25
},
{
+ "avg_size": 10,
"columns": [
"n_name"
],
- "created_at": "2021-09-08 20:48:18.792016",
+ "created_at": "2022-02-25 00:55:34.538185",
"distinct_count": 25,
"histo_buckets": [
{
@@ -9415,23 +9456,24 @@ ALTER TABLE "nation" INJECT STATISTICS '[
"row_count": 25
},
{
+ "avg_size": 77,
"columns": [
"n_comment"
],
- "created_at": "2021-09-08 20:48:18.792016",
+ "created_at": "2022-02-25 00:55:34.538185",
"distinct_count": 25,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": " Message force article begin investment lang"
+ "upper_bound": " haggle. carefully final deposits detect slyly agai"
},
{
"distinct_range": 23,
"num_eq": 1,
"num_range": 23,
- "upper_bound": "uthern thousand claim. PM response how edge discover unit option town. Run just only particular west adm"
+ "upper_bound": "y final packages. slow foxes cajole quickly. quickly silent platelets breach ironic accounts. unusual pinto be"
}
],
"histo_col_type": "VARCHAR(152)",
@@ -9446,10 +9488,11 @@ ALTER TABLE "nation" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "orders" INJECT STATISTICS '[
{
+ "avg_size": 4,
"columns": [
"o_orderkey"
],
- "created_at": "2021-09-08 20:49:26.228164",
+ "created_at": "2022-02-25 00:54:45.88743",
"distinct_count": 1500000,
"histo_buckets": [
{
@@ -9459,1207 +9502,1207 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"upper_bound": "-9223372036854775808"
},
{
- "distinct_range": 1.1641532182693481E-10,
+ "distinct_range": 6.984919309616089E-10,
"num_eq": 1,
"num_range": 0,
- "upper_bound": "1472"
+ "upper_bound": "1505"
},
{
- "distinct_range": 7445.043988806108,
+ "distinct_range": 7343.585478349326,
"num_eq": 1,
- "num_range": 7462,
- "upper_bound": "30469"
+ "num_range": 7407,
+ "upper_bound": "29025"
},
{
- "distinct_range": 7096.380895839631,
+ "distinct_range": 7186.512396111458,
"num_eq": 1,
- "num_range": 7286,
- "upper_bound": "54689"
+ "num_range": 7328,
+ "upper_bound": "54400"
},
{
- "distinct_range": 7594.042512660854,
+ "distinct_range": 7934.625597436033,
"num_eq": 1,
- "num_range": 7545,
- "upper_bound": "85922"
+ "num_range": 7749,
+ "upper_bound": "91106"
},
{
- "distinct_range": 7672.034043945176,
+ "distinct_range": 7395.642489127368,
"num_eq": 1,
- "num_range": 7590,
- "upper_bound": "118369"
+ "num_range": 7434,
+ "upper_bound": "119366"
},
{
- "distinct_range": 6957.04613238319,
+ "distinct_range": 8357.507695213397,
"num_eq": 1,
- "num_range": 7223,
- "upper_bound": "140867"
+ "num_range": 8030,
+ "upper_bound": "163554"
},
{
- "distinct_range": 7178.00024232344,
+ "distinct_range": 7054.925591239351,
"num_eq": 1,
- "num_range": 7325,
- "upper_bound": "166146"
+ "num_range": 7266,
+ "upper_bound": "187236"
},
{
- "distinct_range": 7526.859353114826,
+ "distinct_range": 7406.42136263475,
"num_eq": 1,
- "num_range": 7507,
- "upper_bound": "196357"
+ "num_range": 7440,
+ "upper_bound": "215651"
},
{
- "distinct_range": 7233.345528228113,
+ "distinct_range": 8052.3398507383135,
"num_eq": 1,
- "num_range": 7352,
- "upper_bound": "222375"
+ "num_range": 7824,
+ "upper_bound": "254373"
},
{
- "distinct_range": 7979.4616252210235,
+ "distinct_range": 7564.068706977623,
"num_eq": 1,
- "num_range": 7778,
- "upper_bound": "259877"
+ "num_range": 7527,
+ "upper_bound": "285123"
},
{
- "distinct_range": 7649.48420131907,
+ "distinct_range": 7612.417940096636,
"num_eq": 1,
- "num_range": 7577,
- "upper_bound": "291970"
+ "num_range": 7554,
+ "upper_bound": "316614"
},
{
- "distinct_range": 7906.003077487418,
+ "distinct_range": 7381.951556541155,
"num_eq": 1,
- "num_range": 7732,
- "upper_bound": "328227"
+ "num_range": 7427,
+ "upper_bound": "344678"
},
{
- "distinct_range": 7846.37353213706,
+ "distinct_range": 7500.076392242053,
"num_eq": 1,
- "num_range": 7695,
- "upper_bound": "363490"
+ "num_range": 7491,
+ "upper_bound": "374465"
},
{
- "distinct_range": 7667.968576844277,
+ "distinct_range": 7684.270133176651,
"num_eq": 1,
- "num_range": 7587,
- "upper_bound": "395873"
+ "num_range": 7596,
+ "upper_bound": "407078"
},
{
- "distinct_range": 7637.766211461647,
+ "distinct_range": 7566.237906778984,
"num_eq": 1,
- "num_range": 7570,
- "upper_bound": "427783"
+ "num_range": 7528,
+ "upper_bound": "437861"
},
{
- "distinct_range": 7947.5249213700135,
+ "distinct_range": 7760.0185952918455,
"num_eq": 1,
- "num_range": 7758,
- "upper_bound": "464741"
+ "num_range": 7641,
+ "upper_bound": "471683"
},
{
- "distinct_range": 7732.312535555209,
+ "distinct_range": 7680.086462516366,
"num_eq": 1,
- "num_range": 7625,
- "upper_bound": "498146"
+ "num_range": 7594,
+ "upper_bound": "504230"
},
{
- "distinct_range": 7526.925818404744,
+ "distinct_range": 7301.915728450174,
"num_eq": 1,
- "num_range": 7507,
- "upper_bound": "528358"
+ "num_range": 7385,
+ "upper_bound": "531168"
},
{
- "distinct_range": 7009.622751178384,
+ "distinct_range": 7879.600372791154,
"num_eq": 1,
- "num_range": 7246,
- "upper_bound": "551493"
+ "num_range": 7714,
+ "upper_bound": "566951"
},
{
- "distinct_range": 8046.143277827883,
+ "distinct_range": 7349.970831958723,
"num_eq": 1,
- "num_range": 7821,
- "upper_bound": "590144"
+ "num_range": 7410,
+ "upper_bound": "594561"
},
{
- "distinct_range": 7586.033651314595,
+ "distinct_range": 7021.233794034697,
"num_eq": 1,
- "num_range": 7540,
- "upper_bound": "621254"
+ "num_range": 7250,
+ "upper_bound": "617825"
},
{
- "distinct_range": 7433.536822746123,
+ "distinct_range": 7549.766363176823,
"num_eq": 1,
- "num_range": 7456,
- "upper_bound": "650083"
+ "num_range": 7519,
+ "upper_bound": "648358"
},
{
- "distinct_range": 7672.0975275441615,
+ "distinct_range": 7397.174964562542,
"num_eq": 1,
- "num_range": 7590,
- "upper_bound": "682531"
+ "num_range": 7435,
+ "upper_bound": "676640"
},
{
- "distinct_range": 7921.037868990409,
+ "distinct_range": 7649.4370024514255,
"num_eq": 1,
- "num_range": 7741,
- "upper_bound": "719041"
+ "num_range": 7576,
+ "upper_bound": "708706"
},
{
- "distinct_range": 7698.466195177046,
+ "distinct_range": 7465.823444167181,
"num_eq": 1,
- "num_range": 7605,
- "upper_bound": "751906"
+ "num_range": 7472,
+ "upper_bound": "737986"
},
{
- "distinct_range": 7873.361644119821,
+ "distinct_range": 7135.245507321674,
"num_eq": 1,
- "num_range": 7711,
- "upper_bound": "787617"
+ "num_range": 7303,
+ "upper_bound": "762690"
},
{
- "distinct_range": 7871.560275446427,
+ "distinct_range": 6680.2749296913835,
"num_eq": 1,
- "num_range": 7710,
- "upper_bound": "823298"
+ "num_range": 7110,
+ "upper_bound": "782081"
},
{
- "distinct_range": 7869.457624202335,
+ "distinct_range": 7769.983670175275,
"num_eq": 1,
- "num_range": 7709,
- "upper_bound": "858944"
+ "num_range": 7647,
+ "upper_bound": "816064"
},
{
- "distinct_range": 7499.080566618442,
+ "distinct_range": 7724.637018609971,
"num_eq": 1,
- "num_range": 7491,
- "upper_bound": "888739"
+ "num_range": 7620,
+ "upper_bound": "849318"
},
{
- "distinct_range": 7564.969581740615,
+ "distinct_range": 7657.557040740202,
"num_eq": 1,
- "num_range": 7528,
- "upper_bound": "919527"
+ "num_range": 7580,
+ "upper_bound": "881511"
},
{
- "distinct_range": 7192.350611501609,
+ "distinct_range": 7498.262347025553,
"num_eq": 1,
- "num_range": 7332,
- "upper_bound": "944996"
+ "num_range": 7490,
+ "upper_bound": "911271"
},
{
- "distinct_range": 7151.107892484742,
+ "distinct_range": 7350.254270346866,
"num_eq": 1,
- "num_range": 7312,
- "upper_bound": "969922"
+ "num_range": 7410,
+ "upper_bound": "938885"
},
{
- "distinct_range": 7649.803776907389,
+ "distinct_range": 7724.386582305666,
"num_eq": 1,
- "num_range": 7577,
- "upper_bound": "1002020"
+ "num_range": 7620,
+ "upper_bound": "972135"
},
{
- "distinct_range": 7595.797830114659,
+ "distinct_range": 8024.195803625766,
"num_eq": 1,
- "num_range": 7546,
- "upper_bound": "1033280"
+ "num_range": 7806,
+ "upper_bound": "1010370"
},
{
- "distinct_range": 7079.374251169038,
+ "distinct_range": 7366.360829181636,
"num_eq": 1,
- "num_range": 7278,
- "upper_bound": "1057284"
+ "num_range": 7419,
+ "upper_bound": "1038212"
},
{
- "distinct_range": 7314.516844359543,
+ "distinct_range": 7435.008009278807,
"num_eq": 1,
- "num_range": 7393,
- "upper_bound": "1084416"
+ "num_range": 7455,
+ "upper_bound": "1067041"
},
{
- "distinct_range": 7531.2429126019115,
+ "distinct_range": 7778.25658100595,
"num_eq": 1,
- "num_range": 7509,
- "upper_bound": "1114693"
+ "num_range": 7652,
+ "upper_bound": "1101158"
},
{
- "distinct_range": 7728.318371269166,
+ "distinct_range": 7345.431711133371,
"num_eq": 1,
- "num_range": 7623,
- "upper_bound": "1148034"
+ "num_range": 7408,
+ "upper_bound": "1128704"
},
{
- "distinct_range": 7658.101862794584,
+ "distinct_range": 7083.22556873615,
"num_eq": 1,
- "num_range": 7582,
- "upper_bound": "1180262"
+ "num_range": 7279,
+ "upper_bound": "1152742"
},
{
- "distinct_range": 7975.541327914424,
+ "distinct_range": 7336.686246514694,
"num_eq": 1,
- "num_range": 7776,
- "upper_bound": "1217697"
+ "num_range": 7403,
+ "upper_bound": "1180165"
},
{
- "distinct_range": 7558.464455577618,
+ "distinct_range": 7283.736439494707,
"num_eq": 1,
- "num_range": 7524,
- "upper_bound": "1248386"
+ "num_range": 7376,
+ "upper_bound": "1206852"
},
{
- "distinct_range": 7635.520261635069,
+ "distinct_range": 7283.591066129795,
"num_eq": 1,
- "num_range": 7569,
- "upper_bound": "1280261"
+ "num_range": 7376,
+ "upper_bound": "1233537"
},
{
- "distinct_range": 7486.036208727846,
+ "distinct_range": 7549.36995694725,
"num_eq": 1,
- "num_range": 7484,
- "upper_bound": "1309862"
+ "num_range": 7518,
+ "upper_bound": "1264064"
},
{
- "distinct_range": 7793.898562757112,
+ "distinct_range": 7736.262478770142,
"num_eq": 1,
- "num_range": 7663,
- "upper_bound": "1344263"
+ "num_range": 7627,
+ "upper_bound": "1297504"
},
{
- "distinct_range": 7268.4936275988,
+ "distinct_range": 7817.451371725421,
"num_eq": 1,
- "num_range": 7369,
- "upper_bound": "1370759"
+ "num_range": 7676,
+ "upper_bound": "1332260"
},
{
- "distinct_range": 7461.878062981986,
+ "distinct_range": 7463.3758380369145,
"num_eq": 1,
"num_range": 7471,
- "upper_bound": "1400003"
+ "upper_bound": "1361504"
},
{
- "distinct_range": 7291.970180331927,
+ "distinct_range": 7236.933712675743,
"num_eq": 1,
- "num_range": 7381,
- "upper_bound": "1426822"
+ "num_range": 7353,
+ "upper_bound": "1387553"
},
{
- "distinct_range": 7770.15636239317,
+ "distinct_range": 7687.942410366055,
"num_eq": 1,
- "num_range": 7648,
- "upper_bound": "1460837"
+ "num_range": 7598,
+ "upper_bound": "1420224"
},
{
- "distinct_range": 7293.705989993935,
+ "distinct_range": 7774.1842333341665,
"num_eq": 1,
- "num_range": 7382,
- "upper_bound": "1487680"
+ "num_range": 7650,
+ "upper_bound": "1454275"
},
{
- "distinct_range": 7750.416330606216,
+ "distinct_range": 7534.666514827246,
"num_eq": 1,
- "num_range": 7636,
- "upper_bound": "1521376"
+ "num_range": 7510,
+ "upper_bound": "1484580"
},
{
- "distinct_range": 7499.281829170141,
+ "distinct_range": 7172.183442239095,
"num_eq": 1,
- "num_range": 7491,
- "upper_bound": "1551174"
+ "num_range": 7321,
+ "upper_bound": "1509766"
},
{
- "distinct_range": 7418.120333930512,
+ "distinct_range": 7102.577166357258,
"num_eq": 1,
- "num_range": 7447,
- "upper_bound": "1579779"
+ "num_range": 7288,
+ "upper_bound": "1534050"
},
{
- "distinct_range": 7562.671359783397,
+ "distinct_range": 7262.936570817455,
"num_eq": 1,
- "num_range": 7527,
- "upper_bound": "1610532"
+ "num_range": 7366,
+ "upper_bound": "1560452"
},
{
- "distinct_range": 7407.471848639225,
+ "distinct_range": 7295.3396678327645,
"num_eq": 1,
- "num_range": 7442,
- "upper_bound": "1638983"
+ "num_range": 7382,
+ "upper_bound": "1587299"
},
{
- "distinct_range": 7053.382524615112,
+ "distinct_range": 7478.842418838483,
"num_eq": 1,
- "num_range": 7266,
- "upper_bound": "1662660"
+ "num_range": 7479,
+ "upper_bound": "1616771"
},
{
- "distinct_range": 8255.3148317674,
+ "distinct_range": 7564.397471574838,
"num_eq": 1,
- "num_range": 7961,
- "upper_bound": "1705024"
+ "num_range": 7527,
+ "upper_bound": "1647526"
},
{
- "distinct_range": 7022.793354946244,
+ "distinct_range": 6984.624536490295,
"num_eq": 1,
- "num_range": 7252,
- "upper_bound": "1728321"
+ "num_range": 7234,
+ "upper_bound": "1670343"
},
{
- "distinct_range": 7541.777222661008,
+ "distinct_range": 7818.793427974535,
"num_eq": 1,
- "num_range": 7515,
- "upper_bound": "1758757"
+ "num_range": 7677,
+ "upper_bound": "1705121"
},
{
- "distinct_range": 7116.84125647435,
+ "distinct_range": 7332.552318745278,
"num_eq": 1,
- "num_range": 7295,
- "upper_bound": "1783239"
+ "num_range": 7401,
+ "upper_bound": "1732486"
},
{
- "distinct_range": 7519.8056638762855,
+ "distinct_range": 7921.281327471579,
"num_eq": 1,
- "num_range": 7503,
- "upper_bound": "1813344"
+ "num_range": 7740,
+ "upper_bound": "1768967"
},
{
- "distinct_range": 7097.086762938821,
+ "distinct_range": 7756.04959702425,
"num_eq": 1,
- "num_range": 7286,
- "upper_bound": "1837573"
+ "num_range": 7639,
+ "upper_bound": "1802725"
},
{
- "distinct_range": 7170.792747929397,
+ "distinct_range": 7545.204579518855,
"num_eq": 1,
- "num_range": 7321,
- "upper_bound": "1862757"
+ "num_range": 7516,
+ "upper_bound": "1833189"
},
{
- "distinct_range": 6986.257594285928,
+ "distinct_range": 6933.810414271347,
"num_eq": 1,
- "num_range": 7236,
- "upper_bound": "1885607"
+ "num_range": 7212,
+ "upper_bound": "1855398"
},
{
- "distinct_range": 7426.940142487538,
+ "distinct_range": 6978.91807907423,
"num_eq": 1,
- "num_range": 7452,
- "upper_bound": "1914340"
+ "num_range": 7232,
+ "upper_bound": "1878146"
},
{
- "distinct_range": 8029.697917653356,
+ "distinct_range": 6892.98486423576,
"num_eq": 1,
- "num_range": 7811,
- "upper_bound": "1952706"
+ "num_range": 7195,
+ "upper_bound": "1899877"
},
{
- "distinct_range": 7287.118152769315,
+ "distinct_range": 6876.1838324342325,
"num_eq": 1,
- "num_range": 7379,
- "upper_bound": "1979458"
+ "num_range": 7188,
+ "upper_bound": "1921414"
},
{
- "distinct_range": 7365.0935285477135,
+ "distinct_range": 8145.244266698395,
"num_eq": 1,
- "num_range": 7419,
- "upper_bound": "2007302"
+ "num_range": 7886,
+ "upper_bound": "1961765"
},
{
- "distinct_range": 7793.530695544676,
+ "distinct_range": 7250.668583735788,
"num_eq": 1,
- "num_range": 7662,
- "upper_bound": "2041697"
+ "num_range": 7360,
+ "upper_bound": "1988000"
},
{
- "distinct_range": 7337.936411258045,
+ "distinct_range": 7132.77257619045,
"num_eq": 1,
- "num_range": 7405,
- "upper_bound": "2069157"
+ "num_range": 7302,
+ "upper_bound": "2012672"
},
{
- "distinct_range": 7391.83984628725,
+ "distinct_range": 7504.774286866882,
"num_eq": 1,
- "num_range": 7433,
- "upper_bound": "2097383"
+ "num_range": 7494,
+ "upper_bound": "2042529"
},
{
- "distinct_range": 7655.550831161317,
+ "distinct_range": 7570.768596271675,
"num_eq": 1,
- "num_range": 7580,
- "upper_bound": "2129571"
+ "num_range": 7530,
+ "upper_bound": "2073381"
},
{
- "distinct_range": 8070.326506067905,
+ "distinct_range": 7620.6308862802725,
"num_eq": 1,
- "num_range": 7837,
- "upper_bound": "2168643"
+ "num_range": 7559,
+ "upper_bound": "2104999"
},
{
- "distinct_range": 7416.394456251132,
+ "distinct_range": 6781.937393928953,
"num_eq": 1,
- "num_range": 7446,
- "upper_bound": "2197223"
+ "num_range": 7149,
+ "upper_bound": "2125477"
},
{
- "distinct_range": 7242.363487403518,
+ "distinct_range": 7401.767276876725,
"num_eq": 1,
- "num_range": 7356,
- "upper_bound": "2223363"
+ "num_range": 7438,
+ "upper_bound": "2153825"
},
{
- "distinct_range": 7720.378846857728,
+ "distinct_range": 7206.236140027182,
"num_eq": 1,
- "num_range": 7618,
- "upper_bound": "2256577"
+ "num_range": 7338,
+ "upper_bound": "2179462"
},
{
- "distinct_range": 6680.072629679784,
+ "distinct_range": 7127.431395296418,
"num_eq": 1,
- "num_range": 7111,
- "upper_bound": "2275975"
+ "num_range": 7300,
+ "upper_bound": "2204065"
},
{
- "distinct_range": 7325.752914293891,
+ "distinct_range": 7831.032736246987,
"num_eq": 1,
- "num_range": 7399,
- "upper_bound": "2303264"
+ "num_range": 7684,
+ "upper_bound": "2239044"
},
{
- "distinct_range": 7728.505699983802,
+ "distinct_range": 7388.735738198604,
"num_eq": 1,
- "num_range": 7623,
- "upper_bound": "2336608"
+ "num_range": 7431,
+ "upper_bound": "2267205"
},
{
- "distinct_range": 7782.477408812596,
+ "distinct_range": 7026.182568817781,
"num_eq": 1,
- "num_range": 7656,
- "upper_bound": "2370823"
+ "num_range": 7253,
+ "upper_bound": "2290530"
},
{
- "distinct_range": 7393.58113291961,
+ "distinct_range": 7408.641448719993,
"num_eq": 1,
- "num_range": 7434,
- "upper_bound": "2399074"
+ "num_range": 7441,
+ "upper_bound": "2318977"
},
{
- "distinct_range": 7784.076069063744,
+ "distinct_range": 7457.452168070352,
"num_eq": 1,
- "num_range": 7657,
- "upper_bound": "2433315"
+ "num_range": 7468,
+ "upper_bound": "2348134"
},
{
- "distinct_range": 7337.652059482831,
+ "distinct_range": 7848.379796971768,
"num_eq": 1,
- "num_range": 7405,
- "upper_bound": "2460771"
+ "num_range": 7695,
+ "upper_bound": "2383399"
},
{
- "distinct_range": 7468.597638236475,
+ "distinct_range": 7568.405585466573,
"num_eq": 1,
- "num_range": 7475,
- "upper_bound": "2490114"
+ "num_range": 7529,
+ "upper_bound": "2414215"
},
{
- "distinct_range": 7643.854565067646,
+ "distinct_range": 7410.929051141855,
"num_eq": 1,
- "num_range": 7573,
- "upper_bound": "2522119"
+ "num_range": 7442,
+ "upper_bound": "2442695"
},
{
- "distinct_range": 7836.446240389368,
+ "distinct_range": 7848.077204630903,
"num_eq": 1,
- "num_range": 7689,
- "upper_bound": "2557218"
+ "num_range": 7695,
+ "upper_bound": "2477955"
},
{
- "distinct_range": 7620.915739225423,
+ "distinct_range": 7917.47760120399,
"num_eq": 1,
- "num_range": 7560,
- "upper_bound": "2588866"
+ "num_range": 7738,
+ "upper_bound": "2514372"
},
{
- "distinct_range": 7358.04791956447,
+ "distinct_range": 7560.120795473421,
"num_eq": 1,
- "num_range": 7415,
- "upper_bound": "2616610"
+ "num_range": 7524,
+ "upper_bound": "2545062"
},
{
- "distinct_range": 7558.267115638105,
+ "distinct_range": 7331.910266270814,
"num_eq": 1,
- "num_range": 7524,
- "upper_bound": "2647296"
+ "num_range": 7401,
+ "upper_bound": "2572418"
},
{
- "distinct_range": 7618.916144153545,
+ "distinct_range": 7560.120795473421,
"num_eq": 1,
- "num_range": 7559,
- "upper_bound": "2678913"
+ "num_range": 7524,
+ "upper_bound": "2603108"
},
{
- "distinct_range": 7190.241183853419,
+ "distinct_range": 7858.110525219647,
"num_eq": 1,
- "num_range": 7331,
- "upper_bound": "2704354"
+ "num_range": 7701,
+ "upper_bound": "2638534"
},
{
- "distinct_range": 7668.349925228313,
+ "distinct_range": 6801.884390090418,
"num_eq": 1,
- "num_range": 7588,
- "upper_bound": "2736743"
+ "num_range": 7157,
+ "upper_bound": "2659232"
},
{
- "distinct_range": 7307.6224374343265,
+ "distinct_range": 7237.303921873604,
"num_eq": 1,
- "num_range": 7389,
- "upper_bound": "2763779"
+ "num_range": 7353,
+ "upper_bound": "2685286"
},
{
- "distinct_range": 7185.488216542377,
+ "distinct_range": 7251.110389232323,
"num_eq": 1,
- "num_range": 7328,
- "upper_bound": "2789157"
+ "num_range": 7360,
+ "upper_bound": "2711527"
},
{
- "distinct_range": 7809.437943975772,
+ "distinct_range": 7200.531236502802,
"num_eq": 1,
- "num_range": 7672,
- "upper_bound": "2823812"
+ "num_range": 7335,
+ "upper_bound": "2737088"
},
{
- "distinct_range": 7558.530232750052,
+ "distinct_range": 7415.844482618944,
"num_eq": 1,
- "num_range": 7524,
- "upper_bound": "2854502"
+ "num_range": 7445,
+ "upper_bound": "2765639"
},
{
- "distinct_range": 7834.688098603096,
+ "distinct_range": 7962.537752655243,
"num_eq": 1,
- "num_range": 7688,
- "upper_bound": "2889572"
+ "num_range": 7767,
+ "upper_bound": "2802818"
},
{
- "distinct_range": 7558.596008519145,
+ "distinct_range": 7817.207309665224,
"num_eq": 1,
- "num_range": 7525,
- "upper_bound": "2920263"
+ "num_range": 7676,
+ "upper_bound": "2837570"
},
{
- "distinct_range": 7714.177118412605,
+ "distinct_range": 7537.055701772968,
"num_eq": 1,
- "num_range": 7615,
- "upper_bound": "2953378"
+ "num_range": 7512,
+ "upper_bound": "2867911"
},
{
- "distinct_range": 7449.415404319716,
+ "distinct_range": 7719.812942769868,
"num_eq": 1,
- "num_range": 7464,
- "upper_bound": "2982439"
+ "num_range": 7617,
+ "upper_bound": "2901088"
},
{
- "distinct_range": 7680.086835978335,
+ "distinct_range": 7147.724864222316,
"num_eq": 1,
- "num_range": 7595,
- "upper_bound": "3015013"
+ "num_range": 7309,
+ "upper_bound": "2925954"
},
{
- "distinct_range": 7275.348177326162,
+ "distinct_range": 7680.086462516366,
"num_eq": 1,
- "num_range": 7373,
- "upper_bound": "3041603"
+ "num_range": 7594,
+ "upper_bound": "2958501"
},
{
- "distinct_range": 7807.5449075836395,
+ "distinct_range": 7122.621611682705,
"num_eq": 1,
- "num_range": 7671,
- "upper_bound": "3076227"
+ "num_range": 7297,
+ "upper_bound": "2983042"
},
{
- "distinct_range": 7148.961673075887,
+ "distinct_range": 7618.434205333506,
"num_eq": 1,
- "num_range": 7311,
- "upper_bound": "3101125"
+ "num_range": 7558,
+ "upper_bound": "3014626"
},
{
- "distinct_range": 7063.592433314881,
+ "distinct_range": 7361.990539306529,
"num_eq": 1,
- "num_range": 7271,
- "upper_bound": "3124930"
+ "num_range": 7417,
+ "upper_bound": "3042406"
},
{
- "distinct_range": 7328.679250032614,
+ "distinct_range": 7713.914683943693,
"num_eq": 1,
- "num_range": 7400,
- "upper_bound": "3152260"
+ "num_range": 7614,
+ "upper_bound": "3075489"
},
{
- "distinct_range": 7836.870497089403,
+ "distinct_range": 7372.973269296139,
"num_eq": 1,
- "num_range": 7689,
- "upper_bound": "3187366"
+ "num_range": 7422,
+ "upper_bound": "3103425"
},
{
- "distinct_range": 7492.22942994892,
+ "distinct_range": 7176.8933825922095,
"num_eq": 1,
- "num_range": 7488,
- "upper_bound": "3217059"
+ "num_range": 7323,
+ "upper_bound": "3128673"
},
{
- "distinct_range": 7614.719392888386,
+ "distinct_range": 7665.720877196955,
"num_eq": 1,
- "num_range": 7557,
- "upper_bound": "3248611"
+ "num_range": 7585,
+ "upper_bound": "3160994"
},
{
- "distinct_range": 7261.254335326455,
+ "distinct_range": 7900.435635972785,
"num_eq": 1,
- "num_range": 7366,
- "upper_bound": "3275008"
+ "num_range": 7727,
+ "upper_bound": "3197125"
},
{
- "distinct_range": 7554.31764865858,
+ "distinct_range": 7508.862093342321,
"num_eq": 1,
- "num_range": 7522,
- "upper_bound": "3305634"
+ "num_range": 7496,
+ "upper_bound": "3227043"
},
{
- "distinct_range": 7955.120255559488,
+ "distinct_range": 7397.383872299248,
"num_eq": 1,
- "num_range": 7763,
- "upper_bound": "3342721"
+ "num_range": 7435,
+ "upper_bound": "3255328"
},
{
- "distinct_range": 7303.6642445105435,
+ "distinct_range": 7206.236140027182,
"num_eq": 1,
- "num_range": 7387,
- "upper_bound": "3369702"
+ "num_range": 7338,
+ "upper_bound": "3280965"
},
{
- "distinct_range": 7328.607914768772,
+ "distinct_range": 7426.407522775977,
"num_eq": 1,
- "num_range": 7400,
- "upper_bound": "3397031"
+ "num_range": 7451,
+ "upper_bound": "3309669"
},
{
- "distinct_range": 7626.842713584108,
+ "distinct_range": 7651.484884096072,
"num_eq": 1,
- "num_range": 7563,
- "upper_bound": "3428771"
+ "num_range": 7577,
+ "upper_bound": "3341767"
},
{
- "distinct_range": 7520.40520815977,
+ "distinct_range": 7010.405084923877,
"num_eq": 1,
- "num_range": 7503,
- "upper_bound": "3458885"
+ "num_range": 7246,
+ "upper_bound": "3364898"
},
{
- "distinct_range": 6908.276040163995,
+ "distinct_range": 7734.202717628759,
"num_eq": 1,
- "num_range": 7202,
- "upper_bound": "3480806"
+ "num_range": 7626,
+ "upper_bound": "3398305"
},
{
- "distinct_range": 7681.859655300506,
+ "distinct_range": 7934.447960622574,
"num_eq": 1,
- "num_range": 7596,
- "upper_bound": "3513408"
+ "num_range": 7749,
+ "upper_bound": "3435008"
},
{
- "distinct_range": 7560.568626895423,
+ "distinct_range": 7364.106082029117,
"num_eq": 1,
- "num_range": 7526,
- "upper_bound": "3544129"
+ "num_range": 7418,
+ "upper_bound": "3462818"
},
{
- "distinct_range": 7427.215313927391,
+ "distinct_range": 7859.800315059194,
"num_eq": 1,
- "num_range": 7452,
- "upper_bound": "3572866"
+ "num_range": 7702,
+ "upper_bound": "3498272"
},
{
- "distinct_range": 7086.869672264396,
+ "distinct_range": 7402.531918848284,
"num_eq": 1,
- "num_range": 7281,
- "upper_bound": "3596965"
+ "num_range": 7438,
+ "upper_bound": "3526631"
},
{
- "distinct_range": 7143.664412466349,
+ "distinct_range": 7222.452225508105,
"num_eq": 1,
- "num_range": 7308,
- "upper_bound": "3621794"
+ "num_range": 7346,
+ "upper_bound": "3552485"
},
{
- "distinct_range": 7303.376139636816,
+ "distinct_range": 7549.502098071681,
"num_eq": 1,
- "num_range": 7387,
- "upper_bound": "3648771"
+ "num_range": 7518,
+ "upper_bound": "3583014"
},
{
- "distinct_range": 7221.096591341601,
+ "distinct_range": 7728.016145049116,
"num_eq": 1,
- "num_range": 7346,
- "upper_bound": "3674624"
+ "num_range": 7622,
+ "upper_bound": "3616322"
},
{
- "distinct_range": 7296.813053938428,
+ "distinct_range": 7251.331262765546,
"num_eq": 1,
- "num_range": 7384,
- "upper_bound": "3701510"
+ "num_range": 7360,
+ "upper_bound": "3642566"
},
{
- "distinct_range": 7570.805939534888,
+ "distinct_range": 7318.31908557303,
"num_eq": 1,
- "num_range": 7531,
- "upper_bound": "3732387"
+ "num_range": 7394,
+ "upper_bound": "3669732"
},
{
- "distinct_range": 7865.910576077637,
+ "distinct_range": 7746.107667329812,
"num_eq": 1,
- "num_range": 7707,
- "upper_bound": "3767974"
+ "num_range": 7633,
+ "upper_bound": "3703330"
},
{
- "distinct_range": 7659.504090628647,
+ "distinct_range": 7883.020590917778,
"num_eq": 1,
- "num_range": 7582,
- "upper_bound": "3800224"
+ "num_range": 7716,
+ "upper_bound": "3739170"
},
{
- "distinct_range": 7537.740094673585,
+ "distinct_range": 7620.82463901668,
"num_eq": 1,
- "num_range": 7513,
- "upper_bound": "3830599"
+ "num_range": 7559,
+ "upper_bound": "3770791"
},
{
- "distinct_range": 7581.205437040146,
+ "distinct_range": 7234.266575816272,
"num_eq": 1,
- "num_range": 7537,
- "upper_bound": "3861635"
+ "num_range": 7351,
+ "upper_bound": "3796804"
},
{
- "distinct_range": 6929.715108143893,
+ "distinct_range": 7618.369574316735,
"num_eq": 1,
- "num_range": 7211,
- "upper_bound": "3883808"
+ "num_range": 7558,
+ "upper_bound": "3828387"
},
{
- "distinct_range": 7838.991068307369,
+ "distinct_range": 7332.480987312735,
"num_eq": 1,
- "num_range": 7690,
- "upper_bound": "3918949"
+ "num_range": 7401,
+ "upper_bound": "3855751"
},
{
- "distinct_range": 7787.701193239545,
+ "distinct_range": 7124.87258646369,
"num_eq": 1,
- "num_range": 7659,
- "upper_bound": "3953249"
+ "num_range": 7298,
+ "upper_bound": "3880321"
},
{
- "distinct_range": 7247.302101870608,
+ "distinct_range": 8131.1046475913845,
"num_eq": 1,
- "num_range": 7359,
- "upper_bound": "3979456"
+ "num_range": 7876,
+ "upper_bound": "3920422"
},
{
- "distinct_range": 7768.428051011244,
+ "distinct_range": 7262.496838775527,
"num_eq": 1,
- "num_range": 7647,
- "upper_bound": "4013443"
+ "num_range": 7365,
+ "upper_bound": "3946818"
},
{
- "distinct_range": 7025.6285154671,
+ "distinct_range": 7196.243757015542,
"num_eq": 1,
- "num_range": 7253,
- "upper_bound": "4036775"
+ "num_range": 7333,
+ "upper_bound": "3972322"
},
{
- "distinct_range": 7185.110594923251,
+ "distinct_range": 7441.801026115462,
"num_eq": 1,
- "num_range": 7328,
- "upper_bound": "4062148"
+ "num_range": 7459,
+ "upper_bound": "4001250"
},
{
- "distinct_range": 7560.437158379888,
+ "distinct_range": 7466.027317453128,
"num_eq": 1,
- "num_range": 7526,
- "upper_bound": "4092867"
+ "num_range": 7472,
+ "upper_bound": "4030533"
},
{
- "distinct_range": 7629.030363159459,
+ "distinct_range": 7630.62623317995,
"num_eq": 1,
"num_range": 7565,
- "upper_bound": "4124641"
+ "upper_bound": "4062306"
},
{
- "distinct_range": 7558.661782861937,
+ "distinct_range": 7559.857421395373,
"num_eq": 1,
- "num_range": 7525,
- "upper_bound": "4155333"
+ "num_range": 7524,
+ "upper_bound": "4092992"
},
{
- "distinct_range": 7402.895650914906,
+ "distinct_range": 7065.221416264043,
"num_eq": 1,
- "num_range": 7439,
- "upper_bound": "4183718"
+ "num_range": 7271,
+ "upper_bound": "4116803"
},
{
- "distinct_range": 7503.170206953751,
+ "distinct_range": 7149.875097539047,
"num_eq": 1,
- "num_range": 7494,
- "upper_bound": "4213574"
+ "num_range": 7310,
+ "upper_bound": "4141697"
},
{
- "distinct_range": 7366.992679624095,
+ "distinct_range": 7366.149526802698,
"num_eq": 1,
- "num_range": 7420,
- "upper_bound": "4241445"
+ "num_range": 7419,
+ "upper_bound": "4169536"
},
{
- "distinct_range": 7533.167005505359,
+ "distinct_range": 8256.444772287476,
"num_eq": 1,
- "num_range": 7510,
- "upper_bound": "4271751"
+ "num_range": 7960,
+ "upper_bound": "4211878"
},
{
- "distinct_range": 7681.922952991072,
+ "distinct_range": 7297.364857229888,
"num_eq": 1,
- "num_range": 7596,
- "upper_bound": "4304354"
+ "num_range": 7383,
+ "upper_bound": "4238753"
},
{
- "distinct_range": 7321.965243662316,
+ "distinct_range": 7530.414400326045,
"num_eq": 1,
- "num_range": 7397,
- "upper_bound": "4331590"
+ "num_range": 7508,
+ "upper_bound": "4268994"
},
{
- "distinct_range": 7286.8281885641845,
+ "distinct_range": 7560.252474068937,
"num_eq": 1,
- "num_range": 7379,
- "upper_bound": "4358338"
+ "num_range": 7525,
+ "upper_bound": "4299686"
},
{
- "distinct_range": 7190.467282114254,
+ "distinct_range": 7634.872958862578,
"num_eq": 1,
- "num_range": 7331,
- "upper_bound": "4383782"
+ "num_range": 7567,
+ "upper_bound": "4331525"
},
{
- "distinct_range": 7305.680080681797,
+ "distinct_range": 7865.829251892401,
"num_eq": 1,
- "num_range": 7388,
- "upper_bound": "4410791"
+ "num_range": 7706,
+ "upper_bound": "4367079"
},
{
- "distinct_range": 7608.316814830814,
+ "distinct_range": 8079.679224975241,
"num_eq": 1,
- "num_range": 7553,
- "upper_bound": "4442244"
+ "num_range": 7842,
+ "upper_bound": "4406277"
},
{
- "distinct_range": 7190.39191838817,
+ "distinct_range": 7487.55687159489,
"num_eq": 1,
- "num_range": 7331,
- "upper_bound": "4467687"
+ "num_range": 7484,
+ "upper_bound": "4435878"
},
{
- "distinct_range": 7389.260707379398,
+ "distinct_range": 7834.496353576564,
"num_eq": 1,
- "num_range": 7432,
- "upper_bound": "4495876"
+ "num_range": 7686,
+ "upper_bound": "4470914"
},
{
- "distinct_range": 7877.5092223055635,
+ "distinct_range": 7584.175498890095,
"num_eq": 1,
- "num_range": 7774,
- "upper_bound": "4529761"
+ "num_range": 7606,
+ "upper_bound": "4500294"
},
{
- "distinct_range": 8009.424825166193,
+ "distinct_range": 7714.8478320686845,
"num_eq": 1,
- "num_range": 7854,
- "upper_bound": "4565792"
+ "num_range": 7678,
+ "upper_bound": "4531617"
},
{
- "distinct_range": 7500.355003878401,
+ "distinct_range": 7659.988681175482,
"num_eq": 1,
- "num_range": 7563,
- "upper_bound": "4593991"
+ "num_range": 7648,
+ "upper_bound": "4562114"
},
{
- "distinct_range": 7474.691981513833,
+ "distinct_range": 8218.96264316268,
"num_eq": 1,
- "num_range": 7549,
- "upper_bound": "4621829"
+ "num_range": 7986,
+ "upper_bound": "4601666"
},
{
- "distinct_range": 7999.929181013624,
+ "distinct_range": 8020.955043356342,
"num_eq": 1,
- "num_range": 7848,
- "upper_bound": "4657703"
+ "num_range": 7860,
+ "upper_bound": "4637856"
},
{
- "distinct_range": 8136.903125153307,
+ "distinct_range": 7707.004079858277,
"num_eq": 1,
- "num_range": 7934,
- "upper_bound": "4695878"
+ "num_range": 7674,
+ "upper_bound": "4669060"
},
{
- "distinct_range": 7869.299701941001,
+ "distinct_range": 7810.702713523131,
"num_eq": 1,
- "num_range": 7769,
- "upper_bound": "4729632"
+ "num_range": 7733,
+ "upper_bound": "4701861"
},
{
- "distinct_range": 7819.1853251542525,
+ "distinct_range": 7382.728439757738,
"num_eq": 1,
- "num_range": 7739,
- "upper_bound": "4762593"
+ "num_range": 7502,
+ "upper_bound": "4728416"
},
{
- "distinct_range": 7339.074300935531,
+ "distinct_range": 7376.050373093157,
"num_eq": 1,
- "num_range": 7481,
- "upper_bound": "4788581"
+ "num_range": 7499,
+ "upper_bound": "4754881"
},
{
- "distinct_range": 7715.788254238158,
+ "distinct_range": 7566.241758964452,
"num_eq": 1,
- "num_range": 7680,
- "upper_bound": "4819943"
+ "num_range": 7597,
+ "upper_bound": "4784001"
},
{
- "distinct_range": 7688.065779774202,
+ "distinct_range": 7521.675923127131,
"num_eq": 1,
- "num_range": 7664,
- "upper_bound": "4850885"
+ "num_range": 7573,
+ "upper_bound": "4812482"
},
{
- "distinct_range": 7548.953952308609,
+ "distinct_range": 8003.8458268542545,
"num_eq": 1,
- "num_range": 7588,
- "upper_bound": "4879777"
+ "num_range": 7849,
+ "upper_bound": "4848389"
},
{
- "distinct_range": 7433.444084034987,
+ "distinct_range": 7512.59172464161,
"num_eq": 1,
- "num_range": 7528,
- "upper_bound": "4907042"
+ "num_range": 7568,
+ "upper_bound": "4876741"
},
{
- "distinct_range": 7309.527802399476,
+ "distinct_range": 7478.450417762694,
"num_eq": 1,
- "num_range": 7467,
- "upper_bound": "4932640"
+ "num_range": 7550,
+ "upper_bound": "4904612"
},
{
- "distinct_range": 7263.354506992384,
+ "distinct_range": 7366.22375630842,
"num_eq": 1,
- "num_range": 7445,
- "upper_bound": "4957638"
+ "num_range": 7494,
+ "upper_bound": "4930945"
},
{
- "distinct_range": 7416.849040636232,
+ "distinct_range": 8036.72868369072,
"num_eq": 1,
- "num_range": 7520,
- "upper_bound": "4984675"
+ "num_range": 7870,
+ "upper_bound": "4967397"
},
{
- "distinct_range": 7972.643066552632,
+ "distinct_range": 7397.063846153433,
"num_eq": 1,
- "num_range": 7831,
- "upper_bound": "5020100"
+ "num_range": 7509,
+ "upper_bound": "4994146"
},
{
- "distinct_range": 7513.2016243210965,
+ "distinct_range": 7623.309730648431,
"num_eq": 1,
- "num_range": 7569,
- "upper_bound": "5048481"
+ "num_range": 7627,
+ "upper_bound": "5024099"
},
{
- "distinct_range": 7701.231762987105,
+ "distinct_range": 7881.740435988881,
"num_eq": 1,
- "num_range": 7672,
- "upper_bound": "5079622"
+ "num_range": 7775,
+ "upper_bound": "5058023"
},
{
- "distinct_range": 7641.16275159479,
+ "distinct_range": 8099.450634180005,
"num_eq": 1,
- "num_range": 7638,
- "upper_bound": "5109862"
+ "num_range": 7909,
+ "upper_bound": "5095527"
},
{
- "distinct_range": 7302.123040362028,
+ "distinct_range": 7382.654335834017,
"num_eq": 1,
- "num_range": 7463,
- "upper_bound": "5135363"
+ "num_range": 7502,
+ "upper_bound": "5122081"
},
{
- "distinct_range": 8007.612161088768,
+ "distinct_range": 7992.316747119505,
"num_eq": 1,
- "num_range": 7852,
- "upper_bound": "5171364"
+ "num_range": 7842,
+ "upper_bound": "5157798"
},
{
- "distinct_range": 7343.7388379608465,
+ "distinct_range": 7464.34158288911,
"num_eq": 1,
- "num_range": 7484,
- "upper_bound": "5197414"
+ "num_range": 7543,
+ "upper_bound": "5185472"
},
{
- "distinct_range": 7865.281957424044,
+ "distinct_range": 7616.99365370458,
"num_eq": 1,
- "num_range": 7766,
- "upper_bound": "5231104"
+ "num_range": 7624,
+ "upper_bound": "5215332"
},
{
- "distinct_range": 7277.84110430619,
+ "distinct_range": 7427.535886197532,
"num_eq": 1,
- "num_range": 7452,
- "upper_bound": "5256289"
+ "num_range": 7524,
+ "upper_bound": "5242497"
},
{
- "distinct_range": 8317.133509500793,
+ "distinct_range": 7476.30666195313,
"num_eq": 1,
- "num_range": 8051,
- "upper_bound": "5297604"
+ "num_range": 7549,
+ "upper_bound": "5270338"
},
{
- "distinct_range": 7654.197473516664,
+ "distinct_range": 8207.951589336944,
"num_eq": 1,
- "num_range": 7645,
- "upper_bound": "5328038"
+ "num_range": 7978,
+ "upper_bound": "5309699"
},
{
- "distinct_range": 7794.201394982428,
+ "distinct_range": 7516.891093161458,
"num_eq": 1,
- "num_range": 7725,
- "upper_bound": "5360608"
+ "num_range": 7570,
+ "upper_bound": "5338112"
},
{
- "distinct_range": 7319.492307680189,
+ "distinct_range": 8112.860816549409,
"num_eq": 1,
- "num_range": 7472,
- "upper_bound": "5386337"
+ "num_range": 7917,
+ "upper_bound": "5375843"
},
{
- "distinct_range": 7412.537320772235,
+ "distinct_range": 7599.126398872648,
"num_eq": 1,
- "num_range": 7518,
- "upper_bound": "5413315"
+ "num_range": 7614,
+ "upper_bound": "5405441"
},
{
- "distinct_range": 7972.826027402018,
+ "distinct_range": 8059.735358437824,
"num_eq": 1,
- "num_range": 7831,
- "upper_bound": "5448743"
+ "num_range": 7884,
+ "upper_bound": "5442277"
},
{
- "distinct_range": 7140.152521668399,
+ "distinct_range": 7534.791646010756,
"num_eq": 1,
- "num_range": 7388,
- "upper_bound": "5472197"
+ "num_range": 7580,
+ "upper_bound": "5470945"
},
{
- "distinct_range": 7837.09036847005,
+ "distinct_range": 8357.040353053619,
"num_eq": 1,
- "num_range": 7750,
- "upper_bound": "5505440"
+ "num_range": 8077,
+ "upper_bound": "5512930"
},
{
- "distinct_range": 7467.969205922932,
+ "distinct_range": 7751.110177395089,
"num_eq": 1,
- "num_range": 7546,
- "upper_bound": "5533184"
+ "num_range": 7699,
+ "upper_bound": "5544807"
},
{
- "distinct_range": 7784.502530392918,
+ "distinct_range": 7638.197468163109,
"num_eq": 1,
- "num_range": 7719,
- "upper_bound": "5565603"
+ "num_range": 7636,
+ "upper_bound": "5574980"
},
{
- "distinct_range": 7132.430582441498,
+ "distinct_range": 7441.69727889883,
"num_eq": 1,
- "num_range": 7385,
- "upper_bound": "5588963"
+ "num_range": 7531,
+ "upper_bound": "5602340"
},
{
- "distinct_range": 7305.1029375348835,
+ "distinct_range": 7411.099379330719,
"num_eq": 1,
- "num_range": 7465,
- "upper_bound": "5614503"
+ "num_range": 7516,
+ "upper_bound": "5629280"
},
{
- "distinct_range": 7312.117938080864,
+ "distinct_range": 7706.872083994984,
"num_eq": 1,
- "num_range": 7468,
- "upper_bound": "5640135"
+ "num_range": 7674,
+ "upper_bound": "5660482"
},
{
- "distinct_range": 7938.825875418823,
+ "distinct_range": 7893.804910587482,
"num_eq": 1,
- "num_range": 7810,
- "upper_bound": "5675008"
+ "num_range": 7782,
+ "upper_bound": "5694599"
},
{
- "distinct_range": 7865.972835283134,
+ "distinct_range": 7750.459256622187,
"num_eq": 1,
- "num_range": 7767,
- "upper_bound": "5708709"
+ "num_range": 7699,
+ "upper_bound": "5726466"
},
{
- "distinct_range": 7400.440586827354,
+ "distinct_range": 7345.250772931715,
"num_eq": 1,
- "num_range": 7512,
- "upper_bound": "5735522"
+ "num_range": 7483,
+ "upper_bound": "5752519"
},
{
- "distinct_range": 7647.8887619055595,
+ "distinct_range": 7933.0308605229,
"num_eq": 1,
- "num_range": 7642,
- "upper_bound": "5765862"
+ "num_range": 7806,
+ "upper_bound": "5787268"
},
{
- "distinct_range": 7771.870559242789,
+ "distinct_range": 7881.302094040679,
"num_eq": 1,
- "num_range": 7712,
- "upper_bound": "5798085"
+ "num_range": 7775,
+ "upper_bound": "5821185"
},
{
- "distinct_range": 7802.656727769448,
+ "distinct_range": 7679.427389066794,
"num_eq": 1,
- "num_range": 7730,
- "upper_bound": "5830787"
+ "num_range": 7658,
+ "upper_bound": "5851973"
},
{
- "distinct_range": 7630.369457583342,
+ "distinct_range": 7674.629342330302,
"num_eq": 1,
- "num_range": 7632,
- "upper_bound": "5860867"
+ "num_range": 7656,
+ "upper_bound": "5882689"
},
{
- "distinct_range": 7811.218346558417,
+ "distinct_range": 7535.211446390379,
"num_eq": 1,
- "num_range": 7735,
- "upper_bound": "5893703"
+ "num_range": 7580,
+ "upper_bound": "5911363"
},
{
- "distinct_range": 8134.911690228585,
+ "distinct_range": 7392.6388373235295,
"num_eq": 1,
- "num_range": 7932,
- "upper_bound": "5931844"
+ "num_range": 7507,
+ "upper_bound": "5938052"
},
{
- "distinct_range": 7546.867637258427,
+ "distinct_range": 7816.833266536233,
"num_eq": 1,
- "num_range": 7587,
- "upper_bound": "5960706"
+ "num_range": 7737,
+ "upper_bound": "5970949"
},
{
- "distinct_range": 8185.701071657469,
+ "distinct_range": 7543.942940510782,
"num_eq": 1,
- "num_range": 7965,
- "upper_bound": "5999719"
+ "num_range": 7585,
+ "upper_bound": "5999748"
},
{
- "distinct_range": 1.1641532182693481E-10,
+ "distinct_range": 6.984919309616089E-10,
"num_eq": 0,
"num_range": 0,
"upper_bound": "9223372036854775807"
@@ -10672,1211 +10715,1212 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 4,
"columns": [
"o_custkey"
],
- "created_at": "2021-09-08 20:49:26.228164",
- "distinct_count": 99853,
+ "created_at": "2022-02-25 00:54:45.88743",
+ "distinct_count": 99846,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 150,
"num_range": 0,
- "upper_bound": "25"
+ "upper_bound": "4"
},
{
- "distinct_range": 487.09873066147543,
+ "distinct_range": 634.419663300344,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "758"
+ "upper_bound": "959"
},
{
- "distinct_range": 466.47747953358316,
+ "distinct_range": 597.2815248021925,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "1460"
+ "upper_bound": "1858"
},
{
- "distinct_range": 496.4103648035753,
+ "distinct_range": 607.8974782199557,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "2207"
+ "upper_bound": "2773"
},
{
- "distinct_range": 467.80797750138504,
+ "distinct_range": 460.38259288212737,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "2911"
+ "upper_bound": "3466"
},
{
- "distinct_range": 568.2030262376672,
- "num_eq": 150,
- "num_range": 7350,
- "upper_bound": "3766"
+ "distinct_range": 576.0169729076262,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "4333"
},
{
- "distinct_range": 548.9341844255322,
+ "distinct_range": 460.38259288212737,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "4592"
+ "upper_bound": "5026"
},
{
- "distinct_range": 517.6905642768054,
- "num_eq": 150,
- "num_range": 7350,
- "upper_bound": "5371"
+ "distinct_range": 562.0745133828206,
+ "num_eq": 450,
+ "num_range": 7200,
+ "upper_bound": "5872"
},
{
- "distinct_range": 471.1341699612908,
+ "distinct_range": 464.37327339722094,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "6080"
+ "upper_bound": "6571"
},
{
- "distinct_range": 460.490098490584,
+ "distinct_range": 330.6583833978841,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "6773"
+ "upper_bound": "7069"
},
{
- "distinct_range": 430.55038100803205,
+ "distinct_range": 550.1348567682413,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "7421"
+ "upper_bound": "7897"
},
{
- "distinct_range": 390.6260900729995,
+ "distinct_range": 474.349517178844,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "8009"
+ "upper_bound": "8611"
},
{
- "distinct_range": 437.86934352377085,
+ "distinct_range": 599.9358574199939,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "8668"
+ "upper_bound": "9514"
},
{
- "distinct_range": 608.0394305641271,
+ "distinct_range": 528.2051120534144,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "9583"
+ "upper_bound": "10309"
},
{
- "distinct_range": 582.1508882112205,
+ "distinct_range": 484.3250193842983,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "10459"
+ "upper_bound": "11038"
},
{
- "distinct_range": 439.20004183588594,
+ "distinct_range": 568.0703740649869,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "11120"
+ "upper_bound": "11893"
},
{
- "distinct_range": 499.7357386980566,
- "num_eq": 300,
+ "distinct_range": 490.9748834181482,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "11872"
+ "upper_bound": "12632"
},
{
- "distinct_range": 564.8813979734011,
+ "distinct_range": 543.4903865641995,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "12722"
+ "upper_bound": "13450"
},
{
- "distinct_range": 591.4465550757681,
+ "distinct_range": 434.4411192655975,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "13612"
+ "upper_bound": "14104"
},
{
- "distinct_range": 517.0256429231772,
+ "distinct_range": 544.1548712006161,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "14390"
+ "upper_bound": "14923"
},
{
- "distinct_range": 524.3394393983798,
- "num_eq": 150,
- "num_range": 7350,
- "upper_bound": "15179"
+ "distinct_range": 528.8592173995188,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "15719"
},
{
- "distinct_range": 453.83720352463104,
+ "distinct_range": 440.4278869863655,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "15862"
+ "upper_bound": "16382"
},
{
- "distinct_range": 528.9932675042556,
+ "distinct_range": 489.64494304226184,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "16658"
+ "upper_bound": "17119"
},
{
- "distinct_range": 382.6408662763843,
+ "distinct_range": 506.9327598912881,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "17234"
+ "upper_bound": "17882"
},
{
- "distinct_range": 564.2170414944701,
+ "distinct_range": 544.1548712006161,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "18083"
+ "upper_bound": "18701"
},
{
- "distinct_range": 517.6905642768054,
+ "distinct_range": 581.351065903457,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "18862"
+ "upper_bound": "19576"
},
{
- "distinct_range": 475.12549737014314,
+ "distinct_range": 490.30991531559613,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "19577"
+ "upper_bound": "20314"
},
{
- "distinct_range": 372.65900534427385,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "20138"
+ "distinct_range": 422.467194875143,
+ "num_eq": 150,
+ "num_range": 7350,
+ "upper_bound": "20950"
},
{
- "distinct_range": 485.7684310706443,
+ "distinct_range": 516.2401665045888,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "20869"
+ "upper_bound": "21727"
},
{
- "distinct_range": 515.0308433479466,
+ "distinct_range": 354.6092665386226,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "21644"
+ "upper_bound": "22261"
},
{
- "distinct_range": 412.5849162738522,
+ "distinct_range": 530.1990628082668,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "22265"
+ "upper_bound": "23059"
},
{
- "distinct_range": 558.2373859982524,
+ "distinct_range": 420.47149657531554,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "23105"
+ "upper_bound": "23692"
},
{
- "distinct_range": 572.1886319738434,
+ "distinct_range": 528.8697692069439,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "23966"
+ "upper_bound": "24488"
},
{
- "distinct_range": 542.2879950112214,
+ "distinct_range": 435.77152426266537,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "24782"
+ "upper_bound": "25144"
},
{
- "distinct_range": 498.4056030895973,
+ "distinct_range": 498.9541606519472,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "25532"
+ "upper_bound": "25895"
},
{
- "distinct_range": 521.6799646072122,
+ "distinct_range": 566.077893408884,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "26317"
+ "upper_bound": "26747"
},
{
- "distinct_range": 501.06585530910706,
+ "distinct_range": 599.9358574199939,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "27071"
+ "upper_bound": "27650"
},
{
- "distinct_range": 393.95324028875757,
- "num_eq": 150,
+ "distinct_range": 503.6084307208789,
+ "num_eq": 300,
"num_range": 7350,
- "upper_bound": "27664"
+ "upper_bound": "28408"
},
{
- "distinct_range": 498.4056030895973,
+ "distinct_range": 486.3200204843193,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "28414"
+ "upper_bound": "29140"
},
{
- "distinct_range": 582.8149450886858,
+ "distinct_range": 518.2344648199613,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "29291"
+ "upper_bound": "29920"
},
{
- "distinct_range": 535.6410033623071,
- "num_eq": 150,
+ "distinct_range": 392.5307209467972,
+ "num_eq": 300,
"num_range": 7350,
- "upper_bound": "30097"
+ "upper_bound": "30511"
},
{
- "distinct_range": 544.9465703808315,
- "num_eq": 150,
+ "distinct_range": 498.28924576119016,
+ "num_eq": 300,
"num_range": 7350,
- "upper_bound": "30917"
+ "upper_bound": "31261"
},
{
- "distinct_range": 434.54256718649486,
+ "distinct_range": 490.30991531559613,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "31571"
+ "upper_bound": "31999"
},
{
- "distinct_range": 522.3448428916699,
+ "distinct_range": 611.8774814668541,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "32357"
+ "upper_bound": "32920"
},
{
- "distinct_range": 543.6172989748799,
+ "distinct_range": 510.2569581476869,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "33175"
+ "upper_bound": "33688"
+ },
+ {
+ "distinct_range": 556.0975988040657,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "34525"
},
{
- "distinct_range": 428.5542668882312,
+ "distinct_range": 446.4145041921914,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "33820"
+ "upper_bound": "35197"
},
{
- "distinct_range": 570.1958774184482,
+ "distinct_range": 451.0706469598643,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "34678"
+ "upper_bound": "35876"
},
{
- "distinct_range": 420.5696823989693,
+ "distinct_range": 467.6987634674091,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "35311"
+ "upper_bound": "36580"
},
{
- "distinct_range": 414.5811232411703,
- "num_eq": 300,
+ "distinct_range": 486.9850130254397,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "35935"
+ "upper_bound": "37313"
},
{
- "distinct_range": 501.06585530910706,
+ "distinct_range": 405.8360578383347,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "36689"
+ "upper_bound": "37924"
},
{
- "distinct_range": 445.8534210033777,
+ "distinct_range": 560.7641626273557,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "37360"
+ "upper_bound": "38768"
},
{
- "distinct_range": 404.599996557327,
+ "distinct_range": 446.4145041921914,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "37969"
+ "upper_bound": "39440"
},
{
- "distinct_range": 546.9404153915351,
+ "distinct_range": 456.3918175815247,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "38792"
+ "upper_bound": "40127"
},
{
- "distinct_range": 431.88111609969206,
+ "distinct_range": 583.3427713709922,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "39442"
+ "upper_bound": "41005"
},
{
- "distinct_range": 548.9341844255322,
+ "distinct_range": 534.8513672487994,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "40268"
+ "upper_bound": "41810"
},
{
- "distinct_range": 515.695782409449,
+ "distinct_range": 406.50131588312485,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "41044"
+ "upper_bound": "42422"
},
{
- "distinct_range": 406.596239479234,
+ "distinct_range": 589.9809863458224,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "41656"
+ "upper_bound": "43310"
},
{
- "distinct_range": 474.46028425443257,
+ "distinct_range": 521.5581736670844,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "42370"
+ "upper_bound": "44095"
},
{
- "distinct_range": 475.1217635038806,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "43085"
+ "distinct_range": 364.588719720691,
+ "num_eq": 150,
+ "num_range": 7350,
+ "upper_bound": "44644"
},
{
- "distinct_range": 547.5906006367816,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "43909"
+ "distinct_range": 467.03367125883,
+ "num_eq": 150,
+ "num_range": 7350,
+ "upper_bound": "45347"
},
{
- "distinct_range": 507.0511355980183,
+ "distinct_range": 413.81908961307164,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "44672"
+ "upper_bound": "45970"
},
{
- "distinct_range": 434.54256718649486,
+ "distinct_range": 441.0930744129923,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "45326"
+ "upper_bound": "46634"
},
{
- "distinct_range": 653.7825615066006,
+ "distinct_range": 431.78028951879617,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "46310"
+ "upper_bound": "47284"
},
{
- "distinct_range": 558.2373859982524,
+ "distinct_range": 512.2514118583252,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "47150"
+ "upper_bound": "48055"
},
{
- "distinct_range": 432.5464812890775,
+ "distinct_range": 528.2051120534144,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "47801"
+ "upper_bound": "48850"
},
{
- "distinct_range": 506.3861248015423,
+ "distinct_range": 572.7191239732628,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "48563"
+ "upper_bound": "49712"
},
{
- "distinct_range": 513.7009478602478,
+ "distinct_range": 427.7889979717629,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "49336"
+ "upper_bound": "50356"
},
{
- "distinct_range": 515.0308433479466,
+ "distinct_range": 605.9072714483575,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "50111"
+ "upper_bound": "51268"
},
{
- "distinct_range": 422.56479701329425,
+ "distinct_range": 518.2257224618461,
"num_eq": 300,
"num_range": 7200,
- "upper_bound": "50747"
+ "upper_bound": "52048"
},
{
- "distinct_range": 587.4629999596574,
+ "distinct_range": 347.29096526543526,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "51631"
- },
- {
- "distinct_range": 411.25334060040706,
- "num_eq": 450,
- "num_range": 7200,
- "upper_bound": "52250"
+ "upper_bound": "52571"
},
{
- "distinct_range": 413.91572200905625,
+ "distinct_range": 367.9151888784711,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "52873"
+ "upper_bound": "53125"
},
{
- "distinct_range": 584.7817190376594,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "53753"
- },
- {
- "distinct_range": 584.1430224400463,
- "num_eq": 300,
+ "distinct_range": 639.720708451293,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "54632"
+ "upper_bound": "54088"
},
{
- "distinct_range": 459.8248203718307,
+ "distinct_range": 548.1416047579401,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "55324"
+ "upper_bound": "54913"
},
{
- "distinct_range": 542.9526510328842,
+ "distinct_range": 570.0627599965053,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "56141"
+ "upper_bound": "55771"
},
{
- "distinct_range": 520.3501891741873,
+ "distinct_range": 408.4970843591719,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "56924"
+ "upper_bound": "56386"
},
{
- "distinct_range": 398.61122096359804,
+ "distinct_range": 464.37327339722094,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "57524"
+ "upper_bound": "57085"
},
{
- "distinct_range": 570.1958774184482,
+ "distinct_range": 526.2110998289132,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "58382"
+ "upper_bound": "57877"
},
{
- "distinct_range": 456.49839128957166,
+ "distinct_range": 566.077893408884,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "59069"
+ "upper_bound": "58729"
},
{
- "distinct_range": 562.223911628734,
- "num_eq": 150,
- "num_range": 7350,
- "upper_bound": "59915"
+ "distinct_range": 414.48349406204096,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "59353"
},
{
- "distinct_range": 574.1812880050387,
+ "distinct_range": 518.2344648199613,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "60779"
+ "upper_bound": "60133"
},
{
- "distinct_range": 456.49839128957166,
+ "distinct_range": 540.8323672394422,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "61466"
+ "upper_bound": "60947"
},
{
- "distinct_range": 558.2203242172164,
+ "distinct_range": 481.66496453956546,
"num_eq": 300,
- "num_range": 7200,
- "upper_bound": "62306"
+ "num_range": 7350,
+ "upper_bound": "61672"
},
{
- "distinct_range": 488.42901434348073,
+ "distinct_range": 490.9748834181482,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "63041"
+ "upper_bound": "62411"
},
{
- "distinct_range": 503.72603015145165,
+ "distinct_range": 587.9896542580716,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "63799"
+ "upper_bound": "63296"
},
{
- "distinct_range": 409.2578835660697,
+ "distinct_range": 467.6987634674091,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "64415"
+ "upper_bound": "64000"
},
{
- "distinct_range": 688.7621211281698,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "65452"
+ "distinct_range": 389.2043408898231,
+ "num_eq": 150,
+ "num_range": 7350,
+ "upper_bound": "64586"
},
{
- "distinct_range": 540.9586589663928,
+ "distinct_range": 441.75825995986173,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "66266"
+ "upper_bound": "65251"
},
{
- "distinct_range": 524.3297098273562,
+ "distinct_range": 440.4278869863655,
"num_eq": 300,
- "num_range": 7200,
- "upper_bound": "67055"
+ "num_range": 7350,
+ "upper_bound": "65914"
},
{
- "distinct_range": 464.4817108839535,
- "num_eq": 300,
+ "distinct_range": 324.67063473475525,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "67754"
+ "upper_bound": "66403"
},
{
- "distinct_range": 502.3894559664522,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "68510"
+ "distinct_range": 390.53489485375377,
+ "num_eq": 150,
+ "num_range": 7350,
+ "upper_bound": "66991"
},
{
- "distinct_range": 558.2373859982524,
+ "distinct_range": 536.1805314939674,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "69350"
+ "upper_bound": "67798"
},
{
- "distinct_range": 516.3607156175829,
+ "distinct_range": 462.37794538212387,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "70127"
+ "upper_bound": "68494"
},
{
- "distinct_range": 381.97542731105494,
+ "distinct_range": 605.9072714483575,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "70702"
+ "upper_bound": "69406"
},
{
- "distinct_range": 505.0560876789784,
+ "distinct_range": 465.0383771548559,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "71462"
+ "upper_bound": "70106"
},
{
- "distinct_range": 641.8581310329438,
+ "distinct_range": 541.4838172410665,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "70921"
+ },
+ {
+ "distinct_range": 564.0853198862395,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "72428"
+ "upper_bound": "71770"
},
{
- "distinct_range": 557.5729313651864,
+ "distinct_range": 473.019391706567,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "73267"
+ "upper_bound": "72482"
},
{
- "distinct_range": 490.42440936162063,
+ "distinct_range": 514.245815077231,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "74005"
+ "upper_bound": "73256"
},
{
- "distinct_range": 474.46028425443257,
+ "distinct_range": 549.4704480969368,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "74719"
+ "upper_bound": "74083"
},
{
- "distinct_range": 648.4836362313513,
- "num_eq": 300,
+ "distinct_range": 397.1876243362467,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "75695"
+ "upper_bound": "74681"
},
{
- "distinct_range": 468.47322205220996,
+ "distinct_range": 485.65502400516675,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "76400"
+ "upper_bound": "75412"
},
{
- "distinct_range": 398.61122096359804,
+ "distinct_range": 524.2170275796348,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "77000"
+ "upper_bound": "76201"
},
{
- "distinct_range": 633.2420500512909,
+ "distinct_range": 448.4100068686594,
"num_eq": 300,
"num_range": 7350,
- "upper_bound": "77953"
+ "upper_bound": "76876"
},
{
- "distinct_range": 401.2729073311907,
+ "distinct_range": 536.8451024023464,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "78557"
+ "upper_bound": "77684"
},
{
- "distinct_range": 503.72603015145165,
+ "distinct_range": 489.64494304226184,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "79315"
+ "upper_bound": "78421"
},
{
- "distinct_range": 405.26541177578986,
+ "distinct_range": 423.1324250423067,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "79925"
+ "upper_bound": "79058"
},
{
- "distinct_range": 401.9383268839923,
+ "distinct_range": 565.4137124620019,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "80530"
+ "upper_bound": "79909"
},
{
- "distinct_range": 458.4942563511326,
+ "distinct_range": 453.06610352382353,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "81220"
+ "upper_bound": "80591"
},
{
- "distinct_range": 453.17190063232295,
+ "distinct_range": 435.77152426266537,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "81902"
+ "upper_bound": "81247"
},
{
- "distinct_range": 468.47322205220996,
+ "distinct_range": 476.34468061526053,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "82607"
+ "upper_bound": "81964"
},
{
- "distinct_range": 379.97910734105005,
+ "distinct_range": 578.6952915429015,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "83179"
+ "upper_bound": "82835"
},
{
- "distinct_range": 562.223911628734,
+ "distinct_range": 595.2906300966209,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "84025"
+ "upper_bound": "83731"
},
{
- "distinct_range": 627.9382840157838,
+ "distinct_range": 488.97996663754475,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "84970"
+ "upper_bound": "84467"
},
{
- "distinct_range": 580.822738425197,
+ "distinct_range": 361.9275385227952,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "85844"
+ "upper_bound": "85012"
},
{
- "distinct_range": 540.2939790613342,
+ "distinct_range": 572.7191239732628,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "86657"
+ "upper_bound": "85874"
},
{
- "distinct_range": 350.0338873167435,
- "num_eq": 300,
+ "distinct_range": 513.5810196942666,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "87184"
+ "upper_bound": "86647"
},
{
- "distinct_range": 566.8744060316183,
+ "distinct_range": 334.65021102162234,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "88037"
+ "upper_bound": "87151"
},
{
- "distinct_range": 533.6467581739387,
+ "distinct_range": 466.3685761164783,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "88840"
+ "upper_bound": "87853"
},
{
- "distinct_range": 459.1595396491083,
+ "distinct_range": 458.38721669020515,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "89531"
+ "upper_bound": "88543"
},
{
- "distinct_range": 400.6074869502509,
+ "distinct_range": 585.998207767351,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "90134"
+ "upper_bound": "89425"
},
{
- "distinct_range": 504.3910614433721,
+ "distinct_range": 412.48859456658977,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "90893"
+ "upper_bound": "90046"
},
{
- "distinct_range": 503.72603015145165,
+ "distinct_range": 394.5265409599835,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "91651"
+ "upper_bound": "90640"
},
{
- "distinct_range": 582.8149450886858,
+ "distinct_range": 600.5994054585332,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "92528"
+ "upper_bound": "91544"
},
{
- "distinct_range": 498.4056030895973,
+ "distinct_range": 473.684456071643,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "93278"
+ "upper_bound": "92257"
},
{
- "distinct_range": 442.5267555063047,
+ "distinct_range": 564.7495212650983,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "93944"
+ "upper_bound": "93107"
},
{
- "distinct_range": 421.90045990230146,
+ "distinct_range": 483.6600113177469,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "94579"
+ "upper_bound": "93835"
},
{
- "distinct_range": 749.5361696028739,
+ "distinct_range": 391.20017087567055,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "95708"
+ "upper_bound": "94424"
},
{
- "distinct_range": 408.59247399441387,
+ "distinct_range": 637.0703378243263,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "96323"
+ "upper_bound": "95383"
},
{
- "distinct_range": 565.5457442679992,
+ "distinct_range": 617.8464263873426,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "97174"
+ "upper_bound": "96313"
},
{
- "distinct_range": 453.17190063232295,
+ "distinct_range": 415.14958027847956,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "97856"
+ "upper_bound": "96938"
},
{
- "distinct_range": 495.74527624405687,
+ "distinct_range": 578.031318610409,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "98602"
+ "upper_bound": "97808"
},
{
- "distinct_range": 437.2039917049541,
- "num_eq": 300,
+ "distinct_range": 585.3343672035446,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "99260"
+ "upper_bound": "98689"
},
{
- "distinct_range": 469.8037021296245,
+ "distinct_range": 542.1613929386612,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "99967"
+ "upper_bound": "99505"
},
{
- "distinct_range": 398.61122096359804,
- "num_eq": 300,
+ "distinct_range": 424.4628813707588,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "100567"
+ "upper_bound": "100144"
+ },
+ {
+ "distinct_range": 556.0975988040657,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "100981"
},
{
- "distinct_range": 426.55813945956396,
+ "distinct_range": 542.1613929386612,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "101209"
+ "upper_bound": "101797"
},
{
- "distinct_range": 474.46028425443257,
+ "distinct_range": 504.273306755186,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "101923"
+ "upper_bound": "102556"
},
{
- "distinct_range": 538.9645957792709,
- "num_eq": 300,
+ "distinct_range": 629.7802693802151,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "102734"
+ "upper_bound": "103504"
},
{
- "distinct_range": 535.6410033623071,
+ "distinct_range": 404.5055390023133,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "103540"
+ "upper_bound": "104113"
},
{
- "distinct_range": 572.8528616923891,
+ "distinct_range": 576.0393305605581,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "104402"
+ "upper_bound": "104980"
},
{
- "distinct_range": 464.4817108839535,
+ "distinct_range": 426.45855557605586,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "105101"
+ "upper_bound": "105622"
},
{
- "distinct_range": 500.40079939978204,
+ "distinct_range": 411.1580952621614,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "105854"
+ "upper_bound": "106241"
},
{
- "distinct_range": 540.2939790613342,
+ "distinct_range": 496.29447328172216,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "106667"
+ "upper_bound": "106988"
},
{
- "distinct_range": 609.3664694653594,
- "num_eq": 450,
+ "distinct_range": 391.86544624356884,
+ "num_eq": 150,
"num_range": 7350,
- "upper_bound": "107584"
+ "upper_bound": "107578"
},
{
- "distinct_range": 675.6256085254955,
+ "distinct_range": 480.9999415431384,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "108601"
+ "upper_bound": "108302"
},
{
- "distinct_range": 508.38114143326305,
+ "distinct_range": 400.51396148297584,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "109366"
+ "upper_bound": "108905"
},
{
- "distinct_range": 544.281938777513,
+ "distinct_range": 571.3909637327166,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "110185"
+ "upper_bound": "109765"
},
{
- "distinct_range": 614.0106197715228,
+ "distinct_range": 596.6179069332327,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "111109"
+ "upper_bound": "110663"
},
{
- "distinct_range": 644.5085742366446,
+ "distinct_range": 495.62953999318677,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "112079"
+ "upper_bound": "111409"
},
{
- "distinct_range": 420.5696823989693,
+ "distinct_range": 454.39639631361183,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "112712"
+ "upper_bound": "112093"
},
{
- "distinct_range": 440.5307328990993,
+ "distinct_range": 624.4770275449567,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "113375"
+ "upper_bound": "113033"
},
{
- "distinct_range": 473.7950678464011,
+ "distinct_range": 431.78028951879617,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "114088"
+ "upper_bound": "113683"
},
{
- "distinct_range": 419.2388998582042,
+ "distinct_range": 440.4278869863655,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "114719"
+ "upper_bound": "114346"
},
{
- "distinct_range": 458.4942563511326,
+ "distinct_range": 438.43231365560644,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "115409"
+ "upper_bound": "115006"
},
{
- "distinct_range": 556.2439938079835,
+ "distinct_range": 526.2110998289132,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "116246"
+ "upper_bound": "115798"
},
{
- "distinct_range": 519.6852921277974,
+ "distinct_range": 307.37265894302794,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "117028"
+ "upper_bound": "116261"
},
{
- "distinct_range": 448.5147167151475,
+ "distinct_range": 429.78465057392054,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "117703"
+ "upper_bound": "116908"
},
{
- "distinct_range": 490.42440936162063,
- "num_eq": 300,
- "num_range": 7350,
- "upper_bound": "118441"
+ "distinct_range": 466.37107023819544,
+ "num_eq": 150,
+ "num_range": 7500,
+ "upper_bound": "117610"
},
{
- "distinct_range": 478.45151236858226,
+ "distinct_range": 471.02694916698493,
"num_eq": 300,
- "num_range": 7350,
- "upper_bound": "119161"
+ "num_range": 7500,
+ "upper_bound": "118319"
},
{
- "distinct_range": 498.4056030895973,
+ "distinct_range": 587.3258513706575,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "119911"
+ "upper_bound": "119203"
},
{
- "distinct_range": 419.2388998582042,
- "num_eq": 150,
- "num_range": 7350,
- "upper_bound": "120542"
+ "distinct_range": 568.0870386419328,
+ "num_eq": 300,
+ "num_range": 7500,
+ "upper_bound": "120058"
},
{
- "distinct_range": 564.2170414944701,
+ "distinct_range": 574.0472401526881,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "121391"
+ "upper_bound": "120922"
},
{
- "distinct_range": 544.281938777513,
+ "distinct_range": 518.2416750561313,
"num_eq": 300,
- "num_range": 7350,
- "upper_bound": "122210"
+ "num_range": 7500,
+ "upper_bound": "121702"
},
{
- "distinct_range": 557.5729313651864,
+ "distinct_range": 520.8934443008823,
"num_eq": 150,
"num_range": 7350,
- "upper_bound": "123049"
+ "upper_bound": "122486"
},
{
- "distinct_range": 495.0801831886896,
+ "distinct_range": 509.5982616992731,
"num_eq": 150,
- "num_range": 7350,
- "upper_bound": "123794"
+ "num_range": 7500,
+ "upper_bound": "123253"
},
{
- "distinct_range": 414.5811232411703,
+ "distinct_range": 590.6679911074722,
"num_eq": 150,
- "num_range": 7350,
- "upper_bound": "124418"
+ "num_range": 7500,
+ "upper_bound": "124142"
},
{
- "distinct_range": 485.7684310706443,
+ "distinct_range": 433.77703847928086,
"num_eq": 150,
- "num_range": 7350,
- "upper_bound": "125149"
+ "num_range": 7500,
+ "upper_bound": "124795"
},
{
- "distinct_range": 540.969406674353,
+ "distinct_range": 593.9876675782924,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "125963"
+ "upper_bound": "125689"
},
{
- "distinct_range": 550.2758671053618,
+ "distinct_range": 390.535212954675,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "126791"
+ "upper_bound": "126277"
},
{
- "distinct_range": 495.74994244234546,
+ "distinct_range": 416.48076661195637,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "127537"
+ "upper_bound": "126904"
},
{
- "distinct_range": 566.8907374856144,
+ "distinct_range": 518.2416750561313,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "128390"
+ "upper_bound": "127684"
},
{
- "distinct_range": 449.84703728670155,
+ "distinct_range": 376.56416367826085,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "129067"
+ "upper_bound": "128251"
},
{
- "distinct_range": 356.6885295919354,
+ "distinct_range": 518.9065178552505,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "129604"
+ "upper_bound": "129032"
},
{
- "distinct_range": 529.0020059526132,
- "num_eq": 150,
+ "distinct_range": 587.3480284223818,
+ "num_eq": 300,
"num_range": 7500,
- "upper_bound": "130400"
+ "upper_bound": "129916"
},
{
- "distinct_range": 424.5628748326202,
- "num_eq": 150,
- "num_range": 7500,
- "upper_bound": "131039"
+ "distinct_range": 532.1929506277862,
+ "num_eq": 300,
+ "num_range": 7350,
+ "upper_bound": "130717"
+ },
+ {
+ "distinct_range": 556.114133580368,
+ "num_eq": 300,
+ "num_range": 7350,
+ "upper_bound": "131554"
},
{
- "distinct_range": 473.7980065634827,
+ "distinct_range": 616.5201066924318,
"num_eq": 150,
- "num_range": 7500,
- "upper_bound": "131752"
+ "num_range": 7350,
+ "upper_bound": "132482"
},
{
- "distinct_range": 470.4716671768734,
+ "distinct_range": 615.2262193685497,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "132460"
+ "upper_bound": "133408"
},
{
- "distinct_range": 461.1575812824033,
+ "distinct_range": 574.0654876812074,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "133154"
+ "upper_bound": "134272"
},
{
- "distinct_range": 358.01944110431344,
+ "distinct_range": 532.2022126521657,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "133693"
+ "upper_bound": "135073"
},
{
- "distinct_range": 546.2875576576482,
+ "distinct_range": 528.878505615231,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "134515"
+ "upper_bound": "135869"
},
{
- "distinct_range": 514.3725956585338,
+ "distinct_range": 726.4236347108995,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "135289"
+ "upper_bound": "136963"
},
{
- "distinct_range": 445.1880918992494,
- "num_eq": 300,
- "num_range": 7350,
- "upper_bound": "135959"
+ "distinct_range": 560.1146225556547,
+ "num_eq": 150,
+ "num_range": 7500,
+ "upper_bound": "137806"
},
{
- "distinct_range": 459.8269602102932,
+ "distinct_range": 402.51021774411686,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "136651"
+ "upper_bound": "138412"
},
{
- "distinct_range": 534.9859647132829,
+ "distinct_range": 459.0544509196563,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "137456"
+ "upper_bound": "139103"
},
{
- "distinct_range": 466.4799742377117,
+ "distinct_range": 584.027788238832,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "138158"
+ "upper_bound": "139982"
},
{
- "distinct_range": 524.3394393983798,
+ "distinct_range": 539.5138156326177,
"num_eq": 300,
- "num_range": 7350,
- "upper_bound": "138947"
- },
- {
- "distinct_range": 559.5808373562895,
- "num_eq": 150,
"num_range": 7500,
- "upper_bound": "139789"
+ "upper_bound": "140794"
},
{
- "distinct_range": 538.3101652989824,
+ "distinct_range": 439.09750658510313,
"num_eq": 150,
- "num_range": 7500,
- "upper_bound": "140599"
+ "num_range": 7350,
+ "upper_bound": "141455"
},
{
- "distinct_range": 562.9036500989672,
+ "distinct_range": 625.1769358122915,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "141446"
+ "upper_bound": "142396"
},
{
- "distinct_range": 579.5142949677999,
+ "distinct_range": 432.44658483369136,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "142318"
+ "upper_bound": "143047"
},
{
- "distinct_range": 540.969406674353,
+ "distinct_range": 492.3091679765895,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "143132"
+ "upper_bound": "143788"
},
{
- "distinct_range": 375.9866486498066,
- "num_eq": 300,
+ "distinct_range": 552.8055012067365,
+ "num_eq": 150,
"num_range": 7500,
- "upper_bound": "143698"
+ "upper_bound": "144620"
},
{
- "distinct_range": 522.3448428916699,
+ "distinct_range": 475.68269905622105,
"num_eq": 150,
- "num_range": 7350,
- "upper_bound": "144484"
+ "num_range": 7500,
+ "upper_bound": "145336"
},
{
- "distinct_range": 592.798226045605,
+ "distinct_range": 554.1345050052433,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "145376"
+ "upper_bound": "146170"
},
{
- "distinct_range": 459.8248203718307,
- "num_eq": 300,
- "num_range": 7350,
- "upper_bound": "146068"
- },
- {
- "distinct_range": 469.1411129880723,
+ "distinct_range": 560.7790385372747,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "146774"
+ "upper_bound": "147014"
},
{
- "distinct_range": 635.2724953517655,
+ "distinct_range": 501.61902775719284,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "147730"
+ "upper_bound": "147769"
},
{
- "distinct_range": 469.1411129880723,
- "num_eq": 150,
- "num_range": 7500,
- "upper_bound": "148436"
+ "distinct_range": 490.9748834181482,
+ "num_eq": 300,
+ "num_range": 7350,
+ "upper_bound": "148508"
},
{
- "distinct_range": 590.1417951647596,
+ "distinct_range": 482.333526644166,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "149324"
+ "upper_bound": "149234"
},
{
- "distinct_range": 443.858880740691,
+ "distinct_range": 505.6087238888729,
"num_eq": 150,
"num_range": 7500,
- "upper_bound": "149992"
+ "upper_bound": "149995"
}
],
"histo_col_type": "INT8",
@@ -11886,1210 +11930,1211 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 4,
"columns": [
"o_orderdate"
],
- "created_at": "2021-09-08 20:49:26.228164",
+ "created_at": "2022-02-25 00:54:45.88743",
"distinct_count": 2406,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 750,
+ "num_eq": 450,
"num_range": 0,
"upper_bound": "1992-01-01"
},
{
- "distinct_range": 12,
- "num_eq": 450,
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 6900,
+ "upper_bound": "1992-01-13"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 600,
"num_range": 7350,
- "upper_bound": "1992-01-14"
+ "upper_bound": "1992-01-25"
},
{
"distinct_range": 10,
"num_eq": 900,
- "num_range": 6600,
- "upper_bound": "1992-01-25"
+ "num_range": 6750,
+ "upper_bound": "1992-02-05"
},
{
- "distinct_range": 14,
- "num_eq": 750,
- "num_range": 7200,
- "upper_bound": "1992-02-09"
+ "distinct_range": 12,
+ "num_eq": 1350,
+ "num_range": 7050,
+ "upper_bound": "1992-02-18"
},
{
- "distinct_range": 13,
- "num_eq": 450,
+ "distinct_range": 10,
+ "num_eq": 1350,
"num_range": 7350,
- "upper_bound": "1992-02-23"
+ "upper_bound": "1992-02-29"
},
{
"distinct_range": 11,
- "num_eq": 750,
+ "num_eq": 900,
"num_range": 6750,
- "upper_bound": "1992-03-06"
- },
- {
- "distinct_range": 12,
- "num_eq": 750,
- "num_range": 7350,
- "upper_bound": "1992-03-19"
+ "upper_bound": "1992-03-12"
},
{
"distinct_range": 10,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "1992-03-30"
- },
- {
- "distinct_range": 12,
- "num_eq": 1050,
+ "num_eq": 900,
"num_range": 6600,
- "upper_bound": "1992-04-12"
- },
- {
- "distinct_range": 11,
- "num_eq": 600,
- "num_range": 7350,
- "upper_bound": "1992-04-24"
+ "upper_bound": "1992-03-23"
},
{
"distinct_range": 12,
"num_eq": 600,
"num_range": 7350,
- "upper_bound": "1992-05-07"
+ "upper_bound": "1992-04-05"
},
{
- "distinct_range": 12,
- "num_eq": 900,
+ "distinct_range": 11,
+ "num_eq": 600,
"num_range": 7200,
- "upper_bound": "1992-05-20"
+ "upper_bound": "1992-04-17"
},
{
- "distinct_range": 10,
- "num_eq": 750,
+ "distinct_range": 12,
+ "num_eq": 1050,
"num_range": 7350,
- "upper_bound": "1992-05-31"
+ "upper_bound": "1992-04-30"
},
{
- "distinct_range": 12,
+ "distinct_range": 15,
"num_eq": 750,
"num_range": 6900,
- "upper_bound": "1992-06-13"
+ "upper_bound": "1992-05-16"
},
{
- "distinct_range": 13,
- "num_eq": 900,
+ "distinct_range": 11,
+ "num_eq": 750,
"num_range": 6900,
- "upper_bound": "1992-06-27"
+ "upper_bound": "1992-05-28"
},
{
"distinct_range": 11,
- "num_eq": 900,
- "num_range": 6600,
- "upper_bound": "1992-07-09"
+ "num_eq": 450,
+ "num_range": 7350,
+ "upper_bound": "1992-06-09"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
+ "distinct_range": 12,
+ "num_eq": 600,
"num_range": 7350,
- "upper_bound": "1992-07-21"
+ "upper_bound": "1992-06-22"
},
{
- "distinct_range": 12,
- "num_eq": 1350,
- "num_range": 6600,
- "upper_bound": "1992-08-03"
+ "distinct_range": 11,
+ "num_eq": 750,
+ "num_range": 7200,
+ "upper_bound": "1992-07-04"
},
{
- "distinct_range": 13,
- "num_eq": 900,
- "num_range": 6900,
- "upper_bound": "1992-08-17"
+ "distinct_range": 10,
+ "num_eq": 450,
+ "num_range": 7350,
+ "upper_bound": "1992-07-15"
},
{
- "distinct_range": 14,
- "num_eq": 300,
+ "distinct_range": 10,
+ "num_eq": 750,
"num_range": 7200,
- "upper_bound": "1992-09-01"
+ "upper_bound": "1992-07-26"
},
{
- "distinct_range": 11,
- "num_eq": 600,
- "num_range": 7050,
- "upper_bound": "1992-09-13"
+ "distinct_range": 13,
+ "num_eq": 750,
+ "num_range": 7350,
+ "upper_bound": "1992-08-09"
},
{
"distinct_range": 9,
- "num_eq": 750,
- "num_range": 7350,
- "upper_bound": "1992-09-23"
+ "num_eq": 1200,
+ "num_range": 6150,
+ "upper_bound": "1992-08-19"
},
{
"distinct_range": 12,
"num_eq": 300,
- "num_range": 7200,
- "upper_bound": "1992-10-06"
- },
- {
- "distinct_range": 9,
- "num_eq": 1050,
- "num_range": 6300,
- "upper_bound": "1992-10-16"
+ "num_range": 7050,
+ "upper_bound": "1992-09-01"
},
{
- "distinct_range": 12,
+ "distinct_range": 10,
"num_eq": 600,
- "num_range": 6900,
- "upper_bound": "1992-10-29"
+ "num_range": 7200,
+ "upper_bound": "1992-09-12"
},
{
"distinct_range": 10,
- "num_eq": 900,
- "num_range": 7050,
- "upper_bound": "1992-11-09"
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "1992-09-23"
},
{
"distinct_range": 10,
- "num_eq": 900,
- "num_range": 6450,
- "upper_bound": "1992-11-20"
+ "num_eq": 1350,
+ "num_range": 6600,
+ "upper_bound": "1992-10-04"
},
{
"distinct_range": 12,
- "num_eq": 1200,
- "num_range": 6150,
- "upper_bound": "1992-12-03"
+ "num_eq": 450,
+ "num_range": 7050,
+ "upper_bound": "1992-10-17"
},
{
- "distinct_range": 10,
- "num_eq": 750,
+ "distinct_range": 9,
+ "num_eq": 600,
"num_range": 6750,
- "upper_bound": "1992-12-14"
+ "upper_bound": "1992-10-27"
},
{
- "distinct_range": 12,
+ "distinct_range": 9,
"num_eq": 750,
- "num_range": 7050,
- "upper_bound": "1992-12-27"
+ "num_range": 7200,
+ "upper_bound": "1992-11-06"
},
{
"distinct_range": 12,
- "num_eq": 750,
- "num_range": 6750,
- "upper_bound": "1993-01-09"
+ "num_eq": 450,
+ "num_range": 7050,
+ "upper_bound": "1992-11-19"
},
{
- "distinct_range": 11,
- "num_eq": 1050,
- "num_range": 6900,
- "upper_bound": "1993-01-21"
+ "distinct_range": 10,
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1992-11-30"
},
{
- "distinct_range": 10,
+ "distinct_range": 11,
"num_eq": 900,
- "num_range": 6450,
- "upper_bound": "1993-02-01"
+ "num_range": 7200,
+ "upper_bound": "1992-12-12"
},
{
- "distinct_range": 11,
+ "distinct_range": 10,
"num_eq": 900,
- "num_range": 6450,
- "upper_bound": "1993-02-13"
+ "num_range": 7050,
+ "upper_bound": "1992-12-23"
},
{
- "distinct_range": 9,
- "num_eq": 1200,
- "num_range": 6300,
- "upper_bound": "1993-02-23"
+ "distinct_range": 13,
+ "num_eq": 750,
+ "num_range": 7050,
+ "upper_bound": "1993-01-06"
},
{
"distinct_range": 11,
- "num_eq": 900,
- "num_range": 7200,
- "upper_bound": "1993-03-07"
+ "num_eq": 600,
+ "num_range": 7050,
+ "upper_bound": "1993-01-18"
},
{
- "distinct_range": 9,
+ "distinct_range": 12,
"num_eq": 750,
- "num_range": 6600,
- "upper_bound": "1993-03-17"
+ "num_range": 7200,
+ "upper_bound": "1993-01-31"
},
{
- "distinct_range": 12,
+ "distinct_range": 7,
"num_eq": 1200,
- "num_range": 6900,
- "upper_bound": "1993-03-30"
+ "num_range": 6150,
+ "upper_bound": "1993-02-08"
},
{
"distinct_range": 12,
"num_eq": 1200,
- "num_range": 7050,
- "upper_bound": "1993-04-12"
+ "num_range": 7200,
+ "upper_bound": "1993-02-21"
},
{
- "distinct_range": 11,
- "num_eq": 600,
- "num_range": 7200,
- "upper_bound": "1993-04-24"
+ "distinct_range": 7,
+ "num_eq": 1350,
+ "num_range": 6000,
+ "upper_bound": "1993-03-01"
},
{
- "distinct_range": 13,
+ "distinct_range": 14,
"num_eq": 1200,
- "num_range": 6750,
- "upper_bound": "1993-05-08"
+ "num_range": 6300,
+ "upper_bound": "1993-03-16"
},
{
"distinct_range": 10,
"num_eq": 750,
- "num_range": 6900,
- "upper_bound": "1993-05-19"
- },
- {
- "distinct_range": 12,
- "num_eq": 450,
- "num_range": 6900,
- "upper_bound": "1993-06-01"
+ "num_range": 7200,
+ "upper_bound": "1993-03-27"
},
{
"distinct_range": 10,
- "num_eq": 600,
- "num_range": 6900,
- "upper_bound": "1993-06-12"
- },
- {
- "distinct_range": 7,
- "num_eq": 1650,
+ "num_eq": 1200,
"num_range": 6750,
- "upper_bound": "1993-06-20"
- },
- {
- "distinct_range": 9,
- "num_eq": 1500,
- "num_range": 5850,
- "upper_bound": "1993-06-30"
- },
- {
- "distinct_range": 10,
- "num_eq": 300,
- "num_range": 7200,
- "upper_bound": "1993-07-11"
+ "upper_bound": "1993-04-07"
},
{
- "distinct_range": 10,
- "num_eq": 600,
- "num_range": 7200,
- "upper_bound": "1993-07-22"
+ "distinct_range": 13,
+ "num_eq": 900,
+ "num_range": 6600,
+ "upper_bound": "1993-04-21"
},
{
"distinct_range": 10,
"num_eq": 750,
- "num_range": 6600,
- "upper_bound": "1993-08-02"
+ "num_range": 7050,
+ "upper_bound": "1993-05-02"
},
{
"distinct_range": 11,
- "num_eq": 900,
- "num_range": 7200,
- "upper_bound": "1993-08-14"
+ "num_eq": 450,
+ "num_range": 7050,
+ "upper_bound": "1993-05-14"
},
{
- "distinct_range": 10,
+ "distinct_range": 13,
"num_eq": 900,
- "num_range": 6900,
- "upper_bound": "1993-08-25"
+ "num_range": 7050,
+ "upper_bound": "1993-05-28"
},
{
"distinct_range": 10,
"num_eq": 450,
- "num_range": 6900,
- "upper_bound": "1993-09-05"
+ "num_range": 7200,
+ "upper_bound": "1993-06-08"
},
{
- "distinct_range": 10,
- "num_eq": 750,
- "num_range": 6600,
- "upper_bound": "1993-09-16"
+ "distinct_range": 11,
+ "num_eq": 1050,
+ "num_range": 7200,
+ "upper_bound": "1993-06-20"
},
{
- "distinct_range": 10,
+ "distinct_range": 11,
+ "num_eq": 900,
+ "num_range": 6900,
+ "upper_bound": "1993-07-02"
+ },
+ {
+ "distinct_range": 13,
"num_eq": 1200,
- "num_range": 6750,
- "upper_bound": "1993-09-27"
+ "num_range": 6300,
+ "upper_bound": "1993-07-16"
},
{
"distinct_range": 12,
"num_eq": 600,
"num_range": 6750,
- "upper_bound": "1993-10-10"
+ "upper_bound": "1993-07-29"
},
{
"distinct_range": 13,
- "num_eq": 150,
- "num_range": 7200,
- "upper_bound": "1993-10-24"
+ "num_eq": 900,
+ "num_range": 7050,
+ "upper_bound": "1993-08-12"
},
{
- "distinct_range": 10,
- "num_eq": 1350,
- "num_range": 6900,
- "upper_bound": "1993-11-04"
+ "distinct_range": 12,
+ "num_eq": 450,
+ "num_range": 7050,
+ "upper_bound": "1993-08-25"
},
{
- "distinct_range": 10,
- "num_eq": 1050,
- "num_range": 6300,
- "upper_bound": "1993-11-15"
+ "distinct_range": 12,
+ "num_eq": 1200,
+ "num_range": 6900,
+ "upper_bound": "1993-09-07"
},
{
- "distinct_range": 11,
+ "distinct_range": 14,
"num_eq": 600,
- "num_range": 7200,
- "upper_bound": "1993-11-27"
+ "num_range": 6750,
+ "upper_bound": "1993-09-22"
},
{
"distinct_range": 12,
- "num_eq": 600,
+ "num_eq": 750,
"num_range": 7050,
- "upper_bound": "1993-12-10"
+ "upper_bound": "1993-10-05"
},
{
- "distinct_range": 14,
- "num_eq": 1050,
- "num_range": 7200,
- "upper_bound": "1993-12-25"
+ "distinct_range": 12,
+ "num_eq": 1350,
+ "num_range": 6750,
+ "upper_bound": "1993-10-18"
},
{
- "distinct_range": 13,
- "num_eq": 450,
+ "distinct_range": 12,
+ "num_eq": 600,
"num_range": 7050,
- "upper_bound": "1994-01-08"
+ "upper_bound": "1993-10-31"
},
{
- "distinct_range": 10,
- "num_eq": 900,
+ "distinct_range": 13,
+ "num_eq": 300,
"num_range": 7050,
- "upper_bound": "1994-01-19"
+ "upper_bound": "1993-11-14"
},
{
"distinct_range": 10,
- "num_eq": 750,
+ "num_eq": 450,
"num_range": 7200,
- "upper_bound": "1994-01-30"
+ "upper_bound": "1993-11-25"
},
{
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 6450,
- "upper_bound": "1994-02-12"
+ "distinct_range": 10,
+ "num_eq": 600,
+ "num_range": 7050,
+ "upper_bound": "1993-12-06"
},
{
- "distinct_range": 12,
- "num_eq": 1050,
+ "distinct_range": 13,
+ "num_eq": 450,
"num_range": 6900,
- "upper_bound": "1994-02-25"
+ "upper_bound": "1993-12-20"
},
{
- "distinct_range": 8,
- "num_eq": 900,
- "num_range": 6600,
- "upper_bound": "1994-03-06"
+ "distinct_range": 13,
+ "num_eq": 450,
+ "num_range": 6900,
+ "upper_bound": "1994-01-03"
},
{
- "distinct_range": 12,
- "num_eq": 750,
- "num_range": 7050,
- "upper_bound": "1994-03-19"
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 7200,
+ "upper_bound": "1994-01-15"
},
{
- "distinct_range": 11,
+ "distinct_range": 7,
"num_eq": 900,
- "num_range": 6750,
- "upper_bound": "1994-03-31"
+ "num_range": 6600,
+ "upper_bound": "1994-01-23"
},
{
"distinct_range": 11,
- "num_eq": 600,
+ "num_eq": 750,
"num_range": 6900,
- "upper_bound": "1994-04-12"
+ "upper_bound": "1994-02-04"
},
{
- "distinct_range": 9,
- "num_eq": 450,
- "num_range": 7200,
- "upper_bound": "1994-04-22"
+ "distinct_range": 10,
+ "num_eq": 1800,
+ "num_range": 5700,
+ "upper_bound": "1994-02-15"
},
{
- "distinct_range": 12,
- "num_eq": 600,
+ "distinct_range": 11,
+ "num_eq": 750,
"num_range": 6900,
- "upper_bound": "1994-05-05"
+ "upper_bound": "1994-02-27"
},
{
- "distinct_range": 13,
+ "distinct_range": 9,
+ "num_eq": 1050,
+ "num_range": 6300,
+ "upper_bound": "1994-03-09"
+ },
+ {
+ "distinct_range": 9,
"num_eq": 900,
"num_range": 7050,
- "upper_bound": "1994-05-19"
+ "upper_bound": "1994-03-19"
+ },
+ {
+ "distinct_range": 16,
+ "num_eq": 300,
+ "num_range": 7200,
+ "upper_bound": "1994-04-05"
},
{
"distinct_range": 10,
- "num_eq": 1050,
+ "num_eq": 450,
+ "num_range": 7050,
+ "upper_bound": "1994-04-16"
+ },
+ {
+ "distinct_range": 12,
+ "num_eq": 750,
"num_range": 6600,
- "upper_bound": "1994-05-30"
+ "upper_bound": "1994-04-29"
},
{
"distinct_range": 10,
+ "num_eq": 1200,
+ "num_range": 6450,
+ "upper_bound": "1994-05-10"
+ },
+ {
+ "distinct_range": 13,
"num_eq": 600,
"num_range": 6900,
- "upper_bound": "1994-06-10"
+ "upper_bound": "1994-05-24"
},
{
- "distinct_range": 12,
- "num_eq": 1350,
+ "distinct_range": 10,
+ "num_eq": 1050,
"num_range": 7050,
- "upper_bound": "1994-06-23"
+ "upper_bound": "1994-06-04"
},
{
"distinct_range": 11,
"num_eq": 450,
- "num_range": 7200,
- "upper_bound": "1994-07-05"
+ "num_range": 7050,
+ "upper_bound": "1994-06-16"
},
{
- "distinct_range": 10,
+ "distinct_range": 13,
+ "num_eq": 750,
+ "num_range": 6600,
+ "upper_bound": "1994-06-30"
+ },
+ {
+ "distinct_range": 15,
+ "num_eq": 600,
+ "num_range": 7050,
+ "upper_bound": "1994-07-16"
+ },
+ {
+ "distinct_range": 14,
"num_eq": 900,
"num_range": 6450,
- "upper_bound": "1994-07-16"
+ "upper_bound": "1994-07-31"
},
{
- "distinct_range": 8,
- "num_eq": 1350,
+ "distinct_range": 12,
+ "num_eq": 600,
"num_range": 7050,
- "upper_bound": "1994-07-25"
+ "upper_bound": "1994-08-13"
},
{
- "distinct_range": 11,
- "num_eq": 150,
+ "distinct_range": 13,
+ "num_eq": 900,
"num_range": 7200,
- "upper_bound": "1994-08-06"
+ "upper_bound": "1994-08-27"
},
{
"distinct_range": 11,
+ "num_eq": 900,
+ "num_range": 6750,
+ "upper_bound": "1994-09-08"
+ },
+ {
+ "distinct_range": 14,
"num_eq": 750,
- "num_range": 7050,
- "upper_bound": "1994-08-18"
+ "num_range": 7200,
+ "upper_bound": "1994-09-23"
},
{
"distinct_range": 12,
"num_eq": 1050,
- "num_range": 6900,
- "upper_bound": "1994-08-31"
- },
- {
- "distinct_range": 9,
- "num_eq": 900,
- "num_range": 7050,
- "upper_bound": "1994-09-10"
+ "num_range": 7200,
+ "upper_bound": "1994-10-06"
},
{
- "distinct_range": 14,
+ "distinct_range": 10,
"num_eq": 600,
"num_range": 6750,
- "upper_bound": "1994-09-25"
+ "upper_bound": "1994-10-17"
},
{
"distinct_range": 10,
- "num_eq": 1800,
+ "num_eq": 600,
+ "num_range": 6900,
+ "upper_bound": "1994-10-28"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 1050,
+ "num_range": 6900,
+ "upper_bound": "1994-11-11"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 450,
"num_range": 7050,
- "upper_bound": "1994-10-06"
+ "upper_bound": "1994-11-25"
},
{
- "distinct_range": 14,
+ "distinct_range": 15,
"num_eq": 750,
- "num_range": 6600,
- "upper_bound": "1994-10-21"
+ "num_range": 7050,
+ "upper_bound": "1994-12-11"
},
{
"distinct_range": 10,
"num_eq": 1350,
- "num_range": 6300,
- "upper_bound": "1994-11-01"
- },
- {
- "distinct_range": 10,
- "num_eq": 600,
- "num_range": 7200,
- "upper_bound": "1994-11-12"
+ "num_range": 6000,
+ "upper_bound": "1994-12-22"
},
{
- "distinct_range": 14,
- "num_eq": 450,
- "num_range": 7200,
- "upper_bound": "1994-11-27"
+ "distinct_range": 11,
+ "num_eq": 900,
+ "num_range": 6750,
+ "upper_bound": "1995-01-03"
},
{
- "distinct_range": 10,
+ "distinct_range": 13,
"num_eq": 900,
- "num_range": 6600,
- "upper_bound": "1994-12-08"
+ "num_range": 6900,
+ "upper_bound": "1995-01-17"
},
{
"distinct_range": 12,
- "num_eq": 450,
+ "num_eq": 900,
"num_range": 6900,
- "upper_bound": "1994-12-21"
+ "upper_bound": "1995-01-30"
+ },
+ {
+ "distinct_range": 9,
+ "num_eq": 1050,
+ "num_range": 7050,
+ "upper_bound": "1995-02-09"
},
{
"distinct_range": 13,
"num_eq": 600,
"num_range": 6750,
- "upper_bound": "1995-01-04"
+ "upper_bound": "1995-02-23"
},
{
- "distinct_range": 12,
+ "distinct_range": 14,
"num_eq": 900,
- "num_range": 6600,
- "upper_bound": "1995-01-17"
+ "num_range": 7050,
+ "upper_bound": "1995-03-10"
},
{
- "distinct_range": 14,
+ "distinct_range": 10,
+ "num_eq": 900,
+ "num_range": 6450,
+ "upper_bound": "1995-03-21"
+ },
+ {
+ "distinct_range": 13,
"num_eq": 300,
"num_range": 7050,
- "upper_bound": "1995-02-01"
+ "upper_bound": "1995-04-04"
},
{
- "distinct_range": 9,
- "num_eq": 450,
- "num_range": 7050,
- "upper_bound": "1995-02-11"
+ "distinct_range": 10,
+ "num_eq": 750,
+ "num_range": 6600,
+ "upper_bound": "1995-04-15"
},
{
"distinct_range": 11,
- "num_eq": 750,
+ "num_eq": 1350,
"num_range": 7050,
- "upper_bound": "1995-02-23"
+ "upper_bound": "1995-04-27"
},
{
- "distinct_range": 12,
- "num_eq": 600,
- "num_range": 6900,
- "upper_bound": "1995-03-08"
+ "distinct_range": 14,
+ "num_eq": 450,
+ "num_range": 7200,
+ "upper_bound": "1995-05-12"
},
{
- "distinct_range": 12,
+ "distinct_range": 13,
"num_eq": 750,
- "num_range": 6900,
- "upper_bound": "1995-03-21"
+ "num_range": 7200,
+ "upper_bound": "1995-05-26"
},
{
- "distinct_range": 14,
- "num_eq": 300,
- "num_range": 7050,
- "upper_bound": "1995-04-05"
+ "distinct_range": 8,
+ "num_eq": 600,
+ "num_range": 7200,
+ "upper_bound": "1995-06-04"
+ },
+ {
+ "distinct_range": 8,
+ "num_eq": 900,
+ "num_range": 6300,
+ "upper_bound": "1995-06-13"
},
{
"distinct_range": 12,
- "num_eq": 450,
+ "num_eq": 750,
"num_range": 7050,
- "upper_bound": "1995-04-18"
+ "upper_bound": "1995-06-26"
},
{
"distinct_range": 11,
- "num_eq": 600,
- "num_range": 7200,
- "upper_bound": "1995-04-30"
+ "num_eq": 900,
+ "num_range": 6450,
+ "upper_bound": "1995-07-08"
},
{
- "distinct_range": 12,
- "num_eq": 750,
- "num_range": 7200,
- "upper_bound": "1995-05-13"
+ "distinct_range": 10,
+ "num_eq": 900,
+ "num_range": 6900,
+ "upper_bound": "1995-07-19"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 6600,
+ "upper_bound": "1995-07-31"
},
{
"distinct_range": 11,
- "num_eq": 150,
- "num_range": 7200,
- "upper_bound": "1995-05-25"
+ "num_eq": 600,
+ "num_range": 6600,
+ "upper_bound": "1995-08-12"
},
{
- "distinct_range": 13,
+ "distinct_range": 8,
"num_eq": 750,
- "num_range": 7050,
- "upper_bound": "1995-06-08"
+ "num_range": 6900,
+ "upper_bound": "1995-08-21"
},
{
"distinct_range": 13,
- "num_eq": 1050,
- "num_range": 6750,
- "upper_bound": "1995-06-22"
+ "num_eq": 600,
+ "num_range": 7050,
+ "upper_bound": "1995-09-04"
},
{
- "distinct_range": 14,
- "num_eq": 750,
- "num_range": 7050,
- "upper_bound": "1995-07-07"
+ "distinct_range": 8,
+ "num_eq": 1050,
+ "num_range": 6150,
+ "upper_bound": "1995-09-13"
},
{
"distinct_range": 11,
- "num_eq": 450,
- "num_range": 7050,
- "upper_bound": "1995-07-19"
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1995-09-25"
},
{
- "distinct_range": 9,
+ "distinct_range": 10,
"num_eq": 600,
"num_range": 6600,
- "upper_bound": "1995-07-29"
+ "upper_bound": "1995-10-06"
},
{
- "distinct_range": 14,
- "num_eq": 600,
- "num_range": 6750,
- "upper_bound": "1995-08-13"
+ "distinct_range": 15,
+ "num_eq": 900,
+ "num_range": 7050,
+ "upper_bound": "1995-10-22"
},
{
- "distinct_range": 10,
- "num_eq": 300,
+ "distinct_range": 7,
+ "num_eq": 1650,
"num_range": 7050,
- "upper_bound": "1995-08-24"
+ "upper_bound": "1995-10-30"
},
{
"distinct_range": 11,
- "num_eq": 900,
+ "num_eq": 600,
"num_range": 6750,
- "upper_bound": "1995-09-05"
+ "upper_bound": "1995-11-11"
},
{
- "distinct_range": 14,
- "num_eq": 450,
- "num_range": 6900,
- "upper_bound": "1995-09-20"
+ "distinct_range": 11,
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1995-11-23"
},
{
- "distinct_range": 14,
+ "distinct_range": 12,
"num_eq": 450,
- "num_range": 6900,
- "upper_bound": "1995-10-05"
+ "num_range": 6750,
+ "upper_bound": "1995-12-06"
},
{
- "distinct_range": 8,
+ "distinct_range": 12,
"num_eq": 1050,
- "num_range": 6600,
- "upper_bound": "1995-10-14"
- },
- {
- "distinct_range": 10,
- "num_eq": 450,
"num_range": 7050,
- "upper_bound": "1995-10-25"
+ "upper_bound": "1995-12-19"
},
{
- "distinct_range": 11,
- "num_eq": 1200,
- "num_range": 6300,
- "upper_bound": "1995-11-06"
+ "distinct_range": 12,
+ "num_eq": 1350,
+ "num_range": 6900,
+ "upper_bound": "1996-01-01"
},
{
- "distinct_range": 9,
+ "distinct_range": 11,
"num_eq": 600,
- "num_range": 6750,
- "upper_bound": "1995-11-16"
+ "num_range": 6600,
+ "upper_bound": "1996-01-13"
},
{
"distinct_range": 9,
- "num_eq": 750,
- "num_range": 6900,
- "upper_bound": "1995-11-26"
+ "num_eq": 900,
+ "num_range": 6300,
+ "upper_bound": "1996-01-23"
},
{
- "distinct_range": 12,
- "num_eq": 750,
+ "distinct_range": 10,
+ "num_eq": 600,
"num_range": 6600,
- "upper_bound": "1995-12-09"
+ "upper_bound": "1996-02-03"
},
{
- "distinct_range": 11,
- "num_eq": 450,
- "num_range": 6750,
- "upper_bound": "1995-12-21"
+ "distinct_range": 10,
+ "num_eq": 1050,
+ "num_range": 6300,
+ "upper_bound": "1996-02-14"
},
{
"distinct_range": 9,
- "num_eq": 600,
+ "num_eq": 900,
"num_range": 6750,
- "upper_bound": "1995-12-31"
+ "upper_bound": "1996-02-24"
},
{
- "distinct_range": 10,
+ "distinct_range": 9,
"num_eq": 900,
- "num_range": 7050,
- "upper_bound": "1996-01-11"
+ "num_range": 6300,
+ "upper_bound": "1996-03-05"
},
{
"distinct_range": 11,
- "num_eq": 600,
- "num_range": 6750,
- "upper_bound": "1996-01-23"
+ "num_eq": 1200,
+ "num_range": 7050,
+ "upper_bound": "1996-03-17"
},
{
- "distinct_range": 10,
- "num_eq": 750,
+ "distinct_range": 8,
+ "num_eq": 1200,
"num_range": 6600,
- "upper_bound": "1996-02-03"
- },
- {
- "distinct_range": 17,
- "num_eq": 600,
- "num_range": 6900,
- "upper_bound": "1996-02-21"
- },
- {
- "distinct_range": 9,
- "num_eq": 750,
- "num_range": 6750,
- "upper_bound": "1996-03-02"
+ "upper_bound": "1996-03-26"
},
{
"distinct_range": 13,
"num_eq": 750,
"num_range": 6750,
- "upper_bound": "1996-03-16"
+ "upper_bound": "1996-04-09"
},
{
- "distinct_range": 10,
- "num_eq": 600,
+ "distinct_range": 11,
+ "num_eq": 900,
"num_range": 6900,
- "upper_bound": "1996-03-27"
+ "upper_bound": "1996-04-21"
},
{
"distinct_range": 11,
"num_eq": 600,
- "num_range": 6600,
- "upper_bound": "1996-04-08"
+ "num_range": 6750,
+ "upper_bound": "1996-05-03"
},
{
"distinct_range": 11,
- "num_eq": 1050,
- "num_range": 6300,
- "upper_bound": "1996-04-20"
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1996-05-15"
},
{
"distinct_range": 12,
- "num_eq": 450,
- "num_range": 7050,
- "upper_bound": "1996-05-03"
+ "num_eq": 1200,
+ "num_range": 6150,
+ "upper_bound": "1996-05-28"
},
{
- "distinct_range": 9,
+ "distinct_range": 8,
"num_eq": 1050,
- "num_range": 6750,
- "upper_bound": "1996-05-13"
- },
- {
- "distinct_range": 10,
- "num_eq": 750,
- "num_range": 6750,
- "upper_bound": "1996-05-24"
- },
- {
- "distinct_range": 12,
- "num_eq": 900,
- "num_range": 6750,
+ "num_range": 6450,
"upper_bound": "1996-06-06"
},
{
- "distinct_range": 12,
- "num_eq": 450,
- "num_range": 6900,
- "upper_bound": "1996-06-19"
+ "distinct_range": 9,
+ "num_eq": 750,
+ "num_range": 7050,
+ "upper_bound": "1996-06-16"
},
{
"distinct_range": 10,
- "num_eq": 750,
- "num_range": 6450,
- "upper_bound": "1996-06-30"
+ "num_eq": 1050,
+ "num_range": 6300,
+ "upper_bound": "1996-06-27"
},
{
"distinct_range": 13,
- "num_eq": 300,
- "num_range": 6900,
- "upper_bound": "1996-07-14"
+ "num_eq": 450,
+ "num_range": 7050,
+ "upper_bound": "1996-07-11"
},
{
- "distinct_range": 10,
- "num_eq": 750,
- "num_range": 6450,
- "upper_bound": "1996-07-25"
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1996-07-24"
},
{
- "distinct_range": 9,
- "num_eq": 1050,
- "num_range": 6900,
- "upper_bound": "1996-08-04"
+ "distinct_range": 13,
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1996-08-07"
},
{
- "distinct_range": 14,
+ "distinct_range": 12,
"num_eq": 600,
"num_range": 7050,
- "upper_bound": "1996-08-19"
+ "upper_bound": "1996-08-20"
},
{
"distinct_range": 14,
- "num_eq": 750,
- "num_range": 6900,
- "upper_bound": "1996-09-03"
- },
- {
- "distinct_range": 10,
- "num_eq": 750,
+ "num_eq": 900,
"num_range": 7050,
- "upper_bound": "1996-09-14"
- },
- {
- "distinct_range": 10,
- "num_eq": 1200,
- "num_range": 6600,
- "upper_bound": "1996-09-25"
+ "upper_bound": "1996-09-04"
},
{
- "distinct_range": 13,
- "num_eq": 1050,
- "num_range": 6600,
- "upper_bound": "1996-10-09"
+ "distinct_range": 12,
+ "num_eq": 600,
+ "num_range": 6900,
+ "upper_bound": "1996-09-17"
},
{
- "distinct_range": 9,
- "num_eq": 1050,
- "num_range": 6750,
- "upper_bound": "1996-10-19"
+ "distinct_range": 17,
+ "num_eq": 900,
+ "num_range": 6900,
+ "upper_bound": "1996-10-05"
},
{
"distinct_range": 12,
- "num_eq": 750,
- "num_range": 6600,
- "upper_bound": "1996-11-01"
- },
- {
- "distinct_range": 9,
"num_eq": 600,
"num_range": 6900,
- "upper_bound": "1996-11-11"
+ "upper_bound": "1996-10-18"
},
{
- "distinct_range": 11,
- "num_eq": 150,
- "num_range": 7050,
- "upper_bound": "1996-11-23"
+ "distinct_range": 10,
+ "num_eq": 1200,
+ "num_range": 6450,
+ "upper_bound": "1996-10-29"
},
{
- "distinct_range": 11,
+ "distinct_range": 8,
"num_eq": 450,
- "num_range": 7050,
- "upper_bound": "1996-12-05"
+ "num_range": 6600,
+ "upper_bound": "1996-11-07"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
- "num_range": 6450,
- "upper_bound": "1996-12-19"
+ "distinct_range": 12,
+ "num_eq": 450,
+ "num_range": 6900,
+ "upper_bound": "1996-11-20"
},
{
"distinct_range": 9,
- "num_eq": 750,
- "num_range": 6750,
- "upper_bound": "1996-12-29"
- },
- {
- "distinct_range": 13,
"num_eq": 600,
- "num_range": 7050,
- "upper_bound": "1997-01-12"
+ "num_range": 6750,
+ "upper_bound": "1996-11-30"
},
{
- "distinct_range": 9,
- "num_eq": 450,
- "num_range": 6600,
- "upper_bound": "1997-01-22"
+ "distinct_range": 14,
+ "num_eq": 750,
+ "num_range": 6750,
+ "upper_bound": "1996-12-15"
},
{
"distinct_range": 14,
- "num_eq": 750,
+ "num_eq": 1350,
"num_range": 6750,
- "upper_bound": "1997-02-06"
+ "upper_bound": "1996-12-30"
},
{
- "distinct_range": 17,
- "num_eq": 750,
- "num_range": 6450,
- "upper_bound": "1997-02-24"
+ "distinct_range": 13,
+ "num_eq": 450,
+ "num_range": 6750,
+ "upper_bound": "1997-01-13"
},
{
"distinct_range": 11,
"num_eq": 750,
- "num_range": 6750,
- "upper_bound": "1997-03-08"
+ "num_range": 6600,
+ "upper_bound": "1997-01-25"
},
{
"distinct_range": 10,
- "num_eq": 600,
+ "num_eq": 450,
"num_range": 6600,
- "upper_bound": "1997-03-19"
+ "upper_bound": "1997-02-05"
},
{
- "distinct_range": 12,
- "num_eq": 1350,
- "num_range": 5700,
- "upper_bound": "1997-04-01"
+ "distinct_range": 9,
+ "num_eq": 750,
+ "num_range": 6450,
+ "upper_bound": "1997-02-15"
},
{
- "distinct_range": 10,
- "num_eq": 900,
- "num_range": 6300,
- "upper_bound": "1997-04-12"
+ "distinct_range": 8,
+ "num_eq": 600,
+ "num_range": 6450,
+ "upper_bound": "1997-02-24"
},
{
- "distinct_range": 10,
+ "distinct_range": 9,
"num_eq": 600,
- "num_range": 6900,
- "upper_bound": "1997-04-23"
+ "num_range": 6750,
+ "upper_bound": "1997-03-06"
},
{
"distinct_range": 11,
- "num_eq": 750,
- "num_range": 6750,
- "upper_bound": "1997-05-05"
+ "num_eq": 900,
+ "num_range": 6900,
+ "upper_bound": "1997-03-18"
},
{
- "distinct_range": 9,
- "num_eq": 900,
+ "distinct_range": 11,
+ "num_eq": 750,
"num_range": 6300,
- "upper_bound": "1997-05-15"
+ "upper_bound": "1997-03-30"
},
{
"distinct_range": 9,
- "num_eq": 600,
+ "num_eq": 1200,
"num_range": 6450,
- "upper_bound": "1997-05-25"
+ "upper_bound": "1997-04-09"
},
{
- "distinct_range": 12,
- "num_eq": 450,
- "num_range": 6600,
- "upper_bound": "1997-06-07"
+ "distinct_range": 11,
+ "num_eq": 1500,
+ "num_range": 6000,
+ "upper_bound": "1997-04-21"
+ },
+ {
+ "distinct_range": 9,
+ "num_eq": 900,
+ "num_range": 6900,
+ "upper_bound": "1997-05-01"
},
{
"distinct_range": 10,
- "num_eq": 1050,
+ "num_eq": 1200,
"num_range": 6000,
- "upper_bound": "1997-06-18"
+ "upper_bound": "1997-05-12"
},
{
- "distinct_range": 13,
- "num_eq": 450,
- "num_range": 6750,
- "upper_bound": "1997-07-02"
+ "distinct_range": 11,
+ "num_eq": 750,
+ "num_range": 6300,
+ "upper_bound": "1997-05-24"
},
{
- "distinct_range": 8,
- "num_eq": 900,
- "num_range": 6300,
- "upper_bound": "1997-07-11"
+ "distinct_range": 10,
+ "num_eq": 600,
+ "num_range": 6450,
+ "upper_bound": "1997-06-04"
},
{
- "distinct_range": 12,
- "num_eq": 900,
+ "distinct_range": 10,
+ "num_eq": 1050,
"num_range": 6900,
- "upper_bound": "1997-07-24"
+ "upper_bound": "1997-06-15"
},
{
- "distinct_range": 10,
+ "distinct_range": 12,
"num_eq": 600,
- "num_range": 6450,
- "upper_bound": "1997-08-04"
+ "num_range": 6600,
+ "upper_bound": "1997-06-28"
},
{
- "distinct_range": 12,
- "num_eq": 750,
+ "distinct_range": 11,
+ "num_eq": 1650,
"num_range": 6900,
- "upper_bound": "1997-08-17"
+ "upper_bound": "1997-07-10"
},
{
- "distinct_range": 8,
- "num_eq": 750,
- "num_range": 6450,
- "upper_bound": "1997-08-26"
+ "distinct_range": 9,
+ "num_eq": 1050,
+ "num_range": 5850,
+ "upper_bound": "1997-07-20"
},
{
- "distinct_range": 13,
- "num_eq": 1200,
+ "distinct_range": 9,
+ "num_eq": 750,
"num_range": 6600,
- "upper_bound": "1997-09-09"
+ "upper_bound": "1997-07-30"
},
{
- "distinct_range": 9,
+ "distinct_range": 13,
"num_eq": 450,
- "num_range": 6750,
- "upper_bound": "1997-09-19"
+ "num_range": 6600,
+ "upper_bound": "1997-08-13"
},
{
- "distinct_range": 8,
+ "distinct_range": 10,
"num_eq": 900,
"num_range": 6300,
- "upper_bound": "1997-09-28"
+ "upper_bound": "1997-08-24"
},
{
"distinct_range": 10,
- "num_eq": 600,
+ "num_eq": 300,
"num_range": 6600,
- "upper_bound": "1997-10-09"
+ "upper_bound": "1997-09-04"
},
{
- "distinct_range": 9,
- "num_eq": 1200,
+ "distinct_range": 11,
+ "num_eq": 600,
"num_range": 6600,
- "upper_bound": "1997-10-19"
+ "upper_bound": "1997-09-16"
},
{
"distinct_range": 12,
- "num_eq": 1200,
+ "num_eq": 900,
"num_range": 6750,
- "upper_bound": "1997-11-01"
+ "upper_bound": "1997-09-29"
},
{
- "distinct_range": 11,
- "num_eq": 1050,
+ "distinct_range": 15,
+ "num_eq": 450,
+ "num_range": 6750,
+ "upper_bound": "1997-10-15"
+ },
+ {
+ "distinct_range": 14,
+ "num_eq": 750,
+ "num_range": 6600,
+ "upper_bound": "1997-10-30"
+ },
+ {
+ "distinct_range": 13,
+ "num_eq": 300,
"num_range": 6600,
"upper_bound": "1997-11-13"
},
{
- "distinct_range": 10,
- "num_eq": 1050,
- "num_range": 6300,
- "upper_bound": "1997-11-24"
+ "distinct_range": 11,
+ "num_eq": 900,
+ "num_range": 6150,
+ "upper_bound": "1997-11-25"
},
{
"distinct_range": 10,
- "num_eq": 900,
- "num_range": 6450,
- "upper_bound": "1997-12-05"
+ "num_eq": 600,
+ "num_range": 6750,
+ "upper_bound": "1997-12-06"
},
{
- "distinct_range": 14,
- "num_eq": 450,
- "num_range": 6600,
- "upper_bound": "1997-12-20"
+ "distinct_range": 11,
+ "num_eq": 1050,
+ "num_range": 5850,
+ "upper_bound": "1997-12-18"
},
{
- "distinct_range": 9,
- "num_eq": 600,
+ "distinct_range": 11,
+ "num_eq": 450,
"num_range": 6750,
"upper_bound": "1997-12-30"
},
{
- "distinct_range": 12,
- "num_eq": 600,
- "num_range": 6300,
- "upper_bound": "1998-01-12"
+ "distinct_range": 10,
+ "num_eq": 750,
+ "num_range": 6750,
+ "upper_bound": "1998-01-10"
},
{
- "distinct_range": 10,
- "num_eq": 600,
- "num_range": 6300,
+ "distinct_range": 12,
+ "num_eq": 900,
+ "num_range": 6600,
"upper_bound": "1998-01-23"
},
{
- "distinct_range": 12,
- "num_eq": 1200,
- "num_range": 6000,
- "upper_bound": "1998-02-05"
+ "distinct_range": 9,
+ "num_eq": 600,
+ "num_range": 6150,
+ "upper_bound": "1998-02-02"
},
{
- "distinct_range": 11,
- "num_eq": 1050,
- "num_range": 6450,
- "upper_bound": "1998-02-17"
+ "distinct_range": 12,
+ "num_eq": 450,
+ "num_range": 6600,
+ "upper_bound": "1998-02-15"
},
{
- "distinct_range": 8,
+ "distinct_range": 12,
"num_eq": 750,
"num_range": 6150,
- "upper_bound": "1998-02-26"
- },
- {
- "distinct_range": 13,
- "num_eq": 600,
- "num_range": 6300,
- "upper_bound": "1998-03-12"
+ "upper_bound": "1998-02-28"
},
{
"distinct_range": 10,
- "num_eq": 600,
+ "num_eq": 1350,
"num_range": 6600,
- "upper_bound": "1998-03-23"
+ "upper_bound": "1998-03-11"
},
{
- "distinct_range": 10,
- "num_eq": 600,
- "num_range": 6450,
- "upper_bound": "1998-04-03"
+ "distinct_range": 12,
+ "num_eq": 450,
+ "num_range": 6600,
+ "upper_bound": "1998-03-24"
},
{
"distinct_range": 9,
- "num_eq": 900,
- "num_range": 6600,
- "upper_bound": "1998-04-13"
+ "num_eq": 1200,
+ "num_range": 6000,
+ "upper_bound": "1998-04-03"
},
{
- "distinct_range": 10,
- "num_eq": 1200,
+ "distinct_range": 8,
+ "num_eq": 1350,
"num_range": 5550,
+ "upper_bound": "1998-04-12"
+ },
+ {
+ "distinct_range": 11,
+ "num_eq": 450,
+ "num_range": 6150,
"upper_bound": "1998-04-24"
},
+ {
+ "distinct_range": 10,
+ "num_eq": 450,
+ "num_range": 6300,
+ "upper_bound": "1998-05-05"
+ },
{
"distinct_range": 12,
"num_eq": 900,
"num_range": 6450,
- "upper_bound": "1998-05-07"
+ "upper_bound": "1998-05-18"
},
{
- "distinct_range": 11,
- "num_eq": 1050,
- "num_range": 5550,
- "upper_bound": "1998-05-19"
+ "distinct_range": 12,
+ "num_eq": 750,
+ "num_range": 6450,
+ "upper_bound": "1998-05-31"
},
{
- "distinct_range": 12,
- "num_eq": 900,
+ "distinct_range": 10,
+ "num_eq": 1650,
"num_range": 6000,
- "upper_bound": "1998-06-01"
+ "upper_bound": "1998-06-11"
},
{
- "distinct_range": 11,
- "num_eq": 900,
+ "distinct_range": 8,
+ "num_eq": 750,
"num_range": 5850,
- "upper_bound": "1998-06-13"
+ "upper_bound": "1998-06-20"
},
{
- "distinct_range": 13,
- "num_eq": 300,
- "num_range": 6300,
- "upper_bound": "1998-06-27"
+ "distinct_range": 9,
+ "num_eq": 450,
+ "num_range": 6000,
+ "upper_bound": "1998-06-30"
},
{
- "distinct_range": 14,
- "num_eq": 600,
- "num_range": 6450,
+ "distinct_range": 11,
+ "num_eq": 900,
+ "num_range": 5250,
"upper_bound": "1998-07-12"
},
{
- "distinct_range": 13,
- "num_eq": 450,
- "num_range": 6450,
- "upper_bound": "1998-07-26"
+ "distinct_range": 10,
+ "num_eq": 1050,
+ "num_range": 5400,
+ "upper_bound": "1998-07-23"
},
{
- "distinct_range": 6,
- "num_eq": 450,
- "num_range": 5850,
+ "distinct_range": 9,
+ "num_eq": 600,
+ "num_range": 5400,
"upper_bound": "1998-08-02"
}
],
@@ -13100,22 +13145,23 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 3,
"columns": [
"o_orderstatus"
],
- "created_at": "2021-09-08 20:49:26.228164",
+ "created_at": "2022-02-25 00:54:45.88743",
"distinct_count": 3,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 745350,
+ "num_eq": 733050,
"num_range": 0,
"upper_bound": "F"
},
{
"distinct_range": 1,
"num_eq": 37200,
- "num_range": 717450,
+ "num_range": 729750,
"upper_bound": "P"
}
],
@@ -13126,23 +13172,24 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 9,
"columns": [
"o_totalprice"
],
- "created_at": "2021-09-08 20:49:26.228164",
- "distinct_count": 1469395,
+ "created_at": "2022-02-25 00:54:45.88743",
+ "distinct_count": 1459167,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 150,
"num_range": 0,
- "upper_bound": "929.1190185546875"
+ "upper_bound": "1094.65"
},
{
- "distinct_range": 1469393,
+ "distinct_range": 1459165,
"num_eq": 150,
"num_range": 1499700,
- "upper_bound": "465073.34375"
+ "upper_bound": "477728.86"
}
],
"histo_col_type": "FLOAT8",
@@ -13152,23 +13199,24 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 11,
"columns": [
"o_orderpriority"
],
- "created_at": "2021-09-08 20:49:26.228164",
- "distinct_count": 4,
+ "created_at": "2022-02-25 00:54:45.88743",
+ "distinct_count": 5,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 380100,
+ "num_eq": 292200,
"num_range": 0,
"upper_bound": "1-URGENT"
},
{
- "distinct_range": 1.9999999999999998,
- "num_eq": 384750,
- "num_range": 735150,
- "upper_bound": "4-NOT SPECIFIED"
+ "distinct_range": 3,
+ "num_eq": 291900,
+ "num_range": 915900,
+ "upper_bound": "5-LOW"
}
],
"histo_col_type": "CHAR(15)",
@@ -13178,22 +13226,23 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 17,
"columns": [
"o_clerk"
],
- "created_at": "2021-09-08 20:49:26.228164",
+ "created_at": "2022-02-25 00:54:45.88743",
"distinct_count": 1000,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1350,
+ "num_eq": 900,
"num_range": 0,
"upper_bound": "Clerk#000000001"
},
{
"distinct_range": 998,
- "num_eq": 1950,
- "num_range": 1496700,
+ "num_eq": 1800,
+ "num_range": 1497300,
"upper_bound": "Clerk#000001000"
}
],
@@ -13204,10 +13253,11 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 2,
"columns": [
"o_shippriority"
],
- "created_at": "2021-09-08 20:49:26.228164",
+ "created_at": "2022-02-25 00:54:45.88743",
"distinct_count": 1,
"histo_buckets": [
{
@@ -13224,23 +13274,24 @@ ALTER TABLE "orders" INJECT STATISTICS '[
"row_count": 1500000
},
{
+ "avg_size": 51,
"columns": [
"o_comment"
],
- "created_at": "2021-09-08 20:49:26.228164",
- "distinct_count": 1473851,
+ "created_at": "2022-02-25 00:54:45.88743",
+ "distinct_count": 1469402,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 150,
"num_range": 0,
- "upper_bound": " A factor person not up industry per"
+ "upper_bound": " about the blithely final pack"
},
{
- "distinct_range": 1473849,
+ "distinct_range": 1469400,
"num_eq": 150,
"num_range": 1499700,
- "upper_bound": "zine. Wonder population enter share directo"
+ "upper_bound": "zzle about the thinly unusual asymptotes. quickly bold courts nag"
}
],
"histo_col_type": "VARCHAR(79)",
@@ -13255,1223 +13306,1212 @@ ALTER TABLE "orders" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "part" INJECT STATISTICS '[
{
+ "avg_size": 4,
"columns": [
"p_partkey"
],
- "created_at": "2021-09-08 20:49:15.330151",
+ "created_at": "2022-02-25 00:55:35.512954",
"distinct_count": 199241,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 0,
- "num_range": 0,
- "upper_bound": "-9223372036854775808"
- },
- {
- "distinct_range": 2.9103830456733704E-11,
"num_eq": 4,
"num_range": 0,
- "upper_bound": "28"
- },
- {
- "distinct_range": 1034.1282259367986,
- "num_eq": 4,
- "num_range": 1015,
- "upper_bound": "1067"
+ "upper_bound": "23"
},
{
- "distinct_range": 1086.7393585371906,
+ "distinct_range": 874.221434129422,
"num_eq": 4,
- "num_range": 1044,
- "upper_bound": "2159"
+ "num_range": 930,
+ "upper_bound": "901"
},
{
- "distinct_range": 908.0214064021079,
+ "distinct_range": 1242.4862900983414,
"num_eq": 4,
- "num_range": 947,
- "upper_bound": "3071"
+ "num_range": 1136,
+ "upper_bound": "2150"
},
{
- "distinct_range": 1192.9303222140175,
+ "distinct_range": 862.3016580897098,
"num_eq": 4,
- "num_range": 1106,
- "upper_bound": "4270"
+ "num_range": 924,
+ "upper_bound": "3016"
},
{
- "distinct_range": 1040.0846382179252,
+ "distinct_range": 1071.8074341577637,
"num_eq": 4,
- "num_range": 1018,
- "upper_bound": "5315"
+ "num_range": 1037,
+ "upper_bound": "4093"
},
{
- "distinct_range": 1046.0409364425682,
+ "distinct_range": 940.7620135850256,
"num_eq": 4,
- "num_range": 1021,
- "upper_bound": "6366"
+ "num_range": 965,
+ "upper_bound": "5038"
},
{
- "distinct_range": 775.8840236682298,
+ "distinct_range": 919.9080256268564,
"num_eq": 4,
- "num_range": 881,
- "upper_bound": "7145"
+ "num_range": 954,
+ "upper_bound": "5962"
},
{
- "distinct_range": 923.9122292105164,
+ "distinct_range": 812.6285367846343,
"num_eq": 4,
- "num_range": 955,
- "upper_bound": "8073"
+ "num_range": 900,
+ "upper_bound": "6778"
},
{
- "distinct_range": 781.8470235354425,
+ "distinct_range": 1271.256573943723,
"num_eq": 4,
- "num_range": 884,
- "upper_bound": "8858"
+ "num_range": 1153,
+ "upper_bound": "8056"
},
{
- "distinct_range": 883.1898507261051,
+ "distinct_range": 1214.706342573096,
"num_eq": 4,
- "num_range": 934,
- "upper_bound": "9745"
+ "num_range": 1119,
+ "upper_bound": "9277"
},
{
- "distinct_range": 798.7411268707331,
+ "distinct_range": 1246.454712223711,
"num_eq": 4,
- "num_range": 892,
- "upper_bound": "10547"
+ "num_range": 1138,
+ "upper_bound": "10530"
},
{
- "distinct_range": 1159.1906039738356,
+ "distinct_range": 1232.565081344692,
"num_eq": 4,
- "num_range": 1086,
- "upper_bound": "11712"
+ "num_range": 1130,
+ "upper_bound": "11769"
},
{
- "distinct_range": 1089.717096306502,
+ "distinct_range": 1244.4705055139386,
"num_eq": 4,
- "num_range": 1046,
- "upper_bound": "12807"
+ "num_range": 1137,
+ "upper_bound": "13020"
},
{
- "distinct_range": 1242.5426326480656,
+ "distinct_range": 976.5077251070885,
"num_eq": 4,
- "num_range": 1135,
- "upper_bound": "14056"
+ "num_range": 984,
+ "upper_bound": "14001"
},
{
- "distinct_range": 1023.2078359902926,
+ "distinct_range": 976.5077251070885,
"num_eq": 4,
- "num_range": 1009,
- "upper_bound": "15084"
+ "num_range": 984,
+ "upper_bound": "14982"
},
{
- "distinct_range": 1183.0071672593988,
+ "distinct_range": 1058.9040089425953,
"num_eq": 4,
- "num_range": 1100,
- "upper_bound": "16273"
+ "num_range": 1029,
+ "upper_bound": "16046"
},
{
- "distinct_range": 899.0823530458953,
+ "distinct_range": 1021.1832664187536,
"num_eq": 4,
- "num_range": 942,
- "upper_bound": "17176"
+ "num_range": 1008,
+ "upper_bound": "17072"
},
{
- "distinct_range": 987.4655584979779,
+ "distinct_range": 1071.8074341577637,
"num_eq": 4,
- "num_range": 989,
- "upper_bound": "18168"
+ "num_range": 1037,
+ "upper_bound": "18149"
},
{
- "distinct_range": 1015.2654856545755,
+ "distinct_range": 782.818546124614,
"num_eq": 4,
- "num_range": 1004,
- "upper_bound": "19188"
+ "num_range": 885,
+ "upper_bound": "18935"
},
{
- "distinct_range": 804.7033844042501,
+ "distinct_range": 980.4791731398659,
"num_eq": 4,
- "num_range": 895,
- "upper_bound": "19996"
+ "num_range": 986,
+ "upper_bound": "19920"
},
{
- "distinct_range": 963.6348564617992,
+ "distinct_range": 951.6848362334545,
"num_eq": 4,
- "num_range": 976,
- "upper_bound": "20964"
+ "num_range": 971,
+ "upper_bound": "20876"
},
{
- "distinct_range": 1254.4487642773033,
+ "distinct_range": 1071.8074341577637,
"num_eq": 4,
- "num_range": 1142,
- "upper_bound": "22225"
+ "num_range": 1037,
+ "upper_bound": "21953"
},
{
- "distinct_range": 990.4442515114226,
+ "distinct_range": 902.0317438143205,
"num_eq": 4,
- "num_range": 991,
- "upper_bound": "23220"
+ "num_range": 944,
+ "upper_bound": "22859"
},
{
- "distinct_range": 1024.2006149673812,
+ "distinct_range": 1044.0147929427812,
"num_eq": 4,
- "num_range": 1009,
- "upper_bound": "24249"
+ "num_range": 1021,
+ "upper_bound": "23908"
},
{
- "distinct_range": 1140.334799153503,
+ "distinct_range": 1010.263223971668,
"num_eq": 4,
- "num_range": 1075,
- "upper_bound": "25395"
+ "num_range": 1002,
+ "upper_bound": "24923"
},
{
- "distinct_range": 946.753492320125,
+ "distinct_range": 1010.263223971668,
"num_eq": 4,
- "num_range": 967,
- "upper_bound": "26346"
+ "num_range": 1002,
+ "upper_bound": "25938"
},
{
- "distinct_range": 997.3944129822291,
+ "distinct_range": 922.8872755271803,
"num_eq": 4,
- "num_range": 995,
- "upper_bound": "27348"
+ "num_range": 955,
+ "upper_bound": "26865"
},
{
- "distinct_range": 829.5441337918393,
+ "distinct_range": 1072.799984118485,
"num_eq": 4,
- "num_range": 907,
- "upper_bound": "28181"
+ "num_range": 1037,
+ "upper_bound": "27943"
},
{
- "distinct_range": 1166.1372485838874,
+ "distinct_range": 990.4075415149892,
"num_eq": 4,
- "num_range": 1090,
- "upper_bound": "29353"
+ "num_range": 991,
+ "upper_bound": "28938"
},
{
- "distinct_range": 860.3424017040873,
+ "distinct_range": 871.2415517552771,
"num_eq": 4,
- "num_range": 923,
- "upper_bound": "30217"
+ "num_range": 929,
+ "upper_bound": "29813"
},
{
- "distinct_range": 1027.1789323025148,
+ "distinct_range": 1026.1467885833845,
"num_eq": 4,
"num_range": 1011,
- "upper_bound": "31249"
+ "upper_bound": "30844"
},
{
- "distinct_range": 778.8655484342081,
+ "distinct_range": 799.7114638872596,
"num_eq": 4,
- "num_range": 883,
- "upper_bound": "32031"
+ "num_range": 893,
+ "upper_bound": "31647"
},
{
- "distinct_range": 955.690820612466,
+ "distinct_range": 933.8108801423666,
"num_eq": 4,
- "num_range": 972,
- "upper_bound": "32991"
+ "num_range": 961,
+ "upper_bound": "32585"
},
{
- "distinct_range": 735.1313615952374,
+ "distinct_range": 1113.4920142451888,
"num_eq": 4,
- "num_range": 863,
- "upper_bound": "33729"
+ "num_range": 1060,
+ "upper_bound": "33704"
},
{
- "distinct_range": 957.6768519893668,
+ "distinct_range": 908.9837921384186,
"num_eq": 4,
- "num_range": 973,
- "upper_bound": "34691"
+ "num_range": 948,
+ "upper_bound": "34617"
},
{
- "distinct_range": 866.302835944356,
+ "distinct_range": 827.5317675332893,
"num_eq": 4,
- "num_range": 926,
- "upper_bound": "35561"
+ "num_range": 907,
+ "upper_bound": "35448"
},
{
- "distinct_range": 1278.260119555755,
+ "distinct_range": 886.140559719332,
"num_eq": 4,
- "num_range": 1157,
- "upper_bound": "36846"
+ "num_range": 936,
+ "upper_bound": "36338"
},
{
- "distinct_range": 1179.0378380731963,
+ "distinct_range": 730.1418549185893,
"num_eq": 4,
- "num_range": 1098,
- "upper_bound": "38031"
+ "num_range": 861,
+ "upper_bound": "37071"
},
{
- "distinct_range": 957.6768519893668,
+ "distinct_range": 953.6707538621423,
"num_eq": 4,
- "num_range": 973,
- "upper_bound": "38993"
+ "num_range": 972,
+ "upper_bound": "38029"
},
{
- "distinct_range": 978.5292884382686,
+ "distinct_range": 1127.3857672623624,
"num_eq": 4,
- "num_range": 984,
- "upper_bound": "39976"
+ "num_range": 1068,
+ "upper_bound": "39162"
},
{
- "distinct_range": 1018.2438918206327,
+ "distinct_range": 996.3643922626629,
"num_eq": 4,
- "num_range": 1006,
- "upper_bound": "40999"
+ "num_range": 995,
+ "upper_bound": "40163"
},
{
- "distinct_range": 1094.6799351839372,
+ "distinct_range": 935.7969380342,
"num_eq": 4,
- "num_range": 1049,
- "upper_bound": "42099"
+ "num_range": 962,
+ "upper_bound": "41103"
},
{
- "distinct_range": 1158.1982161381093,
+ "distinct_range": 901.0385771064622,
"num_eq": 4,
- "num_range": 1085,
- "upper_bound": "43263"
+ "num_range": 944,
+ "upper_bound": "42008"
},
{
- "distinct_range": 811.6591147277746,
+ "distinct_range": 816.602843810012,
"num_eq": 4,
- "num_range": 899,
- "upper_bound": "44078"
+ "num_range": 902,
+ "upper_bound": "42828"
},
{
- "distinct_range": 817.6209691424256,
+ "distinct_range": 956.6496017043565,
"num_eq": 4,
- "num_range": 901,
- "upper_bound": "44899"
+ "num_range": 973,
+ "upper_bound": "43789"
},
{
- "distinct_range": 1493.5066847862795,
+ "distinct_range": 926.8595517806217,
"num_eq": 4,
- "num_range": 1290,
- "upper_bound": "46401"
+ "num_range": 957,
+ "upper_bound": "44720"
},
{
- "distinct_range": 741.0957834497686,
+ "distinct_range": 1193.8702051642342,
"num_eq": 4,
- "num_range": 865,
- "upper_bound": "47145"
+ "num_range": 1107,
+ "upper_bound": "45920"
},
{
- "distinct_range": 897.0958503540534,
+ "distinct_range": 1270.2645247623625,
"num_eq": 4,
- "num_range": 941,
- "upper_bound": "48046"
+ "num_range": 1153,
+ "upper_bound": "47197"
},
{
- "distinct_range": 950.7256762075967,
+ "distinct_range": 947.7129549300556,
"num_eq": 4,
- "num_range": 969,
- "upper_bound": "49001"
+ "num_range": 968,
+ "upper_bound": "48149"
},
{
- "distinct_range": 912.98740120603,
+ "distinct_range": 901.0385771064622,
"num_eq": 4,
- "num_range": 950,
- "upper_bound": "49918"
+ "num_range": 944,
+ "upper_bound": "49054"
},
{
- "distinct_range": 1050.0117392243826,
+ "distinct_range": 848.3944078642976,
"num_eq": 4,
- "num_range": 1024,
- "upper_bound": "50973"
+ "num_range": 917,
+ "upper_bound": "49906"
},
{
- "distinct_range": 742.0898326410103,
+ "distinct_range": 1142.2713441107564,
"num_eq": 4,
- "num_range": 866,
- "upper_bound": "51718"
+ "num_range": 1077,
+ "upper_bound": "51054"
},
{
- "distinct_range": 1043.0628015029752,
+ "distinct_range": 882.1675890988172,
"num_eq": 4,
- "num_range": 1020,
- "upper_bound": "52766"
+ "num_range": 934,
+ "upper_bound": "51940"
},
{
- "distinct_range": 1100.6352479639602,
+ "distinct_range": 1197.8390731294216,
"num_eq": 4,
- "num_range": 1052,
- "upper_bound": "53872"
+ "num_range": 1109,
+ "upper_bound": "53144"
},
{
- "distinct_range": 906.0349794347287,
+ "distinct_range": 1151.2024055610655,
"num_eq": 4,
- "num_range": 946,
- "upper_bound": "54782"
+ "num_range": 1082,
+ "upper_bound": "54301"
},
{
- "distinct_range": 876.236530190367,
+ "distinct_range": 961.614272361726,
"num_eq": 4,
- "num_range": 931,
- "upper_bound": "55662"
+ "num_range": 976,
+ "upper_bound": "55267"
},
{
- "distinct_range": 1160.182989291687,
+ "distinct_range": 1046.0000625704315,
"num_eq": 4,
- "num_range": 1087,
- "upper_bound": "56828"
+ "num_range": 1022,
+ "upper_bound": "56318"
},
{
- "distinct_range": 1198.8841013732163,
+ "distinct_range": 1069.8223252112614,
"num_eq": 4,
- "num_range": 1109,
- "upper_bound": "58033"
+ "num_range": 1035,
+ "upper_bound": "57393"
},
{
- "distinct_range": 1188.9610888587772,
+ "distinct_range": 826.538254243168,
"num_eq": 4,
- "num_range": 1103,
- "upper_bound": "59228"
+ "num_range": 906,
+ "upper_bound": "58223"
},
{
- "distinct_range": 974.5575198798955,
+ "distinct_range": 819.5835202345237,
"num_eq": 4,
- "num_range": 982,
- "upper_bound": "60207"
+ "num_range": 903,
+ "upper_bound": "59046"
},
{
- "distinct_range": 947.7465440204509,
+ "distinct_range": 944.734003411183,
"num_eq": 4,
- "num_range": 968,
- "upper_bound": "61159"
+ "num_range": 967,
+ "upper_bound": "59995"
},
{
- "distinct_range": 949.7326359562833,
+ "distinct_range": 1149.21774343676,
"num_eq": 4,
- "num_range": 969,
- "upper_bound": "62113"
+ "num_range": 1081,
+ "upper_bound": "61150"
},
{
- "distinct_range": 1089.717096306502,
+ "distinct_range": 870.2482485517187,
"num_eq": 4,
- "num_range": 1046,
- "upper_bound": "63208"
+ "num_range": 928,
+ "upper_bound": "62024"
},
{
- "distinct_range": 659.5619770135552,
+ "distinct_range": 887.1337913456291,
"num_eq": 4,
- "num_range": 830,
- "upper_bound": "63870"
+ "num_range": 937,
+ "upper_bound": "62915"
},
{
- "distinct_range": 1154.2286395227743,
+ "distinct_range": 1023.1686852101634,
"num_eq": 4,
- "num_range": 1083,
- "upper_bound": "65030"
+ "num_range": 1009,
+ "upper_bound": "63943"
},
{
- "distinct_range": 1183.9994935226025,
+ "distinct_range": 1066.8446391409298,
"num_eq": 4,
- "num_range": 1101,
- "upper_bound": "66220"
+ "num_range": 1034,
+ "upper_bound": "65015"
},
{
- "distinct_range": 1022.2150537363245,
+ "distinct_range": 821.5706123795198,
"num_eq": 4,
- "num_range": 1008,
- "upper_bound": "67247"
+ "num_range": 904,
+ "upper_bound": "65840"
},
{
- "distinct_range": 1081.7764043691864,
+ "distinct_range": 904.0180644747262,
"num_eq": 4,
- "num_range": 1042,
- "upper_bound": "68334"
+ "num_range": 945,
+ "upper_bound": "66748"
},
{
- "distinct_range": 1087.7319406767697,
+ "distinct_range": 832.4992591749703,
"num_eq": 4,
- "num_range": 1045,
- "upper_bound": "69427"
+ "num_range": 909,
+ "upper_bound": "67584"
},
{
- "distinct_range": 761.9695748519457,
+ "distinct_range": 1022.175977473117,
"num_eq": 4,
- "num_range": 875,
- "upper_bound": "70192"
+ "num_range": 1009,
+ "upper_bound": "68611"
},
{
- "distinct_range": 1142.3196644856619,
+ "distinct_range": 1112.499582685247,
"num_eq": 4,
- "num_range": 1076,
- "upper_bound": "71340"
+ "num_range": 1060,
+ "upper_bound": "69729"
},
{
- "distinct_range": 1169.1143446140482,
+ "distinct_range": 1148.2254084895883,
"num_eq": 4,
- "num_range": 1092,
- "upper_bound": "72515"
+ "num_range": 1080,
+ "upper_bound": "70883"
},
{
- "distinct_range": 863.3226394239734,
+ "distinct_range": 838.4600859992099,
"num_eq": 4,
- "num_range": 924,
- "upper_bound": "73382"
+ "num_range": 912,
+ "upper_bound": "71725"
},
{
- "distinct_range": 1096.6650507715824,
+ "distinct_range": 1194.8624257227605,
"num_eq": 4,
- "num_range": 1050,
- "upper_bound": "74484"
+ "num_range": 1108,
+ "upper_bound": "72926"
},
{
- "distinct_range": 1122.4705368632071,
+ "distinct_range": 993.385982712386,
"num_eq": 4,
- "num_range": 1065,
- "upper_bound": "75612"
+ "num_range": 993,
+ "upper_bound": "73924"
},
{
- "distinct_range": 1108.5755076244955,
+ "distinct_range": 962.607195201297,
"num_eq": 4,
- "num_range": 1057,
- "upper_bound": "76726"
+ "num_range": 976,
+ "upper_bound": "74891"
},
{
- "distinct_range": 739.1076670209452,
+ "distinct_range": 1278.200860305189,
"num_eq": 4,
- "num_range": 865,
- "upper_bound": "77468"
+ "num_range": 1157,
+ "upper_bound": "76176"
},
{
- "distinct_range": 1174.0761219570395,
+ "distinct_range": 1082.725319649657,
"num_eq": 4,
- "num_range": 1095,
- "upper_bound": "78648"
+ "num_range": 1043,
+ "upper_bound": "77264"
},
{
- "distinct_range": 858.3555535366979,
+ "distinct_range": 1135.3248161215251,
"num_eq": 4,
- "num_range": 922,
- "upper_bound": "79510"
+ "num_range": 1073,
+ "upper_bound": "78405"
},
{
- "distinct_range": 898.0891038235665,
+ "distinct_range": 848.3944078642976,
"num_eq": 4,
- "num_range": 942,
- "upper_bound": "80412"
+ "num_range": 917,
+ "upper_bound": "79257"
},
{
- "distinct_range": 1106.590459442869,
+ "distinct_range": 1047.9853195450942,
"num_eq": 4,
- "num_range": 1056,
- "upper_bound": "81524"
+ "num_range": 1023,
+ "upper_bound": "80310"
},
{
- "distinct_range": 1087.7319406767697,
+ "distinct_range": 1006.2921979816167,
"num_eq": 4,
- "num_range": 1045,
- "upper_bound": "82617"
+ "num_range": 1000,
+ "upper_bound": "81321"
},
{
- "distinct_range": 895.1093306373282,
+ "distinct_range": 944.734003411183,
"num_eq": 4,
- "num_range": 940,
- "upper_bound": "83516"
+ "num_range": 967,
+ "upper_bound": "82270"
},
{
- "distinct_range": 853.3883519621802,
+ "distinct_range": 888.1270185792088,
"num_eq": 4,
- "num_range": 919,
- "upper_bound": "84373"
+ "num_range": 937,
+ "upper_bound": "83162"
},
{
- "distinct_range": 1083.7615947527906,
+ "distinct_range": 883.1608383901221,
"num_eq": 4,
- "num_range": 1043,
- "upper_bound": "85462"
+ "num_range": 935,
+ "upper_bound": "84049"
},
{
- "distinct_range": 818.6145937670283,
+ "distinct_range": 950.6918716752664,
"num_eq": 4,
- "num_range": 902,
- "upper_bound": "86284"
+ "num_range": 970,
+ "upper_bound": "85004"
},
{
- "distinct_range": 1015.2654856545755,
+ "distinct_range": 1244.4705055139386,
"num_eq": 4,
- "num_range": 1004,
- "upper_bound": "87304"
+ "num_range": 1137,
+ "upper_bound": "86255"
},
{
- "distinct_range": 1313.9749754825118,
+ "distinct_range": 1002.321117186191,
"num_eq": 4,
- "num_range": 1178,
- "upper_bound": "88625"
+ "num_range": 998,
+ "upper_bound": "87262"
},
{
- "distinct_range": 872.2631064475722,
+ "distinct_range": 992.393172505763,
"num_eq": 4,
- "num_range": 929,
- "upper_bound": "89501"
+ "num_range": 992,
+ "upper_bound": "88259"
},
{
- "distinct_range": 1128.4253866551544,
+ "distinct_range": 1012.2487165518983,
"num_eq": 4,
- "num_range": 1068,
- "upper_bound": "90635"
+ "num_range": 1003,
+ "upper_bound": "89276"
},
{
- "distinct_range": 985.4797455525817,
+ "distinct_range": 1092.6503608668809,
"num_eq": 4,
- "num_range": 988,
- "upper_bound": "91625"
+ "num_range": 1048,
+ "upper_bound": "90374"
},
{
- "distinct_range": 762.9635009004877,
+ "distinct_range": 1113.4920142451888,
"num_eq": 4,
- "num_range": 875,
- "upper_bound": "92391"
+ "num_range": 1060,
+ "upper_bound": "91493"
},
{
- "distinct_range": 840.4730773649975,
+ "distinct_range": 956.6496017043565,
"num_eq": 4,
- "num_range": 913,
- "upper_bound": "93235"
+ "num_range": 973,
+ "upper_bound": "92454"
},
{
- "distinct_range": 667.518499627749,
+ "distinct_range": 852.3680022486435,
"num_eq": 4,
- "num_range": 833,
- "upper_bound": "93905"
+ "num_range": 919,
+ "upper_bound": "93310"
},
{
- "distinct_range": 921.9259333611353,
+ "distinct_range": 931.824806339093,
"num_eq": 4,
- "num_range": 954,
- "upper_bound": "94831"
+ "num_range": 960,
+ "upper_bound": "94246"
},
{
- "distinct_range": 1146.2893640019415,
+ "distinct_range": 1155.1716988642695,
"num_eq": 4,
- "num_range": 1079,
- "upper_bound": "95983"
+ "num_range": 1084,
+ "upper_bound": "95407"
},
{
- "distinct_range": 786.8160392381592,
+ "distinct_range": 884.1540832510046,
"num_eq": 4,
- "num_range": 887,
- "upper_bound": "96773"
+ "num_range": 935,
+ "upper_bound": "96295"
},
{
- "distinct_range": 803.709687903128,
+ "distinct_range": 814.6157005911286,
"num_eq": 4,
- "num_range": 895,
- "upper_bound": "97580"
+ "num_range": 901,
+ "upper_bound": "97113"
},
{
- "distinct_range": 893.1227938231891,
+ "distinct_range": 951.6848362334545,
"num_eq": 4,
- "num_range": 939,
- "upper_bound": "98477"
+ "num_range": 971,
+ "upper_bound": "98069"
},
{
- "distinct_range": 984.4868337774674,
+ "distinct_range": 917.9218385600012,
"num_eq": 4,
- "num_range": 988,
- "upper_bound": "99466"
+ "num_range": 953,
+ "upper_bound": "98991"
},
{
- "distinct_range": 981.5080771560171,
+ "distinct_range": 1119.446545548692,
"num_eq": 4,
- "num_range": 986,
- "upper_bound": "100452"
+ "num_range": 1064,
+ "upper_bound": "100116"
},
{
- "distinct_range": 1013.2798649066622,
+ "distinct_range": 752.009658365736,
"num_eq": 4,
- "num_range": 1003,
- "upper_bound": "101470"
+ "num_range": 871,
+ "upper_bound": "100871"
},
{
- "distinct_range": 1084.7541855807863,
+ "distinct_range": 929.8387165578055,
"num_eq": 4,
- "num_range": 1043,
- "upper_bound": "102560"
+ "num_range": 959,
+ "upper_bound": "101805"
},
{
- "distinct_range": 1470.6961424273122,
+ "distinct_range": 1060.8891848735348,
"num_eq": 4,
- "num_range": 1275,
- "upper_bound": "104039"
+ "num_range": 1030,
+ "upper_bound": "102871"
},
{
- "distinct_range": 1108.5755076244955,
+ "distinct_range": 901.0385771064622,
"num_eq": 4,
- "num_range": 1057,
- "upper_bound": "105153"
+ "num_range": 944,
+ "upper_bound": "103776"
},
{
- "distinct_range": 920.9327793846735,
+ "distinct_range": 756.9792086449777,
"num_eq": 4,
- "num_range": 954,
- "upper_bound": "106078"
+ "num_range": 873,
+ "upper_bound": "104536"
},
{
- "distinct_range": 952.7117453163858,
+ "distinct_range": 956.6496017043565,
"num_eq": 4,
- "num_range": 971,
- "upper_bound": "107035"
+ "num_range": 973,
+ "upper_bound": "105497"
},
{
- "distinct_range": 1066.8871012272562,
+ "distinct_range": 1024.1613896364997,
"num_eq": 4,
- "num_range": 1033,
- "upper_bound": "108107"
+ "num_range": 1010,
+ "upper_bound": "106526"
},
{
- "distinct_range": 947.7465440204509,
+ "distinct_range": 763.9363333880165,
"num_eq": 4,
- "num_range": 968,
- "upper_bound": "109059"
+ "num_range": 876,
+ "upper_bound": "107293"
},
{
- "distinct_range": 950.7256762075967,
+ "distinct_range": 1229.588675541321,
"num_eq": 4,
- "num_range": 969,
- "upper_bound": "110014"
+ "num_range": 1128,
+ "upper_bound": "108529"
},
{
- "distinct_range": 891.1362398387278,
+ "distinct_range": 984.450563405726,
"num_eq": 4,
- "num_range": 938,
- "upper_bound": "110909"
+ "num_range": 988,
+ "upper_bound": "109518"
},
{
- "distinct_range": 1235.5972458533338,
+ "distinct_range": 1277.2088255756046,
"num_eq": 4,
- "num_range": 1131,
- "upper_bound": "112151"
+ "num_range": 1157,
+ "upper_bound": "110802"
},
{
- "distinct_range": 852.3948976542463,
+ "distinct_range": 954.6637069484497,
"num_eq": 4,
- "num_range": 919,
- "upper_bound": "113007"
+ "num_range": 972,
+ "upper_bound": "111761"
},
{
- "distinct_range": 824.5762358605028,
+ "distinct_range": 1276.2167887922767,
"num_eq": 4,
- "num_range": 905,
- "upper_bound": "113835"
+ "num_range": 1156,
+ "upper_bound": "113044"
},
{
- "distinct_range": 929.871020536925,
+ "distinct_range": 875.2147192077563,
"num_eq": 4,
- "num_range": 958,
- "upper_bound": "114769"
+ "num_range": 931,
+ "upper_bound": "113923"
},
{
- "distinct_range": 1407.2191430428416,
+ "distinct_range": 1098.6052466682056,
"num_eq": 4,
- "num_range": 1236,
- "upper_bound": "116184"
+ "num_range": 1052,
+ "upper_bound": "115027"
},
{
- "distinct_range": 1193.9226246287624,
+ "distinct_range": 1086.695371136674,
"num_eq": 4,
- "num_range": 1106,
- "upper_bound": "117384"
+ "num_range": 1045,
+ "upper_bound": "116119"
},
{
- "distinct_range": 1026.1861631169945,
+ "distinct_range": 745.0520387943418,
"num_eq": 4,
- "num_range": 1010,
- "upper_bound": "118415"
+ "num_range": 868,
+ "upper_bound": "116867"
},
{
- "distinct_range": 1093.6873731232115,
+ "distinct_range": 810.6413522995009,
"num_eq": 4,
- "num_range": 1048,
- "upper_bound": "119514"
+ "num_range": 899,
+ "upper_bound": "117681"
},
{
- "distinct_range": 915.9669486445752,
+ "distinct_range": 868.2616284676358,
"num_eq": 4,
- "num_range": 951,
- "upper_bound": "120434"
+ "num_range": 927,
+ "upper_bound": "118553"
},
{
- "distinct_range": 1049.0190432037975,
+ "distinct_range": 943.7410118066211,
"num_eq": 4,
- "num_range": 1023,
- "upper_bound": "121488"
+ "num_range": 966,
+ "upper_bound": "119501"
},
{
- "distinct_range": 1132.3952330857855,
+ "distinct_range": 1056.918820677402,
"num_eq": 4,
- "num_range": 1070,
- "upper_bound": "122626"
+ "num_range": 1028,
+ "upper_bound": "120563"
},
{
- "distinct_range": 1018.2438918206327,
+ "distinct_range": 995.3715925837362,
"num_eq": 4,
- "num_range": 1006,
- "upper_bound": "123649"
+ "num_range": 994,
+ "upper_bound": "121563"
},
{
- "distinct_range": 1214.7604364884662,
+ "distinct_range": 870.2482485517187,
"num_eq": 4,
- "num_range": 1119,
- "upper_bound": "124870"
+ "num_range": 928,
+ "upper_bound": "122437"
},
{
- "distinct_range": 656.5781618784149,
+ "distinct_range": 958.6354812902382,
"num_eq": 4,
- "num_range": 829,
- "upper_bound": "125529"
+ "num_range": 974,
+ "upper_bound": "123400"
},
{
- "distinct_range": 1217.7371840348555,
+ "distinct_range": 884.1540832510046,
"num_eq": 4,
- "num_range": 1120,
- "upper_bound": "126753"
+ "num_range": 935,
+ "upper_bound": "124288"
},
{
- "distinct_range": 690.39099354222,
+ "distinct_range": 916.9287388607298,
"num_eq": 4,
- "num_range": 843,
- "upper_bound": "127446"
+ "num_range": 952,
+ "upper_bound": "125209"
},
{
- "distinct_range": 999.3801422260581,
+ "distinct_range": 1020.1905520404507,
"num_eq": 4,
- "num_range": 996,
- "upper_bound": "128450"
+ "num_range": 1008,
+ "upper_bound": "126234"
},
{
- "distinct_range": 977.5363516991938,
+ "distinct_range": 1224.6279544415395,
"num_eq": 4,
- "num_range": 984,
- "upper_bound": "129432"
+ "num_range": 1125,
+ "upper_bound": "127465"
},
{
- "distinct_range": 859.348979929112,
+ "distinct_range": 887.1337913456291,
"num_eq": 4,
- "num_range": 922,
- "upper_bound": "130295"
+ "num_range": 937,
+ "upper_bound": "128356"
},
{
- "distinct_range": 1243.5348220832802,
+ "distinct_range": 1096.6202962083098,
"num_eq": 4,
- "num_range": 1136,
- "upper_bound": "131545"
+ "num_range": 1051,
+ "upper_bound": "129458"
},
{
- "distinct_range": 1245.5191944834191,
+ "distinct_range": 1140.2866350308193,
"num_eq": 4,
- "num_range": 1137,
- "upper_bound": "132797"
+ "num_range": 1076,
+ "upper_bound": "130604"
},
{
- "distinct_range": 956.6838381777901,
+ "distinct_range": 1058.9040089425953,
"num_eq": 4,
- "num_range": 973,
- "upper_bound": "133758"
+ "num_range": 1029,
+ "upper_bound": "131668"
},
{
- "distinct_range": 1226.667305035867,
+ "distinct_range": 756.9792086449777,
"num_eq": 4,
- "num_range": 1126,
- "upper_bound": "134991"
+ "num_range": 873,
+ "upper_bound": "132428"
},
{
- "distinct_range": 789.7973835153502,
+ "distinct_range": 932.8178452338126,
"num_eq": 4,
- "num_range": 888,
- "upper_bound": "135784"
+ "num_range": 961,
+ "upper_bound": "133365"
},
{
- "distinct_range": 1008.3157544164696,
+ "distinct_range": 1033.0955815734594,
"num_eq": 4,
- "num_range": 1001,
- "upper_bound": "136797"
+ "num_range": 1015,
+ "upper_bound": "134403"
},
{
- "distinct_range": 1026.1861631169945,
+ "distinct_range": 1038.0589076410763,
"num_eq": 4,
- "num_range": 1010,
- "upper_bound": "137828"
+ "num_range": 1018,
+ "upper_bound": "135446"
},
{
- "distinct_range": 984.4868337774674,
+ "distinct_range": 730.1418549185893,
"num_eq": 4,
- "num_range": 988,
- "upper_bound": "138817"
+ "num_range": 861,
+ "upper_bound": "136179"
},
{
- "distinct_range": 1126.4404474509786,
+ "distinct_range": 1077.7626890296833,
"num_eq": 4,
- "num_range": 1067,
- "upper_bound": "139949"
+ "num_range": 1040,
+ "upper_bound": "137262"
},
{
- "distinct_range": 909.0146136441656,
+ "distinct_range": 1112.499582685247,
"num_eq": 4,
- "num_range": 948,
- "upper_bound": "140862"
+ "num_range": 1060,
+ "upper_bound": "138380"
},
{
- "distinct_range": 993.4229130102005,
+ "distinct_range": 858.328251937457,
"num_eq": 4,
- "num_range": 992,
- "upper_bound": "141860"
+ "num_range": 922,
+ "upper_bound": "139242"
},
{
- "distinct_range": 1053.9824923038193,
+ "distinct_range": 888.1270185792088,
"num_eq": 4,
- "num_range": 1026,
- "upper_bound": "142919"
+ "num_range": 937,
+ "upper_bound": "140134"
},
{
- "distinct_range": 1217.7371840348555,
+ "distinct_range": 1050.9631813914073,
"num_eq": 4,
- "num_range": 1120,
- "upper_bound": "144143"
+ "num_range": 1025,
+ "upper_bound": "141190"
},
{
- "distinct_range": 1046.0409364425682,
+ "distinct_range": 951.6848362334545,
"num_eq": 4,
- "num_range": 1021,
- "upper_bound": "145194"
+ "num_range": 971,
+ "upper_bound": "142146"
},
{
- "distinct_range": 1069.865015315332,
+ "distinct_range": 1092.6503608668809,
"num_eq": 4,
- "num_range": 1035,
- "upper_bound": "146269"
+ "num_range": 1048,
+ "upper_bound": "143244"
},
{
- "distinct_range": 971.5786555026076,
+ "distinct_range": 849.3878136010371,
"num_eq": 4,
- "num_range": 981,
- "upper_bound": "147245"
+ "num_range": 918,
+ "upper_bound": "144097"
},
{
- "distinct_range": 805.6970756972618,
+ "distinct_range": 909.9769250589679,
"num_eq": 4,
- "num_range": 896,
- "upper_bound": "148054"
+ "num_range": 949,
+ "upper_bound": "145011"
},
{
- "distinct_range": 859.348979929112,
+ "distinct_range": 966.578849177178,
"num_eq": 4,
- "num_range": 922,
- "upper_bound": "148917"
+ "num_range": 979,
+ "upper_bound": "145982"
},
{
- "distinct_range": 941.7881761764115,
+ "distinct_range": 994.3787894026738,
"num_eq": 4,
- "num_range": 965,
- "upper_bound": "149863"
+ "num_range": 994,
+ "upper_bound": "146981"
},
{
- "distinct_range": 1034.1282259367986,
+ "distinct_range": 1219.6671769548573,
"num_eq": 4,
- "num_range": 1015,
- "upper_bound": "150902"
+ "num_range": 1122,
+ "upper_bound": "148207"
},
{
- "distinct_range": 888.219530434847,
+ "distinct_range": 904.0180644747262,
"num_eq": 4,
- "num_range": 947,
- "upper_bound": "151794"
+ "num_range": 945,
+ "upper_bound": "149115"
},
{
- "distinct_range": 1062.9923709213267,
+ "distinct_range": 999.415009564088,
"num_eq": 4,
- "num_range": 1040,
- "upper_bound": "152862"
+ "num_range": 1006,
+ "upper_bound": "150119"
},
{
- "distinct_range": 1018.3167176016416,
+ "distinct_range": 1058.9803888315657,
"num_eq": 4,
- "num_range": 1015,
- "upper_bound": "153885"
+ "num_range": 1038,
+ "upper_bound": "151183"
},
{
- "distinct_range": 903.1196347704877,
+ "distinct_range": 1436.0081165777028,
"num_eq": 4,
- "num_range": 954,
- "upper_bound": "154792"
+ "num_range": 1262,
+ "upper_bound": "152627"
},
{
- "distinct_range": 918.0187759746223,
+ "distinct_range": 1102.6543747832175,
"num_eq": 4,
- "num_range": 962,
- "upper_bound": "155714"
+ "num_range": 1063,
+ "upper_bound": "153735"
},
{
- "distinct_range": 868.3511729697884,
+ "distinct_range": 846.4679734189502,
"num_eq": 4,
- "num_range": 937,
- "upper_bound": "156586"
+ "num_range": 926,
+ "upper_bound": "154585"
},
{
- "distinct_range": 846.4938472563649,
+ "distinct_range": 945.7952830251044,
"num_eq": 4,
- "num_range": 926,
- "upper_bound": "157436"
+ "num_range": 977,
+ "upper_bound": "155535"
},
{
- "distinct_range": 898.1530418386187,
+ "distinct_range": 776.9103414301594,
"num_eq": 4,
- "num_range": 952,
- "upper_bound": "158338"
+ "num_range": 893,
+ "upper_bound": "156315"
},
{
- "distinct_range": 1058.028729165895,
+ "distinct_range": 938.8437594530934,
"num_eq": 4,
- "num_range": 1037,
- "upper_bound": "159401"
+ "num_range": 973,
+ "upper_bound": "157258"
},
{
- "distinct_range": 1028.245211118197,
+ "distinct_range": 1229.6756374914635,
"num_eq": 4,
- "num_range": 1021,
- "upper_bound": "160434"
+ "num_range": 1136,
+ "upper_bound": "158494"
},
{
- "distinct_range": 1053.0650092909545,
+ "distinct_range": 1070.892059602758,
"num_eq": 4,
- "num_range": 1034,
- "upper_bound": "161492"
+ "num_range": 1045,
+ "upper_bound": "159570"
},
{
- "distinct_range": 999.4516432473066,
+ "distinct_range": 913.022070377623,
"num_eq": 4,
- "num_range": 1005,
- "upper_bound": "162496"
+ "num_range": 960,
+ "upper_bound": "160487"
},
{
- "distinct_range": 1087.809433936712,
+ "distinct_range": 972.6065113023361,
"num_eq": 4,
- "num_range": 1054,
- "upper_bound": "163589"
+ "num_range": 991,
+ "upper_bound": "161464"
},
{
- "distinct_range": 1009.3807846728113,
+ "distinct_range": 977.5712495509889,
"num_eq": 4,
- "num_range": 1010,
- "upper_bound": "164603"
+ "num_range": 994,
+ "upper_bound": "162446"
},
{
- "distinct_range": 1159.2725686761644,
+ "distinct_range": 1220.7457885574051,
"num_eq": 4,
- "num_range": 1095,
- "upper_bound": "165768"
+ "num_range": 1131,
+ "upper_bound": "163673"
},
{
- "distinct_range": 946.821160672366,
+ "distinct_range": 832.5584805567267,
"num_eq": 4,
- "num_range": 977,
- "upper_bound": "166719"
+ "num_range": 920,
+ "upper_bound": "164509"
},
{
- "distinct_range": 1014.3452259417493,
+ "distinct_range": 1036.1484090706422,
"num_eq": 4,
- "num_range": 1013,
- "upper_bound": "167738"
+ "num_range": 1026,
+ "upper_bound": "165550"
},
{
- "distinct_range": 1030.2308698505344,
+ "distinct_range": 993.4577938893955,
"num_eq": 4,
- "num_range": 1022,
- "upper_bound": "168773"
+ "num_range": 1002,
+ "upper_bound": "166548"
},
{
- "distinct_range": 1020.3024431279803,
+ "distinct_range": 942.8160825334995,
"num_eq": 4,
- "num_range": 1016,
- "upper_bound": "169798"
+ "num_range": 975,
+ "upper_bound": "167495"
},
{
- "distinct_range": 834.5706911218,
+ "distinct_range": 1100.669318869781,
"num_eq": 4,
- "num_range": 920,
- "upper_bound": "170636"
+ "num_range": 1062,
+ "upper_bound": "168601"
},
{
- "distinct_range": 1131.4830392257488,
+ "distinct_range": 1281.2667776096791,
"num_eq": 4,
- "num_range": 1079,
- "upper_bound": "171773"
+ "num_range": 1167,
+ "upper_bound": "169889"
},
{
- "distinct_range": 1061.0069235451087,
+ "distinct_range": 1022.2498336352598,
"num_eq": 4,
- "num_range": 1039,
- "upper_bound": "172839"
+ "num_range": 1018,
+ "upper_bound": "170916"
},
{
- "distinct_range": 974.6272385947434,
+ "distinct_range": 1104.639419112271,
"num_eq": 4,
- "num_range": 992,
- "upper_bound": "173818"
+ "num_range": 1064,
+ "upper_bound": "172026"
},
{
- "distinct_range": 856.4292785879063,
+ "distinct_range": 1317.9723833135204,
"num_eq": 4,
- "num_range": 931,
- "upper_bound": "174678"
+ "num_range": 1189,
+ "upper_bound": "173351"
},
{
- "distinct_range": 1107.6617525949455,
+ "distinct_range": 922.9538197268306,
"num_eq": 4,
- "num_range": 1065,
- "upper_bound": "175791"
+ "num_range": 965,
+ "upper_bound": "174278"
},
{
- "distinct_range": 917.0255292572797,
+ "distinct_range": 1075.8551243199295,
"num_eq": 4,
- "num_range": 961,
- "upper_bound": "176712"
+ "num_range": 1048,
+ "upper_bound": "175359"
},
{
- "distinct_range": 1012.3594597006547,
+ "distinct_range": 1353.6833643334342,
"num_eq": 4,
- "num_range": 1012,
- "upper_bound": "177729"
+ "num_range": 1211,
+ "upper_bound": "176720"
},
{
- "distinct_range": 934.9033424500099,
+ "distinct_range": 1146.3227497700843,
"num_eq": 4,
- "num_range": 971,
- "upper_bound": "178668"
+ "num_range": 1088,
+ "upper_bound": "177872"
},
{
- "distinct_range": 1175.1513857908883,
+ "distinct_range": 1256.4640829067841,
"num_eq": 4,
- "num_range": 1104,
- "upper_bound": "179849"
+ "num_range": 1152,
+ "upper_bound": "179135"
},
{
- "distinct_range": 990.5151160835449,
+ "distinct_range": 1163.1932153090506,
"num_eq": 4,
- "num_range": 1000,
- "upper_bound": "180844"
+ "num_range": 1097,
+ "upper_bound": "180304"
},
{
- "distinct_range": 1061.9996487835333,
+ "distinct_range": 909.0492525500996,
"num_eq": 4,
- "num_range": 1039,
- "upper_bound": "181911"
+ "num_range": 958,
+ "upper_bound": "181217"
},
{
- "distinct_range": 1184.0829376570114,
+ "distinct_range": 1122.5043039341078,
"num_eq": 4,
- "num_range": 1109,
- "upper_bound": "183101"
+ "num_range": 1074,
+ "upper_bound": "182345"
},
{
- "distinct_range": 1004.4162573947566,
+ "distinct_range": 845.4744702786755,
"num_eq": 4,
- "num_range": 1008,
- "upper_bound": "184110"
+ "num_range": 926,
+ "upper_bound": "183194"
},
{
- "distinct_range": 1440.0470644424604,
+ "distinct_range": 1082.8032870194666,
"num_eq": 4,
- "num_range": 1264,
- "upper_bound": "185558"
+ "num_range": 1052,
+ "upper_bound": "184282"
},
{
- "distinct_range": 708.3362707717972,
+ "distinct_range": 856.4027381354044,
"num_eq": 4,
- "num_range": 862,
- "upper_bound": "186269"
+ "num_range": 931,
+ "upper_bound": "185142"
},
{
- "distinct_range": 1008.387886125304,
+ "distinct_range": 1000.4078663913606,
"num_eq": 4,
- "num_range": 1010,
- "upper_bound": "187282"
+ "num_range": 1006,
+ "upper_bound": "186147"
},
{
- "distinct_range": 830.596148036694,
+ "distinct_range": 947.7813968948736,
"num_eq": 4,
- "num_range": 918,
- "upper_bound": "188116"
+ "num_range": 978,
+ "upper_bound": "187099"
},
{
- "distinct_range": 1168.2044832499096,
+ "distinct_range": 920.9675033164064,
"num_eq": 4,
- "num_range": 1100,
- "upper_bound": "189290"
+ "num_range": 964,
+ "upper_bound": "188024"
},
{
- "distinct_range": 1041.1517582834106,
+ "distinct_range": 1000.4078663913606,
"num_eq": 4,
- "num_range": 1028,
- "upper_bound": "190336"
+ "num_range": 1006,
+ "upper_bound": "189029"
},
{
- "distinct_range": 1007.3949841306187,
+ "distinct_range": 903.0898975161114,
"num_eq": 4,
- "num_range": 1009,
- "upper_bound": "191348"
+ "num_range": 955,
+ "upper_bound": "189936"
},
{
- "distinct_range": 959.7314959005498,
+ "distinct_range": 1036.1484090706422,
"num_eq": 4,
- "num_range": 984,
- "upper_bound": "192312"
+ "num_range": 1026,
+ "upper_bound": "190977"
},
{
- "distinct_range": 1011.3665714536639,
+ "distinct_range": 1061.958348652391,
"num_eq": 4,
- "num_range": 1011,
- "upper_bound": "193328"
+ "num_range": 1040,
+ "upper_bound": "192044"
},
{
- "distinct_range": 1112.6246530914655,
+ "distinct_range": 963.6697459576333,
"num_eq": 4,
- "num_range": 1068,
- "upper_bound": "194446"
+ "num_range": 986,
+ "upper_bound": "193012"
},
{
- "distinct_range": 858.4163077948515,
+ "distinct_range": 842.4939314723146,
"num_eq": 4,
- "num_range": 932,
- "upper_bound": "195308"
+ "num_range": 924,
+ "upper_bound": "193858"
},
{
- "distinct_range": 961.7176438208196,
+ "distinct_range": 1147.31515119649,
"num_eq": 4,
- "num_range": 985,
- "upper_bound": "196274"
+ "num_range": 1088,
+ "upper_bound": "195011"
},
{
- "distinct_range": 739.1580925977532,
+ "distinct_range": 912.0288722952724,
"num_eq": 4,
- "num_range": 875,
- "upper_bound": "197016"
+ "num_range": 959,
+ "upper_bound": "195927"
},
{
- "distinct_range": 995.4798887983827,
+ "distinct_range": 1110.5944830300502,
"num_eq": 4,
- "num_range": 1003,
- "upper_bound": "198016"
+ "num_range": 1067,
+ "upper_bound": "197043"
},
{
- "distinct_range": 904.1129404804241,
+ "distinct_range": 1187.0090767482761,
"num_eq": 4,
- "num_range": 955,
- "upper_bound": "198924"
+ "num_range": 1111,
+ "upper_bound": "198236"
},
{
- "distinct_range": 1064.9778059189762,
+ "distinct_range": 864.3502054887197,
"num_eq": 4,
- "num_range": 1041,
- "upper_bound": "199994"
+ "num_range": 935,
+ "upper_bound": "199104"
},
{
- "distinct_range": 2.9103830456733704E-11,
- "num_eq": 0,
- "num_range": 0,
- "upper_bound": "9223372036854775807"
+ "distinct_range": 887.19751762799,
+ "num_eq": 4,
+ "num_range": 947,
+ "upper_bound": "199995"
}
],
"histo_col_type": "INT8",
@@ -14481,23 +14521,24 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 35,
"columns": [
"p_name"
],
- "created_at": "2021-09-08 20:49:15.330151",
- "distinct_count": 120,
+ "created_at": "2022-02-25 00:55:35.512954",
+ "distinct_count": 198131,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1520,
+ "num_eq": 20,
"num_range": 0,
- "upper_bound": "almond antique aquamarine azure beige"
+ "upper_bound": "almond aquamarine blue puff tan"
},
{
- "distinct_range": 118,
- "num_eq": 1340,
- "num_range": 197140,
- "upper_bound": "beige azure aquamarine antique almond"
+ "distinct_range": 198129,
+ "num_eq": 20,
+ "num_range": 199960,
+ "upper_bound": "yellow wheat goldenrod orange blush"
}
],
"histo_col_type": "VARCHAR(55)",
@@ -14507,22 +14548,23 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 16,
"columns": [
"p_mfgr"
],
- "created_at": "2021-09-08 20:49:15.330151",
+ "created_at": "2022-02-25 00:55:35.512954",
"distinct_count": 5,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 39660,
+ "num_eq": 40940,
"num_range": 0,
"upper_bound": "Manufacturer#1"
},
{
"distinct_range": 3,
- "num_eq": 40440,
- "num_range": 119900,
+ "num_eq": 41120,
+ "num_range": 117940,
"upper_bound": "Manufacturer#5"
}
],
@@ -14533,22 +14575,23 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 10,
"columns": [
"p_brand"
],
- "created_at": "2021-09-08 20:49:15.330151",
+ "created_at": "2022-02-25 00:55:35.512954",
"distinct_count": 25,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 8840,
+ "num_eq": 7640,
"num_range": 0,
"upper_bound": "Brand#11"
},
{
"distinct_range": 23,
- "num_eq": 8540,
- "num_range": 182620,
+ "num_eq": 8060,
+ "num_range": 184300,
"upper_bound": "Brand#55"
}
],
@@ -14559,22 +14602,23 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 23,
"columns": [
"p_type"
],
- "created_at": "2021-09-08 20:49:15.330151",
+ "created_at": "2022-02-25 00:55:35.512954",
"distinct_count": 150,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1340,
+ "num_eq": 1360,
"num_range": 0,
"upper_bound": "ECONOMY ANODIZED BRASS"
},
{
"distinct_range": 148,
- "num_eq": 1160,
- "num_range": 197500,
+ "num_eq": 1560,
+ "num_range": 197080,
"upper_bound": "STANDARD POLISHED TIN"
}
],
@@ -14585,22 +14629,23 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 2,
"columns": [
"p_size"
],
- "created_at": "2021-09-08 20:49:15.330151",
+ "created_at": "2022-02-25 00:55:35.512954",
"distinct_count": 50,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 3740,
+ "num_eq": 4240,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 48,
- "num_eq": 3600,
- "num_range": 192660,
+ "num_eq": 3900,
+ "num_range": 191860,
"upper_bound": "50"
}
],
@@ -14611,22 +14656,23 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 10,
"columns": [
"p_container"
],
- "created_at": "2021-09-08 20:49:15.330151",
- "distinct_count": 28,
+ "created_at": "2022-02-25 00:55:35.512954",
+ "distinct_count": 40,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 6480,
+ "num_eq": 5460,
"num_range": 0,
"upper_bound": "JUMBO BAG"
},
{
- "distinct_range": 26,
- "num_eq": 7500,
- "num_range": 186020,
+ "distinct_range": 38,
+ "num_eq": 4760,
+ "num_range": 189780,
"upper_bound": "WRAP PKG"
}
],
@@ -14637,23 +14683,24 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 9,
"columns": [
"p_retailprice"
],
- "created_at": "2021-09-08 20:49:15.330151",
- "distinct_count": 20917,
+ "created_at": "2022-02-25 00:55:35.512954",
+ "distinct_count": 20831,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 20,
"num_range": 0,
- "upper_bound": "904.0"
+ "upper_bound": "906.0"
},
{
- "distinct_range": 20915,
+ "distinct_range": 20829,
"num_eq": 20,
"num_range": 199960,
- "upper_bound": "2093.989990234375"
+ "upper_bound": "2094.99"
}
],
"histo_col_type": "FLOAT8",
@@ -14663,23 +14710,24 @@ ALTER TABLE "part" INJECT STATISTICS '[
"row_count": 200000
},
{
+ "avg_size": 16,
"columns": [
"p_comment"
],
- "created_at": "2021-09-08 20:49:15.330151",
- "distinct_count": 190165,
+ "created_at": "2022-02-25 00:55:35.512954",
+ "distinct_count": 132344,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 20,
+ "num_eq": 40,
"num_range": 0,
- "upper_bound": " Above third "
+ "upper_bound": " abou"
},
{
- "distinct_range": 190163,
+ "distinct_range": 132342,
"num_eq": 20,
- "num_range": 199960,
- "upper_bound": "zine bec"
+ "num_range": 199940,
+ "upper_bound": "zzle fluffily fluffi"
}
],
"histo_col_type": "VARCHAR(23)",
@@ -14694,1223 +14742,1212 @@ ALTER TABLE "part" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "partsupp" INJECT STATISTICS '[
{
+ "avg_size": 4,
"columns": [
"ps_partkey"
],
- "created_at": "2021-09-08 20:48:28.135856",
+ "created_at": "2022-02-25 00:55:37.590966",
"distinct_count": 199241,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 0,
- "num_range": 0,
- "upper_bound": "-9223372036854775808"
- },
- {
- "distinct_range": 4.3655745685100555E-11,
"num_eq": 80,
"num_range": 0,
- "upper_bound": "5"
+ "upper_bound": "13"
},
{
- "distinct_range": 916.9010733484639,
+ "distinct_range": 925.7492557795443,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "925"
+ "num_range": 3913,
+ "upper_bound": "942"
},
{
- "distinct_range": 1212.9827519543908,
+ "distinct_range": 1147.5937050545829,
"num_eq": 80,
- "num_range": 3942,
- "upper_bound": "2147"
+ "num_range": 3934,
+ "upper_bound": "2097"
},
{
- "distinct_range": 1090.032415606602,
+ "distinct_range": 1025.2204258568865,
"num_eq": 80,
- "num_range": 3927,
- "upper_bound": "3243"
+ "num_range": 3921,
+ "upper_bound": "3127"
},
{
- "distinct_range": 1096.885566484714,
+ "distinct_range": 993.759826271348,
"num_eq": 80,
- "num_range": 3927,
- "upper_bound": "4346"
+ "num_range": 3918,
+ "upper_bound": "4125"
},
{
- "distinct_range": 1091.9907250305791,
+ "distinct_range": 1115.3695875951446,
"num_eq": 80,
- "num_range": 3927,
- "upper_bound": "5444"
+ "num_range": 3930,
+ "upper_bound": "5247"
},
{
- "distinct_range": 984.9594741400174,
+ "distinct_range": 930.685262838559,
"num_eq": 80,
- "num_range": 3917,
- "upper_bound": "6433"
+ "num_range": 3913,
+ "upper_bound": "6181"
},
{
- "distinct_range": 854.5722175477123,
+ "distinct_range": 1137.835179988688,
"num_eq": 80,
- "num_range": 3909,
- "upper_bound": "7290"
+ "num_range": 3933,
+ "upper_bound": "7326"
},
{
- "distinct_range": 931.7153924064378,
- "num_eq": 80,
- "num_range": 3913,
- "upper_bound": "8225"
+ "distinct_range": 1002.613409052917,
+ "num_eq": 159,
+ "num_range": 3919,
+ "upper_bound": "8333"
},
{
- "distinct_range": 1160.3959722155453,
+ "distinct_range": 955.3475139695854,
"num_eq": 80,
- "num_range": 3935,
- "upper_bound": "9393"
+ "num_range": 3915,
+ "upper_bound": "9292"
},
{
- "distinct_range": 1160.3959722155453,
+ "distinct_range": 1111.4595569268304,
"num_eq": 80,
- "num_range": 3935,
- "upper_bound": "10561"
+ "num_range": 3929,
+ "upper_bound": "10410"
},
{
- "distinct_range": 1119.3846007757902,
+ "distinct_range": 895.1202474413385,
"num_eq": 80,
- "num_range": 3930,
- "upper_bound": "11687"
+ "num_range": 3911,
+ "upper_bound": "11308"
},
{
- "distinct_range": 1062.5938554785953,
+ "distinct_range": 747.344331703954,
"num_eq": 80,
- "num_range": 3924,
- "upper_bound": "12755"
+ "num_range": 3905,
+ "upper_bound": "12057"
},
{
- "distinct_range": 1142.8314250075732,
- "num_eq": 159,
- "num_range": 3933,
- "upper_bound": "13905"
+ "distinct_range": 1068.3917576286353,
+ "num_eq": 80,
+ "num_range": 3925,
+ "upper_bound": "13131"
},
{
- "distinct_range": 1011.5283167812981,
+ "distinct_range": 953.3756371752208,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "14921"
+ "num_range": 3915,
+ "upper_bound": "14088"
},
{
- "distinct_range": 972.1542410065233,
+ "distinct_range": 881.2735917800348,
"num_eq": 80,
- "num_range": 3916,
- "upper_bound": "15897"
+ "num_range": 3910,
+ "upper_bound": "14972"
},
{
- "distinct_range": 839.7073828729614,
+ "distinct_range": 998.6789903544741,
"num_eq": 80,
- "num_range": 3908,
- "upper_bound": "16739"
+ "num_range": 3918,
+ "upper_bound": "15975"
},
{
- "distinct_range": 932.7026461742158,
+ "distinct_range": 1090.9175564699306,
"num_eq": 80,
- "num_range": 3913,
- "upper_bound": "17675"
+ "num_range": 3927,
+ "upper_bound": "17072"
},
{
- "distinct_range": 961.3126406820179,
+ "distinct_range": 943.5133601077418,
"num_eq": 80,
- "num_range": 3915,
- "upper_bound": "18640"
+ "num_range": 3914,
+ "upper_bound": "18019"
},
{
- "distinct_range": 1059.6515644729018,
+ "distinct_range": 777.1650889750857,
"num_eq": 80,
- "num_range": 3923,
- "upper_bound": "19705"
+ "num_range": 3906,
+ "upper_bound": "18798"
},
{
- "distinct_range": 962.2984812868785,
+ "distinct_range": 932.659336884681,
"num_eq": 80,
- "num_range": 3915,
- "upper_bound": "20671"
+ "num_range": 3913,
+ "upper_bound": "19734"
},
{
- "distinct_range": 1042.9697318862513,
+ "distinct_range": 1135.8828096366904,
"num_eq": 80,
- "num_range": 3922,
- "upper_bound": "21719"
+ "num_range": 3932,
+ "upper_bound": "20877"
},
{
- "distinct_range": 880.3159618759114,
+ "distinct_range": 1089.9387676241422,
"num_eq": 80,
- "num_range": 3910,
- "upper_bound": "22602"
+ "num_range": 3927,
+ "upper_bound": "21973"
},
{
- "distinct_range": 1105.6929163885347,
+ "distinct_range": 1087.981027415578,
"num_eq": 80,
- "num_range": 3928,
- "upper_bound": "23714"
+ "num_range": 3927,
+ "upper_bound": "23067"
},
{
- "distinct_range": 954.4104181035763,
+ "distinct_range": 817.868573122365,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "24672"
+ "num_range": 3907,
+ "upper_bound": "23887"
},
{
- "distinct_range": 944.5460649903946,
+ "distinct_range": 1064.471327233955,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "25620"
+ "num_range": 3924,
+ "upper_bound": "24957"
},
{
- "distinct_range": 757.3011131907699,
+ "distinct_range": 757.2879379058687,
"num_eq": 80,
"num_range": 3905,
- "upper_bound": "26379"
+ "upper_bound": "25716"
},
{
- "distinct_range": 944.5460649903946,
+ "distinct_range": 732.4229037805927,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "27327"
+ "num_range": 3905,
+ "upper_bound": "26450"
},
{
- "distinct_range": 1034.1321225518661,
- "num_eq": 80,
- "num_range": 3921,
- "upper_bound": "28366"
+ "distinct_range": 838.6918682974648,
+ "num_eq": 159,
+ "num_range": 3908,
+ "upper_bound": "27291"
},
{
- "distinct_range": 950.465244109625,
+ "distinct_range": 1425.2559919818138,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "29320"
+ "num_range": 3980,
+ "upper_bound": "28733"
},
{
- "distinct_range": 748.351072558292,
+ "distinct_range": 803.9768412299787,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "30070"
+ "num_range": 3907,
+ "upper_bound": "29539"
},
{
- "distinct_range": 765.254489632421,
+ "distinct_range": 956.3333796750428,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "30837"
+ "num_range": 3915,
+ "upper_bound": "30499"
},
{
- "distinct_range": 867.4476313451989,
+ "distinct_range": 1008.5135092820738,
"num_eq": 80,
- "num_range": 3909,
- "upper_bound": "31707"
+ "num_range": 3919,
+ "upper_bound": "31512"
},
{
- "distinct_range": 857.5440871213711,
+ "distinct_range": 992.7758418262307,
"num_eq": 80,
- "num_range": 3909,
- "upper_bound": "32567"
+ "num_range": 3918,
+ "upper_bound": "32509"
},
{
- "distinct_range": 1232.4183614632993,
- "num_eq": 80,
- "num_range": 3945,
- "upper_bound": "33809"
+ "distinct_range": 775.0886675953305,
+ "num_eq": 159,
+ "num_range": 3827,
+ "upper_bound": "33286"
},
{
- "distinct_range": 982.0051532346188,
+ "distinct_range": 1170.0171865982447,
"num_eq": 80,
- "num_range": 3917,
- "upper_bound": "34795"
+ "num_range": 3937,
+ "upper_bound": "34464"
},
{
- "distinct_range": 1128.1808181185706,
+ "distinct_range": 844.6381369657128,
"num_eq": 80,
- "num_range": 3931,
- "upper_bound": "35930"
+ "num_range": 3909,
+ "upper_bound": "35311"
},
{
- "distinct_range": 756.3067934153239,
+ "distinct_range": 1088.9599245964066,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "36688"
+ "num_range": 3927,
+ "upper_bound": "36406"
},
{
- "distinct_range": 1106.6712431197436,
+ "distinct_range": 1128.0711159777302,
"num_eq": 80,
- "num_range": 3928,
- "upper_bound": "37801"
+ "num_range": 3931,
+ "upper_bound": "37541"
},
{
- "distinct_range": 1067.4966269635972,
+ "distinct_range": 1362.7803042924668,
"num_eq": 80,
- "num_range": 3924,
- "upper_bound": "38874"
+ "num_range": 3968,
+ "upper_bound": "38918"
},
{
- "distinct_range": 920.8525637247076,
+ "distinct_range": 897.0976302469138,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "39798"
+ "num_range": 3911,
+ "upper_bound": "39818"
},
{
- "distinct_range": 915.913087337228,
+ "distinct_range": 1055.6472397425896,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "40717"
+ "num_range": 3923,
+ "upper_bound": "40879"
},
{
- "distinct_range": 965.2557151429031,
+ "distinct_range": 960.276356598463,
"num_eq": 80,
"num_range": 3915,
- "upper_bound": "41686"
+ "upper_bound": "41843"
},
{
- "distinct_range": 945.5327126028963,
+ "distinct_range": 942.5268685541182,
"num_eq": 80,
"num_range": 3914,
- "upper_bound": "42635"
+ "upper_bound": "42789"
},
{
- "distinct_range": 947.5058666850608,
+ "distinct_range": 964.2185534648744,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "43586"
+ "num_range": 3916,
+ "upper_bound": "43757"
},
{
- "distinct_range": 1055.7277788654685,
+ "distinct_range": 1016.3774426543363,
"num_eq": 80,
- "num_range": 3923,
- "upper_bound": "44647"
+ "num_range": 3920,
+ "upper_bound": "44778"
},
{
- "distinct_range": 539.9384836072204,
+ "distinct_range": 986.8708777401898,
"num_eq": 80,
- "num_range": 3902,
- "upper_bound": "45188"
+ "num_range": 3917,
+ "upper_bound": "45769"
},
{
- "distinct_range": 1056.7088034800774,
+ "distinct_range": 1032.0953974055708,
"num_eq": 80,
- "num_range": 3923,
- "upper_bound": "46250"
+ "num_range": 3921,
+ "upper_bound": "46806"
},
{
- "distinct_range": 1075.3383305093757,
+ "distinct_range": 1087.00207611068,
"num_eq": 80,
- "num_range": 3925,
- "upper_bound": "47331"
+ "num_range": 3927,
+ "upper_bound": "47899"
},
{
- "distinct_range": 1030.2029611559724,
+ "distinct_range": 861.4778385324641,
"num_eq": 80,
- "num_range": 3921,
- "upper_bound": "48366"
+ "num_range": 3909,
+ "upper_bound": "48763"
},
{
- "distinct_range": 1040.0243253701633,
- "num_eq": 80,
- "num_range": 3922,
- "upper_bound": "49411"
+ "distinct_range": 742.3713127323241,
+ "num_eq": 159,
+ "num_range": 3905,
+ "upper_bound": "49507"
},
{
- "distinct_range": 1129.1579051233136,
+ "distinct_range": 1093.8535976296725,
"num_eq": 80,
- "num_range": 3931,
- "upper_bound": "50547"
+ "num_range": 3927,
+ "upper_bound": "50607"
},
{
- "distinct_range": 1083.1766589702452,
+ "distinct_range": 1050.7431099761461,
"num_eq": 80,
- "num_range": 3926,
- "upper_bound": "51636"
+ "num_range": 3923,
+ "upper_bound": "51663"
},
{
- "distinct_range": 948.4923730423039,
+ "distinct_range": 1001.6298806102992,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "52588"
+ "num_range": 3919,
+ "upper_bound": "52669"
},
{
- "distinct_range": 1079.2579176060706,
+ "distinct_range": 853.5547712909904,
"num_eq": 80,
- "num_range": 3925,
- "upper_bound": "53673"
+ "num_range": 3909,
+ "upper_bound": "53525"
},
{
- "distinct_range": 1195.4717196421807,
+ "distinct_range": 1019.3255688696388,
"num_eq": 80,
- "num_range": 3940,
- "upper_bound": "54877"
+ "num_range": 3920,
+ "upper_bound": "54549"
},
{
- "distinct_range": 1108.6277356514213,
+ "distinct_range": 863.4581843075407,
"num_eq": 80,
- "num_range": 3929,
- "upper_bound": "55992"
+ "num_range": 3909,
+ "upper_bound": "55415"
},
{
- "distinct_range": 1073.3782204189956,
+ "distinct_range": 843.6471940721173,
"num_eq": 80,
- "num_range": 3925,
- "upper_bound": "57071"
+ "num_range": 3908,
+ "upper_bound": "56261"
},
{
- "distinct_range": 1009.5615024177979,
+ "distinct_range": 977.0252646915053,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "58085"
+ "num_range": 3917,
+ "upper_bound": "57242"
},
{
- "distinct_range": 1110.5840134408259,
+ "distinct_range": 995.7276436740071,
"num_eq": 80,
- "num_range": 3929,
- "upper_bound": "59202"
+ "num_range": 3918,
+ "upper_bound": "58242"
},
{
- "distinct_range": 987.9133529632321,
+ "distinct_range": 792.0637801777804,
"num_eq": 80,
- "num_range": 3917,
- "upper_bound": "60194"
+ "num_range": 3906,
+ "upper_bound": "59036"
},
{
- "distinct_range": 911.960691501997,
+ "distinct_range": 1009.4966804971689,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "61109"
+ "num_range": 3919,
+ "upper_bound": "60050"
},
{
- "distinct_range": 1172.0958141084684,
+ "distinct_range": 1200.1932473892891,
"num_eq": 80,
- "num_range": 3937,
- "upper_bound": "62289"
+ "num_range": 3941,
+ "upper_bound": "61259"
},
{
- "distinct_range": 1155.5187077354,
+ "distinct_range": 977.0252646915053,
"num_eq": 80,
- "num_range": 3934,
- "upper_bound": "63452"
+ "num_range": 3917,
+ "upper_bound": "62240"
},
{
- "distinct_range": 894.982821494852,
- "num_eq": 159,
- "num_range": 3832,
- "upper_bound": "64350"
+ "distinct_range": 1061.5304438902406,
+ "num_eq": 80,
+ "num_range": 3924,
+ "upper_bound": "63307"
},
{
- "distinct_range": 709.5387362101027,
+ "distinct_range": 868.4083053177889,
"num_eq": 80,
- "num_range": 3904,
- "upper_bound": "65061"
+ "num_range": 3910,
+ "upper_bound": "64178"
},
{
- "distinct_range": 918.8769093948148,
+ "distinct_range": 970.1303786275062,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "65983"
+ "num_range": 3916,
+ "upper_bound": "65152"
},
{
- "distinct_range": 943.5593704055748,
+ "distinct_range": 907.9700150288388,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "66930"
+ "num_range": 3912,
+ "upper_bound": "66063"
},
{
- "distinct_range": 914.9250560840335,
+ "distinct_range": 973.0856265527445,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "67848"
+ "num_range": 3916,
+ "upper_bound": "67040"
},
{
- "distinct_range": 889.2205737090292,
+ "distinct_range": 961.2619790810577,
"num_eq": 80,
- "num_range": 3910,
- "upper_bound": "68740"
+ "num_range": 3915,
+ "upper_bound": "68005"
},
{
- "distinct_range": 943.5593704055748,
+ "distinct_range": 1257.475117178305,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "69687"
+ "num_range": 3949,
+ "upper_bound": "69273"
},
{
- "distinct_range": 1037.078455253592,
+ "distinct_range": 1075.2504495780981,
"num_eq": 80,
- "num_range": 3921,
- "upper_bound": "70729"
+ "num_range": 3925,
+ "upper_bound": "70354"
},
{
- "distinct_range": 893.1770516983019,
+ "distinct_range": 980.9641084843028,
"num_eq": 80,
- "num_range": 3911,
- "upper_bound": "71625"
+ "num_range": 3917,
+ "upper_bound": "71339"
},
{
- "distinct_range": 813.9206194471833,
+ "distinct_range": 1220.6043187256262,
"num_eq": 80,
- "num_range": 3907,
- "upper_bound": "72441"
+ "num_range": 3944,
+ "upper_bound": "72569"
},
{
- "distinct_range": 1016.4444708327667,
+ "distinct_range": 1147.5937050545829,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "73462"
+ "num_range": 3934,
+ "upper_bound": "73724"
},
{
- "distinct_range": 892.1879976469063,
+ "distinct_range": 967.1746871254414,
"num_eq": 80,
- "num_range": 3911,
- "upper_bound": "74357"
+ "num_range": 3916,
+ "upper_bound": "74695"
},
{
- "distinct_range": 866.4574643302362,
+ "distinct_range": 984.9021547087092,
"num_eq": 80,
- "num_range": 3909,
- "upper_bound": "75226"
+ "num_range": 3917,
+ "upper_bound": "75684"
},
{
- "distinct_range": 894.1660620061085,
+ "distinct_range": 958.3049654262154,
"num_eq": 80,
- "num_range": 3911,
- "upper_bound": "76123"
+ "num_range": 3915,
+ "upper_bound": "76646"
},
{
- "distinct_range": 910.9724799113237,
+ "distinct_range": 1019.3255688696388,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "77037"
+ "num_range": 3920,
+ "upper_bound": "77670"
},
{
- "distinct_range": 735.4187126166942,
+ "distinct_range": 982.9332314918934,
"num_eq": 80,
- "num_range": 3904,
- "upper_bound": "77774"
+ "num_range": 3917,
+ "upper_bound": "78657"
},
{
- "distinct_range": 745.3671505844743,
+ "distinct_range": 926.736550883542,
"num_eq": 80,
- "num_range": 3904,
- "upper_bound": "78521"
+ "num_range": 3913,
+ "upper_bound": "79587"
},
{
- "distinct_range": 746.3618228447693,
+ "distinct_range": 742.3713127323241,
"num_eq": 80,
"num_range": 3905,
- "upper_bound": "79269"
+ "upper_bound": "80331"
},
{
- "distinct_range": 1066.5161775056868,
+ "distinct_range": 946.472547737437,
"num_eq": 80,
- "num_range": 3924,
- "upper_bound": "80341"
+ "num_range": 3914,
+ "upper_bound": "81281"
},
{
- "distinct_range": 1155.5187077354,
+ "distinct_range": 866.4283847330101,
"num_eq": 80,
- "num_range": 3934,
- "upper_bound": "81504"
+ "num_range": 3910,
+ "upper_bound": "82150"
},
{
- "distinct_range": 1115.4737671156595,
+ "distinct_range": 961.2619790810577,
"num_eq": 80,
- "num_range": 3929,
- "upper_bound": "82626"
+ "num_range": 3915,
+ "upper_bound": "83115"
},
{
- "distinct_range": 941.372213504134,
- "num_eq": 159,
- "num_range": 3835,
- "upper_bound": "83571"
+ "distinct_range": 896.1089612310299,
+ "num_eq": 80,
+ "num_range": 3911,
+ "upper_bound": "84014"
},
{
- "distinct_range": 1113.5180270480057,
+ "distinct_range": 1062.51079165679,
"num_eq": 80,
- "num_range": 3929,
- "upper_bound": "84691"
+ "num_range": 3924,
+ "upper_bound": "85082"
},
{
- "distinct_range": 755.3124411245228,
+ "distinct_range": 945.4861997570963,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "85448"
+ "num_range": 3914,
+ "upper_bound": "86031"
},
{
- "distinct_range": 1223.6750892413227,
+ "distinct_range": 955.3475139695854,
"num_eq": 80,
- "num_range": 3944,
- "upper_bound": "86681"
+ "num_range": 3915,
+ "upper_bound": "86990"
},
{
- "distinct_range": 881.305535511264,
+ "distinct_range": 1038.9678125619619,
"num_eq": 80,
- "num_range": 3910,
- "upper_bound": "87565"
+ "num_range": 3922,
+ "upper_bound": "88034"
},
{
- "distinct_range": 1224.6467864536073,
+ "distinct_range": 1097.7675589085318,
"num_eq": 80,
- "num_range": 3944,
- "upper_bound": "88799"
+ "num_range": 3928,
+ "upper_bound": "89138"
},
{
- "distinct_range": 1006.6109040075065,
+ "distinct_range": 1043.8751079858548,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "89810"
+ "num_range": 3922,
+ "upper_bound": "90187"
},
{
- "distinct_range": 1019.3935568687056,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "90834"
+ "distinct_range": 1067.411730207805,
+ "num_eq": 159,
+ "num_range": 3925,
+ "upper_bound": "91260"
},
{
- "distinct_range": 1061.6131440867712,
+ "distinct_range": 887.2089335090069,
"num_eq": 80,
- "num_range": 3924,
- "upper_bound": "91901"
+ "num_range": 3911,
+ "upper_bound": "92150"
},
{
- "distinct_range": 986.9287758892453,
+ "distinct_range": 985.8865412721474,
"num_eq": 80,
"num_range": 3917,
- "upper_bound": "92892"
+ "upper_bound": "93140"
},
{
- "distinct_range": 1217.8437385860966,
+ "distinct_range": 1262.3204306134717,
"num_eq": 80,
- "num_range": 3943,
- "upper_bound": "94119"
+ "num_range": 3950,
+ "upper_bound": "94413"
},
{
- "distinct_range": 1157.4697777717759,
+ "distinct_range": 1050.7431099761461,
"num_eq": 80,
- "num_range": 3935,
- "upper_bound": "95284"
+ "num_range": 3923,
+ "upper_bound": "95469"
},
{
- "distinct_range": 1056.7088034800774,
+ "distinct_range": 970.1303786275062,
"num_eq": 80,
- "num_range": 3923,
- "upper_bound": "96346"
+ "num_range": 3916,
+ "upper_bound": "96443"
},
{
- "distinct_range": 856.5535050050245,
+ "distinct_range": 1213.803398614319,
"num_eq": 80,
- "num_range": 3909,
- "upper_bound": "97205"
+ "num_range": 3943,
+ "upper_bound": "97666"
},
{
- "distinct_range": 1021.3593608657861,
+ "distinct_range": 967.1746871254414,
"num_eq": 80,
- "num_range": 3920,
- "upper_bound": "98231"
+ "num_range": 3916,
+ "upper_bound": "98637"
},
{
- "distinct_range": 907.0191849312353,
+ "distinct_range": 991.7918069483601,
"num_eq": 80,
- "num_range": 3911,
- "upper_bound": "99141"
+ "num_range": 3918,
+ "upper_bound": "99633"
},
{
- "distinct_range": 1221.7315280141133,
- "num_eq": 80,
- "num_range": 3944,
- "upper_bound": "100372"
+ "distinct_range": 1025.8958753419417,
+ "num_eq": 159,
+ "num_range": 3843,
+ "upper_bound": "100664"
},
{
- "distinct_range": 938.6251948896149,
+ "distinct_range": 905.0053623906376,
"num_eq": 80,
- "num_range": 3913,
- "upper_bound": "101314"
+ "num_range": 3912,
+ "upper_bound": "101572"
},
{
- "distinct_range": 985.9441495988717,
+ "distinct_range": 1065.4515149774475,
"num_eq": 80,
- "num_range": 3917,
- "upper_bound": "102304"
+ "num_range": 3924,
+ "upper_bound": "102643"
},
{
- "distinct_range": 1278.9728844261572,
+ "distinct_range": 1057.6085204292308,
"num_eq": 80,
- "num_range": 3952,
- "upper_bound": "103594"
+ "num_range": 3924,
+ "upper_bound": "103706"
},
{
- "distinct_range": 1021.3593608657861,
+ "distinct_range": 813.9002711645827,
"num_eq": 80,
- "num_range": 3920,
- "upper_bound": "104620"
+ "num_range": 3907,
+ "upper_bound": "104522"
},
{
- "distinct_range": 814.9128982878366,
+ "distinct_range": 1077.209592748253,
"num_eq": 80,
- "num_range": 3907,
- "upper_bound": "105437"
+ "num_range": 3926,
+ "upper_bound": "105605"
},
{
- "distinct_range": 1033.149909032264,
+ "distinct_range": 1275.879740291561,
"num_eq": 80,
- "num_range": 3921,
- "upper_bound": "106475"
+ "num_range": 3952,
+ "upper_bound": "106892"
},
{
- "distinct_range": 1212.0103880738939,
+ "distinct_range": 1147.5937050545829,
"num_eq": 80,
- "num_range": 3942,
- "upper_bound": "107696"
+ "num_range": 3934,
+ "upper_bound": "108047"
},
{
- "distinct_range": 946.5193131865562,
+ "distinct_range": 984.9021547087092,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "108646"
+ "num_range": 3917,
+ "upper_bound": "109036"
},
{
- "distinct_range": 797.0461836895724,
+ "distinct_range": 683.6330702800857,
"num_eq": 80,
- "num_range": 3906,
- "upper_bound": "109445"
+ "num_range": 3904,
+ "upper_bound": "109721"
},
{
- "distinct_range": 882.2950662290539,
+ "distinct_range": 1063.4910861159117,
"num_eq": 80,
- "num_range": 3910,
- "upper_bound": "110330"
+ "num_range": 3924,
+ "upper_bound": "110790"
},
{
- "distinct_range": 887.2420736122225,
+ "distinct_range": 1140.7633200349787,
"num_eq": 80,
- "num_range": 3910,
- "upper_bound": "111220"
+ "num_range": 3933,
+ "upper_bound": "111938"
},
{
- "distinct_range": 798.0390914918837,
+ "distinct_range": 1107.5486498848365,
"num_eq": 80,
- "num_range": 3906,
- "upper_bound": "112020"
+ "num_range": 3929,
+ "upper_bound": "113052"
},
{
- "distinct_range": 954.4104181035763,
+ "distinct_range": 776.1715586833409,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "112978"
+ "num_range": 3906,
+ "upper_bound": "113830"
},
{
- "distinct_range": 1013.4949297478647,
+ "distinct_range": 1037.9861959925179,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "113996"
+ "num_range": 3922,
+ "upper_bound": "114873"
},
{
- "distinct_range": 1162.346494571004,
+ "distinct_range": 1034.0592060413985,
"num_eq": 80,
- "num_range": 3935,
- "upper_bound": "115166"
+ "num_range": 3921,
+ "upper_bound": "115912"
},
{
- "distinct_range": 670.6838842602468,
+ "distinct_range": 899.0748336850921,
"num_eq": 80,
- "num_range": 3903,
- "upper_bound": "115838"
+ "num_range": 3911,
+ "upper_bound": "116814"
},
{
- "distinct_range": 853.5815123577389,
+ "distinct_range": 919.8245061425729,
"num_eq": 80,
- "num_range": 3908,
- "upper_bound": "116694"
+ "num_range": 3913,
+ "upper_bound": "117737"
},
{
- "distinct_range": 1066.5161775056868,
+ "distinct_range": 979.9794721831687,
"num_eq": 80,
- "num_range": 3924,
- "upper_bound": "117766"
+ "num_range": 3917,
+ "upper_bound": "118721"
},
{
- "distinct_range": 1058.6706963178135,
+ "distinct_range": 1049.7621252121755,
"num_eq": 80,
"num_range": 3923,
- "upper_bound": "118830"
+ "upper_bound": "119776"
},
{
- "distinct_range": 1097.86437476585,
+ "distinct_range": 912.9101903555032,
"num_eq": 80,
- "num_range": 3927,
- "upper_bound": "119934"
+ "num_range": 3912,
+ "upper_bound": "120692"
},
{
- "distinct_range": 997.756406406421,
+ "distinct_range": 805.9618301812986,
"num_eq": 80,
- "num_range": 3918,
- "upper_bound": "120936"
+ "num_range": 3907,
+ "upper_bound": "121500"
},
{
- "distinct_range": 818.7669532741385,
- "num_eq": 159,
- "num_range": 3828,
- "upper_bound": "121757"
+ "distinct_range": 1039.9493766871583,
+ "num_eq": 80,
+ "num_range": 3922,
+ "upper_bound": "122545"
},
{
- "distinct_range": 924.8033252584753,
+ "distinct_range": 908.9581415091006,
"num_eq": 80,
"num_range": 3912,
- "upper_bound": "122685"
+ "upper_bound": "123457"
},
{
- "distinct_range": 913.9369796517045,
+ "distinct_range": 905.9936254037694,
"num_eq": 80,
"num_range": 3912,
- "upper_bound": "123602"
+ "upper_bound": "124366"
},
{
- "distinct_range": 1180.865500875821,
+ "distinct_range": 1093.8535976296725,
"num_eq": 80,
- "num_range": 3938,
- "upper_bound": "124791"
+ "num_range": 3927,
+ "upper_bound": "125466"
},
{
- "distinct_range": 756.3067934153239,
+ "distinct_range": 921.7996087519822,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "125549"
+ "num_range": 3913,
+ "upper_bound": "126391"
},
{
- "distinct_range": 1405.3733580087169,
+ "distinct_range": 1237.109281761335,
"num_eq": 80,
- "num_range": 3976,
- "upper_bound": "126970"
+ "num_range": 3946,
+ "upper_bound": "127638"
},
{
- "distinct_range": 798.0390914918837,
- "num_eq": 159,
- "num_range": 3906,
- "upper_bound": "127770"
- },
- {
- "distinct_range": 1001.69223792924,
+ "distinct_range": 892.1538381135914,
"num_eq": 80,
- "num_range": 3918,
- "upper_bound": "128776"
+ "num_range": 3911,
+ "upper_bound": "128533"
},
{
- "distinct_range": 1007.594487001754,
+ "distinct_range": 1047.7999971608456,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "129788"
+ "num_range": 3923,
+ "upper_bound": "129586"
},
{
- "distinct_range": 811.9359488199957,
+ "distinct_range": 1011.462869251186,
"num_eq": 80,
- "num_range": 3907,
+ "num_range": 3919,
"upper_bound": "130602"
},
{
- "distinct_range": 1131.111916581263,
+ "distinct_range": 903.0287002939757,
"num_eq": 80,
- "num_range": 3931,
- "upper_bound": "131740"
+ "num_range": 3912,
+ "upper_bound": "131508"
},
{
- "distinct_range": 1003.6598544052529,
+ "distinct_range": 996.7114765374026,
"num_eq": 80,
"num_range": 3918,
- "upper_bound": "132748"
+ "upper_bound": "132509"
},
{
- "distinct_range": 881.305535511264,
+ "distinct_range": 1237.109281761335,
"num_eq": 80,
- "num_range": 3910,
- "upper_bound": "133632"
+ "num_range": 3946,
+ "upper_bound": "133756"
},
{
- "distinct_range": 992.8354984247986,
+ "distinct_range": 1086.0230707109124,
"num_eq": 80,
- "num_range": 3917,
- "upper_bound": "134629"
+ "num_range": 3927,
+ "upper_bound": "134848"
},
{
- "distinct_range": 931.7153924064378,
+ "distinct_range": 1089.9387676241422,
"num_eq": 80,
- "num_range": 3913,
- "upper_bound": "135564"
+ "num_range": 3927,
+ "upper_bound": "135944"
},
{
- "distinct_range": 1055.7277788654685,
+ "distinct_range": 996.7114765374026,
"num_eq": 80,
- "num_range": 3923,
- "upper_bound": "136625"
+ "num_range": 3918,
+ "upper_bound": "136945"
},
{
- "distinct_range": 930.7280924201702,
+ "distinct_range": 759.2762635250901,
"num_eq": 80,
- "num_range": 3913,
- "upper_bound": "137559"
+ "num_range": 3905,
+ "upper_bound": "137706"
},
{
- "distinct_range": 836.7333331727727,
+ "distinct_range": 1079.1685207456085,
"num_eq": 80,
- "num_range": 3908,
- "upper_bound": "138398"
+ "num_range": 3926,
+ "upper_bound": "138791"
},
{
- "distinct_range": 803.9957727366622,
+ "distinct_range": 925.7492557795443,
"num_eq": 80,
- "num_range": 3906,
- "upper_bound": "139204"
+ "num_range": 3913,
+ "upper_bound": "139720"
},
{
- "distinct_range": 928.7533540301982,
+ "distinct_range": 933.646303212693,
"num_eq": 80,
"num_range": 3913,
- "upper_bound": "140136"
+ "upper_bound": "140657"
},
{
- "distinct_range": 1137.949247653125,
+ "distinct_range": 1290.3951893913304,
"num_eq": 80,
- "num_range": 3932,
- "upper_bound": "141281"
+ "num_range": 3955,
+ "upper_bound": "141959"
},
{
- "distinct_range": 945.5327126028963,
+ "distinct_range": 966.1893582967808,
"num_eq": 80,
- "num_range": 3914,
- "upper_bound": "142230"
+ "num_range": 3916,
+ "upper_bound": "142929"
},
{
- "distinct_range": 1011.5283167812981,
+ "distinct_range": 921.7996087519822,
"num_eq": 80,
- "num_range": 3919,
- "upper_bound": "143246"
+ "num_range": 3913,
+ "upper_bound": "143854"
},
{
- "distinct_range": 1033.149909032264,
+ "distinct_range": 886.2198198547538,
"num_eq": 80,
- "num_range": 3921,
- "upper_bound": "144284"
+ "num_range": 3911,
+ "upper_bound": "144743"
},
{
- "distinct_range": 924.8033252584753,
+ "distinct_range": 883.2522146877226,
"num_eq": 80,
- "num_range": 3912,
- "upper_bound": "145212"
+ "num_range": 3910,
+ "upper_bound": "145629"
},
{
- "distinct_range": 655.7296505253383,
+ "distinct_range": 915.873745245587,
"num_eq": 80,
- "num_range": 3903,
- "upper_bound": "145869"
+ "num_range": 3912,
+ "upper_bound": "146548"
},
{
- "distinct_range": 999.7244218095967,
+ "distinct_range": 688.6146686658715,
"num_eq": 80,
- "num_range": 3918,
- "upper_bound": "146873"
+ "num_range": 3904,
+ "upper_bound": "147238"
},
{
- "distinct_range": 1032.1676442672285,
+ "distinct_range": 967.1746871254414,
"num_eq": 80,
- "num_range": 3921,
- "upper_bound": "147910"
+ "num_range": 3916,
+ "upper_bound": "148209"
},
{
- "distinct_range": 975.1100259679861,
+ "distinct_range": 1261.3514816953034,
"num_eq": 80,
- "num_range": 3916,
- "upper_bound": "148889"
+ "num_range": 3950,
+ "upper_bound": "149481"
},
{
- "distinct_range": 765.254489632421,
+ "distinct_range": 1061.5304438902406,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "149656"
+ "num_range": 3924,
+ "upper_bound": "150548"
},
{
- "distinct_range": 1434.0737737366787,
+ "distinct_range": 1044.856409321759,
"num_eq": 80,
- "num_range": 4057,
- "upper_bound": "151106"
+ "num_range": 3922,
+ "upper_bound": "151598"
},
{
- "distinct_range": 1223.2255771050106,
+ "distinct_range": 880.2842147005807,
"num_eq": 80,
- "num_range": 4021,
- "upper_bound": "152338"
+ "num_range": 3910,
+ "upper_bound": "152481"
},
{
- "distinct_range": 1112.9172805370672,
+ "distinct_range": 767.2282218563439,
"num_eq": 80,
- "num_range": 4007,
- "upper_bound": "153457"
+ "num_range": 3906,
+ "upper_bound": "153250"
},
{
- "distinct_range": 1383.0515202002066,
+ "distinct_range": 884.3933692905397,
"num_eq": 80,
- "num_range": 4047,
- "upper_bound": "154854"
+ "num_range": 3989,
+ "upper_bound": "154137"
},
{
- "distinct_range": 1112.9172805370672,
+ "distinct_range": 877.462414399018,
"num_eq": 80,
- "num_range": 4007,
- "upper_bound": "155973"
+ "num_range": 3989,
+ "upper_bound": "155017"
},
{
- "distinct_range": 1027.5352458204743,
+ "distinct_range": 1038.2829619571826,
"num_eq": 80,
- "num_range": 3999,
- "upper_bound": "157005"
+ "num_range": 4000,
+ "upper_bound": "156060"
},
{
- "distinct_range": 1165.715984490165,
+ "distinct_range": 1077.5511568874422,
"num_eq": 80,
- "num_range": 4013,
- "upper_bound": "158178"
+ "num_range": 4004,
+ "upper_bound": "157143"
},
{
- "distinct_range": 821.963652935085,
+ "distinct_range": 1021.5693536059752,
"num_eq": 80,
- "num_range": 3986,
- "upper_bound": "159002"
+ "num_range": 3999,
+ "upper_bound": "158169"
},
{
- "distinct_range": 933.8791963517389,
+ "distinct_range": 1227.9415235473562,
"num_eq": 80,
- "num_range": 3992,
- "upper_bound": "159939"
+ "num_range": 4022,
+ "upper_bound": "159406"
},
{
- "distinct_range": 1145.2014648475172,
+ "distinct_range": 1269.7018827514767,
"num_eq": 80,
- "num_range": 4010,
- "upper_bound": "161091"
+ "num_range": 4028,
+ "upper_bound": "160686"
},
{
- "distinct_range": 906.1969155002156,
+ "distinct_range": 1102.0516651580463,
"num_eq": 80,
- "num_range": 3990,
- "upper_bound": "162000"
+ "num_range": 4006,
+ "upper_bound": "161794"
},
{
- "distinct_range": 1302.8404001694455,
+ "distinct_range": 1038.2829619571826,
"num_eq": 80,
- "num_range": 4033,
- "upper_bound": "163314"
+ "num_range": 4000,
+ "upper_bound": "162837"
},
{
- "distinct_range": 913.1206665705784,
+ "distinct_range": 1018.6183928928933,
"num_eq": 80,
- "num_range": 3990,
- "upper_bound": "164230"
+ "num_range": 3998,
+ "upper_bound": "163860"
},
{
- "distinct_range": 923.9965832959886,
+ "distinct_range": 867.557546616752,
"num_eq": 80,
- "num_range": 3991,
- "upper_bound": "165157"
+ "num_range": 3989,
+ "upper_bound": "164730"
},
{
- "distinct_range": 820.9710217131529,
+ "distinct_range": 890.332558538039,
"num_eq": 80,
- "num_range": 3986,
- "upper_bound": "165980"
+ "num_range": 3990,
+ "upper_bound": "165623"
},
{
- "distinct_range": 1252.3955059240136,
+ "distinct_range": 1087.3552898665403,
"num_eq": 80,
- "num_range": 4025,
- "upper_bound": "167242"
+ "num_range": 4005,
+ "upper_bound": "166716"
},
{
- "distinct_range": 961.5267615127751,
+ "distinct_range": 767.304617128859,
"num_eq": 80,
- "num_range": 3994,
- "upper_bound": "168207"
+ "num_range": 3985,
+ "upper_bound": "167485"
},
{
- "distinct_range": 1058.9846978757391,
+ "distinct_range": 1036.3174091326114,
"num_eq": 80,
- "num_range": 4001,
- "upper_bound": "169271"
+ "num_range": 4000,
+ "upper_bound": "168526"
},
{
- "distinct_range": 1344.4426442271742,
+ "distinct_range": 1037.3002107907541,
"num_eq": 80,
- "num_range": 4040,
- "upper_bound": "170628"
+ "num_range": 4000,
+ "upper_bound": "169568"
},
{
- "distinct_range": 872.5380524469095,
+ "distinct_range": 1216.2691824534804,
"num_eq": 80,
- "num_range": 3988,
- "upper_bound": "171503"
+ "num_range": 4020,
+ "upper_bound": "170793"
},
{
- "distinct_range": 1199.854474512547,
+ "distinct_range": 1157.788768195068,
"num_eq": 80,
- "num_range": 4017,
- "upper_bound": "172711"
+ "num_range": 4012,
+ "upper_bound": "171958"
},
{
- "distinct_range": 1202.7775653155259,
+ "distinct_range": 1225.0241843700621,
"num_eq": 80,
- "num_range": 4018,
- "upper_bound": "173922"
+ "num_range": 4021,
+ "upper_bound": "173192"
},
{
- "distinct_range": 927.9501561333147,
+ "distinct_range": 1165.597519391711,
"num_eq": 80,
- "num_range": 3991,
- "upper_bound": "174853"
+ "num_range": 4013,
+ "upper_bound": "174365"
},
{
- "distinct_range": 1028.5188098821436,
+ "distinct_range": 997.9492174114338,
"num_eq": 80,
- "num_range": 3999,
- "upper_bound": "175886"
+ "num_range": 3997,
+ "upper_bound": "175367"
},
{
- "distinct_range": 1073.7089396226022,
+ "distinct_range": 1282.3068698962504,
"num_eq": 80,
- "num_range": 4003,
- "upper_bound": "176965"
+ "num_range": 4030,
+ "upper_bound": "176660"
},
{
- "distinct_range": 1102.1432241974405,
- "num_eq": 80,
- "num_range": 4006,
- "upper_bound": "178073"
+ "distinct_range": 1088.3354157996728,
+ "num_eq": 159,
+ "num_range": 4005,
+ "upper_bound": "177754"
},
{
- "distinct_range": 1087.4412309379647,
+ "distinct_range": 923.7745254640323,
"num_eq": 80,
- "num_range": 4004,
- "upper_bound": "179166"
+ "num_range": 3913,
+ "upper_bound": "178681"
},
{
- "distinct_range": 1059.9666681075241,
+ "distinct_range": 987.1139071956468,
"num_eq": 80,
- "num_range": 4001,
- "upper_bound": "180231"
+ "num_range": 3996,
+ "upper_bound": "179672"
},
{
- "distinct_range": 1264.0497510766609,
+ "distinct_range": 893.3015840712374,
"num_eq": 80,
- "num_range": 4027,
- "upper_bound": "181505"
+ "num_range": 3990,
+ "upper_bound": "180568"
},
{
- "distinct_range": 1000.9605805807828,
+ "distinct_range": 930.8755663462388,
"num_eq": 80,
- "num_range": 3996,
- "upper_bound": "182510"
+ "num_range": 3992,
+ "upper_bound": "181502"
},
{
- "distinct_range": 1026.551632612382,
+ "distinct_range": 839.8025864989403,
"num_eq": 80,
- "num_range": 3998,
- "upper_bound": "183541"
+ "num_range": 3987,
+ "upper_bound": "182344"
},
{
- "distinct_range": 1185.2317460551117,
+ "distinct_range": 824.9213710698856,
"num_eq": 80,
- "num_range": 4015,
- "upper_bound": "184734"
+ "num_range": 3987,
+ "upper_bound": "183171"
},
{
- "distinct_range": 1131.5121366443846,
+ "distinct_range": 1108.9059139395436,
"num_eq": 80,
- "num_range": 4009,
- "upper_bound": "185872"
+ "num_range": 4007,
+ "upper_bound": "184286"
},
{
- "distinct_range": 1079.5954347363195,
+ "distinct_range": 885.3833390802903,
"num_eq": 80,
- "num_range": 4003,
- "upper_bound": "186957"
+ "num_range": 3989,
+ "upper_bound": "185174"
},
{
- "distinct_range": 906.1969155002156,
+ "distinct_range": 891.3222760351191,
"num_eq": 80,
"num_range": 3990,
- "upper_bound": "187866"
+ "upper_bound": "186068"
},
{
- "distinct_range": 1200.8288920753375,
+ "distinct_range": 895.2807223636607,
"num_eq": 80,
- "num_range": 4018,
- "upper_bound": "189075"
+ "num_range": 3990,
+ "upper_bound": "186966"
},
{
- "distinct_range": 1085.4800895139804,
+ "distinct_range": 1026.4866246280062,
"num_eq": 80,
- "num_range": 4004,
- "upper_bound": "190166"
+ "num_range": 3999,
+ "upper_bound": "187997"
},
{
- "distinct_range": 892.3431852024296,
+ "distinct_range": 1163.6456574456647,
"num_eq": 80,
- "num_range": 3989,
- "upper_bound": "191061"
+ "num_range": 4013,
+ "upper_bound": "189168"
},
{
- "distinct_range": 1282.4862218821947,
+ "distinct_range": 1198.7457781397977,
"num_eq": 80,
- "num_range": 4029,
- "upper_bound": "192354"
+ "num_range": 4018,
+ "upper_bound": "190375"
},
{
- "distinct_range": 1021.6328308560746,
+ "distinct_range": 1199.7197683872917,
"num_eq": 80,
- "num_range": 3998,
- "upper_bound": "193380"
+ "num_range": 4018,
+ "upper_bound": "191583"
},
{
- "distinct_range": 1059.9666681075241,
+ "distinct_range": 1000.9032820078913,
"num_eq": 80,
- "num_range": 4001,
- "upper_bound": "194445"
+ "num_range": 3997,
+ "upper_bound": "192588"
},
{
- "distinct_range": 1029.5023247554616,
- "num_eq": 159,
- "num_range": 3999,
- "upper_bound": "195479"
+ "distinct_range": 983.1723461782643,
+ "num_eq": 80,
+ "num_range": 3995,
+ "upper_bound": "193575"
},
{
- "distinct_range": 762.2722210643867,
+ "distinct_range": 1140.2064081747255,
"num_eq": 80,
- "num_range": 3905,
- "upper_bound": "196243"
+ "num_range": 4010,
+ "upper_bound": "194722"
},
{
- "distinct_range": 923.9965832959886,
+ "distinct_range": 987.1139071956468,
"num_eq": 80,
- "num_range": 3991,
- "upper_bound": "197170"
+ "num_range": 3996,
+ "upper_bound": "195713"
},
{
- "distinct_range": 903.2289544328887,
+ "distinct_range": 1007.7943875136632,
"num_eq": 80,
- "num_range": 3990,
- "upper_bound": "198076"
+ "num_range": 3997,
+ "upper_bound": "196725"
},
{
- "distinct_range": 1022.6166891608583,
+ "distinct_range": 924.9470565676515,
"num_eq": 80,
- "num_range": 3998,
- "upper_bound": "199103"
+ "num_range": 3992,
+ "upper_bound": "197653"
},
{
- "distinct_range": 888.3834714349293,
+ "distinct_range": 1107.9268943295128,
"num_eq": 80,
- "num_range": 3989,
- "upper_bound": "199994"
+ "num_range": 4007,
+ "upper_bound": "198767"
},
{
- "distinct_range": 4.3655745685100555E-11,
- "num_eq": 0,
- "num_range": 0,
- "upper_bound": "9223372036854775807"
+ "distinct_range": 1223.0790151221138,
+ "num_eq": 80,
+ "num_range": 4021,
+ "upper_bound": "199999"
}
],
"histo_col_type": "INT8",
@@ -15920,1211 +15957,1212 @@ ALTER TABLE "partsupp" INJECT STATISTICS '[
"row_count": 800000
},
{
+ "avg_size": 3,
"columns": [
"ps_suppkey"
],
- "created_at": "2021-09-08 20:48:28.135856",
+ "created_at": "2022-02-25 00:55:37.590966",
"distinct_count": 9920,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 240,
+ "num_eq": 160,
"num_range": 0,
- "upper_bound": "1"
+ "upper_bound": "2"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 46.6210837840596,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "48"
+ "upper_bound": "50"
+ },
+ {
+ "distinct_range": 52.57271150117359,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "104"
},
{
- "distinct_range": 62.504848422986626,
+ "distinct_range": 47.61302173691193,
"num_eq": 160,
- "num_range": 3840,
- "upper_bound": "112"
+ "num_range": 3920,
+ "upper_bound": "153"
},
{
- "distinct_range": 60.520567520669594,
+ "distinct_range": 58.52433921828758,
"num_eq": 160,
- "num_range": 3840,
- "upper_bound": "174"
+ "num_range": 3920,
+ "upper_bound": "213"
},
{
- "distinct_range": 57.544146167194036,
- "num_eq": 80,
+ "distinct_range": 66.45984284110624,
+ "num_eq": 240,
"num_range": 3920,
- "upper_bound": "233"
+ "upper_bound": "281"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 37.69364220838861,
"num_eq": 240,
"num_range": 3760,
- "upper_bound": "271"
+ "upper_bound": "320"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 44.637207878354936,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "318"
+ "upper_bound": "366"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 160,
- "num_range": 3920,
- "upper_bound": "364"
+ "distinct_range": 43.6452699255026,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "411"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 80,
+ "distinct_range": 49.5968976426166,
+ "num_eq": 240,
"num_range": 3920,
- "upper_bound": "415"
+ "upper_bound": "462"
+ },
+ {
+ "distinct_range": 51.58077354832126,
+ "num_eq": 320,
+ "num_range": 3840,
+ "upper_bound": "515"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 31.74201449127462,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "548"
+ },
+ {
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "468"
+ "upper_bound": "600"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 47.61302173691193,
"num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "649"
+ },
+ {
+ "distinct_range": 46.6210837840596,
+ "num_eq": 240,
"num_range": 3920,
- "upper_bound": "521"
+ "upper_bound": "697"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 44.637207878354936,
"num_eq": 320,
- "num_range": 3760,
- "upper_bound": "565"
+ "num_range": 3920,
+ "upper_bound": "743"
+ },
+ {
+ "distinct_range": 48.604959689764264,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "793"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "617"
+ "upper_bound": "845"
},
{
- "distinct_range": 39.685618046340714,
+ "distinct_range": 46.6210837840596,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "658"
+ "upper_bound": "893"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 58.52433921828758,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "713"
+ "upper_bound": "953"
},
{
- "distinct_range": 52.583443911401446,
- "num_eq": 80,
+ "distinct_range": 51.58077354832126,
+ "num_eq": 240,
"num_range": 3920,
- "upper_bound": "767"
+ "upper_bound": "1006"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 44.637207878354936,
"num_eq": 240,
"num_range": 3760,
- "upper_bound": "817"
+ "upper_bound": "1052"
},
{
- "distinct_range": 59.528427069511075,
- "num_eq": 240,
+ "distinct_range": 49.5968976426166,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "1103"
+ },
+ {
+ "distinct_range": 53.56464945402592,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "878"
+ "upper_bound": "1158"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 39.677518114093274,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "930"
+ "upper_bound": "1199"
+ },
+ {
+ "distinct_range": 45.62914583120727,
+ "num_eq": 160,
+ "num_range": 3920,
+ "upper_bound": "1246"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 54.55658740687825,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "978"
+ "upper_bound": "1302"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 71.41953260536789,
"num_eq": 160,
- "num_range": 3840,
- "upper_bound": "1034"
+ "num_range": 3920,
+ "upper_bound": "1375"
},
{
- "distinct_range": 59.528427069511075,
+ "distinct_range": 41.66139401979794,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1095"
+ "upper_bound": "1418"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 80,
+ "distinct_range": 55.54852535973058,
+ "num_eq": 160,
"num_range": 3920,
- "upper_bound": "1150"
+ "upper_bound": "1475"
},
{
- "distinct_range": 41.66989894865775,
+ "distinct_range": 47.61302173691193,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1193"
+ "upper_bound": "1524"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 37.69364220838861,
"num_eq": 240,
- "num_range": 3920,
- "upper_bound": "1243"
+ "num_range": 3760,
+ "upper_bound": "1563"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 320,
- "num_range": 3920,
- "upper_bound": "1294"
+ "distinct_range": 63.48402898254924,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "1628"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 59.51627717113991,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1348"
+ "upper_bound": "1689"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 49.5968976426166,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1402"
+ "upper_bound": "1740"
},
{
- "distinct_range": 64.48912932530367,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "1468"
+ "distinct_range": 57.53240126543525,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "1799"
+ },
+ {
+ "distinct_range": 49.5968976426166,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "1850"
},
{
- "distinct_range": 37.70133714402368,
+ "distinct_range": 49.5968976426166,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1507"
+ "upper_bound": "1901"
},
{
- "distinct_range": 43.654179850974785,
+ "distinct_range": 45.62914583120727,
"num_eq": 160,
- "num_range": 3920,
- "upper_bound": "1552"
+ "num_range": 3840,
+ "upper_bound": "1948"
},
{
- "distinct_range": 60.520567520669594,
+ "distinct_range": 67.45178079395856,
"num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "2017"
+ },
+ {
+ "distinct_range": 36.70170425553628,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "1614"
+ "upper_bound": "2055"
},
{
- "distinct_range": 57.544146167194036,
+ "distinct_range": 42.65333197265027,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1673"
+ "upper_bound": "2099"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 56.540463312582915,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "1731"
+ "upper_bound": "2157"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "1780"
+ "distinct_range": 55.54852535973058,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "2214"
},
{
- "distinct_range": 52.583443911401446,
- "num_eq": 160,
+ "distinct_range": 51.58077354832126,
+ "num_eq": 240,
"num_range": 3920,
- "upper_bound": "1834"
+ "upper_bound": "2267"
},
{
- "distinct_range": 45.638460753291824,
- "num_eq": 240,
- "num_range": 3840,
- "upper_bound": "1881"
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "2319"
},
{
- "distinct_range": 57.544146167194036,
- "num_eq": 80,
+ "distinct_range": 52.57271150117359,
+ "num_eq": 160,
"num_range": 3920,
- "upper_bound": "1940"
+ "upper_bound": "2373"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 53.56464945402592,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "1994"
+ "upper_bound": "2428"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 48.604959689764264,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "2041"
+ "upper_bound": "2478"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 80,
+ "distinct_range": 66.45984284110624,
+ "num_eq": 160,
"num_range": 3920,
- "upper_bound": "2096"
+ "upper_bound": "2546"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 54.55658740687825,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "2153"
+ "upper_bound": "2602"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 53.56464945402592,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "2199"
+ "upper_bound": "2657"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "2256"
+ "distinct_range": 48.604959689764264,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "2707"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 320,
+ "distinct_range": 51.58077354832126,
+ "num_eq": 160,
"num_range": 3920,
- "upper_bound": "2304"
+ "upper_bound": "2760"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "2349"
+ "distinct_range": 46.6210837840596,
+ "num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "2808"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 42.65333197265027,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "2401"
+ "upper_bound": "2852"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 59.51627717113991,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "2451"
+ "upper_bound": "2913"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 53.56464945402592,
"num_eq": 160,
- "num_range": 3920,
- "upper_bound": "2498"
+ "num_range": 3840,
+ "upper_bound": "2968"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 60.508215123992244,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "2546"
- },
- {
- "distinct_range": 51.59130346024293,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "2599"
+ "upper_bound": "3030"
},
{
- "distinct_range": 42.66203939981627,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "2643"
+ "distinct_range": 37.69364220838861,
+ "num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "3069"
},
{
- "distinct_range": 38.693477595182195,
- "num_eq": 320,
+ "distinct_range": 44.637207878354936,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "2683"
+ "upper_bound": "3115"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 48.604959689764264,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "2731"
+ "upper_bound": "3165"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "2772"
+ "distinct_range": 43.6452699255026,
+ "num_eq": 160,
+ "num_range": 3920,
+ "upper_bound": "3210"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 44.637207878354936,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "2827"
+ "upper_bound": "3256"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 400,
- "num_range": 3680,
- "upper_bound": "2869"
+ "distinct_range": 48.604959689764264,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "3306"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 240,
+ "distinct_range": 57.53240126543525,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "3365"
+ },
+ {
+ "distinct_range": 52.57271150117359,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "2915"
+ "upper_bound": "3419"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 48.604959689764264,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "2973"
+ "upper_bound": "3469"
},
{
- "distinct_range": 48.614882106767375,
- "num_eq": 240,
- "num_range": 3920,
- "upper_bound": "3023"
+ "distinct_range": 52.57271150117359,
+ "num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "3523"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 51.58077354832126,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3078"
+ "upper_bound": "3576"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 320,
+ "distinct_range": 63.48402898254924,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "3129"
+ "upper_bound": "3641"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 320,
- "num_range": 3920,
- "upper_bound": "3184"
+ "distinct_range": 51.58077354832126,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "3694"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 42.65333197265027,
"num_eq": 160,
- "num_range": 3920,
- "upper_bound": "3236"
+ "num_range": 3840,
+ "upper_bound": "3738"
},
{
- "distinct_range": 58.536286618352555,
+ "distinct_range": 66.45984284110624,
"num_eq": 320,
- "num_range": 3760,
- "upper_bound": "3296"
+ "num_range": 3920,
+ "upper_bound": "3806"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 43.6452699255026,
+ "num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "3851"
+ },
+ {
+ "distinct_range": 47.61302173691193,
"num_eq": 240,
- "num_range": 3760,
- "upper_bound": "3353"
+ "num_range": 3840,
+ "upper_bound": "3900"
},
{
- "distinct_range": 58.536286618352555,
+ "distinct_range": 55.54852535973058,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3413"
+ "upper_bound": "3957"
},
{
- "distinct_range": 58.536286618352555,
+ "distinct_range": 45.62914583120727,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3473"
+ "upper_bound": "4004"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 160,
- "num_range": 3840,
- "upper_bound": "3521"
- },
- {
- "distinct_range": 43.654179850974785,
- "num_eq": 320,
- "num_range": 3840,
- "upper_bound": "3566"
+ "distinct_range": 44.637207878354936,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "4050"
},
{
- "distinct_range": 39.685618046340714,
+ "distinct_range": 43.6452699255026,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "3607"
+ "upper_bound": "4095"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 48.604959689764264,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "3657"
+ "upper_bound": "4145"
},
{
- "distinct_range": 59.528427069511075,
+ "distinct_range": 54.55658740687825,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3718"
+ "upper_bound": "4201"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "3775"
+ "distinct_range": 48.604959689764264,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "4251"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 40.66945606694561,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3813"
+ "upper_bound": "4293"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 40.66945606694561,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3868"
+ "upper_bound": "4335"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 43.6452699255026,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "3924"
+ "upper_bound": "4380"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "3971"
+ "upper_bound": "4432"
},
{
- "distinct_range": 35.71705624170664,
- "num_eq": 240,
- "num_range": 3840,
- "upper_bound": "4008"
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "4484"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 55.54852535973058,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "4065"
+ "upper_bound": "4541"
},
{
- "distinct_range": 56.552005716035524,
- "num_eq": 160,
- "num_range": 3840,
- "upper_bound": "4123"
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "4593"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 55.54852535973058,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "4174"
+ "upper_bound": "4650"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 240,
- "num_range": 3840,
- "upper_bound": "4231"
+ "distinct_range": 54.55658740687825,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "4706"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 36.70170425553628,
"num_eq": 160,
- "num_range": 3840,
- "upper_bound": "4269"
+ "num_range": 3920,
+ "upper_bound": "4744"
},
{
- "distinct_range": 61.51270797182811,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "4332"
+ "distinct_range": 58.52433921828758,
+ "num_eq": 320,
+ "num_range": 3760,
+ "upper_bound": "4804"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 160,
+ "distinct_range": 39.677518114093274,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "4385"
+ "upper_bound": "4845"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "4436"
+ "upper_bound": "4897"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 46.6210837840596,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "4484"
- },
- {
- "distinct_range": 51.59130346024293,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "4537"
+ "upper_bound": "4945"
},
{
- "distinct_range": 49.607022557925895,
+ "distinct_range": 45.62914583120727,
"num_eq": 240,
"num_range": 3920,
- "upper_bound": "4588"
+ "upper_bound": "4992"
},
{
- "distinct_range": 43.654179850974785,
- "num_eq": 160,
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "4633"
+ "upper_bound": "5044"
},
{
- "distinct_range": 50.599163009084414,
- "num_eq": 160,
+ "distinct_range": 62.49209102969691,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "4685"
+ "upper_bound": "5108"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 160,
- "num_range": 3840,
- "upper_bound": "4733"
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "5160"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 45.62914583120727,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "4783"
- },
- {
- "distinct_range": 49.607022557925895,
- "num_eq": 80,
- "num_range": 3840,
- "upper_bound": "4834"
- },
- {
- "distinct_range": 38.693477595182195,
- "num_eq": 240,
- "num_range": 3840,
- "upper_bound": "4874"
+ "upper_bound": "5207"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 52.57271150117359,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "4918"
+ "upper_bound": "5261"
},
{
- "distinct_range": 33.73277533938961,
- "num_eq": 160,
+ "distinct_range": 56.540463312582915,
+ "num_eq": 400,
"num_range": 3760,
- "upper_bound": "4953"
+ "upper_bound": "5319"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 160,
- "num_range": 3920,
- "upper_bound": "5008"
+ "distinct_range": 37.69364220838861,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "5358"
+ },
+ {
+ "distinct_range": 44.637207878354936,
+ "num_eq": 320,
+ "num_range": 3680,
+ "upper_bound": "5404"
+ },
+ {
+ "distinct_range": 44.637207878354936,
+ "num_eq": 240,
+ "num_range": 3840,
+ "upper_bound": "5450"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 38.68558016124094,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "5052"
+ "upper_bound": "5490"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 46.6210837840596,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "5096"
+ "upper_bound": "5538"
},
{
- "distinct_range": 49.607022557925895,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "5147"
+ "distinct_range": 50.58883559546893,
+ "num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "5590"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 47.61302173691193,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "5197"
+ "upper_bound": "5639"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 45.62914583120727,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "5245"
+ "upper_bound": "5686"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 54.55658740687825,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "5292"
+ "upper_bound": "5742"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 44.637207878354936,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "5341"
+ "upper_bound": "5788"
},
{
- "distinct_range": 53.575584362559965,
- "num_eq": 240,
+ "distinct_range": 47.61302173691193,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "5396"
+ "upper_bound": "5837"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 160,
+ "distinct_range": 45.62914583120727,
+ "num_eq": 240,
"num_range": 3760,
- "upper_bound": "5449"
+ "upper_bound": "5884"
},
{
- "distinct_range": 47.62274165560886,
+ "distinct_range": 54.55658740687825,
"num_eq": 80,
- "num_range": 3840,
- "upper_bound": "5498"
+ "num_range": 3920,
+ "upper_bound": "5940"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 320,
+ "distinct_range": 43.6452699255026,
+ "num_eq": 240,
"num_range": 3840,
- "upper_bound": "5547"
- },
- {
- "distinct_range": 53.575584362559965,
- "num_eq": 160,
- "num_range": 3760,
- "upper_bound": "5602"
+ "upper_bound": "5985"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 240,
- "num_range": 3680,
- "upper_bound": "5651"
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
+ "num_range": 3840,
+ "upper_bound": "6037"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 51.58077354832126,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "5703"
- },
- {
- "distinct_range": 37.70133714402368,
- "num_eq": 320,
- "num_range": 3760,
- "upper_bound": "5742"
+ "upper_bound": "6090"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 43.6452699255026,
"num_eq": 240,
- "num_range": 3840,
- "upper_bound": "5786"
+ "num_range": 3920,
+ "upper_bound": "6135"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 160,
+ "distinct_range": 48.604959689764264,
+ "num_eq": 80,
"num_range": 3840,
- "upper_bound": "5827"
+ "upper_bound": "6185"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 41.66139401979794,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "5865"
+ "upper_bound": "6228"
},
{
- "distinct_range": 68.45769112993773,
+ "distinct_range": 41.66139401979794,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "5935"
- },
- {
- "distinct_range": 43.654179850974785,
- "num_eq": 80,
- "num_range": 3840,
- "upper_bound": "5980"
+ "upper_bound": "6271"
},
{
- "distinct_range": 68.45769112993773,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "6050"
+ "upper_bound": "6323"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 51.58077354832126,
"num_eq": 240,
- "num_range": 3920,
- "upper_bound": "6096"
- },
- {
- "distinct_range": 55.559865264877004,
- "num_eq": 160,
"num_range": 3760,
- "upper_bound": "6153"
+ "upper_bound": "6376"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 56.540463312582915,
"num_eq": 80,
- "num_range": 3840,
- "upper_bound": "6208"
+ "num_range": 3920,
+ "upper_bound": "6434"
},
{
- "distinct_range": 60.520567520669594,
+ "distinct_range": 38.68558016124094,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "6270"
+ "upper_bound": "6474"
},
{
- "distinct_range": 37.70133714402368,
- "num_eq": 320,
- "num_range": 3600,
- "upper_bound": "6309"
+ "distinct_range": 51.58077354832126,
+ "num_eq": 160,
+ "num_range": 3840,
+ "upper_bound": "6527"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 160,
- "num_range": 3920,
- "upper_bound": "6358"
+ "distinct_range": 57.53240126543525,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "6586"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 45.62914583120727,
"num_eq": 240,
- "num_range": 3840,
- "upper_bound": "6412"
+ "num_range": 3760,
+ "upper_bound": "6633"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 39.677518114093274,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "6464"
+ "upper_bound": "6674"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 35.709766302683946,
"num_eq": 160,
- "num_range": 3840,
- "upper_bound": "6518"
+ "num_range": 3920,
+ "upper_bound": "6711"
},
{
- "distinct_range": 57.544146167194036,
- "num_eq": 160,
+ "distinct_range": 38.68558016124094,
+ "num_eq": 80,
"num_range": 3840,
- "upper_bound": "6577"
+ "upper_bound": "6751"
},
{
- "distinct_range": 61.51270797182811,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "6640"
+ "distinct_range": 44.637207878354936,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "6797"
},
{
- "distinct_range": 34.724915790548124,
- "num_eq": 240,
+ "distinct_range": 36.70170425553628,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "6835"
+ },
+ {
+ "distinct_range": 43.6452699255026,
+ "num_eq": 400,
+ "num_range": 3840,
+ "upper_bound": "6880"
+ },
+ {
+ "distinct_range": 36.70170425553628,
+ "num_eq": 160,
"num_range": 3760,
- "upper_bound": "6676"
+ "upper_bound": "6918"
},
{
- "distinct_range": 57.544146167194036,
+ "distinct_range": 62.49209102969691,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "6735"
+ "upper_bound": "6982"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 42.65333197265027,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "6792"
+ "upper_bound": "7026"
},
{
- "distinct_range": 41.66989894865775,
- "num_eq": 400,
+ "distinct_range": 41.66139401979794,
+ "num_eq": 160,
"num_range": 3760,
- "upper_bound": "6835"
+ "upper_bound": "7069"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 160,
+ "distinct_range": 52.57271150117359,
+ "num_eq": 240,
"num_range": 3840,
- "upper_bound": "6877"
+ "upper_bound": "7123"
},
{
- "distinct_range": 37.70133714402368,
+ "distinct_range": 54.55658740687825,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "6916"
+ "upper_bound": "7179"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 57.53240126543525,
"num_eq": 320,
"num_range": 3680,
- "upper_bound": "6968"
+ "upper_bound": "7238"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 80,
- "num_range": 3840,
- "upper_bound": "7025"
+ "distinct_range": 47.61302173691193,
+ "num_eq": 160,
+ "num_range": 3760,
+ "upper_bound": "7287"
},
{
- "distinct_range": 34.724915790548124,
+ "distinct_range": 47.61302173691193,
"num_eq": 80,
- "num_range": 3840,
- "upper_bound": "7061"
+ "num_range": 3920,
+ "upper_bound": "7336"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "7107"
- },
- {
- "distinct_range": 50.599163009084414,
- "num_eq": 160,
- "num_range": 3840,
- "upper_bound": "7159"
+ "upper_bound": "7388"
},
{
- "distinct_range": 60.520567520669594,
- "num_eq": 160,
+ "distinct_range": 48.604959689764264,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "7221"
+ "upper_bound": "7438"
},
{
- "distinct_range": 41.66989894865775,
+ "distinct_range": 40.66945606694561,
"num_eq": 80,
- "num_range": 3840,
- "upper_bound": "7264"
+ "num_range": 3920,
+ "upper_bound": "7480"
},
{
- "distinct_range": 34.724915790548124,
+ "distinct_range": 46.6210837840596,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "7300"
+ "upper_bound": "7528"
},
{
- "distinct_range": 54.567724813718485,
+ "distinct_range": 44.637207878354936,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "7356"
- },
- {
- "distinct_range": 32.74063488823109,
- "num_eq": 320,
- "num_range": 3920,
- "upper_bound": "7390"
+ "upper_bound": "7574"
},
{
- "distinct_range": 56.552005716035524,
- "num_eq": 160,
+ "distinct_range": 44.637207878354936,
+ "num_eq": 240,
"num_range": 3760,
- "upper_bound": "7448"
+ "upper_bound": "7620"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 42.65333197265027,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "7495"
+ "upper_bound": "7664"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 40.66945606694561,
"num_eq": 80,
- "num_range": 3840,
- "upper_bound": "7547"
+ "num_range": 3920,
+ "upper_bound": "7706"
},
{
- "distinct_range": 56.552005716035524,
+ "distinct_range": 47.61302173691193,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "7605"
- },
- {
- "distinct_range": 41.66989894865775,
- "num_eq": 80,
- "num_range": 3840,
- "upper_bound": "7648"
- },
- {
- "distinct_range": 57.544146167194036,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "7707"
+ "upper_bound": "7755"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 80,
+ "distinct_range": 48.604959689764264,
+ "num_eq": 240,
"num_range": 3920,
- "upper_bound": "7755"
+ "upper_bound": "7805"
},
{
- "distinct_range": 61.51270797182811,
+ "distinct_range": 40.66945606694561,
"num_eq": 160,
- "num_range": 3920,
- "upper_bound": "7818"
+ "num_range": 3840,
+ "upper_bound": "7847"
},
{
- "distinct_range": 38.693477595182195,
+ "distinct_range": 47.61302173691193,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "7858"
+ "upper_bound": "7896"
},
{
- "distinct_range": 44.646320302133304,
- "num_eq": 240,
+ "distinct_range": 56.540463312582915,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "7904"
+ "upper_bound": "7954"
},
{
- "distinct_range": 45.638460753291824,
+ "distinct_range": 58.52433921828758,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "7951"
+ "upper_bound": "8014"
},
{
- "distinct_range": 39.685618046340714,
+ "distinct_range": 48.604959689764264,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "7992"
+ "upper_bound": "8064"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 42.65333197265027,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8049"
- },
- {
- "distinct_range": 47.62274165560886,
- "num_eq": 240,
- "num_range": 3760,
- "upper_bound": "8098"
+ "upper_bound": "8108"
},
{
- "distinct_range": 44.646320302133304,
+ "distinct_range": 49.5968976426166,
"num_eq": 160,
"num_range": 3920,
- "upper_bound": "8144"
+ "upper_bound": "8159"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 46.6210837840596,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "8194"
+ "upper_bound": "8207"
},
{
- "distinct_range": 38.693477595182195,
- "num_eq": 240,
+ "distinct_range": 41.66139401979794,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "8234"
+ "upper_bound": "8250"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 80,
+ "distinct_range": 52.57271150117359,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "8282"
+ "upper_bound": "8304"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 240,
- "num_range": 3680,
- "upper_bound": "8323"
+ "distinct_range": 55.54852535973058,
+ "num_eq": 160,
+ "num_range": 3760,
+ "upper_bound": "8361"
},
{
- "distinct_range": 51.59130346024293,
+ "distinct_range": 47.61302173691193,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8376"
+ "upper_bound": "8410"
},
{
- "distinct_range": 55.559865264877004,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8433"
+ "upper_bound": "8462"
},
{
- "distinct_range": 39.685618046340714,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "8474"
+ "distinct_range": 49.5968976426166,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "8513"
},
{
- "distinct_range": 38.693477595182195,
+ "distinct_range": 47.61302173691193,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8514"
+ "upper_bound": "8562"
+ },
+ {
+ "distinct_range": 44.637207878354936,
+ "num_eq": 240,
+ "num_range": 3760,
+ "upper_bound": "8608"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 34.71782834983161,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8564"
+ "upper_bound": "8644"
},
{
- "distinct_range": 57.544146167194036,
- "num_eq": 160,
+ "distinct_range": 60.508215123992244,
+ "num_eq": 320,
"num_range": 3920,
- "upper_bound": "8623"
+ "upper_bound": "8706"
},
{
- "distinct_range": 51.59130346024293,
- "num_eq": 240,
+ "distinct_range": 44.637207878354936,
+ "num_eq": 160,
+ "num_range": 3760,
+ "upper_bound": "8752"
+ },
+ {
+ "distinct_range": 45.62914583120727,
+ "num_eq": 80,
"num_range": 3840,
- "upper_bound": "8676"
+ "upper_bound": "8799"
},
{
- "distinct_range": 56.552005716035524,
- "num_eq": 160,
+ "distinct_range": 39.677518114093274,
+ "num_eq": 80,
"num_range": 3840,
- "upper_bound": "8734"
+ "upper_bound": "8840"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 60.508215123992244,
"num_eq": 160,
+ "num_range": 3920,
+ "upper_bound": "8902"
+ },
+ {
+ "distinct_range": 50.58883559546893,
+ "num_eq": 80,
"num_range": 3840,
- "upper_bound": "8784"
+ "upper_bound": "8954"
},
{
- "distinct_range": 33.73277533938961,
- "num_eq": 240,
- "num_range": 3680,
- "upper_bound": "8819"
+ "distinct_range": 39.677518114093274,
+ "num_eq": 160,
+ "num_range": 3920,
+ "upper_bound": "8995"
},
{
- "distinct_range": 36.70919669286516,
+ "distinct_range": 66.45984284110624,
"num_eq": 160,
"num_range": 3760,
- "upper_bound": "8857"
+ "upper_bound": "9063"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 41.66139401979794,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8907"
+ "upper_bound": "9106"
},
{
- "distinct_range": 46.63060120445034,
+ "distinct_range": 44.637207878354936,
"num_eq": 80,
"num_range": 3920,
- "upper_bound": "8955"
+ "upper_bound": "9152"
},
{
- "distinct_range": 55.559865264877004,
- "num_eq": 240,
- "num_range": 3760,
- "upper_bound": "9012"
+ "distinct_range": 48.604959689764264,
+ "num_eq": 160,
+ "num_range": 3920,
+ "upper_bound": "9202"
},
{
- "distinct_range": 46.63060120445034,
- "num_eq": 240,
+ "distinct_range": 52.57271150117359,
+ "num_eq": 160,
"num_range": 3840,
- "upper_bound": "9060"
+ "upper_bound": "9256"
},
{
- "distinct_range": 41.66989894865775,
+ "distinct_range": 52.57271150117359,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "9103"
+ "upper_bound": "9310"
},
{
- "distinct_range": 52.583443911401446,
+ "distinct_range": 50.58883559546893,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "9157"
- },
- {
- "distinct_range": 41.66989894865775,
- "num_eq": 240,
- "num_range": 3760,
- "upper_bound": "9200"
+ "upper_bound": "9362"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 160,
+ "distinct_range": 45.62914583120727,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "9249"
+ "upper_bound": "9409"
},
{
- "distinct_range": 50.599163009084414,
- "num_eq": 240,
- "num_range": 3840,
- "upper_bound": "9301"
+ "distinct_range": 51.58077354832126,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "9462"
},
{
- "distinct_range": 36.70919669286516,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "9339"
+ "distinct_range": 40.66945606694561,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "9504"
},
{
- "distinct_range": 40.677758497499234,
+ "distinct_range": 45.62914583120727,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "9381"
+ "upper_bound": "9551"
},
{
- "distinct_range": 47.62274165560886,
- "num_eq": 80,
+ "distinct_range": 45.62914583120727,
+ "num_eq": 240,
"num_range": 3840,
- "upper_bound": "9430"
+ "upper_bound": "9598"
},
{
- "distinct_range": 42.66203939981627,
+ "distinct_range": 44.637207878354936,
"num_eq": 160,
- "num_range": 3760,
- "upper_bound": "9474"
- },
- {
- "distinct_range": 53.575584362559965,
- "num_eq": 240,
- "num_range": 3920,
- "upper_bound": "9529"
+ "num_range": 3840,
+ "upper_bound": "9644"
},
{
- "distinct_range": 48.614882106767375,
+ "distinct_range": 43.6452699255026,
"num_eq": 80,
"num_range": 3840,
- "upper_bound": "9579"
+ "upper_bound": "9689"
},
{
- "distinct_range": 50.599163009084414,
+ "distinct_range": 50.58883559546893,
"num_eq": 80,
- "num_range": 3840,
- "upper_bound": "9631"
+ "num_range": 3920,
+ "upper_bound": "9741"
},
{
- "distinct_range": 40.677758497499234,
- "num_eq": 160,
+ "distinct_range": 57.53240126543525,
+ "num_eq": 240,
"num_range": 3840,
- "upper_bound": "9673"
+ "upper_bound": "9800"
},
{
- "distinct_range": 57.544146167194036,
+ "distinct_range": 53.56464945402592,
"num_eq": 80,
- "num_range": 3920,
- "upper_bound": "9732"
- },
- {
- "distinct_range": 46.63060120445034,
- "num_eq": 320,
- "num_range": 3680,
- "upper_bound": "9780"
+ "num_range": 3840,
+ "upper_bound": "9855"
},
{
- "distinct_range": 50.599163009084414,
- "num_eq": 160,
+ "distinct_range": 39.677518114093274,
+ "num_eq": 80,
"num_range": 3920,
- "upper_bound": "9832"
+ "upper_bound": "9896"
},
{
- "distinct_range": 52.583443911401446,
- "num_eq": 160,
- "num_range": 3760,
- "upper_bound": "9886"
+ "distinct_range": 47.61302173691193,
+ "num_eq": 80,
+ "num_range": 3920,
+ "upper_bound": "9945"
},
{
- "distinct_range": 53.575584362559965,
+ "distinct_range": 53.56464945402592,
"num_eq": 160,
"num_range": 3840,
- "upper_bound": "9941"
- },
- {
- "distinct_range": 54.567724813718485,
- "num_eq": 80,
- "num_range": 3920,
- "upper_bound": "9997"
+ "upper_bound": "10000"
}
],
"histo_col_type": "INT8",
@@ -17134,11 +17172,12 @@ ALTER TABLE "partsupp" INJECT STATISTICS '[
"row_count": 800000
},
{
+ "avg_size": 7,
"columns": [
"ps_partkey",
"ps_suppkey"
],
- "created_at": "2021-09-08 20:48:28.135856",
+ "created_at": "2022-02-25 00:55:37.590966",
"distinct_count": 798302,
"histo_col_type": "",
"name": "__auto__",
@@ -17146,17 +17185,18 @@ ALTER TABLE "partsupp" INJECT STATISTICS '[
"row_count": 800000
},
{
+ "avg_size": 4,
"columns": [
"ps_availqty"
],
- "created_at": "2021-09-08 20:48:28.135856",
+ "created_at": "2022-02-25 00:55:37.590966",
"distinct_count": 9920,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 80,
"num_range": 0,
- "upper_bound": "1"
+ "upper_bound": "2"
},
{
"distinct_range": 9918,
@@ -17172,23 +17212,24 @@ ALTER TABLE "partsupp" INJECT STATISTICS '[
"row_count": 800000
},
{
+ "avg_size": 9,
"columns": [
"ps_supplycost"
],
- "created_at": "2021-09-08 20:48:28.135856",
- "distinct_count": 1000,
+ "created_at": "2022-02-25 00:55:37.590966",
+ "distinct_count": 100379,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1040,
+ "num_eq": 80,
"num_range": 0,
- "upper_bound": "0.009999999776482582"
+ "upper_bound": "1.14"
},
{
- "distinct_range": 998,
- "num_eq": 880,
- "num_range": 798080,
- "upper_bound": "10.0"
+ "distinct_range": 100377,
+ "num_eq": 80,
+ "num_range": 799840,
+ "upper_bound": "999.93"
}
],
"histo_col_type": "FLOAT8",
@@ -17198,23 +17239,24 @@ ALTER TABLE "partsupp" INJECT STATISTICS '[
"row_count": 800000
},
{
+ "avg_size": 127,
"columns": [
"ps_comment"
],
- "created_at": "2021-09-08 20:48:28.135856",
- "distinct_count": 800000,
+ "created_at": "2022-02-25 00:55:37.590966",
+ "distinct_count": 799641,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 1,
+ "num_eq": 80,
"num_range": 0,
- "upper_bound": " Able campaign wish onto charge its check order. Management t"
+ "upper_bound": " Tiresias. furiously unusual deposits nag blithely. blithely regular plate"
},
{
- "distinct_range": 799998,
- "num_eq": 1,
- "num_range": 799998,
- "upper_bound": "zine chance. Month eat car off couple road around. Recently old reflect "
+ "distinct_range": 799639,
+ "num_eq": 80,
+ "num_range": 799840,
+ "upper_bound": "zzle. frays hinder slyly among the slyly regular packages. slyly ironic depths according to the blithely even instructions wake slyly blithely special requests? carefully ironic deposi"
}
],
"histo_col_type": "VARCHAR(199)",
@@ -17229,10 +17271,11 @@ ALTER TABLE "partsupp" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "region" INJECT STATISTICS '[
{
+ "avg_size": 1,
"columns": [
"r_regionkey"
],
- "created_at": "2021-09-08 20:48:09.523291",
+ "created_at": "2022-02-25 00:55:34.449175",
"distinct_count": 5,
"histo_buckets": [
{
@@ -17273,10 +17316,11 @@ ALTER TABLE "region" INJECT STATISTICS '[
"row_count": 5
},
{
+ "avg_size": 9,
"columns": [
"r_name"
],
- "created_at": "2021-09-08 20:48:09.523291",
+ "created_at": "2022-02-25 00:55:34.449175",
"distinct_count": 5,
"histo_buckets": [
{
@@ -17299,23 +17343,24 @@ ALTER TABLE "region" INJECT STATISTICS '[
"row_count": 5
},
{
+ "avg_size": 68,
"columns": [
"r_comment"
],
- "created_at": "2021-09-08 20:48:09.523291",
+ "created_at": "2022-02-25 00:55:34.449175",
"distinct_count": 5,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": " over total plant room dark do. Work of"
+ "upper_bound": "ges. thinly even pinto beans ca"
},
{
"distinct_range": 3,
"num_eq": 1,
"num_range": 3,
- "upper_bound": "ticipant president somebody style. Field person effect teach smal"
+ "upper_bound": "uickly special accounts cajole carefully blithely close requests. carefully final asymptotes haggle furiousl"
}
],
"histo_col_type": "VARCHAR(152)",
@@ -17330,10 +17375,11 @@ ALTER TABLE "region" INJECT STATISTICS '[
exec-ddl
ALTER TABLE "supplier" INJECT STATISTICS '[
{
+ "avg_size": 3,
"columns": [
"s_suppkey"
],
- "created_at": "2021-09-08 20:48:09.344569",
+ "created_at": "2022-02-25 00:55:35.803892",
"distinct_count": 9920,
"histo_buckets": [
{
@@ -18556,159 +18602,160 @@ ALTER TABLE "supplier" INJECT STATISTICS '[
"row_count": 10000
},
{
+ "avg_size": 2,
"columns": [
"s_nationkey"
],
- "created_at": "2021-09-08 20:48:09.344569",
+ "created_at": "2022-02-25 00:55:35.803892",
"distinct_count": 25,
"histo_buckets": [
{
"distinct_range": 0,
- "num_eq": 403,
+ "num_eq": 420,
"num_range": 0,
"upper_bound": "0"
},
{
"distinct_range": 0,
- "num_eq": 384,
+ "num_eq": 413,
"num_range": 0,
"upper_bound": "1"
},
{
"distinct_range": 0,
- "num_eq": 391,
+ "num_eq": 397,
"num_range": 0,
"upper_bound": "2"
},
{
"distinct_range": 0,
- "num_eq": 396,
+ "num_eq": 412,
"num_range": 0,
"upper_bound": "3"
},
{
"distinct_range": 0,
- "num_eq": 406,
+ "num_eq": 415,
"num_range": 0,
"upper_bound": "4"
},
{
"distinct_range": 0,
- "num_eq": 396,
+ "num_eq": 380,
"num_range": 0,
"upper_bound": "5"
},
{
"distinct_range": 0,
- "num_eq": 393,
+ "num_eq": 402,
"num_range": 0,
"upper_bound": "6"
},
{
"distinct_range": 0,
- "num_eq": 399,
+ "num_eq": 396,
"num_range": 0,
"upper_bound": "7"
},
{
"distinct_range": 0,
- "num_eq": 406,
+ "num_eq": 415,
"num_range": 0,
"upper_bound": "8"
},
{
"distinct_range": 0,
- "num_eq": 393,
+ "num_eq": 405,
"num_range": 0,
"upper_bound": "9"
},
{
"distinct_range": 0,
- "num_eq": 383,
+ "num_eq": 393,
"num_range": 0,
"upper_bound": "10"
},
{
"distinct_range": 0,
- "num_eq": 398,
+ "num_eq": 438,
"num_range": 0,
"upper_bound": "11"
},
{
"distinct_range": 0,
- "num_eq": 394,
+ "num_eq": 377,
"num_range": 0,
"upper_bound": "12"
},
{
"distinct_range": 0,
- "num_eq": 414,
+ "num_eq": 362,
"num_range": 0,
"upper_bound": "13"
},
{
"distinct_range": 0,
- "num_eq": 422,
+ "num_eq": 376,
"num_range": 0,
"upper_bound": "14"
},
{
"distinct_range": 0,
- "num_eq": 387,
+ "num_eq": 373,
"num_range": 0,
"upper_bound": "15"
},
{
"distinct_range": 0,
- "num_eq": 435,
+ "num_eq": 406,
"num_range": 0,
"upper_bound": "16"
},
{
"distinct_range": 0,
- "num_eq": 403,
+ "num_eq": 421,
"num_range": 0,
"upper_bound": "17"
},
{
"distinct_range": 0,
- "num_eq": 441,
+ "num_eq": 407,
"num_range": 0,
"upper_bound": "18"
},
{
"distinct_range": 0,
- "num_eq": 357,
+ "num_eq": 398,
"num_range": 0,
"upper_bound": "19"
},
{
"distinct_range": 0,
- "num_eq": 394,
+ "num_eq": 411,
"num_range": 0,
"upper_bound": "20"
},
{
"distinct_range": 0,
- "num_eq": 390,
+ "num_eq": 399,
"num_range": 0,
"upper_bound": "21"
},
{
"distinct_range": 0,
- "num_eq": 421,
+ "num_eq": 401,
"num_range": 0,
"upper_bound": "22"
},
{
"distinct_range": 0,
- "num_eq": 411,
+ "num_eq": 390,
"num_range": 0,
"upper_bound": "23"
},
{
"distinct_range": 0,
- "num_eq": 383,
+ "num_eq": 393,
"num_range": 0,
"upper_bound": "24"
}
@@ -18720,10 +18767,11 @@ ALTER TABLE "supplier" INJECT STATISTICS '[
"row_count": 10000
},
{
+ "avg_size": 20,
"columns": [
"s_name"
],
- "created_at": "2021-09-08 20:48:09.344569",
+ "created_at": "2022-02-25 00:55:35.803892",
"distinct_count": 9990,
"histo_buckets": [
{
@@ -18746,23 +18794,24 @@ ALTER TABLE "supplier" INJECT STATISTICS '[
"row_count": 10000
},
{
+ "avg_size": 27,
"columns": [
"s_address"
],
- "created_at": "2021-09-08 20:48:09.344569",
+ "created_at": "2022-02-25 00:55:35.803892",
"distinct_count": 10000,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": " 7thzdOKLdVP yR7ZbOMnubI6,PrkxBX ZYw1"
+ "upper_bound": " 9aW1wwnBJJPnCx,nox0MA48Y0zpI1IeVfYZ"
},
{
"distinct_range": 9998,
"num_eq": 1,
"num_range": 9998,
- "upper_bound": "zzvmS9DyfR"
+ "upper_bound": "zzfDhdtZcvmVzA8rNFU,Yctj1zBN"
}
],
"histo_col_type": "VARCHAR(40)",
@@ -18772,23 +18821,24 @@ ALTER TABLE "supplier" INJECT STATISTICS '[
"row_count": 10000
},
{
+ "avg_size": 17,
"columns": [
"s_phone"
],
- "created_at": "2021-09-08 20:48:09.344569",
- "distinct_count": 9840,
+ "created_at": "2022-02-25 00:55:35.803892",
+ "distinct_count": 10000,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": "10-101-276-5805"
+ "upper_bound": "10-102-116-6785"
},
{
- "distinct_range": 9838,
+ "distinct_range": 9998,
"num_eq": 1,
"num_range": 9998,
- "upper_bound": "34-997-188-3418"
+ "upper_bound": "34-998-900-4911"
}
],
"histo_col_type": "CHAR(15)",
@@ -18798,23 +18848,24 @@ ALTER TABLE "supplier" INJECT STATISTICS '[
"row_count": 10000
},
{
+ "avg_size": 9,
"columns": [
"s_acctbal"
],
- "created_at": "2021-09-08 20:48:09.344569",
- "distinct_count": 10000,
+ "created_at": "2022-02-25 00:55:35.803892",
+ "distinct_count": 9967,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": "-999.72998046875"
+ "upper_bound": "-998.22"
},
{
- "distinct_range": 9998,
+ "distinct_range": 9965,
"num_eq": 1,
"num_range": 9998,
- "upper_bound": "9999.509765625"
+ "upper_bound": "9999.72"
}
],
"histo_col_type": "FLOAT8",
@@ -18824,23 +18875,24 @@ ALTER TABLE "supplier" INJECT STATISTICS '[
"row_count": 10000
},
{
+ "avg_size": 65,
"columns": [
"s_comment"
],
- "created_at": "2021-09-08 20:48:09.344569",
- "distinct_count": 9903,
+ "created_at": "2022-02-25 00:55:35.803892",
+ "distinct_count": 9934,
"histo_buckets": [
{
"distinct_range": 0,
"num_eq": 1,
"num_range": 0,
- "upper_bound": " A ability south main close despite clearly. Who hold sense everyone. Cou"
+ "upper_bound": " about the blithely express foxes. bli"
},
{
- "distinct_range": 9901,
+ "distinct_range": 9932,
"num_eq": 1,
"num_range": 9998,
- "upper_bound": "zine know whatever discuss. Realize brother co"
+ "upper_bound": "zzle furiously. bold accounts haggle furiously ironic excuses. fur"
}
],
"histo_col_type": "VARCHAR(101)",
|
6f92fa825d49296189c20364eb0bbfcbe8abc801
|
2016-06-23 20:52:32
|
Kenji Kaneda
|
sql: Fix the comment on TestTxnDeadline
| false
|
Fix the comment on TestTxnDeadline
|
sql
|
diff --git a/client/txn.go b/client/txn.go
index 6faf4ccd0e98..d9e11f313229 100644
--- a/client/txn.go
+++ b/client/txn.go
@@ -676,9 +676,9 @@ func (txn *Txn) send(ba roachpb.BatchRequest) (*roachpb.BatchResponse, *roachpb.
br, pErr := txn.db.send(ba)
if elideEndTxn && pErr == nil {
- // Check that read only transactions do not violate their deadline. This can happen
- // when the transaction timestamp is updated by ReadWithinUncertaintyIntervalError
- // (see TestTxnDeadline).
+ // Check that read only transactions do not violate their deadline. This can NOT
+ // happen since the txn deadline is normally updated when it is about to expire
+ // or expired. We will just keep the code for safety (see TestReacquireLeaseOnRestart).
if endTxnRequest.Deadline != nil {
if endTxnRequest.Deadline.Less(txn.Proto.Timestamp) {
return nil, roachpb.NewErrorWithTxn(roachpb.NewTransactionAbortedError(), &txn.Proto)
diff --git a/sql/txn_restart_test.go b/sql/txn_restart_test.go
index d49d4a095c5c..fa343546a89a 100644
--- a/sql/txn_restart_test.go
+++ b/sql/txn_restart_test.go
@@ -859,14 +859,12 @@ func TestNonRetryableErrorFromCommit(t *testing.T) {
}
}
-// Verifies that a read-only transaction that triggers a deadline-exceeded error finishes
-// without causing an Executor error. In particular, this test case creates a read-only txn
-// that elides EndTransactionRequest and makes sure a deadline-exceeded error causes a
-// retryable error.
+// Verifies that an expired lease is released and a new lease is acquired on transaction
+// restart.
//
// This test triggers the above scenario by making ReadWithinUncertaintyIntervalError advance
// the clock, so that the transaction timestamp exceeds the deadline of the EndTransactionRequest.
-func TestTxnDeadline(t *testing.T) {
+func TestReacquireLeaseOnRestart(t *testing.T) {
defer leaktest.AfterTest(t)()
var cmdFilters CommandFilters
@@ -911,7 +909,7 @@ func TestTxnDeadline(t *testing.T) {
if req, ok := args.Req.(*roachpb.ScanRequest); ok {
if bytes.Contains(req.Key, testKey) {
restartDone = true
- // Return ReadWithinUncertaintyIntervalError to update the transaction timestamp on rery.
+ // Return ReadWithinUncertaintyIntervalError to update the transaction timestamp on retry.
txn := args.Hdr.Txn
txn.ResetObservedTimestamps()
now := server.Clock().Now()
@@ -936,14 +934,17 @@ INSERT INTO t.test (k, v) VALUES ('test_key', 'test_val');
t.Fatal(err)
}
// Acquire the lease and enable the auto-retry. The first read attempt will trigger ReadWithinUncertaintyIntervalError
- // and advance the transaction timestmap. The second read attempt will succeed, but the (elided) EndTransactionRequest
- // hits a deadline-exceeded error.
+ // and advance the transaction timestmap. The transaction timestamp will exceed the lease expiration
+ // time, and the second read attempt will re-acquire the lease.
if _, err := sqlDB.Exec(`
SELECT * from t.test WHERE k = 'test_key';
`); err != nil {
t.Fatal(err)
}
+ if !clockUpdate {
+ t.Errorf("expected clock update, but it didn't happen")
+ }
if !restartDone {
t.Errorf("expected restart, but it didn't happen")
}
|
865f92d73bc0769550b30d77587eaa62b020cb24
|
2018-07-25 20:05:54
|
Radu Berinde
|
opt: revive the distsql_interleaved_join planner tests
| false
|
revive the distsql_interleaved_join planner tests
|
opt
|
diff --git a/pkg/sql/opt/exec/execbuilder/testdata/distsql_interleaved_join b/pkg/sql/opt/exec/execbuilder/testdata/distsql_interleaved_join
index 812702c40cd6..c74f3908d838 100644
--- a/pkg/sql/opt/exec/execbuilder/testdata/distsql_interleaved_join
+++ b/pkg/sql/opt/exec/execbuilder/testdata/distsql_interleaved_join
@@ -178,301 +178,278 @@ NULL /2/#/56/1/42/2/#/58/1/2 1 {1} 1
/36/#/55/1/76 /38/#/56/1/78/38/#/58/1/38 10 {4} 4
/38/#/56/1/78/38/#/58/1/38 NULL 20 {5} 5
-# TODO(radu): enable these tests when we plan merge joins.
-# statement ok
-# SET CLUSTER SETTING sql.distsql.interleaved_joins.enabled = true;
-#
-# #####################
-# # Interleaved joins #
-# #####################
-#
-# # Select over two ranges for parent/child with split at children key.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child1 USING(pid1) WHERE pid1 >= 3 AND pid1 <= 5]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzMkkFr6zAQhO_vVzzm9B7dEstpL4aCryklKbkWH4S1SQSOZFZyaSn570VWoU5oQ9tTb5ZmZscf2hc4b3ip9xxQPUCBUIIwR0PoxbccgpckZePCPKEqCNb1Q8zX0caOUWFwXgwLGxAMR227pDeHhtB6YVTv1qW_9P2sPDES_BDfxjaEEPWWUZUHmlSrSfUHgxcusnSsH3nN2rDceutYZsVRE-54E5Hw7F7Lc91rYRcT-dpud1Ol3dnOJCHPAaHjTfxXq4v_N5K84ycIqyFWf2tFdUn1FdXX-IxGHdGUP6JRv5SmOE-z5tB7F_hLr16ktWGz5bxjwQ_S8r34dqzJx9WYGy8Mh5jVeT4sXJbSD07D6my4OAqr03D5rXBz-PMaAAD__y7yGHk=
-#
-# # Swap parent1 and child1 tables.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child1 JOIN parent1 USING(pid1) WHERE pid1 >= 3 AND pid1 <= 5]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzMklFL-zAUxd__n-LPeVK8sqbDl4LQ14lsslfpQ2jutkCXlJtUFNl3lzSC3dChPvnW5JxzT3_kvsJ5w0u954DqEQqEEoQ5GkIvvuUQvCQpGxfmGVVBsK4fYr6ONnaMCoPzYljYgGA4atslvTk0hNYLo_qwLv2172fliZHgh_g-tiGEqLeMqjzQpFpNqj8ZvHCRpWP9xGvWhuXOW8cyK46acM-biIRn91pe6nZnO5PA13a7mwq9FnYxKXkOCB1v4kWtri5vJZnHTxBWQ6z-14rqkuo51Tf4ikYd0ZS_olF_lKY4T7Pm0HsX-FuvXqS1YbPlvGPBD9Lyg_h2rMnH1ZgbLwyHmNV5PixcltIPTsPqbLg4CqvTcPmjcHP49xYAAP__IiwYdw==
-#
-# # Select over two ranges for parent/child with split at grandchild key.
-# # Also, rows with pid1 <= 30 should have 4 rows whereas pid1 > 30 should
-# # have 3 rows.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child1 ON parent1.pid1 = child1.pid1 WHERE parent1.pid1 >= 29 AND parent1.pid1 <= 31 ORDER BY parent1.pid1]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzUUcFq6zAQvL-veOypJSqxnOZiKOiaUpKSa_FBWBtH4EhmtS4twf9eJB0Sl6S0vfVm7czs7IyP4LzBtT5ggOoFJAhYQi2gJ99gCJ7iOJNW5g2qQoB1_cBxXAtoPCFUR2DLHUIFK8dIHepX3KI2SI_eOqR5XGuQte2SyxPuGKKHPWh6V70mdBw5W9vuz5FmbzsTgbwHBHS44xslZ7cPFLnpEwRsBq7-KylUKdRCqHuhllCPAvzAp2MD6xahkqO4EuiUw5NBQjM9W8kZ1OOF1Gt_5_t5OWFfcy8n7vJXdRZ_o84LgbYYeu8CfquqInaNpsX8b4IfqMFn8k2yyc9N0qWBwcAZlfmxcglKB56L5ZfixURcfBaXP3Kux38fAQAA__8x_hkU
-#
-# # Parent-child where pid1 <= 15 have one joined row and pid1 > 15 have no
-# # joined rows (since child2 only has 15 rows up to pid1 = 15).
-# # Note this spans all 5 nodes, which makes sense since we want to read all
-# # parent rows even if child rows are non-existent (so we can support OUTER
-# # joins).
-# # TODO(richardwu): we can remove nodes reading from just one table for INNER
-# # joins or LEFT/RIGHT joins.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child2 USING(pid1) WHERE pid1 >= 12 ORDER BY pid1]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzMlD1rwzAQhvf-ivJOLbkSyx8ZDAWtKSUpWYsHY10Sg2MZSS4twf-92B4Sl6YfzuLN0t3j9x6BdESpFa_SA1vErxAg-CAEIIQgREgIldEZW6tN29IDS_WO2CPkZVW7djshZNow4iNc7gpGjGXp2BScvvGGU8XmSeclm7kHgmKX5kWX-MxbhzYjP6TmQ1ap4dK1Y2zy3f68ku3zQrWz9f8BoeCtu5Nidv9o2t7uE4R17eJbKUj6JEOSEckFkoaga3ca1rp0x4hFQxeETh7aKDashmNLMUPSfGO90g-6mkeD7kvp_iBdjDpOMd3j9EcJ-dMVCkYJBdMVCkcJhdMV-uVJ2rCtdGn5T7fTa683qx33z4HVtcn4xeisi-mX647rNhRb11dFv1iWXakb8BwWP8KLAex9hf1rkoNr4PAaOPoXnDQ3nwEAAP__9wcgdA==
-#
-# # These rows are all on the same node 1 (gateway).
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child2 USING(pid1) WHERE pid1 IN (1, 11, 21, 31) ORDER BY pid1]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJyMUE1LxDAUvPsrZE6KD9ws6iEg5LoirvQqPYTmbTfQTcrLqyhL_7u0OagHwVvmIzOZnJFy4Bd_4gL7BoOWMEruuJQsC1UNu_ABuyHENE660C2hy8KwZ2jUgWGxS8oysH_nhn1gecoxsdxuQAisPg5rwzMfFEtHPHn5dKMXTmpAaGJ__Kl0xziELQg1B4SBD3rlzM31oyze9QjCflJ76Qy5Lbk7cvfkHtDOhDzp92OL-p5hzUz_H9RwGXMq_GvAX8mbuSVw6Ll-WsmTdPwquVtrKtyv91YicNGqmgp2qUpzO198BQAA___Vk4P-
-#
-# # Parent-grandchild.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL)
-# SELECT * FROM parent1 JOIN grandchild2 USING(pid1) WHERE
-# pid1 >= 11 AND pid1 <= 13
-# OR pid1 >= 19 AND pid1 <= 21
-# OR pid1 >= 31 AND pid1 <= 33
-# ]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzslE9r3DAQxe_9FGJOu3RKLDlpqWBBhVJwKd5iemt9ENbEETiSkeTSEvzdi-0u8Yb0Xwohh71ZevPjDX6juQHnDZX6miLIz8ABQQDCBdQIffANxejDJC2FhfkGMkOwrh_SdF0jND4QyBtINnUEEgqXKHSkv1JF2lB4762jcJYBgqGkbTc7faDLBJOHvdbhu-p1IJcm-0lg72yXKEi22SjOvgxZljc7xnMpZVF-2rJ9tVJox_jrg_KmfMvWjOA_le1CraD8IAFCZdurdTtt0M40V7Yz4qA-ek_LfwOEji7TRvHn212YGpk_AWE_JMkURyVQnaO6QPUS1SuoRwQ_pNt8YtItgeQj_iLD2-gG54OhQOYoq3q8J-XSv_D9WX6n8H5rcWTNHzQ-_DQ-T2h8xIMyFKcMn1CGf1jjFcXeu0h_9cKzaUWQaWnZJ9EPoaGPwTezzXLcz9x8YSimReXLoXCzNDe4hvlv4fMjOLsLi_9xzv8JrsdnPwIAAP__gf0kvQ==
-#
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL)
-# SELECT * FROM grandchild2 JOIN parent1 USING(pid1) WHERE
-# pid1 >= 11 AND pid1 <= 13
-# OR pid1 >= 19 AND pid1 <= 21
-# OR pid1 >= 31 AND pid1 <= 33
-# ]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzslE-L2zAQxe_9FGJOCZ2ylr1LqSCgQim4FKeY3lofhDXrFXglI8mlZfF3L7Yb4oT0Xwolh9wsvfnxBr_RPIF1mgr1SAHEJ-CAkALCHVQInXc1heD8KM2Fuf4KIkEwtuvjeF0h1M4TiCeIJrYEAnIbybekvlBJSpN_54wlf5MAgqaoTDs5vaf7CKOHeVT-m2y8srp-MK0e7UeRvTVtJC_YaiU5-9wnSVZvGM-EEHnxcc225UKhDeOvdsrr4g1bMin_oaxnagFlOwkQStM8LFvqlCcb-U757_3M_w0QWrqPK8mfrzd-bGT6BIRtHwWTHGWKMkN5i_IO5UuoBgTXx30-IaqGQPABf5LhPrreOq_Jkz7IqhpOpFy4F667yY4KT1unB9b8rPHh1_G5oPFJz8owvWZ4QRn-Zo2XFDpnA_3RC0_GFUG6oXmfBNf7mj54V08283E7cdOFphBnlc-H3E7S1OAS5r-Ebw_g5BhO_8U5-yu4Gp59DwAA__8zXSS0
-#
-# query TTT
-# EXPLAIN SELECT * FROM grandchild2 JOIN parent1 USING(pid1) WHERE
-# pid1 >= 11 AND pid1 <= 13
-# OR pid1 >= 19 AND pid1 <= 21
-# OR pid1 >= 31 AND pid1 <= 33
-# ----
-# render · ·
-# └── join · ·
-# │ type inner
-# │ equality (pid1) = (pid1)
-# │ mergeJoinOrder +"(pid1=pid1)"
-# ├── scan · ·
-# │ table grandchild2@primary
-# │ spans /11/#/56/1-/13/#/56/2 /19/#/56/1-/21/#/56/2 /31/#/56/1-/33/#/56/2
-# └── scan · ·
-# · table parent1@primary
-# · spans /11-/13/# /19-/21/# /31-/33/#
-#
-# # Join on multiple interleaved columns with an overarching ancestor (parent1).
-# # Note there are 5 nodes because the filter cid2 >= 12 AND cid2 <= 14
-# # creates a giant parent span which requires reading from all rows.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL)
-# SELECT * FROM child2 JOIN grandchild2 ON
-# child2.pid1=grandchild2.pid1
-# AND child2.cid2=grandchild2.cid2
-# AND child2.cid3=grandchild2.cid3
-# WHERE
-# child2.pid1 >= 5 AND child2.pid1 <= 7
-# OR child2.cid2 >= 12 AND child2.cid2 <= 14
-# OR gcid2 >= 49 AND gcid2 <= 51
-# ]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzslUFr2zAUx-_7FOKdHPJGLVluV0FAgzHIGMkIu20-GOs1NbhWkOSxUfLdh-3FrUs21gRy8tH668df8k_wHqG2hlb5A3lQ34ADggCEBBAkIKSQIeycLch769otPbA0P0HFCGW9a0K7nCEU1hGoRwhlqAgULOtArqL8B20oN-Q-2bImdxUDgqGQl1XX-JnuArQd5UPufunivqxMe4JNub1_HmxdXptxyj6WVSCnWBRFmrPvTRwntGCpUmq5-jpj71cf2BAUC3bzJ5ix9YZFkRYDwsWYEQPD5QE6UHKg5O2YkgOV8gMFCP29AaGiuxBpPkct5qiT-Wzh2muMlgBh3QTFNEctUCeoJeoU9TXqG9TvUN9CtkewTXj68T7kWwLF9_gXOU9Omto6Q47MSEK2P6JvZd_a3VX6YuPxajGq5ie9Cz69i0u8C3GSHDHJuYSc5CQ5ySTnEnLkSXLkJOfS4-6InA35na09_dc0i9txSGZL_ez0tnEFfXG26Gr6z3XHdQuGfOhT3n8s6y7qDvgc5v-Er0dw_BIW5zQn58DyHDh9FZzt3_wOAAD__-mfE2o=
-#
-# query TTT
-# EXPLAIN
-# SELECT * FROM child2 JOIN grandchild2 ON
-# child2.pid1=grandchild2.pid1
-# AND child2.cid2=grandchild2.cid2
-# AND child2.cid3=grandchild2.cid3
-# WHERE
-# child2.pid1 >= 5 AND child2.pid1 <= 7
-# OR child2.cid2 >= 12 AND child2.cid2 <= 14
-# OR gcid2 >= 49 AND gcid2 <= 51
-# ----
-# join · ·
-# │ type inner
-# │ equality (pid1, cid2, cid3) = (pid1, cid2, cid3)
-# │ mergeJoinOrder +"(pid1=pid1)",+"(cid2=cid2)",+"(cid3=cid3)"
-# ├── scan · ·
-# │ table child2@primary
-# │ spans ALL
-# └── scan · ·
-# · table grandchild2@primary
-# · spans ALL
-#
-# # Aggregation over parent and child keys.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL)
-# SELECT sum(parent1.pid1), sum(child1.cid1) FROM parent1 JOIN child1 USING(pid1) WHERE
-# pid1 >= 10 AND pid1 <= 39
-# ]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzUlVGrmzAUx9_3KS7n6V4WuEZtbysM3GPHto6OPQ0fgjm1gk0kiWOj-N1HlLVa2jisL74lOefv75z_CeYEQnL8yo6oIfoJFAj4QCAAAiEQWEBCoFQyRa2lsimtYMN_Q-QRyEVZGXucEEilQohOYHJTIESwEQZVgewX7pBxVJ9kLlC9WgRHw_KiIX7GvQHLyI9M_YlLplAYm2MDT9vKRE-x3e7y7NBNTA95wc-Bf4kkttW3JCBQ4N48x_T9ywdls5olEDgnB5DUBGRlLl1owzKEiNbk_zv9mGUKM2akel32u_v-48tzTC2zWfkvd4H-XeCFUwmpOCrkPUhSu0ui3tiagl5NdNS4_RmOe6DTjrdv04zbH2VtMENrBzrtWLuaxtpglLXhDK0d6LRj7Xoaa8NR1noztHag0461i-n__zeAO9SlFBqv3oHbX_bs-4A8w_Yx0bJSKX5TMm0w7Xbb6JoDjtq0UdpuNqIN2QK7YuoU-z0xvRb7bvIAOnCqQ7c4fKTuhVO8dJOXj5DfnOKVm7x6hLx2z8obuCbuS3bNTup3fwMAAP__hy1jzg==
-#
-# ###############
-# # Outer joins #
-# ###############
-#
-# # The schema/values for each table are as follows:
-# # Table: pkey: pkey values (same): values:
-# # outer_p1 (pid1) {1, 2, 3, ... 20} 100 + pkey
-# # outer_c1 (pid1, cid1, cid2) {2, 4, 6, ... 28} 200 + pkey
-# # outer_gc1 (pid1, cid1, cid2, gcid1) {4, 8, 12, ... 36} 300 + pkey
-#
-# # Split between 4 nodes based on pkey value (p):
-# # node 1: p - 1 mod 20 ∈ [1...5)
-# # node 2: p - 1 mod 20 ∈ [5...10)
-# # node 3: p - 1 mod 20 ∈ [10...15)
-# # node 4: p - 1 mod 20 ∈ [15...20)
-#
-# statement ok
-# CREATE TABLE outer_p1 (
-# pid1 INT PRIMARY KEY,
-# pa1 INT
-# )
-#
-# statement ok
-# CREATE TABLE outer_c1 (
-# pid1 INT,
-# cid1 INT,
-# cid2 INT,
-# ca1 INT,
-# PRIMARY KEY (pid1, cid1, cid2)
-# ) INTERLEAVE IN PARENT outer_p1 (pid1)
-#
-# statement ok
-# CREATE TABLE outer_gc1 (
-# pid1 INT,
-# cid1 INT,
-# cid2 INT,
-# gcid1 INT,
-# gca1 INT,
-# PRIMARY KEY (pid1, cid1, cid2, gcid1)
-# ) INTERLEAVE IN PARENT outer_c1 (pid1, cid1, cid2)
-#
-# statement ok
-# ALTER TABLE outer_p1 SPLIT AT
-# SELECT i FROM generate_series(0, 40, 5) AS g(i)
-#
-# statement ok
-# ALTER TABLE outer_p1 EXPERIMENTAL_RELOCATE
-# SELECT ARRAY[(((i-3)/5)%4)::INT + 1], i FROM generate_series(3, 40, 5) AS g(i)
-#
-# query TTITI colnames
-# SHOW EXPERIMENTAL_RANGES FROM TABLE outer_p1
-# ----
-# Start Key End Key Range ID Replicas Lease Holder
-# NULL /0 20 {5} 5
-# /0 /5 31 {1} 1
-# /5 /10 32 {2} 2
-# /10 /15 33 {3} 3
-# /15 /20 34 {4} 4
-# /20 /25 35 {1} 1
-# /25 /30 36 {2} 2
-# /30 /35 37 {3} 3
-# /35 /40 38 {4} 4
-# /40 NULL 39 {5} 5
-#
-# ### Begin OUTER queries
-#
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_p1 FULL OUTER JOIN outer_c1 USING (pid1)]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzclE2L2zAQhu_9FWJOu3TK-nMPhoIuDTgYp5jkVEwx1iQ1OJKR5NIQ_N-L7EOaNP1Y5-abpdEzr585zBmkEpRXRzKQfAEfEAJACAEhAoQYSoROq5qMUdo9mYBU_IDEQ2hk11t3XSLUShMkZ7CNbQkSSKUl3VL1nQqqBOm1aiTpFxchyFZNOyZmtLfgMppjpU9c9Zb01849KprDt99LtStNrQBhe-ooYatdlrHNbvupYOtNmgNCS3v7xP33zx-16zJ-upYkBemEpat8l2VP3EcePiPjATIeIeMxMv4K5YCgensxM7Y6ECT-gH-wv0j3UmlBmsSVZTncmU-uPqjuJb55eD86uIr2Zw0-WMjgg1n24ULsw1n20ULso1n23kLs_7FwCzKdkob-a6N4biWRONC0v4zqdU2ftarHmOm4GbnxQpCxU9WfDqkcS-MP_gr7f4Vfr2DvFg4eSQ4fgaNH4PhNcDm8-xkAAP__5oReVw==
-#
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_gc1 FULL OUTER JOIN outer_c1 USING (pid1, cid1, cid2)]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzklU2LnEAQhu_5FVKnHabC-rlJhEBfsuAiTpCdU5Agdq0R3G7pbkOWwf8eWiEzTiYf6xw9Vlc9_crTUB5ASE5Z-Uwa4i_gAYIPCAEghIAQQYHQKVmR1lLZkQlI-A-IXYRGdL2xxwVCJRVBfADTmJYghkQYUi2V3ymnkpN6kI0gdWsjOJmyacfElJ4M2IzmuVQvTPaG1Ne6slN5U3_7vTe2prsA4fGlo9i536eps9s_fsqdh12SAUJLT-aGeVtk_hZZsN18VPa22ZGNIMFJxU5yn-3T9IZ5yO42-Kv0kb07KQNk7zfosBAdFqHDPkAxIMjeHCVoU9YEsTfgH0Qd_fRCKk6K-ExIMVxQmcm3sruNzgYvR_uzaG_RG_nreyN_kahgfaKCRaLC9YkKF4ly1yfqH_-RnHQnhab_2n6uXZ_Ea5p2rZa9quizktUYM5W7kRsPOGkzdb2pSMTYGj_wFPb-Ct_NYPcc9q9JDq6Bw2vg6FVwMbz5GQAA__8alY8h
-#
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_c1 LEFT OUTER JOIN outer_p1 USING (pid1) WHERE pid1 >= 0 AND pid1 < 40]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzUlE-Lo0AQxe_7KeSddtlaYqu7B2HBSwYMIQ6SOQ0yiF3JCMaW7naYEPzug3rIJJP5l5xys_v1q1e_gnKHWkle5Bs2CO8hQPBA8EEIkBEarQo2RuleHh_H8hmhSyjrprX9dUYolGaEO9jSVowQcW1ZV5w_ccq5ZD1TZc164oIg2eZlNaTNeWXRZ5SbXG8j1VrWD0XfQ1quH99KTS-NpUBYbhsOnfn0Zukkd8tp6sySeAFCxSv7MxK_f_3XfZXhE4SktaETCYo8inyKAor-IesIqrV7DmPzNSMUHb3Dukdsa6Ula5YHTFl3YhoL9Uc1k-Do4elo7yBanDVmcZVj9s5i9a6S1T-L1b9K1k9-FSmbRtWGv7Qdbr9eLNc87qJRrS74VqtiiBmPyeAbLiQbO6piPMT1IA0NvjaLD81_D8zusdm7JNm_xBx8y5x1P14CAAD___ca6HA=
-#
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_p1 RIGHT OUTER JOIN outer_gc1 USING (pid1) WHERE pid1 >= 1 AND pid1 <= 20]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzUlE9r20AQxe_9FOKdWjrF-ucWBIW9lFamWEW4pyCC0I4VgawVu6sQY_Tdg6SDY8f5Z5980-7bN29-A6MdGiV5mW_YILqBB4IPQgBCiIzQalWwMUoP8vQ4lg-IXELVtJ0drjNCoTQj2sFWtmZEiBvLuub8nlPOJeuFqhrWMxcEyTav6jHtL68thoxqk-utUJ1lfdsOPaRVefdcKotBm2qBsNq2HDlp_PvPykn-r36lziKJlyDUvLafhff1y0891Bk_QUg6GzkiIOGTCEnMSXwn8QNZT1Cd3cMYm5eMyOvpBeA9Z9coLVmzPADL-hMjWapvqp2FRw9PR_sH0d5Zs_aud9b-WcD-9QIHZwEH1wv8xu8jZdOqxvC7lsUdto1lydNqGtXpgv9pVYwx0zEZfeOFZGMn1ZsOcTNKY4NPzd6r5vmB2T02-5ckB5eYww-Zs_7TYwAAAP__Vjbt9A==
-#
-# ########################
-# # Non-interleaved joins #
-# ########################
-#
-# # Join on siblings uses merge joiner.
-# # TODO(richardwu): Update this once sibling joins are implemented.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child1 JOIN child2 USING(pid1)]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzElsFq20AQhu99ijCnlmyxdyXZsaCgawpNSuit-KBYU1vgaM1Kgobgdy-yCq5ldUabwfLNsvbbnZ35QP8bFDbDh_QFS4h_ggYFBhQEoCAEBREsFeycXWFZWtcsaYH77DfEUwV5saur5u-lgpV1CPEbVHm1RYjhR_q8xSdMM3STKSjIsErz7eGYnctfUvearDb5NtOw3CuwdfV3q-MOz683m7TcnLJJs36poKzSNUKs9-p9JUVESUZUkvlvScd9rMvQYdbd57Y5eNCqntt9Q7fGrzYv0E10p-Nb_FV9TPTtpy8uX2_an6Dgsa7im0SrxKgkUEmkkplK5p3bH28WDLhZXfRV3Vvwg_1sdxMddVb2nx2enK2HD1qP5J5HSbOR3NPXcU9f3j0zvNlmpPl7lDQfaf7mOvM3l59_MLzZwUjz9yjpbqT5B9eZf3D5-YfDmx2ONH-PkhYjzT-8zvzDcbNHTzlPWO5sUeKgZDFtLoTZGts2lbZ2K_zu7OpwTPv4eOAOX9QMy6p9a9qH-6J91RQ4HJ5J4IUE1qK6dUTT2qNlxg-eSeCFBNaiujstO6NNl57-Swd0vwMS1qc9m3bpUCI4DTOC0zAjOA1zgjM0I3gkEZyGGcFpmBGchjnBGZoRfCYRfC5RlIYZRWmYUZSGOUUZmlH0TqIoDTOK0jCjKA1zijI0o-hCoqgW5QSGZiRlaMZShuY05XAuK8jCgiwtyOKCMC_IAoMWJQZ9Fhm8bKVpzlaa5myladZWBuds9QlL5zPzSUu-NGerV17yxjlbz8IDaety_-FPAAAA__-7ahyi
-#
-# # Join on non-interleaved tables (with key) uses merge joiner.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN parent2 ON pid1=pid2]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJy8lVFr2zAQx9_3Kco9bVQjluykqWHg1w7WjrK34Qc1uiWG1DKSDCsl333YLmQxic5GRG9xrJ_u_r8D3zvUWuGjfEUL-W_gwEAAgxQYZMBgCSWDxugNWqtNd2QAHtRfyBMGVd20rvu7ZLDRBiF_B1e5PUIOv-TLHp9RKjSLBBgodLLa92UaU71K81Y00mDtOJQHBrp1H3cdr3h5u9lJuzuFi-58ycA6uUXI-YFd6Ol4jzYKDarxPbdd4eOptj53rq81zvYDzRa_66pGs1idXrvHP-5zwW-_fDPVdjf8BAZPrctvCs4KwYqUFdko8zFPOiHPjE4f9VfdLDgfnTxfOzupzafPl8eaL48_37trzldMdyxiORbxHa-v6Tid7jiN5TiN7_j-mo6z6Y6zWI5n9LT09SSCehIXe4o0d57EWlBnGnlG2-ja4qT1k3RRUG1xsGN1azb40-hNX2Z4fOq5fhEotG54-_HwUA-vuganw1kIvAqB1yEwJ0LzMZ38Tws_LLwwP6WTMZ2GDMsPE8Pyw8Sw_DAxLCIzEToLGdYyRLcfJnT7YUK3HyZ0E5mJ0KsQ3Xchuv0wodsPE7r9MKGbyEyEXofovg_R7YcJ3X6Y0O2HCd1EZurLP2dZipl0FkSvguh1EM2p4PM2Znn49C8AAP__9ASy7Q==
-#
-# # Join on non-interleaved column uses hash joiner.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child1 ON pa1 = ca1]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJy8llFr2zwUhu-_X1HOVQv6SCTZaWMY-HLdRTvK7oYv3PgsMaSWkRVYKfnvI_Egi-PpWDtEl2nySK_OeaDvBzSmwqfyDTvIvoMEAQoEaBCQgIAUCgGtNSvsOmMPP-mBx-onZHMBddPu3OHPhYCVsQjZB7jabREy-Fa-bvEFywrtbA4CKnRlvT1e09r6rbTveVtabJyEYi_A7Nzvs05HvL7fbMpucw7nCop9IaBz5Rohk3vxb5nS8UyrTb2tQiPps0jqr5FO5-waYyu0WJ2dVBxI6icj7_pcdpsvpm7QzuRg1lv84W5zdffJ1uuNu831HQh43rnsJpciVyLXIk9Eng5efHqNZrxmJOqT-d-0M5kO3z16d3J2t5y-XBlLuIBMi0jCycjCyasKp6YPWMVaekCm-0hLV5GXrq66dD19wDrW0gMyPURauo68dH3VpSfTB5zEWnpApmWkpSeRl55E6xMjQV6wa03T4aS2MD88Bas19qPpzM6u8Ks1q-M1_cfnI3f8J1lh5_pvVf_hsem_OgScDi848JIDS1ZumfppGTAyFQYvOPCSA0tW7sHILmg1pOd_0to_b-2F5fnM5kM64QjuhwnB_TAhuB-mBCdoQvCUI7gfJgT3w4TgfpgSnKAJwRccwe85ivphQlE_TCjqhylFCZpQ9IGjqB8mFPXDhKJ-mFKUoAlFlxxFJasnEDQhKUETlhI0pSmFU12BVxZ4bYFXF5h9gVcYJKsxyIvKEGSrn6Zs9dOUrX6atJXAKVtDytLlzkLaUihN2RrUl4JxytaL8uC1tdj_9ysAAP__U3kYdA==
-#
-# # Prefix join on interleaved columns uses merge joiner.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child2 JOIN grandchild2 USING(pid1, cid2)]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzEll1r2zAUhu_3K8q52qhGItn5Mgx828HaUXY3cuFGZ47BtYxsw0rJfx-2C1kcT8eainzp2I_06uiBvK9QKIn3yTNWEP0EDgwEMAiAQQgMVrBnUGp1wKpSuv2kB-7kb4iWDLKibOr25z2Dg9II0SvUWZ0jRPAjecrxEROJerEEBhLrJMu7bUqdPSf6JT4cs1wK2J8YqKZ-W-q8wtPLzTGpjpdszFncInsGVZ2kCBE_sf9LtRpPleqkkO8TTfwz2nkppSVqlMOlblksbtv9J385ctpvqFP8qrIC9YIPLiHHX_XHN_rTF52lx_MjMHho6uimOxGLAxaHLN6weMvi3WAm58MGEw7bFGOHGM1-rz6rcsFXgy_H9w4v9ubTHeD-zLRItfZsJp_XTO7VTDH9HoQ_OyxSbTzbIea1Q3i1I5h-D4E_OyxSbT3bEcxrR-DVjnD6PYT-7LBItfNsRzivHeFsnWck2SNWpSoqnNRolu3ZUKbYT65SjT7gd60O3Tb940PHdX_fEqu6fyv6h7uif9UGnA6vXeCdC8ydcvOVmeYWIxN28NoF3rnA3Cn3YGRXtBjSy7_pwDzvwAjzy5kth3ToIrgZJgQ3w4TgZpgSnKAJwVcugpthQnAzTAhuhinBCZoQfO0i-MZFUTNMKGqGCUXNMKUoQROKbl0UNcOEomaYUNQMU4oSNKHozkVR7tQTCJqQlKAJSwma0pTCqa7gVhbc2oJbXXDsC26FgTs1Bn5VGaxsNdOUrWaastVMk7YSOGWrTVm6vjObtmRLU7Za9SVrnLL1qjwYbd2fPvwJAAD__4eyQAE=
-#
-# # Subset join on interleaved columns uses hash joiner.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child2 JOIN grandchild2 USING(pid1, cid3)]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzElsGK2zAQhu99imVOLagkkp1sYij42O1htyy9FR-80TQxZK0gOdBlybsX2y1pHFdjdYp6VOxP-jX-IP8r1EbjffmMDrKvIEGAAgEJCEhBwAIKAQdrNuicse0rPXCnv0M2F1DVh2PT_lwI2BiLkL1CUzV7hAy-lE97fMRSo53NQYDGpqz23TEHWz2X9iXf7Kq9VlCcBJhj83Or8w5PLze70u0u2VyKPIHiVAhwTblFyORJ_F2qxXiqrS1r_W-iqT9GO291rI3VaFFfbFa0JPXKyP0-lm73yVQ12pkcTH2P35q3XcZ3H2y13f1agICHY5PddCuRK5GnIl-KfCXy9WAA55sljJuNxL43781hJhfDGYyenV6cLad_cBlPw4BUy8gaysgaymgaqulDV_FUCEh1G1kFFVkFFU2FZPrQk3gqBKRaRVYhiaxCEk2FdPrQ03gqBKRaR1YhjaxC-l96ykioR3QHUzuc1ELm7bVQb7EfkzNHu8HP1my6Y_rlQ8d1f7kaXdM_Vf3iru4ftQGnw0sOvObAkpVbLvy0DBiZCoOXHHjNgSUr92BkV7Qa0vPf6cQ_78QLy8uZzYd0yhHcDxOC-2FCcD9MCU7QhOALjuB-mBDcDxOC-2FKcIImBF9yBL_lKOqHCUX9MKGoH6YUJWhC0RVHUT9MKOqHCUX9MKUoQROKrjmKSlZPIGhCUoImLCVoSlMKp7oCryzw2gKvLjD7Aq8wSFZjkFeVIchWP03Z6qcpW_00aSuBU7aGlKXrbxbSlkJpytagvhSMU7ZelQevrcXpzY8AAAD__5b5Mtw=
-#
-# # Sort node in between join and child nodes produces hash joiner.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN (SELECT * FROM child1 ORDER BY cid1) USING(pid1)]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJy8lk9vm0wQxu_vp4jm9FbdKuyC_yFV4tj0kFRpbxUHYrYxksOiBUuNonz3ClMrApx9mGK41bV_zOzsb_LwQrlJ9W3ypEsKf5IkQYoE-SQoIEELigUV1mx1WRpb_6QBbtLfFHqCsrw4VPV_x4K2xmoKX6jKqr2mkH4kD3t9r5NU22uPBKW6SrL9sUxhs6fEPkdFYnVeSYpfBZlD9fdZb494eL7aJeWuDUf172NBZZU8agrlq_i3nhbne9rusn3abemtnOKU-25spe217Bw_Uh9HHdl_t4e35xxyY1Ntddp6UlyT6CdnDvIlKXdfTZbXh-nMba9_Vf9H8sNnmz3ujv8iQXeHKryKpIiUiAIRLd4dZzDiKGf6vDWfTHGtvO6hz9ZetGrL4ebIuWxm9LS8gM2g3MlmOaXNcmabl9PZrIbfnprLKEZPqwsYBcqdjFJTGqVmNmo1nVH-8Nvz5zKK0dP6AkaBciej_CmN8mc2aj2dUcHw2wvmMorR0-YCRoFyJ6OCKY0KZjZqM8873Jku7nVZmLzUg97QvPocOn3UzVxKc7Bb_c2a7bFM8_HuyB1fHFJdVs23fvPhJm--qhscDq_HwFKNopdjaOW5admlvRbdgr0urBgDVzx4PQbuDJxLL8fQnYH3aN858MB9W4H7tqT7uhZj9sMNg_1ww2g_AA32w02j_Vg6J75yD3w1Zj_cMNgPN4z2A9BgP9w02o_1mP3YjDHcDQPD3TAyHNDAcDcNE6AXIK2JS_BHRfYShCM5oIHlgEaaIxx4DnAkuuzlCMd02csRjuqABq4DGsmOcGA7wKHu7gyVC6A7J0T7d85JUS4NdWflKBeHuruTFOnOiVIujXRnhSkbR7qz4rSPu_NUboDunETt3zknUrk01J0Vqlwc6a7cqdrVPX79708AAAD__3t4GdI=
-#
-# query TTT
-# EXPLAIN SELECT * FROM parent1 JOIN (SELECT * FROM child1 ORDER BY cid1) USING (pid1)
-# ----
-# render · ·
-# └── join · ·
-# │ type inner
-# │ equality (pid1) = (pid1)
-# ├── scan · ·
-# │ table parent1@primary
-# │ spans ALL
-# └── sort · ·
-# │ order +cid1
-# └── scan · ·
-# · table child1@primary
-# · spans ALL
-#
-# # Multi-table staggered join uses interleaved joiner on the bottom join
-# # and a merge joiner.
-# query T
-# SELECT url FROM[EXPLAIN (DISTSQL)
-# SELECT * FROM grandchild1
-# JOIN child1 USING (pid1, cid1)
-# JOIN parent1 USING (pid1)
-# ORDER BY pid1
-# ]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzcls9u2kAQh-99imhOrbIV7NpAsFTJV6o2qVBvlQ8OnoAlx4vWS9Uo4t0rYxLMn-xgRhiJo7377c7OfIffK-Q6wfv4GQsI_oAEAQoEeCDABwE9iATMjZ5gUWhTbqmAUfIPgq6ANJ8vbPk7EjDRBiF4BZvaDCGAUW7RZBj_xTHGCZrvOs3RdLogIEEbp9nqxh_4ZKG8I32OzUs4NXGeTGZplpSljNPprL76vlCdBQIyfLKfQ3krQnX75Zsp979_goCHhQ1uQilCJUJPhL4IBxAtBeiFXRe-qffx5WYWF7Pt8kIJ0TISUNh4ihDIpTi-Ab_jx2z99k5v-9i3B81jg7mVrJrUhzVtztEmQYPJ7jm35cVH7TrwvJ9oprgeqtyZ6ttYaiM5PI7e_kQ2L_N4LztQ873-qucduT2Nj673t66XJ9kur8d2ogF12_tt2S4vY7s8v-3qJN3U9ehGNKCu26At3dRldFPn1807STfvenQjGlDX7a4t3bzL6OadXzf_JN3869GNaEBdt2FbuvmX0c1vNzoeKGeMxVznBR6VCrvlgzCZYtWmQi_MBH8ZPVldU30-rLhVPEmwsNWqqj5GebVUFng83OfAQw4sWXXLnpuWDVqmmsF9DjzkwJJV907L9mi1S3frtOfut-eE5XbPuru0zxHcDROCu2FCcDdMCU7QhOA9juBumBDcDROCu2FKcIImBO9zBB9wFHXDhKJumFDUDVOKEjSh6B1HUTdMKOqGCUXdMKUoQROKDjmKSlZOIGhCUoImLCVoSlMKp7ICLyzw0gIvLjDzAi8wSFZikHuRoZGtbpqy1U1Ttrpp0lYCp2xtEpb2Z9YkLTWlKVsb5aXGOGXrXnhw2hotP_0PAAD__9pnwiY=
-#
-# # Multi-table join with parent1 and child1 at the bottom uses interleaved
-# # joiner but induces a hash joiner on the higher join.
-# query T
-# SELECT url FROM [EXPLAIN (DISTSQL)
-# SELECT * FROM parent1
-# JOIN child1 USING (pid1)
-# JOIN grandchild1 USING (pid1, cid1)
-# ]
-# ----
-# https://cockroachdb.github.io/distsqlplan/decode.html#eJzUls-K2zAQh-99imVOLVXZSLbzx1DwsSllt4Teig_aeDYxeK0gK6XLkncvjrPEdlJNHIEgtzjSJ81ovsPvDUqV4YN8wQri38CBgQAGATAIgUEEKYONVkusKqXrLQ0wz_5CPGKQl5utqf9OGSyVRojfwOSmQIhhXhrUBco_uECZof6u8hL1_QgYZGhkXuxv_IHPBuo78hepX5ON1FiauoxFvlq3V5brvMjqheYcYFDgs_mY8M-fvup67_4nMHjcmvgu4SwRLAlZEkG6Y6C25lDpscCn17u1rNbdemowgHSXMqiMXCHEfMcub_qXfCoO_d5H3ZPfG1lpWWaHbgaXJjqlif-WdjxqWyqdocasc1hak9SWM_19k9X6MEjem-RhHCwJjgNhieiMJHifyoQl0173x7YCh7bO1PygvqjNPY_6D3D27rBzN79KcX7bihNNtxUfe1ace1ac-1FcXKWZuG3NiKbbmk08ayY8ayb8aBZcpVlw25oRTbc1m3rWLPCsWeBHs_AqzcLb1oxouq3ZzLNmoWfNQv-58ExFC6w2qqzwotQ3qnvCbIXNG1Vqq5f4U6vl_prm83HP7TNIhpVpVkXzMS-bpbrAy-GxCzxzgblT3Tyy03zAk4lh8NgFnrnA3Knu3pOd0KJPj9p0YH_vwArz7puN-nToIrgdJgS3w4TgdpgSnKAJwSMXwe0wIbgdJgS3w5TgBE0IPnYRfOKiqB0mFLXDhKJ2mFKUoAlFpy6K2mFCUTtMKGqHKUUJmlB05qIod8oJBE1IStCEpQRNaUrhVFZwCwtuacEtLjjmBbfAwJ0SAz-JDINstdOUrXaastVOk7YSOGXrkLB0OrMhaWkoTdk6KC8NxilbT8KD1dZ09-FfAAAA___T9r_v
+statement ok
+SET CLUSTER SETTING sql.distsql.interleaved_joins.enabled = true;
+
+#####################
+# Interleaved joins #
+#####################
+
+# Select over two ranges for parent/child with split at children key.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child1 USING(pid1) WHERE pid1 >= 3 AND pid1 <= 5]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzUkkFr6zAQhO_vV5g5vcfbEstpL4aAriklKbkWH4S1SQSOZCS5tJT89yKrUCe0oe2tN69mZscf7Aus07xSBw6oHyBAqECYoyH03rUcgvNJysalfkJdEozth5ifo4kdo8ZgndfsWYOgOSrTJb05NoTWeUb9bl25K9fPqjMjwQ3xbW1DCFHtGHV1pEm1mFR_sHhpI_uO1SNvWGn2t85Y9rPypAl3vI1IeOag_LPslWcbE_nG7PZTpd2bTich7wGh4238K8X_fwufvOMnCOtVIUWxKOQ8DUOsCylIViSvSd7gMzRxglb9CE38BrTyMtqGQ-9s4C_dQ5kOivWO8_UFN_iW771rx5o8rsfc-KA5xKzO87C0WUo_OA2Li-HyJCzOw9W3ws3xz2sAAAD__y3KHZU=
+
+# Swap parent1 and child1 tables.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child1 JOIN parent1 USING(pid1) WHERE pid1 >= 3 AND pid1 <= 5]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzUkkFr6zAQhO_vV5g5vcfbEstpL4aAriklKbkWH4S1SQSOZCS5tJT89yKrUCe0oe2tN69mZscf7Aus07xSBw6oHyBAqECYoyH03rUcgvNJysalfkJdEozth5ifo4kdo8ZgndfsWYOgOSrTJb05NoTWeUb9bl25K9fPqjMjwQ3xbW1DCFHtGHV1pEm1mFR_sHhpI_uO1SNvWGn2t85Y9rPypAl3vI1IeOag_LNs96bTCXxjdvup0CvPNiYl7wGh4238K8X_fwufzOMnCOtVIUWxKOR1GoZYF1KQrEjOSd7gMzRxglb9CE38BrTyMtqGQ-9s4C_dQ5kOivWO8_UFN_iW771rx5o8rsfc-KA5xKzO87C0WUo_OA2Li-HyJCzOw9W3ws3xz2sAAAD__yRsHZU=
+
+# Select over two ranges for parent/child with split at grandchild key.
+# Also, rows with pid1 <= 30 should have 4 rows whereas pid1 > 30 should
+# have 3 rows.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child1 ON parent1.pid1 = child1.pid1 WHERE parent1.pid1 >= 29 AND parent1.pid1 <= 31 ORDER BY parent1.pid1]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzUUcFq6zAQvL-vMHt6JSqxnOZiCOiaUpKSa_FBWBtH4EhmtS4twf9eJB8Sl6S0vfXm3ZnR7IxP4LzBjT5igPIFJAhYQiWgI19jCJ7ieiStzRuUuQDrup7juhJQe0IoT8CWW4QS1o6RWtSvuENtkB69dUjz-KxB1rZNLk-4Z4ge9qjpXXWa0HHk7GxzuETqg21NBMZ3QECLe_6v5OxuRZGbPkHAdpMpma0ytYhDz2WmpFCFUAuhHoRaQjUI8D2fLw-sG4RSDuJGunMoTwYJzTSDkjOohisVbPy97-bFhH3LvZi4y191m__Bbq-k22HovAv4rd7yWDyaBscfFXxPNT6Tr5PNOG6TLi0MBh5ROQ5rl6B04KVYfileTMT5Z3HxI-dq-PcRAAD__3DaHjA=
+
+# Parent-child where pid1 <= 15 have one joined row and pid1 > 15 have no
+# joined rows (since child2 only has 15 rows up to pid1 = 15).
+# Note this spans all 5 nodes, which makes sense since we want to read all
+# parent rows even if child rows are non-existent (so we can support OUTER
+# joins).
+# TODO(richardwu): we can remove nodes reading from just one table for INNER
+# joins or LEFT/RIGHT joins.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child2 USING(pid1) WHERE pid1 >= 12 ORDER BY pid1]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzUlM_K2zAQxO99CjOnlmyJ5T85GAK6ppSk5Fp8MNYmMTiWkeTSEvzuRfYhcWna73NOvlnaHc_8FrQ3NFrxvriyRfYdAoQIhBiEBIQUOaE1umRrtfEto2CnfiILCVXTds5f54RSG0Z2g6tczciwaxybmosffORCsfmiq4bNOgRBsSuqenD8yicH71FdC_NLtoXhxvkYx-p8eayUl6pWPtv4HxBqPrmPUqw-bY3vHT5BOOwDKYJtID3EoXNZIAXJiGRCMiW5Qd4TdOfuya0rzoxM9PSE7g6ljWLDasogxQp5_5cR7PVn3a7TSfcz92jiLmbNVixkttEsumghdPEsunghdMksumQhdP_ZaUe2rW4sv-lFh34lsDrzuEKs7kzJ34wuB5vxeBh0w4Vi68aqGA-7ZigNAR_F4p_izUQc_imOXnGOXxEnr4jTd4nz_sPvAAAA__9VWS06
+
+# These rows are all on the same node 1 (gateway).
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child2 USING(pid1) WHERE pid1 IN (1, 11, 21, 31) ORDER BY pid1]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJyMUE1LxDAUvPsrypwUH7hZPw6BhVwrsiu9Sg-hedsNdJOSvIqy9L9Lm4N6ELxlPjKTyQUhOt7bM2foNyi0hDHFjnOOaaGKoXYf0BuCD-MkC90SupgY-gLxMjA06iCcBrbv3LB1nJ6jD5zuNiA4FuuHteGFj4Klw59t-jSjTRxEgdD4_vRT6U5-cFsQSg4IAx_l2qjbm11avOsRhMO-MqraVeZ-AZPoyigyWzIPZB7JPKGdCXGS75dnsT1Dq5n-v67hPMaQ-deav5I3c0tg13P5wRyn1PFrit1aU-BhvbcSjrMUVRVQhyLN7Xz1FQAA__9AfoaM
+
+# Parent-grandchild.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL)
+ SELECT * FROM parent1 JOIN grandchild2 USING(pid1) WHERE
+ pid1 >= 11 AND pid1 <= 13
+ OR pid1 >= 19 AND pid1 <= 21
+ OR pid1 >= 31 AND pid1 <= 33
+]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzslE9r3DAQxe_9FGJOu3RKLDlpqWBBhVLYUrxl6a31QVgTR-BIRpJLS_B3L7K7xBvSfymEHPbm0dOPN_iN5gacN1Tpa4ogPwMHBAEIF1Aj9ME3FKMPWZovbs03kAWCdf2Q8nGN0PhAIG8g2dQRSNi6RKEj_ZX2pA2F9946CmcFIBhK2naT0we6TJA97LUO31WvA7mU7bPA3tkuUZBstVKcfRmKomw2jJdSym31ac12-4VCG8ZfH5Q31Vu2ZAT_qaxnagGVBwkQ9ra9WrbTBu1Mc2U7Iw7qo_c0_zdA6OgyrRR_vt6E3Mj0CQi7iinONkyVuRiSZIqjEqjOUV2geonqFdQjgh_SbVgx6ZZA8hF_EehtjoPzwVAgcxRcPd4TeeVf-P6svHPxfmtxZM0fNEv8NEtPdZbEgwIVp0CfaqB_2PZ7ir13kf7q7Rd5eZBpad400Q-hoY_BN5PNXO4mbjowFNOs8rnYukmaGlzC_Lfw-RFc3IXF_ziX_wTX47MfAQAA__8YYyxn
+
+query T
+SELECT url FROM [EXPLAIN (DISTSQL)
+ SELECT * FROM grandchild2 JOIN parent1 USING(pid1) WHERE
+ pid1 >= 11 AND pid1 <= 13
+ OR pid1 >= 19 AND pid1 <= 21
+ OR pid1 >= 31 AND pid1 <= 33
+]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzslE9r3DAQxe_9FGJOu3RKLDtpqWBBhVJwKd5iemt9ENbEETiSkeTSEvzdi-wu8Yb0Xwohh7159PTjDX6juQHrNFXqmgKIz8ABIQeEC2gQBu9aCsH5JC0XS_0NRIZg7DDGdNwgtM4TiBuIJvYEAkobyfekvlJNSpN_74wlf5YBgqaoTD87faDLCMnDXCv_XXZeWd1emV4n-ySyd6aP5AXbbCRnX8YsK9od44UQoqw-bdm-Xim0Y_z1QXlTvWVrJuc_le1CraDiIAFCbbqrdUuD8mQjPyiP3s_y3wChp8u4kfz5dudTI_MnIOwrJjnbMfkyFWMUTHKUOcoC5TnKC5SvoJkQ3BhvwwpRdQSCT_iLQG9zHK3zmjzpo-Ca6Z7IK_fCDWfFnYv3W-dH1vxBs8RPs_RUZyl_UKD5KdCnGugftn1NYXA20F-9_SwtD9IdLZsmuNG39NG7drZZyv3MzQeaQlxUvhSlnaW5wTXMfwufH8HZXTj_H-fin-BmevYjAAD__-kZLGc=
+
+query TTT
+EXPLAIN SELECT * FROM grandchild2 JOIN parent1 USING(pid1) WHERE
+ pid1 >= 11 AND pid1 <= 13
+ OR pid1 >= 19 AND pid1 <= 21
+ OR pid1 >= 31 AND pid1 <= 33
+----
+render · ·
+ └── join · ·
+ │ type inner
+ │ equality (pid1) = (pid1)
+ │ mergeJoinOrder +"(pid1=pid1)"
+ ├── scan · ·
+ │ table grandchild2@primary
+ │ spans /11/#/56/1-/13/#/56/2 /19/#/56/1-/21/#/56/2 /31/#/56/1-/33/#/56/2
+ └── scan · ·
+· table parent1@primary
+· spans /11-/13/# /19-/21/# /31-/33/#
+
+# Join on multiple interleaved columns with an overarching ancestor (parent1).
+# Note there are 5 nodes because the filter cid2 >= 12 AND cid2 <= 14
+# creates a giant parent span which requires reading from all rows.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL)
+ SELECT * FROM child2 JOIN grandchild2 ON
+ child2.pid1=grandchild2.pid1
+ AND child2.cid2=grandchild2.cid2
+ AND child2.cid3=grandchild2.cid3
+ WHERE
+ child2.pid1 >= 5 AND child2.pid1 <= 7
+ OR child2.cid2 >= 12 AND child2.cid2 <= 14
+ OR gcid2 >= 49 AND gcid2 <= 51
+]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzsls-K2zAQh-99CjEnh0xZS5aTrsCgQimkFKeE3lofjDWbNXitIMulZcm7F9uNs162_5JLDjmORh8_iU8weoTaGkrzB2pAfQEOCAIQIkCQgBBDhrBztqCmsa7bMgAr8x1UiFDWu9Z3yxlCYR2BegRf-opAwar25CrKv9GGckPugy1rcjchIBjyeVn1iR_pzkOXUT7k7ocu7svKdCfYlNv7p42ty2sz7bL3ZeXJKRYEgebsaxuGESUsVkqt0s8z9jZ9x8ZGkbDlr8aMrTcsCLQYES6mjBgZLg_QgZIjJW-nlBypmB8oQBjuDQgV3flA8zlqMUcdzWeJ664xWQKEdcr6-yRMx8cDJUwvZocy6splv7n1immOWqCOUEvUMeoF6iXqN6hvIdsj2NYfLTU-3xIovsffmDwKbGvrDDkyE2PZ_gXXqX1tdzfxs40vR4tJND_pEfHrI7q4RyROMimuJi_OZHSSyehq8uJMypNMyqvJizP5l8_WhpqdrRv6pwkcdiOczJaGed_Y1hX0ydmijxnKdc_1C4YaP3T5UKzqvtUf8CnM_wgvJnD4HBbnJEfnwPIcOP4vONu_-hkAAP__KSY_SA==
+
+query TTT
+EXPLAIN
+ SELECT * FROM child2 JOIN grandchild2 ON
+ child2.pid1=grandchild2.pid1
+ AND child2.cid2=grandchild2.cid2
+ AND child2.cid3=grandchild2.cid3
+ WHERE
+ child2.pid1 >= 5 AND child2.pid1 <= 7
+ OR child2.cid2 >= 12 AND child2.cid2 <= 14
+ OR gcid2 >= 49 AND gcid2 <= 51
+----
+join · ·
+ │ type inner
+ │ equality (pid1, cid2, cid3) = (pid1, cid2, cid3)
+ │ mergeJoinOrder +"(pid1=pid1)",+"(cid2=cid2)",+"(cid3=cid3)"
+ ├── scan · ·
+ │ table child2@primary
+ │ spans ALL
+ └── scan · ·
+· table grandchild2@primary
+· spans ALL
+
+# Aggregation over parent and child keys.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL)
+ SELECT sum(parent1.pid1), sum(child1.cid1) FROM parent1 JOIN child1 USING(pid1) WHERE
+ pid1 >= 10 AND pid1 <= 39
+]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzclcGLm0AUxu_9K-SddunAOmqyWWHBHlPaTUnpqXgYnLeuYGZkZiwtwf-9jNJGQzIuxpM3x3mfv-99T3hHEJLjCzughvgnUCAQAIEQCERAYAUpgUrJDLWWypZ0gi3_DbFPoBBVbezrlEAmFUJ8BFOYEiGGrTCoSmS_cI-Mo_osC4HqwSI4GlaULfELvhqwjOLA1J-kYgqFsTX2wtvVJvYSe9wX-Vu_MHsrSv7_4l8hSaz7jgQESnw1dwn9eP-sbFX7CAR2L15CvWevLT4pSRJC2hCQtTl1pQ3LEWLakPd3_inPFebMSPWwHnb7_cfXu4RaD-1TeH8VGFwFnji1kIqjQj6ApI3bEvWdnoLrnsKBJzpp_MECxj_SeS_rx3nGH0yKOlxA1COd96LezBN1OCnqaAFRj3Tei_ppnqijSVH7C4h6pPNe1Kv598cF4B51JYXGsz1y-cu-3S_Ic-yWkZa1yvCbklmL6Y67Vte-4KhNd0u7w1Z0V9ZgX0yd4mAgpufiwE0eQYdOdeQWR7f4XjnFazd5fQv50SneuMmbW8hP7ln5I7-J-yc7Z6fNh78BAAD___NTc6o=
+
+###############
+# Outer joins #
+###############
+
+# The schema/values for each table are as follows:
+# Table: pkey: pkey values (same): values:
+# outer_p1 (pid1) {1, 2, 3, ... 20} 100 + pkey
+# outer_c1 (pid1, cid1, cid2) {2, 4, 6, ... 28} 200 + pkey
+# outer_gc1 (pid1, cid1, cid2, gcid1) {4, 8, 12, ... 36} 300 + pkey
+
+# Split between 4 nodes based on pkey value (p):
+# node 1: p - 1 mod 20 ∈ [1...5)
+# node 2: p - 1 mod 20 ∈ [5...10)
+# node 3: p - 1 mod 20 ∈ [10...15)
+# node 4: p - 1 mod 20 ∈ [15...20)
+
+statement ok
+CREATE TABLE outer_p1 (
+ pid1 INT PRIMARY KEY,
+ pa1 INT
+)
+
+statement ok
+CREATE TABLE outer_c1 (
+ pid1 INT,
+ cid1 INT,
+ cid2 INT,
+ ca1 INT,
+ PRIMARY KEY (pid1, cid1, cid2)
+) INTERLEAVE IN PARENT outer_p1 (pid1)
+
+statement ok
+CREATE TABLE outer_gc1 (
+ pid1 INT,
+ cid1 INT,
+ cid2 INT,
+ gcid1 INT,
+ gca1 INT,
+ PRIMARY KEY (pid1, cid1, cid2, gcid1)
+) INTERLEAVE IN PARENT outer_c1 (pid1, cid1, cid2)
+
+statement ok
+ALTER TABLE outer_p1 SPLIT AT
+ SELECT i FROM generate_series(0, 40, 5) AS g(i)
+
+statement ok
+ALTER TABLE outer_p1 EXPERIMENTAL_RELOCATE
+ SELECT ARRAY[(((i-3)/5)%4)::INT + 1], i FROM generate_series(3, 40, 5) AS g(i)
+
+query TTITI colnames
+SHOW EXPERIMENTAL_RANGES FROM TABLE outer_p1
+----
+start_key end_key range_id replicas lease_holder
+NULL /0 20 {5} 5
+/0 /5 31 {1} 1
+/5 /10 32 {2} 2
+/10 /15 33 {3} 3
+/15 /20 34 {4} 4
+/20 /25 35 {1} 1
+/25 /30 36 {2} 2
+/30 /35 37 {3} 3
+/35 /40 38 {4} 4
+/40 NULL 39 {5} 5
+
+### Begin OUTER queries
+
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_p1 FULL OUTER JOIN outer_c1 USING (pid1)]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzclE1r3DAQhu_9FWJOCZ0Syx85GAIqYQsOxi5uciqmGGuyNTiSkeTSEPzfi-xDutvtl_fmm6XRo9fzCOYFlJZUNE9kIf0MHBBCQIgAIQaEBGqEweiWrNXGH1mATH6HNEDo1DA6v10jtNoQpC_gOtcTpJApR6an5htV1Egyd7pTZK58hCTXdP2cmNOjA5_RPTXmWejRkfky-ENVt__6a6n1peUqQLh_HihlHx7ynJUP97uK3ZVZAQg9PboLwd9e3hh_y_wJCGXBBGc3TPj-KlKSTMpuy_f57tPt7kJwFNElMhEiEzEykSAT11BPCHp0r41a1-wJUj7hb2S8OhiVNpIMyYOm6-mErkK_08NVcnTwdHR4EM1XvUO4zXcIV8mItikjWiUj3qaMeJWMYJsy_jK7K7KDVpb-aRoFfpyR3NMy-6weTUsfjW7nmGVZzty8Icm6pcqXRabm0vyDP8P8j_D1ARwcw-E5ydE5cHwOnPwXXE9vfgQAAP__bK5tZg==
+
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_gc1 FULL OUTER JOIN outer_c1 USING (pid1, cid1, cid2)]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzsldFr2zAQxt_3V4h7ssmNxrKTdoaCSpdBSrCH1z4NM4x1zQypZCR5rJT870M2o3WXlTR5zeN9d58-8TuQnkBpSVn1QBbS7xABAgeEGBASQJhBidAaXZO12viRwbCUvyGdIjSq7ZyXS4RaG4L0CVzjNgQpLJUjs6HqFxVUSTI3ulFkznyEJFc1mz5xRfcOfEbzUJlHoTtH5se69lNFs_75b69vDWcBwu1jSyn7crdasfzudlGwm3yZAcKG7l0gogkKPkERT8JL408bSYCQZywIRMQumZiH7Cr7zALBfXUe_i1jX1744YKUJJOy6_xqtfh2vQhEhGIe4guBozgfCTGKixCZSJCJGTLxCcotgu7cMzfrqjVBGm3xP2yfkXZKG0mG5Ihhud1BP9MfdXs2ezW4O5qPoqOD1spPa91jrfwgtvGJ7R5s44PYJie2e7BNDmI7PbF951O_g21BttXK0l4v-dR_BSTXNPwbVnempq9G133MUOa9rxckWTd0o6FYqr7VX_ClOXrTPB-Zp6_N_Jjk-Bhzcox59i5zuf3wJwAA___QpMHp
+
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_c1 LEFT OUTER JOIN outer_p1 USING (pid1) WHERE pid1 >= 0 AND pid1 < 40]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzUlE9rg0AQxe_9FDKnlk6Jq6YHIbCXFAxBi6SnIkXcSSoYV3bX0hD87mX1kCZN_yWn3Jx9-_bNb2DcQi0FxfmaNITPwADBAwQfEALIEBolC9JaKisPlyPxDqGLUNZNa-xxhlBIRRBuwZSmIgghqg2pivI3SikXpGayrEmNXEAQZPKy6tPmtDRgM8p1rjZctobUS2F7SMvV61epsdLwFCAsNg2Fznz6sHCSp8U0dWZJFANCRUtzzdntzUTZV_pPQEhihzNn4vCxLVoTOpwh95D7yAPk95B1CLI1Oyht8hVByDr8BnzH29ZSCVIk9gCz7shoYnknm1FwcPF4tLcXzU6aObv8mXsngXuXD-6fBO5fPvgvv5eUdCNrTX9aItduIYkVDSurZasKelSy6GOGMul9_YEgbQaVDUVU91Lf4Gcz-9E83jO7h2bvnGT_HHPwL3PWXX0EAAD__3y68rA=
+
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM outer_p1 RIGHT OUTER JOIN outer_gc1 USING (pid1) WHERE pid1 >= 1 AND pid1 <= 20]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzclE9rs0AQxu_vp5A5vS_vlLhqWhACeymtoWiR9FSkiDuxgnFldy0Nwe9eVg9p0vRfcsvN3WefeeY3MG6gkYLifEUawkdggOABgg8IAWQIrZIFaS2VlcfHkXiF0EWomrYz9jpDKKQiCDdgKlMThBA1hlRN-QullAtSc1k1pCYuIAgyeVUPaXe0NGAzqlWu1lx2htRTa3tIq_L5o1QWVhtrAcJi3VLopNHN7cJJHhbXqTNPohgQalqav5z9_zdTts7wCQhJ7HDmzBxu6ZLOhA73kXvIA-RT5JfIryDrEWRntmTa5CVByHr8hH4L3TVSCVIkdiiz_sB8Ynkh20mw9_BwtLcTzY4aPDuTwXtH0XtnQu8fRe-fCf03v5yUdCsbTT_aKdcuJYmSxg3WslMF3StZDDHjMRl8w4UgbUaVjYeoGaShwfdm9qV5umN2983eKcn-KebgV-as__MWAAD__72G-Cw=
+
+########################
+# Non-interleaved joins #
+########################
+
+# Join on siblings uses merge joiner.
+# TODO(richardwu): Update this once sibling joins are implemented.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child1 JOIN child2 USING(pid1)]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzElkFr2zAUx-_7FOGdNqrRSLaTxlDQtYMlo-w2cnDjt8SQWkF2YKXkuw_HgyyOp2ftgXyra_2kv55_kP87lCbHZfaKFaQ_QIIABQIiEBCDgATWAg7WbLCqjG2WtMBT_gvSqYCiPBzr5t9rARtjEdJ3qIt6j5DC9-xlj8-Y5WjvpyAgxzor9udjDrZ4zeyb3uyKfS5hfRJgjvWfrS47vLxNdlm1u2Z1s34toKqzLUIqT-L_IiWOSIoVSf0z0mUfY3O0mHf3uWsOHrSq53Zf0W7xiylKtPeyM_E9_qw_ann36dEW2137JwhYLSdaTh4nuvnYq2OdTrQUWgkdCZ0IPRN63hnF5ZrRgGsey74r9KZfms_mcC-Tzsr-s-Ors-Xwry4DiegRaRZIRDmOiDKwiGr45FUgGTwizQPJoMaRQQWWIRo--SiQDB6RHgLJEI0jQxRYhnj45ONAMnhEWgSSIR5HhnjEvtKT7RmrgykrHNRGps3tMN9iO7PKHO0Gv1mzOR_TPq7O3PlXOMeqbt-q9uGpbF81AYfDMw684MCSlVsmblp6jEz5wTMOvODAkpW7M7IbWnXp6d905J535ITl9cymXTrmCO6GCcHdMCG4G6YEJ2hC8IQjuBsmBHfDhOBumBKcoAnBZxzB5xxF3TChqBsmFHXDlKIETSj6wFHUDROKumFCUTdMKUrQhKILjqKS1RMImpCUoAlLCZrSlMKprsArC7y2wKsLzL7AKwyS1RjkTWXwstVNU7a6acpWN03aSuCUrT5l6fab-bQlX5qy1asveeOUrTflwWnr-vThdwAAAP__Z2kpbQ==
+
+# Join on non-interleaved tables (with key) uses merge joiner.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN parent2 ON pid1=pid2]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzElVFr2zAQx9_3Kcw9bVQjluykqaGg1w6WjLK34Qc3viWG1DKSDCsl333YLmQxic5GoL3FsX66-_8u5N6hViVuilc0kP0CDgwEMEiAQQoMlpAzaLTaoTFKd0cG4Kn8A1nMoKqb1nZf5wx2SiNk72Are0TI4GfxcsRnLErUixgYlGiL6tiXaXT1Wug32RQaa8shPzFQrf2463zFy1t0KMzhEpbd-ZyBscUeIeMndqOn8z1Kl6ixHN9z1xU-n2rra-f6WuNs31Hv8ZuqatSL1eW1R_xtP0t-9-VRV_vD8BEYbDeR5NFjJDu129ZmkeRMCiYTJtORgHO4ZEK4GW1v1FfVLDgfnbxeO72ozacPm4caNg8_7PtgwxbThYtQwkV44etgwpPpwpNQwpPwwh-CCU-nC09DCZ_R09LVk_DqSdzsKdCPgMf_Zald6eoZTaNqg5NWVtzlwnKPgyqjWr3DH1rt-jLD47bn-uVRorHD24-Hp3p41TU4HU594JUPvPaBORGaj-n4X1q4YeGE-SUdj-nEZ1humBiWGyaG5YaJYRGZidCpz7CWPrrdMKHbDRO63TChm8hMhF756L730e2GCd1umNDthgndRGYi9NpH94OPbjdM6HbDhG43TOgmMlP__HOWpZhJp170yotee9GcCj5vY-anT38DAAD__zUYv7M=
+
+# Join on non-interleaved column uses hash joiner.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM parent1 JOIN child1 ON pa1 = ca1]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJy8llFr2zwUhu-_X1HOVQv6SCTZaWMY-HLdRTvK7oYv3PgsMaSWkRVYKfnvI_Egi-PpWDtEl2nySK_OeaDvBzSmwqfyDTvIvoMEAQoEaBCQgIAUCgGtNSvsOmMPP-mBx-onZHMBddPu3OHPhYCVsQjZB7jabREy-Fa-bvEFywrtbA4CKnRlvT1e09r6rbTveVtabJyEYi_A7Nzvs05HvL7fbMpucw7nCop9IaBz5Rohk3vxb5nS8UyrTb2tQiPps0jqr5FO5-waYyu0WJ2dVBxI6icj7_pcdpsvpm7QzuRg1lv84W5zdffJ1uuNu831HQh43rnsJpciVyLXIk9Eng5efHqNZrxmJOqT-d-0M5kO3z16d3J2t5y-XBlLuIBMi0jCycjCyasKp6YPWMVaekCm-0hLV5GXrq66dD19wDrW0gMyPURauo68dH3VpSfTB5zEWnpApmWkpSeRl55E6xMjQV6wa03T4aS2MD88Bas19qPpzM6u8Ks1q-M1_cfnI3f8J1lh5_pvVf_hsem_OgScDi848JIDS1ZumfppGTAyFQYvOPCSA0tW7sHILmg1pOd_0to_b-2F5fnM5kM64QjuhwnB_TAhuB-mBCdoQvCUI7gfJgT3w4TgfpgSnKAJwRccwe85ivphQlE_TCjqhylFCZpQ9IGjqB8mFPXDhKJ-mFKUoAlFlxxFJasnEDQhKUETlhI0pSmFU12BVxZ4bYFXF5h9gVcYJKsxyIvKEGSrn6Zs9dOUrX6atJXAKVtDytLlzkLaUihN2RrUl4JxytaL8uC1tdj_9ysAAP__U3kYdA==
+
+# Prefix join on interleaved columns uses merge joiner.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child2 JOIN grandchild2 USING(pid1, cid2)]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzMls9r2zAUx-_7K8w7tVQjkWznh6GgwS4dLB1lt5GDG70lhtQKsgMrJf_7sF3I4nh61jScHGXrIz299zl83yDXChfpCxaQ_AAODAQwCIFBBAxiWDLYGb3CotCm2tIAD-oXJGMGWb7bl9XnJYOVNgjJG5RZuUVI4Hv6vMUnTBWa0RgYKCzTbFtfszPZS2pe5WqTbZWA5YGB3pfvRx1PeH4NNmmxOWUlZ7JClgyKMl0jJPzA_q2quLuqtUlz9X9KE38t7XiUNgoNqvZRd0yKu-r-3js7XvsVzRq_6CxHM-KtIWzxZ3nzTt_em2y9OS6BweMiuJE8uA9kfBt8WnwObqSoVpP6575Mgvq5TIZMRkxOmZwxOW817NiJsEcn9nnXCzsfttAf9W7E49bO7rujk7t5f0H4cNo6VDUZWFt-WW359Wgr-g9JDKeOQ1XTgdURl1VHXI86Yf8hhcOp41DVbGB1wsuqE16POlH_IUXDqeNQ1XxgdaLLqhNdjzpEGH7CYqfzAnulqHH1cFRrbNpa6L1Z4TejV_U1zfKx5urIoLAom7-iWTzkza-qwP7wxAee-8Dcq24e22nu0DLhBk984LkPzL3qbrXsjBZtevwnHdr7HVphftqzcZuOfAS3w4TgdpgQ3A5TghM0IXjsI7gdJgS3w4TgdpgSnKAJwSc-gk99FLXDhKJ2mFDUDlOKEjSh6MxHUTtMKGqHCUXtMKUoQROKzn0U5V45gaAJSQmasJSgKU0pnMoKfmHBLy34xQXPvOAXGLhXYuBnkcHJVjtN2WqnKVvtNGkrgVO2uoSl85m5pCVXmrLVKS8545StZ-HBauvy8OF3AAAA___ImVxT
+
+# Subset join on interleaved columns uses hash joiner.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL) SELECT * FROM child2 JOIN grandchild2 USING(pid1, cid3)]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzElsGK2zAQhu99imVOLagkkp1sYij42O1htyy9FR-80TQxZK0gOdBlybsX2y1pHFdjdYp6VOxP-jX-IP8r1EbjffmMDrKvIEGAAgEJCEhBwAIKAQdrNuicse0rPXCnv0M2F1DVh2PT_lwI2BiLkL1CUzV7hAy-lE97fMRSo53NQYDGpqz23TEHWz2X9iXf7Kq9VlCcBJhj83Or8w5PLze70u0u2VyKPIHiVAhwTblFyORJ_F2qxXiqrS1r_W-iqT9GO291rI3VaFFfbFa0JPXKyP0-lm73yVQ12pkcTH2P35q3XcZ3H2y13f1agICHY5PddCuRK5GnIl-KfCXy9WAA55sljJuNxL43781hJhfDGYyenV6cLad_cBlPw4BUy8gaysgaymgaqulDV_FUCEh1G1kFFVkFFU2FZPrQk3gqBKRaRVYhiaxCEk2FdPrQ03gqBKRaR1YhjaxC-l96ykioR3QHUzuc1ELm7bVQb7EfkzNHu8HP1my6Y_rlQ8d1f7kaXdM_Vf3iru4ftQGnw0sOvObAkpVbLvy0DBiZCoOXHHjNgSUr92BkV7Qa0vPf6cQ_78QLy8uZzYd0yhHcDxOC-2FCcD9MCU7QhOALjuB-mBDcDxOC-2FKcIImBF9yBL_lKOqHCUX9MKGoH6YUJWhC0RVHUT9MKOqHCUX9MKUoQROKrjmKSlZPIGhCUoImLCVoSlMKp7oCryzw2gKvLjD7Aq8wSFZjkFeVIchWP03Z6qcpW_00aSuBU7aGlKXrbxbSlkJpytagvhSMU7ZelQevrcXpzY8AAAD__5b5Mtw=
+
+# Multi-table staggered join uses interleaved joiner on the bottom join
+# and a merge joiner.
+query T
+SELECT url FROM[EXPLAIN (DISTSQL)
+ SELECT * FROM grandchild1
+ JOIN child1 USING (pid1, cid1)
+ JOIN parent1 USING (pid1)
+ORDER BY pid1
+]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzklkFr4zwQhu_frzBzaqk-GsmO0xgKWthLl910KXtbfHDjaWJwrSAry5aS_744TlvHSTVxBM4hR0d5JM3MI3hfoVApTpJnLCH6DRwYCGDgA4MAGAwhZrDQaoplqXT1lxq4S_9CNGCQFYulqX6OGUyVRohewWQmR4jgrjCoc0z-4AMmKepvKitQXw-AQYomyfL1id_xyUB1Rvac6Bc500mRTudZnlZXechm8-bq-0K9FzDI8clcSH7FpLi6vNXV_98_gcH9xLuQ3Lv15PDS-zL56l1IUX2F68WliTzJmRRM-kwGTA6ZDJkcQbxioJZmU9tHSY8v3jwp59sVSA7xKmZQmmSGEPEVO7xHv5LHfNOe6-H2tm81LxKNheFOdxKf3uljH6VT1Ji297mqDj7oX3vK-4F6hpu589bg3ybXmNpmYvXAbvZOaMTkuNWKjzJ9tzL3FDBR_6vFNd8ezWfHB1vH86NeBz-r10H0qPk6wr5eBz_N6-A9vw5xlJ7irPQketTUc9SXnuI0eoqe9fSP0tM_Kz2JHjX1vOlLT_80evo96xkcpWdwVnoSPWrqOe5Lz-A0egYnjL577vaA5UIVJR6UagdVdZjOsO5ZqZZ6ij-1mq6PqT_v19w6O6VYmnpV1B93Rb1UXfBwOHSBxy4wd7o3H9pp3qFlohscusBjF5g73bvVsh1atOlBk_bt_fatMN_u2aBNBy6C22FCcDtMCG6HKcEJmhB86CK4HSYEt8OE4HaYEpygCcFDF8FHLoraYUJRO0woaocpRQmaUPTGRVE7TChqhwlF7TClKEETio5dFOVOOYGgCUkJmrCUoClNKZzKCm5hwS0tuMUFx7zgFhi4U2LgO5Ghk612mrLVTlO22mnSVgKnbO0SlnZn1iUtdaUpWzvlpc44ZetOeLDaGq_--xcAAP__p93xug==
+
+# Multi-table join with parent1 and child1 at the bottom uses interleaved
+# joiner but induces a hash joiner on the higher join.
+query T
+SELECT url FROM [EXPLAIN (DISTSQL)
+ SELECT * FROM parent1
+ JOIN child1 USING (pid1)
+ JOIN grandchild1 USING (pid1, cid1)
+]
+----
+https://cockroachdb.github.io/distsqlplan/decode.html#eJzclk9r2z4Yx--_VxGe069Mo5Fsp42hoOM6RjvCbsMHN36aGFwryMpYKXnvw3ZGbCfTE0egQ25N5Y_0_Pkcvh9Qqgyf0jesIP4JHBgIYBAAgxAYRJAw2Gi1xKpSuv6kBR6z3xBPGeTlZmvqfycMlkojxB9gclMgxPBYGtQFpr9wgWmG-qvKS9S3U2CQoUnzonnxG74aqN_I31L9LjepxtLUZSzy1bp7slznRVYftPcAgwJfzf-Sf7p50PW3zZ_A4PlpIvnkYSLrJp63Jp5IzqRgMmAyZDKCZMdAbc2-8kPBL--TdVqt-_XVbAjJLmFQmXSFEPMdO38IP9KXYt__bdS_-W9jK52W2b670aWJXmnin6UdrtqWSmeoMetdltQk9cmJ_r6k1Xq_WD7Y7H49TIaHBTEpbrpbCZvFREzeMzkfdH9oK3Bo60TNT-qz2tzyaDiAk2-Hvbf5Rcrz61KeGEJX-Zln5bln5bkf5cVF2onr0o4YQle7O8_aCc_aCT_aBRdpF1yXdsQQutrde9Yu8Kxd4Ee78CLtwuvSjhhCV7u5Z-1Cz9qF_nPliYoWWG1UWeFZqXFa94TZCtsZVWqrl_hdq2XzTPvzueGazJJhZdpT0f54LNujusDz4ZkLPHeBuVPdPLLTfMTIxDh45gLPXWDuVPdgZEe0GNLTLh3Y5x1YYd6f2XRIhy6C22FCcDtMCG6HKcEJmhA8chHcDhOC22FCcDtMCU7QhOAzF8HvXBS1w4SidphQ1A5TihI0oei9i6J2mFDUDhOK2mFKUYImFJ27KMqdcgJBE5ISNGEpQVOaUjiVFdzCgltacIsLjnnBLTBwp8TAjyLDKFvtNGWrnaZstdOkrQRO2TomLB3vbExaGktTto7KS6Nxytaj8GC1Ndn99ycAAP__c9_P7g==
|
bf8bc44dc1dd12789a4c1e2269cc32baaa8a3827
|
2023-11-23 01:45:31
|
adityamaru
|
sql: add `distsql_plan_gateway_bias` session var
| false
|
add `distsql_plan_gateway_bias` session var
|
sql
|
diff --git a/pkg/sql/distsql_physical_planner_test.go b/pkg/sql/distsql_physical_planner_test.go
index 07960523dc48..4529e6e82177 100644
--- a/pkg/sql/distsql_physical_planner_test.go
+++ b/pkg/sql/distsql_physical_planner_test.go
@@ -41,6 +41,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/randgen"
"github.com/cockroachdb/cockroach/pkg/sql/sem/eval"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
+ "github.com/cockroachdb/cockroach/pkg/sql/sessiondata"
+ "github.com/cockroachdb/cockroach/pkg/sql/sessiondatapb"
"github.com/cockroachdb/cockroach/pkg/sql/sqlinstance"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
@@ -1187,8 +1189,16 @@ func TestPartitionSpans(t *testing.T) {
if tc.locFilter != "" {
require.NoError(t, locFilter.Set(tc.locFilter))
}
+ evalCtx := &eval.Context{
+ Codec: keys.SystemSQLCodec,
+ SessionDataStack: sessiondata.NewStack(&sessiondata.SessionData{
+ SessionData: sessiondatapb.SessionData{
+ DistsqlPlanGatewayBias: 2,
+ },
+ }),
+ }
planCtx := dsp.NewPlanningCtxWithOracle(ctx, &extendedEvalContext{
- Context: eval.Context{Codec: keys.SystemSQLCodec},
+ Context: *evalCtx,
}, nil, nil, DistributionTypeSystemTenantOnly, physicalplan.DefaultReplicaChooser, locFilter)
planCtx.spanPartitionState.testingOverrideRandomSelection = tc.partitionState.testingOverrideRandomSelection
var spans []roachpb.Span
@@ -1409,7 +1419,18 @@ func TestShouldPickGatewayNode(t *testing.T) {
},
},
}
- mockPlanCtx := &PlanningCtx{}
+ evalCtx := &eval.Context{
+ SessionDataStack: sessiondata.NewStack(&sessiondata.SessionData{
+ SessionData: sessiondatapb.SessionData{
+ DistsqlPlanGatewayBias: 2,
+ },
+ }),
+ }
+ mockPlanCtx := &PlanningCtx{
+ ExtendedEvalCtx: &extendedEvalContext{
+ Context: *evalCtx,
+ },
+ }
t.Run(tc.name, func(t *testing.T) {
mockPlanCtx.spanPartitionState = tc.partitionState
for _, partitionCount := range tc.partitionState.partitionSpans {
diff --git a/pkg/sql/exec_util.go b/pkg/sql/exec_util.go
index a5a274b76aa6..586396f5dcf4 100644
--- a/pkg/sql/exec_util.go
+++ b/pkg/sql/exec_util.go
@@ -3705,6 +3705,10 @@ func (m *sessionDataMutator) SetDisableChangefeedReplication(val bool) {
m.data.DisableChangefeedReplication = val
}
+func (m *sessionDataMutator) SetDistSQLPlanGatewayBias(val int64) {
+ m.data.DistsqlPlanGatewayBias = val
+}
+
// Utility functions related to scrubbing sensitive information on SQL Stats.
// quantizeCounts ensures that the Count field in the
diff --git a/pkg/sql/logictest/testdata/logic_test/information_schema b/pkg/sql/logictest/testdata/logic_test/information_schema
index f36c3943e0d6..8ea9cf45cc10 100644
--- a/pkg/sql/logictest/testdata/logic_test/information_schema
+++ b/pkg/sql/logictest/testdata/logic_test/information_schema
@@ -5505,6 +5505,7 @@ disable_hoist_projection_in_join_limitation off
disable_partially_distributed_plans off
disable_plan_gists off
disallow_full_table_scans off
+distsql_plan_gateway_bias 2
enable_auto_rehoming off
enable_create_stats_using_extremes off
enable_durable_locking_for_serializable off
diff --git a/pkg/sql/logictest/testdata/logic_test/pg_catalog b/pkg/sql/logictest/testdata/logic_test/pg_catalog
index af65e63b84b5..f59d6642d499 100644
--- a/pkg/sql/logictest/testdata/logic_test/pg_catalog
+++ b/pkg/sql/logictest/testdata/logic_test/pg_catalog
@@ -2823,6 +2823,7 @@ disable_partially_distributed_plans off N
disable_plan_gists off NULL NULL NULL string
disallow_full_table_scans off NULL NULL NULL string
distsql off NULL NULL NULL string
+distsql_plan_gateway_bias 2 NULL NULL NULL string
enable_auto_rehoming off NULL NULL NULL string
enable_create_stats_using_extremes off NULL NULL NULL string
enable_durable_locking_for_serializable off NULL NULL NULL string
@@ -2993,6 +2994,7 @@ disable_partially_distributed_plans off N
disable_plan_gists off NULL user NULL off off
disallow_full_table_scans off NULL user NULL off off
distsql off NULL user NULL off off
+distsql_plan_gateway_bias 2 NULL user NULL 2 2
enable_auto_rehoming off NULL user NULL off off
enable_create_stats_using_extremes off NULL user NULL off off
enable_durable_locking_for_serializable off NULL user NULL off off
@@ -3159,6 +3161,7 @@ disable_partially_distributed_plans NULL NULL NULL
disable_plan_gists NULL NULL NULL NULL NULL
disallow_full_table_scans NULL NULL NULL NULL NULL
distsql NULL NULL NULL NULL NULL
+distsql_plan_gateway_bias NULL NULL NULL NULL NULL
distsql_workmem NULL NULL NULL NULL NULL
enable_auto_rehoming NULL NULL NULL NULL NULL
enable_create_stats_using_extremes NULL NULL NULL NULL NULL
diff --git a/pkg/sql/logictest/testdata/logic_test/show_source b/pkg/sql/logictest/testdata/logic_test/show_source
index 9030e25be7c1..f71dfc433662 100644
--- a/pkg/sql/logictest/testdata/logic_test/show_source
+++ b/pkg/sql/logictest/testdata/logic_test/show_source
@@ -61,6 +61,7 @@ disable_partially_distributed_plans off
disable_plan_gists off
disallow_full_table_scans off
distsql off
+distsql_plan_gateway_bias 2
enable_auto_rehoming off
enable_create_stats_using_extremes off
enable_durable_locking_for_serializable off
diff --git a/pkg/sql/sessiondatapb/session_data.proto b/pkg/sql/sessiondatapb/session_data.proto
index 9ccbd64ad7ab..61b86a996175 100644
--- a/pkg/sql/sessiondatapb/session_data.proto
+++ b/pkg/sql/sessiondatapb/session_data.proto
@@ -132,6 +132,16 @@ message SessionData {
// head-of-the-line request in case the "eager" memory usage limit has been
// exceeded.
double streamer_head_of_line_only_fraction = 30;
+ // DistSQLPlanGatewayBias controls the factor of times more partition spans
+ // the gateway node is allowed to be assigned in the absence of a better
+ // choice relative to the distribution of partition spans on other eligible
+ // instances. Refer to `shouldPickGateway` for more details.
+ //
+ // This field is in SessionData because that is the format in which a job
+ // serializes and stores session variables at the time of job creation. A job
+ // could be adopted by any node in the cluster (not necessarily the gateway)
+ // and so we will need this information available on all nodes.
+ int64 distsql_plan_gateway_bias = 31;
}
// DataConversionConfig contains the parameters that influence the output
diff --git a/pkg/sql/vars.go b/pkg/sql/vars.go
index debbf8eb5789..a0f9ecbd9539 100644
--- a/pkg/sql/vars.go
+++ b/pkg/sql/vars.go
@@ -3112,6 +3112,29 @@ var varGen = map[string]sessionVar{
},
GlobalDefault: globalFalse,
},
+
+ // CockroachDB extension.
+ `distsql_plan_gateway_bias`: {
+ Get: func(evalCtx *extendedEvalContext, _ *kv.Txn) (string, error) {
+ return strconv.FormatInt(evalCtx.SessionData().DistsqlPlanGatewayBias, 10), nil
+ },
+ GetStringVal: makeIntGetStringValFn(`distsql_plan_gateway_bias`),
+ Set: func(_ context.Context, m sessionDataMutator, s string) error {
+ i, err := strconv.ParseInt(s, 10, 64)
+ if err != nil {
+ return err
+ }
+ if i < 1 {
+ return pgerror.Newf(pgcode.InvalidParameterValue,
+ "cannot set distsql_plan_gateway_bias to a non-positive value: %d", i)
+ }
+ m.SetDistSQLPlanGatewayBias(i)
+ return nil
+ },
+ GlobalDefault: func(sv *settings.Values) string {
+ return strconv.FormatInt(2, 10)
+ },
+ },
}
func ReplicationModeFromString(s string) (sessiondatapb.ReplicationMode, error) {
|
0bd031d026752fdd1be25d23b2e942d65723c5ea
|
2022-01-27 03:51:57
|
Yahor Yuzefovich
|
kvstreamer: fix the bug with corrupting request when it is put back
| false
|
fix the bug with corrupting request when it is put back
|
kvstreamer
|
diff --git a/pkg/kv/kvclient/kvstreamer/BUILD.bazel b/pkg/kv/kvclient/kvstreamer/BUILD.bazel
index dd5d835c41f7..508f70955d90 100644
--- a/pkg/kv/kvclient/kvstreamer/BUILD.bazel
+++ b/pkg/kv/kvclient/kvstreamer/BUILD.bazel
@@ -52,6 +52,7 @@ go_test(
"//pkg/util/log",
"//pkg/util/mon",
"//pkg/util/randutil",
+ "@com_github_dustin_go_humanize//:go-humanize",
"@com_github_stretchr_testify//require",
],
)
diff --git a/pkg/kv/kvclient/kvstreamer/budget.go b/pkg/kv/kvclient/kvstreamer/budget.go
index eebc9db0f8fc..7b400439d9b4 100644
--- a/pkg/kv/kvclient/kvstreamer/budget.go
+++ b/pkg/kv/kvclient/kvstreamer/budget.go
@@ -16,6 +16,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/cockroachdb/cockroach/pkg/util/syncutil"
+ "github.com/cockroachdb/errors"
)
// budget abstracts the memory budget that is provided to the Streamer by its
@@ -94,7 +95,10 @@ func (b *budget) consumeLocked(ctx context.Context, bytes int64, allowDebt bool)
// check whether we'll stay within the budget.
if !allowDebt && b.limitBytes > 5 {
if b.mu.acc.Used()+bytes > b.limitBytes {
- return mon.MemoryResource.NewBudgetExceededError(bytes, b.mu.acc.Used(), b.limitBytes)
+ return errors.Wrap(
+ mon.MemoryResource.NewBudgetExceededError(bytes, b.mu.acc.Used(), b.limitBytes),
+ "streamer budget",
+ )
}
}
return b.mu.acc.Grow(ctx, bytes)
diff --git a/pkg/kv/kvclient/kvstreamer/streamer.go b/pkg/kv/kvclient/kvstreamer/streamer.go
index 250603b29255..2d411e1a72b3 100644
--- a/pkg/kv/kvclient/kvstreamer/streamer.go
+++ b/pkg/kv/kvclient/kvstreamer/streamer.go
@@ -738,7 +738,7 @@ type workerCoordinator struct {
}
// mainLoop runs throughout the lifetime of the Streamer (from the first Enqueue
-// call until Cancel) and routes the single-range batches for asynchronous
+// call until Close) and routes the single-range batches for asynchronous
// execution. This function is dividing up the Streamer's budget for each of
// those batches and won't start executing the batches if the available budget
// is insufficient. The function exits when an error is encountered by one of
@@ -1040,92 +1040,18 @@ func (w *workerCoordinator) performRequestAsync(
return
}
- var resumeReq singleRangeBatch
- // We will reuse the slices for the resume spans, if any.
- resumeReq.reqs = req.reqs[:0]
- resumeReq.positions = req.positions[:0]
- var results []Result
- var numCompleteGetResponses int
- // memoryFootprintBytes tracks the total memory footprint of
- // non-empty responses. This will be equal to the sum of memory
- // tokens created for all Results.
- var memoryFootprintBytes int64
- var hasNonEmptyScanResponse bool
- for i, resp := range br.Responses {
- enqueueKey := req.positions[i]
- if w.s.enqueueKeys != nil {
- enqueueKey = w.s.enqueueKeys[req.positions[i]]
- }
- reply := resp.GetInner()
- origReq := req.reqs[i]
- // Unset the original request so that we lose the reference to
- // the span.
- req.reqs[i] = roachpb.RequestUnion{}
- switch origRequest := origReq.GetInner().(type) {
- case *roachpb.GetRequest:
- get := reply.(*roachpb.GetResponse)
- if get.ResumeSpan != nil {
- // This Get wasn't completed - update the original
- // request according to the ResumeSpan and include it
- // into the batch again.
- origRequest.SetSpan(*get.ResumeSpan)
- resumeReq.reqs = append(resumeReq.reqs, origReq)
- resumeReq.positions = append(resumeReq.positions, req.positions[i])
- } else {
- // This Get was completed.
- toRelease := int64(get.Size())
- result := Result{
- GetResp: get,
- // This currently only works because all requests
- // are unique.
- EnqueueKeysSatisfied: []int{enqueueKey},
- position: req.positions[i],
- }
- result.memoryTok.streamer = w.s
- result.memoryTok.toRelease = toRelease
- memoryFootprintBytes += toRelease
- results = append(results, result)
- numCompleteGetResponses++
- }
-
- case *roachpb.ScanRequest:
- scan := reply.(*roachpb.ScanResponse)
- resumeSpan := scan.ResumeSpan
- if len(scan.Rows) > 0 || len(scan.BatchResponses) > 0 {
- toRelease := int64(scan.Size())
- result := Result{
- // This currently only works because all requests
- // are unique.
- EnqueueKeysSatisfied: []int{enqueueKey},
- position: req.positions[i],
- }
- result.memoryTok.streamer = w.s
- result.memoryTok.toRelease = toRelease
- result.ScanResp.ScanResponse = scan
- // Complete field will be set below.
- memoryFootprintBytes += toRelease
- results = append(results, result)
- hasNonEmptyScanResponse = true
- }
- if resumeSpan != nil {
- // This Scan wasn't completed - update the original
- // request according to the resumeSpan and include it
- // into the batch again.
- origRequest.SetSpan(*resumeSpan)
- resumeReq.reqs = append(resumeReq.reqs, origReq)
- resumeReq.positions = append(resumeReq.positions, req.positions[i])
- }
- }
- }
+ // First, we have to reconcile the memory budget. We do it
+ // separately from processing the results because we want to know
+ // how many Gets and Scans need to be allocated for the ResumeSpans,
+ // if any are present. At the moment, due to limitations of the KV
+ // layer (#75452) we cannot reuse original requests because the KV
+ // doesn't allow mutability.
+ memoryFootprintBytes, resumeReqsMemUsage, numIncompleteGets, numIncompleteScans := calculateFootprint(req, br)
// Now adjust the budget based on the actual memory footprint of
// non-empty responses as well as resume spans, if any.
respOverestimate := targetBytes - memoryFootprintBytes
- var reqsMemUsage int64
- if len(resumeReq.reqs) > 0 {
- reqsMemUsage = requestsMemUsage(resumeReq.reqs)
- }
- reqOveraccounted := req.reqsReservedBytes - reqsMemUsage
+ reqOveraccounted := req.reqsReservedBytes - resumeReqsMemUsage
overaccountedTotal := respOverestimate + reqOveraccounted
if overaccountedTotal >= 0 {
w.s.budget.release(ctx, overaccountedTotal)
@@ -1169,8 +1095,6 @@ func (w *workerCoordinator) performRequestAsync(
return
}
}
- // Update the resume request accordingly.
- resumeReq.reqsReservedBytes = reqsMemUsage
// Do admission control after we've finalized the memory accounting.
if br != nil && w.responseAdmissionQ != nil {
@@ -1185,19 +1109,12 @@ func (w *workerCoordinator) performRequestAsync(
}
}
- // If we have any results, finalize them.
- if len(results) > 0 {
- w.finalizeSingleRangeResults(
- results, memoryFootprintBytes, hasNonEmptyScanResponse,
- numCompleteGetResponses,
- )
- }
-
- // If we have any incomplete requests, add them back into the work
- // pool.
- if len(resumeReq.reqs) > 0 {
- w.addRequest(resumeReq)
- }
+ // Finally, process the results and add the ResumeSpans to be
+ // processed as well.
+ w.processSingleRangeResults(
+ req, br, memoryFootprintBytes, resumeReqsMemUsage,
+ numIncompleteGets, numIncompleteScans,
+ )
}); err != nil {
// The new goroutine for the request wasn't spun up, so we have to
// perform the cleanup of this request ourselves.
@@ -1206,6 +1123,198 @@ func (w *workerCoordinator) performRequestAsync(
}
}
+// calculateFootprint calculates the memory footprint of the batch response as
+// well as of the requests that will have to be created for the ResumeSpans.
+// - memoryFootprintBytes tracks the total memory footprint of non-empty
+// responses. This will be equal to the sum of memory tokens created for all
+// Results.
+// - resumeReqsMemUsage tracks the memory usage of the requests for the
+// ResumeSpans.
+func calculateFootprint(
+ req singleRangeBatch, br *roachpb.BatchResponse,
+) (
+ memoryFootprintBytes int64,
+ resumeReqsMemUsage int64,
+ numIncompleteGets, numIncompleteScans int,
+) {
+ // Note that we cannot use Size() methods that are automatically generated
+ // by the protobuf library because they account for things differently from
+ // how the memory usage is accounted for by the KV layer for the purposes of
+ // tracking TargetBytes limit.
+
+ // getRequestScratch and scanRequestScratch are used to calculate
+ // the size of requests when we set the ResumeSpans on them.
+ var getRequestScratch roachpb.GetRequest
+ var scanRequestScratch roachpb.ScanRequest
+ for i, resp := range br.Responses {
+ reply := resp.GetInner()
+ switch req.reqs[i].GetInner().(type) {
+ case *roachpb.GetRequest:
+ get := reply.(*roachpb.GetResponse)
+ if get.ResumeSpan != nil {
+ // This Get wasn't completed.
+ getRequestScratch.SetSpan(*get.ResumeSpan)
+ resumeReqsMemUsage += int64(getRequestScratch.Size())
+ numIncompleteGets++
+ } else {
+ // This Get was completed.
+ memoryFootprintBytes += getResponseSize(get)
+ }
+ case *roachpb.ScanRequest:
+ scan := reply.(*roachpb.ScanResponse)
+ if len(scan.Rows) > 0 || len(scan.BatchResponses) > 0 {
+ memoryFootprintBytes += scanResponseSize(scan)
+ }
+ if scan.ResumeSpan != nil {
+ // This Scan wasn't completed.
+ scanRequestScratch.SetSpan(*scan.ResumeSpan)
+ resumeReqsMemUsage += int64(scanRequestScratch.Size())
+ numIncompleteScans++
+ }
+ }
+ }
+ // This addendum is the first step of requestsMemUsage() and we've already
+ // added the size of each resume request above.
+ resumeReqsMemUsage += requestUnionOverhead * int64(numIncompleteGets+numIncompleteScans)
+ return memoryFootprintBytes, resumeReqsMemUsage, numIncompleteGets, numIncompleteScans
+}
+
+// processSingleRangeResults creates a Result for each non-empty response found
+// in the BatchResponse. The ResumeSpans, if found, are added into a new
+// singleRangeBatch request that is added to be picked up by the mainLoop of the
+// worker coordinator. This method assumes that req is no longer needed by the
+// caller, so req.positions is reused for the ResumeSpans.
+//
+// It also assumes that the budget has already been reconciled with the
+// reservations for Results that will be created.
+func (w *workerCoordinator) processSingleRangeResults(
+ req singleRangeBatch,
+ br *roachpb.BatchResponse,
+ memoryFootprintBytes int64,
+ resumeReqsMemUsage int64,
+ numIncompleteGets, numIncompleteScans int,
+) {
+ numIncompleteRequests := numIncompleteGets + numIncompleteScans
+ var resumeReq singleRangeBatch
+ // We have to allocate the new slice for requests, but we can reuse the
+ // positions slice.
+ resumeReq.reqs = make([]roachpb.RequestUnion, numIncompleteRequests)
+ // numIncompleteRequests will never exceed the number of requests in req.
+ resumeReq.positions = req.positions[:numIncompleteRequests]
+ // We've already reconciled the budget with the actual reservation for the
+ // requests with the ResumeSpans.
+ resumeReq.reqsReservedBytes = resumeReqsMemUsage
+ gets := make([]struct {
+ req roachpb.GetRequest
+ union roachpb.RequestUnion_Get
+ }, numIncompleteGets)
+ scans := make([]struct {
+ req roachpb.ScanRequest
+ union roachpb.RequestUnion_Scan
+ }, numIncompleteScans)
+ var results []Result
+ var numCompleteGetResponses int
+ var hasNonEmptyScanResponse bool
+ var resumeReqIdx int
+ // memoryTokensBytes accumulates all reservations that are made for all
+ // Results created below. The accounting for these reservations has already
+ // been performed, and memoryTokensBytes should be exactly equal to
+ // memoryFootprintBytes, so we use it only as an additional check.
+ var memoryTokensBytes int64
+ for i, resp := range br.Responses {
+ enqueueKey := req.positions[i]
+ if w.s.enqueueKeys != nil {
+ enqueueKey = w.s.enqueueKeys[req.positions[i]]
+ }
+ reply := resp.GetInner()
+ switch origRequest := req.reqs[i].GetInner().(type) {
+ case *roachpb.GetRequest:
+ get := reply.(*roachpb.GetResponse)
+ if get.ResumeSpan != nil {
+ // This Get wasn't completed - update the original
+ // request according to the ResumeSpan and include it
+ // into the batch again.
+ newGet := gets[0]
+ gets = gets[1:]
+ newGet.req.SetSpan(*get.ResumeSpan)
+ newGet.req.KeyLocking = origRequest.KeyLocking
+ newGet.union.Get = &newGet.req
+ resumeReq.reqs[resumeReqIdx].Value = &newGet.union
+ resumeReq.positions[resumeReqIdx] = req.positions[i]
+ resumeReqIdx++
+ } else {
+ // This Get was completed.
+ result := Result{
+ GetResp: get,
+ // This currently only works because all requests
+ // are unique.
+ EnqueueKeysSatisfied: []int{enqueueKey},
+ position: req.positions[i],
+ }
+ result.memoryTok.streamer = w.s
+ result.memoryTok.toRelease = getResponseSize(get)
+ memoryTokensBytes += result.memoryTok.toRelease
+ results = append(results, result)
+ numCompleteGetResponses++
+ }
+
+ case *roachpb.ScanRequest:
+ scan := reply.(*roachpb.ScanResponse)
+ if len(scan.Rows) > 0 || len(scan.BatchResponses) > 0 {
+ result := Result{
+ // This currently only works because all requests
+ // are unique.
+ EnqueueKeysSatisfied: []int{enqueueKey},
+ position: req.positions[i],
+ }
+ result.memoryTok.streamer = w.s
+ result.memoryTok.toRelease = scanResponseSize(scan)
+ memoryTokensBytes += result.memoryTok.toRelease
+ result.ScanResp.ScanResponse = scan
+ // Complete field will be set below.
+ results = append(results, result)
+ hasNonEmptyScanResponse = true
+ }
+ if scan.ResumeSpan != nil {
+ // This Scan wasn't completed - update the original
+ // request according to the ResumeSpan and include it
+ // into the batch again.
+ newScan := scans[0]
+ scans = scans[1:]
+ newScan.req.SetSpan(*scan.ResumeSpan)
+ newScan.req.KeyLocking = origRequest.KeyLocking
+ newScan.union.Scan = &newScan.req
+ resumeReq.reqs[resumeReqIdx].Value = &newScan.union
+ resumeReq.positions[resumeReqIdx] = req.positions[i]
+ resumeReqIdx++
+ }
+ }
+ }
+
+ if buildutil.CrdbTestBuild {
+ if memoryFootprintBytes != memoryTokensBytes {
+ panic(errors.AssertionFailedf(
+ "different calculation of memory footprint\ncalculateFootprint: %d bytes\n"+
+ "processSingleRangeResults: %d bytes", memoryFootprintBytes, memoryTokensBytes,
+ ))
+ }
+ }
+
+ // If we have any results, finalize them.
+ if len(results) > 0 {
+ w.finalizeSingleRangeResults(
+ results, memoryFootprintBytes, hasNonEmptyScanResponse,
+ numCompleteGetResponses,
+ )
+ }
+
+ // If we have any incomplete requests, add them back into the work
+ // pool.
+ if len(resumeReq.reqs) > 0 {
+ w.addRequest(resumeReq)
+ }
+}
+
// finalizeSingleRangeResults "finalizes" the results of evaluation of a
// singleRangeBatch. By "finalization" we mean setting Complete field of
// ScanResp to correct value for all scan responses, updating the estimate of an
@@ -1270,13 +1379,31 @@ func init() {
zeroIntSlice = make([]int, 1<<10)
}
-const requestUnionSliceOverhead = int64(unsafe.Sizeof([]roachpb.RequestUnion{}))
+const requestUnionOverhead = int64(unsafe.Sizeof(roachpb.RequestUnion{}))
func requestsMemUsage(reqs []roachpb.RequestUnion) int64 {
- memUsage := requestUnionSliceOverhead
- // Slice up to the capacity to account for everything.
- for _, r := range reqs[:cap(reqs)] {
+ // RequestUnion.Size() ignores the overhead of RequestUnion object, so we'll
+ // account for it separately first.
+ memUsage := requestUnionOverhead * int64(cap(reqs))
+ // No need to account for elements past len(reqs) because those must be
+ // unset and we have already accounted for RequestUnion object above.
+ for _, r := range reqs {
memUsage += int64(r.Size())
}
return memUsage
}
+
+// getResponseSize calculates the size of the GetResponse similar to how it is
+// accounted for TargetBytes parameter by the KV layer.
+func getResponseSize(get *roachpb.GetResponse) int64 {
+ if get.Value == nil {
+ return 0
+ }
+ return int64(len(get.Value.RawBytes))
+}
+
+// scanResponseSize calculates the size of the ScanResponse similar to how it is
+// accounted for TargetBytes parameter by the KV layer.
+func scanResponseSize(scan *roachpb.ScanResponse) int64 {
+ return scan.NumBytes
+}
diff --git a/pkg/kv/kvclient/kvstreamer/streamer_test.go b/pkg/kv/kvclient/kvstreamer/streamer_test.go
index 2183cbbd0f42..7b5ac7d45caf 100644
--- a/pkg/kv/kvclient/kvstreamer/streamer_test.go
+++ b/pkg/kv/kvclient/kvstreamer/streamer_test.go
@@ -12,6 +12,7 @@ package kvstreamer
import (
"context"
+ "fmt"
"math"
"testing"
@@ -28,6 +29,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/cockroachdb/cockroach/pkg/util/randutil"
+ "github.com/dustin/go-humanize"
"github.com/stretchr/testify/require"
)
@@ -269,3 +271,68 @@ func TestStreamerBudgetErrorInEnqueue(t *testing.T) {
require.Error(t, streamer.Enqueue(ctx, reqs, nil /* enqueueKeys */))
})
}
+
+// TestStreamerCorrectlyDiscardsResponses verifies that the Streamer behaves
+// correctly in a scenario when partial results are returned, but the original
+// memory reservation was under-provisioned and the budget cannot be reconciled,
+// so the responses have to be discarded.
+func TestStreamerCorrectlyDiscardsResponses(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+ defer log.Scope(t).Close(t)
+
+ // Start a cluster with large --max-sql-memory parameter so that the
+ // Streamer isn't hitting the root budget exceeded error.
+ s, db, _ := serverutils.StartServer(t, base.TestServerArgs{
+ SQLMemoryPoolSize: 1 << 30, /* 1GiB */
+ })
+ ctx := context.Background()
+ defer s.Stopper().Stop(ctx)
+
+ // The initial estimate for TargetBytes argument for each asynchronous
+ // request by the Streamer will be numRowsPerRange x initialAvgResponseSize,
+ // so we pick the blob size such that about half of rows are included in the
+ // partial responses.
+ const blobSize = 2 * initialAvgResponseSize
+ const numRows = 20
+ const numRowsPerRange = 4
+
+ _, err := db.Exec("CREATE TABLE t (pk INT PRIMARY KEY, k INT, blob STRING, INDEX (k))")
+ require.NoError(t, err)
+ for i := 0; i < numRows; i++ {
+ if i > 0 && i%numRowsPerRange == 0 {
+ // Create a new range for the next numRowsPerRange rows.
+ _, err = db.Exec(fmt.Sprintf("ALTER TABLE t SPLIT AT VALUES(%d)", i))
+ require.NoError(t, err)
+ }
+ _, err = db.Exec(fmt.Sprintf("INSERT INTO t SELECT %d, 1, repeat('a', %d)", i, blobSize))
+ require.NoError(t, err)
+ }
+
+ // Populate the range cache.
+ _, err = db.Exec("SELECT count(*) from t")
+ require.NoError(t, err)
+
+ // Perform an index join to read the blobs.
+ query := "SELECT sum(length(blob)) FROM t@t_k_idx WHERE k = 1"
+ // Use several different workmem limits to exercise somewhat different
+ // scenarios.
+ //
+ // All of these values allow for all initial requests to be issued
+ // asynchronously, but only for some of the responses to be "accepted" by
+ // the budget. This includes 4/3 factor since the vectorized ColIndexJoin
+ // gives 3/4 of the workmem limit to the Streamer.
+ for _, workmem := range []int{
+ 3 * initialAvgResponseSize * numRows / 2,
+ 7 * initialAvgResponseSize * numRows / 4,
+ 2 * initialAvgResponseSize * numRows,
+ } {
+ t.Run(fmt.Sprintf("workmem=%s", humanize.Bytes(uint64(workmem))), func(t *testing.T) {
+ _, err = db.Exec(fmt.Sprintf("SET distsql_workmem = '%dB'", workmem))
+ require.NoError(t, err)
+ row := db.QueryRow(query)
+ var sum int
+ require.NoError(t, row.Scan(&sum))
+ require.Equal(t, numRows*blobSize, sum)
+ })
+ }
+}
|
5c61dc38bd6a5b1c7deb1261c6b2f56b5993e37c
|
2020-06-16 02:01:11
|
Jackson Owens
|
ui: remove compactor queue graphs, metrics
| false
|
remove compactor queue graphs, metrics
|
ui
|
diff --git a/pkg/ui/src/views/cluster/containers/nodeGraphs/dashboards/queues.tsx b/pkg/ui/src/views/cluster/containers/nodeGraphs/dashboards/queues.tsx
index 50c89b77818e..67fff90da822 100644
--- a/pkg/ui/src/views/cluster/containers/nodeGraphs/dashboards/queues.tsx
+++ b/pkg/ui/src/views/cluster/containers/nodeGraphs/dashboards/queues.tsx
@@ -29,7 +29,6 @@ export default function (props: GraphDashboardProps) {
<Metric name="cr.store.queue.raftlog.process.failure" title="Raft Log" nonNegativeRate />
<Metric name="cr.store.queue.raftsnapshot.process.failure" title="Raft Snapshot" nonNegativeRate />
<Metric name="cr.store.queue.tsmaintenance.process.failure" title="Time Series Maintenance" nonNegativeRate />
- <Metric name="cr.store.compactor.compactions.failure" title="Compaction" nonNegativeRate />
</Axis>
</LineGraph>,
@@ -43,7 +42,6 @@ export default function (props: GraphDashboardProps) {
<Metric name="cr.store.queue.raftlog.processingnanos" title="Raft Log" nonNegativeRate />
<Metric name="cr.store.queue.raftsnapshot.processingnanos" title="Raft Snapshot" nonNegativeRate />
<Metric name="cr.store.queue.tsmaintenance.processingnanos" title="Time Series Maintenance" nonNegativeRate />
- <Metric name="cr.store.compactor.compactingnanos" title="Compaction" nonNegativeRate />
</Axis>
</LineGraph>,
@@ -120,16 +118,5 @@ export default function (props: GraphDashboardProps) {
<Metric name="cr.store.queue.tsmaintenance.pending" title="Pending Actions" downsampleMax />
</Axis>
</LineGraph>,
-
- <LineGraph
- title="Compaction Queue"
- sources={storeSources}
- tooltip={`The completed (or estimated) bytes of storage that were (or could be) reclaimed by forcing compactions.`}
- >
- <Axis units={AxisUnits.Bytes} label="bytes">
- <Metric name="cr.store.compactor.suggestionbytes.compacted" title="Bytes compacted / sec" nonNegativeRate />
- <Metric name="cr.store.compactor.suggestionbytes.queued" title="Queued bytes" downsampleMax />
- </Axis>
- </LineGraph>,
];
}
|
c0e0588e1c83a1db804ac73fc265988705de1008
|
2022-08-17 00:32:31
|
DrewKimball
|
sql: reset conn buffers after each query
| false
|
reset conn buffers after each query
|
sql
|
diff --git a/pkg/sql/pgwire/command_result.go b/pkg/sql/pgwire/command_result.go
index ef6bfc17bca5..e4f208f40ae7 100644
--- a/pkg/sql/pgwire/command_result.go
+++ b/pkg/sql/pgwire/command_result.go
@@ -161,11 +161,13 @@ func (r *commandResult) Close(ctx context.Context, t sql.TransactionStatusIndica
r.conn.bufferReadyForQuery(byte(t))
// The error is saved on conn.err.
_ /* err */ = r.conn.Flush(r.pos)
+ r.conn.maybeReallocate()
case emptyQueryResponse:
r.conn.bufferEmptyQueryResponse()
case flush:
// The error is saved on conn.err.
_ /* err */ = r.conn.Flush(r.pos)
+ r.conn.maybeReallocate()
case noCompletionMsg:
// nothing to do
default:
diff --git a/pkg/sql/pgwire/conn.go b/pkg/sql/pgwire/conn.go
index a50a722c9a4b..9b721fa10454 100644
--- a/pkg/sql/pgwire/conn.go
+++ b/pkg/sql/pgwire/conn.go
@@ -1593,12 +1593,30 @@ func (c *conn) Flush(pos sql.CmdPos) error {
// maybeFlush flushes the buffer to the network connection if it exceeded
// sessionArgs.ConnResultsBufferSize or if buffering is disabled.
func (c *conn) maybeFlush(pos sql.CmdPos, bufferingDisabled bool) error {
+ // Note that ConnResultsBufferSize cannot be changed during a session, so it
+ // is safe to use the value stored on sessionArgs.
if !bufferingDisabled && int64(c.writerState.buf.Len()) <= c.sessionArgs.ConnResultsBufferSize {
return nil
}
return c.Flush(pos)
}
+// maybeReallocate checks whether the internal slices used to buffer data have
+// overflowed their limits. If so, they will be reallocated to a smaller size.
+// maybeReallocate should only be called after the connection has been flushed
+// and a query has just been processed.
+func (c *conn) maybeReallocate() {
+ // Note that ConnResultsBufferSize cannot be changed during a session, so it
+ // is safe to use the value stored on sessionArgs.
+ limit := int(c.sessionArgs.ConnResultsBufferSize)
+ if c.msgBuilder.wrapped.Len() == 0 && c.msgBuilder.wrapped.Cap() > limit {
+ c.msgBuilder.wrapped = bytes.Buffer{}
+ }
+ if c.writerState.buf.Len() == 0 && c.writerState.buf.Cap() > limit {
+ c.writerState.buf = bytes.Buffer{}
+ }
+}
+
// LockCommunication is part of the ClientComm interface.
//
// The current implementation of conn writes results to the network
|
2dd254b133c97469bfb0dc7bd735777e6dbc5f57
|
2021-03-22 20:00:00
|
Tobias Grieger
|
tracing: elide logtag creation for noop span
| false
|
elide logtag creation for noop span
|
tracing
|
diff --git a/pkg/util/tracing/tracer.go b/pkg/util/tracing/tracer.go
index eaafc27c76ec..e1d960f8da92 100644
--- a/pkg/util/tracing/tracer.go
+++ b/pkg/util/tracing/tracer.go
@@ -289,16 +289,16 @@ func (t *Tracer) startSpanGeneric(
}
}
- if opts.LogTags == nil {
- opts.LogTags = logtags.FromContext(ctx)
- }
-
// Are we tracing everything, or have a parent, or want a real span? Then
// we create a real trace span. In all other cases, a noop span will do.
if !(t.AlwaysTrace() || opts.parentTraceID() != 0 || opts.ForceRealSpan) {
return maybeWrapCtx(ctx, nil /* octx */, t.noopSpan)
}
+ if opts.LogTags == nil {
+ opts.LogTags = logtags.FromContext(ctx)
+ }
+
if opts.LogTags == nil && opts.Parent != nil && !opts.Parent.i.isNoop() {
// If no log tags are specified in the options, use the parent
// span's, if any. This behavior is the reason logTags are
|
2975aadae5c1f51444bf1c202db8ba1afb3bf6e5
|
2018-10-31 00:39:12
|
David Taylor
|
storage: move addsstable command to open-source codebase
| false
|
move addsstable command to open-source codebase
|
storage
|
diff --git a/pkg/ccl/changefeedccl/poller.go b/pkg/ccl/changefeedccl/poller.go
index cf8d8b2201f5..b6eabebe649b 100644
--- a/pkg/ccl/changefeedccl/poller.go
+++ b/pkg/ccl/changefeedccl/poller.go
@@ -15,7 +15,6 @@ import (
"sync/atomic"
"time"
- "github.com/cockroachdb/cockroach/pkg/ccl/storageccl/engineccl"
"github.com/cockroachdb/cockroach/pkg/ccl/utilccl/intervalccl"
"github.com/cockroachdb/cockroach/pkg/gossip"
"github.com/cockroachdb/cockroach/pkg/internal/client"
@@ -514,7 +513,7 @@ func (p *poller) slurpSST(ctx context.Context, sst []byte, schemaTimestamp hlc.T
}
var scratch bufalloc.ByteAllocator
- it, err := engineccl.NewMemSSTIterator(sst, false /* verify */)
+ it, err := engine.NewMemSSTIterator(sst, false /* verify */)
if err != nil {
return err
}
diff --git a/pkg/ccl/changefeedccl/table_history.go b/pkg/ccl/changefeedccl/table_history.go
index 12b14f70ad29..a624c981aca9 100644
--- a/pkg/ccl/changefeedccl/table_history.go
+++ b/pkg/ccl/changefeedccl/table_history.go
@@ -20,7 +20,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/util/syncutil"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
- "github.com/cockroachdb/cockroach/pkg/ccl/storageccl/engineccl"
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/roachpb"
@@ -251,7 +250,7 @@ func fetchTableDescriptorVersions(
var tableDescs []*sqlbase.TableDescriptor
for _, file := range res.(*roachpb.ExportResponse).Files {
if err := func() error {
- it, err := engineccl.NewMemSSTIterator(file.SST, false /* verify */)
+ it, err := engine.NewMemSSTIterator(file.SST, false /* verify */)
if err != nil {
return err
}
diff --git a/pkg/ccl/storageccl/import.go b/pkg/ccl/storageccl/import.go
index b5fcba1abda3..088e4f68ccce 100644
--- a/pkg/ccl/storageccl/import.go
+++ b/pkg/ccl/storageccl/import.go
@@ -17,7 +17,6 @@ import (
"github.com/pkg/errors"
"github.com/cockroachdb/cockroach/pkg/base"
- "github.com/cockroachdb/cockroach/pkg/ccl/storageccl/engineccl"
"github.com/cockroachdb/cockroach/pkg/internal/client"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/settings"
@@ -164,7 +163,7 @@ func AddSSTable(ctx context.Context, db *client.DB, start, end roachpb.Key, sstB
func addSplitSSTable(
ctx context.Context, db *client.DB, sstBytes []byte, start, splitKey roachpb.Key,
) error {
- iter, err := engineccl.NewMemSSTIterator(sstBytes, false)
+ iter, err := engine.NewMemSSTIterator(sstBytes, false)
if err != nil {
return err
}
@@ -281,7 +280,7 @@ func evalImport(ctx context.Context, cArgs batcheval.CommandArgs) (*roachpb.Impo
}
}
- iter, err := engineccl.NewMemSSTIterator(fileContents, false)
+ iter, err := engine.NewMemSSTIterator(fileContents, false)
if err != nil {
return nil, err
}
@@ -297,7 +296,7 @@ func evalImport(ctx context.Context, cArgs batcheval.CommandArgs) (*roachpb.Impo
defer batcher.Close()
startKeyMVCC, endKeyMVCC := engine.MVCCKey{Key: args.DataSpan.Key}, engine.MVCCKey{Key: args.DataSpan.EndKey}
- iter := engineccl.MakeMultiIterator(iters)
+ iter := engine.MakeMultiIterator(iters)
defer iter.Close()
var keyScratch, valueScratch []byte
diff --git a/pkg/ccl/storageccl/add_sstable.go b/pkg/storage/batcheval/cmd_add_sstable.go
similarity index 82%
rename from pkg/ccl/storageccl/add_sstable.go
rename to pkg/storage/batcheval/cmd_add_sstable.go
index b6b50f0e5cf2..331431978f6f 100644
--- a/pkg/ccl/storageccl/add_sstable.go
+++ b/pkg/storage/batcheval/cmd_add_sstable.go
@@ -1,20 +1,24 @@
// Copyright 2017 The Cockroach Authors.
//
-// Licensed as a CockroachDB Enterprise file under the Cockroach Community
-// License (the "License"); you may not use this file except in compliance with
-// the License. You may obtain a copy of the License at
+/// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
//
-// https://github.com/cockroachdb/cockroach/blob/master/licenses/CCL.txt
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
-package storageccl
+package batcheval
import (
"context"
- "github.com/cockroachdb/cockroach/pkg/ccl/storageccl/engineccl"
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/roachpb"
- "github.com/cockroachdb/cockroach/pkg/storage/batcheval"
"github.com/cockroachdb/cockroach/pkg/storage/batcheval/result"
"github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/storage/engine/enginepb"
@@ -25,11 +29,12 @@ import (
)
func init() {
- batcheval.RegisterCommand(roachpb.AddSSTable, batcheval.DefaultDeclareKeys, evalAddSSTable)
+ RegisterCommand(roachpb.AddSSTable, DefaultDeclareKeys, EvalAddSSTable)
}
-func evalAddSSTable(
- ctx context.Context, batch engine.ReadWriter, cArgs batcheval.CommandArgs, _ roachpb.Response,
+// EvalAddSSTable evaluates an AddSSTable command.
+func EvalAddSSTable(
+ ctx context.Context, batch engine.ReadWriter, cArgs CommandArgs, _ roachpb.Response,
) (result.Result, error) {
args := cArgs.Args.(*roachpb.AddSSTableRequest)
h := cArgs.Header
@@ -88,7 +93,7 @@ func verifySSTable(
// we a) pass a verify flag on the iterator so that as ComputeStatsGo calls
// Next, we're also verifying each KV pair. We explicitly check the first key
// is >= start and then that we do not find a key after end.
- dataIter, err := engineccl.NewMemSSTIterator(data, true)
+ dataIter, err := engine.NewMemSSTIterator(data, true)
if err != nil {
return enginepb.MVCCStats{}, err
}
@@ -111,7 +116,7 @@ func verifySSTable(
// ordering. So it's important that the sstable iterator comes after the one
// for the existing data (because the sstable will overwrite it when
// ingested).
- mergedIter := engineccl.MakeMultiIterator([]engine.SimpleIterator{existingIter, dataIter})
+ mergedIter := engine.MakeMultiIterator([]engine.SimpleIterator{existingIter, dataIter})
defer mergedIter.Close()
stats, err := engine.ComputeStatsGo(mergedIter, start, end, nowNanos)
diff --git a/pkg/ccl/storageccl/add_sstable_test.go b/pkg/storage/batcheval/cmd_add_sstable_test.go
similarity index 95%
rename from pkg/ccl/storageccl/add_sstable_test.go
rename to pkg/storage/batcheval/cmd_add_sstable_test.go
index 986bd122ad21..2360cf50f209 100644
--- a/pkg/ccl/storageccl/add_sstable_test.go
+++ b/pkg/storage/batcheval/cmd_add_sstable_test.go
@@ -1,12 +1,18 @@
// Copyright 2017 The Cockroach Authors.
//
-// Licensed as a CockroachDB Enterprise file under the Cockroach Community
-// License (the "License"); you may not use this file except in compliance with
-// the License. You may obtain a copy of the License at
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
//
-// https://github.com/cockroachdb/cockroach/blob/master/licenses/CCL.txt
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
-package storageccl
+package batcheval_test
import (
"bytes"
@@ -345,7 +351,7 @@ func TestAddSSTableMVCCStats(t *testing.T) {
},
Stats: &enginepb.MVCCStats{},
}
- _, err := evalAddSSTable(ctx, e, cArgs, nil)
+ _, err := batcheval.EvalAddSSTable(ctx, e, cArgs, nil)
if err != nil {
t.Fatalf("%+v", err)
}
diff --git a/pkg/storage/batcheval/main_test.go b/pkg/storage/batcheval/main_test.go
new file mode 100644
index 000000000000..70e5c6a2a0b8
--- /dev/null
+++ b/pkg/storage/batcheval/main_test.go
@@ -0,0 +1,42 @@
+// Copyright 2015 The Cockroach Authors.
+//
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
+
+package batcheval_test
+
+import (
+ "os"
+ "testing"
+
+ "github.com/cockroachdb/cockroach/pkg/security"
+ "github.com/cockroachdb/cockroach/pkg/security/securitytest"
+ "github.com/cockroachdb/cockroach/pkg/server"
+ "github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
+ "github.com/cockroachdb/cockroach/pkg/testutils/testcluster"
+ "github.com/cockroachdb/cockroach/pkg/util/randutil"
+)
+
+//go:generate ../../util/leaktest/add-leaktest.sh *_test.go
+
+func init() {
+ security.SetAssetLoader(securitytest.EmbeddedAssets)
+}
+func TestMain(m *testing.M) {
+ randutil.SeedForTests()
+ serverutils.InitTestServerFactory(server.TestServerFactory)
+ serverutils.InitTestClusterFactory(testcluster.TestClusterFactory)
+
+ code := m.Run()
+
+ os.Exit(code)
+}
diff --git a/pkg/ccl/storageccl/engineccl/multi_iterator.go b/pkg/storage/engine/multi_iterator.go
similarity index 86%
rename from pkg/ccl/storageccl/engineccl/multi_iterator.go
rename to pkg/storage/engine/multi_iterator.go
index 1446025c4a5e..7edf3767f98b 100644
--- a/pkg/ccl/storageccl/engineccl/multi_iterator.go
+++ b/pkg/storage/engine/multi_iterator.go
@@ -1,25 +1,30 @@
// Copyright 2017 The Cockroach Authors.
//
-// Licensed as a CockroachDB Enterprise file under the Cockroach Community
-// License (the "License"); you may not use this file except in compliance with
-// the License. You may obtain a copy of the License at
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
//
-// https://github.com/cockroachdb/cockroach/blob/master/licenses/CCL.txt
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
-package engineccl
+package engine
import (
"bytes"
"github.com/cockroachdb/cockroach/pkg/keys"
- "github.com/cockroachdb/cockroach/pkg/storage/engine"
)
const invalidIdxSentinel = -1
-// multiIterator multiplexes iteration over a number of engine.Iterators.
+// multiIterator multiplexes iteration over a number of Iterators.
type multiIterator struct {
- iters []engine.SimpleIterator
+ iters []SimpleIterator
// The index into `iters` of the iterator currently being pointed at.
currentIdx int
// The indexes of every iterator with the same key as the one in currentIdx.
@@ -34,16 +39,16 @@ type multiIterator struct {
err error
}
-var _ engine.SimpleIterator = &multiIterator{}
+var _ SimpleIterator = &multiIterator{}
// MakeMultiIterator creates an iterator that multiplexes
-// engine.SimpleIterators. The caller is responsible for closing the passed
+// SimpleIterators. The caller is responsible for closing the passed
// iterators after closing the returned multiIterator.
//
// If two iterators have an entry with exactly the same key and timestamp, the
// one with a higher index in this constructor arg is preferred. The other is
// skipped.
-func MakeMultiIterator(iters []engine.SimpleIterator) engine.SimpleIterator {
+func MakeMultiIterator(iters []SimpleIterator) SimpleIterator {
return &multiIterator{
iters: iters,
currentIdx: invalidIdxSentinel,
@@ -58,7 +63,7 @@ func (f *multiIterator) Close() {
// Seek advances the iterator to the first key in the engine which is >= the
// provided key.
-func (f *multiIterator) Seek(key engine.MVCCKey) {
+func (f *multiIterator) Seek(key MVCCKey) {
for _, iter := range f.iters {
iter.Seek(key)
}
@@ -81,7 +86,7 @@ func (f *multiIterator) Valid() (bool, error) {
// UnsafeKey returns the current key, but the memory is invalidated on the next
// call to {NextKey,Seek}.
-func (f *multiIterator) UnsafeKey() engine.MVCCKey {
+func (f *multiIterator) UnsafeKey() MVCCKey {
return f.iters[f.currentIdx].UnsafeKey()
}
@@ -135,7 +140,7 @@ func (f *multiIterator) advance() {
// Fill proposedMVCCKey with the mvcc key of the current best for the
// next value for currentIdx (or a sentinel that sorts after everything
// if this is the first non-exhausted iterator).
- proposedMVCCKey := engine.MVCCKey{Key: keys.MaxKey}
+ proposedMVCCKey := MVCCKey{Key: keys.MaxKey}
if proposedNextIdx != invalidIdxSentinel {
proposedMVCCKey = f.iters[proposedNextIdx].UnsafeKey()
}
diff --git a/pkg/ccl/storageccl/engineccl/multi_iterator_test.go b/pkg/storage/engine/multi_iterator_test.go
similarity index 78%
rename from pkg/ccl/storageccl/engineccl/multi_iterator_test.go
rename to pkg/storage/engine/multi_iterator_test.go
index 1a1a97639612..d7378bcc6536 100644
--- a/pkg/ccl/storageccl/engineccl/multi_iterator_test.go
+++ b/pkg/storage/engine/multi_iterator_test.go
@@ -1,12 +1,18 @@
// Copyright 2017 The Cockroach Authors.
//
-// Licensed as a CockroachDB Enterprise file under the Cockroach Community
-// License (the "License"); you may not use this file except in compliance with
-// the License. You may obtain a copy of the License at
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
//
-// https://github.com/cockroachdb/cockroach/blob/master/licenses/CCL.txt
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
-package engineccl
+package engine
import (
"bytes"
@@ -15,7 +21,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/roachpb"
- "github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
@@ -23,7 +28,7 @@ import (
func TestMultiIterator(t *testing.T) {
defer leaktest.AfterTest(t)()
- rocksDB := engine.NewInMem(roachpb.Attributes{}, 1<<20)
+ rocksDB := NewInMem(roachpb.Attributes{}, 1<<20)
defer rocksDB.Close()
// Each `input` is turned into an iterator and these are passed to a new
@@ -75,7 +80,7 @@ func TestMultiIterator(t *testing.T) {
for _, test := range tests {
name := fmt.Sprintf("%q", test.inputs)
t.Run(name, func(t *testing.T) {
- var iters []engine.SimpleIterator
+ var iters []SimpleIterator
for _, input := range test.inputs {
batch := rocksDB.NewBatch()
defer batch.Close()
@@ -96,11 +101,11 @@ func TestMultiIterator(t *testing.T) {
v = []byte{input[i+1]}
}
i += 2
- if err := batch.Put(engine.MVCCKey{Key: k, Timestamp: ts}, v); err != nil {
+ if err := batch.Put(MVCCKey{Key: k, Timestamp: ts}, v); err != nil {
t.Fatalf("%+v", err)
}
}
- iter := batch.NewIterator(engine.IterOptions{UpperBound: roachpb.KeyMax})
+ iter := batch.NewIterator(IterOptions{UpperBound: roachpb.KeyMax})
defer iter.Close()
iters = append(iters, iter)
}
@@ -108,16 +113,16 @@ func TestMultiIterator(t *testing.T) {
subtests := []struct {
name string
expected string
- fn func(engine.SimpleIterator)
+ fn func(SimpleIterator)
}{
- {"NextKey", test.expectedNextKey, (engine.SimpleIterator).NextKey},
- {"Next", test.expectedNext, (engine.SimpleIterator).Next},
+ {"NextKey", test.expectedNextKey, (SimpleIterator).NextKey},
+ {"Next", test.expectedNext, (SimpleIterator).Next},
}
for _, subtest := range subtests {
t.Run(subtest.name, func(t *testing.T) {
var output bytes.Buffer
it := MakeMultiIterator(iters)
- for it.Seek(engine.MVCCKey{Key: keys.MinKey}); ; subtest.fn(it) {
+ for it.Seek(MVCCKey{Key: keys.MinKey}); ; subtest.fn(it) {
ok, err := it.Valid()
if err != nil {
t.Fatalf("unexpected error: %+v", err)
diff --git a/pkg/ccl/storageccl/engineccl/sst_iterator.go b/pkg/storage/engine/sst_iterator.go
similarity index 75%
rename from pkg/ccl/storageccl/engineccl/sst_iterator.go
rename to pkg/storage/engine/sst_iterator.go
index 3ac7fdabdc8a..3578f9e3ff09 100644
--- a/pkg/ccl/storageccl/engineccl/sst_iterator.go
+++ b/pkg/storage/engine/sst_iterator.go
@@ -1,12 +1,18 @@
// Copyright 2017 The Cockroach Authors.
//
-// Licensed as a CockroachDB Enterprise file under the Cockroach Community
-// License (the "License"); you may not use this file except in compliance with
-// the License. You may obtain a copy of the License at
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
//
-// https://github.com/cockroachdb/cockroach/blob/master/licenses/CCL.txt
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
-package engineccl
+package engine
import (
"bytes"
@@ -18,7 +24,6 @@ import (
"github.com/pkg/errors"
"github.com/cockroachdb/cockroach/pkg/roachpb"
- "github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/storage/engine/enginepb"
)
@@ -32,7 +37,7 @@ type sstIterator struct {
valid bool
err error
- mvccKey engine.MVCCKey
+ mvccKey MVCCKey
// For allocation avoidance in NextKey.
nextKeyStart []byte
@@ -46,13 +51,13 @@ type sstIterator struct {
verify bool
}
-var _ engine.SimpleIterator = &sstIterator{}
+var _ SimpleIterator = &sstIterator{}
// NewSSTIterator returns a SimpleIterator for a leveldb formatted sstable on
-// disk. It's compatible with sstables output by engine.RocksDBSstFileWriter,
+// disk. It's compatible with sstables output by RocksDBSstFileWriter,
// which means the keys are CockroachDB mvcc keys and they each have the RocksDB
// trailer (of seqno & value type).
-func NewSSTIterator(path string) (engine.SimpleIterator, error) {
+func NewSSTIterator(path string) (SimpleIterator, error) {
file, err := db.DefaultFileSystem.Open(path)
if err != nil {
return nil, err
@@ -61,10 +66,10 @@ func NewSSTIterator(path string) (engine.SimpleIterator, error) {
}
// NewMemSSTIterator returns a SimpleIterator for a leveldb format sstable in
-// memory. It's compatible with sstables output by engine.RocksDBSstFileWriter,
+// memory. It's compatible with sstables output by RocksDBSstFileWriter,
// which means the keys are CockroachDB mvcc keys and they each have the RocksDB
// trailer (of seqno & value type).
-func NewMemSSTIterator(data []byte, verify bool) (engine.SimpleIterator, error) {
+func NewMemSSTIterator(data []byte, verify bool) (SimpleIterator, error) {
fs := memfs.New()
const filename = "data.sst"
f, err := fs.Create(filename)
@@ -85,7 +90,7 @@ func NewMemSSTIterator(data []byte, verify bool) (engine.SimpleIterator, error)
return &sstIterator{fs: fs, sst: table.NewReader(file, readerOpts), verify: verify}, nil
}
-// Close implements the engine.SimpleIterator interface.
+// Close implements the SimpleIterator interface.
func (r *sstIterator) Close() {
if r.iter != nil {
r.err = errors.Wrap(r.iter.Close(), "closing sstable iterator")
@@ -95,23 +100,23 @@ func (r *sstIterator) Close() {
}
}
-// Seek implements the engine.SimpleIterator interface.
-func (r *sstIterator) Seek(key engine.MVCCKey) {
+// Seek implements the SimpleIterator interface.
+func (r *sstIterator) Seek(key MVCCKey) {
if r.iter != nil {
if r.err = errors.Wrap(r.iter.Close(), "resetting sstable iterator"); r.err != nil {
return
}
}
- r.iter = r.sst.Find(engine.EncodeKey(key), nil)
+ r.iter = r.sst.Find(EncodeKey(key), nil)
r.Next()
}
-// Valid implements the engine.SimpleIterator interface.
+// Valid implements the SimpleIterator interface.
func (r *sstIterator) Valid() (bool, error) {
return r.valid && r.err == nil, r.err
}
-// Next implements the engine.SimpleIterator interface.
+// Next implements the SimpleIterator interface.
func (r *sstIterator) Next() {
if r.valid = r.iter.Next(); !r.valid {
return
@@ -126,7 +131,7 @@ func (r *sstIterator) Next() {
return
}
seqAndValueType := binary.LittleEndian.Uint64(rocksdbInternalKey[len(rocksdbInternalKey)-8:])
- if valueType := engine.BatchType(seqAndValueType & 0xff); valueType != engine.BatchTypeValue {
+ if valueType := BatchType(seqAndValueType & 0xff); valueType != BatchTypeValue {
r.err = errors.Errorf("value type not supported: %d", valueType)
return
}
@@ -147,7 +152,7 @@ func (r *sstIterator) Next() {
}
}
-// NextKey implements the engine.SimpleIterator interface.
+// NextKey implements the SimpleIterator interface.
func (r *sstIterator) NextKey() {
if !r.valid {
return
@@ -157,12 +162,12 @@ func (r *sstIterator) NextKey() {
}
}
-// UnsafeKey implements the engine.SimpleIterator interface.
-func (r *sstIterator) UnsafeKey() engine.MVCCKey {
+// UnsafeKey implements the SimpleIterator interface.
+func (r *sstIterator) UnsafeKey() MVCCKey {
return r.mvccKey
}
-// UnsafeValue implements the engine.SimpleIterator interface.
+// UnsafeValue implements the SimpleIterator interface.
func (r *sstIterator) UnsafeValue() []byte {
return r.iter.Value()
}
diff --git a/pkg/ccl/storageccl/engineccl/sst_iterator_test.go b/pkg/storage/engine/sst_iterator_test.go
similarity index 73%
rename from pkg/ccl/storageccl/engineccl/sst_iterator_test.go
rename to pkg/storage/engine/sst_iterator_test.go
index ea534de43ea5..2ad2075c1f8e 100644
--- a/pkg/ccl/storageccl/engineccl/sst_iterator_test.go
+++ b/pkg/storage/engine/sst_iterator_test.go
@@ -1,12 +1,18 @@
// Copyright 2017 The Cockroach Authors.
//
-// Licensed as a CockroachDB Enterprise file under the Cockroach Community
-// License (the "License"); you may not use this file except in compliance with
-// the License. You may obtain a copy of the License at
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
//
-// https://github.com/cockroachdb/cockroach/blob/master/licenses/CCL.txt
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License.
-package engineccl
+package engine
import (
"io/ioutil"
@@ -14,19 +20,18 @@ import (
"reflect"
"testing"
- "github.com/cockroachdb/cockroach/pkg/storage/engine"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
)
-func runTestSSTIterator(t *testing.T, iter engine.SimpleIterator, allKVs []engine.MVCCKeyValue) {
+func runTestSSTIterator(t *testing.T, iter SimpleIterator, allKVs []MVCCKeyValue) {
// Drop the first kv so we can test Seek.
expected := allKVs[1:]
// Run the test multiple times to check re-Seeking.
for i := 0; i < 3; i++ {
- var kvs []engine.MVCCKeyValue
+ var kvs []MVCCKeyValue
for iter.Seek(expected[0].Key); ; iter.Next() {
ok, err := iter.Valid()
if err != nil {
@@ -35,8 +40,8 @@ func runTestSSTIterator(t *testing.T, iter engine.SimpleIterator, allKVs []engin
if !ok {
break
}
- kv := engine.MVCCKeyValue{
- Key: engine.MVCCKey{
+ kv := MVCCKeyValue{
+ Key: MVCCKey{
Key: append([]byte(nil), iter.UnsafeKey().Key...),
Timestamp: iter.UnsafeKey().Timestamp,
},
@@ -59,15 +64,15 @@ func runTestSSTIterator(t *testing.T, iter engine.SimpleIterator, allKVs []engin
func TestSSTIterator(t *testing.T) {
defer leaktest.AfterTest(t)()
- sst, err := engine.MakeRocksDBSstFileWriter()
+ sst, err := MakeRocksDBSstFileWriter()
if err != nil {
t.Fatalf("%+v", err)
}
defer sst.Close()
- var allKVs []engine.MVCCKeyValue
+ var allKVs []MVCCKeyValue
for i := byte(0); i < 10; i++ {
- kv := engine.MVCCKeyValue{
- Key: engine.MVCCKey{
+ kv := MVCCKeyValue{
+ Key: MVCCKey{
Key: []byte{i},
Timestamp: hlc.Timestamp{WallTime: int64(i)},
},
@@ -112,18 +117,18 @@ func TestSSTIterator(t *testing.T) {
func TestCockroachComparer(t *testing.T) {
defer leaktest.AfterTest(t)()
- keyAMetadata := engine.EncodeKey(engine.MVCCKey{
+ keyAMetadata := EncodeKey(MVCCKey{
Key: []byte("a"),
})
- keyA2 := engine.EncodeKey(engine.MVCCKey{
+ keyA2 := EncodeKey(MVCCKey{
Key: []byte("a"),
Timestamp: hlc.Timestamp{WallTime: 2},
})
- keyA1 := engine.EncodeKey(engine.MVCCKey{
+ keyA1 := EncodeKey(MVCCKey{
Key: []byte("a"),
Timestamp: hlc.Timestamp{WallTime: 1},
})
- keyB2 := engine.EncodeKey(engine.MVCCKey{
+ keyB2 := EncodeKey(MVCCKey{
Key: []byte("b"),
Timestamp: hlc.Timestamp{WallTime: 2},
})
|
bf1a024a9d6b4bc2442182d87642f35600964315
|
2018-03-06 22:16:13
|
Pete Vilter
|
ui: clusterviz: add rect to NodeView to make it more clickable
| false
|
clusterviz: add rect to NodeView to make it more clickable
|
ui
|
diff --git a/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeView.tsx b/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeView.tsx
index d2a0a8e68a72..7faecbde658d 100644
--- a/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeView.tsx
+++ b/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeView.tsx
@@ -88,6 +88,7 @@ export class NodeView extends React.Component<NodeViewProps> {
style={{ cursor: "pointer" }}
>
<g transform={`translate(${TRANSLATE_X},${TRANSLATE_Y})scale(${SCALE_FACTOR})`}>
+ <rect width={180} height={210} opacity={0} />
<Labels
label={`Node ${node.desc.node_id}`}
subLabel={this.getUptimeText()}
|
e3286a74e3ddc50cbb5feac0b64bf8fcc14fcf3d
|
2020-03-26 01:25:17
|
David Taylor
|
workload: set application_name
| false
|
set application_name
|
workload
|
diff --git a/pkg/workload/connection.go b/pkg/workload/connection.go
index e4cdc196a19a..535a2a3e1b74 100644
--- a/pkg/workload/connection.go
+++ b/pkg/workload/connection.go
@@ -66,6 +66,10 @@ func SanitizeUrls(gen Generator, dbOverride string, urls []string) (string, erro
}
parsed.Path = dbName
+ q := parsed.Query()
+ q.Set("application_name", gen.Meta().Name)
+ parsed.RawQuery = q.Encode()
+
switch parsed.Scheme {
case "postgres", "postgresql":
urls[i] = parsed.String()
|
2a2e749432af2aec66ae4d551076b4a621ee54c1
|
2021-06-11 03:25:27
|
Andrei Matei
|
kvserver: don't reset local keys in tscache on r1 lease move
| false
|
don't reset local keys in tscache on r1 lease move
|
kvserver
|
diff --git a/pkg/keys/constants.go b/pkg/keys/constants.go
index 24248f496408..36d72ccc7163 100644
--- a/pkg/keys/constants.go
+++ b/pkg/keys/constants.go
@@ -22,9 +22,7 @@ import (
// These constants are single bytes for performance. They allow single-byte
// comparisons which are considerably faster than bytes.HasPrefix.
const (
- LocalPrefixByte = '\x01'
- localMaxByte = '\x02'
- meta1PrefixByte = localMaxByte
+ meta1PrefixByte = roachpb.LocalMaxByte
meta2PrefixByte = '\x03'
metaMaxByte = '\x04'
systemPrefixByte = metaMaxByte
@@ -43,10 +41,9 @@ var (
MaxKey = roachpb.KeyMax
// LocalPrefix is the prefix for all local keys.
- LocalPrefix = roachpb.Key{LocalPrefixByte}
- // LocalMax is the end of the local key range. It is itself a global
- // key.
- LocalMax = roachpb.Key{localMaxByte}
+ LocalPrefix = roachpb.LocalPrefix
+ // LocalMax is the end of the local key range. It is itself a global key.
+ LocalMax = roachpb.LocalMax
// localSuffixLength specifies the length in bytes of all local
// key suffixes.
diff --git a/pkg/kv/kvserver/BUILD.bazel b/pkg/kv/kvserver/BUILD.bazel
index 3008ab075cf4..82fef9bcc50d 100644
--- a/pkg/kv/kvserver/BUILD.bazel
+++ b/pkg/kv/kvserver/BUILD.bazel
@@ -265,6 +265,7 @@ go_test(
"replica_sst_snapshot_storage_test.go",
"replica_stats_test.go",
"replica_test.go",
+ "replica_tscache_test.go",
"replicate_queue_test.go",
"replicate_test.go",
"reset_quorum_test.go",
@@ -321,10 +322,12 @@ go_test(
"//pkg/kv/kvserver/protectedts/ptverifier",
"//pkg/kv/kvserver/raftentry",
"//pkg/kv/kvserver/rditer",
+ "//pkg/kv/kvserver/readsummary/rspb",
"//pkg/kv/kvserver/spanset",
"//pkg/kv/kvserver/split",
"//pkg/kv/kvserver/stateloader",
"//pkg/kv/kvserver/tenantrate",
+ "//pkg/kv/kvserver/tscache",
"//pkg/kv/kvserver/txnwait",
"//pkg/roachpb",
"//pkg/rpc",
diff --git a/pkg/kv/kvserver/rditer/replica_data_iter.go b/pkg/kv/kvserver/rditer/replica_data_iter.go
index 41f26435e61a..3888afb50067 100644
--- a/pkg/kv/kvserver/rditer/replica_data_iter.go
+++ b/pkg/kv/kvserver/rditer/replica_data_iter.go
@@ -189,16 +189,10 @@ func makeRangeLockTableKeyRanges(d *roachpb.RangeDescriptor) [2]KeyRange {
// MakeUserKeyRange returns the user key range.
func MakeUserKeyRange(d *roachpb.RangeDescriptor) KeyRange {
- // The first range in the keyspace starts at KeyMin, which includes the
- // node-local space. We need the original StartKey to find the range
- // metadata, but the actual data starts at LocalMax.
- dataStartKey := d.StartKey.AsRawKey()
- if d.StartKey.Equal(roachpb.RKeyMin) {
- dataStartKey = keys.LocalMax
- }
+ userKeys := d.KeySpan()
return KeyRange{
- Start: storage.MakeMVCCMetadataKey(dataStartKey),
- End: storage.MakeMVCCMetadataKey(d.EndKey.AsRawKey()),
+ Start: storage.MakeMVCCMetadataKey(userKeys.Key.AsRawKey()),
+ End: storage.MakeMVCCMetadataKey(userKeys.EndKey.AsRawKey()),
}
}
diff --git a/pkg/kv/kvserver/replica_tscache.go b/pkg/kv/kvserver/replica_tscache.go
index 8db84d930c26..27949b944102 100644
--- a/pkg/kv/kvserver/replica_tscache.go
+++ b/pkg/kv/kvserver/replica_tscache.go
@@ -586,10 +586,12 @@ func collectReadSummaryFromTimestampCache(
keys.MakeRangeKeyPrefix(desc.StartKey),
keys.MakeRangeKeyPrefix(desc.EndKey),
)
+ userKeys := desc.KeySpan()
s.Global.LowWater, _ = tc.GetMax(
- desc.StartKey.AsRawKey(),
- desc.EndKey.AsRawKey(),
+ userKeys.Key.AsRawKey(),
+ userKeys.EndKey.AsRawKey(),
)
+
return s
}
@@ -606,9 +608,10 @@ func applyReadSummaryToTimestampCache(
s.Local.LowWater,
uuid.Nil, /* txnID */
)
+ userKeys := desc.KeySpan()
tc.Add(
- desc.StartKey.AsRawKey(),
- desc.EndKey.AsRawKey(),
+ userKeys.Key.AsRawKey(),
+ userKeys.EndKey.AsRawKey(),
s.Global.LowWater,
uuid.Nil, /* txnID */
)
diff --git a/pkg/kv/kvserver/replica_tscache_test.go b/pkg/kv/kvserver/replica_tscache_test.go
new file mode 100644
index 000000000000..938cfc32d123
--- /dev/null
+++ b/pkg/kv/kvserver/replica_tscache_test.go
@@ -0,0 +1,100 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+package kvserver
+
+import (
+ "testing"
+ "time"
+
+ "github.com/cockroachdb/cockroach/pkg/keys"
+ "github.com/cockroachdb/cockroach/pkg/kv/kvserver/readsummary/rspb"
+ "github.com/cockroachdb/cockroach/pkg/kv/kvserver/tscache"
+ "github.com/cockroachdb/cockroach/pkg/roachpb"
+ "github.com/cockroachdb/cockroach/pkg/util/hlc"
+ "github.com/cockroachdb/cockroach/pkg/util/leaktest"
+ "github.com/cockroachdb/cockroach/pkg/util/log"
+ "github.com/cockroachdb/cockroach/pkg/util/uuid"
+ "github.com/stretchr/testify/require"
+)
+
+// Test that, when applying the read summary for the range containing the
+// beginning of the key space to the timestamp cache, the local keyspace is not
+// generally bumped. The first range is special in that its descriptor declares
+// that it includes the local keyspace (\x01...), except that key space is
+// special and is not included in any range. applyReadToTimestampCache has
+// special provisions for this.
+func TestReadSummaryApplyForR1(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+ defer log.Scope(t).Close(t)
+
+ baseTS := hlc.Timestamp{WallTime: 123}
+ manual := hlc.NewManualClock(baseTS.WallTime)
+ clock := hlc.NewClock(manual.UnixNano, time.Nanosecond)
+ tc := tscache.New(clock)
+
+ r1desc := roachpb.RangeDescriptor{
+ RangeID: 1,
+ StartKey: roachpb.RKeyMin,
+ EndKey: roachpb.RKeyMax,
+ }
+ ts1 := hlc.Timestamp{WallTime: 1000}
+ summary := rspb.ReadSummary{
+ Local: rspb.Segment{LowWater: ts1},
+ Global: rspb.Segment{LowWater: ts1},
+ }
+ applyReadSummaryToTimestampCache(tc, &r1desc, summary)
+ tc.GetMax(keys.LocalPrefix, nil)
+
+ // Make sure that updating the tscache did something, so the test is not
+ // fooling itself.
+ ts, _ := tc.GetMax(roachpb.Key("a"), nil)
+ require.Equal(t, ts1, ts)
+
+ // Check that the local keyspace was not affected.
+ ts, _ = tc.GetMax(keys.LocalPrefix, nil)
+ require.Equal(t, baseTS, ts)
+
+ // Check that the range-local keyspace for the range in question was affected.
+ ts, _ = tc.GetMax(keys.MakeRangeKeyPrefix(r1desc.StartKey), nil)
+ require.Equal(t, ts1, ts)
+}
+
+// This is the counter-part to TestReadSummaryApplyForR1, checking that the
+// summary collection for first range has special logic avoiding the range-local
+// keyspace.
+func TestReadSummaryCollectForR1(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+ defer log.Scope(t).Close(t)
+
+ baseTS := hlc.Timestamp{WallTime: 123}
+ manual := hlc.NewManualClock(baseTS.WallTime)
+ clock := hlc.NewClock(manual.UnixNano, time.Nanosecond)
+ tc := tscache.New(clock)
+
+ r1desc := roachpb.RangeDescriptor{
+ RangeID: 1,
+ StartKey: roachpb.RKeyMin,
+ EndKey: roachpb.RKey("a"),
+ }
+ r2desc := roachpb.RangeDescriptor{
+ RangeID: 1,
+ StartKey: roachpb.RKey("a"),
+ EndKey: roachpb.RKeyMax,
+ }
+ // Populate the timestamp cache for a range-local key for r2.
+ tc.Add(keys.MakeRangeKeyPrefix(r2desc.StartKey), nil, hlc.Timestamp{WallTime: 1000}, uuid.Nil)
+
+ // Assert that r1's summary was not influenced by the r2 range-local key we
+ // set above.
+ summary := collectReadSummaryFromTimestampCache(tc, &r1desc)
+ require.Equal(t, baseTS, summary.Global.LowWater)
+ require.Equal(t, baseTS, summary.Local.LowWater)
+}
diff --git a/pkg/roachpb/data.go b/pkg/roachpb/data.go
index dc4cfd53ba6e..584f9a13e7bb 100644
--- a/pkg/roachpb/data.go
+++ b/pkg/roachpb/data.go
@@ -45,6 +45,12 @@ import (
"go.etcd.io/etcd/raft/v3/raftpb"
)
+const (
+ localPrefixByte = '\x01'
+ // LocalMaxByte is the end of the local key range.
+ LocalMaxByte = '\x02'
+)
+
var (
// RKeyMin is a minimum key value which sorts before all other keys.
RKeyMin = RKey("")
@@ -55,6 +61,11 @@ var (
// KeyMax is a maximum key value which sorts after all other keys.
KeyMax = Key(RKeyMax)
+ // LocalPrefix is the prefix for all local keys.
+ LocalPrefix = Key{localPrefixByte}
+ // LocalMax is the end of the local key range. It is itself a global key.
+ LocalMax = Key{LocalMaxByte}
+
// PrettyPrintKey prints a key in human readable format. It's
// implemented in package git.com/cockroachdb/cockroach/keys to avoid
// package circle import.
diff --git a/pkg/roachpb/metadata.go b/pkg/roachpb/metadata.go
index e402e105afd7..5c6b42dd113e 100644
--- a/pkg/roachpb/metadata.go
+++ b/pkg/roachpb/metadata.go
@@ -199,6 +199,26 @@ func (r *RangeDescriptor) RSpan() RSpan {
return RSpan{Key: r.StartKey, EndKey: r.EndKey}
}
+// KeySpan returns the keys covered by this range. Local keys are not included.
+//
+// TODO(andrei): Consider if this logic should be lifted to
+// RangeDescriptor.RSpan(). Or better yet, see if we can changes things such
+// that the first range starts at LocalMax instead at starting at an empty key.
+func (r *RangeDescriptor) KeySpan() RSpan {
+ start := r.StartKey
+ if r.StartKey.Equal(RKeyMin) {
+ // The first range in the keyspace is declared to start at KeyMin (the
+ // lowest possible key). That is a lie, however, since the local key space
+ // ([LocalMin,LocalMax)) doesn't belong to this range; it doesn't belong to
+ // any range in particular.
+ start = RKey(LocalMax)
+ }
+ return RSpan{
+ Key: start,
+ EndKey: r.EndKey,
+ }
+}
+
// ContainsKey returns whether this RangeDescriptor contains the specified key.
func (r *RangeDescriptor) ContainsKey(key RKey) bool {
return r.RSpan().ContainsKey(key)
|
c1d8a2e4824ff87478561828dabc9fcf42626f09
|
2019-04-17 17:52:17
|
Tobias Schottdorf
|
engine: allow taking RocksDB CheckPoint
| false
|
allow taking RocksDB CheckPoint
|
engine
|
diff --git a/c-deps/libroach/db.cc b/c-deps/libroach/db.cc
index efa1aa67a22c..298da9c7e001 100644
--- a/c-deps/libroach/db.cc
+++ b/c-deps/libroach/db.cc
@@ -18,6 +18,7 @@
#include <rocksdb/perf_context.h>
#include <rocksdb/sst_file_writer.h>
#include <rocksdb/table.h>
+#include <rocksdb/utilities/checkpoint.h>
#include <stdarg.h>
#include "batch.h"
#include "cache.h"
@@ -257,6 +258,22 @@ DBStatus DBOpen(DBEngine** db, DBSlice dir, DBOptions db_opts) {
return kSuccess;
}
+DBStatus DBCreateCheckpoint(DBEngine* db, DBSlice dir) {
+ const std::string cp_dir = ToString(dir);
+
+ rocksdb::Checkpoint* cp_ptr;
+ auto status = rocksdb::Checkpoint::Create(db->rep, &cp_ptr);
+ if (!status.ok()) {
+ return ToDBStatus(status);
+ }
+ // NB: passing 0 for log_size_for_flush forces a WAL sync, i.e. makes sure
+ // that the checkpoint is up to date.
+ status = cp_ptr->CreateCheckpoint(cp_dir, 0 /* log_size_for_flush */);
+ delete(cp_ptr);
+ return ToDBStatus(status);
+}
+
+
DBStatus DBDestroy(DBSlice dir) {
rocksdb::Options options;
return ToDBStatus(rocksdb::DestroyDB(ToString(dir), options));
diff --git a/c-deps/libroach/include/libroach.h b/c-deps/libroach/include/libroach.h
index 38e701c0322c..65c9d5982961 100644
--- a/c-deps/libroach/include/libroach.h
+++ b/c-deps/libroach/include/libroach.h
@@ -100,6 +100,12 @@ void DBReleaseCache(DBCache* cache);
// exist.
DBStatus DBOpen(DBEngine** db, DBSlice dir, DBOptions options);
+// Creates a RocksDB checkpoint in the specified directory (which must not exist).
+// A checkpoint is a logical copy of the database, though it will hardlink the
+// SSTs references by it (when possible), thus avoiding duplication of any of
+// the actual data.
+DBStatus DBCreateCheckpoint(DBEngine* db, DBSlice dir);
+
// Set a callback to be invoked during DBOpen that can make changes to RocksDB
// initialization. Used by CCL code to install additional features.
//
diff --git a/pkg/storage/engine/engine.go b/pkg/storage/engine/engine.go
index 2f9fb1031287..7bef4c3648d0 100644
--- a/pkg/storage/engine/engine.go
+++ b/pkg/storage/engine/engine.go
@@ -333,6 +333,10 @@ type Engine interface {
// the engine implementation. For RocksDB, this means using the Env responsible for the file
// which may handle extra logic (eg: copy encryption settings for EncryptedEnv).
LinkFile(oldname, newname string) error
+ // CreateCheckpoint creates a checkpoint of the engine in the given directory,
+ // which must not exist. The directory should be on the same file system so
+ // that hard links can be used.
+ CreateCheckpoint(dir string) error
}
// MapProvidingEngine is an Engine that also provides facilities for making a
diff --git a/pkg/storage/engine/engine_test.go b/pkg/storage/engine/engine_test.go
index e898c3b8409a..f2fb6963cf84 100644
--- a/pkg/storage/engine/engine_test.go
+++ b/pkg/storage/engine/engine_test.go
@@ -18,18 +18,22 @@ import (
"bytes"
"context"
"math/rand"
+ "path/filepath"
"reflect"
"sort"
"strconv"
"testing"
"github.com/cockroachdb/cockroach/pkg/roachpb"
+ "github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/storage/engine/enginepb"
+ "github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
"github.com/cockroachdb/cockroach/pkg/util/stop"
"github.com/pkg/errors"
+ "github.com/stretchr/testify/assert"
)
func ensureRangeEqual(
@@ -790,3 +794,36 @@ func insertKeysAndValues(keys []MVCCKey, values [][]byte, engine Engine, t *test
}
}
}
+
+func TestCreateCheckpoint(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+
+ dir, cleanup := testutils.TempDir(t)
+ defer cleanup()
+
+ // TODO(tbg): use the method below, but only for on-disk stores.
+ _ = runWithAllEngines
+
+ rocksDB, err := NewRocksDB(
+ RocksDBConfig{
+ Settings: cluster.MakeTestingClusterSettings(),
+ Dir: dir,
+ },
+ RocksDBCache{},
+ )
+
+ db := Engine(rocksDB) // be impl neutral from now on
+ defer db.Close()
+
+ dir = filepath.Join(dir, "checkpoint")
+
+ assert.NoError(t, err)
+ assert.NoError(t, db.CreateCheckpoint(dir))
+ assert.DirExists(t, dir)
+ m, err := filepath.Glob(dir + "/*")
+ assert.NoError(t, err)
+ assert.True(t, len(m) > 0)
+ if err := db.CreateCheckpoint(dir); !testutils.IsError(err, "exists") {
+ t.Fatal(err)
+ }
+}
diff --git a/pkg/storage/engine/rocksdb.go b/pkg/storage/engine/rocksdb.go
index fa07523b5d19..832fe8d5097f 100644
--- a/pkg/storage/engine/rocksdb.go
+++ b/pkg/storage/engine/rocksdb.go
@@ -765,6 +765,14 @@ func (r *RocksDB) Close() {
r.syncer.Unlock()
}
+// CreateCheckpoint creates a RocksDB checkpoint in the given directory (which
+// must not exist). This directory should be located on the same file system, or
+// copies of all data are used instead of hard links, which is very expensive.
+func (r *RocksDB) CreateCheckpoint(dir string) error {
+ status := C.DBCreateCheckpoint(r.rdb, goToCSlice([]byte(dir)))
+ return errors.Wrap(statusToError(status), "unable to take RocksDB checkpoint")
+}
+
// Closed returns true if the engine is closed.
func (r *RocksDB) Closed() bool {
return r.rdb == nil
|
ba9c0f420abd372b5d166d4288689488d270a103
|
2022-01-11 22:28:21
|
Marius Posta
|
catalog: add Index*ColumnDirections methods to table descriptor
| false
|
add Index*ColumnDirections methods to table descriptor
|
catalog
|
diff --git a/pkg/sql/catalog/descriptor.go b/pkg/sql/catalog/descriptor.go
index 72c45a51e0c6..0c2144d29edb 100644
--- a/pkg/sql/catalog/descriptor.go
+++ b/pkg/sql/catalog/descriptor.go
@@ -465,6 +465,9 @@ type TableDescriptor interface {
// IndexKeyColumns returns a slice of Column interfaces containing all
// key columns in the specified Index.
IndexKeyColumns(idx Index) []Column
+ // IndexKeyColumnDirections returns a slice of column directions for all
+ // key columns in the specified Index.
+ IndexKeyColumnDirections(idx Index) []descpb.IndexDescriptor_Direction
// IndexKeySuffixColumns returns a slice of Column interfaces containing all
// key suffix columns in the specified Index.
IndexKeySuffixColumns(idx Index) []Column
@@ -472,6 +475,10 @@ type TableDescriptor interface {
// key columns in the specified Index, plus all key suffix columns if that
// index is not a unique index.
IndexFullColumns(idx Index) []Column
+ // IndexFullColumnDirections returns a slice of column directions for all
+ // key columns in the specified Index, plus all key suffix columns if that
+ // index is not a unique index.
+ IndexFullColumnDirections(idx Index) []descpb.IndexDescriptor_Direction
// IndexCompositeColumns returns a slice of Column interfaces containing all
// composite columns among the key and key suffix in the specified Index.
IndexCompositeColumns(idx Index) []Column
diff --git a/pkg/sql/catalog/tabledesc/column.go b/pkg/sql/catalog/tabledesc/column.go
index 7ef3bf067a8a..9a1eb1e27ff9 100644
--- a/pkg/sql/catalog/tabledesc/column.go
+++ b/pkg/sql/catalog/tabledesc/column.go
@@ -266,10 +266,12 @@ type columnCache struct {
type indexColumnCache struct {
all []catalog.Column
key []catalog.Column
+ keyDirs []descpb.IndexDescriptor_Direction
stored []catalog.Column
keySuffix []catalog.Column
composite []catalog.Column
full []catalog.Column
+ fullDirs []descpb.IndexDescriptor_Direction
}
// newColumnCache returns a fresh fully-populated columnCache struct for the
@@ -373,6 +375,11 @@ func makeIndexColumnCache(idx *descpb.IndexDescriptor, all []catalog.Column) ind
if !idx.Unique {
ic.full = append(ic.full, ic.keySuffix...)
}
+ ic.fullDirs = make([]descpb.IndexDescriptor_Direction, len(ic.full))
+ // Only copy key column directions, key suffix directions will remain at their
+ // default value of ASC.
+ copy(ic.fullDirs, idx.KeyColumnDirections)
+ ic.keyDirs = ic.fullDirs[:len(ic.key)]
return ic
}
diff --git a/pkg/sql/catalog/tabledesc/table_desc.go b/pkg/sql/catalog/tabledesc/table_desc.go
index 84875055f492..7714fefd384c 100644
--- a/pkg/sql/catalog/tabledesc/table_desc.go
+++ b/pkg/sql/catalog/tabledesc/table_desc.go
@@ -434,6 +434,16 @@ func (desc *wrapper) IndexKeyColumns(idx catalog.Index) []catalog.Column {
return nil
}
+// IndexKeyColumnDirections implements the TableDescriptor interface.
+func (desc *wrapper) IndexKeyColumnDirections(
+ idx catalog.Index,
+) []descpb.IndexDescriptor_Direction {
+ if ic := desc.getExistingOrNewIndexColumnCache(idx); ic != nil {
+ return ic.keyDirs
+ }
+ return nil
+}
+
// IndexKeySuffixColumns implements the TableDescriptor interface.
func (desc *wrapper) IndexKeySuffixColumns(idx catalog.Index) []catalog.Column {
if ic := desc.getExistingOrNewIndexColumnCache(idx); ic != nil {
@@ -450,6 +460,16 @@ func (desc *wrapper) IndexFullColumns(idx catalog.Index) []catalog.Column {
return nil
}
+// IndexFullColumnDirections implements the TableDescriptor interface.
+func (desc *wrapper) IndexFullColumnDirections(
+ idx catalog.Index,
+) []descpb.IndexDescriptor_Direction {
+ if ic := desc.getExistingOrNewIndexColumnCache(idx); ic != nil {
+ return ic.fullDirs
+ }
+ return nil
+}
+
// IndexCompositeColumns implements the TableDescriptor interface.
func (desc *wrapper) IndexCompositeColumns(idx catalog.Index) []catalog.Column {
if ic := desc.getExistingOrNewIndexColumnCache(idx); ic != nil {
|
326d2ff30331f2609299e8b0d36b2fea7e7af990
|
2020-02-22 21:40:36
|
David Hartunian
|
ui: add license to new files
| false
|
add license to new files
|
ui
|
diff --git a/pkg/ui/src/views/jobs/duration.tsx b/pkg/ui/src/views/jobs/duration.tsx
index 4416a71ae35e..35444c8483a2 100644
--- a/pkg/ui/src/views/jobs/duration.tsx
+++ b/pkg/ui/src/views/jobs/duration.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import {TimestampToMoment} from "src/util/convert";
import {
diff --git a/pkg/ui/src/views/jobs/fractionCompleted.tsx b/pkg/ui/src/views/jobs/fractionCompleted.tsx
index de3b79853bf9..ad22e15a06eb 100644
--- a/pkg/ui/src/views/jobs/fractionCompleted.tsx
+++ b/pkg/ui/src/views/jobs/fractionCompleted.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import {Progress} from "src/views/jobs/progress";
import {Duration} from "src/views/jobs/duration";
diff --git a/pkg/ui/src/views/jobs/highwaterTimestamp.tsx b/pkg/ui/src/views/jobs/highwaterTimestamp.tsx
index cfa2a53b173a..764fcd097370 100644
--- a/pkg/ui/src/views/jobs/highwaterTimestamp.tsx
+++ b/pkg/ui/src/views/jobs/highwaterTimestamp.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import moment from "moment";
import {ToolTipWrapper} from "src/views/shared/components/toolTip";
diff --git a/pkg/ui/src/views/jobs/jobDescriptionCell.tsx b/pkg/ui/src/views/jobs/jobDescriptionCell.tsx
index 7d1b1158d7cd..6fd90effea92 100644
--- a/pkg/ui/src/views/jobs/jobDescriptionCell.tsx
+++ b/pkg/ui/src/views/jobs/jobDescriptionCell.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import {Link} from "react-router-dom";
import {Tooltip} from "src/components";
diff --git a/pkg/ui/src/views/jobs/jobStatusCell.tsx b/pkg/ui/src/views/jobs/jobStatusCell.tsx
index 603a190c5bb8..3d7eae07a33f 100644
--- a/pkg/ui/src/views/jobs/jobStatusCell.tsx
+++ b/pkg/ui/src/views/jobs/jobStatusCell.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import {cockroach} from "src/js/protos";
import {HighwaterTimestamp} from "oss/src/views/jobs/highwaterTimestamp";
diff --git a/pkg/ui/src/views/jobs/jobStatusOptions.ts b/pkg/ui/src/views/jobs/jobStatusOptions.ts
index 5eca0fcd94e2..023903ac5b12 100644
--- a/pkg/ui/src/views/jobs/jobStatusOptions.ts
+++ b/pkg/ui/src/views/jobs/jobStatusOptions.ts
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import {cockroach} from "src/js/protos";
import _ from "lodash";
import Job = cockroach.server.serverpb.JobsResponse.IJob;
diff --git a/pkg/ui/src/views/jobs/jobTable.tsx b/pkg/ui/src/views/jobs/jobTable.tsx
index 03a00478507d..e196fbc3d1d8 100644
--- a/pkg/ui/src/views/jobs/jobTable.tsx
+++ b/pkg/ui/src/views/jobs/jobTable.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import {ColumnDescriptor, SortedTable} from "src/views/shared/components/sortedtable";
import {cockroach} from "src/js/protos";
diff --git a/pkg/ui/src/views/jobs/progress.tsx b/pkg/ui/src/views/jobs/progress.tsx
index c8f4fcefcbe7..2fd7674c1b63 100644
--- a/pkg/ui/src/views/jobs/progress.tsx
+++ b/pkg/ui/src/views/jobs/progress.tsx
@@ -1,3 +1,13 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
import React from "react";
import {
JOB_STATUS_CANCELED,
@@ -34,7 +44,7 @@ export class Progress extends React.PureComponent<{ job: Job }> {
title={percent.toFixed(3) + "%"}>{percent.toFixed(1) + "%"}</div>
<Line
percent={percent}
- strokeWidth={11}
+ strokeWidth={11}Â
trailWidth={11}
strokeColor="#0788ff"
trailColor="#d6dbe7"
|
db2c67215cfaf4a90ba0b87849d98ded8832a2d9
|
2020-02-17 16:07:44
|
Andrii Vorobiov
|
ui: Fix import statement and definition for Button component
| false
|
Fix import statement and definition for Button component
|
ui
|
diff --git a/pkg/ui/src/components/button/button.tsx b/pkg/ui/src/components/button/button.tsx
index 24808f404aa3..bf67564c14ec 100644
--- a/pkg/ui/src/components/button/button.tsx
+++ b/pkg/ui/src/components/button/button.tsx
@@ -62,6 +62,7 @@ export function Button(props: ButtonProps) {
}
Button.defaultProps = {
+ onClick: () => {},
type: "primary",
disabled: false,
size: "default",
diff --git a/pkg/ui/src/components/index.ts b/pkg/ui/src/components/index.ts
index 76d0a347dea8..ab3c89b54795 100644
--- a/pkg/ui/src/components/index.ts
+++ b/pkg/ui/src/components/index.ts
@@ -9,11 +9,13 @@
// licenses/APL.txt.
export * from "./badge";
+export * from "./button";
export * from "./icon";
export * from "./globalNavigation";
export * from "./sideNavigation";
export * from "./pageHeader";
export * from "./text";
+export * from "./textInput";
export * from "./table";
export * from "./tooltip";
export * from "./select";
|
6fcbdfcd9ac29420751b9e9f96350092028d23dc
|
2024-01-30 17:48:44
|
Erik Grinaker
|
rangefeed: use log.Fatalf instead of panic
| false
|
use log.Fatalf instead of panic
|
rangefeed
|
diff --git a/pkg/kv/kvserver/rangefeed/budget.go b/pkg/kv/kvserver/rangefeed/budget.go
index 26ea58bbe8fe..03b2a4f9db1c 100644
--- a/pkg/kv/kvserver/rangefeed/budget.go
+++ b/pkg/kv/kvserver/rangefeed/budget.go
@@ -18,6 +18,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/settings"
"github.com/cockroachdb/cockroach/pkg/util/envutil"
+ "github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/mon"
"github.com/cockroachdb/cockroach/pkg/util/syncutil"
"github.com/cockroachdb/errors"
@@ -249,10 +250,10 @@ type SharedBudgetAllocation struct {
// Use increases usage count for the allocation. It should be called by each
// new consumer that plans to retain allocation after returning to a caller
// that passed this allocation.
-func (a *SharedBudgetAllocation) Use() {
+func (a *SharedBudgetAllocation) Use(ctx context.Context) {
if a != nil {
if atomic.AddInt32(&a.refCount, 1) == 1 {
- panic("unexpected shared memory allocation usage increase after free")
+ log.Fatalf(ctx, "unexpected shared memory allocation usage increase after free")
}
}
}
diff --git a/pkg/kv/kvserver/rangefeed/processor.go b/pkg/kv/kvserver/rangefeed/processor.go
index 58f95cd1b97e..cc4e408a9c05 100644
--- a/pkg/kv/kvserver/rangefeed/processor.go
+++ b/pkg/kv/kvserver/rangefeed/processor.go
@@ -112,14 +112,8 @@ type Config struct {
// SetDefaults initializes unset fields in Config to values
// suitable for use by a Processor.
func (sc *Config) SetDefaults() {
- if sc.TxnPusher == nil {
- if sc.PushTxnsAge != 0 {
- panic("nil TxnPusher with non-zero PushTxnsAge")
- }
- } else {
- if sc.PushTxnsAge == 0 {
- sc.PushTxnsAge = defaultPushTxnsAge
- }
+ if sc.PushTxnsAge == 0 {
+ sc.PushTxnsAge = defaultPushTxnsAge
}
}
diff --git a/pkg/kv/kvserver/rangefeed/registry.go b/pkg/kv/kvserver/rangefeed/registry.go
index 005ba4ec66d1..eb605cf94151 100644
--- a/pkg/kv/kvserver/rangefeed/registry.go
+++ b/pkg/kv/kvserver/rangefeed/registry.go
@@ -152,15 +152,15 @@ func newRegistration(
func (r *registration) publish(
ctx context.Context, event *kvpb.RangeFeedEvent, alloc *SharedBudgetAllocation,
) {
- r.validateEvent(event)
- e := getPooledSharedEvent(sharedEvent{event: r.maybeStripEvent(event), alloc: alloc})
+ r.assertEvent(ctx, event)
+ e := getPooledSharedEvent(sharedEvent{event: r.maybeStripEvent(ctx, event), alloc: alloc})
r.mu.Lock()
defer r.mu.Unlock()
if r.mu.overflowed {
return
}
- alloc.Use()
+ alloc.Use(ctx)
select {
case r.buf <- e:
r.mu.caughtUp = false
@@ -188,43 +188,42 @@ func (r *registration) publish(
}
}
-// validateEvent checks that the event contains enough information for the
-// registation.
-func (r *registration) validateEvent(event *kvpb.RangeFeedEvent) {
+// assertEvent asserts that the event contains the necessary data.
+func (r *registration) assertEvent(ctx context.Context, event *kvpb.RangeFeedEvent) {
switch t := event.GetValue().(type) {
case *kvpb.RangeFeedValue:
if t.Key == nil {
- panic(fmt.Sprintf("unexpected empty RangeFeedValue.Key: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedValue.Key: %v", t)
}
if t.Value.RawBytes == nil {
- panic(fmt.Sprintf("unexpected empty RangeFeedValue.Value.RawBytes: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedValue.Value.RawBytes: %v", t)
}
if t.Value.Timestamp.IsEmpty() {
- panic(fmt.Sprintf("unexpected empty RangeFeedValue.Value.Timestamp: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedValue.Value.Timestamp: %v", t)
}
case *kvpb.RangeFeedCheckpoint:
if t.Span.Key == nil {
- panic(fmt.Sprintf("unexpected empty RangeFeedCheckpoint.Span.Key: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedCheckpoint.Span.Key: %v", t)
}
case *kvpb.RangeFeedSSTable:
if len(t.Data) == 0 {
- panic(fmt.Sprintf("unexpected empty RangeFeedSSTable.Data: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedSSTable.Data: %v", t)
}
if len(t.Span.Key) == 0 {
- panic(fmt.Sprintf("unexpected empty RangeFeedSSTable.Span: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedSSTable.Span: %v", t)
}
if t.WriteTS.IsEmpty() {
- panic(fmt.Sprintf("unexpected empty RangeFeedSSTable.Timestamp: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedSSTable.Timestamp: %v", t)
}
case *kvpb.RangeFeedDeleteRange:
if len(t.Span.Key) == 0 || len(t.Span.EndKey) == 0 {
- panic(fmt.Sprintf("unexpected empty key in RangeFeedDeleteRange.Span: %v", t))
+ log.Fatalf(ctx, "unexpected empty key in RangeFeedDeleteRange.Span: %v", t)
}
if t.Timestamp.IsEmpty() {
- panic(fmt.Sprintf("unexpected empty RangeFeedDeleteRange.Timestamp: %v", t))
+ log.Fatalf(ctx, "unexpected empty RangeFeedDeleteRange.Timestamp: %v", t)
}
default:
- panic(fmt.Sprintf("unexpected RangeFeedEvent variant: %v", t))
+ log.Fatalf(ctx, "unexpected RangeFeedEvent variant: %v", t)
}
}
@@ -232,7 +231,9 @@ func (r *registration) validateEvent(event *kvpb.RangeFeedEvent) {
// applicable to the current registration. If so, it makes a copy of the event
// and strips the incompatible information to match only what the registration
// requested.
-func (r *registration) maybeStripEvent(event *kvpb.RangeFeedEvent) *kvpb.RangeFeedEvent {
+func (r *registration) maybeStripEvent(
+ ctx context.Context, event *kvpb.RangeFeedEvent,
+) *kvpb.RangeFeedEvent {
ret := event
copyOnWrite := func() interface{} {
if ret == event {
@@ -264,7 +265,7 @@ func (r *registration) maybeStripEvent(event *kvpb.RangeFeedEvent) *kvpb.RangeFe
// observed all values up to the checkpoint timestamp over a given
// key span if any updates to that span have been filtered out.
if !t.Span.Contains(r.span) {
- panic(fmt.Sprintf("registration span %v larger than checkpoint span %v", r.span, t.Span))
+ log.Fatalf(ctx, "registration span %v larger than checkpoint span %v", r.span, t.Span)
}
t = copyOnWrite().(*kvpb.RangeFeedCheckpoint)
t.Span = r.span
@@ -279,7 +280,7 @@ func (r *registration) maybeStripEvent(event *kvpb.RangeFeedEvent) *kvpb.RangeFe
// SSTs are always sent in their entirety, it is up to the caller to
// filter out irrelevant entries.
default:
- panic(fmt.Sprintf("unexpected RangeFeedEvent variant: %v", t))
+ log.Fatalf(ctx, "unexpected RangeFeedEvent variant: %v", t)
}
return ret
}
@@ -443,12 +444,13 @@ func (reg *registry) NewFilter() *Filter {
}
// Register adds the provided registration to the registry.
-func (reg *registry) Register(r *registration) {
+func (reg *registry) Register(ctx context.Context, r *registration) {
reg.metrics.RangeFeedRegistrations.Inc(1)
r.id = reg.nextID()
r.keys = r.span.AsRange()
if err := reg.tree.Insert(r, false /* fast */); err != nil {
- panic(err)
+ // TODO(erikgrinaker): these errors should arguably be returned.
+ log.Fatalf(ctx, "%v", err)
}
}
@@ -484,10 +486,10 @@ func (reg *registry) PublishToOverlapping(
// surprising. Revisit this once RangeFeed has more users.
minTS = hlc.MaxTimestamp
default:
- panic(fmt.Sprintf("unexpected RangeFeedEvent variant: %v", t))
+ log.Fatalf(ctx, "unexpected RangeFeedEvent variant: %v", t)
}
- reg.forOverlappingRegs(span, func(r *registration) (bool, *kvpb.Error) {
+ reg.forOverlappingRegs(ctx, span, func(r *registration) (bool, *kvpb.Error) {
// Don't publish events if they:
// 1. are equal to or less than the registration's starting timestamp, or
// 2. have OmitInRangefeeds = true and this registration has opted into filtering.
@@ -507,7 +509,7 @@ func (reg *registry) PublishToOverlapping(
func (reg *registry) Unregister(ctx context.Context, r *registration) {
reg.metrics.RangeFeedRegistrations.Dec(1)
if err := reg.tree.Delete(r, false /* fast */); err != nil {
- panic(err)
+ log.Fatalf(ctx, "%v", err)
}
r.drainAllocations(ctx)
}
@@ -519,21 +521,21 @@ func (reg *registry) Unregister(ctx context.Context, r *registration) {
// errors to registrations.
// TODO: this should be revisited as part of
// https://github.com/cockroachdb/cockroach/issues/110634
-func (reg *registry) DisconnectAllOnShutdown(pErr *kvpb.Error) {
+func (reg *registry) DisconnectAllOnShutdown(ctx context.Context, pErr *kvpb.Error) {
reg.metrics.RangeFeedRegistrations.Dec(int64(reg.tree.Len()))
- reg.DisconnectWithErr(all, pErr)
+ reg.DisconnectWithErr(ctx, all, pErr)
}
// Disconnect disconnects all registrations that overlap the specified span with
// a nil error.
-func (reg *registry) Disconnect(span roachpb.Span) {
- reg.DisconnectWithErr(span, nil /* pErr */)
+func (reg *registry) Disconnect(ctx context.Context, span roachpb.Span) {
+ reg.DisconnectWithErr(ctx, span, nil /* pErr */)
}
// DisconnectWithErr disconnects all registrations that overlap the specified
// span with the provided error.
-func (reg *registry) DisconnectWithErr(span roachpb.Span, pErr *kvpb.Error) {
- reg.forOverlappingRegs(span, func(r *registration) (bool, *kvpb.Error) {
+func (reg *registry) DisconnectWithErr(ctx context.Context, span roachpb.Span, pErr *kvpb.Error) {
+ reg.forOverlappingRegs(ctx, span, func(r *registration) (bool, *kvpb.Error) {
return true /* disconned */, pErr
})
}
@@ -546,7 +548,9 @@ var all = roachpb.Span{Key: roachpb.KeyMin, EndKey: roachpb.KeyMax}
// then that registration is unregistered and the error returned by the
// function is send on its corresponding error channel.
func (reg *registry) forOverlappingRegs(
- span roachpb.Span, fn func(*registration) (disconnect bool, pErr *kvpb.Error),
+ ctx context.Context,
+ span roachpb.Span,
+ fn func(*registration) (disconnect bool, pErr *kvpb.Error),
) {
var toDelete []interval.Interface
matchFn := func(i interval.Interface) (done bool) {
@@ -568,12 +572,12 @@ func (reg *registry) forOverlappingRegs(
reg.tree.Clear()
} else if len(toDelete) == 1 {
if err := reg.tree.Delete(toDelete[0], false /* fast */); err != nil {
- panic(err)
+ log.Fatalf(ctx, "%v", err)
}
} else if len(toDelete) > 1 {
for _, i := range toDelete {
if err := reg.tree.Delete(i, true /* fast */); err != nil {
- panic(err)
+ log.Fatalf(ctx, "%v", err)
}
}
reg.tree.AdjustRanges()
@@ -581,14 +585,14 @@ func (reg *registry) forOverlappingRegs(
}
// Wait for this registration to completely process its internal buffer.
-func (r *registration) waitForCaughtUp() error {
+func (r *registration) waitForCaughtUp(ctx context.Context) error {
opts := retry.Options{
InitialBackoff: 5 * time.Millisecond,
Multiplier: 2,
MaxBackoff: 10 * time.Second,
MaxRetries: 50,
}
- for re := retry.Start(opts); re.Next(); {
+ for re := retry.StartWithCtx(ctx, opts); re.Next(); {
r.mu.Lock()
caughtUp := len(r.buf) == 0 && r.mu.caughtUp
r.mu.Unlock()
@@ -596,6 +600,9 @@ func (r *registration) waitForCaughtUp() error {
return nil
}
}
+ if err := ctx.Err(); err != nil {
+ return err
+ }
return errors.Errorf("registration %v failed to empty in time", r.Range())
}
@@ -610,11 +617,11 @@ func (r *registration) detachCatchUpIter() *CatchUpIterator {
// waitForCaughtUp waits for all registrations overlapping the given span to
// completely process their internal buffers.
-func (reg *registry) waitForCaughtUp(span roachpb.Span) error {
+func (reg *registry) waitForCaughtUp(ctx context.Context, span roachpb.Span) error {
var outerErr error
- reg.forOverlappingRegs(span, func(r *registration) (bool, *kvpb.Error) {
+ reg.forOverlappingRegs(ctx, span, func(r *registration) (bool, *kvpb.Error) {
if outerErr == nil {
- outerErr = r.waitForCaughtUp()
+ outerErr = r.waitForCaughtUp(ctx)
}
return false, nil
})
diff --git a/pkg/kv/kvserver/rangefeed/registry_test.go b/pkg/kv/kvserver/rangefeed/registry_test.go
index fe4b2db1c28d..c61093112577 100644
--- a/pkg/kv/kvserver/rangefeed/registry_test.go
+++ b/pkg/kv/kvserver/rangefeed/registry_test.go
@@ -170,8 +170,8 @@ func TestRegistrationBasic(t *testing.T) {
noCatchupReg.publish(ctx, ev1, nil /* alloc */)
noCatchupReg.publish(ctx, ev2, nil /* alloc */)
require.Equal(t, len(noCatchupReg.buf), 2)
- go noCatchupReg.runOutputLoop(context.Background(), 0)
- require.NoError(t, noCatchupReg.waitForCaughtUp())
+ go noCatchupReg.runOutputLoop(ctx, 0)
+ require.NoError(t, noCatchupReg.waitForCaughtUp(ctx))
require.Equal(t, []*kvpb.RangeFeedEvent{ev1, ev2}, noCatchupReg.stream.Events())
noCatchupReg.disconnect(nil)
@@ -186,8 +186,8 @@ func TestRegistrationBasic(t *testing.T) {
catchupReg.publish(ctx, ev1, nil /* alloc */)
catchupReg.publish(ctx, ev2, nil /* alloc */)
require.Equal(t, len(catchupReg.buf), 2)
- go catchupReg.runOutputLoop(context.Background(), 0)
- require.NoError(t, catchupReg.waitForCaughtUp())
+ go catchupReg.runOutputLoop(ctx, 0)
+ require.NoError(t, catchupReg.waitForCaughtUp(ctx))
events := catchupReg.stream.Events()
require.Equal(t, 5, len(events))
require.Equal(t, []*kvpb.RangeFeedEvent{ev1, ev2}, events[3:])
@@ -199,8 +199,8 @@ func TestRegistrationBasic(t *testing.T) {
false /* withDiff */, false /* withFiltering */)
disconnectReg.publish(ctx, ev1, nil /* alloc */)
disconnectReg.publish(ctx, ev2, nil /* alloc */)
- go disconnectReg.runOutputLoop(context.Background(), 0)
- require.NoError(t, disconnectReg.waitForCaughtUp())
+ go disconnectReg.runOutputLoop(ctx, 0)
+ require.NoError(t, disconnectReg.waitForCaughtUp(ctx))
discErr := kvpb.NewError(fmt.Errorf("disconnection error"))
disconnectReg.disconnect(discErr)
require.Equal(t, discErr.GoError(), disconnectReg.Err())
@@ -212,7 +212,7 @@ func TestRegistrationBasic(t *testing.T) {
disconnectEarlyReg.publish(ctx, ev1, nil /* alloc */)
disconnectEarlyReg.publish(ctx, ev2, nil /* alloc */)
disconnectEarlyReg.disconnect(discErr)
- go disconnectEarlyReg.runOutputLoop(context.Background(), 0)
+ go disconnectEarlyReg.runOutputLoop(ctx, 0)
require.Equal(t, discErr.GoError(), disconnectEarlyReg.Err())
require.Equal(t, 0, len(disconnectEarlyReg.stream.Events()))
@@ -222,7 +222,7 @@ func TestRegistrationBasic(t *testing.T) {
for i := 0; i < cap(overflowReg.buf)+3; i++ {
overflowReg.publish(ctx, ev1, nil /* alloc */)
}
- go overflowReg.runOutputLoop(context.Background(), 0)
+ go overflowReg.runOutputLoop(ctx, 0)
require.Equal(t, newErrBufferCapacityExceeded().GoError(), overflowReg.Err())
require.Equal(t, cap(overflowReg.buf), len(overflowReg.Events()))
@@ -231,7 +231,7 @@ func TestRegistrationBasic(t *testing.T) {
false /* withDiff */, false /* withFiltering */)
streamErr := fmt.Errorf("stream error")
streamErrReg.stream.SetSendErr(streamErr)
- go streamErrReg.runOutputLoop(context.Background(), 0)
+ go streamErrReg.runOutputLoop(ctx, 0)
streamErrReg.publish(ctx, ev1, nil /* alloc */)
require.Equal(t, streamErr.Error(), streamErrReg.Err().Error())
@@ -239,8 +239,8 @@ func TestRegistrationBasic(t *testing.T) {
streamCancelReg := newTestRegistration(spAB, hlc.Timestamp{}, nil, /* catchup */
false /* withDiff */, false /* withFiltering */)
streamCancelReg.stream.Cancel()
- go streamCancelReg.runOutputLoop(context.Background(), 0)
- require.NoError(t, streamCancelReg.waitForCaughtUp())
+ go streamCancelReg.runOutputLoop(ctx, 0)
+ require.NoError(t, streamCancelReg.waitForCaughtUp(ctx))
require.Equal(t, streamCancelReg.stream.Context().Err(), streamCancelReg.Err())
}
@@ -387,20 +387,20 @@ func TestRegistryBasic(t *testing.T) {
reg := makeRegistry(NewMetrics())
require.Equal(t, 0, reg.Len())
- require.NotPanics(t, func() { reg.PublishToOverlapping(ctx, spAB, ev1, false /* omitInRangefeeds */, nil /* alloc */) })
- require.NotPanics(t, func() { reg.Disconnect(spAB) })
- require.NotPanics(t, func() { reg.DisconnectWithErr(spAB, err1) })
+ reg.PublishToOverlapping(ctx, spAB, ev1, false /* omitInRangefeeds */, nil /* alloc */)
+ reg.Disconnect(ctx, spAB)
+ reg.DisconnectWithErr(ctx, spAB, err1)
rAB := newTestRegistration(spAB, hlc.Timestamp{}, nil, false /* withDiff */, false /* withFiltering */)
rBC := newTestRegistration(spBC, hlc.Timestamp{}, nil, true /* withDiff */, false /* withFiltering */)
rCD := newTestRegistration(spCD, hlc.Timestamp{}, nil, true /* withDiff */, false /* withFiltering */)
rAC := newTestRegistration(spAC, hlc.Timestamp{}, nil, false /* withDiff */, false /* withFiltering */)
rACFiltering := newTestRegistration(spAC, hlc.Timestamp{}, nil, false /* withDiff */, true /* withFiltering */)
- go rAB.runOutputLoop(context.Background(), 0)
- go rBC.runOutputLoop(context.Background(), 0)
- go rCD.runOutputLoop(context.Background(), 0)
- go rAC.runOutputLoop(context.Background(), 0)
- go rACFiltering.runOutputLoop(context.Background(), 0)
+ go rAB.runOutputLoop(ctx, 0)
+ go rBC.runOutputLoop(ctx, 0)
+ go rCD.runOutputLoop(ctx, 0)
+ go rAC.runOutputLoop(ctx, 0)
+ go rACFiltering.runOutputLoop(ctx, 0)
defer rAB.disconnect(nil)
defer rBC.disconnect(nil)
defer rCD.disconnect(nil)
@@ -408,15 +408,15 @@ func TestRegistryBasic(t *testing.T) {
defer rACFiltering.disconnect(nil)
// Register 4 registrations.
- reg.Register(&rAB.registration)
+ reg.Register(ctx, &rAB.registration)
require.Equal(t, 1, reg.Len())
- reg.Register(&rBC.registration)
+ reg.Register(ctx, &rBC.registration)
require.Equal(t, 2, reg.Len())
- reg.Register(&rCD.registration)
+ reg.Register(ctx, &rCD.registration)
require.Equal(t, 3, reg.Len())
- reg.Register(&rAC.registration)
+ reg.Register(ctx, &rAC.registration)
require.Equal(t, 4, reg.Len())
- reg.Register(&rACFiltering.registration)
+ reg.Register(ctx, &rACFiltering.registration)
require.Equal(t, 5, reg.Len())
// Publish to different spans.
@@ -425,7 +425,7 @@ func TestRegistryBasic(t *testing.T) {
reg.PublishToOverlapping(ctx, spCD, ev3, false /* omitInRangefeeds */, nil /* alloc */)
reg.PublishToOverlapping(ctx, spAC, ev4, false /* omitInRangefeeds */, nil /* alloc */)
reg.PublishToOverlapping(ctx, spAC, ev5, true /* omitInRangefeeds */, nil /* alloc */)
- require.NoError(t, reg.waitForCaughtUp(all))
+ require.NoError(t, reg.waitForCaughtUp(ctx, all))
require.Equal(t, []*kvpb.RangeFeedEvent{noPrev(ev1), noPrev(ev4), noPrev(ev5)}, rAB.Events())
require.Equal(t, []*kvpb.RangeFeedEvent{ev2, ev4, ev5}, rBC.Events())
require.Equal(t, []*kvpb.RangeFeedEvent{ev3}, rCD.Events())
@@ -463,7 +463,7 @@ func TestRegistryBasic(t *testing.T) {
require.False(t, f.NeedPrevVal(roachpb.Span{Key: keyX}))
// Disconnect span that overlaps with rCD.
- reg.DisconnectWithErr(spCD, err1)
+ reg.DisconnectWithErr(ctx, spCD, err1)
require.Equal(t, 4, reg.Len())
require.Equal(t, err1.GoError(), rCD.Err())
@@ -472,11 +472,11 @@ func TestRegistryBasic(t *testing.T) {
reg.PublishToOverlapping(ctx, spBC, ev3, false /* omitInRangefeeds */, nil /* alloc */)
reg.PublishToOverlapping(ctx, spCD, ev2, false /* omitInRangefeeds */, nil /* alloc */)
reg.PublishToOverlapping(ctx, spAC, ev1, false /* omitInRangefeeds */, nil /* alloc */)
- require.NoError(t, reg.waitForCaughtUp(all))
+ require.NoError(t, reg.waitForCaughtUp(ctx, all))
require.Equal(t, []*kvpb.RangeFeedEvent{noPrev(ev4), noPrev(ev1)}, rAB.Events())
// Disconnect from rAB without error.
- reg.Disconnect(spAB)
+ reg.Disconnect(ctx, spAB)
require.Nil(t, rAC.Err())
require.Nil(t, rAB.Err())
require.Equal(t, 1, reg.Len())
@@ -509,59 +509,6 @@ func TestRegistryBasic(t *testing.T) {
require.Equal(t, 0, reg.Len())
}
-func TestRegistryPublishAssertsPopulatedInformation(t *testing.T) {
- defer leaktest.AfterTest(t)()
- ctx := context.Background()
- reg := makeRegistry(NewMetrics())
-
- rNoDiff := newTestRegistration(spAB, hlc.Timestamp{}, nil, false /* withDiff */, false /* withFiltering */)
- go rNoDiff.runOutputLoop(context.Background(), 0)
- reg.Register(&rNoDiff.registration)
-
- rWithDiff := newTestRegistration(spCD, hlc.Timestamp{}, nil, true /* withDiff */, false /* withFiltering */)
- go rWithDiff.runOutputLoop(context.Background(), 0)
- reg.Register(&rWithDiff.registration)
-
- key := roachpb.Key("a")
- val := roachpb.Value{RawBytes: []byte("val"), Timestamp: hlc.Timestamp{WallTime: 1}}
- noVal := roachpb.Value{Timestamp: hlc.Timestamp{WallTime: 1}}
- ev := new(kvpb.RangeFeedEvent)
-
- // Both registrations require RangeFeedValue events to have a Key.
- ev.MustSetValue(&kvpb.RangeFeedValue{
- Key: nil,
- Value: val,
- PrevValue: val,
- })
- require.Panics(t, func() { reg.PublishToOverlapping(ctx, spAB, ev, false /* omitInRangefeeds */, nil /* alloc */) })
- require.Panics(t, func() { reg.PublishToOverlapping(ctx, spCD, ev, false /* omitInRangefeeds */, nil /* alloc */) })
- require.NoError(t, reg.waitForCaughtUp(all))
-
- // Both registrations require RangeFeedValue events to have a Value.
- ev.MustSetValue(&kvpb.RangeFeedValue{
- Key: key,
- Value: noVal,
- PrevValue: val,
- })
- require.Panics(t, func() { reg.PublishToOverlapping(ctx, spAB, ev, false /* omitInRangefeeds */, nil /* alloc */) })
- require.Panics(t, func() { reg.PublishToOverlapping(ctx, spCD, ev, false /* omitInRangefeeds */, nil /* alloc */) })
- require.NoError(t, reg.waitForCaughtUp(all))
-
- // Neither registrations require RangeFeedValue events to have a PrevValue.
- // Even when they are requested, the previous value can always be nil.
- ev.MustSetValue(&kvpb.RangeFeedValue{
- Key: key,
- Value: val,
- PrevValue: roachpb.Value{},
- })
- require.NotPanics(t, func() { reg.PublishToOverlapping(ctx, spAB, ev, false /* omitInRangefeeds */, nil /* alloc */) })
- require.NotPanics(t, func() { reg.PublishToOverlapping(ctx, spCD, ev, false /* omitInRangefeeds */, nil /* alloc */) })
- require.NoError(t, reg.waitForCaughtUp(all))
-
- rNoDiff.disconnect(nil)
- rWithDiff.disconnect(nil)
-}
-
func TestRegistryPublishBeneathStartTimestamp(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
@@ -569,8 +516,8 @@ func TestRegistryPublishBeneathStartTimestamp(t *testing.T) {
r := newTestRegistration(spAB, hlc.Timestamp{WallTime: 10}, nil, /* catchup */
false /* withDiff */, false /* withFiltering */)
- go r.runOutputLoop(context.Background(), 0)
- reg.Register(&r.registration)
+ go r.runOutputLoop(ctx, 0)
+ reg.Register(ctx, &r.registration)
// Publish a value with a timestamp beneath the registration's start
// timestamp. Should be ignored.
@@ -579,7 +526,7 @@ func TestRegistryPublishBeneathStartTimestamp(t *testing.T) {
Value: roachpb.Value{Timestamp: hlc.Timestamp{WallTime: 5}},
})
reg.PublishToOverlapping(ctx, spAB, ev, false /* omitInRangefeeds */, nil /* alloc */)
- require.NoError(t, reg.waitForCaughtUp(all))
+ require.NoError(t, reg.waitForCaughtUp(ctx, all))
require.Nil(t, r.Events())
// Publish a value with a timestamp equal to the registration's start
@@ -588,7 +535,7 @@ func TestRegistryPublishBeneathStartTimestamp(t *testing.T) {
Value: roachpb.Value{Timestamp: hlc.Timestamp{WallTime: 10}},
})
reg.PublishToOverlapping(ctx, spAB, ev, false /* omitInRangefeeds */, nil /* alloc */)
- require.NoError(t, reg.waitForCaughtUp(all))
+ require.NoError(t, reg.waitForCaughtUp(ctx, all))
require.Nil(t, r.Events())
// Publish a checkpoint with a timestamp beneath the registration's. Should
@@ -597,7 +544,7 @@ func TestRegistryPublishBeneathStartTimestamp(t *testing.T) {
Span: spAB, ResolvedTS: hlc.Timestamp{WallTime: 5},
})
reg.PublishToOverlapping(ctx, spAB, ev, false /* omitInRangefeeds */, nil /* alloc */)
- require.NoError(t, reg.waitForCaughtUp(all))
+ require.NoError(t, reg.waitForCaughtUp(ctx, all))
require.Equal(t, []*kvpb.RangeFeedEvent{ev}, r.Events())
r.disconnect(nil)
@@ -645,18 +592,19 @@ func TestRegistrationString(t *testing.T) {
// implicitly.
func TestRegistryShutdownMetrics(t *testing.T) {
defer leaktest.AfterTest(t)()
+ ctx := context.Background()
reg := makeRegistry(NewMetrics())
regDoneC := make(chan interface{})
r := newTestRegistration(spAB, hlc.Timestamp{WallTime: 10}, nil, /*catchup */
false /* withDiff */, false /* withFiltering */)
go func() {
- r.runOutputLoop(context.Background(), 0)
+ r.runOutputLoop(ctx, 0)
close(regDoneC)
}()
- reg.Register(&r.registration)
+ reg.Register(ctx, &r.registration)
- reg.DisconnectAllOnShutdown(nil)
+ reg.DisconnectAllOnShutdown(ctx, nil)
<-regDoneC
require.Zero(t, reg.metrics.RangeFeedRegistrations.Value(), "metric is not zero on stop")
}
diff --git a/pkg/kv/kvserver/rangefeed/resolved_timestamp.go b/pkg/kv/kvserver/rangefeed/resolved_timestamp.go
index eab7118558c6..19af3aa6e5af 100644
--- a/pkg/kv/kvserver/rangefeed/resolved_timestamp.go
+++ b/pkg/kv/kvserver/rangefeed/resolved_timestamp.go
@@ -110,14 +110,14 @@ func (rts *resolvedTimestamp) Get() hlc.Timestamp {
// closed timestamp. Once initialized, the resolvedTimestamp can begin operating
// in its steady state. The method returns whether this caused the resolved
// timestamp to move forward.
-func (rts *resolvedTimestamp) Init() bool {
+func (rts *resolvedTimestamp) Init(ctx context.Context) bool {
rts.init = true
// Once the resolvedTimestamp is initialized, all prior written intents
// should be accounted for, so reference counts for transactions that
// would drop below zero will all be due to aborted transactions. These
// can all be ignored.
rts.intentQ.AllowNegRefCount(false)
- return rts.recompute()
+ return rts.recompute(ctx)
}
// IsInit returns whether the resolved timestamp is initialized.
@@ -128,11 +128,11 @@ func (rts *resolvedTimestamp) IsInit() bool {
// ForwardClosedTS indicates that the closed timestamp that serves as the basis
// for the resolved timestamp has advanced. The method returns whether this
// caused the resolved timestamp to move forward.
-func (rts *resolvedTimestamp) ForwardClosedTS(newClosedTS hlc.Timestamp) bool {
+func (rts *resolvedTimestamp) ForwardClosedTS(ctx context.Context, newClosedTS hlc.Timestamp) bool {
if rts.closedTS.Forward(newClosedTS) {
- return rts.recompute()
+ return rts.recompute(ctx)
}
- rts.assertNoChange()
+ rts.assertNoChange(ctx)
return false
}
@@ -144,9 +144,9 @@ func (rts *resolvedTimestamp) ConsumeLogicalOp(
ctx context.Context, op enginepb.MVCCLogicalOp,
) bool {
if rts.consumeLogicalOp(ctx, op) {
- return rts.recompute()
+ return rts.recompute(ctx)
}
- rts.assertNoChange()
+ rts.assertNoChange(ctx)
return false
}
@@ -234,20 +234,21 @@ func (rts *resolvedTimestamp) consumeLogicalOp(
return rts.intentQ.Del(t.TxnID)
default:
- panic(errors.AssertionFailedf("unknown logical op %T", t))
+ log.Fatalf(ctx, "unknown logical op %T", t)
+ return false
}
}
// recompute computes the resolved timestamp based on its respective closed
// timestamp and the in-flight intents that it is tracking. The method returns
// whether this caused the resolved timestamp to move forward.
-func (rts *resolvedTimestamp) recompute() bool {
+func (rts *resolvedTimestamp) recompute(ctx context.Context) bool {
if !rts.IsInit() {
return false
}
if rts.closedTS.Less(rts.resolvedTS) {
- panic(fmt.Sprintf("closed timestamp below resolved timestamp: %s < %s",
- rts.closedTS, rts.resolvedTS))
+ log.Fatalf(ctx, "closed timestamp below resolved timestamp: %s < %s",
+ rts.closedTS, rts.resolvedTS)
}
newTS := rts.closedTS
@@ -255,8 +256,8 @@ func (rts *resolvedTimestamp) recompute() bool {
// timestamps cannot be resolved yet.
if txn := rts.intentQ.Oldest(); txn != nil {
if txn.timestamp.LessEq(rts.resolvedTS) {
- panic(fmt.Sprintf("unresolved txn equal to or below resolved timestamp: %s <= %s",
- txn.timestamp, rts.resolvedTS))
+ log.Fatalf(ctx, "unresolved txn equal to or below resolved timestamp: %s <= %s",
+ txn.timestamp, rts.resolvedTS)
}
// txn.timestamp cannot be resolved, so the resolved timestamp must be Prev.
txnTS := txn.timestamp.Prev()
@@ -267,8 +268,8 @@ func (rts *resolvedTimestamp) recompute() bool {
newTS.Logical = 0
if newTS.Less(rts.resolvedTS) {
- panic(fmt.Sprintf("resolved timestamp regression, was %s, recomputed as %s",
- rts.resolvedTS, newTS))
+ log.Fatalf(ctx, "resolved timestamp regression, was %s, recomputed as %s",
+ rts.resolvedTS, newTS)
}
return rts.resolvedTS.Forward(newTS)
}
@@ -276,12 +277,12 @@ func (rts *resolvedTimestamp) recompute() bool {
// assertNoChange asserts that a recomputation of the resolved timestamp does
// not change its value. A violation of this assertion would indicate a logic
// error in the resolvedTimestamp implementation.
-func (rts *resolvedTimestamp) assertNoChange() {
+func (rts *resolvedTimestamp) assertNoChange(ctx context.Context) {
before := rts.resolvedTS
- changed := rts.recompute()
+ changed := rts.recompute(ctx)
if changed || !before.EqOrdering(rts.resolvedTS) {
- panic(fmt.Sprintf("unexpected resolved timestamp change on recomputation, "+
- "was %s, recomputed as %s", before, rts.resolvedTS))
+ log.Fatalf(ctx, "unexpected resolved timestamp change on recomputation, "+
+ "was %s, recomputed as %s", before, rts.resolvedTS)
}
}
@@ -295,9 +296,7 @@ func (rts *resolvedTimestamp) assertOpAboveRTS(
err := errors.AssertionFailedf(
"resolved timestamp %s equal to or above timestamp of operation %v", rts.resolvedTS, op)
if fatal {
- // TODO(erikgrinaker): use log.Fatalf. Panic for now, since tests expect
- // it and to minimize code churn for backports.
- panic(err)
+ log.Fatalf(ctx, "%v", err)
} else {
log.Errorf(ctx, "%v", err)
}
diff --git a/pkg/kv/kvserver/rangefeed/resolved_timestamp_test.go b/pkg/kv/kvserver/rangefeed/resolved_timestamp_test.go
index b13f54c17a64..466f9df6bfa2 100644
--- a/pkg/kv/kvserver/rangefeed/resolved_timestamp_test.go
+++ b/pkg/kv/kvserver/rangefeed/resolved_timestamp_test.go
@@ -183,7 +183,7 @@ func TestResolvedTimestamp(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
rts := makeResolvedTimestamp(cluster.MakeTestingClusterSettings())
- rts.Init()
+ rts.Init(ctx)
// Test empty resolved timestamp.
require.Equal(t, hlc.Timestamp{}, rts.Get())
@@ -201,20 +201,10 @@ func TestResolvedTimestamp(t *testing.T) {
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Set a closed timestamp. Resolved timestamp advances.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 5})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 5})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 5}, rts.Get())
- // Write intent at earlier timestamp. Assertion failure.
- require.Panics(t, func() {
- rts.ConsumeLogicalOp(ctx, writeIntentOp(uuid.MakeV4(), hlc.Timestamp{WallTime: 3}))
- })
-
- // Write value at earlier timestamp. Assertion failure.
- require.Panics(t, func() {
- rts.ConsumeLogicalOp(ctx, writeValueOp(hlc.Timestamp{WallTime: 4}))
- })
-
// Write value at later timestamp. No effect on resolved timestamp.
fwd = rts.ConsumeLogicalOp(ctx, writeValueOp(hlc.Timestamp{WallTime: 6}))
require.False(t, fwd)
@@ -222,7 +212,7 @@ func TestResolvedTimestamp(t *testing.T) {
// Forward closed timestamp. Resolved timestamp advances to the timestamp of
// the earliest intent.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 15})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 15})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 9}, rts.Get())
@@ -237,7 +227,7 @@ func TestResolvedTimestamp(t *testing.T) {
require.Equal(t, hlc.Timestamp{WallTime: 15}, rts.Get())
// Forward closed timestamp to same time as earliest intent.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 18})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 18})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 17}, rts.Get())
@@ -253,7 +243,7 @@ func TestResolvedTimestamp(t *testing.T) {
require.Equal(t, hlc.Timestamp{WallTime: 18}, rts.Get())
// Forward closed timestamp. Resolved timestamp moves to earliest intent.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 30})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 30})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 19}, rts.Get())
@@ -304,7 +294,7 @@ func TestResolvedTimestamp(t *testing.T) {
require.Equal(t, hlc.Timestamp{WallTime: 30}, rts.Get())
// Forward closed timestamp. Resolved timestamp moves to earliest intent.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 40})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 40})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 34}, rts.Get())
@@ -330,7 +320,7 @@ func TestResolvedTimestamp(t *testing.T) {
require.Equal(t, hlc.Timestamp{WallTime: 40}, rts.Get())
// Forward closed timestamp. Resolved timestamp moves to earliest intent.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 50})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 50})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 45}, rts.Get())
@@ -356,7 +346,7 @@ func TestResolvedTimestampNoClosedTimestamp(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
rts := makeResolvedTimestamp(cluster.MakeTestingClusterSettings())
- rts.Init()
+ rts.Init(ctx)
// Add a value. No closed timestamp so no resolved timestamp.
fwd := rts.ConsumeLogicalOp(ctx, writeValueOp(hlc.Timestamp{WallTime: 1}))
@@ -393,31 +383,32 @@ func TestResolvedTimestampNoClosedTimestamp(t *testing.T) {
func TestResolvedTimestampNoIntents(t *testing.T) {
defer leaktest.AfterTest(t)()
+ ctx := context.Background()
rts := makeResolvedTimestamp(cluster.MakeTestingClusterSettings())
- rts.Init()
+ rts.Init(ctx)
// Set a closed timestamp. Resolved timestamp advances.
- fwd := rts.ForwardClosedTS(hlc.Timestamp{WallTime: 1})
+ fwd := rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 1})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 1}, rts.Get())
// Forward closed timestamp. Resolved timestamp advances.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 3})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 3})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 3}, rts.Get())
// Smaller closed timestamp. Resolved timestamp does not advance.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 2})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 2})
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 3}, rts.Get())
// Equal closed timestamp. Resolved timestamp does not advance.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 3})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 3})
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 3}, rts.Get())
// Forward closed timestamp. Resolved timestamp advances.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 4})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 4})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 4}, rts.Get())
}
@@ -431,12 +422,12 @@ func TestResolvedTimestampInit(t *testing.T) {
rts := makeResolvedTimestamp(cluster.MakeTestingClusterSettings())
// Set a closed timestamp. Not initialized so no resolved timestamp.
- fwd := rts.ForwardClosedTS(hlc.Timestamp{WallTime: 5})
+ fwd := rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 5})
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Init. Resolved timestamp moves to closed timestamp.
- fwd = rts.Init()
+ fwd = rts.Init(ctx)
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 5}, rts.Get())
})
@@ -450,7 +441,7 @@ func TestResolvedTimestampInit(t *testing.T) {
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Init. Resolved timestamp undefined.
- fwd = rts.Init()
+ fwd = rts.Init(ctx)
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{}, rts.Get())
})
@@ -464,12 +455,12 @@ func TestResolvedTimestampInit(t *testing.T) {
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Set a closed timestamp. Not initialized so no resolved timestamp.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 5})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 5})
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Init. Resolved timestamp moves below first unresolved intent.
- fwd = rts.Init()
+ fwd = rts.Init(ctx)
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 2}, rts.Get())
})
@@ -496,12 +487,12 @@ func TestResolvedTimestampInit(t *testing.T) {
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Set a closed timestamp. Not initialized so no resolved timestamp.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 5})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 5})
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{}, rts.Get())
// Init. Resolved timestamp moves to closed timestamp.
- fwd = rts.Init()
+ fwd = rts.Init(ctx)
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 5}, rts.Get())
})
@@ -516,7 +507,7 @@ func TestResolvedTimestampInit(t *testing.T) {
// Init. Negative txn ref count causes panic. Init should not have
// been called because an intent must not have been accounted for.
- require.Panics(t, func() { rts.Init() })
+ require.Panics(t, func() { rts.Init(ctx) })
})
}
@@ -524,10 +515,10 @@ func TestResolvedTimestampTxnAborted(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
rts := makeResolvedTimestamp(cluster.MakeTestingClusterSettings())
- rts.Init()
+ rts.Init(ctx)
// Set a closed timestamp. Resolved timestamp advances.
- fwd := rts.ForwardClosedTS(hlc.Timestamp{WallTime: 5})
+ fwd := rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 5})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 5}, rts.Get())
@@ -538,7 +529,7 @@ func TestResolvedTimestampTxnAborted(t *testing.T) {
require.Equal(t, hlc.Timestamp{WallTime: 5}, rts.Get())
// Set a new closed timestamp. Resolved timestamp advances.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 15})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 15})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 9}, rts.Get())
@@ -565,7 +556,7 @@ func TestResolvedTimestampTxnAborted(t *testing.T) {
// Set a new closed timestamp. Resolved timestamp advances, but only up to
// the timestamp of txn1's intent, which we fail remember is uncommittable.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 25})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 25})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 19}, rts.Get())
@@ -581,10 +572,10 @@ func TestClosedTimestampLogicalPart(t *testing.T) {
defer log.Scope(t).Close(t)
ctx := context.Background()
rts := makeResolvedTimestamp(cluster.MakeTestingClusterSettings())
- rts.Init()
+ rts.Init(ctx)
// Set a new closed timestamp. Resolved timestamp advances.
- fwd := rts.ForwardClosedTS(hlc.Timestamp{WallTime: 10, Logical: 2})
+ fwd := rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 10, Logical: 2})
require.True(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 10, Logical: 0}, rts.Get())
@@ -597,7 +588,7 @@ func TestClosedTimestampLogicalPart(t *testing.T) {
// Set a new closed timestamp. Resolved timestamp doesn't advance, since it
// could only theoretically advance up to 10.4, and it doesn't do logical
// parts.
- fwd = rts.ForwardClosedTS(hlc.Timestamp{WallTime: 11, Logical: 6})
+ fwd = rts.ForwardClosedTS(ctx, hlc.Timestamp{WallTime: 11, Logical: 6})
require.False(t, fwd)
require.Equal(t, hlc.Timestamp{WallTime: 10, Logical: 0}, rts.Get())
diff --git a/pkg/kv/kvserver/rangefeed/scheduled_processor.go b/pkg/kv/kvserver/rangefeed/scheduled_processor.go
index 3754f410e01f..f4a295d0ca8c 100644
--- a/pkg/kv/kvserver/rangefeed/scheduled_processor.go
+++ b/pkg/kv/kvserver/rangefeed/scheduled_processor.go
@@ -12,7 +12,6 @@ package rangefeed
import (
"context"
- "fmt"
"time"
"github.com/cockroachdb/cockroach/pkg/kv/kvpb"
@@ -228,6 +227,7 @@ func (p *ScheduledProcessor) processStop() {
}
func (p *ScheduledProcessor) cleanup() {
+ ctx := p.AmbientContext.AnnotateCtx(context.Background())
// Cleanup is normally called when all registrations are disconnected and
// unregistered or were not created yet (processor start failure).
// However, there's a case where processor is stopped by replica action while
@@ -237,14 +237,14 @@ func (p *ScheduledProcessor) cleanup() {
// To avoid leaking any registry resources and metrics, processor performs
// explicit registry termination in that case.
pErr := kvpb.NewError(&kvpb.NodeUnavailableError{})
- p.reg.DisconnectAllOnShutdown(pErr)
+ p.reg.DisconnectAllOnShutdown(ctx, pErr)
// Unregister callback from scheduler
p.scheduler.Unregister()
p.taskCancel()
close(p.stoppedC)
- p.MemBudget.Close(context.Background())
+ p.MemBudget.Close(ctx)
}
// Stop shuts down the processor and closes all registrations. Safe to call on
@@ -271,13 +271,13 @@ func (p *ScheduledProcessor) DisconnectSpanWithErr(span roachpb.Span, pErr *kvpb
return
}
p.enqueueRequest(func(ctx context.Context) {
- p.reg.DisconnectWithErr(span, pErr)
+ p.reg.DisconnectWithErr(ctx, span, pErr)
})
}
func (p *ScheduledProcessor) sendStop(pErr *kvpb.Error) {
p.enqueueRequest(func(ctx context.Context) {
- p.reg.DisconnectWithErr(all, pErr)
+ p.reg.DisconnectWithErr(ctx, all, pErr)
// First set stopping flag to ensure that once all registrations are removed
// processor should stop.
p.stopping = true
@@ -331,7 +331,7 @@ func (p *ScheduledProcessor) Register(
}
// Add the new registration to the registry.
- p.reg.Register(&r)
+ p.reg.Register(ctx, &r)
// Prep response with filter that includes the new registration.
f := p.reg.NewFilter()
@@ -645,7 +645,7 @@ func (p *ScheduledProcessor) consumeEvent(ctx context.Context, e *event) {
p.consumeSSTable(ctx, e.sst.data, e.sst.span, e.sst.ts, e.alloc)
case e.sync != nil:
if e.sync.testRegCatchupSpan != nil {
- if err := p.reg.waitForCaughtUp(*e.sync.testRegCatchupSpan); err != nil {
+ if err := p.reg.waitForCaughtUp(ctx, *e.sync.testRegCatchupSpan); err != nil {
log.Errorf(
ctx,
"error waiting for registries to catch up during test, results might be impacted: %s",
@@ -655,7 +655,7 @@ func (p *ScheduledProcessor) consumeEvent(ctx context.Context, e *event) {
}
close(e.sync.c)
default:
- panic(fmt.Sprintf("missing event variant: %+v", e))
+ log.Fatalf(ctx, "missing event variant: %+v", e)
}
}
@@ -693,7 +693,7 @@ func (p *ScheduledProcessor) consumeLogicalOps(
// No updates to publish.
default:
- panic(errors.AssertionFailedf("unknown logical op %T", t))
+ log.Fatalf(ctx, "unknown logical op %T", t)
}
// Determine whether the operation caused the resolved timestamp to
@@ -715,13 +715,13 @@ func (p *ScheduledProcessor) consumeSSTable(
}
func (p *ScheduledProcessor) forwardClosedTS(ctx context.Context, newClosedTS hlc.Timestamp) {
- if p.rts.ForwardClosedTS(newClosedTS) {
+ if p.rts.ForwardClosedTS(ctx, newClosedTS) {
p.publishCheckpoint(ctx)
}
}
func (p *ScheduledProcessor) initResolvedTS(ctx context.Context) {
- if p.rts.Init() {
+ if p.rts.Init(ctx) {
p.publishCheckpoint(ctx)
}
}
@@ -781,10 +781,10 @@ func (p *ScheduledProcessor) publishSSTable(
alloc *SharedBudgetAllocation,
) {
if sstSpan.Equal(roachpb.Span{}) {
- panic(errors.AssertionFailedf("received SSTable without span"))
+ log.Fatalf(ctx, "received SSTable without span")
}
if sstWTS.IsEmpty() {
- panic(errors.AssertionFailedf("received SSTable without write timestamp"))
+ log.Fatalf(ctx, "received SSTable without write timestamp")
}
p.reg.PublishToOverlapping(ctx, sstSpan, &kvpb.RangeFeedEvent{
SST: &kvpb.RangeFeedSSTable{
|
4f202edfe67b752f1c9f0b08f6e466c3c91e07ce
|
2017-10-09 21:13:46
|
Richard Wu
|
distsql: add cli flag for specifying temp storage directory
| false
|
add cli flag for specifying temp storage directory
|
distsql
|
diff --git a/pkg/base/config.go b/pkg/base/config.go
index 18412e1e53f7..71a768282152 100644
--- a/pkg/base/config.go
+++ b/pkg/base/config.go
@@ -390,3 +390,56 @@ func DefaultRetryOptions() retry.Options {
Multiplier: 2,
}
}
+
+const (
+ // DefaultTempStorageMaxSizeBytes is the default maximum budget
+ // for temp storage.
+ DefaultTempStorageMaxSizeBytes = 32 * 1024 * 1024 * 1024 /* 32GB */
+ // DefaultInMemTempStorageMaxSizeBytes is the default maximum budget
+ // for in-memory temp storages.
+ DefaultInMemTempStorageMaxSizeBytes = 100 * 1024 * 1024 /* 100MB */
+)
+
+// TempStorageConfig contains the details that can be specified in the cli
+// pertaining to temp storage flags, specifically --temp-dir and
+// --max-disk-temp-storage.
+type TempStorageConfig struct {
+ // InMemory specifies whether the temporary storage will remain
+ // in-memory or occupy a temporary subdirectory on-disk.
+ InMemory bool
+ // ParentDir is the path to the parent directory where the temporary
+ // subdirectory (with filepath Path) for temp storage will be created.
+ ParentDir string
+ // Path is the filepath of the temporary subdirectory created for
+ // the temp storage.
+ Path string
+ // MaxSizeBytes is the space budget allocated for temp storage. This
+ // will either be a limit in-memory (if InMemory is true) or on-disk.
+ // If the budget is exceeded, no further allocations on temp storage
+ // will be permitted unless space is freed from previous allocations.
+ MaxSizeBytes int64
+}
+
+// TempStorageConfigFromEnv creates a TempStorageConfig.
+// If parentDir is not specified and the specified store is in-memory,
+// then the temp storage will also be in-memory.
+// If parentDir is unspecified but the specified store has an on-disk path,
+// parentDir will be defaulted to the store's path.
+func TempStorageConfigFromEnv(
+ firstStore StoreSpec, parentDir string, maxSizeBytes int64,
+) TempStorageConfig {
+ tsc := TempStorageConfig{
+ ParentDir: parentDir,
+ MaxSizeBytes: maxSizeBytes,
+ }
+
+ if tsc.ParentDir == "" {
+ if firstStore.InMemory {
+ tsc.InMemory = true
+ } else {
+ tsc.ParentDir = firstStore.Path
+ }
+ }
+
+ return tsc
+}
diff --git a/pkg/base/test_server_args.go b/pkg/base/test_server_args.go
index 617267b7fadf..abf4e3ce883d 100644
--- a/pkg/base/test_server_args.go
+++ b/pkg/base/test_server_args.go
@@ -53,12 +53,17 @@ type TestServerArgs struct {
// will be set to the the address of the cluster's first node.
JoinAddr string
- // StoreSpecs define the stores for this server. If you want more than one
- // store per node, populate this array with StoreSpecs each representing a
- // store. If no StoreSpecs are provided than a single DefaultTestStoreSpec
- // will be used.
+ // StoreSpecs define the stores for this server. If you want more than
+ // one store per node, populate this array with StoreSpecs each
+ // representing a store. If no StoreSpecs are provided then a single
+ // DefaultTestStoreSpec will be used.
StoreSpecs []StoreSpec
+ // TempStorageConfig defines parameters for the temp storage used as
+ // working memory for distributed operations and CSV importing.
+ // If not initialized, will default to DefaultTestTempStorageConfig.
+ TempStorageConfig TempStorageConfig
+
// Fields copied to the server.Config.
Insecure bool
RetryOptions retry.Options
@@ -111,11 +116,20 @@ type TestClusterArgs struct {
ServerArgsPerNode map[int]TestServerArgs
}
-// DefaultTestStoreSpec is just a single in memory store of 100 MiB with no
-// special attributes.
-var DefaultTestStoreSpec = StoreSpec{
- InMemory: true,
-}
+var (
+ // DefaultTestStoreSpec is just a single in memory store of 100 MiB
+ // with no special attributes.
+ DefaultTestStoreSpec = StoreSpec{
+ InMemory: true,
+ }
+ // DefaultTestTempStorageConfig is the associated temp storage for
+ // DefaultTestStoreSpec that is in-memory.
+ // It has a maximum size of 100MiB.
+ DefaultTestTempStorageConfig = TempStorageConfig{
+ InMemory: true,
+ MaxSizeBytes: DefaultInMemTempStorageMaxSizeBytes,
+ }
+)
// TestClusterReplicationMode represents the replication settings for a TestCluster.
type TestClusterReplicationMode int
diff --git a/pkg/cli/cliflags/flags.go b/pkg/cli/cliflags/flags.go
index e87e9785b46a..5c3ef1401575 100644
--- a/pkg/cli/cliflags/flags.go
+++ b/pkg/cli/cliflags/flags.go
@@ -458,6 +458,24 @@ Also, if you use equal signs in the file path to a store, you must use the
"path" field label.`,
}
+ TempDir = FlagInfo{
+ Name: "temp-dir",
+ Description: `
+The parent directory path where a temporary subdirectory will be created to be used for temporary files.
+This path must exist or the node will not start.
+The temporary subdirectory is used primarily as working memory for distributed computations
+and CSV importing.
+For example, the following will generate an arbitrary, temporary subdirectory
+"/mnt/ssd01/temp/cockroach-temp<NUMBER>":
+<PRE>
+
+ --temp-dir=/mnt/ssd01/temp
+
+</PRE>
+If this flag is unspecified, the temporary subdirectory will be located under
+the root of the first store.`,
+ }
+
URL = FlagInfo{
Name: "url",
EnvVar: "COCKROACH_URL",
diff --git a/pkg/cli/flags.go b/pkg/cli/flags.go
index ca5292b5a244..a1bb20503eda 100644
--- a/pkg/cli/flags.go
+++ b/pkg/cli/flags.go
@@ -253,6 +253,7 @@ func init() {
// the stores flag has been parsed and the storage device that a percentage
// refers to becomes known.
varFlag(f, diskTempStorageSizeValue, cliflags.SQLTempStorage)
+ stringFlag(f, &serverCfg.TempStorageConfig.ParentDir, cliflags.TempDir, "")
}
for _, cmd := range certCmds {
diff --git a/pkg/cli/start.go b/pkg/cli/start.go
index bda343550ee6..4ab520bc5e41 100644
--- a/pkg/cli/start.go
+++ b/pkg/cli/start.go
@@ -416,17 +416,18 @@ func runStart(cmd *cobra.Command, args []string) error {
// Deal with flags that may depend on other flags.
+ firstStore := serverCfg.Stores.Specs[0]
// The temp store size can depend on the location of the first regular store
// (if it's expressed as a percentage), so we resolve that flag here.
var tempStorePercentageResolver percentResolverFunc
- if !serverCfg.Stores.Specs[0].InMemory {
- dir := serverCfg.Stores.Specs[0].Path
+ var err error
+ if !firstStore.InMemory {
+ dir := firstStore.Path
// Create the store dir, if it doesn't exist. The dir is required to exist
// by diskPercentResolverFactory.
if err := os.MkdirAll(dir, 0755); err != nil {
return errors.Wrapf(err, "failed to create dir for first store: %s", dir)
}
- var err error
tempStorePercentageResolver, err = diskPercentResolverFactory(dir)
if err != nil {
return errors.Wrapf(err, "failed to create resolver for: %s", dir)
@@ -435,23 +436,29 @@ func runStart(cmd *cobra.Command, args []string) error {
tempStorePercentageResolver = memoryPercentResolver
}
if err := diskTempStorageSizeValue.Resolve(
- &serverCfg.TempStoreMaxSizeBytes, tempStorePercentageResolver,
+ &serverCfg.TempStorageConfig.MaxSizeBytes, tempStorePercentageResolver,
); err != nil {
return err
}
- if serverCfg.Stores.Specs[0].InMemory && !diskTempStorageSizeValue.IsSet() {
- // The default temp store size is different when the first store (and thus
- // also the temp storage) is in memory.
- serverCfg.TempStoreMaxSizeBytes = server.DefaultTempStoreMaxSizeBytesInMemStore
+ if firstStore.InMemory && !diskTempStorageSizeValue.IsSet() {
+ // The default temp store size is different when the first
+ // store (and thus also the temp storage) is in memory.
+ serverCfg.TempStorageConfig.MaxSizeBytes = base.DefaultInMemTempStorageMaxSizeBytes
}
+ // Re-initialize temp storage based on the current attributes
+ // (initialized from CLI flags and above) and the first store's spec.
+ serverCfg.TempStorageConfig = base.TempStorageConfigFromEnv(
+ firstStore,
+ serverCfg.TempStorageConfig.ParentDir,
+ serverCfg.TempStorageConfig.MaxSizeBytes,
+ )
+
// Use the server-specific values for some flags and settings.
serverCfg.Insecure = startCtx.serverInsecure
serverCfg.SSLCertsDir = startCtx.serverSSLCertsDir
serverCfg.User = security.NodeUser
- serverCfg.TempStoreSpec = server.MakeTempStoreSpecFromStoreSpec(serverCfg.Stores.Specs[0])
-
signalCh := make(chan os.Signal, 1)
signal.Notify(signalCh, syscall.SIGINT, syscall.SIGTERM, syscall.SIGQUIT)
diff --git a/pkg/server/config.go b/pkg/server/config.go
index d42c27db3812..d5e65c326a88 100644
--- a/pkg/server/config.go
+++ b/pkg/server/config.go
@@ -31,8 +31,6 @@ import (
"github.com/pkg/errors"
"golang.org/x/net/context"
- "path/filepath"
-
"github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/gossip/resolver"
"github.com/cockroachdb/cockroach/pkg/roachpb"
@@ -57,19 +55,19 @@ const (
// system we're running on (development or production or some shared
// environment). Production users should almost certainly override these
// settings and we'll warn in the logs about doing so.
- DefaultCacheSize = 128 << 20 // 128 MB
- defaultSQLMemoryPoolSize = 128 << 20 // 128 MB
- defaultScanInterval = 10 * time.Minute
- defaultScanMaxIdleTime = 200 * time.Millisecond
- defaultMetricsSampleInterval = 10 * time.Second
- defaultStorePath = "cockroach-data"
- defaultTempStoreRelativePath = "local"
+ DefaultCacheSize = 128 << 20 // 128 MB
+ defaultSQLMemoryPoolSize = 128 << 20 // 128 MB
+ defaultScanInterval = 10 * time.Minute
+ defaultScanMaxIdleTime = 200 * time.Millisecond
+ defaultMetricsSampleInterval = 10 * time.Second
+ defaultStorePath = "cockroach-data"
+ defaultTempStorageDirPrefix = "cockroach-temp"
+ // tempStorageDirsRecordFilename is the filename for the record file
+ // that keeps track of the paths of the temporary directories created.
+ // This file will be stored under the first store's root.
+ tempStorageDirsRecordFilename = "temp-storage-dirs.txt"
defaultEventLogEnabled = true
defaultEnableWebSessionAuthentication = false
- defaultTempStoreMaxSizeBytes = 32 * 1024 * 1024 * 1024 /* 32GB */
- // default size of the "disk" temp storage when the first store is in memory.
- // In this case, the temp storage will also be in memory.
- DefaultTempStoreMaxSizeBytesInMemStore = 100 * 1024 * 1024 /* 100MB */
maximumMaxClockOffset = 5 * time.Second
@@ -130,13 +128,9 @@ type Config struct {
// Stores is specified to enable durable key-value storage.
Stores base.StoreSpecList
- // TempStoreSpec is used to store ephemeral data when processing large queries.
- TempStoreSpec base.StoreSpec
- // TempStoreMaxSizeBytes is the limit on the disk capacity to be used for temp
- // storage. Note that TempStoreSpec.SizeInBytes is not used for this purpose;
- // that spec setting is only used for regular stores for rebalancing purposes,
- // and not particularly enforced, so we opt for our own setting.
- TempStoreMaxSizeBytes int64
+ // TempStorageConfig is used to store ephemeral data when processing large
+ // queries.
+ TempStorageConfig base.TempStorageConfig
// Attrs specifies a colon-separated list of node topography or machine
// capabilities, used to match capabilities or location preferences specified
@@ -347,23 +341,6 @@ func SetOpenFileLimitForOneStore() (uint64, error) {
return setOpenFileLimit(1)
}
-// MakeTempStoreSpecFromStoreSpec creates a spec for a temporary store under
-// the given StoreSpec's path. If the given spec specifies an in-memory store,
-// the temporary store will be in-memory as well. The Attributes field of the
-// given spec is intentionally not propagated to the temporary store.
-//
-// TODO(arjun): Add a CLI flag to override this.
-func MakeTempStoreSpecFromStoreSpec(spec base.StoreSpec) base.StoreSpec {
- if spec.InMemory {
- return base.StoreSpec{
- InMemory: true,
- }
- }
- return base.StoreSpec{
- Path: filepath.Join(spec.Path, defaultTempStoreRelativePath),
- }
-}
-
// MakeConfig returns a Context with default values.
func MakeConfig(st *cluster.Settings) Config {
storeSpec, err := base.NewStoreSpec(defaultStorePath)
@@ -385,8 +362,7 @@ func MakeConfig(st *cluster.Settings) Config {
Stores: base.StoreSpecList{
Specs: []base.StoreSpec{storeSpec},
},
- TempStoreSpec: MakeTempStoreSpecFromStoreSpec(storeSpec),
- TempStoreMaxSizeBytes: defaultTempStoreMaxSizeBytes,
+ TempStorageConfig: base.TempStorageConfigFromEnv(storeSpec, "", base.DefaultTempStorageMaxSizeBytes),
}
cfg.AmbientCtx.Tracer = st.Tracer
diff --git a/pkg/server/config_test.go b/pkg/server/config_test.go
index 2ad0fe95ba59..75b0bd39d842 100644
--- a/pkg/server/config_test.go
+++ b/pkg/server/config_test.go
@@ -17,7 +17,6 @@ package server
import (
"os"
"reflect"
- "strings"
"testing"
"time"
@@ -201,39 +200,3 @@ func TestFilterGossipBootstrapResolvers(t *testing.T) {
t.Fatalf("expected resolver to be %q; got %q", resolverSpecs[1], filtered[0].Addr())
}
}
-
-func TestTempStoreDerivation(t *testing.T) {
- defer leaktest.AfterTest(t)()
-
- testCases := []struct {
- firstStoreArg string
- expectedTempSpec base.StoreSpec
- }{
- {
- firstStoreArg: "type=mem,size=1GiB",
- expectedTempSpec: base.StoreSpec{InMemory: true},
- },
- {
- firstStoreArg: "type=mem,size=1GiB,attrs=garbage:moregarbage",
- expectedTempSpec: base.StoreSpec{InMemory: true},
- },
- {
- firstStoreArg: "path=/foo/bar",
- expectedTempSpec: base.StoreSpec{Path: "/foo/bar/local"},
- },
- }
-
- for i, tc := range testCases {
- spec, err := base.NewStoreSpec(tc.firstStoreArg)
- if err != nil {
- t.Fatal(err)
- }
-
- if e, a := tc.expectedTempSpec, MakeTempStoreSpecFromStoreSpec(spec); e.String() != a.String() {
- t.Fatalf(
- "%d: temp store spec did not match expected:\n%s",
- i, strings.Join(pretty.Diff(e, a), "\n"),
- )
- }
- }
-}
diff --git a/pkg/server/server.go b/pkg/server/server.go
index b34c2f15d5ad..a23b8add25ec 100644
--- a/pkg/server/server.go
+++ b/pkg/server/server.go
@@ -15,6 +15,7 @@
package server
import (
+ "bufio"
"compress/gzip"
"crypto/tls"
"fmt"
@@ -292,11 +293,56 @@ func NewServer(cfg Config, stopper *stop.Stopper) (*Server, error) {
rootSQLMemoryMonitor.Start(context.Background(), nil, mon.MakeStandaloneBudget(s.cfg.SQLMemoryPoolSize))
// Set up the DistSQL temp engine.
- tempEngine, err := engine.NewTempEngine(ctx, s.cfg.TempStoreSpec)
+
+ // We first clean up abandoned temporary directories from the temporary
+ // directory record file.
+ firstStore := s.cfg.Stores.Specs[0]
+ // Record file can only exist if the first store is on-disk.
+ if !firstStore.InMemory {
+ if err := cleanupTempDirs(firstStore.Path); err != nil {
+ return nil, errors.Wrap(err, "could not cleanup temporary directories from record file")
+ }
+ }
+ // Create the temporary subdirectory for the temp engine.
+ var err error
+ if s.cfg.TempStorageConfig.Path, err = createTempDir(s.cfg.TempStorageConfig.ParentDir); err != nil {
+ return nil, errors.Wrap(err, "could not create temporary directory for temp storage")
+ }
+
+ // We record the new temporary directory in the record file (if it
+ // exists) for cleanup in case the node crashes.
+ if !firstStore.InMemory {
+ // Create the store dir, if it doesn't exist. The dir is required to exist
+ // by recordTempDir.
+ if err := os.MkdirAll(firstStore.Path, 0755); err != nil {
+ return nil, errors.Wrapf(err, "failed to create dir for first store: %s", firstStore.Path)
+ }
+ if err = recordTempDir(firstStore.Path, s.cfg.TempStorageConfig.Path); err != nil {
+ return nil, errors.Wrapf(
+ err,
+ "could not record temporary directory path to record file: %s",
+ filepath.Join(firstStore.Path, tempStorageDirsRecordFilename),
+ )
+ }
+ }
+ tempEngine, err := engine.NewTempEngine(s.cfg.TempStorageConfig)
if err != nil {
- log.Fatalf(ctx, "could not create temporary store: %v", err)
+ return nil, errors.Wrap(err, "could not create temp storage")
}
s.stopper.AddCloser(tempEngine)
+ // Remove temporary directory linked to tempEngine after closing
+ // tempEngine.
+ s.stopper.AddCloser(stop.CloserFn(func() {
+ var err error
+ if firstStore.InMemory {
+ err = os.RemoveAll(s.cfg.TempStorageConfig.Path)
+ } else {
+ err = cleanupTempDirs(firstStore.Path)
+ }
+ if err != nil {
+ log.Errorf(context.TODO(), "could not remove temporary store directory: %v", err.Error())
+ }
+ }))
// Set up admin memory metrics for use by admin SQL executors.
s.adminMemMetrics = sql.MakeMemMetrics("admin", cfg.HistogramWindowInterval())
@@ -363,7 +409,7 @@ func NewServer(cfg Config, stopper *stop.Stopper) (*Server, error) {
NodeID: &s.nodeIDContainer,
TempStorage: tempEngine,
- TempStorageMaxSizeBytes: s.cfg.TempStoreMaxSizeBytes,
+ TempStorageMaxSizeBytes: s.cfg.TempStorageConfig.MaxSizeBytes,
ParentMemoryMonitor: &rootSQLMemoryMonitor,
@@ -1335,3 +1381,75 @@ func officialAddr(
return util.NewUnresolvedAddr(lnAddr.Network(), net.JoinHostPort(host, port)), nil
}
+
+// cleanupTempDirs should be invoked on startup (before creating any new
+// temporary directories) to clean up abandoned temporary directories from
+// previous startups.
+// It should also be invoked on shutdown when the server is closed.
+// It reads the temporary paths from the record file named
+// tempStorageDirsRecordFilename in recordDir and removes each directory.
+func cleanupTempDirs(recordDir string) error {
+ // Reading the entire file into memory shouldn't be a problem since
+ // it is extremely rare for this record file to contain more than a few
+ // entries.
+ f, err := os.OpenFile(filepath.Join(recordDir, tempStorageDirsRecordFilename), os.O_RDWR, 0644)
+ // There is no existing record file and thus nothing to clean up.
+ if os.IsNotExist(err) {
+ return nil
+ }
+ if err != nil {
+ return err
+ }
+ defer f.Close()
+
+ scanner := bufio.NewScanner(f)
+ // Iterate through each temporary directory path and remove the
+ // directory.
+ for scanner.Scan() {
+ path := scanner.Text()
+ if path == "" {
+ continue
+ }
+ // If path/directory does not exist, error is nil.
+ if err := os.RemoveAll(path); err != nil {
+ return err
+ }
+ }
+
+ // Clear out the record file now that we're done.
+ if err = f.Truncate(0); err != nil {
+ return err
+ }
+ return f.Sync()
+}
+
+// createTempDir creates a temporary directory under the given parentDir and
+// returns the path of the temporary directory. One should only create
+// temporary directories after calling cleanupTempDirs (see above).
+func createTempDir(parentDir string) (string, error) {
+ // We generate a unique temporary directory with the prefix defaultTempStorageDirPrefix.
+ tempPath, err := ioutil.TempDir(parentDir, defaultTempStorageDirPrefix)
+ if err != nil {
+ return "", err
+ }
+
+ return filepath.Abs(tempPath)
+}
+
+// recordTempDir records tempPath to a record file named
+// tempStorageDirsRecordFilename in recordDir to facilitate deletion of the
+// temporary directory in case the node crashes.
+func recordTempDir(recordDir, tempPath string) error {
+ // If the file does not exist, create it, or append to the file.
+ f, err := os.OpenFile(filepath.Join(recordDir, tempStorageDirsRecordFilename), os.O_APPEND|os.O_CREATE|os.O_WRONLY, 0644)
+ if err != nil {
+ return err
+ }
+ defer f.Close()
+
+ // Record tempPath to the record file.
+ if _, err = f.Write(append([]byte(tempPath), '\n')); err != nil {
+ return err
+ }
+ return f.Sync()
+}
diff --git a/pkg/server/server_test.go b/pkg/server/server_test.go
index 626eb7b86aba..3a58be5217a8 100644
--- a/pkg/server/server_test.go
+++ b/pkg/server/server_test.go
@@ -631,3 +631,155 @@ func TestHeartbeatCallbackForDecommissioning(t *testing.T) {
return nil
})
}
+
+// TestCleanupTempDirs verifies that on server startup, abandoned temporary
+// directories in the record file are removed.
+func TestCleanupTempDirs(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+
+ storeDir, storeDirCleanup := testutils.TempDir(t)
+ defer storeDirCleanup()
+
+ // Create temporary directories and add them to the record file.
+ tempDir1, tempDir1Cleanup := tempStorageDir(t, storeDir)
+ defer tempDir1Cleanup()
+ tempDir2, tempDir2Cleanup := tempStorageDir(t, storeDir)
+ defer tempDir2Cleanup()
+ if err := recordTempDir(storeDir, tempDir1); err != nil {
+ t.Fatal(err)
+ }
+ if err := recordTempDir(storeDir, tempDir2); err != nil {
+ t.Fatal(err)
+ }
+
+ s, _, _ := serverutils.StartServer(t, base.TestServerArgs{
+ StoreSpecs: []base.StoreSpec{{Path: storeDir}},
+ })
+ defer s.Stopper().Stop(context.TODO())
+
+ // Verify that the temporary directories are removed after startup.
+ for i, tempDir := range []string{tempDir1, tempDir2} {
+ _, err := os.Stat(tempDir)
+ // os.Stat returns a nil err if the file exists, so we need to check
+ // the NOT of this condition instead of os.IsExist() (which returns
+ // false and misses this error).
+ if !os.IsNotExist(err) {
+ if err == nil {
+ t.Fatalf("temporary directory %d: %s not cleaned up after stopping server", i, tempDir)
+ } else {
+ // Unexpected error.
+ t.Fatal(err)
+ }
+ }
+ }
+}
+
+// TestTempStorage verifies that on server startup:
+// 1. A temporary directory is created.
+// 2. If store is on disk, The path of the temporary directory is recorded in
+// the store's path.
+// On server shutdown:
+// 3. The temporary directory is removed.
+func TestTempStorage(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+
+ storeDir, storeDirCleanup := testutils.TempDir(t)
+ defer storeDirCleanup()
+ for _, tc := range []struct {
+ name string
+ storeSpec base.StoreSpec
+ }{
+ {
+ name: "OnDiskStore",
+ storeSpec: base.StoreSpec{Path: storeDir},
+ },
+ {
+ name: "InMemStore",
+ storeSpec: base.StoreSpec{InMemory: true},
+ },
+ } {
+ t.Run(tc.name, func(t *testing.T) {
+ tempDir, tempDirCleanup := testutils.TempDir(t)
+ defer tempDirCleanup()
+
+ // This will be cleaned up by tempDirCleanup.
+ tempStorage := base.TempStorageConfigFromEnv(tc.storeSpec, tempDir, base.DefaultTempStorageMaxSizeBytes)
+
+ s, _, _ := serverutils.StartServer(t, base.TestServerArgs{
+ StoreSpecs: []base.StoreSpec{tc.storeSpec},
+ TempStorageConfig: tempStorage,
+ })
+
+ // 1. Verify temporary directory is created. Since
+ // starting a server generates an arbitrary temporary
+ // directory under tempDir, we need to retrieve that
+ // directory and check it exists.
+ files, err := ioutil.ReadDir(tempStorage.ParentDir)
+ if err != nil {
+ t.Fatal(err)
+ }
+ if len(files) != 1 {
+ t.Fatalf("expected only one temporary file to be created during server startup: found %d files", len(files))
+ }
+ tempPath := filepath.Join(tempStorage.ParentDir, files[0].Name())
+
+ // 2. (If on-disk store) Verify that the temporary
+ // directory's path is recorded in the temporary
+ // directory record file under the store's path.
+ if !tc.storeSpec.InMemory {
+ expected := append([]byte(tempPath), '\n')
+ actual, err := ioutil.ReadFile(filepath.Join(storeDir, tempStorageDirsRecordFilename))
+ if err != nil {
+ t.Fatal(err)
+ }
+ if !bytes.Equal(expected, actual) {
+ t.Fatalf("record file not properly appended to.\nexpected: %s\nactual %s", expected, actual)
+ }
+ }
+
+ s.Stopper().Stop(context.TODO())
+
+ // 3. verify that the temporary directory is removed.
+ _, err = os.Stat(tempPath)
+ // os.Stat returns a nil err if the file exists, so we
+ // need to check the NOT of this condition instead of
+ // os.IsExist() (which returns false and misses this
+ // error).
+ if !os.IsNotExist(err) {
+ if err == nil {
+ t.Fatalf("temporary directory %s not cleaned up after stopping server", tempPath)
+ } else {
+ // Unexpected error.
+ t.Fatal(err)
+ }
+ }
+
+ // 4. (If on-disk store) Verify that the removed
+ // temporary directory's path is also removed
+ // from the record file.
+ if !tc.storeSpec.InMemory {
+ contents, err := ioutil.ReadFile(filepath.Join(storeDir, tempStorageDirsRecordFilename))
+ if err != nil {
+ t.Fatal(err)
+ }
+ if len(contents) > 0 {
+ t.Fatalf("temporary directory path not removed from record file.\ncontents: %s", contents)
+ }
+
+ }
+ })
+ }
+}
+
+func tempStorageDir(t *testing.T, dir string) (string, func()) {
+ tempStoragePath, err := ioutil.TempDir(dir, "temp-engine-storage")
+ if err != nil {
+ t.Fatal(err)
+ }
+ cleanup := func() {
+ if err := os.RemoveAll(tempStoragePath); err != nil {
+ t.Fatal(err)
+ }
+ }
+ return tempStoragePath, cleanup
+}
diff --git a/pkg/server/testserver.go b/pkg/server/testserver.go
index 3d35ee7432c1..371c1548541f 100644
--- a/pkg/server/testserver.go
+++ b/pkg/server/testserver.go
@@ -67,8 +67,9 @@ func makeTestConfig(st *cluster.Settings) Config {
// Test servers start in secure mode by default.
cfg.Insecure = false
- // Override the DistSQL local store with an in-memory store.
- cfg.TempStoreSpec = base.DefaultTestStoreSpec
+ // Configure the default in-memory temp storage for all tests unless
+ // otherwise configured.
+ cfg.TempStorageConfig = base.DefaultTestTempStorageConfig
// Load test certs. In addition, the tests requiring certs
// need to call security.SetAssetLoader(securitytest.EmbeddedAssets)
@@ -182,8 +183,11 @@ func makeTestConfigFromParams(params base.TestServerArgs) Config {
// the dir (and the test is then responsible for cleaning it up, not
// TestServer).
}
- // Copy over the store specs.
cfg.Stores = base.StoreSpecList{Specs: params.StoreSpecs}
+ if params.TempStorageConfig != (base.TempStorageConfig{}) {
+ cfg.TempStorageConfig = params.TempStorageConfig
+ }
+
if cfg.TestingKnobs.Store == nil {
cfg.TestingKnobs.Store = &storage.StoreTestingKnobs{}
}
diff --git a/pkg/sql/distsqlrun/disk_row_container_test.go b/pkg/sql/distsqlrun/disk_row_container_test.go
index b23eb52b52e1..3cf1444d8c16 100644
--- a/pkg/sql/distsqlrun/disk_row_container_test.go
+++ b/pkg/sql/distsqlrun/disk_row_container_test.go
@@ -61,7 +61,7 @@ func TestDiskRowContainer(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
- tempEngine, err := engine.NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := engine.NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
@@ -244,7 +244,7 @@ func TestDiskRowContainerDiskFull(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
- tempEngine, err := engine.NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := engine.NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
diff --git a/pkg/sql/distsqlrun/flow.go b/pkg/sql/distsqlrun/flow.go
index 8002fef20764..f62e0cd68d7b 100644
--- a/pkg/sql/distsqlrun/flow.go
+++ b/pkg/sql/distsqlrun/flow.go
@@ -74,6 +74,8 @@ type FlowCtx struct {
// TempStorage is used by some DistSQL processors to store Rows when the
// working set is larger than can be stored in memory.
+ // This is not supposed to be used as a general engine.Engine and thus
+ // one should sparingly use the set of features offered by it.
TempStorage engine.Engine
// diskMonitor is used to monitor temporary storage disk usage.
diskMonitor *mon.BytesMonitor
diff --git a/pkg/sql/distsqlrun/hashjoiner_test.go b/pkg/sql/distsqlrun/hashjoiner_test.go
index ce64d2462156..9fed8f1dc1ad 100644
--- a/pkg/sql/distsqlrun/hashjoiner_test.go
+++ b/pkg/sql/distsqlrun/hashjoiner_test.go
@@ -507,7 +507,7 @@ func TestHashJoiner(t *testing.T) {
}
ctx := context.Background()
- tempEngine, err := engine.NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := engine.NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
diff --git a/pkg/sql/distsqlrun/sorter_test.go b/pkg/sql/distsqlrun/sorter_test.go
index d5e551705d30..711b94e95d28 100644
--- a/pkg/sql/distsqlrun/sorter_test.go
+++ b/pkg/sql/distsqlrun/sorter_test.go
@@ -180,7 +180,7 @@ func TestSorter(t *testing.T) {
}
ctx := context.Background()
- tempEngine, err := engine.NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := engine.NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
diff --git a/pkg/storage/engine/disk_map_test.go b/pkg/storage/engine/disk_map_test.go
index d2427b2a5983..2754504f2dc9 100644
--- a/pkg/storage/engine/disk_map_test.go
+++ b/pkg/storage/engine/disk_map_test.go
@@ -33,7 +33,7 @@ import (
func TestRocksDBMap(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
- tempEngine, err := NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
@@ -134,7 +134,7 @@ func TestRocksDBMap(t *testing.T) {
func TestRocksDBMapSandbox(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
- tempEngine, err := NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
@@ -225,7 +225,7 @@ func TestRocksDBMapSandbox(t *testing.T) {
func TestRocksDBStore(t *testing.T) {
defer leaktest.AfterTest(t)()
ctx := context.Background()
- tempEngine, err := NewTempEngine(ctx, base.DefaultTestStoreSpec)
+ tempEngine, err := NewTempEngine(base.DefaultTestTempStorageConfig)
if err != nil {
t.Fatal(err)
}
@@ -313,7 +313,7 @@ func BenchmarkRocksDBMapWrite(b *testing.B) {
}
}()
ctx := context.Background()
- tempEngine, err := NewTempEngine(ctx, base.StoreSpec{Path: dir})
+ tempEngine, err := NewTempEngine(base.TempStorageConfig{ParentDir: dir})
if err != nil {
b.Fatal(err)
}
@@ -357,8 +357,7 @@ func BenchmarkRocksDBMapIteration(b *testing.B) {
b.Fatal(err)
}
}()
- ctx := context.Background()
- tempEngine, err := NewTempEngine(ctx, base.StoreSpec{Path: dir})
+ tempEngine, err := NewTempEngine(base.TempStorageConfig{ParentDir: dir})
if err != nil {
b.Fatal(err)
}
diff --git a/pkg/storage/engine/temp_engine.go b/pkg/storage/engine/temp_engine.go
index 42f84d14dc5e..0b5e2f92ca2a 100644
--- a/pkg/storage/engine/temp_engine.go
+++ b/pkg/storage/engine/temp_engine.go
@@ -15,36 +15,18 @@
package engine
import (
- "io/ioutil"
- "os"
- "path/filepath"
- "sync"
-
"github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
- "github.com/cockroachdb/cockroach/pkg/util/log"
- "github.com/pkg/errors"
- "golang.org/x/net/context"
)
// NewTempEngine creates a new engine for DistSQL processors to use when the
-// working set is larger than can be stored in memory. It returns nil if it
-// could not set up a temporary Engine. When closed, it destroys the
-// underlying data.
-func NewTempEngine(ctx context.Context, storeCfg base.StoreSpec) (Engine, error) {
- if storeCfg.SizeInBytes != 0 {
- return nil, errors.Errorf("spec.SizeInBytes specified for temp store. " +
- "That's not allowed as the setting doesn't do anything.")
- }
-
- if storeCfg.InMemory {
+// working set is larger than can be stored in memory.
+func NewTempEngine(tempStorage base.TempStorageConfig) (Engine, error) {
+ if tempStorage.InMemory {
// TODO(arjun): Limit the size of the store once #16750 is addressed.
- return NewInMem(storeCfg.Attributes, 0 /* cacheSize */), nil
- }
-
- if err := cleanupTempStorageDirs(ctx, storeCfg.Path, nil /* *WaitGroup */); err != nil {
- return nil, err
+ // Technically we do not pass any attributes to temporary store.
+ return NewInMem(roachpb.Attributes{} /* attrs */, 0 /* cacheSize */), nil
}
// FIXME(tschottdorf): should be passed in.
@@ -53,73 +35,17 @@ func NewTempEngine(ctx context.Context, storeCfg base.StoreSpec) (Engine, error)
rocksDBCfg := RocksDBConfig{
Settings: st,
Attrs: roachpb.Attributes{},
- Dir: storeCfg.Path,
- // MaxSizeBytes doesn't matter for temp stores - it's not enforced in any way.
+ Dir: tempStorage.Path,
+ // MaxSizeBytes doesn't matter for temp storage - it's not
+ // enforced in any way.
MaxSizeBytes: 0,
MaxOpenFiles: 128, // TODO(arjun): Revisit this.
}
rocksDBCache := NewRocksDBCache(0)
rocksdb, err := NewRocksDB(rocksDBCfg, rocksDBCache)
- return &tempEngine{RocksDB: rocksdb}, err
-}
-
-type tempEngine struct {
- *RocksDB
-}
-
-func (e *tempEngine) Close() {
- e.RocksDB.Close()
- dir := e.RocksDB.cfg.Dir
- if dir == "" {
- return
- }
- if err := os.RemoveAll(dir); err != nil {
- log.Errorf(context.TODO(), "could not remove rocksdb dir: %v", err)
- }
-}
-
-// wg is allowed to be nil, if the caller does not want to wait on the cleanup.
-func cleanupTempStorageDirs(ctx context.Context, path string, wg *sync.WaitGroup) error {
- // Removing existing contents might be slow. Instead we rename it to a new
- // name, and spawn a goroutine to clean it up asynchronously.
- if err := os.MkdirAll(path, 0755); err != nil {
- return err
- }
- deletionDir, err := ioutil.TempDir(path, "TO-DELETE-")
if err != nil {
- return err
- }
-
- filesToDelete, err := ioutil.ReadDir(path)
- if err != nil {
- return err
- }
-
- for _, fileToDelete := range filesToDelete {
- toDeleteFull := filepath.Join(path, fileToDelete.Name())
- if toDeleteFull != deletionDir {
- if err := os.Rename(toDeleteFull, filepath.Join(deletionDir, fileToDelete.Name())); err != nil {
- // Fall back to just removing the file if rename fails (e.g. due to #18994).
- if rmErr := os.Remove(toDeleteFull); rmErr != nil {
- return errors.Errorf("failed to remove file %q (%s) after failing to rename it (%s)",
- toDeleteFull, rmErr, err)
- }
- }
- }
- }
- if wg != nil {
- wg.Add(1)
+ return nil, err
}
- go func() {
- if wg != nil {
- defer wg.Done()
- }
- if err := os.RemoveAll(deletionDir); err != nil {
- log.Warningf(ctx, "could not clear old TempEngine files: %v", err.Error())
- // Even if this errors, this is safe since it's in the marked-for-deletion subdirectory.
- return
- }
- }()
- return nil
+ return rocksdb, nil
}
diff --git a/pkg/storage/engine/temp_engine_test.go b/pkg/storage/engine/temp_engine_test.go
index e826cba3d503..a785c1917086 100644
--- a/pkg/storage/engine/temp_engine_test.go
+++ b/pkg/storage/engine/temp_engine_test.go
@@ -15,45 +15,32 @@
package engine
import (
- "fmt"
- "io/ioutil"
- "path/filepath"
- "sync"
"testing"
+ "github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/util/leaktest"
- "golang.org/x/net/context"
)
-func TestCleanupTempStorageDirs(t *testing.T) {
+func TestNewTempEngine(t *testing.T) {
defer leaktest.AfterTest(t)()
- dir, dirCleanup := testutils.TempDir(t)
- defer dirCleanup()
+ // Create the temporary directory for the RocksDB engine.
+ tempDir, tempDirCleanup := testutils.TempDir(t)
+ defer tempDirCleanup()
- tempBytes := []byte{byte(1), byte(2), byte(3)}
- if err := ioutil.WriteFile(filepath.Join(dir, "FOO"), tempBytes, 0777); err != nil {
- t.Fatal(err)
- }
- if err := ioutil.WriteFile(filepath.Join(dir, "BAR"), tempBytes, 0777); err != nil {
- t.Fatal(err)
- }
- if err := ioutil.WriteFile(filepath.Join(dir, "BAZ"), tempBytes, 0777); err != nil {
- t.Fatal(err)
- }
-
- wg := sync.WaitGroup{}
- if err := cleanupTempStorageDirs(context.TODO(), dir, &wg); err != nil {
- t.Fatal(fmt.Sprintf("error encountered in cleanupTempStorageDirs: %v", err))
+ engine, err := NewTempEngine(base.TempStorageConfig{Path: tempDir})
+ if err != nil {
+ t.Fatalf("error encountered when invoking NewTempEngine: %v", err)
}
- wg.Wait()
+ defer engine.Close()
- files, err := ioutil.ReadDir(dir)
- if err != nil {
- t.Fatal(fmt.Sprintf("error reading temporary directory: %v", err))
+ tempEngine, ok := engine.(*RocksDB)
+ if !ok {
+ t.Fatalf("temp engine could not be asserted as a rocksdb instance")
}
- if len(files) != 0 {
- t.Fatalf("directory not cleaned up after calling cleanupTempStorageDirs, still have %d files", len(files))
+ // Temp engine initialized with the temporary directory.
+ if tempDir != tempEngine.cfg.Dir {
+ t.Fatalf("temp engine initialized with unexpected parent directory.\nexpected %s\nactual %s", tempDir, tempEngine.cfg.Dir)
}
}
|
b7307aa85179db3882f6872c0801923fc580b79f
|
2023-04-17 21:41:24
|
maryliag
|
sqlstats: ignore SET stmts on insights
| false
|
ignore SET stmts on insights
|
sqlstats
|
diff --git a/pkg/sql/sqlstats/insights/detector.go b/pkg/sql/sqlstats/insights/detector.go
index 56c9cc78b664..c64bd1b3efec 100644
--- a/pkg/sql/sqlstats/insights/detector.go
+++ b/pkg/sql/sqlstats/insights/detector.go
@@ -12,6 +12,7 @@ package insights
import (
"container/list"
+ "strings"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/appstatspb"
@@ -170,3 +171,15 @@ func (d *latencyThresholdDetector) isSlow(s *Statement) bool {
func isFailed(s *Statement) bool {
return s.Status == Statement_Failed
}
+
+var prefixesToIgnore = []string{"SET "}
+
+// shouldIgnoreStatement returns true if we don't want to analyze the statement.
+func shouldIgnoreStatement(s *Statement) bool {
+ for _, start := range prefixesToIgnore {
+ if strings.HasPrefix(s.Query, start) {
+ return true
+ }
+ }
+ return false
+}
diff --git a/pkg/sql/sqlstats/insights/registry.go b/pkg/sql/sqlstats/insights/registry.go
index ca5869627beb..f67d1369221f 100644
--- a/pkg/sql/sqlstats/insights/registry.go
+++ b/pkg/sql/sqlstats/insights/registry.go
@@ -100,7 +100,7 @@ func (r *lockingRegistry) ObserveTransaction(sessionID clusterunique.ID, transac
// Mark statements which are detected as slow or have a failed status.
var slowOrFailedStatements intsets.Fast
for i, s := range *statements {
- if r.detector.isSlow(s) || isFailed(s) {
+ if !shouldIgnoreStatement(s) && (r.detector.isSlow(s) || isFailed(s)) {
slowOrFailedStatements.Add(i)
}
}
diff --git a/pkg/sql/sqlstats/insights/registry_test.go b/pkg/sql/sqlstats/insights/registry_test.go
index 0590abb5b075..2009418dd532 100644
--- a/pkg/sql/sqlstats/insights/registry_test.go
+++ b/pkg/sql/sqlstats/insights/registry_test.go
@@ -223,7 +223,7 @@ func TestRegistry(t *testing.T) {
FingerprintID: appstatspb.StmtFingerprintID(100),
LatencyInSeconds: 2,
}
- siblingStatment := &Statement{
+ siblingStatement := &Statement{
ID: clusterunique.IDFromBytes([]byte("dddddddddddddddddddddddddddddddd")),
FingerprintID: appstatspb.StmtFingerprintID(101),
}
@@ -233,7 +233,7 @@ func TestRegistry(t *testing.T) {
store := newStore(st)
registry := newRegistry(st, &latencyThresholdDetector{st: st}, store)
registry.ObserveStatement(session.ID, statement)
- registry.ObserveStatement(session.ID, siblingStatment)
+ registry.ObserveStatement(session.ID, siblingStatement)
registry.ObserveTransaction(session.ID, transaction)
expected := []*Insight{
@@ -242,7 +242,7 @@ func TestRegistry(t *testing.T) {
Transaction: transaction,
Statements: []*Statement{
newStmtWithProblemAndCauses(statement, Problem_SlowExecution, nil),
- siblingStatment,
+ siblingStatement,
},
},
}
@@ -306,4 +306,49 @@ func TestRegistry(t *testing.T) {
require.Equal(t, expected, actual)
require.Equal(t, transaction.Status, Transaction_Status(statement.Status))
})
+
+ t.Run("statement that is slow but should be ignored", func(t *testing.T) {
+ statementNotIgnored := &Statement{
+ Status: Statement_Completed,
+ ID: clusterunique.IDFromBytes([]byte("bbbbbbbbbbbbbbbbbbbbbbbbbbbbbbbb")),
+ FingerprintID: appstatspb.StmtFingerprintID(100),
+ LatencyInSeconds: 2,
+ Query: "SELECT * FROM users",
+ }
+ statementIgnored := &Statement{
+ ID: clusterunique.IDFromBytes([]byte("dddddddddddddddddddddddddddddddd")),
+ FingerprintID: appstatspb.StmtFingerprintID(101),
+ LatencyInSeconds: 2,
+ Query: "SET vectorize = '_'",
+ }
+
+ st := cluster.MakeTestingClusterSettings()
+ LatencyThreshold.Override(ctx, &st.SV, 1*time.Second)
+ store := newStore(st)
+ registry := newRegistry(st, &latencyThresholdDetector{st: st}, store)
+ registry.ObserveStatement(session.ID, statementNotIgnored)
+ registry.ObserveStatement(session.ID, statementIgnored)
+ registry.ObserveTransaction(session.ID, transaction)
+
+ expected := []*Insight{
+ {
+ Session: session,
+ Transaction: transaction,
+ Statements: []*Statement{
+ newStmtWithProblemAndCauses(statementNotIgnored, Problem_SlowExecution, nil),
+ statementIgnored,
+ },
+ },
+ }
+ var actual []*Insight
+ store.IterateInsights(
+ context.Background(),
+ func(ctx context.Context, o *Insight) {
+ actual = append(actual, o)
+ },
+ )
+
+ require.Equal(t, expected, actual)
+ require.Equal(t, transaction.Status, Transaction_Status(statementNotIgnored.Status))
+ })
}
|
d67ee3c482309b7b759d4144d1c11bbcd5b20358
|
2024-12-31 00:18:21
|
Xin Hao Zhang
|
server: cleanup creation of storeids slice for span stats
| false
|
cleanup creation of storeids slice for span stats
|
server
|
diff --git a/pkg/server/span_stats_server.go b/pkg/server/span_stats_server.go
index d66b27b21e1f..8b6b6d4cc6f1 100644
--- a/pkg/server/span_stats_server.go
+++ b/pkg/server/span_stats_server.go
@@ -330,16 +330,16 @@ func (s *systemStatusServer) statsForSpan(
return nil, err
}
}
+ }
- spanStats.StoreIDs = make([]roachpb.StoreID, 0, len(storeIDs))
- for storeID := range storeIDs {
- spanStats.StoreIDs = append(spanStats.StoreIDs, storeID)
- }
- sort.Slice(spanStats.StoreIDs, func(i, j int) bool {
- return spanStats.StoreIDs[i] < spanStats.StoreIDs[j]
- })
-
+ spanStats.StoreIDs = make([]roachpb.StoreID, 0, len(storeIDs))
+ for storeID := range storeIDs {
+ spanStats.StoreIDs = append(spanStats.StoreIDs, storeID)
}
+ sort.Slice(spanStats.StoreIDs, func(i, j int) bool {
+ return spanStats.StoreIDs[i] < spanStats.StoreIDs[j]
+ })
+
// If we still have some remaining ranges, request range stats for the current batch.
if len(fullyContainedKeysBatch) > 0 {
// Obtain stats for fully contained ranges via RangeStats.
|
0b362a2c6c2c917394bdcfde72ee0d0f01d840c0
|
2019-02-08 11:42:52
|
Jordan Lewis
|
acceptance: add regression test for empty dec parsing
| false
|
add regression test for empty dec parsing
|
acceptance
|
diff --git a/pkg/acceptance/testdata/java/src/main/java/MainTest.java b/pkg/acceptance/testdata/java/src/main/java/MainTest.java
index 2085811b9983..e7327104d672 100644
--- a/pkg/acceptance/testdata/java/src/main/java/MainTest.java
+++ b/pkg/acceptance/testdata/java/src/main/java/MainTest.java
@@ -240,4 +240,18 @@ public void testWindowFunctions() throws Exception {
rs.next();
Assert.assertEquals(rs.getInt(1), 21);
}
+
+ // Regression for 34429: empty string decimals shouldn't crash the server.
+ @Test
+ public void testEmptyStringDec() throws Exception {
+ PreparedStatement stmt = conn.prepareStatement("create table product_temp_tb (product_master_id int primary key, weight DECIMAL(10,2) NOT NULL DEFAULT 0)");
+ stmt.execute();
+ stmt = conn.prepareStatement("INSERT INTO product_temp_tb values(0,0)");
+ stmt.execute();
+ stmt = conn.prepareStatement("UPDATE product_temp_tb SET weight = ? WHERE product_master_id = ?");
+ stmt.setObject(1, "");
+ stmt.setInt(2, 1);
+ exception.expectMessage("ERROR: could not parse \"\" as type decimal");
+ stmt.execute();
+ }
}
|
e5f1598f88caf3f57b7a4a16970a9903e6eac9dc
|
2019-03-25 23:39:46
|
Bram Gruneir
|
roachtest: clean up the canary tests
| false
|
clean up the canary tests
|
roachtest
|
diff --git a/pkg/cmd/roachtest/canary.go b/pkg/cmd/roachtest/canary.go
new file mode 100644
index 000000000000..7c75b3b4fae2
--- /dev/null
+++ b/pkg/cmd/roachtest/canary.go
@@ -0,0 +1,239 @@
+// Copyright 2018 The Cockroach Authors.
+//
+// Licensed under the Apache License, Version 2.0 (the "License");
+// you may not use this file except in compliance with the License.
+// You may obtain a copy of the License at
+//
+// http://www.apache.org/licenses/LICENSE-2.0
+//
+// Unless required by applicable law or agreed to in writing, software
+// distributed under the License is distributed on an "AS IS" BASIS,
+// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+// implied. See the License for the specific language governing
+// permissions and limitations under the License. See the AUTHORS file
+// for names of contributors.
+
+package main
+
+import (
+ "context"
+ "encoding/json"
+ "fmt"
+ "net/http"
+ "regexp"
+ "sort"
+ "strconv"
+ "strings"
+ "time"
+
+ "github.com/cockroachdb/cockroach/pkg/util/retry"
+)
+
+// This file contains common elements for all 3rd party test suite roachtests.
+// TODO(bram): There are more common elements between all the canary tests,
+// factor more of them into here.
+
+// blacklist is a lists of known test errors and failures.
+type blacklist map[string]string
+
+// blacklistForVersion contains both a blacklist of known test errors and
+// failures but also an optional ignorelist for flaky tests.
+// When the test suite is run, the results are compared to this list.
+// Any passed test that is not on this blacklist is reported as PASS - expected
+// Any passed test that is on this blacklist is reported as PASS - unexpected
+// Any failed test that is on this blacklist is reported as FAIL - expected
+// Any failed test that is not on blackthis list is reported as FAIL - unexpected
+// Any test on this blacklist that is not run is reported as FAIL - not run
+// Ant test in the ignorelist is reported as SKIP if it is run
+type blacklistForVersion struct {
+ versionPrefix string
+ blacklistname string
+ blacklist blacklist
+ ignorelistname string
+ ignorelist blacklist
+}
+
+type blacklistsForVersion []blacklistForVersion
+
+// getLists returns the appropriate blacklist and ignorelist based on the
+// cockroach version. This check only looks to ensure that the prefix that
+// matches.
+func (b blacklistsForVersion) getLists(version string) (string, blacklist, string, blacklist) {
+ for _, info := range b {
+ if strings.HasPrefix(version, info.versionPrefix) {
+ return info.blacklistname, info.blacklist, info.ignorelistname, info.ignorelist
+ }
+ }
+ return "", nil, "", nil
+}
+
+func fetchCockroachVersion(ctx context.Context, c *cluster, nodeIndex int) (string, error) {
+ db, err := c.ConnE(ctx, nodeIndex)
+ if err != nil {
+ return "", err
+ }
+ defer db.Close()
+ var version string
+ if err := db.QueryRowContext(ctx,
+ `SELECT value FROM crdb_internal.node_build_info where field = 'Version'`,
+ ).Scan(&version); err != nil {
+ return "", err
+ }
+ return version, nil
+}
+
+// maybeAddGithubLink will take the issue and if it is just a number, then it
+// will return a full github link.
+func maybeAddGithubLink(issue string) string {
+ if len(issue) == 0 {
+ return ""
+ }
+ issueNum, err := strconv.Atoi(issue)
+ if err != nil {
+ return issue
+ }
+ return fmt.Sprintf("https://github.com/cockroachdb/cockroach/issues/%d", issueNum)
+}
+
+// The following functions are augmented basic cluster functions but there tends
+// to be common networking issues that cause test failures and require putting
+// a retry block around them.
+
+var canaryRetryOptions = retry.Options{
+ InitialBackoff: 10 * time.Second,
+ Multiplier: 2,
+ MaxBackoff: 5 * time.Minute,
+ MaxRetries: 10,
+}
+
+// repeatRunE is the same function as c.RunE but with an automatic retry loop.
+func repeatRunE(
+ ctx context.Context, c *cluster, node nodeListOption, operation string, args ...string,
+) error {
+ var lastError error
+ for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
+ if ctx.Err() != nil {
+ return ctx.Err()
+ }
+ if c.t.Failed() {
+ return fmt.Errorf("test has failed")
+ }
+ attempt++
+ c.l.Printf("attempt %d - %s", attempt, operation)
+ lastError = c.RunE(ctx, node, args...)
+ if lastError != nil {
+ c.l.Printf("error - retrying: %s", lastError)
+ continue
+ }
+ return nil
+ }
+ return fmt.Errorf("all attempts failed for %s due to error: %s", operation, lastError)
+}
+
+// repeatRunWithBuffer is the same function as c.RunWithBuffer but with an
+// automatic retry loop.
+func repeatRunWithBuffer(
+ ctx context.Context, c *cluster, l *logger, node nodeListOption, operation string, args ...string,
+) ([]byte, error) {
+ var lastError error
+ for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
+ if ctx.Err() != nil {
+ return nil, ctx.Err()
+ }
+ if c.t.Failed() {
+ return nil, fmt.Errorf("test has failed")
+ }
+ attempt++
+ c.l.Printf("attempt %d - %s", attempt, operation)
+ var result []byte
+ result, lastError = c.RunWithBuffer(ctx, l, node, args...)
+ if lastError != nil {
+ c.l.Printf("error - retrying: %s", lastError)
+ continue
+ }
+ return result, nil
+ }
+ return nil, fmt.Errorf("all attempts failed for %s, with error: %s", operation, lastError)
+}
+
+// repeatGitCloneE is the same function as c.GitCloneE but with an automatic
+// retry loop.
+func repeatGitCloneE(
+ ctx context.Context, c *cluster, src, dest, branch string, node nodeListOption,
+) error {
+ var lastError error
+ for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
+ if ctx.Err() != nil {
+ return ctx.Err()
+ }
+ if c.t.Failed() {
+ return fmt.Errorf("test has failed")
+ }
+ attempt++
+ c.l.Printf("attempt %d - clone %s", attempt, src)
+ lastError = c.GitCloneE(ctx, src, dest, branch, node)
+ if lastError != nil {
+ c.l.Printf("error - retrying: %s", lastError)
+ continue
+ }
+ return nil
+ }
+ return fmt.Errorf("Could not clone %s due to error: %s", src, lastError)
+}
+
+var canaryTagRegex = regexp.MustCompile(`^[^a-zA-Z]*$`)
+
+// repeatGetLatestTag fetches the latest (sorted) tag from a github repo.
+// There is no equivalent function on the cluster as this is really only needed
+// for the canary tests.
+// NB: that this is kind of brittle, as it looks for the latest tag without any
+// letters in it, as alphas, betas and rcs tend to have letters in them. It
+// might make sense to instead pass in a regex specific to the repo instead
+// of using the one here.
+func repeatGetLatestTag(ctx context.Context, c *cluster, user string, repo string) (string, error) {
+ url := fmt.Sprintf("https://api.github.com/repos/%s/%s/tags", user, repo)
+ httpClient := &http.Client{Timeout: 10 * time.Second}
+ type Tag struct {
+ Name string
+ }
+ type Tags []Tag
+ var lastError error
+ for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
+ if ctx.Err() != nil {
+ return "", ctx.Err()
+ }
+ if c.t.Failed() {
+ return "", fmt.Errorf("test has failed")
+ }
+ attempt++
+
+ c.l.Printf("attempt %d - fetching %s", attempt, url)
+ var resp *http.Response
+ resp, lastError = httpClient.Get(url)
+ if lastError != nil {
+ c.l.Printf("error fetching - retrying: %s", lastError)
+ continue
+ }
+ defer resp.Body.Close()
+
+ var tags Tags
+ lastError = json.NewDecoder(resp.Body).Decode(&tags)
+ if lastError != nil {
+ c.l.Printf("error decoding - retrying: %s", lastError)
+ continue
+ }
+ if len(tags) == 0 {
+ return "", fmt.Errorf("no tags found at %s", url)
+ }
+
+ var actualTags []string
+ for _, t := range tags {
+ if canaryTagRegex.MatchString(t.Name) {
+ actualTags = append(actualTags, t.Name)
+ }
+ }
+ sort.Strings(actualTags)
+ return actualTags[len(actualTags)-1], nil
+ }
+ return "", fmt.Errorf("could not get tags from %s, due to error: %s", url, lastError)
+}
diff --git a/pkg/cmd/roachtest/hibernate.go b/pkg/cmd/roachtest/hibernate.go
index 3df844d190f7..c54286294805 100644
--- a/pkg/cmd/roachtest/hibernate.go
+++ b/pkg/cmd/roachtest/hibernate.go
@@ -20,11 +20,7 @@ import (
"encoding/xml"
"fmt"
"sort"
- "strconv"
"strings"
- "time"
-
- "github.com/cockroachdb/cockroach/pkg/util/retry"
)
// This test runs hibernate-core's full test suite against a single cockroach
@@ -45,95 +41,84 @@ func registerHibernate(r *registry) {
c.Start(ctx, t, c.All())
t.Status("cloning hibernate and installing prerequisites")
- opts := retry.Options{
- InitialBackoff: 10 * time.Second,
- Multiplier: 2,
- MaxBackoff: 5 * time.Minute,
+ latestTag, err := repeatGetLatestTag(ctx, c, "hibernate", "hibernate-orm")
+ if err != nil {
+ t.Fatal(err)
}
- for attempt, r := 0, retry.StartWithCtx(ctx, opts); r.Next(); {
- if ctx.Err() != nil {
- return
- }
- if c.t.Failed() {
- return
- }
- attempt++
+ if len(latestTag) == 0 {
+ t.Fatal(fmt.Sprintf("did not get a latest tag"))
+ }
+ c.l.Printf("Latest Hibernate release is %s.", latestTag)
- c.l.Printf("attempt %d - update dependencies", attempt)
- if err := c.RunE(ctx, node, `sudo apt-get -q update`); err != nil {
- continue
- }
- if err := c.RunE(
- ctx, node, `sudo apt-get -qy install default-jre openjdk-8-jdk-headless gradle`,
- ); err != nil {
- continue
- }
+ if err := repeatRunE(
+ ctx, c, node, "update apt-get", `sudo apt-get -qq update`,
+ ); err != nil {
+ t.Fatal(err)
+ }
- c.l.Printf("attempt %d - cloning hibernate", attempt)
- if err := c.RunE(ctx, node, `rm -rf /mnt/data1/hibernate`); err != nil {
- continue
- }
- if err := c.GitCloneE(
- ctx,
- "https://github.com/hibernate/hibernate-orm.git",
- "/mnt/data1/hibernate",
- "5.3.6",
- node,
- ); err != nil {
- continue
- }
+ if err := repeatRunE(
+ ctx,
+ c,
+ node,
+ "install dependencies",
+ `sudo apt-get -qq install default-jre openjdk-8-jdk-headless gradle`,
+ ); err != nil {
+ t.Fatal(err)
+ }
- // In order to get Hibernate's test suite to connect to cockroach, we have
- // to create a dbBundle as it not possible to specify the individual
- // properties. So here we just steamroll the file with our own config.
- if err := c.RunE(ctx, node, `
-echo "ext {
- db = project.hasProperty('db') ? project.getProperty('db') : 'h2'
- dbBundle = [
- cockroach : [
- 'db.dialect' : 'org.hibernate.dialect.PostgreSQL95Dialect',
- 'jdbc.driver': 'org.postgresql.Driver',
- 'jdbc.user' : 'root',
- 'jdbc.pass' : '',
- 'jdbc.url' : 'jdbc:postgresql://localhost:26257/defaultdb?sslmode=disable'
- ],
- ]
-}" > /mnt/data1/hibernate/gradle/databases.gradle`,
- ); err != nil {
- continue
- }
+ if err := repeatRunE(
+ ctx, c, node, "remove old Hibernate", `rm -rf /mnt/data1/hibernate`,
+ ); err != nil {
+ t.Fatal(err)
+ }
- break
+ if err := repeatGitCloneE(
+ ctx,
+ c,
+ "https://github.com/hibernate/hibernate-orm.git",
+ "/mnt/data1/hibernate",
+ latestTag,
+ node,
+ ); err != nil {
+ t.Fatal(err)
+ }
+
+ // In order to get Hibernate's test suite to connect to cockroach, we have
+ // to create a dbBundle as it not possible to specify the individual
+ // properties. So here we just steamroll the file with our own config.
+ if err := repeatRunE(
+ ctx,
+ c,
+ node,
+ "configuring tests for cockroach only",
+ fmt.Sprintf(
+ "echo \"%s\" > /mnt/data1/hibernate/gradle/databases.gradle", hibernateDatabaseGradle,
+ ),
+ ); err != nil {
+ t.Fatal(err)
}
t.Status("building hibernate (without tests)")
- for attempt, r := 0, retry.StartWithCtx(ctx, opts); r.Next(); {
- if ctx.Err() != nil {
- return
- }
- if c.t.Failed() {
- return
- }
- attempt++
- c.l.Printf("attempt %d - building hibernate", attempt)
- // Build hibernate and run a single test, this step involves some
- // downloading, so it needs a retry loop as well. Just building was not
- // enough as the test libraries are not downloaded unless at least a
- // single test is invoked.
- if err := c.RunE(
- ctx, node, `cd /mnt/data1/hibernate/hibernate-core/ && ./../gradlew test -Pdb=cockroach `+
- `--tests org.hibernate.jdbc.util.BasicFormatterTest.*`,
- ); err != nil {
- continue
- }
- break
+ // Build hibernate and run a single test, this step involves some
+ // downloading, so it needs a retry loop as well. Just building was not
+ // enough as the test libraries are not downloaded unless at least a
+ // single test is invoked.
+ if err := repeatRunE(
+ ctx,
+ c,
+ node,
+ "building hibernate (without tests)",
+ `cd /mnt/data1/hibernate/hibernate-core/ && ./../gradlew test -Pdb=cockroach `+
+ `--tests org.hibernate.jdbc.util.BasicFormatterTest.*`,
+ ); err != nil {
+ t.Fatal(err)
}
version, err := fetchCockroachVersion(ctx, c, node[0])
if err != nil {
t.Fatal(err)
}
- blacklistName, expectedFailures := getHibernateBlacklistForVersion(version)
+ blacklistName, expectedFailures, _, _ := hibernateBlacklists.getLists(version)
if expectedFailures == nil {
t.Fatalf("No hibernate blacklist defined for cockroach version %s", version)
}
@@ -155,23 +140,43 @@ echo "ext {
// copied to the artifacts.
// Copy the html report for the test.
- c.Run(ctx, node,
+ if err := repeatRunE(
+ ctx,
+ c,
+ node,
+ "copy html report",
`cp /mnt/data1/hibernate/hibernate-core/target/reports/tests/test ~/logs/report -a`,
- )
+ ); err != nil {
+ t.Fatal(err)
+ }
// Copy the individual test result files.
- c.Run(ctx, node,
+ if err := repeatRunE(
+ ctx,
+ c,
+ node,
+ "copy test result files",
`cp /mnt/data1/hibernate/hibernate-core/target/test-results/test ~/logs/report/results -a`,
- )
+ ); err != nil {
+ t.Fatal(err)
+ }
// Load the list of all test results files and parse them individually.
// Files are here: /mnt/data1/hibernate/hibernate-core/target/test-results/test
- output, err := c.RunWithBuffer(ctx, t.l, node,
+ output, err := repeatRunWithBuffer(
+ ctx,
+ c,
+ t.l,
+ node,
+ "get list of test files",
`ls /mnt/data1/hibernate/hibernate-core/target/test-results/test/*.xml`,
)
if err != nil {
t.Fatal(err)
}
+ if len(output) == 0 {
+ t.Fatal("could not find any test result files")
+ }
var failUnexpectedCount, failExpectedCount int
var passUnexpectedCount, passExpectedCount, notRunCount int
@@ -181,15 +186,27 @@ echo "ext {
// they were expected or not.
var currentFailures, allTests []string
runTests := make(map[string]struct{})
- files := strings.Split(string(output), "\n")
- for i, file := range files {
- file = strings.TrimSpace(file)
- if len(file) == 0 {
- t.l.Printf("Skipping %d of %d: %s\n", i, len(files), file)
- continue
+ filesRaw := strings.Split(string(output), "\n")
+
+ // There is always at least one entry that's just space characters, remove
+ // it.
+ var files []string
+ for _, f := range filesRaw {
+ file := strings.TrimSpace(f)
+ if len(file) > 0 {
+ files = append(files, file)
}
- t.l.Printf("Parsing %d of %d: %s\n", i, len(files), file)
- fileOutput, err := c.RunWithBuffer(ctx, t.l, node, `cat `+file)
+ }
+ for i, file := range files {
+ t.l.Printf("Parsing %d of %d: %s\n", i+1, len(files), file)
+ fileOutput, err := repeatRunWithBuffer(
+ ctx,
+ c,
+ t.l,
+ node,
+ fmt.Sprintf("fetching results file %s", file),
+ fmt.Sprintf("cat %s", file),
+ )
if err != nil {
t.Fatal(err)
}
@@ -254,6 +271,7 @@ echo "ext {
var bResults strings.Builder
fmt.Fprintf(&bResults, "Tests run on Cockroach %s\n", version)
+ fmt.Fprintf(&bResults, "Tests run against Hibernate %s\n", latestTag)
fmt.Fprintf(&bResults, "%d Total Tests Run\n",
passExpectedCount+passUnexpectedCount+failExpectedCount+failUnexpectedCount,
)
@@ -338,30 +356,17 @@ func extractFailureFromHibernateXML(contents []byte) ([]string, []bool, error) {
return tests, passed, nil
}
-func fetchCockroachVersion(ctx context.Context, c *cluster, nodeIndex int) (string, error) {
- db, err := c.ConnE(ctx, nodeIndex)
- if err != nil {
- return "", err
- }
- defer db.Close()
- var version string
- if err := db.QueryRowContext(ctx,
- `SELECT value FROM crdb_internal.node_build_info where field = 'Version'`,
- ).Scan(&version); err != nil {
- return "", err
- }
- return version, nil
-}
-
-// maybeAddGithubLink will take the issue and if it is just a number, then it
-// will return a full github link.
-func maybeAddGithubLink(issue string) string {
- if len(issue) == 0 {
- return ""
- }
- issueNum, err := strconv.Atoi(issue)
- if err != nil {
- return issue
- }
- return fmt.Sprintf("https://github.com/cockroachdb/cockroach/issues/%d", issueNum)
+const hibernateDatabaseGradle = `
+ext {
+ db = project.hasProperty('db') ? project.getProperty('db') : 'h2'
+ dbBundle = [
+ cockroach : [
+ 'db.dialect' : 'org.hibernate.dialect.PostgreSQL95Dialect',
+ 'jdbc.driver': 'org.postgresql.Driver',
+ 'jdbc.user' : 'root',
+ 'jdbc.pass' : '',
+ 'jdbc.url' : 'jdbc:postgresql://localhost:26257/defaultdb?sslmode=disable'
+ ],
+ ]
}
+`
diff --git a/pkg/cmd/roachtest/hibernate_blacklist.go b/pkg/cmd/roachtest/hibernate_blacklist.go
index c448aa80b5cf..e135805edfb8 100644
--- a/pkg/cmd/roachtest/hibernate_blacklist.go
+++ b/pkg/cmd/roachtest/hibernate_blacklist.go
@@ -15,41 +15,13 @@
package main
-import "strings"
-
-type blacklist map[string]string
-
-var hibernateBlacklists = []struct {
- versionPrefix string
- name string
- list blacklist
-}{
- {"v2.0", "hibernateBlackList2_0", hibernateBlackList2_0},
- {"v2.1", "hibernateBlackList2_1", hibernateBlackList2_1},
- {"v2.2", "hibernateBlackList19_1", hibernateBlackList19_1},
- {"v19.1", "hibernateBlackList19_1", hibernateBlackList19_1},
+var hibernateBlacklists = blacklistsForVersion{
+ {"v2.0", "hibernateBlackList2_0", hibernateBlackList2_0, "", nil},
+ {"v2.1", "hibernateBlackList2_1", hibernateBlackList2_1, "", nil},
+ {"v2.2", "hibernateBlackList19_1", hibernateBlackList19_1, "", nil},
+ {"v19.1", "hibernateBlackList19_1", hibernateBlackList19_1, "", nil},
}
-// getHibernateBlacklistForVersion returns the appropriate hibernate blacklist
-// based on the cockroach version. This check only looks to ensure that the
-// prefix from hibernateBlacklists matches.
-func getHibernateBlacklistForVersion(version string) (string, blacklist) {
- for _, info := range hibernateBlacklists {
- if strings.HasPrefix(version, info.versionPrefix) {
- return info.name, info.list
- }
- }
- return "", nil
-}
-
-// These are lists of known hibernate test failures.
-// When the hibernate test suite is run, the results are compared to this list.
-// Any passed test that is not on this list is reported as PASS - expected
-// Any passed test that is on this list is reported as PASS - unexpected
-// Any failed test that is on this list is reported as FAIL - expected
-// Any failed test that is not on this list is reported as FAIL - unexpected
-// Any test on this list that is not run is reported as FAIL - not run
-//
// Please keep these lists alphabetized for easy diffing.
// After a failed run, an updated version of this blacklist should be available
// in the test log.
diff --git a/pkg/cmd/roachtest/psycopg.go b/pkg/cmd/roachtest/psycopg.go
index 4eae9baea1b4..5c23c4f64090 100644
--- a/pkg/cmd/roachtest/psycopg.go
+++ b/pkg/cmd/roachtest/psycopg.go
@@ -23,9 +23,6 @@ import (
"regexp"
"sort"
"strings"
- "time"
-
- "github.com/cockroachdb/cockroach/pkg/util/retry"
)
var psycopgResultRegex = regexp.MustCompile(`(?P<name>.*) \((?P<class>.*)\) \.\.\. (?P<result>.*)`)
@@ -47,70 +44,60 @@ func registerPsycopg(r *registry) {
c.Start(ctx, t, c.All())
t.Status("cloning psycopg and installing prerequisites")
- opts := retry.Options{
- InitialBackoff: 10 * time.Second,
- Multiplier: 2,
- MaxBackoff: 5 * time.Minute,
+ latestTag, err := repeatGetLatestTag(ctx, c, "psycopg", "psycopg2")
+ if err != nil {
+ t.Fatal(err)
}
- for attempt, r := 0, retry.StartWithCtx(ctx, opts); r.Next(); {
- if ctx.Err() != nil {
- return
- }
- if c.t.Failed() {
- return
- }
- attempt++
+ if len(latestTag) == 0 {
+ t.Fatal(fmt.Sprintf("did not get a latest tag"))
+ }
+ c.l.Printf("Latest Psycopg release is %s.", latestTag)
- c.l.Printf("attempt %d - update dependencies", attempt)
- if err := c.RunE(ctx, node, `sudo apt-get -q update`); err != nil {
- continue
- }
- if err := c.RunE(
- ctx, node, `sudo apt-get -qy install make python3 libpq-dev python-dev gcc`,
- ); err != nil {
- continue
- }
+ if err := repeatRunE(
+ ctx, c, node, "update apt-get", `sudo apt-get -qq update`,
+ ); err != nil {
+ t.Fatal(err)
+ }
- c.l.Printf("attempt %d - cloning psycopg", attempt)
- if err := c.RunE(ctx, node, `rm -rf /mnt/data1/psycopg`); err != nil {
- continue
- }
- if err := c.GitCloneE(
- ctx,
- "https://github.com/psycopg/psycopg2.git",
- "/mnt/data1/psycopg",
- "2_7_7",
- node,
- ); err != nil {
- continue
- }
+ if err := repeatRunE(
+ ctx,
+ c,
+ node,
+ "install dependencies",
+ `sudo apt-get -qq install make python3 libpq-dev python-dev gcc`,
+ ); err != nil {
+ t.Fatal(err)
+ }
- break
+ if err := repeatRunE(
+ ctx, c, node, "remove old Psycopg", `sudo rm -rf /mnt/data1/psycopg`,
+ ); err != nil {
+ t.Fatal(err)
}
- t.Status("building psycopg")
- for attempt, r := 0, retry.StartWithCtx(ctx, opts); r.Next(); {
- if ctx.Err() != nil {
- return
- }
- if c.t.Failed() {
- return
- }
- attempt++
- c.l.Printf("attempt %d - building psycopg", attempt)
- if err := c.RunE(
- ctx, node, `cd /mnt/data1/psycopg/ && make`,
- ); err != nil {
- continue
- }
- break
+ if err := repeatGitCloneE(
+ ctx,
+ c,
+ "https://github.com/psycopg/psycopg2.git",
+ "/mnt/data1/psycopg",
+ latestTag,
+ node,
+ ); err != nil {
+ t.Fatal(err)
+ }
+
+ t.Status("building Psycopg")
+ if err := repeatRunE(
+ ctx, c, node, "building Psycopg", `cd /mnt/data1/psycopg/ && make`,
+ ); err != nil {
+ t.Fatal(err)
}
version, err := fetchCockroachVersion(ctx, c, node[0])
if err != nil {
t.Fatal(err)
}
- blacklistName, expectedFailureList, ignoredlistName, ignoredlist := getPsycopgBlacklistForVersion(version)
+ blacklistName, expectedFailureList, ignoredlistName, ignoredlist := psycopgBlacklists.getLists(version)
if expectedFailureList == nil {
t.Fatalf("No psycopg blacklist defined for cockroach version %s", version)
}
@@ -212,6 +199,7 @@ func registerPsycopg(r *registry) {
var bResults strings.Builder
fmt.Fprintf(&bResults, "Tests run on Cockroach %s\n", version)
+ fmt.Fprintf(&bResults, "Tests run against Pyscopg %s\n", latestTag)
fmt.Fprintf(&bResults, "%d Total Tests Run\n",
passExpectedCount+passUnexpectedCount+failExpectedCount+failUnexpectedCount,
)
diff --git a/pkg/cmd/roachtest/psycopg_blacklist.go b/pkg/cmd/roachtest/psycopg_blacklist.go
index 697ff6635a86..47664f194d67 100644
--- a/pkg/cmd/roachtest/psycopg_blacklist.go
+++ b/pkg/cmd/roachtest/psycopg_blacklist.go
@@ -15,31 +15,11 @@
package main
-import "strings"
-
-var psycopgBlacklists = []struct {
- versionPrefix string
- blacklistname string
- blacklist blacklist
- ignorelistname string
- ignorelist blacklist
-}{
+var psycopgBlacklists = blacklistsForVersion{
{"v2.2", "psycopgBlackList19_1", psycopgBlackList19_1, "psycopgIgnoreList19_1", psycopgIgnoreList19_1},
{"v19.1", "psycopgBlackList19_1", psycopgBlackList19_1, "psycopgIgnoreList19_1", psycopgIgnoreList19_1},
}
-// getPsycopgBlacklistForVersion returns the appropriate psycopg blacklist and
-// ignorelist based on the cockroach version. This check only looks to ensure
-// that the prefix that matches.
-func getPsycopgBlacklistForVersion(version string) (string, blacklist, string, blacklist) {
- for _, info := range psycopgBlacklists {
- if strings.HasPrefix(version, info.versionPrefix) {
- return info.blacklistname, info.blacklist, info.ignorelistname, info.ignorelist
- }
- }
- return "", nil, "", nil
-}
-
// These are lists of known psycopg test errors and failures.
// When the psycopg test suite is run, the results are compared to this list.
// Any passed test that is not on this list is reported as PASS - expected
diff --git a/pkg/cmd/roachtest/typeorm.go b/pkg/cmd/roachtest/typeorm.go
index 50f619cbb9c9..c2fa9bfb1ed5 100644
--- a/pkg/cmd/roachtest/typeorm.go
+++ b/pkg/cmd/roachtest/typeorm.go
@@ -17,13 +17,7 @@ package main
import (
"context"
- "encoding/json"
"fmt"
- "net/http"
- "sort"
- "time"
-
- "github.com/cockroachdb/cockroach/pkg/util/retry"
)
// This test runs TypeORM's full test suite against a single cockroach node.
@@ -41,6 +35,7 @@ func registerTypeORM(r *registry) {
c.Put(ctx, cockroach, "./cockroach", c.All())
c.Start(ctx, t, c.All())
+ t.Status("cloning TypeORM and installing prerequisites")
latestTag, err := repeatGetLatestTag(ctx, c, "typeorm", "typeorm")
if err != nil {
t.Fatal(err)
@@ -50,9 +45,8 @@ func registerTypeORM(r *registry) {
}
c.l.Printf("Latest TypeORM release is %s.", latestTag)
- t.Status("cloning TypeORM and installing prerequisites")
if err := repeatRunE(
- ctx, c, node, "update apt-get", `sudo apt-get -q update`,
+ ctx, c, node, "update apt-get", `sudo apt-get -qq update`,
); err != nil {
t.Fatal(err)
}
@@ -68,7 +62,7 @@ func registerTypeORM(r *registry) {
}
if err := repeatRunE(
- ctx, c, node, "install nodejs and npm", `sudo apt-get -qy install nodejs`,
+ ctx, c, node, "install nodejs and npm", `sudo apt-get -qq install nodejs`,
); err != nil {
t.Fatal(err)
}
@@ -134,100 +128,9 @@ func registerTypeORM(r *registry) {
})
}
-// TODO(bram): Move these functions to either be part of cluster or in a
-// canary helper file. And use them as part of the other canary tests.
-var canaryRetryOptions = retry.Options{
- InitialBackoff: 10 * time.Second,
- Multiplier: 2,
- MaxBackoff: 5 * time.Minute,
-}
-
-func repeatRunE(
- ctx context.Context, c *cluster, node nodeListOption, operation string, args ...string,
-) error {
- for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
- if ctx.Err() != nil {
- return ctx.Err()
- }
- if c.t.Failed() {
- return fmt.Errorf("test has failed")
- }
- attempt++
- c.l.Printf("attempt %d - %s", attempt, operation)
- if err := c.RunE(ctx, node, args...); err != nil {
- c.l.Printf("error - retrying: %s", err)
- continue
- }
- break
- }
- return nil
-}
-
-func repeatGitCloneE(
- ctx context.Context, c *cluster, src, dest, branch string, node nodeListOption,
-) error {
- for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
- if ctx.Err() != nil {
- return ctx.Err()
- }
- if c.t.Failed() {
- return fmt.Errorf("test has failed")
- }
- attempt++
- c.l.Printf("attempt %d - clone %s", attempt, src)
- if err := c.GitCloneE(ctx, src, dest, branch, node); err != nil {
- c.l.Printf("error - retrying: %s", err)
- continue
- }
- break
- }
- return nil
-}
-
-func repeatGetLatestTag(ctx context.Context, c *cluster, user string, repo string) (string, error) {
- url := fmt.Sprintf("https://api.github.com/repos/%s/%s/tags", user, repo)
- httpClient := &http.Client{Timeout: 10 * time.Second}
- type Tag struct {
- Name string
- }
- type Tags []Tag
- for attempt, r := 0, retry.StartWithCtx(ctx, canaryRetryOptions); r.Next(); {
- if ctx.Err() != nil {
- return "", ctx.Err()
- }
- if c.t.Failed() {
- return "", fmt.Errorf("test has failed")
- }
- attempt++
-
- c.l.Printf("attempt %d - fetching %s", attempt, url)
- r, err := httpClient.Get(url)
- if err != nil {
- c.l.Printf("error fetching - retrying: %s", err)
- continue
- }
- defer r.Body.Close()
-
- var tags Tags
- if err := json.NewDecoder(r.Body).Decode(&tags); err != nil {
- c.l.Printf("error decoding - retrying: %s", err)
- continue
- }
- if len(tags) == 0 {
- return "", fmt.Errorf("no tags found at %s", url)
- }
-
- actualTags := make([]string, len(tags))
- for i, t := range tags {
- actualTags[i] = t.Name
- }
- sort.Strings(actualTags)
- return actualTags[len(actualTags)-1], nil
- }
- // This should be unreachable.
- return "", fmt.Errorf("could not get tags from %s", url)
-}
-
+// This full config is required, but notice that all the non-cockroach databases
+// are set to skip. Some of the unit tests look for a specific config, like
+// sqlite and will fail if it is not present.
const typeORMConfigJSON = `
[
{
|
b761eba20b218aee12b295df027d22c4a17c9b61
|
2021-08-05 03:50:04
|
Nathan VanBenschoten
|
kv: assert txn unused in SetFixedTimestamp
| false
|
assert txn unused in SetFixedTimestamp
|
kv
|
diff --git a/pkg/ccl/backupccl/backup_planning.go b/pkg/ccl/backupccl/backup_planning.go
index 965e2f531566..a56c99b5c428 100644
--- a/pkg/ccl/backupccl/backup_planning.go
+++ b/pkg/ccl/backupccl/backup_planning.go
@@ -328,7 +328,9 @@ func spansForAllTableIndexes(
checkForKVInBounds := func(start, end roachpb.Key, endTime hlc.Timestamp) (bool, error) {
var foundKV bool
err := execCfg.DB.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, endTime)
+ if err := txn.SetFixedTimestamp(ctx, endTime); err != nil {
+ return err
+ }
res, err := txn.Scan(ctx, start, end, 1 /* maxRows */)
if err != nil {
return err
diff --git a/pkg/ccl/backupccl/backupresolver/targets.go b/pkg/ccl/backupccl/backupresolver/targets.go
index 03b64e66bfa3..e9ece2248c56 100644
--- a/pkg/ccl/backupccl/backupresolver/targets.go
+++ b/pkg/ccl/backupccl/backupresolver/targets.go
@@ -571,8 +571,11 @@ func LoadAllDescs(
var allDescs []catalog.Descriptor
if err := db.Txn(
ctx,
- func(ctx context.Context, txn *kv.Txn) (err error) {
- txn.SetFixedTimestamp(ctx, asOf)
+ func(ctx context.Context, txn *kv.Txn) error {
+ err := txn.SetFixedTimestamp(ctx, asOf)
+ if err != nil {
+ return err
+ }
allDescs, err = catalogkv.GetAllDescriptors(
ctx, txn, codec, true, /* shouldRunPostDeserializationChanges */
)
diff --git a/pkg/ccl/changefeedccl/changefeed_dist.go b/pkg/ccl/changefeedccl/changefeed_dist.go
index 3e6b617309fb..ee5f6bfe1ed3 100644
--- a/pkg/ccl/changefeedccl/changefeed_dist.go
+++ b/pkg/ccl/changefeedccl/changefeed_dist.go
@@ -129,7 +129,9 @@ func fetchSpansForTargets(
ctx context.Context, txn *kv.Txn, descriptors *descs.Collection,
) error {
spans = nil
- txn.SetFixedTimestamp(ctx, ts)
+ if err := txn.SetFixedTimestamp(ctx, ts); err != nil {
+ return err
+ }
// Note that all targets are currently guaranteed to be tables.
for tableID := range targets {
flags := tree.ObjectLookupFlagsWithRequired()
diff --git a/pkg/ccl/changefeedccl/kvfeed/scanner.go b/pkg/ccl/changefeedccl/kvfeed/scanner.go
index cd42b11ef699..3c098202fefd 100644
--- a/pkg/ccl/changefeedccl/kvfeed/scanner.go
+++ b/pkg/ccl/changefeedccl/kvfeed/scanner.go
@@ -103,7 +103,9 @@ func (p *scanRequestScanner) exportSpan(
if log.V(2) {
log.Infof(ctx, `sending ScanRequest %s at %s`, span, ts)
}
- txn.SetFixedTimestamp(ctx, ts)
+ if err := txn.SetFixedTimestamp(ctx, ts); err != nil {
+ return err
+ }
stopwatchStart := timeutil.Now()
var scanDuration, bufferDuration time.Duration
const targetBytesPerScan = 16 << 20 // 16 MiB
diff --git a/pkg/ccl/changefeedccl/rowfetcher_cache.go b/pkg/ccl/changefeedccl/rowfetcher_cache.go
index 63d6d715a60f..6e8eb87b0c70 100644
--- a/pkg/ccl/changefeedccl/rowfetcher_cache.go
+++ b/pkg/ccl/changefeedccl/rowfetcher_cache.go
@@ -101,8 +101,10 @@ func (c *rowFetcherCache) TableDescForKey(
// descs.Collection directly here.
// TODO (SQL Schema): #53751.
if err := c.db.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, ts)
- var err error
+ err := txn.SetFixedTimestamp(ctx, ts)
+ if err != nil {
+ return err
+ }
tableDesc, err = c.collection.GetImmutableTableByID(ctx, txn, tableID, tree.ObjectLookupFlags{})
return err
}); err != nil {
diff --git a/pkg/ccl/changefeedccl/schemafeed/schema_feed.go b/pkg/ccl/changefeedccl/schemafeed/schema_feed.go
index 43303029a2f4..041f94475016 100644
--- a/pkg/ccl/changefeedccl/schemafeed/schema_feed.go
+++ b/pkg/ccl/changefeedccl/schemafeed/schema_feed.go
@@ -274,7 +274,9 @@ func (tf *schemaFeed) primeInitialTableDescs(ctx context.Context) error {
ctx context.Context, txn *kv.Txn, descriptors *descs.Collection,
) error {
initialDescs = initialDescs[:0]
- txn.SetFixedTimestamp(ctx, initialTableDescTs)
+ if err := txn.SetFixedTimestamp(ctx, initialTableDescTs); err != nil {
+ return err
+ }
// Note that all targets are currently guaranteed to be tables.
for tableID := range tf.targets {
flags := tree.ObjectLookupFlagsWithRequired()
diff --git a/pkg/ccl/kvccl/kvfollowerreadsccl/followerreads_test.go b/pkg/ccl/kvccl/kvfollowerreadsccl/followerreads_test.go
index 5a6fbc6a5023..cf11f95a3503 100644
--- a/pkg/ccl/kvccl/kvfollowerreadsccl/followerreads_test.go
+++ b/pkg/ccl/kvccl/kvfollowerreadsccl/followerreads_test.go
@@ -400,11 +400,11 @@ func TestOracle(t *testing.T) {
c := kv.NewDB(log.AmbientContext{Tracer: tracing.NewTracer()}, kv.MockTxnSenderFactory{}, clock, stopper)
staleTxn := kv.NewTxn(ctx, c, 0)
- staleTxn.SetFixedTimestamp(ctx, stale)
+ require.NoError(t, staleTxn.SetFixedTimestamp(ctx, stale))
currentTxn := kv.NewTxn(ctx, c, 0)
- currentTxn.SetFixedTimestamp(ctx, current)
+ require.NoError(t, currentTxn.SetFixedTimestamp(ctx, current))
futureTxn := kv.NewTxn(ctx, c, 0)
- futureTxn.SetFixedTimestamp(ctx, future)
+ require.NoError(t, futureTxn.SetFixedTimestamp(ctx, future))
nodes := mockNodeStore{
{NodeID: 1, Address: util.MakeUnresolvedAddr("tcp", "1")},
diff --git a/pkg/kv/kvclient/kvcoord/txn_coord_sender.go b/pkg/kv/kvclient/kvcoord/txn_coord_sender.go
index 1525b79b8157..be30aa59d065 100644
--- a/pkg/kv/kvclient/kvcoord/txn_coord_sender.go
+++ b/pkg/kv/kvclient/kvcoord/txn_coord_sender.go
@@ -1008,9 +1008,19 @@ func (tc *TxnCoordSender) CommitTimestampFixed() bool {
}
// SetFixedTimestamp is part of the client.TxnSender interface.
-func (tc *TxnCoordSender) SetFixedTimestamp(ctx context.Context, ts hlc.Timestamp) {
+func (tc *TxnCoordSender) SetFixedTimestamp(ctx context.Context, ts hlc.Timestamp) error {
tc.mu.Lock()
defer tc.mu.Unlock()
+ // The transaction must not have already been used in this epoch.
+ if !tc.interceptorAlloc.txnSpanRefresher.refreshFootprint.empty() {
+ return errors.WithContextTags(errors.AssertionFailedf(
+ "cannot set fixed timestamp, txn %s already performed reads", tc.mu.txn), ctx)
+ }
+ if tc.mu.txn.Sequence != 0 {
+ return errors.WithContextTags(errors.AssertionFailedf(
+ "cannot set fixed timestamp, txn %s already performed writes", tc.mu.txn), ctx)
+ }
+
tc.mu.txn.ReadTimestamp = ts
tc.mu.txn.WriteTimestamp = ts
tc.mu.txn.GlobalUncertaintyLimit = ts
@@ -1019,6 +1029,7 @@ func (tc *TxnCoordSender) SetFixedTimestamp(ctx context.Context, ts hlc.Timestam
// Set the MinTimestamp to the minimum of the existing MinTimestamp and the fixed
// timestamp. This ensures that the MinTimestamp is always <= the other timestamps.
tc.mu.txn.MinTimestamp.Backward(ts)
+ return nil
}
// RequiredFrontier is part of the client.TxnSender interface.
diff --git a/pkg/kv/kvclient/kvcoord/txn_coord_sender_test.go b/pkg/kv/kvclient/kvcoord/txn_coord_sender_test.go
index c19659d09041..3bc03b680640 100644
--- a/pkg/kv/kvclient/kvcoord/txn_coord_sender_test.go
+++ b/pkg/kv/kvclient/kvcoord/txn_coord_sender_test.go
@@ -2672,3 +2672,91 @@ func TestTxnManualRefresh(t *testing.T) {
})
}
}
+
+// TestTxnCoordSenderSetFixedTimestamp tests that SetFixedTimestamp cannot be
+// called after a transaction has already been used in the current epoch to read
+// or write.
+func TestTxnCoordSenderSetFixedTimestamp(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+ defer log.Scope(t).Close(t)
+ ctx := context.Background()
+
+ for _, test := range []struct {
+ name string
+ before func(*testing.T, *kv.Txn)
+ expErr string
+ }{
+ {
+ name: "nothing before",
+ before: func(t *testing.T, txn *kv.Txn) {},
+ },
+ {
+ name: "read before",
+ before: func(t *testing.T, txn *kv.Txn) {
+ _, err := txn.Get(ctx, "k")
+ require.NoError(t, err)
+ },
+ expErr: "cannot set fixed timestamp, .* already performed reads",
+ },
+ {
+ name: "write before",
+ before: func(t *testing.T, txn *kv.Txn) {
+ require.NoError(t, txn.Put(ctx, "k", "v"))
+ },
+ expErr: "cannot set fixed timestamp, .* already performed writes",
+ },
+ {
+ name: "read and write before",
+ before: func(t *testing.T, txn *kv.Txn) {
+ _, err := txn.Get(ctx, "k")
+ require.NoError(t, err)
+ require.NoError(t, txn.Put(ctx, "k", "v"))
+ },
+ expErr: "cannot set fixed timestamp, .* already performed reads",
+ },
+ {
+ name: "read before, in prior epoch",
+ before: func(t *testing.T, txn *kv.Txn) {
+ _, err := txn.Get(ctx, "k")
+ require.NoError(t, err)
+ txn.ManualRestart(ctx, txn.ReadTimestamp().Next())
+ },
+ },
+ {
+ name: "write before, in prior epoch",
+ before: func(t *testing.T, txn *kv.Txn) {
+ require.NoError(t, txn.Put(ctx, "k", "v"))
+ txn.ManualRestart(ctx, txn.ReadTimestamp().Next())
+ },
+ },
+ {
+ name: "read and write before, in prior epoch",
+ before: func(t *testing.T, txn *kv.Txn) {
+ _, err := txn.Get(ctx, "k")
+ require.NoError(t, err)
+ require.NoError(t, txn.Put(ctx, "k", "v"))
+ txn.ManualRestart(ctx, txn.ReadTimestamp().Next())
+ },
+ },
+ } {
+ t.Run(test.name, func(t *testing.T) {
+ s := createTestDB(t)
+ defer s.Stop()
+
+ txn := kv.NewTxn(ctx, s.DB, 0 /* gatewayNodeID */)
+ test.before(t, txn)
+
+ ts := s.Clock.Now()
+ err := txn.SetFixedTimestamp(ctx, ts)
+ if test.expErr != "" {
+ require.Error(t, err)
+ require.Regexp(t, test.expErr, err)
+ require.False(t, txn.CommitTimestampFixed())
+ } else {
+ require.NoError(t, err)
+ require.True(t, txn.CommitTimestampFixed())
+ require.Equal(t, ts, txn.CommitTimestamp())
+ }
+ })
+ }
+}
diff --git a/pkg/kv/kvclient/rangefeed/db_adapter.go b/pkg/kv/kvclient/rangefeed/db_adapter.go
index 5e1cbfaad504..7bf47154392c 100644
--- a/pkg/kv/kvclient/rangefeed/db_adapter.go
+++ b/pkg/kv/kvclient/rangefeed/db_adapter.go
@@ -74,7 +74,9 @@ func (dbc *dbAdapter) Scan(
ctx context.Context, span roachpb.Span, asOf hlc.Timestamp, rowFn func(value roachpb.KeyValue),
) error {
return dbc.db.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, asOf)
+ if err := txn.SetFixedTimestamp(ctx, asOf); err != nil {
+ return err
+ }
sp := span
var b kv.Batch
for {
diff --git a/pkg/kv/kvserver/client_replica_test.go b/pkg/kv/kvserver/client_replica_test.go
index 29d102407c1b..7dad74e8e880 100644
--- a/pkg/kv/kvserver/client_replica_test.go
+++ b/pkg/kv/kvserver/client_replica_test.go
@@ -3174,7 +3174,7 @@ func TestStrictGCEnforcement(t *testing.T) {
}
mkStaleTxn = func() *kv.Txn {
txn := db.NewTxn(ctx, "foo")
- txn.SetFixedTimestamp(ctx, tenSecondsAgo)
+ require.NoError(t, txn.SetFixedTimestamp(ctx, tenSecondsAgo))
return txn
}
getRejectedMsg = func() string {
diff --git a/pkg/kv/kvserver/replica_rangefeed_test.go b/pkg/kv/kvserver/replica_rangefeed_test.go
index 99b4ebbf4f87..906df5c836f5 100644
--- a/pkg/kv/kvserver/replica_rangefeed_test.go
+++ b/pkg/kv/kvserver/replica_rangefeed_test.go
@@ -219,7 +219,9 @@ func TestReplicaRangefeed(t *testing.T) {
// Insert a second key transactionally.
ts3 := initTime.Add(0, 3)
if err := store1.DB().Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, ts3)
+ if err := txn.SetFixedTimestamp(ctx, ts3); err != nil {
+ return err
+ }
return txn.Put(ctx, roachpb.Key("m"), []byte("val3"))
}); err != nil {
t.Fatal(err)
@@ -239,7 +241,9 @@ func TestReplicaRangefeed(t *testing.T) {
// Update the originally incremented key transactionally.
ts5 := initTime.Add(0, 5)
if err := store1.DB().Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, ts5)
+ if err := txn.SetFixedTimestamp(ctx, ts5); err != nil {
+ return err
+ }
_, err := txn.Inc(ctx, incArgs.Key, 7)
return err
}); err != nil {
diff --git a/pkg/kv/mock_transactional_sender.go b/pkg/kv/mock_transactional_sender.go
index abb99de4ab0b..eacffe47115b 100644
--- a/pkg/kv/mock_transactional_sender.go
+++ b/pkg/kv/mock_transactional_sender.go
@@ -109,11 +109,11 @@ func (m *MockTransactionalSender) CommitTimestamp() hlc.Timestamp {
// CommitTimestampFixed is part of the TxnSender interface.
func (m *MockTransactionalSender) CommitTimestampFixed() bool {
- panic("unimplemented")
+ return m.txn.CommitTimestampFixed
}
// SetFixedTimestamp is part of the TxnSender interface.
-func (m *MockTransactionalSender) SetFixedTimestamp(_ context.Context, ts hlc.Timestamp) {
+func (m *MockTransactionalSender) SetFixedTimestamp(_ context.Context, ts hlc.Timestamp) error {
m.txn.WriteTimestamp = ts
m.txn.ReadTimestamp = ts
m.txn.GlobalUncertaintyLimit = ts
@@ -122,6 +122,7 @@ func (m *MockTransactionalSender) SetFixedTimestamp(_ context.Context, ts hlc.Ti
// Set the MinTimestamp to the minimum of the existing MinTimestamp and the fixed
// timestamp. This ensures that the MinTimestamp is always <= the other timestamps.
m.txn.MinTimestamp.Backward(ts)
+ return nil
}
// RequiredFrontier is part of the TxnSender interface.
diff --git a/pkg/kv/sender.go b/pkg/kv/sender.go
index 5097cff213e1..9bf6cdf424a7 100644
--- a/pkg/kv/sender.go
+++ b/pkg/kv/sender.go
@@ -170,11 +170,12 @@ type TxnSender interface {
// such that the transaction can't be pushed to a different
// timestamp.
//
- // This is used to support historical queries (AS OF SYSTEM TIME
- // queries and backups). This method must be called on every
- // transaction retry (but note that retries should be rare for
- // read-only queries with no clock uncertainty).
- SetFixedTimestamp(ctx context.Context, ts hlc.Timestamp)
+ // This is used to support historical queries (AS OF SYSTEM TIME queries
+ // and backups). This method must be called on every transaction retry
+ // (but note that retries should be rare for read-only queries with no
+ // clock uncertainty). The method must not be called after the
+ // transaction has been used in the current epoch to read or write.
+ SetFixedTimestamp(ctx context.Context, ts hlc.Timestamp) error
// ManualRestart bumps the transactions epoch, and can upgrade the
// timestamp and priority.
diff --git a/pkg/kv/txn.go b/pkg/kv/txn.go
index 1e4e3a449c6b..94cc3482df8f 100644
--- a/pkg/kv/txn.go
+++ b/pkg/kv/txn.go
@@ -328,6 +328,14 @@ func (txn *Txn) CommitTimestamp() hlc.Timestamp {
return txn.mu.sender.CommitTimestamp()
}
+// CommitTimestampFixed returns true if the commit timestamp has
+// been fixed to the start timestamp and cannot be pushed forward.
+func (txn *Txn) CommitTimestampFixed() bool {
+ txn.mu.Lock()
+ defer txn.mu.Unlock()
+ return txn.mu.sender.CommitTimestampFixed()
+}
+
// ProvisionalCommitTimestamp returns the transaction's provisional
// commit timestamp. This can evolve throughout a txn's lifecycle. See
// the comment on the WriteTimestamp field of TxnMeta for details.
@@ -1177,16 +1185,19 @@ func (txn *Txn) recordPreviousTxnIDLocked(prevTxnID uuid.UUID) {
// This is used to support historical queries (AS OF SYSTEM TIME queries and
// backups). This method must be called on every transaction retry (but note
// that retries should be rare for read-only queries with no clock uncertainty).
-func (txn *Txn) SetFixedTimestamp(ctx context.Context, ts hlc.Timestamp) {
+func (txn *Txn) SetFixedTimestamp(ctx context.Context, ts hlc.Timestamp) error {
if txn.typ != RootTxn {
- panic(errors.WithContextTags(
- errors.AssertionFailedf("SetFixedTimestamp() called on leaf txn"), ctx))
+ return errors.WithContextTags(errors.AssertionFailedf(
+ "SetFixedTimestamp() called on leaf txn"), ctx)
}
if ts.IsEmpty() {
- log.Fatalf(ctx, "empty timestamp is invalid for SetFixedTimestamp()")
+ return errors.WithContextTags(errors.AssertionFailedf(
+ "empty timestamp is invalid for SetFixedTimestamp()"), ctx)
}
- txn.mu.sender.SetFixedTimestamp(ctx, ts)
+ txn.mu.Lock()
+ defer txn.mu.Unlock()
+ return txn.mu.sender.SetFixedTimestamp(ctx, ts)
}
// GenerateForcedRetryableError returns a TransactionRetryWithProtoRefreshError that will
diff --git a/pkg/sql/backfill.go b/pkg/sql/backfill.go
index 7c8f9d1129bc..76633df7d470 100644
--- a/pkg/sql/backfill.go
+++ b/pkg/sql/backfill.go
@@ -186,7 +186,9 @@ func (sc *SchemaChanger) fixedTimestampTxn(
retryable func(ctx context.Context, txn *kv.Txn, descriptors *descs.Collection) error,
) error {
return sc.txn(ctx, func(ctx context.Context, txn *kv.Txn, descriptors *descs.Collection) error {
- txn.SetFixedTimestamp(ctx, readAsOf)
+ if err := txn.SetFixedTimestamp(ctx, readAsOf); err != nil {
+ return err
+ }
return retryable(ctx, txn, descriptors)
})
}
diff --git a/pkg/sql/catalog/lease/lease.go b/pkg/sql/catalog/lease/lease.go
index 5a608e71db41..ad1a66ac1d70 100644
--- a/pkg/sql/catalog/lease/lease.go
+++ b/pkg/sql/catalog/lease/lease.go
@@ -733,7 +733,9 @@ func (m *Manager) resolveName(
if err := txn.SetUserPriority(roachpb.MaxUserPriority); err != nil {
return err
}
- txn.SetFixedTimestamp(ctx, timestamp)
+ if err := txn.SetFixedTimestamp(ctx, timestamp); err != nil {
+ return err
+ }
var found bool
var err error
found, id, err = catalogkv.LookupObjectID(ctx, txn, m.storage.codec, parentID, parentSchemaID, name)
diff --git a/pkg/sql/catalog/lease/lease_internal_test.go b/pkg/sql/catalog/lease/lease_internal_test.go
index d9b3c345c91e..24a56d8730c3 100644
--- a/pkg/sql/catalog/lease/lease_internal_test.go
+++ b/pkg/sql/catalog/lease/lease_internal_test.go
@@ -303,7 +303,9 @@ CREATE TABLE t.test (k CHAR PRIMARY KEY, v CHAR);
update := func(catalog.MutableDescriptor) error { return nil }
logEvent := func(txn *kv.Txn) error {
txn2 := kvDB.NewTxn(ctx, "future-read")
- txn2.SetFixedTimestamp(ctx, futureTime.Prev())
+ if err := txn2.SetFixedTimestamp(ctx, futureTime.Prev()); err != nil {
+ return err
+ }
if _, err := txn2.Get(ctx, "key"); err != nil {
return errors.Wrap(err, "read from other txn in future")
}
diff --git a/pkg/sql/catalog/lease/lease_test.go b/pkg/sql/catalog/lease/lease_test.go
index 3b3a53e8c1b7..fb33df96758a 100644
--- a/pkg/sql/catalog/lease/lease_test.go
+++ b/pkg/sql/catalog/lease/lease_test.go
@@ -1685,7 +1685,7 @@ CREATE TABLE t.test0 (k CHAR PRIMARY KEY, v CHAR);
log.Infof(ctx, "checking version %d", table.GetVersion())
txn := kv.NewTxn(ctx, t.kvDB, roachpb.NodeID(0))
// Make the txn look back at the known modification timestamp.
- txn.SetFixedTimestamp(ctx, table.GetModificationTime())
+ require.NoError(t, txn.SetFixedTimestamp(ctx, table.GetModificationTime()))
// Look up the descriptor.
descKey := catalogkeys.MakeDescMetadataKey(keys.SystemSQLCodec, descID)
diff --git a/pkg/sql/catalog/lease/storage.go b/pkg/sql/catalog/lease/storage.go
index 4123bba4b6e5..00b0eb5b0a9f 100644
--- a/pkg/sql/catalog/lease/storage.go
+++ b/pkg/sql/catalog/lease/storage.go
@@ -211,9 +211,12 @@ func (s storage) getForExpiration(
ctx context.Context, expiration hlc.Timestamp, id descpb.ID,
) (catalog.Descriptor, error) {
var desc catalog.Descriptor
- err := s.db.Txn(ctx, func(ctx context.Context, txn *kv.Txn) (err error) {
+ err := s.db.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
prevTimestamp := expiration.Prev()
- txn.SetFixedTimestamp(ctx, prevTimestamp)
+ err := txn.SetFixedTimestamp(ctx, prevTimestamp)
+ if err != nil {
+ return err
+ }
desc, err = catalogkv.MustGetDescriptorByID(ctx, txn, s.codec, id)
if err != nil {
return err
diff --git a/pkg/sql/conn_executor.go b/pkg/sql/conn_executor.go
index deaa0fb78da6..31e047be8fc5 100644
--- a/pkg/sql/conn_executor.go
+++ b/pkg/sql/conn_executor.go
@@ -2215,7 +2215,9 @@ func (ex *connExecutor) setTransactionModes(
return errors.AssertionFailedf("expected an evaluated AS OF timestamp")
}
if !asOfTs.IsEmpty() {
- ex.state.setHistoricalTimestamp(ex.Ctx(), asOfTs)
+ if err := ex.state.setHistoricalTimestamp(ex.Ctx(), asOfTs); err != nil {
+ return err
+ }
ex.state.sqlTimestamp = asOfTs.GoTime()
if rwMode == tree.UnspecifiedReadWriteMode {
rwMode = tree.ReadOnly
diff --git a/pkg/sql/conn_executor_exec.go b/pkg/sql/conn_executor_exec.go
index 2a3a4eef6b3b..22676d158e6a 100644
--- a/pkg/sql/conn_executor_exec.go
+++ b/pkg/sql/conn_executor_exec.go
@@ -588,7 +588,9 @@ func (ex *connExecutor) execStmtInOpenState(
if asOf != nil {
p.extendedEvalCtx.AsOfSystemTime = asOf
p.extendedEvalCtx.SetTxnTimestamp(asOf.Timestamp.GoTime())
- ex.state.setHistoricalTimestamp(ctx, asOf.Timestamp)
+ if err := ex.state.setHistoricalTimestamp(ctx, asOf.Timestamp); err != nil {
+ return makeErrEvent(err)
+ }
}
} else {
// If we're in an explicit txn, we allow AOST but only if it matches with
diff --git a/pkg/sql/conn_executor_prepare.go b/pkg/sql/conn_executor_prepare.go
index b45b9b434d6b..bf20cedfd8fb 100644
--- a/pkg/sql/conn_executor_prepare.go
+++ b/pkg/sql/conn_executor_prepare.go
@@ -275,7 +275,9 @@ func (ex *connExecutor) populatePrepared(
"bounded staleness queries do not yet work with prepared statements",
)
}
- txn.SetFixedTimestamp(ctx, asOf.Timestamp)
+ if err := txn.SetFixedTimestamp(ctx, asOf.Timestamp); err != nil {
+ return 0, err
+ }
}
// PREPARE has a limited subset of statements it can be run with. Postgres
diff --git a/pkg/sql/create_stats.go b/pkg/sql/create_stats.go
index 3da365b71df2..560e0cf34a8b 100644
--- a/pkg/sql/create_stats.go
+++ b/pkg/sql/create_stats.go
@@ -543,7 +543,9 @@ func (r *createStatsResumer) Resume(ctx context.Context, execCtx interface{}) er
if details.AsOf != nil {
p.ExtendedEvalContext().AsOfSystemTime = &tree.AsOfSystemTime{Timestamp: *details.AsOf}
p.ExtendedEvalContext().SetTxnTimestamp(details.AsOf.GoTime())
- txn.SetFixedTimestamp(ctx, *details.AsOf)
+ if err := txn.SetFixedTimestamp(ctx, *details.AsOf); err != nil {
+ return err
+ }
}
planCtx := dsp.NewPlanningCtx(ctx, evalCtx, nil /* planner */, txn, true /* distribute */)
diff --git a/pkg/sql/index_backfiller.go b/pkg/sql/index_backfiller.go
index 4658bc05e2c1..c11b537dc566 100644
--- a/pkg/sql/index_backfiller.go
+++ b/pkg/sql/index_backfiller.go
@@ -98,7 +98,9 @@ func (ib *IndexBackfillPlanner) scanTargetSpansToPushTimestampCache(
) error {
const pageSize = 10000
return ib.execCfg.DB.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, backfillTimestamp)
+ if err := txn.SetFixedTimestamp(ctx, backfillTimestamp); err != nil {
+ return err
+ }
for _, span := range targetSpans {
// TODO(dt): a Count() request would be nice here if the target isn't
// empty, since we don't need to drag all the results back just to
diff --git a/pkg/sql/row/fetcher.go b/pkg/sql/row/fetcher.go
index 82c3b17f460a..bd4b89b86c33 100644
--- a/pkg/sql/row/fetcher.go
+++ b/pkg/sql/row/fetcher.go
@@ -629,7 +629,9 @@ func (rf *Fetcher) StartInconsistentScan(
)
}
txn := kv.NewTxnWithSteppingEnabled(ctx, db, 0 /* gatewayNodeID */)
- txn.SetFixedTimestamp(ctx, txnTimestamp)
+ if err := txn.SetFixedTimestamp(ctx, txnTimestamp); err != nil {
+ return err
+ }
if log.V(1) {
log.Infof(ctx, "starting inconsistent scan at timestamp %v", txnTimestamp)
}
@@ -644,7 +646,9 @@ func (rf *Fetcher) StartInconsistentScan(
txnTimestamp = txnTimestamp.Add(now.Sub(txnStartTime).Nanoseconds(), 0 /* logical */)
txnStartTime = now
txn = kv.NewTxnWithSteppingEnabled(ctx, db, 0 /* gatewayNodeID */)
- txn.SetFixedTimestamp(ctx, txnTimestamp)
+ if err := txn.SetFixedTimestamp(ctx, txnTimestamp); err != nil {
+ return nil, err
+ }
if log.V(1) {
log.Infof(ctx, "bumped inconsistent scan timestamp to %v", txnTimestamp)
diff --git a/pkg/sql/row/row_converter.go b/pkg/sql/row/row_converter.go
index 4f1a76c45e0a..1a33e4961e11 100644
--- a/pkg/sql/row/row_converter.go
+++ b/pkg/sql/row/row_converter.go
@@ -268,7 +268,9 @@ func (c *DatumRowConverter) getSequenceAnnotation(
err := evalCtx.DB.Txn(evalCtx.Context, func(ctx context.Context, txn *kv.Txn) error {
seqNameToMetadata = make(map[string]*SequenceMetadata)
seqIDToMetadata = make(map[descpb.ID]*SequenceMetadata)
- txn.SetFixedTimestamp(ctx, hlc.Timestamp{WallTime: evalCtx.TxnTimestamp.UnixNano()})
+ if err := txn.SetFixedTimestamp(ctx, hlc.Timestamp{WallTime: evalCtx.TxnTimestamp.UnixNano()}); err != nil {
+ return err
+ }
for seqID := range sequenceIDs {
seqDesc, err := catalogkv.MustGetTableDescByID(ctx, txn, evalCtx.Codec, seqID)
if err != nil {
diff --git a/pkg/sql/rowexec/indexbackfiller.go b/pkg/sql/rowexec/indexbackfiller.go
index b22ef934671f..902ea184d948 100644
--- a/pkg/sql/rowexec/indexbackfiller.go
+++ b/pkg/sql/rowexec/indexbackfiller.go
@@ -432,7 +432,9 @@ func (ib *indexBackfiller) buildIndexEntryBatch(
start := timeutil.Now()
var entries []rowenc.IndexEntry
if err := ib.flowCtx.Cfg.DB.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, readAsOf)
+ if err := txn.SetFixedTimestamp(ctx, readAsOf); err != nil {
+ return err
+ }
// TODO(knz): do KV tracing in DistSQL processors.
var err error
diff --git a/pkg/sql/schema_change_plan_node.go b/pkg/sql/schema_change_plan_node.go
index 1a4f029fa265..a8dad8a622a1 100644
--- a/pkg/sql/schema_change_plan_node.go
+++ b/pkg/sql/schema_change_plan_node.go
@@ -84,7 +84,9 @@ func (p *planner) WaitForDescriptorSchemaChanges(
if err := p.ExecCfg().CollectionFactory.Txn(
ctx, p.ExecCfg().InternalExecutor, p.ExecCfg().DB,
func(ctx context.Context, txn *kv.Txn, descriptors *descs.Collection) error {
- txn.SetFixedTimestamp(ctx, now)
+ if err := txn.SetFixedTimestamp(ctx, now); err != nil {
+ return err
+ }
table, err := descriptors.GetImmutableTableByID(ctx, txn, descID,
tree.ObjectLookupFlags{
CommonLookupFlags: tree.CommonLookupFlags{
diff --git a/pkg/sql/schema_changer.go b/pkg/sql/schema_changer.go
index bbb34fef730a..95c1fccdc41d 100644
--- a/pkg/sql/schema_changer.go
+++ b/pkg/sql/schema_changer.go
@@ -247,7 +247,9 @@ func (sc *SchemaChanger) backfillQueryIntoTable(
}
return sc.db.Txn(ctx, func(ctx context.Context, txn *kv.Txn) error {
- txn.SetFixedTimestamp(ctx, ts)
+ if err := txn.SetFixedTimestamp(ctx, ts); err != nil {
+ return err
+ }
// Create an internal planner as the planner used to serve the user query
// would have committed by this point.
diff --git a/pkg/sql/txn_state.go b/pkg/sql/txn_state.go
index 878f1d6572db..ff986599c537 100644
--- a/pkg/sql/txn_state.go
+++ b/pkg/sql/txn_state.go
@@ -202,7 +202,9 @@ func (ts *txnState) resetForNewSQLTxn(
ts.mu.txnStart = timeutil.Now()
ts.mu.Unlock()
if historicalTimestamp != nil {
- ts.setHistoricalTimestamp(ts.Ctx, *historicalTimestamp)
+ if err := ts.setHistoricalTimestamp(ts.Ctx, *historicalTimestamp); err != nil {
+ panic(err)
+ }
}
if err := ts.setReadOnlyMode(readOnly); err != nil {
panic(err)
@@ -262,11 +264,16 @@ func (ts *txnState) finishExternalTxn() {
ts.mu.Unlock()
}
-func (ts *txnState) setHistoricalTimestamp(ctx context.Context, historicalTimestamp hlc.Timestamp) {
+func (ts *txnState) setHistoricalTimestamp(
+ ctx context.Context, historicalTimestamp hlc.Timestamp,
+) error {
ts.mu.Lock()
- ts.mu.txn.SetFixedTimestamp(ctx, historicalTimestamp)
- ts.mu.Unlock()
+ defer ts.mu.Unlock()
+ if err := ts.mu.txn.SetFixedTimestamp(ctx, historicalTimestamp); err != nil {
+ return err
+ }
ts.isHistorical = true
+ return nil
}
// getReadTimestamp returns the transaction's current read timestamp.
|
5591e0fe2edaa97f4891b1760ee8a3b324972d99
|
2022-01-29 19:51:39
|
Faizan Qazi
|
logictest: filter the out the new_scheama_changer setting
| false
|
filter the out the new_scheama_changer setting
|
logictest
|
diff --git a/pkg/sql/logictest/testdata/logic_test/event_log b/pkg/sql/logictest/testdata/logic_test/event_log
index 73c9fecadcd9..9a75080129e5 100644
--- a/pkg/sql/logictest/testdata/logic_test/event_log
+++ b/pkg/sql/logictest/testdata/logic_test/event_log
@@ -451,6 +451,7 @@ AND info NOT LIKE '%sql.stats.automatic_collection.enabled%'
AND info NOT LIKE '%sql.defaults.vectorize%'
AND info NOT LIKE '%sql.testing%'
AND info NOT LIKE '%sql.defaults.experimental_distsql_planning%'
+AND info NOT LIKE '%sql.defaults.experimental_new_schema_changer.enabled%'
ORDER BY "timestamp", info
----
0 1 {"ApplicationName": "$ internal-optInToDiagnosticsStatReporting", "EventType": "set_cluster_setting", "SettingName": "diagnostics.reporting.enabled", "Statement": "SET CLUSTER SETTING \"diagnostics.reporting.enabled\" = true", "Tag": "SET CLUSTER SETTING", "User": "root", "Value": "true"}
diff --git a/pkg/sql/logictest/testdata/logic_test/system b/pkg/sql/logictest/testdata/logic_test/system
index cd28dc28256e..8661e1beac87 100644
--- a/pkg/sql/logictest/testdata/logic_test/system
+++ b/pkg/sql/logictest/testdata/logic_test/system
@@ -1054,6 +1054,7 @@ AND name != 'sql.stats.automatic_collection.enabled'
AND name NOT LIKE '%sql.defaults.vectorize%'
AND name NOT LIKE '%sql.testing%'
AND name NOT LIKE '%sql.defaults.experimental_distsql_planning%'
+AND name != 'sql.defaults.experimental_new_schema_changer.enabled'
ORDER BY name
----
cluster.secret
@@ -1091,7 +1092,8 @@ SELECT name, value
FROM system.settings
WHERE name NOT IN ('version', 'sql.defaults.distsql', 'cluster.secret',
'sql.stats.automatic_collection.enabled', 'sql.defaults.vectorize',
- 'sql.defaults.experimental_distsql_planning')
+ 'sql.defaults.experimental_distsql_planning',
+ 'sql.defaults.experimental_new_schema_changer.enabled')
ORDER BY name
----
diagnostics.reporting.enabled true
|
4901896a1c333d3a3e9192f718a41e3dd7eb3c87
|
2020-02-28 18:08:46
|
Andrii Vorobiov
|
ui: Extract NodeName and NodeLocality columns as external components
| false
|
Extract NodeName and NodeLocality columns as external components
|
ui
|
diff --git a/pkg/ui/src/views/cluster/containers/nodesOverview/index.tsx b/pkg/ui/src/views/cluster/containers/nodesOverview/index.tsx
index ce111e26bcf7..f3f73e73acb1 100644
--- a/pkg/ui/src/views/cluster/containers/nodesOverview/index.tsx
+++ b/pkg/ui/src/views/cluster/containers/nodesOverview/index.tsx
@@ -124,6 +124,37 @@ const getStatusDescription = (status: LivenessStatus) => {
}
};
+// tslint:disable-next-line:variable-name
+const NodeNameColumn: React.FC<{ record: NodeStatusRow | DecommissionedNodeStatusRow }> = ({ record }) => {
+ return (
+ <Link className="nodes-table__link" to={`/node/${record.nodeId}`}>
+ <Text textType={TextTypes.BodyStrong}>{`N${record.nodeId} `}</Text>
+ <Text>{record.nodeName}</Text>
+ </Link>
+ );
+};
+
+// tslint:disable-next-line:variable-name
+const NodeLocalityColumn: React.FC<{ record: NodeStatusRow }> = ({ record }) => {
+ return (
+ <Text>
+ <Tooltip
+ placement={"bottom"}
+ title={
+ <div>
+ {
+ record.tiers.map((tier, idx) =>
+ <div key={idx}>{`${tier.key} = ${tier.value}`}</div>)
+ }
+ </div>
+ }
+ >
+ {record.region}
+ </Tooltip>
+ </Text>
+ );
+};
+
/**
* LiveNodeList displays a sortable table of all "live" nodes, which includes
* both healthy and suspect nodes. Included is a side-bar with summary
@@ -137,31 +168,9 @@ export class NodeList extends React.Component<LiveNodeListProps> {
title: "nodes",
render: (_text, record) => {
if (!!record.nodeId) {
- return (
- <Link className="nodes-table__link" to={`/node/${record.nodeId}`}>
- <Text textType={TextTypes.BodyStrong}>{`N${record.nodeId} `}</Text>
- <Text>{record.nodeName}</Text>
- </Link>
- );
+ return <NodeNameColumn record={record} />;
} else {
- // Top level grouping item does not have nodeId
- return (
- <Text>
- <Tooltip
- placement={"bottom"}
- title={
- <div>
- {
- record.tiers.map((tier, idx) =>
- <div key={idx}>{`${tier.key} = ${tier.value}`}</div>)
- }
- </div>
- }
- >
- {record.region}
- </Tooltip>
- </Text>
- );
+ return <NodeLocalityColumn record={record} />;
}
},
sorter: (a, b) => {
@@ -309,11 +318,8 @@ class DecommissionedNodeList extends React.Component<DecommissionedNodeListProps
{
key: "nodes",
title: "decommissioned nodes",
- render: (_text, record) => (
- <Link className="nodes-table__link" to={`/node/${record.nodeId}`}>
- <Text textType={TextTypes.BodyStrong}>{`N${record.nodeId} `}</Text>
- <Text>{record.nodeName}</Text>
- </Link>),
+ render: (_text, record) =>
+ <NodeNameColumn record={record}/>,
},
{
key: "decommissionedSince",
@@ -405,11 +411,11 @@ export const liveNodesTableDataSelector = createSelector(
// from location values.
const firstNodeInGroup = nodesPerRegion[0];
const tiers = getNodeLocalityTiers(firstNodeInGroup);
- const location = _.last(tiers);
+ const lastTier = _.last(tiers);
return {
key: `${regionKey}`,
- region: location?.value,
+ region: lastTier?.value,
tiers,
nodesCount: nodesPerRegion.length,
replicas: _.sum(nestedRows.map(nr => nr.replicas)),
|
4bcb6f4951b8e5b1d89779f6d52812242910c3e4
|
2023-04-05 03:05:27
|
Yahor Yuzefovich
|
builtins: remove crdb_internal.no_constant_folding builtin
| false
|
remove crdb_internal.no_constant_folding builtin
|
builtins
|
diff --git a/docs/generated/sql/functions.md b/docs/generated/sql/functions.md
index 993a58ff4717..f44b62145760 100644
--- a/docs/generated/sql/functions.md
+++ b/docs/generated/sql/functions.md
@@ -3187,8 +3187,6 @@ active for the current transaction.</p>
</span></td><td>Volatile</td></tr>
<tr><td><a name="crdb_internal.locality_value"></a><code>crdb_internal.locality_value(key: <a href="string.html">string</a>) → <a href="string.html">string</a></code></td><td><span class="funcdesc"><p>Returns the value of the specified locality key.</p>
</span></td><td>Stable</td></tr>
-<tr><td><a name="crdb_internal.no_constant_folding"></a><code>crdb_internal.no_constant_folding(input: anyelement) → anyelement</code></td><td><span class="funcdesc"><p>This function is used only by CockroachDB’s developers for testing purposes.</p>
-</span></td><td>Volatile</td></tr>
<tr><td><a name="crdb_internal.node_executable_version"></a><code>crdb_internal.node_executable_version() → <a href="string.html">string</a></code></td><td><span class="funcdesc"><p>Returns the version of CockroachDB this node is running.</p>
</span></td><td>Volatile</td></tr>
<tr><td><a name="crdb_internal.node_id"></a><code>crdb_internal.node_id() → <a href="int.html">int</a></code></td><td><span class="funcdesc"><p>Returns the node ID.</p>
diff --git a/pkg/sql/sem/builtins/builtins.go b/pkg/sql/sem/builtins/builtins.go
index 47533c71e5b1..5922af76badf 100644
--- a/pkg/sql/sem/builtins/builtins.go
+++ b/pkg/sql/sem/builtins/builtins.go
@@ -5307,22 +5307,6 @@ DO NOT USE -- USE 'CREATE TENANT' INSTEAD`,
},
),
- // Identity function which is marked as impure to avoid constant folding.
- "crdb_internal.no_constant_folding": makeBuiltin(
- tree.FunctionProperties{
- Category: builtinconstants.CategorySystemInfo,
- },
- tree.Overload{
- Types: tree.ParamTypes{{Name: "input", Typ: types.Any}},
- ReturnType: tree.IdentityReturnType(0),
- Fn: func(_ context.Context, _ *eval.Context, args tree.Datums) (tree.Datum, error) {
- return args[0], nil
- },
- Info: "This function is used only by CockroachDB's developers for testing purposes.",
- Volatility: volatility.Volatile,
- },
- ),
-
"crdb_internal.trim_tenant_prefix": makeBuiltin(
tree.FunctionProperties{
Category: builtinconstants.CategoryMultiTenancy,
diff --git a/pkg/sql/sem/builtins/fixed_oids.go b/pkg/sql/sem/builtins/fixed_oids.go
index 19c6d48212ff..6d5d39845d71 100644
--- a/pkg/sql/sem/builtins/fixed_oids.go
+++ b/pkg/sql/sem/builtins/fixed_oids.go
@@ -1295,7 +1295,6 @@ var builtinOidsArray = []string{
1314: `crdb_internal.force_log_fatal(msg: string) -> int`,
1315: `crdb_internal.force_retry(val: interval) -> int`,
1316: `crdb_internal.lease_holder(key: bytes) -> int`,
- 1317: `crdb_internal.no_constant_folding(input: anyelement) -> anyelement`,
1318: `crdb_internal.trim_tenant_prefix(key: bytes) -> bytes`,
1319: `crdb_internal.trim_tenant_prefix(keys: bytes[]) -> bytes[]`,
1320: `crdb_internal.tenant_span(tenant_id: int) -> bytes[]`,
diff --git a/pkg/sql/sem/normalize/normalize_test.go b/pkg/sql/sem/normalize/normalize_test.go
index 296715390a7b..8a3878fff9e8 100644
--- a/pkg/sql/sem/normalize/normalize_test.go
+++ b/pkg/sql/sem/normalize/normalize_test.go
@@ -156,7 +156,6 @@ func TestNormalizeExpr(t *testing.T) {
{`crdb_internal.force_panic('a')`, `crdb_internal.force_panic('a')`},
{`crdb_internal.force_log_fatal('a')`, `crdb_internal.force_log_fatal('a')`},
{`crdb_internal.force_retry('1 day'::interval)`, `crdb_internal.force_retry('1 day')`},
- {`crdb_internal.no_constant_folding(123)`, `crdb_internal.no_constant_folding(123)`},
{`crdb_internal.set_vmodule('a')`, `crdb_internal.set_vmodule('a')`},
{`uuid_v4()`, `uuid_v4()`},
{`experimental_uuid_v4()`, `experimental_uuid_v4()`},
|
6bff643e942b8880ed780aef0dee87e568548f05
|
2020-01-22 14:39:04
|
Andrii Vorobiov
|
ui: Rename TabNavigation component to PageHeader
| false
|
Rename TabNavigation component to PageHeader
|
ui
|
diff --git a/pkg/ui/src/components/index.ts b/pkg/ui/src/components/index.ts
index da7529ebafae..76d0a347dea8 100644
--- a/pkg/ui/src/components/index.ts
+++ b/pkg/ui/src/components/index.ts
@@ -12,7 +12,7 @@ export * from "./badge";
export * from "./icon";
export * from "./globalNavigation";
export * from "./sideNavigation";
-export * from "./tabNavigation";
+export * from "./pageHeader";
export * from "./text";
export * from "./table";
export * from "./tooltip";
diff --git a/pkg/ui/src/components/tabNavigation/index.ts b/pkg/ui/src/components/pageHeader/index.ts
similarity index 91%
rename from pkg/ui/src/components/tabNavigation/index.ts
rename to pkg/ui/src/components/pageHeader/index.ts
index e344cdf35eef..ef5234e1442f 100644
--- a/pkg/ui/src/components/tabNavigation/index.ts
+++ b/pkg/ui/src/components/pageHeader/index.ts
@@ -8,4 +8,4 @@
// by the Apache License, Version 2.0, included in the file
// licenses/APL.txt.
-export * from "./tabNavigation";
+export * from "./pageHeader";
diff --git a/pkg/ui/src/components/tabNavigation/tabNavigation.styl b/pkg/ui/src/components/pageHeader/pageHeader.styl
similarity index 88%
rename from pkg/ui/src/components/tabNavigation/tabNavigation.styl
rename to pkg/ui/src/components/pageHeader/pageHeader.styl
index 87335ca595d6..884d14f264b1 100644
--- a/pkg/ui/src/components/tabNavigation/tabNavigation.styl
+++ b/pkg/ui/src/components/pageHeader/pageHeader.styl
@@ -10,11 +10,11 @@
@require '~src/components/core/index.styl'
-.tab-navigation
+.page-header
height 100%
display flex
flex-direction row
align-items center
-.tab-navigation > *
- margin-right $spacing-small
\ No newline at end of file
+.page-header > *
+ margin-right $spacing-small
diff --git a/pkg/ui/src/components/tabNavigation/tabNavigation.tsx b/pkg/ui/src/components/pageHeader/pageHeader.tsx
similarity index 75%
rename from pkg/ui/src/components/tabNavigation/tabNavigation.tsx
rename to pkg/ui/src/components/pageHeader/pageHeader.tsx
index 1a68c2345f39..bca7adeb62f0 100644
--- a/pkg/ui/src/components/tabNavigation/tabNavigation.tsx
+++ b/pkg/ui/src/components/pageHeader/pageHeader.tsx
@@ -10,15 +10,15 @@
import * as React from "react";
-import "./tabNavigation.styl";
+import "./pageHeader.styl";
-export interface TabNavigationProps {
+export interface PageHeaderProps {
children?: React.ReactNode;
}
-export function TabNavigation(props: TabNavigationProps) {
+export function PageHeader(props: PageHeaderProps) {
return (
- <div className="tab-navigation">
+ <div className="page-header">
{props.children}
</div>
);
diff --git a/pkg/ui/src/views/app/containers/layout/index.tsx b/pkg/ui/src/views/app/containers/layout/index.tsx
index c676e151da5b..40a59b05ecaa 100644
--- a/pkg/ui/src/views/app/containers/layout/index.tsx
+++ b/pkg/ui/src/views/app/containers/layout/index.tsx
@@ -25,7 +25,7 @@ import {
CockroachLabsLockupIcon,
Left,
Right,
- TabNavigation,
+ PageHeader,
Text,
TextTypes,
Badge,
@@ -69,10 +69,10 @@ class Layout extends React.Component<LayoutProps & RouterState, {}> {
</GlobalNavigation>
</div>
<div className="layout-panel__navigation-bar">
- <TabNavigation>
+ <PageHeader>
<Text textType={TextTypes.Heading2}>{clusterName || `Cluster id: ${clusterId || ""}`}</Text>
<Badge text={clusterVersion} />
- </TabNavigation>
+ </PageHeader>
</div>
<div className="layout-panel__body">
<div className="layout-panel__sidebar">
|
07ace1ce865ed0417acaf341215ced57aab249bc
|
2023-08-03 12:31:04
|
cockroach-teamcity
|
ci: update bazel builder image
| false
|
update bazel builder image
|
ci
|
diff --git a/build/.bazelbuilderversion b/build/.bazelbuilderversion
index c70572013225..8bfba80d243c 100644
--- a/build/.bazelbuilderversion
+++ b/build/.bazelbuilderversion
@@ -1 +1 @@
-cockroachdb/bazel:20230629-030909
+cockroachdb/bazel:20230803-060342
\ No newline at end of file
|
3ce474153e91031bffbb2a3ac31ddd09c5cc9978
|
2024-02-09 01:54:56
|
Wenyi Hu
|
changefeedccl: skip flaky tests for pulsar
| false
|
skip flaky tests for pulsar
|
changefeedccl
|
diff --git a/pkg/ccl/changefeedccl/helpers_test.go b/pkg/ccl/changefeedccl/helpers_test.go
index 0c938b614e99..c0db383c5908 100644
--- a/pkg/ccl/changefeedccl/helpers_test.go
+++ b/pkg/ccl/changefeedccl/helpers_test.go
@@ -881,7 +881,7 @@ func randomSinkTypeWithOptions(options feedTestOptions) string {
"pubsub": 1,
"sinkless": 2,
"cloudstorage": 0,
- "pulsar": 1,
+ "pulsar": 0,
}
if options.externalIODir != "" {
sinkWeights["cloudstorage"] = 3
|
61d16ff4fa84d1be76c735d3bdadfbef7a118a32
|
2016-10-17 20:43:46
|
Tamir Duberstein
|
build: more `pkg` fallout
| false
|
more `pkg` fallout
|
build
|
diff --git a/build/push-aws.sh b/build/push-aws.sh
index a7bf70460951..af29932200e3 100755
--- a/build/push-aws.sh
+++ b/build/push-aws.sh
@@ -20,8 +20,8 @@ SHA="${CIRCLE_SHA1-$(git rev-parse HEAD)}"
# Linux binaries: cockroach + tests.
./push-one-binary.sh ${SHA} cockroach cockroach
-./push-one-binary.sh ${SHA} sql/sql.test
-./push-one-binary.sh ${SHA} acceptance/acceptance.test
+./push-one-binary.sh ${SHA} pkg/sql/sql.test
+./push-one-binary.sh ${SHA} pkg/acceptance/acceptance.test
./push-one-binary.sh ${SHA} static-tests.tar.gz
# TODO(marc): use these instead of the above "Linux binaries", this requires
diff --git a/build/push-one-binary.sh b/build/push-one-binary.sh
index 00794d36cea6..e8ea59bb63e3 100755
--- a/build/push-one-binary.sh
+++ b/build/push-one-binary.sh
@@ -10,7 +10,7 @@ LATEST_SUFFIX=".LATEST"
REPO_NAME="cockroach"
# $0 takes the path to the binary inside the repo.
-# eg: $0 sql/sql.test sql/sql-foo.test
+# eg: $0 pkg/sql/sql.test sql/sql-foo.test
# The file will be pushed to: s3://BUCKET_NAME/REPO_NAME/sql-foo.test.SHA
# The binary's sha will be stored in s3://BUCKET_NAME/REPO_NAME/sql-foo.test.LATEST
# The .LATEST file will also redirect to the latest binary when fetching through
|
b08930e14e89dbfea7253ef0f12aebc4de08f829
|
2017-10-02 20:51:43
|
Andrei Matei
|
sql: fix schema changer test
| false
|
fix schema changer test
|
sql
|
diff --git a/pkg/sql/schema_changer_test.go b/pkg/sql/schema_changer_test.go
index 0b534aebe5a1..4da6b0a71337 100644
--- a/pkg/sql/schema_changer_test.go
+++ b/pkg/sql/schema_changer_test.go
@@ -87,7 +87,8 @@ CREATE TABLE t.test (k CHAR PRIMARY KEY, v CHAR);
}
if !validExpirationTime(lease.ExpirationTime) {
- t.Fatalf("invalid expiration time: %s", timeutil.Unix(0, lease.ExpirationTime))
+ t.Fatalf("invalid expiration time: %s. now: %s",
+ timeutil.Unix(0, lease.ExpirationTime), timeutil.Now())
}
// Acquiring another lease will fail.
@@ -152,7 +153,7 @@ CREATE TABLE t.test (k CHAR PRIMARY KEY, v CHAR);
func validExpirationTime(expirationTime int64) bool {
now := timeutil.Now()
- return expirationTime > now.Add(sql.LeaseDuration/2).UnixNano() && expirationTime < now.Add(sql.LeaseDuration*3/2).UnixNano()
+ return expirationTime > now.Add(sql.SchemaChangeLeaseDuration/2).UnixNano() && expirationTime < now.Add(sql.SchemaChangeLeaseDuration*3/2).UnixNano()
}
func TestSchemaChangeProcess(t *testing.T) {
|
b50cee279be1445fe30a5883585245bf5b087514
|
2020-02-03 23:51:31
|
Yahor Yuzefovich
|
colexec: fix planning of joiners to output all columns
| false
|
fix planning of joiners to output all columns
|
colexec
|
diff --git a/pkg/sql/colexec/execplan.go b/pkg/sql/colexec/execplan.go
index 68edd536a5db..ac6985483ec9 100644
--- a/pkg/sql/colexec/execplan.go
+++ b/pkg/sql/colexec/execplan.go
@@ -120,133 +120,43 @@ type NewColOperatorResult struct {
BufferingOpMemAccounts []*mon.BoundAccount
}
-// joinerPlanningState is a helper struct used when creating a hash or merge
-// joiner to track the planning state.
-type joinerPlanningState struct {
- // postJoinerProjection is the projection that has to be added after a
- // joiner. It is needed because the joiners always output all the requested
- // columns from the left side first followed by the columns from the right
- // side. However, post.OutputColumns projection can have an arbitrary order
- // of columns, and postJoinerProjection behaves as an "adapter" between the
- // output of the joiner and the requested post.OutputColumns projection.
- postJoinerProjection []uint32
-
- // postFilterPlanning will be set by the operators that handle the
- // projection themselves. This is needed to handle post.Filter correctly so
- // that those operators output all the columns that are used by post.Filter
- // even if some columns are not needed by post.OutputColumns. If it remains
- // unset, then postFilterPlanning will act as a noop.
- postFilterPlanning filterPlanningState
-}
-
// createJoiner adds a new hash or merge join with the argument function
-// createJoinOpWithOnExprPlanning distinguishing between the two.
+// createJoinOp distinguishing between the two.
// Note: the passed in 'result' will be modified accordingly.
func createJoiner(
ctx context.Context,
result *NewColOperatorResult,
flowCtx *execinfra.FlowCtx,
args NewColOperatorArgs,
- planningState *joinerPlanningState,
joinType sqlbase.JoinType,
- createJoinOpWithOnExprPlanning func(
+ createJoinOp func(
result *NewColOperatorResult,
leftTypes, rightTypes []coltypes.T,
- leftOutCols, rightOutCols []uint32,
- ) (*execinfrapb.Expression, filterPlanningState, []uint32, []uint32, error),
+ ) (onExpr *execinfrapb.Expression, err error),
) error {
spec := args.Spec
inputs := args.Inputs
acc := args.StreamingMemAccount
-
- var err error
- if err = checkNumIn(inputs, 2); err != nil {
+ if err := checkNumIn(inputs, 2); err != nil {
return err
}
- post := &spec.Post
-
- var leftTypes, rightTypes []coltypes.T
- leftTypes, err = typeconv.FromColumnTypes(spec.Input[0].ColumnTypes)
+ leftTypes, err := typeconv.FromColumnTypes(spec.Input[0].ColumnTypes)
if err != nil {
return err
}
- rightTypes, err = typeconv.FromColumnTypes(spec.Input[1].ColumnTypes)
+ rightTypes, err := typeconv.FromColumnTypes(spec.Input[1].ColumnTypes)
if err != nil {
return err
}
- nLeftCols := uint32(len(leftTypes))
- nRightCols := uint32(len(rightTypes))
-
- leftOutCols := make([]uint32, 0)
- rightOutCols := make([]uint32, 0)
-
- // Note that we do not need a special treatment in case of LEFT SEMI and
- // LEFT ANTI joins when setting up outCols because in such cases there will
- // be a projection with post.OutputColumns already projecting out the right
- // side.
- if post.Projection {
- for _, col := range post.OutputColumns {
- if col < nLeftCols {
- leftOutCols = append(leftOutCols, col)
- } else {
- rightOutCols = append(rightOutCols, col-nLeftCols)
- }
- }
- // Now that we know how many columns are output from the left side, we
- // can populate the "post-joiner" projection. Consider an example:
- // we have post.OutputColumns = {6, 2, 5, 7, 0, 3} with nLeftCols = 6.
- // We've just populated output columns as follows:
- // leftOutCols = {2, 5, 0, 3} and rightOutCols = {6, 7},
- // and because the joiner always outputs the left columns first, the output
- // will look as {2, 5, 0, 3, 6, 7}, so we need to add an extra projection.
- // The code below will populate postJoinerProjection with
- // {4, 0, 1, 5, 2, 3}.
- // Note that we don't need to pay attention to any filter planning
- // additions since those will be projected out before we will add this
- // "post-joiner" projection.
- var lOutIdx, rOutIdx uint32
- for _, col := range post.OutputColumns {
- if col < nLeftCols {
- planningState.postJoinerProjection = append(planningState.postJoinerProjection, lOutIdx)
- lOutIdx++
- } else {
- planningState.postJoinerProjection = append(planningState.postJoinerProjection, uint32(len(leftOutCols))+rOutIdx)
- rOutIdx++
- }
- }
- } else {
- for i := uint32(0); i < nLeftCols; i++ {
- leftOutCols = append(leftOutCols, i)
- }
- for i := uint32(0); i < nRightCols; i++ {
- rightOutCols = append(rightOutCols, i)
- }
- }
-
- if !post.Filter.Empty() {
- planningState.postFilterPlanning = makeFilterPlanningState(len(leftTypes), len(rightTypes))
- leftOutCols, rightOutCols, err = planningState.postFilterPlanning.renderAllNeededCols(
- post.Filter, leftOutCols, rightOutCols,
- )
- if err != nil {
- return err
- }
- }
-
- var (
- onExpr *execinfrapb.Expression
- onExprPlanning filterPlanningState
- )
- onExpr, onExprPlanning, leftOutCols, rightOutCols, err = createJoinOpWithOnExprPlanning(
- result, leftTypes, rightTypes, leftOutCols, rightOutCols,
- )
+ onExpr, err := createJoinOp(result, leftTypes, rightTypes)
if err != nil {
return err
}
- result.setProjectedByJoinerColumnTypes(spec, leftOutCols, rightOutCols)
+ result.ColumnTypes = append(result.ColumnTypes[:0], spec.Input[0].ColumnTypes...)
+ result.ColumnTypes = append(result.ColumnTypes, spec.Input[1].ColumnTypes...)
if onExpr != nil && joinType == sqlbase.JoinType_INNER {
// We will plan other Operators on top of the joiners, so we need to
@@ -254,9 +164,7 @@ func createJoiner(
if internalMemOp, ok := result.Op.(InternalMemoryOperator); ok {
result.InternalMemUsage += internalMemOp.InternalMemoryUsage()
}
-
- err = result.planFilterExpr(ctx, flowCtx.NewEvalCtx(), *onExpr, onExprPlanning.indexVarMap, acc)
- onExprPlanning.projectOutExtraCols(result)
+ err = result.planFilterExpr(ctx, flowCtx.NewEvalCtx(), *onExpr, acc)
}
return err
}
@@ -369,8 +277,6 @@ func NewColOperator(
core := &spec.Core
post := &spec.Post
- var planningState joinerPlanningState
-
// By default, we safely assume that an operator is not streaming. Note that
// projections, renders, filters, limits, offsets as well as all internal
// operators (like stats collectors and cancel checkers) are streaming, so in
@@ -614,23 +520,17 @@ func NewColOperator(
result.ColumnTypes = append(spec.Input[0].ColumnTypes, *types.Int)
case core.HashJoiner != nil:
- createHashJoinerWithOnExprPlanning := func(
+ createHashJoiner := func(
result *NewColOperatorResult,
leftTypes, rightTypes []coltypes.T,
- leftOutCols, rightOutCols []uint32,
- ) (*execinfrapb.Expression, filterPlanningState, []uint32, []uint32, error) {
+ ) (*execinfrapb.Expression, error) {
var (
- onExpr *execinfrapb.Expression
- onExprPlanning filterPlanningState
+ onExpr *execinfrapb.Expression
)
if !core.HashJoiner.OnExpr.Empty() {
onExpr = &core.HashJoiner.OnExpr
- onExprPlanning = makeFilterPlanningState(len(leftTypes), len(rightTypes))
- leftOutCols, rightOutCols, err = onExprPlanning.renderAllNeededCols(
- *onExpr, leftOutCols, rightOutCols,
- )
if err != nil {
- return onExpr, onExprPlanning, leftOutCols, rightOutCols, err
+ return onExpr, err
}
}
@@ -649,19 +549,16 @@ func NewColOperator(
inputs[1],
core.HashJoiner.LeftEqColumns,
core.HashJoiner.RightEqColumns,
- leftOutCols,
- rightOutCols,
leftTypes,
rightTypes,
rightEqColsAreKey,
core.HashJoiner.Type,
)
- return onExpr, onExprPlanning, leftOutCols, rightOutCols, err
+ return onExpr, err
}
err = createJoiner(
- ctx, &result, flowCtx, args, &planningState,
- core.HashJoiner.Type, createHashJoinerWithOnExprPlanning,
+ ctx, &result, flowCtx, args, core.HashJoiner.Type, createHashJoiner,
)
case core.MergeJoiner != nil:
@@ -672,14 +569,12 @@ func NewColOperator(
// for both of the inputs.
result.IsStreaming = core.MergeJoiner.LeftEqColumnsAreKey && core.MergeJoiner.RightEqColumnsAreKey
- createMergeJoinerWithOnExprPlanning := func(
+ createMergeJoiner := func(
result *NewColOperatorResult,
leftTypes, rightTypes []coltypes.T,
- leftOutCols, rightOutCols []uint32,
- ) (*execinfrapb.Expression, filterPlanningState, []uint32, []uint32, error) {
+ ) (*execinfrapb.Expression, error) {
var (
onExpr *execinfrapb.Expression
- onExprPlanning filterPlanningState
filterOnlyOnLeft bool
filterConstructor func(Operator) (Operator, error)
)
@@ -693,29 +588,22 @@ func NewColOperator(
result.IsStreaming = false
onExpr = &core.MergeJoiner.OnExpr
- onExprPlanning = makeFilterPlanningState(len(leftTypes), len(rightTypes))
switch core.MergeJoiner.Type {
- case sqlbase.JoinType_INNER:
- leftOutCols, rightOutCols, err = onExprPlanning.renderAllNeededCols(
- *onExpr, leftOutCols, rightOutCols,
- )
case sqlbase.JoinType_LEFT_SEMI, sqlbase.JoinType_LEFT_ANTI:
+ onExprPlanning := makeFilterPlanningState(len(leftTypes), len(rightTypes))
filterOnlyOnLeft, err = onExprPlanning.isFilterOnlyOnLeft(*onExpr)
filterConstructor = func(op Operator) (Operator, error) {
r := NewColOperatorResult{
Op: op,
ColumnTypes: append(spec.Input[0].ColumnTypes, spec.Input[1].ColumnTypes...),
}
- // We don't need to specify indexVarMap because the filter will be
- // run alongside the merge joiner, and it will have access to all
- // of the columns from both sides.
- err := r.planFilterExpr(ctx, flowCtx.NewEvalCtx(), *onExpr, nil /* indexVarMap */, streamingMemAccount)
+ err := r.planFilterExpr(ctx, flowCtx.NewEvalCtx(), *onExpr, streamingMemAccount)
return r.Op, err
}
}
}
if err != nil {
- return onExpr, onExprPlanning, leftOutCols, rightOutCols, err
+ return onExpr, err
}
mergeJoinerMemAccount := streamingMemAccount
@@ -728,8 +616,6 @@ func NewColOperator(
core.MergeJoiner.Type,
inputs[0],
inputs[1],
- leftOutCols,
- rightOutCols,
leftTypes,
rightTypes,
core.MergeJoiner.LeftOrdering.Columns,
@@ -737,12 +623,11 @@ func NewColOperator(
filterConstructor,
filterOnlyOnLeft,
)
- return onExpr, onExprPlanning, leftOutCols, rightOutCols, err
+ return onExpr, err
}
err = createJoiner(
- ctx, &result, flowCtx, args, &planningState,
- core.MergeJoiner.Type, createMergeJoinerWithOnExprPlanning,
+ ctx, &result, flowCtx, args, core.MergeJoiner.Type, createMergeJoiner,
)
case core.Sorter != nil:
@@ -914,19 +799,13 @@ func NewColOperator(
if !post.Filter.Empty() {
if err = result.planFilterExpr(
- ctx, flowCtx.NewEvalCtx(), post.Filter,
- planningState.postFilterPlanning.indexVarMap, streamingMemAccount,
+ ctx, flowCtx.NewEvalCtx(), post.Filter, streamingMemAccount,
); err != nil {
return result, err
}
- planningState.postFilterPlanning.projectOutExtraCols(&result)
}
if post.Projection {
- if len(planningState.postJoinerProjection) > 0 {
- result.addProjection(planningState.postJoinerProjection)
- } else {
- result.addProjection(post.OutputColumns)
- }
+ result.addProjection(post.OutputColumns)
} else if post.RenderExprs != nil {
log.VEventf(ctx, 2, "planning render expressions %+v", post.RenderExprs)
var renderedCols []uint32
@@ -971,13 +850,6 @@ func NewColOperator(
type filterPlanningState struct {
numLeftInputCols int
numRightInputCols int
- // indexVarMap will be populated when rendering all needed columns in case
- // when at least one column from either side is used by the filter.
- indexVarMap []int
- // originalLeftOutCols and originalRightOutCols are stored so that we can
- // remove all the extra columns that were added to handle the filter.
- originalLeftOutCols []uint32
- originalRightOutCols []uint32
}
func makeFilterPlanningState(numLeftInputCols, numRightInputCols int) filterPlanningState {
@@ -987,91 +859,6 @@ func makeFilterPlanningState(numLeftInputCols, numRightInputCols int) filterPlan
}
}
-// renderAllNeededCols makes sure that all columns used by filter expression
-// will be output. It does so by extracting the indices of all indexed vars
-// used in the expression and appending those that are missing from *OutCols
-// slices to the slices. Additionally, it populates p.indexVarMap to be used
-// later to correctly remap the indexed vars and stores the original *OutCols
-// to be projected after the filter has been run.
-// It returns updated leftOutCols and rightOutCols.
-// NOTE: projectOutExtraCols must be called after the filter has been run.
-func (p *filterPlanningState) renderAllNeededCols(
- filter execinfrapb.Expression, leftOutCols []uint32, rightOutCols []uint32,
-) ([]uint32, []uint32, error) {
- neededColumnsForFilter, err := findIVarsInRange(
- filter,
- 0, /* start */
- p.numLeftInputCols+p.numRightInputCols,
- )
- if err != nil {
- return nil, nil, errors.Errorf("error parsing filter expression %q: %s", filter, err)
- }
- if len(neededColumnsForFilter) > 0 {
- // Store the original out columns to be restored later.
- p.originalLeftOutCols = leftOutCols
- p.originalRightOutCols = rightOutCols
- // At least one column is referenced by the filter expression.
- p.indexVarMap = make([]int, p.numLeftInputCols+p.numRightInputCols)
- for i := range p.indexVarMap {
- p.indexVarMap[i] = -1
- }
- // First, we process only the left side.
- for i, lCol := range leftOutCols {
- p.indexVarMap[lCol] = i
- }
- for _, neededCol := range neededColumnsForFilter {
- if int(neededCol) < p.numLeftInputCols {
- if p.indexVarMap[neededCol] == -1 {
- p.indexVarMap[neededCol] = len(leftOutCols)
- leftOutCols = append(leftOutCols, neededCol)
- }
- }
- }
- // Now that we know how many columns from the left will be output, we can
- // process the right side.
- //
- // Here is the explanation of all the indices' dance below:
- // suppose we have two inputs with three columns in each, the filter
- // expression as @1 = @4 AND @3 = @5, and leftOutCols = {0} and
- // rightOutCols = {0} when this method was called. Note that only
- // ordinals in the expression are counting from 1, everything else is
- // zero-based.
- // - After we processed the left side above, we have the following state:
- // neededColumnsForFilter = {0, 2, 3, 4}
- // leftOutCols = {0, 2}
- // p.indexVarMap = {0, -1, 1, -1, -1, -1}
- // - We calculate rColOffset = 3 to know which columns for filter are from
- // the right side as well as to remap those for rightOutCols (the
- // remapping step is needed because rightOutCols "thinks" only in the
- // context of the right side).
- // - Next, we add already present rightOutCols to the indexed var map:
- // rightOutCols = {0}
- // p.indexVarMap = {0, -1, 1, 2, -1, -1}
- // Note that we needed to remap the column index, and we could do so only
- // after the left side has been processed because we need to know how
- // many columns will be output from the left.
- // - Then, we go through the needed columns for filter slice again, and add
- // any that are still missing to rightOutCols:
- // rightOutCols = {0, 1}
- // p.indexVarMap = {0, -1, 1, 2, 3, -1}
- // - We also stored the fact that we appended 1 extra column for both
- // inputs, and we will project those out.
- rColOffset := uint32(p.numLeftInputCols)
- for i, rCol := range rightOutCols {
- p.indexVarMap[rCol+rColOffset] = len(leftOutCols) + i
- }
- for _, neededCol := range neededColumnsForFilter {
- if neededCol >= rColOffset {
- if p.indexVarMap[neededCol] == -1 {
- p.indexVarMap[neededCol] = len(rightOutCols) + len(leftOutCols)
- rightOutCols = append(rightOutCols, neededCol-rColOffset)
- }
- }
- }
- }
- return leftOutCols, rightOutCols, nil
-}
-
// isFilterOnlyOnLeft returns whether the filter expression doesn't use columns
// from the right side.
func (p *filterPlanningState) isFilterOnlyOnLeft(filter execinfrapb.Expression) (bool, error) {
@@ -1085,33 +872,6 @@ func (p *filterPlanningState) isFilterOnlyOnLeft(filter execinfrapb.Expression)
return len(neededColumnsForFilter) == 0, nil
}
-// projectOutExtraCols, possibly, adds a projection to remove all the extra
-// columns that were needed by the filter expression.
-// NOTE: result.ColumnTypes is updated if the projection is added.
-func (p *filterPlanningState) projectOutExtraCols(result *NewColOperatorResult) {
- if p.indexVarMap == nil {
- // If p.indexVarMap is nil, then this filter planning didn't add any extra
- // columns, so there is nothing to project out.
- return
- }
- projection := make([]uint32, 0, len(p.originalLeftOutCols)+len(p.originalRightOutCols))
- for _, i := range p.originalLeftOutCols {
- projection = append(projection, uint32(p.indexVarMap[i]))
- }
- rColOffset := uint32(p.numLeftInputCols)
- for _, i := range p.originalRightOutCols {
- projection = append(projection, uint32(p.indexVarMap[rColOffset+i]))
- }
- result.Op = NewSimpleProjectOp(result.Op, len(result.ColumnTypes), projection)
-
- // Update output column types according to the projection.
- newTypes := make([]types.T, 0, len(projection))
- for _, j := range projection {
- newTypes = append(newTypes, result.ColumnTypes[j])
- }
- result.ColumnTypes = newTypes
-}
-
// createBufferingMemAccount instantiates a memory monitor and a memory account
// to be used with a buffering Operator. The receiver is updated to have
// references to both objects.
@@ -1142,33 +902,17 @@ func (r *NewColOperatorResult) createBufferingUnlimitedMemAccount(
return &bufferingMemAccount
}
-// setProjectedByJoinerColumnTypes sets column types on r according to a
-// joiner handled projection.
-// NOTE: r.ColumnTypes is updated.
-func (r *NewColOperatorResult) setProjectedByJoinerColumnTypes(
- spec *execinfrapb.ProcessorSpec, leftOutCols, rightOutCols []uint32,
-) {
- r.ColumnTypes = make([]types.T, 0, len(leftOutCols)+len(rightOutCols))
- for _, leftOutCol := range leftOutCols {
- r.ColumnTypes = append(r.ColumnTypes, spec.Input[0].ColumnTypes[leftOutCol])
- }
- for _, rightOutCol := range rightOutCols {
- r.ColumnTypes = append(r.ColumnTypes, spec.Input[1].ColumnTypes[rightOutCol])
- }
-}
-
func (r *NewColOperatorResult) planFilterExpr(
ctx context.Context,
evalCtx *tree.EvalContext,
filter execinfrapb.Expression,
- indexVarMap []int,
acc *mon.BoundAccount,
) error {
var (
helper execinfra.ExprHelper
selectionInternalMem int
)
- err := helper.InitWithRemapping(filter, r.ColumnTypes, evalCtx, indexVarMap)
+ err := helper.Init(filter, r.ColumnTypes, evalCtx)
if err != nil {
return err
}
diff --git a/pkg/sql/colexec/hashjoiner.go b/pkg/sql/colexec/hashjoiner.go
index b3d75808e2e9..6f777f0d6910 100644
--- a/pkg/sql/colexec/hashjoiner.go
+++ b/pkg/sql/colexec/hashjoiner.go
@@ -570,14 +570,22 @@ func NewEqHashJoinerOp(
rightSource Operator,
leftEqCols []uint32,
rightEqCols []uint32,
- leftOutCols []uint32,
- rightOutCols []uint32,
leftTypes []coltypes.T,
rightTypes []coltypes.T,
rightDistinct bool,
joinType sqlbase.JoinType,
) (Operator, error) {
var leftOuter, rightOuter bool
+ // TODO(yuzefovich): get rid of "outCols" entirely and plumb the assumption
+ // of outputting all columns into the hash joiner itself.
+ leftOutCols := make([]uint32, len(leftTypes))
+ for i := range leftOutCols {
+ leftOutCols[i] = uint32(i)
+ }
+ rightOutCols := make([]uint32, len(rightTypes))
+ for i := range rightOutCols {
+ rightOutCols[i] = uint32(i)
+ }
switch joinType {
case sqlbase.JoinType_INNER:
case sqlbase.JoinType_RIGHT_OUTER:
@@ -596,13 +604,9 @@ func NewEqHashJoinerOp(
// with the row on the right to emit it. However, we don't support ON
// conditions just yet. When we do, we'll have a separate case for that.
rightDistinct = true
- if len(rightOutCols) != 0 {
- return nil, errors.Errorf("semi-join can't have right-side output columns")
- }
+ rightOutCols = rightOutCols[:0]
case sqlbase.JoinType_LEFT_ANTI:
- if len(rightOutCols) != 0 {
- return nil, errors.Errorf("left anti join can't have right-side output columns")
- }
+ rightOutCols = rightOutCols[:0]
default:
return nil, errors.Errorf("hash join of type %s not supported", joinType)
}
diff --git a/pkg/sql/colexec/hashjoiner_test.go b/pkg/sql/colexec/hashjoiner_test.go
index 9b82a1e308bd..a44396fa888c 100644
--- a/pkg/sql/colexec/hashjoiner_test.go
+++ b/pkg/sql/colexec/hashjoiner_test.go
@@ -964,31 +964,6 @@ func TestHashJoiner(t *testing.T) {
}
}
-func TestHashJoinerOutputsOnlyRequestedColumns(t *testing.T) {
- defer leaktest.AfterTest(t)()
- for _, tc := range hjTestCases {
- leftSource := newOpTestInput(1, tc.leftTuples, tc.leftTypes)
- rightSource := newOpTestInput(1, tc.rightTuples, tc.rightTypes)
- hjOp, err := NewEqHashJoinerOp(
- testAllocator,
- leftSource, rightSource,
- tc.leftEqCols, tc.rightEqCols,
- tc.leftOutCols, tc.rightOutCols,
- tc.leftTypes, tc.rightTypes,
- tc.rightEqColsAreKey,
- tc.joinType)
- require.NoError(t, err)
- hjOp.Init()
- for {
- b := hjOp.Next(context.Background())
- if b.Length() == 0 {
- break
- }
- require.Equal(t, len(tc.leftOutCols)+(len(tc.rightOutCols)), b.Width())
- }
- }
-}
-
func BenchmarkHashJoiner(b *testing.B) {
ctx := context.Background()
nCols := 4
diff --git a/pkg/sql/colexec/mergejoiner.go b/pkg/sql/colexec/mergejoiner.go
index 8cd7857a763a..954212105d9b 100644
--- a/pkg/sql/colexec/mergejoiner.go
+++ b/pkg/sql/colexec/mergejoiner.go
@@ -178,8 +178,6 @@ func NewMergeJoinOp(
joinType sqlbase.JoinType,
left Operator,
right Operator,
- leftOutCols []uint32,
- rightOutCols []uint32,
leftTypes []coltypes.T,
rightTypes []coltypes.T,
leftOrdering []execinfrapb.Ordering_Column,
@@ -187,6 +185,19 @@ func NewMergeJoinOp(
filterConstructor func(Operator) (Operator, error),
filterOnlyOnLeft bool,
) (Operator, error) {
+ // TODO(yuzefovich): get rid off "outCols" entirely and plumb the assumption
+ // of outputting all columns into the merge joiner itself.
+ leftOutCols := make([]uint32, len(leftTypes))
+ for i := range leftOutCols {
+ leftOutCols[i] = uint32(i)
+ }
+ rightOutCols := make([]uint32, len(rightTypes))
+ for i := range rightOutCols {
+ rightOutCols[i] = uint32(i)
+ }
+ if joinType == sqlbase.JoinType_LEFT_SEMI || joinType == sqlbase.JoinType_LEFT_ANTI {
+ rightOutCols = rightOutCols[:0]
+ }
base, err := newMergeJoinBase(
allocator,
left,
diff --git a/pkg/sql/colexec/mergejoiner_test.go b/pkg/sql/colexec/mergejoiner_test.go
index ddf85c9dee09..9d42fc14f054 100644
--- a/pkg/sql/colexec/mergejoiner_test.go
+++ b/pkg/sql/colexec/mergejoiner_test.go
@@ -1650,8 +1650,6 @@ func TestFullOuterMergeJoinWithMaximumNumberOfGroups(t *testing.T) {
sqlbase.FullOuterJoin,
leftSource,
rightSource,
- []uint32{0},
- []uint32{0},
typs,
typs,
[]execinfrapb.Ordering_Column{{ColIdx: 0, Direction: execinfrapb.Ordering_Column_ASC}},
@@ -1729,8 +1727,6 @@ func TestMergeJoinerMultiBatch(t *testing.T) {
sqlbase.InnerJoin,
leftSource,
rightSource,
- []uint32{0},
- []uint32{0},
typs,
typs,
[]execinfrapb.Ordering_Column{{ColIdx: 0, Direction: execinfrapb.Ordering_Column_ASC}},
@@ -1813,8 +1809,6 @@ func TestMergeJoinerMultiBatchRuns(t *testing.T) {
sqlbase.InnerJoin,
leftSource,
rightSource,
- []uint32{0},
- []uint32{0},
typs,
typs,
[]execinfrapb.Ordering_Column{{ColIdx: 0, Direction: execinfrapb.Ordering_Column_ASC}, {ColIdx: 1, Direction: execinfrapb.Ordering_Column_ASC}},
@@ -1947,8 +1941,6 @@ func TestMergeJoinerRandomized(t *testing.T) {
sqlbase.InnerJoin,
leftSource,
rightSource,
- []uint32{0},
- []uint32{0},
typs,
typs,
[]execinfrapb.Ordering_Column{{ColIdx: 0, Direction: execinfrapb.Ordering_Column_ASC}},
diff --git a/pkg/sql/colexec/stats_test.go b/pkg/sql/colexec/stats_test.go
index 1f2059eb0085..0d76ee0df3d4 100644
--- a/pkg/sql/colexec/stats_test.go
+++ b/pkg/sql/colexec/stats_test.go
@@ -87,8 +87,6 @@ func TestVectorizedStatsCollector(t *testing.T) {
sqlbase.InnerJoin,
leftInput,
rightInput,
- []uint32{0},
- []uint32{0},
[]coltypes.T{coltypes.Int64},
[]coltypes.T{coltypes.Int64},
[]execinfrapb.Ordering_Column{{ColIdx: 0}},
diff --git a/pkg/sql/execinfra/expr.go b/pkg/sql/execinfra/expr.go
index e2a1a44a83da..e3b0446ff145 100644
--- a/pkg/sql/execinfra/expr.go
+++ b/pkg/sql/execinfra/expr.go
@@ -142,22 +142,13 @@ func (eh *ExprHelper) IndexedVarNodeFormatter(idx int) tree.NodeFormatter {
// Init initializes the ExprHelper.
func (eh *ExprHelper) Init(
expr execinfrapb.Expression, types []types.T, evalCtx *tree.EvalContext,
-) error {
- return eh.InitWithRemapping(expr, types, evalCtx, nil /* indexVarMap */)
-}
-
-// InitWithRemapping initializes the ExprHelper.
-// indexVarMap specifies an optional (i.e. it can be left nil) map that will be
-// used to remap the indices of IndexedVars before binding them to a container.
-func (eh *ExprHelper) InitWithRemapping(
- expr execinfrapb.Expression, types []types.T, evalCtx *tree.EvalContext, indexVarMap []int,
) error {
if expr.Empty() {
return nil
}
eh.evalCtx = evalCtx
eh.Types = types
- eh.Vars = tree.MakeIndexedVarHelperWithRemapping(eh, len(types), indexVarMap)
+ eh.Vars = tree.MakeIndexedVarHelper(eh, len(types))
if expr.LocalExpr != nil {
eh.Expr = expr.LocalExpr
diff --git a/pkg/sql/logictest/testdata/logic_test/dist_vectorize b/pkg/sql/logictest/testdata/logic_test/dist_vectorize
index 4e79c85e039e..b68572684a1e 100644
--- a/pkg/sql/logictest/testdata/logic_test/dist_vectorize
+++ b/pkg/sql/logictest/testdata/logic_test/dist_vectorize
@@ -144,25 +144,26 @@ EXPLAIN (VEC, VERBOSE) SELECT count(*) FROM kv NATURAL INNER HASH JOIN kv kv2
│ └ *colexec.distinctChainOps
│ └ *colexec.ParallelUnorderedSynchronizer
│ ├ *colexec.countOp
-│ │ └ *colexec.hashJoinEqOp
-│ │ ├ *colexec.ParallelUnorderedSynchronizer
-│ │ │ ├ *colexec.routerOutputOp
-│ │ │ │ └ *colexec.HashRouter
-│ │ │ │ └ *colexec.CancelChecker
-│ │ │ │ └ *colexec.colBatchScan
-│ │ │ ├ *colrpc.Inbox
-│ │ │ ├ *colrpc.Inbox
-│ │ │ ├ *colrpc.Inbox
-│ │ │ └ *colrpc.Inbox
-│ │ └ *colexec.ParallelUnorderedSynchronizer
-│ │ ├ *colexec.routerOutputOp
-│ │ │ └ *colexec.HashRouter
-│ │ │ └ *colexec.CancelChecker
-│ │ │ └ *colexec.colBatchScan
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colrpc.Inbox
-│ │ └ *colrpc.Inbox
+│ │ └ *colexec.simpleProjectOp
+│ │ └ *colexec.hashJoinEqOp
+│ │ ├ *colexec.ParallelUnorderedSynchronizer
+│ │ │ ├ *colexec.routerOutputOp
+│ │ │ │ └ *colexec.HashRouter
+│ │ │ │ └ *colexec.CancelChecker
+│ │ │ │ └ *colexec.colBatchScan
+│ │ │ ├ *colrpc.Inbox
+│ │ │ ├ *colrpc.Inbox
+│ │ │ ├ *colrpc.Inbox
+│ │ │ └ *colrpc.Inbox
+│ │ └ *colexec.ParallelUnorderedSynchronizer
+│ │ ├ *colexec.routerOutputOp
+│ │ │ └ *colexec.HashRouter
+│ │ │ └ *colexec.CancelChecker
+│ │ │ └ *colexec.colBatchScan
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colrpc.Inbox
+│ │ └ *colrpc.Inbox
│ ├ *colrpc.Inbox
│ ├ *colrpc.Inbox
│ ├ *colrpc.Inbox
@@ -171,94 +172,98 @@ EXPLAIN (VEC, VERBOSE) SELECT count(*) FROM kv NATURAL INNER HASH JOIN kv kv2
│ └ *colrpc.Outbox
│ └ *colexec.deselectorOp
│ └ *colexec.countOp
-│ └ *colexec.hashJoinEqOp
-│ ├ *colexec.ParallelUnorderedSynchronizer
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colexec.routerOutputOp
-│ │ │ └ *colexec.HashRouter
-│ │ │ └ *colexec.CancelChecker
-│ │ │ └ *colexec.colBatchScan
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colrpc.Inbox
-│ │ └ *colrpc.Inbox
-│ └ *colexec.ParallelUnorderedSynchronizer
-│ ├ *colrpc.Inbox
-│ ├ *colexec.routerOutputOp
-│ │ └ *colexec.HashRouter
-│ │ └ *colexec.CancelChecker
-│ │ └ *colexec.colBatchScan
-│ ├ *colrpc.Inbox
-│ ├ *colrpc.Inbox
-│ └ *colrpc.Inbox
+│ └ *colexec.simpleProjectOp
+│ └ *colexec.hashJoinEqOp
+│ ├ *colexec.ParallelUnorderedSynchronizer
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colexec.routerOutputOp
+│ │ │ └ *colexec.HashRouter
+│ │ │ └ *colexec.CancelChecker
+│ │ │ └ *colexec.colBatchScan
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colrpc.Inbox
+│ │ └ *colrpc.Inbox
+│ └ *colexec.ParallelUnorderedSynchronizer
+│ ├ *colrpc.Inbox
+│ ├ *colexec.routerOutputOp
+│ │ └ *colexec.HashRouter
+│ │ └ *colexec.CancelChecker
+│ │ └ *colexec.colBatchScan
+│ ├ *colrpc.Inbox
+│ ├ *colrpc.Inbox
+│ └ *colrpc.Inbox
├ Node 3
│ └ *colrpc.Outbox
│ └ *colexec.deselectorOp
│ └ *colexec.countOp
-│ └ *colexec.hashJoinEqOp
-│ ├ *colexec.ParallelUnorderedSynchronizer
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colexec.routerOutputOp
-│ │ │ └ *colexec.HashRouter
-│ │ │ └ *colexec.CancelChecker
-│ │ │ └ *colexec.colBatchScan
-│ │ ├ *colrpc.Inbox
-│ │ └ *colrpc.Inbox
-│ └ *colexec.ParallelUnorderedSynchronizer
-│ ├ *colrpc.Inbox
-│ ├ *colrpc.Inbox
-│ ├ *colexec.routerOutputOp
-│ │ └ *colexec.HashRouter
-│ │ └ *colexec.CancelChecker
-│ │ └ *colexec.colBatchScan
-│ ├ *colrpc.Inbox
-│ └ *colrpc.Inbox
+│ └ *colexec.simpleProjectOp
+│ └ *colexec.hashJoinEqOp
+│ ├ *colexec.ParallelUnorderedSynchronizer
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colexec.routerOutputOp
+│ │ │ └ *colexec.HashRouter
+│ │ │ └ *colexec.CancelChecker
+│ │ │ └ *colexec.colBatchScan
+│ │ ├ *colrpc.Inbox
+│ │ └ *colrpc.Inbox
+│ └ *colexec.ParallelUnorderedSynchronizer
+│ ├ *colrpc.Inbox
+│ ├ *colrpc.Inbox
+│ ├ *colexec.routerOutputOp
+│ │ └ *colexec.HashRouter
+│ │ └ *colexec.CancelChecker
+│ │ └ *colexec.colBatchScan
+│ ├ *colrpc.Inbox
+│ └ *colrpc.Inbox
├ Node 4
│ └ *colrpc.Outbox
│ └ *colexec.deselectorOp
│ └ *colexec.countOp
-│ └ *colexec.hashJoinEqOp
-│ ├ *colexec.ParallelUnorderedSynchronizer
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colrpc.Inbox
-│ │ ├ *colexec.routerOutputOp
-│ │ │ └ *colexec.HashRouter
-│ │ │ └ *colexec.CancelChecker
-│ │ │ └ *colexec.colBatchScan
-│ │ └ *colrpc.Inbox
-│ └ *colexec.ParallelUnorderedSynchronizer
-│ ├ *colrpc.Inbox
-│ ├ *colrpc.Inbox
-│ ├ *colrpc.Inbox
-│ ├ *colexec.routerOutputOp
-│ │ └ *colexec.HashRouter
-│ │ └ *colexec.CancelChecker
-│ │ └ *colexec.colBatchScan
-│ └ *colrpc.Inbox
+│ └ *colexec.simpleProjectOp
+│ └ *colexec.hashJoinEqOp
+│ ├ *colexec.ParallelUnorderedSynchronizer
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colrpc.Inbox
+│ │ ├ *colexec.routerOutputOp
+│ │ │ └ *colexec.HashRouter
+│ │ │ └ *colexec.CancelChecker
+│ │ │ └ *colexec.colBatchScan
+│ │ └ *colrpc.Inbox
+│ └ *colexec.ParallelUnorderedSynchronizer
+│ ├ *colrpc.Inbox
+│ ├ *colrpc.Inbox
+│ ├ *colrpc.Inbox
+│ ├ *colexec.routerOutputOp
+│ │ └ *colexec.HashRouter
+│ │ └ *colexec.CancelChecker
+│ │ └ *colexec.colBatchScan
+│ └ *colrpc.Inbox
└ Node 5
└ *colrpc.Outbox
└ *colexec.deselectorOp
└ *colexec.countOp
- └ *colexec.hashJoinEqOp
- ├ *colexec.ParallelUnorderedSynchronizer
- │ ├ *colrpc.Inbox
- │ ├ *colrpc.Inbox
- │ ├ *colrpc.Inbox
- │ ├ *colrpc.Inbox
- │ └ *colexec.routerOutputOp
- │ └ *colexec.HashRouter
- │ └ *colexec.CancelChecker
- │ └ *colexec.colBatchScan
- └ *colexec.ParallelUnorderedSynchronizer
- ├ *colrpc.Inbox
- ├ *colrpc.Inbox
- ├ *colrpc.Inbox
- ├ *colrpc.Inbox
- └ *colexec.routerOutputOp
- └ *colexec.HashRouter
- └ *colexec.CancelChecker
- └ *colexec.colBatchScan
+ └ *colexec.simpleProjectOp
+ └ *colexec.hashJoinEqOp
+ ├ *colexec.ParallelUnorderedSynchronizer
+ │ ├ *colrpc.Inbox
+ │ ├ *colrpc.Inbox
+ │ ├ *colrpc.Inbox
+ │ ├ *colrpc.Inbox
+ │ └ *colexec.routerOutputOp
+ │ └ *colexec.HashRouter
+ │ └ *colexec.CancelChecker
+ │ └ *colexec.colBatchScan
+ └ *colexec.ParallelUnorderedSynchronizer
+ ├ *colrpc.Inbox
+ ├ *colrpc.Inbox
+ ├ *colrpc.Inbox
+ ├ *colrpc.Inbox
+ └ *colexec.routerOutputOp
+ └ *colexec.HashRouter
+ └ *colexec.CancelChecker
+ └ *colexec.colBatchScan
# Test that SelOnDest flag of coldata.SliceArgs is respected when setting
# nulls.
diff --git a/pkg/sql/sem/tree/indexed_vars.go b/pkg/sql/sem/tree/indexed_vars.go
index 825b87b49ed8..6ea992354b56 100644
--- a/pkg/sql/sem/tree/indexed_vars.go
+++ b/pkg/sql/sem/tree/indexed_vars.go
@@ -118,12 +118,6 @@ func NewTypedOrdinalReference(r int, typ *types.T) *IndexedVar {
type IndexedVarHelper struct {
vars []IndexedVar
container IndexedVarContainer
-
- // indexVarMap is an optional mapping for indices of IndexedVars. If it is
- // not nil, it will be used to determine the "actual index" of an IndexedVar
- // before binding - instead of using ivar.Idx, a new IndexedVar will have
- // indexVarMap[ivar.Idx] as its index.
- indexVarMap []int
}
// Container returns the container associated with the helper.
@@ -131,22 +125,6 @@ func (h *IndexedVarHelper) Container() IndexedVarContainer {
return h.container
}
-// getIndex is a helper function that returns an "actual index" of the
-// IndexedVar.
-func (h *IndexedVarHelper) getIndex(ivar *IndexedVar) int {
- if ivar.Used {
- // ivar has already been bound, so the remapping step (if it was needed)
- // has already occurred.
- return ivar.Idx
- }
- if h.indexVarMap != nil {
- // indexVarMap is non-nil, so we need to remap the index.
- return h.indexVarMap[ivar.Idx]
- }
- // indexVarMap is nil, so we return the index as is.
- return ivar.Idx
-}
-
// BindIfUnbound ensures the IndexedVar is attached to this helper's container.
// - for freshly created IndexedVars (with a nil container) this will bind in-place.
// - for already bound IndexedVar, bound to this container, this will return the same ivar unchanged.
@@ -156,33 +134,22 @@ func (h *IndexedVarHelper) BindIfUnbound(ivar *IndexedVar) (*IndexedVar, error)
// We perform the range check always, even if the ivar is already
// bound, as a form of safety assertion against misreuse of ivars
// across containers.
- ivarIdx := h.getIndex(ivar)
- if ivarIdx < 0 || ivarIdx >= len(h.vars) {
+ if ivar.Idx < 0 || ivar.Idx >= len(h.vars) {
return ivar, pgerror.Newf(
- pgcode.UndefinedColumn, "invalid column ordinal: @%d", ivarIdx+1)
+ pgcode.UndefinedColumn, "invalid column ordinal: @%d", ivar.Idx+1)
}
if !ivar.Used {
- return h.IndexedVar(ivarIdx), nil
+ return h.IndexedVar(ivar.Idx), nil
}
return ivar, nil
}
// MakeIndexedVarHelper initializes an IndexedVarHelper structure.
func MakeIndexedVarHelper(container IndexedVarContainer, numVars int) IndexedVarHelper {
- return MakeIndexedVarHelperWithRemapping(container, numVars, nil /* indexVarMap */)
-}
-
-// MakeIndexedVarHelperWithRemapping initializes an IndexedVarHelper structure.
-// An optional (it can be left nil) indexVarMap argument determines a mapping
-// for indices of IndexedVars (see comment above for more details).
-func MakeIndexedVarHelperWithRemapping(
- container IndexedVarContainer, numVars int, indexVarMap []int,
-) IndexedVarHelper {
return IndexedVarHelper{
- vars: make([]IndexedVar, numVars),
- container: container,
- indexVarMap: indexVarMap,
+ vars: make([]IndexedVar, numVars),
+ container: container,
}
}
@@ -280,8 +247,7 @@ var _ Visitor = &IndexedVarHelper{}
// VisitPre implements the Visitor interface.
func (h *IndexedVarHelper) VisitPre(expr Expr) (recurse bool, newExpr Expr) {
if iv, ok := expr.(*IndexedVar); ok {
- ivarIdx := h.getIndex(iv)
- return false, h.IndexedVar(ivarIdx)
+ return false, h.IndexedVar(iv.Idx)
}
return true, expr
}
|
6d36e4bfc64d9b5ed442d3873b141acb228853ca
|
2024-03-29 22:27:00
|
Celia La
|
storage: set version to latest for TestWALFailover
| false
|
set version to latest for TestWALFailover
|
storage
|
diff --git a/pkg/storage/open_test.go b/pkg/storage/open_test.go
index bf9c8d1da710..2eb37a792e46 100644
--- a/pkg/storage/open_test.go
+++ b/pkg/storage/open_test.go
@@ -19,6 +19,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/clusterversion"
+ "github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/storage/fs"
"github.com/cockroachdb/cockroach/pkg/testutils/datapathutils"
@@ -111,15 +112,21 @@ func TestWALFailover(t *testing.T) {
}
openEnv.Ref()
- // Mock a cluster version, defaulting to 24.1.
- minVersionMajor, minVersionMinor := 24, 1
- minVersion := clusterversion.V24_1.Version()
- if td.MaybeScanArgs(t, "min-version", &minVersionMajor, &minVersionMinor) {
- // TODO(jackson): Add datadriven support for scanning into int32s so we can
- // scan directly into minVersion.
- minVersion.Major, minVersion.Minor = int32(minVersionMajor), int32(minVersionMinor)
+ // Mock a cluster version, defaulting to latest.
+ version := clusterversion.Latest.Version()
+ if td.HasArg("min-version") {
+ var major, minor int
+ td.ScanArgs(t, "min-version", &major, &minor)
+ version = roachpb.Version{
+ Major: int32(major),
+ Minor: int32(minor),
+ }
+ }
+ // Match the current offsetting policy.
+ if clusterversion.Latest.Version().Major > clusterversion.DevOffset {
+ version.Major += clusterversion.DevOffset
}
- settings := cluster.MakeTestingClusterSettingsWithVersions(minVersion, minVersion, true /* initializeVersion */)
+ settings := cluster.MakeTestingClusterSettingsWithVersions(version, version, true /* initializeVersion */)
// Mock an enterpise license, or not if disable-enterprise is specified.
enterpriseEnabledFunc := base.CCLDistributionAndEnterpriseEnabled
|
f3211ed3fcec7220016da186f81c532715a12037
|
2018-02-16 04:07:25
|
Pete Vilter
|
ui: style "up" button
| false
|
style "up" button
|
ui
|
diff --git a/pkg/ui/assets/arrowUp.svg b/pkg/ui/assets/arrowUp.svg
new file mode 100644
index 000000000000..8cff4394c22f
--- /dev/null
+++ b/pkg/ui/assets/arrowUp.svg
@@ -0,0 +1,10 @@
+<svg width="13" height="13" viewBox="0 0 13 13" version="1.1" xmlns="http://www.w3.org/2000/svg" xmlns:xlink="http://www.w3.org/1999/xlink">
+ <title>ic-arrow-up</title>
+ <desc>Created using Figma</desc>
+ <g transform="translate(12 1)">
+ <g transform="rotate(90)">
+ <path fill="#595F6C" id="path0_fill" d="M 10.6667 4.66667L 2.55333 4.66667L 6.28 0.94L 5.33333 0L 0 5.33333L 5.33333 10.6667L 6.27333 9.72667L 2.55333 6L 10.6667 6L 10.6667 4.66667Z"/>
+ <path fill="#595F6C" id="path1_stroke" d="M 10.6667 4.66667L 11.1667 4.66667L 11.1667 4.16667L 10.6667 4.16667L 10.6667 4.66667ZM 2.55333 4.66667L 2.19978 4.31311L 1.34623 5.16667L 2.55333 5.16667L 2.55333 4.66667ZM 6.28 0.94L 6.63355 1.29355L 6.98836 0.938748L 6.6323 0.5852L 6.28 0.94ZM 5.33333 0L 5.68564 -0.3548L 5.33209 -0.70586L 4.97978 -0.353553L 5.33333 0ZM 0 5.33333L -0.353553 4.97978L -0.707107 5.33333L -0.353553 5.68689L 0 5.33333ZM 5.33333 10.6667L 4.97978 11.0202L 5.33333 11.3738L 5.68689 11.0202L 5.33333 10.6667ZM 6.27333 9.72667L 6.62689 10.0802L 6.98012 9.72698L 6.6272 9.37343L 6.27333 9.72667ZM 2.55333 6L 2.55333 5.5L 1.34775 5.5L 2.19946 6.35324L 2.55333 6ZM 10.6667 6L 10.6667 6.5L 11.1667 6.5L 11.1667 6L 10.6667 6ZM 10.6667 4.16667L 2.55333 4.16667L 2.55333 5.16667L 10.6667 5.16667L 10.6667 4.16667ZM 2.90689 5.02022L 6.63355 1.29355L 5.92645 0.586447L 2.19978 4.31311L 2.90689 5.02022ZM 6.6323 0.5852L 5.68564 -0.3548L 4.98103 0.3548L 5.9277 1.2948L 6.6323 0.5852ZM 4.97978 -0.353553L -0.353553 4.97978L 0.353553 5.68689L 5.68689 0.353553L 4.97978 -0.353553ZM -0.353553 5.68689L 4.97978 11.0202L 5.68689 10.3131L 0.353553 4.97978L -0.353553 5.68689ZM 5.68689 11.0202L 6.62689 10.0802L 5.91978 9.37311L 4.97978 10.3131L 5.68689 11.0202ZM 6.6272 9.37343L 2.9072 5.64676L 2.19946 6.35324L 5.91946 10.0799L 6.6272 9.37343ZM 2.55333 6.5L 10.6667 6.5L 10.6667 5.5L 2.55333 5.5L 2.55333 6.5ZM 11.1667 6L 11.1667 4.66667L 10.1667 4.66667L 10.1667 6L 11.1667 6Z"/>
+ </g>
+ </g>
+</svg>
diff --git a/pkg/ui/ccl/src/views/clusterviz/containers/map/index.tsx b/pkg/ui/ccl/src/views/clusterviz/containers/map/index.tsx
index da6ee58a341b..e120176419f7 100644
--- a/pkg/ui/ccl/src/views/clusterviz/containers/map/index.tsx
+++ b/pkg/ui/ccl/src/views/clusterviz/containers/map/index.tsx
@@ -35,7 +35,7 @@ export default class ClusterVisualization extends React.Component<RouterState> {
<div style={{
flex: "none",
backgroundColor: "white",
- boxShadow: "0px 4px 5px 0px lightgrey",
+ boxShadow: "0 0 4px 0 rgba(0, 0, 0, 0.2)",
// height: 70,
zIndex: 5,
// display: "flex",
diff --git a/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeCanvas.tsx b/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeCanvas.tsx
index 2d9f47d17b2c..c6e85346ec6d 100644
--- a/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeCanvas.tsx
+++ b/pkg/ui/ccl/src/views/clusterviz/containers/map/nodeCanvas.tsx
@@ -19,6 +19,8 @@ import { LocalityTier, LocalityTree } from "src/redux/localities";
import { LocationTree } from "src/redux/locations";
import { CLUSTERVIZ_ROOT } from "src/routes/visualization";
import { generateLocalityRoute, getLocalityLabel } from "src/util/localities";
+import arrowUpIcon from "!!raw-loader!assets/arrowUp.svg";
+import { trustIcon } from "src/util/trust";
const BACK_BUTTON_OFFSET = 26;
@@ -99,9 +101,28 @@ export class NodeCanvas extends React.Component<NodeCanvasProps, NodeCanvasState
const parentLocality = tiers.slice(0, tiers.length - 1);
return (
- <div style={{ position: "absolute", left: BACK_BUTTON_OFFSET, bottom: BACK_BUTTON_OFFSET }}>
- <Link to={ "/overview/" + generateLocalityRoute(parentLocality) }>
- Back to { getLocalityLabel(parentLocality) }
+ <div
+ style={{
+ position: "absolute",
+ left: BACK_BUTTON_OFFSET,
+ bottom: BACK_BUTTON_OFFSET,
+ backgroundColor: "white",
+ border: "1px solid #EDEDED",
+ borderRadius: 3,
+ padding: 12,
+ boxShadow: "0px 0px 4px 0px rgba(0, 0, 0, 0.2)",
+ letterSpacing: 0.5,
+ }}
+ >
+ <Link
+ to={ "/overview/" + generateLocalityRoute(parentLocality) }
+ style={{ textDecoration: "none", color: "#595f6c" }}
+ >
+ <span dangerouslySetInnerHTML={trustIcon(arrowUpIcon)} style={{ position: "relative", top: 1 }} />
+ Up to{" "}
+ <span style={{ textTransform: "uppercase" }}>
+ { getLocalityLabel(parentLocality) }
+ </span>
</Link>
</div>
);
|
a1795900ce4f4f34e294f4faea437763440a2156
|
2021-08-03 19:07:51
|
Steven Danna
|
changefeedccl: allow changefeeds on regional by row tables
| false
|
allow changefeeds on regional by row tables
|
changefeedccl
|
diff --git a/pkg/ccl/changefeedccl/BUILD.bazel b/pkg/ccl/changefeedccl/BUILD.bazel
index 3edc07cf8d02..9e57cded7bcd 100644
--- a/pkg/ccl/changefeedccl/BUILD.bazel
+++ b/pkg/ccl/changefeedccl/BUILD.bazel
@@ -143,6 +143,7 @@ go_test(
"//pkg/ccl/importccl",
"//pkg/ccl/kvccl/kvtenantccl",
"//pkg/ccl/multiregionccl",
+ "//pkg/ccl/multiregionccl/multiregionccltestutils",
"//pkg/ccl/partitionccl",
"//pkg/ccl/storageccl",
"//pkg/ccl/utilccl",
diff --git a/pkg/ccl/changefeedccl/changefeed_test.go b/pkg/ccl/changefeedccl/changefeed_test.go
index 3c822f06a68f..b02c4fb792b9 100644
--- a/pkg/ccl/changefeedccl/changefeed_test.go
+++ b/pkg/ccl/changefeedccl/changefeed_test.go
@@ -1512,19 +1512,18 @@ func TestChangefeedFailOnTableOffline(t *testing.T) {
t.Run(`webhook`, webhookTest(testFn, feedTestNoTenants))
}
-func TestChangefeedFailOnRBRChange(t *testing.T) {
+func TestChangefeedWorksOnRBRChange(t *testing.T) {
defer leaktest.AfterTest(t)()
defer log.Scope(t).Close(t)
- rbrErrorRegex := regexp.MustCompile(`CHANGEFEED cannot target REGIONAL BY ROW tables: rbr`)
- testFn := func(t *testing.T, db *gosql.DB, f cdctest.TestFeedFactory) {
+ testFnJSON := func(t *testing.T, db *gosql.DB, f cdctest.TestFeedFactory) {
sqlDB := sqlutils.MakeSQLRunner(db)
sqlDB.Exec(t, "SET CLUSTER SETTING kv.closed_timestamp.target_duration = '50ms'")
- t.Run("regional by row change fails changefeed", func(t *testing.T) {
+ t.Run("regional by row change works", func(t *testing.T) {
sqlDB.Exec(t, `CREATE TABLE rbr (a INT PRIMARY KEY, b INT)`)
defer sqlDB.Exec(t, `DROP TABLE rbr`)
sqlDB.Exec(t, `INSERT INTO rbr VALUES (0, NULL)`)
- rbr := feed(t, f, `CREATE CHANGEFEED FOR rbr `)
+ rbr := feed(t, f, `CREATE CHANGEFEED FOR rbr`)
defer closeFeed(t, rbr)
sqlDB.Exec(t, `INSERT INTO rbr VALUES (1, 2)`)
assertPayloads(t, rbr, []string{
@@ -1532,9 +1531,54 @@ func TestChangefeedFailOnRBRChange(t *testing.T) {
`rbr: [1]->{"after": {"a": 1, "b": 2}}`,
})
sqlDB.Exec(t, `ALTER TABLE rbr SET LOCALITY REGIONAL BY ROW`)
- requireErrorSoon(context.Background(), t, rbr, rbrErrorRegex)
+ assertPayloads(t, rbr, []string{
+ `rbr: ["us-east-1", 0]->{"after": {"a": 0, "b": null, "crdb_region": "us-east-1"}}`,
+ `rbr: ["us-east-1", 1]->{"after": {"a": 1, "b": 2, "crdb_region": "us-east-1"}}`,
+ })
})
}
+ testFnAvro := func(t *testing.T, db *gosql.DB, f cdctest.TestFeedFactory) {
+ sqlDB := sqlutils.MakeSQLRunner(db)
+ sqlDB.Exec(t, "SET CLUSTER SETTING kv.closed_timestamp.target_duration = '50ms'")
+ schemaReg := cdctest.StartTestSchemaRegistry()
+ defer schemaReg.Close()
+
+ t.Run("regional by row change works", func(t *testing.T) {
+ sqlDB.Exec(t, `CREATE TABLE rbr (a INT PRIMARY KEY, b INT)`)
+ defer sqlDB.Exec(t, `DROP TABLE rbr`)
+ sqlDB.Exec(t, `INSERT INTO rbr VALUES (0, NULL)`)
+ rbr := feed(t, f, fmt.Sprintf("CREATE CHANGEFEED FOR rbr WITH format=experimental_avro, confluent_schema_registry='%s'", schemaReg.URL()))
+ defer closeFeed(t, rbr)
+ sqlDB.Exec(t, `INSERT INTO rbr VALUES (1, 2)`)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":0}}->{"after":{"rbr":{"a":{"long":0},"b":null}}}`,
+ `rbr: {"a":{"long":1}}->{"after":{"rbr":{"a":{"long":1},"b":{"long":2}}}}`,
+ })
+ sqlDB.Exec(t, `ALTER TABLE rbr SET LOCALITY REGIONAL BY ROW`)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":0},"crdb_region":{"string":"us-east-1"}}->{"after":{"rbr":{"a":{"long":0},"b":null,"crdb_region":{"string":"us-east-1"}}}}`,
+ `rbr: {"a":{"long":1},"crdb_region":{"string":"us-east-1"}}->{"after":{"rbr":{"a":{"long":1},"b":{"long":2},"crdb_region":{"string":"us-east-1"}}}}`,
+ })
+ })
+ t.Run("regional by row as change works", func(t *testing.T) {
+ sqlDB.Exec(t, `CREATE TABLE rbr (a INT PRIMARY KEY, b INT, region crdb_internal_region NOT NULL DEFAULT 'us-east-1')`)
+ defer sqlDB.Exec(t, `DROP TABLE rbr`)
+ sqlDB.Exec(t, `INSERT INTO rbr VALUES (0, NULL)`)
+ rbr := feed(t, f, fmt.Sprintf("CREATE CHANGEFEED FOR rbr WITH format=experimental_avro, confluent_schema_registry='%s'", schemaReg.URL()))
+ defer closeFeed(t, rbr)
+ sqlDB.Exec(t, `INSERT INTO rbr VALUES (1, 2)`)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":0}}->{"after":{"rbr":{"a":{"long":0},"b":null,"region":{"string":"us-east-1"}}}}`,
+ `rbr: {"a":{"long":1}}->{"after":{"rbr":{"a":{"long":1},"b":{"long":2},"region":{"string":"us-east-1"}}}}`,
+ })
+ sqlDB.Exec(t, `ALTER TABLE rbr SET LOCALITY REGIONAL BY ROW AS region`)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":0},"region":{"string":"us-east-1"}}->{"after":{"rbr":{"a":{"long":0},"b":null,"region":{"string":"us-east-1"}}}}`,
+ `rbr: {"a":{"long":1},"region":{"string":"us-east-1"}}->{"after":{"rbr":{"a":{"long":1},"b":{"long":2},"region":{"string":"us-east-1"}}}}`,
+ })
+ })
+ }
+
withTestServerRegion := func(args *base.TestServerArgs) {
args.Locality.Tiers = append(args.Locality.Tiers, roachpb.Tier{
Key: "region",
@@ -1551,11 +1595,48 @@ func TestChangefeedFailOnRBRChange(t *testing.T) {
feedTestNoTenants,
withArgsFn(withTestServerRegion),
}
- t.Run(`sinkless`, sinklessTest(testFn, opts...))
- t.Run(`enterprise`, enterpriseTest(testFn, opts...))
- t.Run(`cloudstorage`, cloudStorageTest(testFn, opts...))
- t.Run(`kafka`, kafkaTest(testFn, opts...))
- t.Run(`webhook`, webhookTest(testFn, opts...))
+ RunRandomSinkTest(t, "format=json", testFnJSON, opts...)
+ t.Run("kafka/format=avro", kafkaTest(testFnAvro, opts...))
+}
+
+func TestChangefeedRBRAvroAddRegion(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+ defer log.Scope(t).Close(t)
+
+ // We need a cluster here to make sure we have multiple active
+ // regions that we can add to the database.
+ cluster, db, cleanup := startTestCluster(t)
+ defer cleanup()
+
+ schemaReg := cdctest.StartTestSchemaRegistry()
+ defer schemaReg.Close()
+
+ f := makeKafkaFeedFactoryForCluster(cluster, db)
+ sqlDB := sqlutils.MakeSQLRunner(db)
+ sqlDB.Exec(t, `CREATE TABLE rbr (a INT PRIMARY KEY)`)
+ waitForSchemaChange(t, sqlDB, `ALTER TABLE rbr SET LOCALITY REGIONAL BY ROW`)
+ sqlDB.Exec(t, `INSERT INTO rbr VALUES (0)`)
+ rbr := feed(t, f, fmt.Sprintf("CREATE CHANGEFEED FOR rbr WITH format=experimental_avro, confluent_schema_registry='%s'", schemaReg.URL()))
+ defer closeFeed(t, rbr)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":0},"crdb_region":{"string":"us-east1"}}->{"after":{"rbr":{"a":{"long":0},"crdb_region":{"string":"us-east1"}}}}`,
+ })
+
+ // We do not expect a backfill from the ADD REGION, but we do
+ // expect the new rows with the added region to be encoded
+ // correctly.
+ sqlDB.Exec(t, `ALTER DATABASE d ADD REGION "us-east2"`)
+ sqlDB.Exec(t, `INSERT INTO rbr (crdb_region, a) VALUES ('us-east2', 1)`)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":1},"crdb_region":{"string":"us-east2"}}->{"after":{"rbr":{"a":{"long":1},"crdb_region":{"string":"us-east2"}}}}`,
+ })
+
+ // An update is seen as a DELETE and and INSERT
+ sqlDB.Exec(t, `UPDATE rbr SET crdb_region = 'us-east2' WHERE a = 0`)
+ assertPayloads(t, rbr, []string{
+ `rbr: {"a":{"long":0},"crdb_region":{"string":"us-east1"}}->{"after":null}`,
+ `rbr: {"a":{"long":0},"crdb_region":{"string":"us-east2"}}->{"after":{"rbr":{"a":{"long":0},"crdb_region":{"string":"us-east2"}}}}`,
+ })
}
func TestChangefeedStopOnSchemaChange(t *testing.T) {
@@ -2489,15 +2570,6 @@ func TestChangefeedErrors(t *testing.T) {
`EXPERIMENTAL CHANGEFEED FOR vw`,
)
- // Regional by row tables are not currently supported
- sqlDB.Exec(t, fmt.Sprintf(`ALTER DATABASE defaultdb PRIMARY REGION "%s"`, testServerRegion))
- sqlDB.Exec(t, `CREATE TABLE test_cdc_rbr_fails (a INT PRIMARY KEY)`)
- sqlDB.Exec(t, `ALTER TABLE test_cdc_rbr_fails SET LOCALITY REGIONAL BY ROW`)
- sqlDB.ExpectErr(
- t, `CHANGEFEED cannot target REGIONAL BY ROW tables: test_cdc_rbr_fails`,
- `CREATE CHANGEFEED FOR test_cdc_rbr_fails`,
- )
-
// Backup has the same bad error message #28170.
sqlDB.ExpectErr(
t, `"information_schema.tables" does not exist`,
diff --git a/pkg/ccl/changefeedccl/changefeedbase/validate.go b/pkg/ccl/changefeedccl/changefeedbase/validate.go
index 481305bac47e..ae6861bc26e4 100644
--- a/pkg/ccl/changefeedccl/changefeedbase/validate.go
+++ b/pkg/ccl/changefeedccl/changefeedbase/validate.go
@@ -39,9 +39,6 @@ func ValidateTable(targets jobspb.ChangefeedTargets, tableDesc catalog.TableDesc
if tableDesc.IsSequence() {
return errors.Errorf(`CHANGEFEED cannot target sequences: %s`, tableDesc.GetName())
}
- if tableDesc.IsLocalityRegionalByRow() {
- return errors.Errorf(`CHANGEFEED cannot target REGIONAL BY ROW tables: %s`, tableDesc.GetName())
- }
if len(tableDesc.GetFamilies()) != 1 {
return errors.Errorf(
`CHANGEFEEDs are currently supported on tables with exactly 1 column family: %s has %d`,
diff --git a/pkg/ccl/changefeedccl/helpers_test.go b/pkg/ccl/changefeedccl/helpers_test.go
index 961ff27760fa..46cd97d586ff 100644
--- a/pkg/ccl/changefeedccl/helpers_test.go
+++ b/pkg/ccl/changefeedccl/helpers_test.go
@@ -29,6 +29,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/ccl/changefeedccl/changefeedbase"
// Imported to allow locality-related table mutations
_ "github.com/cockroachdb/cockroach/pkg/ccl/multiregionccl"
+ "github.com/cockroachdb/cockroach/pkg/ccl/multiregionccl/multiregionccltestutils"
_ "github.com/cockroachdb/cockroach/pkg/ccl/partitionccl"
"github.com/cockroachdb/cockroach/pkg/jobs"
"github.com/cockroachdb/cockroach/pkg/security"
@@ -50,7 +51,7 @@ func waitForSchemaChange(
t testing.TB, sqlDB *sqlutils.SQLRunner, stmt string, arguments ...interface{},
) {
sqlDB.Exec(t, stmt, arguments...)
- row := sqlDB.QueryRow(t, "SELECT job_id FROM [SHOW JOBS] ORDER BY created DESC LIMIT 1")
+ row := sqlDB.QueryRow(t, "SELECT job_id FROM [SHOW JOBS] WHERE job_type = 'SCHEMA CHANGE' ORDER BY created DESC LIMIT 1")
var jobID string
row.Scan(&jobID)
@@ -394,6 +395,42 @@ func startTestFullServer(
return s, db, cleanup
}
+// startTestCluster starts a 3 node cluster.
+//
+// Note, if a testfeed depends on particular testing knobs, those may
+// need to be applied to each of the servers in the test cluster
+// returned from this function.
+func startTestCluster(t testing.TB) (serverutils.TestClusterInterface, *gosql.DB, func()) {
+ ctx := context.Background()
+ knobs := base.TestingKnobs{
+ DistSQL: &execinfra.TestingKnobs{Changefeed: &TestingKnobs{}},
+ JobsTestingKnobs: jobs.NewTestingKnobsWithShortIntervals(),
+ }
+
+ resetFlushFrequency := changefeedbase.TestingSetDefaultFlushFrequency(testSinkFlushFrequency)
+ cluster, db, cleanup := multiregionccltestutils.TestingCreateMultiRegionCluster(
+ t, 3 /* numServers */, knobs,
+ multiregionccltestutils.WithUseDatabase("d"),
+ )
+ cleanupAndReset := func() {
+ cleanup()
+ resetFlushFrequency()
+ }
+
+ var err error
+ defer func() {
+ if err != nil {
+ cleanupAndReset()
+ require.NoError(t, err)
+ }
+ }()
+ _, err = db.ExecContext(ctx, serverSetupStatements)
+ require.NoError(t, err)
+
+ _, err = db.ExecContext(ctx, `ALTER DATABASE d PRIMARY REGION "us-east1"`)
+ return cluster, db, cleanupAndReset
+}
+
func startTestTenant(
t testing.TB, options feedTestOptions,
) (serverutils.TestServerInterface, *gosql.DB, func()) {
@@ -508,6 +545,23 @@ func sinklessTestWithOptions(testFn cdcTestFn, opts feedTestOptions) func(*testi
}
}
+// RunRandomSink runs the testFn against one of a number of possible
+// sinks. Sinkless is not included in the possible sinks.
+func RunRandomSinkTest(t *testing.T, desc string, testFn cdcTestFn, testOpts ...feedTestOption) {
+ // TODO(ssd): It would be nice if explicitly selecting a test
+ // via -run/TESTS= would force it to always run.
+ switch p := rand.Float32(); {
+ case p < 0.20:
+ t.Run(fmt.Sprintf("enterprise/%s", desc), enterpriseTest(testFn, testOpts...))
+ case p < 0.40:
+ t.Run(fmt.Sprintf("cloudstorage/%s", desc), cloudStorageTest(testFn, testOpts...))
+ case p < 0.60:
+ t.Run(fmt.Sprintf("webhook/%s", desc), webhookTest(testFn, testOpts...))
+ default: // Run kafka a bit more often
+ t.Run(fmt.Sprintf("kafka/%s", desc), kafkaTest(testFn, testOpts...))
+ }
+}
+
func enterpriseTest(testFn cdcTestFn, testOpts ...feedTestOption) func(*testing.T) {
return enterpriseTestWithOptions(testFn, makeOptions(testOpts...))
}
diff --git a/pkg/ccl/changefeedccl/kvfeed/kv_feed.go b/pkg/ccl/changefeedccl/kvfeed/kv_feed.go
index cda554a46d49..be64fa21d8ac 100644
--- a/pkg/ccl/changefeedccl/kvfeed/kv_feed.go
+++ b/pkg/ccl/changefeedccl/kvfeed/kv_feed.go
@@ -125,15 +125,6 @@ func (e schemaChangeDetectedError) Error() string {
return fmt.Sprintf("schema change detected at %v", e.ts)
}
-type unsupportedSchemaChangeDetected struct {
- desc string
- ts hlc.Timestamp
-}
-
-func (e unsupportedSchemaChangeDetected) Error() string {
- return fmt.Sprintf("unsupported schema change %s detected at %s", e.desc, e.ts.AsOfSystemTime())
-}
-
type kvFeed struct {
spans []roachpb.Span
checkpoint []roachpb.Span
@@ -206,17 +197,7 @@ func (f *kvFeed) run(ctx context.Context) (err error) {
boundaryType := jobspb.ResolvedSpan_BACKFILL
if f.schemaChangePolicy == changefeedbase.OptSchemaChangePolicyStop {
boundaryType = jobspb.ResolvedSpan_EXIT
- } else if events, err := f.tableFeed.Peek(ctx, highWater.Next()); err == nil && isRegionalByRowChange(events) {
- // NOTE(ssd): The user is unlikely to see this
- // error. The schemafeed will fail with an
- // non-retriable error, meaning we likely
- // return right after runUntilTableEvent
- // above.
- return unsupportedSchemaChangeDetected{
- desc: "SET REGIONAL BY ROW",
- ts: highWater.Next(),
- }
- } else if err == nil && isPrimaryKeyChange(events) {
+ } else if events, err := f.tableFeed.Peek(ctx, highWater.Next()); err == nil && isPrimaryKeyChange(events) {
boundaryType = jobspb.ResolvedSpan_RESTART
} else if err != nil {
return err
@@ -247,15 +228,6 @@ func isPrimaryKeyChange(events []schemafeed.TableEvent) bool {
return false
}
-func isRegionalByRowChange(events []schemafeed.TableEvent) bool {
- for _, ev := range events {
- if schemafeed.IsRegionalByRowChange(ev) {
- return true
- }
- }
- return false
-}
-
// filterCheckpointSpans filters spans which have already been completed,
// and returns the list of spans that still need to be done.
func filterCheckpointSpans(spans []roachpb.Span, completed []roachpb.Span) []roachpb.Span {
diff --git a/pkg/ccl/changefeedccl/testfeed_test.go b/pkg/ccl/changefeedccl/testfeed_test.go
index c739871d5d3a..7a16329be342 100644
--- a/pkg/ccl/changefeedccl/testfeed_test.go
+++ b/pkg/ccl/changefeedccl/testfeed_test.go
@@ -437,27 +437,29 @@ type depInjector struct {
}
// newDepInjector configures specified server with necessary hooks and knobs.
-func newDepInjector(s feedInjectable) *depInjector {
+func newDepInjector(srvs ...feedInjectable) *depInjector {
di := &depInjector{
startedJobs: make(map[jobspb.JobID]*jobFeed),
}
di.cond = sync.NewCond(di)
- // Arrange for our wrapped sink to be instantiated.
- s.DistSQLServer().(*distsql.ServerImpl).TestingKnobs.Changefeed.(*TestingKnobs).WrapSink =
- func(s Sink, jobID jobspb.JobID) Sink {
- f := di.getJobFeed(jobID)
- return f.makeSink(s)
- }
+ for _, s := range srvs {
+ // Arrange for our wrapped sink to be instantiated.
+ s.DistSQLServer().(*distsql.ServerImpl).TestingKnobs.Changefeed.(*TestingKnobs).WrapSink =
+ func(s Sink, jobID jobspb.JobID) Sink {
+ f := di.getJobFeed(jobID)
+ return f.makeSink(s)
+ }
- // Arrange for error reporting resumer to be used.
- s.JobRegistry().(*jobs.Registry).TestingResumerCreationKnobs =
- map[jobspb.Type]func(raw jobs.Resumer) jobs.Resumer{
- jobspb.TypeChangefeed: func(raw jobs.Resumer) jobs.Resumer {
- f := di.getJobFeed(raw.(*changefeedResumer).job.ID())
- return &reportErrorResumer{wrapped: raw, jobFailed: f.jobFailed}
- },
- }
+ // Arrange for error reporting resumer to be used.
+ s.JobRegistry().(*jobs.Registry).TestingResumerCreationKnobs =
+ map[jobspb.Type]func(raw jobs.Resumer) jobs.Resumer{
+ jobspb.TypeChangefeed: func(raw jobs.Resumer) jobs.Resumer {
+ f := di.getJobFeed(raw.(*changefeedResumer).job.ID())
+ return &reportErrorResumer{wrapped: raw, jobFailed: f.jobFailed}
+ },
+ }
+ }
return di
}
@@ -1053,6 +1055,24 @@ func makeKafkaFeedFactory(
}
}
+// makeKafkaFeedFactoryForCluster returns a TestFeedFactory
+// implementation using the `kafka` uri.
+func makeKafkaFeedFactoryForCluster(
+ c serverutils.TestClusterInterface, db *gosql.DB,
+) cdctest.TestFeedFactory {
+ servers := make([]feedInjectable, c.NumServers())
+ for i := 0; i < c.NumServers(); i++ {
+ servers[i] = c.Server(i)
+ }
+ return &kafkaFeedFactory{
+ enterpriseFeedFactory: enterpriseFeedFactory{
+ s: c.Server(0),
+ db: db,
+ di: newDepInjector(servers...),
+ },
+ }
+}
+
func exprAsString(expr tree.Expr) (string, error) {
evalCtx := tree.NewTestingEvalContext(cluster.MakeTestingClusterSettings())
semaCtx := tree.MakeSemaContext()
diff --git a/pkg/ccl/multiregionccl/multiregionccltestutils/testutils.go b/pkg/ccl/multiregionccl/multiregionccltestutils/testutils.go
index 404133189169..fe7dea7a47e9 100644
--- a/pkg/ccl/multiregionccl/multiregionccltestutils/testutils.go
+++ b/pkg/ccl/multiregionccl/multiregionccltestutils/testutils.go
@@ -23,6 +23,7 @@ import (
type multiRegionTestClusterParams struct {
baseDir string
replicationMode base.TestClusterReplicationMode
+ useDatabase string
}
// MultiRegionTestClusterParamsOption is an option that can be passed to
@@ -47,6 +48,13 @@ func WithReplicationMode(
}
}
+// WithUseDatabase is an option to set the UseDatabase server option.
+func WithUseDatabase(db string) MultiRegionTestClusterParamsOption {
+ return func(params *multiRegionTestClusterParams) {
+ params.useDatabase = db
+ }
+}
+
// TestingCreateMultiRegionCluster creates a test cluster with numServers number
// of nodes and the provided testing knobs applied to each of the nodes. Every
// node is placed in its own locality, named "us-east1", "us-east2", and so on.
@@ -69,6 +77,7 @@ func TestingCreateMultiRegionCluster(
serverArgs[i] = base.TestServerArgs{
Knobs: knobs,
ExternalIODir: params.baseDir,
+ UseDatabase: params.useDatabase,
Locality: roachpb.Locality{
Tiers: []roachpb.Tier{{Key: "region", Value: regionNames[i]}},
},
|
4a3fb400a4480ae447cc88a4e113a67fac4d035a
|
2021-09-21 21:29:43
|
Jackson Owens
|
vendor: bump Pebble to 9509dcb7a53a
| false
|
bump Pebble to 9509dcb7a53a
|
vendor
|
diff --git a/DEPS.bzl b/DEPS.bzl
index 3586a45ac347..64754602b9a2 100644
--- a/DEPS.bzl
+++ b/DEPS.bzl
@@ -651,8 +651,8 @@ def go_deps():
name = "com_github_cockroachdb_pebble",
build_file_proto_mode = "disable_global",
importpath = "github.com/cockroachdb/pebble",
- sum = "h1:NBzearGbADR609fptc7ATDj14I2Gji7ne2mphj0j+r4=",
- version = "v0.0.0-20210914174700-0f7e73483566",
+ sum = "h1:BV8fDvAogQeaAUCgx/8/6J/Sv/enyfkJ10l5bTAcQWI=",
+ version = "v0.0.0-20210921140715-9509dcb7a53a",
)
go_repository(
diff --git a/go.mod b/go.mod
index e5879f88fc46..54a364eb63ba 100644
--- a/go.mod
+++ b/go.mod
@@ -44,7 +44,7 @@ require (
github.com/cockroachdb/go-test-teamcity v0.0.0-20191211140407-cff980ad0a55
github.com/cockroachdb/gostdlib v1.13.0
github.com/cockroachdb/logtags v0.0.0-20190617123548-eb05cc24525f
- github.com/cockroachdb/pebble v0.0.0-20210914174700-0f7e73483566
+ github.com/cockroachdb/pebble v0.0.0-20210921140715-9509dcb7a53a
github.com/cockroachdb/redact v1.1.3
github.com/cockroachdb/returncheck v0.0.0-20200612231554-92cdbca611dd
github.com/cockroachdb/sentry-go v0.6.1-cockroachdb.2
diff --git a/go.sum b/go.sum
index c34eedaa8f30..0aa939767b49 100644
--- a/go.sum
+++ b/go.sum
@@ -280,8 +280,8 @@ github.com/cockroachdb/gostdlib v1.13.0 h1:TzSEPYgkKDNei3gbLc0rrHu4iHyBp7/+NxPOF
github.com/cockroachdb/gostdlib v1.13.0/go.mod h1:eXX95p9QDrYwJfJ6AgeN9QnRa/lqqid9LAzWz/l5OgA=
github.com/cockroachdb/logtags v0.0.0-20190617123548-eb05cc24525f h1:o/kfcElHqOiXqcou5a3rIlMc7oJbMQkeLk0VQJ7zgqY=
github.com/cockroachdb/logtags v0.0.0-20190617123548-eb05cc24525f/go.mod h1:i/u985jwjWRlyHXQbwatDASoW0RMlZ/3i9yJHE2xLkI=
-github.com/cockroachdb/pebble v0.0.0-20210914174700-0f7e73483566 h1:NBzearGbADR609fptc7ATDj14I2Gji7ne2mphj0j+r4=
-github.com/cockroachdb/pebble v0.0.0-20210914174700-0f7e73483566/go.mod h1:JXfQr3d+XO4bL1pxGwKKo09xylQSdZ/mpZ9b2wfVcPs=
+github.com/cockroachdb/pebble v0.0.0-20210921140715-9509dcb7a53a h1:BV8fDvAogQeaAUCgx/8/6J/Sv/enyfkJ10l5bTAcQWI=
+github.com/cockroachdb/pebble v0.0.0-20210921140715-9509dcb7a53a/go.mod h1:JXfQr3d+XO4bL1pxGwKKo09xylQSdZ/mpZ9b2wfVcPs=
github.com/cockroachdb/redact v1.0.8/go.mod h1:BVNblN9mBWFyMyqK1k3AAiSxhvhfK2oOZZ2lK+dpvRg=
github.com/cockroachdb/redact v1.1.0/go.mod h1:BVNblN9mBWFyMyqK1k3AAiSxhvhfK2oOZZ2lK+dpvRg=
github.com/cockroachdb/redact v1.1.3 h1:AKZds10rFSIj7qADf0g46UixK8NNLwWTNdCIGS5wfSQ=
diff --git a/vendor b/vendor
index d3a6df5ee942..ac48f2d06202 160000
--- a/vendor
+++ b/vendor
@@ -1 +1 @@
-Subproject commit d3a6df5ee942c9014c859a9ea6d7fd45d96b238e
+Subproject commit ac48f2d062023423b36d7385baa405f03a387258
|
02ddc5a0135bdcdf284c82a7a6047e894a902924
|
2018-01-22 23:28:47
|
Alex Robinson
|
storage: Remove estimatedCommitIndex logic
| false
|
Remove estimatedCommitIndex logic
|
storage
|
diff --git a/pkg/storage/client_test.go b/pkg/storage/client_test.go
index fbe812d787f5..623a11d04428 100644
--- a/pkg/storage/client_test.go
+++ b/pkg/storage/client_test.go
@@ -927,11 +927,6 @@ func (m *multiTestContext) restartStoreWithoutHeartbeat(i int) {
log.Warning(ctx, err)
}
})
-
- // Normally, the newly restarted store would not be able to accept rebalances
- // until the election timeout passed. But we're using a manual clock which
- // won't advance the time properly, so manually enable incoming rebalances.
- m.stores[i].SetIncomingRebalancesDisabled(false)
}
// restartStore restarts a store previously stopped with StopStore.
diff --git a/pkg/storage/helpers_test.go b/pkg/storage/helpers_test.go
index a3986fd96498..0623dae751c5 100644
--- a/pkg/storage/helpers_test.go
+++ b/pkg/storage/helpers_test.go
@@ -22,7 +22,6 @@ package storage
import (
"context"
"fmt"
- "sync/atomic"
"time"
"github.com/pkg/errors"
@@ -194,14 +193,6 @@ func (s *Store) GetOrCreateReplica(
return s.getOrCreateReplica(ctx, rangeID, replicaID, creatingReplica)
}
-func (s *Store) SetIncomingRebalancesDisabled(v bool) {
- var i int32
- if v {
- i = 1
- }
- atomic.StoreInt32(&s.incomingRebalancesDisabled, i)
-}
-
// EnqueueRaftUpdateCheck enqueues the replica for a Raft update check, forcing
// the replica's Raft group into existence.
func (s *Store) EnqueueRaftUpdateCheck(rangeID roachpb.RangeID) {
diff --git a/pkg/storage/metrics.go b/pkg/storage/metrics.go
index 0d7ffd752f39..7bfdfa7111c7 100644
--- a/pkg/storage/metrics.go
+++ b/pkg/storage/metrics.go
@@ -297,9 +297,6 @@ var (
metaRaftLogFollowerBehindCount = metric.Metadata{
Name: "raftlog.behind",
Help: "Number of Raft log entries followers on other stores are behind"}
- metaRaftLogSelfBehindCount = metric.Metadata{
- Name: "raftlog.selfbehind",
- Help: "Number of Raft log entries followers on this store are behind"}
metaRaftLogTruncated = metric.Metadata{
Name: "raftlog.truncated",
Help: "Number of Raft log entries truncated"}
@@ -579,7 +576,6 @@ type StoreMetrics struct {
// Raft log metrics.
RaftLogFollowerBehindCount *metric.Gauge
- RaftLogSelfBehindCount *metric.Gauge
RaftLogTruncated *metric.Counter
// A map for conveniently finding the appropriate metric. The individual
@@ -772,7 +768,6 @@ func newStoreMetrics(histogramWindow time.Duration) *StoreMetrics {
// Raft log metrics.
RaftLogFollowerBehindCount: metric.NewGauge(metaRaftLogFollowerBehindCount),
- RaftLogSelfBehindCount: metric.NewGauge(metaRaftLogSelfBehindCount),
RaftLogTruncated: metric.NewCounter(metaRaftLogTruncated),
// Replica queue metrics.
diff --git a/pkg/storage/replica.go b/pkg/storage/replica.go
index b48c4e571f6e..435b819524cc 100644
--- a/pkg/storage/replica.go
+++ b/pkg/storage/replica.go
@@ -343,10 +343,6 @@ type Replica struct {
// from the Raft log entry. Use the invalidLastTerm constant for this
// case.
lastIndex, lastTerm uint64
- // The most recent commit index seen in a message from the leader. Used by
- // the follower to estimate the number of Raft log entries it is
- // behind. This field is only valid when the Replica is a follower.
- estimatedCommitIndex uint64
// The raft log index of a pending preemptive snapshot. Used to prohibit
// raft log truncation while a preemptive snapshot is in flight. A value of
// 0 indicates that there is no pending snapshot.
@@ -974,14 +970,6 @@ func (r *Replica) setReplicaIDRaftMuLockedMuLocked(replicaID roachpb.ReplicaID)
return nil
}
-func (r *Replica) setEstimatedCommitIndexLocked(commit uint64) {
- // The estimated commit index only ratchets up to account for Raft messages
- // arriving out of order.
- if r.mu.estimatedCommitIndex < commit {
- r.mu.estimatedCommitIndex = commit
- }
-}
-
func (r *Replica) maybeAcquireProposalQuota(ctx context.Context, quota int64) error {
r.mu.RLock()
quotaPool := r.mu.proposalQuota
@@ -1175,43 +1163,6 @@ func (r *Replica) updateProposalQuotaRaftMuLocked(
}
}
-// getEstimatedBehindCountRLocked returns an estimate of how far this replica is
-// behind. A return value of 0 indicates that the replica is up to date.
-func (r *Replica) getEstimatedBehindCountRLocked(raftStatus *raft.Status) int64 {
- if !r.isInitializedRLocked() || r.mu.replicaID == 0 || !r.mu.destroyStatus.IsAlive() {
- // The range is either not fully initialized, has been destroyed, or is slated for removal
- // (and thus likely ignored by its former Raft peers).
- return 0
- }
- if r.mu.quiescent {
- // The range is quiescent, so it is up to date.
- return 0
- }
- if raftStatus != nil && roachpb.ReplicaID(raftStatus.SoftState.Lead) == r.mu.replicaID {
- // We're the leader, so we can't be behind.
- return 0
- }
- if !HasRaftLeader(raftStatus) && r.store.canCampaignIdleReplica() {
- // The Raft group is idle or there is no Raft leader. This can be a
- // temporary situation due to an in progress election or because the group
- // can't achieve quorum. In either case, assume we're up to date.
- return 0
- }
- if r.mu.estimatedCommitIndex == 0 {
- // We haven't heard from the leader, assume we're far behind. This is the
- // case that is commonly hit when a node restarts. In particular, we hit
- // this case until an election timeout passes and canCampaignIdleReplica
- // starts to return true. The result is that a restarted node will
- // consider its replicas far behind initially which will in turn cause it
- // to reject rebalances.
- return prohibitRebalancesBehindThreshold + 1
- }
- if r.mu.estimatedCommitIndex >= r.mu.state.RaftAppliedIndex {
- return int64(r.mu.estimatedCommitIndex - r.mu.state.RaftAppliedIndex)
- }
- return 0
-}
-
// GetMaxBytes gets the range maximum byte limit.
func (r *Replica) GetMaxBytes() int64 {
r.mu.RLock()
@@ -3317,9 +3268,6 @@ func (r *Replica) stepRaftGroup(req *RaftMessageRequest) error {
// We're processing a message from another replica which means that the
// other replica is not quiesced, so we don't need to wake the leader.
r.unquiesceLocked()
- if req.Message.Type == raftpb.MsgApp {
- r.setEstimatedCommitIndexLocked(req.Message.Commit)
- }
r.refreshLastUpdateTimeForReplicaLocked(req.FromReplica.ReplicaID)
return false, /* unquiesceAndWakeLeader */
raftGroup.Step(req.Message)
@@ -3593,9 +3541,6 @@ func (r *Replica) handleRaftReadyRaftMuLocked(
r.mu.lastTerm = lastTerm
r.mu.raftLogSize = raftLogSize
r.mu.leaderID = leaderID
- if r.mu.replicaID == leaderID && !raft.IsEmptyHardState(rd.HardState) {
- r.setEstimatedCommitIndexLocked(rd.HardState.Commit)
- }
r.mu.Unlock()
r.sendRaftMessages(ctx, otherMsgs)
@@ -5785,7 +5730,6 @@ type ReplicaMetrics struct {
Unavailable bool
Underreplicated bool
BehindCount int64
- SelfBehindCount int64
CmdQMetricsLocal CommandQueueMetrics
CmdQMetricsGlobal CommandQueueMetrics
}
@@ -5802,7 +5746,6 @@ func (r *Replica) Metrics(
leaseStatus := r.leaseStatus(*r.mu.state.Lease, now, r.mu.minLeaseProposedTS)
quiescent := r.mu.quiescent || r.mu.internalRaftGroup == nil
desc := r.mu.state.Desc
- selfBehindCount := r.getEstimatedBehindCountRLocked(raftStatus)
r.cmdQMu.Lock()
cmdQMetricsLocal := r.cmdQMu.queues[spanset.SpanLocal].metrics()
cmdQMetricsGlobal := r.cmdQMu.queues[spanset.SpanGlobal].metrics()
@@ -5819,7 +5762,6 @@ func (r *Replica) Metrics(
leaseStatus,
r.store.StoreID(),
quiescent,
- selfBehindCount,
cmdQMetricsLocal,
cmdQMetricsGlobal,
)
@@ -5844,7 +5786,6 @@ func calcReplicaMetrics(
leaseStatus LeaseStatus,
storeID roachpb.StoreID,
quiescent bool,
- selfBehindCount int64,
cmdQMetricsLocal CommandQueueMetrics,
cmdQMetricsGlobal CommandQueueMetrics,
) ReplicaMetrics {
@@ -5860,9 +5801,6 @@ func calcReplicaMetrics(
m.Leaseholder = m.LeaseValid && leaseOwner
m.Leader = isRaftLeader(raftStatus)
m.Quiescent = quiescent
- if !m.Leader {
- m.SelfBehindCount = selfBehindCount
- }
// We gather per-range stats on either the leader or, if there is no leader,
// the first live replica in the descriptor. Note that the first live replica
diff --git a/pkg/storage/replica_test.go b/pkg/storage/replica_test.go
index 38dbe8e6e915..c62fd28dd305 100644
--- a/pkg/storage/replica_test.go
+++ b/pkg/storage/replica_test.go
@@ -8510,7 +8510,6 @@ func TestReplicaMetrics(t *testing.T) {
RangeCounter: false,
Unavailable: false,
Underreplicated: false,
- SelfBehindCount: 5,
}},
// Both replicas of a 2-replica range are live, but follower is behind.
{2, 1, desc(1, 2), status(1, progress(2, 1)), live(1, 2),
@@ -8601,7 +8600,6 @@ func TestReplicaMetrics(t *testing.T) {
RangeCounter: true,
Unavailable: false,
Underreplicated: false,
- SelfBehindCount: 15,
}},
// Range has no leader, local replica is the range counter.
{3, 3, desc(3, 2, 1), status(0, progress(2, 2, 2)), live(1, 2, 3),
@@ -8610,7 +8608,6 @@ func TestReplicaMetrics(t *testing.T) {
RangeCounter: true,
Unavailable: false,
Underreplicated: false,
- SelfBehindCount: 16,
}},
// Range has no leader, local replica is not the range counter.
{3, 2, desc(1, 2, 3), status(0, progress(2, 2, 2)), live(1, 2, 3),
@@ -8619,7 +8616,6 @@ func TestReplicaMetrics(t *testing.T) {
RangeCounter: false,
Unavailable: false,
Underreplicated: false,
- SelfBehindCount: 17,
}},
// Range has no leader, local replica is not the range counter.
{3, 3, desc(1, 2, 3), status(0, progress(2, 2, 2)), live(1, 2, 3),
@@ -8628,7 +8624,6 @@ func TestReplicaMetrics(t *testing.T) {
RangeCounter: false,
Unavailable: false,
Underreplicated: false,
- SelfBehindCount: 18,
}},
}
for i, c := range testCases {
@@ -8642,7 +8637,7 @@ func TestReplicaMetrics(t *testing.T) {
metrics := calcReplicaMetrics(
context.Background(), hlc.Timestamp{}, config.SystemConfig{},
c.liveness, &c.desc, c.raftStatus, LeaseStatus{},
- c.storeID, c.expected.Quiescent, int64(i+1), CommandQueueMetrics{}, CommandQueueMetrics{})
+ c.storeID, c.expected.Quiescent, CommandQueueMetrics{}, CommandQueueMetrics{})
if c.expected != metrics {
t.Fatalf("unexpected metrics:\n%s", pretty.Diff(c.expected, metrics))
}
diff --git a/pkg/storage/store.go b/pkg/storage/store.go
index 58344d35e0c2..531f94a48bf2 100644
--- a/pkg/storage/store.go
+++ b/pkg/storage/store.go
@@ -97,17 +97,9 @@ const (
// gossip update.
systemDataGossipInterval = 1 * time.Minute
- // prohibitRebalancesBehindThreshold is the maximum number of log entries a
- // store allows its replicas to be behind before it starts declining incoming
- // rebalances. We prohibit rebalances in this situation to avoid adding
- // additional work to a store that is either not keeping up or is undergoing
- // recovery because it is on a recently restarted node.
- prohibitRebalancesBehindThreshold = 1000
-
// Messages that provide detail about why a preemptive snapshot was rejected.
- incomingRebalancesDisabledMsg = "incoming rebalances disabled because node is behind"
- snapshotApplySemBusyMsg = "store busy applying snapshots and/or removing replicas"
- storeDrainingMsg = "store is draining"
+ snapshotApplySemBusyMsg = "store busy applying snapshots and/or removing replicas"
+ storeDrainingMsg = "store is draining"
// IntersectingSnapshotMsg is part of the error message returned from
// canApplySnapshotLocked and is exposed here so testing can rely on it.
@@ -405,11 +397,6 @@ type Store struct {
// data destruction.
snapshotApplySem chan struct{}
- // Are rebalances to this store allowed or prohibited. Rebalances are
- // prohibited while a store is catching up replicas (i.e. recovering) after
- // being restarted.
- incomingRebalancesDisabled int32
-
// draining holds a bool which indicates whether this store is draining. See
// SetDraining() for a more detailed explanation of behavior changes.
//
@@ -2824,9 +2811,6 @@ func (s *Store) reserveSnapshot(
// RESTORE or manual SPLIT AT, since it prevents these empty snapshots from
// getting stuck behind large snapshots managed by the replicate queue.
} else if header.CanDecline {
- if atomic.LoadInt32(&s.incomingRebalancesDisabled) == 1 {
- return nil, incomingRebalancesDisabledMsg, nil
- }
select {
case s.snapshotApplySem <- struct{}{}:
case <-ctx.Done():
@@ -4225,7 +4209,6 @@ func (s *Store) updateReplicationGauges(ctx context.Context) error {
unavailableRangeCount int64
underreplicatedRangeCount int64
behindCount int64
- selfBehindCount int64
)
timestamp := s.cfg.Clock.Now()
@@ -4265,7 +4248,6 @@ func (s *Store) updateReplicationGauges(ctx context.Context) error {
}
}
behindCount += metrics.BehindCount
- selfBehindCount += metrics.SelfBehindCount
if qps, dur := rep.writeStats.avgQPS(); dur >= MinStatsDuration {
averageWritesPerSecond += qps
}
@@ -4285,17 +4267,7 @@ func (s *Store) updateReplicationGauges(ctx context.Context) error {
s.metrics.UnavailableRangeCount.Update(unavailableRangeCount)
s.metrics.UnderReplicatedRangeCount.Update(underreplicatedRangeCount)
s.metrics.RaftLogFollowerBehindCount.Update(behindCount)
- s.metrics.RaftLogSelfBehindCount.Update(selfBehindCount)
- if selfBehindCount > prohibitRebalancesBehindThreshold {
- log.Infof(ctx, "temporarily disabling rebalances because RaftLogSelfBehindCount=%d", selfBehindCount)
- atomic.StoreInt32(&s.incomingRebalancesDisabled, 1)
- } else {
- prev := atomic.SwapInt32(&s.incomingRebalancesDisabled, 0)
- if prev == 1 {
- log.Infof(ctx, "re-enabling rebalances because RaftLogSelfBehindCount=%d", selfBehindCount)
- }
- }
return nil
}
|
ab7fbfb454beaf9728635f9d81efb73977158aa3
|
2018-08-15 00:52:28
|
Solon Gordon
|
distsql: account for AggregateFunc memory usage
| false
|
account for AggregateFunc memory usage
|
distsql
|
diff --git a/pkg/sql/distsqlrun/aggregator.go b/pkg/sql/distsqlrun/aggregator.go
index 18de754dd27b..55f16d8014cb 100644
--- a/pkg/sql/distsqlrun/aggregator.go
+++ b/pkg/sql/distsqlrun/aggregator.go
@@ -908,9 +908,11 @@ func (ag *aggregatorBase) createAggregateFuncs() (aggregateFuncs, error) {
}
bucket := make(aggregateFuncs, len(ag.funcs))
for i, f := range ag.funcs {
- // TODO(radu): we should account for the size of impl (this needs to be done
- // in each aggregate constructor).
- bucket[i] = f.create(ag.flowCtx.EvalCtx, f.arguments)
+ agg := f.create(ag.flowCtx.EvalCtx, f.arguments)
+ if err := ag.bucketsAcc.Grow(ag.Ctx, agg.Size()); err != nil {
+ return nil, err
+ }
+ bucket[i] = agg
}
return bucket, nil
}
diff --git a/pkg/sql/sem/builtins/aggregate_builtins.go b/pkg/sql/sem/builtins/aggregate_builtins.go
index 931577a8e160..f57bef0cc844 100644
--- a/pkg/sql/sem/builtins/aggregate_builtins.go
+++ b/pkg/sql/sem/builtins/aggregate_builtins.go
@@ -19,6 +19,7 @@ import (
"context"
"fmt"
"math"
+ "unsafe"
"github.com/cockroachdb/apd"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
@@ -377,11 +378,14 @@ func makeAggOverloadWithReturnType(
var _ tree.AggregateFunc = &arrayAggregate{}
var _ tree.AggregateFunc = &avgAggregate{}
var _ tree.AggregateFunc = &countAggregate{}
+var _ tree.AggregateFunc = &countRowsAggregate{}
var _ tree.AggregateFunc = &MaxAggregate{}
var _ tree.AggregateFunc = &MinAggregate{}
+var _ tree.AggregateFunc = &smallIntSumAggregate{}
var _ tree.AggregateFunc = &intSumAggregate{}
var _ tree.AggregateFunc = &decimalSumAggregate{}
var _ tree.AggregateFunc = &floatSumAggregate{}
+var _ tree.AggregateFunc = &intervalSumAggregate{}
var _ tree.AggregateFunc = &intSqrDiffAggregate{}
var _ tree.AggregateFunc = &floatSqrDiffAggregate{}
var _ tree.AggregateFunc = &decimalSqrDiffAggregate{}
@@ -393,8 +397,39 @@ var _ tree.AggregateFunc = &floatStdDevAggregate{}
var _ tree.AggregateFunc = &decimalStdDevAggregate{}
var _ tree.AggregateFunc = &anyNotNullAggregate{}
var _ tree.AggregateFunc = &concatAggregate{}
+var _ tree.AggregateFunc = &boolAndAggregate{}
+var _ tree.AggregateFunc = &boolOrAggregate{}
var _ tree.AggregateFunc = &bytesXorAggregate{}
var _ tree.AggregateFunc = &intXorAggregate{}
+var _ tree.AggregateFunc = &jsonAggregate{}
+
+const sizeOfArrayAggregate = int64(unsafe.Sizeof(arrayAggregate{}))
+const sizeOfAvgAggregate = int64(unsafe.Sizeof(avgAggregate{}))
+const sizeOfCountAggregate = int64(unsafe.Sizeof(countAggregate{}))
+const sizeOfCountRowsAggregate = int64(unsafe.Sizeof(countRowsAggregate{}))
+const sizeOfMaxAggregate = int64(unsafe.Sizeof(MaxAggregate{}))
+const sizeOfMinAggregate = int64(unsafe.Sizeof(MinAggregate{}))
+const sizeOfSmallIntSumAggregate = int64(unsafe.Sizeof(smallIntSumAggregate{}))
+const sizeOfIntSumAggregate = int64(unsafe.Sizeof(intSumAggregate{}))
+const sizeOfDecimalSumAggregate = int64(unsafe.Sizeof(decimalSumAggregate{}))
+const sizeOfFloatSumAggregate = int64(unsafe.Sizeof(floatSumAggregate{}))
+const sizeOfIntervalSumAggregate = int64(unsafe.Sizeof(intervalSumAggregate{}))
+const sizeOfIntSqrDiffAggregate = int64(unsafe.Sizeof(intSqrDiffAggregate{}))
+const sizeOfFloatSqrDiffAggregate = int64(unsafe.Sizeof(floatSqrDiffAggregate{}))
+const sizeOfDecimalSqrDiffAggregate = int64(unsafe.Sizeof(decimalSqrDiffAggregate{}))
+const sizeOfFloatSumSqrDiffsAggregate = int64(unsafe.Sizeof(floatSumSqrDiffsAggregate{}))
+const sizeOfDecimalSumSqrDiffsAggregate = int64(unsafe.Sizeof(decimalSumSqrDiffsAggregate{}))
+const sizeOfFloatVarianceAggregate = int64(unsafe.Sizeof(floatVarianceAggregate{}))
+const sizeOfDecimalVarianceAggregate = int64(unsafe.Sizeof(decimalVarianceAggregate{}))
+const sizeOfFloatStdDevAggregate = int64(unsafe.Sizeof(floatStdDevAggregate{}))
+const sizeOfDecimalStdDevAggregate = int64(unsafe.Sizeof(decimalStdDevAggregate{}))
+const sizeOfAnyNotNullAggregate = int64(unsafe.Sizeof(anyNotNullAggregate{}))
+const sizeOfConcatAggregate = int64(unsafe.Sizeof(concatAggregate{}))
+const sizeOfBoolAndAggregate = int64(unsafe.Sizeof(boolAndAggregate{}))
+const sizeOfBoolOrAggregate = int64(unsafe.Sizeof(boolOrAggregate{}))
+const sizeOfBytesXorAggregate = int64(unsafe.Sizeof(bytesXorAggregate{}))
+const sizeOfIntXorAggregate = int64(unsafe.Sizeof(intXorAggregate{}))
+const sizeOfJsonAggregate = int64(unsafe.Sizeof(jsonAggregate{}))
// See NewAnyNotNullAggregate.
type anyNotNullAggregate struct {
@@ -441,6 +476,11 @@ func (a *anyNotNullAggregate) Result() (tree.Datum, error) {
// Close is no-op in aggregates using constant space.
func (a *anyNotNullAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *anyNotNullAggregate) Size() int64 {
+ return sizeOfAnyNotNullAggregate
+}
+
type arrayAggregate struct {
arr *tree.DArray
acc mon.BoundAccount
@@ -477,6 +517,11 @@ func (a *arrayAggregate) Close(ctx context.Context) {
a.acc.Close(ctx)
}
+// Size is part of the tree.AggregateFunc interface.
+func (a *arrayAggregate) Size() int64 {
+ return sizeOfArrayAggregate
+}
+
type avgAggregate struct {
agg tree.AggregateFunc
count int
@@ -534,6 +579,11 @@ func (a *avgAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *avgAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *avgAggregate) Size() int64 {
+ return sizeOfAvgAggregate
+}
+
type concatAggregate struct {
forBytes bool
sawNonNull bool
@@ -637,6 +687,11 @@ func (a *concatAggregate) Close(ctx context.Context) {
a.acc.Close(ctx)
}
+// Size is part of the tree.AggregateFunc interface.
+func (a *concatAggregate) Size() int64 {
+ return sizeOfConcatAggregate
+}
+
type boolAndAggregate struct {
sawNonNull bool
result bool
@@ -668,6 +723,11 @@ func (a *boolAndAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *boolAndAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *boolAndAggregate) Size() int64 {
+ return sizeOfBoolAndAggregate
+}
+
type boolOrAggregate struct {
sawNonNull bool
result bool
@@ -696,6 +756,11 @@ func (a *boolOrAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *boolOrAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *boolOrAggregate) Size() int64 {
+ return sizeOfBoolOrAggregate
+}
+
type countAggregate struct {
count int
}
@@ -719,6 +784,11 @@ func (a *countAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *countAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *countAggregate) Size() int64 {
+ return sizeOfCountAggregate
+}
+
type countRowsAggregate struct {
count int
}
@@ -739,6 +809,11 @@ func (a *countRowsAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *countRowsAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *countRowsAggregate) Size() int64 {
+ return sizeOfCountRowsAggregate
+}
+
// MaxAggregate keeps track of the largest value passed to Add.
type MaxAggregate struct {
max tree.Datum
@@ -776,6 +851,11 @@ func (a *MaxAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *MaxAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *MaxAggregate) Size() int64 {
+ return sizeOfMaxAggregate
+}
+
// MinAggregate keeps track of the smallest value passed to Add.
type MinAggregate struct {
min tree.Datum
@@ -813,6 +893,11 @@ func (a *MinAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *MinAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *MinAggregate) Size() int64 {
+ return sizeOfMinAggregate
+}
+
type smallIntSumAggregate struct {
sum int64
seenNonNull bool
@@ -844,6 +929,11 @@ func (a *smallIntSumAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *smallIntSumAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *smallIntSumAggregate) Size() int64 {
+ return sizeOfSmallIntSumAggregate
+}
+
type intSumAggregate struct {
// Either the `intSum` and `decSum` fields contains the
// result. Which one is used is determined by the `large` field
@@ -912,6 +1002,11 @@ func (a *intSumAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *intSumAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *intSumAggregate) Size() int64 {
+ return sizeOfIntSumAggregate
+}
+
type decimalSumAggregate struct {
sum apd.Decimal
sawNonNull bool
@@ -948,6 +1043,11 @@ func (a *decimalSumAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *decimalSumAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *decimalSumAggregate) Size() int64 {
+ return sizeOfDecimalSumAggregate
+}
+
type floatSumAggregate struct {
sum float64
sawNonNull bool
@@ -979,6 +1079,11 @@ func (a *floatSumAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *floatSumAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *floatSumAggregate) Size() int64 {
+ return sizeOfFloatSumAggregate
+}
+
type intervalSumAggregate struct {
sum duration.Duration
sawNonNull bool
@@ -1010,6 +1115,11 @@ func (a *intervalSumAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *intervalSumAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *intervalSumAggregate) Size() int64 {
+ return sizeOfIntervalSumAggregate
+}
+
// Read-only constants used for square difference computations.
var (
decimalOne = apd.New(1, 0)
@@ -1056,6 +1166,11 @@ func (a *intSqrDiffAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *intSqrDiffAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *intSqrDiffAggregate) Size() int64 {
+ return sizeOfIntSqrDiffAggregate
+}
+
type floatSqrDiffAggregate struct {
count int64
mean float64
@@ -1108,6 +1223,11 @@ func (a *floatSqrDiffAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *floatSqrDiffAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *floatSqrDiffAggregate) Size() int64 {
+ return sizeOfFloatSqrDiffAggregate
+}
+
type decimalSqrDiffAggregate struct {
// Variables used across iterations.
ed *apd.ErrDecimal
@@ -1176,6 +1296,11 @@ func (a *decimalSqrDiffAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *decimalSqrDiffAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *decimalSqrDiffAggregate) Size() int64 {
+ return sizeOfDecimalSqrDiffAggregate
+}
+
type floatSumSqrDiffsAggregate struct {
count int64
mean float64
@@ -1241,6 +1366,11 @@ func (a *floatSumSqrDiffsAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *floatSumSqrDiffsAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *floatSumSqrDiffsAggregate) Size() int64 {
+ return sizeOfFloatSumSqrDiffsAggregate
+}
+
type decimalSumSqrDiffsAggregate struct {
// Variables used across iterations.
ed *apd.ErrDecimal
@@ -1329,6 +1459,11 @@ func (a *decimalSumSqrDiffsAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *decimalSumSqrDiffsAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *decimalSumSqrDiffsAggregate) Size() int64 {
+ return sizeOfDecimalSumSqrDiffsAggregate
+}
+
type floatSqrDiff interface {
tree.AggregateFunc
Count() int64
@@ -1439,9 +1574,19 @@ func (a *decimalVarianceAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *floatVarianceAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *floatVarianceAggregate) Size() int64 {
+ return sizeOfFloatVarianceAggregate
+}
+
// Close is part of the tree.AggregateFunc interface.
func (a *decimalVarianceAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *decimalVarianceAggregate) Size() int64 {
+ return sizeOfDecimalVarianceAggregate
+}
+
type floatStdDevAggregate struct {
agg tree.AggregateFunc
}
@@ -1541,9 +1686,19 @@ func (a *decimalStdDevAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *floatStdDevAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *floatStdDevAggregate) Size() int64 {
+ return sizeOfFloatStdDevAggregate
+}
+
// Close is part of the tree.AggregateFunc interface.
func (a *decimalStdDevAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *decimalStdDevAggregate) Size() int64 {
+ return sizeOfDecimalStdDevAggregate
+}
+
type bytesXorAggregate struct {
sum []byte
sawNonNull bool
@@ -1585,6 +1740,11 @@ func (a *bytesXorAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *bytesXorAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *bytesXorAggregate) Size() int64 {
+ return sizeOfBytesXorAggregate
+}
+
type intXorAggregate struct {
sum int64
sawNonNull bool
@@ -1616,6 +1776,11 @@ func (a *intXorAggregate) Result() (tree.Datum, error) {
// Close is part of the tree.AggregateFunc interface.
func (a *intXorAggregate) Close(context.Context) {}
+// Size is part of the tree.AggregateFunc interface.
+func (a *intXorAggregate) Size() int64 {
+ return sizeOfIntXorAggregate
+}
+
type jsonAggregate struct {
builder *json.ArrayBuilderWithCounter
acc mon.BoundAccount
@@ -1658,3 +1823,8 @@ func (a *jsonAggregate) Result() (tree.Datum, error) {
func (a *jsonAggregate) Close(ctx context.Context) {
a.acc.Close(ctx)
}
+
+// Size is part of the tree.AggregateFunc interface.
+func (a *jsonAggregate) Size() int64 {
+ return sizeOfJsonAggregate
+}
diff --git a/pkg/sql/sem/tree/aggregate_funcs.go b/pkg/sql/sem/tree/aggregate_funcs.go
index e71db598c6ff..83392c849227 100644
--- a/pkg/sql/sem/tree/aggregate_funcs.go
+++ b/pkg/sql/sem/tree/aggregate_funcs.go
@@ -36,4 +36,8 @@ type AggregateFunc interface {
// requested during aggregation, and must be called upon completion of the
// aggregation.
Close(context.Context)
+
+ // Size returns the size of the AggregateFunc implementation in bytes. It does
+ // not account for additional memory used during accumulation.
+ Size() int64
}
|
d47d52d2ce90a36bbadff1b54cd13eb906b051af
|
2017-04-13 20:35:19
|
Tamir Duberstein
|
acceptance: use builderImageFull consistently
| false
|
use builderImageFull consistently
|
acceptance
|
diff --git a/pkg/acceptance/cluster/localcluster.go b/pkg/acceptance/cluster/localcluster.go
index c04fbe3f6eb8..f78d6de076dc 100644
--- a/pkg/acceptance/cluster/localcluster.go
+++ b/pkg/acceptance/cluster/localcluster.go
@@ -386,7 +386,7 @@ func (l *LocalCluster) initCluster(ctx context.Context) {
}
if *cockroachImage == builderImageFull {
- maybePanic(pullImage(ctx, l, builderImage+":"+builderTag, types.ImagePullOptions{}))
+ maybePanic(pullImage(ctx, l, builderImageFull, types.ImagePullOptions{}))
}
c, err := createContainer(
ctx,
|
1bd2fc9e386a6b37d768ce9c17a074227b8889d5
|
2019-06-14 03:17:19
|
Rebecca Taft
|
distsqlrun: include nulls in distinct count for table statistics
| false
|
include nulls in distinct count for table statistics
|
distsqlrun
|
diff --git a/pkg/sql/distsqlrun/sample_aggregator_test.go b/pkg/sql/distsqlrun/sample_aggregator_test.go
index 51f7f6c21598..b33159576a02 100644
--- a/pkg/sql/distsqlrun/sample_aggregator_test.go
+++ b/pkg/sql/distsqlrun/sample_aggregator_test.go
@@ -178,7 +178,7 @@ func TestSampleAggregator(t *testing.T) {
name: "a",
colIDs: "{100}",
rowCount: 11,
- distinctCount: 2,
+ distinctCount: 3,
nullCount: 2,
},
{
@@ -186,7 +186,7 @@ func TestSampleAggregator(t *testing.T) {
name: "<NULL>",
colIDs: "{101}",
rowCount: 11,
- distinctCount: 8,
+ distinctCount: 9,
nullCount: 1,
buckets: []resultBucket{
{numEq: 2, numRange: 0, upper: 1},
diff --git a/pkg/sql/distsqlrun/sampler.go b/pkg/sql/distsqlrun/sampler.go
index c5a63d02b6f4..b242dcfcd60b 100644
--- a/pkg/sql/distsqlrun/sampler.go
+++ b/pkg/sql/distsqlrun/sampler.go
@@ -264,11 +264,11 @@ func (s *samplerProcessor) mainLoop(ctx context.Context) (earlyExit bool, err er
// columns.
col := s.sketches[i].spec.Columns[0]
s.sketches[i].numRows++
- if row[col].IsNull() {
+ isNull := row[col].IsNull()
+ if isNull {
s.sketches[i].numNulls++
- continue
}
- if s.outTypes[col].Family() == types.IntFamily {
+ if s.outTypes[col].Family() == types.IntFamily && !isNull {
// Fast path for integers.
// TODO(radu): make this more general.
val, err := row[col].GetInt()
diff --git a/pkg/sql/distsqlrun/sampler_test.go b/pkg/sql/distsqlrun/sampler_test.go
index bcb1bd1ab3c3..978019ae39d7 100644
--- a/pkg/sql/distsqlrun/sampler_test.go
+++ b/pkg/sql/distsqlrun/sampler_test.go
@@ -151,7 +151,7 @@ func TestSamplerSketch(t *testing.T) {
{-1, 3},
{1, -1},
}
- cardinalities := []int{2, 8}
+ cardinalities := []int{3, 9}
numNulls := []int{2, 1}
rows := sqlbase.GenEncDatumRowsInt(inputRows)
diff --git a/pkg/sql/logictest/testdata/logic_test/distsql_automatic_stats b/pkg/sql/logictest/testdata/logic_test/distsql_automatic_stats
index 29426f0129e1..50a474d53c9b 100644
--- a/pkg/sql/logictest/testdata/logic_test/distsql_automatic_stats
+++ b/pkg/sql/logictest/testdata/logic_test/distsql_automatic_stats
@@ -26,7 +26,7 @@ statistics_name column_names row_count distinct_count null_count
__auto__ {a} 1000 10 0
__auto__ {b} 1000 10 0
__auto__ {c} 1000 10 0
-__auto__ {d} 1000 0 1000
+__auto__ {d} 1000 1 1000
# Disable automatic stats
statement ok
@@ -45,7 +45,7 @@ statistics_name column_names row_count distinct_count null_count
__auto__ {a} 1000 10 0
__auto__ {b} 1000 10 0
__auto__ {c} 1000 10 0
-__auto__ {d} 1000 0 1000
+__auto__ {d} 1000 1 1000
# Enable automatic stats
statement ok
@@ -66,8 +66,8 @@ __auto__ {b} 1000 10 0
__auto__ {b} 1000 10 0
__auto__ {c} 1000 10 0
__auto__ {c} 1000 10 0
-__auto__ {d} 1000 0 1000
-__auto__ {d} 1000 1 730
+__auto__ {d} 1000 1 1000
+__auto__ {d} 1000 2 730
# Upsert more than 20% of the table.
statement ok
@@ -90,9 +90,9 @@ __auto__ {b} 1050 10 0
__auto__ {c} 1000 10 0
__auto__ {c} 1000 10 0
__auto__ {c} 1050 10 0
-__auto__ {d} 1000 0 1000
-__auto__ {d} 1000 1 730
-__auto__ {d} 1050 2 365
+__auto__ {d} 1000 1 1000
+__auto__ {d} 1000 2 730
+__auto__ {d} 1050 3 365
# Delete more than 20% of the table.
statement ok
@@ -115,9 +115,9 @@ __auto__ {c} 1000 10 0
__auto__ {c} 1000 10 0
__auto__ {c} 1050 10 0
__auto__ {c} 550 5 0
-__auto__ {d} 1000 0 1000
-__auto__ {d} 1000 1 730
-__auto__ {d} 1050 2 365
+__auto__ {d} 1000 1 1000
+__auto__ {d} 1000 2 730
+__auto__ {d} 1050 3 365
__auto__ {d} 550 1 0
# Test CREATE TABLE ... AS
diff --git a/pkg/sql/logictest/testdata/logic_test/distsql_stats b/pkg/sql/logictest/testdata/logic_test/distsql_stats
index 41de8b96199f..ff26427a3dd0 100644
--- a/pkg/sql/logictest/testdata/logic_test/distsql_stats
+++ b/pkg/sql/logictest/testdata/logic_test/distsql_stats
@@ -223,8 +223,8 @@ FROM [SHOW STATISTICS FOR TABLE simple]
----
statistics_name column_names row_count distinct_count null_count
default_stat2 {rowid} 1 1 0
-default_stat2 {y} 1 0 1
-default_stat2 {x} 1 0 1
+default_stat2 {y} 1 1 1
+default_stat2 {x} 1 1 1
#
# Test numeric references
@@ -431,4 +431,4 @@ FROM [SHOW STATISTICS FOR TABLE arr] ORDER BY statistics_name, column_names::STR
----
statistics_name column_names row_count distinct_count null_count
arr_stats {rowid} 4 4 0
-arr_stats {x} 4 2 1
+arr_stats {x} 4 3 1
|
d4c15ed1c04517c848cfc8972bcb9f757953dae0
|
2025-02-01 00:40:37
|
Andrew Kimball
|
sql: add schema support for vector indexing in CREATE TABLE
| false
|
add schema support for vector indexing in CREATE TABLE
|
sql
|
diff --git a/pkg/ccl/logictestccl/testdata/logic_test/refcursor b/pkg/ccl/logictestccl/testdata/logic_test/refcursor
index 42b14d324cc0..bf207e5707ab 100644
--- a/pkg/ccl/logictestccl/testdata/logic_test/refcursor
+++ b/pkg/ccl/logictestccl/testdata/logic_test/refcursor
@@ -573,29 +573,29 @@ statement ok
CREATE TABLE t112099_no_index (x INT NOT NULL, y TEXT NOT NULL, r REFCURSOR NOT NULL);
# REFCURSOR is not allowed in a primary key.
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
CREATE TABLE t112099 (r REFCURSOR PRIMARY KEY);
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
CREATE TABLE t112099 (x INT, y TEXT, r REFCURSOR, PRIMARY KEY (x, r, y));
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
ALTER TABLE t112099_no_index ADD PRIMARY KEY (r);
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
ALTER TABLE t112099_no_index ADD PRIMARY KEY (x, r, y);
# REFCURSOR is not allowed in a secondary index.
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
CREATE TABLE t112099 (r REFCURSOR, INDEX (r));
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
CREATE TABLE t112099 (x INT, y TEXT, r REFCURSOR, INDEX (x, r, y));
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
CREATE INDEX ON t112099_no_index (r);
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor, which is not indexable
CREATE INDEX ON t112099_no_index (x, r, y);
# Regression test for #115701 - REFCURSOR[] is not a valid index column.
@@ -605,40 +605,35 @@ statement ok
CREATE TABLE t115701_no_index (x INT NOT NULL, y TEXT NOT NULL, r REFCURSOR[] NOT NULL);
# REFCURSOR[] is not allowed in a primary key.
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE TABLE t115701 (r REFCURSOR[] PRIMARY KEY);
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE TABLE t115701 (x INT, y TEXT, r REFCURSOR[], PRIMARY KEY (x, r, y));
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
ALTER TABLE t115701_no_index ADD PRIMARY KEY (r);
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
ALTER TABLE t115701_no_index ADD PRIMARY KEY (x, r, y);
# REFCURSOR[] is not allowed in a secondary index.
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE TABLE t115701 (r REFCURSOR[], INDEX (r));
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE TABLE t115701 (x INT, y TEXT, r REFCURSOR[], INDEX (x, r, y));
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE INDEX ON t115701_no_index (r);
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE INDEX ON t115701_no_index (x, r, y);
-statement error pgcode 0A000 pq: column r of type refcursor\[\] is not allowed as the last column in an inverted index
+statement error pgcode 0A000 pq: column r has type refcursor\[\], which is not allowed as the last column in an inverted index
CREATE INDEX ON t115701_no_index USING GIN (r)
-skipif config local-legacy-schema-changer
-statement error pgcode 0A000 pq: unimplemented: column r is of type refcursor\[\] and thus is not indexable
-CREATE INDEX ON t115701_no_index USING GIN (x, r, y gin_trgm_ops)
-
-onlyif config local-legacy-schema-changer
-statement error pgcode 0A000 pq: column r of type refcursor\[\] is only allowed as the last column in an inverted index
+statement error pgcode 0A000 pq: unimplemented: column r has type refcursor\[\], which is not indexable
CREATE INDEX ON t115701_no_index USING GIN (x, r, y gin_trgm_ops)
# REFCURSOR is allowed as a STORING column.
diff --git a/pkg/ccl/logictestccl/testdata/logic_test/vector b/pkg/ccl/logictestccl/testdata/logic_test/vector
index 96c50cf6e829..16ccfd0238c2 100644
--- a/pkg/ccl/logictestccl/testdata/logic_test/vector
+++ b/pkg/ccl/logictestccl/testdata/logic_test/vector
@@ -12,7 +12,7 @@ CREATE TABLE v (v vector(0))
statement error pgcode 42601 dimensions for type vector cannot exceed 16000
CREATE TABLE v (v vector(16001))
-statement error column v is of type vector and thus is not indexable
+statement error column v has type vector, which is not indexable in a non-vector index
CREATE TABLE v (v vector(2) PRIMARY KEY)
statement ok
@@ -189,7 +189,4 @@ CREATE INDEX ON t_vec USING CSPANN (v);
statement ok
DROP TABLE t_vec;
-statement error pgcode 0A000 pq: unimplemented: VECTOR indexes are not yet supported
-CREATE TABLE t_vec (k INT PRIMARY KEY, v VECTOR(128), VECTOR INDEX (v));
-
subtest end
diff --git a/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go b/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go
index eb927c8fd045..aeced7b8e280 100644
--- a/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/3node-tenant/generated_test.go
@@ -2528,6 +2528,13 @@ func TestTenantLogic_values(
runLogicTest(t, "values")
}
+func TestTenantLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestTenantLogic_vectorize(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go b/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go
index a593f3c23355..462d41f51f25 100644
--- a/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-read-committed/generated_test.go
@@ -2505,6 +2505,13 @@ func TestReadCommittedLogic_values(
runLogicTest(t, "values")
}
+func TestReadCommittedLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestReadCommittedLogic_vectorize_agg(
t *testing.T,
) {
diff --git a/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go b/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go
index 489b45c7be34..a49f341381bd 100644
--- a/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go
+++ b/pkg/ccl/logictestccl/tests/local-repeatable-read/generated_test.go
@@ -2498,6 +2498,13 @@ func TestRepeatableReadLogic_values(
runLogicTest(t, "values")
}
+func TestRepeatableReadLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestRepeatableReadLogic_vectorize_agg(
t *testing.T,
) {
diff --git a/pkg/sql/catalog/BUILD.bazel b/pkg/sql/catalog/BUILD.bazel
index 023e720a54c5..7579bfcb0633 100644
--- a/pkg/sql/catalog/BUILD.bazel
+++ b/pkg/sql/catalog/BUILD.bazel
@@ -46,6 +46,7 @@ go_library(
"//pkg/sql/sessiondatapb",
"//pkg/sql/sqlclustersettings",
"//pkg/sql/types",
+ "//pkg/sql/vecindex/vecpb",
"//pkg/util",
"//pkg/util/hlc",
"//pkg/util/intsets",
diff --git a/pkg/sql/catalog/catformat/index.go b/pkg/sql/catalog/catformat/index.go
index b47c2d9c5d61..abe43b527f9d 100644
--- a/pkg/sql/catalog/catformat/index.go
+++ b/pkg/sql/catalog/catformat/index.go
@@ -102,8 +102,13 @@ func indexForDisplay(
if index.Unique {
f.WriteString("UNIQUE ")
}
- if !f.HasFlags(tree.FmtPGCatalog) && index.Type == idxtype.INVERTED {
- f.WriteString("INVERTED ")
+ if !f.HasFlags(tree.FmtPGCatalog) {
+ switch index.Type {
+ case idxtype.INVERTED:
+ f.WriteString("INVERTED ")
+ case idxtype.VECTOR:
+ f.WriteString("VECTOR ")
+ }
}
f.WriteString("INDEX ")
f.FormatNameP(&index.Name)
@@ -114,9 +119,12 @@ func indexForDisplay(
if f.HasFlags(tree.FmtPGCatalog) {
f.WriteString(" USING")
- if index.Type == idxtype.INVERTED {
+ switch index.Type {
+ case idxtype.INVERTED:
f.WriteString(" gin")
- } else {
+ case idxtype.VECTOR:
+ f.WriteString(" cspann")
+ default:
f.WriteString(" btree")
}
}
@@ -240,6 +248,8 @@ func FormatIndexElements(
} else {
f.FormatNameP(&index.KeyColumnNames[i])
}
+ // TODO(drewk): we might need to print something like "vector_l2_ops" for
+ // vector indexes.
if index.Type == idxtype.INVERTED &&
col.GetID() == index.InvertedColumnID() && len(index.InvertedColumnKinds) > 0 {
switch index.InvertedColumnKinds[0] {
@@ -247,10 +257,11 @@ func FormatIndexElements(
f.WriteString(" gin_trgm_ops")
}
}
- // The last column of an inverted index cannot have a DESC direction.
- // Since the default direction is ASC, we omit the direction entirely
- // for inverted index columns.
- if i < n-1 || index.Type != idxtype.INVERTED {
+ // The last column of an inverted or vector index cannot have a DESC
+ // direction because it does not have a linear ordering. Since the default
+ // direction is ASC, we omit the direction entirely for inverted/vector
+ // index columns.
+ if i < n-1 || index.Type.HasLinearOrdering() {
f.WriteByte(' ')
f.WriteString(index.KeyColumnDirections[i].String())
}
diff --git a/pkg/sql/catalog/catformat/index_test.go b/pkg/sql/catalog/catformat/index_test.go
index 22b67c65b5b4..2e0d02c426d0 100644
--- a/pkg/sql/catalog/catformat/index_test.go
+++ b/pkg/sql/catalog/catformat/index_test.go
@@ -112,6 +112,12 @@ func TestIndexForDisplay(t *testing.T) {
ColumnNames: []string{"a"},
}
+ // VECTOR INDEX baz (a)
+ vectorIndex := baseIndex
+ vectorIndex.Type = idxtype.VECTOR
+ vectorIndex.KeyColumnNames = []string{"a"}
+ vectorIndex.KeyColumnIDs = descpb.ColumnIDs{1}
+
testData := []struct {
index descpb.IndexDescriptor
tableName tree.TableName
@@ -266,6 +272,22 @@ func TestIndexForDisplay(t *testing.T) {
expected: "CREATE INDEX baz ON foo.public.bar (a DESC) USING HASH WITH (bucket_count=8)",
pgExpected: "CREATE INDEX baz ON foo.public.bar USING btree (a DESC) USING HASH WITH (bucket_count=8)",
},
+ {
+ index: vectorIndex,
+ tableName: descpb.AnonymousTable,
+ partition: "",
+ displayMode: IndexDisplayDefOnly,
+ expected: "VECTOR INDEX baz (a)",
+ pgExpected: "INDEX baz USING cspann (a)",
+ },
+ {
+ index: vectorIndex,
+ tableName: tableName,
+ partition: "",
+ displayMode: IndexDisplayShowCreate,
+ expected: "CREATE VECTOR INDEX baz ON foo.public.bar (a)",
+ pgExpected: "CREATE INDEX baz ON foo.public.bar USING cspann (a)",
+ },
}
sd := &sessiondata.SessionData{}
diff --git a/pkg/sql/catalog/colinfo/BUILD.bazel b/pkg/sql/catalog/colinfo/BUILD.bazel
index 7982e3e7ea60..cc2f2d1e5bc6 100644
--- a/pkg/sql/catalog/colinfo/BUILD.bazel
+++ b/pkg/sql/catalog/colinfo/BUILD.bazel
@@ -16,6 +16,7 @@ go_library(
importpath = "github.com/cockroachdb/cockroach/pkg/sql/catalog/colinfo",
visibility = ["//visibility:public"],
deps = [
+ "//pkg/docs",
"//pkg/settings/cluster",
"//pkg/sql/catalog",
"//pkg/sql/catalog/catpb",
@@ -24,7 +25,9 @@ go_library(
"//pkg/sql/pgwire/pgerror",
"//pkg/sql/sem/catconstants",
"//pkg/sql/sem/eval",
+ "//pkg/sql/sem/idxtype",
"//pkg/sql/sem/tree",
+ "//pkg/sql/sqlerrors",
"//pkg/sql/types",
"//pkg/util/encoding",
"//pkg/util/errorutil/unimplemented",
diff --git a/pkg/sql/catalog/colinfo/col_type_info.go b/pkg/sql/catalog/colinfo/col_type_info.go
index 09ae9b82b4be..857cae4838d9 100644
--- a/pkg/sql/catalog/colinfo/col_type_info.go
+++ b/pkg/sql/catalog/colinfo/col_type_info.go
@@ -9,10 +9,13 @@ import (
"context"
"fmt"
+ "github.com/cockroachdb/cockroach/pkg/docs"
"github.com/cockroachdb/cockroach/pkg/settings/cluster"
"github.com/cockroachdb/cockroach/pkg/sql/catalog"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgcode"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
+ "github.com/cockroachdb/cockroach/pkg/sql/sqlerrors"
"github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/errorutil/unimplemented"
"github.com/cockroachdb/errors"
@@ -172,6 +175,12 @@ func ColumnTypeIsOnlyInvertedIndexable(t *types.T) bool {
return true
}
+// ColumnTypeIsVectorIndexable returns true if the type t can be indexed using a
+// vector index.
+func ColumnTypeIsVectorIndexable(t *types.T) bool {
+ return t.Family() == types.PGVectorFamily
+}
+
// MustBeValueEncoded returns true if columns of the given kind can only be value
// encoded.
func MustBeValueEncoded(semanticType *types.T) bool {
@@ -192,3 +201,72 @@ func MustBeValueEncoded(semanticType *types.T) bool {
}
return false
}
+
+// ValidateColumnForIndex checks that the given column type is allowed in the
+// given index. If "isLastCol" is true, then it is the last column in the index.
+// "colDesc" can either be a column name or an expression in the form (a + b).
+func ValidateColumnForIndex(
+ indexType idxtype.T, colDesc string, colType *types.T, isLastCol bool,
+) error {
+ // Inverted and vector indexes only allow certain types for the last column.
+ if isLastCol {
+ switch indexType {
+ case idxtype.INVERTED:
+ if !ColumnTypeIsInvertedIndexable(colType) {
+ return sqlerrors.NewInvalidLastColumnError(colDesc, colType.Name(), indexType)
+ }
+ return nil
+
+ case idxtype.VECTOR:
+ if !ColumnTypeIsVectorIndexable(colType) {
+ return sqlerrors.NewInvalidLastColumnError(colDesc, colType.Name(), indexType)
+ } else if colType.Width() <= 0 {
+ return errors.WithDetail(
+ pgerror.Newf(
+ pgcode.FeatureNotSupported,
+ "%s column %s does not have a fixed number of dimensions, so it cannot be indexed",
+ colType.Name(), colDesc,
+ ),
+ "specify the number of dimensions in the type, like VECTOR(128) for 128 dimensions",
+ )
+ }
+ return nil
+ }
+ }
+
+ if !ColumnTypeIsIndexable(colType) {
+ // If the column is indexable as the last column in the right kind of
+ // index, then use a more descriptive error message.
+ if ColumnTypeIsInvertedIndexable(colType) {
+ if indexType == idxtype.INVERTED {
+ // Column type is allowed, but only as the last column.
+ return sqlerrors.NewColumnOnlyIndexableError(colDesc, colType.Name(), idxtype.INVERTED)
+ }
+
+ // Column type is allowed in an inverted index.
+ return errors.WithHint(pgerror.Newf(
+ pgcode.FeatureNotSupported,
+ "column %s has type %s, which is not indexable in a non-inverted index",
+ colDesc, colType),
+ "you may want to create an inverted index instead. See the documentation for inverted indexes: "+docs.URL("inverted-indexes.html"))
+ }
+
+ if ColumnTypeIsVectorIndexable(colType) {
+ if indexType == idxtype.VECTOR {
+ // Column type is allowed, but only as the last column.
+ return sqlerrors.NewColumnOnlyIndexableError(colDesc, colType.Name(), idxtype.VECTOR)
+ }
+
+ // Column type is allowed in a vector index.
+ return errors.WithHint(pgerror.Newf(
+ pgcode.FeatureNotSupported,
+ "column %s has type %s, which is not indexable in a non-vector index",
+ colDesc, colType),
+ "you may want to create a vector index instead")
+ }
+
+ return sqlerrors.NewColumnNotIndexableError(colDesc, colType.Name(), colType.DebugString())
+ }
+
+ return nil
+}
diff --git a/pkg/sql/catalog/descpb/index.go b/pkg/sql/catalog/descpb/index.go
index 49c01f8f21ed..bdaaf6d07966 100644
--- a/pkg/sql/catalog/descpb/index.go
+++ b/pkg/sql/catalog/descpb/index.go
@@ -97,7 +97,7 @@ func (desc *IndexDescriptor) GetName() string {
}
// InvertedColumnID returns the ColumnID of the inverted column of the inverted
-// index. This is always the last column in ColumnIDs. Panics if the index is
+// index. This is always the last column in KeyColumnIDs. Panics if the index is
// not inverted.
func (desc *IndexDescriptor) InvertedColumnID() ColumnID {
if desc.Type != idxtype.INVERTED {
@@ -126,3 +126,23 @@ func (desc *IndexDescriptor) InvertedColumnKeyType() *types.T {
}
return types.EncodedKey
}
+
+// VectorColumnID returns the ColumnID of the vector column of the vector index.
+// This is always the last column in KeyColumnIDs. Panics if the index is not a
+// vector index.
+func (desc *IndexDescriptor) VectorColumnID() ColumnID {
+ if desc.Type != idxtype.VECTOR {
+ panic(errors.AssertionFailedf("index is not a vector index"))
+ }
+ return desc.KeyColumnIDs[len(desc.KeyColumnIDs)-1]
+}
+
+// VectorColumnName returns the name of the vector column of the vector index.
+// This is always the last column in KeyColumnNames. Panics if the index is
+// not a vector index.
+func (desc *IndexDescriptor) VectorColumnName() string {
+ if desc.Type != idxtype.VECTOR {
+ panic(errors.AssertionFailedf("index is not a vector index"))
+ }
+ return desc.KeyColumnNames[len(desc.KeyColumnNames)-1]
+}
diff --git a/pkg/sql/catalog/table_elements.go b/pkg/sql/catalog/table_elements.go
index b0fcd25f73e9..4625e132195b 100644
--- a/pkg/sql/catalog/table_elements.go
+++ b/pkg/sql/catalog/table_elements.go
@@ -21,6 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/semenumpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
"github.com/cockroachdb/cockroach/pkg/sql/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/vecindex/vecpb"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/intsets"
"github.com/cockroachdb/cockroach/pkg/util/iterutil"
@@ -174,6 +175,7 @@ type Index interface {
GetPredicate() string
GetType() idxtype.T
GetGeoConfig() geopb.Config
+ GetVecConfig() vecpb.Config
GetVersion() descpb.IndexDescriptorVersion
GetEncodingType() catenumpb.IndexDescriptorEncodingType
@@ -223,6 +225,18 @@ type Index interface {
// index.
InvertedColumnKind() catpb.InvertedIndexColumnKind
+ // VectorColumnName returns the name of the vector column of the vector
+ // index.
+ //
+ // Panics if the index is not a vector index.
+ VectorColumnName() string
+
+ // VectorColumnID returns the ColumnID of the vector column of the vector
+ // index.
+ //
+ // Panics if the index is not a vector index.
+ VectorColumnID() descpb.ColumnID
+
NumPrimaryStoredColumns() int
NumSecondaryStoredColumns() int
GetStoredColumnID(storedColumnOrdinal int) descpb.ColumnID
diff --git a/pkg/sql/catalog/tabledesc/BUILD.bazel b/pkg/sql/catalog/tabledesc/BUILD.bazel
index 3e09efc8f559..5f1e15b597ca 100644
--- a/pkg/sql/catalog/tabledesc/BUILD.bazel
+++ b/pkg/sql/catalog/tabledesc/BUILD.bazel
@@ -21,7 +21,6 @@ go_library(
visibility = ["//visibility:public"],
deps = [
"//pkg/clusterversion",
- "//pkg/docs",
"//pkg/geo/geopb",
"//pkg/jobs/jobspb",
"//pkg/keys",
@@ -59,6 +58,7 @@ go_library(
"//pkg/sql/sem/volatility",
"//pkg/sql/sqlerrors",
"//pkg/sql/types",
+ "//pkg/sql/vecindex/vecpb",
"//pkg/util",
"//pkg/util/errorutil/unimplemented",
"//pkg/util/hlc",
@@ -122,6 +122,7 @@ go_test(
"//pkg/sql/sem/idxtype",
"//pkg/sql/sem/semenumpb",
"//pkg/sql/types",
+ "//pkg/sql/vecindex/vecpb",
"//pkg/testutils",
"//pkg/testutils/serverutils",
"//pkg/testutils/sqlutils",
diff --git a/pkg/sql/catalog/tabledesc/index.go b/pkg/sql/catalog/tabledesc/index.go
index f7b7c0f82944..bcdfbe72cc41 100644
--- a/pkg/sql/catalog/tabledesc/index.go
+++ b/pkg/sql/catalog/tabledesc/index.go
@@ -17,6 +17,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/catalog/descpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
"github.com/cockroachdb/cockroach/pkg/sql/types"
+ "github.com/cockroachdb/cockroach/pkg/sql/vecindex/vecpb"
"github.com/cockroachdb/cockroach/pkg/util/iterutil"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
"github.com/cockroachdb/cockroach/pkg/util/timeutil"
@@ -223,6 +224,20 @@ func (w index) InvertedColumnKind() catpb.InvertedIndexColumnKind {
return w.desc.InvertedColumnKinds[0]
}
+// VectorColumnID returns the ColumnID of the vector column of the vector index.
+// This is always the last column in KeyColumnIDs. Panics if the index is not a
+// vector index.
+func (w index) VectorColumnID() descpb.ColumnID {
+ return w.desc.VectorColumnID()
+}
+
+// VectorColumnName returns the name of the vector column of the vector index.
+// This is always the last column in KeyColumnIDs. Panics if the index is not a
+// vector index.
+func (w index) VectorColumnName() string {
+ return w.desc.VectorColumnName()
+}
+
// CollectKeyColumnIDs creates a new set containing the column IDs in the key
// of this index.
func (w index) CollectKeyColumnIDs() catalog.TableColSet {
@@ -265,6 +280,11 @@ func (w index) GetGeoConfig() geopb.Config {
return w.desc.GeoConfig
}
+// GetVecConfig returns the vec config in the index descriptor.
+func (w index) GetVecConfig() vecpb.Config {
+ return w.desc.VecConfig
+}
+
// GetSharded returns the ShardedDescriptor in the index descriptor
func (w index) GetSharded() catpb.ShardedDescriptor {
return w.desc.Sharded
diff --git a/pkg/sql/catalog/tabledesc/index_test.go b/pkg/sql/catalog/tabledesc/index_test.go
index 1dd2059142c2..54e43b24aede 100644
--- a/pkg/sql/catalog/tabledesc/index_test.go
+++ b/pkg/sql/catalog/tabledesc/index_test.go
@@ -28,6 +28,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/catalog/internal/validate"
"github.com/cockroachdb/cockroach/pkg/sql/catalog/tabledesc"
"github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
+ "github.com/cockroachdb/cockroach/pkg/sql/vecindex/vecpb"
"github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
@@ -57,17 +58,19 @@ func TestIndexInterface(t *testing.T) {
c5 VARCHAR,
c6 JSONB,
c7 GEOGRAPHY(GEOMETRY,4326) NULL,
+ c8 VECTOR(3),
CONSTRAINT pk PRIMARY KEY (c1 ASC, c2 ASC, c3 ASC),
INDEX s1 (c4 DESC, c5 DESC),
INVERTED INDEX s2 (c6),
INDEX s3 (c2, c3) STORING (c5, c6),
INDEX s4 (c5) USING HASH WITH (bucket_count=8),
UNIQUE INDEX s5 (c1, c4) WHERE c4 = 'x',
- INVERTED INDEX s6 (c7) WITH (s2_level_mod=2)
+ INVERTED INDEX s6 (c7) WITH (s2_level_mod=2),
+ VECTOR INDEX s7 (c8)
);
`)
- indexNames := []string{"pk", "s1", "s2", "s3", "s4", "s5", "s6"}
+ indexNames := []string{"pk", "s1", "s2", "s3", "s4", "s5", "s6", "s7"}
indexColumns := [][]string{
{"c1", "c2", "c3"},
{"c4", "c5"},
@@ -76,6 +79,7 @@ func TestIndexInterface(t *testing.T) {
{"crdb_internal_c5_shard_8", "c5"},
{"c1", "c4"},
{"c7"},
+ {"c8"},
}
extraColumnsAsPkColOrdinals := [][]int{
{},
@@ -85,6 +89,7 @@ func TestIndexInterface(t *testing.T) {
{0, 1, 2},
{1, 2},
{0, 1, 2},
+ {0, 1, 2},
}
immutable := desctestutils.TestingGetPublicTableDescriptor(db, s.Codec(), "d", "t")
@@ -110,6 +115,7 @@ func TestIndexInterface(t *testing.T) {
s4 := indexes[4]
s5 := indexes[5]
s6 := indexes[6]
+ s7 := indexes[7]
// Check that GetPrimaryIndex returns the primary index.
require.Equal(t, pk, tableI.GetPrimaryIndex())
@@ -265,6 +271,7 @@ func TestIndexInterface(t *testing.T) {
require.Equal(t, "c4 = 'x':::STRING", s5.GetPredicate())
require.Equal(t, "crdb_internal_c5_shard_8", s4.GetShardColumnName())
require.Equal(t, int32(2), s6.GetGeoConfig().S2Geography.S2Config.LevelMod)
+ require.Equal(t, int32(3), s7.GetVecConfig().Dims)
for _, idx := range indexes {
require.Equalf(t, idx == s5, idx.IsPartial(),
errMsgFmt, "IsPartial", idx.GetName())
@@ -284,6 +291,9 @@ func TestIndexInterface(t *testing.T) {
errMsgFmt, "GetSharded", idx.GetName())
require.Equalf(t, idx != s3, idx.NumSecondaryStoredColumns() == 0,
errMsgFmt, "NumSecondaryStoredColumns", idx.GetName())
+ vecConfig := idx.GetVecConfig()
+ require.Equal(t, idx == s7, !(&vecpb.Config{}).Equal(&vecConfig),
+ errMsgFmt, "GetVecConfig", idx.GetName())
}
// Check index columns.
@@ -326,6 +336,8 @@ func TestIndexInterface(t *testing.T) {
require.Equal(t, 2, s3.NumSecondaryStoredColumns())
require.Equal(t, "c5", s3.GetStoredColumnName(0))
require.Equal(t, "c6", s3.GetStoredColumnName(1))
+ require.Equal(t, s7.GetKeyColumnID(0), s7.VectorColumnID())
+ require.Equal(t, "c8", s7.VectorColumnName())
}
// TestIndexStrictColumnIDs tests that the index format version value
diff --git a/pkg/sql/catalog/tabledesc/structured.go b/pkg/sql/catalog/tabledesc/structured.go
index 5b2d46c7f2d8..3bfbf1a5a9c0 100644
--- a/pkg/sql/catalog/tabledesc/structured.go
+++ b/pkg/sql/catalog/tabledesc/structured.go
@@ -12,7 +12,6 @@ import (
"strings"
"github.com/cockroachdb/cockroach/pkg/clusterversion"
- "github.com/cockroachdb/cockroach/pkg/docs"
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/sql/catalog"
@@ -1084,96 +1083,40 @@ func (desc *Mutable) ClusterVersion() descpb.TableDescriptor {
// current heuristic will assign to a family.
const FamilyHeuristicTargetBytes = 256
-func notIndexableError(cols []descpb.ColumnDescriptor) error {
- if len(cols) == 0 {
- return nil
- }
- var msg string
- var typInfo string
- if len(cols) == 1 {
- col := &cols[0]
- msg = "column %s is of type %s and thus is not indexable"
- typInfo = col.Type.DebugString()
- msg = fmt.Sprintf(msg, col.Name, col.Type.Name())
- } else {
- msg = "the following columns are not indexable due to their type: "
- for i := range cols {
- col := &cols[i]
- msg += fmt.Sprintf("%s (type %s)", col.Name, col.Type.Name())
- typInfo += col.Type.DebugString()
- if i != len(cols)-1 {
- msg += ", "
- typInfo += ","
+func checkColumnsValidForIndex(tableDesc *Mutable, indexDesc *descpb.IndexDescriptor) error {
+ indexColNames := indexDesc.KeyColumnNames
+ indexColDirs := indexDesc.KeyColumnDirections
+ lastCol := len(indexColNames) - 1
+ for i, indexCol := range indexColNames {
+ for _, tableCol := range tableDesc.NonDropColumns() {
+ // Skip until we find the matching column in the table, by name.
+ if tableCol.GetName() != indexCol {
+ continue
}
- }
- }
- return unimplemented.NewWithIssueDetailf(35730, typInfo, "%s", msg)
-}
-func checkColumnsValidForIndex(tableDesc *Mutable, indexColNames []string) error {
- invalidColumns := make([]descpb.ColumnDescriptor, 0, len(indexColNames))
- for _, indexCol := range indexColNames {
- for _, col := range tableDesc.NonDropColumns() {
- if col.GetName() == indexCol {
- if !colinfo.ColumnTypeIsIndexable(col.GetType()) {
- invalidColumns = append(invalidColumns, *col.ColumnDesc())
+ // Report error if the index type does not allow DESC to be used in
+ // the last column, because it has no linear ordering.
+ if !indexDesc.Type.HasLinearOrdering() {
+ if i == lastCol && indexColDirs[i] == catenumpb.IndexColumn_DESC {
+ return pgerror.Newf(pgcode.FeatureNotSupported,
+ "the last column in %s cannot have the DESC option",
+ idxtype.ErrorText(indexDesc.Type))
}
}
- }
- }
- if len(invalidColumns) > 0 {
- return notIndexableError(invalidColumns)
- }
- return nil
-}
-func checkColumnsValidForInvertedIndex(
- tableDesc *Mutable, indexColNames []string, colDirs []catenumpb.IndexColumn_Direction,
-) error {
- lastCol := len(indexColNames) - 1
- for i, indexCol := range indexColNames {
- for _, col := range tableDesc.NonDropColumns() {
- if col.GetName() == indexCol {
- // The last column indexed by an inverted index must be
- // inverted indexable.
- if i == lastCol && !colinfo.ColumnTypeIsInvertedIndexable(col.GetType()) {
- return NewInvalidInvertedColumnError(col.GetName(), col.GetType().String())
- }
- if i == lastCol && colDirs[i] == catenumpb.IndexColumn_DESC {
- return pgerror.New(pgcode.FeatureNotSupported,
- "the last column in an inverted index cannot have the DESC option")
- }
- // Any preceding columns must not be inverted indexable.
- if i < lastCol && !colinfo.ColumnTypeIsIndexable(col.GetType()) {
- return errors.WithHint(
- pgerror.Newf(
- pgcode.FeatureNotSupported,
- "column %s of type %s is only allowed as the last column in an inverted index",
- col.GetName(),
- col.GetType().Name(),
- ),
- "see the documentation for more information about inverted indexes: "+docs.URL("inverted-indexes.html"),
- )
- }
+ // Check whether column is allowed in the index, at this position.
+ err := colinfo.ValidateColumnForIndex(
+ indexDesc.Type, tableCol.GetName(), tableCol.GetType(), i == lastCol)
+ if err != nil {
+ return err
}
+
+ break
}
}
return nil
}
-// NewInvalidInvertedColumnError returns an error for a column that's not
-// inverted indexable.
-func NewInvalidInvertedColumnError(colName, colType string) error {
- return errors.WithHint(
- pgerror.Newf(
- pgcode.FeatureNotSupported,
- "column %s of type %s is not allowed as the last column in an inverted index",
- colName, colType,
- ),
- "see the documentation for more information about inverted indexes: "+docs.URL("inverted-indexes.html"),
- )
-}
-
// AddColumn adds a column to the table.
func (desc *Mutable) AddColumn(col *descpb.ColumnDescriptor) {
desc.Columns = append(desc.Columns, *col)
@@ -1187,10 +1130,10 @@ func (desc *Mutable) AddFamily(fam descpb.ColumnFamilyDescriptor) {
// AddPrimaryIndex adds a primary index to a mutable table descriptor, assuming
// that none has yet been set, and performs some sanity checks.
func (desc *Mutable) AddPrimaryIndex(idx descpb.IndexDescriptor) error {
- if idx.Type == idxtype.INVERTED {
- return fmt.Errorf("primary index cannot be inverted")
+ if !idx.Type.CanBePrimary() {
+ return fmt.Errorf("primary index cannot be %s", idxtype.ErrorText(idx.Type))
}
- if err := checkColumnsValidForIndex(desc, idx.KeyColumnNames); err != nil {
+ if err := checkColumnsValidForIndex(desc, &idx); err != nil {
return err
}
if desc.PrimaryIndex.Name != "" {
@@ -1227,16 +1170,8 @@ func (desc *Mutable) AddPrimaryIndex(idx descpb.IndexDescriptor) error {
// AddSecondaryIndex adds a secondary index to a mutable table descriptor.
func (desc *Mutable) AddSecondaryIndex(idx descpb.IndexDescriptor) error {
- if idx.Type == idxtype.FORWARD {
- if err := checkColumnsValidForIndex(desc, idx.KeyColumnNames); err != nil {
- return err
- }
- } else {
- if err := checkColumnsValidForInvertedIndex(
- desc, idx.KeyColumnNames, idx.KeyColumnDirections,
- ); err != nil {
- return err
- }
+ if err := checkColumnsValidForIndex(desc, &idx); err != nil {
+ return err
}
desc.AddPublicNonPrimaryIndex(idx)
return nil
@@ -2022,7 +1957,7 @@ func (desc *Mutable) AddColumnMutation(
// AddDropIndexMutation adds a a dropping index mutation for the given
// index descriptor.
func (desc *Mutable) AddDropIndexMutation(idx *descpb.IndexDescriptor) error {
- if err := desc.checkValidIndex(idx); err != nil {
+ if err := checkColumnsValidForIndex(desc, idx); err != nil {
return err
}
m := descpb.DescriptorMutation{
@@ -2038,7 +1973,7 @@ func (desc *Mutable) AddDropIndexMutation(idx *descpb.IndexDescriptor) error {
func (desc *Mutable) AddIndexMutationMaybeWithTempIndex(
idx *descpb.IndexDescriptor, direction descpb.DescriptorMutation_Direction,
) error {
- if err := desc.checkValidIndex(idx); err != nil {
+ if err := checkColumnsValidForIndex(desc, idx); err != nil {
return err
}
m := descpb.DescriptorMutation{
@@ -2056,7 +1991,7 @@ func (desc *Mutable) AddIndexMutation(
direction descpb.DescriptorMutation_Direction,
state descpb.DescriptorMutation_State,
) error {
- if err := desc.checkValidIndex(idx); err != nil {
+ if err := checkColumnsValidForIndex(desc, idx); err != nil {
return err
}
stateIsValid := func() bool {
@@ -2083,22 +2018,6 @@ func (desc *Mutable) AddIndexMutation(
return nil
}
-func (desc *Mutable) checkValidIndex(idx *descpb.IndexDescriptor) error {
- switch idx.Type {
- case idxtype.FORWARD:
- if err := checkColumnsValidForIndex(desc, idx.KeyColumnNames); err != nil {
- return err
- }
- case idxtype.INVERTED:
- if err := checkColumnsValidForInvertedIndex(
- desc, idx.KeyColumnNames, idx.KeyColumnDirections,
- ); err != nil {
- return err
- }
- }
- return nil
-}
-
// AddPrimaryKeySwapMutation adds a PrimaryKeySwap mutation to the table descriptor.
func (desc *Mutable) AddPrimaryKeySwapMutation(swap *descpb.PrimaryKeySwap) {
desc.addMutation(descpb.DescriptorMutation{
diff --git a/pkg/sql/catalog/tabledesc/structured_test.go b/pkg/sql/catalog/tabledesc/structured_test.go
index 9a0dff8250e9..a45164c94c33 100644
--- a/pkg/sql/catalog/tabledesc/structured_test.go
+++ b/pkg/sql/catalog/tabledesc/structured_test.go
@@ -196,6 +196,7 @@ func TestColumnTypeSQLString(t *testing.T) {
{types.String, "STRING"},
{types.MakeString(10), "STRING(10)"},
{types.Bytes, "BYTES"},
+ {types.MakePGVector(3), "VECTOR(3)"},
}
for i, d := range testData {
t.Run(d.colType.DebugString(), func(t *testing.T) {
diff --git a/pkg/sql/catalog/tabledesc/table_desc_builder.go b/pkg/sql/catalog/tabledesc/table_desc_builder.go
index e55c3b894141..0fb635a9e274 100644
--- a/pkg/sql/catalog/tabledesc/table_desc_builder.go
+++ b/pkg/sql/catalog/tabledesc/table_desc_builder.go
@@ -22,7 +22,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/schemachanger/scpb"
"github.com/cockroachdb/cockroach/pkg/sql/sem/catconstants"
- "github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
"github.com/cockroachdb/cockroach/pkg/util/hlc"
"github.com/cockroachdb/cockroach/pkg/util/intsets"
@@ -843,7 +842,10 @@ func maybeUpgradePrimaryIndexFormatVersion(builder *tableDescriptorBuilder) (has
func maybeUpgradeSecondaryIndexFormatVersion(idx *descpb.IndexDescriptor) (hasChanged bool) {
switch idx.Version {
case descpb.SecondaryIndexFamilyFormatVersion:
- if idx.Type == idxtype.INVERTED {
+ // If the index type does not support STORING columns, then it's not
+ // encoded differently based on whether column families are in use, so
+ // nothing to do.
+ if !idx.Type.SupportsStoring() {
return false
}
case descpb.EmptyArraysInInvertedIndexesVersion:
diff --git a/pkg/sql/create_index.go b/pkg/sql/create_index.go
index 7b3a18f734f0..1123f74b9be1 100644
--- a/pkg/sql/create_index.go
+++ b/pkg/sql/create_index.go
@@ -28,6 +28,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/eval"
"github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
+ "github.com/cockroachdb/cockroach/pkg/sql/sqlerrors"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
"github.com/cockroachdb/cockroach/pkg/sql/storageparam"
"github.com/cockroachdb/cockroach/pkg/sql/storageparam/indexstorageparam"
@@ -424,7 +425,7 @@ func populateInvertedIndexDescriptor(
return newUndefinedOpclassError(invCol.OpClass)
}
default:
- return tabledesc.NewInvalidInvertedColumnError(column.GetName(), column.GetType().Name())
+ return sqlerrors.NewInvalidLastColumnError(column.GetName(), column.GetType().Name(), idxtype.INVERTED)
}
return nil
}
diff --git a/pkg/sql/create_stats.go b/pkg/sql/create_stats.go
index 786a7df72f02..b4099fabef6f 100644
--- a/pkg/sql/create_stats.go
+++ b/pkg/sql/create_stats.go
@@ -578,6 +578,10 @@ func createStatsDefaultColumns(
// Add column stats for each secondary index.
for _, idx := range desc.PublicNonPrimaryIndexes() {
+ if idx.GetType() == idxtype.VECTOR {
+ // Skip vector indexes for now.
+ continue
+ }
for j, n := 0, idx.NumKeyColumns(); j < n; j++ {
colID := idx.GetKeyColumnID(j)
isInverted := idx.GetType() == idxtype.INVERTED && colID == idx.InvertedColumnID()
diff --git a/pkg/sql/create_table.go b/pkg/sql/create_table.go
index ce2da5cf872b..551d40ad927b 100644
--- a/pkg/sql/create_table.go
+++ b/pkg/sql/create_table.go
@@ -1887,9 +1887,6 @@ func NewTableDesc(
// pass, handled above.
case *tree.IndexTableDef:
- if d.Type == idxtype.VECTOR {
- return nil, unimplemented.NewWithIssuef(137370, "VECTOR indexes are not yet supported")
- }
// If the index is named, ensure that the name is unique. Unnamed
// indexes will be given a unique auto-generated name later on when
// AllocateIDs is called.
@@ -1950,6 +1947,14 @@ func NewTableDesc(
return nil, err
}
}
+ if d.Type == idxtype.VECTOR {
+ column, err := catalog.MustFindColumnByName(&desc, idx.VectorColumnName())
+ if err != nil {
+ return nil, err
+ }
+ idx.VecConfig.Dims = column.GetType().Width()
+ idx.VecConfig.Seed = evalCtx.GetRNG().Int63()
+ }
var idxPartitionBy *tree.PartitionBy
if desc.PartitionAllBy && d.PartitionByIndex.ContainsPartitions() {
@@ -2393,6 +2398,12 @@ func NewTableDesc(
telemetry.Inc(sqltelemetry.PartitionedInvertedIndexCounter)
}
}
+ if idx.GetType() == idxtype.VECTOR {
+ telemetry.Inc(sqltelemetry.VectorIndexCounter)
+ if idx.NumKeyColumns() > 1 {
+ telemetry.Inc(sqltelemetry.MultiColumnVectorIndexCounter)
+ }
+ }
if idx.IsPartial() {
telemetry.Inc(sqltelemetry.PartialIndexCounter)
}
@@ -2809,8 +2820,8 @@ func replaceLikeTableOpts(n *tree.CreateTable, params runParams) (tree.TableDefs
indexDef.Columns = append(indexDef.Columns, elem)
}
// The last column of an inverted or vector index cannot have an
- // explicit direction.
- if !indexDef.Type.AllowExplicitDirection() {
+ // explicit direction, because it does not have a linear ordering.
+ if !indexDef.Type.HasLinearOrdering() {
indexDef.Columns[len(indexDef.Columns)-1].Direction = tree.DefaultDirection
}
for j := 0; j < idx.NumSecondaryStoredColumns(); j++ {
diff --git a/pkg/sql/logictest/testdata/logic_test/alter_primary_key b/pkg/sql/logictest/testdata/logic_test/alter_primary_key
index f4e9c57d9788..d71757d8a55d 100644
--- a/pkg/sql/logictest/testdata/logic_test/alter_primary_key
+++ b/pkg/sql/logictest/testdata/logic_test/alter_primary_key
@@ -2006,7 +2006,7 @@ CREATE TABLE tab_122871 (
PRIMARY KEY (col0_18 DESC)
);
-statement error column col0_4 is of type tsvector and thus is not indexable
+statement error column col0_4 has type tsvector, which is not indexable
ALTER TABLE tab_122871 ALTER PRIMARY KEY USING COLUMNS (col0_4);
subtest end
diff --git a/pkg/sql/logictest/testdata/logic_test/array b/pkg/sql/logictest/testdata/logic_test/array
index 057152150a12..88a2456768cc 100644
--- a/pkg/sql/logictest/testdata/logic_test/array
+++ b/pkg/sql/logictest/testdata/logic_test/array
@@ -1693,7 +1693,7 @@ statement error duplicate key value violates unique constraint
CREATE UNIQUE INDEX ON unique_array(b)
# Create an indexes on a bad type.
-statement error pq: unimplemented: column x is of type geography\[\] and thus is not indexable
+statement error column x has type geography\[\], which is not indexable in a non-inverted index\nHINT: you may want to create an inverted index instead. See the documentation for inverted indexes: https://www.cockroachlabs.com/docs/dev/inverted-indexes.html
CREATE TABLE tbad (x GEOGRAPHY[] PRIMARY KEY)
# Test arrays of composite types.
diff --git a/pkg/sql/logictest/testdata/logic_test/create_table b/pkg/sql/logictest/testdata/logic_test/create_table
index 22ba842e1bdd..e81e4be007cf 100644
--- a/pkg/sql/logictest/testdata/logic_test/create_table
+++ b/pkg/sql/logictest/testdata/logic_test/create_table
@@ -114,19 +114,23 @@ CREATE TABLE telemetry (
x INT PRIMARY KEY,
y INT,
z JSONB,
+ v VECTOR(3),
INVERTED INDEX (z),
- INDEX (y) USING HASH WITH (bucket_count=4)
+ INDEX (y) USING HASH WITH (bucket_count=4),
+ VECTOR INDEX (v)
)
query T rowsort
SELECT feature_name FROM crdb_internal.feature_usage
WHERE feature_name IN (
'sql.schema.inverted_index',
- 'sql.schema.hash_sharded_index'
+ 'sql.schema.hash_sharded_index',
+ 'sql.schema.vector_index'
)
----
sql.schema.inverted_index
sql.schema.hash_sharded_index
+sql.schema.vector_index
subtest like_table
@@ -144,12 +148,14 @@ CREATE TABLE like_table (
j JSON,
k INT UNIQUE WITHOUT INDEX,
t TIMESTAMPTZ DEFAULT current_timestamp() - '5s'::interval ON UPDATE current_timestamp(),
+ v VECTOR(3),
PRIMARY KEY (a, b),
UNIQUE INDEX foo (b DESC, c),
INDEX (c) STORING (j),
INVERTED INDEX (j),
UNIQUE WITHOUT INDEX (h),
- UNIQUE WITHOUT INDEX (h) WHERE h > 0
+ UNIQUE WITHOUT INDEX (h) WHERE h > 0,
+ VECTOR INDEX (v)
)
statement ok
@@ -166,6 +172,7 @@ like_none CREATE TABLE public.like_none (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL,
+ v VECTOR(3) NULL,
rowid INT8 NOT VISIBLE NOT NULL DEFAULT unique_rowid(),
CONSTRAINT like_none_pkey PRIMARY KEY (rowid ASC)
)
@@ -184,6 +191,7 @@ like_constraints CREATE TABLE public.like_constraints (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL,
+ v VECTOR(3) NULL,
rowid INT8 NOT VISIBLE NOT NULL DEFAULT unique_rowid(),
CONSTRAINT like_constraints_pkey PRIMARY KEY (rowid ASC),
CONSTRAINT check_a CHECK (a > 3:::INT8),
@@ -206,10 +214,12 @@ like_indexes CREATE TABLE public.like_indexes (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL,
+ v VECTOR(3) NULL,
CONSTRAINT like_table_pkey PRIMARY KEY (a ASC, b ASC),
UNIQUE INDEX foo (b DESC, c ASC),
INDEX like_table_c_idx (c ASC) STORING (j),
- INVERTED INDEX like_table_j_idx (j)
+ INVERTED INDEX like_table_j_idx (j),
+ VECTOR INDEX like_table_v_idx (v)
)
# INCLUDING GENERATED adds "generated columns", aka stored columns.
@@ -227,6 +237,7 @@ like_generated CREATE TABLE public.like_generated (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL,
+ v VECTOR(3) NULL,
rowid INT8 NOT VISIBLE NOT NULL DEFAULT unique_rowid(),
CONSTRAINT like_generated_pkey PRIMARY KEY (rowid ASC)
)
@@ -245,6 +256,7 @@ like_defaults CREATE TABLE public.like_defaults (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL DEFAULT current_timestamp():::TIMESTAMPTZ - '00:00:05':::INTERVAL ON UPDATE current_timestamp():::TIMESTAMPTZ,
+ v VECTOR(3) NULL,
rowid INT8 NOT VISIBLE NOT NULL DEFAULT unique_rowid(),
CONSTRAINT like_defaults_pkey PRIMARY KEY (rowid ASC)
)
@@ -263,10 +275,12 @@ like_all CREATE TABLE public.like_all (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL DEFAULT current_timestamp():::TIMESTAMPTZ - '00:00:05':::INTERVAL ON UPDATE current_timestamp():::TIMESTAMPTZ,
+ v VECTOR(3) NULL,
CONSTRAINT like_table_pkey PRIMARY KEY (a ASC, b ASC),
UNIQUE INDEX foo (b DESC, c ASC),
INDEX like_table_c_idx (c ASC) STORING (j),
INVERTED INDEX like_table_j_idx (j),
+ VECTOR INDEX like_table_v_idx (v),
CONSTRAINT check_a CHECK (a > 3:::INT8),
CONSTRAINT unique_k UNIQUE WITHOUT INDEX (k),
CONSTRAINT unique_h UNIQUE WITHOUT INDEX (h),
@@ -289,10 +303,12 @@ like_mixed CREATE TABLE public.like_mixed (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL DEFAULT current_timestamp():::TIMESTAMPTZ - '00:00:05':::INTERVAL ON UPDATE current_timestamp():::TIMESTAMPTZ,
+ v VECTOR(3) NULL,
CONSTRAINT like_table_pkey PRIMARY KEY (a ASC, b ASC),
UNIQUE INDEX foo (b DESC, c ASC),
INDEX like_table_c_idx (c ASC) STORING (j),
- INVERTED INDEX like_table_j_idx (j)
+ INVERTED INDEX like_table_j_idx (j),
+ VECTOR INDEX like_table_v_idx (v)
)
statement ok
@@ -335,6 +351,7 @@ like_more_specifiers CREATE TABLE public.like_more_specifiers (
j JSONB NULL,
k INT8 NULL,
t TIMESTAMPTZ NULL,
+ v VECTOR(3) NULL,
z DECIMAL NULL,
blah INT8 NULL,
rowid INT8 NOT VISIBLE NOT NULL DEFAULT unique_rowid(),
@@ -1210,3 +1227,6 @@ CREATE TABLE create_table_index_elem_duplicate_storage_params_e (
);
subtest end
+
+statement error pq: unimplemented: column col2 has type refcursor, which is not indexable\nHINT: You have attempted to use a feature that is not yet implemented.\nSee: https://go.crdb.dev/issue-v/35730/dev
+CREATE TABLE not_indexable (COL1 INT PRIMARY KEY, COL2 REFCURSOR, COL3 REFCURSOR, INDEX (COL2, COL3))
diff --git a/pkg/sql/logictest/testdata/logic_test/geospatial b/pkg/sql/logictest/testdata/logic_test/geospatial
index 77815ee0c769..6e8ba5100c59 100644
--- a/pkg/sql/logictest/testdata/logic_test/geospatial
+++ b/pkg/sql/logictest/testdata/logic_test/geospatial
@@ -117,16 +117,16 @@ geog GEOGRAPHY(GEOMETRY,4326) true NULL · {geo_table_geog_idx,geo_table
geom GEOMETRY(POINT) true NULL · {geo_table_geom_idx,geo_table_pkey} false
orphan GEOGRAPHY true NULL · {geo_table_pkey} false
-statement error column bad_pk is of type geography and thus is not indexable
+statement error column bad_pk has type geography, which is not indexable in a non-inverted index\nHINT: you may want to create an inverted index instead. See the documentation for inverted indexes: https://www.cockroachlabs.com/docs/dev/inverted-indexes.html
CREATE TABLE bad_geog_table(bad_pk geography primary key)
-statement error column bad_pk is of type geometry and thus is not indexable
+statement error column bad_pk has type geometry, which is not indexable in a non-inverted index\nHINT: you may want to create an inverted index instead. See the documentation for inverted indexes: https://www.cockroachlabs.com/docs/dev/inverted-indexes.html
CREATE TABLE bad_geom_table(bad_pk geometry primary key)
-statement error column geog is of type geography and thus is not indexable
+statement error column geog has type geography, which is not indexable
CREATE INDEX geog_idx ON geo_table(geog)
-statement error column geom is of type geometry and thus is not indexable
+statement error column geom has type geometry, which is not indexable
CREATE INDEX geom_idx ON geo_table(geom)
statement ok
diff --git a/pkg/sql/logictest/testdata/logic_test/inverted_index b/pkg/sql/logictest/testdata/logic_test/inverted_index
index 2c69525f7308..fe1d6883de49 100644
--- a/pkg/sql/logictest/testdata/logic_test/inverted_index
+++ b/pkg/sql/logictest/testdata/logic_test/inverted_index
@@ -13,10 +13,10 @@ INSERT INTO t VALUES (1,1,1)
statement ok
CREATE INDEX foo ON t (b)
-statement error column b of type int is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
+statement error column b has type int, which is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
CREATE INVERTED INDEX foo_inv ON t(b)
-statement error column b of type int is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
+statement error column b has type int, which is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
CREATE INDEX foo_inv2 ON t USING GIN (b)
statement error pq: inverted indexes can't be unique
@@ -73,7 +73,7 @@ CREATE INVERTED INDEX ON c (foo DESC)
statement ok
CREATE INVERTED INDEX ON c("qUuX")
-statement error column foo of type int is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes
+statement error column foo has type int, which is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes
CREATE TABLE d (
id INT PRIMARY KEY,
foo INT,
diff --git a/pkg/sql/logictest/testdata/logic_test/inverted_index_multi_column b/pkg/sql/logictest/testdata/logic_test/inverted_index_multi_column
index 869264af1ab8..563324214274 100644
--- a/pkg/sql/logictest/testdata/logic_test/inverted_index_multi_column
+++ b/pkg/sql/logictest/testdata/logic_test/inverted_index_multi_column
@@ -1,11 +1,11 @@
# Tests for multi-column inverted indexes.
# Err if the last column is not an invertable type.
-statement error column b of type int is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
+statement error column b has type int, which is not allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
CREATE TABLE m_err (k INT PRIMARY KEY, a INT, b INT, geom GEOMETRY, INVERTED INDEX (a, b))
# Err if a non-last column is not a non-invertable type.
-statement error column geom1 of type geometry is only allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
+statement error column geom1 has type geometry, which is only allowed as the last column in an inverted index\nHINT: see the documentation for more information about inverted indexes: https://www.cockroachlabs.com/docs/.*/inverted-indexes.html
CREATE TABLE m_err (k INT PRIMARY KEY, geom1 GEOMETRY , geom GEOMETRY, INVERTED INDEX (geom1, geom))
diff --git a/pkg/sql/logictest/testdata/logic_test/vector_index b/pkg/sql/logictest/testdata/logic_test/vector_index
new file mode 100644
index 000000000000..f8e26a698857
--- /dev/null
+++ b/pkg/sql/logictest/testdata/logic_test/vector_index
@@ -0,0 +1,140 @@
+# ------------------------------------------------------------------------------
+# CREATE TABLE tests.
+# ------------------------------------------------------------------------------
+
+# Simple vector index.
+statement ok
+CREATE TABLE simple (
+ a INT PRIMARY KEY,
+ vec1 VECTOR(3),
+ VECTOR INDEX (vec1),
+ FAMILY (a, vec1)
+)
+
+query TT
+SHOW CREATE TABLE simple
+----
+simple CREATE TABLE public.simple (
+ a INT8 NOT NULL,
+ vec1 VECTOR(3) NULL,
+ CONSTRAINT simple_pkey PRIMARY KEY (a ASC),
+ VECTOR INDEX simple_vec1_idx (vec1),
+ FAMILY fam_0_a_vec1 (a, vec1)
+ )
+
+statement ok
+SHOW INDEX FROM simple
+
+# Specify name for index.
+statement ok
+CREATE TABLE alt_syntax (
+ a INT PRIMARY KEY,
+ vec1 VECTOR(3),
+ VECTOR INDEX vec_idx (vec1),
+ FAMILY (a, vec1)
+)
+
+query TT
+SHOW CREATE TABLE alt_syntax
+----
+alt_syntax CREATE TABLE public.alt_syntax (
+ a INT8 NOT NULL,
+ vec1 VECTOR(3) NULL,
+ CONSTRAINT alt_syntax_pkey PRIMARY KEY (a ASC),
+ VECTOR INDEX vec_idx (vec1),
+ FAMILY fam_0_a_vec1 (a, vec1)
+ )
+
+# Multiple vector indexes on same table.
+statement ok
+CREATE TABLE multiple_indexes (
+ a INT PRIMARY KEY,
+ vec1 VECTOR(3),
+ vec2 VECTOR(1000),
+ VECTOR INDEX (vec1),
+ VECTOR INDEX (vec2),
+ FAMILY (a, vec1, vec2)
+)
+
+query TT
+SHOW CREATE TABLE multiple_indexes
+----
+multiple_indexes CREATE TABLE public.multiple_indexes (
+ a INT8 NOT NULL,
+ vec1 VECTOR(3) NULL,
+ vec2 VECTOR(1000) NULL,
+ CONSTRAINT multiple_indexes_pkey PRIMARY KEY (a ASC),
+ VECTOR INDEX multiple_indexes_vec1_idx (vec1),
+ VECTOR INDEX multiple_indexes_vec2_idx (vec2),
+ FAMILY fam_0_a_vec1_vec2 (a, vec1, vec2)
+ )
+
+# Use prefix columns in the vector index.
+statement ok
+CREATE TABLE prefix_cols (
+ a INT PRIMARY KEY,
+ b INT,
+ c INT,
+ vec1 VECTOR(3),
+ VECTOR INDEX (c DESC, b, vec1),
+ FAMILY (a, b, c, vec1)
+)
+
+query TT
+SHOW CREATE TABLE prefix_cols
+----
+prefix_cols CREATE TABLE public.prefix_cols (
+ a INT8 NOT NULL,
+ b INT8 NULL,
+ c INT8 NULL,
+ vec1 VECTOR(3) NULL,
+ CONSTRAINT prefix_cols_pkey PRIMARY KEY (a ASC),
+ VECTOR INDEX prefix_cols_c_b_vec1_idx (c DESC, b ASC, vec1),
+ FAMILY fam_0_a_b_c_vec1 (a, b, c, vec1)
+ )
+
+# Use mixed-case column for vector index.
+statement ok
+CREATE TABLE mixed_case (
+ a INT PRIMARY KEY,
+ qUuX VECTOR(3),
+ VECTOR INDEX (qUuX)
+)
+
+# Try to use vector in primary key.
+statement error column a has type vector, which is not indexable in a non-vector index\nHINT: you may want to create a vector index instead
+CREATE TABLE t (a VECTOR(3), PRIMARY KEY (a))
+
+statement error column b has type int, which is not allowed as the last column in a vector index
+CREATE TABLE t (a INT PRIMARY KEY, b INT, VECTOR INDEX (b))
+
+statement error column c has type vector, which is only allowed as the last column in a vector index
+CREATE TABLE t (a INT PRIMARY KEY, b INT, c VECTOR(3), VECTOR INDEX (c, b))
+
+# Try to use inverted indexable type in vector index.
+statement error column b has type tsvector, which is not indexable in a non-inverted index\nHINT: you may want to create an inverted index instead. See the documentation for inverted indexes: https://www.cockroachlabs.com/docs/dev/inverted-indexes.html
+CREATE TABLE t (a INT PRIMARY KEY, b TSVECTOR, c VECTOR(3), VECTOR INDEX (b, c))
+
+statement error the last column in a vector index cannot have the DESC option
+CREATE TABLE t (a INT PRIMARY KEY, b INT, c VECTOR(3), VECTOR INDEX (b, c DESC))
+
+statement error vector column b does not have a fixed number of dimensions, so it cannot be indexed\nDETAIL: specify the number of dimensions in the type, like VECTOR\(128\) for 128 dimensions
+CREATE TABLE t (a INT PRIMARY KEY, b VECTOR, VECTOR INDEX (b))
+
+# Try to use vector type in forward index.
+statement error pq: column c has type vector, which is not indexable in a non-vector index\nHINT: you may want to create a vector index instead
+CREATE TABLE t (a INT PRIMARY KEY, b INT, c VECTOR(3), INDEX (b, c))
+
+# ------------------------------------------------------------------------------
+# Execution tests.
+# ------------------------------------------------------------------------------
+
+statement ok
+CREATE TABLE exec_test (
+ a INT PRIMARY KEY,
+ vec1 VECTOR(3),
+ VECTOR INDEX (vec1)
+)
+
+statement error unimplemented: execution planning for vector index search is not yet implemented
+INSERT INTO exec_test (a, vec1) values (1, '[1, 2, 3]');
diff --git a/pkg/sql/logictest/tests/fakedist-disk/generated_test.go b/pkg/sql/logictest/tests/fakedist-disk/generated_test.go
index f23919c47e31..050735385c9a 100644
--- a/pkg/sql/logictest/tests/fakedist-disk/generated_test.go
+++ b/pkg/sql/logictest/tests/fakedist-disk/generated_test.go
@@ -2481,6 +2481,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize(
t *testing.T,
) {
diff --git a/pkg/sql/logictest/tests/fakedist-vec-off/generated_test.go b/pkg/sql/logictest/tests/fakedist-vec-off/generated_test.go
index a1fd572a2db5..9323b8e59168 100644
--- a/pkg/sql/logictest/tests/fakedist-vec-off/generated_test.go
+++ b/pkg/sql/logictest/tests/fakedist-vec-off/generated_test.go
@@ -2488,6 +2488,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize_agg(
t *testing.T,
) {
diff --git a/pkg/sql/logictest/tests/fakedist/generated_test.go b/pkg/sql/logictest/tests/fakedist/generated_test.go
index 792964409009..683b2d679a1e 100644
--- a/pkg/sql/logictest/tests/fakedist/generated_test.go
+++ b/pkg/sql/logictest/tests/fakedist/generated_test.go
@@ -2502,6 +2502,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize(
t *testing.T,
) {
diff --git a/pkg/sql/logictest/tests/local-legacy-schema-changer/generated_test.go b/pkg/sql/logictest/tests/local-legacy-schema-changer/generated_test.go
index d574449c2415..87e52dd13fdc 100644
--- a/pkg/sql/logictest/tests/local-legacy-schema-changer/generated_test.go
+++ b/pkg/sql/logictest/tests/local-legacy-schema-changer/generated_test.go
@@ -2474,6 +2474,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize_agg(
t *testing.T,
) {
diff --git a/pkg/sql/logictest/tests/local-mixed-24.3/generated_test.go b/pkg/sql/logictest/tests/local-mixed-24.3/generated_test.go
index abc1d25ad439..2a2173052c85 100644
--- a/pkg/sql/logictest/tests/local-mixed-24.3/generated_test.go
+++ b/pkg/sql/logictest/tests/local-mixed-24.3/generated_test.go
@@ -2488,6 +2488,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize_agg(
t *testing.T,
) {
diff --git a/pkg/sql/logictest/tests/local-vec-off/generated_test.go b/pkg/sql/logictest/tests/local-vec-off/generated_test.go
index 9da9861ec225..5006bcbb94e5 100644
--- a/pkg/sql/logictest/tests/local-vec-off/generated_test.go
+++ b/pkg/sql/logictest/tests/local-vec-off/generated_test.go
@@ -2516,6 +2516,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize_agg(
t *testing.T,
) {
diff --git a/pkg/sql/logictest/tests/local/generated_test.go b/pkg/sql/logictest/tests/local/generated_test.go
index f859c26e7db0..a8e4e425645d 100644
--- a/pkg/sql/logictest/tests/local/generated_test.go
+++ b/pkg/sql/logictest/tests/local/generated_test.go
@@ -2740,6 +2740,13 @@ func TestLogic_values(
runLogicTest(t, "values")
}
+func TestLogic_vector_index(
+ t *testing.T,
+) {
+ defer leaktest.AfterTest(t)()
+ runLogicTest(t, "vector_index")
+}
+
func TestLogic_vectorize(
t *testing.T,
) {
diff --git a/pkg/sql/parser/lexer.go b/pkg/sql/parser/lexer.go
index 9e377869a88e..a8411925dfb8 100644
--- a/pkg/sql/parser/lexer.go
+++ b/pkg/sql/parser/lexer.go
@@ -164,7 +164,10 @@ func (l *lexer) Lex(lval *sqlSymType) int {
(afterCommaOrParen && followedByNonPunctThenParen) ||
// CREATE ... (INVERTED INDEX abc (
// CREATE ... (x INT, y INT, INVERTED INDEX abc (
- (afterCommaOrParenThenINVERTED && followedByNonPunctThenParen) {
+ (afterCommaOrParenThenINVERTED && followedByNonPunctThenParen) ||
+ // CREATE ... (VECTOR INDEX abc (
+ // CREATE ... (x INT, y INT, VECTOR INDEX abc (
+ (afterCommaOrParenThenVECTOR && followedByNonPunctThenParen) {
lval.id = INDEX_BEFORE_NAME_THEN_PAREN
break
}
diff --git a/pkg/sql/parser/testdata/create_table b/pkg/sql/parser/testdata/create_table
index 7b02d4f24108..2e02f910fc8a 100644
--- a/pkg/sql/parser/testdata/create_table
+++ b/pkg/sql/parser/testdata/create_table
@@ -1377,6 +1377,23 @@ CREATE TABLE a (b INT8, VECTOR INDEX (b)) -- fully parenthesized
CREATE TABLE a (b INT8, VECTOR INDEX (b)) -- literals removed
CREATE TABLE _ (_ INT8, VECTOR INDEX (_)) -- identifiers removed
+# Explicitly name the index.
+parse
+CREATE TABLE a (b INT8, INVERTED INDEX i (b))
+----
+CREATE TABLE a (b INT8, INVERTED INDEX i (b))
+CREATE TABLE a (b INT8, INVERTED INDEX i (b)) -- fully parenthesized
+CREATE TABLE a (b INT8, INVERTED INDEX i (b)) -- literals removed
+CREATE TABLE _ (_ INT8, INVERTED INDEX _ (_)) -- identifiers removed
+
+parse
+CREATE TABLE a (b INT8, VECTOR INDEX i (b))
+----
+CREATE TABLE a (b INT8, VECTOR INDEX i (b))
+CREATE TABLE a (b INT8, VECTOR INDEX i (b)) -- fully parenthesized
+CREATE TABLE a (b INT8, VECTOR INDEX i (b)) -- literals removed
+CREATE TABLE _ (_ INT8, VECTOR INDEX _ (_)) -- identifiers removed
+
parse
CREATE TABLE a (b INT8, c INT8 REFERENCES foo)
----
diff --git a/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_add_column.go b/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_add_column.go
index 34182e6b5489..b02ed7c5d572 100644
--- a/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_add_column.go
+++ b/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_add_column.go
@@ -36,7 +36,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sqlerrors"
"github.com/cockroachdb/cockroach/pkg/sql/sqltelemetry"
"github.com/cockroachdb/cockroach/pkg/sql/types"
- "github.com/cockroachdb/cockroach/pkg/util/errorutil/unimplemented"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
"github.com/cockroachdb/errors"
"github.com/lib/pq/oid"
@@ -164,10 +163,7 @@ func alterTableAddColumn(
!d.Unique.WithoutIndex &&
!colinfo.ColumnTypeIsIndexable(spec.colType.Type) {
typInfo := spec.colType.Type.DebugString()
- panic(unimplemented.NewWithIssueDetailf(35730, typInfo,
- "column %s is of type %s and thus is not indexable",
- d.Name,
- spec.colType.Type.Name()))
+ panic(sqlerrors.NewColumnNotIndexableError(d.Name.String(), spec.colType.Type.Name(), typInfo))
}
// Block unsupported types.
switch spec.colType.Type.Oid() {
diff --git a/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_alter_primary_key.go b/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_alter_primary_key.go
index cf990f37781a..a55da8874ff7 100644
--- a/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_alter_primary_key.go
+++ b/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/alter_table_alter_primary_key.go
@@ -25,6 +25,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/sem/catid"
"github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
+ "github.com/cockroachdb/cockroach/pkg/sql/sqlerrors"
"github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/errorutil/unimplemented"
"github.com/cockroachdb/cockroach/pkg/util/protoutil"
@@ -348,12 +349,8 @@ func checkForEarlyExit(b BuildCtx, tbl *scpb.Table, t alterPrimaryKeySpec) {
columnType := mustRetrieveColumnTypeElem(b, tbl.TableID, colElem.ColumnID)
// Check if the column type is indexable.
if !colinfo.ColumnTypeIsIndexable(columnType.Type) {
- panic(unimplemented.NewWithIssueDetailf(35730,
- columnType.Type.DebugString(),
- "column %s is of type %s and thus is not indexable",
- col.Column,
- columnType.Type),
- )
+ panic(sqlerrors.NewColumnNotIndexableError(
+ col.Column.String(), columnType.Type.Name(), columnType.Type.DebugString()))
}
}
}
diff --git a/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/create_index.go b/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/create_index.go
index 23bf38478429..12df990a71d8 100644
--- a/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/create_index.go
+++ b/pkg/sql/schemachanger/scbuild/internal/scbuildstmt/create_index.go
@@ -311,8 +311,9 @@ func processColNodeType(
panic(pgerror.New(pgcode.DatatypeMismatch,
"operator classes are only allowed for the last column of an inverted index"))
}
- // Disallow descending last columns in inverted indexes.
- if !n.Type.AllowExplicitDirection() && columnNode.Direction == tree.Descending && lastColIdx {
+ // Disallow descending last column in inverted indexes because they have no
+ // linear ordering.
+ if !n.Type.HasLinearOrdering() && columnNode.Direction == tree.Descending && lastColIdx {
panic(pgerror.New(pgcode.FeatureNotSupported,
"the last column in an inverted index cannot have the DESC option"))
}
@@ -387,15 +388,11 @@ func processColNodeType(
if columnNode.Expr != nil {
colNameForErr = columnNode.Expr.String()
}
- panic(tabledesc.NewInvalidInvertedColumnError(colNameForErr,
- columnType.Type.String()))
+ panic(sqlerrors.NewInvalidLastColumnError(colNameForErr, columnType.Type.String(), n.Type))
} else if (n.Type != idxtype.INVERTED || !lastColIdx) && !colinfo.ColumnTypeIsIndexable(columnType.Type) {
// Otherwise, check if the column type is indexable.
- panic(unimplemented.NewWithIssueDetailf(35730,
- columnType.Type.DebugString(),
- "column %s is of type %s and thus is not indexable",
- colName,
- columnType.Type))
+ panic(sqlerrors.NewColumnNotIndexableError(
+ colName, columnType.Type.String(), columnType.Type.DebugString()))
}
return invertedKind
}
diff --git a/pkg/sql/sem/idxtype/BUILD.bazel b/pkg/sql/sem/idxtype/BUILD.bazel
index 79bfd0e3fecf..63fddc5acbf5 100644
--- a/pkg/sql/sem/idxtype/BUILD.bazel
+++ b/pkg/sql/sem/idxtype/BUILD.bazel
@@ -17,6 +17,7 @@ go_library(
embed = [":idxtype_go_proto"],
importpath = "github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype",
visibility = ["//visibility:public"],
+ deps = ["@com_github_cockroachdb_redact//:redact"],
)
go_proto_library(
@@ -36,14 +37,15 @@ go_library(
)
# idxtype is meant to stay a leaf package. Never add a heavy-weight dependency.
-# In fact, avoid any dependency at all, except protobuf-related.
disallowed_imports_test(
"idxtype",
- allowlist = [
- "//pkg/sql/sem/idxtype:idxtype_go_proto",
- "@com_github_gogo_protobuf//gogoproto",
- "@com_github_gogo_protobuf//proto",
- "@com_github_gogo_protobuf//protoc-gen-gogo/descriptor",
+ disallowed_list = [
+ "//pkg/kv",
+ "//pkg/roachpb",
+ "//pkg/security",
+ "//pkg/server",
+ "//pkg/sql",
+ "//pkg/storage",
+ "//pkg/util/log",
],
- disallow_cdeps = True,
)
diff --git a/pkg/sql/sem/idxtype/idxtype.go b/pkg/sql/sem/idxtype/idxtype.go
index 2e49b2729884..aab87c957039 100644
--- a/pkg/sql/sem/idxtype/idxtype.go
+++ b/pkg/sql/sem/idxtype/idxtype.go
@@ -5,6 +5,8 @@
package idxtype
+import "github.com/cockroachdb/redact"
+
// CanBePrimary is true if this index type can be the primary index that always
// contains unique keys sorted according to the primary ordering of the table.
// Secondary indexes refer to rows in the primary index by unique key value.
@@ -18,11 +20,12 @@ func (t T) CanBeUnique() bool {
return t == FORWARD
}
-// AllowExplicitDirection is true if this index type allows all of its columns
-// to specify an explicit ascending or descending direction. For example,
-// inverted and vector indexes do not allow the last column in the index to
-// specify an explicit direction.
-func (t T) AllowExplicitDirection() bool {
+// HasLinearOrdering is true if this index type does not define a linear
+// ordering on the last key column in the index. For example, a vector index
+// groups nearby vectors, but does not define a linear ordering among them. As
+// another example, an inverted index only defines a linear ordering for tokens,
+// not for the original JSONB or ARRAY data type.
+func (t T) HasLinearOrdering() bool {
return t == FORWARD
}
@@ -33,24 +36,39 @@ func (t T) AllowsPrefixColumns() bool {
return t == INVERTED || t == VECTOR
}
-// SupportsSharding is true if this index can be hash sharded, meaning that its
-// rows are grouped according to a hash value and spread across the keyspace.
+// SupportsSharding is true if this index type can be hash sharded, meaning that
+// its rows are grouped according to a hash value and spread across the
+// keyspace.
func (t T) SupportsSharding() bool {
return t == FORWARD
}
-// SupportsStoring is true if this index allows STORING values, which are
+// SupportsStoring is true if this index type allows STORING values, which are
// un-indexed columns from the table that are stored directly in the index for
// faster retrieval.
func (t T) SupportsStoring() bool {
return t == FORWARD
}
-// SupportsOpClass is true if this index allows columns to specify an operator
-// class, which defines an alternate set of operators used when sorting and
-// querying those columns.
+// SupportsOpClass is true if this index type allows columns to specify an
+// operator class, which defines an alternate set of operators used when sorting
+// and querying those columns.
// NOTE: Currently, only inverted indexes support operator classes, and only on
// the last column of the index.
func (t T) SupportsOpClass() bool {
return t == INVERTED
}
+
+// ErrorText describes the type of the index using the phrase "an inverted
+// index" or "a vector index". This is intended to be included in errors that
+// apply to multiple index types.
+func ErrorText(t T) redact.SafeString {
+ switch t {
+ case INVERTED:
+ return "an inverted index"
+ case VECTOR:
+ return "a vector index"
+ default:
+ return "an index"
+ }
+}
diff --git a/pkg/sql/sqlerrors/BUILD.bazel b/pkg/sql/sqlerrors/BUILD.bazel
index 2e14735bd4cc..e0ea951a971b 100644
--- a/pkg/sql/sqlerrors/BUILD.bazel
+++ b/pkg/sql/sqlerrors/BUILD.bazel
@@ -7,6 +7,7 @@ go_library(
visibility = ["//visibility:public"],
deps = [
"//pkg/build",
+ "//pkg/docs",
"//pkg/roachpb",
"//pkg/security/username",
"//pkg/sql/catalog/catpb",
@@ -15,6 +16,7 @@ go_library(
"//pkg/sql/pgwire/pgerror",
"//pkg/sql/privilege",
"//pkg/sql/sem/catconstants",
+ "//pkg/sql/sem/idxtype",
"//pkg/sql/sem/tree",
"//pkg/sql/types",
"//pkg/util/errorutil/unimplemented",
diff --git a/pkg/sql/sqlerrors/errors.go b/pkg/sql/sqlerrors/errors.go
index fbaa3cef7d26..5c29274350c3 100644
--- a/pkg/sql/sqlerrors/errors.go
+++ b/pkg/sql/sqlerrors/errors.go
@@ -12,6 +12,7 @@ import (
"strings"
"github.com/cockroachdb/cockroach/pkg/build"
+ "github.com/cockroachdb/cockroach/pkg/docs"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/security/username"
"github.com/cockroachdb/cockroach/pkg/sql/catalog/catpb"
@@ -20,6 +21,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/sem/catconstants"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/idxtype"
"github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
"github.com/cockroachdb/cockroach/pkg/sql/types"
"github.com/cockroachdb/cockroach/pkg/util/errorutil/unimplemented"
@@ -512,6 +514,41 @@ func NewInsufficientPrivilegeOnDescriptorError(
user, privsStr, descType, descName)
}
+// NewColumnNotIndexableError returns an error for a column type that cannot be
+// indexed.
+func NewColumnNotIndexableError(colDesc string, colType string, detail string) error {
+ return unimplemented.NewWithIssueDetailf(35730,
+ detail, "column %s has type %s, which is not indexable", colDesc, colType)
+}
+
+// NewInvalidLastColumnError returns an error for the type of the last column in
+// an inverted or vector index.
+func NewInvalidLastColumnError(colDesc, colType string, indexType idxtype.T) error {
+ err := pgerror.Newf(
+ pgcode.FeatureNotSupported,
+ "column %s has type %s, which is not allowed as the last column in %s",
+ colDesc, colType, idxtype.ErrorText(indexType))
+ if indexType == idxtype.INVERTED {
+ err = errors.WithHint(err,
+ "see the documentation for more information about inverted indexes: "+docs.URL("inverted-indexes.html"))
+ }
+ return err
+}
+
+// NewColumnOnlyIndexableError returns an error for a column with a type that
+// can only be indexed as the last column in an inverted or vector index.
+func NewColumnOnlyIndexableError(colDesc string, colType string, indexType idxtype.T) error {
+ err := pgerror.Newf(
+ pgcode.FeatureNotSupported,
+ "column %s has type %s, which is only allowed as the last column in %s",
+ colDesc, colType, idxtype.ErrorText(indexType))
+ if indexType == idxtype.INVERTED {
+ err = errors.WithHint(err,
+ "see the documentation for more information about inverted indexes: "+docs.URL("inverted-indexes.html"))
+ }
+ return err
+}
+
// QueryTimeoutError is an error representing a query timeout.
var QueryTimeoutError = pgerror.New(
pgcode.QueryCanceled, "query execution canceled due to statement timeout")
diff --git a/pkg/sql/sqltelemetry/schema.go b/pkg/sql/sqltelemetry/schema.go
index 4f75640757b5..36722a51db00 100644
--- a/pkg/sql/sqltelemetry/schema.go
+++ b/pkg/sql/sqltelemetry/schema.go
@@ -85,6 +85,15 @@ var (
// index is created. This includes both regular and inverted expression
// indexes.
ExpressionIndexCounter = telemetry.GetCounterOnce("sql.schema.expression_index")
+
+ // VectorIndexCounter is to be incremented every time a vector index is
+ // created. This includes single-column vector indexes, multi-column vector
+ // indexes, and partial vector indexes.
+ VectorIndexCounter = telemetry.GetCounterOnce("sql.schema.vector_index")
+
+ // MultiColumnVectorIndexCounter is to be incremented every time a
+ // multi-column vector index is created.
+ MultiColumnVectorIndexCounter = telemetry.GetCounterOnce("sql.schema.multi_column_vector_index")
)
// SchemaChangeIndexCounter is to be incremented for certain CREATE
diff --git a/pkg/sql/vecindex/vector_index.go b/pkg/sql/vecindex/vector_index.go
index 6b760d52d1c6..8c7d9f3d8304 100644
--- a/pkg/sql/vecindex/vector_index.go
+++ b/pkg/sql/vecindex/vector_index.go
@@ -60,7 +60,7 @@ type VectorIndexOptions struct {
DisableErrorBounds bool
// Seed is used to initialize a deterministic random number generator for
// testing purposes. If this is zero, then the global random number generator
- // is used intead.
+ // is used instead.
Seed int64
// MaxWorkers specifies the maximum number of background workers that can be
// created to process fixups for this vector index instance.
|
0ef988f4c02e085f99ca93e853bb453b4c056366
|
2020-10-07 14:29:11
|
Tobias Grieger
|
rpc: add and populate PingRequest.OriginNodeID
| false
|
add and populate PingRequest.OriginNodeID
|
rpc
|
diff --git a/pkg/rpc/context.go b/pkg/rpc/context.go
index dd5febcba05b..a014e6e57498 100644
--- a/pkg/rpc/context.go
+++ b/pkg/rpc/context.go
@@ -1133,6 +1133,7 @@ func (ctx *Context) runHeartbeat(
// We re-mint the PingRequest to pick up any asynchronous update to clusterID.
clusterID := ctx.ClusterID.Get()
request := &PingRequest{
+ OriginNodeID: ctx.NodeID.Get(),
OriginAddr: ctx.Config.Addr,
OriginMaxOffsetNanos: maxOffsetNanos,
ClusterID: &clusterID,
diff --git a/pkg/rpc/heartbeat.pb.go b/pkg/rpc/heartbeat.pb.go
index 792627f37df5..5d854c93443c 100644
--- a/pkg/rpc/heartbeat.pb.go
+++ b/pkg/rpc/heartbeat.pb.go
@@ -49,7 +49,7 @@ type RemoteOffset struct {
func (m *RemoteOffset) Reset() { *m = RemoteOffset{} }
func (*RemoteOffset) ProtoMessage() {}
func (*RemoteOffset) Descriptor() ([]byte, []int) {
- return fileDescriptor_heartbeat_c48a0290adb87462, []int{0}
+ return fileDescriptor_heartbeat_565332a8a713c8ea, []int{0}
}
func (m *RemoteOffset) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -88,15 +88,18 @@ type PingRequest struct {
// Cluster ID to prevent connections between nodes in different clusters.
ClusterID *github_com_cockroachdb_cockroach_pkg_util_uuid.UUID `protobuf:"bytes,5,opt,name=origin_cluster_id,json=originClusterId,customtype=github.com/cockroachdb/cockroach/pkg/util/uuid.UUID" json:"origin_cluster_id,omitempty"`
ServerVersion roachpb.Version `protobuf:"bytes,6,opt,name=server_version,json=serverVersion" json:"server_version"`
- // Node ID to prevent connections from being misrouted to an invalid node inside the cluster.
+ // NodeID the originator of the request wishes to connect to.
+ // This helps prevent connections from being misrouted when addresses are reused.
TargetNodeID github_com_cockroachdb_cockroach_pkg_roachpb.NodeID `protobuf:"varint,7,opt,name=target_node_id,json=targetNodeId,customtype=github.com/cockroachdb/cockroach/pkg/roachpb.NodeID" json:"target_node_id"`
+ // NodeID of the originator of the PingRequest.
+ OriginNodeID github_com_cockroachdb_cockroach_pkg_roachpb.NodeID `protobuf:"varint,8,opt,name=origin_node_id,json=originNodeId,customtype=github.com/cockroachdb/cockroach/pkg/roachpb.NodeID" json:"origin_node_id"`
}
func (m *PingRequest) Reset() { *m = PingRequest{} }
func (m *PingRequest) String() string { return proto.CompactTextString(m) }
func (*PingRequest) ProtoMessage() {}
func (*PingRequest) Descriptor() ([]byte, []int) {
- return fileDescriptor_heartbeat_c48a0290adb87462, []int{1}
+ return fileDescriptor_heartbeat_565332a8a713c8ea, []int{1}
}
func (m *PingRequest) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -137,7 +140,7 @@ func (m *PingResponse) Reset() { *m = PingResponse{} }
func (m *PingResponse) String() string { return proto.CompactTextString(m) }
func (*PingResponse) ProtoMessage() {}
func (*PingResponse) Descriptor() ([]byte, []int) {
- return fileDescriptor_heartbeat_c48a0290adb87462, []int{2}
+ return fileDescriptor_heartbeat_565332a8a713c8ea, []int{2}
}
func (m *PingResponse) XXX_Unmarshal(b []byte) error {
return m.Unmarshal(b)
@@ -418,6 +421,9 @@ func (m *PingRequest) MarshalTo(dAtA []byte) (int, error) {
dAtA[i] = 0x38
i++
i = encodeVarintHeartbeat(dAtA, i, uint64(m.TargetNodeID))
+ dAtA[i] = 0x40
+ i++
+ i = encodeVarintHeartbeat(dAtA, i, uint64(m.OriginNodeID))
return i, nil
}
@@ -507,6 +513,7 @@ func (m *PingRequest) Size() (n int) {
l = m.ServerVersion.Size()
n += 1 + l + sovHeartbeat(uint64(l))
n += 1 + sovHeartbeat(uint64(m.TargetNodeID))
+ n += 1 + sovHeartbeat(uint64(m.OriginNodeID))
return n
}
@@ -864,6 +871,25 @@ func (m *PingRequest) Unmarshal(dAtA []byte) error {
break
}
}
+ case 8:
+ if wireType != 0 {
+ return fmt.Errorf("proto: wrong wireType = %d for field OriginNodeID", wireType)
+ }
+ m.OriginNodeID = 0
+ for shift := uint(0); ; shift += 7 {
+ if shift >= 64 {
+ return ErrIntOverflowHeartbeat
+ }
+ if iNdEx >= l {
+ return io.ErrUnexpectedEOF
+ }
+ b := dAtA[iNdEx]
+ iNdEx++
+ m.OriginNodeID |= (github_com_cockroachdb_cockroach_pkg_roachpb.NodeID(b) & 0x7F) << shift
+ if b < 0x80 {
+ break
+ }
+ }
default:
iNdEx = preIndex
skippy, err := skipHeartbeat(dAtA[iNdEx:])
@@ -1167,47 +1193,48 @@ var (
ErrIntOverflowHeartbeat = fmt.Errorf("proto: integer overflow")
)
-func init() { proto.RegisterFile("rpc/heartbeat.proto", fileDescriptor_heartbeat_c48a0290adb87462) }
+func init() { proto.RegisterFile("rpc/heartbeat.proto", fileDescriptor_heartbeat_565332a8a713c8ea) }
-var fileDescriptor_heartbeat_c48a0290adb87462 = []byte{
- // 616 bytes of a gzipped FileDescriptorProto
- 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x9c, 0x53, 0x41, 0x4f, 0xd4, 0x40,
- 0x14, 0x6e, 0xd9, 0x05, 0x65, 0xb6, 0x60, 0x1c, 0x09, 0x36, 0x8b, 0xe9, 0xe2, 0x26, 0xe8, 0x9e,
- 0x5a, 0x83, 0x27, 0xf5, 0xc4, 0x42, 0xa2, 0x84, 0xb8, 0x98, 0x15, 0x38, 0x78, 0x69, 0x66, 0x3b,
- 0x8f, 0x32, 0x81, 0xce, 0x94, 0xe9, 0x94, 0xe0, 0xd1, 0x7f, 0x60, 0x3c, 0x79, 0xf4, 0xe7, 0x70,
- 0xe4, 0x48, 0x3c, 0x10, 0x5d, 0xfe, 0x82, 0x3f, 0xc0, 0x4c, 0xa7, 0x85, 0x82, 0x1c, 0x0c, 0xb7,
- 0x37, 0xef, 0x7d, 0xef, 0xbd, 0xef, 0xbd, 0xef, 0x0d, 0x7a, 0x24, 0xd3, 0x28, 0xd8, 0x03, 0x22,
- 0xd5, 0x08, 0x88, 0xf2, 0x53, 0x29, 0x94, 0xc0, 0x33, 0x91, 0x88, 0xf6, 0xa5, 0x20, 0xd1, 0x9e,
- 0x2f, 0xd3, 0xa8, 0x3d, 0x5f, 0x98, 0xe9, 0x28, 0x48, 0x40, 0x11, 0x4a, 0x14, 0x31, 0xb0, 0xf6,
- 0x5c, 0x2c, 0x62, 0x51, 0x98, 0x81, 0xb6, 0x8c, 0xb7, 0xfb, 0xc5, 0x46, 0xce, 0x10, 0x12, 0xa1,
- 0x60, 0x73, 0x77, 0x37, 0x03, 0x85, 0x9f, 0xa0, 0x29, 0x51, 0x58, 0xae, 0xbd, 0x68, 0xf7, 0x1a,
- 0xfd, 0xe6, 0xc9, 0x79, 0xc7, 0x1a, 0x96, 0x3e, 0xfc, 0x0c, 0xb5, 0x72, 0x1e, 0x81, 0x54, 0x84,
- 0x71, 0xf5, 0xd9, 0x9d, 0xa8, 0x41, 0xea, 0x01, 0xbc, 0x84, 0x5a, 0x09, 0x90, 0x2c, 0x97, 0x40,
- 0x43, 0xa2, 0xdc, 0x46, 0x0d, 0x87, 0xaa, 0xc0, 0x8a, 0x7a, 0xdd, 0xfc, 0xfe, 0xa3, 0x63, 0x75,
- 0xff, 0x34, 0x50, 0xeb, 0x03, 0xe3, 0xf1, 0x10, 0x0e, 0x73, 0xc8, 0x14, 0x76, 0x51, 0x33, 0x65,
- 0x3c, 0x2e, 0x08, 0x4c, 0x97, 0x59, 0x85, 0x07, 0xbf, 0xba, 0x24, 0xa7, 0x3b, 0xb7, 0x96, 0x17,
- 0xfc, 0x6b, 0xb3, 0xfb, 0xf5, 0x49, 0x6e, 0x30, 0x5f, 0x42, 0x2d, 0x21, 0x59, 0xcc, 0x78, 0x48,
- 0x28, 0x95, 0x05, 0xa3, 0xaa, 0x36, 0x32, 0x81, 0x15, 0x4a, 0x25, 0x7e, 0x83, 0x1e, 0x97, 0xb0,
- 0x84, 0x1c, 0x87, 0x26, 0x37, 0xe4, 0x84, 0x8b, 0xcc, 0x6d, 0xd6, 0x86, 0x98, 0x33, 0xa0, 0xf7,
- 0xe4, 0xd8, 0x34, 0x1b, 0x68, 0x04, 0x4e, 0xd1, 0xc3, 0x32, 0x39, 0x3a, 0xc8, 0x33, 0x05, 0x32,
- 0x64, 0xd4, 0x9d, 0x5c, 0xb4, 0x7b, 0x4e, 0x7f, 0xed, 0xe7, 0x79, 0xe7, 0x65, 0xcc, 0xd4, 0x5e,
- 0x3e, 0xf2, 0x23, 0x91, 0x04, 0x97, 0xbc, 0xe9, 0xe8, 0xca, 0x0e, 0xd2, 0xfd, 0x38, 0xc8, 0x15,
- 0x3b, 0x08, 0xf2, 0x9c, 0x51, 0x7f, 0x7b, 0x7b, 0x7d, 0x6d, 0x7c, 0xde, 0x99, 0x5e, 0x35, 0xc5,
- 0xd6, 0xd7, 0x86, 0x0f, 0x4c, 0xf9, 0xca, 0x41, 0xf1, 0x5b, 0x34, 0x9b, 0x81, 0x3c, 0x02, 0x19,
- 0x1e, 0x81, 0xcc, 0x98, 0xe0, 0xee, 0x54, 0xb1, 0x98, 0x76, 0x7d, 0x31, 0xe6, 0x1e, 0xfc, 0x1d,
- 0x83, 0x28, 0x27, 0x98, 0x31, 0x79, 0xa5, 0x13, 0x1f, 0xa2, 0x59, 0x45, 0x64, 0xac, 0x87, 0x15,
- 0x14, 0x34, 0xef, 0x7b, 0x8b, 0x76, 0x6f, 0xb2, 0xbf, 0xa1, 0xc1, 0xff, 0xcd, 0xbd, 0x6a, 0x35,
- 0x10, 0x14, 0x0a, 0xee, 0xce, 0x56, 0x51, 0xd4, 0xbc, 0x87, 0x8e, 0xba, 0x7a, 0xd1, 0xee, 0xb7,
- 0x09, 0xe4, 0x18, 0xd9, 0xb3, 0x54, 0xf0, 0x0c, 0x0a, 0xdd, 0xc5, 0x3f, 0xba, 0x0b, 0x1e, 0x6b,
- 0xf1, 0xca, 0x31, 0x15, 0x4b, 0xe0, 0xda, 0xd9, 0x21, 0x13, 0xd8, 0x62, 0x09, 0xdc, 0xb2, 0x8d,
- 0xc6, 0xdd, 0xb6, 0xf1, 0x1c, 0x39, 0x95, 0x82, 0x9c, 0x24, 0x50, 0x48, 0x5f, 0x31, 0x6a, 0x95,
- 0x91, 0x01, 0x49, 0x00, 0x6f, 0xa2, 0xa7, 0x94, 0x65, 0x64, 0x74, 0x00, 0x61, 0x3d, 0x41, 0xf7,
- 0x67, 0xbb, 0x2c, 0x22, 0x4a, 0x93, 0xd0, 0x17, 0x70, 0xbf, 0xcc, 0xf6, 0x4a, 0xf8, 0xea, 0x55,
- 0x91, 0x9d, 0x1a, 0x76, 0x79, 0x80, 0xa6, 0xdf, 0x55, 0xff, 0x1b, 0xaf, 0xa0, 0xa6, 0x5e, 0x10,
- 0x6e, 0xdf, 0x38, 0xf3, 0xda, 0x67, 0x69, 0x2f, 0xdc, 0x1a, 0x33, 0x1b, 0xed, 0x5a, 0xcb, 0x80,
- 0xe6, 0xb7, 0x20, 0x53, 0x8c, 0xc7, 0x97, 0x65, 0x3f, 0x2a, 0x09, 0x24, 0xc1, 0x1b, 0x08, 0x69,
- 0x6c, 0xf9, 0xba, 0x7b, 0x8b, 0x9e, 0xfd, 0xc2, 0xee, 0x2f, 0x9d, 0xfc, 0xf6, 0xac, 0x93, 0xb1,
- 0x67, 0x9f, 0x8e, 0x3d, 0xfb, 0x6c, 0xec, 0xd9, 0xbf, 0xc6, 0x9e, 0xfd, 0xf5, 0xc2, 0xb3, 0x4e,
- 0x2f, 0x3c, 0xeb, 0xec, 0xc2, 0xb3, 0x3e, 0x35, 0x64, 0x1a, 0xfd, 0x0d, 0x00, 0x00, 0xff, 0xff,
- 0xfb, 0xa1, 0xf8, 0xf1, 0xc0, 0x04, 0x00, 0x00,
+var fileDescriptor_heartbeat_565332a8a713c8ea = []byte{
+ // 635 bytes of a gzipped FileDescriptorProto
+ 0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xac, 0x54, 0x41, 0x4f, 0xd4, 0x40,
+ 0x14, 0x6e, 0xd9, 0x05, 0x61, 0x76, 0xc1, 0x38, 0x12, 0x6c, 0x16, 0xd3, 0xc5, 0x4d, 0xd0, 0x3d,
+ 0xb5, 0x06, 0x4f, 0xea, 0x89, 0x85, 0x44, 0x09, 0x71, 0x31, 0x2b, 0x70, 0xf0, 0xd2, 0xcc, 0x76,
+ 0x1e, 0x65, 0x02, 0xed, 0x94, 0xe9, 0x94, 0xe0, 0xd1, 0x7f, 0x60, 0x3c, 0x79, 0xf4, 0xe7, 0x70,
+ 0xe4, 0x48, 0x3c, 0x10, 0x5d, 0x0e, 0xfe, 0x0d, 0x33, 0x9d, 0x29, 0x5b, 0x90, 0x83, 0x21, 0xde,
+ 0xde, 0xbc, 0xf7, 0xbd, 0xf7, 0x7d, 0xef, 0xed, 0xd7, 0x45, 0x0f, 0x45, 0x1a, 0xfa, 0xfb, 0x40,
+ 0x84, 0x1c, 0x02, 0x91, 0x5e, 0x2a, 0xb8, 0xe4, 0x78, 0x36, 0xe4, 0xe1, 0x81, 0xe0, 0x24, 0xdc,
+ 0xf7, 0x44, 0x1a, 0xb6, 0x16, 0x8a, 0x30, 0x1d, 0xfa, 0x31, 0x48, 0x42, 0x89, 0x24, 0x1a, 0xd6,
+ 0x9a, 0x8f, 0x78, 0xc4, 0x8b, 0xd0, 0x57, 0x91, 0xce, 0x76, 0x3e, 0xdb, 0xa8, 0x39, 0x80, 0x98,
+ 0x4b, 0xd8, 0xda, 0xdb, 0xcb, 0x40, 0xe2, 0xc7, 0x68, 0x8a, 0x17, 0x91, 0x63, 0x2f, 0xd9, 0xdd,
+ 0x5a, 0xaf, 0x7e, 0x7a, 0xd1, 0xb6, 0x06, 0x26, 0x87, 0x9f, 0xa2, 0x46, 0x9e, 0x84, 0x20, 0x24,
+ 0x61, 0x89, 0xfc, 0xe4, 0x4c, 0x54, 0x20, 0xd5, 0x02, 0x5e, 0x46, 0x8d, 0x18, 0x48, 0x96, 0x0b,
+ 0xa0, 0x01, 0x91, 0x4e, 0xad, 0x82, 0x43, 0x65, 0x61, 0x55, 0xbe, 0xaa, 0x7f, 0xfb, 0xde, 0xb6,
+ 0x3a, 0xbf, 0xeb, 0xa8, 0xf1, 0x9e, 0x25, 0xd1, 0x00, 0x8e, 0x72, 0xc8, 0x24, 0x76, 0x50, 0x3d,
+ 0x65, 0x49, 0x54, 0x08, 0x98, 0x31, 0x5d, 0x45, 0x06, 0xbf, 0xbc, 0x12, 0xa7, 0x98, 0x1b, 0x2b,
+ 0x8b, 0xde, 0xb5, 0xdd, 0xbd, 0xea, 0x26, 0x37, 0x94, 0x2f, 0xa3, 0x06, 0x17, 0x2c, 0x62, 0x49,
+ 0x40, 0x28, 0x15, 0x85, 0xa2, 0x72, 0x36, 0xd2, 0x85, 0x55, 0x4a, 0x05, 0x7e, 0x8d, 0x1e, 0x19,
+ 0x58, 0x4c, 0x4e, 0x02, 0xdd, 0x1b, 0x24, 0x24, 0xe1, 0x99, 0x53, 0xaf, 0x2c, 0x31, 0xaf, 0x41,
+ 0xef, 0xc8, 0x89, 0x26, 0xeb, 0x2b, 0x04, 0x4e, 0xd1, 0x03, 0xd3, 0x1c, 0x1e, 0xe6, 0x99, 0x04,
+ 0x11, 0x30, 0xea, 0x4c, 0x2e, 0xd9, 0xdd, 0x66, 0x6f, 0xfd, 0xc7, 0x45, 0xfb, 0x45, 0xc4, 0xe4,
+ 0x7e, 0x3e, 0xf4, 0x42, 0x1e, 0xfb, 0x57, 0xba, 0xe9, 0x70, 0x1c, 0xfb, 0xe9, 0x41, 0xe4, 0xe7,
+ 0x92, 0x1d, 0xfa, 0x79, 0xce, 0xa8, 0xb7, 0xb3, 0xb3, 0xb1, 0x3e, 0xba, 0x68, 0xcf, 0xac, 0xe9,
+ 0x61, 0x1b, 0xeb, 0x83, 0xfb, 0x7a, 0x7c, 0x99, 0xa0, 0xf8, 0x0d, 0x9a, 0xcb, 0x40, 0x1c, 0x83,
+ 0x08, 0x8e, 0x41, 0x64, 0x8c, 0x27, 0xce, 0x54, 0x71, 0x98, 0x56, 0xf5, 0x30, 0xda, 0x0f, 0xde,
+ 0xae, 0x46, 0x98, 0x0d, 0x66, 0x75, 0x9f, 0x49, 0xe2, 0x23, 0x34, 0x27, 0x89, 0x88, 0xd4, 0xb2,
+ 0x9c, 0x82, 0xd2, 0x7d, 0x6f, 0xc9, 0xee, 0x4e, 0xf6, 0x36, 0x15, 0xf8, 0x9f, 0xb5, 0x97, 0x54,
+ 0x7d, 0x4e, 0xa1, 0xd0, 0xde, 0xdc, 0x2e, 0x86, 0xea, 0xf7, 0xa0, 0x29, 0xc7, 0x2f, 0xaa, 0x28,
+ 0xcd, 0xb5, 0x4a, 0xca, 0xe9, 0xff, 0x42, 0xb9, 0x55, 0x0c, 0x2d, 0x29, 0xf9, 0xf8, 0x45, 0x3b,
+ 0x5f, 0x27, 0x50, 0x53, 0x3b, 0x2d, 0x4b, 0x79, 0x92, 0x41, 0x61, 0x35, 0xfe, 0x97, 0xd5, 0x78,
+ 0x12, 0x29, 0xbf, 0x98, 0xcb, 0x4a, 0x16, 0xc3, 0x35, 0xa7, 0x23, 0x5d, 0xd8, 0x66, 0x31, 0xdc,
+ 0xf2, 0x03, 0xd4, 0xee, 0xf6, 0x03, 0x3c, 0x43, 0xcd, 0xd2, 0x34, 0x09, 0x89, 0xa1, 0x70, 0x5b,
+ 0xa9, 0xa8, 0x61, 0x2a, 0x7d, 0x12, 0x03, 0xde, 0x42, 0x4f, 0x28, 0xcb, 0xc8, 0xf0, 0x10, 0x82,
+ 0x6a, 0x83, 0xe2, 0x67, 0x7b, 0x2c, 0x24, 0x52, 0x89, 0x50, 0xa6, 0x9b, 0x36, 0xdd, 0xae, 0x81,
+ 0xaf, 0x8d, 0x87, 0xec, 0x56, 0xb0, 0x2b, 0x7d, 0x34, 0xf3, 0xb6, 0xfc, 0x4b, 0xc1, 0xab, 0xa8,
+ 0xae, 0x0e, 0x84, 0x5b, 0x37, 0xbe, 0xac, 0xca, 0xf7, 0xd9, 0x5a, 0xbc, 0xb5, 0xa6, 0x2f, 0xda,
+ 0xb1, 0x56, 0x00, 0x2d, 0x6c, 0x43, 0x26, 0x59, 0x12, 0x5d, 0x8d, 0xfd, 0x20, 0x05, 0x90, 0x18,
+ 0x6f, 0x22, 0xa4, 0xb0, 0xe6, 0x75, 0x77, 0x8a, 0xae, 0xfd, 0xdc, 0xee, 0x2d, 0x9f, 0xfe, 0x72,
+ 0xad, 0xd3, 0x91, 0x6b, 0x9f, 0x8d, 0x5c, 0xfb, 0x7c, 0xe4, 0xda, 0x3f, 0x47, 0xae, 0xfd, 0xe5,
+ 0xd2, 0xb5, 0xce, 0x2e, 0x5d, 0xeb, 0xfc, 0xd2, 0xb5, 0x3e, 0xd6, 0x44, 0x1a, 0xfe, 0x09, 0x00,
+ 0x00, 0xff, 0xff, 0x72, 0x69, 0xb3, 0x22, 0x33, 0x05, 0x00, 0x00,
}
diff --git a/pkg/rpc/heartbeat.proto b/pkg/rpc/heartbeat.proto
index 6b7050c9c47d..7da9f6f4810d 100644
--- a/pkg/rpc/heartbeat.proto
+++ b/pkg/rpc/heartbeat.proto
@@ -50,11 +50,17 @@ message PingRequest {
(gogoproto.customname) = "ClusterID",
(gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/util/uuid.UUID"];
optional roachpb.Version server_version = 6 [(gogoproto.nullable) = false];
- // Node ID to prevent connections from being misrouted to an invalid node inside the cluster.
+ // NodeID the originator of the request wishes to connect to.
+ // This helps prevent connections from being misrouted when addresses are reused.
optional int32 target_node_id = 7 [
(gogoproto.nullable) = false,
(gogoproto.customname) = "TargetNodeID",
(gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/roachpb.NodeID"];
+ // NodeID of the originator of the PingRequest.
+ optional int32 origin_node_id = 8 [
+ (gogoproto.nullable) = false,
+ (gogoproto.customname) = "OriginNodeID",
+ (gogoproto.customtype) = "github.com/cockroachdb/cockroach/pkg/roachpb.NodeID"];
}
// A PingResponse contains the echoed ping request string.
|
51b7e626a0621f55c4781693504cd618c7c5e7ef
|
2022-12-05 15:49:31
|
Erik Grinaker
|
roachtest: add `failover/non-system/blackhole` tests
| false
|
add `failover/non-system/blackhole` tests
|
roachtest
|
diff --git a/pkg/cmd/roachtest/tests/failover.go b/pkg/cmd/roachtest/tests/failover.go
index b1078e831242..af145ebaabfc 100644
--- a/pkg/cmd/roachtest/tests/failover.go
+++ b/pkg/cmd/roachtest/tests/failover.go
@@ -12,45 +12,54 @@ package tests
import (
"context"
+ gosql "database/sql"
"fmt"
"time"
+ "github.com/cockroachdb/cockroach/pkg/base"
"github.com/cockroachdb/cockroach/pkg/cmd/roachtest/cluster"
"github.com/cockroachdb/cockroach/pkg/cmd/roachtest/option"
"github.com/cockroachdb/cockroach/pkg/cmd/roachtest/registry"
"github.com/cockroachdb/cockroach/pkg/cmd/roachtest/spec"
"github.com/cockroachdb/cockroach/pkg/cmd/roachtest/test"
"github.com/cockroachdb/cockroach/pkg/roachprod/install"
+ "github.com/cockroachdb/cockroach/pkg/util/randutil"
"github.com/stretchr/testify/require"
)
func registerFailover(r registry.Registry) {
- r.Add(registry.TestSpec{
- Name: "failover/non-system/crash",
- Owner: registry.OwnerKV,
- Timeout: time.Hour,
- Cluster: r.MakeClusterSpec(7, spec.CPU(4)),
- Run: runFailoverNonSystemCrash,
- })
+ for _, failureMode := range []failureMode{
+ &failureModeBlackhole{},
+ &failureModeBlackholeRecv{},
+ &failureModeBlackholeSend{},
+ &failureModeCrash{},
+ } {
+ failureMode := failureMode // pin loop variable
+ r.Add(registry.TestSpec{
+ Name: fmt.Sprintf("failover/non-system/%s", failureMode),
+ Owner: registry.OwnerKV,
+ Timeout: 20 * time.Minute,
+ Cluster: r.MakeClusterSpec(7, spec.CPU(4)),
+ Run: func(ctx context.Context, t test.Test, c cluster.Cluster) {
+ runFailoverNonSystem(ctx, t, c, failureMode)
+ },
+ })
+ }
}
-// runFailoverNonSystemCrash benchmarks the maximum duration of range
-// unavailability following a leaseholder crash with only non-system ranges. It
-// tests the simplest possible failure:
-//
-// - A process crash, where the host/OS remains available (in particular, the
-// TCP/IP stack is responsive and sends immediate RST packets to peers).
+// runFailoverNonSystem benchmarks the maximum duration of range unavailability
+// following a leaseholder failure with only non-system ranges.
//
-// - No system ranges located on the crashed node.
+// - No system ranges located on the failed node.
//
-// - SQL clients do not connect to the crashed node.
+// - SQL clients do not connect to the failed node.
//
// - The workload consists of individual point reads and writes.
//
// Since the lease unavailability is probabilistic, depending e.g. on the time
-// since the last heartbeat and other variables, we run 9 crashes and record the
-// pMax latency to find the upper bound on unavailability. We expect this
-// worse-case latency to be slightly larger than the lease interval (9s), to
+// since the last heartbeat and other variables, we run 9 failures and record
+// the pMax latency to find the upper bound on unavailability. We expect this
+// worst-case latency to be slightly larger than the lease interval (9s), to
// account for lease acquisition and retry latencies. We do not assert this, but
// instead export latency histograms for graphing.
//
@@ -61,19 +70,27 @@ func registerFailover(r registry.Registry) {
// n7: Workload runner.
//
// The test runs a kv50 workload with batch size 1, using 256 concurrent workers
-// directed at n1-n3 with a rate of 2048 reqs/s. n4-n6 are killed and restarted
-// in order, with 30 seconds between each operation, for 3 cycles totaling 9
-// crashes.
-func runFailoverNonSystemCrash(ctx context.Context, t test.Test, c cluster.Cluster) {
- c.Put(ctx, t.Cockroach(), "./cockroach")
-
+// directed at n1-n3 with a rate of 2048 reqs/s. n4-n6 fail and recover in
+// order, with 30 seconds between each operation, for 3 cycles totaling 9
+// failures.
+func runFailoverNonSystem(
+ ctx context.Context, t test.Test, c cluster.Cluster, failureMode failureMode,
+) {
require.Equal(t, 7, c.Spec().NodeCount)
+ rng, _ := randutil.NewTestRand()
+
// Create cluster.
opts := option.DefaultStartOpts()
settings := install.MakeClusterSettings()
+ c.Put(ctx, t.Cockroach(), "./cockroach")
c.Start(ctx, t.L(), opts, settings, c.Range(1, 6))
+ if f, ok := failureMode.(*failureModeCrash); ok {
+ f.startOpts = opts
+ f.startSettings = settings
+ }
+
conn := c.Conn(ctx, t.L(), 1)
defer conn.Close()
@@ -112,33 +129,11 @@ func runFailoverNonSystemCrash(ctx context.Context, t test.Test, c cluster.Clust
// n4-n6, so we do it ourselves. Precreating the database/range and moving it
// to the correct nodes first is not sufficient, since workload will spread
// the ranges across all nodes regardless.
- relocateRanges := func(predicate string, from, to []int) {
- require.NotEmpty(t, predicate)
- var count int
- for _, source := range from {
- where := fmt.Sprintf("%s AND %d = ANY(replicas)", predicate, source)
- for {
- require.NoError(t, conn.QueryRowContext(ctx,
- `SELECT count(*) FROM crdb_internal.ranges WHERE `+where).Scan(&count))
- if count == 0 {
- break
- }
- t.Status(fmt.Sprintf("moving %d ranges off of n%d (%s)", count, source, predicate))
- for _, target := range to {
- _, err = conn.ExecContext(ctx, `ALTER RANGE RELOCATE FROM $1::int TO $2::int FOR `+
- `SELECT range_id FROM crdb_internal.ranges WHERE `+where,
- source, target)
- require.NoError(t, err)
- }
- time.Sleep(time.Second)
- }
- }
- }
- relocateRanges(`database_name = 'kv'`, []int{1, 2, 3}, []int{4, 5, 6})
+ relocateRanges(t, ctx, conn, `database_name = 'kv'`, []int{1, 2, 3}, []int{4, 5, 6})
// Start workload on n7, using n1-n3 as gateways. Run it for 10 minutes, since
- // we take ~1 minute to kill and restart each node, and we do 3 cycles of
- // killing the 3 nodes in order.
+ // we take ~1 minute to fail and recover each node, and we do 3 cycles of each
+ // of the 3 nodes in order.
t.Status("running workload")
m := c.NewMonitor(ctx, c.Range(1, 6))
m.Go(func(ctx context.Context) error {
@@ -149,8 +144,13 @@ func runFailoverNonSystemCrash(ctx context.Context, t test.Test, c cluster.Clust
return nil
})
- // Start a worker to kill and restart n4-n6 in order, for 3 cycles.
+ // Start a worker to fail and recover n4-n6 in order.
+ defer failureMode.Cleanup(ctx, t, c)
+
m.Go(func(ctx context.Context) error {
+ var raftCfg base.RaftConfig
+ raftCfg.SetDefaults()
+
ticker := time.NewTicker(30 * time.Second)
defer ticker.Stop()
@@ -162,25 +162,180 @@ func runFailoverNonSystemCrash(ctx context.Context, t test.Test, c cluster.Clust
return ctx.Err()
}
+ randTimer := time.After(randutil.RandDuration(rng, raftCfg.RangeLeaseRenewalDuration()))
+
// Ranges may occasionally escape their constraints. Move them
// to where they should be.
- relocateRanges(`database_name = 'kv'`, []int{1, 2, 3}, []int{4, 5, 6})
- relocateRanges(`database_name != 'kv'`, []int{node}, []int{1, 2, 3})
+ relocateRanges(t, ctx, conn, `database_name = 'kv'`, []int{1, 2, 3}, []int{4, 5, 6})
+ relocateRanges(t, ctx, conn, `database_name != 'kv'`, []int{node}, []int{1, 2, 3})
- t.Status(fmt.Sprintf("killing n%d", node))
- m.ExpectDeath()
- c.Stop(ctx, t.L(), option.DefaultStopOpts(), c.Node(node)) // uses SIGKILL
+ // Randomly sleep up to the lease renewal interval, to vary the time
+ // between the last lease renewal and the failure. We start the timer
+ // before the range relocation above to run them concurrently.
+ select {
+ case <-randTimer:
+ case <-ctx.Done():
+ }
+
+ t.Status(fmt.Sprintf("failing n%d (%s)", node, failureMode))
+ if failureMode.ExpectDeath() {
+ m.ExpectDeath()
+ }
+ failureMode.Fail(ctx, t, c, node)
select {
case <-ticker.C:
case <-ctx.Done():
return ctx.Err()
}
- t.Status(fmt.Sprintf("restarting n%d", node))
- c.Start(ctx, t.L(), opts, settings, c.Node(node))
+
+ t.Status(fmt.Sprintf("recovering n%d (%s)", node, failureMode))
+ failureMode.Recover(ctx, t, c, node)
}
}
return nil
})
m.Wait()
}
+
+// failureMode fails and recovers a given node in some particular way.
+type failureMode interface {
+ fmt.Stringer
+
+ // Fail fails the given node.
+ Fail(ctx context.Context, t test.Test, c cluster.Cluster, nodeID int)
+
+ // Recover recovers the given node.
+ Recover(ctx context.Context, t test.Test, c cluster.Cluster, nodeID int)
+
+ // Cleanup cleans up when the test exits. This is needed e.g. when the cluster
+ // is reused by a different test.
+ Cleanup(ctx context.Context, t test.Test, c cluster.Cluster)
+
+ // ExpectDeath returns true if the node is expected to die on failure.
+ ExpectDeath() bool
+}
+
+// failureModeCrash is a process crash where the TCP/IP stack remains responsive
+// and sends immediate RST packets to peers.
+type failureModeCrash struct {
+ startOpts option.StartOpts
+ startSettings install.ClusterSettings
+}
+
+func (f *failureModeCrash) String() string { return "crash" }
+func (f *failureModeCrash) ExpectDeath() bool { return true }
+
+func (f *failureModeCrash) Fail(ctx context.Context, t test.Test, c cluster.Cluster, nodeID int) {
+ c.Stop(ctx, t.L(), option.DefaultStopOpts(), c.Node(nodeID)) // uses SIGKILL
+}
+
+func (f *failureModeCrash) Recover(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Start(ctx, t.L(), f.startOpts, f.startSettings, c.Node(nodeID))
+}
+
+func (f *failureModeCrash) Cleanup(ctx context.Context, t test.Test, c cluster.Cluster) {
+}
+
+// failureModeBlackhole is a network outage where all inbound and outbound
+// TCP/IP packets to/from port 26257 are dropped, causing network hangs and
+// timeouts.
+type failureModeBlackhole struct{}
+
+func (f *failureModeBlackhole) String() string { return "blackhole" }
+func (f *failureModeBlackhole) ExpectDeath() bool { return false }
+
+func (f *failureModeBlackhole) Fail(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -A INPUT -m multiport -p tcp --ports 26257 -j DROP`)
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -A OUTPUT -m multiport -p tcp --ports 26257 -j DROP`)
+}
+
+func (f *failureModeBlackhole) Recover(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -F`)
+}
+
+func (f *failureModeBlackhole) Cleanup(ctx context.Context, t test.Test, c cluster.Cluster) {
+ c.Run(ctx, c.All(), `sudo iptables -F`)
+}
+
+// failureModeBlackholeRecv is an asymmetric network outage where all inbound
+// TCP/IP packets to port 26257 are dropped, causing network hangs and timeouts.
+// The node can still send traffic on outbound connections.
+type failureModeBlackholeRecv struct{}
+
+func (f *failureModeBlackholeRecv) String() string { return "blackhole-recv" }
+func (f *failureModeBlackholeRecv) ExpectDeath() bool { return false }
+
+func (f *failureModeBlackholeRecv) Fail(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -A INPUT -p tcp --dport 26257 -j DROP`)
+}
+
+func (f *failureModeBlackholeRecv) Recover(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -F`)
+}
+
+func (f *failureModeBlackholeRecv) Cleanup(ctx context.Context, t test.Test, c cluster.Cluster) {
+ c.Run(ctx, c.All(), `sudo iptables -F`)
+}
+
+// failureModeBlackholeSend is an asymmetric network outage where all outbound
+// TCP/IP packets to port 26257 are dropped, causing network hangs and
+// timeouts. The node can still receive traffic on inbound connections.
+type failureModeBlackholeSend struct{}
+
+func (f *failureModeBlackholeSend) String() string { return "blackhole-send" }
+func (f *failureModeBlackholeSend) ExpectDeath() bool { return false }
+
+func (f *failureModeBlackholeSend) Fail(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -A OUTPUT -p tcp --dport 26257 -j DROP`)
+}
+
+func (f *failureModeBlackholeSend) Recover(
+ ctx context.Context, t test.Test, c cluster.Cluster, nodeID int,
+) {
+ c.Run(ctx, c.Node(nodeID), `sudo iptables -F`)
+}
+
+func (f *failureModeBlackholeSend) Cleanup(ctx context.Context, t test.Test, c cluster.Cluster) {
+ c.Run(ctx, c.All(), `sudo iptables -F`)
+}
+
+// relocateRanges relocates all ranges matching the given predicate from a set
+// of nodes to a different set of nodes. Moves are attempted sequentially from
+// each source onto each target, and errors are retried indefinitely.
+func relocateRanges(
+ t test.Test, ctx context.Context, conn *gosql.DB, predicate string, from, to []int,
+) {
+ require.NotEmpty(t, predicate)
+ var count int
+ for _, source := range from {
+ where := fmt.Sprintf("%s AND %d = ANY(replicas)", predicate, source)
+ for {
+ require.NoError(t, conn.QueryRowContext(ctx,
+ `SELECT count(*) FROM crdb_internal.ranges WHERE `+where).Scan(&count))
+ if count == 0 {
+ break
+ }
+ t.Status(fmt.Sprintf("moving %d ranges off of n%d (%s)", count, source, predicate))
+ for _, target := range to {
+ _, err := conn.ExecContext(ctx, `ALTER RANGE RELOCATE FROM $1::int TO $2::int FOR `+
+ `SELECT range_id FROM crdb_internal.ranges WHERE `+where,
+ source, target)
+ require.NoError(t, err)
+ }
+ time.Sleep(time.Second)
+ }
+ }
+}
|
5f2f935d7b072e84a90915196ab3aa3638219cf9
|
2021-01-09 02:05:10
|
Ricky Stewart
|
build: filter out debug logging for `bazel query`
| false
|
filter out debug logging for `bazel query`
|
build
|
diff --git a/.bazelrc b/.bazelrc
index a98f4a231fa0..d77f5de5674a 100644
--- a/.bazelrc
+++ b/.bazelrc
@@ -1,3 +1,4 @@
# TODO(irfansharif): We should fold this into `dev` instead (#56965).
build --ui_event_filters=-DEBUG
+query --ui_event_filters=-DEBUG
|
9cb79c6427e6abedcf8a24fb6c460dcda824ddcd
|
2016-06-08 21:23:39
|
Tristan Rice
|
storage: Define the range lease duration as 3 times the raft election cycle to prevent any issues from occurring when the `--raft-tick-interval` flag is set.
| false
|
Define the range lease duration as 3 times the raft election cycle to prevent any issues from occurring when the `--raft-tick-interval` flag is set.
|
storage
|
diff --git a/storage/client_raft_test.go b/storage/client_raft_test.go
index 74cdf52e3060..1f3713ac26ab 100644
--- a/storage/client_raft_test.go
+++ b/storage/client_raft_test.go
@@ -1596,7 +1596,7 @@ func TestLeaderRemoveSelf(t *testing.T) {
clock := mtc.clocks[0]
header := roachpb.Header{}
header.Timestamp = clock.Update(clock.Now().Add(
- storage.LeaderLeaseExpiration(clock), 0))
+ storage.LeaderLeaseExpiration(mtc.stores[0], clock), 0))
// Expect get a RangeNotFoundError.
_, pErr := client.SendWrappedWith(rg1(mtc.stores[0]), nil, header, &getArgs)
diff --git a/storage/client_test.go b/storage/client_test.go
index 089351640ad0..beeafcc41363 100644
--- a/storage/client_test.go
+++ b/storage/client_test.go
@@ -781,7 +781,7 @@ func (m *multiTestContext) waitForValues(key roachpb.Key, expected []int64) {
// future that current leader leases are expired. Useful for tests which modify
// replica sets.
func (m *multiTestContext) expireLeaderLeases() {
- m.manualClock.Increment(storage.LeaderLeaseExpiration(m.clock))
+ m.manualClock.Increment(storage.LeaderLeaseExpiration(m.stores[0], m.clock))
}
// getRaftLeader returns the replica that is the current raft leader for the
diff --git a/storage/replica.go b/storage/replica.go
index 0ae058efdce0..998d4400a059 100644
--- a/storage/replica.go
+++ b/storage/replica.go
@@ -89,15 +89,6 @@ var txnAutoGC = true
const (
raftInitialLogIndex = 10
raftInitialLogTerm = 5
-
- // LeaderLeaseActiveDuration is the duration of the active period of leader
- // leases requested.
- LeaderLeaseActiveDuration = time.Second
- // leaderLeaseRenewalDuration specifies a "time" interval at the
- // end of the active lease interval (i.e. bounded to the right by the
- // start of the stasis period) during which timestamps will trigger an
- // asynchronous renewal of the lease.
- leaderLeaseRenewalDuration = LeaderLeaseActiveDuration / 5
)
// consultsTimestampCacheMethods specifies the set of methods which
@@ -536,7 +527,7 @@ func (r *Replica) requestLeaderLease(timestamp roachpb.Timestamp) <-chan *roachp
pErr := func() *roachpb.Error {
// TODO(tschottdorf): get duration from configuration, either as a
// config flag or, later, dynamically adjusted.
- startStasis := timestamp.Add(int64(LeaderLeaseActiveDuration), 0)
+ startStasis := timestamp.Add(int64(r.store.ctx.leaderLeaseActiveDuration), 0)
expiration := startStasis.Add(int64(r.store.Clock().MaxOffset()), 0)
// Prepare a Raft command to get a leader lease for this replica.
@@ -640,7 +631,7 @@ func (r *Replica) redirectOnOrAcquireLeaderLease(ctx context.Context) *roachpb.E
return roachpb.NewError(r.newNotLeaderError(lease, r.store.StoreID()))
}
if !inFlight && !timestamp.Less(lease.StartStasis.Add(
- -int64(leaderLeaseRenewalDuration), 0)) {
+ -int64(r.store.ctx.leaderLeaseRenewalDuration), 0)) {
if log.V(2) {
log.Warningf("extending lease %s at %s", lease, timestamp)
}
diff --git a/storage/replica_test.go b/storage/replica_test.go
index c30868dc14bc..ba5d79ef624d 100644
--- a/storage/replica_test.go
+++ b/storage/replica_test.go
@@ -87,11 +87,11 @@ const (
// LeaderLeaseExpiration returns an int64 to increment a manual clock with to
// make sure that all active leader leases expire.
-func LeaderLeaseExpiration(clock *hlc.Clock) int64 {
+func LeaderLeaseExpiration(s *Store, clock *hlc.Clock) int64 {
// Due to lease extensions, the remaining interval can be longer than just
// the sum of the offset (=length of stasis period) and the active
// duration, but definitely not by 2x.
- return 2 * int64(LeaderLeaseActiveDuration+clock.MaxOffset())
+ return 2 * int64(s.ctx.leaderLeaseActiveDuration+clock.MaxOffset())
}
// leaseExpiry returns a duration in nanos after which any leader lease the
diff --git a/storage/store.go b/storage/store.go
index 373462132876..75ea69f9a0dd 100644
--- a/storage/store.go
+++ b/storage/store.go
@@ -69,6 +69,14 @@ const (
maxReplicaDescCacheSize = 1000
raftReqBufferSize = 100
+
+ // leaderLeaseRaftElectionTimeoutMultiplier specifies what multiple the leader
+ // lease active duration should be of the raft election timeout.
+ leaderLeaseRaftElectionTimeoutMultiplier = 3
+
+ // leaderLeaseRenewalDivisor specifies what quotient the leader lease renewal
+ // duration should be of the leader lease active time.
+ leaderLeaseRenewalDivisor = 5
)
var changeTypeInternalToRaft = map[roachpb.ReplicaChangeType]raftpb.ConfChangeType{
@@ -397,6 +405,16 @@ type StoreContext struct {
AsyncSnapshotMaxAge time.Duration
TestingKnobs StoreTestingKnobs
+
+ // leaderLeaseActiveDuration is the duration of the active period of leader
+ // leases requested.
+ leaderLeaseActiveDuration time.Duration
+
+ // leaderLeaseRenewalDuration specifies a time interval at the end of the
+ // active lease interval (i.e. bounded to the right by the start of the stasis
+ // period) during which operations will trigger an asynchronous renewal of the
+ // lease.
+ leaderLeaseRenewalDuration time.Duration
}
// StoreTestingKnobs is a part of the context used to control parts of the system.
@@ -627,6 +645,10 @@ func (sc *StoreContext) setDefaults() {
if sc.AsyncSnapshotMaxAge == 0 {
sc.AsyncSnapshotMaxAge = defaultAsyncSnapshotMaxAge
}
+
+ raftElectionTimeout := time.Duration(sc.RaftElectionTimeoutTicks) * sc.RaftTickInterval
+ sc.leaderLeaseActiveDuration = leaderLeaseRaftElectionTimeoutMultiplier * raftElectionTimeout
+ sc.leaderLeaseRenewalDuration = sc.leaderLeaseActiveDuration / leaderLeaseRenewalDivisor
}
// NewStore returns a new instance of a store.
@@ -699,7 +721,7 @@ func (s *Store) DrainLeadership(drain bool) error {
return nil
}
- return util.RetryForDuration(10*LeaderLeaseActiveDuration, func() error {
+ return util.RetryForDuration(10*s.ctx.leaderLeaseActiveDuration, func() error {
var err error
now := s.Clock().Now()
newStoreRangeSet(s).Visit(func(r *Replica) bool {
|
72058a28745c0eed8f816b0197b6ae319f228ec3
|
2024-03-23 21:36:47
|
David Taylor
|
roachprod: improve printing of one-row-per-node queries
| false
|
improve printing of one-row-per-node queries
|
roachprod
|
diff --git a/pkg/roachprod/roachprod.go b/pkg/roachprod/roachprod.go
index 0e2e7a85f3cd..54addf700725 100644
--- a/pkg/roachprod/roachprod.go
+++ b/pkg/roachprod/roachprod.go
@@ -442,17 +442,63 @@ func SQL(
if len(c.Nodes) == 1 {
return c.ExecOrInteractiveSQL(ctx, l, tenantName, tenantInstance, cmdArray)
}
+
results, err := c.ExecSQL(ctx, l, c.Nodes, tenantName, tenantInstance, cmdArray)
if err != nil {
return err
}
- for _, r := range results {
- l.Printf("node %d:\n%s", r.Node, r.CombinedOut)
+ for i, r := range results {
+ printSQLResult(l, i, r, cmdArray)
}
return nil
}
+// printSQLResult does a best-effort attempt to print single-result-row-per-node
+// result-sets gathered from many nodes as one-line-per-node instead of header
+// separated n-line blocks, to improve the overall readability, falling back to
+// normal header-plus-response-block per node otherwise.
+func printSQLResult(l *logger.Logger, i int, r *install.RunResultDetails, args []string) {
+ tableFormatted := false
+ for i, c := range args {
+ if c == "--format=table" || c == "--format" && len(args) > i+1 && args[i+1] == "table" {
+ tableFormatted = true
+ break
+ }
+ }
+
+ singleResultLen, resultLine := 3, 1 // 3 is header, result, empty-trailing.
+ if tableFormatted {
+ // table output adds separator above the result, and a trailing row count.
+ singleResultLen, resultLine = 5, 2
+ }
+ // If we got a header line and zero or one result lines, we can print the
+ // result line as one-line-per-node, rather than a header per node and then
+ // its n result lines, to make the aggregate output more readable. We can
+ // detect this by splitting on newline into only as many lines as we expect,
+ // and seeing if the final piece is empty or has the rest of >1 results in it.
+ lines := strings.SplitN(r.CombinedOut, "\n", singleResultLen)
+ if len(lines) > 0 && lines[len(lines)-1] == "" {
+ if i == 0 { // Print the header line of the results once.
+ fmt.Printf(" %s\n", lines[0])
+ if tableFormatted {
+ fmt.Printf(" %s\n", lines[1])
+ }
+ }
+ // Print the result line if there is one.
+ if len(lines) > resultLine {
+ fmt.Printf("%2d: %s\n", r.Node, lines[resultLine])
+ return
+ }
+ // No result from this node, so print a blank for its ID.
+ fmt.Printf("%2d:\n", r.Node)
+ return
+ }
+ // Just print the roachprod header identifying the node, then the node's whole
+ // response, including its internal header row.
+ l.Printf("node %d:\n%s", r.Node, r.CombinedOut)
+}
+
// IP gets the ip addresses of the nodes in a cluster.
func IP(l *logger.Logger, clusterName string, external bool) ([]string, error) {
if err := LoadClusters(); err != nil {
|
c597758c88d9876728e44d33099574f41525f158
|
2019-11-20 19:34:58
|
Peter Mattis
|
vendor: bump pebble to ef225794302ad35694afd14c8773c3aacd150d39
| false
|
bump pebble to ef225794302ad35694afd14c8773c3aacd150d39
|
vendor
|
diff --git a/Gopkg.lock b/Gopkg.lock
index 7bf4258d8c87..4c852db5519c 100644
--- a/Gopkg.lock
+++ b/Gopkg.lock
@@ -472,7 +472,7 @@
[[projects]]
branch = "master"
- digest = "1:ba8f9d09f7ce85b13edca8794b158a503101477702bb93d26c0d595b1b414b63"
+ digest = "1:c863c18501a5954433e66486057bd844c20374be51803ed74d4fe202acc749a6"
name = "github.com/cockroachdb/pebble"
packages = [
".",
@@ -495,7 +495,7 @@
"vfs",
]
pruneopts = "UT"
- revision = "454f97154cd5bcb3d2a938189eefd8229beda93c"
+ revision = "ef225794302ad35694afd14c8773c3aacd150d39"
[[projects]]
branch = "master"
diff --git a/vendor b/vendor
index ac8a9583925d..361ac676737f 160000
--- a/vendor
+++ b/vendor
@@ -1 +1 @@
-Subproject commit ac8a9583925d5aa97d864f5ec319897f9c9a20bb
+Subproject commit 361ac676737f15b8503a2c3cbf4b9817268c0b1a
|
8b60fec791d1e18cc168e2ec2895b3947a314ab6
|
2023-08-17 22:48:42
|
Faizan Qazi
|
sql: fix use of span after finish in CREATE STATISTICS
| false
|
fix use of span after finish in CREATE STATISTICS
|
sql
|
diff --git a/pkg/sql/create_stats.go b/pkg/sql/create_stats.go
index 77c0f8721578..b8079221efe5 100644
--- a/pkg/sql/create_stats.go
+++ b/pkg/sql/create_stats.go
@@ -84,7 +84,7 @@ func StubTableStats(
}
// createStatsNode is a planNode implemented in terms of a function. The
-// startJob function starts a Job during Start, and the remainder of the
+// runJob function starts a Job during Start, and the remainder of the
// CREATE STATISTICS planning and execution is performed within the jobs
// framework.
type createStatsNode struct {
@@ -97,44 +97,23 @@ type createStatsNode struct {
// If it is false, the flow for create statistics is planned directly; this
// is used when the statement is under EXPLAIN or EXPLAIN ANALYZE.
runAsJob bool
-
- run createStatsRun
-}
-
-// createStatsRun contains the run-time state of createStatsNode during local
-// execution.
-type createStatsRun struct {
- errCh chan error
}
func (n *createStatsNode) startExec(params runParams) error {
telemetry.Inc(sqltelemetry.SchemaChangeCreateCounter("stats"))
- n.run.errCh = make(chan error)
- go func() {
- err := n.startJob(params.ctx)
- select {
- case <-params.ctx.Done():
- case n.run.errCh <- err:
- }
- close(n.run.errCh)
- }()
- return nil
+ return n.runJob(params.ctx)
}
func (n *createStatsNode) Next(params runParams) (bool, error) {
- select {
- case <-params.ctx.Done():
- return false, params.ctx.Err()
- case err := <-n.run.errCh:
- return false, err
- }
+ return false, nil
}
func (*createStatsNode) Close(context.Context) {}
func (*createStatsNode) Values() tree.Datums { return nil }
-// startJob starts a CreateStats job to plan and execute statistics creation.
-func (n *createStatsNode) startJob(ctx context.Context) error {
+// runJob starts a CreateStats job synchronously to plan and execute
+// statistics creation and then waits for the job to complete.
+func (n *createStatsNode) runJob(ctx context.Context) error {
record, err := n.makeJobRecord(ctx)
if err != nil {
return err
@@ -167,8 +146,7 @@ func (n *createStatsNode) startJob(ctx context.Context) error {
if err := job.Start(ctx); err != nil {
return err
}
-
- if err := job.AwaitCompletion(ctx); err != nil {
+ if err = job.AwaitCompletion(ctx); err != nil {
if errors.Is(err, stats.ConcurrentCreateStatsError) {
// Delete the job so users don't see it and get confused by the error.
const stmt = `DELETE FROM system.jobs WHERE id = $1`
@@ -178,9 +156,8 @@ func (n *createStatsNode) startJob(ctx context.Context) error {
log.Warningf(ctx, "failed to delete job: %v", delErr)
}
}
- return err
}
- return nil
+ return err
}
// makeJobRecord creates a CreateStats job record which can be used to plan and
diff --git a/pkg/sql/stats/create_stats_job_test.go b/pkg/sql/stats/create_stats_job_test.go
index 55ea334a782e..7d1b5c2e90e6 100644
--- a/pkg/sql/stats/create_stats_job_test.go
+++ b/pkg/sql/stats/create_stats_job_test.go
@@ -29,6 +29,8 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/rowexec"
"github.com/cockroachdb/cockroach/pkg/testutils"
"github.com/cockroachdb/cockroach/pkg/testutils/jobutils"
+ "github.com/cockroachdb/cockroach/pkg/testutils/serverutils"
+ "github.com/cockroachdb/cockroach/pkg/testutils/skip"
"github.com/cockroachdb/cockroach/pkg/testutils/sqlutils"
"github.com/cockroachdb/cockroach/pkg/testutils/testcluster"
"github.com/cockroachdb/cockroach/pkg/util/encoding"
@@ -36,6 +38,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/util/log"
"github.com/cockroachdb/cockroach/pkg/util/retry"
"github.com/cockroachdb/errors"
+ "github.com/stretchr/testify/require"
)
// TestCreateStatsControlJob tests that PAUSE JOB, RESUME JOB, and CANCEL JOB
@@ -122,6 +125,55 @@ func TestCreateStatsControlJob(t *testing.T) {
})
}
+func TestCreateStatisticsCanBeCancelled(t *testing.T) {
+ defer leaktest.AfterTest(t)()
+ defer log.Scope(t).Close(t)
+ skip.UnderStress(t, "test can be slow to quiesce because of filter")
+
+ var allowRequest chan struct{}
+
+ var serverArgs base.TestServerArgs
+ filter, setTableID := createStatsRequestFilter(&allowRequest)
+ serverArgs.Knobs.JobsTestingKnobs = jobs.NewTestingKnobsWithShortIntervals()
+ serverArgs.Knobs.Store = &kvserver.StoreTestingKnobs{
+ TestingRequestFilter: filter,
+ }
+
+ ctx := context.Background()
+ tc, conn, _ := serverutils.StartServer(t, serverArgs)
+ defer tc.Stopper().Stop(ctx)
+ sqlDB := sqlutils.MakeSQLRunner(conn)
+
+ sqlDB.Exec(t, `CREATE DATABASE d`)
+ sqlDB.Exec(t, `CREATE TABLE d.t (x INT PRIMARY KEY)`)
+ sqlDB.Exec(t, `INSERT INTO d.t SELECT generate_series(1,1000)`)
+ var tID descpb.ID
+ sqlDB.QueryRow(t, `SELECT 'd.t'::regclass::int`).Scan(&tID)
+ setTableID(tID)
+
+ // Run CREATE STATISTICS and wait for to create the job.
+ allowRequest = make(chan struct{})
+ errCh := make(chan error)
+ go func() {
+ _, err := conn.Exec(`CREATE STATISTICS s1 FROM d.t`)
+ errCh <- err
+ }()
+ allowRequest <- struct{}{}
+ testutils.SucceedsSoon(t, func() error {
+ row := conn.QueryRow("SELECT query_id FROM [SHOW CLUSTER STATEMENTS] WHERE query LIKE 'CREATE STATISTICS%';")
+ var queryID string
+ if err := row.Scan(&queryID); err != nil {
+ return err
+ }
+ _, err := conn.Exec("CANCEL QUERIES VALUES ((SELECT query_id FROM [SHOW CLUSTER STATEMENTS] WHERE query LIKE 'CREATE STATISTICS%'));")
+ return err
+ })
+ err := <-errCh
+ allowRequest <- struct{}{}
+
+ require.ErrorContains(t, err, "pq: query execution canceled")
+}
+
func TestAtMostOneRunningCreateStats(t *testing.T) {
defer leaktest.AfterTest(t)()
defer log.Scope(t).Close(t)
|
53bc9d07788d0eb4a37dcc35c628ba2303e18d15
|
2024-04-03 17:50:07
|
Renato Costa
|
roachprod: add `ssh-keys add` command
| false
|
add `ssh-keys add` command
|
roachprod
|
diff --git a/pkg/cmd/roachprod/BUILD.bazel b/pkg/cmd/roachprod/BUILD.bazel
index c98e5370b102..44bc8da26f02 100644
--- a/pkg/cmd/roachprod/BUILD.bazel
+++ b/pkg/cmd/roachprod/BUILD.bazel
@@ -26,6 +26,7 @@ go_library(
"@com_github_cockroachdb_errors//:errors",
"@com_github_fatih_color//:color",
"@com_github_spf13_cobra//:cobra",
+ "@org_golang_x_crypto//ssh",
"@org_golang_x_exp//maps",
"@org_golang_x_term//:term",
"@org_golang_x_text//language",
diff --git a/pkg/cmd/roachprod/flags.go b/pkg/cmd/roachprod/flags.go
index ffedfd0c701f..686d822d65eb 100644
--- a/pkg/cmd/roachprod/flags.go
+++ b/pkg/cmd/roachprod/flags.go
@@ -94,6 +94,8 @@ var (
"user-password": install.AuthUserPassword,
"user-cert": install.AuthUserCert,
}
+
+ sshKeyUser string
)
func initFlags() {
@@ -281,6 +283,10 @@ func initFlags() {
grafanaDumpCmd.Flags().StringVar(&grafanaDumpDir, "dump-dir", "",
"the absolute path to dump prometheus data to (use the contained 'prometheus-docker-run.sh' to visualize")
+ sshKeysAddCmd.Flags().StringVar(&sshKeyUser, "user", config.OSUser.Username,
+ "the user to be associated with the new key",
+ )
+
jaegerStartCmd.Flags().StringVar(&jaegerConfigNodes, "configure-nodes", "",
"the nodes on which to set the relevant CRDB cluster settings")
diff --git a/pkg/cmd/roachprod/main.go b/pkg/cmd/roachprod/main.go
index 4c27ca787dd8..56f9b5cb0070 100644
--- a/pkg/cmd/roachprod/main.go
+++ b/pkg/cmd/roachprod/main.go
@@ -38,6 +38,7 @@ import (
"github.com/cockroachdb/errors"
"github.com/fatih/color"
"github.com/spf13/cobra"
+ "golang.org/x/crypto/ssh"
"golang.org/x/exp/maps"
"golang.org/x/text/language"
"golang.org/x/text/message"
@@ -1192,7 +1193,7 @@ var grafanaAnnotationCmd = &cobra.Command{
Long: fmt.Sprintf(`Adds an annotation to the specified grafana instance
--secure indicates if the grafana instance needs an authentication token to connect
-to. If set, a service account json and audience will be read in from the environment
+to. If set, a service account json and audience will be read in from the environment
variables %s and %s to attempt authentication through google IDP.
--tags specifies the tags the annotation should have.
@@ -1200,7 +1201,7 @@ variables %s and %s to attempt authentication through google IDP.
--dashboard-uid specifies the dashboard you want the annotation to be created in. If
left empty, creates the annotation in the organization instead.
---time-range can be used to specify in epoch millisecond time the annotation's timestamp.
+--time-range can be used to specify in epoch millisecond time the annotation's timestamp.
If left empty, creates the annotation at the current time. If only start-time is specified,
creates an annotation at start-time. If both start-time and end-time are specified,
creates an annotation over time range.
@@ -1556,9 +1557,37 @@ var sshKeysListCmd = &cobra.Command{
}),
}
+var sshKeysAddCmd = &cobra.Command{
+ Use: "add <public-key-path> [--user user]",
+ Short: "add a new SSH public key to the set of keys installed on clusters managed by roachprod",
+ Args: cobra.ExactArgs(1),
+ Run: wrap(func(cmd *cobra.Command, args []string) error {
+ sshKeyPath := args[0]
+ pkBytes, err := os.ReadFile(sshKeyPath)
+ if err != nil {
+ return fmt.Errorf("error reading public key file: %w", err)
+ }
+
+ pubkey, comment, _, _, err := ssh.ParseAuthorizedKey(pkBytes)
+ if err != nil {
+ return fmt.Errorf("error parsing public key: %w", err)
+ }
+
+ ak := gce.AuthorizedKey{
+ User: sshKeyUser,
+ Key: pubkey,
+ Comment: comment,
+ }
+
+ fmt.Printf("Adding new public key for user %s...\n", ak.User)
+ return gce.AddUserAuthorizedKey(ak)
+ }),
+}
+
var _ = func() struct{} {
sshKeysCmd.AddCommand(
sshKeysListCmd,
+ sshKeysAddCmd,
)
return struct{}{}
diff --git a/pkg/roachprod/vm/gce/utils.go b/pkg/roachprod/vm/gce/utils.go
index 1ebaf84b5e9f..6d2dde0d336d 100644
--- a/pkg/roachprod/vm/gce/utils.go
+++ b/pkg/roachprod/vm/gce/utils.go
@@ -354,6 +354,10 @@ type AuthorizedKey struct {
// always displayed.
func (k AuthorizedKey) Format(maxLen int) string {
formatted := string(ssh.MarshalAuthorizedKey(k.Key))
+ // Drop new line character if present. We add it when formatting a
+ // set of keys in `AsSSSH` or `AsProjectMetadata`.
+ formatted = strings.TrimSuffix(formatted, "\n")
+
if maxLen > 0 {
formatted = formatted[:maxLen] + "..."
}
@@ -384,6 +388,19 @@ func (ak AuthorizedKeys) AsSSH() []byte {
return buf.Bytes()
}
+// AsProjectMetadata returns a marshaled version of the authorized
+// keys in a format that can be pushed to GCE's project metadata
+// storage.
+func (ak AuthorizedKeys) AsProjectMetadata() []byte {
+ var buf bytes.Buffer
+
+ for _, k := range ak {
+ buf.WriteString(fmt.Sprintf("%s:%s\n", k.User, k.String()))
+ }
+
+ return buf.Bytes()
+}
+
// GetUserAuthorizedKeys retrieves reads a list of user public keys from the
// gcloud cockroach-ephemeral project and returns them formatted for use in
// an authorized_keys file.
@@ -412,7 +429,7 @@ func GetUserAuthorizedKeys() (AuthorizedKeys, error) {
user := line[:colonIdx]
key := line[colonIdx+1:]
- if user == config.RootUser || user == config.SharedUser {
+ if !isValidSSHUser(user) {
continue
}
@@ -434,3 +451,53 @@ func GetUserAuthorizedKeys() (AuthorizedKeys, error) {
return authorizedKeys, nil
}
+
+// AddUserAuthorizedKey adds the authorized key provided to the set of
+// keys installed on clusters managed by roachprod. Currently, these
+// keys are stored in the project metadata for the roachprod's
+// `DefaultProject`.
+func AddUserAuthorizedKey(ak AuthorizedKey) (retErr error) {
+ existingKeys, err := GetUserAuthorizedKeys()
+ if err != nil {
+ return err
+ }
+
+ if !isValidSSHUser(ak.User) {
+ return fmt.Errorf("invalid SSH key username: %s", ak.User)
+ }
+
+ newKeys := append(existingKeys, ak)
+ tmpFile, err := os.CreateTemp("", "ssh-keys-*")
+ if err != nil {
+ return fmt.Errorf("failed to create temp file: %w", err)
+ }
+ defer func() {
+ retErr = errors.CombineErrors(retErr, os.Remove(tmpFile.Name()))
+ }()
+
+ if err := os.WriteFile(tmpFile.Name(), newKeys.AsProjectMetadata(), 0444); err != nil {
+ return fmt.Errorf("failed to write to temp file: %w", err)
+ }
+
+ cmd := exec.Command("gcloud", "compute", "project-info", "add-metadata",
+ fmt.Sprintf("--project=%s", DefaultProject()),
+ fmt.Sprintf("--metadata-from-file=ssh-keys=%s", tmpFile.Name()),
+ )
+
+ cmd.Stdout = os.Stdout
+ cmd.Stderr = os.Stderr
+ if err := cmd.Run(); err != nil {
+ return fmt.Errorf("error running `gcloud` command (output above): %w", err)
+ }
+
+ return nil
+}
+
+// isValidSSHUser returns whether the username provided is a valid
+// username for the purposes of the shared pool of SSH public keys to
+// be added to clusters. We don't add public keys to the root user or
+// the shared user (the shared user's `authorized_keys` is managed by
+// roachprod).
+func isValidSSHUser(user string) bool {
+ return user != config.RootUser && user != config.SharedUser
+}
|
afdae194afce9b5e03f043f0b88bbe20f83e7344
|
2020-04-09 15:15:06
|
Andrii Vorobiov
|
ui: Add storybook script to package.json
| false
|
Add storybook script to package.json
|
ui
|
diff --git a/pkg/ui/package.json b/pkg/ui/package.json
index e58860b54dbb..f5c508da4a28 100644
--- a/pkg/ui/package.json
+++ b/pkg/ui/package.json
@@ -4,6 +4,9 @@
"main": "index.tsx",
"repository": "github.com/cockroachdb/cockroach",
"license": "MIT",
+ "scripts": {
+ "storybook": "start-storybook -p 9009"
+ },
"dependencies": {
"analytics-node": "^3.4.0-beta.1",
"antd": "^3.25.2",
diff --git a/pkg/ui/src/app.tsx b/pkg/ui/src/app.tsx
index 46fa4d692e73..3994394c4f8d 100644
--- a/pkg/ui/src/app.tsx
+++ b/pkg/ui/src/app.tsx
@@ -51,9 +51,7 @@ import StatementDetails from "src/views/statements/statementDetails";
import StatementsPage from "src/views/statements/statementsPage";
import StatementsDiagnosticsHistoryView from "src/views/reports/containers/statementDiagnosticsHistory";
import "styl/app.styl";
-import "nvd3/build/nv.d3.min.css";
-import "react-select/dist/react-select.css";
-import "antd/es/tooltip/style/css";
+
// NOTE: If you are adding a new path to the router, and that path contains any
// components that are personally identifying information, you MUST update the
// redactions list in src/redux/analytics.ts.
diff --git a/pkg/ui/src/components/tooltip/tooltip.tsx b/pkg/ui/src/components/tooltip/tooltip.tsx
index df0b46137948..6f75af444a2e 100644
--- a/pkg/ui/src/components/tooltip/tooltip.tsx
+++ b/pkg/ui/src/components/tooltip/tooltip.tsx
@@ -12,6 +12,7 @@ import * as React from "react";
import { default as AntTooltip, TooltipProps as AntTooltipProps } from "antd/es/tooltip";
import cn from "classnames";
+import "antd/es/tooltip/style/css";
import "./tooltip.styl";
export interface TooltipProps {
|
fc1b8c9ba49c7eb2978b0da0549a36b04d60093e
|
2022-06-03 15:25:58
|
Erik Grinaker
|
storage: add batch variant of `BenchmarkMVCCGet_Pebble`
| false
|
add batch variant of `BenchmarkMVCCGet_Pebble`
|
storage
|
diff --git a/pkg/storage/bench_pebble_test.go b/pkg/storage/bench_pebble_test.go
index 6be2da01caf6..7006bf27544a 100644
--- a/pkg/storage/bench_pebble_test.go
+++ b/pkg/storage/bench_pebble_test.go
@@ -155,14 +155,18 @@ func BenchmarkMVCCScanTransactionalData_Pebble(b *testing.B) {
func BenchmarkMVCCGet_Pebble(b *testing.B) {
ctx := context.Background()
- for _, numVersions := range []int{1, 10, 100} {
- b.Run(fmt.Sprintf("versions=%d", numVersions), func(b *testing.B) {
- for _, valueSize := range []int{8} {
- b.Run(fmt.Sprintf("valueSize=%d", valueSize), func(b *testing.B) {
- runMVCCGet(ctx, b, setupMVCCPebble, benchDataOptions{
- numVersions: numVersions,
- valueBytes: valueSize,
- })
+ for _, batch := range []bool{false, true} {
+ b.Run(fmt.Sprintf("batch=%t", batch), func(b *testing.B) {
+ for _, numVersions := range []int{1, 10, 100} {
+ b.Run(fmt.Sprintf("versions=%d", numVersions), func(b *testing.B) {
+ for _, valueSize := range []int{8} {
+ b.Run(fmt.Sprintf("valueSize=%d", valueSize), func(b *testing.B) {
+ runMVCCGet(ctx, b, setupMVCCPebble, benchDataOptions{
+ numVersions: numVersions,
+ valueBytes: valueSize,
+ }, batch)
+ })
+ }
})
}
})
@@ -191,13 +195,17 @@ func BenchmarkMVCCFindSplitKey_Pebble(b *testing.B) {
func BenchmarkMVCCPut_Pebble(b *testing.B) {
ctx := context.Background()
for _, batch := range []bool{false, true} {
- for _, valueSize := range []int{10, 100, 1000, 10000} {
- for _, versions := range []int{1, 10} {
- b.Run(fmt.Sprintf("batch=%t,valueSize=%d,versions=%d", batch, valueSize, versions), func(b *testing.B) {
- runMVCCPut(ctx, b, setupMVCCInMemPebble, valueSize, versions, batch)
+ b.Run(fmt.Sprintf("batch=%t", batch), func(b *testing.B) {
+ for _, valueSize := range []int{10, 100, 1000, 10000} {
+ b.Run(fmt.Sprintf("valueSize=%d", valueSize), func(b *testing.B) {
+ for _, versions := range []int{1, 10} {
+ b.Run(fmt.Sprintf("versions=%d", versions), func(b *testing.B) {
+ runMVCCPut(ctx, b, setupMVCCInMemPebble, valueSize, versions, batch)
+ })
+ }
})
}
- }
+ })
}
}
diff --git a/pkg/storage/bench_test.go b/pkg/storage/bench_test.go
index 36393a165486..fa9f8d9c7037 100644
--- a/pkg/storage/bench_test.go
+++ b/pkg/storage/bench_test.go
@@ -905,7 +905,9 @@ func runMVCCScan(ctx context.Context, b *testing.B, emk engineMaker, opts benchS
// runMVCCGet first creates test data (and resets the benchmarking
// timer). It then performs b.N MVCCGets.
-func runMVCCGet(ctx context.Context, b *testing.B, emk engineMaker, opts benchDataOptions) {
+func runMVCCGet(
+ ctx context.Context, b *testing.B, emk engineMaker, opts benchDataOptions, useBatch bool,
+) {
// Use the same number of keys for all of the mvcc scan
// benchmarks. Using a different number of keys per test gives
// preferential treatment to tests with fewer keys. Note that the
@@ -918,6 +920,13 @@ func runMVCCGet(ctx context.Context, b *testing.B, emk engineMaker, opts benchDa
eng, _ := setupMVCCData(ctx, b, emk, opts)
defer eng.Close()
+ r := Reader(eng)
+ if useBatch {
+ batch := eng.NewBatch()
+ defer batch.Close()
+ r = batch
+ }
+
b.SetBytes(int64(opts.valueBytes))
b.ResetTimer()
@@ -928,7 +937,7 @@ func runMVCCGet(ctx context.Context, b *testing.B, emk engineMaker, opts benchDa
key := roachpb.Key(encoding.EncodeUvarintAscending(keyBuf[:4], uint64(keyIdx)))
walltime := int64(5 * (rand.Int31n(int32(opts.numVersions)) + 1))
ts := hlc.Timestamp{WallTime: walltime}
- if v, _, err := MVCCGet(ctx, eng, key, ts, MVCCGetOptions{}); err != nil {
+ if v, _, err := MVCCGet(ctx, r, key, ts, MVCCGetOptions{}); err != nil {
b.Fatalf("failed get: %+v", err)
} else if v == nil {
b.Fatalf("failed get (key not found): %d@%d", keyIdx, walltime)
|
5dab29f8587eed816965af05084fdd66272237d1
|
2020-09-10 22:03:54
|
Raphael 'kena' Poss
|
deps: bump cockroachdb/redact
| false
|
bump cockroachdb/redact
|
deps
|
diff --git a/go.mod b/go.mod
index 7e3e369b357f..eae203611770 100644
--- a/go.mod
+++ b/go.mod
@@ -36,12 +36,12 @@ require (
github.com/cockroachdb/cockroach-go v0.0.0-20200504194139-73ffeee90b62
github.com/cockroachdb/crlfmt v0.0.0-20200116191136-a78e1c207bc0
github.com/cockroachdb/datadriven v1.0.1-0.20200826112548-92602d883b11
- github.com/cockroachdb/errors v1.7.4
+ github.com/cockroachdb/errors v1.7.5
github.com/cockroachdb/go-test-teamcity v0.0.0-20191211140407-cff980ad0a55
github.com/cockroachdb/gostdlib v1.13.0
github.com/cockroachdb/logtags v0.0.0-20190617123548-eb05cc24525f
github.com/cockroachdb/pebble v0.0.0-20200908153531-a9c6d3b6685c
- github.com/cockroachdb/redact v1.0.5
+ github.com/cockroachdb/redact v1.0.6
github.com/cockroachdb/returncheck v0.0.0-20200612231554-92cdbca611dd
github.com/cockroachdb/sentry-go v0.6.1-cockroachdb.2
github.com/cockroachdb/stress v0.0.0-20170808184505-29b5d31b4c3a
diff --git a/go.sum b/go.sum
index 6f852f33392a..3873dc65f5b1 100644
--- a/go.sum
+++ b/go.sum
@@ -148,8 +148,8 @@ github.com/cockroachdb/datadriven v1.0.1-0.20200826112548-92602d883b11/go.mod h1
github.com/cockroachdb/errors v1.2.4 h1:Lap807SXTH5tri2TivECb/4abUkMZC9zRoLarvcKDqs=
github.com/cockroachdb/errors v1.2.4/go.mod h1:rQD95gz6FARkaKkQXUksEje/d9a6wBJoCr5oaCLELYA=
github.com/cockroachdb/errors v1.6.1/go.mod h1:tm6FTP5G81vwJ5lC0SizQo374JNCOPrHyXGitRJoDqM=
-github.com/cockroachdb/errors v1.7.4 h1:ZlMG24ZIxz6Yp00gR3KkJKsMEWWNyeOWiGyaUav5y8o=
-github.com/cockroachdb/errors v1.7.4/go.mod h1:ngNOpuFdFU8EOjSsuVmCU9AODd7yp3XXEr0JUjbCN5U=
+github.com/cockroachdb/errors v1.7.5 h1:ptyO1BLW+sBxwBTSKJfS6kGzYCVKhI7MyBhoXAnPIKM=
+github.com/cockroachdb/errors v1.7.5/go.mod h1:m/IWRCPXYZ6TvLLDuC0kfLR1pp/+BiZ0h16WHaBMRMM=
github.com/cockroachdb/etcd v0.4.7-0.20200615211340-a17df30d5955 h1:1ELogBFqZl2Cj/Rn0wWAU4z2/ghBlHzhXDlbT8RlrKU=
github.com/cockroachdb/etcd v0.4.7-0.20200615211340-a17df30d5955/go.mod h1:Vshs83p1UXI6fjU8eWVgqXeewFxRDP1fNVF5PHiSBm0=
github.com/cockroachdb/go-test-teamcity v0.0.0-20191211140407-cff980ad0a55 h1:YqzBA7tf8Gv8Oz0BbBsPenqkyjiohS7EUIwi7p1QJCU=
@@ -166,8 +166,8 @@ github.com/cockroachdb/pebble v0.0.0-20200908153531-a9c6d3b6685c h1:BNozL+Ezkyba
github.com/cockroachdb/pebble v0.0.0-20200908153531-a9c6d3b6685c/go.mod h1:hU7vhtrqonEphNF+xt8/lHdaBprxmV1h8BOGrd9XwmQ=
github.com/cockroachdb/redact v0.0.0-20200622112456-cd282804bbd3 h1:2+dpIJzYMSbLi0587YXpi8tOJT52qCOI/1I0UNThc/I=
github.com/cockroachdb/redact v0.0.0-20200622112456-cd282804bbd3/go.mod h1:BVNblN9mBWFyMyqK1k3AAiSxhvhfK2oOZZ2lK+dpvRg=
-github.com/cockroachdb/redact v1.0.5 h1:yxqIMS6G2Bvi6GiSHFmsrFGO3aP1rwt8cOm4pixw9eY=
-github.com/cockroachdb/redact v1.0.5/go.mod h1:BVNblN9mBWFyMyqK1k3AAiSxhvhfK2oOZZ2lK+dpvRg=
+github.com/cockroachdb/redact v1.0.6 h1:W34uRRyNR4dlZFd0MibhNELsZSgMkl52uRV/tA1xToY=
+github.com/cockroachdb/redact v1.0.6/go.mod h1:BVNblN9mBWFyMyqK1k3AAiSxhvhfK2oOZZ2lK+dpvRg=
github.com/cockroachdb/returncheck v0.0.0-20200612231554-92cdbca611dd h1:KFOt5I9nEKZgCnOSmy8r4Oykh8BYQO8bFOTgHDS8YZA=
github.com/cockroachdb/returncheck v0.0.0-20200612231554-92cdbca611dd/go.mod h1:AN708GD2FFeLgUHMbD58YPe4Nw8GG//3rwgyG4L9gR0=
github.com/cockroachdb/sentry-go v0.6.1-cockroachdb.2 h1:IKgmqgMQlVJIZj19CdocBeSfSaiCbEBZGKODaixqtHM=
diff --git a/vendor b/vendor
index 193db6c6d9f7..bccfc3e96761 160000
--- a/vendor
+++ b/vendor
@@ -1 +1 @@
-Subproject commit 193db6c6d9f7202701f9b27947ed25bba7fe6735
+Subproject commit bccfc3e967611498b876e3e0f6839d75f17c14c5
|
e0e57b526b54866551919a34fb901a49c69c7e16
|
2023-01-27 08:48:52
|
Chengxiong Ruan
|
sql: wait for one version lease if no job created for a descriptor
| false
|
wait for one version lease if no job created for a descriptor
|
sql
|
diff --git a/pkg/jobs/jobs_test.go b/pkg/jobs/jobs_test.go
index ec9c655eda65..940d5f254e60 100644
--- a/pkg/jobs/jobs_test.go
+++ b/pkg/jobs/jobs_test.go
@@ -2324,7 +2324,7 @@ func TestJobInTxn(t *testing.T) {
// Accessed atomically.
var hasRun int32
- var job *jobs.Job
+ var jobID jobspb.JobID
defer sql.ClearPlanHooks()
// Piggy back on BACKUP to be able to create a succeeding test job.
@@ -2338,7 +2338,7 @@ func TestJobInTxn(t *testing.T) {
}
fn := func(ctx context.Context, _ []sql.PlanNode, _ chan<- tree.Datums) error {
var err error
- job, err = execCtx.ExtendedEvalContext().QueueJob(ctx, execCtx.InternalSQLTxn(), jobs.Record{
+ jobID = execCtx.ExtendedEvalContext().QueueJob(&jobs.Record{
Description: st.String(),
Details: jobspb.BackupDetails{},
Progress: jobspb.BackupProgress{},
@@ -2378,7 +2378,7 @@ func TestJobInTxn(t *testing.T) {
}
fn := func(ctx context.Context, _ []sql.PlanNode, _ chan<- tree.Datums) error {
var err error
- job, err = execCtx.ExtendedEvalContext().QueueJob(ctx, execCtx.InternalSQLTxn(), jobs.Record{
+ jobID = execCtx.ExtendedEvalContext().QueueJob(&jobs.Record{
Description: "RESTORE",
Details: jobspb.RestoreDetails{},
Progress: jobspb.RestoreProgress{},
@@ -2413,14 +2413,14 @@ func TestJobInTxn(t *testing.T) {
// If we rollback then the job should not run
require.NoError(t, txn.Rollback())
registry := s.JobRegistry().(*jobs.Registry)
- _, err = registry.LoadJob(ctx, job.ID())
+ _, err = registry.LoadJob(ctx, jobID)
require.Error(t, err, "the job should not exist after the txn is rolled back")
require.True(t, jobs.HasJobNotFoundError(err))
sqlRunner := sqlutils.MakeSQLRunner(sqlDB)
// Just in case the job was scheduled let's wait for it to finish
// to avoid a race.
- sqlRunner.Exec(t, "SHOW JOB WHEN COMPLETE $1", job.ID())
+ sqlRunner.Exec(t, "SHOW JOB WHEN COMPLETE $1", jobID)
require.Equal(t, int32(0), atomic.LoadInt32(&hasRun),
"job has run in transaction before txn commit")
require.True(t, timeutil.Since(start) < jobs.DefaultAdoptInterval, "job should have been adopted immediately")
@@ -2437,7 +2437,7 @@ func TestJobInTxn(t *testing.T) {
// Committing will block and wait for all jobs to run.
require.NoError(t, txn.Commit())
registry := s.JobRegistry().(*jobs.Registry)
- j, err := registry.LoadJob(ctx, job.ID())
+ j, err := registry.LoadJob(ctx, jobID)
require.NoError(t, err, "queued job not found")
require.NotEqual(t, int32(0), atomic.LoadInt32(&hasRun),
"job scheduled in transaction did not run")
diff --git a/pkg/sql/BUILD.bazel b/pkg/sql/BUILD.bazel
index bc13834ea888..68cdd44d2c2d 100644
--- a/pkg/sql/BUILD.bazel
+++ b/pkg/sql/BUILD.bazel
@@ -44,6 +44,7 @@ go_library(
"completions.go",
"conn_executor.go",
"conn_executor_exec.go",
+ "conn_executor_jobs.go",
"conn_executor_prepare.go",
"conn_executor_savepoints.go",
"conn_executor_show_commit_timestamp.go",
@@ -134,6 +135,7 @@ go_library(
"inverted_join.go",
"job_exec_context.go",
"job_exec_context_test_util.go",
+ "jobs_collection.go",
"join.go",
"join_predicate.go",
"join_token.go",
diff --git a/pkg/sql/conn_executor.go b/pkg/sql/conn_executor.go
index 70c8cf522d83..0e51778ee8a4 100644
--- a/pkg/sql/conn_executor.go
+++ b/pkg/sql/conn_executor.go
@@ -21,7 +21,6 @@ import (
"time"
"unicode/utf8"
- "github.com/cockroachdb/cockroach/pkg/jobs"
"github.com/cockroachdb/cockroach/pkg/jobs/jobspb"
"github.com/cockroachdb/cockroach/pkg/kv"
"github.com/cockroachdb/cockroach/pkg/multitenant"
@@ -1018,9 +1017,8 @@ func (s *Server) newConnExecutor(
ex.extraTxnState.descCollection = s.cfg.CollectionFactory.NewCollection(
ctx, descs.WithDescriptorSessionDataProvider(dsdp), descs.WithMonitor(ex.sessionMon),
)
- ex.extraTxnState.jobs = new(jobsCollection)
+ ex.extraTxnState.jobs = newTxnJobsCollection()
ex.extraTxnState.txnRewindPos = -1
- ex.extraTxnState.schemaChangeJobRecords = make(map[descpb.ID]*jobs.Record)
ex.extraTxnState.schemaChangerState = &SchemaChangerState{
mode: ex.sessionData().NewSchemaChangerMode,
}
@@ -1275,18 +1273,7 @@ type connExecutor struct {
// descCollection collects descriptors used by the current transaction.
descCollection *descs.Collection
- // jobs accumulates jobs staged for execution inside the transaction.
- // Staging happens when executing statements that are implemented with a
- // job. The jobs are staged via the function QueueJob in
- // pkg/sql/planner.go. The staged jobs are executed once the transaction
- // that staged them commits.
- jobs *jobsCollection
-
- // schemaChangeJobRecords is a map of descriptor IDs to job Records.
- // Used in createOrUpdateSchemaChangeJob so we can check if a job has been
- // queued up for the given ID. The cache remains valid only for the current
- // transaction and it is cleared after the transaction is committed.
- schemaChangeJobRecords map[descpb.ID]*jobs.Record
+ jobs *txnJobsCollection
// firstStmtExecuted indicates that the first statement inside this
// transaction has been executed.
@@ -1714,9 +1701,6 @@ func (ex *connExecutor) resetExtraTxnState(ctx context.Context, ev txnEvent) {
}
} else {
ex.extraTxnState.descCollection.ReleaseAll(ctx)
- for k := range ex.extraTxnState.schemaChangeJobRecords {
- delete(ex.extraTxnState.schemaChangeJobRecords, k)
- }
ex.extraTxnState.jobs.reset()
ex.extraTxnState.schemaChangerState = &SchemaChangerState{
mode: ex.sessionData().NewSchemaChangerMode,
@@ -2824,15 +2808,14 @@ func (ex *connExecutor) initEvalCtx(ctx context.Context, evalCtx *extendedEvalCo
DescIDGenerator: ex.getDescIDGenerator(),
RangeStatsFetcher: p.execCfg.RangeStatsFetcher,
},
- Tracing: &ex.sessionTracing,
- MemMetrics: &ex.memMetrics,
- Descs: ex.extraTxnState.descCollection,
- TxnModesSetter: ex,
- Jobs: ex.extraTxnState.jobs,
- SchemaChangeJobRecords: ex.extraTxnState.schemaChangeJobRecords,
- statsProvider: ex.server.sqlStats,
- indexUsageStats: ex.indexUsageStats,
- statementPreparer: ex,
+ Tracing: &ex.sessionTracing,
+ MemMetrics: &ex.memMetrics,
+ Descs: ex.extraTxnState.descCollection,
+ TxnModesSetter: ex,
+ jobs: ex.extraTxnState.jobs,
+ statsProvider: ex.server.sqlStats,
+ indexUsageStats: ex.indexUsageStats,
+ statementPreparer: ex,
}
evalCtx.copyFromExecCfg(ex.server.cfg)
}
@@ -3077,13 +3060,27 @@ func (ex *connExecutor) txnStateTransitionsApplyWrapper(
}
ex.notifyStatsRefresherOfNewTables(ex.Ctx())
+ // If there is any descriptor has new version. We want to make sure there is
+ // only one version of the descriptor in all nodes. In schema changer jobs,
+ // `WaitForOneVersion` has been called for the descriptors included in jobs.
+ // So we just need to do this for descriptors not in jobs.
+ // We need to get descriptor IDs in jobs before jobs are run because we have
+ // operations in declarative schema changer removing descriptor IDs from job
+ // payload as it's done with the descriptors.
+ descIDsInJobs, err := ex.descIDsInSchemaChangeJobs()
+ if err != nil {
+ return advanceInfo{}, err
+ }
ex.statsCollector.PhaseTimes().SetSessionPhaseTime(sessionphase.SessionStartPostCommitJob, timeutil.Now())
if err := ex.server.cfg.JobRegistry.Run(
- ex.ctxHolder.connCtx, *ex.extraTxnState.jobs,
+ ex.ctxHolder.connCtx, ex.extraTxnState.jobs.created,
); err != nil {
handleErr(err)
}
ex.statsCollector.PhaseTimes().SetSessionPhaseTime(sessionphase.SessionEndPostCommitJob, timeutil.Now())
+ if err := ex.waitOneVersionForNewVersionDescriptorsWithoutJobs(descIDsInJobs); err != nil {
+ return advanceInfo{}, err
+ }
fallthrough
case txnRestart, txnRollback:
@@ -3395,7 +3392,7 @@ func (ex *connExecutor) runPreCommitStages(ctx context.Context) error {
scs.state = after
scs.jobID = jobID
if jobID != jobspb.InvalidJobID {
- ex.extraTxnState.jobs.add(jobID)
+ ex.extraTxnState.jobs.addCreatedJobID(jobID)
log.Infof(ctx, "queued new schema change job %d using the new schema changer", jobID)
}
return nil
diff --git a/pkg/sql/conn_executor_exec.go b/pkg/sql/conn_executor_exec.go
index a410f3866f3b..c0d8bdf33ada 100644
--- a/pkg/sql/conn_executor_exec.go
+++ b/pkg/sql/conn_executor_exec.go
@@ -1059,12 +1059,15 @@ func (ex *connExecutor) commitSQLTransactionInternal(ctx context.Context) error
// createJobs creates jobs for the records cached in schemaChangeJobRecords
// during this transaction.
func (ex *connExecutor) createJobs(ctx context.Context) error {
- if len(ex.extraTxnState.schemaChangeJobRecords) == 0 {
+ if !ex.extraTxnState.jobs.hasAnyToCreate() {
return nil
}
var records []*jobs.Record
- for _, record := range ex.extraTxnState.schemaChangeJobRecords {
- records = append(records, record)
+ if err := ex.extraTxnState.jobs.forEachToCreate(func(jobRecord *jobs.Record) error {
+ records = append(records, jobRecord)
+ return nil
+ }); err != nil {
+ return err
}
jobIDs, err := ex.server.cfg.JobRegistry.CreateJobsWithTxn(
ctx, ex.planner.InternalSQLTxn(), records,
@@ -1072,7 +1075,7 @@ func (ex *connExecutor) createJobs(ctx context.Context) error {
if err != nil {
return err
}
- ex.planner.extendedEvalCtx.Jobs.add(jobIDs...)
+ ex.planner.extendedEvalCtx.jobs.addCreatedJobID(jobIDs...)
return nil
}
diff --git a/pkg/sql/conn_executor_jobs.go b/pkg/sql/conn_executor_jobs.go
new file mode 100644
index 000000000000..c2ddb695618c
--- /dev/null
+++ b/pkg/sql/conn_executor_jobs.go
@@ -0,0 +1,124 @@
+// Copyright 2023 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+package sql
+
+import (
+ "github.com/cockroachdb/cockroach/pkg/jobs"
+ "github.com/cockroachdb/cockroach/pkg/jobs/jobspb"
+ "github.com/cockroachdb/cockroach/pkg/sql/catalog"
+ "github.com/cockroachdb/errors"
+)
+
+// waitOneVersionForNewVersionDescriptorsWithoutJobs is to used wait until all
+// descriptors with new versions to converge to one version in the cluster.
+// `descIDsInJobs` are collected with `descIDsInSchemaChangeJobs`. We need to do
+// this to make sure all descriptors mutated are at one version when the schema
+// change finish in the user transaction. In schema change jobs, we do similar
+// thing for affected descriptors. But, in some scenario, jobs are not created
+// for mutated descriptors.
+func (ex *connExecutor) waitOneVersionForNewVersionDescriptorsWithoutJobs(
+ descIDsInJobs catalog.DescriptorIDSet,
+) error {
+ withNewVersion, err := ex.extraTxnState.descCollection.GetOriginalPreviousIDVersionsForUncommitted()
+ if err != nil {
+ return err
+ }
+ for _, idVersion := range withNewVersion {
+ if descIDsInJobs.Contains(idVersion.ID) {
+ continue
+ }
+ if _, err := WaitToUpdateLeases(ex.Ctx(), ex.planner.LeaseMgr(), idVersion.ID); err != nil {
+ // In most cases (normal schema changes), deleted descriptor should have
+ // been handled by jobs. So, normally we won't hit into the situation of
+ // wait for one version of a deleted descriptor. However, we need catch
+ // ErrDescriptorNotFound here because we have a special case of descriptor
+ // repairing where we delete descriptors directly and never record the ids
+ // in jobs payload or details.
+ if errors.Is(err, catalog.ErrDescriptorNotFound) {
+ continue
+ }
+ return err
+ }
+ }
+ return nil
+}
+
+// descIDsInSchemaChangeJobs returns all descriptor IDs with which schema change
+// jobs in this transaction will perform. Within schema change jobs, we also
+// wait until the whole cluster only has leases on the latest version of these
+// descriptors, and we would like to also "wait for one version" for descriptors
+// with new versions but not included in any schema change jobs.
+func (ex *connExecutor) descIDsInSchemaChangeJobs() (catalog.DescriptorIDSet, error) {
+ // Get descriptor IDs from legacy schema changer jobs.
+ var descIDsInJobs catalog.DescriptorIDSet
+ if err := ex.extraTxnState.jobs.forEachToCreate(func(jobRecord *jobs.Record) error {
+ switch t := jobRecord.Details.(type) {
+ case jobspb.SchemaChangeDetails:
+ // In most cases, the field DescriptorIDs contains descriptor IDs the
+ // schema change directly affects. Like it could be a table ID if an index
+ // is created, or it could be a list of schema IDs when dropping a group
+ // of schemas.
+ // But it can be confusing sometimes in two types of schema change jobs:
+ // (1) dropping a database:
+ // In this scenario, the DescriptorIDs is the ids of tables in this
+ // database that will be dropped together. And the DroppedDatabaseID field
+ // is the actual ID of the database that will be dropped.
+ // (2) any other changes on a database (but not drop):
+ // For example, when renaming a schema, database's list of all schemas
+ // need to be updated, and we create a job for this kind of database
+ // changes. DescriptorIDs is empty in this case and the DescID field in
+ // the job
+ // detail is the actual database ID.
+ for _, descID := range jobRecord.DescriptorIDs {
+ descIDsInJobs.Add(descID)
+ }
+ for _, tbl := range t.DroppedTables {
+ descIDsInJobs.Add(tbl.ID)
+ }
+ for _, id := range t.DroppedTypes {
+ descIDsInJobs.Add(id)
+ }
+ for _, id := range t.DroppedSchemas {
+ descIDsInJobs.Add(id)
+ }
+ descIDsInJobs.Add(t.DroppedDatabaseID)
+ descIDsInJobs.Add(t.DescID)
+ }
+ return nil
+ }); err != nil {
+ return catalog.DescriptorIDSet{}, err
+ }
+
+ // If there is no declarative schema changer job, then we are done. Otherwise,
+ // we need to check which descriptor has the jobID in its schema change state.
+ if ex.extraTxnState.schemaChangerState.jobID == jobspb.InvalidJobID {
+ return descIDsInJobs, nil
+ }
+ // Get descriptor IDs with declarative schema changer jobs.
+ withNewVersion, err := ex.extraTxnState.descCollection.GetOriginalPreviousIDVersionsForUncommitted()
+ if err != nil {
+ return catalog.DescriptorIDSet{}, err
+ }
+ for _, idVersion := range withNewVersion {
+ if descIDsInJobs.Contains(idVersion.ID) {
+ continue
+ }
+ desc, err := ex.extraTxnState.descCollection.ByID(ex.state.mu.txn).Get().Desc(ex.Ctx(), idVersion.ID)
+ if err != nil {
+ return catalog.DescriptorIDSet{}, err
+ }
+ state := desc.GetDeclarativeSchemaChangerState()
+ if state != nil && state.JobID != jobspb.InvalidJobID {
+ descIDsInJobs.Add(idVersion.ID)
+ }
+ }
+ return descIDsInJobs, nil
+}
diff --git a/pkg/sql/crdb_internal.go b/pkg/sql/crdb_internal.go
index 353a2508889e..7ef2aae5aaaa 100644
--- a/pkg/sql/crdb_internal.go
+++ b/pkg/sql/crdb_internal.go
@@ -1111,14 +1111,17 @@ func makeJobsTableRows(
}
defer cleanup(ctx)
- sessionJobs := make([]*jobs.Record, 0, len(p.extendedEvalCtx.SchemaChangeJobRecords))
+ sessionJobs := make([]*jobs.Record, 0, p.extendedEvalCtx.jobs.numToCreate())
uniqueJobs := make(map[*jobs.Record]struct{})
- for _, job := range p.extendedEvalCtx.SchemaChangeJobRecords {
+ if err := p.extendedEvalCtx.jobs.forEachToCreate(func(job *jobs.Record) error {
if _, ok := uniqueJobs[job]; ok {
- continue
+ return nil
}
sessionJobs = append(sessionJobs, job)
uniqueJobs[job] = struct{}{}
+ return nil
+ }); err != nil {
+ return matched, err
}
// Loop while we need to skip a row.
@@ -5300,10 +5303,10 @@ func collectMarshaledJobMetadataMap(
if err := it.Close(); err != nil {
return nil, err
}
- for _, record := range p.ExtendedEvalContext().SchemaChangeJobRecords {
+ if err := p.ExtendedEvalContext().jobs.forEachToCreate(func(record *jobs.Record) error {
progressBytes, payloadBytes, err := getPayloadAndProgressFromJobsRecord(p, record)
if err != nil {
- return nil, err
+ return err
}
mj := marshaledJobMetadata{
status: tree.NewDString(string(record.RunningStatus)),
@@ -5311,6 +5314,9 @@ func collectMarshaledJobMetadataMap(
progressBytes: progressBytes,
}
m[record.JobID] = mj
+ return nil
+ }); err != nil {
+ return nil, err
}
return m, nil
}
diff --git a/pkg/sql/database.go b/pkg/sql/database.go
index 6bf506ee155e..0bc108bcee67 100644
--- a/pkg/sql/database.go
+++ b/pkg/sql/database.go
@@ -73,9 +73,7 @@ func (p *planner) renameDatabase(
func (p *planner) writeNonDropDatabaseChange(
ctx context.Context, desc *dbdesc.Mutable, jobDesc string,
) error {
- if err := p.createNonDropDatabaseChangeJob(ctx, desc.ID, jobDesc); err != nil {
- return err
- }
+ p.createNonDropDatabaseChangeJob(ctx, desc.ID, jobDesc)
b := p.Txn().NewBatch()
if err := p.writeDatabaseChangeToBatch(ctx, desc, b); err != nil {
return err
diff --git a/pkg/sql/drop_database.go b/pkg/sql/drop_database.go
index d7c837b0a9b3..190defc9bb24 100644
--- a/pkg/sql/drop_database.go
+++ b/pkg/sql/drop_database.go
@@ -173,16 +173,14 @@ func (n *dropDatabaseNode) startExec(params runParams) error {
}
}
- if err := p.createDropDatabaseJob(
+ p.createDropDatabaseJob(
ctx,
n.dbDesc.GetID(),
schemasIDsToDelete,
n.d.getDroppedTableDetails(),
n.d.typesToDelete,
tree.AsStringWithFQNames(n.n, params.Ann()),
- ); err != nil {
- return err
- }
+ )
n.dbDesc.SetDropped()
b := p.txn.NewBatch()
diff --git a/pkg/sql/drop_schema.go b/pkg/sql/drop_schema.go
index c2a44c495ac6..6254a5a51aa1 100644
--- a/pkg/sql/drop_schema.go
+++ b/pkg/sql/drop_schema.go
@@ -161,15 +161,12 @@ func (n *dropSchemaNode) startExec(params runParams) error {
}
// Create the job to drop the schema.
- if err := p.createDropSchemaJob(
- params.ctx,
+ p.createDropSchemaJob(
schemaIDs,
n.d.getDroppedTableDetails(),
n.d.typesToDelete,
tree.AsStringWithFQNames(n.n, params.Ann()),
- ); err != nil {
- return err
- }
+ )
// Log Drop Schema event. This is an auditable log event and is recorded
// in the same transaction as table descriptor update.
@@ -230,18 +227,17 @@ func (p *planner) dropSchemaImpl(
}
func (p *planner) createDropSchemaJob(
- ctx context.Context,
schemas []descpb.ID,
tableDropDetails []jobspb.DroppedTableDetails,
typesToDrop []*typedesc.Mutable,
jobDesc string,
-) error {
+) {
typeIDs := make([]descpb.ID, 0, len(typesToDrop))
for _, t := range typesToDrop {
typeIDs = append(typeIDs, t.ID)
}
- _, err := p.extendedEvalCtx.QueueJob(ctx, p.InternalSQLTxn(), jobs.Record{
+ p.extendedEvalCtx.QueueJob(&jobs.Record{
Description: jobDesc,
Username: p.User(),
DescriptorIDs: schemas,
@@ -257,7 +253,6 @@ func (p *planner) createDropSchemaJob(
Progress: jobspb.SchemaChangeProgress{},
NonCancelable: true,
})
- return err
}
func (n *dropSchemaNode) Next(params runParams) (bool, error) { return false, nil }
diff --git a/pkg/sql/drop_table.go b/pkg/sql/drop_table.go
index 10c80902fa90..13c1de1d9a40 100644
--- a/pkg/sql/drop_table.go
+++ b/pkg/sql/drop_table.go
@@ -415,8 +415,8 @@ func (p *planner) markTableMutationJobsSuccessful(
// in a batch only when the transaction commits. So, if a job's record exists
// in the cache, we can simply delete that record from cache because the
// job is not created yet.
- if record, exists := p.ExtendedEvalContext().SchemaChangeJobRecords[tableDesc.ID]; exists && record.JobID == jobID {
- delete(p.ExtendedEvalContext().SchemaChangeJobRecords, tableDesc.ID)
+ if record, exists := p.ExtendedEvalContext().jobs.uniqueToCreate[tableDesc.ID]; exists && record.JobID == jobID {
+ delete(p.ExtendedEvalContext().jobs.uniqueToCreate, tableDesc.ID)
continue
}
mutationJob, err := p.execCfg.JobRegistry.LoadJobWithTxn(ctx, jobID, p.InternalSQLTxn())
diff --git a/pkg/sql/exec_util.go b/pkg/sql/exec_util.go
index 1e223a6cec5b..adcd27f79640 100644
--- a/pkg/sql/exec_util.go
+++ b/pkg/sql/exec_util.go
@@ -34,7 +34,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/featureflag"
"github.com/cockroachdb/cockroach/pkg/gossip"
"github.com/cockroachdb/cockroach/pkg/jobs"
- "github.com/cockroachdb/cockroach/pkg/jobs/jobspb"
"github.com/cockroachdb/cockroach/pkg/keys"
"github.com/cockroachdb/cockroach/pkg/keyvisualizer"
"github.com/cockroachdb/cockroach/pkg/kv"
@@ -2200,16 +2199,6 @@ func (r *SessionRegistry) SerializeAll() []serverpb.Session {
// into a serverpb.Session. Exported for testing.
const MaxSQLBytes = 1000
-type jobsCollection []jobspb.JobID
-
-func (jc *jobsCollection) add(ids ...jobspb.JobID) {
- *jc = append(*jc, ids...)
-}
-
-func (jc *jobsCollection) reset() {
- *jc = nil
-}
-
// truncateStatementStringForTelemetry truncates the string
// representation of a statement to a maximum length, so as to not
// create unduly large logging and error payloads.
diff --git a/pkg/sql/grant_revoke.go b/pkg/sql/grant_revoke.go
index e4f6a554bde0..bf9d7ee13114 100644
--- a/pkg/sql/grant_revoke.go
+++ b/pkg/sql/grant_revoke.go
@@ -338,10 +338,7 @@ func (n *changeDescriptorBackedPrivilegesNode) startExec(params runParams) error
if err := p.writeDatabaseChangeToBatch(ctx, d, b); err != nil {
return err
}
- if err := p.createNonDropDatabaseChangeJob(ctx, d.ID,
- fmt.Sprintf("updating privileges for database %d", d.ID)); err != nil {
- return err
- }
+ p.createNonDropDatabaseChangeJob(ctx, d.ID, fmt.Sprintf("updating privileges for database %d", d.ID))
for _, grantee := range n.grantees {
privs := eventDetails // copy the granted/revoked privilege list.
privs.Grantee = grantee.Normalized()
diff --git a/pkg/sql/internal.go b/pkg/sql/internal.go
index a63fe263e567..f58d08125cfb 100644
--- a/pkg/sql/internal.go
+++ b/pkg/sql/internal.go
@@ -17,7 +17,6 @@ import (
"sync"
"time"
- "github.com/cockroachdb/cockroach/pkg/jobs"
"github.com/cockroachdb/cockroach/pkg/kv"
"github.com/cockroachdb/cockroach/pkg/roachpb"
"github.com/cockroachdb/cockroach/pkg/security/username"
@@ -26,7 +25,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/catalog"
"github.com/cockroachdb/cockroach/pkg/sql/catalog/catsessiondata"
"github.com/cockroachdb/cockroach/pkg/sql/catalog/colinfo"
- "github.com/cockroachdb/cockroach/pkg/sql/catalog/descpb"
"github.com/cockroachdb/cockroach/pkg/sql/catalog/descs"
"github.com/cockroachdb/cockroach/pkg/sql/catalog/lease"
"github.com/cockroachdb/cockroach/pkg/sql/isql"
@@ -302,7 +300,6 @@ func (ie *InternalExecutor) newConnExecutorWithTxn(
if ie.extraTxnState != nil {
ex.extraTxnState.descCollection = ie.extraTxnState.descCollection
ex.extraTxnState.fromOuterTxn = true
- ex.extraTxnState.schemaChangeJobRecords = ie.extraTxnState.schemaChangeJobRecords
ex.extraTxnState.jobs = ie.extraTxnState.jobs
ex.extraTxnState.schemaChangerState = ie.extraTxnState.schemaChangerState
ex.extraTxnState.shouldResetSyntheticDescriptors = shouldResetSyntheticDescriptors
@@ -1005,13 +1002,6 @@ func (ie *InternalExecutor) execInternal(
return r, nil
}
-// ReleaseSchemaChangeJobRecords is to release the schema change job records.
-func (ie *InternalExecutor) releaseSchemaChangeJobRecords() {
- for k := range ie.extraTxnState.schemaChangeJobRecords {
- delete(ie.extraTxnState.schemaChangeJobRecords, k)
- }
-}
-
// commitTxn is to commit the txn bound to the internal executor.
// It should only be used in CollectionFactory.TxnWithExecutor().
func (ie *InternalExecutor) commitTxn(ctx context.Context) error {
@@ -1239,11 +1229,10 @@ func (ncl *noopClientLock) RTrim(_ context.Context, pos CmdPos) {
// executor in that it may lead to surprising bugs whereby we forget to add
// fields here and keep them in sync.
type extraTxnState struct {
- txn *kv.Txn
- descCollection *descs.Collection
- jobs *jobsCollection
- schemaChangeJobRecords map[descpb.ID]*jobs.Record
- schemaChangerState *SchemaChangerState
+ txn *kv.Txn
+ descCollection *descs.Collection
+ jobs *txnJobsCollection
+ schemaChangerState *SchemaChangerState
}
// InternalDB stored information needed to construct a new
@@ -1361,11 +1350,10 @@ func (ief *InternalDB) newInternalExecutorWithTxn(
mon: ief.monitor,
memMetrics: ief.memMetrics,
extraTxnState: &extraTxnState{
- txn: txn,
- descCollection: descCol,
- jobs: new(jobsCollection),
- schemaChangeJobRecords: make(map[descpb.ID]*jobs.Record),
- schemaChangerState: schemaChangerState,
+ txn: txn,
+ descCollection: descCol,
+ jobs: newTxnJobsCollection(),
+ schemaChangerState: schemaChangerState,
},
}
populateMinimalSessionData(sd)
@@ -1374,12 +1362,11 @@ func (ief *InternalDB) newInternalExecutorWithTxn(
commitTxnFunc := func(ctx context.Context) error {
defer func() {
ie.extraTxnState.jobs.reset()
- ie.releaseSchemaChangeJobRecords()
}()
if err := ie.commitTxn(ctx); err != nil {
return err
}
- return ie.s.cfg.JobRegistry.Run(ctx, *ie.extraTxnState.jobs)
+ return ie.s.cfg.JobRegistry.Run(ctx, ie.extraTxnState.jobs.created)
}
return ie, commitTxnFunc
diff --git a/pkg/sql/jobs_collection.go b/pkg/sql/jobs_collection.go
new file mode 100644
index 000000000000..45aa3642ba06
--- /dev/null
+++ b/pkg/sql/jobs_collection.go
@@ -0,0 +1,89 @@
+// Copyright 2023 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+package sql
+
+import (
+ "github.com/cockroachdb/cockroach/pkg/jobs"
+ "github.com/cockroachdb/cockroach/pkg/jobs/jobspb"
+ "github.com/cockroachdb/cockroach/pkg/sql/catalog/descpb"
+)
+
+type jobsCollection []jobspb.JobID
+
+func (jc *jobsCollection) add(ids ...jobspb.JobID) {
+ *jc = append(*jc, ids...)
+}
+
+func (jc *jobsCollection) reset() {
+ *jc = nil
+}
+
+// txnJobsCollection is used to collect information of all jobs created in a
+// transaction. It's also used as a cache of job records created outside
+// declarative schema changer.
+type txnJobsCollection struct {
+ // created represents a list of job IDs that has been created and queued to
+ // system.jobs.
+ created jobsCollection
+ // uniqueToCreate contains job records unique to a descriptor ID. Typically,
+ // this kind of jobs are created when mutating relations, we only allow one
+ // job for a relation in one transaction. These jobs will be created and
+ // queued at commit time.
+ uniqueToCreate map[descpb.ID]*jobs.Record
+ // uniqueToCreate contains job records that are not unique to a descriptor
+ // IDs. These jobs will be created and queued at commit time.
+ nonUniqueToCreate []*jobs.Record
+}
+
+func newTxnJobsCollection() *txnJobsCollection {
+ ret := &txnJobsCollection{
+ uniqueToCreate: make(map[descpb.ID]*jobs.Record),
+ }
+ return ret
+}
+
+func (j *txnJobsCollection) addCreatedJobID(jobID ...jobspb.JobID) {
+ j.created.add(jobID...)
+}
+
+func (j *txnJobsCollection) addNonUniqueJobToCreate(jobRecord *jobs.Record) {
+ j.nonUniqueToCreate = append(j.nonUniqueToCreate, jobRecord)
+}
+
+func (j *txnJobsCollection) reset() {
+ j.created.reset()
+ for id := range j.uniqueToCreate {
+ delete(j.uniqueToCreate, id)
+ }
+ j.nonUniqueToCreate = nil
+}
+
+func (j *txnJobsCollection) numToCreate() int {
+ return len(j.uniqueToCreate) + len(j.nonUniqueToCreate)
+}
+
+func (j *txnJobsCollection) hasAnyToCreate() bool {
+ return j.numToCreate() > 0
+}
+
+func (j *txnJobsCollection) forEachToCreate(fn func(jobRecord *jobs.Record) error) error {
+ for _, r := range j.uniqueToCreate {
+ if err := fn(r); err != nil {
+ return err
+ }
+ }
+ for _, r := range j.nonUniqueToCreate {
+ if err := fn(r); err != nil {
+ return err
+ }
+ }
+ return nil
+}
diff --git a/pkg/sql/planner.go b/pkg/sql/planner.go
index 5e1cb9ef5fde..ac8df5d9e392 100644
--- a/pkg/sql/planner.go
+++ b/pkg/sql/planner.go
@@ -16,6 +16,7 @@ import (
"github.com/cockroachdb/cockroach/pkg/clusterversion"
"github.com/cockroachdb/cockroach/pkg/jobs"
+ "github.com/cockroachdb/cockroach/pkg/jobs/jobspb"
"github.com/cockroachdb/cockroach/pkg/keyvisualizer"
"github.com/cockroachdb/cockroach/pkg/kv"
"github.com/cockroachdb/cockroach/pkg/repstream"
@@ -35,7 +36,6 @@ import (
"github.com/cockroachdb/cockroach/pkg/sql/evalcatalog"
"github.com/cockroachdb/cockroach/pkg/sql/exprutil"
"github.com/cockroachdb/cockroach/pkg/sql/idxusage"
- "github.com/cockroachdb/cockroach/pkg/sql/isql"
"github.com/cockroachdb/cockroach/pkg/sql/parser"
"github.com/cockroachdb/cockroach/pkg/sql/privilege"
"github.com/cockroachdb/cockroach/pkg/sql/querycache"
@@ -95,15 +95,8 @@ type extendedEvalContext struct {
TxnModesSetter txnModesSetter
- // Jobs refers to jobs in extraTxnState. Jobs is a pointer to a jobsCollection
- // which is a slice because we need calls to resetExtraTxnState to reset the
- // jobsCollection.
- Jobs *jobsCollection
-
- // SchemaChangeJobRecords refers to schemaChangeJobsCache in extraTxnState of
- // in sql.connExecutor. sql.connExecutor.createJobs() enqueues jobs with these
- // records when transaction is committed.
- SchemaChangeJobRecords map[descpb.ID]*jobs.Record
+ // jobs refers to jobs in extraTxnState.
+ jobs *txnJobsCollection
statsProvider *persistedsqlstats.PersistedSQLStats
@@ -145,21 +138,11 @@ func (evalCtx *extendedEvalContext) copy() *extendedEvalContext {
// QueueJob creates a new job from record and queues it for execution after
// the transaction commits.
-func (evalCtx *extendedEvalContext) QueueJob(
- ctx context.Context, txn isql.Txn, record jobs.Record,
-) (*jobs.Job, error) {
+func (evalCtx *extendedEvalContext) QueueJob(record *jobs.Record) jobspb.JobID {
jobID := evalCtx.ExecCfg.JobRegistry.MakeJobID()
- job, err := evalCtx.ExecCfg.JobRegistry.CreateJobWithTxn(
- ctx,
- record,
- jobID,
- txn,
- )
- if err != nil {
- return nil, err
- }
- evalCtx.Jobs.add(jobID)
- return job, nil
+ record.JobID = jobID
+ evalCtx.jobs.addNonUniqueJobToCreate(record)
+ return jobID
}
// planner is the centerpiece of SQL statement execution combining session
@@ -580,11 +563,10 @@ func (p *planner) InternalSQLTxn() descs.Txn {
ie := MakeInternalExecutor(ief.server, ief.memMetrics, ief.monitor)
ie.SetSessionData(p.SessionData())
ie.extraTxnState = &extraTxnState{
- txn: p.Txn(),
- descCollection: p.Descriptors(),
- jobs: p.extendedEvalCtx.Jobs,
- schemaChangeJobRecords: p.extendedEvalCtx.SchemaChangeJobRecords,
- schemaChangerState: p.extendedEvalCtx.SchemaChangerState,
+ txn: p.Txn(),
+ descCollection: p.Descriptors(),
+ jobs: p.extendedEvalCtx.jobs,
+ schemaChangerState: p.extendedEvalCtx.SchemaChangerState,
}
p.internalSQLTxn.init(p.txn, ie)
}
diff --git a/pkg/sql/schema.go b/pkg/sql/schema.go
index 1bd80e16a2eb..e7524544f293 100644
--- a/pkg/sql/schema.go
+++ b/pkg/sql/schema.go
@@ -56,7 +56,7 @@ func (p *planner) writeSchemaDesc(ctx context.Context, desc *schemadesc.Mutable)
func (p *planner) writeSchemaDescChange(
ctx context.Context, desc *schemadesc.Mutable, jobDesc string,
) error {
- record, recordExists := p.extendedEvalCtx.SchemaChangeJobRecords[desc.ID]
+ record, recordExists := p.extendedEvalCtx.jobs.uniqueToCreate[desc.ID]
if recordExists {
// Update it.
record.AppendDescription(jobDesc)
@@ -77,7 +77,7 @@ func (p *planner) writeSchemaDescChange(
Progress: jobspb.SchemaChangeProgress{},
NonCancelable: true,
}
- p.extendedEvalCtx.SchemaChangeJobRecords[desc.ID] = &jobRecord
+ p.extendedEvalCtx.jobs.uniqueToCreate[desc.ID] = &jobRecord
log.Infof(ctx, "queued new schema change job %d for schema %d", jobRecord.JobID, desc.ID)
}
diff --git a/pkg/sql/table.go b/pkg/sql/table.go
index 0c7a9747bbcd..c5cc7a17ae4b 100644
--- a/pkg/sql/table.go
+++ b/pkg/sql/table.go
@@ -43,7 +43,7 @@ func (p *planner) createDropDatabaseJob(
tableDropDetails []jobspb.DroppedTableDetails,
typesToDrop []*typedesc.Mutable,
jobDesc string,
-) error {
+) {
// TODO (lucy): This should probably be deleting the queued jobs for all the
// tables being dropped, so that we don't have duplicate schema changers.
tableIDs := make([]descpb.ID, 0, len(tableDropDetails))
@@ -54,7 +54,7 @@ func (p *planner) createDropDatabaseJob(
for _, t := range typesToDrop {
typeIDs = append(typeIDs, t.ID)
}
- jobRecord := jobs.Record{
+ jobRecord := &jobs.Record{
Description: jobDesc,
Username: p.User(),
DescriptorIDs: tableIDs,
@@ -68,12 +68,8 @@ func (p *planner) createDropDatabaseJob(
Progress: jobspb.SchemaChangeProgress{},
NonCancelable: true,
}
- newJob, err := p.extendedEvalCtx.QueueJob(ctx, p.InternalSQLTxn(), jobRecord)
- if err != nil {
- return err
- }
- log.Infof(ctx, "queued new drop database job %d for database %d", newJob.ID(), databaseID)
- return nil
+ jobID := p.extendedEvalCtx.QueueJob(jobRecord)
+ log.Infof(ctx, "queued new drop database job %d for database %d", jobID, databaseID)
}
// CreateNonDropDatabaseChangeJob covers all database descriptor updates other
@@ -82,8 +78,8 @@ func (p *planner) createDropDatabaseJob(
// don't queue multiple jobs for the same database.
func (p *planner) createNonDropDatabaseChangeJob(
ctx context.Context, databaseID descpb.ID, jobDesc string,
-) error {
- jobRecord := jobs.Record{
+) {
+ jobRecord := &jobs.Record{
Description: jobDesc,
Username: p.User(),
Details: jobspb.SchemaChangeDetails{
@@ -93,12 +89,8 @@ func (p *planner) createNonDropDatabaseChangeJob(
Progress: jobspb.SchemaChangeProgress{},
NonCancelable: true,
}
- newJob, err := p.extendedEvalCtx.QueueJob(ctx, p.InternalSQLTxn(), jobRecord)
- if err != nil {
- return err
- }
- log.Infof(ctx, "queued new database schema change job %d for database %d", newJob.ID(), databaseID)
- return nil
+ jobID := p.extendedEvalCtx.QueueJob(jobRecord)
+ log.Infof(ctx, "queued new database schema change job %d for database %d", jobID, databaseID)
}
// createOrUpdateSchemaChangeJob queues a new job for the schema change if there
@@ -116,7 +108,7 @@ func (p *planner) createOrUpdateSchemaChangeJob(
return scerrors.ConcurrentSchemaChangeError(tableDesc)
}
- record, recordExists := p.extendedEvalCtx.SchemaChangeJobRecords[tableDesc.ID]
+ record, recordExists := p.extendedEvalCtx.jobs.uniqueToCreate[tableDesc.ID]
if p.extendedEvalCtx.ExecCfg.TestingKnobs.RunAfterSCJobsCacheLookup != nil {
p.extendedEvalCtx.ExecCfg.TestingKnobs.RunAfterSCJobsCacheLookup(record)
}
@@ -174,7 +166,7 @@ func (p *planner) createOrUpdateSchemaChangeJob(
// have mutations, e.g., in CREATE TABLE AS VALUES.
NonCancelable: mutationID == descpb.InvalidMutationID && !tableDesc.Adding(),
}
- p.extendedEvalCtx.SchemaChangeJobRecords[tableDesc.ID] = &newRecord
+ p.extendedEvalCtx.jobs.uniqueToCreate[tableDesc.ID] = &newRecord
// Only add a MutationJob if there's an associated mutation.
// TODO (lucy): get rid of this when we get rid of MutationJobs.
if mutationID != descpb.InvalidMutationID {
diff --git a/pkg/sql/tenant_deletion.go b/pkg/sql/tenant_deletion.go
index eca0554e4be6..3fa5aa0f2ea9 100644
--- a/pkg/sql/tenant_deletion.go
+++ b/pkg/sql/tenant_deletion.go
@@ -45,7 +45,7 @@ func (p *planner) DropTenantByID(
p.ExecCfg().Settings,
p.InternalSQLTxn(),
p.ExecCfg().JobRegistry,
- p.extendedEvalCtx.Jobs,
+ p.extendedEvalCtx.jobs,
p.User(),
info,
synchronousImmediateDrop,
@@ -70,7 +70,7 @@ func dropTenantInternal(
settings *cluster.Settings,
txn isql.Txn,
jobRegistry *jobs.Registry,
- sessionJobs *jobsCollection,
+ sessionJobs *txnJobsCollection,
user username.SQLUsername,
info *mtinfopb.TenantInfo,
synchronousImmediateDrop bool,
@@ -124,7 +124,7 @@ func dropTenantInternal(
return errors.Wrap(err, "scheduling gc job")
}
if synchronousImmediateDrop {
- sessionJobs.add(jobID)
+ sessionJobs.addCreatedJobID(jobID)
}
return nil
}
diff --git a/pkg/sql/type_change.go b/pkg/sql/type_change.go
index e0263c89b715..e13d3c59f517 100644
--- a/pkg/sql/type_change.go
+++ b/pkg/sql/type_change.go
@@ -103,7 +103,7 @@ func (p *planner) writeTypeSchemaChange(
ctx context.Context, typeDesc *typedesc.Mutable, jobDesc string,
) error {
// Check if there is a cached specification for this type, otherwise create one.
- record, recordExists := p.extendedEvalCtx.SchemaChangeJobRecords[typeDesc.ID]
+ record, recordExists := p.extendedEvalCtx.jobs.uniqueToCreate[typeDesc.ID]
transitioningMembers, beingDropped := findTransitioningMembers(typeDesc)
if recordExists {
// Update it.
@@ -142,7 +142,7 @@ func (p *planner) writeTypeSchemaChange(
// a transition that drops an enum member.
NonCancelable: !beingDropped,
}
- p.extendedEvalCtx.SchemaChangeJobRecords[typeDesc.ID] = &newRecord
+ p.extendedEvalCtx.jobs.uniqueToCreate[typeDesc.ID] = &newRecord
log.Infof(ctx, "queued new type change job %d for type %d", newRecord.JobID, typeDesc.ID)
}
|
67179aff0e2f8f2f3bbb08a3555b7eb2aa222eed
|
2023-02-25 09:52:24
|
Jordan Lewis
|
builtins: add to_tsvector, {phrase,plain,}to_tsquery, ts_parse
| false
|
add to_tsvector, {phrase,plain,}to_tsquery, ts_parse
|
builtins
|
diff --git a/docs/generated/sql/functions.md b/docs/generated/sql/functions.md
index 12f3f5a85bc7..97a71432d98e 100644
--- a/docs/generated/sql/functions.md
+++ b/docs/generated/sql/functions.md
@@ -883,6 +883,23 @@ available replica will error.</p>
</span></td><td>Immutable</td></tr></tbody>
</table>
+### Full Text Search functions
+
+<table>
+<thead><tr><th>Function → Returns</th><th>Description</th><th>Volatility</th></tr></thead>
+<tbody>
+<tr><td><a name="phraseto_tsquery"></a><code>phraseto_tsquery(config: <a href="string.html">string</a>, text: <a href="string.html">string</a>) → tsquery</code></td><td><span class="funcdesc"><p>Converts text to a tsquery, normalizing words according to the specified or default configuration. The <-> operator is inserted between each token in the input.</p>
+</span></td><td>Immutable</td></tr>
+<tr><td><a name="plainto_tsquery"></a><code>plainto_tsquery(config: <a href="string.html">string</a>, text: <a href="string.html">string</a>) → tsquery</code></td><td><span class="funcdesc"><p>Converts text to a tsquery, normalizing words according to the specified or default configuration. The & operator is inserted between each token in the input.</p>
+</span></td><td>Immutable</td></tr>
+<tr><td><a name="to_tsquery"></a><code>to_tsquery(config: <a href="string.html">string</a>, text: <a href="string.html">string</a>) → tsquery</code></td><td><span class="funcdesc"><p>Converts the input text into a tsquery by normalizing each word in the input according to the specified or default configuration. The input must already be formatted like a tsquery, in other words, subsequent tokens must be connected by a tsquery operator (&, |, <->, !).</p>
+</span></td><td>Immutable</td></tr>
+<tr><td><a name="to_tsvector"></a><code>to_tsvector(config: <a href="string.html">string</a>, text: <a href="string.html">string</a>) → tsvector</code></td><td><span class="funcdesc"><p>Converts text to a tsvector, normalizing words according to the specified or default configuration. Position information is included in the result.</p>
+</span></td><td>Immutable</td></tr>
+<tr><td><a name="ts_parse"></a><code>ts_parse(parser_name: <a href="string.html">string</a>, document: <a href="string.html">string</a>) → tuple{int AS tokid, string AS token}</code></td><td><span class="funcdesc"><p>ts_parse parses the given document and returns a series of records, one for each token produced by parsing. Each record includes a tokid showing the assigned token type and a token which is the text of the token.</p>
+</span></td><td>Stable</td></tr></tbody>
+</table>
+
### Fuzzy String Matching functions
<table>
diff --git a/pkg/sql/logictest/testdata/logic_test/tsvector b/pkg/sql/logictest/testdata/logic_test/tsvector
index d080df2d04aa..1c1f096ec96c 100644
--- a/pkg/sql/logictest/testdata/logic_test/tsvector
+++ b/pkg/sql/logictest/testdata/logic_test/tsvector
@@ -240,3 +240,38 @@ EXPLAIN SELECT * FROM a@a_a_idx WHERE a @@ b
statement ok
CREATE TABLE t95680 (c1 FLOAT NOT NULL, c2 TSVECTOR NOT NULL, INVERTED INDEX (c1 ASC, c2 ASC));
INSERT INTO t95680 VALUES (1.0::FLOAT, e'\'kCrLZNl\' \'sVDj\' \'yO\' \'z\':54C,440B,519C,794B':::TSVECTOR);
+
+# More tests for these functions live in pkg/util/tsearch/testdata
+query IT
+SELECT * FROM ts_parse('default', 'Hello this is a parsi-ng t.est 1.234 4 case324')
+----
+1 Hello
+1 this
+1 is
+1 a
+1 parsi
+1 ng
+1 t
+1 est
+1 1
+1 234
+1 4
+1 case324
+
+query T
+SELECT * FROM to_tsvector('simple', 'Hello this is a parsi-ng t.est 1.234 4 case324')
+----
+'1':9 '234':10 '4':11 'a':4 'case324':12 'est':8 'hello':1 'is':3 'ng':6 'parsi':5 't':7 'this':2
+
+query T
+SELECT * FROM phraseto_tsquery('simple', 'Hello this is a parsi-ng t.est 1.234 4 case324')
+----
+'hello' <-> 'this' <-> 'is' <-> 'a' <-> 'parsi' <-> 'ng' <-> 't' <-> 'est' <-> '1' <-> '234' <-> '4' <-> 'case324'
+
+query T
+SELECT * FROM to_tsquery('simple', 'a | b & c <-> d')
+----
+'a' | 'b' & 'c' <-> 'd'
+
+query error syntax
+SELECT * FROM to_tsquery('simple', 'Hello this is a parsi-ng t.est 1.234 4 case324')
diff --git a/pkg/sql/sem/builtins/BUILD.bazel b/pkg/sql/sem/builtins/BUILD.bazel
index 07a9f086a962..41b764f4d186 100644
--- a/pkg/sql/sem/builtins/BUILD.bazel
+++ b/pkg/sql/sem/builtins/BUILD.bazel
@@ -24,6 +24,7 @@ go_library(
"show_create_all_tables_builtin.go",
"show_create_all_types_builtin.go",
"trigram_builtins.go",
+ "tsearch_builtins.go",
"window_builtins.go",
"window_frame_builtins.go",
],
@@ -126,6 +127,7 @@ go_library(
"//pkg/util/tracing",
"//pkg/util/tracing/tracingpb",
"//pkg/util/trigram",
+ "//pkg/util/tsearch",
"//pkg/util/ulid",
"//pkg/util/unaccent",
"//pkg/util/uuid",
diff --git a/pkg/sql/sem/builtins/builtins.go b/pkg/sql/sem/builtins/builtins.go
index 08f89d47ca95..cf083f36475d 100644
--- a/pkg/sql/sem/builtins/builtins.go
+++ b/pkg/sql/sem/builtins/builtins.go
@@ -3791,13 +3791,9 @@ value if you rely on the HLC for accuracy.`,
"array_to_tsvector": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"get_current_ts_config": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"numnode": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
- "plainto_tsquery": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
- "phraseto_tsquery": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"querytree": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"setweight": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"strip": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
- "to_tsquery": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
- "to_tsvector": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"json_to_tsvector": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"jsonb_to_tsvector": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
"ts_delete": makeBuiltin(tree.FunctionProperties{UnsupportedWithIssue: 7821, Category: builtinconstants.CategoryFullTextSearch}),
diff --git a/pkg/sql/sem/builtins/fixed_oids.go b/pkg/sql/sem/builtins/fixed_oids.go
index 1e1ae1faaaa8..42df35e3e48f 100644
--- a/pkg/sql/sem/builtins/fixed_oids.go
+++ b/pkg/sql/sem/builtins/fixed_oids.go
@@ -2045,6 +2045,11 @@ var builtinOidsArray = []string{
2069: `crdb_internal.create_tenant(parameters: jsonb) -> int`,
2070: `crdb_internal.num_inverted_index_entries(val: tsvector, version: int) -> int`,
2072: `crdb_internal.upsert_dropped_relation_gc_ttl(desc_id: int, gc_ttl: interval) -> bool`,
+ 2073: `to_tsquery(config: string, text: string) -> tsquery`,
+ 2074: `to_tsvector(config: string, text: string) -> tsvector`,
+ 2075: `phraseto_tsquery(config: string, text: string) -> tsquery`,
+ 2076: `plainto_tsquery(config: string, text: string) -> tsquery`,
+ 2077: `ts_parse(parser_name: string, document: string) -> tuple{int AS tokid, string AS token}`,
}
var builtinOidsBySignature map[string]oid.Oid
diff --git a/pkg/sql/sem/builtins/tsearch_builtins.go b/pkg/sql/sem/builtins/tsearch_builtins.go
new file mode 100644
index 000000000000..e8e71ee7be98
--- /dev/null
+++ b/pkg/sql/sem/builtins/tsearch_builtins.go
@@ -0,0 +1,169 @@
+// Copyright 2022 The Cockroach Authors.
+//
+// Use of this software is governed by the Business Source License
+// included in the file licenses/BSL.txt.
+//
+// As of the Change Date specified in that file, in accordance with
+// the Business Source License, use of this software will be governed
+// by the Apache License, Version 2.0, included in the file
+// licenses/APL.txt.
+
+package builtins
+
+import (
+ "context"
+
+ "github.com/cockroachdb/cockroach/pkg/kv"
+ "github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgcode"
+ "github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/builtins/builtinconstants"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/eval"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/tree"
+ "github.com/cockroachdb/cockroach/pkg/sql/sem/volatility"
+ "github.com/cockroachdb/cockroach/pkg/sql/types"
+ "github.com/cockroachdb/cockroach/pkg/util/tsearch"
+)
+
+func init() {
+ for k, v := range tsearchBuiltins {
+ v.props.Category = builtinconstants.CategoryFullTextSearch
+ v.props.AvailableOnPublicSchema = true
+ registerBuiltin(k, v)
+ }
+}
+
+type tsParseGenerator struct {
+ input string
+ tokens []string
+ nextToken string
+}
+
+func (t tsParseGenerator) ResolvedType() *types.T {
+ return tsParseType
+}
+
+func (t *tsParseGenerator) Start(_ context.Context, _ *kv.Txn) error {
+ t.tokens = tsearch.TSParse(t.input)
+ return nil
+}
+
+func (t *tsParseGenerator) Next(_ context.Context) (bool, error) {
+ if len(t.tokens) == 0 {
+ return false, nil
+ }
+ t.nextToken, t.tokens = t.tokens[0], t.tokens[1:]
+ return true, nil
+}
+
+func (t tsParseGenerator) Values() (tree.Datums, error) {
+ return tree.Datums{tree.NewDInt(1), tree.NewDString(t.nextToken)}, nil
+}
+
+func (t tsParseGenerator) Close(_ context.Context) {}
+
+var tsParseType = types.MakeLabeledTuple(
+ []*types.T{types.Int, types.String},
+ []string{"tokid", "token"},
+)
+
+var tsearchBuiltins = map[string]builtinDefinition{
+ "ts_parse": makeBuiltin(genProps(),
+ makeGeneratorOverload(
+ tree.ParamTypes{{Name: "parser_name", Typ: types.String}, {Name: "document", Typ: types.String}},
+ types.MakeLabeledTuple(
+ []*types.T{types.Int, types.String},
+ []string{"tokid", "token"},
+ ),
+ func(_ context.Context, _ *eval.Context, args tree.Datums) (eval.ValueGenerator, error) {
+ parserName := string(tree.MustBeDString(args[0]))
+ if parserName != "default" {
+ return nil, pgerror.Newf(pgcode.UndefinedObject, "text search parser %q does not exist", parserName)
+ }
+ return &tsParseGenerator{input: string(tree.MustBeDString(args[1]))}, nil
+ },
+ "ts_parse parses the given document and returns a series of records, "+
+ "one for each token produced by parsing. "+
+ "Each record includes a tokid showing the assigned token type and a token which is the text of the token.",
+ volatility.Stable,
+ ),
+ ),
+ // Full text search functions.
+ "to_tsvector": makeBuiltin(
+ tree.FunctionProperties{},
+ tree.Overload{
+ Types: tree.ParamTypes{{Name: "config", Typ: types.String}, {Name: "text", Typ: types.String}},
+ ReturnType: tree.FixedReturnType(types.TSVector),
+ Fn: func(_ context.Context, evalCtx *eval.Context, args tree.Datums) (tree.Datum, error) {
+ // Parse, stem, and stopword the input.
+ config := string(tree.MustBeDString(args[0]))
+ document := string(tree.MustBeDString(args[1]))
+ vector, err := tsearch.DocumentToTSVector(config, document)
+ if err != nil {
+ return nil, err
+ }
+ return &tree.DTSVector{TSVector: vector}, nil
+ },
+ Info: "Converts text to a tsvector, normalizing words according to the specified or default configuration. " +
+ "Position information is included in the result.",
+ Volatility: volatility.Immutable,
+ },
+ ),
+ "to_tsquery": makeBuiltin(
+ tree.FunctionProperties{},
+ tree.Overload{
+ Types: tree.ParamTypes{{Name: "config", Typ: types.String}, {Name: "text", Typ: types.String}},
+ ReturnType: tree.FixedReturnType(types.TSQuery),
+ Fn: func(_ context.Context, evalCtx *eval.Context, args tree.Datums) (tree.Datum, error) {
+ config := string(tree.MustBeDString(args[0]))
+ input := string(tree.MustBeDString(args[1]))
+ query, err := tsearch.ToTSQuery(config, input)
+ if err != nil {
+ return nil, err
+ }
+ return &tree.DTSQuery{TSQuery: query}, nil
+ },
+ Info: "Converts the input text into a tsquery by normalizing each word in the input according to " +
+ "the specified or default configuration. The input must already be formatted like a tsquery, in other words, " +
+ "subsequent tokens must be connected by a tsquery operator (&, |, <->, !).",
+ Volatility: volatility.Immutable,
+ },
+ ),
+ "plainto_tsquery": makeBuiltin(
+ tree.FunctionProperties{},
+ tree.Overload{
+ Types: tree.ParamTypes{{Name: "config", Typ: types.String}, {Name: "text", Typ: types.String}},
+ ReturnType: tree.FixedReturnType(types.TSQuery),
+ Fn: func(_ context.Context, evalCtx *eval.Context, args tree.Datums) (tree.Datum, error) {
+ config := string(tree.MustBeDString(args[0]))
+ input := string(tree.MustBeDString(args[1]))
+ query, err := tsearch.PlainToTSQuery(config, input)
+ if err != nil {
+ return nil, err
+ }
+ return &tree.DTSQuery{TSQuery: query}, nil
+ },
+ Info: "Converts text to a tsquery, normalizing words according to the specified or default configuration." +
+ " The & operator is inserted between each token in the input.",
+ Volatility: volatility.Immutable,
+ },
+ ),
+ "phraseto_tsquery": makeBuiltin(
+ tree.FunctionProperties{},
+ tree.Overload{
+ Types: tree.ParamTypes{{Name: "config", Typ: types.String}, {Name: "text", Typ: types.String}},
+ ReturnType: tree.FixedReturnType(types.TSQuery),
+ Fn: func(_ context.Context, evalCtx *eval.Context, args tree.Datums) (tree.Datum, error) {
+ config := string(tree.MustBeDString(args[0]))
+ input := string(tree.MustBeDString(args[1]))
+ query, err := tsearch.PhraseToTSQuery(config, input)
+ if err != nil {
+ return nil, err
+ }
+ return &tree.DTSQuery{TSQuery: query}, nil
+ },
+ Info: "Converts text to a tsquery, normalizing words according to the specified or default configuration." +
+ " The <-> operator is inserted between each token in the input.",
+ Volatility: volatility.Immutable,
+ },
+ ),
+}
diff --git a/pkg/sql/sem/eval/testdata/eval/tsearch b/pkg/sql/sem/eval/testdata/eval/tsearch
index e259a326fffd..a2b8087d672e 100644
--- a/pkg/sql/sem/eval/testdata/eval/tsearch
+++ b/pkg/sql/sem/eval/testdata/eval/tsearch
@@ -60,3 +60,48 @@ eval
'bar:3 baz:5'::tsvector @@ 'baz <2> bar'::tsquery
----
false
+
+eval
+to_tsvector('simple', 'You have power over your mind – not outside events. Realize this, and you will find strength.')
+----
+'and':12 'events':9 'find':15 'have':2 'mind':6 'not':7 'outside':8 'over':4 'power':3 'realize':10 'strength':16 'this':11 'will':14 'you':1,13 'your':5
+
+eval
+to_tsquery('simple', 'hello')
+----
+'hello'
+
+eval
+to_tsquery('simple', 'hello | there')
+----
+'hello' | 'there'
+
+eval
+to_tsquery('simple', 'hello | the#re')
+----
+'hello' | 'the' <-> 're'
+
+eval
+plainto_tsquery('simple', 'hello there')
+----
+'hello' & 'there'
+
+eval
+plainto_tsquery('simple', 'hello the#re')
+----
+'hello' & 'the' & 're'
+
+eval
+phraseto_tsquery('simple', 'You have power over your mind – not outside events. Realize this, and you will find strength.')
+----
+'you' <-> 'have' <-> 'power' <-> 'over' <-> 'your' <-> 'mind' <-> 'not' <-> 'outside' <-> 'events' <-> 'realize' <-> 'this' <-> 'and' <-> 'you' <-> 'will' <-> 'find' <-> 'strength'
+
+eval
+phraseto_tsquery('simple', 'hello there')
+----
+'hello' <-> 'there'
+
+eval
+phraseto_tsquery('simple', 'hello the#re')
+----
+'hello' <-> 'the' <-> 're'
diff --git a/pkg/util/tsearch/tsquery.go b/pkg/util/tsearch/tsquery.go
index 8b8610b59384..5200e8947cb2 100644
--- a/pkg/util/tsearch/tsquery.go
+++ b/pkg/util/tsearch/tsquery.go
@@ -81,6 +81,24 @@ func (o tsOperator) pgwireEncoding() byte {
panic(errors.AssertionFailedf("no pgwire encoding for operator %d", o))
}
+func (o tsOperator) String() string {
+ switch o {
+ case not:
+ return "!"
+ case and:
+ return "&"
+ case or:
+ return "|"
+ case followedby:
+ return "<->"
+ case lparen:
+ return "("
+ case rparen:
+ return ")"
+ }
+ panic(errors.AssertionFailedf("no string for operator %d", o))
+}
+
func tsOperatorFromPgwireEncoding(b byte) (tsOperator, error) {
switch b {
case 1:
@@ -405,3 +423,107 @@ func (p *tsQueryParser) parseTSExpr(minBindingPower int) (*tsNode, error) {
func (p *tsQueryParser) syntaxError() (*tsNode, error) {
return nil, pgerror.Newf(pgcode.Syntax, "syntax error in TSQuery: %s", p.input)
}
+
+// ToTSQuery implements the to_tsquery builtin, which lexes an input, performs
+// stopwording and normalization on the tokens, and returns a parsed query.
+func ToTSQuery(config string, input string) (TSQuery, error) {
+ return toTSQuery(config, invalid, input)
+}
+
+// PlainToTSQuery implements the plainto_tsquery builtin, which lexes an input,
+// performs stopwording and normalization on the tokens, and returns a parsed
+// query, interposing the & operator between each token.
+func PlainToTSQuery(config string, input string) (TSQuery, error) {
+ return toTSQuery(config, and, input)
+}
+
+// PhraseToTSQuery implements the phraseto_tsquery builtin, which lexes an input,
+// performs stopwording and normalization on the tokens, and returns a parsed
+// query, interposing the <-> operator between each token.
+func PhraseToTSQuery(config string, input string) (TSQuery, error) {
+ return toTSQuery(config, followedby, input)
+}
+
+// toTSQuery implements the to_tsquery builtin, which lexes an input,
+// performs stopwording and normalization on the tokens, and returns a parsed
+// query. If the interpose operator is not invalid, it's interposed between each
+// token in the input.
+func toTSQuery(config string, interpose tsOperator, input string) (TSQuery, error) {
+ switch config {
+ case "simple":
+ default:
+ return TSQuery{}, pgerror.Newf(pgcode.UndefinedObject, "text search configuration %q does not exist", config)
+ }
+
+ vector, err := lexTSQuery(input)
+ if err != nil {
+ return TSQuery{}, err
+ }
+ tokens := make(TSVector, 0, len(vector))
+ for i := range vector {
+ tok := vector[i]
+
+ foundOperator := tok.operator != invalid
+ var lexemeTokens []string
+
+ if !foundOperator {
+ // Try parsing the token.
+ lexemeTokens = TSParse(tok.lexeme)
+ }
+
+ // If we found an operator or were able to parse lexemes from the token,
+ // add the interpose operator if there is one.
+ if interpose != invalid && i > 0 && (foundOperator || len(lexemeTokens) > 0) {
+ term := tsTerm{operator: interpose}
+ if interpose == followedby {
+ term.followedN = 1
+ }
+ tokens = append(tokens, term)
+ }
+
+ if foundOperator {
+ tokens = append(tokens, tok)
+ continue
+ }
+
+ if len(lexemeTokens) == 0 {
+ // We ate some whitespace or whitespace-like text with no tokens.
+ continue
+ }
+
+ // When we support more than just the simple configuration, we'll also
+ // want to remove stopwords, which will affect the interposing, but we can
+ // worry about that later.
+ // Additionally, if we're doing phraseto_tsquery, if we remove a stopword,
+ // we need to make sure to increase the "followedN" of the followedby
+ // operator. For example, phraseto_tsquery('hello a deer') will return
+ // 'hello <2> deer', since the a stopword would be removed.
+
+ tokInterpose := interpose
+ if tokInterpose == invalid {
+ tokInterpose = followedby
+ }
+ for j := range lexemeTokens {
+ if j > 0 {
+ // We found more than one lexeme in our token, so we need to add all of them
+ // to the query, connected by our interpose operator.
+ // If we aren't running with an interpose, like in to_tsquery, Postgres
+ // uses the <-> operator to connect multiple lexemes from a single token.
+ term := tsTerm{operator: tokInterpose}
+ if tokInterpose == followedby {
+ term.followedN = 1
+ }
+ tokens = append(tokens, term)
+ }
+ lexeme, err := TSLexize(config, lexemeTokens[j])
+ if err != nil {
+ return TSQuery{}, err
+ }
+ tokens = append(tokens, tsTerm{lexeme: lexeme})
+ }
+ }
+
+ // Now create the operator tree.
+ queryParser := tsQueryParser{terms: tokens, input: input}
+ return queryParser.parse()
+}
diff --git a/pkg/util/tsearch/tsvector.go b/pkg/util/tsearch/tsvector.go
index 7f3f51333b41..073269b057df 100644
--- a/pkg/util/tsearch/tsvector.go
+++ b/pkg/util/tsearch/tsvector.go
@@ -15,6 +15,7 @@ import (
"sort"
"strconv"
"strings"
+ "unicode"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgcode"
"github.com/cockroachdb/cockroach/pkg/sql/pgwire/pgerror"
@@ -256,6 +257,10 @@ func ParseTSVector(input string) (TSVector, error) {
return ret, err
}
+ return normalizeTSVector(ret)
+}
+
+func normalizeTSVector(ret TSVector) (TSVector, error) {
if len(ret) > 1 {
// Sort and de-duplicate the resultant TSVector.
sort.Slice(ret, func(i, j int) bool {
@@ -289,3 +294,62 @@ func ParseTSVector(input string) (TSVector, error) {
}
return ret, nil
}
+
+var validCharTables = []*unicode.RangeTable{unicode.Letter, unicode.Number}
+
+// TSParse is the function that splits an input text into a list of
+// tokens. For now, the parser that we use is very simple: it merely lowercases
+// the input and splits it into tokens based on assuming that non-letter,
+// non-number characters are whitespace.
+//
+// The Postgres text search parser is much, much more sophisticated. The
+// documentation (https://www.postgresql.org/docs/current/textsearch-parsers.html)
+// gives more information, but roughly, each token is categorized into one of
+// about 20 different buckets, such as asciiword, url, email, host, float, int,
+// version, tag, etc. It uses very specific rules to produce these outputs.
+// Another interesting transformation is returning multiple tokens for a
+// hyphenated word, including a token that represents the entire hyphenated word,
+// as well as one for each of the hyphenated components.
+//
+// It's not clear whether we need to exactly mimic this functionality. Likely,
+// we will eventually want to do this.
+func TSParse(input string) []string {
+ return strings.FieldsFunc(input, func(r rune) bool {
+ return !unicode.IsOneOf(validCharTables, r)
+ })
+}
+
+// TSLexize implements the "dictionary" construct that's exposed via ts_lexize.
+// It gets invoked once per input token to produce an output lexeme during
+// routines like to_tsvector and to_tsquery.
+func TSLexize(config string, token string) (lexeme string, err error) {
+ if config != "simple" {
+ return "", pgerror.Newf(pgcode.UndefinedObject, "text search configuration %q does not exist", config)
+ }
+ return strings.ToLower(token), nil
+}
+
+// DocumentToTSVector parses an input document into lexemes, removes stop words,
+// stems and normalizes the lexemes, and returns a TSVector annotated with
+// lexeme positions according to a text search configuration passed by name.
+func DocumentToTSVector(config string, input string) (TSVector, error) {
+ if config != "simple" {
+ return nil, pgerror.Newf(pgcode.UndefinedObject, "text search configuration %q does not exist", config)
+ }
+
+ tokens := TSParse(input)
+ vector := make(TSVector, len(tokens))
+ for i := range tokens {
+ lexeme, err := TSLexize(config, tokens[i])
+ if err != nil {
+ return nil, err
+ }
+ vector[i].lexeme = lexeme
+ pos := i + 1
+ if i > maxTSVectorPosition {
+ pos = maxTSVectorPosition
+ }
+ vector[i].positions = []tsPosition{{position: uint16(pos)}}
+ }
+ return normalizeTSVector(vector)
+}
|
d517243b5d876a67090ab5b4f0b731417fc54d9e
|
2023-06-29 02:14:09
|
Chengxiong Ruan
|
sql: skip multiregional tests again
| false
|
skip multiregional tests again
|
sql
|
diff --git a/pkg/ccl/multiregionccl/testdata/secondary_region b/pkg/ccl/multiregionccl/testdata/secondary_region
index 9fb454dab0cb..16a3c9fc94da 100644
--- a/pkg/ccl/multiregionccl/testdata/secondary_region
+++ b/pkg/ccl/multiregionccl/testdata/secondary_region
@@ -1,3 +1,6 @@
+skip issue-num=98020
+----
+
new-cluster localities=us-east-1,us-east-1,us-west-1,us-west-1,us-central-1,us-central-1,us-central-1,eu-west-1,eu-west-1,eu-west-1
----
|
2f8130c2bcd43d05e933bd50188f18213fdfea50
|
2018-09-24 05:50:10
|
Nikhil Benesch
|
security: remove stale comment
| false
|
remove stale comment
|
security
|
diff --git a/pkg/security/tls.go b/pkg/security/tls.go
index 1561d6fb7ee4..7e358e4395dc 100644
--- a/pkg/security/tls.go
+++ b/pkg/security/tls.go
@@ -14,9 +14,6 @@
package security
-// TODO(jqmp): The use of TLS here is just a proof of concept; its security
-// properties haven't been analyzed or audited.
-
import (
"crypto/tls"
"crypto/x509"
|
90caff2e97cbfde566da71fa2bdafa5f034cbbf3
|
2016-06-22 03:13:06
|
Cuong Do
|
acceptance: various allocator test enhancements
| false
|
various allocator test enhancements
|
acceptance
|
diff --git a/acceptance/allocator_terraform/load.tf b/acceptance/allocator_terraform/load.tf
index 84e6f72b2b74..0829dab7f9cc 100644
--- a/acceptance/allocator_terraform/load.tf
+++ b/acceptance/allocator_terraform/load.tf
@@ -3,11 +3,8 @@
variable "example_block_writer_instances" {
default = 1
}
-#output "block_writer_ips" {
-# value = "${join(",", google_compute_instance.block_writer.*.network_interface.0.access_config.0.assigned_nat_ip)}"
-#}
output "example_block_writer" {
- value = "${join(",", google_compute_instance.block_writer.*.name)}"
+ value = "${join(",", google_compute_instance.block_writer.*.network_interface.0.access_config.0.assigned_nat_ip)}"
}
resource "google_compute_instance" "block_writer" {
diff --git a/acceptance/allocator_terraform/main.tf b/acceptance/allocator_terraform/main.tf
index a2d74a26dcc5..667b4cbb952f 100644
--- a/acceptance/allocator_terraform/main.tf
+++ b/acceptance/allocator_terraform/main.tf
@@ -49,6 +49,7 @@ resource "template_file" "supervisor" {
# We need to provide one node address for the block writer.
node_address = "${google_compute_instance.cockroach.0.network_interface.0.access_config.0.assigned_nat_ip}"
cockroach_flags = "${var.cockroach_flags}"
+ cockroach_env = "${var.cockroach_env}"
}
}
diff --git a/acceptance/allocator_terraform/supervisor.conf.tpl b/acceptance/allocator_terraform/supervisor.conf.tpl
index d9a5ce18347b..d3f40deea125 100644
--- a/acceptance/allocator_terraform/supervisor.conf.tpl
+++ b/acceptance/allocator_terraform/supervisor.conf.tpl
@@ -22,7 +22,7 @@ serverurl=http://127.0.0.1:9001 ; use an http:// url to specify an inet socket
[program:cockroach]
directory=%(here)s
-command=%(here)s/cockroach start --alsologtostderr=true ${stores} --insecure --join=${join_address} ${cockroach_flags}
+command=%(here)s/cockroach start --alsologtostderr=true ${stores} --insecure --join=${join_address} --verbosity=1 ${cockroach_flags}
process_name=%(program_name)s
numprocs=1
autostart=false
@@ -32,6 +32,7 @@ startretries=0
stopwaitsecs=90
stderr_logfile=%(here)s/logs/%(program_name)s.stderr
stdout_logfile=%(here)s/logs/%(program_name)s.stdout
+environment=${cockroach_env}
[program:block_writer]
directory=%(here)s
diff --git a/acceptance/allocator_terraform/variables.tf b/acceptance/allocator_terraform/variables.tf
index d1cde6f9f8e0..d21bf4f9299a 100644
--- a/acceptance/allocator_terraform/variables.tf
+++ b/acceptance/allocator_terraform/variables.tf
@@ -89,3 +89,15 @@ variable "cockroach_machine_type" {
variable "cockroach_disk_size" {
default = "50" # GB
}
+
+# Environment variables to pass into CockroachDB through the supervisor config.
+# This must be of the following form:
+#
+# VAR1=value1[,VAR2=value2,...]
+#
+# Relevant supervisor docs:
+#
+# https://www.terraform.io/docs/configuration/variables.html
+variable "cockroach_env" {
+ default = ""
+}
diff --git a/acceptance/allocator_test.go b/acceptance/allocator_test.go
index 04d1f6281703..e1645d0728fb 100644
--- a/acceptance/allocator_test.go
+++ b/acceptance/allocator_test.go
@@ -32,7 +32,7 @@ package acceptance
//
// make acceptance \
// TESTFLAGS="-v --remote -key-name google_compute_engine -cwd=allocator_terraform" \
-// TESTS="TestUpreplicate1To3Small" \
+// TESTS="TestUpreplicate1to3Small" \
// TESTTIMEOUT="24h"
//
// Things to note:
@@ -47,7 +47,9 @@ package acceptance
// - Your Google Cloud credentials must be accessible by Terraform, as described
// here:
// https://www.terraform.io/docs/providers/google/
-// - Add "-cockroach-binary" to TESTFLAGS to specify a custom Linux CockroachDB
+// - There are various flags that start with `tf.` and `at.` that control the
+// of Terrafarm and allocator tests, respectively. For example, you can add
+// "-at.cockroach-binary" to TESTFLAGS to specify a custom Linux CockroachDB
// binary. If omitted, your test will use the latest CircleCI Linux build.
import (
@@ -57,7 +59,6 @@ import (
"net/http"
"os"
"strconv"
- "sync"
"testing"
"time"
@@ -104,7 +105,7 @@ func (at *allocatorTest) Run(t *testing.T) {
at.f = farmer(t, at.Prefix)
defer func() {
if r := recover(); r != nil {
- t.Errorf("recovered from panic to destroy cluster")
+ t.Errorf("recovered from panic to destroy cluster: %v", r)
}
at.f.MustDestroy()
}()
@@ -114,8 +115,14 @@ func (at *allocatorTest) Run(t *testing.T) {
}
// Pass on overrides to Terraform input variables.
- if *flagCockroachBinary != "" {
- at.f.AddVars["cockroach_binary"] = *flagCockroachBinary
+ if *flagATCockroachBinary != "" {
+ at.f.AddVars["cockroach_binary"] = *flagATCockroachBinary
+ }
+ if *flagATCockroachFlags != "" {
+ at.f.AddVars["cockroach_flags"] = *flagATCockroachFlags
+ }
+ if *flagATCockroachEnv != "" {
+ at.f.AddVars["cockroach_env"] = *flagATCockroachEnv
}
if at.CockroachDiskSizeGB != 0 {
at.f.AddVars["cockroach_disk_size"] = strconv.Itoa(at.CockroachDiskSizeGB)
@@ -130,18 +137,17 @@ func (at *allocatorTest) Run(t *testing.T) {
log.Info("initial cluster is up")
log.Info("downloading archived stores from Google Cloud Storage in parallel")
- var wg sync.WaitGroup
errors := make(chan error, at.f.NumNodes())
for i := 0; i < at.f.NumNodes(); i++ {
- wg.Add(1)
go func(nodeNum int) {
- defer wg.Done()
- if err := at.f.Exec(nodeNum, "./nodectl download "+at.StoreURL); err != nil {
- errors <- err
- }
+ errors <- at.f.Exec(nodeNum, "./nodectl download "+at.StoreURL)
}(i)
}
- wg.Wait()
+ for i := 0; i < at.f.NumNodes(); i++ {
+ if err := <-errors; err != nil {
+ t.Fatalf("error downloading store %d: %s", i, err)
+ }
+ }
log.Info("restarting cluster with archived store(s)")
for i := 0; i < at.f.NumNodes(); i++ {
@@ -226,17 +232,28 @@ func (at *allocatorTest) printRebalanceStats(db *gosql.DB, host string, adminPor
return nil
}
-// checkAllocatorStable returns whether the replica distribution within the cluster has
-// been stable for at least `StableInterval`.
+// checkAllocatorStable returns whether the replica distribution within the
+// cluster has been stable for at least `StableInterval`. Only unrecoverable
+// errors are returned.
func (at *allocatorTest) checkAllocatorStable(db *gosql.DB) (bool, error) {
- q := `SELECT NOW() - MAX(timestamp) FROM rangelog WHERE eventType IN ($1, $2, $3)`
+ q := `SELECT NOW()-timestamp, rangeID, storeID, eventType FROM rangelog WHERE ` +
+ `timestamp=(SELECT MAX(timestamp) FROM rangelog WHERE eventType IN ($1, $2, $3))`
eventTypes := []interface{}{
string(storage.RangeEventLogSplit),
string(storage.RangeEventLogAdd),
string(storage.RangeEventLogRemove),
}
var elapsedStr string
- if err := db.QueryRow(q, eventTypes...).Scan(&elapsedStr); err != nil {
+ var rangeID int64
+ var storeID int64
+ var eventType string
+
+ row := db.QueryRow(q, eventTypes...)
+ if row == nil {
+ log.Errorf("couldn't find any range events")
+ return false, nil
+ }
+ if err := row.Scan(&elapsedStr, &rangeID, &storeID, &eventType); err != nil {
// Log but don't return errors, to increase resilience against transient
// errors.
log.Errorf("error checking rebalancer: %s", err)
@@ -247,15 +264,9 @@ func (at *allocatorTest) checkAllocatorStable(db *gosql.DB) (bool, error) {
return false, err
}
- var status string
- stable := elapsedSinceLastRangeEvent >= StableInterval
- if stable {
- status = fmt.Sprintf("allocator is stable (idle for %s)", StableInterval)
- } else {
- status = "waiting for idle allocator"
- }
- log.Infof("last range event was %s ago: %s", elapsedSinceLastRangeEvent, status)
- return stable, nil
+ log.Infof("last range event: %s for range %d/store %d (%s ago)",
+ eventType, rangeID, storeID, elapsedSinceLastRangeEvent)
+ return elapsedSinceLastRangeEvent >= StableInterval, nil
}
// WaitForRebalance waits until there's been no recent range adds, removes, and
@@ -305,7 +316,7 @@ func (at *allocatorTest) WaitForRebalance() error {
// TestUpreplicate1To3Small tests up-replication, starting with 1 node
// containing 10 GiB of data and growing to 3 nodes.
-func TestUpreplicate1To3Small(t *testing.T) {
+func TestUpreplicate1to3Small(t *testing.T) {
at := allocatorTest{
StartNodes: 1,
EndNodes: 3,
diff --git a/acceptance/terrafarm/farmer.go b/acceptance/terrafarm/farmer.go
index 3eadbe4a437f..3496ca85e882 100644
--- a/acceptance/terrafarm/farmer.go
+++ b/acceptance/terrafarm/farmer.go
@@ -46,8 +46,9 @@ type Farmer struct {
// state.
StateFile string
// AddVars are additional Terraform variables to be set during calls to Add.
- AddVars map[string]string
- nodes, writers []string
+ AddVars map[string]string
+ KeepClusterAfterTest bool
+ nodes, writers []string
}
func (f *Farmer) refresh() {
@@ -154,6 +155,10 @@ func (f *Farmer) Destroy() error {
if f.LogDir != "" {
defer f.logf("logs copied to %s", f.AbsLogDir())
}
+ if f.KeepClusterAfterTest {
+ f.logf("not destroying cluster")
+ return nil
+ }
return f.Resize(0, 0)
}
diff --git a/acceptance/util_test.go b/acceptance/util_test.go
index 1d2b952d2fcb..25801606d5c2 100644
--- a/acceptance/util_test.go
+++ b/acceptance/util_test.go
@@ -37,6 +37,7 @@ import (
"github.com/cockroachdb/cockroach/base"
"github.com/cockroachdb/cockroach/util/caller"
"github.com/cockroachdb/cockroach/util/log"
+ "github.com/cockroachdb/cockroach/util/timeutil"
_ "github.com/cockroachdb/pq"
)
@@ -54,7 +55,17 @@ var flagConfig = flag.String("config", "", "a json TestConfig proto, see testcon
var flagPrivileged = flag.Bool("privileged", os.Getenv("CIRCLECI") != "true",
"run containers in privileged mode (required for nemesis tests")
-var flagCockroachBinary = flag.String("cockroach-binary", "", "path to custom CockroachDB binary to use")
+var flagTFKeepCluster = flag.Bool("tf.keep-cluster", false, "do not destroy Terraform cluster after test finishes")
+
+// TODO(cuongdo): These should be refactored so that they're not allocator
+// test-specific when we have more than one kind of system test that uses these
+// flags.
+var flagATCockroachBinary = flag.String("at.cockroach-binary", "",
+ "path to custom CockroachDB binary to use for allocator tests")
+var flagATCockroachFlags = flag.String("at.cockroach-flags", "",
+ "command-line flags to pass to cockroach for allocator tests")
+var flagATCockroachEnv = flag.String("at.cockroach-env", "",
+ "supervisor-style environment variables to pass to cockroach")
var testFuncRE = regexp.MustCompile("^(Test|Benchmark)")
@@ -99,14 +110,17 @@ func farmer(t *testing.T, prefix string) *terrafarm.Farmer {
t.Fatalf("farmer prefix must match regex %s", prefixRE)
}
f := &terrafarm.Farmer{
- Output: os.Stderr,
- Cwd: *flagCwd,
- LogDir: logDir,
- KeyName: *flagKeyName,
- Stores: stores,
- Prefix: prefix,
- StateFile: prefix + ".tfstate",
- AddVars: make(map[string]string),
+ Output: os.Stderr,
+ Cwd: *flagCwd,
+ LogDir: logDir,
+ KeyName: *flagKeyName,
+ Stores: stores,
+ Prefix: prefix,
+ // Prepend Terraform resource names and state file name with date/time to
+ // allow concurrent runs of the same test.
+ StateFile: timeutil.Now().Format("20060102-150405-") + prefix + ".tfstate",
+ AddVars: make(map[string]string),
+ KeepClusterAfterTest: *flagTFKeepCluster,
}
log.Infof("logging to %s", logDir)
return f
|
bfc190d964c66cb6d78b11a4900f290e96c01006
|
2018-09-06 04:00:20
|
Raphael 'kena' Poss
|
cli: mark `cockroach zone` commands as deprecated
| false
|
mark `cockroach zone` commands as deprecated
|
cli
|
diff --git a/pkg/cli/zone.go b/pkg/cli/zone.go
index 11caa0286802..22b240e89349 100644
--- a/pkg/cli/zone.go
+++ b/pkg/cli/zone.go
@@ -61,8 +61,9 @@ var getZoneCmd = &cobra.Command{
Fetches and displays the zone configuration for the specified database or
table.
`,
- Args: cobra.ExactArgs(1),
- RunE: MaybeDecorateGRPCError(runGetZone),
+ Args: cobra.ExactArgs(1),
+ RunE: MaybeDecorateGRPCError(runGetZone),
+ Deprecated: "use SHOW ZONE CONFIGURATION FOR ... in a SQL client instead.",
}
// runGetZone retrieves the zone config for a given object id,
@@ -126,8 +127,9 @@ var lsZonesCmd = &cobra.Command{
Long: `
List zone configs.
`,
- Args: cobra.NoArgs,
- RunE: MaybeDecorateGRPCError(runLsZones),
+ Args: cobra.NoArgs,
+ RunE: MaybeDecorateGRPCError(runLsZones),
+ Deprecated: "use SHOW ZONE CONFIGURATIONS in a SQL client instead.",
}
func runLsZones(cmd *cobra.Command, args []string) error {
@@ -179,8 +181,9 @@ var rmZoneCmd = &cobra.Command{
Long: `
Remove an existing zone config for the specified database or table.
`,
- Args: cobra.ExactArgs(1),
- RunE: MaybeDecorateGRPCError(runRmZone),
+ Args: cobra.ExactArgs(1),
+ RunE: MaybeDecorateGRPCError(runRmZone),
+ Deprecated: "use ALTER ... CONFIGURE ZONE DISCARD in a SQL client instead.",
}
func runRmZone(cmd *cobra.Command, args []string) error {
@@ -236,8 +239,9 @@ EOF
Note that the specified zone config is merged with the existing zone config for
the database or table.
`,
- Args: cobra.ExactArgs(1),
- RunE: MaybeDecorateGRPCError(runSetZone),
+ Args: cobra.ExactArgs(1),
+ RunE: MaybeDecorateGRPCError(runSetZone),
+ Deprecated: "use ALTER ... CONFIGURE ZONE in a SQL client instead.",
}
func readZoneConfig() (conf []byte, err error) {
|
dcd32738b79bda3496069160873a07261f7033ab
|
2022-10-17 19:49:37
|
irfan sharif
|
roachtest: de-flake admission-control/tpcc-olap
| false
|
de-flake admission-control/tpcc-olap
|
roachtest
|
diff --git a/pkg/cmd/roachtest/tests/admission_control_tpcc_overload.go b/pkg/cmd/roachtest/tests/admission_control_tpcc_overload.go
index 0117163f2845..60d23a449565 100644
--- a/pkg/cmd/roachtest/tests/admission_control_tpcc_overload.go
+++ b/pkg/cmd/roachtest/tests/admission_control_tpcc_overload.go
@@ -51,6 +51,10 @@ func (s tpccOLAPSpec) run(ctx context.Context, t test.Test, c cluster.Cluster) {
ctx, t, c, tpccOptions{
Warehouses: s.Warehouses, SetupType: usingImport,
})
+ // We make use of querybench below, only available through the `workload`
+ // binary.
+ c.Put(ctx, t.DeprecatedWorkload(), "./workload", workloadNode)
+
const queryFileName = "queries.sql"
// querybench expects the entire query to be on a single line.
queryLine := `"` + strings.Replace(tpccOlapQuery, "\n", " ", -1) + `"`
|
78d3f0c121e25e3408fa39b2984e36f5ad6b32dd
|
2020-08-20 07:21:23
|
Andrei Matei
|
kvclient: improve a test
| false
|
improve a test
|
kvclient
|
diff --git a/pkg/kv/kvclient/kvcoord/dist_sender_test.go b/pkg/kv/kvclient/kvcoord/dist_sender_test.go
index 1c631d425b04..2356435f6464 100644
--- a/pkg/kv/kvclient/kvcoord/dist_sender_test.go
+++ b/pkg/kv/kvclient/kvcoord/dist_sender_test.go
@@ -1674,8 +1674,7 @@ func TestDistSenderDescriptorUpdatesOnSuccessfulRPCs(t *testing.T) {
// Check that the cache has the updated descriptor returned by the RPC.
for _, ri := range tc {
rk := ri.Desc.StartKey
- entry, err := ds.rangeCache.Lookup(ctx, rk)
- require.NoError(t, err)
+ entry := ds.rangeCache.GetCached(ctx, rk, false /* inverted */)
require.NotNil(t, entry)
require.Equal(t, &ri.Desc, entry.Desc())
if ri.Lease.Empty() {
|
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.