summaryrefslogtreecommitdiff
path: root/tests/plugins/informer
diff options
context:
space:
mode:
Diffstat (limited to 'tests/plugins/informer')
-rw-r--r--tests/plugins/informer/.rr-informer.yaml15
-rw-r--r--tests/plugins/informer/informer_test.go136
-rw-r--r--tests/plugins/informer/test_plugin.go71
3 files changed, 0 insertions, 222 deletions
diff --git a/tests/plugins/informer/.rr-informer.yaml b/tests/plugins/informer/.rr-informer.yaml
deleted file mode 100644
index 94c9a856..00000000
--- a/tests/plugins/informer/.rr-informer.yaml
+++ /dev/null
@@ -1,15 +0,0 @@
-server:
- command: "php ../../http/client.php echo pipes"
- user: ""
- group: ""
- env:
- - RR_CONFIG: "/some/place/on/the/C134"
- - RR_CONFIG: "C138"
- relay: "pipes"
- relay_timeout: "20s"
-
-rpc:
- listen: tcp://127.0.0.1:6001
-logs:
- mode: development
- level: error
diff --git a/tests/plugins/informer/informer_test.go b/tests/plugins/informer/informer_test.go
deleted file mode 100644
index c3b5c6a6..00000000
--- a/tests/plugins/informer/informer_test.go
+++ /dev/null
@@ -1,136 +0,0 @@
-package informer
-
-import (
- "net"
- "net/rpc"
- "os"
- "os/signal"
- "sync"
- "syscall"
- "testing"
- "time"
-
- endure "github.com/spiral/endure/pkg/container"
- goridgeRpc "github.com/spiral/goridge/v3/pkg/rpc"
- "github.com/spiral/roadrunner/v2/pkg/state/process"
- "github.com/spiral/roadrunner/v2/plugins/config"
- "github.com/spiral/roadrunner/v2/plugins/informer"
- "github.com/spiral/roadrunner/v2/plugins/logger"
- rpcPlugin "github.com/spiral/roadrunner/v2/plugins/rpc"
- "github.com/spiral/roadrunner/v2/plugins/server"
- "github.com/stretchr/testify/assert"
-)
-
-func TestInformerInit(t *testing.T) {
- cont, err := endure.NewContainer(nil, endure.SetLogLevel(endure.ErrorLevel))
- if err != nil {
- t.Fatal(err)
- }
-
- cfg := &config.Viper{
- Path: ".rr-informer.yaml",
- Prefix: "rr",
- }
-
- err = cont.RegisterAll(
- cfg,
- &server.Plugin{},
- &logger.ZapLogger{},
- &informer.Plugin{},
- &rpcPlugin.Plugin{},
- &Plugin1{},
- )
- assert.NoError(t, err)
-
- err = cont.Init()
- if err != nil {
- t.Fatal(err)
- }
-
- ch, err := cont.Serve()
- assert.NoError(t, err)
-
- sig := make(chan os.Signal, 1)
- signal.Notify(sig, os.Interrupt, syscall.SIGINT, syscall.SIGTERM)
-
- stopCh := make(chan struct{}, 1)
-
- wg := &sync.WaitGroup{}
- wg.Add(1)
-
- go func() {
- defer wg.Done()
- for {
- select {
- case e := <-ch:
- assert.Fail(t, "error", e.Error.Error())
- return
- case <-sig:
- err = cont.Stop()
- if err != nil {
- assert.FailNow(t, "error", err.Error())
- }
- return
- case <-stopCh:
- // timeout
- err = cont.Stop()
- if err != nil {
- assert.FailNow(t, "error", err.Error())
- }
- return
- }
- }
- }()
-
- time.Sleep(time.Second)
- t.Run("InformerWorkersRpcTest", informerWorkersRPCTest)
- t.Run("InformerListRpcTest", informerListRPCTest)
- t.Run("InformerPluginWithoutWorkersRpcTest", informerPluginWOWorkersRPCTest)
-
- stopCh <- struct{}{}
- wg.Wait()
-}
-
-func informerPluginWOWorkersRPCTest(t *testing.T) {
- conn, err := net.Dial("tcp", "127.0.0.1:6001")
- assert.NoError(t, err)
- client := rpc.NewClientWithCodec(goridgeRpc.NewClientCodec(conn))
- // WorkerList contains list of workers.
- list := struct {
- // Workers is list of workers.
- Workers []process.State `json:"workers"`
- }{}
-
- err = client.Call("informer.Workers", "informer.config", &list)
- assert.NoError(t, err)
- assert.Len(t, list.Workers, 0)
-}
-
-func informerWorkersRPCTest(t *testing.T) {
- conn, err := net.Dial("tcp", "127.0.0.1:6001")
- assert.NoError(t, err)
- client := rpc.NewClientWithCodec(goridgeRpc.NewClientCodec(conn))
- // WorkerList contains list of workers.
- list := struct {
- // Workers is list of workers.
- Workers []process.State `json:"workers"`
- }{}
-
- err = client.Call("informer.Workers", "informer.plugin1", &list)
- assert.NoError(t, err)
- assert.Len(t, list.Workers, 10)
-}
-
-func informerListRPCTest(t *testing.T) {
- conn, err := net.Dial("tcp", "127.0.0.1:6001")
- assert.NoError(t, err)
- client := rpc.NewClientWithCodec(goridgeRpc.NewClientCodec(conn))
- // WorkerList contains list of workers.
- list := make([]string, 0, 5)
- // Plugins which are expected to be in the list
- expected := []string{"rpc", "logs", "informer.plugin1", "config", "server"}
-
- err = client.Call("informer.List", true, &list)
- assert.NoError(t, err)
- assert.ElementsMatch(t, list, expected)
-}
diff --git a/tests/plugins/informer/test_plugin.go b/tests/plugins/informer/test_plugin.go
deleted file mode 100644
index 21897f40..00000000
--- a/tests/plugins/informer/test_plugin.go
+++ /dev/null
@@ -1,71 +0,0 @@
-package informer
-
-import (
- "context"
- "time"
-
- "github.com/spiral/roadrunner/v2/pkg/pool"
- "github.com/spiral/roadrunner/v2/pkg/state/process"
- "github.com/spiral/roadrunner/v2/plugins/config"
- "github.com/spiral/roadrunner/v2/plugins/server"
-)
-
-var testPoolConfig = &pool.Config{
- NumWorkers: 10,
- MaxJobs: 100,
- AllocateTimeout: time.Second * 10,
- DestroyTimeout: time.Second * 10,
- Supervisor: &pool.SupervisorConfig{
- WatchTick: 60 * time.Second,
- TTL: 1000 * time.Second,
- IdleTTL: 10 * time.Second,
- ExecTTL: 10 * time.Second,
- MaxWorkerMemory: 1000,
- },
-}
-
-// Gauge //////////////
-type Plugin1 struct {
- config config.Configurer
- server server.Server
-}
-
-func (p1 *Plugin1) Init(cfg config.Configurer, server server.Server) error {
- p1.config = cfg
- p1.server = server
- return nil
-}
-
-func (p1 *Plugin1) Serve() chan error {
- errCh := make(chan error, 1)
- return errCh
-}
-
-func (p1 *Plugin1) Stop() error {
- return nil
-}
-
-func (p1 *Plugin1) Name() string {
- return "informer.plugin1"
-}
-
-func (p1 *Plugin1) Available() {}
-
-func (p1 *Plugin1) Workers() []*process.State {
- p, err := p1.server.NewWorkerPool(context.Background(), testPoolConfig, nil)
- if err != nil {
- panic(err)
- }
-
- ps := make([]*process.State, 0, len(p.Workers()))
- workers := p.Workers()
- for i := 0; i < len(workers); i++ {
- state, err := process.WorkerProcessState(workers[i])
- if err != nil {
- return nil
- }
- ps = append(ps, state)
- }
-
- return ps
-}