# 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. import binascii import errno import fcntl import json from contextlib import contextmanager import logging from textwrap import dedent import mock import os import pickle import shutil import struct import tempfile import unittest import uuid from six.moves import cStringIO as StringIO from swift.cli import relinker from swift.common import exceptions, ring, utils from swift.common import storage_policy from swift.common.exceptions import PathNotDir from swift.common.storage_policy import ( StoragePolicy, StoragePolicyCollection, POLICIES, ECStoragePolicy) from swift.obj.diskfile import write_metadata, DiskFileRouter, \ DiskFileManager, relink_paths from test.unit import FakeLogger, skip_if_no_xattrs, DEFAULT_TEST_EC_TYPE, \ patch_policies PART_POWER = 8 class TestRelinker(unittest.TestCase): def setUp(self): skip_if_no_xattrs() self.logger = FakeLogger() self.testdir = tempfile.mkdtemp() self.devices = os.path.join(self.testdir, 'node') shutil.rmtree(self.testdir, ignore_errors=True) os.mkdir(self.testdir) os.mkdir(self.devices) self.rb = ring.RingBuilder(PART_POWER, 6.0, 1) for i in range(6): ip = "127.0.0.%s" % i self.rb.add_dev({'id': i, 'region': 0, 'zone': 0, 'weight': 1, 'ip': ip, 'port': 10000, 'device': 'sda1'}) self.rb.rebalance(seed=1) self.existing_device = 'sda1' os.mkdir(os.path.join(self.devices, self.existing_device)) self.objects = os.path.join(self.devices, self.existing_device, 'objects') self._setup_object() def _setup_object(self, condition=None): attempts = [] for _ in range(50): account = 'a' container = 'c' obj = 'o-' + str(uuid.uuid4()) self._hash = utils.hash_path(account, container, obj) digest = binascii.unhexlify(self._hash) self.part = struct.unpack_from('>I', digest)[0] >> 24 self.next_part = struct.unpack_from('>I', digest)[0] >> 23 path = os.path.join(os.path.sep, account, container, obj) # There's 1/512 chance that both old and new parts will be 0; # that's not a terribly interesting case, as there's nothing to do attempts.append((self.part, self.next_part, 2**PART_POWER)) if (self.part != self.next_part and (condition(self.part) if condition else True)): break else: self.fail('Failed to setup object satisfying test preconditions %s' % attempts) shutil.rmtree(self.objects, ignore_errors=True) os.mkdir(self.objects) self.objdir = os.path.join( self.objects, str(self.part), self._hash[-3:], self._hash) os.makedirs(self.objdir) self.object_fname = utils.Timestamp.now().internal + ".data" self.objname = os.path.join(self.objdir, self.object_fname) with open(self.objname, "wb") as dummy: dummy.write(b"Hello World!") write_metadata(dummy, {'name': path, 'Content-Length': '12'}) self.policy = StoragePolicy(0, 'platinum', True) storage_policy._POLICIES = StoragePolicyCollection([self.policy]) self.part_dir = os.path.join(self.objects, str(self.part)) self.suffix_dir = os.path.join(self.part_dir, self._hash[-3:]) self.next_part_dir = os.path.join(self.objects, str(self.next_part)) self.next_suffix_dir = os.path.join( self.next_part_dir, self._hash[-3:]) self.expected_dir = os.path.join(self.next_suffix_dir, self._hash) self.expected_file = os.path.join(self.expected_dir, self.object_fname) def _save_ring(self): self.rb._ring = None rd = self.rb.get_ring() for policy in POLICIES: rd.save(os.path.join( self.testdir, '%s.ring.gz' % policy.ring_name)) # Enforce ring reloading in relinker policy.object_ring = None def tearDown(self): shutil.rmtree(self.testdir, ignore_errors=True) storage_policy.reload_storage_policies() @contextmanager def _mock_listdir(self): orig_listdir = utils.listdir def mocked(path): if path == self.objects: raise OSError return orig_listdir(path) with mock.patch('swift.common.utils.listdir', mocked): yield def _do_test_relinker_drop_privileges(self, command): @contextmanager def do_mocks(): # attach mocks to call_capture so that call order can be asserted call_capture = mock.Mock() with mock.patch('swift.cli.relinker.drop_privileges') as mock_dp: with mock.patch('swift.cli.relinker.' + command, return_value=0) as mock_command: call_capture.attach_mock(mock_dp, 'drop_privileges') call_capture.attach_mock(mock_command, command) yield call_capture # no user option with do_mocks() as capture: self.assertEqual(0, relinker.main([command])) self.assertEqual([(command, mock.ANY, mock.ANY)], capture.method_calls) # cli option --user with do_mocks() as capture: self.assertEqual(0, relinker.main([command, '--user', 'cli_user'])) self.assertEqual([('drop_privileges', ('cli_user',), {}), (command, mock.ANY, mock.ANY)], capture.method_calls) # cli option --user takes precedence over conf file user with do_mocks() as capture: with mock.patch('swift.cli.relinker.readconf', return_value={'user': 'conf_user'}): self.assertEqual(0, relinker.main([command, 'conf_file', '--user', 'cli_user'])) self.assertEqual([('drop_privileges', ('cli_user',), {}), (command, mock.ANY, mock.ANY)], capture.method_calls) # conf file user with do_mocks() as capture: with mock.patch('swift.cli.relinker.readconf', return_value={'user': 'conf_user'}): self.assertEqual(0, relinker.main([command, 'conf_file'])) self.assertEqual([('drop_privileges', ('conf_user',), {}), (command, mock.ANY, mock.ANY)], capture.method_calls) def test_relinker_drop_privileges(self): self._do_test_relinker_drop_privileges('relink') self._do_test_relinker_drop_privileges('cleanup') def _do_test_relinker_files_per_second(self, command): # no files per second with mock.patch('swift.cli.relinker.RateLimitedIterator') as it: self.assertEqual(0, relinker.main([ command, '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) it.assert_not_called() # zero files per second with mock.patch('swift.cli.relinker.RateLimitedIterator') as it: self.assertEqual(0, relinker.main([ command, '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--files-per-second', '0' ])) it.assert_not_called() # positive files per second locations = iter([]) with mock.patch('swift.cli.relinker.audit_location_generator', return_value=locations): with mock.patch('swift.cli.relinker.RateLimitedIterator') as it: self.assertEqual(0, relinker.main([ command, '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--files-per-second', '1.23' ])) it.assert_called_once_with(locations, 1.23) # negative files per second err = StringIO() with mock.patch('sys.stderr', err): with self.assertRaises(SystemExit) as cm: relinker.main([ command, '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--files-per-second', '-1' ]) self.assertEqual(2, cm.exception.code) # NB exit code 2 from argparse self.assertIn('--files-per-second: invalid non_negative_float value', err.getvalue()) def test_relink_files_per_second(self): self.rb.prepare_increase_partition_power() self._save_ring() self._do_test_relinker_files_per_second('relink') def test_cleanup_files_per_second(self): self._common_test_cleanup() self._do_test_relinker_files_per_second('cleanup') def test_conf_file(self): config = """ [DEFAULT] swift_dir = %s devices = /test/node mount_check = false reclaim_age = 5184000 [object-relinker] log_level = WARNING log_name = test-relinker """ % self.testdir conf_file = os.path.join(self.testdir, 'relinker.conf') with open(conf_file, 'w') as f: f.write(dedent(config)) # cite conf file on command line with mock.patch('swift.cli.relinker.relink') as mock_relink: relinker.main(['relink', conf_file, '--device', 'sdx', '--debug']) exp_conf = { '__file__': mock.ANY, 'swift_dir': self.testdir, 'devices': '/test/node', 'mount_check': False, 'reclaim_age': '5184000', 'files_per_second': 0.0, 'log_name': 'test-relinker', 'log_level': 'DEBUG', } mock_relink.assert_called_once_with(exp_conf, mock.ANY, device='sdx') logger = mock_relink.call_args[0][1] # --debug overrides conf file self.assertEqual(logging.DEBUG, logger.getEffectiveLevel()) self.assertEqual('test-relinker', logger.logger.name) # check the conf is passed to DiskFileRouter self._save_ring() with mock.patch('swift.cli.relinker.diskfile.DiskFileRouter', side_effect=DiskFileRouter) as mock_dfr: relinker.main(['relink', conf_file, '--device', 'sdx', '--debug']) mock_dfr.assert_called_once_with(exp_conf, mock.ANY) # flip mount_check, no --debug... config = """ [DEFAULT] swift_dir = test/swift/dir devices = /test/node mount_check = true [object-relinker] log_level = WARNING log_name = test-relinker files_per_second = 11.1 """ with open(conf_file, 'w') as f: f.write(dedent(config)) with mock.patch('swift.cli.relinker.relink') as mock_relink: relinker.main(['relink', conf_file, '--device', 'sdx']) mock_relink.assert_called_once_with({ '__file__': mock.ANY, 'swift_dir': 'test/swift/dir', 'devices': '/test/node', 'mount_check': True, 'files_per_second': 11.1, 'log_name': 'test-relinker', 'log_level': 'WARNING', }, mock.ANY, device='sdx') logger = mock_relink.call_args[0][1] self.assertEqual(logging.WARNING, logger.getEffectiveLevel()) self.assertEqual('test-relinker', logger.logger.name) # override with cli options... with mock.patch('swift.cli.relinker.relink') as mock_relink: relinker.main([ 'relink', conf_file, '--device', 'sdx', '--debug', '--swift-dir', 'cli-dir', '--devices', 'cli-devs', '--skip-mount-check', '--files-per-second', '2.2']) mock_relink.assert_called_once_with({ '__file__': mock.ANY, 'swift_dir': 'cli-dir', 'devices': 'cli-devs', 'mount_check': False, 'files_per_second': 2.2, 'log_level': 'DEBUG', 'log_name': 'test-relinker', }, mock.ANY, device='sdx') with mock.patch('swift.cli.relinker.relink') as mock_relink, \ mock.patch('logging.basicConfig') as mock_logging_config: relinker.main(['relink', '--device', 'sdx', '--swift-dir', 'cli-dir', '--devices', 'cli-devs', '--skip-mount-check']) mock_relink.assert_called_once_with({ 'swift_dir': 'cli-dir', 'devices': 'cli-devs', 'mount_check': False, 'files_per_second': 0.0, 'log_level': 'INFO', }, mock.ANY, device='sdx') mock_logging_config.assert_called_once_with( format='%(message)s', level=logging.INFO, filename=None) with mock.patch('swift.cli.relinker.relink') as mock_relink, \ mock.patch('logging.basicConfig') as mock_logging_config: relinker.main(['relink', '--device', 'sdx', '--debug', '--swift-dir', 'cli-dir', '--devices', 'cli-devs', '--skip-mount-check']) mock_relink.assert_called_once_with({ 'swift_dir': 'cli-dir', 'devices': 'cli-devs', 'mount_check': False, 'files_per_second': 0.0, 'log_level': 'DEBUG', }, mock.ANY, device='sdx') # --debug is now effective mock_logging_config.assert_called_once_with( format='%(message)s', level=logging.DEBUG, filename=None) def test_relink_first_quartile_no_rehash(self): # we need object name in lower half of current part self._setup_object(lambda part: part < 2 ** (PART_POWER - 1)) self.assertLess(self.next_part, 2 ** PART_POWER) self.rb.prepare_increase_partition_power() self._save_ring() with mock.patch('swift.obj.diskfile.DiskFileManager._hash_suffix', return_value='foo') as mock_hash_suffix: self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) # ... and no rehash self.assertEqual([], mock_hash_suffix.call_args_list) self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) stat_old = os.stat(os.path.join(self.objdir, self.object_fname)) stat_new = os.stat(self.expected_file) self.assertEqual(stat_old.st_ino, stat_new.st_ino) # Invalidated now, rehashed during cleanup with open(os.path.join(self.next_part_dir, 'hashes.invalid')) as fp: self.assertEqual(fp.read(), self._hash[-3:] + '\n') self.assertFalse(os.path.exists( os.path.join(self.next_part_dir, 'hashes.pkl'))) def test_relink_second_quartile_does_rehash(self): # we need a part in upper half of current part power self._setup_object(lambda part: part >= 2 ** (PART_POWER - 1)) self.assertGreaterEqual(self.next_part, 2 ** PART_POWER) self.assertTrue(self.rb.prepare_increase_partition_power()) self._save_ring() with mock.patch('swift.obj.diskfile.DiskFileManager._hash_suffix', return_value='foo') as mock_hash_suffix: self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) # we rehash the new suffix dirs as we go self.assertEqual([mock.call(self.next_suffix_dir, policy=self.policy)], mock_hash_suffix.call_args_list) # Invalidated and rehashed during relinking with open(os.path.join(self.next_part_dir, 'hashes.invalid')) as fp: self.assertEqual(fp.read(), '') with open(os.path.join(self.next_part_dir, 'hashes.pkl'), 'rb') as fp: hashes = pickle.load(fp) self.assertIn(self._hash[-3:], hashes) self.assertEqual('foo', hashes[self._hash[-3:]]) self.assertFalse(os.path.exists( os.path.join(self.part_dir, 'hashes.invalid'))) def test_relink_link_already_exists(self): self.rb.prepare_increase_partition_power() self._save_ring() orig_relink_paths = relink_paths def mock_relink_paths(target_path, new_target_path): # pretend another process has created the link before this one os.makedirs(self.expected_dir) os.link(target_path, new_target_path) orig_relink_paths(target_path, new_target_path) with mock.patch('swift.cli.relinker.diskfile.relink_paths', mock_relink_paths): self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) stat_old = os.stat(os.path.join(self.objdir, self.object_fname)) stat_new = os.stat(self.expected_file) self.assertEqual(stat_old.st_ino, stat_new.st_ino) def test_relink_link_target_disappears(self): # we need object name in lower half of current part so that there is no # rehash of the new partition which wold erase the empty new partition # - we want to assert it was created self._setup_object(lambda part: part < 2 ** (PART_POWER - 1)) self.rb.prepare_increase_partition_power() self._save_ring() orig_relink_paths = relink_paths def mock_relink_paths(target_path, new_target_path): # pretend another process has cleaned up the target path os.unlink(target_path) orig_relink_paths(target_path, new_target_path) with mock.patch('swift.cli.relinker.diskfile.relink_paths', mock_relink_paths): self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertTrue(os.path.isdir(self.expected_dir)) self.assertFalse(os.path.isfile(self.expected_file)) def test_relink_no_applicable_policy(self): # NB do not prepare part power increase self._save_ring() with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(2, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, ])) self.assertEqual(self.logger.get_lines_for_level('warning'), ['No policy found to increase the partition power.']) def test_relink_not_mounted(self): self.rb.prepare_increase_partition_power() self._save_ring() with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(1, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, ])) self.assertEqual(self.logger.get_lines_for_level('warning'), [ 'Skipping sda1 as it is not mounted', '1 disks were unmounted']) def test_relink_listdir_error(self): self.rb.prepare_increase_partition_power() self._save_ring() with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): with self._mock_listdir(): self.assertEqual(1, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount-check' ])) self.assertEqual(self.logger.get_lines_for_level('warning'), [ 'Skipping %s because ' % self.objects, 'There were 1 errors listing partition directories']) def test_relink_device_filter(self): self.rb.prepare_increase_partition_power() self._save_ring() self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--device', self.existing_device, ])) self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) stat_old = os.stat(os.path.join(self.objdir, self.object_fname)) stat_new = os.stat(self.expected_file) self.assertEqual(stat_old.st_ino, stat_new.st_ino) def test_relink_device_filter_invalid(self): self.rb.prepare_increase_partition_power() self._save_ring() self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--device', 'none', ])) self.assertFalse(os.path.isdir(self.expected_dir)) self.assertFalse(os.path.isfile(self.expected_file)) def _common_test_cleanup(self, relink=True): # Create a ring that has prev_part_power set self.rb.prepare_increase_partition_power() self._save_ring() if relink: conf = {'swift_dir': self.testdir, 'devices': self.devices, 'mount_check': False, 'files_per_second': 0} self.assertEqual(0, relinker.relink( conf, logger=self.logger, device=self.existing_device)) self.rb.increase_partition_power() self._save_ring() def test_cleanup_first_quartile_does_rehash(self): # we need object name in lower half of current part self._setup_object(lambda part: part < 2 ** (PART_POWER - 1)) self.assertLess(self.next_part, 2 ** PART_POWER) self._common_test_cleanup() # don't mock re-hash for variety (and so we can assert side-effects) self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) # Old objectname should be removed, new should still exist self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) self.assertFalse(os.path.isfile( os.path.join(self.objdir, self.object_fname))) self.assertFalse(os.path.exists(self.part_dir)) with open(os.path.join(self.next_part_dir, 'hashes.invalid')) as fp: self.assertEqual(fp.read(), '') with open(os.path.join(self.next_part_dir, 'hashes.pkl'), 'rb') as fp: hashes = pickle.load(fp) self.assertIn(self._hash[-3:], hashes) # create an object in a first quartile partition and pretend it should # be there; check that cleanup does not fail and does not remove the # partition! self._setup_object(lambda part: part < 2 ** (PART_POWER - 1)) with mock.patch('swift.cli.relinker.replace_partition_in_path', lambda *args: args[0]): self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertTrue(os.path.exists(self.objname)) def test_cleanup_second_quartile_no_rehash(self): # we need a part in upper half of current part power self._setup_object(lambda part: part >= 2 ** (PART_POWER - 1)) self.assertGreater(self.part, 2 ** (PART_POWER - 1)) self._common_test_cleanup() def fake_hash_suffix(suffix_dir, policy): # check that the suffix dir is empty and remove it just like the # real _hash_suffix self.assertEqual([self._hash], os.listdir(suffix_dir)) hash_dir = os.path.join(suffix_dir, self._hash) self.assertEqual([], os.listdir(hash_dir)) os.rmdir(hash_dir) os.rmdir(suffix_dir) raise PathNotDir() with mock.patch('swift.obj.diskfile.DiskFileManager._hash_suffix', side_effect=fake_hash_suffix) as mock_hash_suffix: self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) # the old suffix dir is rehashed before the old partition is removed, # but the new suffix dir is not rehashed self.assertEqual([mock.call(self.suffix_dir, policy=self.policy)], mock_hash_suffix.call_args_list) # Old objectname should be removed, new should still exist self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) self.assertFalse(os.path.isfile( os.path.join(self.objdir, self.object_fname))) self.assertFalse(os.path.exists(self.part_dir)) with open(os.path.join(self.objects, str(self.next_part), 'hashes.invalid')) as fp: self.assertEqual(fp.read(), '') with open(os.path.join(self.objects, str(self.next_part), 'hashes.pkl'), 'rb') as fp: hashes = pickle.load(fp) self.assertIn(self._hash[-3:], hashes) def test_cleanup_no_applicable_policy(self): # NB do not prepare part power increase self._save_ring() with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(2, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, ])) self.assertEqual(self.logger.get_lines_for_level('warning'), ['No policy found to increase the partition power.']) def test_cleanup_not_mounted(self): self._common_test_cleanup() with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(1, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, ])) self.assertEqual(self.logger.get_lines_for_level('warning'), [ 'Skipping sda1 as it is not mounted', '1 disks were unmounted']) def test_cleanup_listdir_error(self): self._common_test_cleanup() with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): with self._mock_listdir(): self.assertEqual(1, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount-check' ])) self.assertEqual(self.logger.get_lines_for_level('warning'), [ 'Skipping %s because ' % self.objects, 'There were 1 errors listing partition directories']) def test_cleanup_device_filter(self): self._common_test_cleanup() self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--device', self.existing_device, ])) # Old objectname should be removed, new should still exist self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) self.assertFalse(os.path.isfile( os.path.join(self.objdir, self.object_fname))) def test_cleanup_device_filter_invalid(self): self._common_test_cleanup() self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', '--device', 'none', ])) # Old objectname should still exist, new should still exist self.assertTrue(os.path.isdir(self.expected_dir)) self.assertTrue(os.path.isfile(self.expected_file)) self.assertTrue(os.path.isfile( os.path.join(self.objdir, self.object_fname))) def test_relink_cleanup(self): state_file = os.path.join(self.devices, self.existing_device, 'relink.objects.json') self.rb.prepare_increase_partition_power() self._save_ring() self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) state = {str(self.part): True} with open(state_file, 'rt') as f: orig_inode = os.stat(state_file).st_ino self.assertEqual(json.load(f), { "part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": state}) self.rb.increase_partition_power() self.rb._ring = None # Force builder to reload ring self._save_ring() with open(state_file, 'rt') as f: # Keep the state file open during cleanup so the inode can't be # released/re-used when it gets unlinked self.assertEqual(orig_inode, os.stat(state_file).st_ino) self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertNotEqual(orig_inode, os.stat(state_file).st_ino) if self.next_part < 2 ** PART_POWER: state[str(self.next_part)] = True with open(state_file, 'rt') as f: # NB: part_power/next_part_power tuple changed, so state was reset # (though we track prev_part_power for an efficient clean up) self.assertEqual(json.load(f), { "prev_part_power": PART_POWER, "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 1, "state": state}) def test_devices_filter_filtering(self): # With no filtering, returns all devices devices = relinker.devices_filter(None, "", [self.existing_device]) self.assertEqual(set([self.existing_device]), devices) # With a matching filter, returns what is matching devices = relinker.devices_filter(self.existing_device, "", [self.existing_device, 'sda2']) self.assertEqual(set([self.existing_device]), devices) # With a non matching filter, returns nothing devices = relinker.devices_filter('none', "", [self.existing_device]) self.assertEqual(set(), devices) def test_hook_pre_post_device_locking(self): locks = [None] device_path = os.path.join(self.devices, self.existing_device) datadir = 'object' lock_file = os.path.join(device_path, '.relink.%s.lock' % datadir) # The first run gets the lock states = {"state": {}} relinker.hook_pre_device(locks, states, datadir, device_path) self.assertNotEqual([None], locks) # A following run would block with self.assertRaises(IOError) as raised: with open(lock_file, 'a') as f: fcntl.flock(f.fileno(), fcntl.LOCK_EX | fcntl.LOCK_NB) self.assertEqual(errno.EAGAIN, raised.exception.errno) # Another must not get the lock, so it must return an empty list relinker.hook_post_device(locks, "") self.assertEqual([None], locks) with open(lock_file, 'a') as f: fcntl.flock(f.fileno(), fcntl.LOCK_EX | fcntl.LOCK_NB) def test_state_file(self): device_path = os.path.join(self.devices, self.existing_device) datadir = 'objects' datadir_path = os.path.join(device_path, datadir) state_file = os.path.join(device_path, 'relink.%s.json' % datadir) def call_partition_filter(part_power, next_part_power, parts): # Partition 312 will be ignored because it must have been created # by the relinker return relinker.partitions_filter(states, part_power, next_part_power, datadir_path, parts) # Start relinking states = {"part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": {}} # Load the states: As it starts, it must be empty locks = [None] relinker.hook_pre_device(locks, states, datadir, device_path) self.assertEqual({}, states["state"]) os.close(locks[0]) # Release the lock # Partition 312 is ignored because it must have been created with the # next_part_power, so it does not need to be relinked # 96 and 227 are reverse ordered # auditor_status_ALL.json is ignored because it's not a partition self.assertEqual(['227', '96'], call_partition_filter(PART_POWER, PART_POWER + 1, ['96', '227', '312', 'auditor_status.json'])) self.assertEqual(states["state"], {'96': False, '227': False}) pol = POLICIES[0] mgr = DiskFileRouter({'devices': self.devices, 'mount_check': False}, self.logger)[pol] # Ack partition 96 relinker.hook_post_partition(self.logger, states, relinker.STEP_RELINK, pol, mgr, os.path.join(datadir_path, '96')) self.assertEqual(states["state"], {'96': True, '227': False}) self.assertIn("Device: sda1 Step: relink Partitions: 1/2", self.logger.get_lines_for_level("info")) with open(state_file, 'rt') as f: self.assertEqual(json.load(f), { "part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": {'96': True, '227': False}}) # Restart relinking after only part 96 was done self.assertEqual(['227'], call_partition_filter(PART_POWER, PART_POWER + 1, ['96', '227', '312'])) self.assertEqual(states["state"], {'96': True, '227': False}) # Ack partition 227 relinker.hook_post_partition( self.logger, states, relinker.STEP_RELINK, pol, mgr, os.path.join(datadir_path, '227')) self.assertIn("Device: sda1 Step: relink Partitions: 2/2", self.logger.get_lines_for_level("info")) self.assertEqual(states["state"], {'96': True, '227': True}) with open(state_file, 'rt') as f: self.assertEqual(json.load(f), { "part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": {'96': True, '227': True}}) # If the process restarts, it reload the state locks = [None] states = { "part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": {}, } relinker.hook_pre_device(locks, states, datadir, device_path) self.assertEqual(states, { "part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": {'96': True, '227': True}}) os.close(locks[0]) # Release the lock # Start cleanup -- note that part_power and next_part_power now match! states = { "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 1, "state": {}, } # ...which means our state file was ignored relinker.hook_pre_device(locks, states, datadir, device_path) self.assertEqual(states, { "prev_part_power": PART_POWER, "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 1, "state": {}}) os.close(locks[0]) # Release the lock self.assertEqual(['227', '96'], call_partition_filter(PART_POWER + 1, PART_POWER + 1, ['96', '227', '312'])) # Ack partition 227 relinker.hook_post_partition( self.logger, states, relinker.STEP_CLEANUP, pol, mgr, os.path.join(datadir_path, '227')) self.assertIn("Device: sda1 Step: cleanup Partitions: 1/2", self.logger.get_lines_for_level("info")) self.assertEqual(states["state"], {'96': False, '227': True}) with open(state_file, 'rt') as f: self.assertEqual(json.load(f), { "prev_part_power": PART_POWER, "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 1, "state": {'96': False, '227': True}}) # Restart cleanup after only part 227 was done self.assertEqual(['96'], call_partition_filter(PART_POWER + 1, PART_POWER + 1, ['96', '227', '312'])) self.assertEqual(states["state"], {'96': False, '227': True}) # Ack partition 96 relinker.hook_post_partition(self.logger, states, relinker.STEP_CLEANUP, pol, mgr, os.path.join(datadir_path, '96')) self.assertIn("Device: sda1 Step: cleanup Partitions: 2/2", self.logger.get_lines_for_level("info")) self.assertEqual(states["state"], {'96': True, '227': True}) with open(state_file, 'rt') as f: self.assertEqual(json.load(f), { "prev_part_power": PART_POWER, "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 1, "state": {'96': True, '227': True}}) # At the end, the state is still accurate locks = [None] states = { "prev_part_power": PART_POWER, "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 1, "state": {}, } relinker.hook_pre_device(locks, states, datadir, device_path) self.assertEqual(states["state"], {'96': True, '227': True}) os.close(locks[0]) # Release the lock # If the part_power/next_part_power tuple differs, restart from scratch locks = [None] states = { "part_power": PART_POWER + 1, "next_part_power": PART_POWER + 2, "state": {}, } relinker.hook_pre_device(locks, states, datadir, device_path) self.assertEqual(states["state"], {}) self.assertFalse(os.path.exists(state_file)) os.close(locks[0]) # Release the lock # If the file gets corrupted, restart from scratch with open(state_file, 'wt') as f: f.write('NOT JSON') locks = [None] states = {"part_power": PART_POWER, "next_part_power": PART_POWER + 1, "state": {}} relinker.hook_pre_device(locks, states, datadir, device_path) self.assertEqual(states["state"], {}) self.assertFalse(os.path.exists(state_file)) os.close(locks[0]) # Release the lock def test_cleanup_not_yet_relinked(self): self._common_test_cleanup(relink=False) self.assertEqual(1, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertTrue(os.path.isfile( os.path.join(self.objdir, self.object_fname))) def test_cleanup_deleted(self): self._common_test_cleanup() # Pretend the object got deleted in between and there is a tombstone fname_ts = self.expected_file[:-4] + "ts" os.rename(self.expected_file, fname_ts) self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) def test_cleanup_reapable(self): # relink a tombstone fname_ts = self.objname[:-4] + "ts" os.rename(self.objname, fname_ts) self.objname = fname_ts self.expected_file = self.expected_file[:-4] + "ts" self._common_test_cleanup() self.assertTrue(os.path.exists(self.expected_file)) # sanity check with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger), \ mock.patch('time.time', return_value=1e11): # far, far future self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertEqual(self.logger.get_lines_for_level('error'), []) self.assertEqual(self.logger.get_lines_for_level('warning'), []) self.assertIn( "Found reapable on-disk file: %s" % self.objname, self.logger.get_lines_for_level('debug')) # self.expected_file may or may not exist; it depends on whether the # object was in the upper-half of the partition space. ultimately, # that part doesn't really matter much -- but we definitely *don't* # want self.objname around polluting the old partition space. self.assertFalse(os.path.exists(self.objname)) def test_cleanup_doesnotexist(self): self._common_test_cleanup() # Pretend the file in the new place got deleted inbetween os.remove(self.expected_file) with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(1, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) self.assertEqual(self.logger.get_lines_for_level('warning'), ['Error cleaning up %s: %s' % (self.objname, repr(exceptions.DiskFileNotExist()))]) @patch_policies( [ECStoragePolicy( 0, name='platinum', is_default=True, ec_type=DEFAULT_TEST_EC_TYPE, ec_ndata=4, ec_nparity=2)]) def test_cleanup_diskfile_error(self): self._common_test_cleanup() # Switch the policy type so all fragments raise DiskFileError. with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) log_lines = self.logger.get_lines_for_level('warning') self.assertEqual(3, len(log_lines), 'Expected 3 log lines, got %r' % log_lines) # Once to check the old partition space... self.assertIn('Bad fragment index: None', log_lines[0]) # ... again for the new partition ... self.assertIn('Bad fragment index: None', log_lines[0]) # ... and one last time for the rehash self.assertIn('Bad fragment index: None', log_lines[1]) def test_cleanup_quarantined(self): self._common_test_cleanup() # Pretend the object in the new place got corrupted with open(self.expected_file, "wb") as obj: obj.write(b'trash') with mock.patch.object(relinker.logging, 'getLogger', return_value=self.logger): self.assertEqual(1, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) log_lines = self.logger.get_lines_for_level('warning') self.assertEqual(2, len(log_lines), 'Expected 2 log lines, got %r' % log_lines) self.assertIn('metadata content-length 12 does not match ' 'actual object size 5', log_lines[0]) self.assertIn('failed audit and was quarantined', log_lines[1]) def test_rehashing(self): calls = [] @contextmanager def do_mocks(): orig_invalidate = relinker.diskfile.invalidate_hash orig_get_hashes = DiskFileManager.get_hashes def mock_invalidate(suffix_dir): calls.append(('invalidate', suffix_dir)) return orig_invalidate(suffix_dir) def mock_get_hashes(self, *args): calls.append(('get_hashes', ) + args) return orig_get_hashes(self, *args) with mock.patch.object(relinker.diskfile, 'invalidate_hash', mock_invalidate), \ mock.patch.object(DiskFileManager, 'get_hashes', mock_get_hashes): yield with do_mocks(): self.rb.prepare_increase_partition_power() self._save_ring() self.assertEqual(0, relinker.main([ 'relink', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) expected = [('invalidate', self.next_suffix_dir)] if self.part >= 2 ** (PART_POWER - 1): expected.extend([ ('get_hashes', self.existing_device, self.next_part & ~1, [], POLICIES[0]), ('get_hashes', self.existing_device, self.next_part | 1, [], POLICIES[0]), ]) self.assertEqual(calls, expected) # Depending on partition, there may or may not be a get_hashes here self.rb._ring = None # Force builder to reload ring self.rb.increase_partition_power() self._save_ring() self.assertEqual(0, relinker.main([ 'cleanup', '--swift-dir', self.testdir, '--devices', self.devices, '--skip-mount', ])) if self.part < 2 ** (PART_POWER - 1): expected.append(('get_hashes', self.existing_device, self.next_part, [], POLICIES[0])) expected.extend([ ('invalidate', self.suffix_dir), ('get_hashes', self.existing_device, self.part, [], POLICIES[0]), ]) self.assertEqual(calls, expected) if __name__ == '__main__': unittest.main()