123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254 |
- /*
- *
- * Copyright 2018 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 test
- import (
- "context"
- "reflect"
- "testing"
- "time"
- "github.com/golang/protobuf/proto"
- "google.golang.org/grpc"
- "google.golang.org/grpc/balancer"
- "google.golang.org/grpc/connectivity"
- "google.golang.org/grpc/credentials"
- "google.golang.org/grpc/grpclog"
- "google.golang.org/grpc/internal/balancerload/orca"
- orcapb "google.golang.org/grpc/internal/balancerload/orca/orca_v1"
- "google.golang.org/grpc/resolver"
- testpb "google.golang.org/grpc/test/grpc_testing"
- "google.golang.org/grpc/testdata"
- _ "google.golang.org/grpc/internal/balancerload/orca"
- )
- const testBalancerName = "testbalancer"
- // testBalancer creates one subconn with the first address from resolved
- // addresses.
- //
- // It's used to test options for NewSubConn are applies correctly.
- type testBalancer struct {
- cc balancer.ClientConn
- sc balancer.SubConn
- newSubConnOptions balancer.NewSubConnOptions
- pickOptions []balancer.PickOptions
- doneInfo []balancer.DoneInfo
- }
- func (b *testBalancer) Build(cc balancer.ClientConn, opt balancer.BuildOptions) balancer.Balancer {
- b.cc = cc
- return b
- }
- func (*testBalancer) Name() string {
- return testBalancerName
- }
- func (b *testBalancer) HandleResolvedAddrs(addrs []resolver.Address, err error) {
- // Only create a subconn at the first time.
- if err == nil && b.sc == nil {
- b.sc, err = b.cc.NewSubConn(addrs, b.newSubConnOptions)
- if err != nil {
- grpclog.Errorf("testBalancer: failed to NewSubConn: %v", err)
- return
- }
- b.cc.UpdateBalancerState(connectivity.Connecting, &picker{sc: b.sc, bal: b})
- b.sc.Connect()
- }
- }
- func (b *testBalancer) HandleSubConnStateChange(sc balancer.SubConn, s connectivity.State) {
- grpclog.Infof("testBalancer: HandleSubConnStateChange: %p, %v", sc, s)
- if b.sc != sc {
- grpclog.Infof("testBalancer: ignored state change because sc is not recognized")
- return
- }
- if s == connectivity.Shutdown {
- b.sc = nil
- return
- }
- switch s {
- case connectivity.Ready, connectivity.Idle:
- b.cc.UpdateBalancerState(s, &picker{sc: sc, bal: b})
- case connectivity.Connecting:
- b.cc.UpdateBalancerState(s, &picker{err: balancer.ErrNoSubConnAvailable, bal: b})
- case connectivity.TransientFailure:
- b.cc.UpdateBalancerState(s, &picker{err: balancer.ErrTransientFailure, bal: b})
- }
- }
- func (b *testBalancer) Close() {
- }
- type picker struct {
- err error
- sc balancer.SubConn
- bal *testBalancer
- }
- func (p *picker) Pick(ctx context.Context, opts balancer.PickOptions) (balancer.SubConn, func(balancer.DoneInfo), error) {
- if p.err != nil {
- return nil, nil, p.err
- }
- p.bal.pickOptions = append(p.bal.pickOptions, opts)
- return p.sc, func(d balancer.DoneInfo) { p.bal.doneInfo = append(p.bal.doneInfo, d) }, nil
- }
- func (s) TestCredsBundleFromBalancer(t *testing.T) {
- balancer.Register(&testBalancer{
- newSubConnOptions: balancer.NewSubConnOptions{
- CredsBundle: &testCredsBundle{},
- },
- })
- te := newTest(t, env{name: "creds-bundle", network: "tcp", balancer: ""})
- te.tapHandle = authHandle
- te.customDialOptions = []grpc.DialOption{
- grpc.WithBalancerName(testBalancerName),
- }
- creds, err := credentials.NewServerTLSFromFile(testdata.Path("server1.pem"), testdata.Path("server1.key"))
- if err != nil {
- t.Fatalf("Failed to generate credentials %v", err)
- }
- te.customServerOptions = []grpc.ServerOption{
- grpc.Creds(creds),
- }
- te.startServer(&testServer{})
- defer te.tearDown()
- cc := te.clientConn()
- tc := testpb.NewTestServiceClient(cc)
- if _, err := tc.EmptyCall(context.Background(), &testpb.Empty{}); err != nil {
- t.Fatalf("Test failed. Reason: %v", err)
- }
- }
- func (s) TestDoneInfo(t *testing.T) {
- for _, e := range listTestEnv() {
- testDoneInfo(t, e)
- }
- }
- func testDoneInfo(t *testing.T, e env) {
- te := newTest(t, e)
- b := &testBalancer{}
- balancer.Register(b)
- te.customDialOptions = []grpc.DialOption{
- grpc.WithBalancerName(testBalancerName),
- }
- te.userAgent = failAppUA
- te.startServer(&testServer{security: e.security})
- defer te.tearDown()
- cc := te.clientConn()
- tc := testpb.NewTestServiceClient(cc)
- ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)
- defer cancel()
- wantErr := detailedError
- if _, err := tc.EmptyCall(ctx, &testpb.Empty{}); !reflect.DeepEqual(err, wantErr) {
- t.Fatalf("TestService/EmptyCall(_, _) = _, %v, want _, %v", err, wantErr)
- }
- if _, err := tc.UnaryCall(ctx, &testpb.SimpleRequest{}); err != nil {
- t.Fatalf("TestService.UnaryCall(%v, _, _, _) = _, %v; want _, <nil>", ctx, err)
- }
- if len(b.doneInfo) < 1 || !reflect.DeepEqual(b.doneInfo[0].Err, wantErr) {
- t.Fatalf("b.doneInfo = %v; want b.doneInfo[0].Err = %v", b.doneInfo, wantErr)
- }
- if len(b.doneInfo) < 2 || !reflect.DeepEqual(b.doneInfo[1].Trailer, testTrailerMetadata) {
- t.Fatalf("b.doneInfo = %v; want b.doneInfo[1].Trailer = %v", b.doneInfo, testTrailerMetadata)
- }
- if len(b.pickOptions) != len(b.doneInfo) {
- t.Fatalf("Got %d picks, but %d doneInfo, want equal amount", len(b.pickOptions), len(b.doneInfo))
- }
- // To test done() is always called, even if it's returned with a non-Ready
- // SubConn.
- //
- // Stop server and at the same time send RPCs. There are chances that picker
- // is not updated in time, causing a non-Ready SubConn to be returned.
- finished := make(chan struct{})
- go func() {
- for i := 0; i < 20; i++ {
- tc.UnaryCall(ctx, &testpb.SimpleRequest{})
- }
- close(finished)
- }()
- te.srv.Stop()
- <-finished
- if len(b.pickOptions) != len(b.doneInfo) {
- t.Fatalf("Got %d picks, %d doneInfo, want equal amount", len(b.pickOptions), len(b.doneInfo))
- }
- }
- func (s) TestDoneLoads(t *testing.T) {
- for _, e := range listTestEnv() {
- testDoneLoads(t, e)
- }
- }
- func testDoneLoads(t *testing.T, e env) {
- b := &testBalancer{}
- balancer.Register(b)
- testLoad := &orcapb.LoadReport{
- CpuUtilization: 0.31,
- MemUtilization: 0.41,
- NicInUtilization: 0.59,
- NicOutUtilization: 0.26,
- RequestCostOrUtilization: nil,
- }
- ss := &stubServer{
- emptyCall: func(ctx context.Context, in *testpb.Empty) (*testpb.Empty, error) {
- grpc.SetTrailer(ctx, orca.ToMetadata(testLoad))
- return &testpb.Empty{}, nil
- },
- }
- if err := ss.Start(nil, grpc.WithBalancerName(testBalancerName)); err != nil {
- t.Fatalf("error starting testing server: %v", err)
- }
- defer ss.Stop()
- tc := testpb.NewTestServiceClient(ss.cc)
- ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)
- defer cancel()
- if _, err := tc.EmptyCall(ctx, &testpb.Empty{}); err != nil {
- t.Fatalf("TestService/EmptyCall(_, _) = _, %v, want _, %v", err, nil)
- }
- poWant := []balancer.PickOptions{
- {FullMethodName: "/grpc.testing.TestService/EmptyCall"},
- }
- if !reflect.DeepEqual(b.pickOptions, poWant) {
- t.Fatalf("b.pickOptions = %v; want %v", b.pickOptions, poWant)
- }
- if len(b.doneInfo) < 1 {
- t.Fatalf("b.doneInfo = %v, want length 1", b.doneInfo)
- }
- gotLoad, _ := b.doneInfo[0].ServerLoad.(*orcapb.LoadReport)
- if !proto.Equal(gotLoad, testLoad) {
- t.Fatalf("b.doneInfo[0].ServerLoad = %v; want = %v", b.doneInfo[0].ServerLoad, testLoad)
- }
- }
|