Unit Test Results.

Designed for use with JUnit and Ant.

All Failures

ClassNameStatusTypeTime(s)
8_cythonno_x86_64_23_64test_correct_dc_rack_in_nodetool_infoFailureccmlib.common.UnavailableSocketError: Inet address 127.0.0.2:7000 is not available: [Errno 98] Address already in use; a cluster may already be running or you may need to add the loopback alias

itf = ('127.0.0.2', 7000)

def assert_socket_available(itf):
info = socket.getaddrinfo(itf[0], itf[1], socket.AF_UNSPEC, socket.SOCK_STREAM)
if not info:
raise UnavailableSocketError("Failed to get address info for [%s]:%s" % itf)

(family, socktype, proto, canonname, sockaddr) = info[0]
s = socket.socket(family, socktype)
s.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)

try:
> s.bind(sockaddr)
E OSError: [Errno 98] Address already in use

../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/common.py:631: OSError

During handling of the above exception, another exception occurred:

self = <nodetool_test.TestNodetool object at 0x7f6100307e50>

def test_correct_dc_rack_in_nodetool_info(self):
"""
@jira_ticket CASSANDRA-10382

Test that nodetool info returns the correct rack and dc
"""

cluster = self.cluster
cluster.populate([2, 2])
cluster.set_configuration_options(values={'endpoint_snitch': 'org.apache.cassandra.locator.GossipingPropertyFileSnitch'})

for i, node in enumerate(cluster.nodelist()):
with open(os.path.join(node.get_conf_dir(), 'cassandra-rackdc.properties'), 'w') as snitch_file:
for line in ["dc={}".format(node.data_center), "rack=rack{}".format(i % 2)]:
snitch_file.write(line + os.linesep)

> cluster.start()

nodetool_test.py:59:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/cluster.py:515: in start
common.assert_socket_available(itf)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _

itf = ('127.0.0.2', 7000)

def assert_socket_available(itf):
info = socket.getaddrinfo(itf[0], itf[1], socket.AF_UNSPEC, socket.SOCK_STREAM)
if not info:
raise UnavailableSocketError("Failed to get address info for [%s]:%s" % itf)

(family, socktype, proto, canonname, sockaddr) = info[0]
s = socket.socket(family, socktype)
s.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)

try:
s.bind(sockaddr)
s.close()
return True
except socket.error as msg:
s.close()
addr, port = itf
> raise UnavailableSocketError(
"Inet address %s:%s is not available: %s; a cluster may already be running or you may need to add the loopback alias" % (
addr, port, msg))
E ccmlib.common.UnavailableSocketError: Inet address 127.0.0.2:7000 is not available: [Errno 98] Address already in use; a cluster may already be running or you may need to add the loopback alias

../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/common.py:637: UnavailableSocketError
79.107
8_cythonno_x86_64_23_64test_cell_TTL_expiry_during_pagingFailureccmlib.common.UnavailableSocketError: Inet address 127.0.0.2:7000 is not available: [Errno 98] Address already in use; a cluster may already be running or you may need to add the loopback alias

itf = ('127.0.0.2', 7000)

def assert_socket_available(itf):
info = socket.getaddrinfo(itf[0], itf[1], socket.AF_UNSPEC, socket.SOCK_STREAM)
if not info:
raise UnavailableSocketError("Failed to get address info for [%s]:%s" % itf)

(family, socktype, proto, canonname, sockaddr) = info[0]
s = socket.socket(family, socktype)
s.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)

try:
> s.bind(sockaddr)
E OSError: [Errno 98] Address already in use

../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/common.py:631: OSError

During handling of the above exception, another exception occurred:

self = <paging_test.TestPagingDatasetChanges object at 0x7f61002d6a00>

def test_cell_TTL_expiry_during_paging(self):
> session = self.prepare()

paging_test.py:2950:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
paging_test.py:33: in prepare
cluster.populate(3).start()
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/cluster.py:515: in start
common.assert_socket_available(itf)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _

itf = ('127.0.0.2', 7000)

def assert_socket_available(itf):
info = socket.getaddrinfo(itf[0], itf[1], socket.AF_UNSPEC, socket.SOCK_STREAM)
if not info:
raise UnavailableSocketError("Failed to get address info for [%s]:%s" % itf)

(family, socktype, proto, canonname, sockaddr) = info[0]
s = socket.socket(family, socktype)
s.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)

try:
s.bind(sockaddr)
s.close()
return True
except socket.error as msg:
s.close()
addr, port = itf
> raise UnavailableSocketError(
"Inet address %s:%s is not available: %s; a cluster may already be running or you may need to add the loopback alias" % (
addr, port, msg))
E ccmlib.common.UnavailableSocketError: Inet address 127.0.0.2:7000 is not available: [Errno 98] Address already in use; a cluster may already be running or you may need to add the loopback alias

../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/common.py:637: UnavailableSocketError
26.227
8_cythonno_x86_64_35_64test_mv_lock_contention_during_replayFailurecassandra.cluster.NoHostAvailable: ('Unable to connect to any servers', {'127.0.0.1:9042': ConnectionRefusedError(111, "Tried connecting to [('127.0.0.1', 9042)]. Last error: Connection refused")})

self = <commitlog_test.TestCommitLog object at 0x7f829e1e5d60>

@since('3.0.7')
def test_mv_lock_contention_during_replay(self):
"""
Ensure that we don't generate WriteTimeoutExceptions during commitlog
replay due to MV lock contention. Fixed in 3.0.7 and 3.7.
@jira_ticket CASSANDRA-11891
"""
cluster_ver = self.cluster.version()
if LooseVersion('3.1') <= cluster_ver < LooseVersion('3.7'):
pytest.skip("Fixed in 3.0.7 and 3.7")

node1 = self.node1
node1.set_batch_commitlog(enabled=True, use_batch_window = self.cluster.version() < '5.0')
node1.start()
> session = self.patient_cql_connection(node1)

commitlog_test.py:181:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
dtest_setup.py:284: in patient_cql_connection
session = retry_till_success(
dtest_setup.py:39: in retry_till_success
return fun(*args, **kwargs)
dtest_setup.py:222: in cql_connection
return self._create_session(node, keyspace, user, password, compression,
dtest_setup.py:262: in _create_session
session = cluster.connect(wait_for_all_pools=True)
../cassandra/build/venv/src/cassandra-driver/cassandra/cluster.py:1690: in connect
self.control_connection.connect()
../cassandra/build/venv/src/cassandra-driver/cassandra/cluster.py:3488: in connect
self._set_new_connection(self._reconnect_internal())
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _

self = <cassandra.cluster.ControlConnection object at 0x7f829d15ed90>

def _reconnect_internal(self):
"""
Tries to connect to each host in the query plan until one succeeds
or every attempt fails. If successful, a new Connection will be
returned. Otherwise, :exc:`NoHostAvailable` will be raised
with an "errors" arg that is a dict mapping host addresses
to the exception that was raised when an attempt was made to open
a connection to that host.
"""
errors = {}
lbp = (
self._cluster.load_balancing_policy
if self._cluster._config_mode == _ConfigMode.LEGACY else
self._cluster._default_load_balancing_policy
)

for host in lbp.make_query_plan():
try:
return self._try_connect(host)
except ConnectionException as exc:
errors[str(host.endpoint)] = exc
log.warning("[control connection] Error connecting to %s:", host, exc_info=True)
self._cluster.signal_connection_failure(host, exc, is_host_addition=False)
except Exception as exc:
errors[str(host.endpoint)] = exc
log.warning("[control connection] Error connecting to %s:", host, exc_info=True)
if self._is_shutdown:
raise DriverException("[control connection] Reconnection in progress during shutdown")

> raise NoHostAvailable("Unable to connect to any servers", errors)
E cassandra.cluster.NoHostAvailable: ('Unable to connect to any servers', {'127.0.0.1:9042': ConnectionRefusedError(111, "Tried connecting to [('127.0.0.1', 9042)]. Last error: Connection refused")})

../cassandra/build/venv/src/cassandra-driver/cassandra/cluster.py:3533: NoHostAvailable
57.378
8_cythonno_x86_64_35_64test_disk_balance_replace_same_addressFailureccmlib.node.TimeoutError: 27 Nov 2024 14:23:28 [node1] after 120.16/120 seconds Missing: ['127.0.0.2:7000.* is now UP'] not found in system.log: Head: INFO [GossipStage:1] 2024-11-27 14:21:29,858 Goss Tail: ....0.0.1:7000(/127.0.0.1:41336)->/127.0.0.2:7000-URGENT_MESSAGES-faa40d29 successfully connected, version = 14, framing = CRC, encryption = unencrypted

self = <disk_balance_test.TestDiskBalance object at 0x7f829e1bb130>

def test_disk_balance_replace_same_address(self):
> self._test_disk_balance_replace(same_address=True)

disk_balance_test.py:69:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
disk_balance_test.py:100: in _test_disk_balance_replace
node5.start(jvm_args=["-Dcassandra.replace_address_first_boot={}".format(node2.address())],
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/node.py:922: in start
node.watch_log_for_alive(self, from_mark=mark)
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/node.py:686: in watch_log_for_alive
self.watch_log_for(tofind, from_mark=from_mark, timeout=timeout, filename=filename)
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/node.py:610: in watch_log_for
TimeoutError.raise_if_passed(start=start, timeout=timeout, node=self.name,
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _

start = 1732717287.921752, timeout = 120
msg = "Missing: ['127.0.0.2:7000.* is now UP'] not found in system.log:\n Head: INFO [GossipStage:1] 2024-11-27 14:21:29,85...27.0.0.2:7000-URGENT_MESSAGES-faa40d29 successfully connected, version = 14, framing = CRC, encryption = unencrypted\n"
node = 'node1'

@staticmethod
def raise_if_passed(start, timeout, msg, node=None):
if start + timeout < time.time():
> raise TimeoutError.create(start, timeout, msg, node)
E ccmlib.node.TimeoutError: 27 Nov 2024 14:23:28 [node1] after 120.16/120 seconds Missing: ['127.0.0.2:7000.* is now UP'] not found in system.log:
E Head: INFO [GossipStage:1] 2024-11-27 14:21:29,858 Goss
E Tail: ....0.0.1:7000(/127.0.0.1:41336)->/127.0.0.2:7000-URGENT_MESSAGES-faa40d29 successfully connected, version = 14, framing = CRC, encryption = unencrypted

../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/node.py:56: TimeoutError
467.573
8_cythonno_x86_64_42_64test_disk_balance_after_joining_ring_stcsFailureFailed: Timeout >900.0s

self = <disk_balance_test.TestDiskBalance object at 0x7fbe28b4dfa0>

@since('3.10')
def test_disk_balance_after_joining_ring_stcs(self):
"""
@jira_ticket CASSANDRA-13948
"""
> self._disk_balance_after_joining_ring_test(lcs=False)

disk_balance_test.py:271:
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _
disk_balance_test.py:331: in _disk_balance_after_joining_ring_test
self._assert_balanced_after_boundary_change(node1, total_keys, lcs)
disk_balance_test.py:353: in _assert_balanced_after_boundary_change
node.stress(['read', 'n={}'.format(total_keys), "no-warmup", "cl=ALL", "-pop", "seq=1...{}".format(total_keys), "-rate", "threads=1"])
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/node.py:1529: in stress
return handle_external_tool_process(p, ['stress'] + stress_options)
../cassandra/build/venv/lib/python3.8/site-packages/ccmlib/node.py:2325: in handle_external_tool_process
out, err = process.communicate()
/usr/lib/python3.8/subprocess.py:1028: in communicate
stdout, stderr = self._communicate(input, endtime, timeout)
/usr/lib/python3.8/subprocess.py:1868: in _communicate
ready = selector.select(timeout)
_ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _ _

self = <selectors.PollSelector object at 0x7fbe24220df0>, timeout = None

def select(self, timeout=None):
# This is shared between poll() and epoll().
# epoll() has a different signature and handling of timeout parameter.
if timeout is None:
timeout = None
elif timeout <= 0:
timeout = 0
else:
# poll() has a resolution of 1 millisecond, round away from
# zero to wait *at least* timeout seconds.
timeout = math.ceil(timeout * 1e3)
ready = []
try:
> fd_event_list = self._selector.poll(timeout)
E Failed: Timeout >900.0s

/usr/lib/python3.8/selectors.py:415: Failed
907.429