All Classes Interface Summary Class Summary Enum Summary Exception Summary
| Class |
Description |
| AdminMXBean |
This MBean represents an Admin's operational parameters.
|
| AnyAtomicDef |
AnyAtomicDef is the type that contains all kinds of atomic values.
|
| AnyDef |
AnyDef is the most generic data type; it contains all kinds of values.
|
| AnyJsonAtomicDef |
AnyJsonAtomicDef is the type that contains all kinds of atomic values
that appear in JSON documents.
|
| AnyRecordDef |
AnyRecordDef is the type that contains all kinds of record values.
|
| ArbNodeMXBean |
This MBean represents an Arbiter node's operational parameters.
|
| ArrayDef |
ArrayDef is an extension of FieldDef to encapsulate an array
of values.
|
| ArrayValue |
ArrayValue extends FieldValue to add methods appropriate for array
values.
|
| AuthenticationFailureException |
This exception is thrown if an application passes invalid credentials
to a KVStore authentication operation.
|
| AuthenticationRequiredException |
This exception is thrown when a secured operation is attempted and the
client is not currently authenticated.
|
| BinaryDef |
BinaryDef is an extension of FieldDef to encapsulate a Binary type.
|
| BinaryValue |
BinaryValue extends FieldValue to represent a byte array
value.
|
| BooleanDef |
BooleanDef is an extension of FieldDef to encapsulate a Boolean.
|
| BooleanValue |
BooleanValue extends FieldValue to represent a simple boolean value.
|
| BoundStatement |
Represents a Statement that has been compiled and an execution
plan generated for it.
|
| BulkWriteOptions |
BulkWriteOptions is used to configure bulk write operations.
|
| CacheKeyMapper |
This interface defines a mechanism for translating an Oracle Coherence cache
key object into an Oracle NoSQL Database Key.
|
| CheckpointFailureException |
Exception that is raised when a subscriber fails to make a checkpoint.
|
| ChildTableLimitException |
Thrown when an attempt is made to exceeded a table's child limit.
|
| Consistency |
Used to provide consistency guarantees for read operations.
|
| Consistency.Time |
A consistency policy which describes the amount of time the Replica is
allowed to lag the Master.
|
| Consistency.Version |
A consistency policy which ensures that the environment on a Replica
node is at least as current as denoted by the specified Key-Value pair
Consistency.Version.
|
| ConsistencyException |
Thrown when a single or multiple-operation transaction fails because the
specified Consistency could not be met, within the allowed timeout
period.
|
| ContingencyException |
Used to indicate a status condition or result that is not expressed through
the return value, and that should normally be handled by the caller of the
method.
|
| Depth |
Used with multiple-key and iterator operations to specify whether to select
(return or operate on) the key-value pair for the parent key, and the
key-value pairs for only immediate children or all descendants.
|
| DetailedMetrics |
|
| Direction |
Used with iterator operations to specify the order that keys are returned.
|
| DoubleDef |
DoubleDef is an extension of FieldDef to encapsulate the Double type.
|
| DoubleValue |
DoubleValue extends FieldValue to represent a double.
|
| Durability |
Defines the durability characteristics associated with a standalone write
(put or update) operation, or in the case of KVStore.execute with a set of operations performed in a single transaction.
|
| Durability.ReplicaAckPolicy |
A replicated environment makes it possible to increase an application's
transaction commit guarantees by committing changes to its replicas on
the network.
|
| Durability.SyncPolicy |
Defines the synchronization policy to be used when committing a
transaction.
|
| DurabilityException |
Thrown when write operations cannot be initiated because a quorum of
Replicas as determined by the Durability.ReplicaAckPolicy was not
available.
|
| EntryStream<E> |
The stream interface that supplies the data (Row or Key/Value pair) to be
batched and loaded into the store.
|
| EnumDef |
EnumDef is a extension of FieldDef to support an enumeration type.
|
| EnumValue |
EnumValue extends FieldValue to represent a single value in an
enumeration.
|
| ExecuteOptions |
Class contains several options for the execution of an SQL statement
(DDL or DML).
|
| ExecutionFuture |
An ExecutionFuture is a Future that provides a handle to an
administrative statement that has been issued and is being processed by the
kvstore.
|
| ExecutionFuture |
Deprecated.
|
| ExecutionSubscription |
A subinterface of Subscription implemented by subscriptions supplied
when a Subscriber subscribes to a Publisher associated with
the asynchronous execution of a query.
|
| ExternalTableException |
Runtime Exception for anything related to ExternalTables.
|
| ExternalTableUtils |
|
| FastExternalizableException |
A common exception base class to support internal serialization facilities.
|
| FaultException |
Used to indicate an error condition that cannot normally be handled by the
caller of the method, except by retrying the operation.
|
| FieldDef |
FieldDef represents an immutable metadata object used to represent a single
data type.
|
| FieldDef.Type |
The type of a field definition.
|
| FieldRange |
FieldRange defines a range of values to be used in a table or index
iteration or multiGet operation.
|
| FieldValue |
FieldValue represents an item, that is, a value and its associated type.
|
| FieldValueFactory |
Factory class to create FieldValue instance objects.
|
| FixedBinaryDef |
FixedBinaryDef is an extension of FieldDef to encapsulate a fixed
length binary value.
|
| FixedBinaryValue |
FixedBinaryValue extends FieldValue to represent a fixed-size byte
array.
|
| FloatDef |
FloatDef is an extension of FieldDef to encapsulate the Float type.
|
| FloatValue |
FloatValue extends FieldValue to represent a float.
|
| Formatter |
Formatter is an interface to a user-specified class used for formatting
NoSQL Database records into Strings which are appropriate for importing into
a specific Oracle External Table.
|
| Index |
Index represents an index on a table in Oracle NoSQL Database.
|
| Index.IndexType |
The type of an index.
|
| IndexKey |
IndexKey is a specialization of RecordValue to represent a key used to
access a specific index defined on a table.
|
| IndexLimitException |
Thrown when an attempt is made to exceeded a table's index limit.
|
| InputStreamVersion |
Holds a Stream and Version that are associated with a LOB.
|
| IntegerDef |
IntegerDef is an extension of FieldDef to encapsulate an Integer.
|
| IntegerValue |
IntegerValue extends FieldValue to represent an integer.
|
| IterationSubscription |
A subinterface of Subscription implemented by subscriptions supplied
when a Subscriber subscribes to a Publisher associated with
an asynchronous table iteration.
|
| JsonDef |
JsonDef is an extension of FieldDef to define schemaless data modeled
as JSON.
|
| KerberosCredentials |
Login credentials for Kerberos authentication.
|
| Key |
The Key in a Key/Value store.
|
| KeyPair |
|
| KeyRange |
Defines a range of Key components for use in multiple-key operations and
iterations.
|
| KeyValue |
Represents a key/value pair.
|
| KeyValueVersion |
Represents a key/value pair along with its version.
|
| KVInputFormat |
A Hadoop InputFormat class for reading data from an Oracle NoSQL Database.
|
| KVInputFormatBase<K,V> |
This is the base class for Oracle NoSQL Database InputFormat classes.
|
| KVLargeObject |
The KVLargeObject interface defines the operations used to read and write
Large Objects (LOBs) such as audio and video files.
|
| KVLargeObject.LOBState |
The enumeration defines the states associated with a LOB.
|
| KVLocal |
KVLocal is a handle for managing embedded Oracle NoSQL Database.
|
| KVLocalConfig |
Represents the configuration parameters used to create a KVLocal
object.
|
| KVLocalConfig.Builder |
Base builder class used to set configuration parameters common to both
TCP sockets and Unix domain sockets.
|
| KVLocalConfig.InetBuilder |
InetBuilder to help construct a KVLocalConfig instance using TCP
sockets.
|
| KVLocalConfig.UnixDomainBuilder |
Builder class to help construct a KVLocalConfig instance using
Unix domain sockets.
|
| KVLocalException |
Generic exception class for generating runtime exceptions for KVLocal.
|
| KVSecurityConstants |
The KVSecurityConstants interface defines constants used for security
configuration.
|
| KVSecurityException |
The common abstract base class of KVStore security-related exceptions.
|
| KVStats |
Statistics associated with accessing the KVStore from a client via the
KVStore handle.
|
| KVStore |
KVStore is the handle to a store that is running remotely.
|
| KVStoreConfig |
Represents the configuration parameters used to create a handle to an
existing KV store.
|
| KVStoreFactory |
Factory class used to produce handles to an existing KVStore.
|
| KVVersion |
Oracle NoSQL DB version information.
|
| LoginCredentials |
The common interface of KVStore credential class implementations.
|
| LongDef |
LongDef is an extension of FieldDef to encapsulate a Long.
|
| LongValue |
|
| MapDef |
MapDef is an extension of FieldDef to define an unordered map, where
all entries are constrained to a single type.
|
| MapValue |
MapValue extends FieldValue to define a container object that holds
a map of FieldValue objects all of the same type.
|
| MetadataNotFoundException |
The exception is thrown when an expected piece of metadata is not found.
|
| MultiRowOptions |
Defines parameters used in multi-row operations.
|
| NodeMetrics |
The metrics associated with a node in the KVS.
|
| NoSQLBinaryStore |
|
| NoSQLPublisher |
Object represents a NoSQLPublisher which publishes changes to the NoSQL
store on order, an implementation of Reactive Streams Publisher interface.
|
| NoSQLPublisherConfig |
Configuration used to create an instance of NoSQLPublisher.
|
| NoSQLPublisherConfig.Builder |
Builder to help construct a NoSQLPublisherConfig instance
|
| NoSQLRuntimeException |
Generic exception class for generating runtime exceptions whose messages are
derived from a locale specific message file.
|
| NoSQLStreamMode |
Subscription stream mode used to configure the starting point for a NoSQL
subscription.
|
| NoSQLSubscriber |
The subscriber interface is to be implemented by the application.
|
| NoSQLSubscriberId |
Object to represent a subscriber id in a subscription group.
|
| NoSQLSubscription |
A NoSQL subscription to the source kvstore.
|
| NoSQLSubscriptionConfig |
Configuration used by the NoSQL Publisher to create a subscription.
|
| NoSQLSubscriptionConfig.Builder |
Builder to construct a NoSQLSubscriptionConfig instance
|
| NumberDef |
NumberDef is an extension of FieldDef to encapsulate the
BigDecimal type.
|
| NumberValue |
NumberValue extends FieldValue to represent a BigDecimal.
|
| Operation |
Denotes an Operation in a sequence of operations passed to the KVStore.execute method.
|
| Operation.Type |
The type of operation, as determined by the method used to create it.
|
| OperationExecutionException |
Used to indicate a failure to execute a sequence of operations.
|
| OperationFactory |
A factory to create operations that can be batched for execution by KVStore.execute.
|
| OperationMetrics |
Aggregates the metrics associated with a KVS operation.
|
| OperationResult |
The Result associated with the execution of an Operation.
|
| ParallelScanIterator<K> |
|
| PartialLOBException |
|
| PasswordCredentials |
Username/password credentials.
|
| PofKeySerializer |
This class provides Coherence Portable Object Format (POF) serialization of
the Key class.
|
| PreparedStatement |
Represents a Statement that has been compiled and an execution
plan generated for it.
|
| Preproc |
The Preproc utility is invoked by Oracle Database whenever a
SELECT is performed on an External Table that has been
associated with an Oracle NoSQL Database using the Publish utility.
|
| PrimaryKey |
PrimaryKey is a specialization of Row to represent a primary key used to
access records in a table using the TableAPI.
|
| Publish |
The Publish utility writes information about how to connect to an Oracle
NoSQL Database from an Oracle Database External Table.
|
| PublisherFailureException |
Exception that will be raised when NoSQL Publisher cannot be created due
to errors, or experiences irrecoverable errors and must be closed.
|
| ReadOptions |
ReadOptions is passed to read-only store operations to specify arguments that
control non-default behavior related to consistency and operation timeouts.
|
| ReadThroughputException |
Thrown when a read operation cannot be completed because the read
throughput rate limit has been exceeded.
|
| ReauthenticateHandler |
A callback interface used when KVStore authentication has expired and
requires renewal.
|
| RecordDef |
RecordDef represents a record type, which specifies a set of
RecordValues that conform to this type.
|
| RecordValue |
RecordValue extends FieldValue to represent a record value.
|
| RepNodeMXBean |
This MBean represents the RepNode's status, performance metrics, and
operational parameters.
|
| RequestLimitConfig |
Describes how requests may be limited so that one or more nodes with long
service times don't end up consuming all available threads in the KVS
client.
|
| RequestLimitException |
|
| RequestTimeoutException |
Thrown when a request cannot be processed because the configured timeout
interval is exceeded.
|
| ResourceLimitException |
A common exception base class for exceptions related to resource usage.
|
| ReturnRow |
ReturnRow is used with put and delete operations to return the previous row
value and version.
|
| ReturnRow.Choice |
Specifies whether to return the row value, version, both or neither.
|
| ReturnValueVersion |
Used with put and delete operations to return the previous value and
version.
|
| ReturnValueVersion.Choice |
Specifies whether to return the value, version, both or neither.
|
| Row |
Row is a specialization of RecordValue to represent a single record,
or row, in a table.
|
| SequenceDef |
IdentityDef represents an immutable metadata object used to represent
the properties of an identity column in a table.
|
| ServerResourceLimitException |
Thrown when the server is unable to handle a request because of resource
constraints.
|
| ShardTimeoutException |
Exception raised when publisher does not hear from source shard for a
given period of time.
|
| StaleStoreHandleException |
Thrown when a KVStore instance is no longer valid.
|
| Statement |
Base interface for all statements.
|
| StatementResult |
A StatementResult provides information about the execution and outcome of a
table statement.
|
| StatementResult |
Deprecated.
|
| StatementResult.Kind |
Shows the kind of StatementResult.
|
| StorageNodeMXBean |
This MBean represents the Storage Node's operational parameters.
|
| StoreIteratorConfig |
|
| StoreIteratorException |
|
| StoreIteratorMetrics |
Deprecated.
|
| StreamOperation |
The operation (Put, Delete) that was delivered over the NoSQL stream.
|
| StreamOperation.DeleteEvent |
Used to signal a Delete operation
|
| StreamOperation.PutEvent |
Used to signal a Put operation
|
| StreamOperation.SequenceId |
A SequenceId uniquely identifies a stream operation associated with a
Publisher.
|
| StreamOperation.Type |
The type of the operation.
|
| StreamPosition |
A StreamPosition represents a position in a subscription stream.
|
| StringDef |
StringDef is an extension of FieldDef to encapsulate a String.
|
| StringValue |
StringValue extends FieldValue to represent a string.
|
| SubscriptionChangeNotAppliedException |
Exception raised when change cannot be applied to the running
subscription, and the subscription is unchanged.
|
| SubscriptionChangeNotAppliedException.Reason |
Describes the reason that a change was not applied.
|
| SubscriptionFailureException |
Exception raised when a subscription fails.
|
| SubscriptionInsufficientLogException |
Exception used to indicate that the logs on at least one shard were
insufficient for the purposes of the stream.
|
| SubscriptionMetrics |
Object represents a set of statistics of a single subscription.
|
| SubscriptionTableNotFoundException |
Exception raised when one or more tables are not found in kvstore when
performing an operation on a subscription.
|
| Table |
Table is a handle on a table in the Oracle NoSQL Database.
|
| TableAccessException |
Thrown when an operation to a table cannot be completed due to limits on
write and possibly read access.
|
| TableAPI |
TableAPI is a handle for the table interface to an Oracle NoSQL
store.
|
| TableArrayObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.ARRAY to Hive column type LIST.
|
| TableBinaryObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of either type FieldDef.Type.BINARY or type FieldDef.Type.FIXED_BINARY
to Hive column type BINARY (byte[]).
|
| TableBooleanObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.BOOLEAN to Hive column type BOOLEAN.
|
| TableDoubleObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.DOUBLE to Hive column type DOUBLE.
|
| TableEnumObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.ENUM to Hive column type STRING.
|
| TableFieldTypeEnum |
Enum class that defines values corresponding to each of the enum
values defined in FieldDef.Type; which represent the possible field
types of a KV Store table.
|
| TableFloatObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.FLOAT to Hive column type FLOAT.
|
| TableFormatter |
TableFormatter is an interface to a user-specified class used for formatting
rows in NoSQL Database tables into Strings which are appropriate for
importing into a specific Oracle External Table.
|
| TableHiveInputFormat<K,V> |
A Hadoop MapReduce version 1 InputFormat class for reading data from an
Oracle NoSQL Database when processing a Hive query against data written
to that database using the Table API.
|
| TableHiveInputFormat.ColumnPredicateInfo |
Local class, intended as a convenient return type data structure, that
associates the comparison operation(s) specified in a given predicate
with a corresponding column (field) name.
|
| TableHiveInputSplit |
Concrete implementation of the InputSplit interface required by version 1
of MapReduce to support Hive queries.
|
| TableHiveRecordReader |
Concrete implementation of RecordReader; used to read PrimaryKey/Row pairs
from an InputSplit.
|
| TableInputFormat |
A Hadoop InputFormat class for reading data from an Oracle NoSQL Database.
|
| TableInputFormatBase<K,V> |
This is the base class for Oracle NoSQL Database InputFormat classes that
can be used to run MapReduce against data stored via the Table API.
|
| TableInputFormatBase.TopologyLocatorWrapper |
Special class that wraps the static get method of the TopologyLocator
utility.
|
| TableInputSplit |
Concrete implementation of the InputSplit interface required to perform
Hadoop MapReduce.
|
| TableIntObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.INTEGER to Hive column type INT.
|
| TableIterator<K> |
Interface to the specialized Iterator type returned by the iterator methods
in the oracle.kv.table package.
|
| TableIteratorOptions |
TableIteratorOptions extends ReadOptions and is passed to read-only store
operations that return iterators.
|
| TableJsonObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.JSON to Hive column type STRING.
|
| TableLongObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.LONG to Hive column type LONG.
|
| TableMapObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.MAP to Hive column type MAP.
|
| TableNumberObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.NUMBER to Hive column type DECIMAL.
|
| TableOperation |
Denotes a TableOperation in a sequence of operations passed to the TableAPI.execute method.
|
| TableOperation.Type |
The type of operation, as determined by the method used to create it.
|
| TableOperationFactory |
A factory to create operations that can be batched for execution by TableAPI.execute.
|
| TableOperationResult |
The Result associated with the execution of a TableOperation.
|
| TableOpExecutionException |
|
| TablePartitionSizeLimitException |
Thrown when write operations cannot be completed because a partition size
limit has been exceeded.
|
| TableRecordObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.RECORD to Hive column type STRUCT.
|
| TableRecordObjectInspector.TableStructField |
Special class provided to support testing the
getStructFieldData method; which casts the given
StructField parameter to the MyField
nested class of the StandardStructObjectInspector
class.
|
| TableRecordReader |
Concrete implementation of TableRecordReaderBase that reads table rows
from an InputSplit using a PrimaryKey.
|
| TableSerDe |
Concrete implementation of TableSerDeBase that performs deserialization
and/or serialization of data loaded into a KVStore via the PrimaryKey
based Table API.
|
| TableSizeLimitException |
Thrown when write operations cannot be completed because a table size
limit has been exceeded.
|
| TableStorageHandler |
Concrete implementation of TableStorageHandlerBase; which assumes that the
data accessed from the desired Oracle NoSQL Database has been stored, and
will be accessed, via the Table API.
|
| TableTaskAttemptContext |
Concrete implementation of Hadoop TaskAttemptContext interface.
|
| TableTimestampObjectInspector |
The Hive ObjectInspector that is used to translate KVStore row fields
of type FieldDef.Type.TIMESTAMP to Hive column type TIMESTAMP.
|
| TableUtils |
TableUtils is a utility class that encapsulates a number of useful
functions that do not belong in any specific interface.
|
| ThroughputLimitException |
Thrown when read or write operations cannot be completed because a
throughput rate limit has been exceeded.
|
| TimestampDef |
TimestampDef is an extension of FieldDef to encapsulate a Timestamp
type.
|
| TimestampValue |
TimestampValue extends FieldValue to represent a Timestamp value.
|
| TimeToLive |
TimeToLive is a utility class that represents a period of time, similar to
Java 8's java.time.Duration, but specialized to the needs of Oracle NoSQL
Database.
|
| UnauthorizedException |
This exception is thrown from methods where an authenticated user is
attempting to perform an operation for which they are not authorized.
|
| V1V2TableUtil |
Utility class that provides static convenience methods for managing the
interactions between version 1 and version 2 (YARN) MapReduce classes.
|
| Value |
The Value in a Key/Value store.
|
| Value.Format |
Identifies the format of a value.
|
| ValueBinding<T> |
Deprecated.
|
| ValueVersion |
Holds a Value and Version that are associated with a given Key.
|
| Version |
A Version refers to a specific version of a key-value pair.
|
| WriteOptions |
WriteOptions is passed to store operations that can update the store to
specify non-default behavior relating to durability, timeouts and expiry
operations.
|
| WriteThroughputException |
Thrown when a write operation cannot be completed because the write
throughput rate limit has been exceeded.
|