123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631 |
- /*
- *
- * Copyright 2016 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.
- *
- */
- #include <algorithm>
- #include <memory>
- #include <mutex>
- #include <random>
- #include <set>
- #include <string>
- #include <thread>
- #include <gmock/gmock.h>
- #include <gtest/gtest.h>
- #include "absl/memory/memory.h"
- #include "absl/strings/str_cat.h"
- #include <grpc/grpc.h>
- #include <grpc/support/alloc.h>
- #include <grpc/support/atm.h>
- #include <grpc/support/log.h>
- #include <grpc/support/time.h>
- #include <grpcpp/channel.h>
- #include <grpcpp/client_context.h>
- #include <grpcpp/create_channel.h>
- #include <grpcpp/health_check_service_interface.h>
- #include <grpcpp/impl/codegen/sync.h>
- #include <grpcpp/server.h>
- #include <grpcpp/server_builder.h>
- #include <grpcpp/support/validate_service_config.h>
- #include "src/core/ext/filters/client_channel/backup_poller.h"
- #include "src/core/ext/filters/client_channel/global_subchannel_pool.h"
- #include "src/core/ext/filters/client_channel/resolver/fake/fake_resolver.h"
- #include "src/core/lib/address_utils/parse_address.h"
- #include "src/core/lib/backoff/backoff.h"
- #include "src/core/lib/channel/channel_args.h"
- #include "src/core/lib/gprpp/debug_location.h"
- #include "src/core/lib/gprpp/ref_counted_ptr.h"
- #include "src/core/lib/iomgr/tcp_client.h"
- #include "src/core/lib/resolver/server_address.h"
- #include "src/core/lib/security/credentials/fake/fake_credentials.h"
- #include "src/core/lib/service_config/service_config_impl.h"
- #include "src/core/lib/transport/error_utils.h"
- #include "src/cpp/client/secure_credentials.h"
- #include "src/cpp/server/secure_server_credentials.h"
- #include "src/proto/grpc/testing/echo.grpc.pb.h"
- #include "test/core/util/port.h"
- #include "test/core/util/resolve_localhost_ip46.h"
- #include "test/core/util/test_config.h"
- #include "test/cpp/end2end/test_service_impl.h"
- using grpc::testing::EchoRequest;
- using grpc::testing::EchoResponse;
- namespace grpc {
- namespace testing {
- namespace {
- // Subclass of TestServiceImpl that increments a request counter for
- // every call to the Echo RPC.
- class MyTestServiceImpl : public TestServiceImpl {
- public:
- MyTestServiceImpl() : request_count_(0) {}
- Status Echo(ServerContext* context, const EchoRequest* request,
- EchoResponse* response) override {
- {
- grpc::internal::MutexLock lock(&mu_);
- ++request_count_;
- }
- AddClient(context->peer());
- return TestServiceImpl::Echo(context, request, response);
- }
- int request_count() {
- grpc::internal::MutexLock lock(&mu_);
- return request_count_;
- }
- void ResetCounters() {
- grpc::internal::MutexLock lock(&mu_);
- request_count_ = 0;
- }
- std::set<std::string> clients() {
- grpc::internal::MutexLock lock(&clients_mu_);
- return clients_;
- }
- private:
- void AddClient(const std::string& client) {
- grpc::internal::MutexLock lock(&clients_mu_);
- clients_.insert(client);
- }
- grpc::internal::Mutex mu_;
- int request_count_;
- grpc::internal::Mutex clients_mu_;
- std::set<std::string> clients_;
- };
- class ServiceConfigEnd2endTest : public ::testing::Test {
- protected:
- ServiceConfigEnd2endTest()
- : server_host_("localhost"),
- kRequestMessage_("Live long and prosper."),
- creds_(new SecureChannelCredentials(
- grpc_fake_transport_security_credentials_create())) {}
- static void SetUpTestCase() {
- // Make the backup poller poll very frequently in order to pick up
- // updates from all the subchannels's FDs.
- GPR_GLOBAL_CONFIG_SET(grpc_client_channel_backup_poll_interval_ms, 1);
- }
- void SetUp() override {
- grpc_init();
- response_generator_ =
- grpc_core::MakeRefCounted<grpc_core::FakeResolverResponseGenerator>();
- bool localhost_resolves_to_ipv4 = false;
- bool localhost_resolves_to_ipv6 = false;
- grpc_core::LocalhostResolves(&localhost_resolves_to_ipv4,
- &localhost_resolves_to_ipv6);
- ipv6_only_ = !localhost_resolves_to_ipv4 && localhost_resolves_to_ipv6;
- }
- void TearDown() override {
- for (size_t i = 0; i < servers_.size(); ++i) {
- servers_[i]->Shutdown();
- }
- // Explicitly destroy all the members so that we can make sure grpc_shutdown
- // has finished by the end of this function, and thus all the registered
- // LB policy factories are removed.
- stub_.reset();
- servers_.clear();
- creds_.reset();
- grpc_shutdown();
- }
- void CreateServers(size_t num_servers,
- std::vector<int> ports = std::vector<int>()) {
- servers_.clear();
- for (size_t i = 0; i < num_servers; ++i) {
- int port = 0;
- if (ports.size() == num_servers) port = ports[i];
- servers_.emplace_back(new ServerData(port));
- }
- }
- void StartServer(size_t index) { servers_[index]->Start(server_host_); }
- void StartServers(size_t num_servers,
- std::vector<int> ports = std::vector<int>()) {
- CreateServers(num_servers, std::move(ports));
- for (size_t i = 0; i < num_servers; ++i) {
- StartServer(i);
- }
- }
- grpc_core::Resolver::Result BuildFakeResults(const std::vector<int>& ports) {
- grpc_core::Resolver::Result result;
- result.addresses = grpc_core::ServerAddressList();
- for (const int& port : ports) {
- std::string lb_uri_str =
- absl::StrCat(ipv6_only_ ? "ipv6:[::1]:" : "ipv4:127.0.0.1:", port);
- absl::StatusOr<grpc_core::URI> lb_uri = grpc_core::URI::Parse(lb_uri_str);
- GPR_ASSERT(lb_uri.ok());
- grpc_resolved_address address;
- GPR_ASSERT(grpc_parse_uri(*lb_uri, &address));
- result.addresses->emplace_back(address.addr, address.len,
- nullptr /* args */);
- }
- return result;
- }
- void SetNextResolutionNoServiceConfig(const std::vector<int>& ports) {
- grpc_core::ExecCtx exec_ctx;
- grpc_core::Resolver::Result result = BuildFakeResults(ports);
- response_generator_->SetResponse(result);
- }
- void SetNextResolutionValidServiceConfig(const std::vector<int>& ports) {
- grpc_core::ExecCtx exec_ctx;
- grpc_core::Resolver::Result result = BuildFakeResults(ports);
- grpc_error_handle error = GRPC_ERROR_NONE;
- result.service_config =
- grpc_core::ServiceConfigImpl::Create(nullptr, "{}", &error);
- ASSERT_EQ(error, GRPC_ERROR_NONE) << grpc_error_std_string(error);
- response_generator_->SetResponse(result);
- }
- void SetNextResolutionInvalidServiceConfig(const std::vector<int>& ports) {
- grpc_core::ExecCtx exec_ctx;
- grpc_core::Resolver::Result result = BuildFakeResults(ports);
- result.service_config =
- absl::InvalidArgumentError("error parsing service config");
- response_generator_->SetResponse(result);
- }
- void SetNextResolutionWithServiceConfig(const std::vector<int>& ports,
- const char* svc_cfg) {
- grpc_core::ExecCtx exec_ctx;
- grpc_core::Resolver::Result result = BuildFakeResults(ports);
- grpc_error_handle error = GRPC_ERROR_NONE;
- result.service_config =
- grpc_core::ServiceConfigImpl::Create(nullptr, svc_cfg, &error);
- if (error != GRPC_ERROR_NONE) {
- result.service_config = grpc_error_to_absl_status(error);
- GRPC_ERROR_UNREF(error);
- }
- response_generator_->SetResponse(result);
- }
- std::vector<int> GetServersPorts(size_t start_index = 0) {
- std::vector<int> ports;
- for (size_t i = start_index; i < servers_.size(); ++i) {
- ports.push_back(servers_[i]->port_);
- }
- return ports;
- }
- std::unique_ptr<grpc::testing::EchoTestService::Stub> BuildStub(
- const std::shared_ptr<Channel>& channel) {
- return grpc::testing::EchoTestService::NewStub(channel);
- }
- std::shared_ptr<Channel> BuildChannel() {
- ChannelArguments args;
- args.SetPointer(GRPC_ARG_FAKE_RESOLVER_RESPONSE_GENERATOR,
- response_generator_.get());
- return grpc::CreateCustomChannel("fake:///", creds_, args);
- }
- std::shared_ptr<Channel> BuildChannelWithDefaultServiceConfig() {
- ChannelArguments args;
- EXPECT_THAT(grpc::experimental::ValidateServiceConfigJSON(
- ValidDefaultServiceConfig()),
- ::testing::StrEq(""));
- args.SetServiceConfigJSON(ValidDefaultServiceConfig());
- args.SetPointer(GRPC_ARG_FAKE_RESOLVER_RESPONSE_GENERATOR,
- response_generator_.get());
- return grpc::CreateCustomChannel("fake:///", creds_, args);
- }
- std::shared_ptr<Channel> BuildChannelWithInvalidDefaultServiceConfig() {
- ChannelArguments args;
- EXPECT_THAT(grpc::experimental::ValidateServiceConfigJSON(
- InvalidDefaultServiceConfig()),
- ::testing::HasSubstr("JSON parse error"));
- args.SetServiceConfigJSON(InvalidDefaultServiceConfig());
- args.SetPointer(GRPC_ARG_FAKE_RESOLVER_RESPONSE_GENERATOR,
- response_generator_.get());
- return grpc::CreateCustomChannel("fake:///", creds_, args);
- }
- bool SendRpc(
- const std::unique_ptr<grpc::testing::EchoTestService::Stub>& stub,
- EchoResponse* response = nullptr, int timeout_ms = 1000,
- Status* result = nullptr, bool wait_for_ready = false) {
- const bool local_response = (response == nullptr);
- if (local_response) response = new EchoResponse;
- EchoRequest request;
- request.set_message(kRequestMessage_);
- ClientContext context;
- context.set_deadline(grpc_timeout_milliseconds_to_deadline(timeout_ms));
- if (wait_for_ready) context.set_wait_for_ready(true);
- Status status = stub->Echo(&context, request, response);
- if (result != nullptr) *result = status;
- if (local_response) delete response;
- return status.ok();
- }
- void CheckRpcSendOk(
- const std::unique_ptr<grpc::testing::EchoTestService::Stub>& stub,
- const grpc_core::DebugLocation& location, bool wait_for_ready = false) {
- EchoResponse response;
- Status status;
- const bool success =
- SendRpc(stub, &response, 2000, &status, wait_for_ready);
- ASSERT_TRUE(success) << "From " << location.file() << ":" << location.line()
- << "\n"
- << "Error: " << status.error_message() << " "
- << status.error_details();
- ASSERT_EQ(response.message(), kRequestMessage_)
- << "From " << location.file() << ":" << location.line();
- if (!success) abort();
- }
- void CheckRpcSendFailure(
- const std::unique_ptr<grpc::testing::EchoTestService::Stub>& stub) {
- const bool success = SendRpc(stub);
- EXPECT_FALSE(success);
- }
- struct ServerData {
- const int port_;
- std::unique_ptr<Server> server_;
- MyTestServiceImpl service_;
- std::unique_ptr<std::thread> thread_;
- grpc::internal::Mutex mu_;
- grpc::internal::CondVar cond_;
- bool server_ready_ ABSL_GUARDED_BY(mu_) = false;
- bool started_ ABSL_GUARDED_BY(mu_) = false;
- explicit ServerData(int port = 0)
- : port_(port > 0 ? port : grpc_pick_unused_port_or_die()) {}
- void Start(const std::string& server_host) {
- gpr_log(GPR_INFO, "starting server on port %d", port_);
- grpc::internal::MutexLock lock(&mu_);
- started_ = true;
- thread_ = absl::make_unique<std::thread>(
- std::bind(&ServerData::Serve, this, server_host));
- while (!server_ready_) {
- cond_.Wait(&mu_);
- }
- server_ready_ = false;
- gpr_log(GPR_INFO, "server startup complete");
- }
- void Serve(const std::string& server_host) {
- std::ostringstream server_address;
- server_address << server_host << ":" << port_;
- ServerBuilder builder;
- std::shared_ptr<ServerCredentials> creds(new SecureServerCredentials(
- grpc_fake_transport_security_server_credentials_create()));
- builder.AddListeningPort(server_address.str(), std::move(creds));
- builder.RegisterService(&service_);
- server_ = builder.BuildAndStart();
- grpc::internal::MutexLock lock(&mu_);
- server_ready_ = true;
- cond_.Signal();
- }
- void Shutdown() {
- grpc::internal::MutexLock lock(&mu_);
- if (!started_) return;
- server_->Shutdown(grpc_timeout_milliseconds_to_deadline(0));
- thread_->join();
- started_ = false;
- }
- void SetServingStatus(const std::string& service, bool serving) {
- server_->GetHealthCheckService()->SetServingStatus(service, serving);
- }
- };
- void ResetCounters() {
- for (const auto& server : servers_) server->service_.ResetCounters();
- }
- void WaitForServer(
- const std::unique_ptr<grpc::testing::EchoTestService::Stub>& stub,
- size_t server_idx, const grpc_core::DebugLocation& location,
- bool ignore_failure = false) {
- do {
- if (ignore_failure) {
- SendRpc(stub);
- } else {
- CheckRpcSendOk(stub, location, true);
- }
- } while (servers_[server_idx]->service_.request_count() == 0);
- ResetCounters();
- }
- bool WaitForChannelNotReady(Channel* channel, int timeout_seconds = 5) {
- const gpr_timespec deadline =
- grpc_timeout_seconds_to_deadline(timeout_seconds);
- grpc_connectivity_state state;
- while ((state = channel->GetState(false /* try_to_connect */)) ==
- GRPC_CHANNEL_READY) {
- if (!channel->WaitForStateChange(state, deadline)) return false;
- }
- return true;
- }
- bool WaitForChannelReady(Channel* channel, int timeout_seconds = 5) {
- const gpr_timespec deadline =
- grpc_timeout_seconds_to_deadline(timeout_seconds);
- grpc_connectivity_state state;
- while ((state = channel->GetState(true /* try_to_connect */)) !=
- GRPC_CHANNEL_READY) {
- if (!channel->WaitForStateChange(state, deadline)) return false;
- }
- return true;
- }
- bool SeenAllServers() {
- for (const auto& server : servers_) {
- if (server->service_.request_count() == 0) return false;
- }
- return true;
- }
- // Updates \a connection_order by appending to it the index of the newly
- // connected server. Must be called after every single RPC.
- void UpdateConnectionOrder(
- const std::vector<std::unique_ptr<ServerData>>& servers,
- std::vector<int>* connection_order) {
- for (size_t i = 0; i < servers.size(); ++i) {
- if (servers[i]->service_.request_count() == 1) {
- // Was the server index known? If not, update connection_order.
- const auto it =
- std::find(connection_order->begin(), connection_order->end(), i);
- if (it == connection_order->end()) {
- connection_order->push_back(i);
- return;
- }
- }
- }
- }
- const char* ValidServiceConfigV1() { return "{\"version\": \"1\"}"; }
- const char* ValidServiceConfigV2() { return "{\"version\": \"2\"}"; }
- const char* ValidDefaultServiceConfig() {
- return "{\"version\": \"valid_default\"}";
- }
- const char* InvalidDefaultServiceConfig() {
- return "{\"version\": \"invalid_default\"";
- }
- bool ipv6_only_ = false;
- const std::string server_host_;
- std::unique_ptr<grpc::testing::EchoTestService::Stub> stub_;
- std::vector<std::unique_ptr<ServerData>> servers_;
- grpc_core::RefCountedPtr<grpc_core::FakeResolverResponseGenerator>
- response_generator_;
- const std::string kRequestMessage_;
- std::shared_ptr<ChannelCredentials> creds_;
- };
- TEST_F(ServiceConfigEnd2endTest, NoServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionNoServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ("{}", channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest, NoServiceConfigWithDefaultConfigTest) {
- StartServers(1);
- auto channel = BuildChannelWithDefaultServiceConfig();
- auto stub = BuildStub(channel);
- SetNextResolutionNoServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidDefaultServiceConfig(),
- channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest, InvalidServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- }
- TEST_F(ServiceConfigEnd2endTest, ValidServiceConfigUpdatesTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionWithServiceConfig(GetServersPorts(), ValidServiceConfigV1());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- SetNextResolutionWithServiceConfig(GetServersPorts(), ValidServiceConfigV2());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV2(), channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest,
- NoServiceConfigUpdateAfterValidServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionWithServiceConfig(GetServersPorts(), ValidServiceConfigV1());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- SetNextResolutionNoServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ("{}", channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest,
- NoServiceConfigUpdateAfterValidServiceConfigWithDefaultConfigTest) {
- StartServers(1);
- auto channel = BuildChannelWithDefaultServiceConfig();
- auto stub = BuildStub(channel);
- SetNextResolutionWithServiceConfig(GetServersPorts(), ValidServiceConfigV1());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- SetNextResolutionNoServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidDefaultServiceConfig(),
- channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest,
- InvalidServiceConfigUpdateAfterValidServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionWithServiceConfig(GetServersPorts(), ValidServiceConfigV1());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest,
- InvalidServiceConfigUpdateAfterValidServiceConfigWithDefaultConfigTest) {
- StartServers(1);
- auto channel = BuildChannelWithDefaultServiceConfig();
- auto stub = BuildStub(channel);
- SetNextResolutionWithServiceConfig(GetServersPorts(), ValidServiceConfigV1());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ(ValidServiceConfigV1(), channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest,
- ValidServiceConfigAfterInvalidServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- SetNextResolutionValidServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- }
- TEST_F(ServiceConfigEnd2endTest, NoServiceConfigAfterInvalidServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- SetNextResolutionNoServiceConfig(GetServersPorts());
- CheckRpcSendOk(stub, DEBUG_LOCATION);
- EXPECT_STREQ("{}", channel->GetServiceConfigJSON().c_str());
- }
- TEST_F(ServiceConfigEnd2endTest,
- AnotherInvalidServiceConfigAfterInvalidServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannel();
- auto stub = BuildStub(channel);
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- }
- TEST_F(ServiceConfigEnd2endTest, InvalidDefaultServiceConfigTest) {
- StartServers(1);
- auto channel = BuildChannelWithInvalidDefaultServiceConfig();
- auto stub = BuildStub(channel);
- // An invalid default service config results in a lame channel which fails all
- // RPCs
- CheckRpcSendFailure(stub);
- }
- TEST_F(ServiceConfigEnd2endTest,
- InvalidDefaultServiceConfigTestWithValidServiceConfig) {
- StartServers(1);
- auto channel = BuildChannelWithInvalidDefaultServiceConfig();
- auto stub = BuildStub(channel);
- CheckRpcSendFailure(stub);
- // An invalid default service config results in a lame channel which fails all
- // RPCs
- SetNextResolutionValidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- }
- TEST_F(ServiceConfigEnd2endTest,
- InvalidDefaultServiceConfigTestWithInvalidServiceConfig) {
- StartServers(1);
- auto channel = BuildChannelWithInvalidDefaultServiceConfig();
- auto stub = BuildStub(channel);
- CheckRpcSendFailure(stub);
- // An invalid default service config results in a lame channel which fails all
- // RPCs
- SetNextResolutionInvalidServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- }
- TEST_F(ServiceConfigEnd2endTest,
- InvalidDefaultServiceConfigTestWithNoServiceConfig) {
- StartServers(1);
- auto channel = BuildChannelWithInvalidDefaultServiceConfig();
- auto stub = BuildStub(channel);
- CheckRpcSendFailure(stub);
- // An invalid default service config results in a lame channel which fails all
- // RPCs
- SetNextResolutionNoServiceConfig(GetServersPorts());
- CheckRpcSendFailure(stub);
- }
- } // namespace
- } // namespace testing
- } // namespace grpc
- int main(int argc, char** argv) {
- ::testing::InitGoogleTest(&argc, argv);
- grpc::testing::TestEnvironment env(argc, argv);
- const auto result = RUN_ALL_TESTS();
- return result;
- }
|