| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616261726182619262026212622262326242625262626272628262926302631263226332634263526362637263826392640264126422643264426452646264726482649265026512652265326542655265626572658265926602661266226632664266526662667266826692670267126722673267426752676267726782679268026812682268326842685268626872688268926902691269226932694269526962697269826992700270127022703270427052706270727082709271027112712271327142715271627172718271927202721272227232724272527262727272827292730273127322733273427352736273727382739274027412742274327442745 |
- # object_store.py -- Object store for git objects
- # Copyright (C) 2008-2013 Jelmer Vernooij <jelmer@jelmer.uk>
- # and others
- #
- # SPDX-License-Identifier: Apache-2.0 OR GPL-2.0-or-later
- # Dulwich is dual-licensed under the Apache License, Version 2.0 and the GNU
- # General Public License as published by the Free Software Foundation; version 2.0
- # or (at your option) any later version. You can redistribute it and/or
- # modify it under the terms of either of these two licenses.
- #
- # 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.
- #
- # You should have received a copy of the licenses; if not, see
- # <http://www.gnu.org/licenses/> for a copy of the GNU General Public License
- # and <http://www.apache.org/licenses/LICENSE-2.0> for a copy of the Apache
- # License, Version 2.0.
- #
- """Git object store interfaces and implementation."""
- import binascii
- import os
- import stat
- import sys
- import time
- import warnings
- from collections.abc import Iterable, Iterator, Sequence
- from contextlib import suppress
- from io import BytesIO
- from pathlib import Path
- from typing import (
- TYPE_CHECKING,
- Callable,
- Optional,
- Protocol,
- Union,
- )
- from .errors import NotTreeError
- from .file import GitFile, _GitFile
- from .objects import (
- S_ISGITLINK,
- ZERO_SHA,
- Blob,
- Commit,
- ObjectID,
- ShaFile,
- Tag,
- Tree,
- TreeEntry,
- hex_to_filename,
- hex_to_sha,
- object_class,
- sha_to_hex,
- valid_hexsha,
- )
- from .pack import (
- PACK_SPOOL_FILE_MAX_SIZE,
- ObjectContainer,
- Pack,
- PackData,
- PackedObjectContainer,
- PackFileDisappeared,
- PackHint,
- PackIndexer,
- PackInflater,
- PackStreamCopier,
- UnpackedObject,
- extend_pack,
- full_unpacked_object,
- generate_unpacked_objects,
- iter_sha1,
- load_pack_index_file,
- pack_objects_to_data,
- write_pack_data,
- write_pack_index,
- )
- from .protocol import DEPTH_INFINITE
- from .refs import PEELED_TAG_SUFFIX, Ref
- if TYPE_CHECKING:
- from .commit_graph import CommitGraph
- from .diff_tree import RenameDetector
- class GraphWalker(Protocol):
- """Protocol for graph walker objects."""
- def __next__(self) -> Optional[bytes]:
- """Return the next object SHA to visit."""
- ...
- def ack(self, sha: bytes) -> None:
- """Acknowledge that an object has been received."""
- ...
- INFODIR = "info"
- PACKDIR = "pack"
- # use permissions consistent with Git; just readable by everyone
- # TODO: should packs also be non-writable on Windows? if so, that
- # would requite some rather significant adjustments to the test suite
- PACK_MODE = 0o444 if sys.platform != "win32" else 0o644
- # Grace period for cleaning up temporary pack files (in seconds)
- # Matches git's default of 2 weeks
- DEFAULT_TEMPFILE_GRACE_PERIOD = 14 * 24 * 60 * 60 # 2 weeks
- def find_shallow(
- store: ObjectContainer, heads: Iterable[bytes], depth: int
- ) -> tuple[set[bytes], set[bytes]]:
- """Find shallow commits according to a given depth.
- Args:
- store: An ObjectStore for looking up objects.
- heads: Iterable of head SHAs to start walking from.
- depth: The depth of ancestors to include. A depth of one includes
- only the heads themselves.
- Returns: A tuple of (shallow, not_shallow), sets of SHAs that should be
- considered shallow and unshallow according to the arguments. Note that
- these sets may overlap if a commit is reachable along multiple paths.
- """
- parents: dict[bytes, list[bytes]] = {}
- commit_graph = store.get_commit_graph()
- def get_parents(sha: bytes) -> list[bytes]:
- result = parents.get(sha, None)
- if not result:
- # Try to use commit graph first if available
- if commit_graph:
- graph_parents = commit_graph.get_parents(sha)
- if graph_parents is not None:
- result = graph_parents
- parents[sha] = result
- return result
- # Fall back to loading the object
- commit = store[sha]
- assert isinstance(commit, Commit)
- result = commit.parents
- parents[sha] = result
- return result
- todo = [] # stack of (sha, depth)
- for head_sha in heads:
- obj = store[head_sha]
- # Peel tags if necessary
- while isinstance(obj, Tag):
- _, sha = obj.object
- obj = store[sha]
- if isinstance(obj, Commit):
- todo.append((obj.id, 1))
- not_shallow = set()
- shallow = set()
- while todo:
- sha, cur_depth = todo.pop()
- if cur_depth < depth:
- not_shallow.add(sha)
- new_depth = cur_depth + 1
- todo.extend((p, new_depth) for p in get_parents(sha))
- else:
- shallow.add(sha)
- return shallow, not_shallow
- def get_depth(
- store: ObjectContainer,
- head: bytes,
- get_parents: Callable = lambda commit: commit.parents,
- max_depth: Optional[int] = None,
- ) -> int:
- """Return the current available depth for the given head.
- For commits with multiple parents, the largest possible depth will be
- returned.
- Args:
- store: Object store to search in
- head: commit to start from
- get_parents: optional function for getting the parents of a commit
- max_depth: maximum depth to search
- """
- if head not in store:
- return 0
- current_depth = 1
- queue = [(head, current_depth)]
- commit_graph = store.get_commit_graph()
- while queue and (max_depth is None or current_depth < max_depth):
- e, depth = queue.pop(0)
- current_depth = max(current_depth, depth)
- # Try to use commit graph for parent lookup if available
- parents = None
- if commit_graph:
- parents = commit_graph.get_parents(e)
- if parents is None:
- # Fall back to loading the object
- cmt = store[e]
- if isinstance(cmt, Tag):
- _cls, sha = cmt.object
- cmt = store[sha]
- parents = get_parents(cmt)
- queue.extend((parent, depth + 1) for parent in parents if parent in store)
- return current_depth
- class PackContainer(Protocol):
- """Protocol for containers that can accept pack files."""
- def add_pack(self) -> tuple[BytesIO, Callable[[], None], Callable[[], None]]:
- """Add a new pack."""
- class BaseObjectStore:
- """Object store interface."""
- def determine_wants_all(
- self, refs: dict[Ref, ObjectID], depth: Optional[int] = None
- ) -> list[ObjectID]:
- """Determine which objects are wanted based on refs."""
- def _want_deepen(sha: bytes) -> bool:
- if not depth:
- return False
- if depth == DEPTH_INFINITE:
- return True
- return depth > self._get_depth(sha)
- return [
- sha
- for (ref, sha) in refs.items()
- if (sha not in self or _want_deepen(sha))
- and not ref.endswith(PEELED_TAG_SUFFIX)
- and not sha == ZERO_SHA
- ]
- def contains_loose(self, sha: bytes) -> bool:
- """Check if a particular object is present by SHA1 and is loose."""
- raise NotImplementedError(self.contains_loose)
- def __contains__(self, sha1: bytes) -> bool:
- """Check if a particular object is present by SHA1.
- This method makes no distinction between loose and packed objects.
- """
- return self.contains_loose(sha1)
- @property
- def packs(self) -> list[Pack]:
- """Iterable of pack objects."""
- raise NotImplementedError
- def get_raw(self, name: bytes) -> tuple[int, bytes]:
- """Obtain the raw text for an object.
- Args:
- name: sha for the object.
- Returns: tuple with numeric type and object contents.
- """
- raise NotImplementedError(self.get_raw)
- def __getitem__(self, sha1: ObjectID) -> ShaFile:
- """Obtain an object by SHA1."""
- type_num, uncomp = self.get_raw(sha1)
- return ShaFile.from_raw_string(type_num, uncomp, sha=sha1)
- def __iter__(self) -> Iterator[bytes]:
- """Iterate over the SHAs that are present in this store."""
- raise NotImplementedError(self.__iter__)
- def add_object(self, obj: ShaFile) -> None:
- """Add a single object to this object store."""
- raise NotImplementedError(self.add_object)
- def add_objects(
- self,
- objects: Sequence[tuple[ShaFile, Optional[str]]],
- progress: Optional[Callable] = None,
- ) -> Optional["Pack"]:
- """Add a set of objects to this object store.
- Args:
- objects: Iterable over a list of (object, path) tuples
- progress: Optional progress callback
- """
- raise NotImplementedError(self.add_objects)
- def tree_changes(
- self,
- source: Optional[bytes],
- target: Optional[bytes],
- want_unchanged: bool = False,
- include_trees: bool = False,
- change_type_same: bool = False,
- rename_detector: Optional["RenameDetector"] = None,
- paths: Optional[list[bytes]] = None,
- ) -> Iterator[
- tuple[
- tuple[Optional[bytes], Optional[bytes]],
- tuple[Optional[int], Optional[int]],
- tuple[Optional[bytes], Optional[bytes]],
- ]
- ]:
- """Find the differences between the contents of two trees.
- Args:
- source: SHA1 of the source tree
- target: SHA1 of the target tree
- want_unchanged: Whether unchanged files should be reported
- include_trees: Whether to include trees
- change_type_same: Whether to report files changing
- type in the same entry.
- rename_detector: RenameDetector object for detecting renames.
- paths: Optional list of paths to filter to (as bytes).
- Returns: Iterator over tuples with
- (oldpath, newpath), (oldmode, newmode), (oldsha, newsha)
- """
- from .diff_tree import tree_changes
- for change in tree_changes(
- self,
- source,
- target,
- want_unchanged=want_unchanged,
- include_trees=include_trees,
- change_type_same=change_type_same,
- rename_detector=rename_detector,
- paths=paths,
- ):
- yield (
- (change.old.path, change.new.path),
- (change.old.mode, change.new.mode),
- (change.old.sha, change.new.sha),
- )
- def iter_tree_contents(
- self, tree_id: bytes, include_trees: bool = False
- ) -> Iterator[tuple[bytes, int, bytes]]:
- """Iterate the contents of a tree and all subtrees.
- Iteration is depth-first pre-order, as in e.g. os.walk.
- Args:
- tree_id: SHA1 of the tree.
- include_trees: If True, include tree objects in the iteration.
- Returns: Iterator over TreeEntry namedtuples for all the objects in a
- tree.
- """
- warnings.warn(
- "Please use dulwich.object_store.iter_tree_contents",
- DeprecationWarning,
- stacklevel=2,
- )
- return iter_tree_contents(self, tree_id, include_trees=include_trees)
- def iterobjects_subset(
- self, shas: Iterable[bytes], *, allow_missing: bool = False
- ) -> Iterator[ShaFile]:
- """Iterate over a subset of objects in the store.
- Args:
- shas: Iterable of object SHAs to retrieve
- allow_missing: If True, skip missing objects; if False, raise KeyError
- Returns:
- Iterator of ShaFile objects
- Raises:
- KeyError: If an object is missing and allow_missing is False
- """
- for sha in shas:
- try:
- yield self[sha]
- except KeyError:
- if not allow_missing:
- raise
- def find_missing_objects(
- self,
- haves: Iterable[bytes],
- wants: Iterable[bytes],
- shallow: Optional[set[bytes]] = None,
- progress: Optional[Callable] = None,
- get_tagged: Optional[Callable] = None,
- get_parents: Callable = lambda commit: commit.parents,
- ) -> Iterator[tuple[bytes, Optional[bytes]]]:
- """Find the missing objects required for a set of revisions.
- Args:
- haves: Iterable over SHAs already in common.
- wants: Iterable over SHAs of objects to fetch.
- shallow: Set of shallow commit SHA1s to skip
- progress: Simple progress function that will be called with
- updated progress strings.
- get_tagged: Function that returns a dict of pointed-to sha ->
- tag sha for including tags.
- get_parents: Optional function for getting the parents of a
- commit.
- Returns: Iterator over (sha, path) pairs.
- """
- warnings.warn("Please use MissingObjectFinder(store)", DeprecationWarning)
- finder = MissingObjectFinder(
- self,
- haves=haves,
- wants=wants,
- shallow=shallow,
- progress=progress,
- get_tagged=get_tagged,
- get_parents=get_parents,
- )
- return iter(finder)
- def find_common_revisions(self, graphwalker: GraphWalker) -> list[bytes]:
- """Find which revisions this store has in common using graphwalker.
- Args:
- graphwalker: A graphwalker object.
- Returns: List of SHAs that are in common
- """
- haves = []
- sha = next(graphwalker)
- while sha:
- if sha in self:
- haves.append(sha)
- graphwalker.ack(sha)
- sha = next(graphwalker)
- return haves
- def generate_pack_data(
- self,
- have: Iterable[bytes],
- want: Iterable[bytes],
- shallow: Optional[set[bytes]] = None,
- progress: Optional[Callable] = None,
- ofs_delta: bool = True,
- ) -> tuple[int, Iterator[UnpackedObject]]:
- """Generate pack data objects for a set of wants/haves.
- Args:
- have: List of SHA1s of objects that should not be sent
- want: List of SHA1s of objects that should be sent
- shallow: Set of shallow commit SHA1s to skip
- ofs_delta: Whether OFS deltas can be included
- progress: Optional progress reporting method
- """
- # Note that the pack-specific implementation below is more efficient,
- # as it reuses deltas
- missing_objects = MissingObjectFinder(
- self, haves=have, wants=want, shallow=shallow, progress=progress
- )
- object_ids = list(missing_objects)
- return pack_objects_to_data(
- [(self[oid], path) for oid, path in object_ids],
- ofs_delta=ofs_delta,
- progress=progress,
- )
- def peel_sha(self, sha: bytes) -> bytes:
- """Peel all tags from a SHA.
- Args:
- sha: The object SHA to peel.
- Returns: The fully-peeled SHA1 of a tag object, after peeling all
- intermediate tags; if the original ref does not point to a tag,
- this will equal the original SHA1.
- """
- warnings.warn(
- "Please use dulwich.object_store.peel_sha()",
- DeprecationWarning,
- stacklevel=2,
- )
- return peel_sha(self, sha)[1].id
- def _get_depth(
- self,
- head: bytes,
- get_parents: Callable = lambda commit: commit.parents,
- max_depth: Optional[int] = None,
- ) -> int:
- """Return the current available depth for the given head.
- For commits with multiple parents, the largest possible depth will be
- returned.
- Args:
- head: commit to start from
- get_parents: optional function for getting the parents of a commit
- max_depth: maximum depth to search
- """
- return get_depth(self, head, get_parents=get_parents, max_depth=max_depth)
- def close(self) -> None:
- """Close any files opened by this object store."""
- # Default implementation is a NO-OP
- def prune(self, grace_period: Optional[int] = None) -> None:
- """Prune/clean up this object store.
- This includes removing orphaned temporary files and other
- housekeeping tasks. Default implementation is a NO-OP.
- Args:
- grace_period: Grace period in seconds for removing temporary files.
- If None, uses the default grace period.
- """
- # Default implementation is a NO-OP
- def iter_prefix(self, prefix: bytes) -> Iterator[ObjectID]:
- """Iterate over all SHA1s that start with a given prefix.
- The default implementation is a naive iteration over all objects.
- However, subclasses may override this method with more efficient
- implementations.
- """
- for sha in self:
- if sha.startswith(prefix):
- yield sha
- def get_commit_graph(self) -> Optional["CommitGraph"]:
- """Get the commit graph for this object store.
- Returns:
- CommitGraph object if available, None otherwise
- """
- return None
- def write_commit_graph(
- self, refs: Optional[list[bytes]] = None, reachable: bool = True
- ) -> None:
- """Write a commit graph file for this object store.
- Args:
- refs: List of refs to include. If None, includes all refs from object store.
- reachable: If True, includes all commits reachable from refs.
- If False, only includes the direct ref targets.
- Note:
- Default implementation does nothing. Subclasses should override
- this method to provide commit graph writing functionality.
- """
- raise NotImplementedError(self.write_commit_graph)
- def get_object_mtime(self, sha: bytes) -> float:
- """Get the modification time of an object.
- Args:
- sha: SHA1 of the object
- Returns:
- Modification time as seconds since epoch
- Raises:
- KeyError: if the object is not found
- """
- # Default implementation raises KeyError
- # Subclasses should override to provide actual mtime
- raise KeyError(sha)
- class PackBasedObjectStore(BaseObjectStore, PackedObjectContainer):
- """Object store that uses pack files for storage.
- This class provides a base implementation for object stores that use
- Git pack files as their primary storage mechanism. It handles caching
- of open pack files and provides configuration for pack file operations.
- """
- def __init__(
- self,
- pack_compression_level: int = -1,
- pack_index_version: Optional[int] = None,
- pack_delta_window_size: Optional[int] = None,
- pack_window_memory: Optional[int] = None,
- pack_delta_cache_size: Optional[int] = None,
- pack_depth: Optional[int] = None,
- pack_threads: Optional[int] = None,
- pack_big_file_threshold: Optional[int] = None,
- ) -> None:
- """Initialize a PackBasedObjectStore.
- Args:
- pack_compression_level: Compression level for pack files (-1 to 9)
- pack_index_version: Pack index version to use
- pack_delta_window_size: Window size for delta compression
- pack_window_memory: Maximum memory to use for delta window
- pack_delta_cache_size: Cache size for delta operations
- pack_depth: Maximum depth for pack deltas
- pack_threads: Number of threads to use for packing
- pack_big_file_threshold: Threshold for treating files as "big"
- """
- self._pack_cache: dict[str, Pack] = {}
- self.pack_compression_level = pack_compression_level
- self.pack_index_version = pack_index_version
- self.pack_delta_window_size = pack_delta_window_size
- self.pack_window_memory = pack_window_memory
- self.pack_delta_cache_size = pack_delta_cache_size
- self.pack_depth = pack_depth
- self.pack_threads = pack_threads
- self.pack_big_file_threshold = pack_big_file_threshold
- def add_pack(self) -> tuple[BytesIO, Callable[[], None], Callable[[], None]]:
- """Add a new pack to this object store."""
- raise NotImplementedError(self.add_pack)
- def add_pack_data(
- self,
- count: int,
- unpacked_objects: Iterator[UnpackedObject],
- progress: Optional[Callable] = None,
- ) -> Optional["Pack"]:
- """Add pack data to this object store.
- Args:
- count: Number of items to add
- unpacked_objects: Iterator of UnpackedObject instances
- progress: Optional progress callback
- """
- if count == 0:
- # Don't bother writing an empty pack file
- return None
- f, commit, abort = self.add_pack()
- try:
- write_pack_data(
- f.write,
- unpacked_objects,
- num_records=count,
- progress=progress,
- compression_level=self.pack_compression_level,
- )
- except BaseException:
- abort()
- raise
- else:
- return commit()
- @property
- def alternates(self) -> list:
- """Return list of alternate object stores."""
- return []
- def contains_packed(self, sha: bytes) -> bool:
- """Check if a particular object is present by SHA1 and is packed.
- This does not check alternates.
- """
- for pack in self.packs:
- try:
- if sha in pack:
- return True
- except PackFileDisappeared:
- pass
- return False
- def __contains__(self, sha) -> bool:
- """Check if a particular object is present by SHA1.
- This method makes no distinction between loose and packed objects.
- """
- if self.contains_packed(sha) or self.contains_loose(sha):
- return True
- for alternate in self.alternates:
- if sha in alternate:
- return True
- return False
- def _add_cached_pack(self, base_name: str, pack: Pack) -> None:
- """Add a newly appeared pack to the cache by path."""
- prev_pack = self._pack_cache.get(base_name)
- if prev_pack is not pack:
- self._pack_cache[base_name] = pack
- if prev_pack:
- prev_pack.close()
- def generate_pack_data(
- self, have, want, shallow=None, progress=None, ofs_delta=True
- ) -> tuple[int, Iterator[UnpackedObject]]:
- """Generate pack data objects for a set of wants/haves.
- Args:
- have: List of SHA1s of objects that should not be sent
- want: List of SHA1s of objects that should be sent
- shallow: Set of shallow commit SHA1s to skip
- ofs_delta: Whether OFS deltas can be included
- progress: Optional progress reporting method
- """
- missing_objects = MissingObjectFinder(
- self, haves=have, wants=want, shallow=shallow, progress=progress
- )
- remote_has = missing_objects.get_remote_has()
- object_ids = list(missing_objects)
- return len(object_ids), generate_unpacked_objects(
- self,
- object_ids,
- progress=progress,
- ofs_delta=ofs_delta,
- other_haves=remote_has,
- )
- def _clear_cached_packs(self) -> None:
- pack_cache = self._pack_cache
- self._pack_cache = {}
- while pack_cache:
- (name, pack) = pack_cache.popitem()
- pack.close()
- def _iter_cached_packs(self) -> Iterator[Pack]:
- return iter(self._pack_cache.values())
- def _update_pack_cache(self) -> list[Pack]:
- raise NotImplementedError(self._update_pack_cache)
- def close(self) -> None:
- """Close the object store and release resources.
- This method closes all cached pack files and frees associated resources.
- """
- self._clear_cached_packs()
- @property
- def packs(self) -> list[Pack]:
- """List with pack objects."""
- return list(self._iter_cached_packs()) + list(self._update_pack_cache())
- def count_pack_files(self) -> int:
- """Count the number of pack files.
- Returns:
- Number of pack files (excluding those with .keep files)
- """
- count = 0
- for pack in self.packs:
- # Check if there's a .keep file for this pack
- keep_path = pack._basename + ".keep"
- if not os.path.exists(keep_path):
- count += 1
- return count
- def _iter_alternate_objects(self) -> Iterator[bytes]:
- """Iterate over the SHAs of all the objects in alternate stores."""
- for alternate in self.alternates:
- yield from alternate
- def _iter_loose_objects(self) -> Iterator[bytes]:
- """Iterate over the SHAs of all loose objects."""
- raise NotImplementedError(self._iter_loose_objects)
- def _get_loose_object(self, sha: bytes) -> Optional[ShaFile]:
- raise NotImplementedError(self._get_loose_object)
- def delete_loose_object(self, sha: bytes) -> None:
- """Delete a loose object.
- This method only handles loose objects. For packed objects,
- use repack(exclude=...) to exclude them during repacking.
- """
- raise NotImplementedError(self.delete_loose_object)
- def _remove_pack(self, pack: "Pack") -> None:
- raise NotImplementedError(self._remove_pack)
- def pack_loose_objects(self) -> int:
- """Pack loose objects.
- Returns: Number of objects packed
- """
- objects: list[tuple[ShaFile, None]] = []
- for sha in self._iter_loose_objects():
- obj = self._get_loose_object(sha)
- if obj is not None:
- objects.append((obj, None))
- self.add_objects(objects)
- for obj, path in objects:
- self.delete_loose_object(obj.id)
- return len(objects)
- def repack(self, exclude: Optional[set] = None) -> int:
- """Repack the packs in this repository.
- Note that this implementation is fairly naive and currently keeps all
- objects in memory while it repacks.
- Args:
- exclude: Optional set of object SHAs to exclude from repacking
- """
- if exclude is None:
- exclude = set()
- loose_objects = set()
- excluded_loose_objects = set()
- for sha in self._iter_loose_objects():
- if sha not in exclude:
- obj = self._get_loose_object(sha)
- if obj is not None:
- loose_objects.add(obj)
- else:
- excluded_loose_objects.add(sha)
- objects: set[tuple[ShaFile, None]] = {(obj, None) for obj in loose_objects}
- old_packs = {p.name(): p for p in self.packs}
- for name, pack in old_packs.items():
- objects.update(
- (obj, None) for obj in pack.iterobjects() if obj.id not in exclude
- )
- # Only create a new pack if there are objects to pack
- if objects:
- # The name of the consolidated pack might match the name of a
- # pre-existing pack. Take care not to remove the newly created
- # consolidated pack.
- consolidated = self.add_objects(list(objects))
- if consolidated is not None:
- old_packs.pop(consolidated.name(), None)
- # Delete loose objects that were packed
- for obj in loose_objects:
- if obj is not None:
- self.delete_loose_object(obj.id)
- # Delete excluded loose objects
- for sha in excluded_loose_objects:
- self.delete_loose_object(sha)
- for name, pack in old_packs.items():
- self._remove_pack(pack)
- self._update_pack_cache()
- return len(objects)
- def __iter__(self):
- """Iterate over the SHAs that are present in this store."""
- self._update_pack_cache()
- for pack in self._iter_cached_packs():
- try:
- yield from pack
- except PackFileDisappeared:
- pass
- yield from self._iter_loose_objects()
- yield from self._iter_alternate_objects()
- def contains_loose(self, sha):
- """Check if a particular object is present by SHA1 and is loose.
- This does not check alternates.
- """
- return self._get_loose_object(sha) is not None
- def get_raw(self, name):
- """Obtain the raw fulltext for an object.
- Args:
- name: sha for the object.
- Returns: tuple with numeric type and object contents.
- """
- if name == ZERO_SHA:
- raise KeyError(name)
- if len(name) == 40:
- sha = hex_to_sha(name)
- hexsha = name
- elif len(name) == 20:
- sha = name
- hexsha = None
- else:
- raise AssertionError(f"Invalid object name {name!r}")
- for pack in self._iter_cached_packs():
- try:
- return pack.get_raw(sha)
- except (KeyError, PackFileDisappeared):
- pass
- if hexsha is None:
- hexsha = sha_to_hex(name)
- ret = self._get_loose_object(hexsha)
- if ret is not None:
- return ret.type_num, ret.as_raw_string()
- # Maybe something else has added a pack with the object
- # in the mean time?
- for pack in self._update_pack_cache():
- try:
- return pack.get_raw(sha)
- except KeyError:
- pass
- for alternate in self.alternates:
- try:
- return alternate.get_raw(hexsha)
- except KeyError:
- pass
- raise KeyError(hexsha)
- def iter_unpacked_subset(
- self,
- shas: set[bytes],
- include_comp: bool = False,
- allow_missing: bool = False,
- convert_ofs_delta: bool = True,
- ) -> Iterator[UnpackedObject]:
- """Iterate over a subset of objects, yielding UnpackedObject instances.
- Args:
- shas: Set of object SHAs to retrieve
- include_comp: Whether to include compressed data
- allow_missing: If True, skip missing objects; if False, raise KeyError
- convert_ofs_delta: Whether to convert OFS_DELTA objects
- Returns:
- Iterator of UnpackedObject instances
- Raises:
- KeyError: If an object is missing and allow_missing is False
- """
- todo: set[bytes] = set(shas)
- for p in self._iter_cached_packs():
- for unpacked in p.iter_unpacked_subset(
- todo,
- include_comp=include_comp,
- allow_missing=True,
- convert_ofs_delta=convert_ofs_delta,
- ):
- yield unpacked
- hexsha = sha_to_hex(unpacked.sha())
- todo.remove(hexsha)
- # Maybe something else has added a pack with the object
- # in the mean time?
- for p in self._update_pack_cache():
- for unpacked in p.iter_unpacked_subset(
- todo,
- include_comp=include_comp,
- allow_missing=True,
- convert_ofs_delta=convert_ofs_delta,
- ):
- yield unpacked
- hexsha = sha_to_hex(unpacked.sha())
- todo.remove(hexsha)
- for alternate in self.alternates:
- for unpacked in alternate.iter_unpacked_subset(
- todo,
- include_comp=include_comp,
- allow_missing=True,
- convert_ofs_delta=convert_ofs_delta,
- ):
- yield unpacked
- hexsha = sha_to_hex(unpacked.sha())
- todo.remove(hexsha)
- def iterobjects_subset(
- self, shas: Iterable[bytes], *, allow_missing: bool = False
- ) -> Iterator[ShaFile]:
- """Iterate over a subset of objects in the store.
- This method searches for objects in pack files, alternates, and loose storage.
- Args:
- shas: Iterable of object SHAs to retrieve
- allow_missing: If True, skip missing objects; if False, raise KeyError
- Returns:
- Iterator of ShaFile objects
- Raises:
- KeyError: If an object is missing and allow_missing is False
- """
- todo: set[bytes] = set(shas)
- for p in self._iter_cached_packs():
- for o in p.iterobjects_subset(todo, allow_missing=True):
- yield o
- todo.remove(o.id)
- # Maybe something else has added a pack with the object
- # in the mean time?
- for p in self._update_pack_cache():
- for o in p.iterobjects_subset(todo, allow_missing=True):
- yield o
- todo.remove(o.id)
- for alternate in self.alternates:
- for o in alternate.iterobjects_subset(todo, allow_missing=True):
- yield o
- todo.remove(o.id)
- for oid in todo:
- loose_obj: Optional[ShaFile] = self._get_loose_object(oid)
- if loose_obj is not None:
- yield loose_obj
- elif not allow_missing:
- raise KeyError(oid)
- def get_unpacked_object(
- self, sha1: bytes, *, include_comp: bool = False
- ) -> UnpackedObject:
- """Obtain the unpacked object.
- Args:
- sha1: sha for the object.
- include_comp: Whether to include compression metadata.
- """
- if sha1 == ZERO_SHA:
- raise KeyError(sha1)
- if len(sha1) == 40:
- sha = hex_to_sha(sha1)
- hexsha = sha1
- elif len(sha1) == 20:
- sha = sha1
- hexsha = None
- else:
- raise AssertionError(f"Invalid object sha1 {sha1!r}")
- for pack in self._iter_cached_packs():
- try:
- return pack.get_unpacked_object(sha, include_comp=include_comp)
- except (KeyError, PackFileDisappeared):
- pass
- if hexsha is None:
- hexsha = sha_to_hex(sha1)
- # Maybe something else has added a pack with the object
- # in the mean time?
- for pack in self._update_pack_cache():
- try:
- return pack.get_unpacked_object(sha, include_comp=include_comp)
- except KeyError:
- pass
- for alternate in self.alternates:
- try:
- return alternate.get_unpacked_object(hexsha, include_comp=include_comp)
- except KeyError:
- pass
- raise KeyError(hexsha)
- def add_objects(
- self,
- objects: Sequence[tuple[ShaFile, Optional[str]]],
- progress: Optional[Callable[[str], None]] = None,
- ) -> Optional["Pack"]:
- """Add a set of objects to this object store.
- Args:
- objects: Iterable over (object, path) tuples, should support
- __len__.
- progress: Optional progress reporting function.
- Returns: Pack object of the objects written.
- """
- count = len(objects)
- record_iter = (full_unpacked_object(o) for (o, p) in objects)
- return self.add_pack_data(count, record_iter, progress=progress)
- class DiskObjectStore(PackBasedObjectStore):
- """Git-style object store that exists on disk."""
- path: Union[str, os.PathLike]
- pack_dir: Union[str, os.PathLike]
- _alternates: Optional[list["DiskObjectStore"]]
- _commit_graph: Optional["CommitGraph"]
- def __init__(
- self,
- path: Union[str, os.PathLike],
- loose_compression_level=-1,
- pack_compression_level=-1,
- pack_index_version=None,
- pack_delta_window_size=None,
- pack_window_memory=None,
- pack_delta_cache_size=None,
- pack_depth=None,
- pack_threads=None,
- pack_big_file_threshold=None,
- ) -> None:
- """Open an object store.
- Args:
- path: Path of the object store.
- loose_compression_level: zlib compression level for loose objects
- pack_compression_level: zlib compression level for pack objects
- pack_index_version: pack index version to use (1, 2, or 3)
- pack_delta_window_size: sliding window size for delta compression
- pack_window_memory: memory limit for delta window operations
- pack_delta_cache_size: size of cache for delta operations
- pack_depth: maximum delta chain depth
- pack_threads: number of threads for pack operations
- pack_big_file_threshold: threshold for treating files as big
- """
- super().__init__(
- pack_compression_level=pack_compression_level,
- pack_index_version=pack_index_version,
- pack_delta_window_size=pack_delta_window_size,
- pack_window_memory=pack_window_memory,
- pack_delta_cache_size=pack_delta_cache_size,
- pack_depth=pack_depth,
- pack_threads=pack_threads,
- pack_big_file_threshold=pack_big_file_threshold,
- )
- self.path = path
- self.pack_dir = os.path.join(self.path, PACKDIR)
- self._alternates = None
- self.loose_compression_level = loose_compression_level
- self.pack_compression_level = pack_compression_level
- self.pack_index_version = pack_index_version
- # Commit graph support - lazy loaded
- self._commit_graph = None
- self._use_commit_graph = True # Default to true
- def __repr__(self) -> str:
- """Return string representation of DiskObjectStore.
- Returns:
- String representation including the store path
- """
- return f"<{self.__class__.__name__}({self.path!r})>"
- @classmethod
- def from_config(cls, path: Union[str, os.PathLike], config):
- """Create a DiskObjectStore from a configuration object.
- Args:
- path: Path to the object store directory
- config: Configuration object to read settings from
- Returns:
- New DiskObjectStore instance configured according to config
- """
- try:
- default_compression_level = int(
- config.get((b"core",), b"compression").decode()
- )
- except KeyError:
- default_compression_level = -1
- try:
- loose_compression_level = int(
- config.get((b"core",), b"looseCompression").decode()
- )
- except KeyError:
- loose_compression_level = default_compression_level
- try:
- pack_compression_level = int(
- config.get((b"core",), "packCompression").decode()
- )
- except KeyError:
- pack_compression_level = default_compression_level
- try:
- pack_index_version = int(config.get((b"pack",), b"indexVersion").decode())
- except KeyError:
- pack_index_version = None
- # Read pack configuration options
- try:
- pack_delta_window_size = int(
- config.get((b"pack",), b"deltaWindowSize").decode()
- )
- except KeyError:
- pack_delta_window_size = None
- try:
- pack_window_memory = int(config.get((b"pack",), b"windowMemory").decode())
- except KeyError:
- pack_window_memory = None
- try:
- pack_delta_cache_size = int(
- config.get((b"pack",), b"deltaCacheSize").decode()
- )
- except KeyError:
- pack_delta_cache_size = None
- try:
- pack_depth = int(config.get((b"pack",), b"depth").decode())
- except KeyError:
- pack_depth = None
- try:
- pack_threads = int(config.get((b"pack",), b"threads").decode())
- except KeyError:
- pack_threads = None
- try:
- pack_big_file_threshold = int(
- config.get((b"pack",), b"bigFileThreshold").decode()
- )
- except KeyError:
- pack_big_file_threshold = None
- # Read core.commitGraph setting
- use_commit_graph = config.get_boolean((b"core",), b"commitGraph", True)
- instance = cls(
- path,
- loose_compression_level,
- pack_compression_level,
- pack_index_version,
- pack_delta_window_size,
- pack_window_memory,
- pack_delta_cache_size,
- pack_depth,
- pack_threads,
- pack_big_file_threshold,
- )
- instance._use_commit_graph = use_commit_graph
- return instance
- @property
- def alternates(self):
- """Get the list of alternate object stores.
- Reads from .git/objects/info/alternates if not already cached.
- Returns:
- List of DiskObjectStore instances for alternate object directories
- """
- if self._alternates is not None:
- return self._alternates
- self._alternates = []
- for path in self._read_alternate_paths():
- self._alternates.append(DiskObjectStore(path))
- return self._alternates
- def _read_alternate_paths(self):
- try:
- f = GitFile(os.path.join(self.path, INFODIR, "alternates"), "rb")
- except FileNotFoundError:
- return
- with f:
- for line in f.readlines():
- line = line.rstrip(b"\n")
- if line.startswith(b"#"):
- continue
- if os.path.isabs(line):
- yield os.fsdecode(line)
- else:
- yield os.fsdecode(os.path.join(os.fsencode(self.path), line))
- def add_alternate_path(self, path) -> None:
- """Add an alternate path to this object store."""
- try:
- os.mkdir(os.path.join(self.path, INFODIR))
- except FileExistsError:
- pass
- alternates_path = os.path.join(self.path, INFODIR, "alternates")
- with GitFile(alternates_path, "wb") as f:
- try:
- orig_f = open(alternates_path, "rb")
- except FileNotFoundError:
- pass
- else:
- with orig_f:
- f.write(orig_f.read())
- f.write(os.fsencode(path) + b"\n")
- if not os.path.isabs(path):
- path = os.path.join(self.path, path)
- self.alternates.append(DiskObjectStore(path))
- def _update_pack_cache(self):
- """Read and iterate over new pack files and cache them."""
- try:
- pack_dir_contents = os.listdir(self.pack_dir)
- except FileNotFoundError:
- self.close()
- return []
- pack_files = set()
- for name in pack_dir_contents:
- if name.startswith("pack-") and name.endswith(".pack"):
- # verify that idx exists first (otherwise the pack was not yet
- # fully written)
- idx_name = os.path.splitext(name)[0] + ".idx"
- if idx_name in pack_dir_contents:
- pack_name = name[: -len(".pack")]
- pack_files.add(pack_name)
- # Open newly appeared pack files
- new_packs = []
- for f in pack_files:
- if f not in self._pack_cache:
- pack = Pack(
- os.path.join(self.pack_dir, f),
- delta_window_size=self.pack_delta_window_size,
- window_memory=self.pack_window_memory,
- delta_cache_size=self.pack_delta_cache_size,
- depth=self.pack_depth,
- threads=self.pack_threads,
- big_file_threshold=self.pack_big_file_threshold,
- )
- new_packs.append(pack)
- self._pack_cache[f] = pack
- # Remove disappeared pack files
- for f in set(self._pack_cache) - pack_files:
- self._pack_cache.pop(f).close()
- return new_packs
- def _get_shafile_path(self, sha):
- # Check from object dir
- return hex_to_filename(os.fspath(self.path), sha)
- def _iter_loose_objects(self):
- for base in os.listdir(self.path):
- if len(base) != 2:
- continue
- for rest in os.listdir(os.path.join(self.path, base)):
- sha = os.fsencode(base + rest)
- if not valid_hexsha(sha):
- continue
- yield sha
- def count_loose_objects(self) -> int:
- """Count the number of loose objects in the object store.
- Returns:
- Number of loose objects
- """
- count = 0
- if not os.path.exists(self.path):
- return 0
- for i in range(256):
- subdir = os.path.join(self.path, f"{i:02x}")
- try:
- count += len(
- [
- name
- for name in os.listdir(subdir)
- if len(name) == 38 # 40 - 2 for the prefix
- ]
- )
- except FileNotFoundError:
- # Directory may have been removed or is inaccessible
- continue
- return count
- def _get_loose_object(self, sha):
- path = self._get_shafile_path(sha)
- try:
- return ShaFile.from_path(path)
- except FileNotFoundError:
- return None
- def delete_loose_object(self, sha) -> None:
- """Delete a loose object from disk.
- Args:
- sha: SHA1 of the object to delete
- Raises:
- FileNotFoundError: If the object file doesn't exist
- """
- os.remove(self._get_shafile_path(sha))
- def get_object_mtime(self, sha):
- """Get the modification time of an object.
- Args:
- sha: SHA1 of the object
- Returns:
- Modification time as seconds since epoch
- Raises:
- KeyError: if the object is not found
- """
- # First check if it's a loose object
- if self.contains_loose(sha):
- path = self._get_shafile_path(sha)
- try:
- return os.path.getmtime(path)
- except FileNotFoundError:
- pass
- # Check if it's in a pack file
- for pack in self.packs:
- try:
- if sha in pack:
- # Use the pack file's mtime for packed objects
- pack_path = pack._data_path
- try:
- return os.path.getmtime(pack_path)
- except (FileNotFoundError, AttributeError):
- pass
- except PackFileDisappeared:
- pass
- raise KeyError(sha)
- def _remove_pack(self, pack) -> None:
- try:
- del self._pack_cache[os.path.basename(pack._basename)]
- except KeyError:
- pass
- pack.close()
- os.remove(pack.data.path)
- os.remove(pack.index.path)
- def _get_pack_basepath(self, entries):
- suffix_bytes = iter_sha1(entry[0] for entry in entries)
- # TODO: Handle self.pack_dir being bytes
- suffix = suffix_bytes.decode("ascii")
- return os.path.join(self.pack_dir, "pack-" + suffix)
- def _complete_pack(self, f, path, num_objects, indexer, progress=None):
- """Move a specific file containing a pack into the pack directory.
- Note: The file should be on the same file system as the
- packs directory.
- Args:
- f: Open file object for the pack.
- path: Path to the pack file.
- num_objects: Number of objects in the pack.
- indexer: A PackIndexer for indexing the pack.
- progress: Optional progress reporting function.
- """
- entries = []
- for i, entry in enumerate(indexer):
- if progress is not None:
- progress(f"generating index: {i}/{num_objects}\r".encode("ascii"))
- entries.append(entry)
- pack_sha, extra_entries = extend_pack(
- f,
- indexer.ext_refs(),
- get_raw=self.get_raw,
- compression_level=self.pack_compression_level,
- progress=progress,
- )
- f.flush()
- try:
- fileno = f.fileno()
- except AttributeError:
- pass
- else:
- os.fsync(fileno)
- f.close()
- entries.extend(extra_entries)
- # Move the pack in.
- entries.sort()
- pack_base_name = self._get_pack_basepath(entries)
- for pack in self.packs:
- if pack._basename == pack_base_name:
- return pack
- target_pack_path = pack_base_name + ".pack"
- target_index_path = pack_base_name + ".idx"
- if sys.platform == "win32":
- # Windows might have the target pack file lingering. Attempt
- # removal, silently passing if the target does not exist.
- with suppress(FileNotFoundError):
- os.remove(target_pack_path)
- os.rename(path, target_pack_path)
- # Write the index.
- with GitFile(target_index_path, "wb", mask=PACK_MODE) as index_file:
- write_pack_index(
- index_file, entries, pack_sha, version=self.pack_index_version
- )
- # Add the pack to the store and return it.
- final_pack = Pack(
- pack_base_name,
- delta_window_size=self.pack_delta_window_size,
- window_memory=self.pack_window_memory,
- delta_cache_size=self.pack_delta_cache_size,
- depth=self.pack_depth,
- threads=self.pack_threads,
- big_file_threshold=self.pack_big_file_threshold,
- )
- final_pack.check_length_and_checksum()
- self._add_cached_pack(pack_base_name, final_pack)
- return final_pack
- def add_thin_pack(self, read_all, read_some, progress=None):
- """Add a new thin pack to this object store.
- Thin packs are packs that contain deltas with parents that exist
- outside the pack. They should never be placed in the object store
- directly, and always indexed and completed as they are copied.
- Args:
- read_all: Read function that blocks until the number of
- requested bytes are read.
- read_some: Read function that returns at least one byte, but may
- not return the number of bytes requested.
- progress: Optional progress reporting function.
- Returns: A Pack object pointing at the now-completed thin pack in the
- objects/pack directory.
- """
- import tempfile
- fd, path = tempfile.mkstemp(dir=self.path, prefix="tmp_pack_")
- with os.fdopen(fd, "w+b") as f:
- os.chmod(path, PACK_MODE)
- indexer = PackIndexer(f, resolve_ext_ref=self.get_raw)
- copier = PackStreamCopier(read_all, read_some, f, delta_iter=indexer)
- copier.verify(progress=progress)
- return self._complete_pack(f, path, len(copier), indexer, progress=progress)
- def add_pack(self):
- """Add a new pack to this object store.
- Returns: Fileobject to write to, a commit function to
- call when the pack is finished and an abort
- function.
- """
- import tempfile
- fd, path = tempfile.mkstemp(dir=self.pack_dir, suffix=".pack")
- f = os.fdopen(fd, "w+b")
- os.chmod(path, PACK_MODE)
- def commit():
- if f.tell() > 0:
- f.seek(0)
- with PackData(path, f) as pd:
- indexer = PackIndexer.for_pack_data(
- pd, resolve_ext_ref=self.get_raw
- )
- return self._complete_pack(f, path, len(pd), indexer)
- else:
- f.close()
- os.remove(path)
- return None
- def abort() -> None:
- f.close()
- os.remove(path)
- return f, commit, abort
- def add_object(self, obj) -> None:
- """Add a single object to this object store.
- Args:
- obj: Object to add
- """
- path = self._get_shafile_path(obj.id)
- dir = os.path.dirname(path)
- try:
- os.mkdir(dir)
- except FileExistsError:
- pass
- if os.path.exists(path):
- return # Already there, no need to write again
- with GitFile(path, "wb", mask=PACK_MODE) as f:
- f.write(
- obj.as_legacy_object(compression_level=self.loose_compression_level)
- )
- @classmethod
- def init(cls, path: Union[str, os.PathLike]):
- """Initialize a new disk object store.
- Creates the necessary directory structure for a Git object store.
- Args:
- path: Path where the object store should be created
- Returns:
- New DiskObjectStore instance
- """
- try:
- os.mkdir(path)
- except FileExistsError:
- pass
- os.mkdir(os.path.join(path, "info"))
- os.mkdir(os.path.join(path, PACKDIR))
- return cls(path)
- def iter_prefix(self, prefix):
- """Iterate over all object SHAs with the given prefix.
- Args:
- prefix: Hex prefix to search for (as bytes)
- Returns:
- Iterator of object SHAs (as bytes) matching the prefix
- """
- if len(prefix) < 2:
- yield from super().iter_prefix(prefix)
- return
- seen = set()
- dir = prefix[:2].decode()
- rest = prefix[2:].decode()
- try:
- for name in os.listdir(os.path.join(self.path, dir)):
- if name.startswith(rest):
- sha = os.fsencode(dir + name)
- if sha not in seen:
- seen.add(sha)
- yield sha
- except FileNotFoundError:
- pass
- for p in self.packs:
- bin_prefix = (
- binascii.unhexlify(prefix)
- if len(prefix) % 2 == 0
- else binascii.unhexlify(prefix[:-1])
- )
- for sha in p.index.iter_prefix(bin_prefix):
- sha = sha_to_hex(sha)
- if sha.startswith(prefix) and sha not in seen:
- seen.add(sha)
- yield sha
- for alternate in self.alternates:
- for sha in alternate.iter_prefix(prefix):
- if sha not in seen:
- seen.add(sha)
- yield sha
- def get_commit_graph(self):
- """Get the commit graph for this object store.
- Returns:
- CommitGraph object if available, None otherwise
- """
- if not self._use_commit_graph:
- return None
- if self._commit_graph is None:
- from .commit_graph import read_commit_graph
- # Look for commit graph in our objects directory
- graph_file = os.path.join(self.path, "info", "commit-graph")
- if os.path.exists(graph_file):
- self._commit_graph = read_commit_graph(graph_file)
- return self._commit_graph
- def write_commit_graph(self, refs=None, reachable=True) -> None:
- """Write a commit graph file for this object store.
- Args:
- refs: List of refs to include. If None, includes all refs from object store.
- reachable: If True, includes all commits reachable from refs.
- If False, only includes the direct ref targets.
- """
- from .commit_graph import get_reachable_commits
- if refs is None:
- # Get all commit objects from the object store
- all_refs = []
- # Iterate through all objects to find commits
- for sha in self:
- try:
- obj = self[sha]
- if obj.type_name == b"commit":
- all_refs.append(sha)
- except KeyError:
- continue
- else:
- # Use provided refs
- all_refs = refs
- if not all_refs:
- return # No commits to include
- if reachable:
- # Get all reachable commits
- commit_ids = get_reachable_commits(self, all_refs)
- else:
- # Just use the direct ref targets - ensure they're hex ObjectIDs
- commit_ids = []
- for ref in all_refs:
- if isinstance(ref, bytes) and len(ref) == 40:
- # Already hex ObjectID
- commit_ids.append(ref)
- elif isinstance(ref, bytes) and len(ref) == 20:
- # Binary SHA, convert to hex ObjectID
- from .objects import sha_to_hex
- commit_ids.append(sha_to_hex(ref))
- else:
- # Assume it's already correct format
- commit_ids.append(ref)
- if commit_ids:
- # Write commit graph directly to our object store path
- # Generate the commit graph
- from .commit_graph import generate_commit_graph
- graph = generate_commit_graph(self, commit_ids)
- if graph.entries:
- # Ensure the info directory exists
- info_dir = os.path.join(self.path, "info")
- os.makedirs(info_dir, exist_ok=True)
- # Write using GitFile for atomic operation
- graph_path = os.path.join(info_dir, "commit-graph")
- with GitFile(graph_path, "wb") as f:
- assert isinstance(
- f, _GitFile
- ) # GitFile in write mode always returns _GitFile
- graph.write_to_file(f)
- # Clear cached commit graph so it gets reloaded
- self._commit_graph = None
- def prune(self, grace_period: Optional[int] = None) -> None:
- """Prune/clean up this object store.
- This removes temporary files that were left behind by interrupted
- pack operations. These are files that start with ``tmp_pack_`` in the
- repository directory or files with .pack extension but no corresponding
- .idx file in the pack directory.
- Args:
- grace_period: Grace period in seconds for removing temporary files.
- If None, uses DEFAULT_TEMPFILE_GRACE_PERIOD.
- """
- import glob
- if grace_period is None:
- grace_period = DEFAULT_TEMPFILE_GRACE_PERIOD
- # Clean up tmp_pack_* files in the repository directory
- for tmp_file in glob.glob(os.path.join(self.path, "tmp_pack_*")):
- # Check if file is old enough (more than grace period)
- mtime = os.path.getmtime(tmp_file)
- if time.time() - mtime > grace_period:
- os.remove(tmp_file)
- # Clean up orphaned .pack files without corresponding .idx files
- try:
- pack_dir_contents = os.listdir(self.pack_dir)
- except FileNotFoundError:
- return
- pack_files = {}
- idx_files = set()
- for name in pack_dir_contents:
- if name.endswith(".pack"):
- base_name = name[:-5] # Remove .pack extension
- pack_files[base_name] = name
- elif name.endswith(".idx"):
- base_name = name[:-4] # Remove .idx extension
- idx_files.add(base_name)
- # Remove .pack files without corresponding .idx files
- for base_name, pack_name in pack_files.items():
- if base_name not in idx_files:
- pack_path = os.path.join(self.pack_dir, pack_name)
- # Check if file is old enough (more than grace period)
- mtime = os.path.getmtime(pack_path)
- if time.time() - mtime > grace_period:
- os.remove(pack_path)
- class MemoryObjectStore(BaseObjectStore):
- """Object store that keeps all objects in memory."""
- def __init__(self) -> None:
- """Initialize a MemoryObjectStore.
- Creates an empty in-memory object store.
- """
- super().__init__()
- self._data: dict[str, ShaFile] = {}
- self.pack_compression_level = -1
- def _to_hexsha(self, sha):
- if len(sha) == 40:
- return sha
- elif len(sha) == 20:
- return sha_to_hex(sha)
- else:
- raise ValueError(f"Invalid sha {sha!r}")
- def contains_loose(self, sha):
- """Check if a particular object is present by SHA1 and is loose."""
- return self._to_hexsha(sha) in self._data
- def contains_packed(self, sha) -> bool:
- """Check if a particular object is present by SHA1 and is packed."""
- return False
- def __iter__(self):
- """Iterate over the SHAs that are present in this store."""
- return iter(self._data.keys())
- @property
- def packs(self):
- """List with pack objects."""
- return []
- def get_raw(self, name: ObjectID):
- """Obtain the raw text for an object.
- Args:
- name: sha for the object.
- Returns: tuple with numeric type and object contents.
- """
- obj = self[self._to_hexsha(name)]
- return obj.type_num, obj.as_raw_string()
- def __getitem__(self, name: ObjectID):
- """Retrieve an object by SHA.
- Args:
- name: SHA of the object (as hex string or bytes)
- Returns:
- Copy of the ShaFile object
- Raises:
- KeyError: If the object is not found
- """
- return self._data[self._to_hexsha(name)].copy()
- def __delitem__(self, name: ObjectID) -> None:
- """Delete an object from this store, for testing only."""
- del self._data[self._to_hexsha(name)]
- def add_object(self, obj) -> None:
- """Add a single object to this object store."""
- self._data[obj.id] = obj.copy()
- def add_objects(self, objects, progress=None) -> None:
- """Add a set of objects to this object store.
- Args:
- objects: Iterable over a list of (object, path) tuples
- progress: Optional progress reporting function.
- """
- for obj, path in objects:
- self.add_object(obj)
- def add_pack(self):
- """Add a new pack to this object store.
- Because this object store doesn't support packs, we extract and add the
- individual objects.
- Returns: Fileobject to write to and a commit function to
- call when the pack is finished.
- """
- from tempfile import SpooledTemporaryFile
- f = SpooledTemporaryFile(max_size=PACK_SPOOL_FILE_MAX_SIZE, prefix="incoming-")
- def commit() -> None:
- size = f.tell()
- if size > 0:
- f.seek(0)
- p = PackData.from_file(f, size)
- for obj in PackInflater.for_pack_data(p, self.get_raw):
- self.add_object(obj)
- p.close()
- f.close()
- else:
- f.close()
- def abort() -> None:
- f.close()
- return f, commit, abort
- def add_pack_data(
- self, count: int, unpacked_objects: Iterator[UnpackedObject], progress=None
- ) -> None:
- """Add pack data to this object store.
- Args:
- count: Number of items to add
- unpacked_objects: Iterator of UnpackedObject instances
- progress: Optional progress reporting function.
- """
- if count == 0:
- return
- # Since MemoryObjectStore doesn't support pack files, we need to
- # extract individual objects. To handle deltas properly, we write
- # to a temporary pack and then use PackInflater to resolve them.
- f, commit, abort = self.add_pack()
- try:
- write_pack_data(
- f.write,
- unpacked_objects,
- num_records=count,
- progress=progress,
- )
- except BaseException:
- abort()
- raise
- else:
- commit()
- def add_thin_pack(self, read_all, read_some, progress=None) -> None:
- """Add a new thin pack to this object store.
- Thin packs are packs that contain deltas with parents that exist
- outside the pack. Because this object store doesn't support packs, we
- extract and add the individual objects.
- Args:
- read_all: Read function that blocks until the number of
- requested bytes are read.
- read_some: Read function that returns at least one byte, but may
- not return the number of bytes requested.
- progress: Optional progress reporting function.
- """
- f, commit, abort = self.add_pack()
- try:
- copier = PackStreamCopier(read_all, read_some, f)
- copier.verify()
- except BaseException:
- abort()
- raise
- else:
- commit()
- class ObjectIterator(Protocol):
- """Interface for iterating over objects."""
- def iterobjects(self) -> Iterator[ShaFile]:
- """Iterate over all objects.
- Returns:
- Iterator of ShaFile objects
- """
- raise NotImplementedError(self.iterobjects)
- def tree_lookup_path(lookup_obj, root_sha, path):
- """Look up an object in a Git tree.
- Args:
- lookup_obj: Callback for retrieving object by SHA1
- root_sha: SHA1 of the root tree
- path: Path to lookup
- Returns: A tuple of (mode, SHA) of the resulting path.
- """
- tree = lookup_obj(root_sha)
- if not isinstance(tree, Tree):
- raise NotTreeError(root_sha)
- return tree.lookup_path(lookup_obj, path)
- def _collect_filetree_revs(
- obj_store: ObjectContainer, tree_sha: ObjectID, kset: set[ObjectID]
- ) -> None:
- """Collect SHA1s of files and directories for specified tree.
- Args:
- obj_store: Object store to get objects by SHA from
- tree_sha: tree reference to walk
- kset: set to fill with references to files and directories
- """
- filetree = obj_store[tree_sha]
- assert isinstance(filetree, Tree)
- for name, mode, sha in filetree.iteritems():
- if not S_ISGITLINK(mode) and sha not in kset:
- kset.add(sha)
- if stat.S_ISDIR(mode):
- _collect_filetree_revs(obj_store, sha, kset)
- def _split_commits_and_tags(
- obj_store: ObjectContainer, lst, *, ignore_unknown=False
- ) -> tuple[set[bytes], set[bytes], set[bytes]]:
- """Split object id list into three lists with commit, tag, and other SHAs.
- Commits referenced by tags are included into commits
- list as well. Only SHA1s known in this repository will get
- through, and unless ignore_unknown argument is True, KeyError
- is thrown for SHA1 missing in the repository
- Args:
- obj_store: Object store to get objects by SHA1 from
- lst: Collection of commit and tag SHAs
- ignore_unknown: True to skip SHA1 missing in the repository
- silently.
- Returns: A tuple of (commits, tags, others) SHA1s
- """
- commits: set[bytes] = set()
- tags: set[bytes] = set()
- others: set[bytes] = set()
- for e in lst:
- try:
- o = obj_store[e]
- except KeyError:
- if not ignore_unknown:
- raise
- else:
- if isinstance(o, Commit):
- commits.add(e)
- elif isinstance(o, Tag):
- tags.add(e)
- tagged = o.object[1]
- c, t, os = _split_commits_and_tags(
- obj_store, [tagged], ignore_unknown=ignore_unknown
- )
- commits |= c
- tags |= t
- others |= os
- else:
- others.add(e)
- return (commits, tags, others)
- class MissingObjectFinder:
- """Find the objects missing from another object store.
- Args:
- object_store: Object store containing at least all objects to be
- sent
- haves: SHA1s of commits not to send (already present in target)
- wants: SHA1s of commits to send
- progress: Optional function to report progress to.
- get_tagged: Function that returns a dict of pointed-to sha -> tag
- sha for including tags.
- get_parents: Optional function for getting the parents of a commit.
- """
- def __init__(
- self,
- object_store,
- haves,
- wants,
- *,
- shallow=None,
- progress=None,
- get_tagged=None,
- get_parents=lambda commit: commit.parents,
- ) -> None:
- """Initialize a MissingObjectFinder.
- Args:
- object_store: Object store containing objects
- haves: SHA1s of objects already present in target
- wants: SHA1s of objects to send
- shallow: Set of shallow commit SHA1s
- progress: Optional progress reporting callback
- get_tagged: Function returning dict of pointed-to sha -> tag sha
- get_parents: Function for getting commit parents
- """
- self.object_store = object_store
- if shallow is None:
- shallow = set()
- self._get_parents = get_parents
- # process Commits and Tags differently
- # Note, while haves may list commits/tags not available locally,
- # and such SHAs would get filtered out by _split_commits_and_tags,
- # wants shall list only known SHAs, and otherwise
- # _split_commits_and_tags fails with KeyError
- have_commits, have_tags, have_others = _split_commits_and_tags(
- object_store, haves, ignore_unknown=True
- )
- want_commits, want_tags, want_others = _split_commits_and_tags(
- object_store, wants, ignore_unknown=False
- )
- # all_ancestors is a set of commits that shall not be sent
- # (complete repository up to 'haves')
- all_ancestors = _collect_ancestors(
- object_store, have_commits, shallow=shallow, get_parents=self._get_parents
- )[0]
- # all_missing - complete set of commits between haves and wants
- # common - commits from all_ancestors we hit into while
- # traversing parent hierarchy of wants
- missing_commits, common_commits = _collect_ancestors(
- object_store,
- want_commits,
- all_ancestors,
- shallow=shallow,
- get_parents=self._get_parents,
- )
- self.remote_has: set[bytes] = set()
- # Now, fill sha_done with commits and revisions of
- # files and directories known to be both locally
- # and on target. Thus these commits and files
- # won't get selected for fetch
- for h in common_commits:
- self.remote_has.add(h)
- cmt = object_store[h]
- _collect_filetree_revs(object_store, cmt.tree, self.remote_has)
- # record tags we have as visited, too
- for t in have_tags:
- self.remote_has.add(t)
- self.sha_done = set(self.remote_has)
- # in fact, what we 'want' is commits, tags, and others
- # we've found missing
- self.objects_to_send: set[
- tuple[ObjectID, Optional[bytes], Optional[int], bool]
- ] = {(w, None, Commit.type_num, False) for w in missing_commits}
- missing_tags = want_tags.difference(have_tags)
- self.objects_to_send.update(
- {(w, None, Tag.type_num, False) for w in missing_tags}
- )
- missing_others = want_others.difference(have_others)
- self.objects_to_send.update({(w, None, None, False) for w in missing_others})
- if progress is None:
- self.progress = lambda x: None
- else:
- self.progress = progress
- self._tagged = (get_tagged and get_tagged()) or {}
- def get_remote_has(self):
- """Get the set of SHAs the remote has.
- Returns:
- Set of SHA1s that the remote side already has
- """
- return self.remote_has
- def add_todo(
- self, entries: Iterable[tuple[ObjectID, Optional[bytes], Optional[int], bool]]
- ) -> None:
- """Add objects to the todo list.
- Args:
- entries: Iterable of tuples (sha, name, type_num, is_leaf)
- """
- self.objects_to_send.update([e for e in entries if e[0] not in self.sha_done])
- def __next__(self) -> tuple[bytes, Optional[PackHint]]:
- """Get the next object to send.
- Returns:
- Tuple of (sha, pack_hint)
- Raises:
- StopIteration: When no more objects to send
- """
- while True:
- if not self.objects_to_send:
- self.progress(
- f"counting objects: {len(self.sha_done)}, done.\n".encode("ascii")
- )
- raise StopIteration
- (sha, name, type_num, leaf) = self.objects_to_send.pop()
- if sha not in self.sha_done:
- break
- if not leaf:
- o = self.object_store[sha]
- if isinstance(o, Commit):
- self.add_todo([(o.tree, b"", Tree.type_num, False)])
- elif isinstance(o, Tree):
- self.add_todo(
- [
- (
- s,
- n,
- (Blob.type_num if stat.S_ISREG(m) else Tree.type_num),
- not stat.S_ISDIR(m),
- )
- for n, m, s in o.iteritems()
- if not S_ISGITLINK(m)
- ]
- )
- elif isinstance(o, Tag):
- self.add_todo([(o.object[1], None, o.object[0].type_num, False)])
- if sha in self._tagged:
- self.add_todo([(self._tagged[sha], None, None, True)])
- self.sha_done.add(sha)
- if len(self.sha_done) % 1000 == 0:
- self.progress(f"counting objects: {len(self.sha_done)}\r".encode("ascii"))
- if type_num is None:
- pack_hint = None
- else:
- pack_hint = (type_num, name)
- return (sha, pack_hint)
- def __iter__(self):
- """Return iterator over objects to send.
- Returns:
- Self (this class implements the iterator protocol)
- """
- return self
- class ObjectStoreGraphWalker:
- """Graph walker that finds what commits are missing from an object store."""
- heads: set[ObjectID]
- """Revisions without descendants in the local repo."""
- get_parents: Callable[[ObjectID], list[ObjectID]]
- """Function to retrieve parents in the local repo."""
- shallow: set[ObjectID]
- def __init__(
- self,
- local_heads: Iterable[ObjectID],
- get_parents,
- shallow: Optional[set[ObjectID]] = None,
- update_shallow=None,
- ) -> None:
- """Create a new instance.
- Args:
- local_heads: Heads to start search with
- get_parents: Function for finding the parents of a SHA1.
- shallow: Set of shallow commits.
- update_shallow: Function to update shallow commits.
- """
- self.heads = set(local_heads)
- self.get_parents = get_parents
- self.parents: dict[ObjectID, Optional[list[ObjectID]]] = {}
- if shallow is None:
- shallow = set()
- self.shallow = shallow
- self.update_shallow = update_shallow
- def nak(self) -> None:
- """Nothing in common was found."""
- def ack(self, sha: ObjectID) -> None:
- """Ack that a revision and its ancestors are present in the source."""
- if len(sha) != 40:
- raise ValueError(f"unexpected sha {sha!r} received")
- ancestors = {sha}
- # stop if we run out of heads to remove
- while self.heads:
- for a in ancestors:
- if a in self.heads:
- self.heads.remove(a)
- # collect all ancestors
- new_ancestors = set()
- for a in ancestors:
- ps = self.parents.get(a)
- if ps is not None:
- new_ancestors.update(ps)
- self.parents[a] = None
- # no more ancestors; stop
- if not new_ancestors:
- break
- ancestors = new_ancestors
- def next(self):
- """Iterate over ancestors of heads in the target."""
- if self.heads:
- ret = self.heads.pop()
- try:
- ps = self.get_parents(ret)
- except KeyError:
- return None
- self.parents[ret] = ps
- self.heads.update([p for p in ps if p not in self.parents])
- return ret
- return None
- __next__ = next
- def commit_tree_changes(object_store, tree, changes):
- """Commit a specified set of changes to a tree structure.
- This will apply a set of changes on top of an existing tree, storing new
- objects in object_store.
- changes are a list of tuples with (path, mode, object_sha).
- Paths can be both blobs and trees. See the mode and
- object sha to None deletes the path.
- This method works especially well if there are only a small
- number of changes to a big tree. For a large number of changes
- to a large tree, use e.g. commit_tree.
- Args:
- object_store: Object store to store new objects in
- and retrieve old ones from.
- tree: Original tree root
- changes: changes to apply
- Returns: New tree root object
- """
- # TODO(jelmer): Save up the objects and add them using .add_objects
- # rather than with individual calls to .add_object.
- nested_changes: dict[bytes, list[tuple[bytes, Optional[int], Optional[bytes]]]] = {}
- for path, new_mode, new_sha in changes:
- try:
- (dirname, subpath) = path.split(b"/", 1)
- except ValueError:
- if new_sha is None:
- del tree[path]
- else:
- tree[path] = (new_mode, new_sha)
- else:
- nested_changes.setdefault(dirname, []).append((subpath, new_mode, new_sha))
- for name, subchanges in nested_changes.items():
- try:
- orig_subtree = object_store[tree[name][1]]
- except KeyError:
- orig_subtree = Tree()
- subtree = commit_tree_changes(object_store, orig_subtree, subchanges)
- if len(subtree) == 0:
- del tree[name]
- else:
- tree[name] = (stat.S_IFDIR, subtree.id)
- object_store.add_object(tree)
- return tree
- class OverlayObjectStore(BaseObjectStore):
- """Object store that can overlay multiple object stores."""
- def __init__(self, bases, add_store=None) -> None:
- """Initialize an OverlayObjectStore.
- Args:
- bases: List of base object stores to overlay
- add_store: Optional store to write new objects to
- """
- self.bases = bases
- self.add_store = add_store
- def add_object(self, object):
- """Add a single object to the store.
- Args:
- object: Object to add
- Raises:
- NotImplementedError: If no add_store was provided
- """
- if self.add_store is None:
- raise NotImplementedError(self.add_object)
- return self.add_store.add_object(object)
- def add_objects(self, objects, progress=None):
- """Add multiple objects to the store.
- Args:
- objects: Iterator of objects to add
- progress: Optional progress reporting callback
- Raises:
- NotImplementedError: If no add_store was provided
- """
- if self.add_store is None:
- raise NotImplementedError(self.add_object)
- return self.add_store.add_objects(objects, progress)
- @property
- def packs(self):
- """Get the list of packs from all overlaid stores.
- Returns:
- Combined list of packs from all base stores
- """
- ret = []
- for b in self.bases:
- ret.extend(b.packs)
- return ret
- def __iter__(self):
- """Iterate over all object SHAs in the overlaid stores.
- Returns:
- Iterator of object SHAs (deduped across stores)
- """
- done = set()
- for b in self.bases:
- for o_id in b:
- if o_id not in done:
- yield o_id
- done.add(o_id)
- def iterobjects_subset(
- self, shas: Iterable[bytes], *, allow_missing: bool = False
- ) -> Iterator[ShaFile]:
- """Iterate over a subset of objects from the overlaid stores.
- Args:
- shas: Iterable of object SHAs to retrieve
- allow_missing: If True, skip missing objects; if False, raise KeyError
- Returns:
- Iterator of ShaFile objects
- Raises:
- KeyError: If an object is missing and allow_missing is False
- """
- todo = set(shas)
- found: set[bytes] = set()
- for b in self.bases:
- # Create a copy of todo for each base to avoid modifying
- # the set while iterating through it
- current_todo = todo - found
- for o in b.iterobjects_subset(current_todo, allow_missing=True):
- yield o
- found.add(o.id)
- # Check for any remaining objects not found
- missing = todo - found
- if missing and not allow_missing:
- raise KeyError(next(iter(missing)))
- def iter_unpacked_subset(
- self,
- shas: Iterable[bytes],
- *,
- include_comp=False,
- allow_missing: bool = False,
- convert_ofs_delta=True,
- ) -> Iterator[ShaFile]:
- """Iterate over unpacked objects from the overlaid stores.
- Args:
- shas: Iterable of object SHAs to retrieve
- include_comp: Whether to include compressed data
- allow_missing: If True, skip missing objects; if False, raise KeyError
- convert_ofs_delta: Whether to convert OFS_DELTA objects
- Returns:
- Iterator of unpacked objects
- Raises:
- KeyError: If an object is missing and allow_missing is False
- """
- todo = set(shas)
- for b in self.bases:
- for o in b.iter_unpacked_subset(
- todo,
- include_comp=include_comp,
- allow_missing=True,
- convert_ofs_delta=convert_ofs_delta,
- ):
- yield o
- todo.remove(o.id)
- if todo and not allow_missing:
- raise KeyError(o.id)
- def get_raw(self, sha_id):
- """Get the raw object data from the overlaid stores.
- Args:
- sha_id: SHA of the object
- Returns:
- Tuple of (type_num, raw_data)
- Raises:
- KeyError: If object not found in any base store
- """
- for b in self.bases:
- try:
- return b.get_raw(sha_id)
- except KeyError:
- pass
- raise KeyError(sha_id)
- def contains_packed(self, sha) -> bool:
- """Check if an object is packed in any base store.
- Args:
- sha: SHA of the object
- Returns:
- True if object is packed in any base store
- """
- for b in self.bases:
- if b.contains_packed(sha):
- return True
- return False
- def contains_loose(self, sha) -> bool:
- """Check if an object is loose in any base store.
- Args:
- sha: SHA of the object
- Returns:
- True if object is loose in any base store
- """
- for b in self.bases:
- if b.contains_loose(sha):
- return True
- return False
- def read_packs_file(f):
- """Yield the packs listed in a packs file."""
- for line in f.read().splitlines():
- if not line:
- continue
- (kind, name) = line.split(b" ", 1)
- if kind != b"P":
- continue
- yield os.fsdecode(name)
- class BucketBasedObjectStore(PackBasedObjectStore):
- """Object store implementation that uses a bucket store like S3 as backend."""
- def _iter_loose_objects(self):
- """Iterate over the SHAs of all loose objects."""
- return iter([])
- def _get_loose_object(self, sha) -> None:
- return None
- def delete_loose_object(self, sha) -> None:
- """Delete a loose object (no-op for bucket stores).
- Bucket-based stores don't have loose objects, so this is a no-op.
- Args:
- sha: SHA of the object to delete
- """
- # Doesn't exist..
- def pack_loose_objects(self) -> int:
- """Pack loose objects. Returns number of objects packed.
- BucketBasedObjectStore doesn't support loose objects, so this is a no-op.
- """
- return 0
- def _remove_pack_by_name(self, name: str) -> None:
- """Remove a pack by name. Subclasses should implement this."""
- raise NotImplementedError(self._remove_pack_by_name)
- def _iter_pack_names(self) -> Iterator[str]:
- raise NotImplementedError(self._iter_pack_names)
- def _get_pack(self, name) -> Pack:
- raise NotImplementedError(self._get_pack)
- def _update_pack_cache(self):
- pack_files = set(self._iter_pack_names())
- # Open newly appeared pack files
- new_packs = []
- for f in pack_files:
- if f not in self._pack_cache:
- pack = self._get_pack(f)
- new_packs.append(pack)
- self._pack_cache[f] = pack
- # Remove disappeared pack files
- for f in set(self._pack_cache) - pack_files:
- self._pack_cache.pop(f).close()
- return new_packs
- def _upload_pack(self, basename, pack_file, index_file) -> None:
- raise NotImplementedError
- def add_pack(self):
- """Add a new pack to this object store.
- Returns: Fileobject to write to, a commit function to
- call when the pack is finished and an abort
- function.
- """
- import tempfile
- pf = tempfile.SpooledTemporaryFile(
- max_size=PACK_SPOOL_FILE_MAX_SIZE, prefix="incoming-"
- )
- def commit():
- if pf.tell() == 0:
- pf.close()
- return None
- pf.seek(0)
- p = PackData(pf.name, pf)
- entries = p.sorted_entries()
- basename = iter_sha1(entry[0] for entry in entries).decode("ascii")
- idxf = tempfile.SpooledTemporaryFile(
- max_size=PACK_SPOOL_FILE_MAX_SIZE, prefix="incoming-"
- )
- checksum = p.get_stored_checksum()
- write_pack_index(idxf, entries, checksum, version=self.pack_index_version)
- idxf.seek(0)
- idx = load_pack_index_file(basename + ".idx", idxf)
- for pack in self.packs:
- if pack.get_stored_checksum() == p.get_stored_checksum():
- p.close()
- idx.close()
- pf.close()
- idxf.close()
- return pack
- pf.seek(0)
- idxf.seek(0)
- self._upload_pack(basename, pf, idxf)
- final_pack = Pack.from_objects(p, idx)
- self._add_cached_pack(basename, final_pack)
- pf.close()
- idxf.close()
- return final_pack
- return pf, commit, pf.close
- def _collect_ancestors(
- store: ObjectContainer,
- heads,
- common: frozenset[ObjectID] = frozenset(),
- shallow: frozenset[ObjectID] = frozenset(),
- get_parents=lambda commit: commit.parents,
- ):
- """Collect all ancestors of heads up to (excluding) those in common.
- Args:
- store: Object store to get commits from
- heads: commits to start from
- common: commits to end at, or empty set to walk repository
- completely
- shallow: Set of shallow commits
- get_parents: Optional function for getting the parents of a
- commit.
- Returns: a tuple (A, B) where A - all commits reachable
- from heads but not present in common, B - common (shared) elements
- that are directly reachable from heads
- """
- bases = set()
- commits = set()
- queue = []
- queue.extend(heads)
- # Try to use commit graph if available
- commit_graph = store.get_commit_graph()
- while queue:
- e = queue.pop(0)
- if e in common:
- bases.add(e)
- elif e not in commits:
- commits.add(e)
- if e in shallow:
- continue
- # Try to use commit graph for parent lookup
- parents = None
- if commit_graph:
- parents = commit_graph.get_parents(e)
- if parents is None:
- # Fall back to loading the object
- cmt = store[e]
- parents = get_parents(cmt)
- queue.extend(parents)
- return (commits, bases)
- def iter_tree_contents(
- store: ObjectContainer, tree_id: Optional[ObjectID], *, include_trees: bool = False
- ):
- """Iterate the contents of a tree and all subtrees.
- Iteration is depth-first pre-order, as in e.g. os.walk.
- Args:
- store: Object store to get trees from
- tree_id: SHA1 of the tree.
- include_trees: If True, include tree objects in the iteration.
- Yields: TreeEntry namedtuples for all the objects in a tree.
- """
- if tree_id is None:
- return
- # This could be fairly easily generalized to >2 trees if we find a use
- # case.
- todo = [TreeEntry(b"", stat.S_IFDIR, tree_id)]
- while todo:
- entry = todo.pop()
- if stat.S_ISDIR(entry.mode):
- extra = []
- tree = store[entry.sha]
- assert isinstance(tree, Tree)
- for subentry in tree.iteritems(name_order=True):
- extra.append(subentry.in_path(entry.path))
- todo.extend(reversed(extra))
- if not stat.S_ISDIR(entry.mode) or include_trees:
- yield entry
- def iter_commit_contents(
- store: ObjectContainer,
- commit: Union[Commit, bytes],
- *,
- include: Optional[Sequence[Union[str, bytes, Path]]] = None,
- ):
- """Iterate the contents of the repository at the specified commit.
- This is a wrapper around iter_tree_contents() and
- tree_lookup_path() to simplify the common task of getting the
- contest of a repo at a particular commit. See also
- dulwich.index.build_file_from_blob() for writing individual files
- to disk.
- Args:
- store: Object store to get trees from
- commit: Commit object, or SHA1 of a commit
- include: if provided, only the entries whose paths are in the
- list, or whose parent tree is in the list, will be
- included. Note that duplicate or overlapping paths
- (e.g. ["foo", "foo/bar"]) may result in duplicate entries
- Yields: TreeEntry namedtuples for all matching files in a commit.
- """
- sha = commit.id if isinstance(commit, Commit) else commit
- if not isinstance(obj := store[sha], Commit):
- raise TypeError(
- f"{sha.decode('ascii')} should be ID of a Commit, but is {type(obj)}"
- )
- commit = obj
- encoding = commit.encoding or "utf-8"
- include = (
- [
- path if isinstance(path, bytes) else str(path).encode(encoding)
- for path in include
- ]
- if include is not None
- else [b""]
- )
- for path in include:
- mode, obj_id = tree_lookup_path(store.__getitem__, commit.tree, path)
- # Iterate all contained files if path points to a dir, otherwise just get that
- # single file
- if isinstance(store[obj_id], Tree):
- for entry in iter_tree_contents(store, obj_id):
- yield entry.in_path(path)
- else:
- yield TreeEntry(path, mode, obj_id)
- def peel_sha(store: ObjectContainer, sha: bytes) -> tuple[ShaFile, ShaFile]:
- """Peel all tags from a SHA.
- Args:
- store: Object store to get objects from
- sha: The object SHA to peel.
- Returns: The fully-peeled SHA1 of a tag object, after peeling all
- intermediate tags; if the original ref does not point to a tag,
- this will equal the original SHA1.
- """
- unpeeled = obj = store[sha]
- obj_class = object_class(obj.type_name)
- while obj_class is Tag:
- assert isinstance(obj, Tag)
- obj_class, sha = obj.object
- obj = store[sha]
- return unpeeled, obj
|