123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833 |
- from configparser import ConfigParser
- from binascii import unhexlify
- from datetime import datetime
- from itertools import islice
- import errno
- import logging
- logger = logging.getLogger(__name__)
- import os
- import shutil
- import struct
- from zlib import crc32
- import msgpack
- from .helpers import Error, ErrorWithTraceback, IntegrityError, Location, ProgressIndicatorPercent, bin_to_hex
- from .hashindex import NSIndex
- from .locking import Lock, LockError, LockErrorT
- from .lrucache import LRUCache
- from .platform import sync_dir
- MAX_OBJECT_SIZE = 20 * 1024 * 1024
- MAGIC = b'BORG_SEG'
- MAGIC_LEN = len(MAGIC)
- TAG_PUT = 0
- TAG_DELETE = 1
- TAG_COMMIT = 2
- class Repository:
- """Filesystem based transactional key value store
- On disk layout:
- dir/README
- dir/config
- dir/data/<X / SEGMENTS_PER_DIR>/<X>
- dir/index.X
- dir/hints.X
- """
- DEFAULT_MAX_SEGMENT_SIZE = 5 * 1024 * 1024
- DEFAULT_SEGMENTS_PER_DIR = 10000
- class DoesNotExist(Error):
- """Repository {} does not exist."""
- class AlreadyExists(Error):
- """Repository {} already exists."""
- class InvalidRepository(Error):
- """{} is not a valid repository. Check repo config."""
- class CheckNeeded(ErrorWithTraceback):
- """Inconsistency detected. Please run "borg check {}"."""
- class ObjectNotFound(ErrorWithTraceback):
- """Object with key {} not found in repository {}."""
- def __init__(self, path, create=False, exclusive=False, lock_wait=None, lock=True, append_only=False):
- self.path = os.path.abspath(path)
- self._location = Location('file://%s' % self.path)
- self.io = None
- self.lock = None
- self.index = None
- self._active_txn = False
- self.lock_wait = lock_wait
- self.do_lock = lock
- self.do_create = create
- self.exclusive = exclusive
- self.append_only = append_only
- def __del__(self):
- if self.lock:
- self.close()
- assert False, "cleanup happened in Repository.__del__"
- def __repr__(self):
- return '<%s %s>' % (self.__class__.__name__, self.path)
- def __enter__(self):
- if self.do_create:
- self.do_create = False
- self.create(self.path)
- self.open(self.path, bool(self.exclusive), lock_wait=self.lock_wait, lock=self.do_lock)
- return self
- def __exit__(self, exc_type, exc_val, exc_tb):
- if exc_type is not None:
- no_space_left_on_device = exc_type is OSError and exc_val.errno == errno.ENOSPC
- # The ENOSPC could have originated somewhere else besides the Repository. The cleanup is always safe, unless
- # EIO or FS corruption ensues, which is why we specifically check for ENOSPC.
- if self._active_txn and no_space_left_on_device:
- logger.warning('No space left on device, cleaning up partial transaction to free space.')
- self.io.cleanup(self.io.get_segments_transaction_id())
- self.rollback()
- self.close()
- def create(self, path):
- """Create a new empty repository at `path`
- """
- if os.path.exists(path) and (not os.path.isdir(path) or os.listdir(path)):
- raise self.AlreadyExists(path)
- if not os.path.exists(path):
- os.mkdir(path)
- with open(os.path.join(path, 'README'), 'w') as fd:
- fd.write('This is a Borg repository\n')
- os.mkdir(os.path.join(path, 'data'))
- config = ConfigParser(interpolation=None)
- config.add_section('repository')
- config.set('repository', 'version', '1')
- config.set('repository', 'segments_per_dir', str(self.DEFAULT_SEGMENTS_PER_DIR))
- config.set('repository', 'max_segment_size', str(self.DEFAULT_MAX_SEGMENT_SIZE))
- config.set('repository', 'append_only', str(int(self.append_only)))
- config.set('repository', 'id', bin_to_hex(os.urandom(32)))
- self.save_config(path, config)
- def save_config(self, path, config):
- config_path = os.path.join(path, 'config')
- with open(config_path, 'w') as fd:
- config.write(fd)
- def save_key(self, keydata):
- assert self.config
- keydata = keydata.decode('utf-8') # remote repo: msgpack issue #99, getting bytes
- self.config.set('repository', 'key', keydata)
- self.save_config(self.path, self.config)
- def load_key(self):
- keydata = self.config.get('repository', 'key')
- return keydata.encode('utf-8') # remote repo: msgpack issue #99, returning bytes
- def destroy(self):
- """Destroy the repository at `self.path`
- """
- if self.append_only:
- raise ValueError(self.path + " is in append-only mode")
- self.close()
- os.remove(os.path.join(self.path, 'config')) # kill config first
- shutil.rmtree(self.path)
- def get_index_transaction_id(self):
- indices = sorted(int(fn[6:])
- for fn in os.listdir(self.path)
- if fn.startswith('index.') and fn[6:].isdigit() and os.stat(os.path.join(self.path, fn)).st_size != 0)
- if indices:
- return indices[-1]
- else:
- return None
- def get_transaction_id(self):
- index_transaction_id = self.get_index_transaction_id()
- segments_transaction_id = self.io.get_segments_transaction_id()
- if index_transaction_id is not None and segments_transaction_id is None:
- raise self.CheckNeeded(self.path)
- # Attempt to automatically rebuild index if we crashed between commit
- # tag write and index save
- if index_transaction_id != segments_transaction_id:
- if index_transaction_id is not None and index_transaction_id > segments_transaction_id:
- replay_from = None
- else:
- replay_from = index_transaction_id
- self.replay_segments(replay_from, segments_transaction_id)
- return self.get_index_transaction_id()
- def break_lock(self):
- Lock(os.path.join(self.path, 'lock')).break_lock()
- def open(self, path, exclusive, lock_wait=None, lock=True):
- self.path = path
- if not os.path.isdir(path):
- raise self.DoesNotExist(path)
- if lock:
- self.lock = Lock(os.path.join(path, 'lock'), exclusive, timeout=lock_wait).acquire()
- else:
- self.lock = None
- self.config = ConfigParser(interpolation=None)
- self.config.read(os.path.join(self.path, 'config'))
- if 'repository' not in self.config.sections() or self.config.getint('repository', 'version') != 1:
- self.close()
- raise self.InvalidRepository(path)
- self.max_segment_size = self.config.getint('repository', 'max_segment_size')
- self.segments_per_dir = self.config.getint('repository', 'segments_per_dir')
- # append_only can be set in the constructor
- # it shouldn't be overridden (True -> False) here
- self.append_only = self.append_only or self.config.getboolean('repository', 'append_only', fallback=False)
- self.id = unhexlify(self.config.get('repository', 'id').strip())
- self.io = LoggedIO(self.path, self.max_segment_size, self.segments_per_dir)
- def close(self):
- if self.lock:
- if self.io:
- self.io.close()
- self.io = None
- self.lock.release()
- self.lock = None
- def commit(self, save_space=False):
- """Commit transaction
- """
- self.io.write_commit()
- if not self.append_only:
- self.compact_segments(save_space=save_space)
- self.write_index()
- self.rollback()
- def open_index(self, transaction_id):
- if transaction_id is None:
- return NSIndex()
- return NSIndex.read((os.path.join(self.path, 'index.%d') % transaction_id).encode('utf-8'))
- def prepare_txn(self, transaction_id, do_cleanup=True):
- self._active_txn = True
- if not self.lock.got_exclusive_lock():
- if self.exclusive is not None:
- # self.exclusive is either True or False, thus a new client is active here.
- # if it is False and we get here, the caller did not use exclusive=True although
- # it is needed for a write operation. if it is True and we get here, something else
- # went very wrong, because we should have a exclusive lock, but we don't.
- raise AssertionError("bug in code, exclusive lock should exist here")
- # if we are here, this is an old client talking to a new server (expecting lock upgrade).
- # or we are replaying segments and might need a lock upgrade for that.
- try:
- self.lock.upgrade()
- except (LockError, LockErrorT):
- # if upgrading the lock to exclusive fails, we do not have an
- # active transaction. this is important for "serve" mode, where
- # the repository instance lives on - even if exceptions happened.
- self._active_txn = False
- raise
- if not self.index or transaction_id is None:
- self.index = self.open_index(transaction_id)
- if transaction_id is None:
- self.segments = {} # XXX bad name: usage_count_of_segment_x = self.segments[x]
- self.compact = set() # XXX bad name: segments_needing_compaction = self.compact
- else:
- if do_cleanup:
- self.io.cleanup(transaction_id)
- with open(os.path.join(self.path, 'hints.%d' % transaction_id), 'rb') as fd:
- hints = msgpack.unpack(fd)
- hints_version = hints[b'version']
- if hints_version not in (1, 2):
- raise ValueError('Unknown hints file version: %d' % hints_version)
- self.segments = hints[b'segments']
- if hints_version == 1:
- self.compact = set(hints[b'compact'])
- elif hints_version == 2:
- self.compact = set(hints[b'compact'].keys())
- def write_index(self):
- hints = {b'version': 1,
- b'segments': self.segments,
- b'compact': list(self.compact)}
- transaction_id = self.io.get_segments_transaction_id()
- assert transaction_id is not None
- hints_file = os.path.join(self.path, 'hints.%d' % transaction_id)
- with open(hints_file + '.tmp', 'wb') as fd:
- msgpack.pack(hints, fd)
- fd.flush()
- os.fsync(fd.fileno())
- os.rename(hints_file + '.tmp', hints_file)
- self.index.write(os.path.join(self.path, 'index.tmp'))
- os.rename(os.path.join(self.path, 'index.tmp'),
- os.path.join(self.path, 'index.%d' % transaction_id))
- if self.append_only:
- with open(os.path.join(self.path, 'transactions'), 'a') as log:
- print('transaction %d, UTC time %s' % (transaction_id, datetime.utcnow().isoformat()), file=log)
- # Remove old indices
- current = '.%d' % transaction_id
- for name in os.listdir(self.path):
- if not name.startswith('index.') and not name.startswith('hints.'):
- continue
- if name.endswith(current):
- continue
- os.unlink(os.path.join(self.path, name))
- self.index = None
- def compact_segments(self, save_space=False):
- """Compact sparse segments by copying data into new segments
- """
- if not self.compact:
- return
- index_transaction_id = self.get_index_transaction_id()
- segments = self.segments
- unused = [] # list of segments, that are not used anymore
- def complete_xfer():
- # complete the transfer (usually exactly when some target segment
- # is full, or at the very end when everything is processed)
- nonlocal unused
- # commit the new, compact, used segments
- self.io.write_commit()
- # get rid of the old, sparse, unused segments. free space.
- for segment in unused:
- assert self.segments.pop(segment) == 0
- self.io.delete_segment(segment)
- unused = []
- # The first segment compaction creates, if any
- first_new_segment = self.io.get_latest_segment() + 1
- for segment in sorted(self.compact):
- if self.io.segment_exists(segment):
- for tag, key, offset, data in self.io.iter_objects(segment, include_data=True):
- if tag == TAG_PUT and self.index.get(key, (-1, -1)) == (segment, offset):
- try:
- new_segment, offset = self.io.write_put(key, data, raise_full=save_space)
- except LoggedIO.SegmentFull:
- complete_xfer()
- new_segment, offset = self.io.write_put(key, data)
- self.index[key] = new_segment, offset
- segments.setdefault(new_segment, 0)
- segments[new_segment] += 1
- segments[segment] -= 1
- elif tag == TAG_DELETE:
- if index_transaction_id is None or segment > index_transaction_id:
- # (introduced in 6425d16aa84be1eaaf88)
- # This is needed to avoid object un-deletion if we crash between the commit and the deletion
- # of old segments in complete_xfer().
- #
- # However, this only happens if the crash also affects the FS to the effect that file deletions
- # did not materialize consistently after journal recovery. If they always materialize in-order
- # then this is not a problem, because the old segment containing a deleted object would be deleted
- # before the segment containing the delete.
- #
- # Consider the following series of operations if we would not do this, ie. this entire if:
- # would be removed.
- # Columns are segments, lines are different keys (line 1 = some key, line 2 = some other key)
- # Legend: P=TAG_PUT, D=TAG_DELETE, c=commit, i=index is written for latest commit
- #
- # Segment | 1 | 2 | 3
- # --------+-------+-----+------
- # Key 1 | P | D |
- # Key 2 | P | | P
- # commits | c i | c | c i
- # --------+-------+-----+------
- # ^- compact_segments starts
- # ^- complete_xfer commits, after that complete_xfer deletes
- # segments 1 and 2 (and then the index would be written).
- #
- # Now we crash. But only segment 2 gets deleted, while segment 1 is still around. Now key 1
- # is suddenly undeleted (because the delete in segment 2 is now missing).
- # Again, note the requirement here. We delete these in the correct order that this doesn't happen,
- # and only if the FS materialization of these deletes is reordered or parts dropped this can happen.
- # In this case it doesn't cause outright corruption, 'just' an index count mismatch, which will be
- # fixed by borg-check --repair.
- #
- # Note that in this check the index state is the proxy for a "most definitely settled" repository state,
- # ie. the assumption is that *all* operations on segments <= index state are completed and stable.
- try:
- new_segment = self.io.write_delete(key, raise_full=save_space)
- except LoggedIO.SegmentFull:
- complete_xfer()
- new_segment = self.io.write_delete(key)
- self.compact.add(new_segment)
- self.segments.setdefault(new_segment, 0)
- assert segments[segment] == 0
- unused.append(segment)
- complete_xfer()
- # Moving of deletes creates new sparse segments, only store these. All other segments
- # are compact now.
- self.compact = {segment for segment in self.compact if segment >= first_new_segment}
- def replay_segments(self, index_transaction_id, segments_transaction_id):
- # fake an old client, so that in case we do not have an exclusive lock yet, prepare_txn will upgrade the lock:
- remember_exclusive = self.exclusive
- self.exclusive = None
- self.prepare_txn(index_transaction_id, do_cleanup=False)
- try:
- segment_count = sum(1 for _ in self.io.segment_iterator())
- pi = ProgressIndicatorPercent(total=segment_count, msg="Replaying segments %3.0f%%", same_line=True)
- for i, (segment, filename) in enumerate(self.io.segment_iterator()):
- pi.show(i)
- if index_transaction_id is not None and segment <= index_transaction_id:
- continue
- if segment > segments_transaction_id:
- break
- objects = self.io.iter_objects(segment)
- self._update_index(segment, objects)
- pi.finish()
- self.write_index()
- finally:
- self.exclusive = remember_exclusive
- self.rollback()
- def _update_index(self, segment, objects, report=None):
- """some code shared between replay_segments and check"""
- self.segments[segment] = 0
- for tag, key, offset in objects:
- if tag == TAG_PUT:
- try:
- s, _ = self.index[key]
- self.compact.add(s)
- self.segments[s] -= 1
- except KeyError:
- pass
- self.index[key] = segment, offset
- self.segments[segment] += 1
- elif tag == TAG_DELETE:
- try:
- s, _ = self.index.pop(key)
- self.segments[s] -= 1
- self.compact.add(s)
- except KeyError:
- pass
- self.compact.add(segment)
- elif tag == TAG_COMMIT:
- continue
- else:
- msg = 'Unexpected tag {} in segment {}'.format(tag, segment)
- if report is None:
- raise self.CheckNeeded(msg)
- else:
- report(msg)
- if self.segments[segment] == 0:
- self.compact.add(segment)
- def check(self, repair=False, save_space=False):
- """Check repository consistency
- This method verifies all segment checksums and makes sure
- the index is consistent with the data stored in the segments.
- """
- if self.append_only and repair:
- raise ValueError(self.path + " is in append-only mode")
- error_found = False
- def report_error(msg):
- nonlocal error_found
- error_found = True
- logger.error(msg)
- logger.info('Starting repository check')
- assert not self._active_txn
- try:
- transaction_id = self.get_transaction_id()
- current_index = self.open_index(transaction_id)
- except Exception:
- transaction_id = self.io.get_segments_transaction_id()
- current_index = None
- if transaction_id is None:
- transaction_id = self.get_index_transaction_id()
- if transaction_id is None:
- transaction_id = self.io.get_latest_segment()
- if repair:
- self.io.cleanup(transaction_id)
- segments_transaction_id = self.io.get_segments_transaction_id()
- self.prepare_txn(None) # self.index, self.compact, self.segments all empty now!
- segment_count = sum(1 for _ in self.io.segment_iterator())
- pi = ProgressIndicatorPercent(total=segment_count, msg="Checking segments %3.1f%%", step=0.1, same_line=True)
- for i, (segment, filename) in enumerate(self.io.segment_iterator()):
- pi.show(i)
- if segment > transaction_id:
- continue
- try:
- objects = list(self.io.iter_objects(segment))
- except IntegrityError as err:
- report_error(str(err))
- objects = []
- if repair:
- self.io.recover_segment(segment, filename)
- objects = list(self.io.iter_objects(segment))
- self._update_index(segment, objects, report_error)
- pi.finish()
- # self.index, self.segments, self.compact now reflect the state of the segment files up to <transaction_id>
- # We might need to add a commit tag if no committed segment is found
- if repair and segments_transaction_id is None:
- report_error('Adding commit tag to segment {}'.format(transaction_id))
- self.io.segment = transaction_id + 1
- self.io.write_commit()
- if current_index and not repair:
- # current_index = "as found on disk"
- # self.index = "as rebuilt in-memory from segments"
- if len(current_index) != len(self.index):
- report_error('Index object count mismatch. {} != {}'.format(len(current_index), len(self.index)))
- elif current_index:
- for key, value in self.index.iteritems():
- if current_index.get(key, (-1, -1)) != value:
- report_error('Index mismatch for key {}. {} != {}'.format(key, value, current_index.get(key, (-1, -1))))
- if repair:
- self.compact_segments(save_space=save_space)
- self.write_index()
- self.rollback()
- if error_found:
- if repair:
- logger.info('Completed repository check, errors found and repaired.')
- else:
- logger.error('Completed repository check, errors found.')
- else:
- logger.info('Completed repository check, no problems found.')
- return not error_found or repair
- def rollback(self):
- """
- """
- self.index = None
- self._active_txn = False
- def __len__(self):
- if not self.index:
- self.index = self.open_index(self.get_transaction_id())
- return len(self.index)
- def __contains__(self, id):
- if not self.index:
- self.index = self.open_index(self.get_transaction_id())
- return id in self.index
- def list(self, limit=None, marker=None):
- if not self.index:
- self.index = self.open_index(self.get_transaction_id())
- return [id_ for id_, _ in islice(self.index.iteritems(marker=marker), limit)]
- def get(self, id_):
- if not self.index:
- self.index = self.open_index(self.get_transaction_id())
- try:
- segment, offset = self.index[id_]
- return self.io.read(segment, offset, id_)
- except KeyError:
- raise self.ObjectNotFound(id_, self.path) from None
- def get_many(self, ids, is_preloaded=False):
- for id_ in ids:
- yield self.get(id_)
- def put(self, id, data, wait=True):
- if not self._active_txn:
- self.prepare_txn(self.get_transaction_id())
- try:
- segment, _ = self.index[id]
- self.segments[segment] -= 1
- self.compact.add(segment)
- segment = self.io.write_delete(id)
- self.segments.setdefault(segment, 0)
- self.compact.add(segment)
- except KeyError:
- pass
- segment, offset = self.io.write_put(id, data)
- self.segments.setdefault(segment, 0)
- self.segments[segment] += 1
- self.index[id] = segment, offset
- def delete(self, id, wait=True):
- if not self._active_txn:
- self.prepare_txn(self.get_transaction_id())
- try:
- segment, offset = self.index.pop(id)
- except KeyError:
- raise self.ObjectNotFound(id, self.path) from None
- self.segments[segment] -= 1
- self.compact.add(segment)
- segment = self.io.write_delete(id)
- self.compact.add(segment)
- self.segments.setdefault(segment, 0)
- def preload(self, ids):
- """Preload objects (only applies to remote repositories)
- """
- class LoggedIO:
- class SegmentFull(Exception):
- """raised when a segment is full, before opening next"""
- header_fmt = struct.Struct('<IIB')
- assert header_fmt.size == 9
- put_header_fmt = struct.Struct('<IIB32s')
- assert put_header_fmt.size == 41
- header_no_crc_fmt = struct.Struct('<IB')
- assert header_no_crc_fmt.size == 5
- crc_fmt = struct.Struct('<I')
- assert crc_fmt.size == 4
- _commit = header_no_crc_fmt.pack(9, TAG_COMMIT)
- COMMIT = crc_fmt.pack(crc32(_commit)) + _commit
- def __init__(self, path, limit, segments_per_dir, capacity=90):
- self.path = path
- self.fds = LRUCache(capacity,
- dispose=lambda fd: fd.close())
- self.segment = 0
- self.limit = limit
- self.segments_per_dir = segments_per_dir
- self.offset = 0
- self._write_fd = None
- def close(self):
- self.close_segment()
- self.fds.clear()
- self.fds = None # Just to make sure we're disabled
- def segment_iterator(self, reverse=False):
- data_path = os.path.join(self.path, 'data')
- dirs = sorted((dir for dir in os.listdir(data_path) if dir.isdigit()), key=int, reverse=reverse)
- for dir in dirs:
- filenames = os.listdir(os.path.join(data_path, dir))
- sorted_filenames = sorted((filename for filename in filenames
- if filename.isdigit()), key=int, reverse=reverse)
- for filename in sorted_filenames:
- yield int(filename), os.path.join(data_path, dir, filename)
- def get_latest_segment(self):
- for segment, filename in self.segment_iterator(reverse=True):
- return segment
- return None
- def get_segments_transaction_id(self):
- """Return last committed segment
- """
- for segment, filename in self.segment_iterator(reverse=True):
- if self.is_committed_segment(segment):
- return segment
- return None
- def cleanup(self, transaction_id):
- """Delete segment files left by aborted transactions
- """
- self.segment = transaction_id + 1
- for segment, filename in self.segment_iterator(reverse=True):
- if segment > transaction_id:
- os.unlink(filename)
- else:
- break
- def is_committed_segment(self, segment):
- """Check if segment ends with a COMMIT_TAG tag
- """
- try:
- iterator = self.iter_objects(segment)
- except IntegrityError:
- return False
- with open(self.segment_filename(segment), 'rb') as fd:
- try:
- fd.seek(-self.header_fmt.size, os.SEEK_END)
- except OSError as e:
- # return False if segment file is empty or too small
- if e.errno == errno.EINVAL:
- return False
- raise e
- if fd.read(self.header_fmt.size) != self.COMMIT:
- return False
- seen_commit = False
- while True:
- try:
- tag, key, offset = next(iterator)
- except IntegrityError:
- return False
- except StopIteration:
- break
- if tag == TAG_COMMIT:
- seen_commit = True
- continue
- if seen_commit:
- return False
- return seen_commit
- def segment_filename(self, segment):
- return os.path.join(self.path, 'data', str(segment // self.segments_per_dir), str(segment))
- def get_write_fd(self, no_new=False, raise_full=False):
- if not no_new and self.offset and self.offset > self.limit:
- if raise_full:
- raise self.SegmentFull
- self.close_segment()
- if not self._write_fd:
- if self.segment % self.segments_per_dir == 0:
- dirname = os.path.join(self.path, 'data', str(self.segment // self.segments_per_dir))
- if not os.path.exists(dirname):
- os.mkdir(dirname)
- sync_dir(os.path.join(self.path, 'data'))
- self._write_fd = open(self.segment_filename(self.segment), 'ab')
- self._write_fd.write(MAGIC)
- self.offset = MAGIC_LEN
- return self._write_fd
- def get_fd(self, segment):
- try:
- return self.fds[segment]
- except KeyError:
- fd = open(self.segment_filename(segment), 'rb')
- self.fds[segment] = fd
- return fd
- def delete_segment(self, segment):
- if segment in self.fds:
- del self.fds[segment]
- try:
- os.unlink(self.segment_filename(segment))
- except FileNotFoundError:
- pass
- def segment_exists(self, segment):
- return os.path.exists(self.segment_filename(segment))
- def iter_objects(self, segment, include_data=False):
- fd = self.get_fd(segment)
- fd.seek(0)
- if fd.read(MAGIC_LEN) != MAGIC:
- raise IntegrityError('Invalid segment magic [segment {}, offset {}]'.format(segment, 0))
- offset = MAGIC_LEN
- header = fd.read(self.header_fmt.size)
- while header:
- size, tag, key, data = self._read(fd, self.header_fmt, header, segment, offset,
- (TAG_PUT, TAG_DELETE, TAG_COMMIT))
- if include_data:
- yield tag, key, offset, data
- else:
- yield tag, key, offset
- offset += size
- # we must get the fd via get_fd() here again as we yielded to our caller and it might
- # have triggered closing of the fd we had before (e.g. by calling io.read() for
- # different segment(s)).
- # by calling get_fd() here again we also make our fd "recently used" so it likely
- # does not get kicked out of self.fds LRUcache.
- fd = self.get_fd(segment)
- fd.seek(offset)
- header = fd.read(self.header_fmt.size)
- def recover_segment(self, segment, filename):
- if segment in self.fds:
- del self.fds[segment]
- with open(filename, 'rb') as fd:
- data = memoryview(fd.read())
- os.rename(filename, filename + '.beforerecover')
- logger.info('attempting to recover ' + filename)
- with open(filename, 'wb') as fd:
- fd.write(MAGIC)
- while len(data) >= self.header_fmt.size:
- crc, size, tag = self.header_fmt.unpack(data[:self.header_fmt.size])
- if size < self.header_fmt.size or size > len(data):
- data = data[1:]
- continue
- if crc32(data[4:size]) & 0xffffffff != crc:
- data = data[1:]
- continue
- fd.write(data[:size])
- data = data[size:]
- def read(self, segment, offset, id):
- if segment == self.segment and self._write_fd:
- self._write_fd.flush()
- fd = self.get_fd(segment)
- fd.seek(offset)
- header = fd.read(self.put_header_fmt.size)
- size, tag, key, data = self._read(fd, self.put_header_fmt, header, segment, offset, (TAG_PUT, ))
- if id != key:
- raise IntegrityError('Invalid segment entry header, is not for wanted id [segment {}, offset {}]'.format(
- segment, offset))
- return data
- def _read(self, fd, fmt, header, segment, offset, acceptable_tags):
- # some code shared by read() and iter_objects()
- try:
- hdr_tuple = fmt.unpack(header)
- except struct.error as err:
- raise IntegrityError('Invalid segment entry header [segment {}, offset {}]: {}'.format(
- segment, offset, err)) from None
- if fmt is self.put_header_fmt:
- crc, size, tag, key = hdr_tuple
- elif fmt is self.header_fmt:
- crc, size, tag = hdr_tuple
- key = None
- else:
- raise TypeError("_read called with unsupported format")
- if size > MAX_OBJECT_SIZE:
- # if you get this on an archive made with borg < 1.0.7 and millions of files and
- # you need to restore it, you can disable this check by using "if False:" above.
- raise IntegrityError('Invalid segment entry size {} - too big [segment {}, offset {}]'.format(
- size, segment, offset))
- if size < fmt.size:
- raise IntegrityError('Invalid segment entry size {} - too small [segment {}, offset {}]'.format(
- size, segment, offset))
- length = size - fmt.size
- data = fd.read(length)
- if len(data) != length:
- raise IntegrityError('Segment entry data short read [segment {}, offset {}]: expected {}, got {} bytes'.format(
- segment, offset, length, len(data)))
- if crc32(data, crc32(memoryview(header)[4:])) & 0xffffffff != crc:
- raise IntegrityError('Segment entry checksum mismatch [segment {}, offset {}]'.format(
- segment, offset))
- if tag not in acceptable_tags:
- raise IntegrityError('Invalid segment entry header, did not get acceptable tag [segment {}, offset {}]'.format(
- segment, offset))
- if key is None and tag in (TAG_PUT, TAG_DELETE):
- key, data = data[:32], data[32:]
- return size, tag, key, data
- def write_put(self, id, data, raise_full=False):
- data_size = len(data)
- if data_size > MAX_DATA_SIZE:
- # this would push the segment entry size beyond MAX_OBJECT_SIZE.
- raise IntegrityError('More than allowed put data [{} > {}]'.format(data_size, MAX_DATA_SIZE))
- fd = self.get_write_fd(raise_full=raise_full)
- size = data_size + self.put_header_fmt.size
- offset = self.offset
- header = self.header_no_crc_fmt.pack(size, TAG_PUT)
- crc = self.crc_fmt.pack(crc32(data, crc32(id, crc32(header))) & 0xffffffff)
- fd.write(b''.join((crc, header, id, data)))
- self.offset += size
- return self.segment, offset
- def write_delete(self, id, raise_full=False):
- fd = self.get_write_fd(raise_full=raise_full)
- header = self.header_no_crc_fmt.pack(self.put_header_fmt.size, TAG_DELETE)
- crc = self.crc_fmt.pack(crc32(id, crc32(header)) & 0xffffffff)
- fd.write(b''.join((crc, header, id)))
- self.offset += self.put_header_fmt.size
- return self.segment
- def write_commit(self):
- fd = self.get_write_fd(no_new=True)
- header = self.header_no_crc_fmt.pack(self.header_fmt.size, TAG_COMMIT)
- crc = self.crc_fmt.pack(crc32(header) & 0xffffffff)
- # first fsync(fd) here (to ensure data supposedly hits the disk before the commit tag)
- fd.flush()
- os.fsync(fd.fileno())
- fd.write(b''.join((crc, header)))
- self.close_segment() # after-commit fsync()
- def close_segment(self):
- if self._write_fd:
- self.segment += 1
- self.offset = 0
- self._write_fd.flush()
- os.fsync(self._write_fd.fileno())
- if hasattr(os, 'posix_fadvise'): # only on UNIX
- # tell the OS that it does not need to cache what we just wrote,
- # avoids spoiling the cache for the OS and other processes.
- os.posix_fadvise(self._write_fd.fileno(), 0, 0, os.POSIX_FADV_DONTNEED)
- self._write_fd.close()
- sync_dir(os.path.dirname(self._write_fd.name))
- self._write_fd = None
- MAX_DATA_SIZE = MAX_OBJECT_SIZE - LoggedIO.put_header_fmt.size
|