How to use Shutdown method of internal Package

Best Ginkgo code snippet using internal.Shutdown

queue_disk_channel.go

Source:queue_disk_channel.go Github

copy

Full Screen

...118 return q.channelQueue.Push(data)119 }120}121// Run starts to run the queue122func (q *PersistableChannelQueue) Run(atShutdown, atTerminate func(context.Context, func())) {123 log.Debug("PersistableChannelQueue: %s Starting", q.delayedStarter.name)124 q.lock.Lock()125 if q.internal == nil {126 err := q.setInternal(atShutdown, q.channelQueue.handle, q.channelQueue.exemplar)127 q.lock.Unlock()128 if err != nil {129 log.Fatal("Unable to create internal queue for %s Error: %v", q.Name(), err)130 return131 }132 } else {133 q.lock.Unlock()134 }135 atShutdown(context.Background(), q.Shutdown)136 atTerminate(context.Background(), q.Terminate)137 // Just run the level queue - we shut it down later138 go q.internal.Run(func(_ context.Context, _ func()) {}, func(_ context.Context, _ func()) {})139 go func() {140 _ = q.channelQueue.AddWorkers(q.channelQueue.workers, 0)141 }()142 log.Trace("PersistableChannelQueue: %s Waiting til closed", q.delayedStarter.name)143 <-q.closed144 log.Trace("PersistableChannelQueue: %s Cancelling pools", q.delayedStarter.name)145 q.channelQueue.cancel()146 q.internal.(*LevelQueue).cancel()147 log.Trace("PersistableChannelQueue: %s Waiting til done", q.delayedStarter.name)148 q.channelQueue.Wait()149 q.internal.(*LevelQueue).Wait()150 // Redirect all remaining data in the chan to the internal channel151 go func() {152 log.Trace("PersistableChannelQueue: %s Redirecting remaining data", q.delayedStarter.name)153 for data := range q.channelQueue.dataChan {154 _ = q.internal.Push(data)155 atomic.AddInt64(&q.channelQueue.numInQueue, -1)156 }157 log.Trace("PersistableChannelQueue: %s Done Redirecting remaining data", q.delayedStarter.name)158 }()159 log.Trace("PersistableChannelQueue: %s Done main loop", q.delayedStarter.name)160}161// Flush flushes the queue and blocks till the queue is empty162func (q *PersistableChannelQueue) Flush(timeout time.Duration) error {163 var ctx context.Context164 var cancel context.CancelFunc165 if timeout > 0 {166 ctx, cancel = context.WithTimeout(context.Background(), timeout)167 } else {168 ctx, cancel = context.WithCancel(context.Background())169 }170 defer cancel()171 return q.FlushWithContext(ctx)172}173// FlushWithContext flushes the queue and blocks till the queue is empty174func (q *PersistableChannelQueue) FlushWithContext(ctx context.Context) error {175 errChan := make(chan error, 1)176 go func() {177 errChan <- q.channelQueue.FlushWithContext(ctx)178 }()179 go func() {180 q.lock.Lock()181 if q.internal == nil {182 q.lock.Unlock()183 errChan <- fmt.Errorf("not ready to flush internal queue %s yet", q.Name())184 return185 }186 q.lock.Unlock()187 errChan <- q.internal.FlushWithContext(ctx)188 }()189 err1 := <-errChan190 err2 := <-errChan191 if err1 != nil {192 return err1193 }194 return err2195}196// IsEmpty checks if a queue is empty197func (q *PersistableChannelQueue) IsEmpty() bool {198 if !q.channelQueue.IsEmpty() {199 return false200 }201 q.lock.Lock()202 defer q.lock.Unlock()203 if q.internal == nil {204 return false205 }206 return q.internal.IsEmpty()207}208// Shutdown processing this queue209func (q *PersistableChannelQueue) Shutdown() {210 log.Trace("PersistableChannelQueue: %s Shutting down", q.delayedStarter.name)211 q.lock.Lock()212 defer q.lock.Unlock()213 select {214 case <-q.closed:215 default:216 if q.internal != nil {217 q.internal.(*LevelQueue).Shutdown()218 }219 close(q.closed)220 log.Debug("PersistableChannelQueue: %s Shutdown", q.delayedStarter.name)221 }222}223// Terminate this queue and close the queue224func (q *PersistableChannelQueue) Terminate() {225 log.Trace("PersistableChannelQueue: %s Terminating", q.delayedStarter.name)226 q.Shutdown()227 q.lock.Lock()228 defer q.lock.Unlock()229 if q.internal != nil {230 q.internal.(*LevelQueue).Terminate()231 }232 log.Debug("PersistableChannelQueue: %s Terminated", q.delayedStarter.name)233}234func init() {235 queuesMap[PersistableChannelQueueType] = NewPersistableChannelQueue236}...

Full Screen

Full Screen

queue_wrapped.go

Source:queue_wrapped.go Github

copy

Full Screen

...30 maxAttempts int31 name string32}33// setInternal must be called with the lock locked.34func (q *delayedStarter) setInternal(atShutdown func(context.Context, func()), handle HandlerFunc, exemplar interface{}) error {35 var ctx context.Context36 var cancel context.CancelFunc37 if q.timeout > 0 {38 ctx, cancel = context.WithTimeout(context.Background(), q.timeout)39 } else {40 ctx, cancel = context.WithCancel(context.Background())41 }42 defer cancel()43 // Ensure we also stop at shutdown44 atShutdown(ctx, func() {45 cancel()46 })47 i := 148 for q.internal == nil {49 select {50 case <-ctx.Done():51 var cfg = q.cfg52 if s, ok := cfg.([]byte); ok {53 cfg = string(s)54 }55 return fmt.Errorf("Timedout creating queue %v with cfg %#v in %s", q.underlying, cfg, q.name)56 default:57 queue, err := NewQueue(q.underlying, handle, q.cfg, exemplar)58 if err == nil {59 q.internal = queue60 break61 }62 if err.Error() != "resource temporarily unavailable" {63 if bs, ok := q.cfg.([]byte); ok {64 log.Warn("[Attempt: %d] Failed to create queue: %v for %s cfg: %s error: %v", i, q.underlying, q.name, string(bs), err)65 } else {66 log.Warn("[Attempt: %d] Failed to create queue: %v for %s cfg: %#v error: %v", i, q.underlying, q.name, q.cfg, err)67 }68 }69 i++70 if q.maxAttempts > 0 && i > q.maxAttempts {71 if bs, ok := q.cfg.([]byte); ok {72 return fmt.Errorf("Unable to create queue %v for %s with cfg %s by max attempts: error: %v", q.underlying, q.name, string(bs), err)73 }74 return fmt.Errorf("Unable to create queue %v for %s with cfg %#v by max attempts: error: %v", q.underlying, q.name, q.cfg, err)75 }76 sleepTime := 100 * time.Millisecond77 if q.timeout > 0 && q.maxAttempts > 0 {78 sleepTime = (q.timeout - 200*time.Millisecond) / time.Duration(q.maxAttempts)79 }80 t := time.NewTimer(sleepTime)81 select {82 case <-ctx.Done():83 util.StopTimer(t)84 case <-t.C:85 }86 }87 }88 return nil89}90// WrappedQueue wraps a delayed starting queue91type WrappedQueue struct {92 delayedStarter93 lock sync.Mutex94 handle HandlerFunc95 exemplar interface{}96 channel chan Data97 numInQueue int6498}99// NewWrappedQueue will attempt to create a queue of the provided type,100// but if there is a problem creating this queue it will instead create101// a WrappedQueue with delayed startup of the queue instead and a102// channel which will be redirected to the queue103func NewWrappedQueue(handle HandlerFunc, cfg, exemplar interface{}) (Queue, error) {104 configInterface, err := toConfig(WrappedQueueConfiguration{}, cfg)105 if err != nil {106 return nil, err107 }108 config := configInterface.(WrappedQueueConfiguration)109 queue, err := NewQueue(config.Underlying, handle, config.Config, exemplar)110 if err == nil {111 // Just return the queue there is no need to wrap112 return queue, nil113 }114 if IsErrInvalidConfiguration(err) {115 // Retrying ain't gonna make this any better...116 return nil, ErrInvalidConfiguration{cfg: cfg}117 }118 queue = &WrappedQueue{119 handle: handle,120 channel: make(chan Data, config.QueueLength),121 exemplar: exemplar,122 delayedStarter: delayedStarter{123 cfg: config.Config,124 underlying: config.Underlying,125 timeout: config.Timeout,126 maxAttempts: config.MaxAttempts,127 name: config.Name,128 },129 }130 _ = GetManager().Add(queue, WrappedQueueType, config, exemplar)131 return queue, nil132}133// Name returns the name of the queue134func (q *WrappedQueue) Name() string {135 return q.name + "-wrapper"136}137// Push will push the data to the internal channel checking it against the exemplar138func (q *WrappedQueue) Push(data Data) error {139 if !assignableTo(data, q.exemplar) {140 return fmt.Errorf("unable to assign data: %v to same type as exemplar: %v in %s", data, q.exemplar, q.name)141 }142 atomic.AddInt64(&q.numInQueue, 1)143 q.channel <- data144 return nil145}146func (q *WrappedQueue) flushInternalWithContext(ctx context.Context) error {147 q.lock.Lock()148 if q.internal == nil {149 q.lock.Unlock()150 return fmt.Errorf("not ready to flush wrapped queue %s yet", q.Name())151 }152 q.lock.Unlock()153 select {154 case <-ctx.Done():155 return ctx.Err()156 default:157 }158 return q.internal.FlushWithContext(ctx)159}160// Flush flushes the queue and blocks till the queue is empty161func (q *WrappedQueue) Flush(timeout time.Duration) error {162 var ctx context.Context163 var cancel context.CancelFunc164 if timeout > 0 {165 ctx, cancel = context.WithTimeout(context.Background(), timeout)166 } else {167 ctx, cancel = context.WithCancel(context.Background())168 }169 defer cancel()170 return q.FlushWithContext(ctx)171}172// FlushWithContext implements the final part of Flushable173func (q *WrappedQueue) FlushWithContext(ctx context.Context) error {174 log.Trace("WrappedQueue: %s FlushWithContext", q.Name())175 errChan := make(chan error, 1)176 go func() {177 errChan <- q.flushInternalWithContext(ctx)178 close(errChan)179 }()180 select {181 case err := <-errChan:182 return err183 case <-ctx.Done():184 go func() {185 <-errChan186 }()187 return ctx.Err()188 }189}190// IsEmpty checks whether the queue is empty191func (q *WrappedQueue) IsEmpty() bool {192 if atomic.LoadInt64(&q.numInQueue) != 0 {193 return false194 }195 q.lock.Lock()196 defer q.lock.Unlock()197 if q.internal == nil {198 return false199 }200 return q.internal.IsEmpty()201}202// Run starts to run the queue and attempts to create the internal queue203func (q *WrappedQueue) Run(atShutdown, atTerminate func(context.Context, func())) {204 log.Debug("WrappedQueue: %s Starting", q.name)205 q.lock.Lock()206 if q.internal == nil {207 err := q.setInternal(atShutdown, q.handle, q.exemplar)208 q.lock.Unlock()209 if err != nil {210 log.Fatal("Unable to set the internal queue for %s Error: %v", q.Name(), err)211 return212 }213 go func() {214 for data := range q.channel {215 _ = q.internal.Push(data)216 atomic.AddInt64(&q.numInQueue, -1)217 }218 }()219 } else {220 q.lock.Unlock()221 }222 q.internal.Run(atShutdown, atTerminate)223 log.Trace("WrappedQueue: %s Done", q.name)224}225// Shutdown this queue and stop processing226func (q *WrappedQueue) Shutdown() {227 log.Trace("WrappedQueue: %s Shutting down", q.name)228 q.lock.Lock()229 defer q.lock.Unlock()230 if q.internal == nil {231 return232 }233 if shutdownable, ok := q.internal.(Shutdownable); ok {234 shutdownable.Shutdown()235 }236 log.Debug("WrappedQueue: %s Shutdown", q.name)237}238// Terminate this queue and close the queue239func (q *WrappedQueue) Terminate() {240 log.Trace("WrappedQueue: %s Terminating", q.name)241 q.lock.Lock()242 defer q.lock.Unlock()243 if q.internal == nil {244 return245 }246 if shutdownable, ok := q.internal.(Shutdownable); ok {247 shutdownable.Terminate()248 }249 log.Debug("WrappedQueue: %s Terminated", q.name)250}251func init() {252 queuesMap[WrappedQueueType] = NewWrappedQueue253}...

Full Screen

Full Screen

manager.go

Source:manager.go Github

copy

Full Screen

...16 Name: "manager",17 Usage: "Manage the running gitea process",18 Description: "This is a command for managing the running gitea process",19 Subcommands: []cli.Command{20 subcmdShutdown,21 subcmdRestart,22 subcmdFlushQueues,23 },24 }25 subcmdShutdown = cli.Command{26 Name: "shutdown",27 Usage: "Gracefully shutdown the running process",28 Action: runShutdown,29 }30 subcmdRestart = cli.Command{31 Name: "restart",32 Usage: "Gracefully restart the running process - (not implemented for windows servers)",33 Action: runRestart,34 }35 subcmdFlushQueues = cli.Command{36 Name: "flush-queues",37 Usage: "Flush queues in the running process",38 Action: runFlushQueues,39 Flags: []cli.Flag{40 cli.DurationFlag{41 Name: "timeout",42 Value: 60 * time.Second,43 Usage: "Timeout for the flushing process",44 },45 cli.BoolFlag{46 Name: "non-blocking",47 Usage: "Set to true to not wait for flush to complete before returning",48 },49 },50 }51)52func runShutdown(c *cli.Context) error {53 setup("manager", false)54 statusCode, msg := private.Shutdown()55 switch statusCode {56 case http.StatusInternalServerError:57 fail("InternalServerError", msg)58 }59 fmt.Fprintln(os.Stdout, msg)60 return nil61}62func runRestart(c *cli.Context) error {63 setup("manager", false)64 statusCode, msg := private.Restart()65 switch statusCode {66 case http.StatusInternalServerError:67 fail("InternalServerError", msg)68 }...

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1func main() {2 s := &Server{}3 s.Shutdown()4}5func main() {6 s := &Server{}7 s.Shutdown()8}9func main() {10 s := &Server{}11 s.Shutdown()12}13func main() {14 s := &Server{}15 s.Shutdown()16}17func main() {18 s := &Server{}19 s.Shutdown()20}21func main() {22 s := &Server{}23 s.Shutdown()24}25func main() {26 s := &Server{}27 s.Shutdown()28}29func main() {30 s := &Server{}31 s.Shutdown()32}33func main() {34 s := &Server{}35 s.Shutdown()36}37func main() {38 s := &Server{}39 s.Shutdown()40}41func main() {42 s := &Server{}43 s.Shutdown()44}45func main() {46 s := &Server{}47 s.Shutdown()48}49func main() {50 s := &Server{}51 s.Shutdown()52}53func main() {54 s := &Server{}55 s.Shutdown()56}57func main() {58 s := &Server{}59 s.Shutdown()60}61func main()

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1import (2func main() {3 fmt.Println("Starting the program")4 time.Sleep(2 * time.Second)5 fmt.Println("The End")6}7import (8func main() {9 fmt.Println("Starting the program")10 time.Sleep(2 * time.Second)11 fmt.Println("The End")12}13import (14func main() {15 fmt.Println("Starting the program")16 time.Sleep(2 * time.Second)17 fmt.Println("The End")18}19import (20func main() {21 fmt.Println("Starting the program")22 time.Sleep(2 * time.Second)23 fmt.Println("The End")24}25import (26func main() {27 fmt.Println("Starting the program")28 time.Sleep(2 * time.Second)29 fmt.Println("The End")30}31import (32func main() {33 fmt.Println("Starting the program")34 time.Sleep(2 * time.Second)35 fmt.Println("The End")36}37import (38func main() {39 fmt.Println("Starting the program")40 time.Sleep(2 * time.Second)41 fmt.Println("The End")42}43import (44func main() {45 fmt.Println("Starting the program")46 time.Sleep(2 * time

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1import (2func main() {3 sig := make(chan os.Signal, 1)4 signal.Notify(sig, syscall.SIGINT, syscall.SIGTERM)5 done := make(chan bool, 1)6 go func() {7 fmt.Println("Starting...")8 Shutdown()9 }()10 select {11 }12 fmt.Println("Done.")13}14import (15func main() {16 sig := make(chan os.Signal, 1)17 signal.Notify(sig, syscall.SIGINT, syscall.SIGTERM)18 done := make(chan bool, 1)19 go func() {20 fmt.Println("Starting...")21 Shutdown()22 }()23 select {24 }25 fmt.Println("Done.")26}27import (28func main() {29 sig := make(chan os.Signal, 1)30 signal.Notify(sig, syscall.SIGINT, syscall.SIGTERM)31 done := make(chan bool, 1)32 go func() {33 fmt.Println("Starting...")34 Shutdown()35 }()36 select {37 }38 fmt.Println("Done.")39}

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1import (2func main() {3 internal.New().Shutdown()4}5type internal struct{}6func New() *internal {7 return &internal{}8}9func (i *internal) Shutdown() {10 println("Shutting down")11}12import (13func TestShutdown(t *testing.T) {14 internal := New()15 internal.Shutdown()16}17# cd /home/username/1; /usr/local/go/pkg/tool/linux_amd64/test2json -t /tmp/go-build568406846/b001/testmain -test.v18--- PASS: TestShutdown (0.00s)19# cd /home/username/1/internal; /usr/local/go/pkg/tool/linux_amd64/test2json -t /tmp/go-build568406846/b001/testmain -test.v20--- FAIL: TestShutdown (0.00s)21testing.tRunner.func1(0xc42008e0f0)22panic(0x55f220, 0xc42000a2b0)23github.com/golang/mock/gomock.(*Controller).Finish(0xc42000a2a0)24panic(0x55f220, 0xc42000a2b0)25github.com/golang/mock/gomock.(*Controller).Finish(0xc42000a2a0)26panic(0x55f220, 0xc42000a2b0

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1import (2type server struct {3}4func (s *server) Shutdown() {5 fmt.Println("Shutting down the server")6 s.Server.Shutdown(nil)7}8func handler(w http.ResponseWriter, r *http.Request) {9 fmt.Fprintf(w, "Hello World")10}11func main() {12 s := &server{13 Server: http.Server{14 Handler: http.HandlerFunc(handler),15 },16 }17 stop := make(chan os.Signal, 1)18 signal.Notify(stop, os.Interrupt, syscall.SIGTERM)19 done := make(chan bool, 1)20 go func() {21 fmt.Println("Starting the server")22 if err := s.ListenAndServe(); err != nil {23 fmt.Println(err)24 }25 }()26 select {27 fmt.Println("Shutting down the server")28 s.Shutdown()29 fmt.Println("Server shutdown")30 }31 time.Sleep(time.Second)32}33import (34func handler(w http.ResponseWriter, r *http.Request) {35 fmt.Fprintf(w, "Hello World")36}37func main() {38 s := &http.Server{39 Handler: http.HandlerFunc(handler),40 }41 stop := make(chan os.Signal, 1)42 signal.Notify(stop, os.Interrupt, syscall.SIGTERM)

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1import (2func main() {3 s := NewServer()4 go s.Run()5 fmt.Println("Server running on port 8080")6 quit := make(chan os.Signal, 1)7 signal.Notify(quit, syscall.SIGINT, syscall.SIGTERM)8 log.Println("Shutdown Server ...")9 ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)10 defer cancel()11 if err := s.Shutdown(ctx); err != nil {12 log.Fatal("Server Shutdown:", err)13 }14 select {15 case <-ctx.Done():16 log.Println("timeout of 5 seconds.")17 }18 log.Println("Server exiting")19}20import (21type Server struct {22}23func NewServer() *Server {24 return &Server{25 httpServer: &http.Server{26 },27 }28}29func (s *Server) Run() {30 http.HandleFunc("/", func(w http.ResponseWriter, r *http.Request) {31 fmt.Fprintf(w, "Hello World!")32 })33 if err := s.httpServer.ListenAndServe(); err != nil && err != http.ErrServerClosed {34 log.Fatalf("listen: %s\n", err)35 }36}37func (s *Server) Shutdown(ctx context.Context) error {38 return s.httpServer.Shutdown(ctx)39}40func main() {41 s := NewServer()42 go s.Run()43 fmt.Println("Server running on port 8080")44 quit := make(chan os.Signal, 1)45 signal.Notify(quit, syscall.SIGINT, syscall.SIGTERM)46 log.Println("Shutdown Server ...")47 ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)48 defer cancel()

Full Screen

Full Screen

Shutdown

Using AI Code Generation

copy

Full Screen

1import (2func main() {3 fmt.Println("Go-Internals")4 internal.Shutdown()5}6import "fmt"7func Shutdown() {8 fmt.Println("Shutdown")9}

Full Screen

Full Screen

Automation Testing Tutorials

Learn to execute automation testing from scratch with LambdaTest Learning Hub. Right from setting up the prerequisites to run your first automation test, to following best practices and diving deeper into advanced test scenarios. LambdaTest Learning Hubs compile a list of step-by-step guides to help you be proficient with different test automation frameworks i.e. Selenium, Cypress, TestNG etc.

LambdaTest Learning Hubs:

YouTube

You could also refer to video tutorials over LambdaTest YouTube channel to get step by step demonstration from industry experts.

Run Ginkgo automation tests on LambdaTest cloud grid

Perform automation testing on 3000+ real desktop and mobile devices online.

Most used method in

Try LambdaTest Now !!

Get 100 minutes of automation test minutes FREE!!

Next-Gen App & Browser Testing Cloud

Was this article helpful?

Helpful

NotHelpful