Uses of Interface
org.eclipse.jgit.lib.ProgressMonitor
Packages that use ProgressMonitor
Package
Description
High-level API commands (the porcelain of JGit).
Comparing file contents by computing diffs.
Reading and editing the directory cache (index).
Distributed file system based repository storage.
File based repository storage.
Reading/writing Git pack files.
Core API for repository, config, refs, object database.
Content and commit history merge algorithms.
Walking revision graphs (commit history).
Transport (fetch/push) for different protocols.
Utility classes.
-
Uses of ProgressMonitor in org.eclipse.jgit.api
Fields in org.eclipse.jgit.api declared as ProgressMonitorModifier and TypeFieldDescriptionprivate ProgressMonitorCheckoutCommand.monitorprivate ProgressMonitorCherryPickCommand.monitorprivate ProgressMonitorCloneCommand.monitorprivate ProgressMonitorDiffCommand.monitorprivate ProgressMonitorFetchCommand.monitorprivate ProgressMonitorGarbageCollectCommand.monitorprivate ProgressMonitorMergeCommand.monitorprivate ProgressMonitorPullCommand.monitorprivate ProgressMonitorPushCommand.monitorprivate ProgressMonitorRebaseCommand.monitorprivate ProgressMonitorResetCommand.monitorprivate ProgressMonitorRevertCommand.monitorprivate ProgressMonitorSubmoduleAddCommand.monitorprivate ProgressMonitorSubmoduleUpdateCommand.monitorprivate ProgressMonitorStatusCommand.progressMonitorMethods in org.eclipse.jgit.api that return ProgressMonitorModifier and TypeMethodDescriptionFetchCommand.getProgressMonitor()Get progress monitorPushCommand.getProgressMonitor()Get the progress monitorMethods in org.eclipse.jgit.api with parameters of type ProgressMonitorModifier and TypeMethodDescriptionCheckoutCommand.setProgressMonitor(ProgressMonitor monitor) CherryPickCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the cherry-pick operation.CloneCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the clone operation.DiffCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the diff operation.FetchCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the fetch operation.GarbageCollectCommand.setProgressMonitor(ProgressMonitor monitor) Set progress monitorMergeCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the diff operation.PullCommand.setProgressMonitor(ProgressMonitor monitor) Set progress monitorPushCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the push operation.RebaseCommand.setProgressMonitor(ProgressMonitor monitor) Set progress monitorResetCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the reset operation.RevertCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the revert operation.StatusCommand.setProgressMonitor(ProgressMonitor progressMonitor) To set theProgressMonitorwhich contains callback methods to inform you about the progress of this command.SubmoduleAddCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the clone operation.SubmoduleUpdateCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the clone operation. -
Uses of ProgressMonitor in org.eclipse.jgit.diff
Fields in org.eclipse.jgit.diff declared as ProgressMonitorMethods in org.eclipse.jgit.diff with parameters of type ProgressMonitorModifier and TypeMethodDescriptionprivate voidRenameDetector.advanceOrCancel(ProgressMonitor pm) private voidRenameDetector.breakModifies(ContentSource.Pair reader, ProgressMonitor pm) private intSimilarityRenameDetector.buildMatrix(ProgressMonitor pm) RenameDetector.compute(ContentSource.Pair reader, ProgressMonitor pm) Detect renames in the current file set.RenameDetector.compute(ObjectReader reader, ProgressMonitor pm) Detect renames in the current file set.RenameDetector.compute(ProgressMonitor pm) Detect renames in the current file set.(package private) voidSimilarityRenameDetector.compute(ProgressMonitor pm) private voidRenameDetector.findContentRenames(ContentSource.Pair reader, ProgressMonitor pm) private voidRenameDetector.findExactRenames(ProgressMonitor pm) private HashMap<AbbreviatedObjectId,Object> RenameDetector.populateMap(List<DiffEntry> diffEntries, ProgressMonitor pm) private voidRenameDetector.rejoinModifies(ProgressMonitor pm) voidDiffFormatter.setProgressMonitor(ProgressMonitor pm) Set the progress monitor for long running rename detection. -
Uses of ProgressMonitor in org.eclipse.jgit.dircache
Fields in org.eclipse.jgit.dircache declared as ProgressMonitorMethods in org.eclipse.jgit.dircache with parameters of type ProgressMonitorModifier and TypeMethodDescriptionvoidDirCacheCheckout.setProgressMonitor(ProgressMonitor monitor) Set a progress monitor which can be passed to built-in filter commands, providing progress information for long running tasks. -
Uses of ProgressMonitor in org.eclipse.jgit.gitrepo
Fields in org.eclipse.jgit.gitrepo declared as ProgressMonitorModifier and TypeFieldDescriptionprivate ProgressMonitorRegularSuperprojectWriter.monitorprivate ProgressMonitorRepoCommand.monitorMethods in org.eclipse.jgit.gitrepo with parameters of type ProgressMonitorModifier and TypeMethodDescriptionRepoCommand.setProgressMonitor(ProgressMonitor monitor) The progress monitor associated with the clone operation.Constructors in org.eclipse.jgit.gitrepo with parameters of type ProgressMonitorModifierConstructorDescription(package private)RegularSuperprojectWriter(Repository repo, ProgressMonitor monitor) -
Uses of ProgressMonitor in org.eclipse.jgit.internal.storage.dfs
Methods in org.eclipse.jgit.internal.storage.dfs with parameters of type ProgressMonitorModifier and TypeMethodDescriptionprivate voidDfsPackCompactor.addObjectsToPack(PackWriter pw, DfsReader ctx, ProgressMonitor pm) DfsFsck.check(ProgressMonitor pm) Verify the integrity and connectivity of all objects in the object database.private voidDfsFsck.checkConnectivity(ProgressMonitor pm, FsckError errors) private voidDfsFsck.checkGitModules(ProgressMonitor pm, FsckError errors) private voidDfsFsck.checkPacks(ProgressMonitor pm, FsckError errors) voidDfsPackCompactor.compact(ProgressMonitor pm) Compact the pack files together.private voidDfsPackCompactor.compactPacks(DfsReader ctx, ProgressMonitor pm) booleanDfsGarbageCollector.pack(ProgressMonitor pm) Create a single new pack file containing all of the live objects.private voidDfsGarbageCollector.packGarbage(ProgressMonitor pm) private voidDfsGarbageCollector.packHeads(ProgressMonitor pm) private voidDfsGarbageCollector.packRest(ProgressMonitor pm) DfsPackParser.parse(ProgressMonitor receiving, ProgressMonitor resolving) Parse the pack stream.voidDfsReader.selectObjectRepresentation(PackWriter packer, ProgressMonitor monitor, Iterable<ObjectToPack> objects) private voidDfsReader.trySelectRepresentation(PackWriter packer, ProgressMonitor monitor, Iterable<ObjectToPack> objects, List<DfsPackFile> packs, boolean skipFound) private voidDfsFsck.verifyPack(ProgressMonitor pm, FsckError errors, DfsReader ctx, DfsPackFile pack, ReadableChannel ch) static voidDfsBundleWriter.writeEntireRepositoryAsBundle(ProgressMonitor pm, OutputStream os, DfsRepository db) Writes the entireDfsRepositoryto a Git bundle.private DfsPackDescriptionDfsGarbageCollector.writePack(DfsObjDatabase.PackSource source, PackWriter pw, ProgressMonitor pm, long estimatedPackSize) private static voidDfsPackCompactor.writePack(DfsObjDatabase objdb, DfsPackDescription pack, PackWriter pw, ProgressMonitor pm) -
Uses of ProgressMonitor in org.eclipse.jgit.internal.storage.file
Fields in org.eclipse.jgit.internal.storage.file declared as ProgressMonitorMethods in org.eclipse.jgit.internal.storage.file with parameters of type ProgressMonitorModifier and TypeMethodDescriptionvoidFileRepository.autoGC(ProgressMonitor monitor) Check whether any housekeeping is required; if yes, run garbage collection; if not, exit without performing any work.voidPackedBatchRefUpdate.execute(RevWalk walk, ProgressMonitor monitor, List<String> options) Execute this batch update.ObjectDirectoryPackParser.parse(ProgressMonitor receiving, ProgressMonitor resolving) Parse the pack stream.voidWindowCursor.selectObjectRepresentation(PackWriter packer, ProgressMonitor monitor, Iterable<ObjectToPack> objects) Select the best object representation for a packer.Set the progress monitor used for garbage collection methods. -
Uses of ProgressMonitor in org.eclipse.jgit.internal.storage.io
Fields in org.eclipse.jgit.internal.storage.io declared as ProgressMonitorModifier and TypeFieldDescriptionprivate final ProgressMonitorCancellableDigestOutputStream.writeMonitorMethods in org.eclipse.jgit.internal.storage.io that return ProgressMonitorModifier and TypeMethodDescriptionfinal ProgressMonitorCancellableDigestOutputStream.getWriteMonitor()Get the monitor which is used to update on output progress and check cancel.Constructors in org.eclipse.jgit.internal.storage.io with parameters of type ProgressMonitorModifierConstructorDescriptionCancellableDigestOutputStream(ProgressMonitor writeMonitor, OutputStream out) Initialize a CancellableDigestOutputStream. -
Uses of ProgressMonitor in org.eclipse.jgit.internal.storage.pack
Fields in org.eclipse.jgit.internal.storage.pack declared as ProgressMonitorModifier and TypeFieldDescriptionprivate final ProgressMonitorDeltaWindow.monitorprivate final ProgressMonitorPackWriterBitmapPreparer.pmprivate final ProgressMonitorBaseSearch.progressMethods in org.eclipse.jgit.internal.storage.pack with parameters of type ProgressMonitorModifier and TypeMethodDescriptionprivate voidPackWriter.beginPhase(PackWriter.PackingPhase phase, ProgressMonitor monitor, long cnt) private voidPackWriter.endPhase(ProgressMonitor monitor) private voidPackWriter.findObjectsToPack(ProgressMonitor countingMonitor, ObjectWalk walker, Set<? extends ObjectId> want, Set<? extends ObjectId> have, Set<? extends ObjectId> noBitmaps) private voidPackWriter.parallelDeltaSearch(ProgressMonitor monitor, ObjectToPack[] list, int cnt, int threads) booleanPackWriter.prepareBitmapIndex(ProgressMonitor pm) Prepares the bitmaps to be written to the bitmap index file.voidPackWriter.preparePack(ProgressMonitor countingMonitor, Set<? extends ObjectId> want, Set<? extends ObjectId> have) Prepare the list of objects to be written to the pack stream.voidPackWriter.preparePack(ProgressMonitor countingMonitor, Set<? extends ObjectId> want, Set<? extends ObjectId> have, Set<? extends ObjectId> shallow) Prepare the list of objects to be written to the pack stream.voidPackWriter.preparePack(ProgressMonitor countingMonitor, Set<? extends ObjectId> want, Set<? extends ObjectId> have, Set<? extends ObjectId> shallow, Set<? extends ObjectId> noBitmaps) Prepare the list of objects to be written to the pack stream.voidPackWriter.preparePack(ProgressMonitor countingMonitor, ObjectWalk walk, Set<? extends ObjectId> interestingObjects, Set<? extends ObjectId> uninterestingObjects, Set<? extends ObjectId> noBitmaps) Prepare the list of objects to be written to the pack stream.private voidPackWriter.searchForDeltas(ProgressMonitor monitor) private voidPackWriter.searchForDeltas(ProgressMonitor monitor, ObjectToPack[] list, int cnt) private voidPackWriter.searchForReuse(ProgressMonitor monitor) private voidPackWriter.searchForReuse(ProgressMonitor monitor, List<ObjectToPack> list) voidObjectReuseAsIs.selectObjectRepresentation(PackWriter packer, ProgressMonitor monitor, Iterable<ObjectToPack> objects) Select the best object representation for a packer.private voidPackWriter.singleThreadDeltaSearch(ProgressMonitor monitor, ObjectToPack[] list, int cnt) voidPackWriter.writePack(ProgressMonitor compressMonitor, ProgressMonitor writeMonitor, OutputStream packStream) Write the prepared pack to the supplied stream.Constructors in org.eclipse.jgit.internal.storage.pack with parameters of type ProgressMonitorModifierConstructorDescription(package private)BaseSearch(ProgressMonitor countingMonitor, Set<RevTree> bases, ObjectIdOwnerMap<ObjectToPack> objects, List<ObjectToPack> edges, ObjectReader or) (package private)DeltaWindow(PackConfig pc, DeltaCache dc, ObjectReader or, ProgressMonitor pm, long bpu, ObjectToPack[] in, int beginIndex, int endIndex) PackOutputStream(ProgressMonitor writeMonitor, OutputStream out, PackWriter pw) Initialize a pack output stream.(package private)PackWriterBitmapPreparer(ObjectReader reader, PackBitmapIndexBuilder writeBitmaps, ProgressMonitor pm, Set<? extends ObjectId> want, PackConfig config) -
Uses of ProgressMonitor in org.eclipse.jgit.internal.storage.reftable
Methods in org.eclipse.jgit.internal.storage.reftable with parameters of type ProgressMonitorModifier and TypeMethodDescriptionvoidReftableBatchRefUpdate.execute(RevWalk rw, ProgressMonitor pm, List<String> options) Execute this batch update. -
Uses of ProgressMonitor in org.eclipse.jgit.internal.transport.connectivity
Methods in org.eclipse.jgit.internal.transport.connectivity with parameters of type ProgressMonitorModifier and TypeMethodDescriptionprivate voidFullConnectivityChecker.checkCommitTree(ConnectivityChecker.ConnectivityCheckInfo connectivityCheckInfo, ObjectWalk ow, ProgressMonitor pm) voidFullConnectivityChecker.checkConnectivity(ConnectivityChecker.ConnectivityCheckInfo connectivityCheckInfo, Set<ObjectId> haves, ProgressMonitor pm) voidIterativeConnectivityChecker.checkConnectivity(ConnectivityChecker.ConnectivityCheckInfo connectivityCheckInfo, Set<ObjectId> advertisedHaves, ProgressMonitor pm) private voidFullConnectivityChecker.checkObjects(ConnectivityChecker.ConnectivityCheckInfo connectivityCheckInfo, ObjectWalk ow, ProgressMonitor pm) private booleanFullConnectivityChecker.markStartAndKnownNodes(ConnectivityChecker.ConnectivityCheckInfo connectivityCheckInfo, ObjectWalk ow, Set<ObjectId> haves, ProgressMonitor pm) -
Uses of ProgressMonitor in org.eclipse.jgit.lib
Classes in org.eclipse.jgit.lib that implement ProgressMonitorModifier and TypeClassDescriptionclassProgressMonitor that batches update events.classA convenient base class which provides empty method bodies for all ProgressMonitor methods.classA NullProgressMonitor does not report progress anywhere.classA simple progress reporter printing on a stream.classWrapper around the generalProgressMonitorto make it thread safe.Fields in org.eclipse.jgit.lib declared as ProgressMonitorModifier and TypeFieldDescriptionprivate final ProgressMonitorIndexDiff.ProgressReportingFilter.monitorprivate final ProgressMonitorThreadSafeProgressMonitor.pmMethods in org.eclipse.jgit.lib with parameters of type ProgressMonitorModifier and TypeMethodDescriptionvoidRepository.autoGC(ProgressMonitor monitor) Check whether any housekeeping is required; if yes, run garbage collection; if not, exit without performing any work.booleanIndexDiff.diff(ProgressMonitor monitor, int estWorkTreeSize, int estIndexSize, String title) Run the diff operation.booleanIndexDiff.diff(ProgressMonitor monitor, int estWorkTreeSize, int estIndexSize, String title, RepositoryBuilderFactory factory) Run the diff operation.voidBatchRefUpdate.execute(RevWalk walk, ProgressMonitor monitor) Execute this batch update without option strings.voidBatchRefUpdate.execute(RevWalk walk, ProgressMonitor monitor, List<String> options) Execute this batch update.Constructors in org.eclipse.jgit.lib with parameters of type ProgressMonitorModifierConstructorDescriptionprivateProgressReportingFilter(ProgressMonitor monitor, int total) Wrap a ProgressMonitor to be thread safe. -
Uses of ProgressMonitor in org.eclipse.jgit.merge
Fields in org.eclipse.jgit.merge declared as ProgressMonitorMethods in org.eclipse.jgit.merge with parameters of type ProgressMonitorModifier and TypeMethodDescriptionvoidMerger.setProgressMonitor(ProgressMonitor monitor) Set a progress monitor. -
Uses of ProgressMonitor in org.eclipse.jgit.pgm.debug
Fields in org.eclipse.jgit.pgm.debug declared as ProgressMonitor -
Uses of ProgressMonitor in org.eclipse.jgit.revwalk
Fields in org.eclipse.jgit.revwalk declared as ProgressMonitorMethods in org.eclipse.jgit.revwalk with parameters of type ProgressMonitorModifier and TypeMethodDescriptionRevWalkUtils.findBranchesReachableFrom(RevCommit commit, RevWalk revWalk, Collection<Ref> refs, ProgressMonitor monitor) Find the list of branches a given commit is reachable from when following parents.RevWalk.getMergedInto(RevCommit needle, Collection<Ref> haystacks, Enum returnStrategy, ProgressMonitor monitor) RevWalk.getMergedInto(RevCommit commit, Collection<Ref> refs, ProgressMonitor monitor) Determine the Refs into which a commit is merged.Constructors in org.eclipse.jgit.revwalk with parameters of type ProgressMonitorModifierConstructorDescriptionBitmapWalker(ObjectWalk walker, BitmapIndex bitmapIndex, ProgressMonitor pm) Create a BitmapWalker. -
Uses of ProgressMonitor in org.eclipse.jgit.transport
Classes in org.eclipse.jgit.transport that implement ProgressMonitorModifier and TypeClassDescription(package private) classWrite progress messages out to the sideband channel.Fields in org.eclipse.jgit.transport declared as ProgressMonitorMethods in org.eclipse.jgit.transport with parameters of type ProgressMonitorModifier and TypeMethodDescriptionAmazonS3.beginPut(String bucket, String key, ProgressMonitor monitor, String monitorTask) Atomically create or replace a single large object.voidConnectivityChecker.checkConnectivity(ConnectivityChecker.ConnectivityCheckInfo connectivityCheckInfo, Set<ObjectId> haves, ProgressMonitor pm) Checks connectivity of the commit graph after pack uploading.protected abstract voidBaseFetchConnection.doFetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have) Implementation ofBaseFetchConnection.fetch(ProgressMonitor, Collection, Set)without checking for multiple fetch.protected voidBasePackFetchConnection.doFetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have, OutputStream outputStream) Execute common ancestor negotiation and fetch the objects.protected voidBundleFetchConnection.doFetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have) Implementation ofBaseFetchConnection.fetch(ProgressMonitor, Collection, Set)without checking for multiple fetch.protected voidTransportHttp.SmartHttpFetchConnection.doFetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have, OutputStream outputStream) protected voidWalkFetchConnection.doFetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have) Implementation ofBaseFetchConnection.fetch(ProgressMonitor, Collection, Set)without checking for multiple fetch.private voidBasePackFetchConnection.doFetchV2(ProgressMonitor monitor, Collection<Ref> want, OutputStream outputStream) protected voidBasePackPushConnection.doPush(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates, OutputStream outputStream) Push one or more objects and update the remote repository.protected voidTransportHttp.SmartHttpPushConnection.doPush(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates, OutputStream outputStream) private voidWalkFetchConnection.downloadObject(ProgressMonitor pm, AnyObjectId id) (package private) voidWalkFetchConnection.RemotePack.downloadPack(ProgressMonitor monitor) private booleanWalkFetchConnection.downloadPackedObject(ProgressMonitor monitor, AnyObjectId id) private StringBasePackPushConnection.enableCapabilities(ProgressMonitor monitor, OutputStream outputStream) (package private) voidFetchProcess.execute(ProgressMonitor monitor, FetchResult result, String initialBranch) (package private) PushResultPushProcess.execute(ProgressMonitor monitor) Perform push operation between local and remote repository - set remote refs appropriately, send needed objects and update local tracking refs.private voidFetchProcess.executeImp(ProgressMonitor monitor, FetchResult result, String initialBranch) private Collection<WalkRemoteObjectDatabase>WalkFetchConnection.expandOneAlternate(AnyObjectId id, ProgressMonitor pm) final voidBaseFetchConnection.fetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have) Fetch objects we don't have but that are reachable from advertised refs.final voidBaseFetchConnection.fetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have, OutputStream out) Fetch objects we don't have but that are reachable from advertised refs.final voidBasePackFetchConnection.fetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have) Fetch objects we don't have but that are reachable from advertised refs.final voidBasePackFetchConnection.fetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have, OutputStream outputStream) Fetch objects we don't have but that are reachable from advertised refs.voidFetchConnection.fetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have) Fetch objects we don't have but that are reachable from advertised refs.voidFetchConnection.fetch(ProgressMonitor monitor, Collection<Ref> want, Set<ObjectId> have, OutputStream out) Fetch objects we don't have but that are reachable from advertised refs.Transport.fetch(ProgressMonitor monitor, Collection<RefSpec> toFetch) Fetch objects and refs from the remote repository to the local one.Transport.fetch(ProgressMonitor monitor, Collection<RefSpec> toFetch, String branch) Fetch objects and refs from the remote repository to the local one.private voidFetchProcess.fetchObjects(ProgressMonitor monitor) private voidBasePackFetchConnection.negotiate(ProgressMonitor monitor) (package private) voidWalkFetchConnection.RemotePack.openIndex(ProgressMonitor pm) final PackLockPackParser.parse(ProgressMonitor progress) Parse the pack stream.PackParser.parse(ProgressMonitor receiving, ProgressMonitor resolving) Parse the pack stream.private voidPackParser.processDeltas(ProgressMonitor resolving) voidBasePackPushConnection.push(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates) Pushes to the remote repository basing on provided specification.voidBasePackPushConnection.push(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates, OutputStream outputStream) Pushes to the remote repository basing on provided specification.voidPushConnection.push(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates) Pushes to the remote repository basing on provided specification.voidPushConnection.push(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates, OutputStream out) Pushes to the remote repository basing on provided specification.Transport.push(ProgressMonitor monitor, Collection<RemoteRefUpdate> toPush) Push objects and refs from the local repository to the remote one.Transport.push(ProgressMonitor monitor, Collection<RemoteRefUpdate> toPush, OutputStream out) Push objects and refs from the local repository to the remote one.voidWalkPushConnection.push(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates) Pushes to the remote repository basing on provided specification.voidWalkPushConnection.push(ProgressMonitor monitor, Map<String, RemoteRefUpdate> refUpdates, OutputStream out) Pushes to the remote repository basing on provided specification.(package private) voidAmazonS3.putImpl(String bucket, String key, byte[] csum, TemporaryBuffer buf, ProgressMonitor monitor, String monitorTask) private booleanBasePackFetchConnection.readAcknowledgments(BasePackFetchConnection.FetchStateV2 fetchState, PacketLineIn input, ProgressMonitor monitor) Reads and processes acknowledgments, adding ACKed objects as "have"s to the global stateTemporaryBuffer.private voidBasePackFetchConnection.receivePack(ProgressMonitor monitor, OutputStream outputStream) private voidPackParser.resolveDeltas(ProgressMonitor progress) private voidPackParser.resolveDeltas(PackedObjectInfo oe, ProgressMonitor progress) private voidPackParser.resolveDeltas(PackParser.DeltaVisit visit, int type, PackParser.ObjectTypeAndSize info, ProgressMonitor progress) private voidPackParser.resolveDeltasWithExternalBases(ProgressMonitor progress) private booleanBasePackFetchConnection.sendNextHaveBatch(BasePackFetchConnection.FetchStateV2 fetchState, PacketLineOut output, ProgressMonitor monitor) Sends the next batch of "have"s and terminates theoutput.private voidWalkPushConnection.sendpack(List<RemoteRefUpdate> updates, ProgressMonitor monitor) private voidUploadPack.sendPack(ProgressMonitor pm, PacketLineOut pckOut, OutputStream packOut, FetchRequest req, PackStatistics.Accumulator accumulator, Collection<Ref> allTags, List<ObjectId> unshallowCommits, List<ObjectId> deepenNots) Send the requested objects to the client.voidBundleWriter.writeBundle(ProgressMonitor monitor, OutputStream os) Generate and write the bundle to the output stream.private voidBasePackPushConnection.writeCommands(Collection<RemoteRefUpdate> refUpdates, ProgressMonitor monitor, OutputStream outputStream) (package private) OutputStreamTransportAmazonS3.DatabaseS3.writeFile(String path, ProgressMonitor monitor, String monitorTask) (package private) OutputStreamTransportSftp.SftpObjectDB.writeFile(String path, ProgressMonitor monitor, String monitorTask) (package private) OutputStreamWalkRemoteObjectDatabase.writeFile(String path, ProgressMonitor monitor, String monitorTask) Open a remote file for writing.private voidBasePackPushConnection.writePack(Map<String, RemoteRefUpdate> refUpdates, ProgressMonitor monitor) Constructors in org.eclipse.jgit.transport with parameters of type ProgressMonitorModifierConstructorDescription(package private)SideBandInputStream(InputStream in, ProgressMonitor progress, Writer messageStream, OutputStream outputStream) -
Uses of ProgressMonitor in org.eclipse.jgit.util
Methods in org.eclipse.jgit.util with parameters of type ProgressMonitorModifier and TypeMethodDescriptionvoidTemporaryBuffer.LocalFile.writeTo(OutputStream os, ProgressMonitor pm) voidTemporaryBuffer.writeTo(OutputStream os, ProgressMonitor pm) Send this buffer to an output stream.