Skip navigation links
A B C D E F G I L M N O P R S T U V W 

A

abort() - Method in interface io.pravega.client.stream.Transaction
Drops the transaction, causing all events written to it to be deleted.
AbstractNotifier<T extends Notification> - Class in io.pravega.client.stream.notifications.notifier
AbstractNotifier which is used by all types of Notifiers.
AbstractNotifier(NotificationSystem, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.notifications.notifier.AbstractNotifier
 
AbstractPollingNotifier<T extends Notification> - Class in io.pravega.client.stream.notifications.notifier
 
addListeners(String, Listener<T>, ScheduledExecutorService) - Method in class io.pravega.client.stream.notifications.NotificationSystem
 
applyTo(StateT, Revision) - Method in interface io.pravega.client.state.InitialUpdate
 
applyTo(StateT, Revision) - Method in interface io.pravega.client.state.Update
Return an object of type StateT that is the same as oldState with this update applied to it.
asImpl() - Method in interface io.pravega.client.batch.SegmentRange
For internal use.
asImpl() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
For internal use.
asImpl() - Method in interface io.pravega.client.state.Revision
Returns the actual instance.
asImpl() - Method in interface io.pravega.client.stream.Checkpoint
For internal use.
asImpl() - Method in interface io.pravega.client.stream.EventPointer
Used internally.
asImpl() - Method in interface io.pravega.client.stream.Position
Used internally.
asImpl() - Method in interface io.pravega.client.stream.StreamCut
Used internally.

B

BatchClient - Interface in io.pravega.client.batch
Please note this is an experimental API.
beginTxn() - Method in interface io.pravega.client.stream.EventStreamWriter
Start a new transaction on this stream.
build() - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
build() - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
byDataRate(int, int, int) - Static method in class io.pravega.client.stream.ScalingPolicy
Create a scaling policy to configure a stream to scale up and down according to byte rate.
byEventRate(int, int, int) - Static method in class io.pravega.client.stream.ScalingPolicy
Create a scaling policy to configure a stream to scale up and down according to event rate.
bySizeBytes(long) - Static method in class io.pravega.client.stream.RetentionPolicy
Create a retention policy to configure a stream to truncate a stream according to the amount of data currently stored.
bytesWrittenSinceCompaction() - Method in interface io.pravega.client.state.StateSynchronizer
Calculates the number of bytes that have been written since the state has last been compacted by calling StateSynchronizer.compact(Function) This may be useful when calculating when a compaction should occur.
byTime(Duration) - Static method in class io.pravega.client.stream.RetentionPolicy
Create a retention policy to configure a stream to periodically truncated according to the specified duration.

C

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
 
ClientFactory - Interface in io.pravega.client
Used to create Writers, Readers, and Synchronizers operating on a stream.
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.ClientFactory
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.
commit() - Method in interface io.pravega.client.stream.Transaction
Causes all messages previously written to the transaction to go into the stream contiguously.
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
Records a provided location that can later be obtained by calling RevisionedStreamClient.getMark().
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(String, Revision) - Method in interface io.pravega.client.state.InitialUpdate
Returns an object of type StateT with the provided revision.
createBatchClient() - Method in interface io.pravega.client.ClientFactory
Create a new batch client.
createEventWriter(String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.ClientFactory
Creates a new writer that can write to the specified stream.
createReader(String, String, Serializer<T>, ReaderConfig) - Method in interface io.pravega.client.ClientFactory
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.ClientFactory
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.ClientFactory
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

D

deleteReaderGroup(String) - Method in interface io.pravega.client.admin.ReaderGroupManager
Deletes a reader group, removing any state associated with it.
deleteScope(String) - Method in interface io.pravega.client.admin.StreamManager
Deletes an existing scope.
deleteStream(String, String) - Method in interface io.pravega.client.admin.StreamManager
Deletes the provided stream.
deserialize(ByteBuffer) - Method in interface io.pravega.client.stream.Serializer
Deserializes the given ByteBuffer into an event.
disableAutomaticCheckpoints() - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
Disables automatic checkpointing.

E

EndOfDataNotification - Class in io.pravega.client.stream.notifications
Class to represent a end of data notification.
EndOfDataNotification() - Constructor for class io.pravega.client.stream.notifications.EndOfDataNotification
 
EndOfDataNotifier - Class in io.pravega.client.stream.notifications.notifier
 
EndOfDataNotifier(NotificationSystem, StateSynchronizer<ReaderGroupState>, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.notifications.notifier.EndOfDataNotifier
 
EventPointer - Interface in io.pravega.client.stream
A pointer to an event.
EventRead<T> - Interface in io.pravega.client.stream
An event that was read from a stream or a checkpoint marker if one has been requested.
EventStreamReader<T> - Interface in io.pravega.client.stream
A reader for a stream.
EventStreamWriter<Type> - Interface in io.pravega.client.stream
A writer can write events to a stream.
EventWriterConfig - Class in io.pravega.client.stream
 
EventWriterConfig() - Constructor for class io.pravega.client.stream.EventWriterConfig
 
EventWriterConfig.EventWriterConfigBuilder - Class in io.pravega.client.stream
 
EventWriterConfigBuilder() - Constructor for class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
executor - Variable in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
 

F

fetchEvent(EventPointer) - Method in interface io.pravega.client.stream.EventStreamReader
Re-read an event that was previously read, by passing the pointer returned from EventRead.getEventPointer().
fetchLatestRevision() - Method in interface io.pravega.client.state.RevisionedStreamClient
Returns the latest revision.
fetchOldestRevision() - Method in interface io.pravega.client.state.RevisionedStreamClient
Returns the oldest revision that reads can start from.
fetchUpdates() - Method in interface io.pravega.client.state.StateSynchronizer
Fetch and apply all updates needed to the state object held locally up to date.
fixed(int) - Static method in class io.pravega.client.stream.ScalingPolicy
Create a scaling policy to configure a stream to have a fixed number of segments.
flush() - Method in interface io.pravega.client.stream.EventStreamWriter
Block until all events that have been passed to writeEvent's corresponding futures have completed.
flush() - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
Block until all events that have been passed to writeEvent's corresponding futures have completed.
flush() - Method in interface io.pravega.client.stream.Transaction
Blocks until all events passed to Transaction.writeEvent(String, Object) make it to durable storage.
fromBytes(ByteBuffer) - Static method in interface io.pravega.client.stream.Checkpoint
Deserializes the checkpoint from its serialized from obtained from calling Checkpoint.toBytes().
fromBytes(ByteBuffer) - Static method in interface io.pravega.client.stream.EventPointer
Deserializes the event pointer from its serialized from obtained from calling EventPointer.toBytes().
fromBytes(ByteBuffer) - Static method in interface io.pravega.client.stream.Position
Deserializes the position from its serialized from obtained from calling Position.toBytes().
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.ReaderGroupConfig
 
fromBytes(ByteBuffer) - Static method in interface io.pravega.client.stream.StreamCut
Deserializes the cut from its serialized from obtained from calling StreamCut.toBytes().
fromString(String) - Static method in interface io.pravega.client.state.Revision
Deserializes the revision from its serialized from obtained from calling Revision.toString().

G

getCheckpointName() - Method in interface io.pravega.client.stream.EventRead
If a checkpoint has been requested this will return the checkpointName passed to ReaderGroup.initiateCheckpoint(String,ScheduledExecutorService) otherwise this will return null.
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.
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
This returns an iterator for SegmentRange specified in BatchClient.getSegments(Stream, StreamCut, StreamCut).
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.
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.
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.batch.BatchClient
Provide 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 stream cut for each stream that this reader group is reading from.
getStreamInfo(Stream) - Method in interface io.pravega.client.batch.BatchClient
Get information about a given Stream, StreamInfo.
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 stream names which was used to configure this group.
getTxn(UUID) - Method in interface io.pravega.client.stream.EventStreamWriter
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.

I

IdempotentEventStreamWriter<Type> - Interface in io.pravega.client.stream
A writer can write events to a stream.
initialize(InitialUpdate<StateT>) - Method in interface io.pravega.client.state.StateSynchronizer
This method can be used to provide an initial value for a new stream if the stream has not been previously initialized.
InitialUpdate<StateT extends Revisioned> - Interface in io.pravega.client.state
A constructor for a StateT object.
initiateCheckpoint(String, ScheduledExecutorService) - Method in interface io.pravega.client.stream.ReaderGroup
Initiate a checkpoint.
InvalidStreamException - Exception in io.pravega.client.stream
 
InvalidStreamException(String) - Constructor for exception io.pravega.client.stream.InvalidStreamException
 
InvalidStreamException(Throwable) - Constructor for exception io.pravega.client.stream.InvalidStreamException
 
InvalidStreamException(String, Throwable) - Constructor for exception io.pravega.client.stream.InvalidStreamException
 
io.pravega.client - package io.pravega.client
 
io.pravega.client.admin - package io.pravega.client.admin
 
io.pravega.client.batch - package io.pravega.client.batch
 
io.pravega.client.state - package io.pravega.client.state
 
io.pravega.client.stream - package io.pravega.client.stream
 
io.pravega.client.stream.notifications - package io.pravega.client.stream.notifications
 
io.pravega.client.stream.notifications.notifier - package io.pravega.client.stream.notifications.notifier
 
isCheckpoint() - Method in interface io.pravega.client.stream.EventRead
A boolean indicating if this is a checkpoint.
isEnableTls() - Method in class io.pravega.client.ClientConfig
 
isListenerPresent(String) - Method in class io.pravega.client.stream.notifications.NotificationSystem
Check if a Listener is present for a given notification type.

L

Listener<T> - Interface in io.pravega.client.stream.notifications
Listener interface for receiving notifications.

M

MAX_EVENT_SIZE - Static variable in interface io.pravega.client.stream.Serializer
The maximum event size, in bytes.
MAX_VALUE - Static variable in class io.pravega.client.stream.Sequence
 
MIN_VALUE - Static variable in class io.pravega.client.stream.Sequence
 

N

Notification - Class in io.pravega.client.stream.notifications
Represents base notification type.
Notification() - Constructor for class io.pravega.client.stream.notifications.Notification
 
NotificationSystem - Class in io.pravega.client.stream.notifications
 
NotificationSystem() - Constructor for class io.pravega.client.stream.notifications.NotificationSystem
 
NotifierFactory - Class in io.pravega.client.stream.notifications
Factory used to create different types of notifiers.
NotifierFactory(NotificationSystem, StateSynchronizer<ReaderGroupState>) - Constructor for class io.pravega.client.stream.notifications.NotifierFactory
 
notify(T) - Method in class io.pravega.client.stream.notifications.NotificationSystem
This method will ensure the notification is intimated to the listeners of the same type.
notifySystem - Variable in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
 

O

Observable<T> - Interface in io.pravega.client.stream.notifications
This represents an observable notification.
of(String, String) - Static method in interface io.pravega.client.stream.Stream
Helper utility to create a Stream object.
of(String) - Static method in interface io.pravega.client.stream.Stream
Helper utility to create a Stream object from a scopedName of a Stream.
onNotification(T) - Method in interface io.pravega.client.stream.notifications.Listener
 

P

PingFailedException - Exception in io.pravega.client.stream
Transaction heartbeat to a controller instance failed, because of one of the following reasons.
PingFailedException() - Constructor for exception io.pravega.client.stream.PingFailedException
 
PingFailedException(Throwable) - Constructor for exception io.pravega.client.stream.PingFailedException
 
PingFailedException(String, Throwable) - Constructor for exception io.pravega.client.stream.PingFailedException
 
PingFailedException(String) - Constructor for exception io.pravega.client.stream.PingFailedException
 
Position - Interface in io.pravega.client.stream
A position in a stream.

R

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.
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.
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.batch.BatchClient
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
Reset a reader group with the provided ReaderGroupConfig.
resetReadersToCheckpoint(Checkpoint) - Method in interface io.pravega.client.stream.ReaderGroup
Deprecated.
Use ReaderGroup.resetReaderGroup(ReaderGroupConfig) to reset readers to a given Checkpoint.
RetentionPolicy - Class in io.pravega.client.stream
 
RetentionPolicy() - Constructor for class io.pravega.client.stream.RetentionPolicy
 
RetentionPolicy.RetentionType - Enum in io.pravega.client.stream
 
Revision - Interface in io.pravega.client.state
A maker for a version of a Revisioned object.
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.

S

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.
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.
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.
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
Similar to StateSynchronizer.UpdateGenerator but it also returns a result for the caller.
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.batch
This class is used to represent Stream information.
StreamInfo() - Constructor for class io.pravega.client.batch.StreamInfo
 
StreamManager - Interface in io.pravega.client.admin
Used to create, delete, and manage Streams and ReaderGroups.
StreamSegmentsIterator - Interface in io.pravega.client.batch
 
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
 

T

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.Status - Enum in io.pravega.client.stream
 
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.

U

UNBOUNDED - Static variable in interface io.pravega.client.stream.StreamCut
This is used represents an unbounded StreamCut.
unreadBytes() - Method in interface io.pravega.client.stream.ReaderGroupMetrics
Returns the number of bytes between the last recorded position of the readers in the ReaderGroup and the end of the stream(s).
unregisterAllListeners() - Method in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
 
unregisterAllListeners() - Method in class io.pravega.client.stream.notifications.notifier.AbstractPollingNotifier
 
unregisterAllListeners() - Method in interface io.pravega.client.stream.notifications.Observable
Remove all listeners for a given type.
unregisterListener(Listener<T>) - Method in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
 
unregisterListener(Listener<T>) - Method in class io.pravega.client.stream.notifications.notifier.AbstractPollingNotifier
 
unregisterListener(Listener<T>) - Method in interface io.pravega.client.stream.notifications.Observable
Remove a listener.
Update<StateT extends Revisioned> - Interface in io.pravega.client.state
An update to a StateT object coordinated via a StateSynchronizer.
updateState(StateSynchronizer.UpdateGenerator<StateT>) - Method in interface io.pravega.client.state.StateSynchronizer
Creates a new update for the latest state object and applies it atomically.
updateState(StateSynchronizer.UpdateGeneratorFunction<StateT, ReturnT>) - Method in interface io.pravega.client.state.StateSynchronizer
Similar to StateSynchronizer.updateState(UpdateGenerator) but this version returns a result object supplied by the StateSynchronizer.UpdateGeneratorFunction.
updateStateUnconditionally(Update<StateT>) - Method in interface io.pravega.client.state.StateSynchronizer
Persists the provided update.
updateStateUnconditionally(List<? extends Update<StateT>>) - Method in interface io.pravega.client.state.StateSynchronizer
Same as StateSynchronizer.updateStateUnconditionally(Update), except it persists multiple updates at the same time so they will not be interleaved with other updates.
updateStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.admin.StreamManager
Change the configuration for an existing stream.

V

valueOf(String) - Static method in enum io.pravega.client.stream.RetentionPolicy.RetentionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.pravega.client.stream.ScalingPolicy.ScaleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.pravega.client.stream.Transaction.Status
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.pravega.client.stream.RetentionPolicy.RetentionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.pravega.client.stream.ScalingPolicy.ScaleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.pravega.client.stream.Transaction.Status
Returns an array containing the constants of this enum type, in the order they are declared.

W

withScope(String, URI) - Static method in interface io.pravega.client.admin.ReaderGroupManager
Creates a new instance of ReaderGroupManager.
withScope(String, ClientConfig) - Static method in interface io.pravega.client.admin.ReaderGroupManager
Creates a new instance of ReaderGroupManager.
withScope(String, URI) - Static method in interface io.pravega.client.ClientFactory
Creates a new instance of Client Factory.
withScope(String, ClientConfig) - Static method in interface io.pravega.client.ClientFactory
Creates a new instance of Client Factory.
writeConditionally(Revision, T) - Method in interface io.pravega.client.state.RevisionedStreamClient
If the supplied revision is the latest revision in the stream write the provided value and return the new revision.
writeEvent(Type) - Method in interface io.pravega.client.stream.EventStreamWriter
Send an event to the stream.
writeEvent(String, Type) - Method in interface io.pravega.client.stream.EventStreamWriter
Write an event to the stream.
writeEvent(String, Sequence, Type) - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
Send an event to the stream.
writeEvent(Type) - Method in interface io.pravega.client.stream.Transaction
Sends an event to the stream just like EventStreamWriter.writeEvent(Type) but with the caveat that the message will not be visible to anyone until Transaction.commit() is called.
writeEvent(String, Type) - Method in interface io.pravega.client.stream.Transaction
Sends an event to the stream just like EventStreamWriter.writeEvent(Type) but with the caveat that the message will not be visible to anyone until Transaction.commit() is called.
writeUnconditionally(T) - Method in interface io.pravega.client.state.RevisionedStreamClient
Write a new value to the stream.
A B C D E F G I L M N O P R S T U V W 
Skip navigation links