Skip navigation links
A B C D E F G H I J K 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.
abortTransaction(Stream, UUID) - Method in interface io.pravega.client.stream.impl.Controller
Aborts a transaction.
abortTransaction(Stream, UUID) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
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
 
advanceTo(Map<SegmentWithRange, Long>) - Method in class io.pravega.client.stream.impl.WatermarkReaderImpl
Advances the position in the watermark segment based on the provided position.
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 class io.pravega.client.batch.impl.SegmentRangeImpl
 
asImpl() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl
 
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 class io.pravega.client.state.impl.RevisionImpl
 
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 class io.pravega.client.stream.impl.CheckpointImpl
 
asImpl() - Method in class io.pravega.client.stream.impl.EventPointerImpl
 
asImpl() - Method in class io.pravega.client.stream.impl.PositionImpl
 
asImpl() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
asImpl() - Method in interface io.pravega.client.stream.Position
Used internally.
asImpl() - Method in interface io.pravega.client.stream.StreamCut
Used internally.
asLong() - Method in class io.pravega.client.netty.impl.Flow
Return a long representation of Flow.
asPair() - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
asText() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
asText() - Method in interface io.pravega.client.stream.StreamCut
Obtains the compact base64 string representation of StreamCut.
automaticallyNoteTime(boolean) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
automaticCheckpointIntervalMillis(long) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
available() - Method in class io.pravega.client.byteStream.ByteStreamReader
Returns the number of bytes that can be read without blocking.
available() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 

B

backoffMultiple(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
backoffMultiple(int) - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
BatchClientFactory - Interface in io.pravega.client
Please note this is an experimental API.
BatchClientFactoryImpl - Class in io.pravega.client.batch.impl
 
BatchClientFactoryImpl(Controller, ConnectionFactory) - Constructor for class io.pravega.client.batch.impl.BatchClientFactoryImpl
 
beginTxn() - Method in class io.pravega.client.stream.impl.TransactionalEventStreamWriterImpl
 
beginTxn() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
Start a new transaction on this stream.
BUFFER_SIZE - Static variable in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
BufferedByteStreamWriterImpl - Class in io.pravega.client.byteStream.impl
This class buffers individual calls to BufferedByteStreamWriterImpl.write(int) so that we don't make a separate RPC per byte.
BufferedByteStreamWriterImpl(ByteStreamWriterImpl) - Constructor for class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
build() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl.SegmentRangeImplBuilder
 
build() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl.StreamSegmentsInfoImplBuilder
 
build() - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
build() - Method in class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
 
build() - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
build() - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
build() - Method in class io.pravega.client.stream.impl.WriterPosition.WriterPositionBuilder
 
build() - Method in class io.pravega.client.stream.notifications.SegmentNotification.SegmentNotificationBuilder
 
build() - Method in class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
 
build() - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
build() - Method in class io.pravega.client.stream.ReaderSegmentDistribution.ReaderSegmentDistributionBuilder
 
build() - Method in class io.pravega.client.stream.RetentionPolicy.RetentionPolicyBuilder
 
build() - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
 
build() - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
 
builder() - Static method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
builder() - Static method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl
 
builder() - Static method in class io.pravega.client.ClientConfig
 
builder() - Static method in class io.pravega.client.state.SynchronizerConfig
 
builder() - Static method in class io.pravega.client.stream.EventWriterConfig
 
builder() - Static method in class io.pravega.client.stream.impl.CheckpointImpl
 
builder() - Static method in class io.pravega.client.stream.impl.CheckpointState
 
builder() - Static method in class io.pravega.client.stream.impl.ControllerImplConfig
 
builder() - Static method in class io.pravega.client.stream.impl.EventPointerImpl
 
builder() - Static method in class io.pravega.client.stream.impl.PositionImpl
 
builder() - Static method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
builder() - Static method in class io.pravega.client.stream.impl.StreamCutImpl
 
builder() - Static method in class io.pravega.client.stream.impl.WriterPosition
 
builder() - Static method in class io.pravega.client.stream.notifications.SegmentNotification
 
builder() - Static method in class io.pravega.client.stream.ReaderConfig
 
builder() - Static method in class io.pravega.client.stream.ReaderGroupConfig
 
builder() - Static method in class io.pravega.client.stream.ReaderSegmentDistribution
 
builder() - Static method in class io.pravega.client.stream.RetentionPolicy
 
builder() - Static method in class io.pravega.client.stream.ScalingPolicy
 
builder() - Static method in class io.pravega.client.stream.StreamConfiguration
 
builder() - Static method in class io.pravega.client.tables.impl.KeyVersionImpl
 
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.
ByteArraySerializer - Class in io.pravega.client.stream.impl
An implementation of Serializer that converts byte arrays.
ByteArraySerializer() - Constructor for class io.pravega.client.stream.impl.ByteArraySerializer
 
ByteBufferSerializer - Class in io.pravega.client.stream.impl
An implementation of Serializer that accepts byteBuffers.
ByteBufferSerializer() - Constructor for class io.pravega.client.stream.impl.ByteBufferSerializer
 
bytesInBuffer() - Method in interface io.pravega.client.segment.impl.SegmentInputStream
Returns > 0 if SegmentInputStream.read(ByteBuffer, long) can be invoked without blocking.
ByteStreamClientFactory - Interface in io.pravega.client
Used to create Writers and Readers operating on a Byte Stream.
ByteStreamClientImpl - Class in io.pravega.client.byteStream.impl
 
ByteStreamClientImpl(String, Controller, ConnectionFactory) - Constructor for class io.pravega.client.byteStream.impl.ByteStreamClientImpl
 
ByteStreamClientImpl(String, Controller, ConnectionFactory, SegmentInputStreamFactory, SegmentOutputStreamFactory, SegmentMetadataClientFactory) - Constructor for class io.pravega.client.byteStream.impl.ByteStreamClientImpl
 
ByteStreamReader - Class in io.pravega.client.byteStream
Allows for reading raw bytes from a segment.
ByteStreamReader() - Constructor for class io.pravega.client.byteStream.ByteStreamReader
 
ByteStreamReaderImpl - Class in io.pravega.client.byteStream.impl
 
ByteStreamReaderImpl(SegmentInputStream, SegmentMetadataClient) - Constructor for class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
ByteStreamWriter - Class in io.pravega.client.byteStream
Allows for writing raw bytes directly to a segment.
ByteStreamWriter() - Constructor for class io.pravega.client.byteStream.ByteStreamWriter
 
ByteStreamWriterImpl - Class in io.pravega.client.byteStream.impl
 
ByteStreamWriterImpl(SegmentOutputStream, SegmentMetadataClient) - Constructor for class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
bytesWrittenSinceCompaction() - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
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

cancel() - Method in class io.pravega.client.stream.impl.CancellableRequest
 
CancellableRequest<T> - Class in io.pravega.client.stream.impl
 
CancellableRequest() - Constructor for class io.pravega.client.stream.impl.CancellableRequest
 
canEqual(Object) - Method in class io.pravega.client.admin.StreamInfo
 
canEqual(Object) - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
canEqual(Object) - Method in class io.pravega.client.ClientConfig
 
canEqual(Object) - Method in class io.pravega.client.netty.impl.Connection
 
canEqual(Object) - Method in class io.pravega.client.netty.impl.Flow
 
canEqual(Object) - Method in class io.pravega.client.segment.impl.Segment
 
canEqual(Object) - Method in class io.pravega.client.segment.impl.SegmentInfo
 
canEqual(Object) - Method in class io.pravega.client.state.impl.RevisionImpl
 
canEqual(Object) - Method in class io.pravega.client.state.SynchronizerConfig
 
canEqual(Object) - Method in class io.pravega.client.stream.EventWriterConfig
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.CheckpointImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.CheckpointState
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.DefaultCredentials
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.EventPointerImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.EventReadImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.JavaSerializer
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.PendingEvent
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.PositionImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.StreamImpl
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.StreamSegments
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.TxnSegments
 
canEqual(Object) - Method in class io.pravega.client.stream.impl.WriterPosition
 
canEqual(Object) - Method in class io.pravega.client.stream.notifications.Notification
 
canEqual(Object) - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
canEqual(Object) - Method in class io.pravega.client.stream.ReaderConfig
 
canEqual(Object) - Method in class io.pravega.client.stream.ReaderGroupConfig
 
canEqual(Object) - Method in class io.pravega.client.stream.RetentionPolicy
 
canEqual(Object) - Method in class io.pravega.client.stream.ScalingPolicy
 
canEqual(Object) - Method in class io.pravega.client.stream.Sequence
 
canEqual(Object) - Method in class io.pravega.client.stream.StreamConfiguration
 
canEqual(Object) - Method in class io.pravega.client.stream.TimeWindow
 
canEqual(Object) - Method in class io.pravega.client.tables.impl.IteratorStateImpl
 
canEqual(Object) - Method in class io.pravega.client.tables.impl.KeyVersionImpl
 
canEqual(Object) - Method in class io.pravega.client.tables.impl.TableEntryImpl
 
canEqual(Object) - Method in class io.pravega.client.tables.impl.TableKeyImpl
 
canEqual(Object) - Method in class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
channelActive(ChannelHandlerContext) - Method in class io.pravega.client.netty.impl.FlowHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.pravega.client.netty.impl.FlowHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class io.pravega.client.netty.impl.FlowHandler
Invoke all the ReplyProcessor.connectionDropped() for all the registered flows once the connection is disconnected.
Checkpoint - Interface in io.pravega.client.stream
 
CheckpointFailedException - Exception in io.pravega.client.stream.impl
 
CheckpointFailedException(String) - Constructor for exception io.pravega.client.stream.impl.CheckpointFailedException
 
CheckpointFailedException(Throwable) - Constructor for exception io.pravega.client.stream.impl.CheckpointFailedException
 
CheckpointFailedException(String, Throwable) - Constructor for exception io.pravega.client.stream.impl.CheckpointFailedException
 
CheckpointImpl - Class in io.pravega.client.stream.impl
 
CheckpointState - Class in io.pravega.client.stream.impl
 
CheckpointState() - Constructor for class io.pravega.client.stream.impl.CheckpointState
 
checkScaleStatus(Stream, int) - Method in interface io.pravega.client.stream.impl.Controller
API to check the status of scale for a given epoch.
checkScaleStatus(Stream, int) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
checkStatus() - Method in interface io.pravega.client.stream.Transaction
Gets the status of the transaction.
checkTransactionStatus(Stream, UUID) - Method in interface io.pravega.client.stream.impl.Controller
Returns the status of the specified transaction.
checkTransactionStatus(Stream, UUID) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
ClientConfig - Class in io.pravega.client
This class contains configuration that is passed on to Pravega client.
clientConfig(ClientConfig) - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
ClientConfig.ClientConfigBuilder - Class in io.pravega.client
This class overrides the lombok builder.
ClientConnection - Interface in io.pravega.client.netty.impl
A connection object.
ClientConnection.CompletedCallback - Interface in io.pravega.client.netty.impl
 
ClientConnectionImpl - Class in io.pravega.client.netty.impl
 
ClientConnectionImpl(String, int, FlowHandler) - Constructor for class io.pravega.client.netty.impl.ClientConnectionImpl
 
ClientFactoryImpl - Class in io.pravega.client.stream.impl
 
ClientFactoryImpl(String, Controller) - Constructor for class io.pravega.client.stream.impl.ClientFactoryImpl
Creates a new instance of ClientFactory class.
ClientFactoryImpl(String, Controller, ConnectionFactory) - Constructor for class io.pravega.client.stream.impl.ClientFactoryImpl
Creates a new instance of the ClientFactory class.
ClientFactoryImpl(String, Controller, ConnectionFactory, SegmentInputStreamFactory, SegmentOutputStreamFactory, ConditionalOutputStreamFactory, SegmentMetadataClientFactory) - Constructor for class io.pravega.client.stream.impl.ClientFactoryImpl
 
close() - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl
 
close() - Method in class io.pravega.client.admin.impl.StreamManagerImpl
 
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 class io.pravega.client.batch.impl.BatchClientFactoryImpl
 
close() - Method in class io.pravega.client.batch.impl.SegmentIteratorImpl
 
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 class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
close() - Method in class io.pravega.client.byteStream.impl.ByteStreamClientImpl
 
close() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
close() - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
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.netty.impl.ClientConnection
Drop the connection.
close() - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
close() - Method in interface io.pravega.client.netty.impl.ConnectionFactory
 
close() - Method in class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
close() - Method in interface io.pravega.client.netty.impl.ConnectionPool
 
close() - Method in class io.pravega.client.netty.impl.ConnectionPoolImpl
 
close() - Method in class io.pravega.client.netty.impl.FlowHandler
 
close() - Method in class io.pravega.client.netty.impl.RawClient
 
close() - Method in interface io.pravega.client.segment.impl.ConditionalOutputStream
Flushes and then closes the output stream.
close() - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Closes this reader.
close() - Method in interface io.pravega.client.segment.impl.SegmentInputStream
Closes this InputStream.
close() - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
 
close() - Method in interface io.pravega.client.segment.impl.SegmentOutputStream
Flushes and then closes the output stream.
close() - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
close() - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
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 class io.pravega.client.stream.impl.ClientFactoryImpl
 
close() - Method in interface io.pravega.client.stream.impl.Controller
Closes controller client.
close() - Method in class io.pravega.client.stream.impl.ControllerImpl
 
close() - Method in class io.pravega.client.stream.impl.EventStreamReaderImpl
 
close() - Method in class io.pravega.client.stream.impl.EventStreamWriterImpl
 
close() - Method in class io.pravega.client.stream.impl.Pinger
 
close() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
close() - Method in interface io.pravega.client.stream.impl.SegmentTransaction
Calls SegmentTransaction.flush() and then closes the connection.
close() - Method in class io.pravega.client.stream.impl.TransactionalEventStreamWriterImpl
 
close() - Method in class io.pravega.client.stream.impl.WatermarkReaderImpl
 
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.
close() - Method in interface io.pravega.client.tables.impl.TableSegment
 
closeAndSeal() - Method in class io.pravega.client.byteStream.ByteStreamWriter
Closes the writer similar to ByteStreamWriter.close() but also seals it so that no future writes can ever be made.
closeAndSeal() - Method in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
closeAndSeal() - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
closeAt(Position) - Method in interface io.pravega.client.stream.EventStreamReader
Close the reader at a specific position.
closeAt(Position) - Method in class io.pravega.client.stream.impl.EventStreamReaderImpl
 
closeFlow(ClientConnection) - Method in class io.pravega.client.netty.impl.FlowHandler
Close a flow.
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
Commits the transaction similar to Transaction.commit(), but also notes an associated timestamp.
commitTransaction(Stream, String, Long, UUID) - Method in interface io.pravega.client.stream.impl.Controller
Commits a transaction, atomically committing all events to the stream, subject to the ordering guarantees specified in EventStreamWriter.
commitTransaction(Stream, String, Long, UUID) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
compact(Function<StateT, InitialUpdate<StateT>>) - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
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.
compareAndSetAttribute(SegmentAttribute, long, long) - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
Atomically replaces the value of attribute with newValue if it is expectedValue.
compareAndSetMark(Revision, Revision) - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
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(Segment) - Method in class io.pravega.client.segment.impl.Segment
 
compareTo(Revision) - Method in class io.pravega.client.state.impl.RevisionImpl
 
compareTo(Sequence) - Method in class io.pravega.client.stream.Sequence
 
complete(ConnectionFailedException) - Method in interface io.pravega.client.netty.impl.ClientConnection.CompletedCallback
Invoked when the ClientConnection.sendAsync(List, CompletedCallback) data has either been written to the wire or failed.
ConditionalOutputStream - Interface in io.pravega.client.segment.impl
Defines a ConditionalOutputStream for a segment.
ConditionalOutputStreamFactory - Interface in io.pravega.client.segment.impl
Creates ConditionalOutputStream for conditional appends on existing segments.
ConditionalOutputStreamFactoryImpl - Class in io.pravega.client.segment.impl
 
ConditionalOutputStreamFactoryImpl(Controller, ConnectionFactory) - Constructor for class io.pravega.client.segment.impl.ConditionalOutputStreamFactoryImpl
 
Connection - Class in io.pravega.client.netty.impl
This class represents a Connection that is established with a Segment Store instance and its attributes.
Connection(PravegaNodeUri, FlowHandler, CompletableFuture<Void>) - Constructor for class io.pravega.client.netty.impl.Connection
 
ConnectionClosedException - Exception in io.pravega.client.stream.impl
 
ConnectionClosedException() - Constructor for exception io.pravega.client.stream.impl.ConnectionClosedException
 
ConnectionFactory - Interface in io.pravega.client.netty.impl
A factory that establishes connections to Pravega servers.
ConnectionFactoryImpl - Class in io.pravega.client.netty.impl
A Connection factory implementation used to create ClientConnections by creating new Flow over existing connection pool.
ConnectionFactoryImpl(ClientConfig) - Constructor for class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
ConnectionFactoryImpl(ClientConfig, ConnectionPool, Integer) - Constructor for class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
ConnectionFactoryImpl(ClientConfig, ConnectionPool, ScheduledExecutorService) - Constructor for class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
ConnectionPool - Interface in io.pravega.client.netty.impl
This represents a ConnectionPool that manages the actual network connections to different SegmentStore instances.
ConnectionPoolImpl - Class in io.pravega.client.netty.impl
 
ConnectionPoolImpl(ClientConfig) - Constructor for class io.pravega.client.netty.impl.ConnectionPoolImpl
 
Controller - Interface in io.pravega.client.stream.impl
Stream Controller APIs.
ControllerFailureException - Exception in io.pravega.client.stream.impl
 
ControllerFailureException(String) - Constructor for exception io.pravega.client.stream.impl.ControllerFailureException
 
ControllerFailureException(Throwable) - Constructor for exception io.pravega.client.stream.impl.ControllerFailureException
 
ControllerFailureException(String, Throwable) - Constructor for exception io.pravega.client.stream.impl.ControllerFailureException
 
ControllerImpl - Class in io.pravega.client.stream.impl
RPC based client implementation of Stream Controller V1 API.
ControllerImpl(ControllerImplConfig, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.impl.ControllerImpl
Creates a new instance of the Controller client class.
ControllerImpl(ManagedChannelBuilder<?>, ControllerImplConfig, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.impl.ControllerImpl
Creates a new instance of the Controller client class.
ControllerImplConfig - Class in io.pravega.client.stream.impl
 
ControllerImplConfig.ControllerImplConfigBuilder - Class in io.pravega.client.stream.impl
 
ControllerResolverFactory - Class in io.pravega.client.stream.impl
gRPC Factory for resolving controller host ips and ports.
ControllerResolverFactory(ScheduledExecutorService) - Constructor for class io.pravega.client.stream.impl.ControllerResolverFactory
 
controllerURI(URI) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
convert() - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
CorruptedStateException - Exception in io.pravega.client.state.impl
 
CorruptedStateException(String) - Constructor for exception io.pravega.client.state.impl.CorruptedStateException
Constructor for corrupted state exception with message.
CorruptedStateException(String, Exception) - Constructor for exception io.pravega.client.state.impl.CorruptedStateException
Constructor for corrupted state exception with message and exception.
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() - Static method in class io.pravega.client.netty.impl.Flow
Create a new Flow.
create(Controller, String, String) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
Creates a DelegationTokenProvider instance with null delegation token.
create(Controller, Segment) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
Creates a DelegationTokenProvider instance with null delegation token.
create(String, Controller, Segment) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
Creates a DelegationTokenProvider instance with the specified delegation token.
create(String, Controller, String, String) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
Creates a DelegationTokenProvider instance of an appropriate type.
create(String, Revision) - Method in interface io.pravega.client.state.InitialUpdate
Returns an object of type StateT with the provided revision.
create(String, Revision) - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
create(long, long) - Static method in class io.pravega.client.stream.Sequence
 
createByteStreamReader(String) - Method in class io.pravega.client.byteStream.impl.ByteStreamClientImpl
 
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 class io.pravega.client.byteStream.impl.ByteStreamClientImpl
 
createByteStreamWriter(String) - Method in interface io.pravega.client.ByteStreamClientFactory
Creates a new ByteStreamWriter on the specified stream.
createConditionalOutputStream(Segment, DelegationTokenProvider, EventWriterConfig) - Method in interface io.pravega.client.segment.impl.ConditionalOutputStreamFactory
Opens an existing segment for conditional append operations.
createConditionalOutputStream(Segment, DelegationTokenProvider, EventWriterConfig) - Method in class io.pravega.client.segment.impl.ConditionalOutputStreamFactoryImpl
 
createConnectionWithFlowDisabled(ReplyProcessor) - Method in class io.pravega.client.netty.impl.FlowHandler
Create a ClientConnection where flows are disabled.
createEventReaderForSegment(Segment) - Method in interface io.pravega.client.segment.impl.SegmentInputStreamFactory
Opens an existing segment for reading events.
createEventReaderForSegment(Segment, Semaphore, long) - Method in interface io.pravega.client.segment.impl.SegmentInputStreamFactory
Open an existing segment for reading up to the provided end offset.
createEventReaderForSegment(Segment, int) - Method in interface io.pravega.client.segment.impl.SegmentInputStreamFactory
Opens an existing segment for reading.
createEventReaderForSegment(Segment) - Method in class io.pravega.client.segment.impl.SegmentInputStreamFactoryImpl
 
createEventReaderForSegment(Segment, Semaphore, long) - Method in class io.pravega.client.segment.impl.SegmentInputStreamFactoryImpl
 
createEventReaderForSegment(Segment, int) - Method in class io.pravega.client.segment.impl.SegmentInputStreamFactoryImpl
 
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.
createEventWriter(String, Serializer<T>, EventWriterConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
createEventWriter(String, String, Serializer<T>, EventWriterConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
createFlow(Flow, ReplyProcessor) - Method in class io.pravega.client.netty.impl.FlowHandler
Create a flow on existing connection.
createInputStreamForSegment(Segment, DelegationTokenProvider) - Method in interface io.pravega.client.segment.impl.SegmentInputStreamFactory
Opens an existing segment for reading bytes.
createInputStreamForSegment(Segment, DelegationTokenProvider) - Method in class io.pravega.client.segment.impl.SegmentInputStreamFactoryImpl
 
createOutputStreamForSegment(Segment, Consumer<Segment>, EventWriterConfig, DelegationTokenProvider) - Method in interface io.pravega.client.segment.impl.SegmentOutputStreamFactory
Creates a stream for an existing segment.
createOutputStreamForSegment(Segment, EventWriterConfig, DelegationTokenProvider) - Method in interface io.pravega.client.segment.impl.SegmentOutputStreamFactory
Creates a SegmentOutputStream for an existing segment.
createOutputStreamForSegment(Segment, Consumer<Segment>, EventWriterConfig, DelegationTokenProvider) - Method in class io.pravega.client.segment.impl.SegmentOutputStreamFactoryImpl
 
createOutputStreamForSegment(Segment, EventWriterConfig, DelegationTokenProvider) - Method in class io.pravega.client.segment.impl.SegmentOutputStreamFactoryImpl
 
createOutputStreamForTransaction(Segment, UUID, EventWriterConfig, DelegationTokenProvider) - Method in interface io.pravega.client.segment.impl.SegmentOutputStreamFactory
Creates a stream for an open transaction.
createOutputStreamForTransaction(Segment, UUID, EventWriterConfig, DelegationTokenProvider) - Method in class io.pravega.client.segment.impl.SegmentOutputStreamFactoryImpl
 
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.
createReader(String, String, Serializer<T>, ReaderConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
createReader(String, String, Serializer<T>, ReaderConfig, Supplier<Long>, Supplier<Long>) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
createReaderGroup(String, ReaderGroupConfig) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl
 
createReaderGroup(String, ReaderGroupConfig) - Method in interface io.pravega.client.admin.ReaderGroupManager
Creates a new ReaderGroup.
createRevisionedStreamClient(String, Serializer<T>, SynchronizerConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
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 class io.pravega.client.admin.impl.StreamManagerImpl
 
createScope(String) - Method in interface io.pravega.client.admin.StreamManager
Creates a new scope.
createScope(String) - Method in interface io.pravega.client.stream.impl.Controller
API to create a scope.
createScope(String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
createScopeInfo(String) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
createSegmentId(String, String, long) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
createSegmentMetadataClient(Segment, DelegationTokenProvider) - Method in interface io.pravega.client.segment.impl.SegmentMetadataClientFactory
Opens an existing segment for metadata operations.
createSegmentMetadataClient(Segment, DelegationTokenProvider) - Method in class io.pravega.client.segment.impl.SegmentMetadataClientFactoryImpl
 
createSegmentRange(String, String, long, double, double) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
createStateSynchronizer(String, Serializer<UpdateT>, Serializer<InitT>, SynchronizerConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
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 class io.pravega.client.admin.impl.StreamManagerImpl
 
createStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.admin.StreamManager
Creates a new stream
createStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.stream.impl.Controller
API to create a stream.
createStream(String, String, StreamConfiguration) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
createStreamCut(Stream, WriterPosition) - Static method in class io.pravega.client.stream.impl.ModelHelper
Builds a stream cut, mapping the segments of a stream to their offsets from a writer position object.
createStreamCutRangeResponse(String, String, List<Controller.SegmentId>, String) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
createStreamInfo(String, String) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
createSuccessorResponse(Map<Controller.SegmentRange, List<Long>>) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
createTransaction(Stream, long) - Method in interface io.pravega.client.stream.impl.Controller
API to create a new transaction.
createTransaction(Stream, long) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
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.
createTransactionalEventWriter(String, String, Serializer<T>, EventWriterConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
createTransactionalEventWriter(String, Serializer<T>, EventWriterConfig) - Method in class io.pravega.client.stream.impl.ClientFactoryImpl
 
createWithEmptyToken() - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
Creates a DelegationTokenProvider instance with empty token.
credentials(Credentials) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
Credentials - Interface in io.pravega.client.stream.impl
This interface represents the credentials passed to Pravega for authentication and authorizing the access.

D

declareSerializers(VersionedSerializer.MultiType<InitialUpdate<ReaderGroupState>>.Builder) - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupInitSerializer
 
declareSerializers(VersionedSerializer.MultiType<Update<ReaderGroupState>>.Builder) - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupUpdateSerializer
 
declareVersions() - Method in class io.pravega.client.stream.impl.StreamCutImpl.StreamCutSerializer
 
declareVersions() - Method in class io.pravega.client.tables.impl.KeyVersionImpl.KeyVersionImplSerializer
 
decode(UUID) - Static method in class io.pravega.client.stream.impl.ModelHelper
Returns TxnId object instance for a given transaction with UUID.
decode(Segment) - Static method in class io.pravega.client.stream.impl.ModelHelper
Decodes segment and returns an instance of SegmentId.
decode(ScalingPolicy) - Static method in class io.pravega.client.stream.impl.ModelHelper
Decodes ScalingPolicy and returns an instance of Scaling Policy impl.
decode(RetentionPolicy) - Static method in class io.pravega.client.stream.impl.ModelHelper
Decodes RetentionPolicy and returns an instance of Retention Policy impl.
decode(String, String, StreamConfiguration) - Static method in class io.pravega.client.stream.impl.ModelHelper
Converts StreamConfiguration into StreamConfig.
decode(PravegaNodeUri) - Static method in class io.pravega.client.stream.impl.ModelHelper
Converts PravegaNodeURI into NodeURI.
decode(String, String, Map<Long, Long>) - Static method in class io.pravega.client.stream.impl.ModelHelper
Creates a stream cut object.
decode(String, String, Map<Long, Long>, Map<Long, Long>) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
DefaultCredentials - Class in io.pravega.client.stream.impl
Username/password credentials for basic authentication.
DefaultCredentials(String, String) - Constructor for class io.pravega.client.stream.impl.DefaultCredentials
 
DelegationTokenProvider - Interface in io.pravega.client.security.auth
A client-side proxy for obtaining a delegation token from the server.
DelegationTokenProviderFactory - Class in io.pravega.client.security.auth
Factory class for DelegationTokenProvider instances.
DelegationTokenProviderFactory() - Constructor for class io.pravega.client.security.auth.DelegationTokenProviderFactory
 
deleteReaderGroup(String) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl
 
deleteReaderGroup(String) - Method in interface io.pravega.client.admin.ReaderGroupManager
Deletes a reader group, removing any state associated with it.
deleteScope(String) - Method in class io.pravega.client.admin.impl.StreamManagerImpl
 
deleteScope(String) - Method in interface io.pravega.client.admin.StreamManager
Deletes an existing scope.
deleteScope(String) - Method in interface io.pravega.client.stream.impl.Controller
API to delete a scope.
deleteScope(String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
deleteStream(String, String) - Method in class io.pravega.client.admin.impl.StreamManagerImpl
 
deleteStream(String, String) - Method in interface io.pravega.client.admin.StreamManager
Deletes the provided stream.
deleteStream(String, String) - Method in interface io.pravega.client.stream.impl.Controller
API to delete a stream.
deleteStream(String, String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
deserialize(ByteBuffer) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl.ReaderGroupStateInitSerializer
 
deserialize(ByteBuffer) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl.ReaderGroupStateUpdatesSerializer
 
deserialize(ByteBuffer) - Method in class io.pravega.client.state.impl.UpdateOrInitSerializer
 
deserialize(ByteBuffer) - Method in class io.pravega.client.stream.impl.ByteArraySerializer
 
deserialize(ByteBuffer) - Method in class io.pravega.client.stream.impl.ByteBufferSerializer
 
deserialize(ByteBuffer) - Method in class io.pravega.client.stream.impl.JavaSerializer
 
deserialize(ByteBuffer) - Method in class io.pravega.client.stream.impl.UTF8StringSerializer
 
deserialize(ByteBuffer) - Method in interface io.pravega.client.stream.Serializer
Deserializes the given ByteBuffer into an event.
deserialize(ByteBuffer) - Method in class io.pravega.client.watermark.WatermarkSerializer
 
disableAutomaticCheckpoints() - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
Disables automatic checkpointing.
disableTimeWindows(boolean) - Method in class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
 

E

EMPTY - Static variable in interface io.pravega.client.tables.impl.IteratorState
 
EmptyTokenProviderImpl - Class in io.pravega.client.security.auth
Provides empty delegation tokens.
EmptyTokenProviderImpl() - Constructor for class io.pravega.client.security.auth.EmptyTokenProviderImpl
 
enableConnectionPooling(boolean) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
enableTlsToController(boolean) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
enableTlsToSegmentStore(boolean) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
encode(Controller.TxnId) - Static method in class io.pravega.client.stream.impl.ModelHelper
Returns UUID of transaction with given TxnId.
encode(Controller.SegmentId) - Static method in class io.pravega.client.stream.impl.ModelHelper
Helper to convert Segment Id into Segment object.
encode(Controller.ScalingPolicy) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
encode(Controller.RetentionPolicy) - Static method in class io.pravega.client.stream.impl.ModelHelper
Helper to convert retention policy from RPC call to internal representation.
encode(Controller.StreamConfig) - Static method in class io.pravega.client.stream.impl.ModelHelper
Helper to convert StreamConfig into Stream Configuration Impl.
encode(Controller.NodeUri) - Static method in class io.pravega.client.stream.impl.ModelHelper
Helper to convert NodeURI into PravegaNodeURI.
encode(Map<Double, Double>) - Static method in class io.pravega.client.stream.impl.ModelHelper
Return list of key ranges available.
encode(Controller.TxnState.State, String) - Static method in class io.pravega.client.stream.impl.ModelHelper
Returns actual status of given transaction status instance.
encode(Controller.PingTxnStatus.Status, String) - Static method in class io.pravega.client.stream.impl.ModelHelper
Returns the status of Ping Transaction.
encode(Controller.SegmentRange) - Static method in class io.pravega.client.stream.impl.ModelHelper
Helper to convert SegmentRange to SegmentWithRange.
encode(Controller.StreamCut) - Static method in class io.pravega.client.stream.impl.ModelHelper
Helper method to convery stream cut to map of segment to position.
endingStreamCuts(Map<Stream, StreamCut>) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
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
 
endOffset(long) - Method in class io.pravega.client.batch.impl.SegmentRangeImpl.SegmentRangeImplBuilder
 
EndOfSegmentException - Exception in io.pravega.client.segment.impl
A segment has ended.
EndOfSegmentException() - Constructor for exception io.pravega.client.segment.impl.EndOfSegmentException
 
EndOfSegmentException(EndOfSegmentException.ErrorType) - Constructor for exception io.pravega.client.segment.impl.EndOfSegmentException
 
EndOfSegmentException.ErrorType - Enum in io.pravega.client.segment.impl
 
endStreamCut(StreamCut) - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl.StreamSegmentsInfoImplBuilder
 
entryIterator(IteratorState) - Method in interface io.pravega.client.tables.impl.TableSegment
Creates a new Iterator over all the Entries in the Table Segment.
equals(Object) - Method in class io.pravega.client.admin.StreamInfo
 
equals(Object) - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
equals(Object) - Method in class io.pravega.client.ClientConfig
 
equals(Object) - Method in class io.pravega.client.netty.impl.Connection
 
equals(Object) - Method in class io.pravega.client.netty.impl.Flow
 
equals(Object) - Method in class io.pravega.client.segment.impl.Segment
 
equals(Object) - Method in class io.pravega.client.segment.impl.SegmentInfo
 
equals(Object) - Method in class io.pravega.client.state.impl.RevisionImpl
 
equals(Object) - Method in class io.pravega.client.state.SynchronizerConfig
 
equals(Object) - Method in class io.pravega.client.stream.EventWriterConfig
 
equals(Object) - Method in class io.pravega.client.stream.impl.CheckpointImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.CheckpointState
 
equals(Object) - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
equals(Object) - Method in class io.pravega.client.stream.impl.DefaultCredentials
 
equals(Object) - Method in class io.pravega.client.stream.impl.EventPointerImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.EventReadImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.JavaSerializer
 
equals(Object) - Method in class io.pravega.client.stream.impl.PendingEvent
 
equals(Object) - Method in class io.pravega.client.stream.impl.PositionImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
equals(Object) - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
equals(Object) - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
equals(Object) - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.StreamImpl
 
equals(Object) - Method in class io.pravega.client.stream.impl.StreamSegments
 
equals(Object) - Method in class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
equals(Object) - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
 
equals(Object) - Method in class io.pravega.client.stream.impl.TxnSegments
 
equals(Object) - Method in class io.pravega.client.stream.impl.WriterPosition
 
equals(Object) - Method in class io.pravega.client.stream.notifications.Notification
 
equals(Object) - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
equals(Object) - Method in class io.pravega.client.stream.ReaderConfig
 
equals(Object) - Method in class io.pravega.client.stream.ReaderGroupConfig
 
equals(Object) - Method in class io.pravega.client.stream.RetentionPolicy
 
equals(Object) - Method in class io.pravega.client.stream.ScalingPolicy
 
equals(Object) - Method in class io.pravega.client.stream.Sequence
 
equals(Object) - Method in class io.pravega.client.stream.StreamConfiguration
 
equals(Object) - Method in class io.pravega.client.stream.TimeWindow
 
equals(Object) - Method in class io.pravega.client.tables.impl.IteratorStateImpl
 
equals(Object) - Method in class io.pravega.client.tables.impl.KeyVersionImpl
 
equals(Object) - Method in class io.pravega.client.tables.impl.TableEntryImpl
 
equals(Object) - Method in class io.pravega.client.tables.impl.TableKeyImpl
 
equals(Object) - Method in class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
establishConnection(PravegaNodeUri, ReplyProcessor) - Method in interface io.pravega.client.netty.impl.ConnectionFactory
Establishes a connection between server and client with given parameters.
establishConnection(Flow, PravegaNodeUri, ReplyProcessor) - Method in interface io.pravega.client.netty.impl.ConnectionFactory
This method is used to establish a client connection using a Flow on the underlying Connection pool.
establishConnection(Flow, PravegaNodeUri, ReplyProcessor) - Method in class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
establishConnection(PravegaNodeUri, ReplyProcessor) - Method in class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
EventPointer - Interface in io.pravega.client.stream
A pointer to an event.
EventPointerImpl - Class in io.pravega.client.stream.impl
Implementation of the EventPointer interface.
EventPointerInternal - Class in io.pravega.client.stream.impl
Pravega provides to a reader the ability to read an isolated event.
EventPointerInternal() - Constructor for class io.pravega.client.stream.impl.EventPointerInternal
 
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.
EventReadImpl<T> - Class in io.pravega.client.stream.impl
 
EventReadImpl(T, Position, EventPointer, String) - Constructor for class io.pravega.client.stream.impl.EventReadImpl
 
EventSegmentReader - Interface in io.pravega.client.segment.impl
Defines an event reader for a single segment.
EventStreamClientFactory - Interface in io.pravega.client
Used to create Writers and Readers operating on a stream.
EventStreamReader<T> - Interface in io.pravega.client.stream
A reader for a stream.
EventStreamReaderImpl<Type> - Class in io.pravega.client.stream.impl
 
EventStreamWriter<Type> - Interface in io.pravega.client.stream
A writer can write events to a stream.
EventStreamWriterImpl<Type> - Class in io.pravega.client.stream.impl
This class takes in events, finds out which segment they belong to and then calls write on the appropriate segment.
eventWriterConfig(EventWriterConfig) - Method in class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
 
EventWriterConfig - Class in io.pravega.client.stream
 
EventWriterConfig.EventWriterConfigBuilder - Class in io.pravega.client.stream
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.pravega.client.netty.impl.FlowHandler
 
executor - Variable in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
 

F

fetchCurrentSegmentLength() - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
Returns the length of the current segment.
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().
fetchEvent(EventPointer) - Method in class io.pravega.client.stream.impl.EventStreamReaderImpl
 
fetchHeadStreamCut(Stream) - Method in class io.pravega.client.admin.impl.StreamCutHelper
Obtain the StreamCut pointing to the current HEAD of the Stream.
fetchLatestRevision() - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
fetchLatestRevision() - Method in interface io.pravega.client.state.RevisionedStreamClient
Returns the latest revision.
fetchOldestRevision() - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
fetchOldestRevision() - Method in interface io.pravega.client.state.RevisionedStreamClient
Returns the oldest revision that reads can start from.
fetchProperty(SegmentAttribute) - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
Gets the current value of the provided attribute.
fetchTailOffset() - Method in class io.pravega.client.byteStream.ByteStreamReader
This make an RPC to the server to fetch the offset at which new bytes would be written.
fetchTailOffset() - Method in class io.pravega.client.byteStream.ByteStreamWriter
This makes a synchronous RPC call to the server to obtain the total number of bytes written to the segment in its history.
fetchTailOffset() - Method in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
fetchTailOffset() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
fetchTailOffset() - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
fetchTailStreamCut(Stream) - Method in class io.pravega.client.admin.impl.StreamCutHelper
Obtain the StreamCut pointing to the current TAIL of the Stream.
fetchUpdates() - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
fetchUpdates() - Method in interface io.pravega.client.state.StateSynchronizer
Fetch and apply all updates needed to the state object held locally up to date.
fillBuffer() - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Issues a request to asynchronously fill up the buffer.
fillBuffer() - Method in interface io.pravega.client.segment.impl.SegmentInputStream
Issue a request to asynchronously fill the buffer.
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.
Flow - Class in io.pravega.client.netty.impl
The class represents a Flow between a Segment client and the SegmentStore.
Flow(int, int) - Constructor for class io.pravega.client.netty.impl.Flow
 
FlowHandler - Class in io.pravega.client.netty.impl
 
FlowHandler(String) - Constructor for class io.pravega.client.netty.impl.FlowHandler
 
FlowHandler(String, MetricNotifier) - Constructor for class io.pravega.client.netty.impl.FlowHandler
 
flush() - Method in class io.pravega.client.byteStream.ByteStreamWriter
Blocks until all data written has been durably persisted.
flush() - Method in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
flush() - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
flush() - Method in interface io.pravega.client.segment.impl.SegmentOutputStream
Block on all writes that have not yet completed.
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 class io.pravega.client.stream.impl.EventStreamWriterImpl
 
flush() - Method in interface io.pravega.client.stream.impl.SegmentTransaction
Blocks until all events passed to the write call have made it to durable storage.
flush() - Method in interface io.pravega.client.stream.Transaction
Blocks until all events passed to Transaction.writeEvent(String, Object) make it to durable storage.
from(long) - Static method in class io.pravega.client.netty.impl.Flow
Obtain a Flow from a long representation.
from(String) - Static method in class io.pravega.client.stream.impl.StreamCutImpl
Obtains the a StreamCut object from its compact Base64 representation obtained via StreamCutImpl.asText().
from(String) - Static method in class io.pravega.client.stream.impl.StreamCutInternal
 
from(String) - Static method in interface io.pravega.client.stream.StreamCut
Obtains the a StreamCut object from its Base64 representation obtained via StreamCut.asText().
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 class io.pravega.client.stream.impl.CheckpointImpl
 
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.CheckpointState
 
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.EventPointerImpl
 
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.EventPointerInternal
 
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.PositionImpl
 
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.PositionInternal
Deserializes the position from its serialized from obtained from calling Position.toBytes().
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.StreamCutImpl
 
fromBytes(ByteBuffer) - Static method in class io.pravega.client.stream.impl.StreamCutInternal
 
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().
fromBytes(ByteBuf) - Static method in interface io.pravega.client.tables.impl.IteratorState
Deserializes the IteratorState from its serialized form obtained from calling IteratorState.toBytes().
fromBytes(ByteBuffer) - Static method in interface io.pravega.client.tables.impl.KeyVersion
Deserializes the KeyVersion from its serialized form obtained from calling KeyVersion.toBytes().
fromBytes(ByteBuffer) - Static method in class io.pravega.client.tables.impl.KeyVersionImpl
 
fromPair(Pair<Double, Double>) - Static method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
fromScopedName(String) - Static method in class io.pravega.client.segment.impl.Segment
Parses fully scoped name, and creates the segment.
fromScopedName(String) - Static method in interface io.pravega.client.stream.impl.StreamInternal
 
fromString(String) - Static method in class io.pravega.client.state.impl.RevisionImpl
 
fromString(String) - Static method in interface io.pravega.client.state.Revision
Deserializes the revision from its serialized from obtained from calling Revision.toString().
fromString(String) - Static method in class io.pravega.client.stream.impl.EventPointerImpl
 

G

generateStreamCuts(ScheduledExecutorService) - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
generateStreamCuts(ScheduledExecutorService) - Method in interface io.pravega.client.stream.ReaderGroup
Generates a StreamCut after co-ordinating with all the readers using StateSynchronizer.
get(KeyT) - Method in interface io.pravega.client.tables.impl.TableSegment
Gets the latest value for the given Key.
get(Collection<KeyT>) - Method in interface io.pravega.client.tables.impl.TableSegment
Gets the latest values for the given Keys.
getAckFuture() - Method in class io.pravega.client.stream.impl.PendingEvent
Callback to be invoked when the data is written.
getActiveChannelCount() - Method in class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
getActiveChannelCount() - Method in interface io.pravega.client.netty.impl.ConnectionPool
Fetch the current active Channel count, which represents the number of active connections being managed by the connection pool.
getActiveChannelCount() - Method in class io.pravega.client.netty.impl.ConnectionPoolImpl
 
getActiveChannels() - Method in class io.pravega.client.netty.impl.ConnectionPoolImpl
 
getAppendBatchSizeTracker(long) - Method in class io.pravega.client.netty.impl.FlowHandler
Get a Batch size tracker for requestID.
getAuthenticationToken() - Method in interface io.pravega.client.stream.impl.Credentials
Returns the authorization token to be sent to Pravega.
getAuthenticationToken() - Method in class io.pravega.client.stream.impl.DefaultCredentials
 
getAuthenticationType() - Method in interface io.pravega.client.stream.impl.Credentials
Returns the authentication type.
getAuthenticationType() - Method in class io.pravega.client.stream.impl.DefaultCredentials
 
getAuthenticationType() - Method in class io.pravega.client.stream.impl.PravegaCredentialsWrapper
 
getAutomaticCheckpointIntervalMillis() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
getBackoffMultiple() - Method in class io.pravega.client.stream.EventWriterConfig
 
getBackoffMultiple() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
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.
getCheckpointName() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
getClientConfig() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
getClientConnection(Flow, PravegaNodeUri, ReplyProcessor) - Method in interface io.pravega.client.netty.impl.ConnectionPool
This is used to create a ClientConnection on an existing Connection pool.
getClientConnection(PravegaNodeUri, ReplyProcessor) - Method in interface io.pravega.client.netty.impl.ConnectionPool
This is used to create a ClientConnection where flows are disabled.
getClientConnection(Flow, PravegaNodeUri, ReplyProcessor) - Method in class io.pravega.client.netty.impl.ConnectionPoolImpl
 
getClientConnection(PravegaNodeUri, ReplyProcessor) - Method in class io.pravega.client.netty.impl.ConnectionPoolImpl
 
getCompletedSegments() - Method in class io.pravega.client.stream.impl.PositionImpl
 
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 class io.pravega.client.stream.impl.EventStreamReaderImpl
 
getConfig() - Method in class io.pravega.client.stream.impl.EventStreamWriterImpl
 
getConfig() - Method in class io.pravega.client.stream.impl.ReaderGroupState
 
getConfig() - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
getConfig() - Method in class io.pravega.client.stream.impl.TransactionalEventStreamWriterImpl
 
getConfig() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
Returns the configuration that this writer was created with.
getConnected() - Method in class io.pravega.client.netty.impl.Connection
A future that completes when the connection is first established.
getConnectionName() - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
getConnectionPool() - Method in class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
getController() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getControllerURI() - Method in class io.pravega.client.ClientConfig
controllerURI The controller rpc URI.
getCredentials() - Method in class io.pravega.client.ClientConfig
Credentials to be passed on to the Pravega controller for authentication and authorization.
getCurrentSegments(String, String) - Method in interface io.pravega.client.stream.impl.Controller
API to get list of current segments for the stream to write to.
getCurrentSegments(String, String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getCurrentTimeWindow(Stream) - Method in interface io.pravega.client.stream.EventStreamReader
Returns a window which represents the range of time that this reader is currently reading as provided by writers via the EventStreamWriter.noteTime(long) API.
getCurrentTimeWindow(Stream) - Method in class io.pravega.client.stream.impl.EventStreamReaderImpl
 
getData() - Method in class io.pravega.client.stream.impl.PendingEvent
The data to be written.
getDefaultScheme() - Method in class io.pravega.client.stream.impl.ControllerResolverFactory
 
getDelegationToken() - Method in class io.pravega.client.stream.impl.StreamSegments
 
getDelegationToken() - Method in class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
getDelegationToken() - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
 
getEndingStreamCuts() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
getEndOfDataNotifier(ScheduledExecutorService) - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
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 class io.pravega.client.batch.impl.SegmentRangeImpl
End offset for the segment.
getEndOffset() - Method in interface io.pravega.client.batch.SegmentRange
Returns the end offset of the segment.
getEndpointForSegment(String) - Method in interface io.pravega.client.stream.impl.Controller
Given a segment return the endpoint that currently is the owner of that segment.
getEndpointForSegment(String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getEndSegments() - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
getEndSegmentsForStreams(ReaderGroupConfig) - Static method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getEndStreamCut() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl
 
getEndStreamCut() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
getErrorType() - Method in exception io.pravega.client.segment.impl.EndOfSegmentException
 
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.
getEvent() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
getEventPointer() - Method in interface io.pravega.client.stream.EventRead
Returns a pointer object for the event read.
getEventPointer() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
getEventWriterConfig() - Method in class io.pravega.client.state.SynchronizerConfig
 
getFlow() - Method in class io.pravega.client.netty.impl.RawClient
 
getFlowCount() - Method in class io.pravega.client.netty.impl.Connection
Returns the number of open flows on this connection.
getFlowHandler() - Method in class io.pravega.client.netty.impl.Connection
 
getFlowId() - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
getFlowId() - Method in class io.pravega.client.netty.impl.Flow
 
getFuture() - Method in class io.pravega.client.stream.impl.CancellableRequest
 
getGroupName() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getGroupName() - Method in interface io.pravega.client.stream.ReaderGroup
Returns the name of the group.
getGroupRefreshTimeMillis() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
getHeadStreamCut() - Method in class io.pravega.client.admin.StreamInfo
StreamCut representing the current HEAD of the stream.
getHigh() - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
getHighOrder() - Method in class io.pravega.client.stream.Sequence
 
getId() - Method in interface io.pravega.client.stream.impl.SegmentTransaction
 
getInitalBackoffMillis() - Method in class io.pravega.client.stream.EventWriterConfig
 
getInitialAllocationDelay() - Method in class io.pravega.client.stream.ReaderConfig
 
getInitialBackoffMillis() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
getInternalExecutor() - Method in interface io.pravega.client.netty.impl.ConnectionFactory
Get the internal executor which is used by the client.
getInternalExecutor() - Method in class io.pravega.client.netty.impl.ConnectionFactoryImpl
 
getItems() - Method in class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
getIterator() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl
 
getIterator() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
getKey() - Method in interface io.pravega.client.tables.impl.TableEntry
The Key.
getKey() - Method in class io.pravega.client.tables.impl.TableEntryImpl
 
getKey() - Method in interface io.pravega.client.tables.impl.TableKey
The Key.
getKey() - Method in class io.pravega.client.tables.impl.TableKeyImpl
 
getLastModifiedTime() - Method in class io.pravega.client.segment.impl.SegmentInfo
The last time the segment was written to.
getLastObservedWriteOffset() - Method in interface io.pravega.client.segment.impl.SegmentOutputStream
This returns the write offset of a segment that was most recently observed from an Ack.
getLow() - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
getLowerTimeBound() - Method in class io.pravega.client.stream.TimeWindow
 
getLowOrder() - Method in class io.pravega.client.stream.Sequence
 
getMark() - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
getMark() - Method in interface io.pravega.client.state.RevisionedStreamClient
getMaxBackoffMillis() - Method in class io.pravega.client.stream.EventWriterConfig
 
getMaxBackoffMillis() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
getMaxConnectionsPerSegmentStore() - Method in class io.pravega.client.ClientConfig
Maximum number of connections per Segment store to be used by connection pooling.
getMaxOutstandingCheckpointRequest() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
getMeta() - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
getMetaFactory() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getMetricListener() - Method in class io.pravega.client.ClientConfig
An optional listener which can be used to get performance metrics from the client.
getMetricNotifier() - Method in class io.pravega.client.netty.impl.FlowHandler
 
getMetrics() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getMetrics() - Method in interface io.pravega.client.stream.ReaderGroup
Returns metrics for this reader group.
getMinNumSegments() - Method in class io.pravega.client.stream.ScalingPolicy
 
getName() - Method in interface io.pravega.client.stream.Checkpoint
getName() - Method in class io.pravega.client.stream.impl.CheckpointImpl
 
getNettyHandler() - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
getNextSequenceNumber() - Method in class io.pravega.client.netty.impl.Flow
Obtain a long representation of Flow with the next sequence number.
getNotifierFactory() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getNumberOfSegments() - Method in class io.pravega.client.stream.impl.ReaderGroupState
Returns the number of segments currently being read from and that are unassigned within the reader group.
getNumOfReaders() - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
getNumOfSegments() - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
getOffset() - Method in class io.pravega.client.batch.impl.SegmentIteratorImpl
 
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.
getOffset() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
getOffset() - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Gets the current offset.
getOffset() - Method in interface io.pravega.client.segment.impl.SegmentInputStream
Gets the current offset.
getOffsetForOwnedSegment(Segment) - Method in class io.pravega.client.stream.impl.PositionImpl
 
getOnlineReaders() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getOnlineReaders() - Method in class io.pravega.client.stream.impl.ReaderGroupState
 
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.
getOpenFlowCount() - Method in class io.pravega.client.netty.impl.FlowHandler
Returns the number of open flows.
getOrRefreshDelegationTokenFor(String, String) - Method in interface io.pravega.client.stream.impl.Controller
Refreshes an expired/non-existent delegation token.
getOrRefreshDelegationTokenFor(String, String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getOrRefreshDelegationTokenFor(Segment) - Method in class io.pravega.client.stream.impl.ReaderGroupStateManager
 
getOwnedSegments() - Method in class io.pravega.client.stream.impl.PositionImpl
 
getOwnedSegmentsWithOffsets() - Method in class io.pravega.client.stream.impl.PositionImpl
 
getPosition() - Method in interface io.pravega.client.stream.EventRead
The position in the stream that represents where the reader is immediately following this event.
getPosition() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
getPositions() - Method in class io.pravega.client.stream.impl.CheckpointImpl
 
getPositions() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
getPositions() - Method in class io.pravega.client.stream.impl.StreamCutInternal
Get a mapping of Segment and its offset.
getRange() - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
getReadBufferSize() - Method in class io.pravega.client.state.SynchronizerConfig
 
getReaderGroup(String) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl
 
getReaderGroup(String) - Method in interface io.pravega.client.admin.ReaderGroupManager
Returns the requested reader group.
getReaderId() - Method in class io.pravega.client.stream.impl.ReaderGroupStateManager
 
getReaderId() - Method in exception io.pravega.client.stream.ReaderNotInReaderGroupException
 
getReaderSegmentDistribution() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getReaderSegmentDistribution() - Method in interface io.pravega.client.stream.ReaderGroup
Returns current distribution of number of segments assigned to each reader in the reader group.
getReaderSegmentDistribution() - Method in class io.pravega.client.stream.ReaderSegmentDistribution
 
getReadTimeout() - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
getRegisteredFutureLatch() - Method in class io.pravega.client.netty.impl.FlowHandler
 
getReplacementRanges() - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
Returns a map of the segment numbers to segment/ranges.
getRequestMetadata(URI) - Method in class io.pravega.client.stream.impl.PravegaCredentialsWrapper
 
getRetentionParam() - Method in class io.pravega.client.stream.RetentionPolicy
 
getRetentionPolicy() - Method in class io.pravega.client.stream.StreamConfiguration
API to return retention policy.
getRetentionType() - Method in class io.pravega.client.stream.RetentionPolicy
 
getRetryAttempts() - Method in class io.pravega.client.stream.EventWriterConfig
 
getRetryAttempts() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
getRevision() - Method in interface io.pravega.client.state.Revisioned
Returns the revision corresponding to this object.
getRevision() - Method in class io.pravega.client.stream.impl.ReaderGroupState
 
getRoutingKey() - Method in class io.pravega.client.stream.impl.PendingEvent
The routing key that was provided to route the data.
getScaleFactor() - Method in class io.pravega.client.stream.ScalingPolicy
 
getScaleType() - Method in class io.pravega.client.stream.ScalingPolicy
 
getScalingPolicy() - Method in class io.pravega.client.stream.StreamConfiguration
API to return scaling policy.
getScope() - Method in class io.pravega.client.admin.StreamInfo
Scope name of the stream.
getScope() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
getScope() - Method in interface io.pravega.client.batch.SegmentRange
Returns the scope name of the stream the segment is associated with.
getScope() - Method in class io.pravega.client.segment.impl.Segment
 
getScope() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getScope() - Method in class io.pravega.client.stream.impl.StreamImpl
 
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 class io.pravega.client.segment.impl.Segment
 
getScopedName() - Method in interface io.pravega.client.stream.impl.StreamInternal
Gets the scoped name of this stream.
getScopedName() - Method in interface io.pravega.client.stream.Stream
Gets the scoped name of this stream.
getScopedSegmentName() - Method in interface io.pravega.client.segment.impl.ConditionalOutputStream
Returns the scoped name of the segment associated to this output stream.
getScopedStreamName() - Method in class io.pravega.client.segment.impl.Segment
 
getScopedStreamName() - Method in interface io.pravega.client.state.Revisioned
Returns the scoped name of this stream used to persist this object.
getScopedStreamName() - Method in class io.pravega.client.stream.impl.ReaderGroupState
 
getSegment() - Method in class io.pravega.client.segment.impl.SegmentInfo
Which segment these properties relate to.
getSegment() - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
getSegmentForEvent(String) - Method in class io.pravega.client.stream.impl.SegmentSelector
 
getSegmentForKey(String) - Method in class io.pravega.client.stream.impl.StreamSegments
 
getSegmentForKey(double) - Method in class io.pravega.client.stream.impl.StreamSegments
 
getSegmentId() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
getSegmentId() - Method in interface io.pravega.client.batch.SegmentRange
Returns the segment number of Segment.
getSegmentId() - Method in interface io.pravega.client.segment.impl.EventSegmentReader
 
getSegmentId() - Method in class io.pravega.client.segment.impl.Segment
 
getSegmentId() - Method in interface io.pravega.client.segment.impl.SegmentInputStream
 
getSegmentInfo() - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
Returns info for the current segment.
getSegmentName() - Method in interface io.pravega.client.segment.impl.SegmentOutputStream
Returns the name of the segment associated to this output stream.
getSegmentNotifier(ScheduledExecutorService) - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
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.
getSegmentOutputStreamForKey(String) - Method in class io.pravega.client.stream.impl.SegmentSelector
Selects which segment an event should be written to.
getSegments(Stream, StreamCut, StreamCut) - Method in class io.pravega.client.batch.impl.BatchClientFactoryImpl
 
getSegments(Stream, StreamCut, StreamCut) - Method in interface io.pravega.client.BatchClientFactory
Provides a list of segments for a given stream between fromStreamCut and toStreamCut.
getSegments(StreamCut, StreamCut) - Method in interface io.pravega.client.stream.impl.Controller
Returns all the segments from the fromStreamCut till toStreamCut.
getSegments(StreamCut, StreamCut) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getSegments() - Method in class io.pravega.client.stream.impl.SegmentSelector
 
getSegments() - Method in class io.pravega.client.stream.impl.StreamSegments
 
getSegments() - Method in class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
getSegmentsAtTime(Stream, long) - Method in interface io.pravega.client.stream.impl.Controller
Given a timestamp and a stream returns segments and offsets that were present at that time in the stream.
getSegmentsAtTime(Stream, long) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getSegmentsForStreams(Controller, ReaderGroupConfig) - Static method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getSegmentsFromPositions(List<PositionInternal>) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
getSegmentsWithOffsets() - Method in class io.pravega.client.stream.impl.WriterPosition
 
getSegmentToPredecessor() - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
Get Segment to Predecessor mapping.
getSegmentVersion() - Method in interface io.pravega.client.tables.impl.KeyVersion
Gets a value representing the internal version inside the Table Segment for this Key.
getSegmentVersion() - Method in class io.pravega.client.tables.impl.KeyVersionImpl
 
getStartingOffset() - Method in class io.pravega.client.batch.impl.SegmentIteratorImpl
 
getStartingOffset() - Method in class io.pravega.client.segment.impl.SegmentInfo
The offset at which data is available.
getStartingSegments() - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
getStartingStreamCuts() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
getStartOffset() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
Start offset for the segment.
getStartOffset() - Method in interface io.pravega.client.batch.SegmentRange
Returns the start offset of the segment.
getStartStreamCut() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl
 
getStartStreamCut() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
getState() - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
getState() - Method in interface io.pravega.client.state.StateSynchronizer
Gets the state object currently held in memory.
getState() - Method in class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
getStream() - Method in class io.pravega.client.segment.impl.Segment
 
getStream() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
getStream() - Method in class io.pravega.client.stream.impl.StreamCutInternal
Get Stream for the StreamCut.
getStreamCuts() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
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 class io.pravega.client.admin.impl.StreamManagerImpl
 
getStreamInfo(String, String) - Method in interface io.pravega.client.admin.StreamManager
Get information about a given Stream, StreamInfo.
getStreamName() - Method in class io.pravega.client.admin.StreamInfo
Stream name.
getStreamName() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
getStreamName() - Method in interface io.pravega.client.batch.SegmentRange
Returns the stream name the segment is associated with.
getStreamName() - Method in class io.pravega.client.segment.impl.Segment
 
getStreamName() - Method in class io.pravega.client.stream.impl.StreamImpl
 
getStreamName() - Method in interface io.pravega.client.stream.Stream
Gets the name of this stream (Not including the scope).
getStreamNames() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getStreamNames() - Method in interface io.pravega.client.stream.ReaderGroup
Returns the set of scoped stream names which was used to configure this group.
getStreamSegments() - Method in class io.pravega.client.stream.impl.TxnSegments
 
getSuccessors(Segment) - Method in interface io.pravega.client.stream.impl.Controller
Returns StreamSegmentsWithPredecessors containing each of the segments that are successors to the segment requested mapped to a list of their predecessors.
getSuccessors(StreamCut) - Method in interface io.pravega.client.stream.impl.Controller
Returns all the segments that come after the provided cutpoint.
getSuccessors(Segment) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getSuccessors(StreamCut) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
getSynchronizer() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
getTailStreamCut() - Method in class io.pravega.client.admin.StreamInfo
StreamCut representing the current TAIL of the stream.
getTargetRate() - Method in class io.pravega.client.stream.ScalingPolicy
 
getTimeoutMillis() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
getTimestampAggregationTimeout() - Method in class io.pravega.client.stream.StreamConfiguration
The duration after the last call to EventStreamWriter.noteTime(long) which the timestamp should be considered valid before it is forgotten.
getTimeWindow() - Method in class io.pravega.client.stream.impl.WatermarkReaderImpl
Returns the current time window of the reader group for the associated stream.
getToken() - Method in class io.pravega.client.tables.impl.IteratorStateImpl
 
getTransactionTimeoutTime() - Method in class io.pravega.client.stream.EventWriterConfig
 
getTrustStore() - Method in class io.pravega.client.ClientConfig
Path to an optional truststore.
getTxn(UUID) - Method in class io.pravega.client.stream.impl.TransactionalEventStreamWriterImpl
 
getTxn(UUID) - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
Returns a previously created transaction.
getTxnId() - Method in class io.pravega.client.stream.impl.TxnSegments
 
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.
getUnackedEventsOnSeal() - Method in interface io.pravega.client.segment.impl.SegmentOutputStream
Change the state of SegmentOutputStream to sealed to prevent future writes and return the list of unackedEvents.
getUnassignedSegments() - Method in class io.pravega.client.stream.ReaderSegmentDistribution
 
getUpperTimeBound() - Method in class io.pravega.client.stream.TimeWindow
 
getUri() - Method in class io.pravega.client.netty.impl.Connection
 
getValue() - Method in enum io.pravega.client.segment.impl.SegmentAttribute
 
getValue() - Method in enum io.pravega.client.stream.ScalingPolicy.ScaleType
 
getValue() - Method in interface io.pravega.client.tables.impl.TableEntry
The Value.
getValue() - Method in class io.pravega.client.tables.impl.TableEntryImpl
 
getVersion() - Method in interface io.pravega.client.tables.impl.TableKey
The Version.
getVersion() - Method in class io.pravega.client.tables.impl.TableKeyImpl
 
getWriteOffset() - Method in class io.pravega.client.segment.impl.SegmentInfo
The offset at which new data would be written if it were to be added.
getWriters() - Method in class io.pravega.client.stream.impl.SegmentSelector
 
getWriteVersion() - Method in class io.pravega.client.stream.impl.StreamCutImpl.StreamCutSerializer
 
getWriteVersion() - Method in class io.pravega.client.tables.impl.KeyVersionImpl.KeyVersionImplSerializer
 
groupRefreshTimeMillis(long) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 

H

hashCode() - Method in class io.pravega.client.admin.StreamInfo
 
hashCode() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
hashCode() - Method in class io.pravega.client.ClientConfig
 
hashCode() - Method in class io.pravega.client.netty.impl.Connection
 
hashCode() - Method in class io.pravega.client.netty.impl.Flow
 
hashCode() - Method in class io.pravega.client.segment.impl.Segment
 
hashCode() - Method in class io.pravega.client.segment.impl.SegmentInfo
 
hashCode() - Method in class io.pravega.client.state.impl.RevisionImpl
 
hashCode() - Method in class io.pravega.client.state.SynchronizerConfig
 
hashCode() - Method in class io.pravega.client.stream.EventWriterConfig
 
hashCode() - Method in class io.pravega.client.stream.impl.CheckpointImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.CheckpointState
 
hashCode() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
hashCode() - Method in class io.pravega.client.stream.impl.DefaultCredentials
 
hashCode() - Method in class io.pravega.client.stream.impl.EventPointerImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.JavaSerializer
 
hashCode() - Method in class io.pravega.client.stream.impl.PendingEvent
 
hashCode() - Method in class io.pravega.client.stream.impl.PositionImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
hashCode() - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
hashCode() - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
hashCode() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.StreamImpl
 
hashCode() - Method in class io.pravega.client.stream.impl.StreamSegments
 
hashCode() - Method in class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
hashCode() - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
 
hashCode() - Method in class io.pravega.client.stream.impl.TxnSegments
 
hashCode() - Method in class io.pravega.client.stream.impl.WriterPosition
 
hashCode() - Method in class io.pravega.client.stream.notifications.Notification
 
hashCode() - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
hashCode() - Method in class io.pravega.client.stream.ReaderConfig
 
hashCode() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
hashCode() - Method in class io.pravega.client.stream.RetentionPolicy
 
hashCode() - Method in class io.pravega.client.stream.ScalingPolicy
 
hashCode() - Method in class io.pravega.client.stream.Sequence
 
hashCode() - Method in class io.pravega.client.stream.StreamConfiguration
 
hashCode() - Method in class io.pravega.client.stream.TimeWindow
 
hashCode() - Method in class io.pravega.client.tables.impl.IteratorStateImpl
 
hashCode() - Method in class io.pravega.client.tables.impl.KeyVersionImpl
 
hashCode() - Method in class io.pravega.client.tables.impl.TableEntryImpl
 
hashCode() - Method in class io.pravega.client.tables.impl.TableKeyImpl
 
hashCode() - Method in class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
hasNext() - Method in class io.pravega.client.batch.impl.SegmentIteratorImpl
 
hasRequestMetadata() - Method in class io.pravega.client.stream.impl.PravegaCredentialsWrapper
 
hasRequestMetadataOnly() - Method in class io.pravega.client.stream.impl.PravegaCredentialsWrapper
 

I

IdempotentEventStreamWriter<Type> - Interface in io.pravega.client.stream
A writer can write events to a stream.
initalBackoffMillis(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
initialAllocationDelay(long) - Method in class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
 
initialBackoffMillis(int) - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
initialize(InitialUpdate<StateT>) - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
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 class io.pravega.client.stream.impl.ReaderGroupImpl
 
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.admin.impl - package io.pravega.client.admin.impl
 
io.pravega.client.batch - package io.pravega.client.batch
 
io.pravega.client.batch.impl - package io.pravega.client.batch.impl
 
io.pravega.client.byteStream - package io.pravega.client.byteStream
 
io.pravega.client.byteStream.impl - package io.pravega.client.byteStream.impl
 
io.pravega.client.netty.impl - package io.pravega.client.netty.impl
 
io.pravega.client.security.auth - package io.pravega.client.security.auth
 
io.pravega.client.segment.impl - package io.pravega.client.segment.impl
 
io.pravega.client.state - package io.pravega.client.state
 
io.pravega.client.state.impl - package io.pravega.client.state.impl
 
io.pravega.client.stream - package io.pravega.client.stream
 
io.pravega.client.stream.impl - package io.pravega.client.stream.impl
 
io.pravega.client.stream.notifications - package io.pravega.client.stream.notifications
 
io.pravega.client.stream.notifications.notifier - package io.pravega.client.stream.notifications.notifier
 
io.pravega.client.tables.impl - package io.pravega.client.tables.impl
 
io.pravega.client.watermark - package io.pravega.client.watermark
 
isAutomaticallyNoteTime() - Method in class io.pravega.client.stream.EventWriterConfig
Automatically invoke EventStreamWriter.noteTime(long) passing System.currentTimeMillis() on a regular interval.
isCheckpoint() - Method in interface io.pravega.client.stream.EventRead
A boolean indicating if this is a checkpoint.
isCheckpoint() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
isClosed() - Method in class io.pravega.client.netty.impl.RawClient
 
isConnectionEstablished() - Method in class io.pravega.client.netty.impl.FlowHandler
Check the current status of Connection.
isDisableTimeWindows() - Method in class io.pravega.client.stream.ReaderConfig
 
isEnableConnectionPooling() - Method in class io.pravega.client.stream.EventWriterConfig
 
isEnableTls() - Method in class io.pravega.client.ClientConfig
Returns whether TLS is enabled for client-to-server (Controller and Segment Store) communications.
isEnableTlsToController() - Method in class io.pravega.client.ClientConfig
 
isEnableTlsToSegmentStore() - Method in class io.pravega.client.ClientConfig
 
isEndOfData() - Method in class io.pravega.client.stream.impl.ReaderGroupState
This functions returns true if the readers part of reader group for sealed streams have completely read the data.
isListenerPresent(String) - Method in class io.pravega.client.stream.notifications.NotificationSystem
Check if a Listener is present for a given notification type.
isNearHeadOfStream() - Method in class io.pravega.client.stream.TimeWindow
Returns true if the reader is currently near the head of the stream and therefore no lower time bound can be obtained.
isNearTailOfStream() - Method in class io.pravega.client.stream.TimeWindow
Returns true if the reader is currently near the tail of the stream and therefore no upper time bound can be obtained.
isOpen() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
isSealed() - Method in class io.pravega.client.segment.impl.SegmentInfo
If the segment is sealed and can no longer be written to.
isSegmentOpen(Segment) - Method in interface io.pravega.client.stream.impl.Controller
Checks to see if a segment exists and is not sealed.
isSegmentOpen(Segment) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
isSegmentReady() - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Returns true if EventSegmentReader.read() can be invoked without blocking.
isValidateHostName() - Method in class io.pravega.client.ClientConfig
If the flag ClientConfig.isEnableTls() is set, this flag decides whether to enable host name validation or not.
IteratorItem(IteratorState, List<T>) - Constructor for class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
IteratorState - Interface in io.pravega.client.tables.impl
Defines the state of a resumable iterator.
IteratorStateImpl - Class in io.pravega.client.tables.impl
Implementation of KeyVersion.
IteratorStateImpl(ByteBuf) - Constructor for class io.pravega.client.tables.impl.IteratorStateImpl
 

J

JavaSerializer<T extends java.io.Serializable> - Class in io.pravega.client.stream.impl
An implementation of Serializer that uses Java serialization.
JavaSerializer() - Constructor for class io.pravega.client.stream.impl.JavaSerializer
 
JwtTokenProviderImpl - Class in io.pravega.client.security.auth
Provides JWT-based delegation tokens.

K

keyIterator(IteratorState) - Method in interface io.pravega.client.tables.impl.TableSegment
Creates a new Iterator over all the Keys in the Table Segment.
KeyVersion - Interface in io.pravega.client.tables.impl
Version of a Key in a Table.
KeyVersionImpl - Class in io.pravega.client.tables.impl
Implementation of KeyVersion.
KeyVersionImpl(long) - Constructor for class io.pravega.client.tables.impl.KeyVersionImpl
 
KeyVersionImpl.KeyVersionImplSerializer - Class in io.pravega.client.tables.impl
 
KeyVersionImplSerializer() - Constructor for class io.pravega.client.tables.impl.KeyVersionImpl.KeyVersionImplSerializer
 

L

Listener<T> - Interface in io.pravega.client.stream.notifications
Listener interface for receiving notifications.
listStreams(String) - Method in class io.pravega.client.admin.impl.StreamManagerImpl
 
listStreams(String) - Method in interface io.pravega.client.admin.StreamManager
Gets an iterator for all streams in scope.
listStreams(String) - Method in interface io.pravega.client.stream.impl.Controller
Gets an async iterator on streams in scope.
listStreams(String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 

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
 
MAX_WRITE_SIZE - Static variable in class io.pravega.client.stream.impl.PendingEvent
The serialized event max size.
maxBackoffMillis(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
maxBackoffMillis(int) - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
maxConnectionsPerSegmentStore(int) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
MaxNumberOfCheckpointsExceededException - Exception in io.pravega.client.stream.impl
 
MaxNumberOfCheckpointsExceededException(String) - Constructor for exception io.pravega.client.stream.impl.MaxNumberOfCheckpointsExceededException
 
MaxNumberOfCheckpointsExceededException(Throwable) - Constructor for exception io.pravega.client.stream.impl.MaxNumberOfCheckpointsExceededException
 
MaxNumberOfCheckpointsExceededException(String, Throwable) - Constructor for exception io.pravega.client.stream.impl.MaxNumberOfCheckpointsExceededException
 
maxOutstandingCheckpointRequest(int) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
metricListener(MetricListener) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
MIN_VALUE - Static variable in class io.pravega.client.stream.Sequence
 
minNumSegments(int) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
 
ModelHelper - Class in io.pravega.client.stream.impl
Provides translation (encode/decode) between the Model classes and its gRPC representation.
ModelHelper() - Constructor for class io.pravega.client.stream.impl.ModelHelper
 

N

newBuilder() - Method in class io.pravega.client.stream.impl.StreamCutImpl.StreamCutSerializer
 
newBuilder() - Method in class io.pravega.client.tables.impl.KeyVersionImpl.KeyVersionImplSerializer
 
newNameResolver(URI, Attributes) - Method in class io.pravega.client.stream.impl.ControllerResolverFactory
 
next() - Method in class io.pravega.client.batch.impl.SegmentIteratorImpl
 
nextSegment(List<T>) - Method in class io.pravega.client.stream.impl.Orderer
Given a list of segments this reader owns, (which contain their positions) returns the one that should be read from next.
NO_VERSION - Static variable in interface io.pravega.client.tables.impl.KeyVersion
A special KeyVersion which indicates that no versioning is required.
NoSuchEventException - Exception in io.pravega.client.segment.impl
Could not retrieve an event given the event pointer.
NoSuchEventException(String) - Constructor for exception io.pravega.client.segment.impl.NoSuchEventException
 
NoSuchScopeException - Exception in io.pravega.client.stream
 
NoSuchScopeException() - Constructor for exception io.pravega.client.stream.NoSuchScopeException
Creates a new instance of NoSuchScopeException class.
NoSuchSegmentException - Exception in io.pravega.client.segment.impl
A segment does not exist and hence cannot be written to.
NoSuchSegmentException(String) - Constructor for exception io.pravega.client.segment.impl.NoSuchSegmentException
 
NoSuchSegmentException(String, Throwable) - Constructor for exception io.pravega.client.segment.impl.NoSuchSegmentException
 
NOT_EXISTS - Static variable in interface io.pravega.client.tables.impl.KeyVersion
A special KeyVersion which indicates the Key must not exist when performing Conditional Updates.
noteTime(long) - Method in interface io.pravega.client.stream.EventStreamWriter
Notes a time that can be seen by readers which read from this stream by EventStreamReader.getCurrentTimeWindow(Stream).
noteTime(long) - Method in class io.pravega.client.stream.impl.EventStreamWriterImpl
 
noteTimestampFromWriter(String, Stream, long, WriterPosition) - Method in interface io.pravega.client.stream.impl.Controller
Notifies that the specified writer has noted the provided timestamp when it was at lastWrittenPosition.
noteTimestampFromWriter(String, Stream, long, WriterPosition) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
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
 
NULL_VALUE - Static variable in enum io.pravega.client.segment.impl.SegmentAttribute
 
numOfReaders(int) - Method in class io.pravega.client.stream.notifications.SegmentNotification.SegmentNotificationBuilder
 
numOfSegments(int) - Method in class io.pravega.client.stream.notifications.SegmentNotification.SegmentNotificationBuilder
 

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.
onDataAvailable() - Method in class io.pravega.client.byteStream.ByteStreamReader
Returns a future that will be completed when there is data available to be read.
onDataAvailable() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
onNotification(T) - Method in interface io.pravega.client.stream.notifications.Listener
 
Orderer - Class in io.pravega.client.stream.impl
Used to select which event should go next when consuming from multiple segments.
Orderer() - Constructor for class io.pravega.client.stream.impl.Orderer
 
overlapsWith(SegmentWithRange.Range) - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 

P

PendingEvent - Class in io.pravega.client.stream.impl
This is a internal wrapper object used in the writer to pass along the routing key and the future with the actual event during write.
Pinger - Class in io.pravega.client.stream.impl
Pinger is used to send pings to renew the transaction lease for active transactions.
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
 
pingTransaction(Stream, UUID, long) - Method in interface io.pravega.client.stream.impl.Controller
API to send transaction heartbeat and increase the transaction timeout by lease amount of milliseconds.
pingTransaction(Stream, UUID, long) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
pollNow() - Method in class io.pravega.client.stream.notifications.notifier.EndOfDataNotifier
Invokes the periodic processing now in the current thread.
pollNow() - Method in class io.pravega.client.stream.notifications.notifier.SegmentNotifier
Invokes the periodic processing now in the current thread.
populateToken(String) - Method in interface io.pravega.client.security.auth.DelegationTokenProvider
Populates the object with the specified delegation token.
populateToken(String) - Method in class io.pravega.client.security.auth.EmptyTokenProviderImpl
 
populateToken(String) - Method in class io.pravega.client.security.auth.JwtTokenProviderImpl
 
populateToken(String) - Method in class io.pravega.client.security.auth.StringTokenProviderImpl
 
Position - Interface in io.pravega.client.stream
A position in a stream.
PositionImpl - Class in io.pravega.client.stream.impl
 
PositionImpl(Map<SegmentWithRange, Long>) - Constructor for class io.pravega.client.stream.impl.PositionImpl
Instantiates Position with current and future owned segments.
PositionInternal - Class in io.pravega.client.stream.impl
A position has ownedSegments -- segments that can be read currently (or have been completed and not yet replaced).
PositionInternal() - Constructor for class io.pravega.client.stream.impl.PositionInternal
 
PravegaCredentialsWrapper - Class in io.pravega.client.stream.impl
 
PravegaCredentialsWrapper(Credentials) - Constructor for class io.pravega.client.stream.impl.PravegaCredentialsWrapper
 
pruneUnusedConnections() - Method in class io.pravega.client.netty.impl.ConnectionPoolImpl
Used only for testing.
put(TableEntry<KeyT, ValueT>) - Method in interface io.pravega.client.tables.impl.TableSegment
Inserts or updates an existing Table Entry into this Table Segment.
put(Collection<TableEntry<KeyT, ValueT>>) - Method in interface io.pravega.client.tables.impl.TableSegment
Inserts new or updates existing Table Entries into this Table Segment.

R

Range(double, double) - Constructor for class io.pravega.client.stream.impl.SegmentWithRange.Range
 
RawClient - Class in io.pravega.client.netty.impl
 
RawClient(PravegaNodeUri, ConnectionFactory) - Constructor for class io.pravega.client.netty.impl.RawClient
 
RawClient(Controller, ConnectionFactory, Segment) - Constructor for class io.pravega.client.netty.impl.RawClient
 
read() - Method in class io.pravega.client.byteStream.ByteStreamReader
Reads a single byte.
read(byte[]) - Method in class io.pravega.client.byteStream.ByteStreamReader
This is equivalent to calling read(b, 0, b.length) Will only block if ByteStreamReader.available() is 0.
read(byte[], int, int) - Method in class io.pravega.client.byteStream.ByteStreamReader
If ByteStreamReader.available() is non-zero, this method will read bytes from an in-memory buffer into the provided array.
read(ByteBuffer) - Method in class io.pravega.client.byteStream.ByteStreamReader
Similar to ByteStreamReader.read(byte[], int, int) but takes a byteBuffer.
read(ByteBuffer) - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
read() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
read(byte[]) - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
read(byte[], int, int) - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
read() - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Reads the bytes of a single event from the segment.
read(long) - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Reads bytes of a single event from the segment.
read(ByteBuffer, long) - Method in interface io.pravega.client.segment.impl.SegmentInputStream
If data is available this will copy bytes from an internal buffer into the buffer provided.
readBufferSize(int) - Method in class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
 
ReaderConfig - Class in io.pravega.client.stream
 
ReaderConfig.ReaderConfigBuilder - Class in io.pravega.client.stream
 
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.ReaderGroupConfigBuilder - Class in io.pravega.client.stream
 
ReaderGroupImpl - Class in io.pravega.client.stream.impl
 
ReaderGroupImpl(String, String, SynchronizerConfig, Serializer<InitialUpdate<ReaderGroupState>>, Serializer<Update<ReaderGroupState>>, SynchronizerClientFactory, Controller, ConnectionFactory) - Constructor for class io.pravega.client.stream.impl.ReaderGroupImpl
 
ReaderGroupInitSerializer() - Constructor for class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupInitSerializer
 
ReaderGroupManager - Interface in io.pravega.client.admin
Used to create and manage reader groups.
ReaderGroupManagerImpl - Class in io.pravega.client.admin.impl
A stream manager.
ReaderGroupManagerImpl(String, ClientConfig, ConnectionFactory) - Constructor for class io.pravega.client.admin.impl.ReaderGroupManagerImpl
 
ReaderGroupManagerImpl(String, Controller, SynchronizerClientFactory, ConnectionFactory) - Constructor for class io.pravega.client.admin.impl.ReaderGroupManagerImpl
 
ReaderGroupManagerImpl.ReaderGroupStateInitSerializer - Class in io.pravega.client.admin.impl
 
ReaderGroupManagerImpl.ReaderGroupStateUpdatesSerializer - Class in io.pravega.client.admin.impl
 
ReaderGroupMetrics - Interface in io.pravega.client.stream
 
ReaderGroupNotificationListener - Interface in io.pravega.client.stream.notifications
ReaderGroup notification listener interface.
ReaderGroupState - Class in io.pravega.client.stream.impl
This class encapsulates the state machine of a reader group.
ReaderGroupState.ReaderGroupInitSerializer - Class in io.pravega.client.stream.impl
 
ReaderGroupState.ReaderGroupStateInit - Class in io.pravega.client.stream.impl
 
ReaderGroupState.ReaderGroupUpdateSerializer - Class in io.pravega.client.stream.impl
 
ReaderGroupStateInit(ReaderGroupConfig, Map<SegmentWithRange, Long>, Map<Segment, Long>) - Constructor for class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
ReaderGroupStateInitSerializer() - Constructor for class io.pravega.client.admin.impl.ReaderGroupManagerImpl.ReaderGroupStateInitSerializer
 
ReaderGroupStateManager - Class in io.pravega.client.stream.impl
Manages the state of the reader group on behalf of a reader.
ReaderGroupStateUpdatesSerializer() - Constructor for class io.pravega.client.admin.impl.ReaderGroupManagerImpl.ReaderGroupStateUpdatesSerializer
 
ReaderGroupUpdateSerializer() - Constructor for class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupUpdateSerializer
 
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 class io.pravega.client.stream.impl.ReaderGroupImpl
 
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(Map<String, Integer>) - Method in class io.pravega.client.stream.ReaderSegmentDistribution.ReaderSegmentDistributionBuilder
 
ReaderSegmentDistribution.ReaderSegmentDistributionBuilder - Class in io.pravega.client.stream
 
readFrom(Revision) - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
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.
readNextEvent(long) - Method in class io.pravega.client.stream.impl.EventStreamReaderImpl
 
readSegment(SegmentRange, Serializer<T>) - Method in class io.pravega.client.batch.impl.BatchClientFactoryImpl
 
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.
refresh() - Method in class io.pravega.client.stream.impl.PravegaCredentialsWrapper
 
refreshSegmentEventWriters(Consumer<Segment>) - Method in class io.pravega.client.stream.impl.SegmentSelector
Refresh the latest list of segments in the given stream.
refreshSegmentEventWritersUponSealed(Segment, Consumer<Segment>) - Method in class io.pravega.client.stream.impl.SegmentSelector
Refresh segment writers corresponding to the successors of the sealed segment and return inflight event list of the sealed 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
 
remove(TableKey<KeyT>) - Method in interface io.pravega.client.tables.impl.TableSegment
Removes the given key from this Table Segment.
remove(Collection<TableKey<KeyT>>) - Method in interface io.pravega.client.tables.impl.TableSegment
Removes one or more keys from this Table Segment.
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.
removeWriter(String, Stream) - Method in interface io.pravega.client.stream.impl.Controller
Notifies the controller that the specified writer is shutting down gracefully and no longer needs to be considered for calculating entries for the marks segment.
removeWriter(String, Stream) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
resetReaderGroup(ReaderGroupConfig) - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
resetReaderGroup(ReaderGroupConfig) - Method in interface io.pravega.client.stream.ReaderGroup
Reset a reader group with the provided ReaderGroupConfig.
retentionParam(long) - Method in class io.pravega.client.stream.RetentionPolicy.RetentionPolicyBuilder
 
RetentionPolicy - Class in io.pravega.client.stream
 
retentionPolicy(RetentionPolicy) - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
 
RetentionPolicy.RetentionPolicyBuilder - Class in io.pravega.client.stream
 
RetentionPolicy.RetentionType - Enum in io.pravega.client.stream
 
retentionType(RetentionPolicy.RetentionType) - Method in class io.pravega.client.stream.RetentionPolicy.RetentionPolicyBuilder
 
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
 
retryAttempts(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
retryAttempts(int) - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
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.
RevisionedStreamClientImpl<T> - Class in io.pravega.client.state.impl
 
RevisionedStreamClientImpl(Segment, EventSegmentReader, SegmentOutputStreamFactory, ConditionalOutputStream, SegmentMetadataClient, Serializer<T>, EventWriterConfig, DelegationTokenProvider) - Constructor for class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
RevisionImpl - Class in io.pravega.client.state.impl
 

S

scaleFactor(int) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
 
scaleStream(Stream, List<Long>, Map<Double, Double>, ScheduledExecutorService) - Method in interface io.pravega.client.stream.impl.Controller
API to merge or split stream segments.
scaleStream(Stream, List<Long>, Map<Double, Double>, ScheduledExecutorService) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
scaleType(ScalingPolicy.ScaleType) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
 
ScalingPolicy - Class in io.pravega.client.stream
A policy that specifies how the number of segments in a stream should scale over time.
scalingPolicy(ScalingPolicy) - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
 
ScalingPolicy.ScaleType - Enum in io.pravega.client.stream
 
ScalingPolicy.ScalingPolicyBuilder - Class in io.pravega.client.stream
 
sealSegment() - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
Seals the segment so that no more writes can go to it.
sealStream(String, String) - Method in class io.pravega.client.admin.impl.StreamManagerImpl
 
sealStream(String, String) - Method in interface io.pravega.client.admin.StreamManager
Seal an existing stream.
sealStream(String, String) - Method in interface io.pravega.client.stream.impl.Controller
API to seal a stream.
sealStream(String, String) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
seekToOffset(long) - Method in class io.pravega.client.byteStream.ByteStreamReader
Seeks to the provided offset (It can be anywhere in the segment).
seekToOffset(long) - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
segment(Segment) - Method in class io.pravega.client.batch.impl.SegmentRangeImpl.SegmentRangeImplBuilder
 
Segment - Class in io.pravega.client.segment.impl
An identifier for a segment of a stream.
Segment(String, String, long) - Constructor for class io.pravega.client.segment.impl.Segment
Creates a new instance of Segment class.
SegmentAttribute - Enum in io.pravega.client.segment.impl
Attributes that can be set by the client on a segment.
SegmentInfo - Class in io.pravega.client.segment.impl
Information about a segment of a stream.
SegmentInfo(Segment, long, long, boolean, long) - Constructor for class io.pravega.client.segment.impl.SegmentInfo
 
SegmentInputStream - Interface in io.pravega.client.segment.impl
Defines a InputStream for a single segment.
SegmentInputStreamFactory - Interface in io.pravega.client.segment.impl
Creates SegmentInputStream for reading from existing segments.
SegmentInputStreamFactoryImpl - Class in io.pravega.client.segment.impl
 
SegmentInputStreamFactoryImpl(Controller, ConnectionFactory) - Constructor for class io.pravega.client.segment.impl.SegmentInputStreamFactoryImpl
 
SegmentIterator<T> - Interface in io.pravega.client.batch
Please note this is an experimental API.
SegmentIteratorImpl<T> - Class in io.pravega.client.batch.impl
 
SegmentIteratorImpl(SegmentInputStreamFactory, Segment, Serializer<T>, long, long) - Constructor for class io.pravega.client.batch.impl.SegmentIteratorImpl
 
SegmentMetadataClient - Interface in io.pravega.client.segment.impl
A client for looking at and editing the metadata related to a specific segment.
SegmentMetadataClientFactory - Interface in io.pravega.client.segment.impl
Creates SegmentMetadataClient for metadata operations on existing segments.
SegmentMetadataClientFactoryImpl - Class in io.pravega.client.segment.impl
 
SegmentMetadataClientFactoryImpl(Controller, ConnectionFactory) - Constructor for class io.pravega.client.segment.impl.SegmentMetadataClientFactoryImpl
 
SegmentNotification - Class in io.pravega.client.stream.notifications
Class to represent a segment notification.
SegmentNotification.SegmentNotificationBuilder - Class in io.pravega.client.stream.notifications
 
SegmentNotifier - Class in io.pravega.client.stream.notifications.notifier
 
SegmentNotifier(NotificationSystem, StateSynchronizer<ReaderGroupState>, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.notifications.notifier.SegmentNotifier
 
SegmentOutputStream - Interface in io.pravega.client.segment.impl
Defines an OutputStream for a segment.
SegmentOutputStreamFactory - Interface in io.pravega.client.segment.impl
Creates SegmentOutputStream for segments and transactions.
SegmentOutputStreamFactoryImpl - Class in io.pravega.client.segment.impl
 
SegmentOutputStreamFactoryImpl(Controller, ConnectionFactory) - Constructor for class io.pravega.client.segment.impl.SegmentOutputStreamFactoryImpl
 
SegmentRange - Interface in io.pravega.client.batch
This is used to represent range bounded portion of a Segment.
SegmentRangeImpl - Class in io.pravega.client.batch.impl
Implementation of SegmentRange.
SegmentRangeImpl.SegmentRangeImplBuilder - Class in io.pravega.client.batch.impl
 
segmentRangeIterator(Iterator<SegmentRange>) - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl.StreamSegmentsInfoImplBuilder
 
segments(Map<Segment, Long>) - Method in class io.pravega.client.stream.impl.WriterPosition.WriterPositionBuilder
 
SegmentSealedException - Exception in io.pravega.client.segment.impl
A segment has been sealed and no more events may be written to it.
SegmentSealedException(String) - Constructor for exception io.pravega.client.segment.impl.SegmentSealedException
 
SegmentSelector - Class in io.pravega.client.stream.impl
A class that determines to which segment an event associated with a routing key will go.
SegmentSelector(Stream, Controller, SegmentOutputStreamFactory, EventWriterConfig, DelegationTokenProvider) - Constructor for class io.pravega.client.stream.impl.SegmentSelector
 
SegmentTransaction<Type> - Interface in io.pravega.client.stream.impl
The mirror of Transaction but that is specific to one segment.
SegmentTruncatedException - Exception in io.pravega.client.segment.impl
The data being read has been truncated and no longer exists.
SegmentTruncatedException() - Constructor for exception io.pravega.client.segment.impl.SegmentTruncatedException
 
SegmentTruncatedException(Throwable) - Constructor for exception io.pravega.client.segment.impl.SegmentTruncatedException
 
SegmentTruncatedException(String) - Constructor for exception io.pravega.client.segment.impl.SegmentTruncatedException
 
SegmentWithRange - Class in io.pravega.client.stream.impl
An identifier for a segment of a stream.
SegmentWithRange(Segment, double, double) - Constructor for class io.pravega.client.stream.impl.SegmentWithRange
 
SegmentWithRange(Segment, SegmentWithRange.Range) - Constructor for class io.pravega.client.stream.impl.SegmentWithRange
 
SegmentWithRange.Range - Class in io.pravega.client.stream.impl
 
send(WireCommand) - Method in interface io.pravega.client.netty.impl.ClientConnection
Sends the provided command.
send(Append) - Method in interface io.pravega.client.netty.impl.ClientConnection
Sends the provided append request.
send(WireCommand) - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
send(Append) - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
sendAsync(WireCommand, ClientConnection.CompletedCallback) - Method in interface io.pravega.client.netty.impl.ClientConnection
Sends a wire command asynchronously.
sendAsync(List<Append>, ClientConnection.CompletedCallback) - Method in interface io.pravega.client.netty.impl.ClientConnection
Sends the provided append commands.
sendAsync(WireCommand, ClientConnection.CompletedCallback) - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
sendAsync(List<Append>, ClientConnection.CompletedCallback) - Method in class io.pravega.client.netty.impl.ClientConnectionImpl
 
sendRequest(long, T) - Method in class io.pravega.client.netty.impl.RawClient
 
Sequence - Class in io.pravega.client.stream
A wrapper for two numbers.
serialize(InitialUpdate<ReaderGroupState>) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl.ReaderGroupStateInitSerializer
 
serialize(Update<ReaderGroupState>) - Method in class io.pravega.client.admin.impl.ReaderGroupManagerImpl.ReaderGroupStateUpdatesSerializer
 
serialize(UpdateOrInit<StateT>) - Method in class io.pravega.client.state.impl.UpdateOrInitSerializer
 
serialize(byte[]) - Method in class io.pravega.client.stream.impl.ByteArraySerializer
 
serialize(ByteBuffer) - Method in class io.pravega.client.stream.impl.ByteBufferSerializer
 
serialize(T) - Method in class io.pravega.client.stream.impl.JavaSerializer
 
serialize(String) - Method in class io.pravega.client.stream.impl.UTF8StringSerializer
 
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.
setEventWriterConfig(EventWriterConfig) - Method in class io.pravega.client.state.SynchronizerConfig
 
setNumOfReaders(int) - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
setNumOfSegments(int) - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
setOffset(long) - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Sets the offset for reading from the segment.
setOffset(long, boolean) - Method in interface io.pravega.client.segment.impl.EventSegmentReader
Sets the offset for reading from the segment.
setOffset(long) - Method in interface io.pravega.client.segment.impl.SegmentInputStream
Sets the offset for reading from the segment.
setOffset(long, boolean) - Method in interface io.pravega.client.segment.impl.SegmentInputStream
Sets the offset for reading from the segment.
setReadBufferSize(int) - Method in class io.pravega.client.state.SynchronizerConfig
 
skip(long) - Method in class io.pravega.client.byteStream.ByteStreamReader
This method attempts to skip forward by the provided number of bytes.
skip(long) - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
start(Supplier<CompletableFuture<T>>, Predicate<T>, ScheduledExecutorService) - Method in class io.pravega.client.stream.impl.CancellableRequest
 
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.
startingStreamCuts(Map<Stream, StreamCut>) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
startOffset(long) - Method in class io.pravega.client.batch.impl.SegmentRangeImpl.SegmentRangeImplBuilder
 
startScale(Stream, List<Long>, Map<Double, Double>) - Method in interface io.pravega.client.stream.impl.Controller
API to request start of scale operation on controller.
startScale(Stream, List<Long>, Map<Double, Double>) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
startStreamCut(StreamCut) - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl.StreamSegmentsInfoImplBuilder
 
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.
StateSynchronizerImpl<StateT extends Revisioned> - Class in io.pravega.client.state.impl
 
StateSynchronizerImpl(Segment, RevisionedStreamClient<UpdateOrInit<StateT>>) - Constructor for class io.pravega.client.state.impl.StateSynchronizerImpl
Creates a new instance of StateSynchronizer class.
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.StreamConfigurationBuilder - Class in io.pravega.client.stream
 
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.
StreamCutHelper - Class in io.pravega.client.admin.impl
Helper class to obtain the current HEAD and TAIL StreamCuts for a given Stream.
StreamCutHelper(Controller, ConnectionFactory) - Constructor for class io.pravega.client.admin.impl.StreamCutHelper
 
StreamCutImpl - Class in io.pravega.client.stream.impl
Implementation of StreamCut interface.
StreamCutImpl(Stream, Map<Segment, Long>) - Constructor for class io.pravega.client.stream.impl.StreamCutImpl
 
StreamCutImpl.StreamCutSerializer - Class in io.pravega.client.stream.impl
 
StreamCutInternal - Class in io.pravega.client.stream.impl
This is an abstract class which acts an intermediate class to make the actual StreamCut implementation opaque.
StreamCutInternal() - Constructor for class io.pravega.client.stream.impl.StreamCutInternal
 
StreamCutSerializer() - Constructor for class io.pravega.client.stream.impl.StreamCutImpl.StreamCutSerializer
 
StreamImpl - Class in io.pravega.client.stream.impl
 
StreamImpl(String, String) - Constructor for class io.pravega.client.stream.impl.StreamImpl
Creates a new instance of the Stream class.
StreamInfo - Class in io.pravega.client.admin
This class is used to represent Stream information.
StreamInfo(String, String, StreamCut, StreamCut) - Constructor for class io.pravega.client.admin.StreamInfo
 
StreamInternal - Interface in io.pravega.client.stream.impl
 
StreamManager - Interface in io.pravega.client.admin
Used to create, delete, and manage Streams and ReaderGroups.
StreamManagerImpl - Class in io.pravega.client.admin.impl
A stream manager.
StreamManagerImpl(ClientConfig) - Constructor for class io.pravega.client.admin.impl.StreamManagerImpl
 
StreamManagerImpl(Controller, ConnectionFactory) - Constructor for class io.pravega.client.admin.impl.StreamManagerImpl
 
StreamSegments - Class in io.pravega.client.stream.impl
The segments that within a stream at a particular point in time.
StreamSegments(NavigableMap<Double, SegmentWithRange>, String) - Constructor for class io.pravega.client.stream.impl.StreamSegments
Creates a new instance of the StreamSegments class.
StreamSegmentsInfoImpl - Class in io.pravega.client.batch.impl
This class contains the segment information of a stream between two StreamCuts.
StreamSegmentsInfoImpl.StreamSegmentsInfoImplBuilder - Class in io.pravega.client.batch.impl
 
StreamSegmentsIterator - Interface in io.pravega.client.batch
 
StreamSegmentSuccessors - Class in io.pravega.client.stream.impl
Successor segments of a given segment.
StreamSegmentSuccessors(Set<Segment>, String) - Constructor for class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
StreamSegmentsWithPredecessors - Class in io.pravega.client.stream.impl
The successor segments of a given segment.
StreamSegmentsWithPredecessors(Map<SegmentWithRange, List<Long>>, String) - Constructor for class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
 
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.SynchronizerConfigBuilder - Class in io.pravega.client.state
 

T

TableEntry<KeyT,ValueT> - Interface in io.pravega.client.tables.impl
A Table Entry with a Version.
TableEntryImpl<KeyT,ValueT> - Class in io.pravega.client.tables.impl
Implementation of TableEntry.
TableEntryImpl(TableKey<KeyT>, ValueT) - Constructor for class io.pravega.client.tables.impl.TableEntryImpl
 
TableKey<KeyT> - Interface in io.pravega.client.tables.impl
A Table Key with a Version.
TableKeyImpl<KeyT> - Class in io.pravega.client.tables.impl
Implementation of TableKey.
TableKeyImpl(KeyT, KeyVersion) - Constructor for class io.pravega.client.tables.impl.TableKeyImpl
 
TableSegment<KeyT,ValueT> - Interface in io.pravega.client.tables.impl
Defines all operations that are supported on a Table Segment.
TableSegment.IteratorItem<T> - Class in io.pravega.client.tables.impl
An iteration result item returned by AsyncIterator when invoking TableSegment.entryIterator(IteratorState) or TableSegment.keyIterator(IteratorState).
targetRate(int) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
 
timeoutMillis(long) - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
timestampAggregationTimeout(long) - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
 
TimeWindow - Class in io.pravega.client.stream
Represents a time window for the events which are currently being read by a reader.
TimeWindow(Long, Long) - Constructor for class io.pravega.client.stream.TimeWindow
 
toBuilder() - Method in class io.pravega.client.ClientConfig
 
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 class io.pravega.client.stream.impl.CheckpointImpl
 
toBytes() - Method in class io.pravega.client.stream.impl.CheckpointState
 
toBytes() - Method in class io.pravega.client.stream.impl.EventPointerImpl
 
toBytes() - Method in class io.pravega.client.stream.impl.PositionImpl
 
toBytes() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
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.
toBytes() - Method in interface io.pravega.client.tables.impl.IteratorState
Serializes the IteratorState instance to a compact byte array.
toBytes() - Method in class io.pravega.client.tables.impl.IteratorStateImpl
 
toBytes() - Method in interface io.pravega.client.tables.impl.KeyVersion
Serializes the KeyVersion instance to a compact byte array.
toBytes() - Method in class io.pravega.client.tables.impl.KeyVersionImpl
 
toFlowID(long) - Static method in class io.pravega.client.netty.impl.Flow
Obtain a FlowID from a long representation.
toSegmentOffsetMap(PositionInternal) - Static method in class io.pravega.client.stream.impl.ModelHelper
 
toString() - Method in class io.pravega.client.admin.StreamInfo
 
toString() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl.SegmentRangeImplBuilder
 
toString() - Method in class io.pravega.client.batch.impl.SegmentRangeImpl
 
toString() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl.StreamSegmentsInfoImplBuilder
 
toString() - Method in class io.pravega.client.batch.impl.StreamSegmentsInfoImpl
 
toString() - Method in class io.pravega.client.byteStream.impl.ByteStreamReaderImpl
 
toString() - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
toString() - Method in class io.pravega.client.ClientConfig
 
toString() - Method in class io.pravega.client.netty.impl.Connection
 
toString() - Method in class io.pravega.client.netty.impl.Flow
 
toString() - Method in class io.pravega.client.segment.impl.Segment
 
toString() - Method in class io.pravega.client.segment.impl.SegmentInfo
 
toString() - Method in class io.pravega.client.state.impl.RevisionImpl
 
toString() - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
toString() - Method in interface io.pravega.client.state.Revision
Serializes the Revision to a human readable string.
toString() - Method in class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
 
toString() - Method in class io.pravega.client.state.SynchronizerConfig
 
toString() - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
toString() - Method in class io.pravega.client.stream.EventWriterConfig
 
toString() - Method in class io.pravega.client.stream.impl.CheckpointState
 
toString() - Method in class io.pravega.client.stream.impl.ControllerImplConfig.ControllerImplConfigBuilder
 
toString() - Method in class io.pravega.client.stream.impl.ControllerImplConfig
 
toString() - Method in class io.pravega.client.stream.impl.EventPointerImpl
 
toString() - Method in class io.pravega.client.stream.impl.EventReadImpl
 
toString() - Method in class io.pravega.client.stream.impl.EventStreamReaderImpl
 
toString() - Method in class io.pravega.client.stream.impl.EventStreamWriterImpl
 
toString() - Method in class io.pravega.client.stream.impl.PendingEvent
 
toString() - Method in class io.pravega.client.stream.impl.PositionImpl
 
toString() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
toString() - Method in class io.pravega.client.stream.impl.ReaderGroupState.ReaderGroupStateInit
 
toString() - Method in class io.pravega.client.stream.impl.ReaderGroupState
 
toString() - Method in class io.pravega.client.stream.impl.SegmentWithRange.Range
 
toString() - Method in class io.pravega.client.stream.impl.SegmentWithRange
 
toString() - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
toString() - Method in class io.pravega.client.stream.impl.StreamImpl
 
toString() - Method in class io.pravega.client.stream.impl.StreamSegments
 
toString() - Method in class io.pravega.client.stream.impl.StreamSegmentSuccessors
 
toString() - Method in class io.pravega.client.stream.impl.StreamSegmentsWithPredecessors
 
toString() - Method in class io.pravega.client.stream.impl.TransactionalEventStreamWriterImpl
 
toString() - Method in class io.pravega.client.stream.impl.TxnSegments
 
toString() - Method in class io.pravega.client.stream.impl.WriterPosition
 
toString() - Method in class io.pravega.client.stream.impl.WriterPosition.WriterPositionBuilder
 
toString() - Method in class io.pravega.client.stream.notifications.Notification
 
toString() - Method in class io.pravega.client.stream.notifications.SegmentNotification.SegmentNotificationBuilder
 
toString() - Method in class io.pravega.client.stream.notifications.SegmentNotification
 
toString() - Method in class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
 
toString() - Method in class io.pravega.client.stream.ReaderConfig
 
toString() - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
 
toString() - Method in class io.pravega.client.stream.ReaderGroupConfig
 
toString() - Method in class io.pravega.client.stream.ReaderSegmentDistribution.ReaderSegmentDistributionBuilder
 
toString() - Method in class io.pravega.client.stream.RetentionPolicy.RetentionPolicyBuilder
 
toString() - Method in class io.pravega.client.stream.RetentionPolicy
 
toString() - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
 
toString() - Method in class io.pravega.client.stream.ScalingPolicy
 
toString() - Method in class io.pravega.client.stream.Sequence
 
toString() - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
 
toString() - Method in class io.pravega.client.stream.StreamConfiguration
 
toString() - Method in class io.pravega.client.stream.TimeWindow
 
toString() - Method in class io.pravega.client.tables.impl.IteratorStateImpl
 
toString() - Method in class io.pravega.client.tables.impl.KeyVersionImpl
 
toString() - Method in class io.pravega.client.tables.impl.TableEntryImpl
 
toString() - Method in class io.pravega.client.tables.impl.TableKeyImpl
 
toString() - Method in class io.pravega.client.tables.impl.TableSegment.IteratorItem
 
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.
TransactionalEventStreamWriterImpl<Type> - Class in io.pravega.client.stream.impl
This class creates transactions, and manages their lifecycle.
transactionTimeoutTime(long) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
 
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.
truncateSegment(long) - Method in interface io.pravega.client.segment.impl.SegmentMetadataClient
Deletes all data before the offset of the provided segment.
truncateStream(String, String, StreamCut) - Method in class io.pravega.client.admin.impl.StreamManagerImpl
 
truncateStream(String, String, StreamCut) - Method in interface io.pravega.client.admin.StreamManager
Truncate stream at given stream cut.
truncateStream(String, String, StreamCut) - Method in interface io.pravega.client.stream.impl.Controller
API to Truncate stream.
truncateStream(String, String, StreamCut) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
truncateToRevision(Revision) - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
truncateToRevision(Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
Removes all data through the revision provided.
trustStore(String) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
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.
TxnSegments - Class in io.pravega.client.stream.impl
 
TxnSegments(StreamSegments, UUID) - Constructor for class io.pravega.client.stream.impl.TxnSegments
 

U

unassignedSegments(int) - Method in class io.pravega.client.stream.ReaderSegmentDistribution.ReaderSegmentDistributionBuilder
 
UNBOUNDED - Static variable in interface io.pravega.client.stream.StreamCut
This is used represents an unbounded StreamCut.
unreadBytes() - Method in class io.pravega.client.stream.impl.ReaderGroupImpl
 
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.
UpdateOrInitSerializer<StateT extends Revisioned,UpdateT extends Update<StateT>,InitT extends InitialUpdate<StateT>> - Class in io.pravega.client.state.impl
 
UpdateOrInitSerializer(Serializer<UpdateT>, Serializer<InitT>) - Constructor for class io.pravega.client.state.impl.UpdateOrInitSerializer
 
updateState(StateSynchronizer.UpdateGenerator<StateT>) - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
updateState(StateSynchronizer.UpdateGeneratorFunction<StateT, ReturnT>) - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
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 class io.pravega.client.state.impl.StateSynchronizerImpl
 
updateStateUnconditionally(List<? extends Update<StateT>>) - Method in class io.pravega.client.state.impl.StateSynchronizerImpl
 
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 class io.pravega.client.admin.impl.StreamManagerImpl
 
updateStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.admin.StreamManager
Change the configuration for an existing stream.
updateStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.stream.impl.Controller
API to update the configuration of a stream.
updateStream(String, String, StreamConfiguration) - Method in class io.pravega.client.stream.impl.ControllerImpl
 
UTF8StringSerializer - Class in io.pravega.client.stream.impl
An implementation of Serializer that converts UTF-8 strings.
UTF8StringSerializer() - Constructor for class io.pravega.client.stream.impl.UTF8StringSerializer
 

V

validate(Set<String>) - Method in class io.pravega.client.stream.impl.StreamCutImpl
 
validateHostName(boolean) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
 
valueOf(String) - Static method in enum io.pravega.client.segment.impl.EndOfSegmentException.ErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.pravega.client.segment.impl.SegmentAttribute
Returns the enum constant of this type with the specified name.
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.PingStatus
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.segment.impl.EndOfSegmentException.ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.pravega.client.segment.impl.SegmentAttribute
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.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.PingStatus
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

WatermarkReaderImpl - Class in io.pravega.client.stream.impl
 
WatermarkReaderImpl(Stream, RevisionedStreamClient<Watermark>, Executor) - Constructor for class io.pravega.client.stream.impl.WatermarkReaderImpl
Creates a Reader to keep track of the current time window for a given stream.
WatermarkSerializer - Class in io.pravega.client.watermark
 
WatermarkSerializer() - Constructor for class io.pravega.client.watermark.WatermarkSerializer
 
withHeader(String, ByteBuffer, CompletableFuture<Void>) - Static method in class io.pravega.client.stream.impl.PendingEvent
 
withoutHeader(String, ByteBuffer, CompletableFuture<Void>) - Static method in class io.pravega.client.stream.impl.PendingEvent
 
withReplacementRange(Segment, StreamSegmentsWithPredecessors) - Method in class io.pravega.client.stream.impl.StreamSegments
 
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, ClientConfig) - Static method in interface io.pravega.client.BatchClientFactory
Creates a new instance of BatchClientFactory.
withScope(String, ClientConfig) - Static method in interface io.pravega.client.ByteStreamClientFactory
Creates a new instance of ByteStreamClientFactory.
withScope(String, ClientConfig) - Static method in interface io.pravega.client.EventStreamClientFactory
Creates a new instance of Client Factory.
withScope(String, ClientConfig) - Static method in interface io.pravega.client.SynchronizerClientFactory
Creates a new instance of Client Factory.
write(ByteBuffer) - Method in class io.pravega.client.byteStream.ByteStreamWriter
Similar to ByteStreamWriter.write(byte[], int, int) Writes the provided data to the segment.
write(byte[], int, int) - Method in class io.pravega.client.byteStream.ByteStreamWriter
Writes the provided data to the segment.
write(int) - Method in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
write(ByteBuffer) - Method in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
write(byte[], int, int) - Method in class io.pravega.client.byteStream.impl.BufferedByteStreamWriterImpl
 
write(int) - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
write(ByteBuffer) - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
write(byte[], int, int) - Method in class io.pravega.client.byteStream.impl.ByteStreamWriterImpl
 
write(ByteBuffer, long) - Method in interface io.pravega.client.segment.impl.ConditionalOutputStream
Writes the provided data to the SegmentOutputStream.
write(PendingEvent) - Method in interface io.pravega.client.segment.impl.SegmentOutputStream
Writes the provided data to the SegmentOutputStream.
writeConditionally(Revision, T) - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
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 class io.pravega.client.stream.impl.EventStreamWriterImpl
 
writeEvent(String, Type) - Method in class io.pravega.client.stream.impl.EventStreamWriterImpl
 
writeEvent(Type) - Method in interface io.pravega.client.stream.impl.SegmentTransaction
Writes the provided event to this transaction on this segment.
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.
WriterPosition - Class in io.pravega.client.stream.impl
 
WriterPosition(Map<Segment, Long>) - Constructor for class io.pravega.client.stream.impl.WriterPosition
 
WriterPosition.WriterPositionBuilder - Class in io.pravega.client.stream.impl
 
writeUnconditionally(T) - Method in class io.pravega.client.state.impl.RevisionedStreamClientImpl
 
writeUnconditionally(T) - Method in interface io.pravega.client.state.RevisionedStreamClient
Write a new value to the stream.
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links