Skip to content

Commit

Permalink
fix test
Browse files Browse the repository at this point in the history
Signed-off-by: Yang Keao <yangkeao@chunibyo.icu>
  • Loading branch information
YangKeao committed Oct 23, 2023
1 parent 264a5bc commit bbf2ed9
Show file tree
Hide file tree
Showing 33 changed files with 119 additions and 126 deletions.
3 changes: 2 additions & 1 deletion pkg/ddl/backfilling_scheduler.go
Original file line number Diff line number Diff line change
Expand Up @@ -32,6 +32,7 @@ import (
"github.com/pingcap/tidb/pkg/sessionctx"
"github.com/pingcap/tidb/pkg/sessionctx/variable"
"github.com/pingcap/tidb/pkg/table"
"github.com/pingcap/tidb/pkg/types"
"github.com/pingcap/tidb/pkg/util"
"github.com/pingcap/tidb/pkg/util/dbterror"
"github.com/pingcap/tidb/pkg/util/intest"
Expand Down Expand Up @@ -160,7 +161,7 @@ func initSessCtx(
sessCtx.GetSessionVars().StmtCtx.OverflowAsWarning = !sqlMode.HasStrictMode()
sessCtx.GetSessionVars().StmtCtx.DividedByZeroAsWarning = !sqlMode.HasStrictMode()

typeFlags := sessCtx.GetSessionVars().StmtCtx.TypeFlags().
typeFlags := types.StrictFlags.
WithTruncateAsWarning(!sqlMode.HasStrictMode()).
WithIgnoreInvalidDateErr(sqlMode.HasAllowInvalidDatesMode()).
WithIgnoreZeroInDate(!sqlMode.HasStrictMode() || sqlMode.HasAllowInvalidDatesMode())
Expand Down
2 changes: 1 addition & 1 deletion pkg/ddl/ddl_api.go
Original file line number Diff line number Diff line change
Expand Up @@ -1344,7 +1344,7 @@ func getDefaultValue(ctx sessionctx.Context, col *table.Column, option *ast.Colu
if tp == mysql.TypeBit || tp == mysql.TypeString || tp == mysql.TypeVarchar ||
tp == mysql.TypeVarString || tp == mysql.TypeEnum || tp == mysql.TypeSet {
// For BinaryLiteral or bit fields, we decode the default value to utf8 string.
str, err := v.GetBinaryStringDecoded(types.DefaultStmtFlags, col.GetCharset())
str, err := v.GetBinaryStringDecoded(types.StrictFlags, col.GetCharset())
if err != nil {
// Overwrite the decoding error with invalid default value error.
err = dbterror.ErrInvalidDefaultValue.GenWithStackByArgs(col.Name.O)
Expand Down
1 change: 0 additions & 1 deletion pkg/domain/BUILD.bazel
Original file line number Diff line number Diff line change
Expand Up @@ -141,7 +141,6 @@ go_test(
"//pkg/parser/terror",
"//pkg/server",
"//pkg/session",
"//pkg/sessionctx/stmtctx",
"//pkg/sessionctx/variable",
"//pkg/store/mockstore",
"//pkg/testkit",
Expand Down
3 changes: 1 addition & 2 deletions pkg/domain/domain_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -35,7 +35,6 @@ import (
"github.com/pingcap/tidb/pkg/parser/ast"
"github.com/pingcap/tidb/pkg/parser/model"
"github.com/pingcap/tidb/pkg/parser/mysql"
"github.com/pingcap/tidb/pkg/sessionctx/stmtctx"
"github.com/pingcap/tidb/pkg/sessionctx/variable"
"github.com/pingcap/tidb/pkg/store/mockstore"
"github.com/pingcap/tidb/pkg/types"
Expand Down Expand Up @@ -196,7 +195,7 @@ func TestStatWorkRecoverFromPanic(t *testing.T) {
require.Equal(t, expiredTimeStamp, ts)

// set expiredTimeStamp4PC to "2023-08-02 12:15:00"
ts, _ = types.ParseTimestamp(stmtctx.NewStmtCtxWithTimeZone(time.UTC), "2023-08-02 12:15:00")
ts, _ = types.ParseTimestamp(types.DefaultStmtNoWarningContext, "2023-08-02 12:15:00")
dom.SetExpiredTimeStamp4PC(ts)
expiredTimeStamp = dom.ExpiredTimeStamp4PC()
require.Equal(t, expiredTimeStamp, ts)
Expand Down
1 change: 0 additions & 1 deletion pkg/executor/aggfuncs/BUILD.bazel
Original file line number Diff line number Diff line change
Expand Up @@ -97,7 +97,6 @@ go_test(
"//pkg/parser/mysql",
"//pkg/planner/util",
"//pkg/sessionctx",
"//pkg/sessionctx/stmtctx",
"//pkg/sessionctx/variable",
"//pkg/testkit",
"//pkg/testkit/testsetup",
Expand Down
3 changes: 1 addition & 2 deletions pkg/executor/aggfuncs/func_count_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,6 @@ import (
"github.com/pingcap/tidb/pkg/executor/aggfuncs"
"github.com/pingcap/tidb/pkg/parser/ast"
"github.com/pingcap/tidb/pkg/parser/mysql"
"github.com/pingcap/tidb/pkg/sessionctx/stmtctx"
"github.com/pingcap/tidb/pkg/types"
"github.com/pingcap/tidb/pkg/util/hack"
"github.com/pingcap/tidb/pkg/util/mock"
Expand Down Expand Up @@ -158,7 +157,7 @@ func TestMemCount(t *testing.T) {
}

func TestWriteTime(t *testing.T) {
tt, err := types.ParseDate(stmtctx.NewStmtCtx(), "2020-11-11")
tt, err := types.ParseDate(types.DefaultStmtNoWarningContext, "2020-11-11")
require.NoError(t, err)

buf := make([]byte, 16)
Expand Down
6 changes: 2 additions & 4 deletions pkg/executor/executor.go
Original file line number Diff line number Diff line change
Expand Up @@ -2107,14 +2107,12 @@ func ResetContextOfStmt(ctx sessionctx.Context, s ast.StmtNode) (err error) {
vars.SQLMode.HasAllowInvalidDatesMode()))
case *ast.CreateTableStmt, *ast.AlterTableStmt:
sc.InCreateOrAlterStmt = true
sc.SetTypeFlags(
sc.TypeFlags().
WithIgnoreZeroDateErr(!vars.SQLMode.HasNoZeroDateMode()))
sc.SetTypeFlags(sc.TypeFlags().
WithTruncateAsWarning(!vars.StrictSQLMode).
WithIgnoreInvalidDateErr(vars.SQLMode.HasAllowInvalidDatesMode()).
WithIgnoreZeroInDate(!vars.SQLMode.HasNoZeroInDateMode() || !vars.StrictSQLMode ||
vars.SQLMode.HasAllowInvalidDatesMode()))
vars.SQLMode.HasAllowInvalidDatesMode()).
WithIgnoreZeroDateErr(!vars.SQLMode.HasNoZeroDateMode()))

case *ast.LoadDataStmt:
sc.InLoadDataStmt = true
Expand Down
10 changes: 5 additions & 5 deletions pkg/executor/inspection_result_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -179,7 +179,7 @@ func TestInspectionResult(t *testing.T) {
}

func parseTime(t *testing.T, se session.Session, str string) types.Time {
time, err := types.ParseTime(se.GetSessionVars().StmtCtx, str, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(se.GetSessionVars().StmtCtx.TypeCtx(), str, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down Expand Up @@ -338,7 +338,7 @@ func TestThresholdCheckInspection2(t *testing.T) {
tk := testkit.NewTestKit(t, store)
tk.MustExec("use test")
datetime := func(s string) types.Time {
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx, s, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), s, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down Expand Up @@ -421,7 +421,7 @@ func TestThresholdCheckInspection3(t *testing.T) {
tk := testkit.NewTestKit(t, store)
tk.MustExec("use test")
datetime := func(s string) types.Time {
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx, s, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), s, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down Expand Up @@ -628,7 +628,7 @@ func TestNodeLoadInspection(t *testing.T) {
tk := testkit.NewTestKit(t, store)
tk.MustExec("use test")
datetime := func(s string) types.Time {
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx, s, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), s, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down Expand Up @@ -704,7 +704,7 @@ func TestConfigCheckOfStorageBlockCacheSize(t *testing.T) {
tk := testkit.NewTestKit(t, store)
tk.MustExec("use test")
datetime := func(s string) types.Time {
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx, s, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), s, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down
2 changes: 1 addition & 1 deletion pkg/executor/inspection_summary_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -51,7 +51,7 @@ func TestInspectionSummary(t *testing.T) {
defer func() { require.NoError(t, failpoint.Disable(fpName)) }()

datetime := func(s string) types.Time {
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx, s, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), s, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -87,7 +87,7 @@ func TestCalibrateResource(t *testing.T) {
}()

datetime := func(s string) types.Time {
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx, s, mysql.TypeDatetime, types.MaxFsp, nil)
time, err := types.ParseTime(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), s, mysql.TypeDatetime, types.MaxFsp, nil)
require.NoError(t, err)
return time
}
Expand Down
12 changes: 6 additions & 6 deletions pkg/executor/test/executor/executor_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -2670,23 +2670,23 @@ func TestAdminShowDDLJobs(t *testing.T) {
tk.MustExec(`set @@time_zone = 'Asia/Shanghai'`)
re = tk.MustQuery("admin show ddl jobs where end_time is not NULL")
row = re.Rows()[0]
createTime, err := types.ParseDatetime(nil, row[8].(string))
createTime, err := types.ParseDatetime(types.DefaultStmtNoWarningContext, row[8].(string))
require.NoError(t, err)
startTime, err := types.ParseDatetime(nil, row[9].(string))
startTime, err := types.ParseDatetime(types.DefaultStmtNoWarningContext, row[9].(string))
require.NoError(t, err)
endTime, err := types.ParseDatetime(nil, row[10].(string))
endTime, err := types.ParseDatetime(types.DefaultStmtNoWarningContext, row[10].(string))
require.NoError(t, err)
tk.MustExec(`set @@time_zone = 'Europe/Amsterdam'`)
re = tk.MustQuery("admin show ddl jobs where end_time is not NULL")
row2 := re.Rows()[0]
require.NotEqual(t, row[8], row2[8])
require.NotEqual(t, row[9], row2[9])
require.NotEqual(t, row[10], row2[10])
createTime2, err := types.ParseDatetime(nil, row2[8].(string))
createTime2, err := types.ParseDatetime(types.DefaultStmtNoWarningContext, row2[8].(string))
require.NoError(t, err)
startTime2, err := types.ParseDatetime(nil, row2[9].(string))
startTime2, err := types.ParseDatetime(types.DefaultStmtNoWarningContext, row2[9].(string))
require.NoError(t, err)
endTime2, err := types.ParseDatetime(nil, row2[10].(string))
endTime2, err := types.ParseDatetime(types.DefaultStmtNoWarningContext, row2[10].(string))
require.NoError(t, err)
loc, err := time.LoadLocation("Asia/Shanghai")
require.NoError(t, err)
Expand Down
2 changes: 1 addition & 1 deletion pkg/expression/builtin_other_vec_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ import (
)

func dateTimeFromString(s string) types.Time {
t, err := types.ParseDate(nil, s)
t, err := types.ParseDate(types.DefaultStmtNoWarningContext, s)
if err != nil {
panic(err)
}
Expand Down
35 changes: 17 additions & 18 deletions pkg/expression/builtin_time_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -421,7 +421,7 @@ func TestDate(t *testing.T) {
func TestMonthName(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
cases := []struct {
args interface{}
expected string
Expand Down Expand Up @@ -457,7 +457,7 @@ func TestMonthName(t *testing.T) {
func TestDayName(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
cases := []struct {
args interface{}
expected string
Expand Down Expand Up @@ -495,7 +495,7 @@ func TestDayName(t *testing.T) {
func TestDayOfWeek(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
cases := []struct {
args interface{}
expected int64
Expand Down Expand Up @@ -531,7 +531,7 @@ func TestDayOfWeek(t *testing.T) {
func TestDayOfMonth(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
cases := []struct {
args interface{}
expected int64
Expand Down Expand Up @@ -567,7 +567,7 @@ func TestDayOfMonth(t *testing.T) {
func TestDayOfYear(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
cases := []struct {
args interface{}
expected int64
Expand Down Expand Up @@ -964,7 +964,7 @@ func TestAddTimeSig(t *testing.T) {
{"-110:00:00", "1 02:00:00", "-84:00:00"},
}
for _, c := range tbl {
dur, _, err := types.ParseDuration(ctx.GetSessionVars().StmtCtx, c.Input, types.GetFsp(c.Input))
dur, _, err := types.ParseDuration(ctx.GetSessionVars().StmtCtx.TypeCtx(), c.Input, types.GetFsp(c.Input))
require.NoError(t, err)
tmpInput := types.NewDurationDatum(dur)
tmpInputDuration := types.NewStringDatum(c.InputDuration)
Expand Down Expand Up @@ -1065,7 +1065,7 @@ func TestSubTimeSig(t *testing.T) {
{"235959", "00:00:01", "23:59:58"},
}
for _, c := range tbl {
dur, _, err := types.ParseDuration(ctx.GetSessionVars().StmtCtx, c.Input, types.GetFsp(c.Input))
dur, _, err := types.ParseDuration(ctx.GetSessionVars().StmtCtx.TypeCtx(), c.Input, types.GetFsp(c.Input))
require.NoError(t, err)
tmpInput := types.NewDurationDatum(dur)
tmpInputDuration := types.NewStringDatum(c.InputDuration)
Expand Down Expand Up @@ -1613,7 +1613,7 @@ func TestDateDiff(t *testing.T) {
func TestTimeDiff(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
// Test cases from https://dev.mysql.com/doc/refman/5.7/en/date-and-time-functions.html#function_timediff
tests := []struct {
args []interface{}
Expand Down Expand Up @@ -1717,7 +1717,7 @@ func TestWeekWithoutModeSig(t *testing.T) {
func TestYearWeek(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
// Test cases from https://dev.mysql.com/doc/refman/5.7/en/date-and-time-functions.html#function_yearweek
tests := []struct {
t string
Expand Down Expand Up @@ -1781,8 +1781,7 @@ func TestTimestampDiff(t *testing.T) {
}

sc := ctx.GetSessionVars().StmtCtx
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreTruncateErr(true))
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreTruncateErr(true).WithIgnoreZeroInDate(true))
resetStmtContext(ctx)
f, err := fc.getFunction(ctx, datumsToConstants([]types.Datum{types.NewStringDatum("DAY"),
types.NewStringDatum("2017-01-00"),
Expand Down Expand Up @@ -1843,7 +1842,7 @@ func TestUnixTimestamp(t *testing.T) {

// Set the time_zone variable, because UnixTimestamp() result depends on it.
ctx.GetSessionVars().TimeZone = time.UTC
ctx.GetSessionVars().StmtCtx.IgnoreZeroInDate = true
ctx.GetSessionVars().StmtCtx.SetTypeFlags(ctx.GetSessionVars().StmtCtx.TypeFlags().WithIgnoreZeroInDate(true))
tests := []struct {
inputDecimal int
input types.Datum
Expand Down Expand Up @@ -2161,7 +2160,7 @@ func TestDateArithFuncs(t *testing.T) {
},
}
for _, tt := range testDurations {
dur, _, ok, err := types.StrToDuration(nil, tt.dur, tt.fsp)
dur, _, ok, err := types.StrToDuration(types.DefaultStmtNoWarningContext, tt.dur, tt.fsp)
require.NoError(t, err)
require.True(t, ok)
args = types.MakeDatums(dur, tt.format, tt.unit)
Expand Down Expand Up @@ -2400,7 +2399,7 @@ func TestMakeTime(t *testing.T) {
func TestQuarter(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
tests := []struct {
t string
expect int64
Expand Down Expand Up @@ -2479,7 +2478,7 @@ func TestGetFormat(t *testing.T) {
func TestToSeconds(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
tests := []struct {
param interface{}
expect int64
Expand Down Expand Up @@ -2522,7 +2521,7 @@ func TestToSeconds(t *testing.T) {
func TestToDays(t *testing.T) {
ctx := createContext(t)
sc := ctx.GetSessionVars().StmtCtx
sc.IgnoreZeroInDate = true
sc.SetTypeFlags(sc.TypeFlags().WithIgnoreZeroInDate(true))
tests := []struct {
param interface{}
expect int64
Expand Down Expand Up @@ -2951,7 +2950,7 @@ func TestLastDay(t *testing.T) {
}

var timeData types.Time
timeData.StrToDate(ctx.GetSessionVars().StmtCtx, "202010", "%Y%m")
timeData.StrToDate(ctx.GetSessionVars().StmtCtx.TypeCtx(), "202010", "%Y%m")
testsNull := []struct {
param interface{}
isNilNoZeroDate bool
Expand Down Expand Up @@ -2996,7 +2995,7 @@ func TestWithTimeZone(t *testing.T) {
return result
}
durationToGoTime := func(d types.Datum, loc *time.Location) time.Time {
t, _ := d.GetMysqlDuration().ConvertToTime(sv.StmtCtx, mysql.TypeDatetime)
t, _ := d.GetMysqlDuration().ConvertToTime(sv.StmtCtx.TypeCtx(), mysql.TypeDatetime)
result, _ := t.GoTime(sv.TimeZone)
return result
}
Expand Down
6 changes: 3 additions & 3 deletions pkg/expression/builtin_vectorized_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -279,7 +279,7 @@ func (p *mockBuiltinDouble) vecEvalTime(input *chunk.Chunk, result *chunk.Column
if err != nil {
return err
}
if ts[i], err = ts[i].Add(p.ctx.GetSessionVars().StmtCtx, d); err != nil {
if ts[i], err = ts[i].Add(p.ctx.GetSessionVars().StmtCtx.TypeCtx(), d); err != nil {
return err
}
}
Expand Down Expand Up @@ -371,7 +371,7 @@ func (p *mockBuiltinDouble) evalTime(row chunk.Row) (types.Time, bool, error) {
if err != nil {
return types.ZeroTime, false, err
}
v, err = v.Add(p.ctx.GetSessionVars().StmtCtx, d)
v, err = v.Add(p.ctx.GetSessionVars().StmtCtx.TypeCtx(), d)
return v, isNull, err
}

Expand Down Expand Up @@ -512,7 +512,7 @@ func checkVecEval(t *testing.T, eType types.EvalType, sel []int, result *chunk.C
tt := types.NewTime(gt, convertETType(eType), 0)
d, err := tt.ConvertToDuration()
require.NoError(t, err)
v, err := tt.Add(mock.NewContext().GetSessionVars().StmtCtx, d)
v, err := tt.Add(mock.NewContext().GetSessionVars().StmtCtx.TypeCtx(), d)
require.NoError(t, err)
require.Equal(t, 0, v.Compare(ds[i]))
}
Expand Down
2 changes: 1 addition & 1 deletion pkg/expression/distsql_builtin_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -963,7 +963,7 @@ func newDuration(dur time.Duration) types.Duration {
}

func newDateTime(t *testing.T, s string) types.Time {
tt, err := types.ParseDate(nil, s)
tt, err := types.ParseDate(types.DefaultStmtNoWarningContext, s)
require.NoError(t, err)
return tt
}
Expand Down
2 changes: 1 addition & 1 deletion pkg/planner/core/memtable_predicate_extractor_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -1815,7 +1815,7 @@ func TestExtractorInPreparedStmt(t *testing.T) {
prepared: "select * from information_schema.tidb_hot_regions_history where update_time>=?",
userVars: []interface{}{"cast('2019-10-10 10:10:10' as datetime)"},
params: []interface{}{func() types.Time {
tt, err := types.ParseTimestamp(tk.Session().GetSessionVars().StmtCtx, "2019-10-10 10:10:10")
tt, err := types.ParseTimestamp(tk.Session().GetSessionVars().StmtCtx.TypeCtx(), "2019-10-10 10:10:10")
require.NoError(t, err)
return tt
}()},
Expand Down
Loading

0 comments on commit bbf2ed9

Please sign in to comment.