A B C D E F G H I J K L M N O P R S T U V W

A

AbstractColumnList<C> - Class in com.netflix.astyanax.model
 
AbstractColumnList() - Constructor for class com.netflix.astyanax.model.AbstractColumnList
 
AbstractComposite - Class in com.netflix.astyanax.model
Parent class of Composite and DynamicComposite.
AbstractComposite(boolean) - Constructor for class com.netflix.astyanax.model.AbstractComposite
 
AbstractComposite(boolean, Object...) - Constructor for class com.netflix.astyanax.model.AbstractComposite
 
AbstractComposite(boolean, List<?>) - Constructor for class com.netflix.astyanax.model.AbstractComposite
 
AbstractComposite.Component<T> - Class in com.netflix.astyanax.model
 
AbstractComposite.Component(T, ByteBuffer, Serializer<T>, String, AbstractComposite.ComponentEquality) - Constructor for class com.netflix.astyanax.model.AbstractComposite.Component
 
AbstractComposite.ComponentEquality - Enum in com.netflix.astyanax.model
 
AbstractExecuteWithFailoverImpl<CL,R> - Class in com.netflix.astyanax.connectionpool.impl
 
AbstractExecuteWithFailoverImpl(ConnectionPoolConfiguration, ConnectionPoolMonitor) - Constructor for class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
AbstractExecutionImpl<R> - Class in com.netflix.astyanax.connectionpool.impl
 
AbstractExecutionImpl() - Constructor for class com.netflix.astyanax.connectionpool.impl.AbstractExecutionImpl
 
AbstractHostPartitionConnectionPool<CL> - Class in com.netflix.astyanax.connectionpool.impl
Base for all connection pools that keep a separate pool of connections for each host.
AbstractHostPartitionConnectionPool(ConnectionPoolConfiguration, ConnectionFactory<CL>, ConnectionPoolMonitor) - Constructor for class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
AbstractIndexQueryImpl<K,C> - Class in com.netflix.astyanax.thrift
 
AbstractIndexQueryImpl(ColumnFamily<K, C>) - Constructor for class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
AbstractKeyspaceOperationImpl<R> - Class in com.netflix.astyanax.thrift
 
AbstractKeyspaceOperationImpl(CassandraOperationTracer, Host, String) - Constructor for class com.netflix.astyanax.thrift.AbstractKeyspaceOperationImpl
 
AbstractKeyspaceOperationImpl(CassandraOperationTracer, String) - Constructor for class com.netflix.astyanax.thrift.AbstractKeyspaceOperationImpl
 
AbstractOperationImpl<R> - Class in com.netflix.astyanax.thrift
 
AbstractOperationImpl(CassandraOperationTracer, Host) - Constructor for class com.netflix.astyanax.thrift.AbstractOperationImpl
 
AbstractOperationImpl(CassandraOperationTracer) - Constructor for class com.netflix.astyanax.thrift.AbstractOperationImpl
 
AbstractRowQueryImpl<K,C> - Class in com.netflix.astyanax.thrift
 
AbstractRowQueryImpl(Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
AbstractRowSliceQueryImpl<K,C> - Class in com.netflix.astyanax.thrift
 
AbstractRowSliceQueryImpl(Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
AbstractSerializer<T> - Class in com.netflix.astyanax.serializers
A base class for serializer implementations.
AbstractSerializer() - Constructor for class com.netflix.astyanax.serializers.AbstractSerializer
 
AbstractThriftAllRowsQueryImpl<K,C> - Class in com.netflix.astyanax.thrift
 
AbstractThriftAllRowsQueryImpl(ColumnFamily<K, C>) - Constructor for class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
AbstractThriftColumnMutationImpl - Class in com.netflix.astyanax.thrift
 
AbstractThriftColumnMutationImpl(ByteBuffer, ByteBuffer, Clock) - Constructor for class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
AbstractThriftMutationBatchImpl - Class in com.netflix.astyanax.thrift
Basic implementation of a mutation batch using the thrift data structures.
AbstractThriftMutationBatchImpl(Clock) - Constructor for class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
AckingQueue - Interface in com.netflix.astyanax.impl
Abstraction for a durable queue requiring an ack to do the final remove
ackMutation(MutationBatch) - Method in interface com.netflix.astyanax.impl.AckingQueue
Ack a mutation so that it may be removed from the queue
ackMutation(MutationBatch) - Method in class com.netflix.astyanax.util.BlockingAckingQueue
 
acquire() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Write a lock column using the current time
acquire() - Method in interface com.netflix.astyanax.recipes.locks.DistributedRowLock
 
acquire() - Method in class com.netflix.astyanax.recipes.uniqueness.ColumnPrefixUniquenessConstraint
 
acquire() - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
 
acquire() - Method in class com.netflix.astyanax.recipes.uniqueness.RowUniquenessConstraint
 
acquire() - Method in interface com.netflix.astyanax.recipes.uniqueness.UniquenessConstraint
Acquire the row(s) for uniqueness.
add(int, Object) - Method in class com.netflix.astyanax.model.AbstractComposite
 
add(T, Serializer<T>) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
add(T, Serializer<T>) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addAll(Collection<? extends Object>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addAll(int, Collection<? extends Object>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addAlternateIpAddress(String) - Method in class com.netflix.astyanax.connectionpool.Host
 
addBoolean(Boolean) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addBoolean(Boolean) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addBytes(byte[]) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addBytes(ByteBuffer) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addBytes(byte[]) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addBytes(ByteBuffer) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addColumnDefinition(ColumnDefinition) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
addColumnDefinition(ColumnDefinition) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
addColumnFamily(ColumnFamilyDefinition) - Method in interface com.netflix.astyanax.Cluster
Add a column family to an existing keyspace
addColumnFamily(ColumnFamilyDefinition) - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
addColumnFamily(ColumnFamilyDefinition) - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
addColumnFamily(ColumnFamilyDefinition) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
addComponent(T, Serializer<T>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addComponent(T, Serializer<T>, AbstractComposite.ComponentEquality) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addComponent(T, Serializer<T>, String) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addComponent(T, Serializer<T>, String, AbstractComposite.ComponentEquality) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addComponent(int, T, Serializer<T>, String, AbstractComposite.ComponentEquality) - Method in class com.netflix.astyanax.model.AbstractComposite
 
addExpression() - Method in interface com.netflix.astyanax.query.IndexQuery
Add an expression (EQ, GT, GTE, LT, LTE) to the clause.
addExpression() - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
addExtra(String, String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
addHost(Host, boolean) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Add a host to the connection pool.
addHost(Host, boolean) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
addHost(String) - Method in class com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitor
 
addHost(String) - Method in interface com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitorMBean
 
addInteger(Integer) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addInteger(Integer) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addKeyspace(KeyspaceDefinition) - Method in interface com.netflix.astyanax.Cluster
Add a new keyspace to the cluster.
addKeyspace(KeyspaceDefinition) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
addLatencySample(long, long) - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Add a single latency sample after an operation on a connection belonging to this pool
addLatencySample(long, long) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
addLong(Long) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addLong(Long) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addPool(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
addPool(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
addPool(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Add a pool without knowing it's token.
addPreparedExpressions(Collection<PreparedIndexExpression<K, C>>) - Method in interface com.netflix.astyanax.query.IndexQuery
Add a set of prepare index expressions.
addPreparedExpressions(Collection<PreparedIndexExpression<K, C>>) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
addSample(long) - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyInstanceImpl
 
addSample(long) - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Instance
Add a single latency sample
addStrategyOption(String, String) - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
addStrategyOption(String, String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
addString(String) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addString(String) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addTimeoutSample() - Method in interface com.netflix.astyanax.connectionpool.BadHostDetector.Instance
Add a timeout sample and return false if the host should be quarantined
addTimeUUID(UUID) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addTimeUUID(Long, TimeUnit) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addTimeUUID(UUID) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addTimeUUID(Long, TimeUnit) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
addUUID(UUID) - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
addUUID(UUID) - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
allowRetry() - Method in class com.netflix.astyanax.retry.RetryNTimes
 
allowRetry() - Method in interface com.netflix.astyanax.retry.RetryPolicy
Ask the policy if a retry is allowed.
allowRetry() - Method in class com.netflix.astyanax.retry.RunOnce
 
allowRetry() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
AllRowsQuery<K,C> - Interface in com.netflix.astyanax.query
Specialized query to iterate the contents of a column family.
AnnotatedCompositeSerializer<T> - Class in com.netflix.astyanax.serializers
Serializer for a Pojo annotated with Component field annotations Serialized data is formatted as a list of components with each component having the format: <2 byte length><0>
AnnotatedCompositeSerializer(Class<T>) - Constructor for class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer
 
AnnotatedCompositeSerializer.ComponentSerializer<P> - Class in com.netflix.astyanax.serializers
Serializer for a single component within the Pojo
AnnotatedCompositeSerializer.ComponentSerializer(Field, Serializer<P>, int) - Constructor for class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer.ComponentSerializer
 
AnnotationSet<ID extends Annotation,COLUMN extends Annotation> - Interface in com.netflix.astyanax.mapping
Allows for any annotations to be used to mark columns in a bean
append(C2, Serializer<C2>) - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated. Add a depth to the path
append(String) - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated.  
append(int) - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated.  
append(double) - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated.  
append(Object, Equality) - Method in interface com.netflix.astyanax.model.RangeEndpoint
 
append(List<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
Append a list of ByteBuffers to this stream.
append(ByteBufferOutputStream, Object, Equality) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
asByteArray(UUID) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
As byte array.
asByteBuffer(UUID) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Coverts a java.util.UUID into a ByteBuffer.
AsciiSerializer - Class in com.netflix.astyanax.serializers
Almost identical to StringSerializer except we use the US-ASCII character set code
AsciiSerializer() - Constructor for class com.netflix.astyanax.serializers.AsciiSerializer
 
asConfig - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
AstyanaxConfiguration - Interface in com.netflix.astyanax
Interface defining all astyanax API configuration parameters.
AstyanaxConfigurationImpl - Class in com.netflix.astyanax.impl
 
AstyanaxConfigurationImpl() - Constructor for class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
AstyanaxContext<Entity> - Class in com.netflix.astyanax
This object tracks the context of an astyanax instance of either a Cluster or Keyspace
AstyanaxContext.Builder - Class in com.netflix.astyanax
 
AstyanaxContext.Builder() - Constructor for class com.netflix.astyanax.AstyanaxContext.Builder
 
AstyanaxTypeFactory<T> - Interface in com.netflix.astyanax
Factory that groups a family of Keyspace, Client and ConnectionFactory for a specific RPC to cassandra (i.e.
AuthenticationCredentials - Interface in com.netflix.astyanax
Representation for a user/password used to log into a keyspace.
AuthenticationException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
AuthenticationException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.AuthenticationException
 
AuthenticationException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.AuthenticationException
 
AutoAllocatingLinkedBlockingQueue<T> - Class in com.netflix.astyanax.recipes.storage
 
AutoAllocatingLinkedBlockingQueue(int) - Constructor for class com.netflix.astyanax.recipes.storage.AutoAllocatingLinkedBlockingQueue
 
autoPaginate(boolean) - Method in interface com.netflix.astyanax.query.RowQuery
When used in conjunction with a column range this will call subsequent calls to execute() to get the next block of columns.
autoPaginate(boolean) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
autoPaginateRows(boolean) - Method in interface com.netflix.astyanax.query.IndexQuery
Automatically sets the next start key so that the next call to execute will fetch the next block of rows
autoPaginateRows(boolean) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 

B

BadConfigurationException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
BadConfigurationException(String, String, String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
BadConfigurationException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
BadConfigurationException(String, String, String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
BadConfigurationException(String, String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
BadHostDetector - Interface in com.netflix.astyanax.connectionpool
Interface for algorithm to detect when a host is considered down.
BadHostDetector.Instance - Interface in com.netflix.astyanax.connectionpool
 
BadHostDetectorImpl - Class in com.netflix.astyanax.connectionpool.impl
BadHostDetector which marks the host as failed if there is a transport exception or if it timed out too many times within a certain time window
BadHostDetectorImpl(ConnectionPoolConfiguration) - Constructor for class com.netflix.astyanax.connectionpool.impl.BadHostDetectorImpl
 
BadRequestException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
BadRequestException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadRequestException
 
BadRequestException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadRequestException
 
BadRequestException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.BadRequestException
 
BagOfConnectionsConnectionPoolImpl<CL> - Class in com.netflix.astyanax.connectionpool.impl
Connection pool which puts all connections in a single queue.
BagOfConnectionsConnectionPoolImpl(ConnectionPoolConfiguration, ConnectionFactory<CL>, ConnectionPoolMonitor) - Constructor for class com.netflix.astyanax.connectionpool.impl.BagOfConnectionsConnectionPoolImpl
 
begin() - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy.Instance
Start the reconnect process
begin() - Method in class com.netflix.astyanax.retry.RetryNTimes
 
begin() - Method in interface com.netflix.astyanax.retry.RetryPolicy
Operation is starting
begin() - Method in class com.netflix.astyanax.retry.RunOnce
 
begin() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
BigIntegerSerializer - Class in com.netflix.astyanax.serializers
Serializer implementation for BigInteger
BigIntegerSerializer() - Constructor for class com.netflix.astyanax.serializers.BigIntegerSerializer
 
BlockingAckingQueue - Class in com.netflix.astyanax.util
 
BlockingAckingQueue() - Constructor for class com.netflix.astyanax.util.BlockingAckingQueue
 
BlockingConcurrentWindowCounter - Class in com.netflix.astyanax.util
 
BlockingConcurrentWindowCounter(int) - Constructor for class com.netflix.astyanax.util.BlockingConcurrentWindowCounter
 
BlockingConcurrentWindowCounter(int, int) - Constructor for class com.netflix.astyanax.util.BlockingConcurrentWindowCounter
 
BooleanSerializer - Class in com.netflix.astyanax.serializers
Converts bytes to Boolean and vice versa
BooleanSerializer() - Constructor for class com.netflix.astyanax.serializers.BooleanSerializer
 
borrowConnection(int) - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Borrow a connection from the host.
borrowConnection(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
borrowConnection(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
borrowConnection(int) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
Create a connection as long the max hasn't been reached
BoundedExponentialBackoff - Class in com.netflix.astyanax.retry
 
BoundedExponentialBackoff(int, int, int) - Constructor for class com.netflix.astyanax.retry.BoundedExponentialBackoff
 
BUFFER_SIZE - Static variable in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
build() - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
build() - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
build() - Method in interface com.netflix.astyanax.recipes.Shards.Builder
 
build() - Method in class com.netflix.astyanax.recipes.Shards.StringShardBuilder
 
build() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
build() - Method in class com.netflix.astyanax.util.RangeBuilder
 
buildCluster(AstyanaxTypeFactory<T>) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
buildKeyspace(AstyanaxTypeFactory<T>) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
buildRange() - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer
 
BusyLockException - Exception in com.netflix.astyanax.recipes.locks
 
BusyLockException(Exception) - Constructor for exception com.netflix.astyanax.recipes.locks.BusyLockException
 
BusyLockException(String, Exception) - Constructor for exception com.netflix.astyanax.recipes.locks.BusyLockException
 
BusyLockException(String) - Constructor for exception com.netflix.astyanax.recipes.locks.BusyLockException
 
ByteBufferOutputStream - Class in com.netflix.astyanax.serializers
Utility to collect data written to an OutputStream in ByteBuffers.
ByteBufferOutputStream() - Constructor for class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
ByteBufferRange - Interface in com.netflix.astyanax.model
Interface to get a raw byte buffer range.
ByteBufferRangeImpl - Class in com.netflix.astyanax.util
 
ByteBufferRangeImpl(ByteBuffer, ByteBuffer, int, boolean) - Constructor for class com.netflix.astyanax.util.ByteBufferRangeImpl
 
ByteBufferSerializer - Class in com.netflix.astyanax.serializers
The BytesExtractor is a simple identity function.
ByteBufferSerializer() - Constructor for class com.netflix.astyanax.serializers.ByteBufferSerializer
 
BytesArraySerializer - Class in com.netflix.astyanax.serializers
A BytesArraySerializer translates the byte[] to and from ByteBuffer.
BytesArraySerializer() - Constructor for class com.netflix.astyanax.serializers.BytesArraySerializer
 

C

call() - Method in class com.netflix.astyanax.recipes.storage.ObjectDeleter
 
call() - Method in class com.netflix.astyanax.recipes.storage.ObjectInfoReader
 
call() - Method in class com.netflix.astyanax.recipes.storage.ObjectReader
 
call() - Method in class com.netflix.astyanax.recipes.storage.ObjectWriter
 
Callback<T> - Interface in com.netflix.astyanax.recipes
 
canRetry() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
canRetry() - Method in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
CassandraChunkedStorageProvider - Class in com.netflix.astyanax.recipes.storage
ChunkProvider responsible for reading and writing chunks to cassandra.
CassandraChunkedStorageProvider(Keyspace, String) - Constructor for class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
CassandraChunkedStorageProvider(Keyspace, ColumnFamily<String, String>) - Constructor for class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
CassandraChunkedStorageProvider.Columns - Enum in com.netflix.astyanax.recipes.storage
 
CassandraOperationTracer - Interface in com.netflix.astyanax
Notification interface of success or failures executing keyspace operations.
CassandraOperationType - Enum in com.netflix.astyanax
 
CharSerializer - Class in com.netflix.astyanax.serializers
Uses Char Serializer
CharSerializer() - Constructor for class com.netflix.astyanax.serializers.CharSerializer
 
check() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleRateLimiterImpl
 
check(long) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleRateLimiterImpl
 
check() - Method in interface com.netflix.astyanax.connectionpool.RateLimiter
 
check(long) - Method in interface com.netflix.astyanax.connectionpool.RateLimiter
 
ChunkedStorage - Class in com.netflix.astyanax.recipes.storage
 
ChunkedStorage() - Constructor for class com.netflix.astyanax.recipes.storage.ChunkedStorage
 
ChunkedStorageProvider - Interface in com.netflix.astyanax.recipes.storage
 
clear() - Method in class com.netflix.astyanax.model.AbstractComposite
 
Clock - Interface in com.netflix.astyanax
Interface for a clock used for setting the column timestamp
clock - Variable in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
ClockType - Enum in com.netflix.astyanax.clock
 
clone(ByteBuffer) - Static method in class com.netflix.astyanax.util.RangeBuilder
 
close() - Method in interface com.netflix.astyanax.connectionpool.Connection
Shut down the connection.
closeConnection(Connection<CL>) - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Close this connection and update internal state
closeConnection(Connection<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
Cluster - Interface in com.netflix.astyanax
Interface for cluster operations.
clusterName - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
Column - Annotation Type in com.netflix.astyanax.mapping
 
Column<C> - Interface in com.netflix.astyanax.model
Common interface for extracting column values after a query.
column - Variable in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
ColumnarRecordWriter - Class in com.netflix.astyanax.util
Writer rows where the first pair is the key and subsequent pairs are columns.
ColumnarRecordWriter(Keyspace, String) - Constructor for class com.netflix.astyanax.util.ColumnarRecordWriter
 
ColumnarRecordWriter(Keyspace, String, SerializerPackage) - Constructor for class com.netflix.astyanax.util.ColumnarRecordWriter
 
columnAsByteBuffer(String) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a string column name to a ByteBuffer using the package's column serializer
columnAsByteBuffer(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
columnAsString(ByteBuffer) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a column name to a string using the package's column serializer
columnAsString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
ColumnCountQuery - Interface in com.netflix.astyanax.query
 
ColumnDefinition - Interface in com.netflix.astyanax.ddl
Interface to get/set a single column definition.
ColumnFamily<K,C> - Class in com.netflix.astyanax.model
Basic column family definition.
ColumnFamily(String, Serializer<K>, Serializer<C>, ColumnType) - Constructor for class com.netflix.astyanax.model.ColumnFamily
Deprecated. Super columns should be replaced with composite columns
ColumnFamily(String, Serializer<K>, Serializer<C>) - Constructor for class com.netflix.astyanax.model.ColumnFamily
 
columnFamily - Variable in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
ColumnFamilyDefinition - Interface in com.netflix.astyanax.ddl
 
ColumnFamilyQuery<K,C> - Interface in com.netflix.astyanax.query
Top level column family query lets you choose the type of query being performed at the key level.
ColumnList<C> - Interface in com.netflix.astyanax.model
Interface to a list of columns.
ColumnListMutation<C> - Interface in com.netflix.astyanax
Abstraction for batching column operations on a single row.
ColumnMutation - Interface in com.netflix.astyanax
 
ColumnPath<C> - Class in com.netflix.astyanax.model
Deprecated. Super columns should be replaced with composite columns
ColumnPath(Serializer<C>) - Constructor for class com.netflix.astyanax.model.ColumnPath
Deprecated. Construct an empty path and give it the serializer for column names at the end of the path.
ColumnPath() - Constructor for class com.netflix.astyanax.model.ColumnPath
Deprecated. Construct a column path for a mutation.
ColumnPrefixDistributedRowLock<K> - Class in com.netflix.astyanax.recipes.locks
Takes a distributed row lock for a single row.
ColumnPrefixDistributedRowLock(Keyspace, ColumnFamily<K, String>, K) - Constructor for class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
ColumnPrefixUniquenessConstraint<K> - Class in com.netflix.astyanax.recipes.uniqueness
 
ColumnPrefixUniquenessConstraint(Keyspace, ColumnFamily<K, String>, K) - Constructor for class com.netflix.astyanax.recipes.uniqueness.ColumnPrefixUniquenessConstraint
 
ColumnQuery<C> - Interface in com.netflix.astyanax.query
Interface to execute a column query on a single row.
ColumnSlice<C> - Class in com.netflix.astyanax.model
Definition for a sub set of slices.
ColumnSlice(Collection<C>) - Constructor for class com.netflix.astyanax.model.ColumnSlice
 
ColumnSlice(C, C) - Constructor for class com.netflix.astyanax.model.ColumnSlice
 
ColumnType - Enum in com.netflix.astyanax.model
Deprecated. Super columns should be replaced with composite columns
com.netflix.astyanax - package com.netflix.astyanax
 
com.netflix.astyanax.annotations - package com.netflix.astyanax.annotations
 
com.netflix.astyanax.clock - package com.netflix.astyanax.clock
 
com.netflix.astyanax.connectionpool - package com.netflix.astyanax.connectionpool
 
com.netflix.astyanax.connectionpool.exceptions - package com.netflix.astyanax.connectionpool.exceptions
 
com.netflix.astyanax.connectionpool.impl - package com.netflix.astyanax.connectionpool.impl
 
com.netflix.astyanax.ddl - package com.netflix.astyanax.ddl
 
com.netflix.astyanax.impl - package com.netflix.astyanax.impl
 
com.netflix.astyanax.mapping - package com.netflix.astyanax.mapping
 
com.netflix.astyanax.model - package com.netflix.astyanax.model
 
com.netflix.astyanax.query - package com.netflix.astyanax.query
 
com.netflix.astyanax.recipes - package com.netflix.astyanax.recipes
 
com.netflix.astyanax.recipes.locks - package com.netflix.astyanax.recipes.locks
 
com.netflix.astyanax.recipes.storage - package com.netflix.astyanax.recipes.storage
 
com.netflix.astyanax.recipes.uniqueness - package com.netflix.astyanax.recipes.uniqueness
 
com.netflix.astyanax.retry - package com.netflix.astyanax.retry
 
com.netflix.astyanax.serializers - package com.netflix.astyanax.serializers
 
com.netflix.astyanax.shallows - package com.netflix.astyanax.shallows
 
com.netflix.astyanax.thrift - package com.netflix.astyanax.thrift
 
com.netflix.astyanax.thrift.ddl - package com.netflix.astyanax.thrift.ddl
 
com.netflix.astyanax.thrift.model - package com.netflix.astyanax.thrift.model
 
com.netflix.astyanax.util - package com.netflix.astyanax.util
 
ComparatorType - Enum in com.netflix.astyanax.serializers
 
compareTo(AbstractComposite) - Method in class com.netflix.astyanax.model.AbstractComposite
 
compareTo(AnnotatedCompositeSerializer.ComponentSerializer<?>) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer.ComponentSerializer
 
Component - Annotation Type in com.netflix.astyanax.annotations
Annotation for components of a composite type.
componentsIterator() - Method in class com.netflix.astyanax.model.AbstractComposite
 
Composite - Class in com.netflix.astyanax.model
 
Composite() - Constructor for class com.netflix.astyanax.model.Composite
 
Composite(Object...) - Constructor for class com.netflix.astyanax.model.Composite
 
Composite(List<?>) - Constructor for class com.netflix.astyanax.model.Composite
 
CompositeBuilder - Interface in com.netflix.astyanax.model
 
CompositeBuilderImpl - Class in com.netflix.astyanax.model
 
CompositeBuilderImpl(AbstractComposite) - Constructor for class com.netflix.astyanax.model.CompositeBuilderImpl
 
CompositeParser - Interface in com.netflix.astyanax.model
 
CompositeParserImpl - Class in com.netflix.astyanax.model
 
CompositeParserImpl(ByteBuffer) - Constructor for class com.netflix.astyanax.model.CompositeParserImpl
 
CompositeRangeBuilder - Class in com.netflix.astyanax.serializers
 
CompositeRangeBuilder() - Constructor for class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
Composites - Class in com.netflix.astyanax.model
 
Composites() - Constructor for class com.netflix.astyanax.model.Composites
 
CompositeSerializer - Class in com.netflix.astyanax.serializers
 
CompositeSerializer() - Constructor for class com.netflix.astyanax.serializers.CompositeSerializer
 
computeInitialHashSize(int) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
config - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
config - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
config - Variable in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
Connection<CL> - Interface in com.netflix.astyanax.connectionpool
Interface to an instance of a connection on a host.
connection - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
Connection.AsyncOpenCallback<CL> - Interface in com.netflix.astyanax.connectionpool
 
ConnectionAbortedException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
ConnectionAbortedException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ConnectionAbortedException
 
ConnectionAbortedException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ConnectionAbortedException
 
ConnectionAbortedException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ConnectionAbortedException
 
ConnectionException - Exception in com.netflix.astyanax.connectionpool.exceptions
Connection exception caused by an error in the connection pool or a transport error related to the connection itself.
ConnectionException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
ConnectionException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
ConnectionException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
ConnectionFactory<CL> - Interface in com.netflix.astyanax.connectionpool
Factory used to create and open new connections on a host.
ConnectionPool<CL> - Interface in com.netflix.astyanax.connectionpool
Base interface for a pool of connections.
ConnectionPoolConfiguration - Interface in com.netflix.astyanax.connectionpool
 
ConnectionPoolConfigurationImpl - Class in com.netflix.astyanax.connectionpool.impl
 
ConnectionPoolConfigurationImpl(String) - Constructor for class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
ConnectionPoolMBeanManager - Class in com.netflix.astyanax.connectionpool.impl
 
ConnectionPoolMonitor - Interface in com.netflix.astyanax.connectionpool
Monitoring interface to receive notification of pool events.
ConnectionPoolType - Enum in com.netflix.astyanax.connectionpool.impl
 
ConsistencyLevel - Enum in com.netflix.astyanax.model
Consistency Level thin abstraction
ConstantBackoff - Class in com.netflix.astyanax.retry
 
ConstantBackoff(int, int) - Constructor for class com.netflix.astyanax.retry.ConstantBackoff
 
ConstantClock - Class in com.netflix.astyanax.clock
 
ConstantClock(long) - Constructor for class com.netflix.astyanax.clock.ConstantClock
 
containsAll(Collection<?>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
copyTo(ColumnFamily<K, C>, K) - Method in interface com.netflix.astyanax.query.RowQuery
Copy the results of the query to another column family
CountingConnectionPoolMonitor - Class in com.netflix.astyanax.connectionpool.impl
 
CountingConnectionPoolMonitor() - Constructor for class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
cp - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
cpConfig - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
CqlQuery<K,C> - Interface in com.netflix.astyanax.query
Interface for executing a CQL query.
CqlResult<K,C> - Interface in com.netflix.astyanax.model
Interface for a CQL query result.
createCluster(ConnectionPool<T>, AstyanaxConfiguration, KeyspaceTracerFactory) - Method in interface com.netflix.astyanax.AstyanaxTypeFactory
 
createCluster(ConnectionPool<Cassandra.Client>, AstyanaxConfiguration, KeyspaceTracerFactory) - Method in class com.netflix.astyanax.thrift.ThriftFamilyFactory
 
createConnection(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.ConnectionFactory
 
createConnection(HostConnectionPool<Cassandra.Client>) - Method in class com.netflix.astyanax.thrift.ThriftSyncConnectionFactoryImpl
 
createConnectionFactory(ConnectionPoolConfiguration, KeyspaceTracerFactory, ConnectionPoolMonitor) - Method in interface com.netflix.astyanax.AstyanaxTypeFactory
 
createConnectionFactory(ConnectionPoolConfiguration, KeyspaceTracerFactory, ConnectionPoolMonitor) - Method in class com.netflix.astyanax.thrift.ThriftFamilyFactory
 
createConnectionPool(ConnectionFactory<T>) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
createEntry() - Method in class com.netflix.astyanax.impl.NoOpWriteAheadLog
 
createEntry() - Method in interface com.netflix.astyanax.WriteAheadLog
Add an entry to WAL before it is sent to Cassandra.
createInstance() - Method in interface com.netflix.astyanax.connectionpool.BadHostDetector
 
createInstance() - Method in class com.netflix.astyanax.connectionpool.impl.BadHostDetectorImpl
 
createInstance() - Method in class com.netflix.astyanax.connectionpool.impl.ExponentialRetryBackoffStrategy
 
createInstance() - Method in class com.netflix.astyanax.connectionpool.impl.FixedRetryBackoffStrategy
 
createInstance() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
createInstance() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Create a new instance to associate with an endpoint
createInstance() - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy
Create an instance of the strategy for a single host
createInstance() - Method in class com.netflix.astyanax.shallows.EmptyBadHostDetectorImpl
 
createInstance() - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
createKeyspace(String, ConnectionPool<T>, AstyanaxConfiguration, KeyspaceTracerFactory) - Method in interface com.netflix.astyanax.AstyanaxTypeFactory
 
createKeyspace(String, ConnectionPool<Cassandra.Client>, AstyanaxConfiguration, KeyspaceTracerFactory) - Method in class com.netflix.astyanax.thrift.ThriftFamilyFactory
 
createSliceRange(Serializer<C>, C, C, boolean, int) - Static method in class com.netflix.astyanax.thrift.ThriftUtils
 
createStreamReader(InputStream) - Method in class com.netflix.astyanax.serializers.JaxbSerializer
Get a new XML stream reader.
createStreamWriter(OutputStream) - Method in class com.netflix.astyanax.serializers.JaxbSerializer
Get a new XML stream writer.
CsvColumnReader - Class in com.netflix.astyanax.util
Read a CSV where each row represents a single column rowkey, columname, columnvalue
CsvColumnReader(Reader) - Constructor for class com.netflix.astyanax.util.CsvColumnReader
 
CsvRecordReader - Class in com.netflix.astyanax.util
 
CsvRecordReader(Reader) - Constructor for class com.netflix.astyanax.util.CsvRecordReader
 
CsvRowsWriter - Class in com.netflix.astyanax.util
 
CsvRowsWriter() - Constructor for class com.netflix.astyanax.util.CsvRowsWriter
 

D

DateSerializer - Class in com.netflix.astyanax.serializers
Converts bytes to Date and vice versa, by first converting the Date to or from a long which represents the specified number of milliseconds since the standard base time known as "the Unix epoch", that is January 1, 1970, 00:00:00 UTC.
DateSerializer() - Constructor for class com.netflix.astyanax.serializers.DateSerializer
 
DEFAULT_ALIAS_TO_COMPARATOR_MAPPING - Static variable in class com.netflix.astyanax.model.AbstractComposite
 
DEFAULT_BAD_HOST_DETECTOR - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_CONNECT_TIMEOUT - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_CONNECTION_LIMITER_MAX_PENDING_COUNT - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_CONNECTION_LIMITER_WINDOW_SIZE - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_FAILOVER_COUNT - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_ID_COLUMN_NAME - Static variable in class com.netflix.astyanax.mapping.Mapping
If the ID column does not have a Column annotation, this column name is used
DEFAULT_INIT_PER_PARTITION - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_LATENCY_AWARE_BADNESS_THRESHOLD - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_LATENCY_AWARE_RESET_INTERVAL - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_LATENCY_AWARE_SENTINEL_COMPARE - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_LATENCY_AWARE_UPDATE_INTERVAL - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_LATENCY_AWARE_WINDOW_SIZE - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_LOCK_PREFIX - Static variable in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
DEFAULT_MAX_ACTIVE_PER_PARTITION - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_MAX_BLOCKED_THREADS_PER_HOST - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_MAX_CONNS - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_MAX_OPERATIONS_PER_CONNECTION - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_MAX_PENDING_CONNECTIONS_PER_HOST - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_MAX_TIME_WHEN_EXHAUSTED - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
Default values
DEFAULT_MAX_TIMEOUT_COUNT - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_OPERATION_TIMEOUT_UNITS - Static variable in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
DEFAULT_PORT - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_RETRY_DELAY_SLICE - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_RETRY_MAX_DELAY_SLICE - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_RETRY_SUSPEND_WINDOW - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_SERIALIZER_PACKAGE - Static variable in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
DEFAULT_SERIALIZER_TO_COMPARATOR_MAPPING - Static variable in class com.netflix.astyanax.model.AbstractComposite
 
DEFAULT_SOCKET_TIMEOUT - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DEFAULT_TIMEOUT_WINDOW - Static variable in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
DefaultAnnotationSet - Class in com.netflix.astyanax.mapping
The default annotation set.
DefaultAnnotationSet() - Constructor for class com.netflix.astyanax.mapping.DefaultAnnotationSet
 
delete() - Method in interface com.netflix.astyanax.ColumnListMutation
Deletes all columns at the current column path location.
delete() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
delete() - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
delete() - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
deleteColumn(C) - Method in interface com.netflix.astyanax.ColumnListMutation
 
deleteColumn() - Method in interface com.netflix.astyanax.ColumnMutation
 
deleteColumn(C) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
deleteColumn(C) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
deleteColumn(C) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
deleteCounterColumn() - Method in interface com.netflix.astyanax.ColumnMutation
 
deleteObject(String, Integer) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
deleteObject(String, Integer) - Method in interface com.netflix.astyanax.recipes.storage.ChunkedStorageProvider
Delete a chunk
deleteRow(Collection<ColumnFamily<K, ?>>, K) - Method in interface com.netflix.astyanax.MutationBatch
Delete the row for all the specified column families
deleteRow(Collection<ColumnFamily<K, ?>>, K) - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
describeClusterName() - Method in interface com.netflix.astyanax.Cluster
The cluster name is completely arbitrary
describeClusterName() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
describeKeyspace(String) - Method in interface com.netflix.astyanax.Cluster
Describe a single keyspace
describeKeyspace() - Method in interface com.netflix.astyanax.Keyspace
Return a complete description of the keyspace and its column families
describeKeyspace(String) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
describeKeyspace() - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
describeKeyspaces() - Method in interface com.netflix.astyanax.Cluster
Return details about all keyspaces in the cluster
describeKeyspaces() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
describePartitioner() - Method in interface com.netflix.astyanax.Cluster
Describe the partitioner used by the cluster
describePartitioner() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
describeRing() - Method in interface com.netflix.astyanax.Keyspace
Get a list of all tokens and their endpoints
describeRing() - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
describeSchemaVersions() - Method in interface com.netflix.astyanax.Cluster
 
describeSchemaVersions() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
describeSnitch() - Method in interface com.netflix.astyanax.Cluster
Describe the snitch name used on the cluster
describeSnitch() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
deserialize(ByteBuffer) - Method in class com.netflix.astyanax.model.AbstractComposite
 
deserialize(ByteBuffer) - Method in interface com.netflix.astyanax.MutationBatch
Re-recreate a mutation batch from a serialized ByteBuffer created by a call to serialize().
deserialize(Object, ByteBuffer) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer.ComponentSerializer
 
deserialize(ByteBuffer) - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
discardMutations() - Method in interface com.netflix.astyanax.MutationBatch
Discard any pending mutations.
discardMutations() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
discovery - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
DistributedMergeSort - Class in com.netflix.astyanax.recipes
 
DistributedMergeSort() - Constructor for class com.netflix.astyanax.recipes.DistributedMergeSort
 
DistributedRowLock - Interface in com.netflix.astyanax.recipes.locks
Base interface to acquiring and release a row lock Usage: DistributedRowLock lock = new SomeLockImplementation(...); try { lock.acquire(); // Do something ...
DoubleSerializer - Class in com.netflix.astyanax.serializers
Uses LongSerializer via translating Doubles to and from raw long bytes form.
DoubleSerializer() - Constructor for class com.netflix.astyanax.serializers.DoubleSerializer
 
dropColumnFamily(String, String) - Method in interface com.netflix.astyanax.Cluster
Delete the column family from the keyspace
dropColumnFamily(String, String) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
dropKeyspace(String) - Method in interface com.netflix.astyanax.Cluster
Delete a keyspace from the cluster
dropKeyspace(String) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
duplicate() - Method in class com.netflix.astyanax.retry.ConstantBackoff
 
duplicate() - Method in class com.netflix.astyanax.retry.ExponentialBackoff
 
duplicate() - Method in class com.netflix.astyanax.retry.RetryNTimes
 
duplicate() - Method in interface com.netflix.astyanax.retry.RetryPolicy
Duplicate this policy into a fresh instance
duplicate() - Method in class com.netflix.astyanax.retry.RunOnce
 
DynamicComposite - Class in com.netflix.astyanax.model
 
DynamicComposite() - Constructor for class com.netflix.astyanax.model.DynamicComposite
 
DynamicComposite(Object...) - Constructor for class com.netflix.astyanax.model.DynamicComposite
 
DynamicComposite(List<?>) - Constructor for class com.netflix.astyanax.model.DynamicComposite
 
DynamicCompositeSerializer - Class in com.netflix.astyanax.serializers
 
DynamicCompositeSerializer() - Constructor for class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 

E

EMPTY_BYTE_BUFFER - Static variable in class com.netflix.astyanax.thrift.ThriftUtils
 
EmptyBadHostDetectorImpl - Class in com.netflix.astyanax.shallows
 
EmptyColumn<C> - Class in com.netflix.astyanax.shallows
 
EmptyColumn() - Constructor for class com.netflix.astyanax.shallows.EmptyColumn
 
EmptyColumnList<C> - Class in com.netflix.astyanax.shallows
 
EmptyColumnList() - Constructor for class com.netflix.astyanax.shallows.EmptyColumnList
 
EmptyConnectionPoolMonitor - Class in com.netflix.astyanax.shallows
 
EmptyIterator - Class in com.netflix.astyanax.shallows
 
EmptyIterator() - Constructor for class com.netflix.astyanax.shallows.EmptyIterator
 
EmptyKeyspaceTracer - Class in com.netflix.astyanax.shallows
 
EmptyKeyspaceTracerFactory - Class in com.netflix.astyanax.shallows
 
EmptyLatencyScoreStrategyImpl - Class in com.netflix.astyanax.shallows
 
EmptyLatencyScoreStrategyImpl() - Constructor for class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
EmptyNodeDiscoveryImpl - Class in com.netflix.astyanax.shallows
 
EmptyRowsImpl<K,C> - Class in com.netflix.astyanax.shallows
 
EmptyRowsImpl() - Constructor for class com.netflix.astyanax.shallows.EmptyRowsImpl
 
Equality - Enum in com.netflix.astyanax.model
 
equals(Object) - Method in class com.netflix.astyanax.connectionpool.Host
 
equals() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
equals() - Method in interface com.netflix.astyanax.query.IndexOperationExpression
 
equals() - Method in interface com.netflix.astyanax.query.PreparedIndexOperationExpression
 
ExceptionCallback - Interface in com.netflix.astyanax
ExceptionCallback is used in situation where it is not possible to return a checked exception, such as when implementing a custom iterator.
execute(Operation<CL, R>) - Method in interface com.netflix.astyanax.connectionpool.Connection
Execute an operation on the connection and return a result
execute(CL) - Method in interface com.netflix.astyanax.connectionpool.Operation
Execute the operation on the client object and return the results
execute() - Method in interface com.netflix.astyanax.Execution
Block while executing the operations
execute() - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
execute(Cassandra.Client) - Method in class com.netflix.astyanax.thrift.AbstractOperationImpl
 
execute(MutationBatch) - Method in class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 
execute(MutationBatch) - Method in class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
Write a mutation to the wal and execute it
executeAsync() - Method in interface com.netflix.astyanax.Execution
Return a future to the operation.
executeWithCallback(RowCallback<K, C>) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Execute the operation in a separate thread for each token range and provide the results in a callback.
executeWithFailover(Operation<CL, R>, RetryPolicy) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Execute an operation with failover within the context of the connection pool.
ExecuteWithFailover<CL,R> - Interface in com.netflix.astyanax.connectionpool
 
executeWithFailover(Operation<CL, R>, RetryPolicy) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
executeWithRetry(RetryPolicy) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecutionImpl
 
Execution<R> - Interface in com.netflix.astyanax
Interface for an operation that can be executed on the cluster.
expireLockAfter(long, TimeUnit) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Time for failed locks.
ExponentialBackoff - Class in com.netflix.astyanax.retry
 
ExponentialBackoff(int, int) - Constructor for class com.netflix.astyanax.retry.ExponentialBackoff
 
ExponentialRetryBackoffStrategy - Class in com.netflix.astyanax.connectionpool.impl
 
ExponentialRetryBackoffStrategy(ConnectionPoolConfiguration) - Constructor for class com.netflix.astyanax.connectionpool.impl.ExponentialRetryBackoffStrategy
 

F

factory - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
failOnStaleLock(boolean) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
When set to true the operation will fail if a stale lock is detected
failure(ConnectionException) - Method in interface com.netflix.astyanax.CassandraOperationTracer
 
failure(Connection<CL>, ConnectionException) - Method in interface com.netflix.astyanax.connectionpool.Connection.AsyncOpenCallback
 
failure(Exception) - Method in class com.netflix.astyanax.retry.RetryNTimes
 
failure(Exception) - Method in interface com.netflix.astyanax.retry.RetryPolicy
Operation has failed
failure(Exception) - Method in class com.netflix.astyanax.retry.RunOnce
 
failure(Exception) - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
failure(ConnectionException) - Method in interface com.netflix.astyanax.RowCallback
Notification of an error calling cassandra.
failure(ConnectionException) - Method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracer
 
fillLockMutation(MutationBatch, Long, Integer) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Fill a mutation with the lock column.
fillMutation(T, ColumnListMutation<String>) - Method in class com.netflix.astyanax.mapping.Mapping
Map a bean to a column mutation.
fillReleaseMutation(MutationBatch) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Fill a mutation that will release the locks.
FilteringHostSupplier - Class in com.netflix.astyanax.impl
Node discovery supplier that only return suppliers that come from both sources
FilteringHostSupplier(Supplier<Map<BigInteger, List<Host>>>, Supplier<Map<BigInteger, List<Host>>>) - Constructor for class com.netflix.astyanax.impl.FilteringHostSupplier
 
firstPage - Variable in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
FixedRetryBackoffStrategy - Class in com.netflix.astyanax.connectionpool.impl
 
FixedRetryBackoffStrategy(int, int) - Constructor for class com.netflix.astyanax.connectionpool.impl.FixedRetryBackoffStrategy
 
FloatSerializer - Class in com.netflix.astyanax.serializers
Uses IntSerializer via translating Float objects to and from raw long bytes form.
FloatSerializer() - Constructor for class com.netflix.astyanax.serializers.FloatSerializer
 
forCluster(String) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
forEach(Function<Row<K, C>, Void>) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
forEachIndexEntry(ReverseIndexQuery.IndexEntryCallback<K, V>) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
forKeyspace(String) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
fromByte(byte) - Static method in enum com.netflix.astyanax.model.AbstractComposite.ComponentEquality
 
fromByte(byte) - Static method in enum com.netflix.astyanax.model.Equality
 
fromByteBuffer(ByteBuffer) - Static method in class com.netflix.astyanax.model.Composite
 
fromByteBuffer(ByteBuffer) - Static method in class com.netflix.astyanax.model.DynamicComposite
 
fromByteBuffer(ByteBuffer) - Method in interface com.netflix.astyanax.Serializer
Extract an object of type T from the bytes.
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.AsciiSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BooleanSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BytesArraySerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.CharSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.CompositeSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DateSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DoubleSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.FloatSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.IntegerSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.JaxbSerializer
Extract an object of type T from the bytes.
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.LongSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ObjectSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.PrefixedSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ShortSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.StringSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.TypeInferringSerializer
 
fromByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.UUIDSerializer
 
fromBytes(byte[]) - Method in interface com.netflix.astyanax.Serializer
 
fromBytes(byte[]) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
fromBytes(byte[]) - Method in class com.netflix.astyanax.serializers.IntegerSerializer
 
fromBytesList(List<ByteBuffer>) - Method in interface com.netflix.astyanax.Serializer
 
fromBytesList(List<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
fromBytesList(List<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
fromBytesList(List<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.PrefixedSerializer
 
fromBytesMap(Map<ByteBuffer, V>) - Method in interface com.netflix.astyanax.Serializer
 
fromBytesMap(Map<ByteBuffer, V>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
fromBytesMap(Map<ByteBuffer, V>) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
fromBytesMap(Map<ByteBuffer, V>) - Method in class com.netflix.astyanax.serializers.PrefixedSerializer
 
fromBytesSet(Set<ByteBuffer>) - Method in interface com.netflix.astyanax.Serializer
 
fromBytesSet(Set<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
fromIndexValue(V) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
fromString(String) - Method in interface com.netflix.astyanax.Serializer
Create a ByteBuffer by first parsing the type out of a string
fromString(String) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.AsciiSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.BooleanSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.BytesArraySerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.CharSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.DateSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.DoubleSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.FloatSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.IntegerSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.LongSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.ShortSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.SpecificCompositeSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.StringSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.TimeUUIDSerializer
 
fromString(String) - Method in class com.netflix.astyanax.serializers.UUIDSerializer
 

G

get() - Method in enum com.netflix.astyanax.clock.ClockType
 
get() - Method in class com.netflix.astyanax.impl.FilteringHostSupplier
 
get() - Method in class com.netflix.astyanax.impl.RingDescribeHostSupplier
 
get(ColumnFamily<K, String>, K, Class<T>) - Method in class com.netflix.astyanax.mapping.MappingUtil
Get the specified item by its key/id
get(int) - Method in class com.netflix.astyanax.model.AbstractComposite
 
get(int, Serializer<T>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
get(int) - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated. Get a path element from a specific depth
get() - Method in class com.netflix.astyanax.recipes.UUIDStringSupplier
 
get() - Static method in class com.netflix.astyanax.retry.RunOnce
 
get() - Static method in class com.netflix.astyanax.serializers.AsciiSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.BooleanSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.BytesArraySerializer
 
get() - Static method in class com.netflix.astyanax.serializers.CharSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.CompositeSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.DateSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.DoubleSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.FloatSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.IntegerSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.LongSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.ObjectSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.ShortSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.StringSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.TimeUUIDSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.TypeInferringSerializer
 
get() - Static method in class com.netflix.astyanax.serializers.UUIDSerializer
 
get() - Static method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
get() - Static method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
getActiveConnectionCount() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Get number of open connections including any that are currently borrowed and those that are currently idel
getActiveConnectionCount() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getActiveHosts() - Method in class com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitor
 
getActiveHosts() - Method in interface com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitorMBean
 
getActivePools() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Return list of active hosts on which connections can be created
getActivePools() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
getAliasesToComparatorMapping() - Method in class com.netflix.astyanax.model.AbstractComposite
 
getAll(Rows<?, String>) - Method in class com.netflix.astyanax.mapping.Mapping
Load a set of rows into new instances populated with values from the column lists
getAll(ColumnFamily<K, String>, Class<T>) - Method in class com.netflix.astyanax.mapping.MappingUtil
Get all rows of the specified item
getAllPools() - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
getAllPools() - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Return a partition that represents all hosts in the ring
getAllRows() - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Query to get an iterator to all rows in the column family
getAllRows() - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
getAlternateIpAddresses() - Method in class com.netflix.astyanax.connectionpool.Host
 
getAstyanaxConfiguration() - Method in class com.netflix.astyanax.AstyanaxContext
 
getAsyncExecutor() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Return the maximum number of allows async threads to executeAsync()
getAsyncExecutor() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getAttemptCount() - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy.Instance
 
getAttemptCount() - Method in class com.netflix.astyanax.retry.RetryNTimes
 
getAttemptCount() - Method in interface com.netflix.astyanax.retry.RetryPolicy
Return the number of attempts since begin was called
getAttemptCount() - Method in class com.netflix.astyanax.retry.RunOnce
 
getAttemptCount() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
getAttemptsCount() - Method in class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
getAttemptsCount() - Method in interface com.netflix.astyanax.connectionpool.OperationResult
Return the number of times the operation had to be retried.
getAttribute(String) - Method in interface com.netflix.astyanax.AuthenticationCredentials
Retrieve a single attribute by name
getAttribute(String) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
getAttributeNames() - Method in interface com.netflix.astyanax.AuthenticationCredentials
Array of all custom attribute names
getAttributeNames() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
getAuthenticationCredentials() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Can return null if no login required
getAuthenticationCredentials() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getBadHostDetector() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
TODO
getBadHostDetector() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getBadnessThreshold() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
getBlockedThreadCount() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Get number of threads blocked waiting for a free connection
getBlockedThreadCount() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getBlockSize() - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
getBooleanValue(C, Boolean) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getBooleanValue() - Method in interface com.netflix.astyanax.model.Column
Get value as a boolean
getBooleanValue(C, Boolean) - Method in interface com.netflix.astyanax.model.ColumnList
Get value as a boolean
getBooleanValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getBooleanValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getBooleanValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getBooleanValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getBooleanValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getBufferList() - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
Returns all data written and resets the stream to be empty.
getBusyConnectionCount() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Get number of currently borrowed connections
getBusyConnectionCount() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getByClassName(String) - Static method in enum com.netflix.astyanax.serializers.ComparatorType
 
getByteArrayValue(C, byte[]) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getByteArrayValue() - Method in interface com.netflix.astyanax.model.Column
Get the raw byte[] value
getByteArrayValue(C, byte[]) - Method in interface com.netflix.astyanax.model.ColumnList
Get the raw byte[] value
getByteArrayValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getByteArrayValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getByteArrayValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getByteArrayValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getByteArrayValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getByteBuffer() - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
getByteBufferValue(C, ByteBuffer) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getByteBufferValue() - Method in interface com.netflix.astyanax.model.Column
Get the raw ByteBuffer value
getByteBufferValue(C, ByteBuffer) - Method in interface com.netflix.astyanax.model.ColumnList
Get the raw ByteBuffer value
getByteBufferValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getByteBufferValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getByteBufferValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getByteBufferValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getByteBufferValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getBytes(Serializer<A>) - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getBytes() - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getBytes(ByteBuffer, int) - Static method in class com.netflix.astyanax.model.AbstractComposite
 
getCassandraMonitor(String) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolMBeanManager
 
getCassandraMonitor(String) - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryMonitorManager
 
getChunkCount() - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
getChunkSize() - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
getClassName() - Method in enum com.netflix.astyanax.serializers.ComparatorType
 
getClock() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Return clock to use when setting timestamps for column insertion and deletion operations.
getClock() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getClusterName() - Method in class com.netflix.astyanax.AstyanaxContext
 
getColumn() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
getColumn() - Method in interface com.netflix.astyanax.query.PreparedIndexExpression
 
getColumn(C) - Method in interface com.netflix.astyanax.query.RowQuery
Specify the path to a single column (either Standard or Super).
getColumnAnnotation() - Method in interface com.netflix.astyanax.mapping.AnnotationSet
 
getColumnAnnotation() - Method in class com.netflix.astyanax.mapping.DefaultAnnotationSet
 
getColumnByIndex(int) - Method in interface com.netflix.astyanax.model.ColumnList
Queries column by index
getColumnByIndex(int) - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
getColumnByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
getColumnByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
getColumnByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
getColumnByName(C) - Method in interface com.netflix.astyanax.model.ColumnList
Queries column by name
getColumnByName(C) - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
getColumnByName(C) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
getColumnByName(C) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
getColumnByName(C) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
getColumnDefinitionList() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getColumnDefinitionList() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getColumnFamily(String) - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
getColumnFamily(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
getColumnFamilyList() - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
getColumnFamilyList() - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
getColumnName(Field, COLUMN) - Method in interface com.netflix.astyanax.mapping.AnnotationSet
Return the column name to use for the given field.
getColumnName(Field, Column) - Method in class com.netflix.astyanax.mapping.DefaultAnnotationSet
 
getColumnNames() - Method in interface com.netflix.astyanax.SerializerPackage
Return the set of supported column names
getColumnNames() - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
getColumnNameSerializer() - Method in interface com.netflix.astyanax.SerializerPackage
Return serializer for column names
getColumnNameSerializer() - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
getColumnParent(ColumnFamily<?, ?>, ColumnPath<?>) - Static method in class com.netflix.astyanax.thrift.ThriftConverter
Construct a Hector ColumnParent based on the information in the query and the type of column family being queried.
getColumnPath(ColumnFamily<?, ?>, ColumnPath<?>) - Static method in class com.netflix.astyanax.thrift.ThriftConverter
Construct a Thrift ColumnPath based on the information in the query and the type of column family being queried.
getColumns() - Method in class com.netflix.astyanax.model.ColumnSlice
 
getColumns() - Method in interface com.netflix.astyanax.model.Row
Child columns of the row.
getColumns() - Method in class com.netflix.astyanax.thrift.model.ThriftRowImpl
 
getColumnSerializer() - Method in class com.netflix.astyanax.model.ColumnFamily
Serializer for first level column names.
getColumnSerializer() - Method in interface com.netflix.astyanax.SerializerPackage
Deprecated. use getColumnNameSerializer()
getColumnSerializer(ByteBuffer) - Method in interface com.netflix.astyanax.SerializerPackage
Return the value serializer for the specified column name
getColumnSerializer(String) - Method in interface com.netflix.astyanax.SerializerPackage
Return the value serializer for the specified column name
getColumnSerializer() - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
Deprecated. 
getColumnSerializer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
getColumnSerializer(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
getColumnValue(T, String, Class<V>) - Method in class com.netflix.astyanax.mapping.Mapping
Return the value for the given column from the given instance
getComment() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getComment() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getComparator() - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getComparatorsByPosition() - Method in class com.netflix.astyanax.model.AbstractComposite
 
getComparatorType() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getComparatorType() - Method in interface com.netflix.astyanax.Serializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.AsciiSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.BooleanSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.CompositeSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.DoubleSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.FloatSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.LongSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.StringSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.TimeUUIDSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.serializers.UUIDSerializer
 
getComparatorType() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getComponent(int) - Method in class com.netflix.astyanax.model.AbstractComposite
 
getComponents() - Method in class com.netflix.astyanax.model.AbstractComposite
 
getConfig() - Method in interface com.netflix.astyanax.Cluster
Configuration object for this Cluster
getConfig() - Method in interface com.netflix.astyanax.Keyspace
Return the configuration object used to set up this keyspace
getConfig() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
getConfig() - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
getConnectionBorrowedCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getConnectionBorrowedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getConnectionBorrowedCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getConnectionClosedCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getConnectionClosedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getConnectionClosedCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getConnectionCreatedCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getConnectionCreatedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getConnectionCreatedCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getConnectionCreateFailedCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getConnectionCreateFailedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getConnectionCreateFailedCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getConnectionLimiterMaxPendingCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Maximum number of connection attempts in a given window
getConnectionLimiterMaxPendingCount() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getConnectionLimiterWindowSize() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Window size for limiting the number of connection open requests
getConnectionLimiterWindowSize() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getConnectionPool() - Method in class com.netflix.astyanax.AstyanaxContext
 
getConnectionPoolConfiguration() - Method in class com.netflix.astyanax.AstyanaxContext
 
getConnectionPoolMonitor() - Method in class com.netflix.astyanax.AstyanaxContext
 
getConnectionPoolType() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Type of connection pool to use for this instance
getConnectionPoolType() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getConnectionReturnedCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getConnectionReturnedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getConnectionReturnedCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getConnectionsClosed() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getConnectionsCreated() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getConnectionsCreateFailed() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getConnectTimeout() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Socket connect timeout
getConnectTimeout() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getConsistencyLevel() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
getConsistencyLevel() - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
getCount() - Method in interface com.netflix.astyanax.query.RowQuery
Returns the number of columns in the response without returning any data
getCurrentHost() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
getCurrentHostConnectionPool() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
getCurrentHostConnectionPool() - Method in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
getCurrentTime() - Method in class com.netflix.astyanax.clock.ConstantClock
 
getCurrentTime() - Method in interface com.netflix.astyanax.Clock
 
getCurrentTime() - Method in class com.netflix.astyanax.clock.MicrosecondsAsyncClock
 
getCurrentTime() - Method in class com.netflix.astyanax.clock.MicrosecondsClock
 
getCurrentTime() - Method in class com.netflix.astyanax.clock.MicrosecondsSyncClock
 
getCurrentTime() - Method in class com.netflix.astyanax.clock.MillisecondsClock
 
getDateValue(C, Date) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getDateValue() - Method in interface com.netflix.astyanax.model.Column
Get the value as a date object
getDateValue(C, Date) - Method in interface com.netflix.astyanax.model.ColumnList
Get the value as a date object
getDateValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getDateValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getDateValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getDateValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getDateValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getDefaultChunkSize() - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
getDefaultChunkSize() - Method in interface com.netflix.astyanax.recipes.storage.ChunkedStorageProvider
Return the preferred chunk size for this provider
getDefaultReadConsistencyLevel() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Default consistency level used when reading from the cluster.
getDefaultReadConsistencyLevel() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getDefaultValidationClass() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getDefaultValidationClass() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getDefaultValueSerializer() - Method in interface com.netflix.astyanax.SerializerPackage
Return the default value serializer
getDefaultValueSerializer() - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
getDefaultWriteConsistencyLevel() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Default consistency level used when reading from the cluster.
getDefaultWriteConsistencyLevel() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getDiscoveryDelayInSeconds() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Fixed delay for node disocvery refresh
getDiscoveryDelayInSeconds() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getDiscoveryType() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
Get type of node discovery to perform
getDiscoveryType() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getDoubleValue(C, Double) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getDoubleValue() - Method in interface com.netflix.astyanax.model.Column
Return value as a double
getDoubleValue(C, Double) - Method in interface com.netflix.astyanax.model.ColumnList
Return value as a double
getDoubleValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getDoubleValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getDoubleValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getDoubleValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getDoubleValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getEnd() - Method in interface com.netflix.astyanax.model.ByteBufferRange
 
getEnd() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
Deprecated. 
getEnd() - Method in class com.netflix.astyanax.util.ByteBufferRangeImpl
 
getEndColumn() - Method in class com.netflix.astyanax.model.ColumnSlice
 
getEndKey() - Method in class com.netflix.astyanax.model.KeySlice
 
getEndpoints() - Method in class com.netflix.astyanax.connectionpool.impl.TokenRangeImpl
 
getEndpoints() - Method in interface com.netflix.astyanax.connectionpool.TokenRange
 
getEndToken() - Method in class com.netflix.astyanax.connectionpool.impl.TokenRangeImpl
 
getEndToken() - Method in interface com.netflix.astyanax.connectionpool.TokenRange
 
getEndToken() - Method in class com.netflix.astyanax.model.KeySlice
 
getEntity() - Method in class com.netflix.astyanax.AstyanaxContext
 
getEquality() - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getErrorCount() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getErrorCount() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
getErrorCount() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Get total number of errors encountered during a refresh
getErrorCount() - Method in class com.netflix.astyanax.connectionpool.NodeDiscoveryMonitor
 
getErrorCount() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscoveryMonitorMBean
 
getErrorCount() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
getExceptionCallback() - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
getExpected() - Method in exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
getFailoverCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getFailoverCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getFailoverCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getFailureCount() - Method in class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 
getField() - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer.ComponentSerializer
 
getHost() - Method in interface com.netflix.astyanax.connectionpool.Connection
Get the host for this connection
getHost() - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
getHost() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Get the host to which this pool is associated
getHost() - Method in class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
getHost() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getHost() - Method in interface com.netflix.astyanax.connectionpool.OperationResult
Get the host on which the operation was performed
getHostAddedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getHostConnectionPool() - Method in interface com.netflix.astyanax.connectionpool.Connection
Get the parent host connection pool.
getHostDownCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getHostName() - Method in class com.netflix.astyanax.connectionpool.Host
 
getHostPool(Host) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Return an immutable connection pool for this host
getHostPool(Host) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
getHostReactivatedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getHostRemovedCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getHostStats() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Return a mapping of all hosts and their statistics
getHostStats() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getHostStats() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getId() - Method in class com.netflix.astyanax.connectionpool.Host
 
getId() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getId() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getIdAnnotation() - Method in interface com.netflix.astyanax.mapping.AnnotationSet
 
getIdAnnotation() - Method in class com.netflix.astyanax.mapping.DefaultAnnotationSet
 
getIdleConnectionCount() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Return the number of idle active connections.
getIdleConnectionCount() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getIdName(Field, ID) - Method in interface com.netflix.astyanax.mapping.AnnotationSet
Return the ID/Key name to use
getIdName(Field, Id) - Method in class com.netflix.astyanax.mapping.DefaultAnnotationSet
 
getIdValue(T, Class<V>) - Method in class com.netflix.astyanax.mapping.Mapping
Return the value for the ID/Key column from the given instance
getIndexName() - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Return the index name
getIndexName() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
getIndexType() - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Return the index type.
getIndexType() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
getInitConnsPerHost() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Initial number of connections created when a connection pool is started
getInitConnsPerHost() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getInstance() - Static method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolMBeanManager
 
getInstance() - Static method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryMonitorManager
 
getInstance() - Static method in class com.netflix.astyanax.recipes.UUIDStringSupplier
 
getInstance() - Static method in class com.netflix.astyanax.shallows.EmptyBadHostDetectorImpl
 
getInstance() - Static method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getInstance() - Static method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracer
 
getInstance() - Static method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracerFactory
 
getInstance() - Static method in class com.netflix.astyanax.thrift.ThriftFamilyFactory
 
getIntegerValue(C, Integer) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getIntegerValue() - Method in interface com.netflix.astyanax.model.Column
Return value as an integer
getIntegerValue(C, Integer) - Method in interface com.netflix.astyanax.model.ColumnList
Return value as an integer
getIntegerValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getIntegerValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getIntegerValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getIntegerValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getIntegerValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getIpAddress() - Method in class com.netflix.astyanax.connectionpool.Host
 
getKey() - Method in interface com.netflix.astyanax.model.Row
Return the key value
getKey(K) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Query a single key
getKey() - Method in class com.netflix.astyanax.thrift.model.ThriftRowImpl
 
getKey(K) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
getKeyAlias() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getKeyAlias() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getKeyCacheSavePeriodInSeconds() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getKeyCacheSavePeriodInSeconds() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getKeyCacheSize() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getKeyCacheSize() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getKeyRange(K, K, String, String, int) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Query a range of keys.
getKeyRange(K, K, String, String, int) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
getKeys() - Method in class com.netflix.astyanax.model.KeySlice
 
getKeySerializer() - Method in class com.netflix.astyanax.model.ColumnFamily
Serializer used to generate row keys.
getKeySerializer() - Method in interface com.netflix.astyanax.SerializerPackage
Return the serializer for keys
getKeySerializer() - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
getKeySlice(K...) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Query a non-contiguous set of keys.
getKeySlice(Collection<K>) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Query a non-contiguous set of keys.
getKeySlice(K[]) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
getKeySlice(Collection<K>) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
getKeyspace(String) - Method in interface com.netflix.astyanax.Cluster
Return a keyspace client.
getKeyspace() - Method in interface com.netflix.astyanax.connectionpool.Operation
Return keyspace for this operation.
getKeyspace() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getKeyspace() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
getKeyspace() - Method in class com.netflix.astyanax.thrift.AbstractKeyspaceOperationImpl
 
getKeyspace() - Method in class com.netflix.astyanax.thrift.AbstractOperationImpl
 
getKeyspace() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getKeyspace(String) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
getKeyspaceName() - Method in class com.netflix.astyanax.AstyanaxContext
 
getKeyspaceName() - Method in interface com.netflix.astyanax.Keyspace
Returns keyspace name
getKeyspaceName() - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
getKeyValidationClass() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getKeyValidationClass() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getLast() - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated. Returns the last element in the path.
getLastException() - Method in interface com.netflix.astyanax.connectionpool.Connection
Get the last exception that caused the connection to be closed
getLastException() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
getLastException() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Get the last exception that was encountered
getLastException() - Method in class com.netflix.astyanax.connectionpool.NodeDiscoveryMonitor
 
getLastException() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscoveryMonitorMBean
 
getLastException() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
getLastRefreshTime() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
getLastRefreshTime() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Get the last refresh time in the discovery thread
getLastRefreshTime() - Method in class com.netflix.astyanax.connectionpool.NodeDiscoveryMonitor
 
getLastRefreshTime() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscoveryMonitorMBean
 
getLastRefreshTime() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
getLatency() - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
getLatency(TimeUnit) - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
getLatency() - Method in class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
getLatency(TimeUnit) - Method in class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
getLatency() - Method in interface com.netflix.astyanax.connectionpool.OperationResult
Return the length of time to perform the operation.
getLatency(TimeUnit) - Method in interface com.netflix.astyanax.connectionpool.OperationResult
Return the length of time to perform the operation.
getLatencyAwareBadnessThreshold() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Return the threshold after which a host will not be considered good enough for executing operations.
getLatencyAwareBadnessThreshold() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getLatencyAwareResetInterval() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
 
getLatencyAwareResetInterval() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getLatencyAwareSentinelCompare() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Sentinel compare value for Phi Accrual
getLatencyAwareSentinelCompare() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getLatencyAwareUpdateInterval() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
 
getLatencyAwareUpdateInterval() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getLatencyAwareWindowSize() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Latency samples window size for scoring algorithm
getLatencyAwareWindowSize() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getLatencyScoreStrategy() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
TODO
getLatencyScoreStrategy() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getLatencyWithPool() - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
getLimit() - Method in interface com.netflix.astyanax.model.ByteBufferRange
 
getLimit() - Method in class com.netflix.astyanax.model.ColumnSlice
 
getLimit() - Method in class com.netflix.astyanax.model.KeySlice
 
getLimit() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
Deprecated. 
getLimit() - Method in class com.netflix.astyanax.util.ByteBufferRangeImpl
 
getLockColumn() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
getLockColumn() - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
Return the lock column written to ALL rows
getLongValue(C, Long) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getLongValue() - Method in interface com.netflix.astyanax.model.Column
Return value as a long.
getLongValue(C, Long) - Method in interface com.netflix.astyanax.model.ColumnList
Return value as a long.
getLongValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getLongValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getLongValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getLongValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getLongValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getMapping(Class<T>) - Method in class com.netflix.astyanax.mapping.MappingCache
Return a new or cached mapper
getMapping(Class<T>, AnnotationSet<?, ?>) - Method in class com.netflix.astyanax.mapping.MappingCache
Return a new or cached mapper
getMapping(Class<T>) - Method in class com.netflix.astyanax.mapping.MappingUtil
Return the mapping instance for the given class
getMax() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
getMaxBlockedThreadsPerHost() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Get max number of blocked clients for a host.
getMaxBlockedThreadsPerHost() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaxConns() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Maximum number of connections in the pool, not used by all connection pool implementations
getMaxConns() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaxConnsPerHost() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Maximum number of connections to allocate for a single host's pool
getMaxConnsPerHost() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaxFailoverCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Get the max number of failover attempts
getMaxFailoverCount() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaximumToken() - Static method in class com.netflix.astyanax.util.TokenGenerator
 
getMaxOperationsPerConnection() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Maximum allowed operations per connections before forcing the connection to close
getMaxOperationsPerConnection() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaxPendingConnectionsPerHost() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Maximum number of pending connect attempts per host
getMaxPendingConnectionsPerHost() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaxTimeoutCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Number of allowed timeouts within getTimeoutWindow() milliseconds
getMaxTimeoutCount() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMaxTimeoutWhenExhausted() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Maximum amount of time to wait for a connection to free up when a connection pool is exhausted.
getMaxTimeoutWhenExhausted() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getMean() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyInstanceImpl
 
getMean() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Instance
Get the mean for the sample window
getMeanLatency() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Get the average latency as calculated by the scoring strategy
getMeanLatency() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getMemtableFlushAfterMins() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
Deprecated. 
getMemtableFlushAfterMins() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
Deprecated. 
getMemtableOperationsInMillions() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
Deprecated. 
getMemtableOperationsInMillions() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
Deprecated. 
getMemtableThroughputInMb() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
Deprecated. 
getMemtableThroughputInMb() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
Deprecated. 
getMergeShardsChance() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getMergeShardsChance() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getMessage() - Method in exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
getMessage() - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
getMicrosTimeFromUUID(UUID) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
 
getMicrosTimeUUID(long) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
 
getMinCompactionThreshold() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getMinCompactionThreshold() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getMinimumToken() - Static method in class com.netflix.astyanax.util.TokenGenerator
 
getMutationMap() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
getName() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Unique name assigned to this connection pool
getName() - Method in class com.netflix.astyanax.connectionpool.Host
 
getName() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getName() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
getName() - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Get the column name
getName() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getName() - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
getName() - Method in interface com.netflix.astyanax.model.Column
Column or super column name
getName() - Method in class com.netflix.astyanax.model.ColumnFamily
 
getName() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getName() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
getName() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getName() - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
getName() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getName() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getName() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getName() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getNameByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
getNames() - Method in class com.netflix.astyanax.mapping.Mapping
Return the set of column names discovered from the bean class
getNext(ByteBuffer) - Method in interface com.netflix.astyanax.Serializer
Return the byte buffer for the next value in sorted order for the matching comparator type.
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BooleanSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.CharSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.CompositeSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DateSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DoubleSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.FloatSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.IntegerSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.LongSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ShortSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.TimeUUIDSerializer
 
getNext(ByteBuffer) - Method in class com.netflix.astyanax.serializers.UUIDSerializer
 
getNextBlock(KeyRange) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
getNextDelay() - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy.Instance
Return the next backoff delay in the strategy
getNextHostIndex() - Method in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
getNextMutation(long, TimeUnit) - Method in interface com.netflix.astyanax.impl.AckingQueue
Get the next item from the queue
getNextMutation(long, TimeUnit) - Method in class com.netflix.astyanax.util.BlockingAckingQueue
 
getNodeDiscovery() - Method in class com.netflix.astyanax.AstyanaxContext
 
getNodeDiscoveryType() - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
getNoHostCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getNoHostCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getNoHostCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getNoHostsCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getNumber() - Method in interface com.netflix.astyanax.model.CqlResult
 
getNumber() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlResultImpl
 
getNumBusyConnections() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getNumOpenConnections() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getObjectSize() - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
getOperationCount() - Method in interface com.netflix.astyanax.connectionpool.Connection
Number of operations performed on this connections since it was opened
getOperationFailureCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getOperationFailureCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getOperationFailureCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getOperationSuccessCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getOperationSuccessCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getOperationSuccessCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getOperationTimeoutCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getOperationTimeoutCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getOperationTimeoutCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getOperator() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
getOperator() - Method in interface com.netflix.astyanax.query.PreparedIndexExpression
 
getOriginalMessage() - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
getParameter() - Method in exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
getPartition(BigInteger) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
getPartition(BigInteger) - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Search for the partition that owns this token
getPartitionCount() - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
getPartitionCount() - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Get total number of tokens in the topology
getPassword() - Method in interface com.netflix.astyanax.AuthenticationCredentials
The password
getPassword() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
getPendingConnectionCount() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Get the number of pending connection open attempts
getPendingConnectionCount() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getPinnedHost() - Method in interface com.netflix.astyanax.connectionpool.Operation
Return the host to run on or null to select a host using the load blancer.
getPinnedHost() - Method in class com.netflix.astyanax.thrift.AbstractOperationImpl
 
getPool() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getPoolExhaustedTimeoutCount() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
 
getPoolExhaustedTimeoutCount() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
getPoolExhaustedTimeoutCount() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
getPools() - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
getPort() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Data port to be used when no port is specified to a list of seeds or when doing a ring describe since the ring describe does not include a host
getPort() - Method in class com.netflix.astyanax.connectionpool.Host
 
getPort() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getPredicate(ColumnSlice<C>, Serializer<C>) - Static method in class com.netflix.astyanax.thrift.ThriftConverter
Return a Hector SlicePredicate based on the provided column slice
getRawHostList() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
getRawHostList() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Get the raw list of nodes from the underlying refresh mechanism
getRawHostList() - Method in class com.netflix.astyanax.connectionpool.NodeDiscoveryMonitor
 
getRawHostList() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscoveryMonitorMBean
 
getRawHostList() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
getRawKey() - Method in interface com.netflix.astyanax.model.Row
Return the raw byte buffer for this key
getRawKey() - Method in class com.netflix.astyanax.thrift.model.ThriftRowImpl
 
getRawName() - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Get the raw column name.
getRawName() - Method in interface com.netflix.astyanax.model.Column
Return the raw byet buffer for the column name
getRawName() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getRawName() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
getRawName() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getRawName() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getRawName() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getRawName() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getReadRepairChance() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getReadRepairChance() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getRefreshCount() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
getRefreshCount() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Get the number of refreshes
getRefreshCount() - Method in class com.netflix.astyanax.connectionpool.NodeDiscoveryMonitor
 
getRefreshCount() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscoveryMonitorMBean
 
getRefreshCount() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
getRepeatLastToken() - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
getReplicateOnWrite() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getReplicateOnWrite() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getResetInterval() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
getResult() - Method in class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
getResult() - Method in interface com.netflix.astyanax.connectionpool.OperationResult
Get the result data
getRetryBackoffStrategy() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Return the backoff strategy to use.
getRetryBackoffStrategy() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getRetryDelaySlice() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
TODO
getRetryDelaySlice() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getRetryMaxDelaySlice() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
TODO
getRetryMaxDelaySlice() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getRetryPolicy() - Method in interface com.netflix.astyanax.AstyanaxConfiguration
TODO
getRetryPolicy() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
getRetrySuspendWindow() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
TODO
getRetrySuspendWindow() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getReversed() - Method in class com.netflix.astyanax.model.ColumnSlice
 
getRow(K) - Method in interface com.netflix.astyanax.model.Rows
Return the row for a specific key.
getRow(K) - Method in class com.netflix.astyanax.shallows.EmptyRowsImpl
 
getRow(K) - Method in class com.netflix.astyanax.thrift.model.ThriftCqlRowsImpl
 
getRow(K) - Method in class com.netflix.astyanax.thrift.model.ThriftRowsListImpl
 
getRow(K) - Method in class com.netflix.astyanax.thrift.model.ThriftRowsSliceImpl
 
getRow(K) - Method in class com.netflix.astyanax.thrift.ThriftAllRowsImpl
 
getRowByIndex(int) - Method in interface com.netflix.astyanax.model.Rows
Return a row by it's index in the response.
getRowByIndex(int) - Method in class com.netflix.astyanax.shallows.EmptyRowsImpl
 
getRowByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftCqlRowsImpl
 
getRowByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftRowsListImpl
 
getRowByIndex(int) - Method in class com.netflix.astyanax.thrift.model.ThriftRowsSliceImpl
 
getRowByIndex(int) - Method in class com.netflix.astyanax.thrift.ThriftAllRowsImpl
 
getRowCacheProvider() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getRowCacheProvider() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getRowCacheSavePeriodInSeconds() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getRowCacheSavePeriodInSeconds() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getRowCacheSize() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
getRowCacheSize() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getRowCount() - Method in interface com.netflix.astyanax.MutationBatch
Returns the number of rows being mutated
getRowCount() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
getRowKeys() - Method in interface com.netflix.astyanax.MutationBatch
Return a mapping of column families to rows being modified
getRowKeys() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
getRows() - Method in interface com.netflix.astyanax.model.CqlResult
 
getRows() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlResultImpl
 
getScore() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Return implementation specific score to be used by weighted pool selection algorithms
getScore() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
getScore() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyInstanceImpl
 
getScore() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Instance
Get the cached score for this endpoint
getSeedHosts() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Return a list of Host objects from the list of seeds returned by getSeeds().
getSeedHosts() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getSeeds() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
List of comma delimited host:port combinations.
getSeeds() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getSerializer() - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getSerializer() - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated. Return serializer for column names at the end of the path
getSerializer() - Method in enum com.netflix.astyanax.serializers.ComparatorType
 
getSerializer(Object) - Static method in class com.netflix.astyanax.serializers.SerializerTypeInferer
 
getSerializer(Class<?>) - Static method in class com.netflix.astyanax.serializers.SerializerTypeInferer
 
getSerializerPackage(String, boolean) - Method in interface com.netflix.astyanax.Keyspace
Return the serializer package for a specific column family.
getSerializerPackage(String, boolean) - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
getSerializersByPosition() - Method in class com.netflix.astyanax.model.AbstractComposite
 
getSerializerToComparatorMapping() - Method in class com.netflix.astyanax.model.AbstractComposite
 
getShortLength(ByteBuffer) - Static method in class com.netflix.astyanax.model.AbstractComposite
 
getSleepTimeMs() - Method in class com.netflix.astyanax.retry.BoundedExponentialBackoff
 
getSleepTimeMs() - Method in class com.netflix.astyanax.retry.ConstantBackoff
 
getSleepTimeMs() - Method in class com.netflix.astyanax.retry.ExponentialBackoff
 
getSleepTimeMs() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
getSocketTimeout() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Socket read/write timeout
getSocketTimeout() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getStart() - Method in interface com.netflix.astyanax.model.ByteBufferRange
 
getStart() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
Deprecated. 
getStart() - Method in class com.netflix.astyanax.util.ByteBufferRangeImpl
 
getStartColumn() - Method in class com.netflix.astyanax.model.ColumnSlice
 
getStartKey() - Method in class com.netflix.astyanax.model.KeySlice
 
getStartToken() - Method in class com.netflix.astyanax.connectionpool.impl.TokenRangeImpl
 
getStartToken() - Method in interface com.netflix.astyanax.connectionpool.TokenRange
 
getStartToken() - Method in class com.netflix.astyanax.model.KeySlice
 
getStrategyClass() - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
getStrategyClass() - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
getStrategyOptions() - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
getStrategyOptions() - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
getString(ByteBuffer) - Method in interface com.netflix.astyanax.Serializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.AsciiSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BooleanSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.BytesArraySerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.CharSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DateSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DoubleSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.FloatSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.IntegerSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.LongSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ShortSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.SpecificCompositeSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.StringSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.TimeUUIDSerializer
 
getString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.UUIDSerializer
 
getStringValue(C, String) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getStringValue() - Method in interface com.netflix.astyanax.model.Column
Return value as a string
getStringValue(C, String) - Method in interface com.netflix.astyanax.model.ColumnList
Return value as a string
getStringValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getStringValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getStringValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getStringValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getStringValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getSubColumns(Serializer<C2>) - Method in interface com.netflix.astyanax.model.Column
Deprecated. Super columns should be replaced with composite columns
getSubColumns(Serializer<C2>) - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getSubColumns(Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getSubColumns(Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getSubColumns(Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getSubColumns(Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getSuccessCount() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getSuccessCount() - Method in class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 
getSuperColumn(C, Serializer<C2>) - Method in interface com.netflix.astyanax.model.ColumnList
Deprecated. Super columns should be replaced with composite columns
getSuperColumn(int, Serializer<C2>) - Method in interface com.netflix.astyanax.model.ColumnList
Deprecated. Super columns should be replaced with composite columns
getSuperColumn(C, Serializer<C2>) - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
getSuperColumn(int, Serializer<C2>) - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
getSuperColumn(C, Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
getSuperColumn(int, Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
getSuperColumn(C, Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
getSuperColumn(int, Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
getSuperColumn(C, Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
getSuperColumn(int, Serializer<C2>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
getThriftColumnFamilyDefinition() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
getThriftKeyspaceDefinition() - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
getTimeCreated() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getTimeFromUUID(byte[]) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Retrieves the time as long based on the byte[] representation of a UUID.
getTimeFromUUID(UUID) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
 
getTimeoutWindow() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolConfiguration
Shut down a host if it times out too many time within this window
getTimeoutWindow() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
getTimesDown() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getTimestamp() - Method in interface com.netflix.astyanax.model.Column
Returns the column timestamp.
getTimestamp() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getTimestamp() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getTimestamp() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getTimestamp() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getTimestamp() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getTimesUp() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getTimeUUID(Clock) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Gets a new time uuid using ClockResolution#createClock() as a time generator.
getTimeUUID(long) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Gets a new time uuid based on time.
getToken() - Method in interface com.netflix.astyanax.connectionpool.Operation
Return the unique key on which the operation is performed or null if the operation is performed on multiple keys.
getToken() - Method in class com.netflix.astyanax.thrift.AbstractOperationImpl
 
getTtl() - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
getType() - Method in class com.netflix.astyanax.model.ColumnFamily
Deprecated. Super columns should be replaced with composite columns
getTypeName() - Method in enum com.netflix.astyanax.serializers.ComparatorType
 
getUniqueTimeUUIDinMicros() - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
 
getUniqueTimeUUIDinMillis() - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Gets a new and unique time uuid in milliseconds.
getUpdateInterval() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
getUpTime() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
getUrl() - Method in class com.netflix.astyanax.connectionpool.Host
 
getUsername() - Method in interface com.netflix.astyanax.AuthenticationCredentials
The username
getUsername() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
getUUIDValue(C, UUID) - Method in class com.netflix.astyanax.model.AbstractColumnList
 
getUUIDValue() - Method in interface com.netflix.astyanax.model.Column
Get the value as a UUID
getUUIDValue(C, UUID) - Method in interface com.netflix.astyanax.model.ColumnList
Get the value as a UUID
getUUIDValue() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getUUIDValue() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getUUIDValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getUUIDValue() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getUUIDValue() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getValidationClass() - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Return the value validation type.
getValidationClass() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
getValue() - Method in exception com.netflix.astyanax.connectionpool.exceptions.BadConfigurationException
 
getValue() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
getValue(Serializer<A>) - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getValue() - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
getValue(Serializer<V>) - Method in interface com.netflix.astyanax.model.Column
Return the value
getValue() - Method in interface com.netflix.astyanax.query.PreparedIndexExpression
 
getValue(Serializer<V>) - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
getValue(Serializer<V>) - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
getValue(Serializer<V>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
getValue(Serializer<V>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
getValue(Serializer<V>) - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
getValueSerializer() - Method in interface com.netflix.astyanax.SerializerPackage
Deprecated. use getDefaultValueSerializer()
getValueSerializer(ByteBuffer) - Method in interface com.netflix.astyanax.SerializerPackage
Deprecated. use getColumnSerializer()
getValueSerializer(String) - Method in interface com.netflix.astyanax.SerializerPackage
Deprecated. use getColumnSerializer
getValueSerializer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
Deprecated. 
getValueSerializer(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
Deprecated. 
getValueSerializer() - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
Deprecated. 
getVersion() - Method in interface com.netflix.astyanax.Cluster
Return version of cassandra running on the cluster
getVersion() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
Get the version from the cluster
getWindowSize() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
getWithShortLength(ByteBuffer) - Static method in class com.netflix.astyanax.model.AbstractComposite
 
greaterThan() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
greaterThan() - Method in interface com.netflix.astyanax.query.IndexOperationExpression
 
greaterThan() - Method in interface com.netflix.astyanax.query.PreparedIndexOperationExpression
 
greaterThan(Object) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
greaterThanEquals() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
greaterThanEquals() - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
greaterThanEquals() - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
greaterThanEquals() - Method in interface com.netflix.astyanax.query.IndexOperationExpression
 
greaterThanEquals() - Method in interface com.netflix.astyanax.query.PreparedIndexOperationExpression
 
greaterThanEquals(Object) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
growConnections(int) - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Create numConnections new connections and add them to the
growConnections(int) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 

H

handle(T) - Method in interface com.netflix.astyanax.recipes.Callback
 
handleEntry(K, V, ByteBuffer) - Method in interface com.netflix.astyanax.recipes.ReverseIndexQuery.IndexEntryCallback
 
hashCode() - Method in class com.netflix.astyanax.connectionpool.Host
 
hasHost(Host) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Return true if host is contained within the connection pool
hasHost(Host) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
hasHost(String) - Method in class com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitor
 
hasHost(String) - Method in interface com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitorMBean
 
hasIndex() - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Returns true if there is an index on this column
hasIndex() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
hasNext() - Method in class com.netflix.astyanax.shallows.EmptyIterator
 
hasNumber() - Method in interface com.netflix.astyanax.model.CqlResult
 
hasNumber() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlResultImpl
 
hasRows() - Method in interface com.netflix.astyanax.model.CqlResult
 
hasRows() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlResultImpl
 
hasTtl() - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
Host - Class in com.netflix.astyanax.connectionpool
 
Host(String, int) - Constructor for class com.netflix.astyanax.connectionpool.Host
 
HostConnectionPool<CL> - Interface in com.netflix.astyanax.connectionpool
Pool of connections for a single host
HostConnectionPoolPartition<CL> - Class in com.netflix.astyanax.connectionpool.impl
 
HostConnectionPoolPartition(BigInteger, LatencyScoreStrategy) - Constructor for class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
HostDownException - Exception in com.netflix.astyanax.connectionpool.exceptions
No more connections may be opened on a host and no timeout was specified.
HostDownException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.HostDownException
 
HostDownException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.HostDownException
 
HostDownException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.HostDownException
 
hosts - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
HostStats - Interface in com.netflix.astyanax.connectionpool
 
hostSupplier - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 

I

id() - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
Token or shard identifying this partition.
Id - Annotation Type in com.netflix.astyanax.mapping
 
incConnectionBorrowed(Host, long) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Incremented for each connection borrowed
incConnectionBorrowed(Host, long) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incConnectionBorrowed(Host, long) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incConnectionClosed(Host, Exception) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Closed a connection
incConnectionClosed(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incConnectionClosed(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
incConnectionClosed(Host, Exception) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incConnectionCreated(Host) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Created a connection successfully
incConnectionCreated(Host) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incConnectionCreated(Host) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incConnectionCreateFailed(Host, Exception) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Attempt to create a connection failed
incConnectionCreateFailed(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incConnectionCreateFailed(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
incConnectionCreateFailed(Host, Exception) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incConnectionReturned(Host) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Incremented for each connection returned.
incConnectionReturned(Host) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incConnectionReturned(Host) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incFailover(Host, Exception) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
An operation failed by the connection pool will attempt to fail over to another host/connection.
incFailover(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incFailover(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
incFailover(Host, Exception) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incNoHosts() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
There were no active hosts in the pool to borrow from.
incNoHosts() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incNoHosts() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incOperationFailure(Host, Exception) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Errors trying to execute an operation
incOperationFailure(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incOperationFailure(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
incOperationFailure(Host, Exception) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incOperationSuccess(Host, long) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Succeeded in executing an operation
incOperationSuccess(Host, long) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incOperationSuccess(Host, long) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incOperationTimeout() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Timeout waiting for a response from the cluster
incOperationTimeout() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incOperationTimeout() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incPoolExhaustedTimeout() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
Timeout trying to get a connection from the pool
incPoolExhaustedTimeout() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
incPoolExhaustedTimeout() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
incrementAndGet() - Method in class com.netflix.astyanax.util.BlockingConcurrentWindowCounter
 
incrementAndGet(long, TimeUnit) - Method in class com.netflix.astyanax.util.BlockingConcurrentWindowCounter
 
incrementCounterColumn(C, long) - Method in interface com.netflix.astyanax.ColumnListMutation
 
incrementCounterColumn(long) - Method in interface com.netflix.astyanax.ColumnMutation
 
incrementCounterColumn(C, long) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
incrementCounterColumn(C, long) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
incrementCounterColumn(C, long) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
indexClause - Variable in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
IndexColumnExpression<K,C> - Interface in com.netflix.astyanax.query
 
IndexOperationExpression<K,C> - Interface in com.netflix.astyanax.query
 
IndexOperator - Enum in com.netflix.astyanax.query
 
IndexQuery<K,C> - Interface in com.netflix.astyanax.query
 
IndexValueExpression<K,C> - Interface in com.netflix.astyanax.query
 
informException(ConnectionException) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
initInstance(T, ColumnList<String>) - Method in class com.netflix.astyanax.mapping.Mapping
Populate the given instance with the values from the given column list
insertValue(ByteBuffer, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
instance - Static variable in class com.netflix.astyanax.retry.RunOnce
 
Instance - Static variable in class com.netflix.astyanax.shallows.EmptyIterator
 
instance - Static variable in class com.netflix.astyanax.shallows.EmptyKeyspaceTracerFactory
 
instance - Static variable in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
IntegerSerializer - Class in com.netflix.astyanax.serializers
Converts bytes to Integer and vice versa
IntegerSerializer() - Constructor for class com.netflix.astyanax.serializers.IntegerSerializer
 
internalCreateInstance() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
internalExecute(Cassandra.Client) - Method in class com.netflix.astyanax.thrift.AbstractOperationImpl
 
internalRun() - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery.Task
 
intialToken(int, int) - Static method in class com.netflix.astyanax.util.TokenGenerator
 
ipPattern - Static variable in class com.netflix.astyanax.connectionpool.Host
 
IsDeadConnectionException - Interface in com.netflix.astyanax.connectionpool.exceptions
Describes an exception after which a connection is no longer usable.
isDynamic() - Method in class com.netflix.astyanax.model.AbstractComposite
 
isEmpty() - Method in interface com.netflix.astyanax.model.ColumnList
Indicates if the list of columns is empty
isEmpty() - Method in interface com.netflix.astyanax.model.Rows
Determine if the row list has data
isEmpty() - Method in interface com.netflix.astyanax.MutationBatch
Returns true if there are no rows in the mutation.
isEmpty() - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
isEmpty() - Method in class com.netflix.astyanax.shallows.EmptyRowsImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
Checks whether the mutation object contains rows.
isEmpty() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlRowsImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.model.ThriftRowsListImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.model.ThriftRowsSliceImpl
 
isEmpty() - Method in class com.netflix.astyanax.thrift.ThriftAllRowsImpl
 
isHostUp(Host) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Return true if the host is up
isHostUp(Host) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
isHostUp(String) - Method in class com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitor
 
isHostUp(String) - Method in interface com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitorMBean
 
isInRing() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
isPaginating - Variable in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
isPaginating - Variable in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
isParentColumn() - Method in interface com.netflix.astyanax.model.Column
Deprecated. Super columns should be replaced with composite columns
isParentColumn() - Method in class com.netflix.astyanax.shallows.EmptyColumn
 
isParentColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
isParentColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
isParentColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
isParentColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
IsRetryableException - Interface in com.netflix.astyanax.connectionpool.exceptions
Defines that an exception is retryable for the context of a single execute with failover.
isReversed() - Method in interface com.netflix.astyanax.model.ByteBufferRange
 
isReversed() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
Deprecated. 
isReversed() - Method in class com.netflix.astyanax.util.ByteBufferRangeImpl
 
isShutdown() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Determine if pool is shut down.
isShutdown() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
isSorted() - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
isSuperColumn() - Method in interface com.netflix.astyanax.model.ColumnList
Deprecated. Super columns should be replaced with composite columns
isSuperColumn() - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
isSuperColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
isSuperColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
isSuperColumn() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
IsTimeoutException - Interface in com.netflix.astyanax.connectionpool.exceptions
 
isUnique(K) - Method in class com.netflix.astyanax.recipes.UniquenessConstraint
 
isUnique(K) - Method in class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
isUp() - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
isValidForRead() - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
iterator() - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated.  
iterator() - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
iterator() - Method in class com.netflix.astyanax.shallows.EmptyRowsImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlRowsImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.model.ThriftRowsListImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.model.ThriftRowsSliceImpl
 
iterator() - Method in class com.netflix.astyanax.thrift.ThriftAllRowsImpl
Each call to .iterator() returns a new context starting at the beginning of the column family.

J

JaxbSerializer - Class in com.netflix.astyanax.serializers
Serializes Objects using Jaxb.
JaxbSerializer(Class...) - Constructor for class com.netflix.astyanax.serializers.JaxbSerializer
Constructor.
JmxConnectionPoolMonitor - Class in com.netflix.astyanax.connectionpool
MBean monitoring for a connection pool
JmxConnectionPoolMonitor(ConnectionPool<?>) - Constructor for class com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitor
 
JmxConnectionPoolMonitorMBean - Interface in com.netflix.astyanax.connectionpool
 
joinClassAttributeValues(T, String, Class<T>) - Static method in class com.netflix.astyanax.util.StringUtils
 
joinClassGettersValues(T, String, Class<T>) - Static method in class com.netflix.astyanax.util.StringUtils
 
JsonRowsWriter - Class in com.netflix.astyanax.util
 
JsonRowsWriter(PrintWriter, SerializerPackage) - Constructor for class com.netflix.astyanax.util.JsonRowsWriter
 
JsonRowsWriter.ErrorHandler - Interface in com.netflix.astyanax.util
 

K

key - Variable in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
keyAsByteBuffer(String) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a string key to a ByteBuffer using the package's key serializer
keyAsByteBuffer(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
keyAsString(ByteBuffer) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a key to a string using the package's key serializer
keyAsString(ByteBuffer) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
KeySlice<K> - Class in com.netflix.astyanax.model
Definition of a set of keys.
KeySlice(Collection<K>) - Constructor for class com.netflix.astyanax.model.KeySlice
 
KeySlice(K, K, String, String, int) - Constructor for class com.netflix.astyanax.model.KeySlice
 
Keyspace - Interface in com.netflix.astyanax
Interface providing access to mutate and query columns from a cassandra keyspace.
KeyspaceDefinition - Interface in com.netflix.astyanax.ddl
 
keyspaceName - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
KeyspaceTracerFactory - Interface in com.netflix.astyanax
TODO: Rename to AstyanaxTracerFactory
ks_def - Variable in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 

L

LatencyScoreStrategy - Interface in com.netflix.astyanax.connectionpool
 
LatencyScoreStrategy.Instance - Interface in com.netflix.astyanax.connectionpool
Single instance of this strategy associated with an endpoint
LatencyScoreStrategy.Listener - Interface in com.netflix.astyanax.connectionpool
 
LatencyScoreStrategyType - Enum in com.netflix.astyanax.connectionpool
 
length() - Method in class com.netflix.astyanax.model.ColumnPath
Deprecated. Return the path 'depth'
lessThan() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
lessThan() - Method in interface com.netflix.astyanax.query.IndexOperationExpression
 
lessThan() - Method in interface com.netflix.astyanax.query.PreparedIndexOperationExpression
 
lessThan(Object) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
lessThanEquals() - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
lessThanEquals() - Method in interface com.netflix.astyanax.model.CompositeBuilder
 
lessThanEquals() - Method in class com.netflix.astyanax.model.CompositeBuilderImpl
 
lessThanEquals() - Method in interface com.netflix.astyanax.query.IndexOperationExpression
 
lessThanEquals() - Method in interface com.netflix.astyanax.query.PreparedIndexOperationExpression
 
lessThanEquals(Object) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
limit(int) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
LOCK_TIMEOUT - Static variable in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
lockCurrentTimestamp() - Method in interface com.netflix.astyanax.MutationBatch
Deprecated. Mutation timestamps are now locked by default.
lockCurrentTimestamp() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
Deprecated. 
LongSerializer - Class in com.netflix.astyanax.serializers
Converts bytes to Long and vise a versa
LongSerializer() - Constructor for class com.netflix.astyanax.serializers.LongSerializer
 

M

make(Class<T>) - Static method in class com.netflix.astyanax.mapping.Mapping
Convenience for allocation a mapping object
make(Class<T>, AnnotationSet<?, ?>) - Static method in class com.netflix.astyanax.mapping.Mapping
Convenience for allocation a mapping object
makeColumnDefinition() - Method in interface com.netflix.astyanax.Cluster
Make a column definitio to be added to a ColumnFamilyDefinition
makeColumnDefinition() - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
makeColumnDefinition() - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
makeColumnDefinition() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
makeColumnFamilyDefinition() - Method in interface com.netflix.astyanax.Cluster
Prepare a column family definition.
makeColumnFamilyDefinition() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
makeEndpoint(T1, Equality) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer
 
makeKeyspaceDefinition() - Method in interface com.netflix.astyanax.Cluster
Prepare a keyspace definition.
makeKeyspaceDefinition() - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
makePartition(BigInteger) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
Mapping<T> - Class in com.netflix.astyanax.mapping
Utility for doing object/relational mapping between bean-like instances and Cassandra
Mapping(Class<T>) - Constructor for class com.netflix.astyanax.mapping.Mapping
 
Mapping(Class<T>, AnnotationSet<?, ?>) - Constructor for class com.netflix.astyanax.mapping.Mapping
 
MappingCache - Class in com.netflix.astyanax.mapping
Utility to cache mappers.
MappingCache() - Constructor for class com.netflix.astyanax.mapping.MappingCache
 
MappingUtil - Class in com.netflix.astyanax.mapping
Higher level mapping functions.
MappingUtil(Keyspace) - Constructor for class com.netflix.astyanax.mapping.MappingUtil
 
MappingUtil(Keyspace, AnnotationSet<?, ?>) - Constructor for class com.netflix.astyanax.mapping.MappingUtil
 
MappingUtil(Keyspace, MappingCache) - Constructor for class com.netflix.astyanax.mapping.MappingUtil
 
MappingUtil(Keyspace, MappingCache, AnnotationSet<?, ?>) - Constructor for class com.netflix.astyanax.mapping.MappingUtil
 
markAsDown(ConnectionException) - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Shut down the host so no more connections may be created when borrowConnections is called and connections will be terminated when returnConnection is called.
markAsDown(ConnectionException) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
Mark the host as down.
MaxConnsPerHostReachedException - Exception in com.netflix.astyanax.connectionpool.exceptions
No more connections may be opened on a host and no timeout was specified.
MaxConnsPerHostReachedException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.MaxConnsPerHostReachedException
 
MaxConnsPerHostReachedException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.MaxConnsPerHostReachedException
 
MaxConnsPerHostReachedException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.MaxConnsPerHostReachedException
 
MAXIMUM - Static variable in class com.netflix.astyanax.util.TokenGenerator
 
mergeShallow(MutationBatch) - Method in interface com.netflix.astyanax.MutationBatch
Perform a shallow merge of mutations from another batch.
mergeShallow(MutationBatch) - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
MicrosecondsAsyncClock - Class in com.netflix.astyanax.clock
 
MicrosecondsAsyncClock() - Constructor for class com.netflix.astyanax.clock.MicrosecondsAsyncClock
 
MicrosecondsClock - Class in com.netflix.astyanax.clock
 
MicrosecondsClock() - Constructor for class com.netflix.astyanax.clock.MicrosecondsClock
 
MicrosecondsSyncClock - Class in com.netflix.astyanax.clock
Clock which uses a rolling counter to avoid duplicates.
MicrosecondsSyncClock() - Constructor for class com.netflix.astyanax.clock.MicrosecondsSyncClock
 
MillisecondsClock - Class in com.netflix.astyanax.clock
 
MillisecondsClock() - Constructor for class com.netflix.astyanax.clock.MillisecondsClock
 
MINIMUM - Static variable in class com.netflix.astyanax.util.TokenGenerator
 
monitor - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
monitor - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
MultiRowUniquenessConstraint - Class in com.netflix.astyanax.recipes.uniqueness
Check uniqueness for multiple rows.
MultiRowUniquenessConstraint(Keyspace) - Constructor for class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
 
MUTATION_OVERHEAD - Static variable in class com.netflix.astyanax.thrift.ThriftUtils
 
MutationBatch - Interface in com.netflix.astyanax
Batch mutator which operates at the row level assuming the hierarchy: RowKey -> ColumnFamily -> Mutation.
MutationBatchExecutorWithQueue - Class in com.netflix.astyanax.util
 
MutationBatchExecutorWithQueue(AckingQueue, int) - Constructor for class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 

N

newColumnFamily(String, Serializer<K>, Serializer<C>) - Static method in class com.netflix.astyanax.model.ColumnFamily
 
newCompositeBuilder() - Static method in class com.netflix.astyanax.model.Composites
 
newCompositeParser(ByteBuffer) - Static method in class com.netflix.astyanax.model.Composites
 
newDeleter(ChunkedStorageProvider, String) - Static method in class com.netflix.astyanax.recipes.storage.ChunkedStorage
 
newDynamicCompositeBuilder() - Static method in class com.netflix.astyanax.model.Composites
 
newDynamicCompositeParser(ByteBuffer) - Static method in class com.netflix.astyanax.model.Composites
 
newExecuteWithFailover(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
Return a new failover context.
newExecuteWithFailover(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.BagOfConnectionsConnectionPoolImpl
 
newExecuteWithFailover(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.RoundRobinConnectionPoolImpl
 
newExecuteWithFailover(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.TokenAwareConnectionPoolImpl
 
newHostConnectionPool(Host, ConnectionFactory<CL>, ConnectionPoolConfiguration) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
newIndexClause() - Method in class com.netflix.astyanax.model.ColumnFamily
 
newInfoReader(ChunkedStorageProvider, String) - Static method in class com.netflix.astyanax.recipes.storage.ChunkedStorage
 
newInstance(ColumnList<String>) - Method in class com.netflix.astyanax.mapping.Mapping
Allocate a new instance and populate it with the values from the given column list
newQuery(Keyspace, ColumnFamily<K, C>, String, Serializer<V>) - Static method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
newReader(ChunkedStorageProvider, String, OutputStream) - Static method in class com.netflix.astyanax.recipes.storage.ChunkedStorage
 
newStringShardBuilder() - Static method in class com.netflix.astyanax.recipes.Shards
 
newTracer(CassandraOperationType) - Method in interface com.netflix.astyanax.KeyspaceTracerFactory
Create a tracer for cluster level operations
newTracer(CassandraOperationType, ColumnFamily<?, ?>) - Method in interface com.netflix.astyanax.KeyspaceTracerFactory
Create a tracer for a column family operation
newTracer(CassandraOperationType) - Method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracerFactory
 
newTracer(CassandraOperationType, ColumnFamily<?, ?>) - Method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracerFactory
 
newWriter(ChunkedStorageProvider, String, InputStream) - Static method in class com.netflix.astyanax.recipes.storage.ChunkedStorage
 
next() - Method in class com.netflix.astyanax.shallows.EmptyIterator
 
next() - Method in class com.netflix.astyanax.util.CsvColumnReader
 
next() - Method in class com.netflix.astyanax.util.CsvRecordReader
 
next() - Method in interface com.netflix.astyanax.util.RecordReader
 
nextComponent() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
NO_HOST - Static variable in class com.netflix.astyanax.connectionpool.Host
 
NoAvailableHostsException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
NoAvailableHostsException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.NoAvailableHostsException
 
NoAvailableHostsException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.NoAvailableHostsException
 
NoAvailableHostsException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.NoAvailableHostsException
 
NodeDiscovery - Interface in com.netflix.astyanax.connectionpool
Interface for a module that periodically updates the nodes in a connection pool.
NodeDiscoveryImpl - Class in com.netflix.astyanax.connectionpool.impl
Re-discover the ring on a fixed interval to identify new nodes or changes to the ring tokens.
NodeDiscoveryImpl(String, int, Supplier<Map<BigInteger, List<Host>>>, ConnectionPool<?>) - Constructor for class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
NodeDiscoveryMonitor - Class in com.netflix.astyanax.connectionpool
 
NodeDiscoveryMonitor(NodeDiscovery) - Constructor for class com.netflix.astyanax.connectionpool.NodeDiscoveryMonitor
 
NodeDiscoveryMonitorManager - Class in com.netflix.astyanax.connectionpool.impl
 
NodeDiscoveryMonitorMBean - Interface in com.netflix.astyanax.connectionpool
 
NodeDiscoveryType - Enum in com.netflix.astyanax.connectionpool
 
NoOpObjectReadCallback - Class in com.netflix.astyanax.recipes.storage
 
NoOpObjectReadCallback() - Constructor for class com.netflix.astyanax.recipes.storage.NoOpObjectReadCallback
 
NoOpObjectWriteCallback - Class in com.netflix.astyanax.recipes.storage
 
NoOpObjectWriteCallback() - Constructor for class com.netflix.astyanax.recipes.storage.NoOpObjectWriteCallback
 
NoOpWriteAheadLog - Class in com.netflix.astyanax.impl
 
NoOpWriteAheadLog() - Constructor for class com.netflix.astyanax.impl.NoOpWriteAheadLog
 
NotFoundException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
NotFoundException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.NotFoundException
 
NotUniqueException - Exception in com.netflix.astyanax.recipes.uniqueness
 
NotUniqueException() - Constructor for exception com.netflix.astyanax.recipes.uniqueness.NotUniqueException
 
NotUniqueException(Exception) - Constructor for exception com.netflix.astyanax.recipes.uniqueness.NotUniqueException
 
NotUniqueException(String, Exception) - Constructor for exception com.netflix.astyanax.recipes.uniqueness.NotUniqueException
 
NotUniqueException(String) - Constructor for exception com.netflix.astyanax.recipes.uniqueness.NotUniqueException
 

O

ObjectDeleter - Class in com.netflix.astyanax.recipes.storage
 
ObjectDeleter(ChunkedStorageProvider, String) - Constructor for class com.netflix.astyanax.recipes.storage.ObjectDeleter
 
ObjectInfoReader - Class in com.netflix.astyanax.recipes.storage
 
ObjectInfoReader(ChunkedStorageProvider, String) - Constructor for class com.netflix.astyanax.recipes.storage.ObjectInfoReader
 
ObjectMetadata - Class in com.netflix.astyanax.recipes.storage
 
ObjectMetadata() - Constructor for class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
ObjectReadCallback - Interface in com.netflix.astyanax.recipes.storage
 
ObjectReader - Class in com.netflix.astyanax.recipes.storage
 
ObjectReader(ChunkedStorageProvider, String, OutputStream) - Constructor for class com.netflix.astyanax.recipes.storage.ObjectReader
 
ObjectSerializer - Class in com.netflix.astyanax.serializers
The ObjectSerializer is used to turn objects into their binary representations.
ObjectSerializer() - Constructor for class com.netflix.astyanax.serializers.ObjectSerializer
 
ObjectWriteCallback - Interface in com.netflix.astyanax.recipes.storage
 
ObjectWriter - Class in com.netflix.astyanax.recipes.storage
 
ObjectWriter(ChunkedStorageProvider, String, InputStream) - Constructor for class com.netflix.astyanax.recipes.storage.ObjectWriter
 
onChunk(int, ByteBuffer) - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectReadCallback
 
onChunk(int, int) - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectWriteCallback
 
onChunk(int, ByteBuffer) - Method in interface com.netflix.astyanax.recipes.storage.ObjectReadCallback
 
onChunk(int, int) - Method in interface com.netflix.astyanax.recipes.storage.ObjectWriteCallback
 
onChunkException(int, Exception) - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectReadCallback
 
onChunkException(int, Exception) - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectWriteCallback
 
onChunkException(int, Exception) - Method in interface com.netflix.astyanax.recipes.storage.ObjectReadCallback
 
onChunkException(int, Exception) - Method in interface com.netflix.astyanax.recipes.storage.ObjectWriteCallback
 
onException(ConnectionException) - Method in interface com.netflix.astyanax.ExceptionCallback
 
onException(Exception) - Method in interface com.netflix.astyanax.util.JsonRowsWriter.ErrorHandler
 
onFailure(Exception) - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectReadCallback
 
onFailure(Exception) - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectWriteCallback
 
onFailure(Exception) - Method in interface com.netflix.astyanax.recipes.storage.ObjectReadCallback
 
onFailure(Exception) - Method in interface com.netflix.astyanax.recipes.storage.ObjectWriteCallback
 
onHostAdded(Host, HostConnectionPool<?>) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
A host was added and given the associated pool.
onHostAdded(Host, HostConnectionPool<?>) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
onHostAdded(Host, HostConnectionPool<?>) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
onHostAdded(Host, HostConnectionPool<?>) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
onHostDown(Host, Exception) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
A host was identified as downed.
onHostDown(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
onHostDown(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
onHostDown(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool.Listener
 
onHostDown(Host, Exception) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
onHostDown(Host, Exception) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
onHostReactivated(Host, HostConnectionPool<?>) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
A host was reactivated after being marked down
onHostReactivated(Host, HostConnectionPool<?>) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
onHostReactivated(Host, HostConnectionPool<?>) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
onHostReactivated(Host, HostConnectionPool<?>) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
onHostRemoved(Host) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPoolMonitor
A host was removed from the pool.
onHostRemoved(Host) - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
onHostRemoved(Host) - Method in class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
onHostRemoved(Host) - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
onHostUp(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
onHostUp(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool.Listener
 
onReset() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Listener
 
onSuccess() - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectReadCallback
 
onSuccess() - Method in class com.netflix.astyanax.recipes.storage.NoOpObjectWriteCallback
 
onSuccess() - Method in interface com.netflix.astyanax.recipes.storage.ObjectReadCallback
 
onSuccess() - Method in interface com.netflix.astyanax.recipes.storage.ObjectWriteCallback
 
onUpdate() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Listener
 
onViolation(K, C) - Method in interface com.netflix.astyanax.recipes.UniquenessConstraintViolationMonitor
 
open() - Method in interface com.netflix.astyanax.connectionpool.Connection
Open a new connection
openAsync(Connection.AsyncOpenCallback<CL>) - Method in interface com.netflix.astyanax.connectionpool.Connection
Open a connection asynchronously and call the callback on connection or failure
openConnection() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
This open is different from borrowConnection in that it actually creates a new connection without waiting for one that may be idle.
openConnection() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
Open a new connection synchronously
Operation<CL,R> - Interface in com.netflix.astyanax.connectionpool
Callback interface to perform an operation on a client associated with a connection pool's connection resource
OperationException - Exception in com.netflix.astyanax.connectionpool.exceptions
Application exception for an operation executed within the context of the connection pool.
OperationException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.OperationException
 
OperationException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.OperationException
 
OperationException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.OperationException
 
OperationResult<R> - Interface in com.netflix.astyanax.connectionpool
 
OperationResultImpl<R> - Class in com.netflix.astyanax.connectionpool.impl
 
OperationResultImpl(Host, R, long) - Constructor for class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
OperationTimeoutException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
OperationTimeoutException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.OperationTimeoutException
 
OperationTimeoutException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.OperationTimeoutException
 
OperationTimeoutException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.OperationTimeoutException
 

P

paginateNoMore - Variable in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
paginateNoMore - Variable in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
parseHostFromUrl(String) - Static method in class com.netflix.astyanax.connectionpool.Host
Parse the hostname from a "hostname:port" formatted string
parsePortFromUrl(String, int) - Static method in class com.netflix.astyanax.connectionpool.Host
Parse the port from a "hostname:port" formatted string
pinToHost(Host) - Method in interface com.netflix.astyanax.MutationBatch
Pin this operation to a specific host
pinToHost(Host) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Run the query on the specified host
pinToHost(Host) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
poll(Supplier<T>) - Method in class com.netflix.astyanax.recipes.storage.AutoAllocatingLinkedBlockingQueue
 
pool - Variable in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
pools - Variable in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
PoolTimeoutException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
PoolTimeoutException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.PoolTimeoutException
 
PoolTimeoutException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.PoolTimeoutException
 
PoolTimeoutException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.PoolTimeoutException
 
predicate - Variable in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
predicate - Variable in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
predicate - Variable in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
predicate - Variable in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
PrefixedSerializer<P,S> - Class in com.netflix.astyanax.serializers
 
PrefixedSerializer(P, Serializer<P>, Serializer<S>) - Constructor for class com.netflix.astyanax.serializers.PrefixedSerializer
 
prepareColumnMutation(ColumnFamily<K, C>, K, C) - Method in interface com.netflix.astyanax.Keyspace
Mutation for a single column
prepareColumnMutation(ColumnFamily<K, C>, K, C) - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
PreparedIndexColumnExpression<K,C> - Interface in com.netflix.astyanax.query
 
PreparedIndexExpression<K,C> - Interface in com.netflix.astyanax.query
 
PreparedIndexExpressionImpl<K,C> - Class in com.netflix.astyanax.impl
 
PreparedIndexExpressionImpl(Serializer<C>) - Constructor for class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
PreparedIndexOperationExpression<K,C> - Interface in com.netflix.astyanax.query
 
PreparedIndexValueExpression<K,C> - Interface in com.netflix.astyanax.query
 
prepareMutationBatch() - Method in interface com.netflix.astyanax.Keyspace
Prepare a batch mutation object.
prepareMutationBatch() - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
prepareQuery(ColumnFamily<K, C>) - Method in interface com.netflix.astyanax.Keyspace
Starting point for constructing a query.
prepareQuery(ColumnFamily<K, C>) - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
prepend(List<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
Prepend a list of ByteBuffers to this stream.
pushMutation(MutationBatch) - Method in interface com.netflix.astyanax.impl.AckingQueue
Insert an item into the queue
pushMutation(MutationBatch) - Method in class com.netflix.astyanax.util.BlockingAckingQueue
 
put(ColumnFamily<K, String>, T) - Method in class com.netflix.astyanax.mapping.MappingUtil
Add/update the given item
putColumn(C, V, Serializer<V>, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
Generic call to insert a column value with a custom serializer.
putColumn(C, String, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, byte[], Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, int, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, long, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, boolean, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, ByteBuffer, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, Date, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, float, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, double, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, UUID, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putColumn(C, V, Serializer<V>, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, String, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, byte[], Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, int, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, long, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, boolean, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, ByteBuffer, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, Date, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, float, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, double, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, UUID, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putColumn(C, V, Serializer<V>, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, String, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, byte[], Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, int, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, long, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, boolean, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, ByteBuffer, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, Date, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, float, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, double, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, UUID, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putColumn(C, V, Serializer<V>, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, String, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, byte[], Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, int, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, long, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, boolean, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, ByteBuffer, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, Date, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, float, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, double, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putColumn(C, UUID, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putEmptyColumn(C, Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
 
putEmptyColumn(Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putEmptyColumn(Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putEmptyColumn(C, Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
putEmptyColumn(C, Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
putEmptyColumn(C, Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
putValue(String, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(byte[], Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(int, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(long, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(boolean, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(ByteBuffer, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(Date, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(double, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(UUID, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(T, Serializer<T>, Integer) - Method in interface com.netflix.astyanax.ColumnMutation
 
putValue(String, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(byte[], Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(int, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(long, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(boolean, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(ByteBuffer, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(Date, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(double, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(UUID, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 
putValue(T, Serializer<T>, Integer) - Method in class com.netflix.astyanax.thrift.AbstractThriftColumnMutationImpl
 

R

RANGE_ALL - Static variable in class com.netflix.astyanax.thrift.ThriftUtils
 
RangeBuilder - Class in com.netflix.astyanax.util
Utility builder to construct a ByteBufferRange to be used in a slice query.
RangeBuilder() - Constructor for class com.netflix.astyanax.util.RangeBuilder
 
RangeEndpoint - Interface in com.netflix.astyanax.model
 
RateLimiter - Interface in com.netflix.astyanax.connectionpool
Very very simple interface for a rate limiter.
read(Serializer<T>) - Method in interface com.netflix.astyanax.model.CompositeParser
 
read(Serializer<T>) - Method in class com.netflix.astyanax.model.CompositeParserImpl
 
readBoolean() - Method in interface com.netflix.astyanax.model.CompositeParser
 
readBoolean() - Method in class com.netflix.astyanax.model.CompositeParserImpl
 
readChunk(String, int) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
readChunk(String, int) - Method in interface com.netflix.astyanax.recipes.storage.ChunkedStorageProvider
Read the request chunk id from the storage
readInteger() - Method in interface com.netflix.astyanax.model.CompositeParser
 
readInteger() - Method in class com.netflix.astyanax.model.CompositeParserImpl
 
readLockColumns() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Return a mapping of existing lock columns and their expiration time
readLong() - Method in interface com.netflix.astyanax.model.CompositeParser
 
readLong() - Method in class com.netflix.astyanax.model.CompositeParserImpl
 
readMetadata(String) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
readMetadata(String) - Method in interface com.netflix.astyanax.recipes.storage.ChunkedStorageProvider
Retrieve information for a file
readMutation(MutationBatch) - Method in interface com.netflix.astyanax.WriteAheadEntry
Fill a MutationBatch from the data in this entry
readNextEntry() - Method in class com.netflix.astyanax.impl.NoOpWriteAheadLog
 
readNextEntry() - Method in interface com.netflix.astyanax.WriteAheadLog
Read the next entry to retry from the wall.
readString() - Method in interface com.netflix.astyanax.model.CompositeParser
 
readString() - Method in class com.netflix.astyanax.model.CompositeParserImpl
 
readUUID() - Method in interface com.netflix.astyanax.model.CompositeParser
 
readUUID() - Method in class com.netflix.astyanax.model.CompositeParserImpl
 
rebuildPartitions() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
Called every time a host is added, removed or is marked as down
RecordReader - Interface in com.netflix.astyanax.util
 
RecordWriter - Interface in com.netflix.astyanax.util
 
refresh() - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
refresh() - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
refresh() - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Refresh the internal state and apply the latency score strategy
registerMonitor(String, ConnectionPool<?>) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolMBeanManager
 
registerMonitor(String, NodeDiscovery) - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryMonitorManager
 
release() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Release the lock by releasing this and any other stale lock columns
release() - Method in interface com.netflix.astyanax.recipes.locks.DistributedRowLock
 
release() - Method in class com.netflix.astyanax.recipes.uniqueness.ColumnPrefixUniquenessConstraint
 
release() - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
 
release() - Method in class com.netflix.astyanax.recipes.uniqueness.RowUniquenessConstraint
 
release() - Method in interface com.netflix.astyanax.recipes.uniqueness.UniquenessConstraint
Release the uniqueness lock for this row.
release(int) - Method in class com.netflix.astyanax.util.BlockingConcurrentWindowCounter
 
releaseAllLocks() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Release all locks.
releaseConnection() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
releaseExpiredLocks() - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Release all expired locks for this key.
releaseLocks(boolean) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Delete locks columns.
remove(ColumnFamily<K, String>, T) - Method in class com.netflix.astyanax.mapping.MappingUtil
Remove the given item
remove(int) - Method in class com.netflix.astyanax.model.AbstractComposite
 
remove() - Method in class com.netflix.astyanax.shallows.EmptyIterator
 
removeAll(Collection<?>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
removeAttribute(String) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
removeEntry(WriteAheadEntry) - Method in class com.netflix.astyanax.impl.NoOpWriteAheadLog
 
removeEntry(WriteAheadEntry) - Method in interface com.netflix.astyanax.WriteAheadLog
Remove an entry from the WAL after it was successfully written to cassandra
removeHost(Host, boolean) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Remove a host from the connection pool.
removeHost(Host, boolean) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
removeHost(String) - Method in class com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitor
 
removeHost(String) - Method in interface com.netflix.astyanax.connectionpool.JmxConnectionPoolMonitorMBean
 
removeInstance(BadHostDetector.Instance) - Method in interface com.netflix.astyanax.connectionpool.BadHostDetector
 
removeInstance(BadHostDetector.Instance) - Method in class com.netflix.astyanax.connectionpool.impl.BadHostDetectorImpl
 
removeInstance(LatencyScoreStrategy.Instance) - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
removeInstance(LatencyScoreStrategy.Instance) - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Remove the instance for an endpoint that is no longer being tracked
removeInstance(BadHostDetector.Instance) - Method in class com.netflix.astyanax.shallows.EmptyBadHostDetectorImpl
 
removeInstance(LatencyScoreStrategy.Instance) - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
removePool(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
removePool(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
removePool(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Remove this pool from all partitions
replayWal(int) - Method in class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
Replay records from the WAL
repushMutation(MutationBatch) - Method in interface com.netflix.astyanax.impl.AckingQueue
Return a mutation that couldn't be retried for it be requeued and retryed later
repushMutation(MutationBatch) - Method in class com.netflix.astyanax.util.BlockingAckingQueue
 
reset() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
reset() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyInstanceImpl
 
reset() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Instance
Reset the score and any internal stats
reset() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Reset all instance scores
reset() - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
reset() - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
resumePool(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
resumePool(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Resume a host that was previously down
retainAll(Collection<?>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
RetryBackoffStrategy - Interface in com.netflix.astyanax.connectionpool
Strategy used to calculate how much to back off for each subsequent attempt to reconnect to a downed host
RetryBackoffStrategy.Callback - Interface in com.netflix.astyanax.connectionpool
 
RetryBackoffStrategy.Instance - Interface in com.netflix.astyanax.connectionpool
 
retryEntry(WriteAheadEntry) - Method in class com.netflix.astyanax.impl.NoOpWriteAheadLog
 
retryEntry(WriteAheadEntry) - Method in interface com.netflix.astyanax.WriteAheadLog
Retry an entry retrieved by calling getNextEntry();
RetryNTimes - Class in com.netflix.astyanax.retry
 
RetryNTimes(int) - Constructor for class com.netflix.astyanax.retry.RetryNTimes
 
RetryPolicy - Interface in com.netflix.astyanax.retry
Interface for any retry logic
returnConnection(Connection<CL>) - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Return a connection to the host's pool.
returnConnection(Connection<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.BagOfConnectionsConnectionPoolImpl
 
returnConnection(Connection<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
Return a connection to this host
reverse() - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
ReverseIndexQuery<K,C,V> - Class in com.netflix.astyanax.recipes
Performs a search on a reverse index and fetches all the matching rows CFData:K C=V1 C=V2 CFIndex: V1:K
ReverseIndexQuery(Keyspace, ColumnFamily<K, C>, String, Serializer<V>) - Constructor for class com.netflix.astyanax.recipes.ReverseIndexQuery
 
ReverseIndexQuery.IndexEntryCallback<K,V> - Interface in com.netflix.astyanax.recipes
 
ReverseIndexQuery.Task - Class in com.netflix.astyanax.recipes
 
ReverseIndexQuery.Task() - Constructor for class com.netflix.astyanax.recipes.ReverseIndexQuery.Task
 
RingDescribeHostSupplier - Class in com.netflix.astyanax.impl
 
RingDescribeHostSupplier(Keyspace, int) - Constructor for class com.netflix.astyanax.impl.RingDescribeHostSupplier
 
RoundRobinConnectionPoolImpl<CL> - Class in com.netflix.astyanax.connectionpool.impl
Connection pool implementation using simple round robin.
RoundRobinConnectionPoolImpl(ConnectionPoolConfiguration, ConnectionFactory<CL>, ConnectionPoolMonitor) - Constructor for class com.netflix.astyanax.connectionpool.impl.RoundRobinConnectionPoolImpl
 
RoundRobinExecuteWithFailover<CL,R> - Class in com.netflix.astyanax.connectionpool.impl
 
RoundRobinExecuteWithFailover(ConnectionPoolConfiguration, ConnectionPoolMonitor, List<HostConnectionPool<CL>>, int) - Constructor for class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
Row<K,C> - Interface in com.netflix.astyanax.model
Instance of a row with key type K and column name type C.
RowCallback<K,C> - Interface in com.netflix.astyanax
 
RowCopier<K,C> - Interface in com.netflix.astyanax
 
RowQuery<K,C> - Interface in com.netflix.astyanax.query
Interface to narrow down the path and column slices within a query after the keys were seleted using the ColumnFamilyQuery.
Rows<K,C> - Interface in com.netflix.astyanax.model
Interface to a collection or Rows with key type K and column type C.
RowSliceQuery<K,C> - Interface in com.netflix.astyanax.query
Interface to narrow down the path and column slices within a query after the keys were seleted using the ColumnFamilyQuery.
RowsWriter - Interface in com.netflix.astyanax.util
 
RowUniquenessConstraint<K,C> - Class in com.netflix.astyanax.recipes.uniqueness
Test uniqueness for a single row.
RowUniquenessConstraint(Keyspace, ColumnFamily<K, C>, K, Supplier<C>) - Constructor for class com.netflix.astyanax.recipes.uniqueness.RowUniquenessConstraint
 
run() - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery.Task
 
RunOnce - Class in com.netflix.astyanax.retry
 
RunOnce() - Constructor for class com.netflix.astyanax.retry.RunOnce
 

S

SchemaDisagreementException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
SchemaDisagreementException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.SchemaDisagreementException
 
searchWithIndex() - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Search for keys matching the provided index clause
searchWithIndex() - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
SerializationException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
SerializationException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.SerializationException
 
SerializationException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.SerializationException
 
SerializationException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.SerializationException
 
serialize() - Method in class com.netflix.astyanax.model.AbstractComposite
 
serialize() - Method in interface com.netflix.astyanax.MutationBatch
Serialize the entire mutation batch into a ByteBuffer.
serialize(Object) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer.ComponentSerializer
 
serialize() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
Serializer<T> - Interface in com.netflix.astyanax
Serializes a type T from the given bytes, or vice a versa.
serializer - Variable in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
SerializerPackage - Interface in com.netflix.astyanax
Grouping of serializers for a single column family.
SerializerPackageImpl - Class in com.netflix.astyanax.serializers
Basic implementation of SerializerPackage which can be configured either from a ColumnFamilyDefinition or by manually setting either the ComparatorType or Serializer for keys, columns and values.
SerializerPackageImpl() - Constructor for class com.netflix.astyanax.serializers.SerializerPackageImpl
 
SerializerPackageImpl(ColumnFamilyDefinition, boolean) - Constructor for class com.netflix.astyanax.serializers.SerializerPackageImpl
Construct a serializer package from a column family definition retrieved from the keyspace.
SerializerTypeInferer - Class in com.netflix.astyanax.serializers
Utility class that infers the concrete Serializer needed to turn a value into its binary representation
SerializerTypeInferer() - Constructor for class com.netflix.astyanax.serializers.SerializerTypeInferer
 
serializeValue(Object) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer.ComponentSerializer
 
set(int, Object) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setAliasesToComparatorMapping(Map<Byte, String>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setAsyncExecutor(ExecutorService) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setAttempt(int) - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
setAttemptsCount(int) - Method in class com.netflix.astyanax.connectionpool.impl.OperationResultImpl
 
setAttemptsCount(int) - Method in interface com.netflix.astyanax.connectionpool.OperationResult
Set the number of attempts executing this connection
setAttribute(String, Object) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
setAuthenticationCredentials(AuthenticationCredentials) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setBadHostDetector(BadHostDetector) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setBatchSize(int) - Method in class com.netflix.astyanax.util.ColumnarRecordWriter
 
setBlockSize(int) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Deprecated. Use setRowLimit instead
setBlockSize(int) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
setChunkCount(Integer) - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
setChunkSize(Integer) - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
setClock(Clock) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setColumnNameSerializer(Serializer<?>) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setColumnNameSupplier(Supplier<String>) - Method in class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
setColumnNameType(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setColumnsAsRows(boolean) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setColumnType(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
Deprecated. 
setColumnValue(T, String, V) - Method in class com.netflix.astyanax.mapping.Mapping
Set the value for the given column for the given instance
setComment(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setComment(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setComparatorByPosition(int, String) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setComparatorsByPosition(List<String>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setComparatorsByPosition(String...) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setComparatorType(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setComparatorType(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setComponent(int, T, Serializer<T>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setComponent(int, T, Serializer<T>, String) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setComponent(int, T, Serializer<T>, String, AbstractComposite.ComponentEquality) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setComponents(List<AbstractComposite.Component<?>>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setConnectionLimiterMaxPendingCount(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setConnectionLimiterWindowSize(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setConnectionPoolType(ConnectionPoolType) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setConnectTimeout(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setConsistencyLevel(ConsistencyLevel) - Method in interface com.netflix.astyanax.ColumnMutation
 
setConsistencyLevel(ConsistencyLevel) - Method in interface com.netflix.astyanax.MutationBatch
Set the consistency level for this mutation
setConsistencyLevel(ConsistencyLevel) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Set the consistency level for this operations.
setConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
setConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
setConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
setCountName(String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setDefaultReadConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setDefaultTtl(Integer) - Method in interface com.netflix.astyanax.ColumnListMutation
Set the default TTL to use when null is specified to a column insert.
setDefaultTtl(Integer) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
setDefaultTtl(Integer) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
setDefaultTtl(Integer) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
setDefaultValidationClass(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setDefaultValidationClass(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setDefaultValueSerializer(Serializer<?>) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setDefaultValueType(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setDefaultWriteConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setDiscoveryDelayInSeconds(int) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setDiscoveryType(NodeDiscoveryType) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setDynamicColumnNames(boolean) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setEnd(String) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(byte[]) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(int) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(long) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(boolean) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(ByteBuffer) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(Date) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(double) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(UUID) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setEnd(T, Serializer<T>) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setErrorValueText(String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setExceptionCallback(ExceptionCallback) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Sets the exception handler to use when handling exceptions inside Iterator.next().
setExceptionCallback(ExceptionCallback) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
setExceptionCallback(ExceptionCallback) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setExtra(String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setFixedColumnNames(String...) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setHasHeaderLine(boolean) - Method in class com.netflix.astyanax.util.CsvColumnReader
 
setHasHeaderLine(boolean) - Method in class com.netflix.astyanax.util.CsvRecordReader
 
setHost(Host) - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
setHosts(Map<BigInteger, List<Host>>) - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Sets the complete set of hosts keyed by token.
setHosts(Map<BigInteger, List<Host>>) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
setId(String) - Method in class com.netflix.astyanax.connectionpool.Host
 
setId(int) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setId(int) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setIdValue(T, V) - Method in class com.netflix.astyanax.mapping.Mapping
Set the value for the ID/Key column for the given instance
setIgnoreColumnNames(String...) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setIgnoreUndefinedColumns(boolean) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setIndex(String, String) - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Sets an index on this column.
setIndex(String, String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
setInitConnsPerHost(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setIsPaginating() - Method in interface com.netflix.astyanax.query.IndexQuery
Deprecated. autoPaginateRows()
setIsPaginating() - Method in interface com.netflix.astyanax.query.RowQuery
Deprecated. 
setIsPaginating() - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
setIsPaginating() - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
setKeyAlias(ByteBuffer) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setKeyAlias(ByteBuffer) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setKeyCacheSavePeriodInSeconds(int) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setKeyCacheSavePeriodInSeconds(int) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setKeyCacheSize(double) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setKeyCacheSize(double) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setKeySerializer(Serializer<?>) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setKeysIndex(String) - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Sets a keys index on this column
setKeysIndex(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
setKeyspace(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setKeyspace(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setKeyType(String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setKeyValidationClass(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setKeyValidationClass(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setLatency(long) - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
setLatencyAwareBadnessThreshold(float) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setLatencyAwareResetInterval(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setLatencyAwareSentinelCompare(float) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setLatencyAwareUpdateInterval(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setLatencyAwareWindowSize(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setLatencyScoreStrategy(LatencyScoreStrategy) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setLatencyWithPool(long) - Method in exception com.netflix.astyanax.connectionpool.exceptions.ConnectionException
 
setLimit(int) - Method in class com.netflix.astyanax.model.ColumnSlice
 
setLimit(int) - Method in interface com.netflix.astyanax.query.IndexQuery
Deprecated. Use setRowLimit instead
setLimit(int) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
setLimit(int) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setMaxBlockedThreadsPerHost(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxConns(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxConnsPerHost(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxFailoverCount(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxLength(int) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setMaxOperationsPerConnection(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxPendingConnectionsPerHost(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxSize(int) - Method in class com.netflix.astyanax.util.RangeBuilder
Deprecated. use setLimit instead
setMaxTimeoutCount(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMaxTimeoutWhenExhausted(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setMemtableFlushAfterMins(int) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
Deprecated. 
setMemtableFlushAfterMins(int) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
Deprecated. 
setMemtableOperationsInMillions(double) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
Deprecated. 
setMemtableOperationsInMillions(double) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
Deprecated. 
setMemtableThroughputInMb(int) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
Deprecated. 
setMemtableThroughputInMb(int) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
Deprecated. 
setMergeShardsChance(double) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setMergeShardsChance(double) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setMinCompactionThreshold(int) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setMinCompactionThreshold(int) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setMonitor(UniquenessConstraintViolationMonitor<K, C>) - Method in class com.netflix.astyanax.recipes.UniquenessConstraint
 
setMonitor(UniquenessConstraintViolationMonitor<K, String>) - Method in class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
setName(String) - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Sets the column name
setName(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setName(String) - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
setName(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
setName(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setName(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
setNames(String...) - Method in class com.netflix.astyanax.util.CsvRecordReader
 
setNamesName(String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setNextStartKey(ByteBuffer) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
setObjectSize(Long) - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
setPassword(String) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
setPool(HostConnectionPool<?>) - Method in interface com.netflix.astyanax.connectionpool.HostStats
 
setPools(Collection<HostConnectionPool<CL>>) - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
Sets all pools for this partition.
setPools(Map<BigInteger, Collection<HostConnectionPool<CL>>>) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
setPools(Map<BigInteger, Collection<HostConnectionPool<CL>>>) - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Refresh the internal topology structure
setPort(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setPrefix(String) - Method in class com.netflix.astyanax.recipes.Shards.StringShardBuilder
 
setPrefix(String) - Method in class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
setReadRepairChance(double) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setReadRepairChance(double) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setRepeatLastToken(boolean) - Method in interface com.netflix.astyanax.query.AllRowsQuery
If true will repeat the last token in the previous block.
setRepeatLastToken(boolean) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
setReplicateOnWrite(boolean) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setReplicateOnWrite(boolean) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setRetryBackoffStrategy(RetryBackoffStrategy) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setRetryDelaySlice(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setRetryMaxDelaySlice(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setRetryPolicy(RetryPolicy) - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
setRetrySuspendWindow(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setReversed(boolean) - Method in class com.netflix.astyanax.model.ColumnSlice
 
setReversed() - Method in class com.netflix.astyanax.util.RangeBuilder
Deprecated. Use setReversed(boolean reversed)
setReversed(boolean) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setRowCacheProvider(String) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setRowCacheProvider(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setRowCacheSavePeriodInSeconds(int) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setRowCacheSavePeriodInSeconds(int) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setRowCacheSize(double) - Method in interface com.netflix.astyanax.ddl.ColumnFamilyDefinition
 
setRowCacheSize(double) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
setRowKeyName(String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setRowLimit(int) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Maximum number of rows to return for each incremental query to Cassandra.
setRowLimit(int) - Method in interface com.netflix.astyanax.query.IndexQuery
Limits the number of rows returned
setRowLimit(int) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
setRowLimit(int) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
setRowsAsArray(boolean) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setRowsName(String) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
setSeeds(String) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setSerializerByPosition(int, Serializer<?>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setSerializersByPosition(List<Serializer<?>>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setSerializersByPosition(Serializer<?>...) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setSerializerToComparatorMapping(Map<Class<? extends Serializer>, String>) - Method in class com.netflix.astyanax.model.AbstractComposite
 
setShardBlockSize(int) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
Set the number shard keys to fetch for the first query
setShardCount(int) - Method in class com.netflix.astyanax.recipes.Shards.StringShardBuilder
 
setShardNextPageSize(int) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
setShardPageSize(int) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
Set the number columns to read from each shard when paginating.
setSocketTimeout(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setStart(String) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(byte[]) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(int) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(long) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(boolean) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(ByteBuffer) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(Date) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(double) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(UUID) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStart(T, Serializer<T>) - Method in class com.netflix.astyanax.util.RangeBuilder
 
setStartKey(K) - Method in interface com.netflix.astyanax.query.IndexQuery
?
setStartKey(K) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
setStrategyClass(String) - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
setStrategyClass(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
setStrategyOptions(Map<String, String>) - Method in interface com.netflix.astyanax.ddl.KeyspaceDefinition
 
setStrategyOptions(Map<String, String>) - Method in class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
setTimeout(long) - Method in interface com.netflix.astyanax.MutationBatch
Deprecated. 
setTimeout(long) - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
setTimeoutWindow(int) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
setTimestamp(long) - Method in interface com.netflix.astyanax.ColumnListMutation
 
setTimestamp(long) - Method in interface com.netflix.astyanax.MutationBatch
Set the timestamp for all subsequent operations on this mutation
setTimestamp(long) - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
setTimestamp(long) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
setTimestamp(long) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
setTimestamp(long) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
setTtl(Integer) - Method in class com.netflix.astyanax.recipes.storage.ObjectMetadata
 
setTtl(Integer) - Method in class com.netflix.astyanax.recipes.UniquenessConstraint
 
setTtl(Integer) - Method in class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
setUsername(String) - Method in class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
setValidationClass(String) - Method in interface com.netflix.astyanax.ddl.ColumnDefinition
Sets the validation class for the column values.
setValidationClass(String) - Method in class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
setValueSerializer(String, Serializer<?>) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setValueSerializer(ByteBuffer, Serializer<?>) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setValueType(String, String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
setValueType(ByteBuffer, String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
Shards - Class in com.netflix.astyanax.recipes
 
Shards() - Constructor for class com.netflix.astyanax.recipes.Shards
 
Shards.Builder - Interface in com.netflix.astyanax.recipes
 
Shards.StringShardBuilder - Class in com.netflix.astyanax.recipes
 
Shards.StringShardBuilder() - Constructor for class com.netflix.astyanax.recipes.Shards.StringShardBuilder
 
ShortSerializer - Class in com.netflix.astyanax.serializers
Serializer for Shorts (no pun intended).
ShortSerializer() - Constructor for class com.netflix.astyanax.serializers.ShortSerializer
 
shutdown() - Method in class com.netflix.astyanax.AstyanaxContext
 
shutdown() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Shut down the connection pool and terminate all existing connections
shutdown() - Method in interface com.netflix.astyanax.connectionpool.HostConnectionPool
Completely shut down this connection pool as part of a client shutdown
shutdown() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
shutdown() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
shutdown() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
shutdown() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
shutdown() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Shutdown the threads created by calling start()
shutdown() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Stop the node discovery thread
shutdown() - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
shutdown() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
shutdown() - Method in class com.netflix.astyanax.util.ColumnarRecordWriter
 
shutdown() - Method in class com.netflix.astyanax.util.CsvColumnReader
 
shutdown() - Method in class com.netflix.astyanax.util.CsvRecordReader
 
shutdown() - Method in class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 
shutdown() - Method in interface com.netflix.astyanax.util.RecordReader
 
shutdown() - Method in interface com.netflix.astyanax.util.RecordWriter
 
shutdown() - Method in class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
 
SimpleAuthenticationCredentials - Class in com.netflix.astyanax.connectionpool.impl
 
SimpleAuthenticationCredentials(String, String) - Constructor for class com.netflix.astyanax.connectionpool.impl.SimpleAuthenticationCredentials
 
SimpleHostConnectionPool<CL> - Class in com.netflix.astyanax.connectionpool.impl
Pool of connections for a single host.
SimpleHostConnectionPool(Host, ConnectionFactory<CL>, ConnectionPoolMonitor, ConnectionPoolConfiguration, SimpleHostConnectionPool.Listener<CL>) - Constructor for class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
SimpleHostConnectionPool.Listener<CL> - Interface in com.netflix.astyanax.connectionpool.impl
Interface to notify the owning connection pool of up/down state changes.
SimpleRateLimiterImpl - Class in com.netflix.astyanax.connectionpool.impl
 
SimpleRateLimiterImpl(ConnectionPoolConfiguration) - Constructor for class com.netflix.astyanax.connectionpool.impl.SimpleRateLimiterImpl
 
size - Variable in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
size() - Method in interface com.netflix.astyanax.impl.AckingQueue
Return the number of mutations in the queue
size() - Method in class com.netflix.astyanax.model.AbstractComposite
 
size() - Method in interface com.netflix.astyanax.model.ColumnList
returns the number of columns in the row
size() - Method in interface com.netflix.astyanax.model.Rows
Get the number of rows in the list
size() - Method in class com.netflix.astyanax.shallows.EmptyColumnList
 
size() - Method in class com.netflix.astyanax.shallows.EmptyRowsImpl
 
size() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
size() - Method in class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
size() - Method in class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
size() - Method in class com.netflix.astyanax.thrift.model.ThriftCqlRowsImpl
 
size() - Method in class com.netflix.astyanax.thrift.model.ThriftRowsListImpl
 
size() - Method in class com.netflix.astyanax.thrift.model.ThriftRowsSliceImpl
 
size() - Method in class com.netflix.astyanax.thrift.ThriftAllRowsImpl
 
size() - Method in class com.netflix.astyanax.util.BlockingAckingQueue
 
SleepingRetryPolicy - Class in com.netflix.astyanax.retry
Base sleeping retry policy with optional count limit
SleepingRetryPolicy(int) - Constructor for class com.netflix.astyanax.retry.SleepingRetryPolicy
 
Slf4jConnectionPoolMonitorImpl - Class in com.netflix.astyanax.connectionpool.impl
 
Slf4jConnectionPoolMonitorImpl() - Constructor for class com.netflix.astyanax.connectionpool.impl.Slf4jConnectionPoolMonitorImpl
 
SmaLatencyScoreStrategyImpl - Class in com.netflix.astyanax.connectionpool.impl
 
SmaLatencyScoreStrategyImpl(int, int, int, double) - Constructor for class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
SmaLatencyScoreStrategyInstanceImpl - Class in com.netflix.astyanax.connectionpool.impl
 
SmaLatencyScoreStrategyInstanceImpl(SmaLatencyScoreStrategyImpl) - Constructor for class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyInstanceImpl
 
sortAndfilterPartition(List<HostConnectionPool<CL>>, AtomicBoolean) - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
sortAndfilterPartition(List<HostConnectionPool<CL>>, AtomicBoolean) - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Sorts and filters a list of hosts by looking at their up state and score.
sortAndfilterPartition(List<HostConnectionPool<CL>>, AtomicBoolean) - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
SpecificCompositeSerializer - Class in com.netflix.astyanax.serializers
 
SpecificCompositeSerializer(CompositeType) - Constructor for class com.netflix.astyanax.serializers.SpecificCompositeSerializer
 
StaleLockException - Exception in com.netflix.astyanax.recipes.locks
 
StaleLockException(Exception) - Constructor for exception com.netflix.astyanax.recipes.locks.StaleLockException
 
StaleLockException(String, Exception) - Constructor for exception com.netflix.astyanax.recipes.locks.StaleLockException
 
StaleLockException(String) - Constructor for exception com.netflix.astyanax.recipes.locks.StaleLockException
 
start() - Method in class com.netflix.astyanax.AstyanaxContext
 
start() - Method in interface com.netflix.astyanax.CassandraOperationTracer
 
start() - Method in interface com.netflix.astyanax.connectionpool.ConnectionPool
Setup the connection pool and start any maintenance threads
start() - Method in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
start() - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryImpl
 
start(LatencyScoreStrategy.Listener) - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
start(LatencyScoreStrategy.Listener) - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Start updating stats for instances created using createInstance.
start() - Method in interface com.netflix.astyanax.connectionpool.NodeDiscovery
Start the node discovery thread
start() - Method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracer
 
start(LatencyScoreStrategy.Listener) - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
start() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
start() - Method in class com.netflix.astyanax.util.ColumnarRecordWriter
 
start() - Method in class com.netflix.astyanax.util.CsvColumnReader
 
start() - Method in class com.netflix.astyanax.util.CsvRecordReader
 
start() - Method in interface com.netflix.astyanax.util.RecordReader
 
start() - Method in interface com.netflix.astyanax.util.RecordWriter
 
startConsumers() - Method in class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 
StringSerializer - Class in com.netflix.astyanax.serializers
A StringSerializer translates the byte[] to and from string using utf-8 encoding.
StringSerializer() - Constructor for class com.netflix.astyanax.serializers.StringSerializer
 
StringUtils - Class in com.netflix.astyanax.util
 
StringUtils() - Constructor for class com.netflix.astyanax.util.StringUtils
 
success() - Method in interface com.netflix.astyanax.CassandraOperationTracer
 
success(Connection<CL>) - Method in interface com.netflix.astyanax.connectionpool.Connection.AsyncOpenCallback
 
success() - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy.Instance
Called when a connection was established successfully
success() - Method in class com.netflix.astyanax.retry.RetryNTimes
 
success() - Method in interface com.netflix.astyanax.retry.RetryPolicy
Operation has completed successfully
success() - Method in class com.netflix.astyanax.retry.RunOnce
 
success() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
success(Rows<K, C>) - Method in interface com.netflix.astyanax.RowCallback
Notification for each block of rows.
success() - Method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracer
 
suspend() - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy.Instance
Suspend the host for being bad (i.e.
suspendPool(HostConnectionPool<CL>) - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
suspendPool(HostConnectionPool<CL>) - Method in interface com.netflix.astyanax.connectionpool.impl.Topology
Suspend a host that is down

T

testOperation(Operation<?, ?>) - Method in interface com.netflix.astyanax.Keyspace
This method is used for testing purposes only.
testOperation(Operation<?, ?>, RetryPolicy) - Method in interface com.netflix.astyanax.Keyspace
This method is used for testing purposes only.
testOperation(Operation<?, ?>) - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
testOperation(Operation<?, ?>, RetryPolicy) - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
ThriftAllRowsImpl<K,C> - Class in com.netflix.astyanax.thrift
 
ThriftAllRowsImpl(AbstractThriftAllRowsQueryImpl<K, C>, ColumnFamily<K, C>) - Constructor for class com.netflix.astyanax.thrift.ThriftAllRowsImpl
 
ThriftClusterImpl - Class in com.netflix.astyanax.thrift
 
ThriftClusterImpl(AstyanaxConfiguration, ConnectionPool<Cassandra.Client>, KeyspaceTracerFactory) - Constructor for class com.netflix.astyanax.thrift.ThriftClusterImpl
 
ThriftColumnDefinitionImpl - Class in com.netflix.astyanax.thrift.ddl
 
ThriftColumnDefinitionImpl() - Constructor for class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
ThriftColumnDefinitionImpl(ColumnDef) - Constructor for class com.netflix.astyanax.thrift.ddl.ThriftColumnDefinitionImpl
 
ThriftColumnFamilyDefinitionImpl - Class in com.netflix.astyanax.thrift.ddl
 
ThriftColumnFamilyDefinitionImpl() - Constructor for class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
ThriftColumnFamilyDefinitionImpl(CfDef) - Constructor for class com.netflix.astyanax.thrift.ddl.ThriftColumnFamilyDefinitionImpl
 
ThriftColumnFamilyMutationImpl<C> - Class in com.netflix.astyanax.thrift
Implementation of a row mutation at the root of the column family.
ThriftColumnFamilyMutationImpl(Long, List<Mutation>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
ThriftColumnFamilyQueryImpl<K,C> - Class in com.netflix.astyanax.thrift
Implementation of all column family queries using the thrift API.
ThriftColumnFamilyQueryImpl(ExecutorService, KeyspaceTracerFactory, Keyspace, ConnectionPool<Cassandra.Client>, ColumnFamily<K, C>, ConsistencyLevel, RetryPolicy) - Constructor for class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
ThriftColumnImpl<C> - Class in com.netflix.astyanax.thrift.model
TODO: All serializers
ThriftColumnImpl(C, Column) - Constructor for class com.netflix.astyanax.thrift.model.ThriftColumnImpl
 
ThriftColumnListImpl<C> - Class in com.netflix.astyanax.thrift.model
Wrapper for a simple list of columns where each column has a scalar value.
ThriftColumnListImpl(List<Column>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftColumnListImpl
 
ThriftColumnOrSuperColumnListImpl<C> - Class in com.netflix.astyanax.thrift.model
List of columns that can be either a list of super columns or standard columns.
ThriftColumnOrSuperColumnListImpl(List<ColumnOrSuperColumn>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftColumnOrSuperColumnListImpl
 
ThriftConverter - Class in com.netflix.astyanax.thrift
 
ThriftConverter() - Constructor for class com.netflix.astyanax.thrift.ThriftConverter
 
ThriftCounterColumnImpl<C> - Class in com.netflix.astyanax.thrift.model
 
ThriftCounterColumnImpl(C, CounterColumn) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCounterColumnImpl
 
ThriftCounterColumnListImpl<C> - Class in com.netflix.astyanax.thrift.model
 
ThriftCounterColumnListImpl(List<CounterColumn>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCounterColumnListImpl
 
ThriftCounterSuperColumnImpl<C> - Class in com.netflix.astyanax.thrift.model
 
ThriftCounterSuperColumnImpl(C, CounterSuperColumn) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnImpl
 
ThriftCounterSuperColumnMutationImpl<C> - Class in com.netflix.astyanax.thrift.model
 
ThriftCounterSuperColumnMutationImpl(long, List<Mutation>, ColumnPath<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
ThriftCqlResultImpl<K,C> - Class in com.netflix.astyanax.thrift.model
 
ThriftCqlResultImpl(Rows<K, C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCqlResultImpl
 
ThriftCqlResultImpl(Integer) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCqlResultImpl
 
ThriftCqlRowsImpl<K,C> - Class in com.netflix.astyanax.thrift.model
 
ThriftCqlRowsImpl(List<CqlRow>, Serializer<K>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftCqlRowsImpl
 
ThriftFamilyFactory - Class in com.netflix.astyanax.thrift
 
ThriftFamilyFactory() - Constructor for class com.netflix.astyanax.thrift.ThriftFamilyFactory
 
ThriftKeyspaceDefinitionImpl - Class in com.netflix.astyanax.thrift.ddl
 
ThriftKeyspaceDefinitionImpl() - Constructor for class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
ThriftKeyspaceDefinitionImpl(KsDef) - Constructor for class com.netflix.astyanax.thrift.ddl.ThriftKeyspaceDefinitionImpl
 
ThriftKeyspaceImpl - Class in com.netflix.astyanax.thrift
 
ThriftKeyspaceImpl(String, ConnectionPool<Cassandra.Client>, AstyanaxConfiguration, KeyspaceTracerFactory) - Constructor for class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
ThriftRowImpl<K,C> - Class in com.netflix.astyanax.thrift.model
 
ThriftRowImpl(K, ByteBuffer, ColumnList<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftRowImpl
 
ThriftRowsListImpl<K,C> - Class in com.netflix.astyanax.thrift.model
 
ThriftRowsListImpl(Map<ByteBuffer, List<ColumnOrSuperColumn>>, Serializer<K>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftRowsListImpl
 
ThriftRowsSliceImpl<K,C> - Class in com.netflix.astyanax.thrift.model
 
ThriftRowsSliceImpl(List<KeySlice>, Serializer<K>, Serializer<C>) - Constructor for class com.netflix.astyanax.thrift.model.ThriftRowsSliceImpl
 
ThriftStateException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
ThriftStateException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ThriftStateException
 
ThriftStateException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ThriftStateException
 
ThriftStateException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ThriftStateException
 
ThriftSuperColumnImpl<C> - Class in com.netflix.astyanax.thrift.model
 
ThriftSuperColumnImpl(C, SuperColumn) - Constructor for class com.netflix.astyanax.thrift.model.ThriftSuperColumnImpl
 
ThriftSuperColumnMutationImpl<C> - Class in com.netflix.astyanax.thrift
Deprecated. Use composite columns instead
ThriftSuperColumnMutationImpl(long, List<Mutation>, ColumnPath<C>) - Constructor for class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
ThriftSyncConnectionFactoryImpl - Class in com.netflix.astyanax.thrift
 
ThriftSyncConnectionFactoryImpl(ConnectionPoolConfiguration, KeyspaceTracerFactory, ConnectionPoolMonitor) - Constructor for class com.netflix.astyanax.thrift.ThriftSyncConnectionFactoryImpl
 
ThriftUtils - Class in com.netflix.astyanax.thrift
 
ThriftUtils() - Constructor for class com.netflix.astyanax.thrift.ThriftUtils
 
ThrottledException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
ThrottledException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ThrottledException
 
ThrottledException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ThrottledException
 
ThrottledException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.ThrottledException
 
TimeoutException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
TimeoutException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TimeoutException
 
TimeoutException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TimeoutException
 
timestamp - Variable in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
TimeUUIDSerializer - Class in com.netflix.astyanax.serializers
 
TimeUUIDSerializer() - Constructor for class com.netflix.astyanax.serializers.TimeUUIDSerializer
 
TimeUUIDUtils - Class in com.netflix.astyanax.util
Utilitary class to generate TimeUUID (type 1)
TimeUUIDUtils() - Constructor for class com.netflix.astyanax.util.TimeUUIDUtils
 
toByte() - Method in enum com.netflix.astyanax.model.AbstractComposite.ComponentEquality
 
toByte() - Method in enum com.netflix.astyanax.model.Equality
 
toByteBuffer(Object...) - Static method in class com.netflix.astyanax.model.Composite
 
toByteBuffer(List<?>) - Static method in class com.netflix.astyanax.model.Composite
 
toByteBuffer(Object...) - Static method in class com.netflix.astyanax.model.DynamicComposite
 
toByteBuffer(List<?>) - Static method in class com.netflix.astyanax.model.DynamicComposite
 
toByteBuffer(T) - Method in interface com.netflix.astyanax.Serializer
Extract bytes from the obj of type T
toByteBuffer(T) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
toByteBuffer(T) - Method in class com.netflix.astyanax.serializers.AnnotatedCompositeSerializer
 
toByteBuffer(String) - Method in class com.netflix.astyanax.serializers.AsciiSerializer
 
toByteBuffer(BigInteger) - Method in class com.netflix.astyanax.serializers.BigIntegerSerializer
 
toByteBuffer(Boolean) - Method in class com.netflix.astyanax.serializers.BooleanSerializer
 
toByteBuffer(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
toByteBuffer(byte[]) - Method in class com.netflix.astyanax.serializers.BytesArraySerializer
 
toByteBuffer(Character) - Method in class com.netflix.astyanax.serializers.CharSerializer
 
toByteBuffer(Composite) - Method in class com.netflix.astyanax.serializers.CompositeSerializer
 
toByteBuffer(Date) - Method in class com.netflix.astyanax.serializers.DateSerializer
 
toByteBuffer(Double) - Method in class com.netflix.astyanax.serializers.DoubleSerializer
 
toByteBuffer(DynamicComposite) - Method in class com.netflix.astyanax.serializers.DynamicCompositeSerializer
 
toByteBuffer(Float) - Method in class com.netflix.astyanax.serializers.FloatSerializer
 
toByteBuffer(Integer) - Method in class com.netflix.astyanax.serializers.IntegerSerializer
 
toByteBuffer(Object) - Method in class com.netflix.astyanax.serializers.JaxbSerializer
Extract bytes from the obj of type T
toByteBuffer(Long) - Method in class com.netflix.astyanax.serializers.LongSerializer
 
toByteBuffer(Object) - Method in class com.netflix.astyanax.serializers.ObjectSerializer
 
toByteBuffer(S) - Method in class com.netflix.astyanax.serializers.PrefixedSerializer
 
toByteBuffer(Short) - Method in class com.netflix.astyanax.serializers.ShortSerializer
 
toByteBuffer(String) - Method in class com.netflix.astyanax.serializers.StringSerializer
 
toByteBuffer(T) - Method in class com.netflix.astyanax.serializers.TypeInferringSerializer
 
toByteBuffer(UUID) - Method in class com.netflix.astyanax.serializers.UUIDSerializer
 
toBytes() - Method in interface com.netflix.astyanax.model.RangeEndpoint
 
toBytes(T) - Method in interface com.netflix.astyanax.Serializer
 
toBytes(T) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
toBytesList(List<T>) - Method in interface com.netflix.astyanax.Serializer
 
toBytesList(Collection<T>) - Method in interface com.netflix.astyanax.Serializer
 
toBytesList(List<T>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
toBytesList(Collection<T>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
toBytesList(List<ByteBuffer>) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
toBytesMap(Map<T, V>) - Method in interface com.netflix.astyanax.Serializer
 
toBytesMap(Map<T, V>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
toBytesMap(Map<ByteBuffer, V>) - Method in class com.netflix.astyanax.serializers.ByteBufferSerializer
 
toBytesSet(List<T>) - Method in interface com.netflix.astyanax.Serializer
 
toBytesSet(List<T>) - Method in class com.netflix.astyanax.serializers.AbstractSerializer
 
toCamelCase(String) - Static method in class com.netflix.astyanax.util.StringUtils
Convert a string from "_" delimited to lower camel case
ToConnectionPoolException(Exception) - Static method in class com.netflix.astyanax.thrift.ThriftConverter
Convert from Thrift exceptions to an internal ConnectionPoolException
toIndexValue(V) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
TokenAwareConnectionPoolImpl<CL> - Class in com.netflix.astyanax.connectionpool.impl
Connection pool that partitions connections by the hosts which own the token being operated on.
TokenAwareConnectionPoolImpl(ConnectionPoolConfiguration, ConnectionFactory<CL>, ConnectionPoolMonitor) - Constructor for class com.netflix.astyanax.connectionpool.impl.TokenAwareConnectionPoolImpl
 
TokenGenerator - Class in com.netflix.astyanax.util
 
TokenGenerator() - Constructor for class com.netflix.astyanax.util.TokenGenerator
 
tokenMinusOne(String) - Static method in class com.netflix.astyanax.util.TokenGenerator
 
TokenPartitionedTopology<CL> - Class in com.netflix.astyanax.connectionpool.impl
 
TokenPartitionedTopology(LatencyScoreStrategy) - Constructor for class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
TokenRange - Interface in com.netflix.astyanax.connectionpool
 
TokenRangeImpl - Class in com.netflix.astyanax.connectionpool.impl
 
TokenRangeImpl(String, String, List<String>) - Constructor for class com.netflix.astyanax.connectionpool.impl.TokenRangeImpl
 
TokenRangeOfflineException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
TokenRangeOfflineException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TokenRangeOfflineException
 
TokenRangeOfflineException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TokenRangeOfflineException
 
TokenRangeOfflineException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TokenRangeOfflineException
 
topology - Variable in class com.netflix.astyanax.connectionpool.impl.AbstractHostPartitionConnectionPool
 
Topology<CL> - Interface in com.netflix.astyanax.connectionpool.impl
 
toProperCase(String) - Static method in class com.netflix.astyanax.util.StringUtils
 
toString() - Method in class com.netflix.astyanax.clock.MicrosecondsAsyncClock
 
toString() - Method in class com.netflix.astyanax.clock.MicrosecondsClock
 
toString() - Method in class com.netflix.astyanax.clock.MicrosecondsSyncClock
 
toString() - Method in class com.netflix.astyanax.clock.MillisecondsClock
 
toString() - Method in class com.netflix.astyanax.connectionpool.Host
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.BadHostDetectorImpl
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolConfigurationImpl
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.CountingConnectionPoolMonitor
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.ExponentialRetryBackoffStrategy
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.HostConnectionPoolPartition
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.SimpleHostConnectionPool
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
toString() - Method in class com.netflix.astyanax.connectionpool.impl.TokenPartitionedTopology
 
toString() - Method in class com.netflix.astyanax.impl.AstyanaxConfigurationImpl
 
toString() - Method in class com.netflix.astyanax.model.AbstractComposite.Component
 
toString() - Method in class com.netflix.astyanax.retry.BoundedExponentialBackoff
 
toString() - Method in class com.netflix.astyanax.retry.ConstantBackoff
 
toString() - Method in class com.netflix.astyanax.retry.ExponentialBackoff
 
toString() - Method in class com.netflix.astyanax.retry.RetryNTimes
 
toString() - Method in class com.netflix.astyanax.retry.RunOnce
 
toString() - Method in class com.netflix.astyanax.retry.SleepingRetryPolicy
 
toString() - Method in class com.netflix.astyanax.shallows.EmptyConnectionPoolMonitor
 
toString() - Method in class com.netflix.astyanax.shallows.EmptyKeyspaceTracerFactory
 
toString() - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
toString() - Method in class com.netflix.astyanax.shallows.EmptyNodeDiscoveryImpl
 
toString() - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
Generate a string representation of the mutation with the following syntax Key1: cf1: Mutation count cf2: Mutation count Key2: cf1: Mutation count cf2: Mutation count
ToThriftConsistencyLevel(ConsistencyLevel) - Static method in class com.netflix.astyanax.thrift.ThriftConverter
 
toUUID(byte[]) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Returns an instance of uuid.
tracerFactory - Variable in class com.netflix.astyanax.AstyanaxContext.Builder
 
TransportException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
TransportException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TransportException
 
TransportException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TransportException
 
TransportException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.TransportException
 
truncateColumnFamily(ColumnFamily<K, C>) - Method in interface com.netflix.astyanax.Keyspace
Delete all rows in a column family
truncateColumnFamily(ColumnFamily<K, C>) - Method in class com.netflix.astyanax.thrift.ThriftKeyspaceImpl
 
tryConnect(int) - Method in interface com.netflix.astyanax.connectionpool.RetryBackoffStrategy.Callback
 
tryOperation(Operation<CL, R>) - Method in interface com.netflix.astyanax.connectionpool.ExecuteWithFailover
 
tryOperation(Operation<CL, R>) - Method in class com.netflix.astyanax.connectionpool.impl.AbstractExecuteWithFailoverImpl
 
TypeInferringSerializer<T> - Class in com.netflix.astyanax.serializers
A serializer that dynamically delegates to a proper serializer based on the value passed
TypeInferringSerializer() - Constructor for class com.netflix.astyanax.serializers.TypeInferringSerializer
 

U

UniquenessConstraint - Interface in com.netflix.astyanax.recipes.uniqueness
 
UniquenessConstraint<K,C> - Class in com.netflix.astyanax.recipes
 
UniquenessConstraint(Keyspace, ColumnFamily<K, C>, Supplier<C>) - Constructor for class com.netflix.astyanax.recipes.UniquenessConstraint
 
UniquenessConstraintViolationMonitor<K,C> - Interface in com.netflix.astyanax.recipes
 
UniquenessConstraintWithPrefix<K> - Class in com.netflix.astyanax.recipes
 
UniquenessConstraintWithPrefix(Keyspace, ColumnFamily<K, String>) - Constructor for class com.netflix.astyanax.recipes.UniquenessConstraintWithPrefix
 
UnknownComparatorException - Exception in com.netflix.astyanax.serializers
 
UnknownComparatorException(String) - Constructor for exception com.netflix.astyanax.serializers.UnknownComparatorException
 
UnknownException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
UnknownException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.UnknownException
 
UnknownException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.UnknownException
 
UnknownException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.UnknownException
 
unregisterMonitor(String, ConnectionPool<?>) - Method in class com.netflix.astyanax.connectionpool.impl.ConnectionPoolMBeanManager
 
unregisterMonitor(String, NodeDiscovery) - Method in class com.netflix.astyanax.connectionpool.impl.NodeDiscoveryMonitorManager
 
update() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyImpl
 
update() - Method in class com.netflix.astyanax.connectionpool.impl.SmaLatencyScoreStrategyInstanceImpl
 
update() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy.Instance
Update the score
update() - Method in interface com.netflix.astyanax.connectionpool.LatencyScoreStrategy
Update all instance scores
update() - Method in class com.netflix.astyanax.shallows.EmptyLatencyScoreStrategyImpl
 
updateColumnFamily(ColumnFamilyDefinition) - Method in interface com.netflix.astyanax.Cluster
Update an existing column family
updateColumnFamily(ColumnFamilyDefinition) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
updateKeyspace(KeyspaceDefinition) - Method in interface com.netflix.astyanax.Cluster
Update a new keyspace in the cluster.
updateKeyspace(KeyspaceDefinition) - Method in class com.netflix.astyanax.thrift.ThriftClusterImpl
 
useCompression() - Method in interface com.netflix.astyanax.query.CqlQuery
Turns on compression for the response
useExecutor(ExecutorService) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
useRetryPolicy(RetryPolicy) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
usingRetryablePredicate(Predicate<Exception>) - Method in class com.netflix.astyanax.util.MutationBatchExecutorWithQueue
 
usingRetryablePredicate(Predicate<Exception>) - Method in class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
 
usingWriteAheadLog(WriteAheadLog) - Method in interface com.netflix.astyanax.MutationBatch
Specify a write ahead log implementation to use for this mutation
usingWriteAheadLog(WriteAheadLog) - Method in class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
 
uuid(byte[], int) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
 
uuid(ByteBuffer) - Static method in class com.netflix.astyanax.util.TimeUUIDUtils
Converts a ByteBuffer containing a UUID into a java.util.UUID
UUIDSerializer - Class in com.netflix.astyanax.serializers
A UUIDSerializer translates the byte[] to and from UUID types.
UUIDSerializer() - Constructor for class com.netflix.astyanax.serializers.UUIDSerializer
 
UUIDStringSupplier - Class in com.netflix.astyanax.recipes
 
UUIDStringSupplier() - Constructor for class com.netflix.astyanax.recipes.UUIDStringSupplier
 

V

value(String) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(long) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(int) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(boolean) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(Date) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(byte[]) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(ByteBuffer) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(double) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(UUID) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(V, Serializer<V>) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
value(String) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(long) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(int) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(boolean) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(Date) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(byte[]) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(ByteBuffer) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(double) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(UUID) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(V, Serializer<V>) - Method in interface com.netflix.astyanax.query.IndexValueExpression
 
value(String) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(long) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(int) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(boolean) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(Date) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(byte[]) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(ByteBuffer) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(double) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(UUID) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
value(V, Serializer<V>) - Method in interface com.netflix.astyanax.query.PreparedIndexValueExpression
 
valueAsByteBuffer(ByteBuffer, String) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a string value to a string using the package's value serializer
valueAsByteBuffer(String, String) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a string value to a string using the package's value serializer
valueAsByteBuffer(ByteBuffer, String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
valueAsByteBuffer(String, String) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
valueAsString(ByteBuffer, ByteBuffer) - Method in interface com.netflix.astyanax.SerializerPackage
Convert a value to a string using the package's value serializer.
valueAsString(ByteBuffer, ByteBuffer) - Method in class com.netflix.astyanax.serializers.SerializerPackageImpl
 
valueOf(String) - Static method in enum com.netflix.astyanax.CassandraOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.clock.ClockType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.connectionpool.impl.ConnectionPoolType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.connectionpool.LatencyScoreStrategyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.connectionpool.NodeDiscoveryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.model.AbstractComposite.ComponentEquality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.model.ColumnType
Deprecated. Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.model.ConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.model.Equality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.query.IndexOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider.Columns
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.netflix.astyanax.serializers.ComparatorType
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.netflix.astyanax.CassandraOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.clock.ClockType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.connectionpool.impl.ConnectionPoolType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.connectionpool.LatencyScoreStrategyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.connectionpool.NodeDiscoveryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.model.AbstractComposite.ComponentEquality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.model.ColumnType
Deprecated. Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.model.ConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.model.Equality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.query.IndexOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider.Columns
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.netflix.astyanax.serializers.ComparatorType
Returns an array containing the constants of this enum type, in the order they are declared.
verifyLock(long) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Verify that the lock was acquired

W

waitDelta - Variable in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
waitMultiplier - Variable in class com.netflix.astyanax.connectionpool.impl.RoundRobinExecuteWithFailover
 
WalException - Exception in com.netflix.astyanax.connectionpool.exceptions
 
WalException(String) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.WalException
 
WalException(Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.WalException
 
WalException(String, Throwable) - Constructor for exception com.netflix.astyanax.connectionpool.exceptions.WalException
 
whereColumn(C) - Method in class com.netflix.astyanax.impl.PreparedIndexExpressionImpl
 
whereColumn(C) - Method in interface com.netflix.astyanax.query.IndexColumnExpression
Set the column part of the expression
whereColumn(C) - Method in interface com.netflix.astyanax.query.PreparedIndexColumnExpression
Set the column part of the expression
withAstyanaxConfiguration(AstyanaxConfiguration) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
withBatchSize(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectReader
 
withCallback(ObjectReadCallback) - Method in class com.netflix.astyanax.recipes.storage.ObjectReader
 
withCallback(ObjectWriteCallback) - Method in class com.netflix.astyanax.recipes.storage.ObjectWriter
 
withChunkCountToDelete(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectDeleter
 
withChunkSize(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectWriter
 
withColumnName(CassandraChunkedStorageProvider.Columns, String) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
withColumnPrefix(String) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Specify the prefix that uniquely distinguishes the lock columns from data column
withColumnPrefix(String) - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
Specify the prefix that uniquely distinguishes the lock columns from data columns
withColumnRange(C, C, boolean, int) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Specify a range of columns to return.
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Specify a range and provide pre-constructed start and end columns.
withColumnRange(ByteBufferRange) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Specify a range of composite columns.
withColumnRange(C, C, boolean, int) - Method in interface com.netflix.astyanax.query.IndexQuery
Specify a range of columns to return.
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in interface com.netflix.astyanax.query.IndexQuery
Specify a range and provide pre-constructed start and end columns.
withColumnRange(ByteBufferRange) - Method in interface com.netflix.astyanax.query.IndexQuery
Specify a range of composite columns.
withColumnRange(C, C, boolean, int) - Method in interface com.netflix.astyanax.query.RowQuery
Specify a range of columns to return.
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in interface com.netflix.astyanax.query.RowQuery
Specify a range and provide pre-constructed start and end columns.
withColumnRange(ByteBufferRange) - Method in interface com.netflix.astyanax.query.RowQuery
Specify a range of composite columns.
withColumnRange(C, C, boolean, int) - Method in interface com.netflix.astyanax.query.RowSliceQuery
Specify a range of columns to return.
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in interface com.netflix.astyanax.query.RowSliceQuery
Specify a range and provide pre-constructed start and end columns.
withColumnRange(ByteBufferRange) - Method in interface com.netflix.astyanax.query.RowSliceQuery
Specify a range of composite columns.
withColumnRange(C, C, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
withColumnRange(ByteBufferRange) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
withColumnRange(C, C, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
withColumnRange(ByteBufferRange) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
withColumnRange(C, C, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
withColumnRange(ByteBufferRange) - Method in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
withColumnRange(C, C, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
withColumnRange(ByteBuffer, ByteBuffer, boolean, int) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
withColumnRange(ByteBufferRange) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
withColumnSlice(C...) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(Collection<C>) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(ColumnSlice<C>) - Method in interface com.netflix.astyanax.query.AllRowsQuery
Use this when your application caches the column slice.
withColumnSlice(C...) - Method in interface com.netflix.astyanax.query.IndexQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(Collection<C>) - Method in interface com.netflix.astyanax.query.IndexQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(ColumnSlice<C>) - Method in interface com.netflix.astyanax.query.IndexQuery
Use this when your application caches the column slice.
withColumnSlice(Collection<C>) - Method in interface com.netflix.astyanax.query.RowQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(C...) - Method in interface com.netflix.astyanax.query.RowQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(ColumnSlice<C>) - Method in interface com.netflix.astyanax.query.RowQuery
Use this when your application caches the column slice.
withColumnSlice(C...) - Method in interface com.netflix.astyanax.query.RowSliceQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(Collection<C>) - Method in interface com.netflix.astyanax.query.RowSliceQuery
Specify a non-contiguous set of columns to retrieve.
withColumnSlice(ColumnSlice<C>) - Method in interface com.netflix.astyanax.query.RowSliceQuery
Use this when your application caches the column slice.
withColumnSlice(Collection<C>) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
withColumnSlice(C...) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
withColumnSlice(Collection<C>) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
withColumnSlice(ColumnSlice<C>) - Method in class com.netflix.astyanax.thrift.AbstractIndexQueryImpl
 
withColumnSlice(C...) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
withColumnSlice(Collection<C>) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
withColumnSlice(ColumnSlice<C>) - Method in class com.netflix.astyanax.thrift.AbstractRowQueryImpl
 
withColumnSlice(C...) - Method in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
withColumnSlice(Collection<C>) - Method in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
withColumnSlice(ColumnSlice<C>) - Method in class com.netflix.astyanax.thrift.AbstractRowSliceQueryImpl
 
withColumnSlice(C...) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
withColumnSlice(Collection<C>) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
withColumnSlice(ColumnSlice<C>) - Method in class com.netflix.astyanax.thrift.AbstractThriftAllRowsQueryImpl
 
withConcurrencyLevel(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectReader
 
withConcurrencyLevel(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectWriter
 
withConnectionPoolConfiguration(ConnectionPoolConfiguration) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
withConnectionPoolMonitor(ConnectionPoolMonitor) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
withConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Modify the consistency level being used.
withConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
withConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.uniqueness.ColumnPrefixUniquenessConstraint
 
withConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
Consistency level used
withConsistencyLevel(ConsistencyLevel) - Method in class com.netflix.astyanax.recipes.uniqueness.RowUniquenessConstraint
 
withCql(String) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Prepare a CQL Query
withCql(String) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
withHostSupplier(Supplier<Map<BigInteger, List<Host>>>) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
withIndexShards(Collection<ByteBuffer>) - Method in class com.netflix.astyanax.recipes.ReverseIndexQuery
 
withLockColumn(String) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Override the autogenerated lock column.
withLockColumn(String) - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
Override the autogenerated lock column.
withMaxWaitTime(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectReader
 
withMaxWaitTime(int) - Method in class com.netflix.astyanax.recipes.storage.ObjectWriter
 
withPrefix(Object) - Method in class com.netflix.astyanax.serializers.CompositeRangeBuilder
 
withRetryPolicy(RetryPolicy) - Method in interface com.netflix.astyanax.ColumnMutation
 
withRetryPolicy(RetryPolicy) - Method in interface com.netflix.astyanax.MutationBatch
Set the retry policy to use instead of the one specified in the configuration
withRetryPolicy(RetryPolicy) - Method in interface com.netflix.astyanax.query.ColumnFamilyQuery
Set the retry policy to use instead of the default
withRetryPolicy(RetryPolicy) - Method in class com.netflix.astyanax.recipes.storage.ObjectReader
 
withRetryPolicy(RetryPolicy) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyQueryImpl
 
withRow(ColumnFamily<K, C>, K) - Method in interface com.netflix.astyanax.MutationBatch
Mutate a row.
withRow(ColumnFamily<String, String>, String) - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
Add a row to the set of rows being tested for uniqueness
withRow(ColumnFamily<K, C>, K) - Method in class com.netflix.astyanax.thrift.AbstractThriftMutationBatchImpl
 
withRowKeyFormat(String) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
withSuperColumn(ColumnPath<SC>) - Method in interface com.netflix.astyanax.ColumnListMutation
Deprecated. Super columns are being phased out. Use composite columns instead.
withSuperColumn(ColumnPath<SC>) - Method in class com.netflix.astyanax.thrift.model.ThriftCounterSuperColumnMutationImpl
 
withSuperColumn(ColumnPath<SC>) - Method in class com.netflix.astyanax.thrift.ThriftColumnFamilyMutationImpl
 
withSuperColumn(ColumnPath<SC>) - Method in class com.netflix.astyanax.thrift.ThriftSuperColumnMutationImpl
Deprecated.  
withTracerFactory(KeyspaceTracerFactory) - Method in class com.netflix.astyanax.AstyanaxContext.Builder
 
withTtl(Integer) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
 
withTtl(Integer) - Method in class com.netflix.astyanax.recipes.storage.ObjectWriter
 
withTtl(Integer) - Method in class com.netflix.astyanax.recipes.uniqueness.ColumnPrefixUniquenessConstraint
 
withTtl(Integer) - Method in class com.netflix.astyanax.recipes.uniqueness.MultiRowUniquenessConstraint
TTL to use for the uniquness operation.
withTtl(Integer) - Method in class com.netflix.astyanax.recipes.uniqueness.RowUniquenessConstraint
 
write(int) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
write(ByteBuffer) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
Add a buffer to the output without copying, if possible.
write(List<Pair<String, String>>) - Method in class com.netflix.astyanax.util.ColumnarRecordWriter
 
write(Rows<?, ?>) - Method in class com.netflix.astyanax.util.CsvRowsWriter
 
write(Rows<?, ?>) - Method in class com.netflix.astyanax.util.JsonRowsWriter
 
write(List<Pair<String, String>>) - Method in interface com.netflix.astyanax.util.RecordWriter
 
write(Rows<?, ?>) - Method in interface com.netflix.astyanax.util.RowsWriter
 
WriteAheadEntry - Interface in com.netflix.astyanax
 
WriteAheadLog - Interface in com.netflix.astyanax
Base interface for a write ahead log.
WriteAheadMutationBatchExecutor - Class in com.netflix.astyanax.util
 
WriteAheadMutationBatchExecutor(Keyspace, int) - Constructor for class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
 
WriteAheadMutationBatchExecutor(Keyspace, ExecutorService) - Constructor for class com.netflix.astyanax.util.WriteAheadMutationBatchExecutor
 
writeChar(char) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
writeChunk(String, int, ByteBuffer, Integer) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
writeChunk(String, int, ByteBuffer, Integer) - Method in interface com.netflix.astyanax.recipes.storage.ChunkedStorageProvider
Write a single chunk to the storage
writeDouble(double) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
writeFloat(float) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
writeInt(int) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
writeLockColumn(long) - Method in class com.netflix.astyanax.recipes.locks.ColumnPrefixDistributedRowLock
Write a lock for the specified time.
writeLong(long) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 
writeMetadata(String, ObjectMetadata) - Method in class com.netflix.astyanax.recipes.storage.CassandraChunkedStorageProvider
 
writeMetadata(String, ObjectMetadata) - Method in interface com.netflix.astyanax.recipes.storage.ChunkedStorageProvider
Persist all attributes for an object.
writeMutation(MutationBatch) - Method in interface com.netflix.astyanax.WriteAheadEntry
Write the contents of this mutation to the WAL entry.
writeShort(short) - Method in class com.netflix.astyanax.serializers.ByteBufferOutputStream
 

A B C D E F G H I J K L M N O P R S T U V W

Copyright © 2012. All Rights Reserved.