A B C D E F G H I J K L M N O P R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort() - Method in interface io.pravega.client.stream.Transaction
-
Drops the transaction, causing all events written to it to be deleted.
- ABORTED - io.pravega.client.stream.Transaction.PingStatus
- ABORTED - io.pravega.client.stream.Transaction.Status
- ABORTING - io.pravega.client.stream.Transaction.Status
- AbstractNotifier<T extends Notification> - Class in io.pravega.client.stream.notifications.notifier
-
AbstractNotifier which is used by all types of Notifiers.
- AbstractNotifier(NotificationSystem, ScheduledExecutorService) - Constructor for class io.pravega.client.stream.notifications.notifier.AbstractNotifier
- AbstractPollingNotifier<T extends Notification> - Class in io.pravega.client.stream.notifications.notifier
- addListeners(String, Listener<T>, ScheduledExecutorService) - Method in class io.pravega.client.stream.notifications.NotificationSystem
- applyTo(StateT, Revision) - Method in interface io.pravega.client.state.InitialUpdate
- applyTo(StateT, Revision) - Method in interface io.pravega.client.state.Update
-
Return an object of type StateT that is the same as oldState with this update applied to it.
- asImpl() - Method in interface io.pravega.client.batch.SegmentRange
-
For internal use.
- asImpl() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
For internal use.
- asImpl() - Method in interface io.pravega.client.state.Revision
-
Returns the actual instance.
- asImpl() - Method in interface io.pravega.client.stream.Checkpoint
-
For internal use.
- asImpl() - Method in interface io.pravega.client.stream.EventPointer
-
Used internally.
- asImpl() - Method in interface io.pravega.client.stream.Position
-
Used internally.
- asImpl() - Method in interface io.pravega.client.stream.StreamCut
-
Used internally.
- asImpl() - Method in interface io.pravega.client.tables.Version
-
Returns the actual instance.
- asText() - Method in interface io.pravega.client.stream.StreamCut
-
Obtains the compact base64 string representation of StreamCut.
- AUTOMATIC_RELEASE_AT_LAST_CHECKPOINT - io.pravega.client.stream.ReaderGroupConfig.StreamDataRetention
- automaticallyNoteTime(boolean) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
-
Automatically invoke
EventStreamWriter.noteTime(long)
passingSystem.currentTimeMillis()
on a regular interval. - 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.
B
- backoffMultiple(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
- backoffMultiple(int) - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder
- BadKeyVersionException - Exception in io.pravega.client.tables
-
Exception that is thrown whenever a conditional
KeyValueTable
update failed due to the provided key version mismatching. - BadKeyVersionException(String) - Constructor for exception io.pravega.client.tables.BadKeyVersionException
-
Creates a new instance of the
BadKeyVersionException
class. - BadKeyVersionException(String, String) - Constructor for exception io.pravega.client.tables.BadKeyVersionException
-
Creates a new instance of the
BadKeyVersionException
class. - BatchClientFactory - Interface in io.pravega.client
-
Please note this is an experimental API.
- beginTxn() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Start a new transaction on this stream.
- bufferSize(int) - Method in class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
- 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.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
- build() - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder
- build() - Method in class io.pravega.client.tables.KeyValueTableConfiguration.KeyValueTableConfigurationBuilder
- 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.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.KeyValueTableClientConfiguration
- builder() - Static method in class io.pravega.client.tables.KeyValueTableConfiguration
- BY_RATE_IN_EVENTS_PER_SEC - io.pravega.client.stream.ScalingPolicy.ScaleType
-
Scale based on the rate in events specified in
ScalingPolicy.targetRate
. - BY_RATE_IN_KBYTES_PER_SEC - io.pravega.client.stream.ScalingPolicy.ScaleType
-
Scale based on the rate in bytes specified in
ScalingPolicy.targetRate
. - 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.
- bySizeBytes(long, 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.
- ByteStreamClientFactory - Interface in io.pravega.client
-
Used to create Writers and Readers operating on a Byte Stream.
- ByteStreamReader - Class in io.pravega.client.byteStream
-
Allows for reading raw bytes from a segment.
- ByteStreamReader() - Constructor for class io.pravega.client.byteStream.ByteStreamReader
- 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
- 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 be periodically truncated according to the specified duration.
- byTime(Duration, 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
- canEqual(Object) - Method in class io.pravega.client.admin.KeyValueTableInfo
- canEqual(Object) - Method in class io.pravega.client.admin.StreamInfo
- canEqual(Object) - Method in class io.pravega.client.ClientConfig
- 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.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.IteratorItem
- canEqual(Object) - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration
- canEqual(Object) - Method in class io.pravega.client.tables.KeyValueTableConfiguration
- Checkpoint - Interface in io.pravega.client.stream
- checkScopeExists(String) - Method in interface io.pravega.client.admin.StreamManager
-
Checks if a scope exists.
- checkStatus() - Method in interface io.pravega.client.stream.Transaction
-
Gets the status of the transaction.
- checkStreamExists(String, String) - Method in interface io.pravega.client.admin.StreamManager
-
Checks if a stream exists in scope.
- ClientConfig - Class in io.pravega.client
-
This class contains configuration that is passed on to Pravega client.
- ClientConfig.ClientConfigBuilder - Class in io.pravega.client
-
This class overrides the lombok builder.
- close() - Method in interface io.pravega.client.admin.KeyValueTableManager
-
Closes the
KeyValueTableManager
. - close() - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Close this manager class.
- close() - Method in interface io.pravega.client.admin.StreamManager
-
Closes the stream manager.
- close() - Method in interface io.pravega.client.batch.SegmentIterator
-
Closes the iterator, freeing any resources associated with it.
- close() - Method in interface io.pravega.client.BatchClientFactory
-
Closes the client factory.
- close() - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Closes the reader.
- close() - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
Flushes the buffer and closes the writer.
- close() - Method in interface io.pravega.client.ByteStreamClientFactory
-
Closes the ByteStreamClientFactory.
- close() - Method in interface io.pravega.client.EventStreamClientFactory
-
Closes the client factory.
- close() - Method in interface io.pravega.client.KeyValueTableFactory
-
Closes the
KeyValueTableFactory
. - close() - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Closes the client and frees any resources associated with it.
- close() - Method in interface io.pravega.client.state.StateSynchronizer
-
Closes the StateSynchronizer and frees any resources associated with it.
- close() - Method in interface io.pravega.client.stream.EventStreamReader
-
Close the reader.
- close() - Method in interface io.pravega.client.stream.EventStreamWriter
-
Calls flush and then closes the writer.
- close() - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
-
Calls flush and then closes the writer.
- close() - Method in interface io.pravega.client.stream.ReaderGroup
-
Closes the reader group, freeing any resources associated with it.
- close() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Closes the writer.
- close() - Method in interface io.pravega.client.SynchronizerClientFactory
-
Closes the client factory.
- close() - Method in interface io.pravega.client.tables.KeyValueTable
-
Closes the
KeyValueTable
. - 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. - closeAt(Position) - Method in interface io.pravega.client.stream.EventStreamReader
-
Close the reader at a specific position.
- commit() - Method in interface io.pravega.client.stream.Transaction
-
Causes all messages previously written to the transaction to go into the stream contiguously.
- commit(long) - Method in interface io.pravega.client.stream.Transaction
-
Commits the transaction similar to
Transaction.commit()
, but also notes an associated timestamp. - COMMITTED - io.pravega.client.stream.Transaction.PingStatus
- COMMITTED - io.pravega.client.stream.Transaction.Status
- COMMITTING - io.pravega.client.stream.Transaction.Status
- compact(Function<StateT, InitialUpdate<StateT>>) - Method in interface io.pravega.client.state.StateSynchronizer
-
Provide a function that generates compacted version of localState so that we can drop some of the history updates.
- compareAndSetMark(Revision, Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Records a provided location that can later be obtained by calling
RevisionedStreamClient.getMark()
. - compareTo(Sequence) - Method in class io.pravega.client.stream.Sequence
- ConditionalTableUpdateException - Exception in io.pravega.client.tables
-
Exception that is thrown whenever a Conditional Update to a
KeyValueTable
failed. - ConditionalTableUpdateException(String) - Constructor for exception io.pravega.client.tables.ConditionalTableUpdateException
-
Creates a new instance of the
ConditionalTableUpdateException
class. - ConditionalTableUpdateException(String, String) - Constructor for exception io.pravega.client.tables.ConditionalTableUpdateException
-
Creates a new instance of the
ConditionalTableUpdateException
class. - controllerURI(URI) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
-
controllerURI The controller rpc URI.
- create(long, long) - Static method in class io.pravega.client.stream.Sequence
- create(ClientConfig) - Static method in interface io.pravega.client.admin.KeyValueTableManager
-
Creates a new instance of
KeyValueTableManager
. - create(ClientConfig) - Static method in interface io.pravega.client.admin.StreamManager
-
Creates a new instance of StreamManager.
- create(Controller, Segment, AccessOperation) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
Creates a
DelegationTokenProvider
instance with null delegation token. - create(Controller, String, String, AccessOperation) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
Creates a
DelegationTokenProvider
instance with null delegation token. - create(String, Controller, Segment, AccessOperation) - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
Creates a
DelegationTokenProvider
instance with the specified delegation token. - create(String, Controller, String, String, AccessOperation) - 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(URI) - Static method in interface io.pravega.client.admin.KeyValueTableManager
-
Creates a new instance of
KeyValueTableManager
. - create(URI) - Static method in interface io.pravega.client.admin.StreamManager
-
Creates a new instance of StreamManager.
- createByteStreamReader(String) - Method in interface io.pravega.client.ByteStreamClientFactory
-
Creates a new ByteStreamReader on the specified stream initialized to offset 0.
- createByteStreamWriter(String) - Method in interface io.pravega.client.ByteStreamClientFactory
-
Creates a new ByteStreamWriter on the specified stream.
- createEventWriter(String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates a new writer that can write to the specified stream.
- createEventWriter(String, String, Serializer<T>, EventWriterConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates a new writer that can write to the specified stream.
- createKeyValueTable(String, String, KeyValueTableConfiguration) - Method in interface io.pravega.client.admin.KeyValueTableManager
-
Creates a new Key-Value Table.
- createReader(String, String, Serializer<T>, ReaderConfig) - Method in interface io.pravega.client.EventStreamClientFactory
-
Creates (or recreates) a new reader that is part of a
ReaderGroup
. - createReaderGroup(String, ReaderGroupConfig) - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Creates a new ReaderGroup.
- createRevisionedStreamClient(String, Serializer<T>, SynchronizerConfig) - Method in interface io.pravega.client.SynchronizerClientFactory
-
Creates a new RevisionedStreamClient that will work with the specified stream.
- createScope(String) - Method in interface io.pravega.client.admin.StreamManager
-
Creates a new scope.
- createStateSynchronizer(String, Serializer<UpdateT>, Serializer<InitT>, SynchronizerConfig) - Method in interface io.pravega.client.SynchronizerClientFactory
-
Creates a new StateSynchronizer that will work on the specified stream.
- createStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.admin.StreamManager
-
Creates a new stream
- createTransactionalEventWriter(String, 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 interface io.pravega.client.EventStreamClientFactory
-
Creates a new transactional writer that can write to the specified stream atomically.
- createWithEmptyToken() - Static method in class io.pravega.client.security.auth.DelegationTokenProviderFactory
-
Creates a
DelegationTokenProvider
instance with empty token. - credentials(Credentials) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
-
Credentials to be passed on to the Pravega controller for authentication and authorization.
D
- 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
- deleteKeyValueTable(String, String) - Method in interface io.pravega.client.admin.KeyValueTableManager
-
Deletes the provided Key-Value Table.
- deleteReaderGroup(String) - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Deletes a reader group, removing any state associated with it.
- deleteScope(String) - Method in interface io.pravega.client.admin.StreamManager
-
Deletes an existing scope.
- deleteScope(String, boolean) - Method in interface io.pravega.client.admin.StreamManager
-
Deletes scope by listing and deleting all streams in scope.
- DeleteScopeFailedException - Exception in io.pravega.client.stream
-
Delete scope failed, typically because we failed to seal and delete the streams.
- DeleteScopeFailedException(String, Throwable) - Constructor for exception io.pravega.client.stream.DeleteScopeFailedException
- deleteStream(String, String) - Method in interface io.pravega.client.admin.StreamManager
-
Deletes the provided stream.
- deserialize(ByteBuffer) - Method in interface io.pravega.client.stream.Serializer
-
Deserializes the given ByteBuffer into an event.
- 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
- 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
- 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
- entryIterator(String, int, IteratorState) - Method in interface io.pravega.client.tables.KeyValueTable
-
Creates a new Iterator over all the
TableEntry
instances in thisKeyValueTable
that belong to a specific Key Family. - equals(Object) - Method in class io.pravega.client.admin.KeyValueTableInfo
- equals(Object) - Method in class io.pravega.client.admin.StreamInfo
- equals(Object) - Method in class io.pravega.client.ClientConfig
- 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.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.IteratorItem
- equals(Object) - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration
- equals(Object) - Method in class io.pravega.client.tables.KeyValueTableConfiguration
- EventPointer - Interface in io.pravega.client.stream
-
A pointer to an event.
- EventRead<T> - Interface in io.pravega.client.stream
-
An event that was read from a stream or a checkpoint marker if one has been requested.
- 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.
- EventStreamWriter<Type> - Interface in io.pravega.client.stream
-
A writer can write events to a stream.
- eventWriterConfig(EventWriterConfig) - Method in class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
-
This writer config is used by the segment writers in the StateSyncrhonizer.
- EventWriterConfig - Class in io.pravega.client.stream
- EventWriterConfig.EventWriterConfigBuilder - Class in io.pravega.client.stream
- executor - Variable in class io.pravega.client.stream.notifications.notifier.AbstractNotifier
F
- fetchEvent(EventPointer) - Method in interface io.pravega.client.stream.EventStreamReader
-
Re-read an event that was previously read, by passing the pointer returned from
EventRead.getEventPointer()
. - fetchLatestRevision() - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Returns the latest revision.
- fetchOldestRevision() - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Returns the oldest revision that reads can start from.
- 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.
- fetchUpdates() - Method in interface io.pravega.client.state.StateSynchronizer
-
Fetch and apply all updates needed to the state object held locally up to date.
- fixed(int) - Static method in class io.pravega.client.stream.ScalingPolicy
-
Create a scaling policy to configure a stream to have a fixed number of segments.
- FIXED_NUM_SEGMENTS - io.pravega.client.stream.ScalingPolicy.ScaleType
-
No scaling, there will only ever be
ScalingPolicy.minNumSegments
at any given time. - flush() - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
Blocks until all data written has been durably persisted.
- flush() - Method in interface io.pravega.client.stream.EventStreamWriter
-
Block until all events that have been passed to writeEvent's corresponding futures have completed.
- flush() - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
-
Block until all events that have been passed to writeEvent's corresponding futures have completed.
- flush() - Method in interface io.pravega.client.stream.Transaction
-
Blocks until all events passed to
Transaction.writeEvent(String, Object)
make it to durable storage. - forKeyValueTable(String, Serializer<KeyT>, Serializer<ValueT>, KeyValueTableClientConfiguration) - Method in interface io.pravega.client.KeyValueTableFactory
-
Creates a new
KeyValueTable
that provides access to a Pravega Key-Value Table. - 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 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(ByteBuffer) - Static method in interface io.pravega.client.tables.IteratorState
-
Creates a new
IteratorState
from the givenByteBuffer
. - 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 interface io.pravega.client.tables.Version
-
Deserializes the
Version
from its serialized form obtained from callingVersion.toString()
.
G
- generateStreamCuts(ScheduledExecutorService) - Method in interface io.pravega.client.stream.ReaderGroup
-
Generates a
StreamCut
after co-ordinating with all the readers usingStateSynchronizer
. - generation(long) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
- get(String, KeyT) - Method in interface io.pravega.client.tables.KeyValueTable
-
Gets the latest value for the a Key that belong to a specific Key Family.
- getAll(String, Iterable<KeyT>) - Method in interface io.pravega.client.tables.KeyValueTable
-
Gets the latest values for a set of Keys that do belong to the same Key Family.
- 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.tables.KeyValueTableClientConfiguration
- getBufferSize() - Method in class io.pravega.client.stream.ReaderConfig
- getCheckpointName() - Method in interface io.pravega.client.stream.EventRead
-
If a checkpoint has been requested this will return the checkpointName passed to
ReaderGroup.initiateCheckpoint(String,ScheduledExecutorService)
otherwise this will return null. - getConfig() - Method in interface io.pravega.client.stream.EventStreamReader
-
Gets the configuration that this reader was created with.
- getConfig() - Method in interface io.pravega.client.stream.EventStreamWriter
-
Returns the configuration that this writer was create with.
- getConfig() - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
-
Returns the configuration that this writer was create with.
- getConfig() - Method in interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Returns the configuration that this writer was created with.
- 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.
- 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. - getEndingStreamCuts() - Method in class io.pravega.client.stream.ReaderGroupConfig
- getEndOfDataNotifier(ScheduledExecutorService) - Method in class io.pravega.client.stream.notifications.NotifierFactory
- getEndOfDataNotifier(ScheduledExecutorService) - Method in interface io.pravega.client.stream.notifications.ReaderGroupNotificationListener
-
Get an end of data notifier for a given reader group.
- getEndOffset() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the end offset of the segment.
- getEndStreamCut() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
This returns the end
StreamCut
specified inBatchClientFactory.getSegments(Stream, StreamCut, StreamCut)
. - getEvent() - Method in interface io.pravega.client.stream.EventRead
-
Returns the event that is wrapped in this EventRead or null a timeout occurred or if a checkpoint was requested.
- getEventPointer() - Method in interface io.pravega.client.stream.EventRead
-
Returns a pointer object for the event read.
- getEventWriterConfig() - Method in class io.pravega.client.state.SynchronizerConfig
-
This writer config is used by the segment writers in the StateSyncrhonizer.
- getGeneration() - Method in class io.pravega.client.stream.ReaderGroupConfig
- 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. - getHighOrder() - Method in class io.pravega.client.stream.Sequence
- getInitialAllocationDelay() - Method in class io.pravega.client.stream.ReaderConfig
- getInitialBackoffMillis() - Method in class io.pravega.client.stream.EventWriterConfig
- getInitialBackoffMillis() - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration
- getItems() - Method in class io.pravega.client.tables.IteratorItem
-
A List of items that are contained in this instance.
- getIterator() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
This returns an iterator for
SegmentRange
specified inBatchClientFactory.getSegments(Stream, StreamCut, StreamCut)
. - getKey() - Method in class io.pravega.client.tables.TableEntry
-
The
TableKey
. - getKey() - Method in class io.pravega.client.tables.TableKey
-
The Key.
- getKeyFamily() - Method in interface io.pravega.client.tables.KeyValueTableMap
-
Gets the Key Family over which this
KeyValueTableMap
applies. - getKeyValueTableName() - Method in class io.pravega.client.admin.KeyValueTableInfo
-
Key-Value Table name.
- getLowerTimeBound() - Method in class io.pravega.client.stream.TimeWindow
- getLowOrder() - Method in class io.pravega.client.stream.Sequence
- getMapFor(String) - Method in interface io.pravega.client.tables.KeyValueTable
-
Exposes this
KeyValueTable
instance as aMap
. - getMark() - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Returns a location previously set by
RevisionedStreamClient.compareAndSetMark(Revision, Revision)
. - getMaxBackoffMillis() - Method in class io.pravega.client.stream.EventWriterConfig
- getMaxBackoffMillis() - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration
- 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
- getMetricListener() - Method in class io.pravega.client.ClientConfig
-
An optional listener which can be used to get performance metrics from the client.
- 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
-
Returns the name of the Checkpoint specified in
ReaderGroup.initiateCheckpoint(String, java.util.concurrent.ScheduledExecutorService)
. - getNumOfReaders() - Method in class io.pravega.client.stream.notifications.SegmentNotification
- getNumOfSegments() - Method in class io.pravega.client.stream.notifications.SegmentNotification
- getOffset() - Method in interface io.pravega.client.batch.SegmentIterator
-
Provides the current offset in the segment.
- getOffset() - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Returns the current byte offset in the segment.
- getOnlineReaders() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns a set of readerIds for the readers that are considered to be online by the group.
- getPartitionCount() - Method in class io.pravega.client.tables.KeyValueTableConfiguration
-
The number of Partitions for a Key-Value Table.
- getPosition() - Method in interface io.pravega.client.stream.EventRead
-
The position in the stream that represents where the reader is immediately following this event.
- getReadBufferSize() - Method in class io.pravega.client.state.SynchronizerConfig
-
This size is used to allocate buffer space for the bytes the reader in the StateSyncrhonizer reads from the segment.
- getReaderGroup(String) - Method in interface io.pravega.client.admin.ReaderGroupManager
-
Returns the requested reader group.
- getReaderGroupId() - Method in class io.pravega.client.stream.ReaderGroupConfig
- getReaderId() - Method in exception io.pravega.client.stream.ReaderNotInReaderGroupException
- 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
- getRetentionMax() - Method in class io.pravega.client.stream.RetentionPolicy
- 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.ReaderGroupConfig
- 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.tables.KeyValueTableClientConfiguration
- getRevision() - Method in interface io.pravega.client.state.Revisioned
-
Returns the revision corresponding to this object.
- 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.KeyValueTableInfo
-
Scope name of the Key-Value Table.
- getScope() - Method in class io.pravega.client.admin.StreamInfo
-
Scope name of the stream.
- getScope() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the scope name of the stream the segment is associated with.
- getScope() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns the scope of the stream which the group is associated with.
- getScope() - Method in interface io.pravega.client.stream.Stream
-
Gets the scope of this stream.
- getScopedName() - Method in class io.pravega.client.admin.KeyValueTableInfo
-
Gets a Fully Qualified Key-Value Table Name.
- getScopedName() - Method in interface io.pravega.client.stream.Stream
-
Gets the scoped name of this stream.
- getScopedStreamName() - Method in interface io.pravega.client.state.Revisioned
-
Returns the scoped name of this stream used to persist this object.
- getSegmentId() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the segment number of Segment.
- getSegmentNotifier(ScheduledExecutorService) - Method in class io.pravega.client.stream.notifications.NotifierFactory
- getSegmentNotifier(ScheduledExecutorService) - Method in interface io.pravega.client.stream.notifications.ReaderGroupNotificationListener
-
Get a segment notifier for a given reader group.
- getSegments(Stream, StreamCut, StreamCut) - Method in interface io.pravega.client.BatchClientFactory
-
Provides a list of segments for a given stream between fromStreamCut and toStreamCut.
- getStartingStreamCuts() - Method in class io.pravega.client.stream.ReaderGroupConfig
- getStartOffset() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the start offset of the segment.
- getStartStreamCut() - Method in interface io.pravega.client.batch.StreamSegmentsIterator
-
This returns the start
StreamCut
specified inBatchClientFactory.getSegments(Stream, StreamCut, StreamCut)
. - 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.IteratorItem
-
Gets an
IteratorState
that can be used to reinvokeKeyValueTable.entryIterator(java.lang.String, int, io.pravega.client.tables.IteratorState)
orKeyValueTable.keyIterator(java.lang.String, int, io.pravega.client.tables.IteratorState)
if a previous iteration has been interrupted (by losing the pointer to theAsyncIterator
), system restart, etc. - getStreamCuts() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns a
StreamCut
for each stream that this reader group is reading from. - getStreamInfo(String, String) - Method in interface io.pravega.client.admin.StreamManager
-
Get information about a given Stream,
StreamInfo
. - getStreamName() - Method in class io.pravega.client.admin.StreamInfo
-
Stream name.
- getStreamName() - Method in interface io.pravega.client.batch.SegmentRange
-
Returns the stream name the segment is associated with.
- getStreamName() - Method in interface io.pravega.client.stream.Stream
-
Gets the name of this stream (Not including the scope).
- getStreamNames() - Method in interface io.pravega.client.stream.ReaderGroup
-
Returns the set of scoped stream names which was used to configure this group.
- getTableName() - Method in exception io.pravega.client.tables.ConditionalTableUpdateException
- 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
- 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. - 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 interface io.pravega.client.stream.TransactionalEventStreamWriter
-
Returns a previously created transaction.
- getTxnId() - Method in interface io.pravega.client.stream.Transaction
-
Returns a unique ID that can be used to identify this transaction.
- getType() - Method in class io.pravega.client.stream.notifications.notifier.EndOfDataNotifier
- getType() - Method in class io.pravega.client.stream.notifications.notifier.SegmentNotifier
- getType() - Method in interface io.pravega.client.stream.notifications.Observable
-
Get the notification type.
- getUnassignedSegments() - Method in class io.pravega.client.stream.ReaderSegmentDistribution
- getUpperTimeBound() - Method in class io.pravega.client.stream.TimeWindow
- getValue() - Method in enum io.pravega.client.stream.ScalingPolicy.ScaleType
- getValue() - Method in class io.pravega.client.tables.TableEntry
-
The Value.
- getVersion() - Method in class io.pravega.client.tables.TableKey
-
The Version.
- groupRefreshTimeMillis(long) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
H
- hashCode() - Method in class io.pravega.client.admin.KeyValueTableInfo
- hashCode() - Method in class io.pravega.client.admin.StreamInfo
- hashCode() - Method in class io.pravega.client.ClientConfig
- 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.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.IteratorItem
- hashCode() - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration
- hashCode() - Method in class io.pravega.client.tables.KeyValueTableConfiguration
I
- IdempotentEventStreamWriter<Type> - Interface in io.pravega.client.stream
-
A writer can write events to a stream.
- initialAllocationDelay(long) - Method in class io.pravega.client.stream.ReaderConfig.ReaderConfigBuilder
- initialBackoffMillis(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
- initialBackoffMillis(int) - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder
- initialize(InitialUpdate<StateT>) - Method in interface io.pravega.client.state.StateSynchronizer
-
This method can be used to provide an initial value for a new stream if the stream has not been previously initialized.
- InitialUpdate<StateT extends Revisioned> - Interface in io.pravega.client.state
-
A constructor for a StateT object.
- initiateCheckpoint(String, ScheduledExecutorService) - Method in interface io.pravega.client.stream.ReaderGroup
-
Initiate a checkpoint.
- InvalidStreamException - Exception in io.pravega.client.stream
- InvalidStreamException(String) - Constructor for exception io.pravega.client.stream.InvalidStreamException
- InvalidStreamException(String, Throwable) - Constructor for exception io.pravega.client.stream.InvalidStreamException
- InvalidStreamException(Throwable) - Constructor for exception io.pravega.client.stream.InvalidStreamException
- io.pravega.client - package io.pravega.client
- io.pravega.client.admin - package io.pravega.client.admin
- io.pravega.client.batch - package io.pravega.client.batch
- io.pravega.client.byteStream - package io.pravega.client.byteStream
- io.pravega.client.security.auth - package io.pravega.client.security.auth
- io.pravega.client.state - package io.pravega.client.state
- io.pravega.client.stream - package io.pravega.client.stream
- io.pravega.client.stream.notifications - package io.pravega.client.stream.notifications
- io.pravega.client.stream.notifications.notifier - package io.pravega.client.stream.notifications.notifier
- io.pravega.client.tables - package io.pravega.client.tables
- io.pravega.client.watermark - package io.pravega.client.watermark
- isAutomaticallyNoteTime() - Method in class io.pravega.client.stream.EventWriterConfig
-
Automatically invoke
EventStreamWriter.noteTime(long)
passingSystem.currentTimeMillis()
on a regular interval. - isCheckpoint() - Method in interface io.pravega.client.stream.EventRead
-
A boolean indicating if this is a checkpoint.
- isDisableTimeWindows() - Method in class io.pravega.client.stream.ReaderConfig
- isEmpty() - Method in interface io.pravega.client.tables.IteratorState
-
Gets a value indicating whether this
IteratorState
instance is empty. - 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
- 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.
- isSealed() - Method in class io.pravega.client.admin.StreamInfo
-
Indicates whether the Stream is sealed (true) or not (false).
- 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<T> - Class in io.pravega.client.tables
-
An iteration result item returned by
AsyncIterator
when invokingKeyValueTable.entryIterator(java.lang.String, int, io.pravega.client.tables.IteratorState)
orKeyValueTable.keyIterator(java.lang.String, int, io.pravega.client.tables.IteratorState)
. - IteratorItem(IteratorState, List<T>) - Constructor for class io.pravega.client.tables.IteratorItem
- IteratorState - Interface in io.pravega.client.tables
-
Represents the state of a resumable iterator.
J
- JwtTokenProviderImpl - Class in io.pravega.client.security.auth
-
Provides JWT-based delegation tokens.
K
- keyIterator(String, int, IteratorState) - Method in interface io.pravega.client.tables.KeyValueTable
-
Creates a new Iterator over all the
TableKey
s in thisKeyValueTable
that belong to a specific Key Family. - KeyValueTable<KeyT,ValueT> - Interface in io.pravega.client.tables
-
Defines all operations that are supported on a Key-Value Table.
- KeyValueTableClientConfiguration - Class in io.pravega.client.tables
-
Configuration for the
KeyValueTable
client. - KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder - Class in io.pravega.client.tables
- KeyValueTableConfiguration - Class in io.pravega.client.tables
-
The configuration of a Key-Value Table.
- KeyValueTableConfiguration.KeyValueTableConfigurationBuilder - Class in io.pravega.client.tables
- KeyValueTableFactory - Interface in io.pravega.client
-
Creates instances of
KeyValueTable
. - KeyValueTableInfo - Class in io.pravega.client.admin
-
Information about a Key-Value Table.
- KeyValueTableInfo(String, String) - Constructor for class io.pravega.client.admin.KeyValueTableInfo
- KeyValueTableManager - Interface in io.pravega.client.admin
-
Used to create, delete and manage Key-Value Tables.
- KeyValueTableMap<KeyT,ValueT> - Interface in io.pravega.client.tables
-
Map
implementation for aKeyValueTable
's Key Family. - KeyVersion - Class in io.pravega.client.tables
-
Version of a Key in a Table.
L
- Listener<T> - Interface in io.pravega.client.stream.notifications
-
Listener interface for receiving notifications.
- listKeyValueTables(String) - Method in interface io.pravega.client.admin.KeyValueTableManager
-
Gets an iterator for all Key-Value Table in the given scope.
- listScopes() - Method in interface io.pravega.client.admin.StreamManager
-
Gets an iterator for all scopes.
- listStreams(String) - Method in interface io.pravega.client.admin.StreamManager
-
Gets an iterator for all streams in scope.
M
- MANUAL_RELEASE_AT_USER_STREAMCUT - io.pravega.client.stream.ReaderGroupConfig.StreamDataRetention
- 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
- maxBackoffMillis(int) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
- maxBackoffMillis(int) - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder
- maxConnectionsPerSegmentStore(int) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
-
Maximum number of connections per Segment store to be used by connection pooling.
- MAXIMUM_SERIALIZED_KEY_LENGTH - Static variable in interface io.pravega.client.tables.KeyValueTable
-
The maximum serialization length of a Table Segment Key.
- MAXIMUM_SERIALIZED_VALUE_LENGTH - Static variable in interface io.pravega.client.tables.KeyValueTable
-
The maximum serialized length of a Table Segment Value.
- maxOutstandingCheckpointRequest(int) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
- metricListener(MetricListener) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
-
An optional listener which can be used to get performance metrics from the client.
- MIN_VALUE - Static variable in class io.pravega.client.stream.Sequence
- minNumSegments(int) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
N
- NO_VERSION - Static variable in class io.pravega.client.tables.KeyVersion
-
KeyVersion
that indicates no specific version is desired. - NO_VERSION - Static variable in interface io.pravega.client.tables.Version
-
Version
that indicates no specific version is desired. - NONE - io.pravega.client.stream.ReaderGroupConfig.StreamDataRetention
- NoSuchKeyException - Exception in io.pravega.client.tables
-
Exception that is thrown whenever a conditional
KeyValueTable
update failed due to the key not existing. - NoSuchKeyException(String) - Constructor for exception io.pravega.client.tables.NoSuchKeyException
-
Creates a new instance of the
NoSuchKeyException
class. - NoSuchScopeException - Exception in io.pravega.client.stream
- NoSuchScopeException() - Constructor for exception io.pravega.client.stream.NoSuchScopeException
-
Creates a new instance of NoSuchScopeException class.
- NOT_EXISTS - Static variable in class io.pravega.client.tables.KeyVersion
-
KeyVersion
that indicates theTableKey
must not exist. - NOT_EXISTS - Static variable in interface io.pravega.client.tables.Version
- 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)
. - notExists(KeyT) - Static method in class io.pravega.client.tables.TableKey
-
Creates a new
TableKey
with a version that indicates the key must not exist. - notExists(KeyT, ValueT) - Static method in class io.pravega.client.tables.TableEntry
-
Creates a new
TableEntry
with a version that indicates the key must not exist. - 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
- 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) - Static method in interface io.pravega.client.stream.Stream
-
Helper utility to create a Stream object from a scopedName of a Stream.
- of(String, String) - Static method in interface io.pravega.client.stream.Stream
-
Helper utility to create a Stream object.
- onDataAvailable() - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Returns a future that will be completed when there is data available to be read.
- onNotification(T) - Method in interface io.pravega.client.stream.notifications.Listener
- OPEN - io.pravega.client.stream.Transaction.PingStatus
- OPEN - io.pravega.client.stream.Transaction.Status
P
- partitionCount(int) - Method in class io.pravega.client.tables.KeyValueTableConfiguration.KeyValueTableConfigurationBuilder
-
The number of Partitions for a Key-Value Table.
- 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(String) - Constructor for exception io.pravega.client.stream.PingFailedException
- PingFailedException(String, Throwable) - Constructor for exception io.pravega.client.stream.PingFailedException
- PingFailedException(Throwable) - Constructor for exception io.pravega.client.stream.PingFailedException
- 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.
- put(String, KeyT, ValueT) - Method in interface io.pravega.client.tables.KeyValueTable
-
Unconditionally inserts a new or updates an existing Entry in the
KeyValueTable
. - putAll(String, Iterable<Map.Entry<KeyT, ValueT>>) - Method in interface io.pravega.client.tables.KeyValueTable
-
Unconditionally inserts new or updates existing
TableEntry
instances that belong to the same Key Family into thisKeyValueTable
. - putDirect(KeyT, ValueT) - Method in interface io.pravega.client.tables.KeyValueTableMap
-
Same as
Map.put(K, V)
, but does not attempt to retrieve the existing value. - putIfAbsent(String, KeyT, ValueT) - Method in interface io.pravega.client.tables.KeyValueTable
-
Conditionally inserts a new Entry in the
KeyValueTable
if the given Key is not already present.
R
- 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 ifByteStreamReader.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. - readBufferSize(int) - Method in class io.pravega.client.state.SynchronizerConfig.SynchronizerConfigBuilder
-
This size is used to allocate buffer space for the bytes the reader in the StateSyncrhonizer reads from the segment.
- 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
- ReaderGroupConfig.StreamDataRetention - Enum in io.pravega.client.stream
-
If a Reader Group wants unconsumed data to be retained in a Stream, the retentionType in
ReaderGroupConfig
should be set to to 'MANUAL_RELEASE_AT_USER_STREAMCUT' or 'AUTOMATIC_RELEASE_AT_LAST_CHECKPOINT'. - readerGroupId(UUID) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
- ReaderGroupManager - Interface in io.pravega.client.admin
-
Used to create and manage reader groups.
- ReaderGroupMetrics - Interface in io.pravega.client.stream
- ReaderGroupNotificationListener - Interface in io.pravega.client.stream.notifications
-
ReaderGroup notification listener interface.
- ReaderNotInReaderGroupException - Exception in io.pravega.client.stream
-
Read was invoked on a reader that the reader group does not consider a member.
- ReaderNotInReaderGroupException(String) - Constructor for exception io.pravega.client.stream.ReaderNotInReaderGroupException
- readerOffline(String, Position) - Method in interface io.pravega.client.stream.ReaderGroup
-
Invoked when a reader that was added to the group is no longer consuming events.
- readerSegmentDistribution(Map<String, Integer>) - Method in class io.pravega.client.stream.ReaderSegmentDistribution.ReaderSegmentDistributionBuilder
- ReaderSegmentDistribution - Class in io.pravega.client.stream
-
Describes current distribution of number of segments assigned to each reader in the reader group.
- ReaderSegmentDistribution.ReaderSegmentDistributionBuilder - Class in io.pravega.client.stream
- readFrom(Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Read all data after a specified revision to the end of the stream.
- readNextEvent(long) - Method in interface io.pravega.client.stream.EventStreamReader
-
Gets the next event in the stream.
- readSegment(SegmentRange, Serializer<T>) - Method in interface io.pravega.client.BatchClientFactory
-
Provides a SegmentIterator to read the events in the requested segment starting from the beginning of the segment and ending at the current end of the segment.
- registerListener(Listener<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 class io.pravega.client.stream.notifications.notifier.AbstractNotifier
- 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(String) - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
- ReinitializationRequiredException(String, Throwable) - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
- ReinitializationRequiredException(Throwable) - Constructor for exception io.pravega.client.stream.ReinitializationRequiredException
- remove(String, KeyT) - Method in interface io.pravega.client.tables.KeyValueTable
-
Unconditionally removes a Key from this Table Segment.
- remove(String, KeyT, Version) - Method in interface io.pravega.client.tables.KeyValueTable
-
Conditionally Removes a Key from this Table Segment.
- removeAll(String, Iterable<TableKey<KeyT>>) - Method in interface io.pravega.client.tables.KeyValueTable
-
Removes one or more
TableKey
instances that belong to the same Key Family from this Table Segment. - removeDirect(KeyT) - Method in interface io.pravega.client.tables.KeyValueTableMap
-
Same as
Map.remove(java.lang.Object)
, but does not attempt to retrieve the existing value. - 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.
- replace(String, KeyT, ValueT, Version) - Method in interface io.pravega.client.tables.KeyValueTable
-
Conditionally updates an existing Entry in the
KeyValueTable
if the given Key exists and its version matches the givenVersion
. - replaceAll(String, Iterable<TableEntry<KeyT, ValueT>>) - Method in interface io.pravega.client.tables.KeyValueTable
-
Inserts new or updates existing
TableEntry
instances that belong to the same Key Family into thisKeyValueTable
. - resetReaderGroup(ReaderGroupConfig) - Method in interface io.pravega.client.stream.ReaderGroup
-
Reset a reader group with the provided
ReaderGroupConfig
. - retentionMax(long) - Method in class io.pravega.client.stream.RetentionPolicy.RetentionPolicyBuilder
- retentionParam(long) - Method in class io.pravega.client.stream.RetentionPolicy.RetentionPolicyBuilder
- retentionPolicy(RetentionPolicy) - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
-
API to return retention policy.
- RetentionPolicy - Class in io.pravega.client.stream
- RetentionPolicy.RetentionPolicyBuilder - Class in io.pravega.client.stream
- RetentionPolicy.RetentionType - Enum in io.pravega.client.stream
- retentionType(ReaderGroupConfig.StreamDataRetention) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Set the retention config for the
ReaderGroup
. - 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.tables.KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder
- Revision - Interface in io.pravega.client.state
-
A maker for a version of a
Revisioned
object. - Revisioned - Interface in io.pravega.client.state
-
An object that has a revision associated with it.
- RevisionedStreamClient<T> - Interface in io.pravega.client.state
-
Provides a stream that can be read and written to with strong consistency.
S
- scaleFactor(int) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
- scaleType(ScalingPolicy.ScaleType) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
- scalingPolicy(ScalingPolicy) - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
-
API to return scaling policy.
- ScalingPolicy - Class in io.pravega.client.stream
-
A policy that specifies how the number of segments in a stream should scale over time.
- ScalingPolicy.ScaleType - Enum in io.pravega.client.stream
- ScalingPolicy.ScalingPolicyBuilder - Class in io.pravega.client.stream
- sealStream(String, String) - Method in interface io.pravega.client.admin.StreamManager
-
Seal an existing stream.
- seekToOffset(long) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
Seeks to the provided offset (It can be anywhere in the segment).
- SegmentIterator<T> - Interface in io.pravega.client.batch
-
Please note this is an experimental API.
- SegmentNotification - Class in io.pravega.client.stream.notifications
-
Class to represent a segment notification.
- SegmentNotification.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
- SegmentRange - Interface in io.pravega.client.batch
-
This is used to represent range bounded portion of a Segment.
- Sequence - Class in io.pravega.client.stream
-
A wrapper for two numbers.
- serialize(Watermark) - Method in class io.pravega.client.watermark.WatermarkSerializer
- serialize(T) - Method in interface io.pravega.client.stream.Serializer
-
Serializes the given event.
- Serializer<T> - Interface in io.pravega.client.stream
-
Takes events being written and serializes them to byteBuffers so they can be sent over the wire and deserializes these same byte buffers back into objects.
- setEventWriterConfig(EventWriterConfig) - Method in class io.pravega.client.state.SynchronizerConfig
-
This writer config is used by the segment writers in the StateSyncrhonizer.
- setNumOfReaders(int) - Method in class io.pravega.client.stream.notifications.SegmentNotification
- setNumOfSegments(int) - Method in class io.pravega.client.stream.notifications.SegmentNotification
- setReadBufferSize(int) - Method in class io.pravega.client.state.SynchronizerConfig
-
This size is used to allocate buffer space for the bytes the reader in the StateSyncrhonizer reads from the segment.
- signalTokenExpired() - Method in interface io.pravega.client.security.auth.DelegationTokenProvider
-
Signals the object that the token it may be holding has expired.
- signalTokenExpired() - Method in class io.pravega.client.security.auth.EmptyTokenProviderImpl
- signalTokenExpired() - Method in class io.pravega.client.security.auth.JwtTokenProviderImpl
- signalTokenExpired() - Method in class io.pravega.client.security.auth.StringTokenProviderImpl
- SIZE - io.pravega.client.stream.RetentionPolicy.RetentionType
-
Set retention based on the total size of the data in the stream in bytes.
- skip(long) - Method in class io.pravega.client.byteStream.ByteStreamReader
-
This method attempts to skip forward by the provided number of bytes.
- startFromCheckpoint(Checkpoint) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Ensure the readers of the ReaderGroup start from the provided
Checkpoint
. - startFromStreamCuts(Map<Stream, StreamCut>) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
-
Ensure the readers of the ReaderGroup start from this provided streamCuts.
- startingStreamCuts(Map<Stream, StreamCut>) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
- StateSynchronizer<StateT extends Revisioned> - Interface in io.pravega.client.state
-
Provides a means to have state that is synchronized between many processes.
- StateSynchronizer.UpdateGenerator<StateT extends Revisioned> - Interface in io.pravega.client.state
-
A function which given a state object populates a list of updates that should be applied.
- StateSynchronizer.UpdateGeneratorFunction<StateT extends Revisioned,ReturnT> - Interface in io.pravega.client.state
-
Similar to
StateSynchronizer.UpdateGenerator
but it also returns a result for the caller. - stream(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(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, StreamCut, StreamCut) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
- 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(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, StreamCut, StreamCut) - Method in class io.pravega.client.stream.ReaderGroupConfig.ReaderGroupConfigBuilder
- 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.
- StreamInfo - Class in io.pravega.client.admin
-
This class is used to represent Stream information.
- StreamInfo(String, String, StreamCut, StreamCut, boolean) - Constructor for class io.pravega.client.admin.StreamInfo
- StreamManager - Interface in io.pravega.client.admin
-
Used to create, delete, and manage Streams and ReaderGroups.
- StreamSegmentsIterator - Interface in io.pravega.client.batch
- StringTokenProviderImpl - Class in io.pravega.client.security.auth
-
A provider for handling non-JWT, non-empty delegation tokens.
- SynchronizerClientFactory - Interface in io.pravega.client
-
Used to create StateSynchronizer and RevisionedStreamClient objects which allow for reading and writing data from a pre-configured stream with strong consistency guarantees.
- SynchronizerConfig - Class in io.pravega.client.state
-
The configuration for a Consistent replicated state synchronizer.
- SynchronizerConfig.SynchronizerConfigBuilder - Class in io.pravega.client.state
T
- TableEntry<KeyT,ValueT> - Class in io.pravega.client.tables
-
A
KeyValueTable
Entry. - TableKey<KeyT> - Class in io.pravega.client.tables
-
A
KeyValueTable
Key with aVersion
. - targetRate(int) - Method in class io.pravega.client.stream.ScalingPolicy.ScalingPolicyBuilder
- TIME - io.pravega.client.stream.RetentionPolicy.RetentionType
-
Set retention based on how long data has been in the stream in milliseconds.
- timestampAggregationTimeout(long) - Method in class io.pravega.client.stream.StreamConfiguration.StreamConfigurationBuilder
-
The duration after the last call to
EventStreamWriter.noteTime(long)
which the timestamp should be considered valid before it is forgotten. - 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
- toBuilder() - Method in class io.pravega.client.stream.ReaderGroupConfig
- toBytes() - Method in interface io.pravega.client.stream.Checkpoint
-
Serializes the checkpoint to a compact byte array.
- toBytes() - Method in interface io.pravega.client.stream.EventPointer
-
Serializes the Event pointer to a compact binary form.
- toBytes() - Method in interface io.pravega.client.stream.Position
-
Serializes the position to a compact byte array.
- toBytes() - Method in class io.pravega.client.stream.ReaderGroupConfig
- toBytes() - Method in interface io.pravega.client.stream.StreamCut
-
Serializes the cut to a compact byte array.
- toBytes() - Method in interface io.pravega.client.tables.IteratorState
-
Serializes this
IteratorState
to aByteBuffer
. - toString() - Method in class io.pravega.client.admin.KeyValueTableInfo
- toString() - Method in class io.pravega.client.admin.StreamInfo
- toString() - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
- toString() - Method in class io.pravega.client.ClientConfig
- 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.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.IteratorItem
- toString() - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration.KeyValueTableClientConfigurationBuilder
- toString() - Method in class io.pravega.client.tables.KeyValueTableClientConfiguration
- toString() - Method in class io.pravega.client.tables.KeyValueTableConfiguration.KeyValueTableConfigurationBuilder
- toString() - Method in class io.pravega.client.tables.KeyValueTableConfiguration
- toString() - Method in class io.pravega.client.tables.TableEntry
- toString() - Method in class io.pravega.client.tables.TableKey
- toString() - Method in interface io.pravega.client.tables.Version
-
Serializes the
Version
to a human readable string. - Transaction<Type> - Interface in io.pravega.client.stream
-
Provides a mechanism for writing many events atomically.
- Transaction.PingStatus - Enum in io.pravega.client.stream
- Transaction.Status - Enum in io.pravega.client.stream
- TransactionalEventStreamWriter<Type> - Interface in io.pravega.client.stream
-
A writer that writes Events to an Event stream transactionally.
- transactionTimeoutTime(long) - Method in class io.pravega.client.stream.EventWriterConfig.EventWriterConfigBuilder
- truncateDataBefore(long) - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
This makes a synchronous RPC call to the server to truncate the segment at the provided offset.
- TruncatedDataException - Exception in io.pravega.client.stream
- TruncatedDataException() - 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.
- TruncatedDataException(String, Throwable) - 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.
- truncateStream(String, String, StreamCut) - Method in interface io.pravega.client.admin.StreamManager
-
Truncate stream at given stream cut.
- truncateToRevision(Revision) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Removes all data through the revision provided.
- trustStore(String) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
-
Path to an optional truststore.
- 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(String) - 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(Throwable) - Constructor for exception io.pravega.client.stream.TxnFailedException
-
Creates a new instance of TxnFailedException class.
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 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.
- unversioned(KeyT) - Static method in class io.pravega.client.tables.TableKey
-
Creates a new
TableKey
with no specific version. - unversioned(KeyT, ValueT) - Static method in class io.pravega.client.tables.TableEntry
-
Creates a new
TableEntry
with no specific version. - Update<StateT extends Revisioned> - Interface in io.pravega.client.state
-
An update to a StateT object coordinated via a
StateSynchronizer
. - updateRetentionStreamCut(Map<Stream, StreamCut>) - Method in interface io.pravega.client.stream.ReaderGroup
-
Update Retention Stream-Cut for Streams in this Reader Group.
- 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 theStateSynchronizer.UpdateGeneratorFunction
. - updateStateUnconditionally(Update<StateT>) - Method in interface io.pravega.client.state.StateSynchronizer
-
Persists the provided update.
- updateStateUnconditionally(List<? extends Update<StateT>>) - Method in interface io.pravega.client.state.StateSynchronizer
-
Same as
StateSynchronizer.updateStateUnconditionally(Update)
, except it persists multiple updates at the same time so they will not be interleaved with other updates. - updateStream(String, String, StreamConfiguration) - Method in interface io.pravega.client.admin.StreamManager
-
Change the configuration for an existing stream.
V
- validateHostName(boolean) - Method in class io.pravega.client.ClientConfig.ClientConfigBuilder
-
If the flag
ClientConfig.isEnableTls()
is set, this flag decides whether to enable host name validation or not. - valueOf(String) - Static method in enum io.pravega.client.stream.ReaderGroupConfig.StreamDataRetention
-
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.stream.ReaderGroupConfig.StreamDataRetention
-
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.
- Version - Interface in io.pravega.client.tables
-
Version of a Key in a Table.
- versioned(KeyT, Version) - Static method in class io.pravega.client.tables.TableKey
-
Creates a new
TableKey
with a specific version. - versioned(KeyT, Version, ValueT) - Static method in class io.pravega.client.tables.TableEntry
-
Creates a new
TableEntry
with a specific key version..
W
- WatermarkSerializer - Class in io.pravega.client.watermark
- WatermarkSerializer() - Constructor for class io.pravega.client.watermark.WatermarkSerializer
- 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.KeyValueTableFactory
-
Creates a new instance of
KeyValueTableFactory
. - withScope(String, ClientConfig) - Static method in interface io.pravega.client.SynchronizerClientFactory
-
Creates a new instance of Client Factory.
- withScope(String, URI) - Static method in interface io.pravega.client.admin.ReaderGroupManager
-
Creates a new instance of ReaderGroupManager.
- write(byte[], int, int) - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
Writes the provided data to the segment.
- write(ByteBuffer) - Method in class io.pravega.client.byteStream.ByteStreamWriter
-
Similar to
ByteStreamWriter.write(byte[], int, int)
Writes the provided data to the segment. - 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(String, Sequence, Type) - Method in interface io.pravega.client.stream.IdempotentEventStreamWriter
-
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, 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 untilTransaction.commit()
is called. - writeEvent(Type) - Method in interface io.pravega.client.stream.EventStreamWriter
-
Send an event to the stream.
- writeEvent(Type) - Method in interface io.pravega.client.stream.Transaction
-
Sends an event to the stream just like
EventStreamWriter.writeEvent(Type)
but with the caveat that the message will not be visible to anyone untilTransaction.commit()
is called. - writeEvents(String, List<Type>) - Method in interface io.pravega.client.stream.EventStreamWriter
-
Write an ordered list of events to the stream atomically for a given routing key.
- writeUnconditionally(T) - Method in interface io.pravega.client.state.RevisionedStreamClient
-
Write a new value to the stream.
All Classes All Packages