123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489 |
- /*
- *
- * Copyright 2014 gRPC authors.
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- *
- */
- package grpc
- import (
- "context"
- "fmt"
- "io"
- "math"
- "net"
- "strconv"
- "strings"
- "sync"
- "testing"
- "time"
- "google.golang.org/grpc/codes"
- "google.golang.org/grpc/internal/transport"
- "google.golang.org/grpc/status"
- )
- var (
- expectedRequest = "ping"
- expectedResponse = "pong"
- weirdError = "format verbs: %v%s"
- sizeLargeErr = 1024 * 1024
- canceled = 0
- )
- type testCodec struct {
- }
- func (testCodec) Marshal(v interface{}) ([]byte, error) {
- return []byte(*(v.(*string))), nil
- }
- func (testCodec) Unmarshal(data []byte, v interface{}) error {
- *(v.(*string)) = string(data)
- return nil
- }
- func (testCodec) String() string {
- return "test"
- }
- type testStreamHandler struct {
- port string
- t transport.ServerTransport
- }
- func (h *testStreamHandler) handleStream(t *testing.T, s *transport.Stream) {
- p := &parser{r: s}
- for {
- pf, req, err := p.recvMsg(math.MaxInt32)
- if err == io.EOF {
- break
- }
- if err != nil {
- return
- }
- if pf != compressionNone {
- t.Errorf("Received the mistaken message format %d, want %d", pf, compressionNone)
- return
- }
- var v string
- codec := testCodec{}
- if err := codec.Unmarshal(req, &v); err != nil {
- t.Errorf("Failed to unmarshal the received message: %v", err)
- return
- }
- if v == "weird error" {
- h.t.WriteStatus(s, status.New(codes.Internal, weirdError))
- return
- }
- if v == "canceled" {
- canceled++
- h.t.WriteStatus(s, status.New(codes.Internal, ""))
- return
- }
- if v == "port" {
- h.t.WriteStatus(s, status.New(codes.Internal, h.port))
- return
- }
- if v != expectedRequest {
- h.t.WriteStatus(s, status.New(codes.Internal, strings.Repeat("A", sizeLargeErr)))
- return
- }
- }
- // send a response back to end the stream.
- data, err := encode(testCodec{}, &expectedResponse)
- if err != nil {
- t.Errorf("Failed to encode the response: %v", err)
- return
- }
- hdr, payload := msgHeader(data, nil)
- h.t.Write(s, hdr, payload, &transport.Options{})
- h.t.WriteStatus(s, status.New(codes.OK, ""))
- }
- type server struct {
- lis net.Listener
- port string
- addr string
- startedErr chan error // sent nil or an error after server starts
- mu sync.Mutex
- conns map[transport.ServerTransport]bool
- }
- type ctxKey string
- func newTestServer() *server {
- return &server{startedErr: make(chan error, 1)}
- }
- // start starts server. Other goroutines should block on s.startedErr for further operations.
- func (s *server) start(t *testing.T, port int, maxStreams uint32) {
- var err error
- if port == 0 {
- s.lis, err = net.Listen("tcp", "localhost:0")
- } else {
- s.lis, err = net.Listen("tcp", "localhost:"+strconv.Itoa(port))
- }
- if err != nil {
- s.startedErr <- fmt.Errorf("failed to listen: %v", err)
- return
- }
- s.addr = s.lis.Addr().String()
- _, p, err := net.SplitHostPort(s.addr)
- if err != nil {
- s.startedErr <- fmt.Errorf("failed to parse listener address: %v", err)
- return
- }
- s.port = p
- s.conns = make(map[transport.ServerTransport]bool)
- s.startedErr <- nil
- for {
- conn, err := s.lis.Accept()
- if err != nil {
- return
- }
- config := &transport.ServerConfig{
- MaxStreams: maxStreams,
- }
- st, err := transport.NewServerTransport("http2", conn, config)
- if err != nil {
- continue
- }
- s.mu.Lock()
- if s.conns == nil {
- s.mu.Unlock()
- st.Close()
- return
- }
- s.conns[st] = true
- s.mu.Unlock()
- h := &testStreamHandler{
- port: s.port,
- t: st,
- }
- go st.HandleStreams(func(s *transport.Stream) {
- go h.handleStream(t, s)
- }, func(ctx context.Context, method string) context.Context {
- return ctx
- })
- }
- }
- func (s *server) wait(t *testing.T, timeout time.Duration) {
- select {
- case err := <-s.startedErr:
- if err != nil {
- t.Fatal(err)
- }
- case <-time.After(timeout):
- t.Fatalf("Timed out after %v waiting for server to be ready", timeout)
- }
- }
- func (s *server) stop() {
- s.lis.Close()
- s.mu.Lock()
- for c := range s.conns {
- c.Close()
- }
- s.conns = nil
- s.mu.Unlock()
- }
- func setUp(t *testing.T, port int, maxStreams uint32) (*server, *ClientConn) {
- return setUpWithOptions(t, port, maxStreams)
- }
- func setUpWithOptions(t *testing.T, port int, maxStreams uint32, dopts ...DialOption) (*server, *ClientConn) {
- server := newTestServer()
- go server.start(t, port, maxStreams)
- server.wait(t, 2*time.Second)
- addr := "localhost:" + server.port
- dopts = append(dopts, WithBlock(), WithInsecure(), WithCodec(testCodec{}))
- cc, err := Dial(addr, dopts...)
- if err != nil {
- t.Fatalf("Failed to create ClientConn: %v", err)
- }
- return server, cc
- }
- func (s) TestUnaryClientInterceptor(t *testing.T) {
- parentKey := ctxKey("parentKey")
- interceptor := func(ctx context.Context, method string, req, reply interface{}, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("interceptor should have %v in context", parentKey)
- }
- return invoker(ctx, method, req, reply, cc, opts...)
- }
- server, cc := setUpWithOptions(t, 0, math.MaxUint32, WithUnaryInterceptor(interceptor))
- defer func() {
- cc.Close()
- server.stop()
- }()
- var reply string
- ctx := context.Background()
- parentCtx := context.WithValue(ctx, ctxKey("parentKey"), 0)
- if err := cc.Invoke(parentCtx, "/foo/bar", &expectedRequest, &reply); err != nil || reply != expectedResponse {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) = %v, want <nil>", err)
- }
- }
- func (s) TestChainUnaryClientInterceptor(t *testing.T) {
- var (
- parentKey = ctxKey("parentKey")
- firstIntKey = ctxKey("firstIntKey")
- secondIntKey = ctxKey("secondIntKey")
- )
- firstInt := func(ctx context.Context, method string, req, reply interface{}, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("first interceptor should have %v in context", parentKey)
- }
- if ctx.Value(firstIntKey) != nil {
- t.Fatalf("first interceptor should not have %v in context", firstIntKey)
- }
- if ctx.Value(secondIntKey) != nil {
- t.Fatalf("first interceptor should not have %v in context", secondIntKey)
- }
- firstCtx := context.WithValue(ctx, firstIntKey, 1)
- err := invoker(firstCtx, method, req, reply, cc, opts...)
- *(reply.(*string)) += "1"
- return err
- }
- secondInt := func(ctx context.Context, method string, req, reply interface{}, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("second interceptor should have %v in context", parentKey)
- }
- if ctx.Value(firstIntKey) == nil {
- t.Fatalf("second interceptor should have %v in context", firstIntKey)
- }
- if ctx.Value(secondIntKey) != nil {
- t.Fatalf("second interceptor should not have %v in context", secondIntKey)
- }
- secondCtx := context.WithValue(ctx, secondIntKey, 2)
- err := invoker(secondCtx, method, req, reply, cc, opts...)
- *(reply.(*string)) += "2"
- return err
- }
- lastInt := func(ctx context.Context, method string, req, reply interface{}, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("last interceptor should have %v in context", parentKey)
- }
- if ctx.Value(firstIntKey) == nil {
- t.Fatalf("last interceptor should have %v in context", firstIntKey)
- }
- if ctx.Value(secondIntKey) == nil {
- t.Fatalf("last interceptor should have %v in context", secondIntKey)
- }
- err := invoker(ctx, method, req, reply, cc, opts...)
- *(reply.(*string)) += "3"
- return err
- }
- server, cc := setUpWithOptions(t, 0, math.MaxUint32, WithChainUnaryInterceptor(firstInt, secondInt, lastInt))
- defer func() {
- cc.Close()
- server.stop()
- }()
- var reply string
- ctx := context.Background()
- parentCtx := context.WithValue(ctx, ctxKey("parentKey"), 0)
- if err := cc.Invoke(parentCtx, "/foo/bar", &expectedRequest, &reply); err != nil || reply != expectedResponse+"321" {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) = %v, want <nil>", err)
- }
- }
- func (s) TestChainOnBaseUnaryClientInterceptor(t *testing.T) {
- var (
- parentKey = ctxKey("parentKey")
- baseIntKey = ctxKey("baseIntKey")
- )
- baseInt := func(ctx context.Context, method string, req, reply interface{}, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("base interceptor should have %v in context", parentKey)
- }
- if ctx.Value(baseIntKey) != nil {
- t.Fatalf("base interceptor should not have %v in context", baseIntKey)
- }
- baseCtx := context.WithValue(ctx, baseIntKey, 1)
- return invoker(baseCtx, method, req, reply, cc, opts...)
- }
- chainInt := func(ctx context.Context, method string, req, reply interface{}, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("chain interceptor should have %v in context", parentKey)
- }
- if ctx.Value(baseIntKey) == nil {
- t.Fatalf("chain interceptor should have %v in context", baseIntKey)
- }
- return invoker(ctx, method, req, reply, cc, opts...)
- }
- server, cc := setUpWithOptions(t, 0, math.MaxUint32, WithUnaryInterceptor(baseInt), WithChainUnaryInterceptor(chainInt))
- defer func() {
- cc.Close()
- server.stop()
- }()
- var reply string
- ctx := context.Background()
- parentCtx := context.WithValue(ctx, ctxKey("parentKey"), 0)
- if err := cc.Invoke(parentCtx, "/foo/bar", &expectedRequest, &reply); err != nil || reply != expectedResponse {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) = %v, want <nil>", err)
- }
- }
- func (s) TestChainStreamClientInterceptor(t *testing.T) {
- var (
- parentKey = ctxKey("parentKey")
- firstIntKey = ctxKey("firstIntKey")
- secondIntKey = ctxKey("secondIntKey")
- )
- firstInt := func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, streamer Streamer, opts ...CallOption) (ClientStream, error) {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("first interceptor should have %v in context", parentKey)
- }
- if ctx.Value(firstIntKey) != nil {
- t.Fatalf("first interceptor should not have %v in context", firstIntKey)
- }
- if ctx.Value(secondIntKey) != nil {
- t.Fatalf("first interceptor should not have %v in context", secondIntKey)
- }
- firstCtx := context.WithValue(ctx, firstIntKey, 1)
- return streamer(firstCtx, desc, cc, method, opts...)
- }
- secondInt := func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, streamer Streamer, opts ...CallOption) (ClientStream, error) {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("second interceptor should have %v in context", parentKey)
- }
- if ctx.Value(firstIntKey) == nil {
- t.Fatalf("second interceptor should have %v in context", firstIntKey)
- }
- if ctx.Value(secondIntKey) != nil {
- t.Fatalf("second interceptor should not have %v in context", secondIntKey)
- }
- secondCtx := context.WithValue(ctx, secondIntKey, 2)
- return streamer(secondCtx, desc, cc, method, opts...)
- }
- lastInt := func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, streamer Streamer, opts ...CallOption) (ClientStream, error) {
- if ctx.Value(parentKey) == nil {
- t.Fatalf("last interceptor should have %v in context", parentKey)
- }
- if ctx.Value(firstIntKey) == nil {
- t.Fatalf("last interceptor should have %v in context", firstIntKey)
- }
- if ctx.Value(secondIntKey) == nil {
- t.Fatalf("last interceptor should have %v in context", secondIntKey)
- }
- return streamer(ctx, desc, cc, method, opts...)
- }
- server, cc := setUpWithOptions(t, 0, math.MaxUint32, WithChainStreamInterceptor(firstInt, secondInt, lastInt))
- defer func() {
- cc.Close()
- server.stop()
- }()
- ctx := context.Background()
- parentCtx := context.WithValue(ctx, ctxKey("parentKey"), 0)
- _, err := cc.NewStream(parentCtx, &StreamDesc{}, "/foo/bar")
- if err != nil {
- t.Fatalf("grpc.NewStream(_, _, _) = %v, want <nil>", err)
- }
- }
- func (s) TestInvoke(t *testing.T) {
- server, cc := setUp(t, 0, math.MaxUint32)
- var reply string
- if err := cc.Invoke(context.Background(), "/foo/bar", &expectedRequest, &reply); err != nil || reply != expectedResponse {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) = %v, want <nil>", err)
- }
- cc.Close()
- server.stop()
- }
- func (s) TestInvokeLargeErr(t *testing.T) {
- server, cc := setUp(t, 0, math.MaxUint32)
- var reply string
- req := "hello"
- err := cc.Invoke(context.Background(), "/foo/bar", &req, &reply)
- if _, ok := status.FromError(err); !ok {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) receives non rpc error.")
- }
- if status.Code(err) != codes.Internal || len(errorDesc(err)) != sizeLargeErr {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) = %v, want an error of code %d and desc size %d", err, codes.Internal, sizeLargeErr)
- }
- cc.Close()
- server.stop()
- }
- // TestInvokeErrorSpecialChars checks that error messages don't get mangled.
- func (s) TestInvokeErrorSpecialChars(t *testing.T) {
- server, cc := setUp(t, 0, math.MaxUint32)
- var reply string
- req := "weird error"
- err := cc.Invoke(context.Background(), "/foo/bar", &req, &reply)
- if _, ok := status.FromError(err); !ok {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) receives non rpc error.")
- }
- if got, want := errorDesc(err), weirdError; got != want {
- t.Fatalf("grpc.Invoke(_, _, _, _, _) error = %q, want %q", got, want)
- }
- cc.Close()
- server.stop()
- }
- // TestInvokeCancel checks that an Invoke with a canceled context is not sent.
- func (s) TestInvokeCancel(t *testing.T) {
- server, cc := setUp(t, 0, math.MaxUint32)
- var reply string
- req := "canceled"
- for i := 0; i < 100; i++ {
- ctx, cancel := context.WithCancel(context.Background())
- cancel()
- cc.Invoke(ctx, "/foo/bar", &req, &reply)
- }
- if canceled != 0 {
- t.Fatalf("received %d of 100 canceled requests", canceled)
- }
- cc.Close()
- server.stop()
- }
- // TestInvokeCancelClosedNonFail checks that a canceled non-failfast RPC
- // on a closed client will terminate.
- func (s) TestInvokeCancelClosedNonFailFast(t *testing.T) {
- server, cc := setUp(t, 0, math.MaxUint32)
- var reply string
- cc.Close()
- req := "hello"
- ctx, cancel := context.WithCancel(context.Background())
- cancel()
- if err := cc.Invoke(ctx, "/foo/bar", &req, &reply, WaitForReady(true)); err == nil {
- t.Fatalf("canceled invoke on closed connection should fail")
- }
- server.stop()
- }
|