sq/testh/testh.go

757 lines
22 KiB
Go
Raw Normal View History

2020-08-06 20:58:47 +03:00
// Package testh (test helper) contains functionality
// for testing.
package testh
import (
"context"
"io"
"os"
"path/filepath"
"strings"
"sync"
"testing"
"time"
2020-08-06 20:58:47 +03:00
"github.com/neilotoole/sq/drivers"
"github.com/neilotoole/sq/cli"
"github.com/neilotoole/sq/cli/buildinfo"
"github.com/neilotoole/sq/cli/config/yamlstore"
"github.com/neilotoole/sq/libsq/core/ioz"
"github.com/neilotoole/sq/libsq/core/options"
"github.com/neilotoole/sq/libsq/core/lg/lga"
"github.com/neilotoole/sq/libsq/core/lg/lgm"
"github.com/neilotoole/sq/libsq/core/lg"
"github.com/neilotoole/slogt"
"golang.org/x/exp/slog"
"github.com/neilotoole/sq/libsq/ast"
2020-08-06 20:58:47 +03:00
"github.com/neilotoole/sq/cli/config"
"github.com/neilotoole/sq/cli/output"
"github.com/neilotoole/sq/drivers/csv"
"github.com/neilotoole/sq/drivers/json"
2020-08-06 20:58:47 +03:00
"github.com/neilotoole/sq/drivers/mysql"
"github.com/neilotoole/sq/drivers/postgres"
"github.com/neilotoole/sq/drivers/sqlite3"
"github.com/neilotoole/sq/drivers/sqlserver"
"github.com/neilotoole/sq/drivers/userdriver"
"github.com/neilotoole/sq/drivers/userdriver/xmlud"
"github.com/neilotoole/sq/drivers/xlsx"
"github.com/neilotoole/sq/libsq"
"github.com/neilotoole/sq/libsq/core/cleanup"
"github.com/neilotoole/sq/libsq/core/errz"
"github.com/neilotoole/sq/libsq/core/sqlmodel"
"github.com/neilotoole/sq/libsq/core/stringz"
2020-08-06 20:58:47 +03:00
"github.com/neilotoole/sq/libsq/driver"
"github.com/neilotoole/sq/libsq/source"
"github.com/neilotoole/sq/testh/proj"
"github.com/neilotoole/sq/testh/sakila"
"github.com/neilotoole/sq/testh/testsrc"
"github.com/stretchr/testify/assert"
"github.com/stretchr/testify/require"
2020-08-06 20:58:47 +03:00
)
// defaultDBOpenTimeout is the timeout for tests to open (and ping) their DBs.
// This should be a low value, because, well, we can either connect
// or not.
const defaultDBOpenTimeout = time.Second * 5
func init() { //nolint:gochecknoinits
slogt.Default = slogt.Factory(func(w io.Writer) slog.Handler {
return slog.HandlerOptions{
Level: slog.LevelDebug,
AddSource: true,
}.NewTextHandler(w)
})
}
// Option is a functional option type used with New to
// configure the helper.
type Option func(h *Helper)
// OptLongOpen allows a longer DB open timeout, which is necessary
// for some tests. Note that DB open performs an import for file-based
// sources, so it can take some time. Usage:
//
// testh.New(t, testh.OptLongOpen())
//
// Most tests don't need this.
func OptLongOpen() Option {
return func(h *Helper) {
2023-05-26 08:02:11 +03:00
h.dbOpenTimeout = time.Second * 180
}
}
2020-08-06 20:58:47 +03:00
// Helper encapsulates a test helper session.
type Helper struct {
mu sync.Mutex
T testing.TB
Log *slog.Logger
registry *driver.Registry
files *source.Files
databases *driver.Databases
initOnce sync.Once
coll *source.Collection
2020-08-06 20:58:47 +03:00
srcCache map[string]*source.Source
2020-08-06 20:58:47 +03:00
Context context.Context
cancelFn context.CancelFunc
Cleanup *cleanup.Cleanup
dbOpenTimeout time.Duration
2020-08-06 20:58:47 +03:00
}
// New returns a new Helper. The helper's Close func will be
// automatically invoked via t.Cleanup.
func New(t testing.TB, opts ...Option) *Helper {
2020-08-06 20:58:47 +03:00
h := &Helper{
T: t,
Log: slogt.New(t),
Cleanup: cleanup.New(),
dbOpenTimeout: defaultDBOpenTimeout,
}
for _, opt := range opts {
opt(h)
2020-08-06 20:58:47 +03:00
}
ctx, cancelFn := context.WithCancel(context.Background())
h.cancelFn = cancelFn
h.Context = lg.NewContext(ctx, h.Log)
2020-08-06 20:58:47 +03:00
t.Cleanup(h.Close)
return h
}
// NewWith is a convenience wrapper for New that also returns
// a Source for handle, an open Database and the SQLDriver.
// The function will fail if handle is not the handle for a
// source whose driver implements driver.SQLDriver.
func NewWith(t testing.TB, handle string) (*Helper, *source.Source, driver.Database, driver.SQLDriver) {
th := New(t)
src := th.Source(handle)
dbase := th.Open(src)
drvr := th.SQLDriverFor(src)
return th, src, dbase, drvr
}
func (h *Helper) init() {
h.initOnce.Do(func() {
log := h.Log
h.registry = driver.NewRegistry(log)
var err error
h.files, err = source.NewFiles(h.Context)
require.NoError(h.T, err)
h.Cleanup.Add(func() {
h.T.Logf("Executing outer Files cleanup")
err := h.files.Close()
assert.NoError(h.T, err)
})
h.files.AddDriverDetectors(source.DetectMagicNumber)
h.databases = driver.NewDatabases(log, h.registry, sqlite3.NewScratchSource)
h.Cleanup.AddC(h.databases)
h.registry.AddProvider(sqlite3.Type, &sqlite3.Provider{Log: log})
h.registry.AddProvider(postgres.Type, &postgres.Provider{Log: log})
h.registry.AddProvider(sqlserver.Type, &sqlserver.Provider{Log: log})
h.registry.AddProvider(mysql.Type, &mysql.Provider{Log: log})
csvp := &csv.Provider{Log: log, Scratcher: h.databases, Files: h.files}
h.registry.AddProvider(csv.TypeCSV, csvp)
h.registry.AddProvider(csv.TypeTSV, csvp)
h.files.AddDriverDetectors(csv.DetectCSV, csv.DetectTSV)
jsonp := &json.Provider{Log: log, Scratcher: h.databases, Files: h.files}
h.registry.AddProvider(json.TypeJSON, jsonp)
h.registry.AddProvider(json.TypeJSONA, jsonp)
h.registry.AddProvider(json.TypeJSONL, jsonp)
h.files.AddDriverDetectors(
json.DetectJSON(drivers.OptIngestSampleSize.Get(nil)),
json.DetectJSONA(drivers.OptIngestSampleSize.Get(nil)),
json.DetectJSONL(drivers.OptIngestSampleSize.Get(nil)),
)
h.registry.AddProvider(xlsx.Type, &xlsx.Provider{Log: log, Scratcher: h.databases, Files: h.files})
h.files.AddDriverDetectors(xlsx.DetectXLSX)
h.addUserDrivers()
})
}
2020-08-06 20:58:47 +03:00
// Close runs any cleanup tasks, failing h's testing.T if any cleanup
// error occurs. Close is automatically invoked via t.Cleanup, it does
// not need to be explicitly invoked unless desired.
func (h *Helper) Close() {
err := h.Cleanup.Run()
lg.WarnIfError(h.Log, "helper cleanup", err)
2020-08-06 20:58:47 +03:00
assert.NoError(h.T, err)
h.cancelFn()
}
// Source returns a test Source with the given handle. The source
// is loaded from the sq config file at TestSourcesConfigPath. Variables
// such as ${SQ_ROOT} in the config file are expanded. The same
// instance of *source.Source will be returned for multiple invocations
// of this method on the same Helper instance.
//
// For certain file-based driver types, the returned src's Location
2020-08-06 20:58:47 +03:00
// may point to a copy of the file. This helps avoid tests dirtying
// a version-controlled data file.
//
// Any external database source (that is, any SQL source other than SQLite3)
// will have its location determined from an envar. Given a source @sakila_pg12,
// its location is derived from an envar SQ_TEST_SRC__SAKILA_PG12. If that envar
// is not set, the test calling this method will be skipped.
//
// If envar SQ_TEST_DIFFDB is true, DiffDB is run on every SQL source
// returned by Source.
2020-08-06 20:58:47 +03:00
func (h *Helper) Source(handle string) *source.Source {
h.mu.Lock()
defer h.mu.Unlock()
t := h.T
// invoke h.init to ensure that its cleanup side effects
// happen in the correct order (files get cleaned after
// databases, etc.).
h.init()
2020-08-06 20:58:47 +03:00
// If the handle refers to an external database, we will skip
// the test if the envar for the handle is not set.
if stringz.InSlice(sakila.SQLAllExternal(), handle) {
2020-08-06 20:58:47 +03:00
// Skip the test if the envar for the handle is not set
handleEnvar := "SQ_TEST_SRC__" + strings.ToUpper(strings.TrimPrefix(handle, "@"))
if envar, ok := os.LookupEnv(handleEnvar); !ok || strings.TrimSpace(envar) == "" {
h.T.Skipf("Skip test %s because envar {%s} for {%s} is not set",
2020-08-06 20:58:47 +03:00
h.T.Name(), handleEnvar, handle)
}
}
if h.coll == nil {
2020-08-06 20:58:47 +03:00
// It might be expected that we would simply use the
// collection (h.coll) to return the source, but this
2020-08-06 20:58:47 +03:00
// method also uses a cache. This is because this
// method makes a copy the data file of file-based sources
// as mentioned in the method godoc.
2023-04-22 16:37:07 +03:00
h.coll = mustLoadCollection(h.Context, t)
2020-08-06 20:58:47 +03:00
h.srcCache = map[string]*source.Source{}
}
// If it's already in the cache, return it.
src, ok := h.srcCache[handle]
if ok {
return src
}
src, err := h.coll.Get(handle)
2020-08-06 20:58:47 +03:00
require.NoError(t, err,
"source %s was not found in %s", handle, testsrc.PathSrcsConfig)
if src.Type == sqlite3.Type {
2020-08-06 20:58:47 +03:00
// This could be easily generalized for CSV/XLSX etc.
fpath, err := sqlite3.PathFromLocation(src)
2020-08-06 20:58:47 +03:00
require.NoError(t, err)
srcFile, err := os.Open(fpath)
require.NoError(t, err)
defer func() {
assert.NoError(t, srcFile.Close())
}()
2020-08-06 20:58:47 +03:00
2022-12-18 02:11:33 +03:00
destFile, err := os.CreateTemp("", "*_"+filepath.Base(src.Location))
2020-08-06 20:58:47 +03:00
require.NoError(t, err)
defer func() {
assert.NoError(t, destFile.Close())
}()
destFileName := destFile.Name()
h.Files().CleanupE(func() error {
return errz.Err(os.Remove(destFileName))
2020-08-06 20:58:47 +03:00
})
_, err = io.Copy(destFile, srcFile)
require.NoError(t, err)
src.Location = sqlite3.Prefix + destFileName
2020-08-06 20:58:47 +03:00
}
2020-08-06 20:58:47 +03:00
h.srcCache[handle] = src
// envDiffDB is the name of the envar that controls whether the testing
// diffdb mechanism is executed automatically by Helper.Source.
const envDiffDB = "SQ_TEST_DIFFDB"
if proj.BoolEnvar(envDiffDB) {
h.DiffDB(src)
}
2020-08-06 20:58:47 +03:00
return src
}
// NewCollection is a convenience function for building a
// new *source.Collection incorporating the supplied handles. See
// Helper.Source for more on the behavior.
func (h *Helper) NewCollection(handles ...string) *source.Collection {
coll := &source.Collection{}
for _, handle := range handles {
require.NoError(h.T, coll.Add(h.Source(handle)))
}
return coll
}
2020-08-06 20:58:47 +03:00
// Open opens a Database for src via h's internal Databases
// instance: thus subsequent calls to Open may return the
// same Database instance. The opened Database will be closed
// during h.Close.
func (h *Helper) Open(src *source.Source) driver.Database {
ctx, cancelFn := context.WithTimeout(h.Context, h.dbOpenTimeout)
defer cancelFn()
dbase, err := h.Databases().Open(ctx, src)
2020-08-06 20:58:47 +03:00
require.NoError(h.T, err)
require.NoError(h.T, dbase.DB().PingContext(ctx))
2020-08-06 20:58:47 +03:00
return dbase
}
// openNew opens a new Database. It is the caller's responsibility
// to close the returned Database. Unlike method Open, this method
// will always invoke the driver's Open method.
//
// Some of Helper's methods (e.g. DropTable) need to use openNew rather
// than Open, as the Database returned by Open can be closed by test code,
// potentially causing problems during Cleanup.
func (h *Helper) openNew(src *source.Source) driver.Database {
h.Log.Debug("openNew", lga.Src, src)
2020-08-06 20:58:47 +03:00
reg := h.Registry()
drvr, err := reg.DriverFor(src.Type)
require.NoError(h.T, err)
dbase, err := drvr.Open(h.Context, src)
require.NoError(h.T, err)
return dbase
}
// SQLDriverFor is a convenience method to get src's driver.SQLDriver.
func (h *Helper) SQLDriverFor(src *source.Source) driver.SQLDriver {
reg := h.Registry()
drvr, err := reg.DriverFor(src.Type)
require.NoError(h.T, err)
sqlDrvr, ok := drvr.(driver.SQLDriver)
require.True(h.T, ok,
"driver %T is not a driver.SQLDriver: ensure that the src passed to SQLDriverFor implements driver.SQLDriver",
drvr)
2020-08-06 20:58:47 +03:00
return sqlDrvr
}
// DriverFor is a convenience method to get src's driver.Driver.
func (h *Helper) DriverFor(src *source.Source) driver.Driver {
reg := h.Registry()
drvr, err := reg.DriverFor(src.Type)
require.NoError(h.T, err)
return drvr
}
// RowCount returns the result of "SELECT COUNT(*) FROM tbl",
// failing h's test on any error.
func (h *Helper) RowCount(src *source.Source, tbl string) int64 {
dbase := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, dbase)
2020-08-06 20:58:47 +03:00
query := "SELECT COUNT(*) FROM " + dbase.SQLDriver().Dialect().Enquote(tbl)
var count int64
require.NoError(h.T, dbase.DB().QueryRowContext(h.Context, query).Scan(&count))
return count
}
// CreateTable creates a new table in src, and inserts data, returning
// the number of data rows inserted. If dropAfter is true, the created
// table is dropped when t.Cleanup is run.
func (h *Helper) CreateTable(dropAfter bool, src *source.Source, tblDef *sqlmodel.TableDef,
data ...[]any,
) (affected int64) {
2020-08-06 20:58:47 +03:00
dbase := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, dbase)
2020-08-06 20:58:47 +03:00
require.NoError(h.T, dbase.SQLDriver().CreateTable(h.Context, dbase.DB(), tblDef))
h.T.Logf("Created table %s.%s", src.Handle, tblDef.Name)
if dropAfter {
h.Cleanup.Add(func() { h.DropTable(src, tblDef.Name) })
}
if len(data) == 0 {
return 0
}
return h.Insert(src, tblDef.Name, tblDef.ColNames(), data...)
}
// Insert inserts records for cols into src.tbl, returning the number of
// records inserted. Note that the records arg may be mutated by src's
// driver InsertMungeFunc.
2022-12-17 02:34:33 +03:00
func (h *Helper) Insert(src *source.Source, tbl string, cols []string, records ...[]any) (affected int64) {
if len(records) == 0 {
2020-08-06 20:58:47 +03:00
return 0
}
dbase := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, dbase)
2020-08-06 20:58:47 +03:00
drvr := dbase.SQLDriver()
conn, err := dbase.DB().Conn(h.Context)
require.NoError(h.T, err)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, conn)
batchSize := driver.MaxBatchRows(drvr, len(cols))
bi, err := driver.NewBatchInsert(h.Context, drvr, conn, tbl, cols, batchSize)
2020-08-06 20:58:47 +03:00
require.NoError(h.T, err)
for _, rec := range records {
require.NoError(h.T, bi.Munge(rec))
select {
case <-h.Context.Done():
// Should not happen
close(bi.RecordCh)
require.NoError(h.T, h.Context.Err())
case err = <-bi.ErrCh:
// Should not happen
if err != nil {
close(bi.RecordCh)
require.NoError(h.T, err)
} else {
break
}
case bi.RecordCh <- rec:
}
2020-08-06 20:58:47 +03:00
}
close(bi.RecordCh) // Indicate that we're finished writing records
err = <-bi.ErrCh // Wait for bi to complete
require.NoError(h.T, err)
h.T.Logf("Inserted %d rows to %s.%s", bi.Written(), src.Handle, tbl)
return bi.Written()
2020-08-06 20:58:47 +03:00
}
// CopyTable copies fromTable into a new table toTable. If
// toTable is empty, a table name is generated based on
// fromTable. The table name used is returned.
// If dropAfter is true, the table is dropped when t.Cleanup is run.
// If copyData is true, fromTable's data is also copied.
// Constraints (keys, defaults etc.) may not be copied.
func (h *Helper) CopyTable(dropAfter bool, src *source.Source, fromTable, toTable string, copyData bool) string {
if toTable == "" {
2020-08-13 06:22:53 +03:00
toTable = stringz.UniqTableName(fromTable)
2020-08-06 20:58:47 +03:00
}
dbase := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, dbase)
2020-08-06 20:58:47 +03:00
copied, err := dbase.SQLDriver().CopyTable(h.Context, dbase.DB(), fromTable, toTable, copyData)
require.NoError(h.T, err)
if dropAfter {
h.Cleanup.Add(func() { h.DropTable(src, toTable) })
}
h.Log.Debug("Copied table",
lga.From, source.Target(src, fromTable),
lga.To, source.Target(src, toTable),
"copy_data", copyData,
lga.Count, copied,
"drop_after", dropAfter,
)
2020-08-06 20:58:47 +03:00
return toTable
}
// DropTable drops tbl from src.
func (h *Helper) DropTable(src *source.Source, tbl string) {
dbase := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, dbase)
2020-08-06 20:58:47 +03:00
require.NoError(h.T, dbase.SQLDriver().DropTable(h.Context, dbase.DB(), tbl, true))
h.Log.Debug("Dropped table", lga.Target, source.Target(src, tbl))
2020-08-06 20:58:47 +03:00
}
// QuerySQL uses libsq.QuerySQL to execute SQL query
// against src, returning a sink to which all records have
// been written. Note that QuerySQL uses the
// same Database instance as returned by h.Open.
2022-12-17 02:34:33 +03:00
func (h *Helper) QuerySQL(src *source.Source, query string, args ...any) (*RecordSink, error) {
2020-08-06 20:58:47 +03:00
dbase := h.Open(src)
sink := &RecordSink{}
recw := output.NewRecordWriterAdapter(h.Context, sink)
err := libsq.QuerySQL(h.Context, dbase, recw, query, args...)
2020-08-06 20:58:47 +03:00
if err != nil {
return nil, err
}
_, err = recw.Wait()
if err != nil {
return nil, err
}
return sink, nil
}
// QuerySLQ executes the SLQ query. Args are predefined variables for
// substitution.
func (h *Helper) QuerySLQ(query string, args map[string]string) (*RecordSink, error) {
// We need to ensure that each of the handles in the query is loaded.
a, err := ast.Parse(h.Log, query)
require.NoError(h.T, err)
for _, handle := range ast.NewInspector(a).FindHandles() {
// This triggers handle loading
_ = h.Source(handle)
}
qc := &libsq.QueryContext{
Collection: h.coll,
DBOpener: h.databases,
JoinDBOpener: h.databases,
Args: args,
}
sink := &RecordSink{}
recw := output.NewRecordWriterAdapter(h.Context, sink)
err = libsq.ExecuteSLQ(h.Context, qc, query, recw)
if err != nil {
return nil, err
}
if _, err = recw.Wait(); err != nil {
return nil, err
}
return sink, nil
}
2020-08-06 20:58:47 +03:00
// ExecSQL is a convenience wrapper for sql.DB.Exec that returns the
// rows affected, failing on any error. Note that ExecSQL uses the
// same Database instance as returned by h.Open.
2022-12-17 02:34:33 +03:00
func (h *Helper) ExecSQL(src *source.Source, query string, args ...any) (affected int64) {
2020-08-06 20:58:47 +03:00
dbase := h.Open(src)
res, err := dbase.DB().ExecContext(h.Context, query, args...)
require.NoError(h.T, err)
affected, err = res.RowsAffected()
require.NoError(h.T, err)
return affected
}
// InsertDefaultRow executes the equivalent
// of INSERT INTO tbl DEFAULT VALUES.
// It fails if a row was not inserted.
//
// Note that for some driver types, the driver does not
// support DEFAULT values for some col types. For example
// this method may fail for a MySQL column "col_text TEXT NOT NULL",
// as TEXT and BLOB cannot have a DEFAULT value.
func (h *Helper) InsertDefaultRow(src *source.Source, tbl string) {
drvr := h.SQLDriverFor(src)
var query string
if src.Type == mysql.Type {
// One driver had to be different...
// We could push this mysql-specific logic down to the driver impl
// but prob not worth the effort just for one driver.
query = "INSERT INTO " + drvr.Dialect().Enquote(tbl) + " () VALUES ()"
} else {
query = "INSERT INTO " + drvr.Dialect().Enquote(tbl) + " DEFAULT VALUES"
}
affected := h.ExecSQL(src, query)
require.Equal(h.T, int64(1), affected)
}
// TruncateTable truncates tbl in src.
func (h *Helper) TruncateTable(src *source.Source, tbl string) (affected int64) {
dbase := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, dbase)
2020-08-06 20:58:47 +03:00
affected, err := h.DriverFor(src).Truncate(h.Context, src, tbl, true)
require.NoError(h.T, err)
return affected
}
// Registry returns the helper's registry instance,
// configured with standard providers.
2020-08-06 20:58:47 +03:00
func (h *Helper) Registry() *driver.Registry {
h.init()
return h.registry
2020-08-06 20:58:47 +03:00
}
// addUserDrivers adds some user drivers to the registry.
func (h *Helper) addUserDrivers() {
userDriverDefs := DriverDefsFrom(h.T, testsrc.PathDriverDefPpl, testsrc.PathDriverDefRSS)
// One day we may have more supported user driver genres.
userDriverImporters := map[string]userdriver.ImportFunc{
xmlud.Genre: xmlud.Import,
}
for _, userDriverDef := range userDriverDefs {
userDriverDef := userDriverDef
errs := userdriver.ValidateDriverDef(userDriverDef)
require.Empty(h.T, errs)
importFn, ok := userDriverImporters[userDriverDef.Genre]
require.True(h.T, ok, "unsupported genre {%s} for user driver {%s} specified via config",
2020-08-06 20:58:47 +03:00
userDriverDef.Genre, userDriverDef.Name)
// For each user driver definition, we register a
// distinct userdriver.Provider instance.
udp := &userdriver.Provider{
Log: h.Log,
DriverDef: userDriverDef,
ImportFn: importFn,
Scratcher: h.databases,
2020-08-06 20:58:47 +03:00
Files: h.files,
}
h.registry.AddProvider(source.DriverType(userDriverDef.Name), udp)
h.files.AddDriverDetectors(udp.Detectors()...)
2020-08-06 20:58:47 +03:00
}
}
// IsMonotable returns true if src's driver is monotable.
func (h *Helper) IsMonotable(src *source.Source) bool {
return h.DriverFor(src).DriverMetadata().Monotable
}
// Databases returns the helper's Databases instance.
func (h *Helper) Databases() *driver.Databases {
h.init()
return h.databases
2020-08-06 20:58:47 +03:00
}
// Files returns the helper's Files instance.
func (h *Helper) Files() *source.Files {
h.init()
2020-08-06 20:58:47 +03:00
return h.files
}
// DiffDB fails the test if src's metadata is substantially different
// when t.Cleanup runs vs when DiffDB is invoked. Effectively DiffDB
2020-08-06 20:58:47 +03:00
// takes before and after snapshots of src's metadata, and compares
// various elements such as the number of tables, table row counts, etc.
// DiffDB is useful for verifying that tests are leaving the database
2020-08-06 20:58:47 +03:00
// as they found it.
//
// Note that DiffDB adds considerable overhead to test runtime.
//
// If envar SQ_TEST_DIFFDB is true, DiffDB is run on every SQL source
// returned by Helper.Source.
func (h *Helper) DiffDB(src *source.Source) {
if !h.DriverFor(src).DriverMetadata().IsSQL {
// SkipDiffDB for non-SQL driver types
return
}
2020-08-06 20:58:47 +03:00
h.T.Logf("Executing DiffDB for %s", src.Handle)
beforeDB := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, beforeDB)
2020-08-06 20:58:47 +03:00
beforeMeta, err := beforeDB.SourceMetadata(h.Context)
2020-08-06 20:58:47 +03:00
require.NoError(h.T, err)
h.Cleanup.Add(func() {
// Currently DiffDB just checks if the tables and each
2020-08-06 20:58:47 +03:00
// table's row count match.
afterDB := h.openNew(src)
defer lg.WarnIfCloseError(h.Log, lgm.CloseDB, afterDB)
2020-08-06 20:58:47 +03:00
afterMeta, err := afterDB.SourceMetadata(h.Context)
2020-08-06 20:58:47 +03:00
require.NoError(h.T, err)
require.Equal(h.T, beforeMeta.TableNames(), afterMeta.TableNames(),
"diffdb: should have the same set of tables before and after")
2020-08-06 20:58:47 +03:00
for i, beforeTbl := range beforeMeta.Tables {
assert.Equal(h.T, beforeTbl.RowCount, afterMeta.Tables[i].RowCount,
"diffdb: %s: row count for {%s} is expected to be %d but got %d", src.Handle, beforeTbl.Name,
beforeTbl.RowCount, afterMeta.Tables[i].RowCount)
2020-08-06 20:58:47 +03:00
}
})
}
2023-04-22 16:37:07 +03:00
func mustLoadCollection(ctx context.Context, t testing.TB) *source.Collection {
2020-08-06 20:58:47 +03:00
hookExpand := func(data []byte) ([]byte, error) {
// expand vars such as "${SQ_ROOT}"
return []byte(proj.Expand(string(data))), nil
}
fs := &yamlstore.Store{
Path: proj.Rel(testsrc.PathSrcsConfig),
OptionsRegistry: &options.Registry{},
HookLoad: hookExpand,
}
cli.RegisterDefaultOpts(fs.OptionsRegistry)
cfg, err := fs.Load(ctx)
2020-08-06 20:58:47 +03:00
require.NoError(t, err)
require.NotNil(t, cfg)
require.NotNil(t, cfg.Collection)
2020-08-06 20:58:47 +03:00
return cfg.Collection
2020-08-06 20:58:47 +03:00
}
// DriverDefsFrom builds DriverDef values from cfg files.
func DriverDefsFrom(t testing.TB, cfgFiles ...string) []*userdriver.DriverDef {
var userDriverDefs []*userdriver.DriverDef
for _, f := range cfgFiles {
ext := &config.Ext{}
require.NoError(t, ioz.UnmarshallYAML(proj.ReadFile(f), ext))
2020-08-06 20:58:47 +03:00
userDriverDefs = append(userDriverDefs, ext.UserDrivers...)
}
return userDriverDefs
}
// DriverDetectors returns the common set of TypeDetectorFuncs.
func DriverDetectors() []source.DriverDetectFunc {
return []source.DriverDetectFunc{
source.DetectMagicNumber,
xlsx.DetectXLSX,
csv.DetectCSV, csv.DetectTSV,
/*json.DetectJSON,*/ json.DetectJSONA(1000), json.DetectJSONL(1000), // FIXME: enable DetectJSON when it's ready
}
2020-08-06 20:58:47 +03:00
}
// SetBuildVersion sets the build version for the lifecycle
// of test t.
func SetBuildVersion(t testing.TB, vers string) {
prevVers := buildinfo.Version
t.Setenv(buildinfo.EnvOverrideVersion, vers)
buildinfo.Version = vers
t.Cleanup(func() {
buildinfo.Version = prevVers
})
}