- Checkpoint - Interface in io.pravega.client.stream
-
- checkStatus() - Method in interface io.pravega.client.stream.Transaction
-
Gets the status of the transaction.
- ClientConfig - Class in io.pravega.client
-
This class contains configuration that is passed on to Pravega client.
- ClientConfig() - Constructor for class io.pravega.client.ClientConfig
-
- ClientConfig.ClientConfigBuilder - Class in io.pravega.client
-
This class overrides the lombok builder.
- ClientConfigBuilder() - Constructor for class io.pravega.client.ClientConfig.ClientConfigBuilder
-
- close() - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Close this manager class.
- close() - Method in interface io.pravega.client.admin.StreamManager
-
Closes the stream manager.
- close() - Method in interface io.pravega.client.batch.SegmentIterator
-
Closes the iterator, freeing any resources associated with it.
- close() - Method in interface io.pravega.client.BatchClientFactory
-
Closes the client factory.
- close() - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Closes the reader.
- close() - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
Flushes the buffer and closes the writer.
- close() - Method in interface io.pravega.client.ByteStreamClientFactory
-
Closes the ByteStreamClientFactory.
- close() - Method in interface io.pravega.client.EventStreamClientFactory
-
Closes the client factory.
- close() - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Closes the client and frees any resources associated with it.
- close() - Method in interface io.pravega.client.state.StateSynchronizer
-
Closes the StateSynchronizer and frees any resources associated with it.
- close() - Method in interface io.pravega.client.stream.EventStreamReader
-
Close the reader.
- close() - Method in interface io.pravega.client.stream.EventStreamWriter
-
Calls flush and then closes the writer.
- close() - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
-
Calls flush and then closes the writer.
- close() - Method in interface io.pravega.client.stream.ReaderGroup
-
Closes the reader group, freeing any resources associated with it.
- close() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Closes the writer.
- close() - Method in interface io.pravega.client.SynchronizerClientFactory
-
Closes the client factory.
- closeAndSeal() - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
- closeAt(Position) - Method in interface io.pravega.client.stream.EventStreamReader
-
Close the reader at a specific position.
- commit() - Method in interface io.pravega.client.stream.Transaction
-
Causes all messages previously written to the transaction to go into the stream contiguously.
- commit(long) - Method in interface io.pravega.client.stream.Transaction
-
- compact(Function<StateT, InitialUpdate<StateT>>) - Method in interface io.pravega.client.state.StateSynchronizer
-
Provide a function that generates compacted version of localState so that we can drop some of the
history updates.
- compareAndSetMark(Revision, Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
- compareTo(Sequence) - Method in class io.pravega.client.stream.Sequence
-
- create(URI) - Static method in interface io.pravega.client.admin.StreamManager
-
Creates a new instance of StreamManager.
- create(ClientConfig) - Static method in interface io.pravega.client.admin.StreamManager
-
Creates a new instance of StreamManager.
- create(Controller, String, String) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
- create(Controller, Segment) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
- create(String, Controller, Segment) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
- create(String, Controller, String, String) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
- create(String, Revision) - Method in interface io.pravega.client.state.InitialUpdate
-
Returns an object of type StateT with the provided revision.
- createByteStreamReader(String) - Method in interface io.pravega.client.ByteStreamClientFactory
-
Creates a new ByteStreamReader on the specified stream initialized to offset 0.
- createByteStreamWriter(String) - Method in interface io.pravega.client.ByteStreamClientFactory
-
Creates a new ByteStreamWriter on the specified stream.
- createEventWriter(String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates a new writer that can write to the specified stream.
- createEventWriter(String, String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates a new writer that can write to the specified stream.
- createReader(String, String, Serializer<T>, ReaderConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates (or recreates) a new reader that is part of a
ReaderGroup
.
- createReaderGroup(String, ReaderGroupConfig) - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Creates a new ReaderGroup.
- createRevisionedStreamClient(String, Serializer<T>, SynchronizerConfig) - Method in interface io.pravega.client.SynchronizerClientFactory
-
Creates a new RevisionedStreamClient that will work with the specified stream.
- createScope(String) - Method in interface io.pravega.client.admin.StreamManager
-
Creates a new scope.
- createStateSynchronizer(String, Serializer<UpdateT>, Serializer<InitT>, SynchronizerConfig) - Method in interface io.pravega.client.SynchronizerClientFactory
-
Creates a new StateSynchronizer that will work on the specified stream.
- createStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.admin.StreamManager
-
Creates a new stream
- createTransactionalEventWriter(String, String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates a new transactional writer that can write to the specified stream atomically.
- createTransactionalEventWriter(String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates a new transactional writer that can write to the specified stream atomically.
- createWithEmptyToken() - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
- generateStreamCuts(ScheduledExecutorService) - Method in interface io.pravega.client.stream.ReaderGroup
-
- getCheckpointName() - Method in interface io.pravega.client.stream.EventRead
-
- getConfig() - Method in interface io.pravega.client.stream.EventStreamReader
-
Gets the configuration that this reader was created with.
- getConfig() - Method in interface io.pravega.client.stream.EventStreamWriter
-
Returns the configuration that this writer was create with.
- getConfig() - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
-
Returns the configuration that this writer was create with.
- getConfig() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Returns the configuration that this writer was created with.
- getCurrentTimeWindow(Stream) - Method in interface io.pravega.client.stream.EventStreamReader
-
- getEndOfDataNotifier(ScheduledExecutorService) - Method in class io.pravega.client.stream.notifications.NotifierFactory
-
- getEndOfDataNotifier(ScheduledExecutorService) - Method in interface io.pravega.client.stream.notifications.ReaderGroupNotificationListener
-
Get an end of data notifier for a given reader group.
- getEndOffset() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the end offset of the segment.
- getEndStreamCut() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
- getEvent() - Method in interface io.pravega.client.stream.EventRead
-
Returns the event that is wrapped in this EventRead or null a timeout occurred or if a checkpoint was requested.
- getEventPointer() - Method in interface io.pravega.client.stream.EventRead
-
Returns a pointer object for the event read.
- getGroupName() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns the name of the group.
- getIterator() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
- getMark() - Method in interface io.pravega.client.state.RevisionedStreamClient
-
- getMetrics() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns metrics for this reader group.
- getName() - Method in interface io.pravega.client.stream.Checkpoint
-
- getOffset() - Method in interface io.pravega.client.batch.SegmentIterator
-
Provides the current offset in the segment.
- getOffset() - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Returns the current byte offset in the segment.
- getOnlineReaders() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns a set of readerIds for the readers that are considered to be online by the group.
- getPosition() - Method in interface io.pravega.client.stream.EventRead
-
The position in the stream that represents where the reader is immediately following this
event.
- getReaderGroup(String) - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Returns the requested reader group.
- getReaderSegmentDistribution() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns current distribution of number of segments assigned to each reader in the reader group.
- getRevision() - Method in interface io.pravega.client.state.Revisioned
-
Returns the revision corresponding to this object.
- getScope() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the scope name of the stream the segment is associated with.
- getScope() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns the scope of the stream which the group is associated with.
- getScope() - Method in interface io.pravega.client.stream.Stream
-
Gets the scope of this stream.
- getScopedName() - Method in interface io.pravega.client.stream.Stream
-
Gets the scoped name of this stream.
- getScopedStreamName() - Method in interface io.pravega.client.state.Revisioned
-
Returns the scoped name of this stream used to persist this object.
- getSegmentId() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the segment number of Segment.
- getSegmentNotifier(ScheduledExecutorService) - Method in class io.pravega.client.stream.notifications.NotifierFactory
-
- getSegmentNotifier(ScheduledExecutorService) - Method in interface io.pravega.client.stream.notifications.ReaderGroupNotificationListener
-
Get a segment notifier for a given reader group.
- getSegments(Stream, StreamCut, StreamCut) - Method in interface io.pravega.client.BatchClientFactory
-
Provides a list of segments for a given stream between fromStreamCut and toStreamCut.
- getStartOffset() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the start offset of the segment.
- getStartStreamCut() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
- getState() - Method in interface io.pravega.client.state.StateSynchronizer
-
Gets the state object currently held in memory.
- getStreamCuts() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns a
StreamCut
for each stream that this reader group is reading from.
- getStreamInfo(String, String) - Method in interface io.pravega.client.admin.StreamManager
-
- getStreamName() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the stream name the segment is associated with.
- getStreamName() - Method in interface io.pravega.client.stream.Stream
-
Gets the name of this stream (Not including the scope).
- getStreamNames() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns the set of scoped stream names which was used to configure this group.
- getTxn(UUID) - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Returns a previously created transaction.
- getTxnId() - Method in interface io.pravega.client.stream.Transaction
-
Returns a unique ID that can be used to identify this transaction.
- getType() - Method in class io.pravega.client.stream.notifications.notifier.EndOfDataNotifier
-
- getType() - Method in class io.pravega.client.stream.notifications.notifier.SegmentNotifier
-
- getType() - Method in interface io.pravega.client.stream.notifications.Observable
-
Get the notification type.
- read() - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Reads a single byte.
- read(byte[]) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
- read(byte[], int, int) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
- read(ByteBuffer) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
- ReaderConfig - Class in io.pravega.client.stream
-
- ReaderConfig() - Constructor for class io.pravega.client.stream.ReaderConfig
-
- ReaderConfig.ReaderConfigBuilder - Class in io.pravega.client.stream
-
- ReaderConfigBuilder() - Constructor for class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
-
- ReaderGroup - Interface in io.pravega.client.stream
-
A reader group is a collection of readers that collectively read all the events in the
stream.
- ReaderGroupConfig - Class in io.pravega.client.stream
-
- ReaderGroupConfig() - Constructor for class io.pravega.client.stream.ReaderGroupConfig
-
- ReaderGroupConfig.ReaderGroupConfigBuilder - Class in io.pravega.client.stream
-
- ReaderGroupConfigBuilder() - Constructor for class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
- ReaderGroupManager - Interface in io.pravega.client.admin
-
Used to create and manage reader groups.
- ReaderGroupMetrics - Interface in io.pravega.client.stream
-
- ReaderGroupNotificationListener - Interface in io.pravega.client.stream.notifications
-
ReaderGroup notification listener interface.
- ReaderNotInReaderGroupException - Exception in io.pravega.client.stream
-
Read was invoked on a reader that the reader group does not consider a member.
- ReaderNotInReaderGroupException(String) - Constructor for exception io.pravega.client.stream.ReaderNotInReaderGroupException
-
- readerOffline(String, Position) - Method in interface io.pravega.client.stream.ReaderGroup
-
Invoked when a reader that was added to the group is no longer consuming events.
- ReaderSegmentDistribution - Class in io.pravega.client.stream
-
Describes current distribution of number of segments assigned to each reader in the reader group.
- ReaderSegmentDistribution() - Constructor for class io.pravega.client.stream.ReaderSegmentDistribution
-
- readFrom(Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Read all data after a specified revision to the end of the stream.
- readNextEvent(long) - Method in interface io.pravega.client.stream.EventStreamReader
-
Gets the next event in the stream.
- readSegment(SegmentRange, Serializer<T>) - Method in interface io.pravega.client.BatchClientFactory
-
Provides a SegmentIterator to read the events in the requested segment starting from the
beginning of the segment and ending at the current end of the segment.
- registerListener(Listener<T>) - Method in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
-
- registerListener(Listener<EndOfDataNotification>) - Method in class io.pravega.client.stream.notifications.notifier.EndOfDataNotifier
-
- registerListener(Listener<SegmentNotification>) - Method in class io.pravega.client.stream.notifications.notifier.SegmentNotifier
-
- registerListener(Listener<T>) - Method in interface io.pravega.client.stream.notifications.Observable
-
Register listener for notification type T.
- ReinitializationRequiredException - Exception in io.pravega.client.stream
-
- ReinitializationRequiredException() - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
-
- ReinitializationRequiredException(Throwable) - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
-
- ReinitializationRequiredException(String, Throwable) - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
-
- ReinitializationRequiredException(String) - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
-
- removeListener(String, Listener<T>) - Method in class io.pravega.client.stream.notifications.NotificationSystem
-
Remove Listener of a given notification type.
- removeListeners(String) - Method in class io.pravega.client.stream.notifications.NotificationSystem
-
Remove all listeners of a notification type.
- resetReaderGroup(ReaderGroupConfig) - Method in interface io.pravega.client.stream.ReaderGroup
-
- RetentionPolicy - Class in io.pravega.client.stream
-
- RetentionPolicy() - Constructor for class io.pravega.client.stream.RetentionPolicy
-
- RetentionPolicy.RetentionType - Enum in io.pravega.client.stream
-
- retrieveToken() - Method in interface io.pravega.client.security.auth.DelegationTokenProvider
-
Retrieve delegation token.
- retrieveToken() - Method in class io.pravega.client.security.auth.EmptyTokenProviderImpl
-
- retrieveToken() - Method in class io.pravega.client.security.auth.JwtTokenProviderImpl
-
Returns the delegation token.
- retrieveToken() - Method in class io.pravega.client.security.auth.StringTokenProviderImpl
-
- Revision - Interface in io.pravega.client.state
-
- Revisioned - Interface in io.pravega.client.state
-
An object that has a revision associated with it.
- RevisionedStreamClient<T> - Interface in io.pravega.client.state
-
Provides a stream that can be read and written to with strong consistency.
- ScalingPolicy - Class in io.pravega.client.stream
-
A policy that specifies how the number of segments in a stream should scale over time.
- ScalingPolicy() - Constructor for class io.pravega.client.stream.ScalingPolicy
-
- ScalingPolicy.ScaleType - Enum in io.pravega.client.stream
-
- sealStream(String, String) - Method in interface io.pravega.client.admin.StreamManager
-
Seal an existing stream.
- seekToOffset(long) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Seeks to the provided offset (It can be anywhere in the segment).
- SegmentIterator<T> - Interface in io.pravega.client.batch
-
Please note this is an experimental API.
- SegmentNotification - Class in io.pravega.client.stream.notifications
-
Class to represent a segment notification.
- SegmentNotification() - Constructor for class io.pravega.client.stream.notifications.SegmentNotification
-
- SegmentNotifier - Class in io.pravega.client.stream.notifications.notifier
-
- SegmentNotifier(NotificationSystem, StateSynchronizer<ReaderGroupState>, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.notifications.notifier.SegmentNotifier
-
- SegmentRange - Interface in io.pravega.client.batch
-
This is used to represent range bounded portion of a Segment.
- Sequence - Class in io.pravega.client.stream
-
A wrapper for two numbers.
- Sequence() - Constructor for class io.pravega.client.stream.Sequence
-
- serialize(T) - Method in interface io.pravega.client.stream.Serializer
-
Serializes the given event.
- serialize(Watermark) - Method in class io.pravega.client.watermark.WatermarkSerializer
-
- Serializer<T> - Interface in io.pravega.client.stream
-
Takes events being written and serializes them to byteBuffers so they can be sent over the wire
and deserializes these same byte buffers back into objects.
- skip(long) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
This method attempts to skip forward by the provided number of bytes.
- startFromCheckpoint(Checkpoint) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Ensure the readers of the ReaderGroup start from the provided
Checkpoint
.
- startFromStreamCuts(Map<Stream, StreamCut>) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Ensure the readers of the ReaderGroup start from this provided streamCuts.
- StateSynchronizer<StateT extends Revisioned> - Interface in io.pravega.client.state
-
Provides a means to have state that is synchronized between many processes.
- StateSynchronizer.UpdateGenerator<StateT extends Revisioned> - Interface in io.pravega.client.state
-
A function which given a state object populates a list of updates that should be applied.
- StateSynchronizer.UpdateGeneratorFunction<StateT extends Revisioned,ReturnT> - Interface in io.pravega.client.state
-
- stream(String, StreamCut, StreamCut) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Add a stream and its associated start
StreamCut
and end
StreamCut
to be read by the
readers of a ReaderGroup.
- stream(String, StreamCut) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Add a stream and its associated start
StreamCut
to be read by the readers of a ReaderGroup.
- stream(String) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Add a stream that needs to be read by the readers of a ReaderGroup.
- stream(Stream, StreamCut, StreamCut) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Add a stream and its associated start
StreamCut
and end
StreamCut
to be read by
the readers of a ReaderGroup.
- stream(Stream, StreamCut) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Add a stream and its associated start
StreamCut
to be read by the readers of a ReaderGroup.
- stream(Stream) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Add a stream that needs to be read by the readers of a ReaderGroup.
- Stream - Interface in io.pravega.client.stream
-
A stream can be thought of as an unbounded sequence of events.
- StreamConfiguration - Class in io.pravega.client.stream
-
The configuration of a Stream.
- StreamConfiguration() - Constructor for class io.pravega.client.stream.StreamConfiguration
-
- StreamConfiguration.StreamConfigurationBuilder - Class in io.pravega.client.stream
-
- StreamConfigurationBuilder() - Constructor for class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
-
- StreamCut - Interface in io.pravega.client.stream
-
A set of segment/offset pairs for a single stream that represent a consistent position in the
stream.
- StreamInfo - Class in io.pravega.client.admin
-
This class is used to represent Stream information.
- StreamInfo() - Constructor for class io.pravega.client.admin.StreamInfo
-
- StreamManager - Interface in io.pravega.client.admin
-
Used to create, delete, and manage Streams and ReaderGroups.
- StreamSegmentsIterator - Interface in io.pravega.client.batch
-
- StringTokenProviderImpl - Class in io.pravega.client.security.auth
-
A provider for handling non-JWT, non-empty delegation tokens.
- SynchronizerClientFactory - Interface in io.pravega.client
-
Used to create StateSynchronizer and RevisionedStreamClient objects which allow for
reading and writing data from a pre-configured stream with strong consistency guarantees.
- SynchronizerConfig - Class in io.pravega.client.state
-
The configuration for a Consistent replicated state synchronizer.
- SynchronizerConfig() - Constructor for class io.pravega.client.state.SynchronizerConfig
-
- SynchronizerConfig.SynchronizerConfigBuilder - Class in io.pravega.client.state
-
- SynchronizerConfigBuilder() - Constructor for class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
-
- TimeWindow - Class in io.pravega.client.stream
-
Represents a time window for the events which are currently being read by a reader.
- TimeWindow() - Constructor for class io.pravega.client.stream.TimeWindow
-
- toBytes() - Method in interface io.pravega.client.stream.Checkpoint
-
Serializes the checkpoint to a compact byte array.
- toBytes() - Method in interface io.pravega.client.stream.EventPointer
-
Serializes the Event pointer to a compact binary form.
- toBytes() - Method in interface io.pravega.client.stream.Position
-
Serializes the position to a compact byte array.
- toBytes() - Method in class io.pravega.client.stream.ReaderGroupConfig
-
- toBytes() - Method in interface io.pravega.client.stream.StreamCut
-
Serializes the cut to a compact byte array.
- toString() - Method in interface io.pravega.client.state.Revision
-
Serializes the Revision to a human readable string.
- Transaction<Type> - Interface in io.pravega.client.stream
-
Provides a mechanism for writing many events atomically.
- Transaction.PingStatus - Enum in io.pravega.client.stream
-
- Transaction.Status - Enum in io.pravega.client.stream
-
- TransactionalEventStreamWriter<Type> - Interface in io.pravega.client.stream
-
A writer that writes Events to an Event stream transactionally.
- TruncatedDataException - Exception in io.pravega.client.stream
-
- TruncatedDataException() - Constructor for exception io.pravega.client.stream.TruncatedDataException
-
Creates a new instance of TruncatedDataException class.
- TruncatedDataException(Throwable) - Constructor for exception io.pravega.client.stream.TruncatedDataException
-
Creates a new instance of TruncatedDataException class.
- TruncatedDataException(String, Throwable) - Constructor for exception io.pravega.client.stream.TruncatedDataException
-
Creates a new instance of TruncatedDataException class.
- TruncatedDataException(String) - Constructor for exception io.pravega.client.stream.TruncatedDataException
-
Creates a new instance of TruncatedDataException class.
- truncateStream(String, String, StreamCut) - Method in interface io.pravega.client.admin.StreamManager
-
Truncate stream at given stream cut.
- truncateToRevision(Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Removes all data through the revision provided.
- TxnFailedException - Exception in io.pravega.client.stream
-
A transaction has failed.
- TxnFailedException() - Constructor for exception io.pravega.client.stream.TxnFailedException
-
Creates a new instance of TxnFailedException class.
- TxnFailedException(Throwable) - Constructor for exception io.pravega.client.stream.TxnFailedException
-
Creates a new instance of TxnFailedException class.
- TxnFailedException(String, Throwable) - Constructor for exception io.pravega.client.stream.TxnFailedException
-
Creates a new instance of TxnFailedException class.
- TxnFailedException(String) - Constructor for exception io.pravega.client.stream.TxnFailedException
-
Creates a new instance of TxnFailedException class.