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

A

abort(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSUploadStream
Aborts the upload and deletes any data.
abort() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
Aborts the upload and deletes any data.
AbstractBsonReader - Class in org.bson
Abstract base class for BsonReader implementations.
AbstractBsonReader() - Constructor for class org.bson.AbstractBsonReader
Initializes a new instance of the BsonReader class.
AbstractBsonReader.Context - Class in org.bson
The context for the reader.
AbstractBsonReader.Mark - Class in org.bson
 
AbstractBsonReader.State - Enum in org.bson
The state of a reader.
AbstractBsonWriter - Class in org.bson
Represents a BSON writer for some external format (see subclasses).
AbstractBsonWriter(BsonWriterSettings) - Constructor for class org.bson.AbstractBsonWriter
Initializes a new instance of the BsonWriter class.
AbstractBsonWriter(BsonWriterSettings, FieldNameValidator) - Constructor for class org.bson.AbstractBsonWriter
Initializes a new instance of the BsonWriter class.
AbstractBsonWriter.Context - Class in org.bson
The context for the writer.
AbstractBsonWriter.Mark - Class in org.bson
Capture the current state of this writer - its AbstractBsonWriter.Context, AbstractBsonWriter.State, field name and depth.
AbstractBsonWriter.State - Enum in org.bson
The state of a writer.
Accumulators - Class in com.mongodb.client.model
Builders for accumulators used in the group pipeline stage of an aggregation pipeline.
acknowledged(WriteRequest.Type, int, List<BulkWriteUpsert>) - Static method in class com.mongodb.bulk.BulkWriteResult
Create an acknowledged BulkWriteResult
acknowledged(WriteRequest.Type, int, Integer, List<BulkWriteUpsert>) - Static method in class com.mongodb.bulk.BulkWriteResult
Create an acknowledged BulkWriteResult
acknowledged(int, int, int, Integer, List<BulkWriteUpsert>) - Static method in class com.mongodb.bulk.BulkWriteResult
Create an acknowledged BulkWriteResult
acknowledged(long) - Static method in class com.mongodb.client.result.DeleteResult
Create an acknowledged DeleteResult
acknowledged(long, Long, BsonValue) - Static method in class com.mongodb.client.result.UpdateResult
Create an acknowledged UpdateResult
ACKNOWLEDGED - Static variable in class com.mongodb.WriteConcern
Write operations that use this write concern will wait for acknowledgement, using the default write concern configured on the server.
acknowledged(int, boolean, BsonValue) - Static method in class com.mongodb.WriteConcernResult
Create an acknowledged WriteConcernResult
action(MapReduceAction) - Method in interface com.mongodb.async.client.MapReduceIterable
Specify the MapReduceAction to be used when writing to a collection.
action(MapReduceAction) - Method in interface com.mongodb.client.MapReduceIterable
Specify the MapReduceAction to be used when writing to a collection.
action(String) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the output action one of: "replace", "merge", "reduce"
add(String, Object) - Method in class com.mongodb.BasicDBObjectBuilder
Same as append
add(ConnectionListener) - Method in class com.mongodb.event.ConnectionEventMulticaster
Adds the given connection listener to the list of listeners to invoke on connection events.
add(ConnectionPoolListener) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Adds the given connection pool listener to the list of listeners to invoke on connection pool events.
add(BsonValue) - Method in class org.bson.BsonArray
 
add(int, BsonValue) - Method in class org.bson.BsonArray
 
add(Object) - Method in class org.bson.LazyBSONList
 
add(int, Object) - Method in class org.bson.LazyBSONList
 
addAll(Collection<? extends BsonValue>) - Method in class org.bson.BsonArray
 
addAll(int, Collection<? extends BsonValue>) - Method in class org.bson.BsonArray
 
addAll(Collection) - Method in class org.bson.LazyBSONList
 
addAll(int, Collection) - Method in class org.bson.LazyBSONList
 
addClusterListener(ClusterListener) - Method in class com.mongodb.connection.ClusterSettings.Builder
Adds a cluster listener.
addClusterListener(ClusterListener) - Method in class com.mongodb.MongoClientOptions.Builder
Adds the given cluster listener.
addCommandListener(CommandListener) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Adds the given command listener.
addCommandListener(CommandListener) - Method in class com.mongodb.MongoClientOptions.Builder
Adds the given command listener.
addDecodingHook(Class<?>, Transformer) - Static method in class org.bson.BSON
Registers a Transformer to use when decoding a specific class from BSON.
addEachToSet(String, List<TItem>) - Static method in class com.mongodb.client.model.Updates
Creates an update that adds each of the given values to the array value of the field with the given name, unless the value is already present, in which case it does nothing
addEncodingHook(Class<?>, Transformer) - Static method in class org.bson.BSON
Registers a Transformer to use to encode a specific class into BSON.
addErrorResult(MongoBulkWriteException, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Add an error result
addErrorResult(List<BulkWriteError>, WriteConcernError, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Add a list of error results and a write concern error
addFields(Field<?>...) - Static method in class com.mongodb.client.model.Aggregates
Creates an $addFields pipeline stage
addFields(List<Field<?>>) - Static method in class com.mongodb.client.model.Aggregates
Creates an $addFields pipeline stage
addOption(int) - Method in class com.mongodb.DB
Adds the given flag to the default query options.
addOption(int) - Method in class com.mongodb.DBCollection
Adds the given flag to the default query options.
addOption(int) - Method in class com.mongodb.DBCursor
Adds a query option.
addOption(int) - Method in class com.mongodb.Mongo
Deprecated.
Add options instead on instances of DBCursor
address(ServerAddress) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the address of the server.
addResult(BulkWriteResult, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Add a result
addServerListener(ServerListener) - Method in class com.mongodb.connection.ServerSettings.Builder
Add a server listener.
addServerListener(ServerListener) - Method in class com.mongodb.MongoClientOptions.Builder
Adds the given server listener.
addServerMonitorListener(ServerMonitorListener) - Method in class com.mongodb.connection.ServerSettings.Builder
Adds a server monitor listener.
addServerMonitorListener(ServerMonitorListener) - Method in class com.mongodb.MongoClientOptions.Builder
Adds the given server monitro listener.
addSpecial(String, Object) - Method in class com.mongodb.DBCursor
Adds a special operator like $maxScan or $returnKey.
addToSet(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing all unique values that results from applying the given expression to each document in a group of documents that share the same group by key.
addToSet(String, TItem) - Static method in class com.mongodb.client.model.Updates
Creates an update that adds the given value to the array value of the field with the given name, unless the value is already present, in which case it does nothing
addUser(String, char[]) - Method in class com.mongodb.DB
Deprecated.
Use DB.command to call either the createUser or updateUser command
addUser(String, char[], boolean) - Method in class com.mongodb.DB
Deprecated.
Use DB.command to call either the createUser or updateUser command
addWriteConcernErrorResult(WriteConcernError) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Add a write concern error result
addWriteErrorResult(BulkWriteError, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Add a write error result
aggregate(List<? extends Bson>) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified aggregation pipeline.
aggregate(List<? extends Bson>, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified aggregation pipeline.
aggregate(List<? extends Bson>) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified aggregation pipeline.
aggregate(List<? extends Bson>, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified aggregation pipeline.
aggregate(DBObject, DBObject...) - Method in class com.mongodb.DBCollection
aggregate(List<? extends DBObject>) - Method in class com.mongodb.DBCollection
Method implements aggregation framework.
aggregate(List<? extends DBObject>, ReadPreference) - Method in class com.mongodb.DBCollection
Method implements aggregation framework.
aggregate(List<? extends DBObject>, AggregationOptions) - Method in class com.mongodb.DBCollection
Method implements aggregation framework.
aggregate(List<? extends DBObject>, AggregationOptions, ReadPreference) - Method in class com.mongodb.DBCollection
Method implements aggregation framework.
AggregateIterable<TResult> - Interface in com.mongodb.async.client
Iterable for aggregate.
AggregateIterable<TResult> - Interface in com.mongodb.client
Iterable for aggregate.
AggregateOperation<T> - Class in com.mongodb.operation
An operation that executes an aggregation query.
AggregateOperation(MongoNamespace, List<BsonDocument>, Decoder<T>) - Constructor for class com.mongodb.operation.AggregateOperation
Construct a new instance.
Aggregates - Class in com.mongodb.client.model
Builders for aggregation pipeline stages.
AggregateToCollectionOperation - Class in com.mongodb.operation
An operation that executes an aggregation that writes its results to a collection (which is what makes this a write operation rather than a read operation).
AggregateToCollectionOperation(MongoNamespace, List<BsonDocument>) - Constructor for class com.mongodb.operation.AggregateToCollectionOperation
AggregateToCollectionOperation(MongoNamespace, List<BsonDocument>, WriteConcern) - Constructor for class com.mongodb.operation.AggregateToCollectionOperation
Construct a new instance.
AggregationOptions - Class in com.mongodb
The options to apply to an aggregate operation.
AggregationOptions.Builder - Class in com.mongodb
Builder for creating AggregationOptions.
AggregationOptions.OutputMode - Enum in com.mongodb
Enumeration to define where the results of the aggregation will be output.
AggregationOutput - Class in com.mongodb
Container for the result of aggregation operation.
all(String, TItem...) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of a field is an array that contains all the specified values.
all(String, Iterable<TItem>) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of a field is an array that contains all the specified values.
all(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $all operand
ALL - Static variable in class com.mongodb.QueryOperators
 
allocator(ByteBufAllocator) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
Sets the allocator.
allowDiskUse(Boolean) - Method in class com.mongodb.AggregationOptions.Builder
Set whether to enable external sort capabilities.
allowDiskUse(Boolean) - Method in interface com.mongodb.async.client.AggregateIterable
Enables writing to temporary files.
allowDiskUse(Boolean) - Method in interface com.mongodb.client.AggregateIterable
Enables writing to temporary files.
allowDiskUse(Boolean) - Method in class com.mongodb.operation.AggregateOperation
Enables writing to temporary files.
allowDiskUse(Boolean) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Enables writing to temporary files.
alwaysUseMBeans(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Sets whether JMX beans registered by the driver should always be MBeans, regardless of whether the VM is Java 6 or greater.
alwaysUseMBeans - Variable in class com.mongodb.MongoOptions
Deprecated.
Sets whether JMX beans registered by the driver should always be MBeans, regardless of whether the VM is Java 6 or greater.
and(Iterable<Bson>) - Static method in class com.mongodb.client.model.Filters
Creates a filter that performs a logical AND of the provided list of filters.
and(Bson...) - Static method in class com.mongodb.client.model.Filters
Creates a filter that performs a logical AND of the provided list of filters.
and(String) - Method in class com.mongodb.QueryBuilder
Equivalent to QueryBuilder.put(key).
and(DBObject...) - Method in class com.mongodb.QueryBuilder
Equivalent to an $and operand
AND - Static variable in class com.mongodb.QueryOperators
 
append(String, Object) - Method in class com.mongodb.BasicDBObject
Add a key/value pair to this object
append(String, Object) - Method in class com.mongodb.BasicDBObjectBuilder
Appends the key/value to the active object
append(String, Object) - Method in class org.bson.BasicBSONObject
Add a key/value pair to this object
append(String, BsonValue) - Method in class org.bson.BsonDocument
Put the given key and value into this document, and return the document.
append(String, Object) - Method in class org.bson.Document
Put the given key/value pair into this Document and return this.
append(String, BsonValue) - Method in class org.bson.RawBsonDocument
 
applicationName(String) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the logical name of the application using this MongoClient.
applicationName(String) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the logical name of the application using this MongoClient.
apply(T) - Method in interface com.mongodb.Block
Apply some logic to the value.
apply(T) - Method in interface com.mongodb.Function
Yield an appropriate result object for the input object.
applyConnectionString(ConnectionString) - Method in class com.mongodb.connection.ClusterSettings.Builder
Take the settings from the given ConnectionString and add them to the builder
applyConnectionString(ConnectionString) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
Takes connection pool settings from the given connection string and applies them to this builder.
applyConnectionString(ConnectionString) - Method in class com.mongodb.connection.ServerSettings.Builder
Take the settings from the given ConnectionString and add them to the builder
applyConnectionString(ConnectionString) - Method in class com.mongodb.connection.SocketSettings.Builder
Apply any socket settings specified in the connection string to this builder.
applyConnectionString(ConnectionString) - Method in class com.mongodb.connection.SslSettings.Builder
Take the settings from the given ConnectionString and set them in this builder.
applyDecodingHooks(Object) - Static method in class org.bson.BSON
Transforms the objectToDecode using all transformers registered for the class of this object.
applyEncodingHooks(Object) - Static method in class org.bson.BSON
Transforms the objectToEncode using all transformers registered for the class of this object.
arbiters(Set<String>) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the arbiters in the replica set
ARRAY - Static variable in class org.bson.BSON
 
array() - Method in interface org.bson.ByteBuf
Returns the byte array that backs this buffer (optional operation).
array() - Method in class org.bson.ByteBufNIO
 
arrayDone() - Method in class org.bson.BasicBSONCallback
 
arrayDone() - Method in interface org.bson.BSONCallback
Called the end of the array, and returns the completed array.
arrayDone() - Method in class org.bson.EmptyBSONCallback
 
arrayStart(String) - Method in class com.mongodb.util.JSONCallback
 
arrayStart() - Method in class org.bson.BasicBSONCallback
 
arrayStart(String) - Method in class org.bson.BasicBSONCallback
 
arrayStart() - Method in interface org.bson.BSONCallback
Signals the start of a BSON array.
arrayStart(String) - Method in interface org.bson.BSONCallback
Signals the start of a BSON array, with its field name.
arrayStart() - Method in class org.bson.EmptyBSONCallback
 
arrayStart(String) - Method in class org.bson.EmptyBSONCallback
 
asArray() - Method in class org.bson.BsonValue
Gets this value as a BsonArray if it is one, otherwise throws exception
asBinary() - Method in class org.bson.BsonValue
Gets this value as a BsonBinary if it is one, otherwise throws exception
asBoolean() - Method in class org.bson.BsonValue
Gets this value as a BsonBoolean if it is one, otherwise throws exception
asBsonDocument(Object, CodecRegistry) - Static method in class org.bson.BsonDocumentWrapper
A helper to convert an document of type Object to a BsonDocument
ascending(String...) - Static method in class com.mongodb.client.model.Indexes
Create an index key for an ascending index on the given fields.
ascending(List<String>) - Static method in class com.mongodb.client.model.Indexes
Create an index key for an ascending index on the given fields.
ascending(String...) - Static method in class com.mongodb.client.model.Sorts
Create a sort specification for an ascending sort on the given fields.
ascending(List<String>) - Static method in class com.mongodb.client.model.Sorts
Create a sort specification for an ascending sort on the given fields.
asDateTime() - Method in class org.bson.BsonValue
Gets this value as a BsonDateTime if it is one, otherwise throws exception
asDBPointer() - Method in class org.bson.BsonValue
Gets this value as a BsonDbPointer if it is one, otherwise throws exception
asDecimal128() - Method in class org.bson.BsonValue
Gets this value as a BsonDecimal128 if it is one, otherwise throws exception
asDocument() - Method in class com.mongodb.client.model.Collation
Gets this collation options as a document.
asDocument() - Method in class com.mongodb.ReadConcern
Gets this read concern as a document.
asDocument() - Method in class com.mongodb.WriteConcern
Gets this write concern as a document.
asDocument() - Method in class org.bson.BsonValue
Gets this value as a BsonDocument if it is one, otherwise throws exception
asDouble() - Method in class org.bson.BsonValue
Gets this value as a BsonDouble if it is one, otherwise throws exception
asExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.AggregateOperation
Gets an operation whose execution explains this operation.
asExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.CountOperation
Gets an operation whose execution explains this operation.
asExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.FindOperation
Gets an operation whose execution explains this operation.
asExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets an operation whose execution explains this operation.
asExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets an operation whose execution explains this operation.
asExplainableOperationAsync(ExplainVerbosity) - Method in class com.mongodb.operation.AggregateOperation
Gets an operation whose execution explains this operation.
asExplainableOperationAsync(ExplainVerbosity) - Method in class com.mongodb.operation.CountOperation
Gets an operation whose execution explains this operation.
asExplainableOperationAsync(ExplainVerbosity) - Method in class com.mongodb.operation.FindOperation
Gets an operation whose execution explains this operation.
asExplainableOperationAsync(ExplainVerbosity) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets an operation whose execution explains this operation.
asExplainableOperationAsync(ExplainVerbosity) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets an operation whose execution explains this operation.
asInt32() - Method in class org.bson.BsonValue
Gets this value as a BsonInt32 if it is one, otherwise throws exception
asInt64() - Method in class org.bson.BsonValue
Gets this value as a BsonInt64 if it is one, otherwise throws exception
asJavaScript() - Method in class org.bson.BsonValue
Gets this value as a BsonJavaScript if it is one, otherwise throws exception
asJavaScriptWithScope() - Method in class org.bson.BsonValue
Gets this value as a BsonJavaScriptWithScope if it is one, otherwise throws exception
asNIO() - Method in interface org.bson.ByteBuf
Gets the underlying NIO ByteBuffer.
asNIO() - Method in class org.bson.ByteBufNIO
 
asNumber() - Method in class org.bson.BsonValue
Gets this value as a BsonNumber if it is one, otherwise throws exception
asObjectId() - Method in class org.bson.BsonValue
Gets this value as an BsonObjectId if it is one, otherwise throws exception
asReadOnly() - Method in interface org.bson.ByteBuf
Creates a new, read-only byte buffer that shares this buffer's content.
asReadOnly() - Method in class org.bson.ByteBufNIO
 
asRegularExpression() - Method in class org.bson.BsonValue
Gets this value as a BsonRegularExpression if it is one, otherwise throws exception
Assertions - Class in com.mongodb.assertions
Design by contract assertions.
Assertions - Class in org.bson.assertions
Design by contract assertions.
asString() - Method in class org.bson.BsonValue
Gets this value as a BsonString if it is one, otherwise throws exception
asSymbol() - Method in class org.bson.BsonValue
Gets this value as a BsonSymbol if it is one, otherwise throws exception
asTimestamp() - Method in class org.bson.BsonValue
Gets this value as a BsonTimestamp if it is one, otherwise throws exception
AsyncBatchCursor<T> - Interface in com.mongodb.async
MongoDB returns query results as batches, and this interface provides an asynchronous iterator over those batches.
AsyncClusterBinding - Class in com.mongodb.binding
A simple ReadWriteBinding implementation that supplies write connection sources bound to a possibly different primary each time, and a read connection source bound to a possible different server each time.
AsyncClusterBinding(Cluster, ReadPreference) - Constructor for class com.mongodb.binding.AsyncClusterBinding
Creates an instance.
AsyncCompletionHandler<T> - Interface in com.mongodb.connection
Completion handler for asynchronous I/O.
AsyncConnection - Interface in com.mongodb.connection
An asynchronous connection to a MongoDB server with non-blocking operations.
AsyncConnectionSource - Interface in com.mongodb.binding
A source of connections to a single MongoDB server.
AsynchronousChannelHelper - Class in com.mongodb.async.client.gridfs.helpers
A helper class to convert to AsynchronousByteChannel or AsynchronousFileChannel instances into AsyncInputStream or AsyncOutputStream instances.
AsynchronousSocketChannelStreamFactory - Class in com.mongodb.connection
Factory to create a Stream that's an AsynchronousSocketChannelStream.
AsynchronousSocketChannelStreamFactory(SocketSettings, SslSettings) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStreamFactory
Create a new factory.
AsynchronousSocketChannelStreamFactoryFactory - Class in com.mongodb.connection
A StreamFactoryFactory implementation for AsynchronousSocketChannel-based streams.
AsynchronousSocketChannelStreamFactoryFactory() - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory
 
AsyncInputStream - Interface in com.mongodb.async.client.gridfs
The Async Input Stream interface represents some asynchronous input stream of bytes.
AsyncOperationExecutor - Interface in com.mongodb.operation
An interface describing the execution of a read or a write operation.
AsyncOutputStream - Interface in com.mongodb.async.client.gridfs
The Async Output Stream interface represents some asynchronous output stream of bytes.
AsyncReadBinding - Interface in com.mongodb.binding
An asynchronous factory of connection sources to servers that can be read from and that satisfy the specified read preference.
AsyncReadOperation<T> - Interface in com.mongodb.operation
An operation which asynchronously reads from a MongoDB server.
AsyncReadWriteBinding - Interface in com.mongodb.binding
An asynchronous factory of connection sources to servers that can be read from or written to.
AsyncSingleConnectionReadBinding - Class in com.mongodb.binding
An asynchronous read binding that is bound to a single connection.
AsyncSingleConnectionReadBinding(ReadPreference, ServerDescription, AsyncConnection) - Constructor for class com.mongodb.binding.AsyncSingleConnectionReadBinding
Construct an instance.
AsyncStreamHelper - Class in com.mongodb.async.client.gridfs.helpers
A general helper class that creates AsyncInputStream or AsyncOutputStream instances.
AsyncWriteBinding - Interface in com.mongodb.binding
An asynchronous factory of connection sources to servers that can be written to, e.g, a standalone, a mongos, or a replica set primary.
AsyncWriteOperation<T> - Interface in com.mongodb.operation
An operation which asynchronously writes to a MongoDB server.
AtomicBooleanCodec - Class in org.bson.codecs
Encodes and decodes AtomicBoolean objects.
AtomicBooleanCodec() - Constructor for class org.bson.codecs.AtomicBooleanCodec
 
AtomicIntegerCodec - Class in org.bson.codecs
Encodes and decodes AtomicInteger objects.
AtomicIntegerCodec() - Constructor for class org.bson.codecs.AtomicIntegerCodec
 
AtomicLongCodec - Class in org.bson.codecs
Encodes and decodes AtomicLong objects.
AtomicLongCodec() - Constructor for class org.bson.codecs.AtomicLongCodec
 
AuthenticationMechanism - Enum in com.mongodb
An enumeration of the MongodDB-supported authentication mechanisms.
autoIndex(boolean) - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets if auto-index is to be enabled on the collection
autoIndex(boolean) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets if _id field of the collection is indexed.
available() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
avg(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the average of the values of the given expression when applied to all members of the group.

B

B_BINARY - Static variable in class org.bson.BSON
 
B_FUNC - Static variable in class org.bson.BSON
 
B_GENERAL - Static variable in class org.bson.BSON
 
B_UUID - Static variable in class org.bson.BSON
 
background(boolean) - Method in class com.mongodb.bulk.IndexRequest
Should the index should be created in the background
background(boolean) - Method in class com.mongodb.client.model.IndexOptions
Should the index should be created in the background
backwards(Boolean) - Method in class com.mongodb.client.model.Collation.Builder
Sets the backwards value
BaseWriteOperation - Class in com.mongodb.operation
Abstract base class for write operations.
BaseWriteOperation(MongoNamespace, boolean, WriteConcern) - Constructor for class com.mongodb.operation.BaseWriteOperation
Construct an instance
BasicBSONCallback - Class in org.bson
An implementation of BsonCallback that creates an instance of BSONObject.
BasicBSONCallback() - Constructor for class org.bson.BasicBSONCallback
Creates a new instance.
BasicBSONDecoder - Class in org.bson
Basic implementation of BSONDecoder interface that creates BasicBSONObject instances
BasicBSONDecoder() - Constructor for class org.bson.BasicBSONDecoder
 
BasicBSONEncoder - Class in org.bson
This is meant to be pooled or cached.
BasicBSONEncoder() - Constructor for class org.bson.BasicBSONEncoder
 
BasicBSONList - Class in org.bson.types
Utility class to allow array DBObjects to be created.
BasicBSONList() - Constructor for class org.bson.types.BasicBSONList
 
BasicBSONObject - Class in org.bson
A simple implementation of DBObject.
BasicBSONObject() - Constructor for class org.bson.BasicBSONObject
Creates an empty object.
BasicBSONObject(int) - Constructor for class org.bson.BasicBSONObject
Creates an empty object.
BasicBSONObject(String, Object) - Constructor for class org.bson.BasicBSONObject
Creates a BSONObject initialised with a single key/value pair.
BasicBSONObject(Map) - Constructor for class org.bson.BasicBSONObject
Creates a DBObject from a map.
BasicDBList - Class in com.mongodb
An implementation of List that reflects the way BSON lists work.
BasicDBList() - Constructor for class com.mongodb.BasicDBList
 
BasicDBObject - Class in com.mongodb
A basic implementation of BSON object that is MongoDB specific.
BasicDBObject() - Constructor for class com.mongodb.BasicDBObject
Creates an empty object.
BasicDBObject(int) - Constructor for class com.mongodb.BasicDBObject
Creates an empty object
BasicDBObject(String, Object) - Constructor for class com.mongodb.BasicDBObject
Creates an object with the given key/value
BasicDBObject(Map) - Constructor for class com.mongodb.BasicDBObject
Creates an object from a map.
BasicDBObjectBuilder - Class in com.mongodb
Utility for building complex objects.
BasicDBObjectBuilder() - Constructor for class com.mongodb.BasicDBObjectBuilder
Creates a builder intialized with an empty document.
BasicOutputBuffer - Class in org.bson.io
A BSON output stream that stores the output in a single, un-pooled byte array.
BasicOutputBuffer() - Constructor for class org.bson.io.BasicOutputBuffer
Construct an instance with a default initial byte array size.
BasicOutputBuffer(int) - Constructor for class org.bson.io.BasicOutputBuffer
Construct an instance with the specified initial byte array size.
batchCursor(SingleResultCallback<AsyncBatchCursor<TResult>>) - Method in interface com.mongodb.async.client.MongoIterable
Provide the underlying AsyncBatchCursor allowing fine grained control of the cursor.
BatchCursor<T> - Interface in com.mongodb.operation
MongoDB returns query results as batches, and this interface provideds an iterator over those batches.
batchSize(Integer) - Method in class com.mongodb.AggregationOptions.Builder
Sets the size of batches to use when iterating over results.
batchSize(int) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.FindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.gridfs.GridFSDownloadStream
Sets the number of chunks to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.ListCollectionsIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.ListDatabasesIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.ListIndexesIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.async.client.MongoIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.AggregateIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.DistinctIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.FindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
Sets the number of chunks to return per batch.
batchSize(int) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.ListCollectionsIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.ListDatabasesIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.ListIndexesIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in interface com.mongodb.client.MapReduceIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.client.model.FindOptions
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.client.model.ParallelCollectionScanOptions
Deprecated.
The batch size to use for each cursor.
batchSize(int) - Method in interface com.mongodb.client.MongoIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.DBCursor
Limits the number of elements returned in one batch.
batchSize(Integer) - Method in class com.mongodb.operation.AggregateOperation
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.operation.FindOperation
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.operation.ListCollectionsOperation
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.operation.ListIndexesOperation
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
The batch size to use for each cursor.
batchSize(int) - Method in class com.mongodb.ParallelScanOptions.Builder
The batch size to use for each cursor.
Beta - Annotation Type in com.mongodb.annotations
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
bigDecimalValue() - Method in class org.bson.types.Decimal128
Gets a BigDecimal that is equivalent to this Decimal128.
BINARY - Static variable in class org.bson.BSON
 
Binary - Class in org.bson.types
Generic binary holder.
Binary(byte[]) - Constructor for class org.bson.types.Binary
Creates a Binary object with the default binary type of 0
Binary(BsonBinarySubType, byte[]) - Constructor for class org.bson.types.Binary
Creates a Binary with the specified type and data.
Binary(byte, byte[]) - Constructor for class org.bson.types.Binary
Creates a Binary object
BinaryCodec - Class in org.bson.codecs
A Codec for the BSON Binary type.
BinaryCodec() - Constructor for class org.bson.codecs.BinaryCodec
 
bits(Integer) - Method in class com.mongodb.bulk.IndexRequest
Sets the number of precision of the stored geohash value of the location data in 2d indexes.
bits(Integer) - Method in class com.mongodb.client.model.IndexOptions
Sets the number of precision of the stored geohash value of the location data in 2d indexes.
Bits - Class in org.bson.io
Utility class for reading values from an input stream.
Bits() - Constructor for class org.bson.io.Bits
 
bitsAllClear(String, long) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where all of the bit positions are clear in the field.
bitsAllSet(String, long) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where all of the bit positions are set in the field.
bitsAnyClear(String, long) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where any of the bit positions are clear in the field.
bitsAnySet(String, long) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where any of the bit positions are set in the field.
bitwiseAnd(String, int) - Static method in class com.mongodb.client.model.Updates
Creates an update that performs a bitwise and between the given integer value and the integral value of the field with the given name.
bitwiseAnd(String, long) - Static method in class com.mongodb.client.model.Updates
Creates an update that performs a bitwise and between the given long value and the integral value of the field with the given name.
bitwiseOr(String, int) - Static method in class com.mongodb.client.model.Updates
Creates an update that performs a bitwise or between the given integer value and the integral value of the field with the given name.
bitwiseOr(String, long) - Static method in class com.mongodb.client.model.Updates
Creates an update that performs a bitwise or between the given long value and the integral value of the field with the given name.
bitwiseXor(String, int) - Static method in class com.mongodb.client.model.Updates
Creates an update that performs a bitwise xor between the given integer value and the integral value of the field with the given name.
bitwiseXor(String, long) - Static method in class com.mongodb.client.model.Updates
Creates an update that performs a bitwise xor between the given long value and the integral value of the field with the given name.
Block<T> - Interface in com.mongodb
An interface for applying some logic against the given parameter.
BOOLEAN - Static variable in class org.bson.BSON
 
BooleanCodec - Class in org.bson.codecs
Encodes and decodes Boolean objects.
BooleanCodec() - Constructor for class org.bson.codecs.BooleanCodec
 
BOX - Static variable in class com.mongodb.QueryOperators
 
BSON - Class in org.bson
Contains byte representations of all the BSON types (see the BSON Specification).
BSON() - Constructor for class org.bson.BSON
 
Bson - Interface in org.bson.conversions
An interface for types that are able to render themselves into a BsonDocument.
BsonArray - Class in org.bson
A type-safe representation of the BSON array type.
BsonArray(List<? extends BsonValue>) - Constructor for class org.bson.BsonArray
Construct an instance with the given list of values.
BsonArray() - Constructor for class org.bson.BsonArray
Construct an empty B
BsonArrayCodec - Class in org.bson.codecs
A codec for BsonArray instances.
BsonArrayCodec(CodecRegistry) - Constructor for class org.bson.codecs.BsonArrayCodec
Construct an instance with the given registry
BsonBinary - Class in org.bson
A representation of the BSON Binary type.
BsonBinary(byte[]) - Constructor for class org.bson.BsonBinary
Construct a new instance with the given data and the default sub-type
BsonBinary(BsonBinarySubType, byte[]) - Constructor for class org.bson.BsonBinary
Construct a new instance with the given data and binary sub type.
BsonBinary(byte, byte[]) - Constructor for class org.bson.BsonBinary
Construct a new instance with the given data and binary sub type.
BsonBinaryCodec - Class in org.bson.codecs
A Codec for the BSON Binary type.
BsonBinaryCodec() - Constructor for class org.bson.codecs.BsonBinaryCodec
 
BsonBinaryReader - Class in org.bson
A BsonReader implementation that reads from a binary stream of data.
BsonBinaryReader(ByteBuffer) - Constructor for class org.bson.BsonBinaryReader
Construct an instance.
BsonBinaryReader(BsonInput) - Constructor for class org.bson.BsonBinaryReader
Construct an instance.
BsonBinaryReader.Context - Class in org.bson
 
BsonBinaryReader.Mark - Class in org.bson
 
BsonBinarySubType - Enum in org.bson
The Binary subtype
BsonBinaryWriter - Class in org.bson
A BsonWriter implementation that writes to a binary stream of data.
BsonBinaryWriter(BsonOutput, FieldNameValidator) - Constructor for class org.bson.BsonBinaryWriter
Construct an instance.
BsonBinaryWriter(BsonOutput) - Constructor for class org.bson.BsonBinaryWriter
Construct an instance.
BsonBinaryWriter(BsonWriterSettings, BsonBinaryWriterSettings, BsonOutput) - Constructor for class org.bson.BsonBinaryWriter
Construct an instance.
BsonBinaryWriter(BsonWriterSettings, BsonBinaryWriterSettings, BsonOutput, FieldNameValidator) - Constructor for class org.bson.BsonBinaryWriter
Construct an instance.
BsonBinaryWriter.Context - Class in org.bson
 
BsonBinaryWriter.Mark - Class in org.bson
 
BsonBinaryWriterSettings - Class in org.bson
The customisable settings for writing BSON.
BsonBinaryWriterSettings(int) - Constructor for class org.bson.BsonBinaryWriterSettings
Creates a new instance of the settings with the given maximum document size.
BsonBinaryWriterSettings() - Constructor for class org.bson.BsonBinaryWriterSettings
Creates a new instance of the settings with Integer.MAX_VALUE as the maximum document size.
BsonBoolean - Class in org.bson
A representation of the BSON Boolean type.
BsonBoolean(boolean) - Constructor for class org.bson.BsonBoolean
Construct a new instance with the given value.
BsonBooleanCodec - Class in org.bson.codecs
A Codec for BsonBoolean instances.
BsonBooleanCodec() - Constructor for class org.bson.codecs.BsonBooleanCodec
 
BSONCallback - Interface in org.bson
A callback interface for describing the structure of a BSON document.
BsonContextType - Enum in org.bson
Used by BsonReader and BsonWriter implementations to represent the current context.
BsonDateTime - Class in org.bson
A representation of the BSON DateTime type.
BsonDateTime(long) - Constructor for class org.bson.BsonDateTime
Construct a new instance with the given value.
BsonDateTimeCodec - Class in org.bson.codecs
A Codec for BsonDateTime instances.
BsonDateTimeCodec() - Constructor for class org.bson.codecs.BsonDateTimeCodec
 
BsonDbPointer - Class in org.bson
Holder for a BSON type DBPointer(0x0c).
BsonDbPointer(String, ObjectId) - Constructor for class org.bson.BsonDbPointer
Construct a new instance with the given namespace and id.
BsonDBPointerCodec - Class in org.bson.codecs
Converts BSON type DBPointer(0x0c) to database references as DBPointer is deprecated.
BsonDBPointerCodec() - Constructor for class org.bson.codecs.BsonDBPointerCodec
 
BsonDecimal128 - Class in org.bson
A representation of the BSON Decimal128 type.
BsonDecimal128(Decimal128) - Constructor for class org.bson.BsonDecimal128
Construct a new instance with the given value.
BsonDecimal128Codec - Class in org.bson.codecs
A Codec for BsonDecimal128 instances.
BsonDecimal128Codec() - Constructor for class org.bson.codecs.BsonDecimal128Codec
 
BSONDecoder - Interface in org.bson
An interface for decoders of BSON documents.
BsonDocument - Class in org.bson
A type-safe container for a BSON document.
BsonDocument(List<BsonElement>) - Constructor for class org.bson.BsonDocument
Construct a new instance with the given list BsonElement, none of which may be null.
BsonDocument(String, BsonValue) - Constructor for class org.bson.BsonDocument
Construct a new instance with a single key value pair
BsonDocument() - Constructor for class org.bson.BsonDocument
Construct an empty document.
BsonDocumentCodec - Class in org.bson.codecs
A codec for BsonDocument instances.
BsonDocumentCodec() - Constructor for class org.bson.codecs.BsonDocumentCodec
Creates a new instance with a default codec registry that uses the BsonValueCodecProvider.
BsonDocumentCodec(CodecRegistry) - Constructor for class org.bson.codecs.BsonDocumentCodec
Creates a new instance initialised with the given codec registry.
BsonDocumentReader - Class in org.bson
A BsonReader implementation that reads from an instance of BsonDocument.
BsonDocumentReader(BsonDocument) - Constructor for class org.bson.BsonDocumentReader
Construct a new instance.
BsonDocumentReader.Context - Class in org.bson
 
BsonDocumentReader.Mark - Class in org.bson
 
BsonDocumentWrapper<T> - Class in org.bson
A BsonDocument that begins its life as a document of any type and an Encoder for that document, which lets an instance of any class with an Encoder be treated as a BsonDocument.
BsonDocumentWrapper(T, Encoder<T>) - Constructor for class org.bson.BsonDocumentWrapper
Construct a new instance with the given document and encoder for the document.
BsonDocumentWrapperCodec - Class in org.bson.codecs
A Codec
BsonDocumentWrapperCodec(Codec<BsonDocument>) - Constructor for class org.bson.codecs.BsonDocumentWrapperCodec
Construct a new instance,
BsonDocumentWriter - Class in org.bson
A BsonWriter implementation that writes to an instance of BsonDocument.
BsonDocumentWriter(BsonDocument) - Constructor for class org.bson.BsonDocumentWriter
Construct a new instance.
BsonDouble - Class in org.bson
A representation of the BSON Double type.
BsonDouble(double) - Constructor for class org.bson.BsonDouble
Construct a new instance with the given value.
BsonDoubleCodec - Class in org.bson.codecs
A Codec for BsonDouble instances.
BsonDoubleCodec() - Constructor for class org.bson.codecs.BsonDoubleCodec
 
BsonElement - Class in org.bson
A mapping from a name to a BsonValue.
BsonElement(String, BsonValue) - Constructor for class org.bson.BsonElement
Construct a new instance with the given key and value
BSONEncoder - Interface in org.bson
A BSONEncoder is a class which can be used to turn documents into byte arrays.
BSONException - Exception in org.bson
A general runtime exception raised in BSON processing.
BSONException(String) - Constructor for exception org.bson.BSONException
 
BSONException(int, String) - Constructor for exception org.bson.BSONException
 
BSONException(String, Throwable) - Constructor for exception org.bson.BSONException
 
BSONException(int, String, Throwable) - Constructor for exception org.bson.BSONException
 
BsonField - Class in com.mongodb.client.model
A representation of a BSON document field whose value is another BSON document.
BsonField(String, Bson) - Constructor for class com.mongodb.client.model.BsonField
Construct an instance
BsonInput - Interface in org.bson.io
An input stream that is optimized for reading BSON values directly from the underlying stream.
BsonInt32 - Class in org.bson
A representation of the BSON Int32 type.
BsonInt32(int) - Constructor for class org.bson.BsonInt32
Construct a new instance with the given value.
BsonInt32Codec - Class in org.bson.codecs
A Codec for BsonInt32 instances.
BsonInt32Codec() - Constructor for class org.bson.codecs.BsonInt32Codec
 
BsonInt64 - Class in org.bson
A representation of the BSON Int64 type.
BsonInt64(long) - Constructor for class org.bson.BsonInt64
Construct a new instance with the given value.
BsonInt64Codec - Class in org.bson.codecs
A Codec for BsonInt64 instances.
BsonInt64Codec() - Constructor for class org.bson.codecs.BsonInt64Codec
 
BsonInvalidOperationException - Exception in org.bson
An exception indicating an invalid BSON operation.
BsonInvalidOperationException(String) - Constructor for exception org.bson.BsonInvalidOperationException
Construct a new instance.
BsonJavaScript - Class in org.bson
For using the JavaScript Code type.
BsonJavaScript(String) - Constructor for class org.bson.BsonJavaScript
Construct a new instance with the given JavaScript code.
BsonJavaScriptCodec - Class in org.bson.codecs
A Codec for the BsonJavaScript type.
BsonJavaScriptCodec() - Constructor for class org.bson.codecs.BsonJavaScriptCodec
 
BsonJavaScriptWithScope - Class in org.bson
A representation of the JavaScript Code with Scope BSON type.
BsonJavaScriptWithScope(String, BsonDocument) - Constructor for class org.bson.BsonJavaScriptWithScope
Construct a new instance with the given code and scope.
BsonJavaScriptWithScopeCodec - Class in org.bson.codecs
A Codec for BsonJavaScriptWithScope instances.
BsonJavaScriptWithScopeCodec(Codec<BsonDocument>) - Constructor for class org.bson.codecs.BsonJavaScriptWithScopeCodec
Construct a new instance with the given codec to use for the nested document
BsonMaxKey - Class in org.bson
Represent the maximum key value regardless of the key's type
BsonMaxKey() - Constructor for class org.bson.BsonMaxKey
 
BsonMaxKeyCodec - Class in org.bson.codecs
A codec for BsonMaxKey instances.
BsonMaxKeyCodec() - Constructor for class org.bson.codecs.BsonMaxKeyCodec
 
BsonMinKey - Class in org.bson
Represent the minimum key value regardless of the key's type
BsonMinKey() - Constructor for class org.bson.BsonMinKey
 
BsonMinKeyCodec - Class in org.bson.codecs
A codec for BsonMinKey instances.
BsonMinKeyCodec() - Constructor for class org.bson.codecs.BsonMinKeyCodec
 
BsonNull - Class in org.bson
A representation of the BSON Null type.
BsonNull() - Constructor for class org.bson.BsonNull
 
BsonNullCodec - Class in org.bson.codecs
A Codec for BsonNull instances.
BsonNullCodec() - Constructor for class org.bson.codecs.BsonNullCodec
 
BsonNumber - Class in org.bson
Base class for the three numeric BSON types.
BsonNumber() - Constructor for class org.bson.BsonNumber
 
BSONObject - Interface in org.bson
A key-value map that can be saved to the database.
BsonObjectId - Class in org.bson
A representation of the BSON ObjectId type.
BsonObjectId() - Constructor for class org.bson.BsonObjectId
Construct a new instance with a new ObjectId.
BsonObjectId(ObjectId) - Constructor for class org.bson.BsonObjectId
Construct a new instance with the given ObjectId instance.
BsonObjectIdCodec - Class in org.bson.codecs
A Codec for BsonObjectId instances.
BsonObjectIdCodec() - Constructor for class org.bson.codecs.BsonObjectIdCodec
 
BsonOutput - Interface in org.bson.io
An output stream that is optimized for writing BSON values directly to the underlying stream.
BsonReader - Interface in org.bson
An interface for reading a logical BSON document using a pull-oriented API.
BsonRegularExpression - Class in org.bson
A holder class for a BSON regular expression, so that we can delay compiling into a Pattern until necessary.
BsonRegularExpression(String, String) - Constructor for class org.bson.BsonRegularExpression
Creates a new instance
BsonRegularExpression(String) - Constructor for class org.bson.BsonRegularExpression
Creates a new instance with no options set.
BsonRegularExpressionCodec - Class in org.bson.codecs
A codec for BSON regular expressions.
BsonRegularExpressionCodec() - Constructor for class org.bson.codecs.BsonRegularExpressionCodec
 
BsonSerializationException - Exception in org.bson
An exception indicating a failure to serialize a BSON value.
BsonSerializationException(String) - Constructor for exception org.bson.BsonSerializationException
Construct a new instance.
BsonString - Class in org.bson
A representation of the BSON String type.
BsonString(String) - Constructor for class org.bson.BsonString
Construct a new instance with the given value.
BsonStringCodec - Class in org.bson.codecs
A Codec for BsonString instances.
BsonStringCodec() - Constructor for class org.bson.codecs.BsonStringCodec
 
BsonSymbol - Class in org.bson
Class to hold a BSON symbol object, which is an interned string in Ruby
BsonSymbol(String) - Constructor for class org.bson.BsonSymbol
Creates a new instance.
BsonSymbolCodec - Class in org.bson.codecs
A codec for BSON symbol type.
BsonSymbolCodec() - Constructor for class org.bson.codecs.BsonSymbolCodec
 
BsonTimestamp - Class in org.bson
A value representing the BSON timestamp type.
BsonTimestamp() - Constructor for class org.bson.BsonTimestamp
Construct a new instance with a null time and a 0 increment.
BsonTimestamp(int, int) - Constructor for class org.bson.BsonTimestamp
Construct a new instance for the given time and increment.
BSONTimestamp - Class in org.bson.types
This is used for internal increment values.
BSONTimestamp() - Constructor for class org.bson.types.BSONTimestamp
Creates a new instance.
BSONTimestamp(int, int) - Constructor for class org.bson.types.BSONTimestamp
Creates a new instance.
BSONTimestampCodec - Class in com.mongodb
Knows how to encode and decode BSON timestamps.
BSONTimestampCodec() - Constructor for class com.mongodb.BSONTimestampCodec
 
BsonTimestampCodec - Class in org.bson.codecs
A Codec for BSON Timestamp instances.
BsonTimestampCodec() - Constructor for class org.bson.codecs.BsonTimestampCodec
 
BsonType - Enum in org.bson
Enumeration of all the BSON types currently supported.
BsonTypeClassMap - Class in org.bson.codecs
A map from a BSON types to the Class to which it should be decoded.
BsonTypeClassMap(Map<BsonType, Class<?>>) - Constructor for class org.bson.codecs.BsonTypeClassMap
Construct an instance with the default mapping, but replacing the default mapping with any values contained in the given map.
BsonTypeClassMap() - Constructor for class org.bson.codecs.BsonTypeClassMap
Construct an instance with the default mappings.
BsonTypeCodecMap - Class in org.bson.codecs
An efficient map of BsonType to Codec
BsonTypeCodecMap(BsonTypeClassMap, CodecRegistry) - Constructor for class org.bson.codecs.BsonTypeCodecMap
Initializes the map by iterating the keys of the given BsonTypeClassMap and looking up the Codec for the Class mapped to each key.
BsonUndefined - Class in org.bson
Represents the value associated with the BSON Undefined type.
BsonUndefined() - Constructor for class org.bson.BsonUndefined
 
BsonUndefinedCodec - Class in org.bson.codecs
Allows reading and writing of the BSON Undefined type.
BsonUndefinedCodec() - Constructor for class org.bson.codecs.BsonUndefinedCodec
 
BsonValue - Class in org.bson
Base class for any BSON type.
BsonValueCodec - Class in org.bson.codecs
A codec for unknown BsonValues.
BsonValueCodec() - Constructor for class org.bson.codecs.BsonValueCodec
Creates a new instance with a default codec registry that uses the BsonValueCodecProvider.
BsonValueCodec(CodecRegistry) - Constructor for class org.bson.codecs.BsonValueCodec
Creates a new instance initialised with the given codec registry.
BsonValueCodecProvider - Class in org.bson.codecs
A CodecProvider for all subclass of BsonValue.
BsonValueCodecProvider() - Constructor for class org.bson.codecs.BsonValueCodecProvider
Construct a new instance with the default codec for each BSON type.
BsonWriter - Interface in org.bson
An interface for writing a logical BSON document using a push-oriented API.
BsonWriterSettings - Class in org.bson
All the customisable settings for writing BSON.
BsonWriterSettings(int) - Constructor for class org.bson.BsonWriterSettings
Creates a new instance of the settings with the given maximum serialization depth.
BsonWriterSettings() - Constructor for class org.bson.BsonWriterSettings
Creates a new instance of the settings with the default maximum serialization depth of 1024.
bucket(TExpression, List<Boundary>) - Static method in class com.mongodb.client.model.Aggregates
Creates a $bucket pipeline stage
bucket(TExpression, List<TBoundary>, BucketOptions) - Static method in class com.mongodb.client.model.Aggregates
Creates a $bucket pipeline stage
bucketAuto(TExpression, int) - Static method in class com.mongodb.client.model.Aggregates
Creates a $bucketAuto pipeline stage
bucketAuto(TExpression, int, BucketAutoOptions) - Static method in class com.mongodb.client.model.Aggregates
Creates a $bucketAuto pipeline stage
BucketAutoOptions - Class in com.mongodb.client.model
The options for a $bucketAuto aggregation pipeline stage
BucketAutoOptions() - Constructor for class com.mongodb.client.model.BucketAutoOptions
 
BucketGranularity - Enum in com.mongodb.client.model
Granularity values for automatic bucketing.
BucketOptions - Class in com.mongodb.client.model
The options for a $bucket aggregation pipeline stage
BucketOptions() - Constructor for class com.mongodb.client.model.BucketOptions
 
bucketSize(Double) - Method in class com.mongodb.bulk.IndexRequest
Sets the specified the number of units within which to group the location values for geoHaystack Indexes
bucketSize(Double) - Method in class com.mongodb.client.model.IndexOptions
Sets the specified the number of units within which to group the location values for geoHaystack Indexes
BufferProvider - Interface in com.mongodb.connection
A provider of instances of ByteBuf.
build() - Method in class com.mongodb.AggregationOptions.Builder
Return the options based on this builder.
build() - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Build an instance of MongoClientSettings.
build() - Method in class com.mongodb.client.model.Collation.Builder
Creates a new Collation object with the settings initialised on this builder.
build() - Method in class com.mongodb.client.MongoDriverInformation.Builder
 
build() - Method in class com.mongodb.connection.ClusterSettings.Builder
Build the settings from the builder.
build() - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
Creates a new ConnectionPoolSettings object with the settings initialised on this builder.
build() - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
Build an instance of NettyStreamFactoryFactory.
build() - Method in class com.mongodb.connection.ServerDescription.Builder
Create a new ServerDescription from the settings in this builder.
build() - Method in class com.mongodb.connection.ServerSettings.Builder
Create a new ServerSettings from the settings applied to this builder.
build() - Method in class com.mongodb.connection.SocketSettings.Builder
Build an instance of SocketSettings.
build() - Method in class com.mongodb.connection.SslSettings.Builder
Create a new SSLSettings from the settings in this builder.
build() - Method in class com.mongodb.MongoClientOptions.Builder
Build an instance of MongoClientOptions.
build() - Method in class com.mongodb.ParallelScanOptions.Builder
Creates a ParallelScanOptions with the settings initialised in this builder.
build() - Method in class org.bson.codecs.DecoderContext.Builder
Build an instance of DecoderContext.
build() - Method in class org.bson.codecs.EncoderContext.Builder
Build an instance of EncoderContext.
builder() - Static method in class com.mongodb.AggregationOptions
Creates a new Builder for AggregationOptions.
builder() - Static method in class com.mongodb.async.client.MongoClientSettings
Convenience method to create a Builder.
builder(MongoClientSettings) - Static method in class com.mongodb.async.client.MongoClientSettings
Convenience method to create a from an existing MongoClientSettings.
builder() - Static method in class com.mongodb.client.model.Collation
Convenience method to create a Builder.
builder(Collation) - Static method in class com.mongodb.client.model.Collation
Convenience method to create a from an existing Collation.
builder() - Static method in class com.mongodb.client.MongoDriverInformation
Convenience method to create a Builder.
builder(MongoDriverInformation) - Static method in class com.mongodb.client.MongoDriverInformation
Convenience method to create a Builder.
builder() - Static method in class com.mongodb.connection.ClusterSettings
Get a builder for this class.
builder() - Static method in class com.mongodb.connection.ConnectionPoolSettings
Gets a Builder for creating a new ConnectionPoolSettings instance.
Builder() - Constructor for class com.mongodb.connection.ConnectionPoolSettings.Builder
 
builder() - Static method in class com.mongodb.connection.netty.NettyStreamFactoryFactory
Gets a builder for an instance of NettyStreamFactoryFactory.
builder() - Static method in class com.mongodb.connection.ServerDescription
Gets a Builder for creating a new ServerDescription instance.
Builder() - Constructor for class com.mongodb.connection.ServerDescription.Builder
 
builder() - Static method in class com.mongodb.connection.ServerSettings
Creates a builder for ServerSettings.
Builder() - Constructor for class com.mongodb.connection.ServerSettings.Builder
 
builder() - Static method in class com.mongodb.connection.SocketSettings
Gets a builder for an instance of SocketSettings.
Builder() - Constructor for class com.mongodb.connection.SocketSettings.Builder
 
builder() - Static method in class com.mongodb.connection.SslSettings
Gets a Builder for creating a new SSLSettings instance.
Builder() - Constructor for class com.mongodb.connection.SslSettings.Builder
 
builder() - Static method in class com.mongodb.MongoClientOptions
Creates a builder instance.
builder(MongoClientOptions) - Static method in class com.mongodb.MongoClientOptions
Creates a builder instance.
Builder() - Constructor for class com.mongodb.MongoClientOptions.Builder
Creates a Builder for MongoClientOptions, getting the appropriate system properties for initialization.
Builder(MongoClientOptions) - Constructor for class com.mongodb.MongoClientOptions.Builder
Creates a Builder from an existing MongoClientOptions.
builder() - Static method in class com.mongodb.ParallelScanOptions
Create a builder for the options
Builder() - Constructor for class com.mongodb.ParallelScanOptions.Builder
 
builder() - Static method in class org.bson.codecs.DecoderContext
Create a builder.
builder() - Static method in class org.bson.codecs.EncoderContext
Create a builder.
BulkUpdateRequestBuilder - Class in com.mongodb
A builder for a single update request.
bulkWrite(List<? extends WriteModel<? extends TDocument>>, SingleResultCallback<BulkWriteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Executes a mix of inserts, updates, replaces, and deletes.
bulkWrite(List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions, SingleResultCallback<BulkWriteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Executes a mix of inserts, updates, replaces, and deletes.
bulkWrite(List<? extends WriteModel<? extends TDocument>>) - Method in interface com.mongodb.client.MongoCollection
Executes a mix of inserts, updates, replaces, and deletes.
bulkWrite(List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions) - Method in interface com.mongodb.client.MongoCollection
Executes a mix of inserts, updates, replaces, and deletes.
BulkWriteBatchCombiner - Class in com.mongodb.connection
This class is not part of the public API.
BulkWriteBatchCombiner(ServerAddress, boolean, WriteConcern) - Constructor for class com.mongodb.connection.BulkWriteBatchCombiner
Construct an instance.
BulkWriteError - Class in com.mongodb.bulk
Represents an error for an item included in a bulk write operation, e.g.
BulkWriteError(int, String, BsonDocument, int) - Constructor for class com.mongodb.bulk.BulkWriteError
Constructs a new instance.
BulkWriteError - Class in com.mongodb
Represents an error for an item included in a bulk write operation, e.g.
BulkWriteError(int, String, DBObject, int) - Constructor for class com.mongodb.BulkWriteError
Constructs a new instance.
BulkWriteException - Exception in com.mongodb
An exception that represents all errors associated with a bulk write operation.
BulkWriteOperation - Class in com.mongodb
A bulk write operation.
BulkWriteOptions - Class in com.mongodb.client.model
The options to apply to a bulk write.
BulkWriteOptions() - Constructor for class com.mongodb.client.model.BulkWriteOptions
 
BulkWriteRequestBuilder - Class in com.mongodb
A builder for a single write request.
BulkWriteResult - Class in com.mongodb.bulk
The result of a successful bulk write operation.
BulkWriteResult() - Constructor for class com.mongodb.bulk.BulkWriteResult
 
BulkWriteResult - Class in com.mongodb
The result of a successful bulk write operation.
BulkWriteResult() - Constructor for class com.mongodb.BulkWriteResult
 
BulkWriteUpsert - Class in com.mongodb.bulk
Represents an item in the bulk write that was upserted.
BulkWriteUpsert(int, BsonValue) - Constructor for class com.mongodb.bulk.BulkWriteUpsert
Construct an instance.
BulkWriteUpsert - Class in com.mongodb
Represents an upsert request in a bulk write operation that resulted in an insert.
BulkWriteUpsert(int, Object) - Constructor for class com.mongodb.BulkWriteUpsert
Constructs an instance.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.AggregationOptions.Builder
Sets whether to bypass document validation.
bypassDocumentValidation(Boolean) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in interface com.mongodb.client.AggregateIterable
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in interface com.mongodb.client.MapReduceIterable
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.BulkWriteOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the bypassDocumentValidation
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.InsertManyOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.InsertOneOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.UpdateOptions
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.InsertOptions
Sets whether to bypass document validation.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.BaseWriteOperation
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the bypass document level validation flag.
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.MixedBulkWriteOperation
Sets the bypass document level validation flag.
ByteArrayCodec - Class in org.bson.codecs
Encodes and decodes byte arrays.
ByteArrayCodec() - Constructor for class org.bson.codecs.ByteArrayCodec
 
ByteBuf - Interface in org.bson
An interface wrapper around a java.nio.ByteBuffer which additionally is Closeable, so that pooled byte buffers know how.
ByteBufferBsonInput - Class in org.bson.io
An implementation of BsonInput that is backed by a ByteBuf.
ByteBufferBsonInput(ByteBuf) - Constructor for class org.bson.io.ByteBufferBsonInput
Construct an instance with the given byte buffer.
ByteBufferBsonOutput - Class in com.mongodb.connection
This class should not be considered as part of the public API, and it may change or be removed at any time.
ByteBufferBsonOutput(BufferProvider) - Constructor for class com.mongodb.connection.ByteBufferBsonOutput
Construct an instance that uses the given buffer provider to allocate byte buffers as needs as it grows.
ByteBufNIO - Class in org.bson
Implementation of ByteBuf which simply wraps an NIO ByteBuffer and forwards all calls to it.
ByteBufNIO(ByteBuffer) - Constructor for class org.bson.ByteBufNIO
Creates a new instance.
ByteCodec - Class in org.bson.codecs
Encodes and decodes Byte objects.
ByteCodec() - Constructor for class org.bson.codecs.ByteCodec
 
Bytes - Class in com.mongodb
Class that hold definitions of the wire protocol
Bytes() - Constructor for class com.mongodb.Bytes
 

C

callGetLastError() - Method in class com.mongodb.WriteConcern
Deprecated.
canonicalAddress(String) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the canonical host name and port of this server.
CANONICALIZE_HOST_NAME_KEY - Static variable in class com.mongodb.MongoCredential
Mechanism property key for specifying whether to canonicalize the host name for GSSAPI authentication.
capacity() - Method in interface org.bson.ByteBuf
Returns this buffer's capacity.
capacity() - Method in class org.bson.ByteBufNIO
 
capped(boolean) - Method in class com.mongodb.client.model.CreateCollectionOptions
sets whether the collection is capped.
capped(boolean) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets whether the collection is capped.
caseLevel(Boolean) - Method in class com.mongodb.client.model.Collation.Builder
Sets the case level value
caseSensitive(Boolean) - Method in class com.mongodb.client.model.TextSearchOptions
Set the case-sensitive flag for the text search
CENTER - Static variable in class com.mongodb.QueryOperators
 
CENTER_SPHERE - Static variable in class com.mongodb.QueryOperators
 
channelToInputStream(AsynchronousByteChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
channelToInputStream(AsynchronousFileChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
channelToOutputStream(AsynchronousByteChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
channelToOutputStream(AsynchronousFileChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
CharacterCodec - Class in org.bson.codecs
Encodes and decodes Character objects.
CharacterCodec() - Constructor for class org.bson.codecs.CharacterCodec
 
checkPreconditions(String, BsonType) - Method in class org.bson.AbstractBsonReader
Ensures any conditions are met before reading commences.
checkPreconditions(String, AbstractBsonWriter.State...) - Method in class org.bson.AbstractBsonWriter
Checks the writer is in the correct state.
checkState(AbstractBsonWriter.State[]) - Method in class org.bson.AbstractBsonWriter
Checks if this writer's current state is in the list of given states.
choose(ClusterDescription) - Method in class com.mongodb.ReadPreference
Chooses the servers from the given cluster than match this read preference.
chooseForNonReplicaSet(ClusterDescription) - Method in class com.mongodb.ReadPreference
 
chooseForNonReplicaSet(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.ReadPreference
 
chunkSizeBytes(Integer) - Method in class com.mongodb.client.gridfs.model.GridFSUploadOptions
Sets the chunk size in bytes.
ClassMap<T> - Class in org.bson.util
Maps Class objects to values.
ClassMap() - Constructor for class org.bson.util.ClassMap
 
clear() - Method in class org.bson.BsonArray
 
clear() - Method in class org.bson.BsonDocument
 
clear() - Method in class org.bson.BsonDocumentWrapper
 
clear() - Method in interface org.bson.ByteBuf
Clears this buffer.
clear() - Method in class org.bson.ByteBufNIO
 
clear() - Method in class org.bson.Document
 
clear() - Method in class org.bson.LazyBSONList
 
clear() - Method in class org.bson.RawBsonDocument
 
clear() - Method in class org.bson.util.ClassMap
As per java.util.Map, removes all of the mappings from this map (optional operation).
clearAllHooks() - Static method in class org.bson.BSON
Remove all decoding and encoding hooks for all classes.
clearDecodingHooks() - Static method in class org.bson.BSON
Clears all decoding hooks.
clearEncodingHooks() - Static method in class org.bson.BSON
Clears all encoding hooks.
CLI - Class in com.mongodb.gridfs
A simple CLI for GridFS.
CLI() - Constructor for class com.mongodb.gridfs.CLI
 
clone() - Method in class org.bson.BsonArray
 
clone() - Method in class org.bson.BsonDocument
 
clone() - Method in class org.bson.BsonDocumentWrapper
 
clone() - Method in class org.bson.RawBsonDocument
 
close() - Method in interface com.mongodb.async.AsyncBatchCursor
 
close(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.AsyncInputStream
Closes the input stream
close(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.AsyncOutputStream
Closes the output stream
close() - Method in interface com.mongodb.async.client.MongoClient
Close the client, which will close all underlying cached resources, including, for example, sockets and background monitoring threads.
close() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
close() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
 
close() - Method in interface com.mongodb.client.MongoCursor
 
close() - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
close() - Method in interface com.mongodb.connection.Cluster
Closes connections to the servers in the cluster.
close() - Method in interface com.mongodb.connection.Stream
Closes the connection.
close() - Method in interface com.mongodb.Cursor
Terminates this cursor on the server.
close() - Method in class com.mongodb.DBCursor
 
close() - Method in class com.mongodb.Mongo
Closes all resources associated with this instance, in particular any open network connections.
close() - Method in interface com.mongodb.operation.BatchCursor
 
close() - Method in class org.bson.AbstractBsonReader
Closes the reader.
close() - Method in class org.bson.AbstractBsonWriter
 
close() - Method in class org.bson.BsonBinaryReader
 
close() - Method in class org.bson.BsonBinaryWriter
 
close() - Method in class org.bson.io.BasicOutputBuffer
 
close() - Method in interface org.bson.io.BsonInput
 
close() - Method in interface org.bson.io.BsonOutput
 
close() - Method in class org.bson.io.ByteBufferBsonInput
 
close() - Method in class org.bson.io.OutputBuffer
 
Cluster - Interface in com.mongodb.connection
Represents a cluster of MongoDB servers.
ClusterBinding - Class in com.mongodb.binding
A simple ReadWriteBinding implementation that supplies write connection sources bound to a possibly different primary each time, and a read connection source bound to a possible different server each time.
ClusterBinding(Cluster, ReadPreference) - Constructor for class com.mongodb.binding.ClusterBinding
Creates an instance.
clusterClosed(ClusterClosedEvent) - Method in class com.mongodb.event.ClusterEventMulticaster
 
clusterClosed(ClusterClosedEvent) - Method in interface com.mongodb.event.ClusterListener
Invoked when a cluster is closed.
clusterClosed(ClusterClosedEvent) - Method in class com.mongodb.event.ClusterListenerAdapter
 
ClusterClosedEvent - Class in com.mongodb.event
A cluster closed event.
ClusterClosedEvent(ClusterId) - Constructor for class com.mongodb.event.ClusterClosedEvent
Constructs a new instance of the event.
ClusterConnectionMode - Enum in com.mongodb.connection
The cluster connection mode.
ClusterDescription - Class in com.mongodb.connection
Immutable snapshot state of a cluster.
ClusterDescription(ClusterConnectionMode, ClusterType, List<ServerDescription>) - Constructor for class com.mongodb.connection.ClusterDescription
Creates a new ClusterDescription.
ClusterDescription(ClusterConnectionMode, ClusterType, List<ServerDescription>, ClusterSettings, ServerSettings) - Constructor for class com.mongodb.connection.ClusterDescription
Creates a new ClusterDescription.
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in class com.mongodb.event.ClusterEventMulticaster
 
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in interface com.mongodb.event.ClusterListener
Invoked when a cluster description changes.
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in class com.mongodb.event.ClusterListenerAdapter
 
ClusterDescriptionChangedEvent - Class in com.mongodb.event
An event signifying that the cluster description has changed.
ClusterDescriptionChangedEvent(ClusterId, ClusterDescription, ClusterDescription) - Constructor for class com.mongodb.event.ClusterDescriptionChangedEvent
Constructs a new instance of the event.
ClusterEventMulticaster - Class in com.mongodb.event
A multicaster for cluster events.
ClusterEventMulticaster(List<ClusterListener>) - Constructor for class com.mongodb.event.ClusterEventMulticaster
Construct an instance with the given list of cluster listeners
ClusterFactory - Interface in com.mongodb.connection
Factory for Cluster implementations.
ClusterId - Class in com.mongodb.connection
A client-generated identifier that uniquely identifies a connection to a MongoDB cluster, which could be sharded, replica set, or standalone.
ClusterId() - Constructor for class com.mongodb.connection.ClusterId
Construct an instance.
ClusterId(String) - Constructor for class com.mongodb.connection.ClusterId
Construct an instance.
ClusterListener - Interface in com.mongodb.event
A listener for cluster-related events.
ClusterListenerAdapter - Class in com.mongodb.event
An adapter for cluster listener implementations, for clients that want to listen for a subset of cluster events.
ClusterListenerAdapter() - Constructor for class com.mongodb.event.ClusterListenerAdapter
 
clusterOpening(ClusterOpeningEvent) - Method in class com.mongodb.event.ClusterEventMulticaster
 
clusterOpening(ClusterOpeningEvent) - Method in interface com.mongodb.event.ClusterListener
Invoked when a cluster is opened.
clusterOpening(ClusterOpeningEvent) - Method in class com.mongodb.event.ClusterListenerAdapter
 
ClusterOpeningEvent - Class in com.mongodb.event
A cluster opening event.
ClusterOpeningEvent(ClusterId) - Constructor for class com.mongodb.event.ClusterOpeningEvent
Constructs a new instance of the event.
clusterSettings(ClusterSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the cluster settings.
ClusterSettings - Class in com.mongodb.connection
Settings for the cluster.
ClusterSettings.Builder - Class in com.mongodb.connection
A builder for the cluster settings.
ClusterType - Enum in com.mongodb.connection
An enumeration of all possible cluster types.
CODE - Static variable in class org.bson.BSON
 
Code - Class in org.bson.types
For using the Code type.
Code(String) - Constructor for class org.bson.types.Code
Construct a new instance with the given code.
CODE_W_SCOPE - Static variable in class org.bson.BSON
 
Codec<T> - Interface in org.bson.codecs
Implementations of this interface can both encode and decode values of type T.
CodecConfigurationException - Exception in org.bson.codecs.configuration
An exception indicating that a codec registry has been misconfigured in some way, preventing it from providing a codec for the requested class.
CodecConfigurationException(String) - Constructor for exception org.bson.codecs.configuration.CodecConfigurationException
Construct a new instance.
CodeCodec - Class in org.bson.codecs
Encodes and decodes instances of type Code.
CodeCodec() - Constructor for class org.bson.codecs.CodeCodec
 
CodecProvider - Interface in org.bson.codecs.configuration
A provider of Codec instances.
CodecRegistries - Class in org.bson.codecs.configuration
A helper class for creating and combining codecs, codec providers, and codec registries
codecRegistry(CodecRegistry) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the codec registry
codecRegistry(CodecRegistry) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the codec registry
CodecRegistry - Interface in org.bson.codecs.configuration
A registry of Codec instances searchable by the class that the Codec can encode and decode.
CodeWithScope - Class in org.bson.types
A representation of the JavaScript Code with Scope BSON type.
CodeWithScope(String, Document) - Constructor for class org.bson.types.CodeWithScope
Construct an instance.
CodeWithScopeCodec - Class in org.bson.codecs
Encodes and decodes CodeWithScope instances.
CodeWithScopeCodec(Codec<Document>) - Constructor for class org.bson.codecs.CodeWithScopeCodec
Creates a new CodeWithScopeCodec.
CodeWScope - Class in org.bson.types
Represents the CodeWScope BSON type.
CodeWScope(String, BSONObject) - Constructor for class org.bson.types.CodeWScope
Creates a new instance
collation(Collation) - Method in class com.mongodb.AggregationOptions.Builder
Sets the collation
collation(Collation) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.async.client.FindIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the collation options
collation(Collation) - Method in class com.mongodb.bulk.DeleteRequest
Sets the collation options
collation(Collation) - Method in class com.mongodb.bulk.IndexRequest
Sets the collation options
collation(Collation) - Method in class com.mongodb.bulk.UpdateRequest
Sets the collation options
collation(Collation) - Method in class com.mongodb.BulkUpdateRequestBuilder
Sets the collation
collation(Collation) - Method in class com.mongodb.BulkWriteRequestBuilder
Sets the collation
collation(Collation) - Method in interface com.mongodb.client.AggregateIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.client.DistinctIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.client.FindIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.client.MapReduceIterable
Sets the collation options
Collation - Class in com.mongodb.client.model
The options regarding collation support in MongoDB 3.4+
collation(Collation) - Method in class com.mongodb.client.model.CountOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.CreateCollectionOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.CreateViewOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DBCreateViewOptions
Sets the collation
collation(Collation) - Method in class com.mongodb.client.model.DeleteOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.FindOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.IndexOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.client.model.UpdateOptions
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.AggregateOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.CountOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.CreateViewOperation
Sets the default collation for the view.
collation(Collation) - Method in class com.mongodb.operation.DistinctOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.FindOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.GroupOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the collation options
collation(Collation) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the collation options
Collation.Builder - Class in com.mongodb.client.model
A Collation builder.
collationAlternate(CollationAlternate) - Method in class com.mongodb.client.model.Collation.Builder
Sets the alternate
CollationAlternate - Enum in com.mongodb.client.model
Collation support allows the specific configuration of whether or not spaces and punctuation are considered base characters.
collationCaseFirst(CollationCaseFirst) - Method in class com.mongodb.client.model.Collation.Builder
Sets the collation case first value
CollationCaseFirst - Enum in com.mongodb.client.model
Collation support allows the specific configuration of how character cases are handled.
collationMaxVariable(CollationMaxVariable) - Method in class com.mongodb.client.model.Collation.Builder
Sets the maxVariable
CollationMaxVariable - Enum in com.mongodb.client.model
Collation support allows the specific configuration of whether or not spaces and punctuation are considered base characters.
collationStrength(CollationStrength) - Method in class com.mongodb.client.model.Collation.Builder
Sets the collation strength
CollationStrength - Enum in com.mongodb.client.model
Collation support allows the specific configuration of how differences between characters are handled.
CollectibleCodec<T> - Interface in org.bson.codecs
A Codec that generates complete BSON documents for storage in a MongoDB collection.
collectionExists(String) - Method in class com.mongodb.DB
Checks to see if a collection with a given name exists on a server.
collectionName(String) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the collectionName for the output of the MapReduce
collectionName(String) - Method in interface com.mongodb.client.MapReduceIterable
Sets the collectionName for the output of the MapReduce
com.mongodb - package com.mongodb
The core mongodb package
com.mongodb.annotations - package com.mongodb.annotations
Contains annotations that can apply to any part of the driver code.
com.mongodb.assertions - package com.mongodb.assertions
Contains design by contract assertions
com.mongodb.async - package com.mongodb.async
This package contains async interfaces
com.mongodb.async.client - package com.mongodb.async.client
This packages contains classes for the new async client
com.mongodb.async.client.gridfs - package com.mongodb.async.client.gridfs
Contains the classes for supporting MongoDB's specification for storing very large files, GridFS.
com.mongodb.async.client.gridfs.helpers - package com.mongodb.async.client.gridfs.helpers
Contains helper classes to create AsyncInputStream and AsyncOutputStream's from external sources.
com.mongodb.binding - package com.mongodb.binding
This package contains classes that manage binding to MongoDB servers for various operations.
com.mongodb.bulk - package com.mongodb.bulk
Contains classes for representing the result of a bulk write operation.
com.mongodb.client - package com.mongodb.client
This package contains classes for the new client api for MongoDatabase and MongoCollection
com.mongodb.client.gridfs - package com.mongodb.client.gridfs
This package contains the new GridFS implementation
com.mongodb.client.gridfs.codecs - package com.mongodb.client.gridfs.codecs
This package contains codecs for use with GridFS
com.mongodb.client.gridfs.model - package com.mongodb.client.gridfs.model
This package contains models for use with GridFS
com.mongodb.client.jndi - package com.mongodb.client.jndi
This package contains a JNDI ObjectFactory implementation.
com.mongodb.client.model - package com.mongodb.client.model
This package contains models and options that help describe MongoCollection operations
com.mongodb.client.model.geojson - package com.mongodb.client.model.geojson
This package contains classes that represent GeoJSON objects.
com.mongodb.client.model.geojson.codecs - package com.mongodb.client.model.geojson.codecs
This package contains classes that encode and decode GeoJSON objects.
com.mongodb.client.result - package com.mongodb.client.result
This package contains classes representing operation results
com.mongodb.connection - package com.mongodb.connection
Contains classes that manage connecting to MongoDB servers.
com.mongodb.connection.netty - package com.mongodb.connection.netty
This package contains netty specific classes
com.mongodb.diagnostics.logging - package com.mongodb.diagnostics.logging
This package contains logging classes
com.mongodb.event - package com.mongodb.event
This package contains cluster and connection event related classes
com.mongodb.gridfs - package com.mongodb.gridfs
Contains the classes for supporting MongoDB's specification for storing very large files, GridFS.
com.mongodb.management - package com.mongodb.management
Contains classes for monitoring the server/driver via Java Management Extensions (JMX).
com.mongodb.operation - package com.mongodb.operation
The core of the MongoDB driver works via operations, using the command pattern.
com.mongodb.selector - package com.mongodb.selector
Contains classes that determine how to select the server to connect to in order to send commands or queries.
com.mongodb.util - package com.mongodb.util
Contains classes that can be used everywhere in the driver, and have no specific domain.
combine(Bson...) - Static method in class com.mongodb.client.model.Updates
Combine a list of updates into a single update.
combine(List<Bson>) - Static method in class com.mongodb.client.model.Updates
Combine a list of updates into a single update.
command(String, BsonDocument, boolean, FieldNameValidator, Decoder<T>) - Method in interface com.mongodb.connection.Connection
Execute the command.
command(String) - Method in class com.mongodb.DB
Executes a database command.
command(DBObject) - Method in class com.mongodb.DB
Executes a database command.
command(DBObject, DBEncoder) - Method in class com.mongodb.DB
Executes a database command.
command(DBObject, ReadPreference, DBEncoder) - Method in class com.mongodb.DB
Executes a database command with the selected readPreference, and encodes the command using the given encoder.
command(DBObject, ReadPreference) - Method in class com.mongodb.DB
Executes the command against the database with the given read preference.
command(String, ReadPreference) - Method in class com.mongodb.DB
Executes a database command.
COMMAND_COLLECTION_NAME - Static variable in class com.mongodb.MongoNamespace
 
commandAsync(String, BsonDocument, boolean, FieldNameValidator, Decoder<T>, SingleResultCallback<T>) - Method in interface com.mongodb.connection.AsyncConnection
Execute the command asynchronously.
CommandEvent - Class in com.mongodb.event
An event representing a MongoDB database command.
CommandEvent(int, ConnectionDescription, String) - Constructor for class com.mongodb.event.CommandEvent
Construct an instance.
CommandEventMulticaster - Class in com.mongodb.event
A multicaster for command events.
CommandEventMulticaster(List<CommandListener>) - Constructor for class com.mongodb.event.CommandEventMulticaster
Construct an instance with the given list of command listeners
commandFailed(CommandFailedEvent) - Method in class com.mongodb.event.CommandEventMulticaster
 
commandFailed(CommandFailedEvent) - Method in interface com.mongodb.event.CommandListener
Listener for command failure events
commandFailed(CommandFailedEvent) - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
CommandFailedEvent - Class in com.mongodb.event
An event representing the failure of a MongoDB database command.
CommandFailedEvent(int, ConnectionDescription, String, long, Throwable) - Constructor for class com.mongodb.event.CommandFailedEvent
Construct an instance.
CommandListener - Interface in com.mongodb.event
A listener for command events
CommandListenerMulticaster - Class in com.mongodb.event
Deprecated.
CommandListenerMulticaster(List<CommandListener>) - Constructor for class com.mongodb.event.CommandListenerMulticaster
Deprecated.
Construct an instance with the given list of command listeners
CommandReadOperation<T> - Class in com.mongodb.operation
An operation that executes an arbitrary command that reads from the server.
CommandReadOperation(String, BsonDocument, Decoder<T>) - Constructor for class com.mongodb.operation.CommandReadOperation
Construct a new instance.
CommandResult - Class in com.mongodb
A simple wrapper to hold the result of a command.
commandStarted(CommandStartedEvent) - Method in class com.mongodb.event.CommandEventMulticaster
 
commandStarted(CommandStartedEvent) - Method in interface com.mongodb.event.CommandListener
Listener for command started events.
commandStarted(CommandStartedEvent) - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
CommandStartedEvent - Class in com.mongodb.event
An event representing the start of a command execution.
CommandStartedEvent(int, ConnectionDescription, String, String, BsonDocument) - Constructor for class com.mongodb.event.CommandStartedEvent
Construct an instance.
commandSucceeded(CommandSucceededEvent) - Method in class com.mongodb.event.CommandEventMulticaster
 
commandSucceeded(CommandSucceededEvent) - Method in interface com.mongodb.event.CommandListener
Listener for command completed events
commandSucceeded(CommandSucceededEvent) - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
CommandSucceededEvent - Class in com.mongodb.event
An event representing the completion of a MongoDB database command.
CommandSucceededEvent(int, ConnectionDescription, String, BsonDocument, long) - Constructor for class com.mongodb.event.CommandSucceededEvent
Construct an instance.
CommandWriteOperation<T> - Class in com.mongodb.operation
An operation that executes an arbitrary command that writes to the server.
CommandWriteOperation(String, BsonDocument, Decoder<T>) - Constructor for class com.mongodb.operation.CommandWriteOperation
Construct a new instance.
comment(String) - Method in class com.mongodb.DBCursor
Adds a comment to the query to identify queries in the database profiler output.
COMMENT - Static variable in class com.mongodb.QueryOperators
 
compareTo(ServerVersion) - Method in class com.mongodb.connection.ServerVersion
 
compareTo(BsonBoolean) - Method in class org.bson.BsonBoolean
 
compareTo(BsonDateTime) - Method in class org.bson.BsonDateTime
 
compareTo(BsonDouble) - Method in class org.bson.BsonDouble
 
compareTo(BsonInt32) - Method in class org.bson.BsonInt32
 
compareTo(BsonInt64) - Method in class org.bson.BsonInt64
 
compareTo(BsonObjectId) - Method in class org.bson.BsonObjectId
 
compareTo(BsonString) - Method in class org.bson.BsonString
 
compareTo(BsonTimestamp) - Method in class org.bson.BsonTimestamp
 
compareTo(BSONTimestamp) - Method in class org.bson.types.BSONTimestamp
 
compareTo(ObjectId) - Method in class org.bson.types.ObjectId
 
completed(T) - Method in interface com.mongodb.connection.AsyncCompletionHandler
Invoked when an operation has completed.
CompositeServerSelector - Class in com.mongodb.selector
A server selector that composes a list of server selectors, and selects the servers by iterating through the list from start to finish, passing the result of the previous into the next, and finally returning the result of the last one.
CompositeServerSelector(List<? extends ServerSelector>) - Constructor for class com.mongodb.selector.CompositeServerSelector
Constructs a new instance.
compoundIndex(Bson...) - Static method in class com.mongodb.client.model.Indexes
create a compound index specifications.
compoundIndex(List<Bson>) - Static method in class com.mongodb.client.model.Indexes
compound multiple index specifications.
computed(String, TExpression) - Static method in class com.mongodb.client.model.Projections
Creates a projection of a field whose value is computed from the given expression.
connect(MongoURI) - Method in class com.mongodb.Mongo.Holder
Deprecated.
connect(MongoClientURI) - Method in class com.mongodb.Mongo.Holder
Attempts to find an existing MongoClient instance matching that URI in the holder, and returns it if exists.
connect() - Method in class com.mongodb.MongoURI
Deprecated.
Creates a Mongo instance based on the URI.
connectCollection(DB) - Method in class com.mongodb.MongoURI
Deprecated.
Returns the URI's Collection from a given DB object.
connectCollection(Mongo) - Method in class com.mongodb.MongoURI
Deprecated.
Returns the URI's Collection from a given Mongo instance
connectDB() - Method in class com.mongodb.MongoURI
Deprecated.
Returns the DB object from a newly created Mongo instance based on this URI.
connectDB(Mongo) - Method in class com.mongodb.MongoURI
Deprecated.
Returns the URI's DB object from a given Mongo instance.
Connection - Interface in com.mongodb.connection
A synchronous connection to a MongoDB server with blocking operations.
connectionAdded(ConnectionAddedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
 
connectionAdded(ConnectionAddedEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection is added to a pool.
connectionAdded(ConnectionAddedEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionAdded(ConnectionAddedEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
ConnectionAddedEvent - Class in com.mongodb.event
An event for adding a new connection to the pool.
ConnectionAddedEvent(ConnectionId) - Constructor for class com.mongodb.event.ConnectionAddedEvent
Construct an instance
connectionCheckedIn(ConnectionCheckedInEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
 
connectionCheckedIn(ConnectionCheckedInEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection is checked in to a pool.
connectionCheckedIn(ConnectionCheckedInEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionCheckedIn(ConnectionCheckedInEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
ConnectionCheckedInEvent - Class in com.mongodb.event
An event for checking in a connection to the pool.
ConnectionCheckedInEvent(ConnectionId) - Constructor for class com.mongodb.event.ConnectionCheckedInEvent
Construct an instance
connectionCheckedOut(ConnectionCheckedOutEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
 
connectionCheckedOut(ConnectionCheckedOutEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection is checked out of a pool.
connectionCheckedOut(ConnectionCheckedOutEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionCheckedOut(ConnectionCheckedOutEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
ConnectionCheckedOutEvent - Class in com.mongodb.event
An event for checking our a connection from the pool.
ConnectionCheckedOutEvent(ConnectionId) - Constructor for class com.mongodb.event.ConnectionCheckedOutEvent
Construct an instance
connectionClosed(ConnectionClosedEvent) - Method in class com.mongodb.event.ConnectionEventMulticaster
 
connectionClosed(ConnectionClosedEvent) - Method in interface com.mongodb.event.ConnectionListener
Publish a connection message closed event.
connectionClosed(ConnectionClosedEvent) - Method in class com.mongodb.event.ConnectionListenerAdapter
 
ConnectionClosedEvent - Class in com.mongodb.event
A connection closed event.
ConnectionClosedEvent(ConnectionId) - Constructor for class com.mongodb.event.ConnectionClosedEvent
Constructs a new instance of the event.
ConnectionDescription - Class in com.mongodb.connection
A description of a connection to a MongoDB server.
ConnectionDescription(ServerId) - Constructor for class com.mongodb.connection.ConnectionDescription
Construct a defaulted connection description instance.
ConnectionDescription(ConnectionId, ServerVersion, ServerType, int, int, int) - Constructor for class com.mongodb.connection.ConnectionDescription
Construct an instance.
ConnectionEventMulticaster - Class in com.mongodb.event
A multicaster for connection events.
ConnectionEventMulticaster() - Constructor for class com.mongodb.event.ConnectionEventMulticaster
 
ConnectionId - Class in com.mongodb.connection
An immutable connection identifier of a connection to a MongoDB server.
ConnectionListener - Interface in com.mongodb.event
A listener for connection-related events.
ConnectionListenerAdapter - Class in com.mongodb.event
An adapter for connection listener implementations, for clients that want to listen for a subset of connection events.
ConnectionListenerAdapter() - Constructor for class com.mongodb.event.ConnectionListenerAdapter
 
ConnectionMessageReceivedEvent - Class in com.mongodb.event
An event signifying that a message has been received on a connection.
ConnectionMessageReceivedEvent(ConnectionId, int, int) - Constructor for class com.mongodb.event.ConnectionMessageReceivedEvent
Constructs a new instance of the event.
ConnectionMessagesSentEvent - Class in com.mongodb.event
An event signifying that a message has been sent on a connection.
ConnectionMessagesSentEvent(ConnectionId, int, int) - Constructor for class com.mongodb.event.ConnectionMessagesSentEvent
Constructs a new instance of the event.
connectionOpened(ConnectionOpenedEvent) - Method in class com.mongodb.event.ConnectionEventMulticaster
 
connectionOpened(ConnectionOpenedEvent) - Method in interface com.mongodb.event.ConnectionListener
Publish a connection opened event.
connectionOpened(ConnectionOpenedEvent) - Method in class com.mongodb.event.ConnectionListenerAdapter
 
ConnectionOpenedEvent - Class in com.mongodb.event
An event for opening a new connection.
ConnectionOpenedEvent(ConnectionId) - Constructor for class com.mongodb.event.ConnectionOpenedEvent
Construct an instance
connectionPoolClosed(ConnectionPoolClosedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
 
connectionPoolClosed(ConnectionPoolClosedEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection pool is closed.
connectionPoolClosed(ConnectionPoolClosedEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionPoolClosed(ConnectionPoolClosedEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
ConnectionPoolClosedEvent - Class in com.mongodb.event
An event signifying the closing of a connection pool.
ConnectionPoolClosedEvent(ServerId) - Constructor for class com.mongodb.event.ConnectionPoolClosedEvent
Constructs a new instance of the event.
ConnectionPoolEventMulticaster - Class in com.mongodb.event
A multicaster for connection pool events.
ConnectionPoolEventMulticaster() - Constructor for class com.mongodb.event.ConnectionPoolEventMulticaster
 
ConnectionPoolListener - Interface in com.mongodb.event
A listener for connection pool-related events.
ConnectionPoolListenerAdapter - Class in com.mongodb.event
An adapter for connection pool listener implementations, for clients that want to listen for a subset of connection pool events.
ConnectionPoolListenerAdapter() - Constructor for class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionPoolOpened(ConnectionPoolOpenedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
 
connectionPoolOpened(ConnectionPoolOpenedEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection pool is opened.
connectionPoolOpened(ConnectionPoolOpenedEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionPoolOpened(ConnectionPoolOpenedEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
ConnectionPoolOpenedEvent - Class in com.mongodb.event
An event signifying the opening of a connection pool.
ConnectionPoolOpenedEvent(ServerId, ConnectionPoolSettings) - Constructor for class com.mongodb.event.ConnectionPoolOpenedEvent
Constructs a new instance of the event.
connectionPoolSettings(ConnectionPoolSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the connection pool settings.
ConnectionPoolSettings - Class in com.mongodb.connection
All settings that relate to the pool of connections to a MongoDB server.
ConnectionPoolSettings.Builder - Class in com.mongodb.connection
A builder for creating ConnectionPoolSettings.
ConnectionPoolStatisticsMBean - Interface in com.mongodb.management
A standard MXBean interface for a Mongo connection pool, for use on Java 6 and above virtual machines.
ConnectionPoolWaitQueueEnteredEvent - Class in com.mongodb.event
An event for entering the wait queue of the connection pool.
ConnectionPoolWaitQueueEnteredEvent(ServerId, long) - Constructor for class com.mongodb.event.ConnectionPoolWaitQueueEnteredEvent
Construct an instance.
ConnectionPoolWaitQueueExitedEvent - Class in com.mongodb.event
An event for entering the wait queue of the connection pool.
ConnectionPoolWaitQueueExitedEvent(ServerId, long) - Constructor for class com.mongodb.event.ConnectionPoolWaitQueueExitedEvent
Construct an instance.
connectionRemoved(ConnectionRemovedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
 
connectionRemoved(ConnectionRemovedEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection is removed from a pool.
connectionRemoved(ConnectionRemovedEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
connectionRemoved(ConnectionRemovedEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
ConnectionRemovedEvent - Class in com.mongodb.event
An event for removing a connection from the pool.
ConnectionRemovedEvent(ConnectionId) - Constructor for class com.mongodb.event.ConnectionRemovedEvent
Construct an instance
ConnectionSource - Interface in com.mongodb.binding
A source of connections to a single MongoDB server.
connectionsPerHost(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the maximum number of connections per host.
connectionsPerHost - Variable in class com.mongodb.MongoOptions
Deprecated.
The maximum number of connections allowed per host for this Mongo instance.
ConnectionString - Class in com.mongodb
Represents a Connection String.
ConnectionString(String) - Constructor for class com.mongodb.ConnectionString
Creates a ConnectionString from the given string.
connectTimeout(int, TimeUnit) - Method in class com.mongodb.connection.SocketSettings.Builder
Sets the socket connect timeout.
connectTimeout(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the connection timeout.
connectTimeout - Variable in class com.mongodb.MongoOptions
Deprecated.
The connection timeout in milliseconds.
contains(Object) - Method in class org.bson.BsonArray
 
contains(Object) - Method in class org.bson.LazyBSONList
 
containsAll(TagSet) - Method in class com.mongodb.TagSet
Returns true if this tag set contains all of the elements of the specified tag set.
containsAll(Collection<?>) - Method in class org.bson.BsonArray
 
containsAll(Collection) - Method in class org.bson.LazyBSONList
 
containsField(String) - Method in class com.mongodb.gridfs.GridFSFile
 
containsField(String) - Method in class com.mongodb.ReflectionDBObject
 
containsField(String) - Method in class org.bson.BasicBSONObject
Checks if this object contains a given field
containsField(String) - Method in interface org.bson.BSONObject
Checks if this object contains a field with the given name.
containsField(String) - Method in class org.bson.LazyBSONObject
 
containsField(String) - Method in class org.bson.types.BasicBSONList
 
containsKey(String) - Method in class com.mongodb.gridfs.GridFSFile
Deprecated.
containsKey(String) - Method in class com.mongodb.ReflectionDBObject
Deprecated.
containsKey(String) - Method in class com.mongodb.ReflectionDBObject.JavaWrapper
Deprecated. 
containsKey(String) - Method in class org.bson.BasicBSONObject
Deprecated.
containsKey(Object) - Method in class org.bson.BsonDocument
 
containsKey(Object) - Method in class org.bson.BsonDocumentWrapper
 
containsKey(String) - Method in interface org.bson.BSONObject
Deprecated.
containsKey(Object) - Method in class org.bson.Document
 
containsKey(String) - Method in class org.bson.LazyBSONObject
Deprecated.
containsKey(Object) - Method in class org.bson.RawBsonDocument
 
containsKey(String) - Method in class org.bson.types.BasicBSONList
Deprecated.
containsValue(Object) - Method in class org.bson.BsonDocument
 
containsValue(Object) - Method in class org.bson.BsonDocumentWrapper
 
containsValue(Object) - Method in class org.bson.Document
 
containsValue(Object) - Method in class org.bson.RawBsonDocument
 
Context(AbstractBsonReader.Context, BsonContextType) - Constructor for class org.bson.AbstractBsonReader.Context
Creates a new instance.
Context(AbstractBsonWriter.Context) - Constructor for class org.bson.AbstractBsonWriter.Context
Creates a new instance, copying values from an existing context.
Context(AbstractBsonWriter.Context, BsonContextType) - Constructor for class org.bson.AbstractBsonWriter.Context
Creates a new instance.
Context(BsonBinaryWriter.Context, BsonContextType, int) - Constructor for class org.bson.BsonBinaryWriter.Context
Creates a new instance
Context(BsonBinaryWriter.Context) - Constructor for class org.bson.BsonBinaryWriter.Context
Creates a new instance by copying the values from the given context.
Context(BsonDocumentReader.Context, BsonContextType, BsonArray) - Constructor for class org.bson.BsonDocumentReader.Context
 
Context(BsonDocumentReader.Context, BsonContextType, BsonDocument) - Constructor for class org.bson.BsonDocumentReader.Context
 
Context(AbstractBsonReader.Context, BsonContextType) - Constructor for class org.bson.json.JsonReader.Context
 
Context(JsonWriter.Context, BsonContextType, String) - Constructor for class org.bson.json.JsonWriter.Context
Creates a new context.
continueOnError(boolean) - Method in class com.mongodb.InsertOptions
Set whether documents will continue to be inserted after a failure to insert one.
convertToType(Class<T>, Object, String) - Static method in class org.bson.assertions.Assertions
Cast an object to the given class and return it, or throw IllegalArgumentException if it's not assignable to that class.
CoordinateReferenceSystem - Class in com.mongodb.client.model.geojson
A GeoJSON Coordinate Reference System (CRS).
CoordinateReferenceSystem() - Constructor for class com.mongodb.client.model.geojson.CoordinateReferenceSystem
 
CoordinateReferenceSystemType - Enum in com.mongodb.client.model.geojson
An enumeration of the GeoJSON coordinate reference system types.
copy() - Method in class com.mongodb.BasicDBList
Copies this instance into a new Object.
copy() - Method in class com.mongodb.BasicDBObject
Creates a new instance which is a copy of this BasicDBObject.
copy() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Copy this DBCollectionFindOptions instance into a new instance.
copy() - Method in class com.mongodb.DBCursor
Creates a copy of an existing database cursor.
copy() - Method in class com.mongodb.MongoOptions
Deprecated.
Copy this MongoOptions instance into a new instance.
copy() - Method in class org.bson.AbstractBsonWriter.Context
Copies the values from this Context into a new instance.
copy() - Method in class org.bson.BsonBinaryWriter.Context
 
copyClusterDescription(ClusterDescription, List<ServerDescription>) - Static method in class com.mongodb.TaggableReadPreference
 
count(SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.MongoCollection
Counts the number of documents in the collection.
count(Bson, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.MongoCollection
Counts the number of documents in the collection according to the given options.
count(Bson, CountOptions, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.MongoCollection
Counts the number of documents in the collection according to the given options.
count() - Static method in class com.mongodb.client.model.Aggregates
Creates a $count pipeline stage using the field name "count" to store the result
count(String) - Static method in class com.mongodb.client.model.Aggregates
Creates a $count pipeline stage using the named field to store the result
count() - Method in interface com.mongodb.client.MongoCollection
Counts the number of documents in the collection.
count(Bson) - Method in interface com.mongodb.client.MongoCollection
Counts the number of documents in the collection according to the given options.
count(Bson, CountOptions) - Method in interface com.mongodb.client.MongoCollection
Counts the number of documents in the collection according to the given options.
count() - Method in class com.mongodb.DBCollection
count(DBObject) - Method in class com.mongodb.DBCollection
count(DBObject, ReadPreference) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
count(DBObject, DBCollectionCountOptions) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
count() - Method in class com.mongodb.DBCursor
Counts the number of objects matching the query.
CountOperation - Class in com.mongodb.operation
An operation that executes a count.
CountOperation(MongoNamespace) - Constructor for class com.mongodb.operation.CountOperation
Construct a new instance.
CountOptions - Class in com.mongodb.client.model
The options for a count operation.
CountOptions() - Constructor for class com.mongodb.client.model.CountOptions
 
create(MongoDatabase) - Static method in class com.mongodb.async.client.gridfs.GridFSBuckets
Create a new GridFS bucket with the default 'fs' bucket name
create(MongoDatabase, String) - Static method in class com.mongodb.async.client.gridfs.GridFSBuckets
Create a new GridFS bucket with a custom bucket name
create() - Static method in class com.mongodb.async.client.MongoClients
Creates a new client with the default connection string "mongodb://localhost".
create(MongoClientSettings) - Static method in class com.mongodb.async.client.MongoClients
Create a new client with the given client settings.
create(String) - Static method in class com.mongodb.async.client.MongoClients
Create a new client with the given connection string as if by a call to MongoClients.create(ConnectionString).
create(ConnectionString) - Static method in class com.mongodb.async.client.MongoClients
Create a new client with the given connection string.
create(MongoClientSettings, MongoDriverInformation) - Static method in class com.mongodb.async.client.MongoClients
Creates a new client with the given client settings.
create(ConnectionString, MongoDriverInformation) - Static method in class com.mongodb.async.client.MongoClients
Create a new client with the given connection string.
create(MongoDatabase) - Static method in class com.mongodb.client.gridfs.GridFSBuckets
Create a new GridFS bucket with the default 'fs' bucket name
create(MongoDatabase, String) - Static method in class com.mongodb.client.gridfs.GridFSBuckets
Create a new GridFS bucket with a custom bucket name
create(ServerAddress) - Method in class com.mongodb.connection.AsynchronousSocketChannelStreamFactory
 
create(SocketSettings, SslSettings) - Method in class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory
 
create(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, ClusterListener, ConnectionPoolListener, ConnectionListener) - Method in interface com.mongodb.connection.ClusterFactory
Creates a cluster with the given settings.
create(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, ClusterListener, ConnectionPoolListener, ConnectionListener) - Method in class com.mongodb.connection.DefaultClusterFactory
 
create(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, ClusterListener, ConnectionPoolListener, ConnectionListener, CommandListener) - Method in class com.mongodb.connection.DefaultClusterFactory
Creates a cluster with the given settings.
create(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, ClusterListener, ConnectionPoolListener, ConnectionListener, CommandListener, String, MongoDriverInformation) - Method in class com.mongodb.connection.DefaultClusterFactory
Creates a cluster with the given settings.
create(ServerAddress) - Method in class com.mongodb.connection.netty.NettyStreamFactory
 
create(SocketSettings, SslSettings) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
create(ServerAddress) - Method in class com.mongodb.connection.SocketStreamFactory
 
create(ServerAddress) - Method in interface com.mongodb.connection.StreamFactory
Create a Stream to the given address
create(SocketSettings, SslSettings) - Method in interface com.mongodb.connection.StreamFactoryFactory
Create a StreamFactory with the given settings.
create(DBCollection) - Method in interface com.mongodb.DBCallbackFactory
Creates a DBCallback for the given collection.
create() - Method in interface com.mongodb.DBDecoderFactory
Creates an instance.
create() - Method in interface com.mongodb.DBEncoderFactory
Creates an instance.
create() - Method in class com.mongodb.DefaultDBCallback
 
create(boolean, List<String>) - Method in class com.mongodb.DefaultDBCallback
 
create() - Method in class com.mongodb.util.JSONCallback
 
create() - Method in class org.bson.BasicBSONCallback
Factory method for creating a new BSONObject.
create(boolean, List<String>) - Method in class org.bson.BasicBSONCallback
Helper method to create either a BSON Object or a BSON List depending upon whether the array parameter is true or not.
createArray(byte[], int) - Method in class com.mongodb.LazyDBCallback
 
createArray(byte[], int) - Method in class org.bson.LazyBSONCallback
Create a LazyBSONList from the given bytes starting from the given offset.
createBSONCallback() - Method in class org.bson.BasicBSONCallback
 
createBSONCallback() - Method in interface org.bson.BSONCallback
Factory method for BSONCallbacks.
createBSONCallback() - Method in class org.bson.EmptyBSONCallback
 
createChunk(Object, int, byte[]) - Method in class com.mongodb.gridfs.GridFSInputFile
Creates a new chunk of this file.
createCollection(String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new collection with the given name.
createCollection(String, CreateCollectionOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new collection with the selected options
createCollection(String) - Method in interface com.mongodb.client.MongoDatabase
Create a new collection with the given name.
createCollection(String, CreateCollectionOptions) - Method in interface com.mongodb.client.MongoDatabase
Create a new collection with the selected options
createCollection(String, DBObject) - Method in class com.mongodb.DB
Creates a collection with a given name and options.
CreateCollectionOperation - Class in com.mongodb.operation
An operation to create a collection
CreateCollectionOperation(String, String) - Constructor for class com.mongodb.operation.CreateCollectionOperation
Construct a new instance.
CreateCollectionOperation(String, String, WriteConcern) - Constructor for class com.mongodb.operation.CreateCollectionOperation
Construct a new instance.
CreateCollectionOptions - Class in com.mongodb.client.model
Options for creating a collection
CreateCollectionOptions() - Constructor for class com.mongodb.client.model.CreateCollectionOptions
 
createCredential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance with an unspecified mechanism.
createDBRef(String, ObjectId) - Method in class com.mongodb.LazyDBCallback
 
createDBRef(String, ObjectId) - Method in class org.bson.LazyBSONCallback
This is a factory method pattern to create appropriate objects for BSON type DBPointer(0x0c).
createFile(byte[]) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile(File) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile(InputStream) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile(InputStream, boolean) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile(InputStream, String) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile(InputStream, String, boolean) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile(String) - Method in class com.mongodb.gridfs.GridFS
Creates a file entry.
createFile() - Method in class com.mongodb.gridfs.GridFS
This method creates an empty GridFSInputFile instance.
createFromLegacyFormat(int, int, int) - Static method in class org.bson.types.ObjectId
Creates an ObjectId using time, machine and inc values.
createGSSAPICredential(String) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the GSSAPI SASL mechanism.
createIndex(Bson, SingleResultCallback<String>) - Method in interface com.mongodb.async.client.MongoCollection
Creates an index.
createIndex(Bson, IndexOptions, SingleResultCallback<String>) - Method in interface com.mongodb.async.client.MongoCollection
Creates an index.
createIndex(Bson) - Method in interface com.mongodb.client.MongoCollection
Create an index with the given keys.
createIndex(Bson, IndexOptions) - Method in interface com.mongodb.client.MongoCollection
Create an index with the given keys and options.
createIndex(String) - Method in class com.mongodb.DBCollection
Forces creation of an ascending index on a field with the default options.
createIndex(DBObject, String) - Method in class com.mongodb.DBCollection
Forces creation of an index on a set of fields, if one does not already exist.
createIndex(DBObject, String, boolean) - Method in class com.mongodb.DBCollection
Forces creation of an index on a set of fields, if one does not already exist.
createIndex(DBObject) - Method in class com.mongodb.DBCollection
Creates an index on the field specified, if that index does not already exist.
createIndex(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Creates an index on the field specified, if that index does not already exist.
createIndexes(List<IndexModel>, SingleResultCallback<List<String>>) - Method in interface com.mongodb.async.client.MongoCollection
Create multiple indexes.
createIndexes(List<IndexModel>) - Method in interface com.mongodb.client.MongoCollection
Create multiple indexes.
CreateIndexesOperation - Class in com.mongodb.operation
An operation that creates one or more indexes.
CreateIndexesOperation(MongoNamespace, List<IndexRequest>) - Constructor for class com.mongodb.operation.CreateIndexesOperation
CreateIndexesOperation(MongoNamespace, List<IndexRequest>, WriteConcern) - Constructor for class com.mongodb.operation.CreateIndexesOperation
Construct a new instance.
createList() - Method in class com.mongodb.util.JSONCallback
 
createList() - Method in class org.bson.BasicBSONCallback
Factory method for creating a new BSON List.
createMongoCRCredential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the MongoDB Challenge Response protocol.
createMongoX509Credential(String) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the MongoDB X.509 protocol.
createObject(byte[], int) - Method in class com.mongodb.LazyDBCallback
 
createObject(byte[], int) - Method in class org.bson.LazyBSONCallback
Create a LazyBSONObject instance from the given bytes starting from the given offset.
createPlainCredential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the PLAIN SASL mechanism.
createScramSha1Credential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the SCRAM-SHA-1 SASL mechanism.
CreateUserOperation - Class in com.mongodb.operation
An operation to create a user.
CreateUserOperation(MongoCredential, boolean) - Constructor for class com.mongodb.operation.CreateUserOperation
CreateUserOperation(MongoCredential, boolean, WriteConcern) - Constructor for class com.mongodb.operation.CreateUserOperation
Construct a new instance.
createView(String, String, List<? extends Bson>, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Creates a view with the given name, backing collection/view name, and aggregation pipeline that defines the view.
createView(String, String, List<? extends Bson>, CreateViewOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Creates a view with the given name, backing collection/view name, aggregation pipeline, and options that defines the view.
createView(String, String, List<? extends Bson>) - Method in interface com.mongodb.client.MongoDatabase
Creates a view with the given name, backing collection/view name, and aggregation pipeline that defines the view.
createView(String, String, List<? extends Bson>, CreateViewOptions) - Method in interface com.mongodb.client.MongoDatabase
Creates a view with the given name, backing collection/view name, aggregation pipeline, and options that defines the view.
createView(String, String, List<? extends DBObject>) - Method in class com.mongodb.DB
Creates a view with the given name, backing collection/view name, and aggregation pipeline that defines the view.
createView(String, String, List<? extends DBObject>, DBCreateViewOptions) - Method in class com.mongodb.DB
Creates a view with the given name, backing collection/view name, aggregation pipeline, and options that defines the view.
CreateViewOperation - Class in com.mongodb.operation
An operation to create a view.
CreateViewOperation(String, String, String, List<BsonDocument>, WriteConcern) - Constructor for class com.mongodb.operation.CreateViewOperation
Construct a new instance.
CreateViewOptions - Class in com.mongodb.client.model
Options for creating a view
CreateViewOptions() - Constructor for class com.mongodb.client.model.CreateViewOptions
 
credentialList(List<MongoCredential>) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the credential list.
CRS_84 - Static variable in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
The urn:ogc:def:crs:OGC:1.3:CRS84 Coordinate Reference System
cur() - Method in class org.bson.BasicBSONCallback
Gets the current value
curName() - Method in class org.bson.BasicBSONCallback
Gets the name of the current field
curr() - Method in class com.mongodb.DBCursor
Returns the element the cursor is at.
currentDate(String) - Static method in class com.mongodb.client.model.Updates
Creates an update that sets the value of the field to the current date as a BSON date.
CurrentOpOperation - Class in com.mongodb.operation
An operation that determines the current operation on a MongoDB server.
CurrentOpOperation() - Constructor for class com.mongodb.operation.CurrentOpOperation
 
currentTimestamp(String) - Static method in class com.mongodb.client.model.Updates
Creates an update that sets the value of the field to the current date as a BSON timestamp.
Cursor - Interface in com.mongodb
Interface for providing consistent behaviour between different Cursor implementations.
cursorFinalizerEnabled(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Sets whether cursor finalizers are enabled.
cursorFinalizerEnabled - Variable in class com.mongodb.MongoOptions
Deprecated.
Sets whether there is a a finalize method created that cleans up instances of DBCursor that the client does not close.
cursorType(CursorType) - Method in interface com.mongodb.async.client.FindIterable
Sets the cursor type.
cursorType(CursorType) - Method in interface com.mongodb.client.FindIterable
Sets the cursor type.
cursorType(CursorType) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the cursor type.
cursorType(CursorType) - Method in class com.mongodb.client.model.FindOptions
Sets the cursor type.
CursorType - Enum in com.mongodb
An enumeration of cursor types.
cursorType(CursorType) - Method in class com.mongodb.operation.FindOperation
Sets the cursor type.

D

databaseName(String) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the name of the database to output into.
databaseName(String) - Method in interface com.mongodb.client.MapReduceIterable
Sets the name of the database to output into.
databaseName(String) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the name of the database to output into.
DATE - Static variable in class org.bson.BSON
 
DateCodec - Class in org.bson.codecs
Encodes and decodes java.util.Date objects.
DateCodec() - Constructor for class org.bson.codecs.DateCodec
 
DB - Class in com.mongodb
A thread-safe client view of a logical database in a MongoDB cluster.
DB(Mongo, String) - Constructor for class com.mongodb.DB
Constructs a new instance of the DB.
DBAddress - Class in com.mongodb
Deprecated.
This class is no longer needed, as the driver does not rely on it for anything anymore. Use ServerAddress instead.
DBAddress(String) - Constructor for class com.mongodb.DBAddress
Deprecated.
Creates a new address.
DBAddress(DBAddress, String) - Constructor for class com.mongodb.DBAddress
Deprecated.
Create a DBAddress using the host and port from an existing DBAddress, and connected to a given database.
DBAddress(String, String) - Constructor for class com.mongodb.DBAddress
Deprecated.
Creates a DBAddress for the given database on the given host.
DBAddress(String, int, String) - Constructor for class com.mongodb.DBAddress
Deprecated.
Creates a DBAddress for the given database on the given host at the given port.
DBAddress(InetAddress, int, String) - Constructor for class com.mongodb.DBAddress
Deprecated.
 
DBCallback - Interface in com.mongodb
The DB callback interface.
DBCallbackFactory - Interface in com.mongodb
Factory for creating concrete implementations of DBCallback.
DBCollection - Class in com.mongodb
Implementation of a database collection.
DBCollection(DB, String) - Constructor for class com.mongodb.DBCollection
Initializes a new collection.
DBCollectionCountOptions - Class in com.mongodb.client.model
The options for a count operation.
DBCollectionCountOptions() - Constructor for class com.mongodb.client.model.DBCollectionCountOptions
Construct a new instance
DBCollectionDistinctOptions - Class in com.mongodb.client.model
The options for a count operation.
DBCollectionDistinctOptions() - Constructor for class com.mongodb.client.model.DBCollectionDistinctOptions
Construct a new instance
DBCollectionFindAndModifyOptions - Class in com.mongodb.client.model
The oprtions for find and modify operations.
DBCollectionFindAndModifyOptions() - Constructor for class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Construct a new instance
DBCollectionFindOptions - Class in com.mongodb.client.model
The options to apply to a find operation (also commonly referred to as a query).
DBCollectionFindOptions() - Constructor for class com.mongodb.client.model.DBCollectionFindOptions
Construct a new instance
DBCollectionRemoveOptions - Class in com.mongodb.client.model
The options to apply when removing documents from the DBCollection
DBCollectionRemoveOptions() - Constructor for class com.mongodb.client.model.DBCollectionRemoveOptions
Construct a new instance
DBCollectionUpdateOptions - Class in com.mongodb.client.model
The options to apply when updating documents in the DBCollection
DBCollectionUpdateOptions() - Constructor for class com.mongodb.client.model.DBCollectionUpdateOptions
Construct a new instance
DBCreateViewOptions - Class in com.mongodb.client.model
The options to apply when creating a view
DBCreateViewOptions() - Constructor for class com.mongodb.client.model.DBCreateViewOptions
 
DBCursor - Class in com.mongodb
An iterator over database results.
DBCursor(DBCollection, DBObject, DBObject, ReadPreference) - Constructor for class com.mongodb.DBCursor
Initializes a new database cursor.
DBDecoder - Interface in com.mongodb
An interface for decoders of BSON into instances of DBObject that belong to a DBCollection.
DBDecoderFactory - Interface in com.mongodb
Creates concrete DBDecoder instances.
dbDecoderFactory(DBDecoderFactory) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the decoder factory.
dbDecoderFactory - Variable in class com.mongodb.MongoOptions
Deprecated.
Override the DBCallback factory.
DBEncoder - Interface in com.mongodb
An interface for encoders of BSONObject to BSON.
dbEncoder(DBEncoder) - Method in class com.mongodb.InsertOptions
Set the encoder to use for the documents.
DBEncoderFactory - Interface in com.mongodb
Creates concrete DBEncoder instances.
dbEncoderFactory(DBEncoderFactory) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the encoder factory.
dbEncoderFactory - Variable in class com.mongodb.MongoOptions
Deprecated.
Override the encoding factory.
DBObject - Interface in com.mongodb
This interface adds some specific behaviour to BSONObject for MongoDB documents.
DBObjectCodec - Class in com.mongodb
A collectible codec for a DBObject.
DBObjectCodec(CodecRegistry) - Constructor for class com.mongodb.DBObjectCodec
Construct an instance with the given codec registry.
DBObjectCodec(CodecRegistry, BsonTypeClassMap) - Constructor for class com.mongodb.DBObjectCodec
Construct an instance.
DBObjectCodec(CodecRegistry, BsonTypeClassMap, DBObjectFactory) - Constructor for class com.mongodb.DBObjectCodec
Construct an instance.
DBObjectCodecProvider - Class in com.mongodb
A provider for a DBObjectCodec.
DBObjectCodecProvider() - Constructor for class com.mongodb.DBObjectCodecProvider
Construct an instance using the default BsonTypeClassMap.
DBObjectCodecProvider(BsonTypeClassMap) - Constructor for class com.mongodb.DBObjectCodecProvider
Construct an instance with the given BsonTypeClassMap.
DBRef - Class in com.mongodb
A representation of a database reference.
DBRef(String, Object) - Constructor for class com.mongodb.DBRef
Construct an instance.
DBRef(String, String, Object) - Constructor for class com.mongodb.DBRef
Construct an instance.
DBRefCodec - Class in com.mongodb
A Codec for DBRef instances.
DBRefCodec(CodecRegistry) - Constructor for class com.mongodb.DBRefCodec
Construct an instance with the given registry, which is used to encode the id of the referenced document.
DBRefCodecProvider - Class in com.mongodb
A codec provider for DBRef.
DBRefCodecProvider() - Constructor for class com.mongodb.DBRefCodecProvider
 
debug(String) - Method in interface com.mongodb.diagnostics.logging.Logger
Log a message at the DEBUG level.
debug(String, Throwable) - Method in interface com.mongodb.diagnostics.logging.Logger
Log an exception (throwable) at the DEBUG level with an accompanying message.
Decimal128 - Class in org.bson.types
A representation of a 128-bit decimal.
Decimal128(long) - Constructor for class org.bson.types.Decimal128
Constructs a Decimal128 value representing the given long.
Decimal128(BigDecimal) - Constructor for class org.bson.types.Decimal128
Constructs a Decimal128 value representing the given BigDecimal.
Decimal128Codec - Class in org.bson.codecs
Encodes and decodes Decimal128 objects.
Decimal128Codec() - Constructor for class org.bson.codecs.Decimal128Codec
 
decimal128Value() - Method in class org.bson.BsonDecimal128
 
decimal128Value() - Method in class org.bson.BsonDouble
 
decimal128Value() - Method in class org.bson.BsonInt32
 
decimal128Value() - Method in class org.bson.BsonInt64
 
decimal128Value() - Method in class org.bson.BsonNumber
Returns the value of the specified number as a Decimal128, which may involve rounding.
decode(BsonReader, DecoderContext) - Method in class com.mongodb.BSONTimestampCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.GeometryCollectionCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.LineStringCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.MultiLineStringCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.MultiPointCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.MultiPolygonCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.PointCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.PolygonCodec
 
decode(InputStream, DBCollection) - Method in interface com.mongodb.DBDecoder
Decode a single DBObject belonging to the given collection from the given input stream.
decode(byte[], DBCollection) - Method in interface com.mongodb.DBDecoder
Decode a single DBObject belonging to the given collection from the given array of bytes.
decode(BsonReader, DecoderContext) - Method in class com.mongodb.DBObjectCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.DBRefCodec
 
decode(InputStream, DBCollection) - Method in class com.mongodb.DefaultDBDecoder
 
decode(byte[], DBCollection) - Method in class com.mongodb.DefaultDBDecoder
 
decode(InputStream, DBCollection) - Method in class com.mongodb.LazyDBDecoder
 
decode(byte[], DBCollection) - Method in class com.mongodb.LazyDBDecoder
 
decode(byte[], BSONCallback) - Method in class org.bson.BasicBSONDecoder
 
decode(InputStream, BSONCallback) - Method in class org.bson.BasicBSONDecoder
 
decode(byte[]) - Static method in class org.bson.BSON
Decodes a BSON byte array into a DBObject instance.
decode(byte[], BSONCallback) - Method in interface org.bson.BSONDecoder
Decode a single BSON object into the given callback from the given byte array.
decode(InputStream, BSONCallback) - Method in interface org.bson.BSONDecoder
Decode a single BSON object into the given callback from the given input stream.
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.AtomicBooleanCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.AtomicIntegerCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.AtomicLongCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BinaryCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BooleanCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonArrayCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonBinaryCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonBooleanCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDateTimeCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDBPointerCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDecimal128Codec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDocumentCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDocumentWrapperCodec
Decoding of BsonDocumentWrapper instances is not supported, so this method will throw UnsupportedOperationException in all cases.
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDoubleCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonInt32Codec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonInt64Codec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonJavaScriptCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonJavaScriptWithScopeCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonMaxKeyCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonMinKeyCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonNullCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonObjectIdCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonRegularExpressionCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonStringCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonSymbolCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonTimestampCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonUndefinedCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonValueCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.ByteArrayCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.ByteCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.CharacterCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.CodeCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.CodeWithScopeCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.DateCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.Decimal128Codec
 
decode(BsonReader, DecoderContext) - Method in interface org.bson.codecs.Decoder
Decodes a BSON value from the given reader into an instance of the type parameter T.
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.DocumentCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.DoubleCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.FloatCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.IntegerCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.IterableCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.LongCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.MaxKeyCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.MinKeyCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.ObjectIdCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.PatternCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.RawBsonDocumentCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.ShortCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.StringCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.SymbolCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.UuidCodec
 
decode(byte[], BSONCallback) - Method in class org.bson.LazyBSONDecoder
 
decode(InputStream, BSONCallback) - Method in class org.bson.LazyBSONDecoder
 
decode(Codec<T>) - Method in class org.bson.RawBsonDocument
Decode this into a document.
Decoder<T> - Interface in org.bson.codecs
Decoders are used for reading BSON types from MongoDB and converting them into Java objects.
DecoderContext - Class in org.bson.codecs
The context for decoding values to BSON.
DecoderContext.Builder - Class in org.bson.codecs
A builder for DecoderContext instances.
DEFAULT - Static variable in class com.mongodb.ReadConcern
Use the servers default read concern.
DEFAULT_BUCKET - Static variable in class com.mongodb.gridfs.GridFS
Bucket to use for the collection namespaces
DEFAULT_CHUNKSIZE - Static variable in class com.mongodb.gridfs.GridFS
File's chunk size
defaultBucket(Object) - Method in class com.mongodb.client.model.BucketOptions
The name of the default bucket for values outside the defined buckets
DefaultClusterFactory - Class in com.mongodb.connection
The default factory for cluster implementations.
DefaultClusterFactory() - Constructor for class com.mongodb.connection.DefaultClusterFactory
 
DefaultDBCallback - Class in com.mongodb
An implementation of DBCallback that decodes into a DBObject.
DefaultDBCallback(DBCollection) - Constructor for class com.mongodb.DefaultDBCallback
Creates a new DefaultDBCallback.
DefaultDBDecoder - Class in com.mongodb
An implementation of DBDecoder
DefaultDBDecoder() - Constructor for class com.mongodb.DefaultDBDecoder
 
DefaultDBEncoder - Class in com.mongodb
The default BSON encoder for BSONObject instances.
DefaultDBEncoder() - Constructor for class com.mongodb.DefaultDBEncoder
 
defaultHost() - Static method in class com.mongodb.ServerAddress
Returns the default database host: "127.0.0.1"
defaultLanguage(String) - Method in class com.mongodb.bulk.IndexRequest
Sets the language for the text index.
defaultLanguage(String) - Method in class com.mongodb.client.model.IndexOptions
Sets the language for the text index.
defaultPort() - Static method in class com.mongodb.ServerAddress
Returns the default database port: 27017
delete(ObjectId, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Given a id, delete this stored file's files collection document and associated chunks from a GridFS bucket.
delete(BsonValue, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Given a id, delete this stored file's files collection document and associated chunks from a GridFS bucket.
delete(ObjectId) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Given a id, delete this stored file's files collection document and associated chunks from a GridFS bucket.
delete(BsonValue) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Given a id, delete this stored file's files collection document and associated chunks from a GridFS bucket.
delete(MongoNamespace, boolean, WriteConcern, List<DeleteRequest>) - Method in interface com.mongodb.connection.Connection
Delete the documents using the delete wire protocol and apply the write concern.
deleteAsync(MongoNamespace, boolean, WriteConcern, List<DeleteRequest>, SingleResultCallback<WriteConcernResult>) - Method in interface com.mongodb.connection.AsyncConnection
Delete the documents using the delete wire protocol and apply the write concern asynchronously.
deleteCommand(MongoNamespace, boolean, WriteConcern, List<DeleteRequest>) - Method in interface com.mongodb.connection.Connection
Delete the documents using the delete command.
deleteCommandAsync(MongoNamespace, boolean, WriteConcern, List<DeleteRequest>, SingleResultCallback<BulkWriteResult>) - Method in interface com.mongodb.connection.AsyncConnection
Delete the documents using the delete command asynchronously.
deleteMany(Bson, SingleResultCallback<DeleteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Removes all documents from the collection that match the given query filter.
deleteMany(Bson, DeleteOptions, SingleResultCallback<DeleteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Removes all documents from the collection that match the given query filter.
deleteMany(Bson) - Method in interface com.mongodb.client.MongoCollection
Removes all documents from the collection that match the given query filter.
deleteMany(Bson, DeleteOptions) - Method in interface com.mongodb.client.MongoCollection
Removes all documents from the collection that match the given query filter.
DeleteManyModel<T> - Class in com.mongodb.client.model
A model describing the removal of all documents matching the query filter.
DeleteManyModel(Bson) - Constructor for class com.mongodb.client.model.DeleteManyModel
Construct a new instance.
DeleteManyModel(Bson, DeleteOptions) - Constructor for class com.mongodb.client.model.DeleteManyModel
Construct a new instance.
deleteOne(Bson, SingleResultCallback<DeleteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Removes at most one document from the collection that matches the given filter.
deleteOne(Bson, DeleteOptions, SingleResultCallback<DeleteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Removes at most one document from the collection that matches the given filter.
deleteOne(Bson) - Method in interface com.mongodb.client.MongoCollection
Removes at most one document from the collection that matches the given filter.
deleteOne(Bson, DeleteOptions) - Method in interface com.mongodb.client.MongoCollection
Removes at most one document from the collection that matches the given filter.
DeleteOneModel<T> - Class in com.mongodb.client.model
A model describing the removal of at most one document matching the query filter.
DeleteOneModel(Bson) - Constructor for class com.mongodb.client.model.DeleteOneModel
Construct a new instance.
DeleteOneModel(Bson, DeleteOptions) - Constructor for class com.mongodb.client.model.DeleteOneModel
Construct a new instance.
DeleteOperation - Class in com.mongodb.operation
An operation that deletes one or more documents from a collection.
DeleteOperation(MongoNamespace, boolean, WriteConcern, List<DeleteRequest>) - Constructor for class com.mongodb.operation.DeleteOperation
Construct an instance.
DeleteOptions - Class in com.mongodb.client.model
The options to apply when deleting documents.
DeleteOptions() - Constructor for class com.mongodb.client.model.DeleteOptions
 
DeleteRequest - Class in com.mongodb.bulk
A representation of a delete.
DeleteRequest(BsonDocument) - Constructor for class com.mongodb.bulk.DeleteRequest
Construct a new instance.
DeleteResult - Class in com.mongodb.client.result
The result of a delete operation.
DeleteResult() - Constructor for class com.mongodb.client.result.DeleteResult
 
depthField(String) - Method in class com.mongodb.client.model.GraphLookupOptions
The name of the field in which to store the depth value
descending(String...) - Static method in class com.mongodb.client.model.Indexes
Create an index key for an ascending index on the given fields.
descending(List<String>) - Static method in class com.mongodb.client.model.Indexes
Create an index key for an ascending index on the given fields.
descending(String...) - Static method in class com.mongodb.client.model.Sorts
Create a sort specification for an ascending sort on the given fields.
descending(List<String>) - Static method in class com.mongodb.client.model.Sorts
Create a sort specification for an ascending sort on the given fields.
description(String) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the user defined description of the MongoClient.
description(String) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the description.
description - Variable in class com.mongodb.MongoOptions
Deprecated.
The description for Mongo instances created with these options.
diacriticSensitive(Boolean) - Method in class com.mongodb.client.model.TextSearchOptions
Set the diacritic-sensitive flag for the text search
distinct(String, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Gets the distinct values of the specified field name.
distinct(String, Bson, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Gets the distinct values of the specified field name.
distinct(String, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Gets the distinct values of the specified field name.
distinct(String, Bson, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Gets the distinct values of the specified field name.
distinct(String) - Method in class com.mongodb.DBCollection
Find the distinct values for a specified field across a collection and returns the results in an array.
distinct(String, ReadPreference) - Method in class com.mongodb.DBCollection
Find the distinct values for a specified field across a collection and returns the results in an array.
distinct(String, DBObject) - Method in class com.mongodb.DBCollection
Find the distinct values for a specified field across a collection and returns the results in an array.
distinct(String, DBObject, ReadPreference) - Method in class com.mongodb.DBCollection
Find the distinct values for a specified field across a collection and returns the results in an array.
distinct(String, DBCollectionDistinctOptions) - Method in class com.mongodb.DBCollection
Find the distinct values for a specified field across a collection and returns the results in an array.
DistinctIterable<TResult> - Interface in com.mongodb.async.client
Iterable for distinct.
DistinctIterable<TResult> - Interface in com.mongodb.client
Iterable interface for distinct.
DistinctOperation<T> - Class in com.mongodb.operation
Finds the distinct values for a specified field across a single collection.
DistinctOperation(MongoNamespace, String, Decoder<T>) - Constructor for class com.mongodb.operation.DistinctOperation
Construct an instance.
Document - Class in org.bson
A representation of a document as a Map.
Document() - Constructor for class org.bson.Document
Creates an empty Document instance.
Document(String, Object) - Constructor for class org.bson.Document
Create a Document instance initialized with the given key/value pair.
Document(Map<String, Object>) - Constructor for class org.bson.Document
Creates a Document instance initialized with the given map.
DocumentCodec - Class in org.bson.codecs
A Codec for Document instances.
DocumentCodec() - Constructor for class org.bson.codecs.DocumentCodec
Construct a new instance with a default CodecRegistry and
DocumentCodec(CodecRegistry, BsonTypeClassMap) - Constructor for class org.bson.codecs.DocumentCodec
Construct a new instance with the given registry and BSON type class map.
DocumentCodec(CodecRegistry, BsonTypeClassMap, Transformer) - Constructor for class org.bson.codecs.DocumentCodec
Construct a new instance with the given registry and BSON type class map.
DocumentCodecProvider - Class in org.bson.codecs
A CodecProvider for the Document class and all the default Codec implementations on which it depends.
DocumentCodecProvider() - Constructor for class org.bson.codecs.DocumentCodecProvider
Construct a new instance with a default BsonTypeClassMap.
DocumentCodecProvider(Transformer) - Constructor for class org.bson.codecs.DocumentCodecProvider
Construct a new instance with a default BsonTypeClassMap and the given Transformer.
DocumentCodecProvider(BsonTypeClassMap) - Constructor for class org.bson.codecs.DocumentCodecProvider
Construct a new instance with the given instance of BsonTypeClassMap.
DocumentCodecProvider(BsonTypeClassMap, Transformer) - Constructor for class org.bson.codecs.DocumentCodecProvider
Construct a new instance with the given instance of BsonTypeClassMap.
documentHasId(DBObject) - Method in class com.mongodb.DBObjectCodec
 
documentHasId(BsonDocument) - Method in class org.bson.codecs.BsonDocumentCodec
 
documentHasId(T) - Method in interface org.bson.codecs.CollectibleCodec
Returns true if the given document has an _id.
documentHasId(Document) - Method in class org.bson.codecs.DocumentCodec
 
doEval(String, Object...) - Method in class com.mongodb.DB
Evaluates JavaScript functions on the database server.
doGetCollection(String) - Method in class com.mongodb.DB
Gets a collection with a given name.
done() - Method in class org.bson.BasicBSONEncoder
 
done() - Method in interface org.bson.BSONEncoder
Free the resources.
doPeekBinarySubType() - Method in class org.bson.AbstractBsonReader
Handles the logic to peek at the binary subtype.
doPeekBinarySubType() - Method in class org.bson.BsonBinaryReader
 
doPeekBinarySubType() - Method in class org.bson.BsonDocumentReader
 
doPeekBinarySubType() - Method in class org.bson.json.JsonReader
 
doReadBinaryData() - Method in class org.bson.AbstractBsonReader
Handles the logic to read binary data
doReadBinaryData() - Method in class org.bson.BsonBinaryReader
 
doReadBinaryData() - Method in class org.bson.BsonDocumentReader
 
doReadBinaryData() - Method in class org.bson.json.JsonReader
 
doReadBoolean() - Method in class org.bson.AbstractBsonReader
Handles the logic to read booleans
doReadBoolean() - Method in class org.bson.BsonBinaryReader
 
doReadBoolean() - Method in class org.bson.BsonDocumentReader
 
doReadBoolean() - Method in class org.bson.json.JsonReader
 
doReadDateTime() - Method in class org.bson.AbstractBsonReader
Handles the logic to read date time
doReadDateTime() - Method in class org.bson.BsonBinaryReader
 
doReadDateTime() - Method in class org.bson.BsonDocumentReader
 
doReadDateTime() - Method in class org.bson.json.JsonReader
 
doReadDBPointer() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a DBPointer
doReadDBPointer() - Method in class org.bson.BsonBinaryReader
 
doReadDBPointer() - Method in class org.bson.BsonDocumentReader
 
doReadDBPointer() - Method in class org.bson.json.JsonReader
 
doReadDecimal128() - Method in class org.bson.AbstractBsonReader
Handles the logic to read Decimal128
doReadDecimal128() - Method in class org.bson.BsonBinaryReader
 
doReadDecimal128() - Method in class org.bson.BsonDocumentReader
 
doReadDecimal128() - Method in class org.bson.json.JsonReader
 
doReadDouble() - Method in class org.bson.AbstractBsonReader
Handles the logic to read doubles
doReadDouble() - Method in class org.bson.BsonBinaryReader
 
doReadDouble() - Method in class org.bson.BsonDocumentReader
 
doReadDouble() - Method in class org.bson.json.JsonReader
 
doReadEndArray() - Method in class org.bson.AbstractBsonReader
Handles the logic when reading the end of an array
doReadEndArray() - Method in class org.bson.BsonBinaryReader
 
doReadEndArray() - Method in class org.bson.BsonDocumentReader
 
doReadEndArray() - Method in class org.bson.json.JsonReader
 
doReadEndDocument() - Method in class org.bson.AbstractBsonReader
Handles the logic when reading the end of a document
doReadEndDocument() - Method in class org.bson.BsonBinaryReader
 
doReadEndDocument() - Method in class org.bson.BsonDocumentReader
 
doReadEndDocument() - Method in class org.bson.json.JsonReader
 
doReadInt32() - Method in class org.bson.AbstractBsonReader
Handles the logic to read 32 bit ints
doReadInt32() - Method in class org.bson.BsonBinaryReader
 
doReadInt32() - Method in class org.bson.BsonDocumentReader
 
doReadInt32() - Method in class org.bson.json.JsonReader
 
doReadInt64() - Method in class org.bson.AbstractBsonReader
Handles the logic to read 64 bit ints
doReadInt64() - Method in class org.bson.BsonBinaryReader
 
doReadInt64() - Method in class org.bson.BsonDocumentReader
 
doReadInt64() - Method in class org.bson.json.JsonReader
 
doReadJavaScript() - Method in class org.bson.AbstractBsonReader
Handles the logic to read Javascript functions
doReadJavaScript() - Method in class org.bson.BsonBinaryReader
 
doReadJavaScript() - Method in class org.bson.BsonDocumentReader
 
doReadJavaScript() - Method in class org.bson.json.JsonReader
 
doReadJavaScriptWithScope() - Method in class org.bson.AbstractBsonReader
Handles the logic to read scoped Javascript functions
doReadJavaScriptWithScope() - Method in class org.bson.BsonBinaryReader
 
doReadJavaScriptWithScope() - Method in class org.bson.BsonDocumentReader
 
doReadJavaScriptWithScope() - Method in class org.bson.json.JsonReader
 
doReadMaxKey() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a Max key
doReadMaxKey() - Method in class org.bson.BsonBinaryReader
 
doReadMaxKey() - Method in class org.bson.BsonDocumentReader
 
doReadMaxKey() - Method in class org.bson.json.JsonReader
 
doReadMinKey() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a Min key
doReadMinKey() - Method in class org.bson.BsonBinaryReader
 
doReadMinKey() - Method in class org.bson.BsonDocumentReader
 
doReadMinKey() - Method in class org.bson.json.JsonReader
 
doReadNull() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a null value
doReadNull() - Method in class org.bson.BsonBinaryReader
 
doReadNull() - Method in class org.bson.BsonDocumentReader
 
doReadNull() - Method in class org.bson.json.JsonReader
 
doReadObjectId() - Method in class org.bson.AbstractBsonReader
Handles the logic to read an ObjectId
doReadObjectId() - Method in class org.bson.BsonBinaryReader
 
doReadObjectId() - Method in class org.bson.BsonDocumentReader
 
doReadObjectId() - Method in class org.bson.json.JsonReader
 
doReadRegularExpression() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a regular expression
doReadRegularExpression() - Method in class org.bson.BsonBinaryReader
 
doReadRegularExpression() - Method in class org.bson.BsonDocumentReader
 
doReadRegularExpression() - Method in class org.bson.json.JsonReader
 
doReadStartArray() - Method in class org.bson.AbstractBsonReader
Handles the logic to read the start of an array
doReadStartArray() - Method in class org.bson.BsonBinaryReader
 
doReadStartArray() - Method in class org.bson.BsonDocumentReader
 
doReadStartArray() - Method in class org.bson.json.JsonReader
 
doReadStartDocument() - Method in class org.bson.AbstractBsonReader
Handles the logic to read the start of a document
doReadStartDocument() - Method in class org.bson.BsonBinaryReader
 
doReadStartDocument() - Method in class org.bson.BsonDocumentReader
 
doReadStartDocument() - Method in class org.bson.json.JsonReader
 
doReadString() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a String
doReadString() - Method in class org.bson.BsonBinaryReader
 
doReadString() - Method in class org.bson.BsonDocumentReader
 
doReadString() - Method in class org.bson.json.JsonReader
 
doReadSymbol() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a Symbol
doReadSymbol() - Method in class org.bson.BsonBinaryReader
 
doReadSymbol() - Method in class org.bson.BsonDocumentReader
 
doReadSymbol() - Method in class org.bson.json.JsonReader
 
doReadTimestamp() - Method in class org.bson.AbstractBsonReader
Handles the logic to read a timestamp
doReadTimestamp() - Method in class org.bson.BsonBinaryReader
 
doReadTimestamp() - Method in class org.bson.BsonDocumentReader
 
doReadTimestamp() - Method in class org.bson.json.JsonReader
 
doReadUndefined() - Method in class org.bson.AbstractBsonReader
Handles the logic to read an Undefined value
doReadUndefined() - Method in class org.bson.BsonBinaryReader
 
doReadUndefined() - Method in class org.bson.BsonDocumentReader
 
doReadUndefined() - Method in class org.bson.json.JsonReader
 
doSkipName() - Method in class org.bson.AbstractBsonReader
Handles any logic required to skip the name (reader must be positioned on a name).
doSkipName() - Method in class org.bson.BsonBinaryReader
 
doSkipName() - Method in class org.bson.BsonDocumentReader
 
doSkipName() - Method in class org.bson.json.JsonReader
 
doSkipValue() - Method in class org.bson.AbstractBsonReader
Handles any logic required to skip the value (reader must be positioned on a value).
doSkipValue() - Method in class org.bson.BsonBinaryReader
 
doSkipValue() - Method in class org.bson.BsonDocumentReader
 
doSkipValue() - Method in class org.bson.json.JsonReader
 
DoubleCodec - Class in org.bson.codecs
Encodes and decodes Double objects.
DoubleCodec() - Constructor for class org.bson.codecs.DoubleCodec
 
doubleValue() - Method in class org.bson.BsonDecimal128
 
doubleValue() - Method in class org.bson.BsonDouble
 
doubleValue() - Method in class org.bson.BsonInt32
 
doubleValue() - Method in class org.bson.BsonInt64
 
doubleValue() - Method in class org.bson.BsonNumber
Returns the value of the specified number as a double, which may involve rounding.
downloadToStream(ObjectId, AsyncOutputStream, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Downloads the contents of the stored file specified by id and writes the contents to the destination AsyncOutputStream.
downloadToStream(BsonValue, AsyncOutputStream, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Downloads the contents of the stored file specified by id and writes the contents to the destination AsyncOutputStream.
downloadToStream(String, AsyncOutputStream, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Downloads the contents of the latest version of the stored file specified by filename and writes the contents to the destination Stream.
downloadToStream(String, AsyncOutputStream, GridFSDownloadOptions, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Downloads the contents of the stored file specified by filename and by the revision in options and writes the contents to the destination Stream.
downloadToStream(ObjectId, OutputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Downloads the contents of the stored file specified by id and writes the contents to the destination Stream.
downloadToStream(BsonValue, OutputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Downloads the contents of the stored file specified by id and writes the contents to the destination Stream.
downloadToStream(String, OutputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Downloads the contents of the latest version of the stored file specified by filename and writes the contents to the destination Stream.
downloadToStream(String, OutputStream, GridFSDownloadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Downloads the contents of the stored file specified by filename and by the revision in options and writes the contents to the destination Stream.
downloadToStreamByName(String, OutputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
downloadToStreamByName(String, OutputStream, GridFSDownloadByNameOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
doWriteBinaryData(BsonBinary) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a BsonBinary value
doWriteBinaryData(BsonBinary) - Method in class org.bson.BsonBinaryWriter
 
doWriteBinaryData(BsonBinary) - Method in class org.bson.BsonDocumentWriter
 
doWriteBinaryData(BsonBinary) - Method in class org.bson.json.JsonWriter
 
doWriteBoolean(boolean) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a boolean value
doWriteBoolean(boolean) - Method in class org.bson.BsonBinaryWriter
 
doWriteBoolean(boolean) - Method in class org.bson.BsonDocumentWriter
 
doWriteBoolean(boolean) - Method in class org.bson.json.JsonWriter
 
doWriteDateTime(long) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a date time value
doWriteDateTime(long) - Method in class org.bson.BsonBinaryWriter
 
doWriteDateTime(long) - Method in class org.bson.BsonDocumentWriter
 
doWriteDateTime(long) - Method in class org.bson.json.JsonWriter
 
doWriteDBPointer(BsonDbPointer) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a DbPointer value
doWriteDBPointer(BsonDbPointer) - Method in class org.bson.BsonBinaryWriter
 
doWriteDBPointer(BsonDbPointer) - Method in class org.bson.BsonDocumentWriter
 
doWriteDBPointer(BsonDbPointer) - Method in class org.bson.json.JsonWriter
 
doWriteDecimal128(Decimal128) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a Decimal128 value
doWriteDecimal128(Decimal128) - Method in class org.bson.BsonBinaryWriter
 
doWriteDecimal128(Decimal128) - Method in class org.bson.BsonDocumentWriter
 
doWriteDecimal128(Decimal128) - Method in class org.bson.json.JsonWriter
 
doWriteDouble(double) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a Double value
doWriteDouble(double) - Method in class org.bson.BsonBinaryWriter
 
doWriteDouble(double) - Method in class org.bson.BsonDocumentWriter
 
doWriteDouble(double) - Method in class org.bson.json.JsonWriter
 
doWriteEndArray() - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing the end of an array
doWriteEndArray() - Method in class org.bson.BsonBinaryWriter
 
doWriteEndArray() - Method in class org.bson.BsonDocumentWriter
 
doWriteEndArray() - Method in class org.bson.json.JsonWriter
 
doWriteEndDocument() - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing the end of a document
doWriteEndDocument() - Method in class org.bson.BsonBinaryWriter
 
doWriteEndDocument() - Method in class org.bson.BsonDocumentWriter
 
doWriteEndDocument() - Method in class org.bson.json.JsonWriter
 
doWriteInt32(int) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing an int32 value
doWriteInt32(int) - Method in class org.bson.BsonBinaryWriter
 
doWriteInt32(int) - Method in class org.bson.BsonDocumentWriter
 
doWriteInt32(int) - Method in class org.bson.json.JsonWriter
 
doWriteInt64(long) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing an int64 value
doWriteInt64(long) - Method in class org.bson.BsonBinaryWriter
 
doWriteInt64(long) - Method in class org.bson.BsonDocumentWriter
 
doWriteInt64(long) - Method in class org.bson.json.JsonWriter
 
doWriteJavaScript(String) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a JavaScript function
doWriteJavaScript(String) - Method in class org.bson.BsonBinaryWriter
 
doWriteJavaScript(String) - Method in class org.bson.BsonDocumentWriter
 
doWriteJavaScript(String) - Method in class org.bson.json.JsonWriter
 
doWriteJavaScriptWithScope(String) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a scoped JavaScript function
doWriteJavaScriptWithScope(String) - Method in class org.bson.BsonBinaryWriter
 
doWriteJavaScriptWithScope(String) - Method in class org.bson.BsonDocumentWriter
 
doWriteJavaScriptWithScope(String) - Method in class org.bson.json.JsonWriter
 
doWriteMaxKey() - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a Max key
doWriteMaxKey() - Method in class org.bson.BsonBinaryWriter
 
doWriteMaxKey() - Method in class org.bson.BsonDocumentWriter
 
doWriteMaxKey() - Method in class org.bson.json.JsonWriter
 
doWriteMinKey() - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a Min key
doWriteMinKey() - Method in class org.bson.BsonBinaryWriter
 
doWriteMinKey() - Method in class org.bson.BsonDocumentWriter
 
doWriteMinKey() - Method in class org.bson.json.JsonWriter
 
doWriteNull() - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a Null value
doWriteNull() - Method in class org.bson.BsonBinaryWriter
 
doWriteNull() - Method in class org.bson.BsonDocumentWriter
 
doWriteNull() - Method in class org.bson.json.JsonWriter
 
doWriteObjectId(ObjectId) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing an ObjectId
doWriteObjectId(ObjectId) - Method in class org.bson.BsonBinaryWriter
 
doWriteObjectId(ObjectId) - Method in class org.bson.BsonDocumentWriter
 
doWriteObjectId(ObjectId) - Method in class org.bson.json.JsonWriter
 
doWriteRegularExpression(BsonRegularExpression) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a regular expression
doWriteRegularExpression(BsonRegularExpression) - Method in class org.bson.BsonBinaryWriter
 
doWriteRegularExpression(BsonRegularExpression) - Method in class org.bson.BsonDocumentWriter
 
doWriteRegularExpression(BsonRegularExpression) - Method in class org.bson.json.JsonWriter
 
doWriteStartArray() - Method in class org.bson.AbstractBsonWriter
Handles the logic to start writing an array
doWriteStartArray() - Method in class org.bson.BsonBinaryWriter
 
doWriteStartArray() - Method in class org.bson.BsonDocumentWriter
 
doWriteStartArray() - Method in class org.bson.json.JsonWriter
 
doWriteStartDocument() - Method in class org.bson.AbstractBsonWriter
Handles the logic to start writing a document
doWriteStartDocument() - Method in class org.bson.BsonBinaryWriter
 
doWriteStartDocument() - Method in class org.bson.BsonDocumentWriter
 
doWriteStartDocument() - Method in class org.bson.json.JsonWriter
 
doWriteString(String) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a String
doWriteString(String) - Method in class org.bson.BsonBinaryWriter
 
doWriteString(String) - Method in class org.bson.BsonDocumentWriter
 
doWriteString(String) - Method in class org.bson.json.JsonWriter
 
doWriteSymbol(String) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a Symbol
doWriteSymbol(String) - Method in class org.bson.BsonBinaryWriter
 
doWriteSymbol(String) - Method in class org.bson.BsonDocumentWriter
 
doWriteSymbol(String) - Method in class org.bson.json.JsonWriter
 
doWriteTimestamp(BsonTimestamp) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing a timestamp
doWriteTimestamp(BsonTimestamp) - Method in class org.bson.BsonBinaryWriter
 
doWriteTimestamp(BsonTimestamp) - Method in class org.bson.BsonDocumentWriter
 
doWriteTimestamp(BsonTimestamp) - Method in class org.bson.json.JsonWriter
 
doWriteUndefined() - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing an Undefined value
doWriteUndefined() - Method in class org.bson.BsonBinaryWriter
 
doWriteUndefined() - Method in class org.bson.BsonDocumentWriter
 
doWriteUndefined() - Method in class org.bson.json.JsonWriter
 
driverName(String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
Sets the name
driverPlatform(String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
Sets the platform
driverVersion(String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
Sets the version
drop(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Drops the data associated with this bucket from the database.
drop(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops this collection from the Database.
drop(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Drops this database.
drop() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Drops the data associated with this bucket from the database.
drop() - Method in interface com.mongodb.client.MongoCollection
Drops this collection from the Database.
drop() - Method in interface com.mongodb.client.MongoDatabase
Drops this database.
drop() - Method in class com.mongodb.DBCollection
Drops (deletes) this collection from the database.
drop() - Method in class com.mongodb.MapReduceOutput
Drops the collection that holds the results.
DropCollectionOperation - Class in com.mongodb.operation
Operation to drop a Collection in MongoDB.
DropCollectionOperation(MongoNamespace) - Constructor for class com.mongodb.operation.DropCollectionOperation
DropCollectionOperation(MongoNamespace, WriteConcern) - Constructor for class com.mongodb.operation.DropCollectionOperation
Construct a new instance.
dropDatabase() - Method in class com.mongodb.DB
Drops this database.
dropDatabase(String) - Method in class com.mongodb.Mongo
Drops the database if it exists.
DropDatabaseOperation - Class in com.mongodb.operation
Operation to drop a database in MongoDB.
DropDatabaseOperation(String) - Constructor for class com.mongodb.operation.DropDatabaseOperation
Deprecated.
DropDatabaseOperation(String, WriteConcern) - Constructor for class com.mongodb.operation.DropDatabaseOperation
Construct a new instance.
dropDups(boolean) - Method in class com.mongodb.bulk.IndexRequest
Sets the legacy dropDups setting
dropIndex(String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given its name.
dropIndex(Bson, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(String) - Method in interface com.mongodb.client.MongoCollection
Drops the index given its name.
dropIndex(Bson) - Method in interface com.mongodb.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(DBObject) - Method in class com.mongodb.DBCollection
Drops an index from this collection.
dropIndex(String) - Method in class com.mongodb.DBCollection
Drops the index with the given name from this collection.
dropIndexes(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes() - Method in interface com.mongodb.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes() - Method in class com.mongodb.DBCollection
Drop all indexes on this collection.
dropIndexes(String) - Method in class com.mongodb.DBCollection
Drops the index with the given name from this collection.
DropIndexOperation - Class in com.mongodb.operation
An operation that drops an index.
DropIndexOperation(MongoNamespace, String) - Constructor for class com.mongodb.operation.DropIndexOperation
DropIndexOperation(MongoNamespace, BsonDocument) - Constructor for class com.mongodb.operation.DropIndexOperation
DropIndexOperation(MongoNamespace, String, WriteConcern) - Constructor for class com.mongodb.operation.DropIndexOperation
Construct a new instance.
DropIndexOperation(MongoNamespace, BsonDocument, WriteConcern) - Constructor for class com.mongodb.operation.DropIndexOperation
Construct a new instance.
dropTarget(boolean) - Method in class com.mongodb.client.model.RenameCollectionOptions
Sets if mongod should drop the target of renameCollection prior to renaming the collection.
dropTarget(boolean) - Method in class com.mongodb.operation.RenameCollectionOperation
Sets if mongod should drop the target of renameCollection prior to renaming the collection.
DropUserOperation - Class in com.mongodb.operation
An operation to remove a user.
DropUserOperation(String, String) - Constructor for class com.mongodb.operation.DropUserOperation
DropUserOperation(String, String, WriteConcern) - Constructor for class com.mongodb.operation.DropUserOperation
Construct a new instance.
duplicate() - Method in interface org.bson.ByteBuf
Creates a new byte buffer that shares this buffer's content.
duplicate() - Method in class org.bson.ByteBufNIO
 
DuplicateKeyException - Exception in com.mongodb
Subclass of WriteConcernException representing a duplicate key exception
DuplicateKeyException(BsonDocument, ServerAddress, WriteConcernResult) - Constructor for exception com.mongodb.DuplicateKeyException
Construct an instance.

E

electionId(ObjectId) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the electionId reported by this server.
ELEM_MATCH - Static variable in class com.mongodb.QueryOperators
 
elemMatch(String, Bson) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field that is an array where at least one member of the array matches the given filter.
elemMatch(String) - Static method in class com.mongodb.client.model.Projections
Creates a projection that includes for the given field only the first element of an array that matches the query filter.
elemMatch(String, Bson) - Static method in class com.mongodb.client.model.Projections
Creates a projection that includes for the given field only the first element of the array value of that field that matches the given query filter.
elemMatch(DBObject) - Method in class com.mongodb.QueryBuilder
Equivalent to the $elemMatch operand
EmptyBSONCallback - Class in org.bson
Convenience implementation of BSONCallback that throws UnsupportedOperationException for all methods.
EmptyBSONCallback() - Constructor for class org.bson.EmptyBSONCallback
 
enabled(boolean) - Method in class com.mongodb.connection.SslSettings.Builder
Define whether SSL should be enabled.
encode(BsonWriter, BSONTimestamp, EncoderContext) - Method in class com.mongodb.BSONTimestampCodec
 
encode(BsonWriter, GridFSFile, EncoderContext) - Method in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
encode(BsonWriter, GeometryCollection, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.GeometryCollectionCodec
 
encode(BsonWriter, LineString, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.LineStringCodec
 
encode(BsonWriter, MultiLineString, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.MultiLineStringCodec
 
encode(BsonWriter, MultiPoint, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.MultiPointCodec
 
encode(BsonWriter, MultiPolygon, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.MultiPolygonCodec
 
encode(BsonWriter, NamedCoordinateReferenceSystem, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
encode(BsonWriter, Point, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.PointCodec
 
encode(BsonWriter, Polygon, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.PolygonCodec
 
encode(BsonWriter, DBObject, EncoderContext) - Method in class com.mongodb.DBObjectCodec
 
encode(BsonWriter, DBRef, EncoderContext) - Method in class com.mongodb.DBRefCodec
 
encode(BSONObject) - Method in class org.bson.BasicBSONEncoder
 
encode(BSONObject) - Static method in class org.bson.BSON
Encodes a DBObject as a BSON byte array.
encode(BSONObject) - Method in interface org.bson.BSONEncoder
Encode a document into byte array.
encode(BsonWriter, AtomicBoolean, EncoderContext) - Method in class org.bson.codecs.AtomicBooleanCodec
 
encode(BsonWriter, AtomicInteger, EncoderContext) - Method in class org.bson.codecs.AtomicIntegerCodec
 
encode(BsonWriter, AtomicLong, EncoderContext) - Method in class org.bson.codecs.AtomicLongCodec
 
encode(BsonWriter, Binary, EncoderContext) - Method in class org.bson.codecs.BinaryCodec
 
encode(BsonWriter, Boolean, EncoderContext) - Method in class org.bson.codecs.BooleanCodec
 
encode(BsonWriter, BsonArray, EncoderContext) - Method in class org.bson.codecs.BsonArrayCodec
 
encode(BsonWriter, BsonBinary, EncoderContext) - Method in class org.bson.codecs.BsonBinaryCodec
 
encode(BsonWriter, BsonBoolean, EncoderContext) - Method in class org.bson.codecs.BsonBooleanCodec
 
encode(BsonWriter, BsonDateTime, EncoderContext) - Method in class org.bson.codecs.BsonDateTimeCodec
 
encode(BsonWriter, BsonDbPointer, EncoderContext) - Method in class org.bson.codecs.BsonDBPointerCodec
 
encode(BsonWriter, BsonDecimal128, EncoderContext) - Method in class org.bson.codecs.BsonDecimal128Codec
 
encode(BsonWriter, BsonDocument, EncoderContext) - Method in class org.bson.codecs.BsonDocumentCodec
 
encode(BsonWriter, BsonDocumentWrapper, EncoderContext) - Method in class org.bson.codecs.BsonDocumentWrapperCodec
 
encode(BsonWriter, BsonDouble, EncoderContext) - Method in class org.bson.codecs.BsonDoubleCodec
 
encode(BsonWriter, BsonInt32, EncoderContext) - Method in class org.bson.codecs.BsonInt32Codec
 
encode(BsonWriter, BsonInt64, EncoderContext) - Method in class org.bson.codecs.BsonInt64Codec
 
encode(BsonWriter, BsonJavaScript, EncoderContext) - Method in class org.bson.codecs.BsonJavaScriptCodec
 
encode(BsonWriter, BsonJavaScriptWithScope, EncoderContext) - Method in class org.bson.codecs.BsonJavaScriptWithScopeCodec
 
encode(BsonWriter, BsonMaxKey, EncoderContext) - Method in class org.bson.codecs.BsonMaxKeyCodec
 
encode(BsonWriter, BsonMinKey, EncoderContext) - Method in class org.bson.codecs.BsonMinKeyCodec
 
encode(BsonWriter, BsonNull, EncoderContext) - Method in class org.bson.codecs.BsonNullCodec
 
encode(BsonWriter, BsonObjectId, EncoderContext) - Method in class org.bson.codecs.BsonObjectIdCodec
 
encode(BsonWriter, BsonRegularExpression, EncoderContext) - Method in class org.bson.codecs.BsonRegularExpressionCodec
 
encode(BsonWriter, BsonString, EncoderContext) - Method in class org.bson.codecs.BsonStringCodec
 
encode(BsonWriter, BsonSymbol, EncoderContext) - Method in class org.bson.codecs.BsonSymbolCodec
 
encode(BsonWriter, BsonTimestamp, EncoderContext) - Method in class org.bson.codecs.BsonTimestampCodec
 
encode(BsonWriter, BsonUndefined, EncoderContext) - Method in class org.bson.codecs.BsonUndefinedCodec
 
encode(BsonWriter, BsonValue, EncoderContext) - Method in class org.bson.codecs.BsonValueCodec
 
encode(BsonWriter, byte[], EncoderContext) - Method in class org.bson.codecs.ByteArrayCodec
 
encode(BsonWriter, Byte, EncoderContext) - Method in class org.bson.codecs.ByteCodec
 
encode(BsonWriter, Character, EncoderContext) - Method in class org.bson.codecs.CharacterCodec
 
encode(BsonWriter, Code, EncoderContext) - Method in class org.bson.codecs.CodeCodec
 
encode(BsonWriter, CodeWithScope, EncoderContext) - Method in class org.bson.codecs.CodeWithScopeCodec
 
encode(BsonWriter, Date, EncoderContext) - Method in class org.bson.codecs.DateCodec
 
encode(BsonWriter, Decimal128, EncoderContext) - Method in class org.bson.codecs.Decimal128Codec
 
encode(BsonWriter, Document, EncoderContext) - Method in class org.bson.codecs.DocumentCodec
 
encode(BsonWriter, Double, EncoderContext) - Method in class org.bson.codecs.DoubleCodec
 
encode(BsonWriter, T, EncoderContext) - Method in interface org.bson.codecs.Encoder
Encode an instance of the type parameter T into a BSON value.
encode(BsonWriter, Float, EncoderContext) - Method in class org.bson.codecs.FloatCodec
 
encode(BsonWriter, Integer, EncoderContext) - Method in class org.bson.codecs.IntegerCodec
 
encode(BsonWriter, Iterable, EncoderContext) - Method in class org.bson.codecs.IterableCodec
 
encode(BsonWriter, Long, EncoderContext) - Method in class org.bson.codecs.LongCodec
 
encode(BsonWriter, MaxKey, EncoderContext) - Method in class org.bson.codecs.MaxKeyCodec
 
encode(BsonWriter, MinKey, EncoderContext) - Method in class org.bson.codecs.MinKeyCodec
 
encode(BsonWriter, ObjectId, EncoderContext) - Method in class org.bson.codecs.ObjectIdCodec
 
encode(BsonWriter, Pattern, EncoderContext) - Method in class org.bson.codecs.PatternCodec
 
encode(BsonWriter, RawBsonDocument, EncoderContext) - Method in class org.bson.codecs.RawBsonDocumentCodec
 
encode(BsonWriter, Short, EncoderContext) - Method in class org.bson.codecs.ShortCodec
 
encode(BsonWriter, String, EncoderContext) - Method in class org.bson.codecs.StringCodec
 
encode(BsonWriter, Symbol, EncoderContext) - Method in class org.bson.codecs.SymbolCodec
 
encode(BsonWriter, UUID, EncoderContext) - Method in class org.bson.codecs.UuidCodec
 
encoder(DBEncoder) - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Sets the encoder
encoder(DBEncoder) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the encoder
Encoder<T> - Interface in org.bson.codecs
Instances of this class are capable of encoding an instance of the type parameter T into a BSON value.
EncoderContext - Class in org.bson.codecs
The context for encoding values to BSON.
EncoderContext.Builder - Class in org.bson.codecs
A builder for EncoderContext instances.
encodeWithChildContext(Encoder<T>, BsonWriter, T) - Method in class org.bson.codecs.EncoderContext
Creates a child context based on this and serializes the value with it to the writer.
entrySet() - Method in class org.bson.BsonDocument
 
entrySet() - Method in class org.bson.BsonDocumentWrapper
 
entrySet() - Method in class org.bson.Document
 
entrySet() - Method in class org.bson.LazyBSONObject
Gets the entry set for all the key/value pairs in this BSONObject.
entrySet() - Method in class org.bson.RawBsonDocument
 
EOO - Static variable in class org.bson.BSON
 
EPSG_4326 - Static variable in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
The EPSG:4326 Coordinate Reference System.
EPSG_4326_STRICT_WINDING - Static variable in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
A custom MongoDB EPSG:4326 Coordinate Reference System that uses a strict counter-clockwise winding order.
eq(String, TItem) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the field name equals the specified value.
equals(Object) - Method in class com.mongodb.bulk.BulkWriteError
 
equals(Object) - Method in class com.mongodb.bulk.BulkWriteUpsert
 
equals(Object) - Method in class com.mongodb.bulk.WriteConcernError
 
equals(Object) - Method in class com.mongodb.BulkWriteError
 
equals(Object) - Method in exception com.mongodb.BulkWriteException
 
equals(Object) - Method in class com.mongodb.BulkWriteUpsert
 
equals(Object) - Method in class com.mongodb.client.gridfs.model.GridFSFile
 
equals(Object) - Method in class com.mongodb.client.model.Collation
 
equals(Object) - Method in class com.mongodb.client.model.Field
 
equals(Object) - Method in class com.mongodb.client.model.geojson.Geometry
 
equals(Object) - Method in class com.mongodb.client.model.geojson.GeometryCollection
 
equals(Object) - Method in class com.mongodb.client.model.geojson.LineString
 
equals(Object) - Method in class com.mongodb.client.model.geojson.MultiLineString
 
equals(Object) - Method in class com.mongodb.client.model.geojson.MultiPoint
 
equals(Object) - Method in class com.mongodb.client.model.geojson.MultiPolygon
 
equals(Object) - Method in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
 
equals(Object) - Method in class com.mongodb.client.model.geojson.Point
 
equals(Object) - Method in class com.mongodb.client.model.geojson.Polygon
 
equals(Object) - Method in class com.mongodb.client.model.geojson.PolygonCoordinates
 
equals(Object) - Method in class com.mongodb.client.model.geojson.Position
 
equals(Object) - Method in class com.mongodb.connection.ClusterDescription
 
equals(Object) - Method in class com.mongodb.connection.ClusterId
 
equals(Object) - Method in class com.mongodb.connection.ClusterSettings
 
equals(Object) - Method in class com.mongodb.connection.ConnectionDescription
 
equals(Object) - Method in class com.mongodb.connection.ConnectionId
 
equals(Object) - Method in class com.mongodb.connection.ConnectionPoolSettings
 
equals(Object) - Method in class com.mongodb.connection.ServerDescription
Returns true if this instance is equals to @code{o}.
equals(Object) - Method in class com.mongodb.connection.ServerId
 
equals(Object) - Method in class com.mongodb.connection.ServerSettings
 
equals(Object) - Method in class com.mongodb.connection.ServerVersion
 
equals(Object) - Method in class com.mongodb.connection.SocketSettings
 
equals(Object) - Method in class com.mongodb.connection.SslSettings
 
equals(Object) - Method in class com.mongodb.ConnectionString
 
equals(Object) - Method in class com.mongodb.DBAddress
Deprecated.
 
equals(Object) - Method in class com.mongodb.DBObjectCodecProvider
 
equals(Object) - Method in class com.mongodb.DBRef
 
equals(Object) - Method in class com.mongodb.DBRefCodecProvider
 
equals(Object) - Method in exception com.mongodb.MongoBulkWriteException
 
equals(Object) - Method in class com.mongodb.MongoClientOptions
 
equals(Object) - Method in class com.mongodb.MongoClientURI
 
equals(Object) - Method in class com.mongodb.MongoCredential
 
equals(Object) - Method in class com.mongodb.MongoNamespace
 
equals(Object) - Method in class com.mongodb.MongoOptions
Deprecated.
 
equals(Object) - Method in class com.mongodb.ReadConcern
 
equals(Object) - Method in class com.mongodb.ServerAddress
 
equals(Object) - Method in class com.mongodb.ServerCursor
 
equals(Object) - Method in class com.mongodb.Tag
 
equals(Object) - Method in class com.mongodb.TaggableReadPreference
 
equals(Object) - Method in class com.mongodb.TagSet
 
equals(Object) - Method in class com.mongodb.WriteConcern
 
equals(Object) - Method in class com.mongodb.WriteConcernError
 
equals(Object) - Method in class com.mongodb.WriteError
 
equals(Object) - Method in class org.bson.BasicBSONObject
Compares two documents according to their serialized form, ignoring the order of keys.
equals(Object) - Method in class org.bson.BsonArray
 
equals(Object) - Method in class org.bson.BsonBinary
 
equals(Object) - Method in class org.bson.BsonBoolean
 
equals(Object) - Method in class org.bson.BsonDateTime
 
equals(Object) - Method in class org.bson.BsonDbPointer
 
equals(Object) - Method in class org.bson.BsonDecimal128
 
equals(Object) - Method in class org.bson.BsonDocument
 
equals(Object) - Method in class org.bson.BsonDocumentWrapper
 
equals(Object) - Method in class org.bson.BsonDouble
 
equals(Object) - Method in class org.bson.BsonInt32
 
equals(Object) - Method in class org.bson.BsonInt64
 
equals(Object) - Method in class org.bson.BsonJavaScript
 
equals(Object) - Method in class org.bson.BsonJavaScriptWithScope
 
equals(Object) - Method in class org.bson.BsonMaxKey
 
equals(Object) - Method in class org.bson.BsonMinKey
 
equals(Object) - Method in class org.bson.BsonNull
 
equals(Object) - Method in class org.bson.BsonObjectId
 
equals(Object) - Method in class org.bson.BsonRegularExpression
 
equals(Object) - Method in class org.bson.BsonString
 
equals(Object) - Method in class org.bson.BsonSymbol
Will compare equal to a String that is equal to the String that this holds
equals(Object) - Method in class org.bson.BsonTimestamp
 
equals(Object) - Method in class org.bson.BsonUndefined
 
equals(Object) - Method in class org.bson.codecs.BsonTypeClassMap
 
equals(Object) - Method in class org.bson.codecs.DocumentCodecProvider
 
equals(Object) - Method in class org.bson.codecs.IterableCodecProvider
 
equals(Object) - Method in class org.bson.codecs.ValueCodecProvider
 
equals(Object) - Method in class org.bson.Document
 
equals(Object) - Method in class org.bson.LazyBSONObject
 
equals(Object) - Method in class org.bson.RawBsonDocument
 
equals(Object) - Method in class org.bson.types.Binary
 
equals(Object) - Method in class org.bson.types.BSONTimestamp
 
equals(Object) - Method in class org.bson.types.Code
 
equals(Object) - Method in class org.bson.types.CodeWithScope
 
equals(Object) - Method in class org.bson.types.CodeWScope
 
equals(Object) - Method in class org.bson.types.Decimal128
Returns true if the encoded representation of this instance is the same as the encoded representation of o.
equals(Object) - Method in class org.bson.types.MaxKey
 
equals(Object) - Method in class org.bson.types.MinKey
 
equals(Object) - Method in class org.bson.types.ObjectId
 
equals(Object) - Method in class org.bson.types.Symbol
Will compare equal to a String that is equal to the String that this holds
error(String) - Method in interface com.mongodb.diagnostics.logging.Logger
Log a message at the ERROR level.
error(String, Throwable) - Method in interface com.mongodb.diagnostics.logging.Logger
Log an exception (throwable) at the ERROR level with an accompanying message.
ErrorCategory - Enum in com.mongodb
A categorization of errors returned by a MongoDB server command.
eval(String, Object...) - Method in class com.mongodb.DB
eventLoopGroup(EventLoopGroup) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
Sets the event loop group.
exception(Throwable) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the exception thrown while attempting to determine the server description.
exclude(String...) - Static method in class com.mongodb.client.model.Projections
Creates a projection that excludes all of the given fields.
exclude(List<String>) - Static method in class com.mongodb.client.model.Projections
Creates a projection that excludes all of the given fields.
excludeId() - Static method in class com.mongodb.client.model.Projections
Creates a projection that excludes the _id field.
execute() - Method in class com.mongodb.BulkWriteOperation
Execute the bulk write operation with the default write concern of the collection from which this came.
execute(WriteConcern) - Method in class com.mongodb.BulkWriteOperation
Execute the bulk write operation with the given write concern.
execute(ReadBinding) - Method in class com.mongodb.operation.AggregateOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.AggregateToCollectionOperation
 
execute(AsyncReadOperation<T>, ReadPreference, SingleResultCallback<T>) - Method in interface com.mongodb.operation.AsyncOperationExecutor
Execute the read operation with the given read preference.
execute(AsyncWriteOperation<T>, SingleResultCallback<T>) - Method in interface com.mongodb.operation.AsyncOperationExecutor
Execute the write operation.
execute(WriteBinding) - Method in class com.mongodb.operation.BaseWriteOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.CommandReadOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.CommandWriteOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.CountOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.CreateCollectionOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.CreateIndexesOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.CreateUserOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.CreateViewOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.CurrentOpOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.DistinctOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.DropCollectionOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.DropDatabaseOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.DropIndexOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.DropUserOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.FindAndDeleteOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.FindAndReplaceOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.FindAndUpdateOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.FindOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.FsyncUnlockOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.GroupOperation
Will return a cursor of Documents containing the results of the group operation.
execute(ReadBinding) - Method in class com.mongodb.operation.ListCollectionsOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.ListDatabasesOperation
Executing this will return a list of all the databases names in the MongoDB instance.
execute(ReadBinding) - Method in class com.mongodb.operation.ListIndexesOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Executing this will return a cursor with your results in.
execute(ReadBinding) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Executing this will return a cursor with your results and the statistics in.
execute(WriteBinding) - Method in class com.mongodb.operation.MixedBulkWriteOperation
Executes a bulk write operation.
execute(ReadOperation<T>, ReadPreference) - Method in interface com.mongodb.operation.OperationExecutor
Execute the read operation with the given read preference.
execute(WriteOperation<T>) - Method in interface com.mongodb.operation.OperationExecutor
Execute the write operation.
execute(ReadBinding) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
execute(ReadBinding) - Method in interface com.mongodb.operation.ReadOperation
General execute which can return anything of type T
execute(WriteBinding) - Method in class com.mongodb.operation.RenameCollectionOperation
Rename the collection with oldCollectionName in database databaseName to the newCollectionName.
execute(WriteBinding) - Method in class com.mongodb.operation.UpdateUserOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.UserExistsOperation
 
execute(WriteBinding) - Method in interface com.mongodb.operation.WriteOperation
General execute which can return anything of type T
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.AggregateOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.AggregateToCollectionOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<T>) - Method in interface com.mongodb.operation.AsyncReadOperation
General execute which can return anything of type T
executeAsync(AsyncWriteBinding, SingleResultCallback<T>) - Method in interface com.mongodb.operation.AsyncWriteOperation
General execute which can return anything of type T
executeAsync(AsyncWriteBinding, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.operation.BaseWriteOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<T>) - Method in class com.mongodb.operation.CommandReadOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<T>) - Method in class com.mongodb.operation.CommandWriteOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<Long>) - Method in class com.mongodb.operation.CountOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.CreateCollectionOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.CreateIndexesOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.CreateUserOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.CreateViewOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.DistinctOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.DropCollectionOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.DropDatabaseOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.DropIndexOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.DropUserOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<T>) - Method in class com.mongodb.operation.FindAndDeleteOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<T>) - Method in class com.mongodb.operation.FindAndReplaceOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<T>) - Method in class com.mongodb.operation.FindAndUpdateOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.FindOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.GroupOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.ListCollectionsOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.ListDatabasesOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.ListIndexesOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<MapReduceStatistics>) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<MapReduceAsyncBatchCursor<T>>) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<List<AsyncBatchCursor<T>>>) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.RenameCollectionOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.operation.UpdateUserOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<Boolean>) - Method in class com.mongodb.operation.UserExistsOperation
 
executeCommandProtocol(Connection) - Method in class com.mongodb.operation.BaseWriteOperation
Executes the write command protocol.
executeCommandProtocol(Connection) - Method in class com.mongodb.operation.DeleteOperation
 
executeCommandProtocol(Connection) - Method in class com.mongodb.operation.InsertOperation
 
executeCommandProtocol(Connection) - Method in class com.mongodb.operation.UpdateOperation
 
executeCommandProtocolAsync(AsyncConnection, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.BaseWriteOperation
Asynchronously executes the write command protocol.
executeCommandProtocolAsync(AsyncConnection, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.DeleteOperation
 
executeCommandProtocolAsync(AsyncConnection, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.InsertOperation
 
executeCommandProtocolAsync(AsyncConnection, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.UpdateOperation
 
executeProtocol(Connection) - Method in class com.mongodb.operation.BaseWriteOperation
Executes the write protocol
executeProtocol(Connection) - Method in class com.mongodb.operation.DeleteOperation
 
executeProtocol(Connection) - Method in class com.mongodb.operation.InsertOperation
 
executeProtocol(Connection) - Method in class com.mongodb.operation.UpdateOperation
 
executeProtocolAsync(AsyncConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.operation.BaseWriteOperation
Asynchronously executes the write protocol
executeProtocolAsync(AsyncConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.operation.DeleteOperation
 
executeProtocolAsync(AsyncConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.operation.InsertOperation
 
executeProtocolAsync(AsyncConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.operation.UpdateOperation
 
exists(String) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents that contain the given field.
exists(String, boolean) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents that either contain or do not contain the given field, depending on the value of the exists parameter.
exists(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $exists operand
EXISTS - Static variable in class com.mongodb.QueryOperators
 
expireAfter(Long, TimeUnit) - Method in class com.mongodb.bulk.IndexRequest
Sets the time to live for documents in the collection
expireAfter(Long, TimeUnit) - Method in class com.mongodb.client.model.IndexOptions
Sets the time to live for documents in the collection
explain() - Method in class com.mongodb.DBCursor
Returns an object containing basic information about the execution of the query that created this cursor.
EXPLAIN - Static variable in class com.mongodb.QueryOperators
 
explainAggregate(List<? extends DBObject>, AggregationOptions) - Method in class com.mongodb.DBCollection
Return the explain plan for the aggregation pipeline.
ExplainVerbosity - Enum in com.mongodb
An enumeration of the verbosity levels available for explaining query execution.
extractErrorCode(BsonDocument) - Static method in exception com.mongodb.WriteConcernException
For internal use only: extract the error code from the response to a getlasterror command.
extractErrorMessage(BsonDocument) - Static method in exception com.mongodb.WriteConcernException
For internal use only: extract the error message from the response to a getlasterror command.

F

facet(List<Facet>) - Static method in class com.mongodb.client.model.Aggregates
Creates a facet pipeline stage
facet(Facet...) - Static method in class com.mongodb.client.model.Aggregates
Creates a facet pipeline stage
Facet - Class in com.mongodb.client.model
Defines a Facet for use in $facet pipeline stages.
Facet(String, List<? extends Bson>) - Constructor for class com.mongodb.client.model.Facet
 
Facet(String, Bson...) - Constructor for class com.mongodb.client.model.Facet
 
FACTORY - Static variable in class com.mongodb.DefaultDBCallback
 
FACTORY - Static variable in class com.mongodb.DefaultDBDecoder
 
FACTORY - Static variable in class com.mongodb.DefaultDBEncoder
 
FACTORY - Static variable in class com.mongodb.LazyDBDecoder
 
failed(Throwable) - Method in interface com.mongodb.connection.AsyncCompletionHandler
Invoked when an operation fails.
FALSE - Static variable in class org.bson.BsonBoolean
 
Field<TExpression> - Class in com.mongodb.client.model
Helps define new fields for the $addFields pipeline stage
Field(String, TExpression) - Constructor for class com.mongodb.client.model.Field
Creates a new field definition for use in $addFields pipeline stages
FieldNameValidator - Interface in org.bson
A field name validator, for use by BSON writers to validate field names as documents are encoded.
fields(Bson...) - Static method in class com.mongodb.client.model.Projections
Creates a projection that combines the list of projections into a single one.
fields(List<Bson>) - Static method in class com.mongodb.client.model.Projections
Creates a projection that combines the list of projections into a single one.
filter(Bson) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.async.client.ListCollectionsIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.client.DistinctIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.client.FindIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.client.ListCollectionsIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in interface com.mongodb.client.MapReduceIterable
Sets the query filter to apply to the query.
filter(DBObject) - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Sets the selection query to determine the subset of documents from which to retrieve the distinct values.
filter(BsonDocument) - Method in class com.mongodb.operation.CountOperation
Sets the filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.DistinctOperation
Sets the query filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets the filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the query filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets the query filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.GroupOperation
Sets the optional query filter to determine which documents in the collection to process.
filter(BsonDocument) - Method in class com.mongodb.operation.ListCollectionsOperation
Sets the query filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the filter to apply to the query.
filter(BsonDocument) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the filter to apply to the query.
Filters - Class in com.mongodb.client.model
A factory for query filters.
finalizeFunction(String) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the JavaScript function that follows the reduce method and modifies the output.
finalizeFunction(String) - Method in interface com.mongodb.client.MapReduceIterable
Sets the JavaScript function that follows the reduce method and modifies the output.
finalizeFunction(BsonJavaScript) - Method in class com.mongodb.operation.GroupOperation
Sets the function that runs each item in the result set before returning the final value.
finalizeFunction(BsonJavaScript) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the JavaScript function that follows the reduce method and modifies the output.
finalizeFunction(BsonJavaScript) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the JavaScript function that follows the reduce method and modifies the output.
find() - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Finds all documents in the files collection.
find(Bson) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Finds all documents in the collection that match the filter.
find() - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(Bson) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(Bson, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(DBObject) - Method in class com.mongodb.BulkWriteOperation
Start building a write request to add to the bulk write operation.
find() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Finds all documents in the files collection.
find(Bson) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Finds all documents in the collection that match the filter.
find() - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(Bson) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(Bson, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(DBObject, DBObject, int, int, int) - Method in class com.mongodb.DBCollection
find(DBObject, DBObject, int, int) - Method in class com.mongodb.DBCollection
Deprecated.
find(DBObject) - Method in class com.mongodb.DBCollection
Select documents in collection and get a cursor to the selected documents.
find(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Select documents in collection and get a cursor to the selected documents.
find() - Method in class com.mongodb.DBCollection
Select all documents in collection and get a cursor to the selected documents.
find(DBObject, DBCollectionFindOptions) - Method in class com.mongodb.DBCollection
Select documents in collection and get a cursor to the selected documents.
find(ObjectId) - Method in class com.mongodb.gridfs.GridFS
Finds one file matching the given objectId.
find(String) - Method in class com.mongodb.gridfs.GridFS
Finds a list of files matching the given filename.
find(String, DBObject) - Method in class com.mongodb.gridfs.GridFS
Finds a list of files matching the given filename.
find(DBObject) - Method in class com.mongodb.gridfs.GridFS
Finds a list of files matching the given query.
find(DBObject, DBObject) - Method in class com.mongodb.gridfs.GridFS
Finds a list of files matching the given query.
FindAndDeleteOperation<T> - Class in com.mongodb.operation
An operation that atomically finds and deletes a single document.
FindAndDeleteOperation(MongoNamespace, Decoder<T>) - Constructor for class com.mongodb.operation.FindAndDeleteOperation
FindAndDeleteOperation(MongoNamespace, WriteConcern, Decoder<T>) - Constructor for class com.mongodb.operation.FindAndDeleteOperation
Construct a new instance.
findAndModify(DBObject, DBObject, DBObject) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject, DBObject, boolean, DBObject, boolean, boolean) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject, DBObject, boolean, DBObject, boolean, boolean, WriteConcern) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject, DBObject, boolean, DBObject, boolean, boolean, long, TimeUnit) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject, DBObject, boolean, DBObject, boolean, boolean, long, TimeUnit, WriteConcern) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject, DBObject, boolean, DBObject, boolean, boolean, boolean, long, TimeUnit) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBObject, DBObject, boolean, DBObject, boolean, boolean, boolean, long, TimeUnit, WriteConcern) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndModify(DBObject, DBCollectionFindAndModifyOptions) - Method in class com.mongodb.DBCollection
Atomically modify and return a single document.
findAndRemove(DBObject) - Method in class com.mongodb.DBCollection
Atomically remove and return a single document.
FindAndReplaceOperation<T> - Class in com.mongodb.operation
An operation that atomically finds and replaces a single document.
FindAndReplaceOperation(MongoNamespace, Decoder<T>, BsonDocument) - Constructor for class com.mongodb.operation.FindAndReplaceOperation
FindAndReplaceOperation(MongoNamespace, WriteConcern, Decoder<T>, BsonDocument) - Constructor for class com.mongodb.operation.FindAndReplaceOperation
Construct a new instance.
FindAndUpdateOperation<T> - Class in com.mongodb.operation
An operation that atomically finds and updates a single document.
FindAndUpdateOperation(MongoNamespace, Decoder<T>, BsonDocument) - Constructor for class com.mongodb.operation.FindAndUpdateOperation
FindAndUpdateOperation(MongoNamespace, WriteConcern, Decoder<T>, BsonDocument) - Constructor for class com.mongodb.operation.FindAndUpdateOperation
Construct a new instance.
findByValue(int) - Static method in enum org.bson.BsonType
Gets the BsonType that corresponds to the given int value.
FindIterable<T> - Interface in com.mongodb.async.client
Iterable for find.
FindIterable<TResult> - Interface in com.mongodb.client
Iterable for find.
findOne() - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(DBObject) - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(DBObject, DBObject, DBObject) - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(DBObject, DBObject, ReadPreference) - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(DBObject, DBObject, DBObject, ReadPreference) - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(Object) - Method in class com.mongodb.DBCollection
Get a single document from collection by '_id'.
findOne(Object, DBObject) - Method in class com.mongodb.DBCollection
Get a single document from collection by '_id'.
findOne(DBObject, DBCollectionFindOptions) - Method in class com.mongodb.DBCollection
Get a single document from collection.
findOne(ObjectId) - Method in class com.mongodb.gridfs.GridFS
Finds one file matching the given objectId.
findOne(String) - Method in class com.mongodb.gridfs.GridFS
Finds one file matching the given filename.
findOne(DBObject) - Method in class com.mongodb.gridfs.GridFS
Finds one file matching the given query.
findOneAndDelete(Bson, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(Bson, FindOneAndDeleteOptions, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(Bson) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(Bson, FindOneAndDeleteOptions) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and remove it.
FindOneAndDeleteOptions - Class in com.mongodb.client.model
The options to apply to an operation that atomically finds a document and deletes it.
FindOneAndDeleteOptions() - Constructor for class com.mongodb.client.model.FindOneAndDeleteOptions
 
findOneAndReplace(Bson, TDocument, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(Bson, TDocument, FindOneAndReplaceOptions, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(Bson, TDocument) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(Bson, TDocument, FindOneAndReplaceOptions) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and replace it.
FindOneAndReplaceOptions - Class in com.mongodb.client.model
The options to apply to an operation that atomically finds a document and replaces it.
FindOneAndReplaceOptions() - Constructor for class com.mongodb.client.model.FindOneAndReplaceOptions
 
findOneAndUpdate(Bson, Bson, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(Bson, Bson, FindOneAndUpdateOptions, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(Bson, Bson) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(Bson, Bson, FindOneAndUpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and update it.
FindOneAndUpdateOptions - Class in com.mongodb.client.model
The options to apply to an operation that atomically finds a document and updates it.
FindOneAndUpdateOptions() - Constructor for class com.mongodb.client.model.FindOneAndUpdateOptions
 
FindOperation<T> - Class in com.mongodb.operation
An operation that queries a collection using the provided criteria.
FindOperation(MongoNamespace, Decoder<T>) - Constructor for class com.mongodb.operation.FindOperation
Construct a new instance.
FindOptions - Class in com.mongodb.client.model
The options to apply to a find operation (also commonly referred to as a query).
FindOptions() - Constructor for class com.mongodb.client.model.FindOptions
Construct a new instance.
FindOptions(FindOptions) - Constructor for class com.mongodb.client.model.FindOptions
Construct a new instance by making a shallow copy of the given model.
first(SingleResultCallback<TResult>) - Method in interface com.mongodb.async.client.MongoIterable
Helper to return the first item in the iterator or null.
first(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the value of the given expression when applied to the first member of the group.
first() - Method in interface com.mongodb.client.MongoIterable
Helper to return the first item in the iterator or null.
flip() - Method in interface org.bson.ByteBuf
Flips this buffer.
flip() - Method in class org.bson.ByteBufNIO
 
FloatCodec - Class in org.bson.codecs
Encodes and decodes Float objects.
FloatCodec() - Constructor for class org.bson.codecs.FloatCodec
 
flush() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
 
flush() - Method in class org.bson.BsonBinaryWriter
 
flush() - Method in class org.bson.BsonDocumentWriter
 
flush() - Method in interface org.bson.BsonWriter
Flushes any pending data to the output destination.
flush() - Method in class org.bson.json.JsonWriter
 
forEach(Block<? super TResult>, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoIterable
Iterates over all documents in the view, applying the given block to each, and completing the returned future after all documents have been iterated, or an exception has occurred.
forEach(Block<? super TResult>) - Method in interface com.mongodb.client.MongoIterable
Iterates over all documents in the view, applying the given block to each.
fromCodecs(Codec<?>...) - Static method in class org.bson.codecs.configuration.CodecRegistries
Creates a CodecRegistry from the provided list of Codec instances.
fromCodecs(List<? extends Codec<?>>) - Static method in class org.bson.codecs.configuration.CodecRegistries
Creates a CodecRegistry from the provided list of Codec instances.
fromErrorCode(int) - Static method in enum com.mongodb.ErrorCategory
Translate an error code into an error category
fromIEEE754BIDEncoding(long, long) - Static method in class org.bson.types.Decimal128
Create an instance with the given high and low order bits representing this Decimal128 as an IEEE 754-2008 128-bit decimal floating point using the BID encoding scheme.
fromInt(int) - Static method in enum com.mongodb.client.model.CollationStrength
Gets the order from the given integer representation.
fromInt(int) - Static method in enum com.mongodb.operation.OrderBy
Gets the order from the given integer representation.
fromMechanismName(String) - Static method in enum com.mongodb.AuthenticationMechanism
Gets the mechanism by its name.
fromProviders(CodecProvider...) - Static method in class org.bson.codecs.configuration.CodecRegistries
Creates a CodecRegistry from the provided list of CodecProvider instances.
fromProviders(List<? extends CodecProvider>) - Static method in class org.bson.codecs.configuration.CodecRegistries
Creates a CodecRegistry from the provided list of CodecProvider instances.
fromRegistries(CodecRegistry...) - Static method in class org.bson.codecs.configuration.CodecRegistries
A CodecRegistry that combines the given CodecRegistry instances into a single registry.
fromRegistries(List<? extends CodecRegistry>) - Static method in class org.bson.codecs.configuration.CodecRegistries
A CodecRegistry that combines the given CodecRegistry instances into a single registry.
fromString(String) - Static method in enum com.mongodb.client.model.BucketGranularity
Tries find the enum instance for the given value
fromString(String) - Static method in enum com.mongodb.client.model.CollationAlternate
Returns the CollationAlternate from the string value.
fromString(String) - Static method in enum com.mongodb.client.model.CollationCaseFirst
Returns the CollationCaseFirst from the string value.
fromString(String) - Static method in enum com.mongodb.client.model.CollationMaxVariable
Returns the CollationMaxVariable from the string value.
fromString(String) - Static method in enum com.mongodb.client.model.ValidationAction
Returns the validationAction from the string representation of a validation action.
fromString(String) - Static method in enum com.mongodb.client.model.ValidationLevel
Returns the ValidationLevel from the string representation of the validation level.
fromString(String) - Static method in enum com.mongodb.ReadConcernLevel
Returns the ReadConcern from the string read concern level.
fromThrowable(Throwable) - Static method in exception com.mongodb.MongoException
Static helper to create or cast a MongoException from a throwable
fsync(boolean) - Method in class com.mongodb.Mongo
Forces the master server to fsync the RAM data to disk This is done automatically by the server at intervals, but can be forced for better reliability.
fsync - Variable in class com.mongodb.MongoOptions
Deprecated.
The "fsync" value of the global WriteConcern.
fsync() - Method in class com.mongodb.WriteConcern
Deprecated.
FSYNC_SAFE - Static variable in class com.mongodb.WriteConcern
Deprecated.
fsyncAndLock() - Method in class com.mongodb.Mongo
Forces the master server to fsync the RAM data to disk, then lock all writes.
FSYNCED - Static variable in class com.mongodb.WriteConcern
Deprecated.
FsyncUnlockOperation - Class in com.mongodb.operation
Unlocks the MongoDB server, allowing write operations to go through.
FsyncUnlockOperation() - Constructor for class com.mongodb.operation.FsyncUnlockOperation
 
Function<T,R> - Interface in com.mongodb
Apply a function to the input object yielding an appropriate result object.

G

generate() - Method in interface org.bson.codecs.IdGenerator
Generates an ID for a MongoDB Document.
generate() - Method in class org.bson.codecs.ObjectIdGenerator
 
generateIdIfAbsentFromDocument(DBObject) - Method in class com.mongodb.DBObjectCodec
 
generateIdIfAbsentFromDocument(BsonDocument) - Method in class org.bson.codecs.BsonDocumentCodec
 
generateIdIfAbsentFromDocument(T) - Method in interface org.bson.codecs.CollectibleCodec
Generates a value for the _id field on the given document, if the document does not have one.
generateIdIfAbsentFromDocument(Document) - Method in class org.bson.codecs.DocumentCodec
 
geo2d(String) - Static method in class com.mongodb.client.model.Indexes
Create an index key for a 2d index on the given field.
geo2dsphere(String...) - Static method in class com.mongodb.client.model.Indexes
Create an index key for an 2dsphere index on the given fields.
geo2dsphere(List<String>) - Static method in class com.mongodb.client.model.Indexes
Create an index key for an ascending index on the given fields.
geoHaystack(String, Bson) - Static method in class com.mongodb.client.model.Indexes
Create an index key for a geohaystack index on the given field.
geoIntersects(String, Bson) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that intersects with the specified shape.
geoIntersects(String, Geometry) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that intersects with the specified shape.
GeoJsonCodecProvider - Class in com.mongodb.client.model.geojson.codecs
A provider of codecs for GeoJSON objects.
GeoJsonCodecProvider() - Constructor for class com.mongodb.client.model.geojson.codecs.GeoJsonCodecProvider
 
GeoJsonObjectType - Enum in com.mongodb.client.model.geojson
An enumeration of GeoJSON object types.
Geometry - Class in com.mongodb.client.model.geojson
An abstract class for representations of GeoJSON geometry objects.
Geometry() - Constructor for class com.mongodb.client.model.geojson.Geometry
Construct an instance with no specified coordinate reference system.
Geometry(CoordinateReferenceSystem) - Constructor for class com.mongodb.client.model.geojson.Geometry
Construct an instance with the specified coordinate reference system.
GeometryCollection - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON GeometryCollection.
GeometryCollection(List<? extends Geometry>) - Constructor for class com.mongodb.client.model.geojson.GeometryCollection
Construct an instance with the given list of Geometry objects
GeometryCollection(CoordinateReferenceSystem, List<? extends Geometry>) - Constructor for class com.mongodb.client.model.geojson.GeometryCollection
Construct an instance with the given list of Geometry objects
GeometryCollectionCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON GeometryCollection.
GeometryCollectionCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.GeometryCollectionCodec
Constructs an instance.
geoWithin(String, Geometry) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that exists entirely within the specified shape.
geoWithin(String, Bson) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that exists entirely within the specified shape.
geoWithinBox(String, double, double, double, double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with grid coordinates data that exist entirely within the specified box.
geoWithinCenter(String, double, double, double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with grid coordinates data that exist entirely within the specified circle.
geoWithinCenterSphere(String, double, double, double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data (GeoJSON or legacy coordinate pairs) that exist entirely within the specified circle, using spherical geometry.
geoWithinPolygon(String, List<List<Double>>) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with grid coordinates data that exist entirely within the specified polygon.
get() - Method in class com.mongodb.BasicDBObjectBuilder
Gets the top level document.
get(Class<T>, CodecRegistry) - Method in class com.mongodb.client.gridfs.codecs.GridFSFileCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class com.mongodb.client.model.geojson.codecs.GeoJsonCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class com.mongodb.DBObjectCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class com.mongodb.DBRefCodecProvider
 
get(String) - Method in class com.mongodb.gridfs.GridFSFile
 
get() - Method in class com.mongodb.QueryBuilder
Creates a DBObject query to be used for the driver's find operations
get(String) - Method in class com.mongodb.ReflectionDBObject
 
get(ReflectionDBObject, String) - Method in class com.mongodb.ReflectionDBObject.JavaWrapper
Gets the value for the given field from the given document.
get() - Method in class org.bson.BasicBSONCallback
 
get(String) - Method in class org.bson.BasicBSONObject
Gets a value from this object
get(int) - Method in class org.bson.BsonArray
 
get() - Method in interface org.bson.BSONCallback
Returns the finished top-level Document.
get(Object) - Method in class org.bson.BsonDocument
 
get(Object, BsonValue) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
get(Object) - Method in class org.bson.BsonDocumentWrapper
 
get(String) - Method in interface org.bson.BSONObject
Gets a field from this object by a given name.
get() - Method in interface org.bson.ByteBuf
Relative get method.
get(int) - Method in interface org.bson.ByteBuf
Absolute get method.
get(byte[]) - Method in interface org.bson.ByteBuf
Relative bulk get method.
get(int, byte[]) - Method in interface org.bson.ByteBuf
Absolute bulk get method.
get(byte[], int, int) - Method in interface org.bson.ByteBuf
Relative bulk get method.
get(int, byte[], int, int) - Method in interface org.bson.ByteBuf
Absolute bulk get method.
get() - Method in class org.bson.ByteBufNIO
 
get(int) - Method in class org.bson.ByteBufNIO
 
get(byte[]) - Method in class org.bson.ByteBufNIO
 
get(int, byte[]) - Method in class org.bson.ByteBufNIO
 
get(byte[], int, int) - Method in class org.bson.ByteBufNIO
 
get(int, byte[], int, int) - Method in class org.bson.ByteBufNIO
 
get(BsonType) - Method in class org.bson.codecs.BsonTypeClassMap
Gets the Class that is mapped to the given BSON type.
get(BsonType) - Method in class org.bson.codecs.BsonTypeCodecMap
Gets the Codec mapped to the given bson type.
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.BsonValueCodecProvider
 
get(Class<T>, CodecRegistry) - Method in interface org.bson.codecs.configuration.CodecProvider
Get a Codec using the given context, which includes, most importantly, the Class for which a Codec is required.
get(Class<T>) - Method in interface org.bson.codecs.configuration.CodecRegistry
Gets a Codec for the given Class.
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.DocumentCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.IterableCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.UuidCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.ValueCodecProvider
 
get(Object, Class<T>) - Method in class org.bson.Document
Gets the value of the given key, casting it to the given Class<T>.
get(Object) - Method in class org.bson.Document
 
get() - Method in class org.bson.EmptyBSONCallback
 
get() - Method in class org.bson.LazyBSONCallback
 
get(int) - Method in class org.bson.LazyBSONList
 
get(String) - Method in class org.bson.LazyBSONObject
 
get(Object) - Method in class org.bson.RawBsonDocument
 
get(String) - Method in class org.bson.types.BasicBSONList
Gets a value at an index.
get() - Static method in class org.bson.types.ObjectId
Gets a new object id.
get(Object) - Method in class org.bson.util.ClassMap
Gets the value associated with either this Class or a superclass of this class.
get_id() - Method in class com.mongodb.ReflectionDBObject
Gets the _id
getAcceptableLatencyDifference(TimeUnit) - Method in class com.mongodb.selector.LatencyMinimizingServerSelector
Gets the acceptable latency difference.
getAction() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the output action, one of: "replace", "merge", "reduce".
getAddress() - Method in class com.mongodb.connection.QueryResult
Gets the server address.
getAddress() - Method in class com.mongodb.connection.ServerDescription
Gets the address of this server
getAddress() - Method in class com.mongodb.connection.ServerId
Gets the server address.
getAddress() - Method in interface com.mongodb.connection.Stream
The address that this stream is connected to.
getAddress() - Method in class com.mongodb.Mongo
Gets the address of the current master
getAddress() - Method in class com.mongodb.ServerCursor
Gets the server address.
getAliases() - Method in class com.mongodb.client.gridfs.model.GridFSFile
Deprecated.
aliases should be stored in the metadata document.
getAliases() - Method in class com.mongodb.gridfs.GridFSFile
Gets the aliases from the metadata.
getAll() - Method in class com.mongodb.connection.ClusterDescription
getAllAddress() - Method in class com.mongodb.Mongo
Gets a list of all server addresses used when this Mongo was created
getAllowDiskUse() - Method in class com.mongodb.AggregationOptions
If true, this enables external sort capabilities, otherwise $sort produces an error if the operation consumes 10 percent or more of RAM.
getAllowDiskUse() - Method in class com.mongodb.operation.AggregateOperation
Whether writing to temporary files is enabled.
getAllowDiskUse() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Whether writing to temporary files is enabled.
getAlternate() - Method in class com.mongodb.client.model.Collation
Returns the collation alternate
getAncestry(Class<T>) - Static method in class org.bson.util.ClassMap
Helper method that walks superclass and interface graph, superclasses first, then interfaces, to compute an ancestry list.
getAny() - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getAnyPrimaryOrSecondary() - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getAnyPrimaryOrSecondary(TagSet) - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getApplicationName() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the logical name of the application using this MongoClient.
getApplicationName() - Method in class com.mongodb.ConnectionString
Gets the logical name of the application.
getApplicationName() - Method in class com.mongodb.MongoClientOptions
Gets the logical name of the application using this MongoClient.
getArbiters() - Method in class com.mongodb.connection.ServerDescription
Gets the arbiters in the replica set
getArray(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonArray, or throws if not.
getArray(Object, BsonArray) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getAuthenticationMechanism() - Method in class com.mongodb.MongoCredential
Gets the mechanism
getBackwards() - Method in class com.mongodb.client.model.Collation
Returns the backwards value
getBatchSize() - Method in class com.mongodb.AggregationOptions
The size of batches to use when iterating over results.
getBatchSize() - Method in interface com.mongodb.async.AsyncBatchCursor
Gets the batch size to use when requesting the next batch.
getBatchSize() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets the number of documents to return per batch.
getBatchSize() - Method in class com.mongodb.client.model.FindOptions
Gets the number of documents to return per batch.
getBatchSize() - Method in class com.mongodb.client.model.ParallelCollectionScanOptions
Deprecated.
Gets the batch size to use for each cursor.
getBatchSize() - Method in class com.mongodb.DBCursor
Gets the batch size.
getBatchSize() - Method in class com.mongodb.operation.AggregateOperation
Gets the number of documents to return per batch.
getBatchSize() - Method in interface com.mongodb.operation.BatchCursor
Gets the batch size to use when requesting the next batch.
getBatchSize() - Method in class com.mongodb.operation.FindOperation
Gets the number of documents to return per batch.
getBatchSize() - Method in class com.mongodb.operation.ListCollectionsOperation
Gets the number of documents to return per batch.
getBatchSize() - Method in class com.mongodb.operation.ListIndexesOperation
Gets the number of documents to return per batch.
getBatchSize() - Method in class com.mongodb.operation.ParallelCollectionScanOperation
Gets the batch size to use for each cursor.
getBatchSize() - Method in class com.mongodb.ParallelScanOptions
Gets the batch size to use for each cursor.
getBinary(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonBinary, or throws if not.
getBinary(Object, BsonBinary) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getBits() - Method in class com.mongodb.bulk.IndexRequest
Gets the number of precision of the stored geohash value of the location data in 2d indexes.
getBits() - Method in class com.mongodb.client.model.IndexOptions
Gets the number of precision of the stored geohash value of the location data in 2d indexes.
getBoolean(String) - Method in class org.bson.BasicBSONObject
Returns the value of a field as a boolean.
getBoolean(String, boolean) - Method in class org.bson.BasicBSONObject
Returns the value of a field as a boolean
getBoolean(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonBoolean, or throws if not.
getBoolean(Object, BsonBoolean) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getBoolean(Object) - Method in class org.bson.Document
Gets the value of the given key as a Boolean.
getBoolean(Object, boolean) - Method in class org.bson.Document
Gets the value of the given key as a primitive boolean.
getBsonInput() - Method in class org.bson.BsonBinaryReader
Gets the BSON input backing this instance.
getBsonOutput() - Method in class org.bson.BsonBinaryWriter
Gets the BSON output backing this instance.
getBSONSize() - Method in class org.bson.LazyBSONObject
Gets the size in bytes of the BSON document.
getBsonType() - Method in class org.bson.BsonArray
 
getBsonType() - Method in class org.bson.BsonBinary
 
getBsonType() - Method in class org.bson.BsonBoolean
 
getBsonType() - Method in class org.bson.BsonDateTime
 
getBsonType() - Method in class org.bson.BsonDbPointer
 
getBsonType() - Method in class org.bson.BsonDecimal128
 
getBsonType() - Method in class org.bson.BsonDocument
 
getBsonType() - Method in class org.bson.BsonDouble
 
getBsonType() - Method in class org.bson.BsonInt32
 
getBsonType() - Method in class org.bson.BsonInt64
 
getBsonType() - Method in class org.bson.BsonJavaScript
 
getBsonType() - Method in class org.bson.BsonJavaScriptWithScope
 
getBsonType() - Method in class org.bson.BsonMaxKey
 
getBsonType() - Method in class org.bson.BsonMinKey
 
getBsonType() - Method in class org.bson.BsonNull
 
getBsonType() - Method in class org.bson.BsonObjectId
 
getBsonType() - Method in class org.bson.BsonRegularExpression
 
getBsonType() - Method in class org.bson.BsonString
 
getBsonType() - Method in class org.bson.BsonSymbol
 
getBsonType() - Method in class org.bson.BsonTimestamp
 
getBsonType() - Method in class org.bson.BsonUndefined
 
getBsonType() - Method in class org.bson.BsonValue
Gets the BSON type of this value.
getBsonTypeClassMap() - Static method in class org.bson.codecs.BsonValueCodecProvider
Gets the BsonTypeClassMap used by this provider.
getBsonWriter() - Method in class org.bson.BasicBSONEncoder
Gets the writer responsible for writing the encoded BSON.
getBucketName() - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
The bucket name.
getBucketName() - Method in interface com.mongodb.client.gridfs.GridFSBucket
The bucket name.
getBucketName() - Method in class com.mongodb.gridfs.GridFS
Gets the bucket name used in the collection's namespace.
getBucketSize() - Method in class com.mongodb.bulk.IndexRequest
Gets the specified the number of units within which to group the location values for geoHaystack Indexes
getBucketSize() - Method in class com.mongodb.client.model.IndexOptions
Gets the specified the number of units within which to group the location values for geoHaystack Indexes
getBuffer(int) - Method in interface com.mongodb.connection.BufferProvider
Gets a buffer with the givens capacity.
getBypassDocumentValidation() - Method in class com.mongodb.AggregationOptions
Gets whether to bypass document validation, or null if unspecified.
getBypassDocumentValidation() - Method in class com.mongodb.BulkWriteOperation
Gets whether to bypass document validation, or null if unspecified.
getBypassDocumentValidation() - Method in class com.mongodb.client.model.BulkWriteOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the bypassDocumentValidation
getBypassDocumentValidation() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.client.model.InsertManyOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.client.model.InsertOneOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.client.model.UpdateOptions
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.InsertOptions
Gets whether to bypass document validation, or null if unspecified.
getBypassDocumentValidation() - Method in class com.mongodb.MapReduceCommand
Gets whether to bypass document validation, or null if unspecified.
getBypassDocumentValidation() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Gets the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.operation.BaseWriteOperation
Gets the the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the bypass document level validation flag
getBypassDocumentValidation() - Method in class com.mongodb.operation.MixedBulkWriteOperation
Gets the the bypass document level validation flag
getByServerAddress(ServerAddress) - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getByteBuffer() - Method in class org.bson.RawBsonDocument
Returns a ByteBuf that wraps the byte array, with the proper byte order.
getByteBuffers() - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
getByteBuffers() - Method in class org.bson.io.BasicOutputBuffer
 
getByteBuffers() - Method in class org.bson.io.OutputBuffer
Get a list of byte buffers that are prepared to be read from; in other words, whose position is 0 and whose limit is the number of bytes that should read.
getBytes() - Method in class org.bson.LazyBSONObject
Gets the raw bytes.
getCanonicalAddress() - Method in class com.mongodb.connection.ServerDescription
Gets the string representing the host name and port that this member of a replica set was configured with, e.g.
getCaseFirst() - Method in class com.mongodb.client.model.Collation
Returns the collation case first value
getCaseLevel() - Method in class com.mongodb.client.model.Collation
Returns the case level value
getCaseSensitive() - Method in class com.mongodb.client.model.TextSearchOptions
Returns the case-sensitive flag to use with the text search
getCategory() - Method in class com.mongodb.WriteError
Gets the category of this error.
getCheckedOutCount() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the count of connections that are currently in use.
getChildContext() - Method in class org.bson.codecs.EncoderContext
Gets a child context based on this.
getChunksCollection() - Method in class com.mongodb.gridfs.GridFS
Gets the DBCollection in which the binary chunks are stored.
getChunkSize() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The size, in bytes, of each data chunk of this file
getChunkSize() - Method in class com.mongodb.gridfs.GridFSFile
Gets the size of a chunk.
getChunkSizeBytes() - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Sets the chunk size in bytes.
getChunkSizeBytes() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Sets the chunk size in bytes.
getChunkSizeBytes() - Method in class com.mongodb.client.gridfs.model.GridFSUploadOptions
The number of bytes per chunk of this file.
getClassForBsonType(BsonType) - Static method in class org.bson.codecs.BsonValueCodecProvider
Get the BsonValue subclass associated with the given BsonType.
getClusterDescription() - Method in exception com.mongodb.MongoIncompatibleDriverException
The cluster description which was determined to be incompatible.
getClusterId() - Method in class com.mongodb.connection.ServerId
Gets the cluster identifier.
getClusterId() - Method in class com.mongodb.event.ClusterClosedEvent
Gets the cluster id associated with this event.
getClusterId() - Method in class com.mongodb.event.ClusterDescriptionChangedEvent
Gets the cluster id associated with this event.
getClusterId() - Method in class com.mongodb.event.ClusterOpeningEvent
Gets the cluster id.
getClusterListeners() - Method in class com.mongodb.connection.ClusterSettings
Gets the cluster listeners.
getClusterListeners() - Method in class com.mongodb.event.ClusterEventMulticaster
Gets the cluster listeners.
getClusterListeners() - Method in class com.mongodb.MongoClientOptions
Gets the list of added ClusterListener.
getClusterSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the cluster settings.
getClusterSettings() - Method in class com.mongodb.connection.ClusterDescription
Gets the cluster settings, which may be null if not provided.
getClusterType() - Method in class com.mongodb.connection.ServerDescription
Gets the type of the cluster this server is in (for example, replica set).
getClusterType() - Method in enum com.mongodb.connection.ServerType
The type of the cluster to which this server belongs
getCode() - Method in class com.mongodb.bulk.WriteConcernError
Gets the code associated with this error.
getCode() - Method in class com.mongodb.BulkWriteError
Gets the code associated with this error.
getCode() - Method in exception com.mongodb.MongoException
Gets the exception code
getCode() - Method in class com.mongodb.WriteConcernError
Gets the code associated with this error.
getCode() - Method in class com.mongodb.WriteError
Gets the code associated with this error.
getCode() - Method in class org.bson.BsonJavaScript
Get the Javascript code.
getCode() - Method in class org.bson.BsonJavaScriptWithScope
Get the code.
getCode() - Method in class org.bson.types.Code
Get the Javascript code.
getCodecRegistry() - Method in class com.mongodb.async.client.MongoClientSettings
The codec registry to use.
getCodecRegistry() - Method in interface com.mongodb.async.client.MongoCollection
Get the codec registry for the MongoCollection.
getCodecRegistry() - Method in interface com.mongodb.async.client.MongoDatabase
Get the codec registry for the MongoDatabase.
getCodecRegistry() - Method in interface com.mongodb.client.MongoCollection
Get the codec registry for the MongoCollection.
getCodecRegistry() - Method in interface com.mongodb.client.MongoDatabase
Get the codec registry for the MongoDatabase.
getCodecRegistry() - Method in class com.mongodb.MongoClientOptions
The codec registry to use.
getCodecRegistry() - Method in class org.bson.codecs.BsonDocumentCodec
Gets the CodecRegistry for this Codec.
getCollation() - Method in class com.mongodb.AggregationOptions
Returns the collation options
getCollation() - Method in class com.mongodb.bulk.DeleteRequest
Returns the collation options
getCollation() - Method in class com.mongodb.bulk.IndexRequest
Returns the collation options
getCollation() - Method in class com.mongodb.bulk.UpdateRequest
Returns the collation options
getCollation() - Method in class com.mongodb.BulkUpdateRequestBuilder
Returns the collation
getCollation() - Method in class com.mongodb.BulkWriteRequestBuilder
Returns the collation
getCollation() - Method in class com.mongodb.client.model.CountOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.CreateCollectionOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.CreateViewOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DBCreateViewOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.DeleteOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.FindOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.IndexOptions
Returns the collation options
getCollation() - Method in class com.mongodb.client.model.UpdateOptions
Returns the collation options
getCollation() - Method in class com.mongodb.DBCursor
Returns the collation options
getCollation() - Method in class com.mongodb.MapReduceCommand
Returns the collation
getCollation() - Method in class com.mongodb.operation.AggregateOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.CountOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.CreateCollectionOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.CreateViewOperation
Gets the default collation for the view
getCollation() - Method in class com.mongodb.operation.DistinctOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.FindAndDeleteOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.FindAndReplaceOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.FindAndUpdateOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.FindOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.GroupOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Returns the collation options
getCollation() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Returns the collation options
getCollection(String) - Method in interface com.mongodb.async.client.MongoDatabase
Gets a collection.
getCollection(String, Class<TDocument>) - Method in interface com.mongodb.async.client.MongoDatabase
Gets a collection, with a specific default document class.
getCollection(String) - Method in interface com.mongodb.client.MongoDatabase
Gets a collection.
getCollection(String, Class<TDocument>) - Method in interface com.mongodb.client.MongoDatabase
Gets a collection, with a specific default document class.
getCollection() - Method in class com.mongodb.ConnectionString
Gets the collection name
getCollection(String) - Method in class com.mongodb.DB
Gets a collection with a given name.
getCollection(String) - Method in class com.mongodb.DBCollection
Find a collection that is prefixed with this collection's name.
getCollection() - Method in class com.mongodb.DBCursor
Gets the collection.
getCollection() - Method in class com.mongodb.MongoClientURI
Gets the collection name
getCollection() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the collection name.
getCollectionFromString(String) - Method in class com.mongodb.DB
Returns a collection matching a given string.
getCollectionName() - Method in class com.mongodb.DBRef
Gets the name of the collection in which the referenced document is stored.
getCollectionName() - Method in class com.mongodb.MapReduceOutput
Get the name of the collection that the results of the map reduce were saved into.
getCollectionName() - Method in class com.mongodb.MongoNamespace
Gets the collection name.
getCollectionName() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the name of the collection to create.
getCollectionName() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the name of the collection to output the results to.
getCollectionNames() - Method in class com.mongodb.DB
Returns a set containing the names of all collections in this database.
getCommand() - Method in class com.mongodb.event.CommandStartedEvent
Gets the command document.
getCommand() - Method in class com.mongodb.MapReduceOutput
Get the original command that was sent to the database.
getCommandListeners() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the list of added CommandListener.
getCommandListeners() - Method in class com.mongodb.event.CommandEventMulticaster
Gets the command listeners.
getCommandListeners() - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
Gets the command listeners.
getCommandListeners() - Method in class com.mongodb.MongoClientOptions
Gets the list of added CommandListener.
getCommandName() - Method in class com.mongodb.event.CommandEvent
Gets the name of the command.
getConnection(SingleResultCallback<AsyncConnection>) - Method in interface com.mongodb.binding.AsyncConnectionSource
Gets a connection from this source.
getConnection() - Method in interface com.mongodb.binding.ConnectionSource
Gets a connection from this source.
getConnection() - Method in interface com.mongodb.connection.Server
Gets a connection to this server.
getConnectionAsync(SingleResultCallback<AsyncConnection>) - Method in interface com.mongodb.connection.Server
Gets a connection to this server asynchronously.
getConnectionDescription() - Method in class com.mongodb.event.CommandEvent
Gets the description of the connection to which the operation will be sent.
getConnectionId() - Method in class com.mongodb.connection.ConnectionDescription
Gets the id of the connection.
getConnectionId() - Method in class com.mongodb.event.ConnectionAddedEvent
Gets the connection id
getConnectionId() - Method in class com.mongodb.event.ConnectionCheckedInEvent
Gets the connection id
getConnectionId() - Method in class com.mongodb.event.ConnectionCheckedOutEvent
Gets the connection id
getConnectionId() - Method in class com.mongodb.event.ConnectionClosedEvent
Gets the identifier for this connection.
getConnectionId() - Method in class com.mongodb.event.ConnectionMessageReceivedEvent
Gets the identifier for this connection.
getConnectionId() - Method in class com.mongodb.event.ConnectionMessagesSentEvent
Gets the identifier for this connection.
getConnectionId() - Method in class com.mongodb.event.ConnectionOpenedEvent
Gets the connection id
getConnectionId() - Method in class com.mongodb.event.ConnectionRemovedEvent
Gets the connection id
getConnectionId() - Method in class com.mongodb.event.ServerHeartbeatFailedEvent
Gets the connectionId.
getConnectionId() - Method in class com.mongodb.event.ServerHeartbeatStartedEvent
Gets the connectionId.
getConnectionId() - Method in class com.mongodb.event.ServerHeartbeatSucceededEvent
Gets the connectionId.
getConnectionMode() - Method in class com.mongodb.connection.ClusterDescription
Gets whether this cluster is connecting to a single server or multiple servers.
getConnectionPoolSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the settings for the connection provider in a settings object.
getConnectionsPerHost() - Method in class com.mongodb.MongoClientOptions
The maximum number of connections allowed per host for this MongoClient instance.
getConnectionsPerHost() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the maximum number of connections allowed per host for this Mongo instance.
getConnectionString() - Method in class com.mongodb.ConnectionString
Get the unparsed connection string.
getConnectPoint() - Method in class com.mongodb.Mongo
Gets a String representation of current connection point, i.e.
getConnectTimeout(TimeUnit) - Method in class com.mongodb.connection.SocketSettings
Gets the timeout for socket connect.
getConnectTimeout() - Method in class com.mongodb.ConnectionString
Gets the socket connect timeout specified in the connection string.
getConnectTimeout() - Method in class com.mongodb.MongoClientOptions
The connection timeout in milliseconds.
getConnectTimeout() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the connection timeout in milliseconds.
getContentType() - Method in class com.mongodb.client.gridfs.model.GridFSFile
Deprecated.
content type information stored in the metadata document.
getContentType() - Method in class com.mongodb.gridfs.GridFSFile
Gets the content type.
getContext() - Method in class org.bson.AbstractBsonReader
Get the context, which will indicate which state the reader is in, for example which part of a document it's currently reading.
getContext() - Method in class org.bson.AbstractBsonWriter
Get the context, which will indicate which state the writer is in, for example which part of a document it's currently writing.
getContext() - Method in class org.bson.BsonBinaryReader
 
getContext() - Method in class org.bson.BsonBinaryWriter
 
getContext() - Method in class org.bson.BsonDocumentReader
 
getContext() - Method in class org.bson.BsonDocumentWriter
 
getContext() - Method in class org.bson.json.JsonReader
 
getContext() - Method in class org.bson.json.JsonWriter
 
getContextType() - Method in class org.bson.AbstractBsonReader.Context
Return the type of this context.
getContextType() - Method in class org.bson.AbstractBsonReader.Mark
 
getContextType() - Method in class org.bson.AbstractBsonWriter.Context
Gets the current context type.
getContextType() - Method in class org.bson.json.JsonReader.Context
 
getCoordinateReferenceSystem() - Method in class com.mongodb.client.model.geojson.Geometry
Gets the coordinate reference system, which may be null
getCoordinates() - Method in class com.mongodb.client.model.geojson.LineString
Gets the GeoJSON coordinates of this LineString.
getCoordinates() - Method in class com.mongodb.client.model.geojson.MultiLineString
Gets the GeoJSON coordinates of this MultiLineString
getCoordinates() - Method in class com.mongodb.client.model.geojson.MultiPoint
Gets the GeoJSON coordinates of this MultiPoint.
getCoordinates() - Method in class com.mongodb.client.model.geojson.MultiPolygon
Gets the coordinates.
getCoordinates() - Method in class com.mongodb.client.model.geojson.Point
Gets the GeoJSON coordinates of this point.
getCoordinates() - Method in class com.mongodb.client.model.geojson.Polygon
Gets the GeoJSON coordinates of the polygon
getCount() - Method in interface com.mongodb.binding.ReferenceCounted
Gets the current reference count, which starts at 0.
getCount() - Method in class com.mongodb.DBCollection
Get the count of documents in collection.
getCount(ReadPreference) - Method in class com.mongodb.DBCollection
Get the count of documents in collection.
getCount(DBObject) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
getCount(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
getCount(DBObject, DBObject, ReadPreference) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
getCount(DBObject, DBObject, long, long) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
getCount(DBObject, DBObject, long, long, ReadPreference) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
getCount(DBObject, DBCollectionCountOptions) - Method in class com.mongodb.DBCollection
Get the count of documents in collection that would match a criteria.
getCount(BulkWriteResult) - Method in class com.mongodb.operation.BaseWriteOperation
 
getCount(BulkWriteResult) - Method in class com.mongodb.operation.DeleteOperation
 
getCount(BulkWriteResult) - Method in class com.mongodb.operation.InsertOperation
 
getCount(BulkWriteResult) - Method in class com.mongodb.operation.UpdateOperation
 
getCount() - Method in class com.mongodb.WriteConcernResult
Returns the number of documents affected by the write operation.
getCounter() - Method in class org.bson.types.ObjectId
Gets the counter.
getCredential() - Method in exception com.mongodb.MongoSecurityException
The credential being authenticated.
getCredential() - Method in class com.mongodb.operation.CreateUserOperation
Gets the users credentials.
getCredential() - Method in class com.mongodb.operation.UpdateUserOperation
Gets the users credentials.
getCredentialList() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the credential list.
getCredentialList() - Method in class com.mongodb.ConnectionString
Gets the credentials.
getCredentials() - Method in class com.mongodb.MongoClientURI
Gets the credentials.
getCredentials() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the credentials.
getCredentialsList() - Method in class com.mongodb.MongoClient
Gets the list of credentials that this client authenticates all connections with
getCurrentBsonType() - Method in class org.bson.AbstractBsonReader
 
getCurrentBsonType() - Method in interface org.bson.BsonReader
 
getCurrentCounter() - Static method in class org.bson.types.ObjectId
Gets the current value of the auto-incrementing counter.
getCurrentName() - Method in class org.bson.AbstractBsonReader
 
getCurrentName() - Method in interface org.bson.BsonReader
Gets the most recently read name.
getCursor() - Method in class com.mongodb.connection.QueryResult
Gets the cursor.
getCursorId() - Method in interface com.mongodb.Cursor
Gets the server's identifier for this Cursor.
getCursorId() - Method in class com.mongodb.DBCursor
 
getCursorId() - Method in exception com.mongodb.MongoCursorNotFoundException
Get the cursor id that wasn't found.
getCursorType() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Get the cursor type.
getCursorType() - Method in class com.mongodb.client.model.FindOptions
Get the cursor type.
getCursorType() - Method in class com.mongodb.operation.FindOperation
Get the cursor type.
getData() - Method in class org.bson.BsonBinary
Gets the data of this Binary.
getData() - Method in class org.bson.types.Binary
Get a copy of the binary value.
getDatabase(String) - Method in interface com.mongodb.async.client.MongoClient
Gets the database with the given name.
getDatabase() - Method in class com.mongodb.ConnectionString
Gets the database name
getDatabase(String) - Method in class com.mongodb.MongoClient
 
getDatabase() - Method in class com.mongodb.MongoClientURI
Gets the database name
getDatabase() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the database name.
getDatabaseName() - Method in class com.mongodb.DBRef
Gets the name of the database in which the referenced document is stored.
getDatabaseName() - Method in class com.mongodb.event.CommandStartedEvent
Gets the database on which the operation will be executed.
getDatabaseName() - Method in class com.mongodb.MapReduceOutput
Get the name of the database that the results of the map reduce were saved into.
getDatabaseName() - Method in class com.mongodb.MongoNamespace
Gets the database name.
getDatabaseName() - Method in class com.mongodb.operation.CreateViewOperation
Gets the database name
getDatabaseName() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the name of the database to output into.
getDatabaseNames() - Method in class com.mongodb.Mongo
Deprecated.
getDate(String) - Method in class org.bson.BasicBSONObject
Returns the date or null if not set.
getDate(String, Date) - Method in class org.bson.BasicBSONObject
Returns the date or def if not set.
getDate(Object) - Method in class org.bson.Document
Gets the value of the given key as a Date.
getDate() - Method in class org.bson.types.ObjectId
Gets the timestamp as a Date instance.
getDateTime(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonDateTime, or throws if not.
getDateTime(Object, BsonDateTime) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getDB() - Method in class com.mongodb.DBCollection
Returns the database this collection is a member of.
getDB() - Method in class com.mongodb.gridfs.GridFS
Gets the database used.
getDB(String) - Method in class com.mongodb.Mongo
getDBCallback(DBCollection) - Method in interface com.mongodb.DBDecoder
Get a callback for the given collection.
getDBCallback(DBCollection) - Method in class com.mongodb.DefaultDBDecoder
 
getDBCallback(DBCollection) - Method in class com.mongodb.LazyDBDecoder
 
getDBDecoderFactory() - Method in class com.mongodb.DBCollection
Get the decoder factory for this collection.
getDbDecoderFactory() - Method in class com.mongodb.MongoClientOptions
Override the decoder factory.
getDbDecoderFactory() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the DBCallback factory.
getDbEncoder() - Method in class com.mongodb.InsertOptions
The encoder to use for the documents.
getDBEncoderFactory() - Method in class com.mongodb.DBCollection
Get the encoder factory for this collection.
getDbEncoderFactory() - Method in class com.mongodb.MongoClientOptions
Override the encoder factory.
getDbEncoderFactory() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the encoding factory.
getDBName() - Method in class com.mongodb.DBAddress
Deprecated.
Gets the database name
getDecimal128(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonDecimal128, or throws if not.
getDecimal128(Object, BsonDecimal128) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getDecoder() - Method in class com.mongodb.operation.FindAndDeleteOperation
Gets the decoder used to decode the result documents.
getDecoder() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the decoder used to decode the result documents.
getDecoder() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the decoder used to decode the result documents.
getDecoder() - Method in class com.mongodb.operation.FindOperation
Gets the decoder used to decode the result documents.
getDecoder() - Method in class com.mongodb.operation.GroupOperation
Gets the decoder used to decode the result documents.
getDecoder() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the decoder used to decode the result documents.
getDecoderFactory() - Method in class com.mongodb.DBCursor
Gets the decoder factory that creates the decoder this cursor will use to decode objects from MongoDB.
getDecodingHooks(Class<?>) - Static method in class org.bson.BSON
Returns the decoding hook(s) associated with the specific class
getDefaultBucket() - Method in class com.mongodb.client.model.BucketOptions
 
getDefaultCodecRegistry() - Static method in class com.mongodb.async.client.MongoClients
Gets the default codec registry.
getDefaultCodecRegistry() - Static method in class com.mongodb.MongoClient
Gets the default codec registry.
getDefaultLanguage() - Method in class com.mongodb.bulk.IndexRequest
Gets the language for a text index.
getDefaultLanguage() - Method in class com.mongodb.client.model.IndexOptions
Gets the language for a text index.
getDefaultMaxDocumentSize() - Static method in class com.mongodb.connection.ServerDescription
Get the default maximum document size.
getDefaultMaxMessageSize() - Static method in class com.mongodb.connection.ConnectionDescription
Get the default maximum message size.
getDefaultMaxWireVersion() - Static method in class com.mongodb.connection.ServerDescription
Get the default maximum wire version
getDefaultMaxWriteBatchSize() - Static method in class com.mongodb.connection.ConnectionDescription
Get the default maximum write batch size.
getDefaultMinWireVersion() - Static method in class com.mongodb.connection.ServerDescription
Get the default minimum wire version
getDeletedCount() - Method in class com.mongodb.bulk.BulkWriteResult
Returns the number of documents deleted by the write operation.
getDeletedCount() - Method in class com.mongodb.client.result.DeleteResult
Gets the number of documents deleted.
getDeleteRequests() - Method in class com.mongodb.operation.DeleteOperation
Gets the list of remove requests.
getDepthField() - Method in class com.mongodb.client.model.GraphLookupOptions
 
getDescription() - Method in interface com.mongodb.connection.AsyncConnection
Gets the description of the connection.
getDescription() - Method in interface com.mongodb.connection.Cluster
Get the description of this cluster.
getDescription() - Method in class com.mongodb.connection.ClusterId
Gets the user defined description of the MongoClient.
getDescription() - Method in class com.mongodb.connection.ClusterSettings
Gets the user defined description of the MongoClient.
getDescription() - Method in interface com.mongodb.connection.Connection
Gets the description of the connection.
getDescription() - Method in interface com.mongodb.connection.Server
Gets the description of this server.
getDescription() - Method in class com.mongodb.MongoClientOptions
Gets the description for this MongoClient, which is used in various places like logging and JMX.
getDescription() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the description for Mongo instances created with these options.
getDetails() - Method in class com.mongodb.bulk.WriteConcernError
Gets the details associated with this error.
getDetails() - Method in class com.mongodb.BulkWriteError
Gets the details associated with this error.
getDetails() - Method in class com.mongodb.WriteConcernError
Gets the details associated with this error.
getDetails() - Method in class com.mongodb.WriteError
Gets the details associated with this error.
getDiacriticSensitive() - Method in class com.mongodb.client.model.TextSearchOptions
Returns the diacritic-sensitive flag to use with the text search
getDocument() - Method in class com.mongodb.bulk.InsertRequest
Gets the document to insert.
getDocument() - Method in class com.mongodb.client.model.InsertOneModel
Gets the document to insert.
getDocument(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonDocument, or throws if not.
getDocument(Object, BsonDocument) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getDocument() - Method in class org.bson.BsonDocumentWriter
Gets the document that the writer is writing to.
getDocumentClass() - Method in interface com.mongodb.async.client.MongoCollection
Get the class of documents stored in this collection.
getDocumentClass() - Method in interface com.mongodb.client.MongoCollection
Get the class of documents stored in this collection.
getDocumentId(DBObject) - Method in class com.mongodb.DBObjectCodec
 
getDocumentId(BsonDocument) - Method in class org.bson.codecs.BsonDocumentCodec
 
getDocumentId(T) - Method in interface org.bson.codecs.CollectibleCodec
Gets the _id of the given document if it contains one, otherwise throws IllegalArgumentException.
getDocumentId(Document) - Method in class org.bson.codecs.DocumentCodec
 
getDouble(String) - Method in class org.bson.BasicBSONObject
Returns the value of a field as a double.
getDouble(String, double) - Method in class org.bson.BasicBSONObject
Returns the value of a field as an double.
getDouble(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonDouble, or throws if not.
getDouble(Object, BsonDouble) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getDouble() - Method in interface org.bson.ByteBuf
Relative get method for reading a double value.
getDouble(int) - Method in interface org.bson.ByteBuf
Absolute get method for reading a double value.
getDouble() - Method in class org.bson.ByteBufNIO
 
getDouble(int) - Method in class org.bson.ByteBufNIO
 
getDouble(Object) - Method in class org.bson.Document
Gets the value of the given key as a Double.
getDriverNames() - Method in class com.mongodb.client.MongoDriverInformation
Returns the driverNames
getDriverPlatforms() - Method in class com.mongodb.client.MongoDriverInformation
Returns the driverPlatforms
getDriverVersions() - Method in class com.mongodb.client.MongoDriverInformation
Returns the driverVersions
getDropDups() - Method in class com.mongodb.bulk.IndexRequest
Returns the legacy dropDups setting
getDuration() - Method in class com.mongodb.MapReduceOutput
Get the amount of time, in milliseconds, that it took to run this map reduce.
getDuration() - Method in class com.mongodb.operation.MapReduceStatistics
Get the amount of time it took to run the map-reduce.
getElapsedTime(TimeUnit) - Method in class com.mongodb.event.CommandFailedEvent
Gets the elapsed time in the given unit of time.
getElapsedTime(TimeUnit) - Method in class com.mongodb.event.CommandSucceededEvent
Gets the elapsed time in the given unit of time.
getElapsedTime(TimeUnit) - Method in class com.mongodb.event.ServerHeartbeatFailedEvent
Gets the elapsed time in the given time unit.
getElapsedTime(TimeUnit) - Method in class com.mongodb.event.ServerHeartbeatSucceededEvent
Gets the elapsed time in the given time unit.
getElectionId() - Method in class com.mongodb.connection.ServerDescription
The replica set electionid reported by this MongoDB server.
getEmitCount() - Method in class com.mongodb.MapReduceOutput
Get the number of messages emitted from the provided map function.
getEmitCount() - Method in class com.mongodb.operation.MapReduceStatistics
Get the number of messages emitted from the provided map function.
getEncoder() - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Returns the encoder
getEncoder() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Returns the encoder
getEncoder() - Method in class org.bson.BsonDocumentWrapper
Get the encoder to use for the wrapped document.
getEncoderClass() - Method in class com.mongodb.BSONTimestampCodec
 
getEncoderClass() - Method in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.GeometryCollectionCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.LineStringCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.MultiLineStringCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.MultiPointCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.MultiPolygonCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.PointCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.PolygonCodec
 
getEncoderClass() - Method in class com.mongodb.DBObjectCodec
 
getEncoderClass() - Method in class com.mongodb.DBRefCodec
 
getEncoderClass() - Method in class org.bson.codecs.AtomicBooleanCodec
 
getEncoderClass() - Method in class org.bson.codecs.AtomicIntegerCodec
 
getEncoderClass() - Method in class org.bson.codecs.AtomicLongCodec
 
getEncoderClass() - Method in class org.bson.codecs.BinaryCodec
 
getEncoderClass() - Method in class org.bson.codecs.BooleanCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonArrayCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonBinaryCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonBooleanCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonDateTimeCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonDBPointerCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonDecimal128Codec
 
getEncoderClass() - Method in class org.bson.codecs.BsonDocumentCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonDocumentWrapperCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonDoubleCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonInt32Codec
 
getEncoderClass() - Method in class org.bson.codecs.BsonInt64Codec
 
getEncoderClass() - Method in class org.bson.codecs.BsonJavaScriptCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonJavaScriptWithScopeCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonMaxKeyCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonMinKeyCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonNullCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonObjectIdCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonRegularExpressionCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonStringCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonSymbolCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonTimestampCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonUndefinedCodec
 
getEncoderClass() - Method in class org.bson.codecs.BsonValueCodec
 
getEncoderClass() - Method in class org.bson.codecs.ByteArrayCodec
 
getEncoderClass() - Method in class org.bson.codecs.ByteCodec
 
getEncoderClass() - Method in class org.bson.codecs.CharacterCodec
 
getEncoderClass() - Method in class org.bson.codecs.CodeCodec
 
getEncoderClass() - Method in class org.bson.codecs.CodeWithScopeCodec
 
getEncoderClass() - Method in class org.bson.codecs.DateCodec
 
getEncoderClass() - Method in class org.bson.codecs.Decimal128Codec
 
getEncoderClass() - Method in class org.bson.codecs.DocumentCodec
 
getEncoderClass() - Method in class org.bson.codecs.DoubleCodec
 
getEncoderClass() - Method in interface org.bson.codecs.Encoder
Returns the Class instance that this encodes.
getEncoderClass() - Method in class org.bson.codecs.FloatCodec
 
getEncoderClass() - Method in class org.bson.codecs.IntegerCodec
 
getEncoderClass() - Method in class org.bson.codecs.IterableCodec
 
getEncoderClass() - Method in class org.bson.codecs.LongCodec
 
getEncoderClass() - Method in class org.bson.codecs.MaxKeyCodec
 
getEncoderClass() - Method in class org.bson.codecs.MinKeyCodec
 
getEncoderClass() - Method in class org.bson.codecs.ObjectIdCodec
 
getEncoderClass() - Method in class org.bson.codecs.PatternCodec
 
getEncoderClass() - Method in class org.bson.codecs.RawBsonDocumentCodec
 
getEncoderClass() - Method in class org.bson.codecs.ShortCodec
 
getEncoderClass() - Method in class org.bson.codecs.StringCodec
 
getEncoderClass() - Method in class org.bson.codecs.SymbolCodec
 
getEncoderClass() - Method in class org.bson.codecs.UuidCodec
 
getEncodingHooks(Class<?>) - Static method in class org.bson.BSON
Returns the encoding hook(s) associated with the specified class.
getError() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Gets the combined errors as an exception
getError() - Method in exception com.mongodb.MongoWriteException
Gets the error.
getErrorCode() - Method in exception com.mongodb.MongoCommandException
Gets the error code associated with the command failure.
getErrorCode() - Method in exception com.mongodb.MongoQueryException
Gets the error code for this query failure.
getErrorCode() - Method in exception com.mongodb.WriteConcernException
Gets the error code associated with the write concern failure.
getErrorCode() - Method in exception org.bson.BSONException
Returns the error code.
getErrorMessage() - Method in class com.mongodb.CommandResult
Gets the error message associated with a failed command.
getErrorMessage() - Method in exception com.mongodb.MongoCommandException
Gets the error message associated with the command failure.
getErrorMessage() - Method in exception com.mongodb.MongoQueryException
Gets the error message for this query failure.
getErrorMessage() - Method in exception com.mongodb.WriteConcernException
Gets the error message associated with the write concern failure.
getException() - Method in class com.mongodb.CommandResult
Utility method to create an exception from a failed command.
getException() - Method in class com.mongodb.connection.ServerDescription
Gets the exception thrown while attempting to determine the server description.
getExpireAfter(TimeUnit) - Method in class com.mongodb.bulk.IndexRequest
Gets the time to live for documents in the collection
getExpireAfter(TimeUnit) - Method in class com.mongodb.client.model.IndexOptions
Gets the time to live for documents in the collection
getExterior() - Method in class com.mongodb.client.model.geojson.Polygon
Gets the exterior coordinates.
getExterior() - Method in class com.mongodb.client.model.geojson.PolygonCoordinates
Gets the exterior of the polygon.
getExtraElements() - Method in class com.mongodb.client.gridfs.model.GridFSFile
Deprecated.
any extra information should be stored in the metadata document.
getFileId() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
Deprecated.
getFileList() - Method in class com.mongodb.gridfs.GridFS
Gets the list of files stored in this gridfs, sorted by filename.
getFileList(DBObject) - Method in class com.mongodb.gridfs.GridFS
Gets a filtered list of files stored in this gridfs, sorted by filename.
getFileList(DBObject, DBObject) - Method in class com.mongodb.gridfs.GridFS
Gets a sorted, filtered list of files stored in this gridfs.
getFilename() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The filename
getFilename() - Method in class com.mongodb.gridfs.GridFSFile
Gets the filename.
getFilesCollection() - Method in class com.mongodb.gridfs.GridFS
Gets the DBCollection in which the file's metadata is stored.
getFilter() - Method in class com.mongodb.bulk.DeleteRequest
Gets the query Object filter.
getFilter() - Method in class com.mongodb.bulk.UpdateRequest
Gets the query filter for the update.
getFilter() - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Gets the selection query to determine the subset of documents from which to retrieve the distinct values
getFilter() - Method in class com.mongodb.client.model.DeleteManyModel
Gets the query filter.
getFilter() - Method in class com.mongodb.client.model.DeleteOneModel
Gets the query filter.
getFilter() - Method in class com.mongodb.client.model.ReplaceOneModel
Gets the query filter.
getFilter() - Method in class com.mongodb.client.model.UpdateManyModel
Gets the query filter.
getFilter() - Method in class com.mongodb.client.model.UpdateOneModel
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.CountOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.DistinctOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.FindAndDeleteOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.FindOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.GroupOperation
Gets the query filter to determine which documents in the collection to process.
getFilter() - Method in class com.mongodb.operation.ListCollectionsOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the query filter.
getFilter() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the query filter.
getFinalize() - Method in class com.mongodb.MapReduceCommand
Gets the Finalize JS Function
getFinalizeFunction() - Method in class com.mongodb.operation.GroupOperation
Gets the function that runs each item in the result before returning the final value.
getFinalizeFunction() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the JavaScript function that follows the reduce method and modifies the output.
getFinalizeFunction() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the JavaScript function that follows the reduce method and modifies the output.
getFsync() - Method in class com.mongodb.WriteConcern
Deprecated.
getFullName() - Method in class com.mongodb.DBCollection
Get the full name of a collection, with the database name as a prefix.
getFullName() - Method in class com.mongodb.MongoNamespace
Gets the full name, which is the database name and the collection name, separated by a period.
getGeneratedMachineIdentifier() - Static method in class org.bson.types.ObjectId
Gets the generated machine identifier.
getGeneratedProcessIdentifier() - Static method in class org.bson.types.ObjectId
Gets the generated process identifier.
getGeometries() - Method in class com.mongodb.client.model.geojson.GeometryCollection
Gets the list of Geometry objects in this collection.
getGranularity() - Method in class com.mongodb.client.model.BucketAutoOptions
 
getGridFS() - Method in class com.mongodb.gridfs.GridFSFile
Gets the GridFS associated with this file
getGridFSFile(SingleResultCallback<GridFSFile>) - Method in interface com.mongodb.async.client.gridfs.GridFSDownloadStream
Gets the corresponding GridFSFile for the file being downloaded
getGridFSFile() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
Gets the corresponding GridFSFile for the file being downloaded
getHeartbeatConnectTimeout() - Method in class com.mongodb.MongoClientOptions
Gets the connect timeout for connections used for the cluster heartbeat.
getHeartbeatFrequency(TimeUnit) - Method in class com.mongodb.connection.ServerSettings
Gets the frequency that the cluster monitor attempts to reach each server.
getHeartbeatFrequency() - Method in class com.mongodb.ConnectionString
 
getHeartbeatFrequency() - Method in class com.mongodb.MongoClientOptions
Gets the heartbeat frequency.
getHeartbeatSocketSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the connection settings for the heartbeat thread (the background task that checks the state of the cluster) wrapped in a settings object.
getHeartbeatSocketTimeout() - Method in class com.mongodb.MongoClientOptions
Gets the socket timeout for connections used for the cluster heartbeat.
getHigh() - Method in class org.bson.types.Decimal128
Gets the high-order 64 bits of the IEEE 754-2008 128-bit decimal floating point encoding for this Decimal128, using the BID encoding scheme.
getHint() - Method in class com.mongodb.client.model.CountOptions
Gets the hint to apply.
getHint() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Gets the hint to apply.
getHint() - Method in class com.mongodb.operation.CountOperation
Gets the hint to apply.
getHintFields() - Method in class com.mongodb.DBCollection
Get hint fields for this collection (used to optimize queries).
getHintString() - Method in class com.mongodb.client.model.CountOptions
Gets the hint string to apply.
getHintString() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Gets the hint string to apply.
getHoles() - Method in class com.mongodb.client.model.geojson.Polygon
Get the holes in this polygon.
getHoles() - Method in class com.mongodb.client.model.geojson.PolygonCoordinates
Gets the holes in the polygon.
getHost() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the host that this connection pool is connecting to.
getHost() - Method in class com.mongodb.ServerAddress
Gets the hostname
getHosts() - Method in class com.mongodb.connection.ClusterSettings
Gets the seed list of hosts for the cluster.
getHosts() - Method in class com.mongodb.connection.ServerDescription
Get a Set of strings in the format of "[hostname]:[port]" that contains all members of the replica set that are neither hidden, passive, nor arbiters.
getHosts() - Method in class com.mongodb.ConnectionString
Gets the list of hosts
getHosts() - Method in class com.mongodb.MongoClientURI
Gets the list of hosts
getHosts() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the list of hosts.
getId() - Method in interface com.mongodb.async.client.gridfs.GridFSUploadStream
The BsonValue id for this file.
getId() - Method in class com.mongodb.bulk.BulkWriteUpsert
Gets the id of the upserted item.
getId() - Method in class com.mongodb.BulkWriteUpsert
Gets the id of the upserted item.
getId() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
Gets the BsonValue for the file to be uploaded
getId() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The BsonValue id for this file.
getId() - Method in class com.mongodb.DBRef
Gets the _id of the referenced document
getId() - Method in class com.mongodb.gridfs.GridFSFile
Gets the id.
getId() - Method in class com.mongodb.ServerCursor
Gets the cursor id that the server uses to uniquely identify the cursor.
getId() - Method in class org.bson.BsonDbPointer
Gets the id.
getInc() - Method in class org.bson.BsonTimestamp
Gets the increment value.
getInc() - Method in class org.bson.types.BSONTimestamp
Gets the incrementing ordinal for operations within a given second.
getIncludeArrayIndex() - Method in class com.mongodb.client.model.UnwindOptions
Gets the includeArrayIndex field if set or null
getIndentCharacters() - Method in class org.bson.json.JsonWriterSettings
The indent characters to use if indent mode is enabled.
getIndex() - Method in class com.mongodb.bulk.BulkWriteError
The index of the item in the bulk write operation with this error.
getIndex() - Method in class com.mongodb.bulk.BulkWriteUpsert
Gets the index of the upserted item based on the order it was added to the bulk write operation.
getIndex() - Method in class com.mongodb.BulkWriteError
The index of the item in the bulk write operation with this error.
getIndex() - Method in class com.mongodb.BulkWriteUpsert
Gets the index of the upserted item based on the order it was added to the bulk write operation.
getIndexInfo() - Method in class com.mongodb.DBCollection
Return a list of the indexes for this collection.
getIndexNames() - Method in class com.mongodb.operation.CreateIndexesOperation
Gets the index names.
getIndexOptionDefaults() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets the index option defaults for the collection.
getIndexOptionDefaults() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the index option defaults for the collection.
getInitial() - Method in class com.mongodb.operation.GroupOperation
Gets the initial the aggregation result document.
getInput() - Method in class com.mongodb.MapReduceCommand
Get the name of the collection the MapReduce will read from
getInputCount() - Method in class com.mongodb.MapReduceOutput
Get the number of documents that were input into the map reduce operation
getInputCount() - Method in class com.mongodb.operation.MapReduceStatistics
Get the number of documents that were input into the map reduce operation
getInputStream() - Method in class com.mongodb.gridfs.GridFSDBFile
Returns an InputStream from which data can be read.
getInsertedCount() - Method in class com.mongodb.bulk.BulkWriteResult
Returns the number of documents inserted by the write operation.
getInsertedCount() - Method in class com.mongodb.BulkWriteResult
Returns the number of documents inserted by the write operation.
getInsertRequests() - Method in class com.mongodb.operation.InsertOperation
Gets the list of insert requests.
getInt(String) - Method in class org.bson.BasicBSONObject
Returns the value of a field as an int.
getInt(String, int) - Method in class org.bson.BasicBSONObject
Returns the value of a field as an int.
getInt() - Method in interface org.bson.ByteBuf
Relative get method for reading an int value.
getInt(int) - Method in interface org.bson.ByteBuf
Absolute get method for reading an int value.
getInt() - Method in class org.bson.ByteBufNIO
 
getInt(int) - Method in class org.bson.ByteBufNIO
 
getInt32(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonInt32, or throws if not.
getInt32(Object, BsonInt32) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getInt64(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonInt64, or throws if not.
getInt64(Object, BsonInt64) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getInteger(Object) - Method in class org.bson.Document
Gets the value of the given key as an Integer.
getInteger(Object, int) - Method in class org.bson.Document
Gets the value of the given key as a primitive int.
getInternalBuffer() - Method in class org.bson.io.BasicOutputBuffer
Gets the internal buffer.
getInternalClass(String) - Method in class com.mongodb.DBCollection
Gets the internal class for the given path in the document hierarchy
getIntRepresentation() - Method in enum com.mongodb.client.model.CollationStrength
The integer representation of the collation strength.
getIntRepresentation() - Method in enum com.mongodb.operation.OrderBy
The integer representation of the order.
getJ() - Method in class com.mongodb.WriteConcern
Deprecated.
getJournal() - Method in class com.mongodb.WriteConcern
Gets the journal property.
getJsMode() - Method in class com.mongodb.MapReduceCommand
Gets the (optional) JavaScript mode
getKey() - Method in class com.mongodb.operation.GroupOperation
Gets the document containing the field or fields to group.
getKeyFunction() - Method in class com.mongodb.operation.GroupOperation
Gets the function that creates a "key object" for use as the grouping key.
getKeys() - Method in class com.mongodb.bulk.IndexRequest
Gets the index keys
getKeys() - Method in class com.mongodb.client.model.IndexModel
Gets the index keys.
getKeysWanted() - Method in class com.mongodb.DBCursor
Gets the fields to be returned.
getLanguage() - Method in class com.mongodb.client.model.TextSearchOptions
Returns the language to be used with the text search
getLanguageOverride() - Method in class com.mongodb.bulk.IndexRequest
Gets the name of the field that contains the language string.
getLanguageOverride() - Method in class com.mongodb.client.model.IndexOptions
Gets the name of the field that contains the language string.
getLastUpdateTime(TimeUnit) - Method in class com.mongodb.connection.ServerDescription
Gets the time that this server description was created, using a monotonic clock like System.nanoTime().
getLastWriteDate() - Method in class com.mongodb.connection.ServerDescription
Gets the last write date.
getLegacy() - Static method in class com.mongodb.util.JSONSerializers
Returns an ObjectSerializer that mostly conforms to the strict JSON format defined in extended JSON, but with a few differences to keep compatibility with previous versions of the driver.
getLength() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The length, in bytes of this file
getLength() - Method in class com.mongodb.gridfs.GridFSFile
Gets the file's length.
getLimit() - Method in class com.mongodb.client.model.CountOptions
Gets the limit to apply.
getLimit() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Gets the limit to apply.
getLimit() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets the limit to apply.
getLimit() - Method in class com.mongodb.client.model.FindOptions
Gets the limit to apply.
getLimit() - Method in class com.mongodb.DBCursor
Gets the query limit.
getLimit() - Method in class com.mongodb.MapReduceCommand
Gets the (optional) limit on input
getLimit() - Method in class com.mongodb.operation.CountOperation
Gets the limit to apply.
getLimit() - Method in class com.mongodb.operation.FindOperation
Gets the limit to apply.
getLimit() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the limit to apply.
getLimit() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the limit to apply.
getLocale() - Method in class com.mongodb.client.model.Collation
Returns the locale
getLocalThreshold() - Method in class com.mongodb.ConnectionString
 
getLocalThreshold() - Method in class com.mongodb.MongoClientOptions
Gets the local threshold.
getLocalValue() - Method in class com.mongodb.connection.ConnectionId
Gets the locally created id value for the connection
getLogger(String) - Static method in class com.mongodb.diagnostics.logging.Loggers
Gets a logger with the given suffix appended on to PREFIX, separated by a '.'.
getLogger(String) - Static method in class org.bson.diagnostics.Loggers
Gets a logger with the given suffix appended on to PREFIX, separated by a '.'.
getLong(String) - Method in class org.bson.BasicBSONObject
Returns the value of a field as a long.
getLong(String, long) - Method in class org.bson.BasicBSONObject
Returns the value of a field as an long.
getLong() - Method in interface org.bson.ByteBuf
Relative get method for reading a long value.
getLong(int) - Method in interface org.bson.ByteBuf
Absolute get method for reading a long value.
getLong() - Method in class org.bson.ByteBufNIO
 
getLong(int) - Method in class org.bson.ByteBufNIO
 
getLong(Object) - Method in class org.bson.Document
Gets the value of the given key as a Long.
getLow() - Method in class org.bson.types.Decimal128
Gets the low-order 64 bits of the IEEE 754-2008 128-bit decimal floating point encoding for this Decimal128, using the BID encoding scheme.
getMachineIdentifier() - Method in class org.bson.types.ObjectId
Gets the machine identifier.
getMaintenanceFrequency(TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings
Returns the time period between runs of the maintenance job.
getMaintenanceInitialDelay(TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings
Returns the period of time to wait before running the first maintenance job on the connection pool.
getMap() - Method in class com.mongodb.MapReduceCommand
Get the map function, as a JS String
getMapFunction() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the JavaScript function that associates or "maps" a value with a key and emits the key and value pair.
getMapFunction() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the JavaScript function that associates or "maps" a value with a key and emits the key and value pair.
getMaster() - Method in class com.mongodb.ReplicaSetStatus
Gets the ServerAddress of the master server in this replica set.
getMatchedCount() - Method in class com.mongodb.bulk.BulkWriteResult
Returns the number of documents matched by updates or replacements in the write operation.
getMatchedCount() - Method in class com.mongodb.BulkWriteResult
Returns the number of documents matched by updates or replacements in the write operation.
getMatchedCount() - Method in class com.mongodb.client.result.UpdateResult
Gets the number of documents matched by the query.
getMax() - Method in class com.mongodb.bulk.IndexRequest
Gets the upper inclusive boundary for the longitude and latitude values for 2d indexes..
getMax() - Method in class com.mongodb.client.model.IndexOptions
Gets the upper inclusive boundary for the longitude and latitude values for 2d indexes..
getMaxAwaitTime(TimeUnit) - Method in class com.mongodb.client.model.DBCollectionFindOptions
The maximum amount of time for the server to wait on new documents to satisfy a tailable cursor query.
getMaxAwaitTime(TimeUnit) - Method in class com.mongodb.client.model.FindOptions
The maximum amount of time for the server to wait on new documents to satisfy a tailable cursor query.
getMaxAwaitTime(TimeUnit) - Method in class com.mongodb.operation.FindOperation
The maximum amount of time for the server to wait on new documents to satisfy a tailable cursor query.
getMaxBatchCount() - Method in class com.mongodb.connection.ConnectionDescription
Gets the max batch count for bulk write operations.
getMaxBsonObjectSize() - Method in class com.mongodb.Mongo
Gets the maximum size for a BSON object supported by the current master server.
getMaxBsonObjectSize() - Method in class com.mongodb.ReplicaSetStatus
Gets the maximum size for a BSON object supported by the current master server.
getMaxConnectionIdleTime(TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings
Returns the maximum idle time of a pooled connection.
getMaxConnectionIdleTime() - Method in class com.mongodb.ConnectionString
Gets the maximum connection idle time specified in the connection string.
getMaxConnectionIdleTime() - Method in class com.mongodb.MongoClientOptions
The maximum idle time of a pooled connection.
getMaxConnectionLifeTime(TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings
The maximum time a pooled connection can live for.
getMaxConnectionLifeTime() - Method in class com.mongodb.ConnectionString
Gets the maximum connection life time specified in the connection string.
getMaxConnectionLifeTime() - Method in class com.mongodb.MongoClientOptions
The maximum life time of a pooled connection.
getMaxConnectionPoolSize() - Method in class com.mongodb.ConnectionString
Gets the maximum connection pool size specified in the connection string.
getMaxDepth() - Method in class com.mongodb.client.model.GraphLookupOptions
 
getMaxDocuments() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets the maximum number of documents allowed in a capped collection.
getMaxDocuments() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the maximum number of documents allowed in the collection.
getMaxDocumentSize() - Method in class com.mongodb.connection.ConnectionDescription
Gets the max document size in bytes for documents to be stored in collections.
getMaxDocumentSize() - Method in class com.mongodb.connection.ServerDescription
The maximum permitted size of a BSON object in bytes for this mongod process.
getMaxDocumentSize() - Method in class org.bson.BsonBinaryWriterSettings
Gets the maximum size for BSON documents.
getMaxMessageSize() - Method in class com.mongodb.connection.ConnectionDescription
Gets the max message size in bytes for wire protocol messages to be sent to the server.
getMaxSerializationDepth() - Method in class org.bson.BsonWriterSettings
Gets the maximum nuber of levels of depth defined by this settings object.
getMaxSize() - Method in class com.mongodb.connection.ConnectionPoolSettings
The maximum number of connections allowed.
getMaxSize() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the maximum allowed size of the pool, including idle and in-use members.
getMaxStaleness(TimeUnit) - Method in class com.mongodb.TaggableReadPreference
Gets the maximum acceptable staleness of a secondary in order to be considered for read operations.
getMaxTime(TimeUnit) - Method in class com.mongodb.AggregationOptions
Gets the maximum execution time for the aggregation command.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.CountOptions
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Gets the maximum execution time for the find one and delete operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Gets the maximum execution time for the find one and replace operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Gets the maximum execution time for the find one and update operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.client.model.FindOptions
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.MapReduceCommand
Gets the max execution time for this command, in the given time unit.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.AggregateOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.CountOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.DistinctOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.FindAndDeleteOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.FindOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.ListCollectionsOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.ListDatabasesOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.ListIndexesOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the maximum execution time on the server for this operation.
getMaxTime(TimeUnit) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the maximum execution time on the server for this operation.
getMaxVariable() - Method in class com.mongodb.client.model.Collation
Returns the maxVariable
getMaxWaitQueueSize() - Method in class com.mongodb.connection.ClusterSettings
This is the maximum number of threads that may be waiting for a connection to become available from the pool.
getMaxWaitQueueSize() - Method in class com.mongodb.connection.ConnectionPoolSettings
This is the maximum number of operations that may be waiting for a connection to become available from the pool.
getMaxWaitTime(TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings
The maximum time that a thread may wait for a connection to become available.
getMaxWaitTime() - Method in class com.mongodb.ConnectionString
Gets the maximum wait time of a thread waiting for a connection specified in the connection string.
getMaxWaitTime() - Method in class com.mongodb.MongoClientOptions
The maximum wait time in milliseconds that a thread may wait for a connection to become available.
getMaxWaitTime() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the maximum wait time in milliseconds that a thread may wait for a connection to become available.
getMaxWireVersion() - Method in class com.mongodb.connection.ServerDescription
The latest version of the wire protocol that this MongoDB server is capable of using to communicate with clients.
getMBeanServer() - Static method in class com.mongodb.management.MBeanServerFactory
Gets the MBeanServer for registering or unregistering MBeans.
getMD5() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The hash of the contents of the stored file
getMD5() - Method in class com.mongodb.gridfs.GridFSFile
Gets the observed MD5 during transfer
getMechanism() - Method in class com.mongodb.MongoCredential
Gets the mechanism
getMechanismName() - Method in enum com.mongodb.AuthenticationMechanism
Get the mechanism name.
getMechanismProperty(String, T) - Method in class com.mongodb.MongoCredential
Get the value of the given key to a mechanism property, or defaultValue if there is no mapping.
getMessage() - Method in class com.mongodb.bulk.WriteConcernError
Gets the message associated with this error.
getMessage() - Method in class com.mongodb.BulkWriteError
Gets the message associated with this error.
getMessage() - Method in exception com.mongodb.util.JSONParseException
 
getMessage() - Method in class com.mongodb.WriteConcernError
Gets the message associated with this error.
getMessage() - Method in class com.mongodb.WriteError
Gets the message associated with this error.
getMetadata() - Method in class com.mongodb.client.gridfs.model.GridFSFile
Any additional metadata stored along with the file
getMetadata() - Method in class com.mongodb.client.gridfs.model.GridFSUploadOptions
Returns any user provided data for the 'metadata' field of the files collection document.
getMetaData() - Method in class com.mongodb.gridfs.GridFSFile
Gets the file metadata.
getMin() - Method in class com.mongodb.bulk.IndexRequest
Gets the lower inclusive boundary for the longitude and latitude values for 2d indexes..
getMin() - Method in class com.mongodb.client.model.IndexOptions
Gets the lower inclusive boundary for the longitude and latitude values for 2d indexes..
getMinConnectionPoolSize() - Method in class com.mongodb.ConnectionString
Gets the minimum connection pool size specified in the connection string.
getMinConnectionsPerHost() - Method in class com.mongodb.MongoClientOptions
The minimum number of connections per host for this MongoClient instance.
getMinHeartbeatFrequency(TimeUnit) - Method in class com.mongodb.connection.ServerSettings
Gets the minimum heartbeat frequency.
getMinHeartbeatFrequency() - Method in class com.mongodb.MongoClientOptions
Gets the minimum heartbeat frequency.
getMinSize() - Method in class com.mongodb.connection.