Re-enable allmost all base tests.

BUG=3836
R=marpan@google.com

Review URL: https://webrtc-codereview.appspot.com/22989004

git-svn-id: http://webrtc.googlecode.com/svn/trunk@7416 4adac7df-926f-26a2-2b94-8c16560cd09d
This commit is contained in:
henrike@webrtc.org
2014-10-09 22:08:15 +00:00
parent 4a73519690
commit c732a3e511
19 changed files with 120 additions and 120 deletions

View File

@@ -127,7 +127,7 @@ class AsyncHttpRequestTest : public testing::Test,
TestHttpServer server_;
};
TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestGetSuccess)) {
TEST_F(AsyncHttpRequestTest, TestGetSuccess) {
AsyncHttpRequest* req = CreateGetRequest(
kServerHostnameAddr.hostname(), server().address().port(),
kServerGetPath);
@@ -144,7 +144,7 @@ TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestGetSuccess)) {
req->Release();
}
TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestGetNotFound)) {
TEST_F(AsyncHttpRequestTest, TestGetNotFound) {
AsyncHttpRequest* req = CreateGetRequest(
kServerHostnameAddr.hostname(), server().address().port(),
"/bad");
@@ -158,7 +158,7 @@ TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestGetNotFound)) {
req->Release();
}
TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestGetToNonServer)) {
TEST_F(AsyncHttpRequestTest, TestGetToNonServer) {
AsyncHttpRequest* req = CreateGetRequest(
"127.0.0.1", server().address().port(),
kServerGetPath);
@@ -188,7 +188,7 @@ TEST_F(AsyncHttpRequestTest, DISABLED_TestGetToInvalidHostname) {
req->Release();
}
TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestPostSuccess)) {
TEST_F(AsyncHttpRequestTest, TestPostSuccess) {
AsyncHttpRequest* req = CreatePostRequest(
kServerHostnameAddr.hostname(), server().address().port(),
kServerPostPath, "text/plain", new MemoryStream("abcd1234"));
@@ -204,7 +204,7 @@ TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestPostSuccess)) {
}
// Ensure that we shut down properly even if work is outstanding.
TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestCancel)) {
TEST_F(AsyncHttpRequestTest, TestCancel) {
AsyncHttpRequest* req = CreateGetRequest(
kServerHostnameAddr.hostname(), server().address().port(),
kServerGetPath);
@@ -212,7 +212,7 @@ TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestCancel)) {
req->Destroy(true);
}
TEST_F(AsyncHttpRequestTest, DISABLED_ON_MAC(TestGetSuccessDelay)) {
TEST_F(AsyncHttpRequestTest, TestGetSuccessDelay) {
AsyncHttpRequest* req = CreateGetRequest(
kServerHostnameAddr.hostname(), server().address().port(),
kServerGetPath);

View File

@@ -100,26 +100,26 @@ class AutoDetectProxyTest : public testing::Test, public sigslot::has_slots<> {
bool done_;
};
TEST_F(AutoDetectProxyTest, DISABLED_ON_MAC(TestDetectUnresolvedProxy)) {
TEST_F(AutoDetectProxyTest, TestDetectUnresolvedProxy) {
TestCopesWithProxy(rtc::SocketAddress("localhost", 9999));
}
TEST_F(AutoDetectProxyTest, DISABLED_ON_MAC(TestDetectUnresolvableProxy)) {
TEST_F(AutoDetectProxyTest, TestDetectUnresolvableProxy) {
TestCopesWithProxy(rtc::SocketAddress("invalid", 9999));
}
TEST_F(AutoDetectProxyTest, DISABLED_ON_MAC(TestDetectIPv6Proxy)) {
TEST_F(AutoDetectProxyTest, TestDetectIPv6Proxy) {
TestCopesWithProxy(rtc::SocketAddress("::1", 9999));
}
TEST_F(AutoDetectProxyTest, DISABLED_ON_MAC(TestDetectIPv4Proxy)) {
TEST_F(AutoDetectProxyTest, TestDetectIPv4Proxy) {
TestCopesWithProxy(rtc::SocketAddress("127.0.0.1", 9999));
}
// Test that proxy detection completes successfully. (Does not actually verify
// the correct detection result since we don't know what proxy to expect on an
// arbitrary machine.)
TEST_F(AutoDetectProxyTest, DISABLED_ON_MAC(TestProxyDetection)) {
TEST_F(AutoDetectProxyTest, TestProxyDetection) {
ASSERT_TRUE(Create(kUserAgent,
kPath,
kHost,

View File

@@ -338,7 +338,7 @@ TEST(CpuMonitorTest, TestGetSystemLoadForceFallback) {
#endif
// Tests both process and system functions in use at same time.
TEST(CpuMonitorTest, DISABLED_ON_MAC(TestGetBothLoad)) {
TEST(CpuMonitorTest, TestGetBothLoad) {
TestCpuSampler(true, true, false);
}

View File

@@ -120,7 +120,7 @@ TEST(AtomicOpsTest, Simple) {
EXPECT_EQ(0, value);
}
TEST(AtomicOpsTest, DISABLED_ON_MAC(Increment)) {
TEST(AtomicOpsTest, Increment) {
// Create and start lots of threads.
AtomicOpRunner<IncrementOp> runner(0);
ScopedPtrCollection<Thread> threads;
@@ -132,7 +132,7 @@ TEST(AtomicOpsTest, DISABLED_ON_MAC(Increment)) {
EXPECT_EQ(kOperationsToRun * kNumThreads, runner.value());
}
TEST(AtomicOpsTest, DISABLED_ON_MAC(Decrement)) {
TEST(AtomicOpsTest, Decrement) {
// Create and start lots of threads.
AtomicOpRunner<DecrementOp> runner(kOperationsToRun * kNumThreads);
ScopedPtrCollection<Thread> threads;

View File

@@ -77,7 +77,7 @@ TEST_F(FileLockTest, TestLockX2) {
EXPECT_TRUE(lock2.get() == NULL);
}
TEST_F(FileLockTest, DISABLED_ON_MAC(TestThreadedLock)) {
TEST_F(FileLockTest, TestThreadedLock) {
scoped_ptr<FileLock> lock(FileLock::TryLock(temp_file_.pathname()));
EXPECT_TRUE(lock.get() != NULL);

View File

@@ -83,7 +83,7 @@ class LogThread : public Thread {
}
};
TEST(LogTest, DISABLED_ON_MAC(MultipleThreads)) {
TEST(LogTest, MultipleThreads) {
int sev = LogMessage::GetLogToStream(NULL);
LogThread thread1, thread2, thread3;

View File

@@ -33,7 +33,7 @@ class WakeThread : public Thread {
#ifndef CARBON_DEPRECATED
// Test that MacCFSocketServer::Wait works as expected.
TEST(MacCFSocketServerTest, DISABLED_TestWait) {
TEST(MacCFSocketServerTest, TestWait) {
MacCFSocketServer server;
uint32 start = Time();
server.Wait(1000, true);
@@ -41,7 +41,7 @@ TEST(MacCFSocketServerTest, DISABLED_TestWait) {
}
// Test that MacCFSocketServer::Wakeup works as expected.
TEST(MacCFSocketServerTest, DISABLED_TestWakeup) {
TEST(MacCFSocketServerTest, TestWakeup) {
MacCFSocketServer server;
WakeThread thread(&server);
uint32 start = Time();
@@ -51,7 +51,7 @@ TEST(MacCFSocketServerTest, DISABLED_TestWakeup) {
}
// Test that MacCarbonSocketServer::Wait works as expected.
TEST(MacCarbonSocketServerTest, DISABLED_TestWait) {
TEST(MacCarbonSocketServerTest, TestWait) {
MacCarbonSocketServer server;
uint32 start = Time();
server.Wait(1000, true);
@@ -59,7 +59,7 @@ TEST(MacCarbonSocketServerTest, DISABLED_TestWait) {
}
// Test that MacCarbonSocketServer::Wakeup works as expected.
TEST(MacCarbonSocketServerTest, DISABLED_TestWakeup) {
TEST(MacCarbonSocketServerTest, TestWakeup) {
MacCarbonSocketServer server;
WakeThread thread(&server);
uint32 start = Time();
@@ -69,7 +69,7 @@ TEST(MacCarbonSocketServerTest, DISABLED_TestWakeup) {
}
// Test that MacCarbonAppSocketServer::Wait works as expected.
TEST(MacCarbonAppSocketServerTest, DISABLED_TestWait) {
TEST(MacCarbonAppSocketServerTest, TestWait) {
MacCarbonAppSocketServer server;
uint32 start = Time();
server.Wait(1000, true);
@@ -77,7 +77,7 @@ TEST(MacCarbonAppSocketServerTest, DISABLED_TestWait) {
}
// Test that MacCarbonAppSocketServer::Wakeup works as expected.
TEST(MacCarbonAppSocketServerTest, DISABLED_TestWakeup) {
TEST(MacCarbonAppSocketServerTest, TestWakeup) {
MacCarbonAppSocketServer server;
WakeThread thread(&server);
uint32 start = Time();
@@ -102,19 +102,19 @@ class MacAsyncSocketTest : public SocketTest {
SocketServerScope scope_;
};
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectIPv4) {
TEST_F(MacAsyncSocketTest, TestConnectIPv4) {
SocketTest::TestConnectIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectIPv6) {
TEST_F(MacAsyncSocketTest, TestConnectIPv6) {
SocketTest::TestConnectIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectWithDnsLookupIPv4) {
TEST_F(MacAsyncSocketTest, TestConnectWithDnsLookupIPv4) {
SocketTest::TestConnectWithDnsLookupIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectWithDnsLookupIPv6) {
TEST_F(MacAsyncSocketTest, TestConnectWithDnsLookupIPv6) {
SocketTest::TestConnectWithDnsLookupIPv6();
}
@@ -123,7 +123,7 @@ TEST_F(MacAsyncSocketTest, DISABLED_TestConnectFailIPv4) {
SocketTest::TestConnectFailIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectFailIPv6) {
TEST_F(MacAsyncSocketTest, TestConnectFailIPv6) {
SocketTest::TestConnectFailIPv6();
}
@@ -136,11 +136,11 @@ TEST_F(MacAsyncSocketTest, DISABLED_TestConnectWithDnsLookupFailIPv6) {
SocketTest::TestConnectWithDnsLookupFailIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectWithClosedSocketIPv4) {
TEST_F(MacAsyncSocketTest, TestConnectWithClosedSocketIPv4) {
SocketTest::TestConnectWithClosedSocketIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestConnectWithClosedSocketIPv6) {
TEST_F(MacAsyncSocketTest, TestConnectWithClosedSocketIPv6) {
SocketTest::TestConnectWithClosedSocketIPv6();
}
@@ -155,51 +155,51 @@ TEST_F(MacAsyncSocketTest, DISABLED_TestServerCloseDuringConnectIPv6) {
}
// Flaky at the moment (0.5% failure rate). Seems the client doesn't get
// signalled in a timely manner...
TEST_F(MacAsyncSocketTest, DISABLED_TestClientCloseDuringConnectIPv4) {
TEST_F(MacAsyncSocketTest, TestClientCloseDuringConnectIPv4) {
SocketTest::TestClientCloseDuringConnectIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestClientCloseDuringConnectIPv6) {
TEST_F(MacAsyncSocketTest, TestClientCloseDuringConnectIPv6) {
SocketTest::TestClientCloseDuringConnectIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestServerCloseIPv4) {
TEST_F(MacAsyncSocketTest, TestServerCloseIPv4) {
SocketTest::TestServerCloseIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestServerCloseIPv6) {
TEST_F(MacAsyncSocketTest, TestServerCloseIPv6) {
SocketTest::TestServerCloseIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestCloseInClosedCallbackIPv4) {
TEST_F(MacAsyncSocketTest, TestCloseInClosedCallbackIPv4) {
SocketTest::TestCloseInClosedCallbackIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestCloseInClosedCallbackIPv6) {
TEST_F(MacAsyncSocketTest, TestCloseInClosedCallbackIPv6) {
SocketTest::TestCloseInClosedCallbackIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestSocketServerWaitIPv4) {
TEST_F(MacAsyncSocketTest, TestSocketServerWaitIPv4) {
SocketTest::TestSocketServerWaitIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestSocketServerWaitIPv6) {
TEST_F(MacAsyncSocketTest, TestSocketServerWaitIPv6) {
SocketTest::TestSocketServerWaitIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestTcpIPv4) {
TEST_F(MacAsyncSocketTest, TestTcpIPv4) {
SocketTest::TestTcpIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestTcpIPv6) {
TEST_F(MacAsyncSocketTest, TestTcpIPv6) {
SocketTest::TestTcpIPv6();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestSingleFlowControlCallbackIPv4) {
TEST_F(MacAsyncSocketTest, TestSingleFlowControlCallbackIPv4) {
SocketTest::TestSingleFlowControlCallbackIPv4();
}
TEST_F(MacAsyncSocketTest, DISABLED_TestSingleFlowControlCallbackIPv6) {
TEST_F(MacAsyncSocketTest, TestSingleFlowControlCallbackIPv6) {
SocketTest::TestSingleFlowControlCallbackIPv6();
}
@@ -226,11 +226,11 @@ class MacCarbonAppAsyncSocketTest : public MacAsyncSocketTest {
};
};
TEST_F(MacCarbonAppAsyncSocketTest, DISABLED_TestSocketServerWaitIPv4) {
TEST_F(MacCarbonAppAsyncSocketTest, TestSocketServerWaitIPv4) {
SocketTest::TestSocketServerWaitIPv4();
}
TEST_F(MacCarbonAppAsyncSocketTest, DISABLED_TestSocketServerWaitIPv6) {
TEST_F(MacCarbonAppAsyncSocketTest, TestSocketServerWaitIPv6) {
SocketTest::TestSocketServerWaitIPv6();
}
#endif

View File

@@ -80,7 +80,7 @@ TEST_F(MessageQueueTest,
DelayedPostsWithIdenticalTimesAreProcessedInFifoOrder(&q_nullss);
}
TEST_F(MessageQueueTest, DISABLED_ON_MAC(DisposeNotLocked)) {
TEST_F(MessageQueueTest, DisposeNotLocked) {
bool was_locked = true;
bool deleted = false;
DeletedLockChecker* d = new DeletedLockChecker(this, &was_locked, &deleted);

View File

@@ -237,11 +237,11 @@ void TestPhysicalInternal(const SocketAddress& int_addr) {
TestFilters(int_pss.get(), int_addr, ext_pss.get(), ext_addrs);
}
TEST(NatTest, DISABLED_ON_MAC(TestPhysicalIPv4)) {
TEST(NatTest, TestPhysicalIPv4) {
TestPhysicalInternal(SocketAddress("127.0.0.1", 0));
}
TEST(NatTest, DISABLED_ON_MAC(TestPhysicalIPv6)) {
TEST(NatTest, TestPhysicalIPv6) {
if (HasIPv6Enabled()) {
TestPhysicalInternal(SocketAddress("::1", 0));
} else {
@@ -279,11 +279,11 @@ void TestVirtualInternal(int family) {
TestFilters(int_vss.get(), int_addr, ext_vss.get(), ext_addrs);
}
TEST(NatTest, DISABLED_ON_MAC(TestVirtualIPv4)) {
TEST(NatTest, TestVirtualIPv4) {
TestVirtualInternal(AF_INET);
}
TEST(NatTest, DISABLED_ON_MAC(TestVirtualIPv6)) {
TEST(NatTest, TestVirtualIPv6) {
if (HasIPv6Enabled()) {
TestVirtualInternal(AF_INET6);
} else {

View File

@@ -28,7 +28,7 @@ class NullSocketServerTest
NullSocketServer ss_;
};
TEST_F(NullSocketServerTest, DISABLED_ON_MAC(WaitAndSet)) {
TEST_F(NullSocketServerTest, WaitAndSet) {
Thread thread;
EXPECT_TRUE(thread.Start());
thread.Post(this, 0);

View File

@@ -107,11 +107,11 @@ TEST_F(PhysicalSocketTest, TestCloseInClosedCallbackIPv6) {
SocketTest::TestCloseInClosedCallbackIPv6();
}
TEST_F(PhysicalSocketTest, DISABLED_ON_MAC(TestSocketServerWaitIPv4)) {
TEST_F(PhysicalSocketTest, TestSocketServerWaitIPv4) {
SocketTest::TestSocketServerWaitIPv4();
}
TEST_F(PhysicalSocketTest, DISABLED_ON_MAC(TestSocketServerWaitIPv6)) {
TEST_F(PhysicalSocketTest, TestSocketServerWaitIPv6) {
SocketTest::TestSocketServerWaitIPv6();
}
@@ -141,7 +141,7 @@ TEST_F(PhysicalSocketTest, TestUdpReadyToSendIPv4) {
#endif // if !defined(THREAD_SANITIZER)
TEST_F(PhysicalSocketTest, DISABLED_ON_WIN(TestUdpReadyToSendIPv6)) {
TEST_F(PhysicalSocketTest, TestUdpReadyToSendIPv6) {
SocketTest::TestUdpReadyToSendIPv6();
}
@@ -207,7 +207,7 @@ Thread *PosixSignalDeliveryTest::signaled_thread_ = NULL;
// Test receiving a synchronous signal while not in Wait() and then entering
// Wait() afterwards.
TEST_F(PosixSignalDeliveryTest, DISABLED_ON_MAC(RaiseThenWait)) {
TEST_F(PosixSignalDeliveryTest, RaiseThenWait) {
ASSERT_TRUE(ss_->SetPosixSignalHandler(SIGTERM, &RecordSignal));
raise(SIGTERM);
EXPECT_TRUE(ss_->Wait(0, true));
@@ -217,7 +217,7 @@ TEST_F(PosixSignalDeliveryTest, DISABLED_ON_MAC(RaiseThenWait)) {
// Test that we can handle getting tons of repeated signals and that we see all
// the different ones.
TEST_F(PosixSignalDeliveryTest, DISABLED_ON_MAC(InsanelyManySignals)) {
TEST_F(PosixSignalDeliveryTest, InsanelyManySignals) {
ss_->SetPosixSignalHandler(SIGTERM, &RecordSignal);
ss_->SetPosixSignalHandler(SIGINT, &RecordSignal);
for (int i = 0; i < 10000; ++i) {
@@ -232,7 +232,7 @@ TEST_F(PosixSignalDeliveryTest, DISABLED_ON_MAC(InsanelyManySignals)) {
}
// Test that a signal during a Wait() call is detected.
TEST_F(PosixSignalDeliveryTest, DISABLED_ON_MAC(SignalDuringWait)) {
TEST_F(PosixSignalDeliveryTest, SignalDuringWait) {
ss_->SetPosixSignalHandler(SIGALRM, &RecordSignal);
alarm(1);
EXPECT_TRUE(ss_->Wait(1500, true));
@@ -257,7 +257,7 @@ class RaiseSigTermRunnable : public Runnable {
// Test that it works no matter what thread the kernel chooses to give the
// signal to (since it's not guaranteed to be the one that Wait() runs on).
TEST_F(PosixSignalDeliveryTest, DISABLED_ON_MAC(SignalOnDifferentThread)) {
TEST_F(PosixSignalDeliveryTest, SignalOnDifferentThread) {
ss_->SetPosixSignalHandler(SIGTERM, &RecordSignal);
// Mask out SIGTERM so that it can't be delivered to this thread.
sigset_t mask;

View File

@@ -75,7 +75,7 @@ class ProxyTest : public testing::Test {
};
// Tests whether we can use a SOCKS5 proxy to connect to a server.
TEST_F(ProxyTest, DISABLED_ON_MAC(TestSocks5Connect)) {
TEST_F(ProxyTest, TestSocks5Connect) {
rtc::AsyncSocket* socket =
ss()->CreateAsyncSocket(kSocksProxyIntAddr.family(), SOCK_STREAM);
rtc::AsyncSocksProxySocket* proxy_socket =
@@ -119,7 +119,7 @@ TEST_F(ProxyTest, TestHttpsConnect) {
*/
// Tests whether we can autodetect a SOCKS5 proxy.
TEST_F(ProxyTest, DISABLED_ON_MAC(TestAutoDetectSocks5)) {
TEST_F(ProxyTest, TestAutoDetectSocks5) {
EXPECT_EQ(rtc::PROXY_SOCKS5, DetectProxyType(kSocksProxyIntAddr));
}
@@ -131,6 +131,6 @@ TEST_F(ProxyTest, TestAutoDetectHttps) {
*/
// Tests whether we fail properly for no proxy.
TEST_F(ProxyTest, DISABLED_ON_MAC(TestAutoDetectBogus)) {
TEST_F(ProxyTest, TestAutoDetectBogus) {
EXPECT_EQ(rtc::PROXY_UNKNOWN, DetectProxyType(kBogusProxyIntAddr));
}

View File

@@ -133,7 +133,7 @@ class SharedExclusiveLockTest
};
// Flaky: https://code.google.com/p/webrtc/issues/detail?id=3318
TEST_F(SharedExclusiveLockTest, DISABLED_TestSharedShared) {
TEST_F(SharedExclusiveLockTest, TestSharedShared) {
int value0, value1;
bool done0, done1;
ReadTask reader0(shared_exclusive_lock_.get(), &value_, &done0);
@@ -158,7 +158,7 @@ TEST_F(SharedExclusiveLockTest, DISABLED_TestSharedShared) {
EXPECT_LE(reader1.waiting_time_in_ms(), kNoWaitThresholdInMs);
}
TEST_F(SharedExclusiveLockTest, DISABLED_ON_MAC(TestSharedExclusive)) {
TEST_F(SharedExclusiveLockTest, TestSharedExclusive) {
bool done;
WriteTask writer(shared_exclusive_lock_.get(), &value_, &done);
@@ -177,7 +177,7 @@ TEST_F(SharedExclusiveLockTest, DISABLED_ON_MAC(TestSharedExclusive)) {
EXPECT_GE(writer.waiting_time_in_ms(), kWaitThresholdInMs);
}
TEST_F(SharedExclusiveLockTest, DISABLED_ON_MAC(TestExclusiveShared)) {
TEST_F(SharedExclusiveLockTest, TestExclusiveShared) {
int value;
bool done;
ReadTask reader(shared_exclusive_lock_.get(), &value_, &done);
@@ -197,7 +197,7 @@ TEST_F(SharedExclusiveLockTest, DISABLED_ON_MAC(TestExclusiveShared)) {
EXPECT_GE(reader.waiting_time_in_ms(), kWaitThresholdInMs);
}
TEST_F(SharedExclusiveLockTest, DISABLED_ON_MAC(TestExclusiveExclusive)) {
TEST_F(SharedExclusiveLockTest, TestExclusiveExclusive) {
bool done;
WriteTask writer(shared_exclusive_lock_.get(), &value_, &done);

View File

@@ -134,7 +134,7 @@ class OwnerThread : public Thread, public sigslot::has_slots<> {
// Test for when the main thread goes away while the
// signal thread is still working. This may happen
// when shutting down the process.
TEST_F(SignalThreadTest, DISABLED_ON_MAC(OwnerThreadGoesAway)) {
TEST_F(SignalThreadTest, OwnerThreadGoesAway) {
{
scoped_ptr<OwnerThread> owner(new OwnerThread(this));
main_thread_ = owner.get();
@@ -157,7 +157,7 @@ TEST_F(SignalThreadTest, DISABLED_ON_MAC(OwnerThreadGoesAway)) {
EXPECT_EQ(stopped, thread_stopped_); \
EXPECT_EQ(deleted, thread_deleted_);
TEST_F(SignalThreadTest, DISABLED_ON_MAC(ThreadFinishes)) {
TEST_F(SignalThreadTest, ThreadFinishes) {
thread_->Start();
EXPECT_STATE(1, 0, 0, 0, 0);
Thread::SleepMs(500);
@@ -166,7 +166,7 @@ TEST_F(SignalThreadTest, DISABLED_ON_MAC(ThreadFinishes)) {
EXPECT_STATE(1, 1, 1, 0, 1);
}
TEST_F(SignalThreadTest, DISABLED_ON_MAC(ReleasedThreadFinishes)) {
TEST_F(SignalThreadTest, ReleasedThreadFinishes) {
thread_->Start();
EXPECT_STATE(1, 0, 0, 0, 0);
thread_->Release();
@@ -178,7 +178,7 @@ TEST_F(SignalThreadTest, DISABLED_ON_MAC(ReleasedThreadFinishes)) {
EXPECT_STATE(1, 1, 1, 0, 1);
}
TEST_F(SignalThreadTest, DISABLED_ON_MAC(DestroyedThreadCleansUp)) {
TEST_F(SignalThreadTest, DestroyedThreadCleansUp) {
thread_->Start();
EXPECT_STATE(1, 0, 0, 0, 0);
thread_->Destroy(true);
@@ -187,7 +187,7 @@ TEST_F(SignalThreadTest, DISABLED_ON_MAC(DestroyedThreadCleansUp)) {
EXPECT_STATE(1, 0, 0, 1, 1);
}
TEST_F(SignalThreadTest, DISABLED_ON_MAC(DeferredDestroyedThreadCleansUp)) {
TEST_F(SignalThreadTest, DeferredDestroyedThreadCleansUp) {
thread_->Start();
EXPECT_STATE(1, 0, 0, 0, 0);
thread_->Destroy(false);

View File

@@ -289,7 +289,7 @@ class TaskTest : public sigslot::has_slots<> {
TaskInfo happy_[HAPPY_TASK_COUNT];
};
TEST(start_task_test, DISABLED_ON_MAC(Timeout)) {
TEST(start_task_test, Timeout) {
TaskTest task_test;
task_test.Start();
task_test.check_passed();
@@ -336,7 +336,7 @@ class TaskAbortTest : public sigslot::has_slots<> {
DISALLOW_EVIL_CONSTRUCTORS(TaskAbortTest);
};
TEST(start_task_test, DISABLED_ON_MAC(Abort)) {
TEST(start_task_test, Abort) {
TaskAbortTest abort_test;
abort_test.Start();
}
@@ -399,7 +399,7 @@ class AbortShouldWakeTest : public sigslot::has_slots<> {
DISALLOW_EVIL_CONSTRUCTORS(AbortShouldWakeTest);
};
TEST(start_task_test, DISABLED_ON_MAC(AbortShouldWake)) {
TEST(start_task_test, AbortShouldWake) {
AbortShouldWakeTest abort_should_wake_test;
abort_should_wake_test.Start();
}
@@ -480,7 +480,7 @@ class TimeoutChangeTest : public sigslot::has_slots<> {
DISALLOW_EVIL_CONSTRUCTORS(TimeoutChangeTest);
};
TEST(start_task_test, DISABLED_ON_MAC(TimeoutChange)) {
TEST(start_task_test, TimeoutChange) {
TimeoutChangeTest timeout_change_test;
timeout_change_test.Start();
}
@@ -497,7 +497,7 @@ class DeleteTestTaskRunner : public TaskRunner {
DISALLOW_EVIL_CONSTRUCTORS(DeleteTestTaskRunner);
};
TEST(unstarted_task_test, DISABLED_ON_MAC(DeleteTask)) {
TEST(unstarted_task_test, DeleteTask) {
// This test ensures that we don't
// crash if a task is deleted without running it.
DeleteTestTaskRunner task_runner;
@@ -512,7 +512,7 @@ TEST(unstarted_task_test, DISABLED_ON_MAC(DeleteTask)) {
task_runner.RunTasks();
}
TEST(unstarted_task_test, DISABLED_ON_MAC(DoNotDeleteTask1)) {
TEST(unstarted_task_test, DoNotDeleteTask1) {
// This test ensures that we don't
// crash if a task runner is deleted without
// running a certain task.
@@ -526,7 +526,7 @@ TEST(unstarted_task_test, DISABLED_ON_MAC(DoNotDeleteTask1)) {
// Never run the tasks
}
TEST(unstarted_task_test, DISABLED_ON_MAC(DoNotDeleteTask2)) {
TEST(unstarted_task_test, DoNotDeleteTask2) {
// This test ensures that we don't
// crash if a taskrunner is delete with a
// task that has never been started.

View File

@@ -52,11 +52,11 @@ void TestTcpInternal(const SocketAddress& loopback) {
}
// Tests whether the TestClient can send UDP to itself.
TEST(TestClientTest, DISABLED_ON_MAC(TestUdpIPv4)) {
TEST(TestClientTest, TestUdpIPv4) {
TestUdpInternal(SocketAddress("127.0.0.1", 0));
}
TEST(TestClientTest, DISABLED_ON_MAC(TestUdpIPv6)) {
TEST(TestClientTest, TestUdpIPv6) {
if (HasIPv6Enabled()) {
TestUdpInternal(SocketAddress("::1", 0));
} else {
@@ -65,11 +65,11 @@ TEST(TestClientTest, DISABLED_ON_MAC(TestUdpIPv6)) {
}
// Tests whether the TestClient can connect to a server and exchange data.
TEST(TestClientTest, DISABLED_ON_MAC(TestTcpIPv4)) {
TEST(TestClientTest, TestTcpIPv4) {
TestTcpInternal(SocketAddress("127.0.0.1", 0));
}
TEST(TestClientTest, DISABLED_ON_MAC(TestTcpIPv6)) {
TEST(TestClientTest, TestTcpIPv6) {
if (HasIPv6Enabled()) {
TestTcpInternal(SocketAddress("::1", 0));
} else {

View File

@@ -105,7 +105,7 @@ class DeleteThreadCheckerClassOnThread : public Thread {
} // namespace
TEST(ThreadCheckerTest, DISABLED_ON_MAC(CallsAllowedOnSameThread)) {
TEST(ThreadCheckerTest, CallsAllowedOnSameThread) {
scoped_ptr<ThreadCheckerClass> thread_checker_class(
new ThreadCheckerClass);
@@ -116,7 +116,7 @@ TEST(ThreadCheckerTest, DISABLED_ON_MAC(CallsAllowedOnSameThread)) {
thread_checker_class.reset();
}
TEST(ThreadCheckerTest, DISABLED_ON_MAC(DestructorAllowedOnDifferentThread)) {
TEST(ThreadCheckerTest, DestructorAllowedOnDifferentThread) {
scoped_ptr<ThreadCheckerClass> thread_checker_class(
new ThreadCheckerClass);
@@ -129,7 +129,7 @@ TEST(ThreadCheckerTest, DISABLED_ON_MAC(DestructorAllowedOnDifferentThread)) {
delete_on_thread.Join();
}
TEST(ThreadCheckerTest, DISABLED_ON_MAC(DetachFromThread)) {
TEST(ThreadCheckerTest, DetachFromThread) {
scoped_ptr<ThreadCheckerClass> thread_checker_class(
new ThreadCheckerClass);

View File

@@ -199,7 +199,7 @@ TEST(ThreadTest, DISABLED_Main) {
// Test that setting thread names doesn't cause a malfunction.
// There's no easy way to verify the name was set properly at this time.
TEST(ThreadTest, DISABLED_ON_MAC(Names)) {
TEST(ThreadTest, Names) {
// Default name
Thread *thread;
thread = new Thread();
@@ -222,7 +222,7 @@ TEST(ThreadTest, DISABLED_ON_MAC(Names)) {
// Test that setting thread priorities doesn't cause a malfunction.
// There's no easy way to verify the priority was set properly at this time.
TEST(ThreadTest, DISABLED_ON_MAC(Priorities)) {
TEST(ThreadTest, Priorities) {
Thread *thread;
thread = new Thread();
EXPECT_TRUE(thread->SetPriority(PRIORITY_HIGH));
@@ -260,7 +260,7 @@ TEST(ThreadTest, Wrap) {
current_thread->WrapCurrent();
}
TEST(ThreadTest, DISABLED_ON_MAC(Invoke)) {
TEST(ThreadTest, Invoke) {
// Create and start the thread.
Thread thread;
thread.Start();
@@ -391,7 +391,7 @@ TEST_F(AsyncInvokeTest, FireAndForget) {
EXPECT_TRUE_WAIT(called, kWaitTimeout);
}
TEST_F(AsyncInvokeTest, DISABLED_WithCallback) {
TEST_F(AsyncInvokeTest, WithCallback) {
AsyncInvoker invoker;
// Create and start the thread.
Thread thread;
@@ -404,7 +404,7 @@ TEST_F(AsyncInvokeTest, DISABLED_WithCallback) {
EXPECT_EQ_WAIT(42, int_value_, kWaitTimeout);
}
TEST_F(AsyncInvokeTest, DISABLED_CancelInvoker) {
TEST_F(AsyncInvokeTest, CancelInvoker) {
// Create and start the thread.
Thread thread;
thread.Start();
@@ -420,7 +420,7 @@ TEST_F(AsyncInvokeTest, DISABLED_CancelInvoker) {
EXPECT_EQ(0, int_value_);
}
TEST_F(AsyncInvokeTest, DISABLED_CancelCallingThread) {
TEST_F(AsyncInvokeTest, CancelCallingThread) {
AsyncInvoker invoker;
{ // Create and start the thread.
Thread thread;
@@ -437,7 +437,7 @@ TEST_F(AsyncInvokeTest, DISABLED_CancelCallingThread) {
EXPECT_EQ(0, int_value_);
}
TEST_F(AsyncInvokeTest, DISABLED_KillInvokerBeforeExecute) {
TEST_F(AsyncInvokeTest, KillInvokerBeforeExecute) {
Thread thread;
thread.Start();
{
@@ -454,7 +454,7 @@ TEST_F(AsyncInvokeTest, DISABLED_KillInvokerBeforeExecute) {
EXPECT_EQ(0, int_value_);
}
TEST_F(AsyncInvokeTest, DISABLED_Flush) {
TEST_F(AsyncInvokeTest, Flush) {
AsyncInvoker invoker;
bool flag1 = false;
bool flag2 = false;
@@ -472,7 +472,7 @@ TEST_F(AsyncInvokeTest, DISABLED_Flush) {
EXPECT_TRUE(flag2);
}
TEST_F(AsyncInvokeTest, DISABLED_FlushWithIds) {
TEST_F(AsyncInvokeTest, FlushWithIds) {
AsyncInvoker invoker;
bool flag1 = false;
bool flag2 = false;

View File

@@ -776,37 +776,37 @@ class VirtualSocketServerTest : public testing::Test {
const SocketAddress kIPv6AnyAddress;
};
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(basic_v4)) {
TEST_F(VirtualSocketServerTest, basic_v4) {
SocketAddress ipv4_test_addr(IPAddress(INADDR_ANY), 5000);
BasicTest(ipv4_test_addr);
}
TEST_F(VirtualSocketServerTest,DISABLED_ON_MAC( basic_v6)) {
TEST_F(VirtualSocketServerTest, basic_v6) {
SocketAddress ipv6_test_addr(IPAddress(in6addr_any), 5000);
BasicTest(ipv6_test_addr);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(connect_v4)) {
TEST_F(VirtualSocketServerTest, connect_v4) {
ConnectTest(kIPv4AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(connect_v6)) {
TEST_F(VirtualSocketServerTest, connect_v6) {
ConnectTest(kIPv6AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(connect_to_non_listener_v4)) {
TEST_F(VirtualSocketServerTest, connect_to_non_listener_v4) {
ConnectToNonListenerTest(kIPv4AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(connect_to_non_listener_v6)) {
TEST_F(VirtualSocketServerTest, connect_to_non_listener_v6) {
ConnectToNonListenerTest(kIPv6AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(close_during_connect_v4)) {
TEST_F(VirtualSocketServerTest, close_during_connect_v4) {
CloseDuringConnectTest(kIPv4AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(close_during_connect_v6)) {
TEST_F(VirtualSocketServerTest, close_during_connect_v6) {
CloseDuringConnectTest(kIPv6AnyAddress);
}
@@ -818,11 +818,11 @@ TEST_F(VirtualSocketServerTest, close_v6) {
CloseTest(kIPv6AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(tcp_send_v4)) {
TEST_F(VirtualSocketServerTest, tcp_send_v4) {
TcpSendTest(kIPv4AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(tcp_send_v6)) {
TEST_F(VirtualSocketServerTest, tcp_send_v6) {
TcpSendTest(kIPv6AnyAddress);
}
@@ -834,17 +834,17 @@ TEST_F(VirtualSocketServerTest, TcpSendsPacketsInOrder_v6) {
TcpSendsPacketsInOrderTest(kIPv6AnyAddress);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(bandwidth_v4)) {
TEST_F(VirtualSocketServerTest, bandwidth_v4) {
SocketAddress ipv4_test_addr(IPAddress(INADDR_ANY), 1000);
BandwidthTest(ipv4_test_addr);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(bandwidth_v6)) {
TEST_F(VirtualSocketServerTest, bandwidth_v6) {
SocketAddress ipv6_test_addr(IPAddress(in6addr_any), 1000);
BandwidthTest(ipv6_test_addr);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(delay_v4)) {
TEST_F(VirtualSocketServerTest, delay_v4) {
SocketAddress ipv4_test_addr(IPAddress(INADDR_ANY), 1000);
DelayTest(ipv4_test_addr);
}
@@ -856,104 +856,104 @@ TEST_F(VirtualSocketServerTest, DISABLED_delay_v6) {
}
// Works, receiving socket sees 127.0.0.2.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanConnectFromMappedIPv6ToIPv4Any)) {
TEST_F(VirtualSocketServerTest, CanConnectFromMappedIPv6ToIPv4Any) {
CrossFamilyConnectionTest(SocketAddress("::ffff:127.0.0.2", 0),
SocketAddress("0.0.0.0", 5000),
true);
}
// Fails.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CantConnectFromUnMappedIPv6ToIPv4Any)) {
TEST_F(VirtualSocketServerTest, CantConnectFromUnMappedIPv6ToIPv4Any) {
CrossFamilyConnectionTest(SocketAddress("::2", 0),
SocketAddress("0.0.0.0", 5000),
false);
}
// Fails.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CantConnectFromUnMappedIPv6ToMappedIPv6)) {
TEST_F(VirtualSocketServerTest, CantConnectFromUnMappedIPv6ToMappedIPv6) {
CrossFamilyConnectionTest(SocketAddress("::2", 0),
SocketAddress("::ffff:127.0.0.1", 5000),
false);
}
// Works. receiving socket sees ::ffff:127.0.0.2.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanConnectFromIPv4ToIPv6Any)) {
TEST_F(VirtualSocketServerTest, CanConnectFromIPv4ToIPv6Any) {
CrossFamilyConnectionTest(SocketAddress("127.0.0.2", 0),
SocketAddress("::", 5000),
true);
}
// Fails.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CantConnectFromIPv4ToUnMappedIPv6)) {
TEST_F(VirtualSocketServerTest, CantConnectFromIPv4ToUnMappedIPv6) {
CrossFamilyConnectionTest(SocketAddress("127.0.0.2", 0),
SocketAddress("::1", 5000),
false);
}
// Works. Receiving socket sees ::ffff:127.0.0.1.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanConnectFromIPv4ToMappedIPv6)) {
TEST_F(VirtualSocketServerTest, CanConnectFromIPv4ToMappedIPv6) {
CrossFamilyConnectionTest(SocketAddress("127.0.0.1", 0),
SocketAddress("::ffff:127.0.0.2", 5000),
true);
}
// Works, receiving socket sees a result from GetNextIP.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanConnectFromUnboundIPv6ToIPv4Any)) {
TEST_F(VirtualSocketServerTest, CanConnectFromUnboundIPv6ToIPv4Any) {
CrossFamilyConnectionTest(SocketAddress("::", 0),
SocketAddress("0.0.0.0", 5000),
true);
}
// Works, receiving socket sees whatever GetNextIP gave the client.
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanConnectFromUnboundIPv4ToIPv6Any)) {
TEST_F(VirtualSocketServerTest, CanConnectFromUnboundIPv4ToIPv6Any) {
CrossFamilyConnectionTest(SocketAddress("0.0.0.0", 0),
SocketAddress("::", 5000),
true);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanSendDatagramFromUnboundIPv4ToIPv6Any)) {
TEST_F(VirtualSocketServerTest, CanSendDatagramFromUnboundIPv4ToIPv6Any) {
CrossFamilyDatagramTest(SocketAddress("0.0.0.0", 0),
SocketAddress("::", 5000),
true);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanSendDatagramFromMappedIPv6ToIPv4Any)) {
TEST_F(VirtualSocketServerTest, CanSendDatagramFromMappedIPv6ToIPv4Any) {
CrossFamilyDatagramTest(SocketAddress("::ffff:127.0.0.1", 0),
SocketAddress("0.0.0.0", 5000),
true);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CantSendDatagramFromUnMappedIPv6ToIPv4Any)) {
TEST_F(VirtualSocketServerTest, CantSendDatagramFromUnMappedIPv6ToIPv4Any) {
CrossFamilyDatagramTest(SocketAddress("::2", 0),
SocketAddress("0.0.0.0", 5000),
false);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CantSendDatagramFromUnMappedIPv6ToMappedIPv6)) {
TEST_F(VirtualSocketServerTest, CantSendDatagramFromUnMappedIPv6ToMappedIPv6) {
CrossFamilyDatagramTest(SocketAddress("::2", 0),
SocketAddress("::ffff:127.0.0.1", 5000),
false);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanSendDatagramFromIPv4ToIPv6Any)) {
TEST_F(VirtualSocketServerTest, CanSendDatagramFromIPv4ToIPv6Any) {
CrossFamilyDatagramTest(SocketAddress("127.0.0.2", 0),
SocketAddress("::", 5000),
true);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CantSendDatagramFromIPv4ToUnMappedIPv6)) {
TEST_F(VirtualSocketServerTest, CantSendDatagramFromIPv4ToUnMappedIPv6) {
CrossFamilyDatagramTest(SocketAddress("127.0.0.2", 0),
SocketAddress("::1", 5000),
false);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanSendDatagramFromIPv4ToMappedIPv6)) {
TEST_F(VirtualSocketServerTest, CanSendDatagramFromIPv4ToMappedIPv6) {
CrossFamilyDatagramTest(SocketAddress("127.0.0.1", 0),
SocketAddress("::ffff:127.0.0.2", 5000),
true);
}
TEST_F(VirtualSocketServerTest, DISABLED_ON_MAC(CanSendDatagramFromUnboundIPv6ToIPv4Any)) {
TEST_F(VirtualSocketServerTest, CanSendDatagramFromUnboundIPv6ToIPv4Any) {
CrossFamilyDatagramTest(SocketAddress("::", 0),
SocketAddress("0.0.0.0", 5000),
true);