123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357 |
- package redis_test
- import (
- "errors"
- "fmt"
- "net"
- "os"
- "os/exec"
- "path/filepath"
- "sync"
- "sync/atomic"
- "testing"
- "time"
- "github.com/go-redis/redis"
- . "github.com/onsi/ginkgo"
- . "github.com/onsi/gomega"
- )
- const (
- redisPort = "6380"
- redisAddr = ":" + redisPort
- redisSecondaryPort = "6381"
- )
- const (
- ringShard1Port = "6390"
- ringShard2Port = "6391"
- )
- const (
- sentinelName = "mymaster"
- sentinelMasterPort = "8123"
- sentinelSlave1Port = "8124"
- sentinelSlave2Port = "8125"
- sentinelPort = "8126"
- )
- var (
- redisMain *redisProcess
- ringShard1, ringShard2 *redisProcess
- sentinelMaster, sentinelSlave1, sentinelSlave2, sentinel *redisProcess
- )
- var cluster = &clusterScenario{
- ports: []string{"8220", "8221", "8222", "8223", "8224", "8225"},
- nodeIds: make([]string, 6),
- processes: make(map[string]*redisProcess, 6),
- clients: make(map[string]*redis.Client, 6),
- }
- var _ = BeforeSuite(func() {
- var err error
- redisMain, err = startRedis(redisPort)
- Expect(err).NotTo(HaveOccurred())
- ringShard1, err = startRedis(ringShard1Port)
- Expect(err).NotTo(HaveOccurred())
- ringShard2, err = startRedis(ringShard2Port)
- Expect(err).NotTo(HaveOccurred())
- sentinelMaster, err = startRedis(sentinelMasterPort)
- Expect(err).NotTo(HaveOccurred())
- sentinel, err = startSentinel(sentinelPort, sentinelName, sentinelMasterPort)
- Expect(err).NotTo(HaveOccurred())
- sentinelSlave1, err = startRedis(
- sentinelSlave1Port, "--slaveof", "127.0.0.1", sentinelMasterPort)
- Expect(err).NotTo(HaveOccurred())
- sentinelSlave2, err = startRedis(
- sentinelSlave2Port, "--slaveof", "127.0.0.1", sentinelMasterPort)
- Expect(err).NotTo(HaveOccurred())
- Expect(startCluster(cluster)).NotTo(HaveOccurred())
- })
- var _ = AfterSuite(func() {
- Expect(redisMain.Close()).NotTo(HaveOccurred())
- Expect(ringShard1.Close()).NotTo(HaveOccurred())
- Expect(ringShard2.Close()).NotTo(HaveOccurred())
- Expect(sentinel.Close()).NotTo(HaveOccurred())
- Expect(sentinelSlave1.Close()).NotTo(HaveOccurred())
- Expect(sentinelSlave2.Close()).NotTo(HaveOccurred())
- Expect(sentinelMaster.Close()).NotTo(HaveOccurred())
- Expect(stopCluster(cluster)).NotTo(HaveOccurred())
- })
- func TestGinkgoSuite(t *testing.T) {
- RegisterFailHandler(Fail)
- RunSpecs(t, "go-redis")
- }
- //------------------------------------------------------------------------------
- func redisOptions() *redis.Options {
- return &redis.Options{
- Addr: redisAddr,
- DB: 15,
- DialTimeout: 10 * time.Second,
- ReadTimeout: 30 * time.Second,
- WriteTimeout: 30 * time.Second,
- PoolSize: 10,
- PoolTimeout: 30 * time.Second,
- IdleTimeout: 500 * time.Millisecond,
- IdleCheckFrequency: 500 * time.Millisecond,
- }
- }
- func redisClusterOptions() *redis.ClusterOptions {
- return &redis.ClusterOptions{
- DialTimeout: 10 * time.Second,
- ReadTimeout: 30 * time.Second,
- WriteTimeout: 30 * time.Second,
- PoolSize: 10,
- PoolTimeout: 30 * time.Second,
- IdleTimeout: 500 * time.Millisecond,
- IdleCheckFrequency: 500 * time.Millisecond,
- }
- }
- func redisRingOptions() *redis.RingOptions {
- return &redis.RingOptions{
- Addrs: map[string]string{
- "ringShardOne": ":" + ringShard1Port,
- "ringShardTwo": ":" + ringShard2Port,
- },
- DialTimeout: 10 * time.Second,
- ReadTimeout: 30 * time.Second,
- WriteTimeout: 30 * time.Second,
- PoolSize: 10,
- PoolTimeout: 30 * time.Second,
- IdleTimeout: 500 * time.Millisecond,
- IdleCheckFrequency: 500 * time.Millisecond,
- }
- }
- func performAsync(n int, cbs ...func(int)) *sync.WaitGroup {
- var wg sync.WaitGroup
- for _, cb := range cbs {
- for i := 0; i < n; i++ {
- wg.Add(1)
- go func(cb func(int), i int) {
- defer GinkgoRecover()
- defer wg.Done()
- cb(i)
- }(cb, i)
- }
- }
- return &wg
- }
- func perform(n int, cbs ...func(int)) {
- wg := performAsync(n, cbs...)
- wg.Wait()
- }
- func eventually(fn func() error, timeout time.Duration) error {
- var exit int32
- errCh := make(chan error)
- done := make(chan struct{})
- go func() {
- defer GinkgoRecover()
- for atomic.LoadInt32(&exit) == 0 {
- err := fn()
- if err == nil {
- close(done)
- return
- }
- select {
- case errCh <- err:
- default:
- }
- time.Sleep(timeout / 100)
- }
- }()
- select {
- case <-done:
- return nil
- case <-time.After(timeout):
- atomic.StoreInt32(&exit, 1)
- select {
- case err := <-errCh:
- return err
- default:
- return fmt.Errorf("timeout after %s", timeout)
- }
- }
- }
- func execCmd(name string, args ...string) (*os.Process, error) {
- cmd := exec.Command(name, args...)
- if testing.Verbose() {
- cmd.Stdout = os.Stdout
- cmd.Stderr = os.Stderr
- }
- return cmd.Process, cmd.Start()
- }
- func connectTo(port string) (*redis.Client, error) {
- client := redis.NewClient(&redis.Options{
- Addr: ":" + port,
- })
- err := eventually(func() error {
- return client.Ping().Err()
- }, 30*time.Second)
- if err != nil {
- return nil, err
- }
- return client, nil
- }
- type redisProcess struct {
- *os.Process
- *redis.Client
- }
- func (p *redisProcess) Close() error {
- if err := p.Kill(); err != nil {
- return err
- }
- err := eventually(func() error {
- if err := p.Client.Ping().Err(); err != nil {
- return nil
- }
- return errors.New("client is not shutdown")
- }, 10*time.Second)
- if err != nil {
- return err
- }
- p.Client.Close()
- return nil
- }
- var (
- redisServerBin, _ = filepath.Abs(filepath.Join("testdata", "redis", "src", "redis-server"))
- redisServerConf, _ = filepath.Abs(filepath.Join("testdata", "redis.conf"))
- )
- func redisDir(port string) (string, error) {
- dir, err := filepath.Abs(filepath.Join("testdata", "instances", port))
- if err != nil {
- return "", err
- }
- if err := os.RemoveAll(dir); err != nil {
- return "", err
- }
- if err := os.MkdirAll(dir, 0775); err != nil {
- return "", err
- }
- return dir, nil
- }
- func startRedis(port string, args ...string) (*redisProcess, error) {
- dir, err := redisDir(port)
- if err != nil {
- return nil, err
- }
- if err = exec.Command("cp", "-f", redisServerConf, dir).Run(); err != nil {
- return nil, err
- }
- baseArgs := []string{filepath.Join(dir, "redis.conf"), "--port", port, "--dir", dir}
- process, err := execCmd(redisServerBin, append(baseArgs, args...)...)
- if err != nil {
- return nil, err
- }
- client, err := connectTo(port)
- if err != nil {
- process.Kill()
- return nil, err
- }
- return &redisProcess{process, client}, err
- }
- func startSentinel(port, masterName, masterPort string) (*redisProcess, error) {
- dir, err := redisDir(port)
- if err != nil {
- return nil, err
- }
- process, err := execCmd(redisServerBin, os.DevNull, "--sentinel", "--port", port, "--dir", dir)
- if err != nil {
- return nil, err
- }
- client, err := connectTo(port)
- if err != nil {
- process.Kill()
- return nil, err
- }
- for _, cmd := range []*redis.StatusCmd{
- redis.NewStatusCmd("SENTINEL", "MONITOR", masterName, "127.0.0.1", masterPort, "1"),
- redis.NewStatusCmd("SENTINEL", "SET", masterName, "down-after-milliseconds", "500"),
- redis.NewStatusCmd("SENTINEL", "SET", masterName, "failover-timeout", "1000"),
- redis.NewStatusCmd("SENTINEL", "SET", masterName, "parallel-syncs", "1"),
- } {
- client.Process(cmd)
- if err := cmd.Err(); err != nil {
- process.Kill()
- return nil, err
- }
- }
- return &redisProcess{process, client}, nil
- }
- //------------------------------------------------------------------------------
- type badConnError string
- func (e badConnError) Error() string { return string(e) }
- func (e badConnError) Timeout() bool { return false }
- func (e badConnError) Temporary() bool { return false }
- type badConn struct {
- net.TCPConn
- readDelay, writeDelay time.Duration
- readErr, writeErr error
- }
- var _ net.Conn = &badConn{}
- func (cn *badConn) Read([]byte) (int, error) {
- if cn.readDelay != 0 {
- time.Sleep(cn.readDelay)
- }
- if cn.readErr != nil {
- return 0, cn.readErr
- }
- return 0, badConnError("bad connection")
- }
- func (cn *badConn) Write([]byte) (int, error) {
- if cn.writeDelay != 0 {
- time.Sleep(cn.writeDelay)
- }
- if cn.writeErr != nil {
- return 0, cn.writeErr
- }
- return 0, badConnError("bad connection")
- }
|