Class TrackerWithProgress
java.lang.Object
org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker<org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange,org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteProgress>
org.apache.beam.sdk.io.gcp.pubsublite.internal.TrackerWithProgress
- All Implemented Interfaces:
RestrictionTracker.HasProgress
public abstract class TrackerWithProgress
extends RestrictionTracker<org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteRange,org.apache.beam.sdk.io.gcp.pubsublite.internal.OffsetByteProgress>
implements RestrictionTracker.HasProgress
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
RestrictionTracker.HasProgress, RestrictionTracker.IsBounded, RestrictionTracker.Progress, RestrictionTracker.TruncateResult<RestrictionT>
-
Constructor Summary
Constructors -
Method Summary
Methods inherited from class org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker
checkDone, currentRestriction, isBounded, tryClaim, trySplit
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.apache.beam.sdk.transforms.splittabledofn.RestrictionTracker.HasProgress
getProgress
-
Constructor Details
-
TrackerWithProgress
public TrackerWithProgress()
-