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 X Z _ 

A

abort(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSUploadStream
Aborts the upload and deletes any data.
abort(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
abort() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
Aborts the upload and deletes any data.
abort() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
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.
AbstractByteBufBsonDocument - Class in com.mongodb.connection
 
AbstractByteBufBsonDocument() - Constructor for class com.mongodb.connection.AbstractByteBufBsonDocument
 
AbstractByteBufBsonDocument.Finder<T> - Interface in com.mongodb.connection
 
AbstractCopyOnWriteMap<K,V,M extends java.util.Map<K,V>> - Class in org.bson.util
Abstract base class for COW Map implementations that delegate to an internal map.
AbstractCopyOnWriteMap(N, AbstractCopyOnWriteMap.View.Type) - Constructor for class org.bson.util.AbstractCopyOnWriteMap
Create a new CopyOnWriteMap with the supplied Map to initialize the values.
AbstractCopyOnWriteMap.CollectionView<E> - Class in org.bson.util
 
AbstractCopyOnWriteMap.EntrySet - Class in org.bson.util
 
AbstractCopyOnWriteMap.Immutable - Class in org.bson.util
 
AbstractCopyOnWriteMap.KeySet - Class in org.bson.util
 
AbstractCopyOnWriteMap.Mutable - Class in org.bson.util
 
AbstractCopyOnWriteMap.UnmodifiableIterator<T> - Class in org.bson.util
 
AbstractCopyOnWriteMap.Values - Class in org.bson.util
 
AbstractCopyOnWriteMap.View<K,V> - Class in org.bson.util
Provides access to the views of the underlying key, value and entry collections.
AbstractCopyOnWriteMap.View.Type - Enum in org.bson.util
The different types of AbstractCopyOnWriteMap.View available
AbstractGeometryCodec<T extends Geometry> - Class in com.mongodb.client.model.geojson.codecs
 
AbstractGeometryCodec(CodecRegistry, Class<T>) - Constructor for class com.mongodb.client.model.geojson.codecs.AbstractGeometryCodec
 
AbstractObjectSerializer - Class in com.mongodb.util
 
AbstractObjectSerializer() - Constructor for class com.mongodb.util.AbstractObjectSerializer
 
AbstractReferenceCounted - Class in com.mongodb.binding
 
AbstractReferenceCounted() - Constructor for class com.mongodb.binding.AbstractReferenceCounted
 
AbstractReferenceCounted - Class in com.mongodb.connection
 
AbstractReferenceCounted() - Constructor for class com.mongodb.connection.AbstractReferenceCounted
 
AbstractSubscription<TResult> - Class in com.mongodb.async.client
 
AbstractSubscription(Observer<? super TResult>) - Constructor for class com.mongodb.async.client.AbstractSubscription
 
acceptableLatencyDifferenceNanos - Variable in class com.mongodb.selector.LatencyMinimizingServerSelector
 
accumulator(String, String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
 
Accumulators - Class in com.mongodb.client.model
Builders for accumulators used in the group pipeline stage of an aggregation pipeline.
Accumulators() - Constructor for class com.mongodb.client.model.Accumulators
 
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
acknowledged - Variable in class com.mongodb.WriteResult
 
AcknowledgedBulkWriteResult - Class in com.mongodb
 
AcknowledgedBulkWriteResult(int, int, int, Integer, List<BulkWriteUpsert>) - Constructor for class com.mongodb.AcknowledgedBulkWriteResult
 
AcknowledgedDeleteResult(long) - Constructor for class com.mongodb.client.result.DeleteResult.AcknowledgedDeleteResult
 
AcknowledgedUpdateResult(long, Long, BsonValue) - Constructor for class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
acquirePermit(long, TimeUnit) - Method in class com.mongodb.internal.connection.ConcurrentPool
 
action(MapReduceAction) - Method in interface com.mongodb.async.client.MapReduceIterable
Specify the MapReduceAction to be used when writing to a collection.
action - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
action(MapReduceAction) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
action(MapReduceAction) - Method in interface com.mongodb.client.MapReduceIterable
Specify the MapReduceAction to be used when writing to a collection.
action - Variable in class com.mongodb.MapReduceIterableImpl
 
action(MapReduceAction) - Method in class com.mongodb.MapReduceIterableImpl
 
action - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
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(int) - Method in class com.mongodb.Bytes.OptionHolder
 
add(ConnectionPoolListener) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
Adds the given connection pool listener to the list of listeners to invoke on connection pool events.
add(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Inserts the specified element at the tail of this deque.
add(int, int) - Method in class com.mongodb.internal.connection.IndexMap
Add a new index to the map
add(int, int) - Method in class com.mongodb.internal.connection.IndexMap.HashBased
 
add(int, int) - Method in class com.mongodb.internal.connection.IndexMap.RangeBased
 
add(BsonValue) - Method in class com.mongodb.operation.BsonArrayWrapper
 
add(int, BsonValue) - Method in class com.mongodb.operation.BsonArrayWrapper
 
add(BsonValue) - Method in class org.bson.BsonArray
 
add(int, BsonValue) - Method in class org.bson.BsonArray
 
add(BsonValue) - Method in class org.bson.BsonDocumentWriter.Context
 
add(Object) - Method in class org.bson.LazyBSONList
 
add(int, Object) - Method in class org.bson.LazyBSONList
 
add(String) - Method in class org.bson.types.StringRangeSet
 
add(E) - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
addAll(Collection<? extends E>) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Appends all of the elements in the specified collection to the end of this deque, in the order that they are returned by the specified collection's iterator.
addAll(Collection<? extends BsonValue>) - Method in class com.mongodb.operation.BsonArrayWrapper
 
addAll(int, Collection<? extends BsonValue>) - Method in class com.mongodb.operation.BsonArrayWrapper
 
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
 
addAll(Collection<? extends String>) - Method in class org.bson.types.StringRangeSet
 
addAll(Collection<? extends E>) - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
addAll(Map<? extends K, ? extends V>) - Method in class org.bson.util.CopyOnWriteMap.Builder
Views are live (reflecting concurrent updates) and mutator methods are supported.
addBulkWriteResultToResponse(BulkWriteResult, BsonDocument) - Method in class com.mongodb.operation.BaseWriteOperation
 
addClassModel(ClassModel<?>) - Method in class org.bson.codecs.pojo.DiscriminatorLookup
 
addClause(BsonDocument, Map.Entry<String, BsonValue>) - Method in class com.mongodb.client.model.Filters.AndFilter
 
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.
addCodec(Codec<T>) - Method in class com.mongodb.operation.CommandResultCodecProvider
 
addCodec(Codec<T>) - Method in class org.bson.codecs.BsonValueCodecProvider
 
addCodec(Codec<T>) - Method in class org.bson.codecs.ValueCodecProvider
 
addCodecs() - Method in class com.mongodb.operation.CommandResultCodecProvider
 
addCodecs() - Method in class org.bson.codecs.BsonValueCodecProvider
 
addCodecs() - Method in class org.bson.codecs.ValueCodecProvider
 
addCollectibleDocument(BsonDocument, BsonOutput, FieldNameValidator) - Method in class com.mongodb.connection.RequestMessage
Appends a document to the message that is intended for storage in a collection.
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.
addCommonSerializers() - Static method in class com.mongodb.util.JSONSerializers
Deprecated.
 
addConnectionPoolListener(ConnectionPoolListener) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
Adds the given connection pool listener.
addConnectionPoolListener(ConnectionPoolListener) - Method in class com.mongodb.MongoClientOptions.Builder
Adds the given connection pool listener.
addCreatorPropertyToClassModelBuilder(ClassModelBuilder<T>, String, Class<S>) - Method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
addDecodingHook(Class<?>, Transformer) - Static method in class org.bson.BSON
Registers a Transformer to use when decoding a specific class from BSON.
addDefaults() - Method in class org.bson.codecs.BsonTypeClassMap
 
addDocument(BsonDocument, BsonOutput, FieldNameValidator) - Method in class com.mongodb.connection.RequestMessage
Appends a document to the message.
addDocument(BsonDocument, BsonOutput, FieldNameValidator, List<BsonElement>) - Method in class com.mongodb.connection.RequestMessage
 
addDocument(T, Encoder<T>, EncoderContext, BsonOutput, FieldNameValidator, int, List<BsonElement>) - Method in class com.mongodb.connection.RequestMessage
 
addDocumentWithPayload(BsonOutput, int) - Method in class com.mongodb.connection.CommandMessage
 
addDriverInformation(MongoDriverInformation, BsonDocument) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
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
AddFieldsStage(List<Field<?>>) - Constructor for class com.mongodb.client.model.Aggregates.AddFieldsStage
 
addFirst(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Inserts the specified element at the front of this deque.
addFSync(BsonDocument) - Method in class com.mongodb.WriteConcern
 
addHostsToSet(Set<String>, Set<ServerAddress>) - Method in class com.mongodb.connection.MultiServerCluster
 
addIndex(int) - Method in class org.bson.codecs.pojo.TypeParameterMap.Builder
Adds the type parameter index for a class that represents the whole property
addIndex(int, int) - Method in class org.bson.codecs.pojo.TypeParameterMap.Builder
Adds a mapping that represents the property
additionalFieldsToString() - Method in class com.mongodb.client.model.Updates.PushUpdate
 
additionalFieldsToString() - Method in class com.mongodb.client.model.Updates.WithEachUpdate
 
addJ(BsonDocument) - Method in class com.mongodb.WriteConcern
 
addLast(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Inserts the specified element at the end of this deque.
addNewHosts(Set<String>) - Method in class com.mongodb.connection.MultiServerCluster
 
addObjectSerializer(Class, ObjectSerializer) - Method in class com.mongodb.util.ClassMapBasedObjectSerializer
Assign a ObjectSerializer to perform a type specific serialization scheme
addOperand(String, Object) - Method in class com.mongodb.QueryBuilder
 
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
addOrphanedCursor(ServerCursor, MongoNamespace) - Method in class com.mongodb.Mongo
 
addProperty(PropertyModelBuilder<?>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
addReadAnnotation(Annotation) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
addRequest(WriteRequest) - Method in class com.mongodb.BulkWriteOperation
 
address - Variable in class com.mongodb.CommandResult
 
address - Variable in class com.mongodb.connection.netty.NettyStream
 
address - Variable in class com.mongodb.connection.ServerDescription
 
address - Variable in class com.mongodb.connection.ServerDescription.Builder
 
address(ServerAddress) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the address of the server.
address - Variable in class com.mongodb.connection.ServerId
 
address - Variable in class com.mongodb.connection.SocketChannelStream
 
address - Variable in class com.mongodb.connection.SocketStream
 
address - Variable in class com.mongodb.ServerCursor
 
addressToServerTupleMap - Variable in class com.mongodb.connection.MultiServerCluster
 
addResult(BulkWriteResult, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Add a result
addResult(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
addSample(long) - Method in class com.mongodb.connection.ExponentiallyWeightedMovingAverage
 
addServer(ServerAddress) - Method in class com.mongodb.connection.MultiServerCluster
 
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 monitor listener.
addSpecial(String, Object) - Method in class com.mongodb.DBCursor
Adds a special operator like $maxScan or $returnKey.
addToCache(PropertyModel<S>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
addToQueue(TResult) - Method in class com.mongodb.async.client.AbstractSubscription
 
addToQueue(List<TResult>) - Method in class com.mongodb.async.client.AbstractSubscription
 
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
addTypeParameter(TypeData<S>) - Method in class org.bson.codecs.pojo.TypeData.Builder
Adds a type parameter
addTypeParameters(List<TypeData<?>>) - Method in class org.bson.codecs.pojo.TypeData.Builder
Adds multiple type parameters
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
addW(BsonDocument) - Method in class com.mongodb.WriteConcern
 
addWriteAnnotation(Annotation) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
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
addWTimeout(BsonDocument) - Method in class com.mongodb.WriteConcern
 
adjustTimeout(boolean) - Method in class com.mongodb.connection.netty.NettyStream
 
ADMIN_DATABASE_NAME - Static variable in class com.mongodb.Mongo
 
advance(BsonDocument) - Method in class com.mongodb.connection.ClusterClock
 
advanceClusterTime(BsonDocument) - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
advanceClusterTime(BsonDocument) - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
advanceClusterTime(BsonDocument) - Method in class com.mongodb.internal.session.ClientSessionContext
 
advanceClusterTime(BsonDocument) - Method in class com.mongodb.internal.session.ClientSessionImpl
 
advanceClusterTime(BsonDocument) - Method in interface com.mongodb.session.ClientSession
 
advanceClusterTime(BsonDocument) - Method in interface com.mongodb.session.SessionContext
Advance the cluster time.
advanceOperationTime(BsonTimestamp) - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
advanceOperationTime(BsonTimestamp) - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
advanceOperationTime(BsonTimestamp) - Method in class com.mongodb.internal.session.ClientSessionContext
 
advanceOperationTime(BsonTimestamp) - Method in class com.mongodb.internal.session.ClientSessionImpl
 
advanceOperationTime(BsonTimestamp) - Method in interface com.mongodb.session.ClientSession
Set the operation time of the last operation executed in this session.
advanceOperationTime(BsonTimestamp) - Method in interface com.mongodb.session.SessionContext
Advance the operation time.
advanceTransactionNumber() - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
advanceTransactionNumber() - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
advanceTransactionNumber() - Method in class com.mongodb.internal.session.ClientSessionContext
 
advanceTransactionNumber() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
advanceTransactionNumber() - Method in interface com.mongodb.session.ServerSession
Return the next available transaction number.
advanceTransactionNumber() - Method in interface com.mongodb.session.SessionContext
Advance the transaction number.
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(ClientSession, List<? extends Bson>) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified aggregation pipeline.
aggregate(ClientSession, 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 class com.mongodb.async.client.MongoCollectionImpl
 
aggregate(List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
aggregate(ClientSession, List<? extends Bson>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
aggregate(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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(ClientSession, List<? extends Bson>) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified aggregation pipeline.
aggregate(ClientSession, 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
aggregate(List<? extends DBObject>, ReadPreference) - Method in class com.mongodb.DBCollection
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.
aggregate(List<? extends DBObject>, AggregationOptions, ReadPreference, boolean) - Method in class com.mongodb.DBCollection
 
aggregate(List<? extends Bson>) - Method in class com.mongodb.MongoCollectionImpl
 
aggregate(List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
aggregate(ClientSession, List<? extends Bson>) - Method in class com.mongodb.MongoCollectionImpl
 
aggregate(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
AggregateExplainOperation - Class in com.mongodb.operation
 
AggregateExplainOperation(MongoNamespace, List<BsonDocument>) - Constructor for class com.mongodb.operation.AggregateExplainOperation
 
AggregateIterable<TResult> - Interface in com.mongodb.async.client
Iterable for aggregate.
AggregateIterable<TResult> - Interface in com.mongodb.client
Iterable for aggregate.
AggregateIterableImpl<TDocument,TResult> - Class in com.mongodb
 
AggregateIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, WriteConcern, OperationExecutor, List<? extends Bson>) - Constructor for class com.mongodb.AggregateIterableImpl
 
AggregateIterableImpl<TDocument,TResult> - Class in com.mongodb.async.client
 
AggregateIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, WriteConcern, AsyncOperationExecutor, List<? extends Bson>) - Constructor for class com.mongodb.async.client.AggregateIterableImpl
 
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.
Aggregates() - Constructor for class com.mongodb.client.model.Aggregates
 
Aggregates.AddFieldsStage - Class in com.mongodb.client.model
 
Aggregates.BucketAutoStage<TExpression> - Class in com.mongodb.client.model
 
Aggregates.BucketStage<TExpression,TBoundary> - Class in com.mongodb.client.model
 
Aggregates.FacetStage - Class in com.mongodb.client.model
 
Aggregates.GraphLookupStage<TExpression> - Class in com.mongodb.client.model
 
Aggregates.GroupStage<TExpression> - Class in com.mongodb.client.model
 
Aggregates.ReplaceRootStage<TExpression> - Class in com.mongodb.client.model
 
Aggregates.SimplePipelineStage - Class in com.mongodb.client.model
 
Aggregates.SortByCountStage<TExpression> - Class in com.mongodb.client.model
 
aggregateToCollectionOperation - Variable in class com.mongodb.async.client.AggregateToCollectionThenFindOperation
 
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.
AggregateToCollectionThenFindOperation<T> - Class in com.mongodb.async.client
 
AggregateToCollectionThenFindOperation(AsyncWriteOperation<Void>, FindOperation<T>) - Constructor for class com.mongodb.async.client.AggregateToCollectionThenFindOperation
 
AggregationOptions - Class in com.mongodb
The options to apply to an aggregate operation.
AggregationOptions(AggregationOptions.Builder) - Constructor for class com.mongodb.AggregationOptions
 
AggregationOptions.Builder - Class in com.mongodb
Builder for creating AggregationOptions.
AggregationOptions.OutputMode - Enum in com.mongodb
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
AggregationOutput - Class in com.mongodb
Deprecated.
Replace with use of aggregate methods in DBCollection that return instances of Cursor.
AggregationOutput(List<DBObject>) - Constructor for class com.mongodb.AggregationOutput
Deprecated.
 
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 - Variable in class com.mongodb.DBCursor
 
all(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $all operand
ALL - Static variable in class com.mongodb.QueryOperators
 
ALL_KEYS - Static variable in class com.mongodb.ConnectionString
 
allocator - Variable in class com.mongodb.connection.netty.NettyBufferProvider
 
allocator - Variable in class com.mongodb.connection.netty.NettyStream
 
allocator - Variable in class com.mongodb.connection.netty.NettyStreamFactory
 
allocator - Variable in class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
allocator - Variable in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
 
allocator(ByteBufAllocator) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
Sets the allocator.
allowDiskUse - Variable in class com.mongodb.AggregateIterableImpl
 
allowDiskUse(Boolean) - Method in class com.mongodb.AggregateIterableImpl
 
allowDiskUse - Variable in class com.mongodb.AggregationOptions
 
allowDiskUse - Variable in class com.mongodb.AggregationOptions.Builder
 
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 - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
allowDiskUse(Boolean) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
allowDiskUse(Boolean) - Method in interface com.mongodb.client.AggregateIterable
Enables writing to temporary files.
allowDiskUse - Variable in class com.mongodb.operation.AggregateExplainOperation
 
allowDiskUse(Boolean) - Method in class com.mongodb.operation.AggregateExplainOperation
Enables writing to temporary files.
allowDiskUse - Variable in class com.mongodb.operation.AggregateOperation
 
allowDiskUse(Boolean) - Method in class com.mongodb.operation.AggregateOperation
Enables writing to temporary files.
allowDiskUse - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
allowDiskUse(Boolean) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Enables writing to temporary files.
ALLOWED_OPTIONS_IN_TXT_RECORD - Static variable in class com.mongodb.ConnectionString
 
alpha - Variable in class com.mongodb.connection.ExponentiallyWeightedMovingAverage
 
alternate - Variable in class com.mongodb.client.model.Collation
 
alternate - Variable in class com.mongodb.client.model.Collation.Builder
 
alwaysUseMBeans - Variable in class com.mongodb.MongoClientOptions
 
alwaysUseMBeans - Variable in class com.mongodb.MongoClientOptions.Builder
 
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
 
AndFilter(Iterable<Bson>) - Constructor for class com.mongodb.client.model.Filters.AndFilter
 
ANNOTATION_CONVENTION - Static variable in class org.bson.codecs.pojo.Conventions
The annotation convention.
annotations - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
annotations(List<Annotation>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Sets the annotations for the model
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, BsonValue) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
append(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Tries to insert a node holding element as successor, failing if this node is deleted.
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
 
appendReadConcernToCommand(ReadConcern, SessionContext, BsonDocument) - Static method in class com.mongodb.operation.ReadConcernHelper
 
appendWriteConcernToCommand(WriteConcern, BsonDocument, ConnectionDescription) - Static method in class com.mongodb.operation.WriteConcernHelper
 
APPLICATION_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
APPLICATION_NAME_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
applicationName - Variable in class com.mongodb.async.client.MongoClientSettings
 
applicationName - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
applicationName(String) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the logical name of the application using this MongoClient.
applicationName - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
applicationName - Variable in class com.mongodb.ConnectionString
 
applicationName - Variable in class com.mongodb.MongoClientOptions
 
applicationName - Variable in class com.mongodb.MongoClientOptions.Builder
 
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(ServerDescription) - Method in interface com.mongodb.connection.ClusterDescription.Predicate
 
apply(T) - Method in interface com.mongodb.Function
Yield an appropriate result object for the input object.
apply(AsyncBatchCursor<RawBsonDocument>, SingleResultCallback<List<RawBsonDocument>>) - Method in interface com.mongodb.operation.AsyncChangeStreamBatchCursor.AsyncBlock
 
apply(T, ServerAddress) - Method in interface com.mongodb.operation.CommandOperationHelper.CommandTransformer
Yield an appropriate result object for the input object.
apply(T, ServerAddress) - Method in class com.mongodb.operation.CommandOperationHelper.IdentityTransformer
 
apply(ClassModelBuilder<?>) - Method in interface org.bson.codecs.pojo.Convention
This method applies this Convention to the given ClassModelBuilder
apply(ClassModelBuilder<?>) - Method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
apply(ClassModelBuilder<?>) - Method in class org.bson.codecs.pojo.ConventionDefaultsImpl
 
apply(ClassModelBuilder<?>) - Method in class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl
 
apply(ClassModelBuilder<?>) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl
 
apply(Class<?>) - Method in class org.bson.util.ClassMap.ComputeFunction
 
apply(K) - Method in class org.bson.util.ComputingMap
 
apply(A) - Method in interface org.bson.util.Function
 
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.
applyGetLastErrorResult(BsonDocument, ConnectionDescription) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
arbiters - Variable in class com.mongodb.connection.ServerDescription
 
arbiters - Variable in class com.mongodb.connection.ServerDescription.Builder
 
arbiters(Set<String>) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the arbiters in the replica set
areEquivalentTypes(Class<S>, Class<V>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
array() - Method in class com.mongodb.connection.CompositeByteBuf
 
array() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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
 
arrayFilters - Variable in class com.mongodb.bulk.UpdateRequest
 
arrayFilters(List<BsonDocument>) - Method in class com.mongodb.bulk.UpdateRequest
Sets the array filters option
arrayFilters - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
arrayFilters(List<? extends DBObject>) - Method in class com.mongodb.BulkWriteRequestBuilder
Specifies that the request being built should use the given array filters for an update.
arrayFilters - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
arrayFilters(List<? extends DBObject>) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the array filters option
arrayFilters - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
arrayFilters(List<? extends DBObject>) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the array filters option
arrayFilters - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
arrayFilters(List<? extends Bson>) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the array filters option
arrayFilters - Variable in class com.mongodb.client.model.UpdateOptions
 
arrayFilters(List<? extends Bson>) - Method in class com.mongodb.client.model.UpdateOptions
Sets the array filters option
arrayFilters - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
arrayFilters(List<BsonDocument>) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the array filters option
arrayFilters - Variable in class com.mongodb.UpdateRequest
 
arrayIterator - Variable in class org.bson.BsonDocumentReader.Context
 
arrayStart(String) - Method in class com.mongodb.util.JSONCallback
Deprecated.
 
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
 
as - Variable in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
asArray() - Method in class org.bson.BsonValue
Gets this value as a BsonArray if it is one, otherwise throws exception
asAsyncReadOperation() - Method in class com.mongodb.async.client.AggregateIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.DistinctIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.FindIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.ListCollectionsIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.ListDatabasesIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.ListIndexesIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
asAsyncReadOperation() - Method in class com.mongodb.async.client.MongoIterableImpl
 
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
asByteBuf() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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.
asCollectionInsertDocument(MongoCredential, boolean) - Static method in class com.mongodb.operation.UserOperationHelper
 
asCollectionQueryDocument(MongoCredential) - Static method in class com.mongodb.operation.UserOperationHelper
 
asCollectionUpdateDocument(MongoCredential, boolean) - Static method in class com.mongodb.operation.UserOperationHelper
 
asCommandDocument() - Method in class com.mongodb.connection.KillCursorProtocol
 
asCommandDocument(MongoCredential, boolean, String) - Static method in class com.mongodb.operation.UserOperationHelper
 
asCommandResponseDocument() - Method in class com.mongodb.connection.KillCursorProtocol
 
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(ConnectionDescription, ReadPreference) - Method in class com.mongodb.operation.FindOperation
 
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
asDocumentOrNull(BsonDocument) - Method in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
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.AggregateToCollectionOperation
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.
asExplainCommand(BsonDocument, ExplainVerbosity) - Static method in class com.mongodb.operation.ExplainHelper
 
asFindCommandDocument(ByteBufferBsonOutput, int) - Method in class com.mongodb.connection.QueryProtocol
 
asFindCommandResponseDocument(ResponseBuffers, QueryResult<T>, boolean) - Method in class com.mongodb.connection.QueryProtocol
 
asGetMoreCommandDocument() - Method in class com.mongodb.connection.GetMoreProtocol
 
asGetMoreCommandDocument(long) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
asGetMoreCommandDocument() - Method in class com.mongodb.operation.QueryBatchCursor
 
asGetMoreCommandResponseDocument(QueryResult<T>, ResponseBuffers) - Method in class com.mongodb.connection.GetMoreProtocol
 
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
asKillCursorsCommandDocument(ServerCursor) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
asKillCursorsCommandDocument() - Method in class com.mongodb.operation.QueryBatchCursor
 
asNIO() - Method in class com.mongodb.connection.CompositeByteBuf
 
asNIO() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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
asQueryDocument(ConnectionDescription, ReadPreference) - Method in class com.mongodb.operation.ListCollectionsOperation
 
asQueryDocument(ConnectionDescription, ReadPreference) - Method in class com.mongodb.operation.ListIndexesOperation
 
asReadOnly() - Method in class com.mongodb.connection.CompositeByteBuf
 
asReadOnly() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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
 
asReadOperation() - Method in class com.mongodb.AggregateIterableImpl
 
asReadOperation() - Method in class com.mongodb.ChangeStreamIterableImpl
 
asReadOperation() - Method in class com.mongodb.DistinctIterableImpl
 
asReadOperation() - Method in class com.mongodb.FindIterableImpl
 
asReadOperation() - Method in class com.mongodb.ListCollectionsIterableImpl
 
asReadOperation() - Method in class com.mongodb.ListDatabasesIterableImpl
 
asReadOperation() - Method in class com.mongodb.ListIndexesIterableImpl
 
asReadOperation() - Method in class com.mongodb.MapReduceIterableImpl
 
asReadOperation() - Method in class com.mongodb.MongoIterableImpl
 
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() - Constructor for class com.mongodb.assertions.Assertions
 
Assertions - Class in org.bson.assertions
Design by contract assertions.
Assertions() - Constructor for class org.bson.assertions.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
asValueOrNull(BsonValue) - Static method in class com.mongodb.operation.MapReduceToCollectionOperation
 
asValueOrNull(BsonValue) - Static method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
AsyncBatchCursor<T> - Interface in com.mongodb.async
MongoDB returns query results as batches, and this interface provides an asynchronous iterator over those batches.
AsyncCallableWithConnectionAndSourceCallback(OperationHelper.AsyncCallableWithConnectionAndSource) - Constructor for class com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionAndSourceCallback
 
AsyncCallableWithConnectionCallback(OperationHelper.AsyncCallableWithConnection) - Constructor for class com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionCallback
 
AsyncChangeStreamBatchCursor<T> - Class in com.mongodb.operation
 
AsyncChangeStreamBatchCursor(ChangeStreamOperation<T>, AsyncBatchCursor<RawBsonDocument>, AsyncReadBinding) - Constructor for class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
AsyncChangeStreamBatchCursor.AsyncBlock - Interface in com.mongodb.operation
 
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.
AsyncClusterBinding.AsyncClusterBindingConnectionSource - Class in com.mongodb.binding
 
AsyncClusterBindingConnectionSource(Server) - Constructor for class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
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.
asyncGetter - Variable in class com.mongodb.connection.DefaultConnectionPool
 
AsynchronousChannelHelper - Class in com.mongodb.async.client.gridfs.helpers
A helper class to convert to AsynchronousByteChannel or AsynchronousFileChannel instances into AsyncInputStream or AsyncOutputStream instances.
AsynchronousChannelHelper() - Constructor for class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
 
AsynchronousSocketChannelStream - Class in com.mongodb.connection
 
AsynchronousSocketChannelStream(ServerAddress, SocketSettings, BufferProvider, AsynchronousChannelGroup) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStream
 
AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter - Class in com.mongodb.connection
 
AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter.WriteCompletionHandler - Class in com.mongodb.connection
 
AsynchronousSocketChannelStream.BaseCompletionHandler<T,V,A> - Class in com.mongodb.connection
 
AsynchronousSocketChannelStream.BasicCompletionHandler - Class in com.mongodb.connection
 
AsynchronousSocketChannelStream.OpenCompletionHandler - Class in com.mongodb.connection
 
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 with the default BufferProvider and AsynchronousChannelGroup.
AsynchronousSocketChannelStreamFactory(SocketSettings, SslSettings, AsynchronousChannelGroup) - 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
Deprecated.
Use AsynchronousSocketChannelStreamFactoryFactory.builder() instead to construct the AsynchronousSocketChannelStreamFactoryFactory.
AsynchronousSocketChannelStreamFactoryFactory(AsynchronousSocketChannelStreamFactoryFactory.Builder) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory
 
AsynchronousSocketChannelStreamFactoryFactory.Builder - Class in com.mongodb.connection
A builder for an instance of 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.
AsyncOperationExecutorImpl - Class in com.mongodb.async.client
 
AsyncOperationExecutorImpl(MongoClientImpl, ClientSessionHelper) - Constructor for class com.mongodb.async.client.AsyncOperationExecutorImpl
 
AsyncOutputStream - Interface in com.mongodb.async.client.gridfs
The Async Output Stream interface represents some asynchronous output stream of bytes.
AsyncQueryBatchCursor<T> - Class in com.mongodb.operation
 
AsyncQueryBatchCursor(QueryResult<T>, int, int, long, Decoder<T>, AsyncConnectionSource, AsyncConnection) - Constructor for class com.mongodb.operation.AsyncQueryBatchCursor
 
AsyncQueryBatchCursor.CommandResultSingleResultCallback - Class in com.mongodb.operation
 
AsyncQueryBatchCursor.QueryResultSingleResultCallback - Class in com.mongodb.operation
 
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.
AsyncSingleBatchQueryCursor<T> - Class in com.mongodb.operation
 
AsyncSingleBatchQueryCursor(QueryResult<T>) - Constructor for class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
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.
AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource - Class in com.mongodb.binding
 
AsyncSingleConnectionSource() - Constructor for class com.mongodb.binding.AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource
 
AsyncStreamHelper - Class in com.mongodb.async.client.gridfs.helpers
A general helper class that creates AsyncInputStream or AsyncOutputStream instances.
AsyncStreamHelper() - Constructor for class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
 
asyncTransformer(AsyncConnectionSource, AsyncConnection) - Method in class com.mongodb.operation.AggregateOperation
 
asyncTransformer(ConnectionDescription) - Method in class com.mongodb.operation.DistinctOperation
 
asyncTransformer(AsyncConnectionSource, AsyncConnection) - Method in class com.mongodb.operation.FindOperation
 
asyncTransformer(AsyncConnection) - Method in class com.mongodb.operation.GroupOperation
 
asyncTransformer(AsyncConnectionSource, AsyncConnection) - Method in class com.mongodb.operation.ListCollectionsOperation
 
asyncTransformer(AsyncConnectionSource, AsyncConnection) - Method in class com.mongodb.operation.ListDatabasesOperation
 
asyncTransformer(AsyncConnectionSource, AsyncConnection) - Method in class com.mongodb.operation.ListIndexesOperation
 
asyncTransformer(AsyncConnection) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
asyncTransformer(AsyncConnectionSource, AsyncConnection) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
AsyncWritableByteChannel - Interface in com.mongodb.connection
An asynchronous channel that can write bytes.
AsyncWritableByteChannelAdapter() - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter
 
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
 
AUTH_KEYS - Static variable in class com.mongodb.ConnectionString
 
AUTH_MAP - Static variable in enum com.mongodb.AuthenticationMechanism
 
authenticate(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.Authenticator
 
authenticate(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.DefaultAuthenticator
 
authenticate(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.NativeAuthenticator
 
authenticate(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.SaslAuthenticator
 
authenticate(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.X509Authenticator
 
authenticateAll(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
authenticateAsync(InternalConnection, ConnectionDescription, SingleResultCallback<Void>) - Method in class com.mongodb.connection.Authenticator
 
authenticateAsync(InternalConnection, ConnectionDescription, SingleResultCallback<Void>) - Method in class com.mongodb.connection.DefaultAuthenticator
 
authenticateAsync(InternalConnection, ConnectionDescription, SingleResultCallback<Void>) - Method in class com.mongodb.connection.NativeAuthenticator
 
authenticateAsync(InternalConnection, ConnectionDescription, SingleResultCallback<Void>) - Method in class com.mongodb.connection.SaslAuthenticator
 
authenticateAsync(InternalConnection, ConnectionDescription, SingleResultCallback<Void>) - Method in class com.mongodb.connection.X509Authenticator
 
authenticateNext() - Method in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
AuthenticationMechanism - Enum in com.mongodb
An enumeration of the MongodDB-supported authentication mechanisms.
AuthenticationMechanism(String) - Constructor for enum com.mongodb.AuthenticationMechanism
 
Authenticator - Class in com.mongodb.connection
 
Authenticator(MongoCredential) - Constructor for class com.mongodb.connection.Authenticator
 
authenticators - Variable in class com.mongodb.connection.InternalStreamConnectionFactory
 
authenticators - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer
 
autoIndex - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
autoIndex(boolean) - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets if auto-index is to be enabled on the collection
autoIndex - Variable in class com.mongodb.operation.CreateCollectionOperation
 
autoIndex(boolean) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets if _id field of the collection is indexed.
automatic - Variable in class org.bson.codecs.pojo.PojoCodecProvider
 
automatic - Variable in class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
automatic(boolean) - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Sets whether the provider should automatically try to create a ClassModel for any class that is requested.
AutomaticPojoCodec<T> - Class in org.bson.codecs.pojo
 
AutomaticPojoCodec(PojoCodec<T>) - Constructor for class org.bson.codecs.pojo.AutomaticPojoCodec
 
available() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
available() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
available() - Method in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
available - Variable in class com.mongodb.internal.connection.ConcurrentPool
 
average - Variable in class com.mongodb.connection.ExponentiallyWeightedMovingAverage
 
averageRoundTripTime - Variable in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
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.
awaitData - Variable in class com.mongodb.connection.BaseQueryMessage
 
awaitData(boolean) - Method in class com.mongodb.connection.BaseQueryMessage
Sets if the cursor should await for data.
awaitData - Variable in class com.mongodb.connection.QueryProtocol
 
awaitData(boolean) - Method in class com.mongodb.connection.QueryProtocol
Sets if the cursor should await for data.

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
 
back() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns previous node containing a nondeleted user element, if possible.
background - Variable in class com.mongodb.bulk.IndexRequest
 
background(boolean) - Method in class com.mongodb.bulk.IndexRequest
Should the index should be created in the background
background - Variable in class com.mongodb.client.model.IndexOptions
 
background(boolean) - Method in class com.mongodb.client.model.IndexOptions
Should the index should be created in the background
backpatchMessageLength(int, BsonOutput) - Method in class com.mongodb.connection.RequestMessage
Backpatches the message length into the beginning of the message.
backpatchSize() - Method in class org.bson.BsonBinaryWriter
 
backwards - Variable in class com.mongodb.client.model.Collation
 
backwards - Variable in class com.mongodb.client.model.Collation.Builder
 
backwards(Boolean) - Method in class com.mongodb.client.model.Collation.Builder
Sets the backwards value
Base64 - Class in org.bson.internal
Provides Base64 encoding and decoding.
Base64() - Constructor for class org.bson.internal.Base64
 
BaseCluster - Class in com.mongodb.connection
 
BaseCluster(ClusterId, ClusterSettings, ClusterableServerFactory) - Constructor for class com.mongodb.connection.BaseCluster
 
BaseCluster.ServerSelectionRequest - Class in com.mongodb.connection
 
BaseCluster.WaitQueueHandler - Class in com.mongodb.connection
 
BaseCompletionHandler(AsyncCompletionHandler<T>) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStream.BaseCompletionHandler
 
BaseFindAndModifyOperation<T> - Class in com.mongodb.operation
 
BaseFindAndModifyOperation() - Constructor for class com.mongodb.operation.BaseFindAndModifyOperation
 
baseIterator - Variable in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
BaseQueryMessage - Class in com.mongodb.connection
Base class for OP_QUERY messages.
BaseQueryMessage(String, int, int, MessageSettings) - Constructor for class com.mongodb.connection.BaseQueryMessage
 
BaseWriteOperation - Class in com.mongodb.operation
Abstract base class for write operations.
BaseWriteOperation(MongoNamespace, boolean, WriteConcern) - Constructor for class com.mongodb.operation.BaseWriteOperation
BaseWriteOperation(MongoNamespace, boolean, WriteConcern, boolean) - 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.
BasicCompletionHandler(ByteBuf, AsyncCompletionHandler<ByteBuf>) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStream.BasicCompletionHandler
 
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.
BasicDBObjectFactory - Class in com.mongodb
 
BasicDBObjectFactory() - Constructor for class com.mongodb.BasicDBObjectFactory
 
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<GridFSFile>>) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
batchCursor - Variable in class com.mongodb.async.client.MappingAsyncBatchCursor
 
batchCursor(SingleResultCallback<AsyncBatchCursor<V>>) - Method in class com.mongodb.async.client.MappingIterable
 
batchCursor(SingleResultCallback<AsyncBatchCursor<TResult>>) - Method in interface com.mongodb.async.client.MongoIterable
Provide the underlying AsyncBatchCursor allowing fine grained control of the cursor.
batchCursor(SingleResultCallback<AsyncBatchCursor<TResult>>) - Method in class com.mongodb.async.client.MongoIterableImpl
 
batchCursor - Variable in class com.mongodb.async.client.MongoIterableSubscription
 
batchCursor - Variable in class com.mongodb.MongoBatchCursorAdapter
 
BatchCursor<T> - Interface in com.mongodb.operation
MongoDB returns query results as batches, and this interface provideds an iterator over those batches.
batchSize(int) - Method in class com.mongodb.AggregateIterableImpl
 
batchSize - Variable in class com.mongodb.AggregationOptions
 
batchSize - Variable in class com.mongodb.AggregationOptions.Builder
 
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 class com.mongodb.async.client.AggregateIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.ChangeStreamIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.DistinctIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.FindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.FindIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.gridfs.GridFSDownloadStream
Sets the number of chunks to return per batch.
batchSize - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
batchSize(int) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.ListCollectionsIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.ListCollectionsIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.ListDatabasesIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.ListDatabasesIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.ListIndexesIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.ListIndexesIterableImpl
 
batchSize(int) - Method in class com.mongodb.async.client.MappingIterable
 
batchSize(int) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
batchSize(int) - Method in interface com.mongodb.async.client.MongoIterable
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.async.client.MongoIterableImpl
 
batchSize(int) - Method in class com.mongodb.async.client.MongoIterableImpl
 
batchSize(int) - Method in class com.mongodb.ChangeStreamIterableImpl
 
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.ChangeStreamIterable
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 - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
batchSize(int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
batchSize(int) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the number of documents to return per batch.
batchSize(int) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
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 - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
batchSize(int) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.client.model.FindOptions
 
batchSize(int) - Method in class com.mongodb.client.model.FindOptions
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.client.model.ParallelCollectionScanOptions
Deprecated.
 
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 - Variable in class com.mongodb.connection.QueryProtocol
 
batchSize(int) - Method in class com.mongodb.DBCursor
Limits the number of elements returned in one batch.
batchSize(int) - Method in class com.mongodb.DistinctIterableImpl
 
batchSize(int) - Method in class com.mongodb.FindIterableImpl
 
batchSize(int) - Method in class com.mongodb.ListCollectionsIterableImpl
 
batchSize(int) - Method in class com.mongodb.ListDatabasesIterableImpl
 
batchSize(int) - Method in class com.mongodb.ListIndexesIterableImpl
 
batchSize(int) - Method in class com.mongodb.MappingIterable
 
batchSize(int) - Method in class com.mongodb.MapReduceIterableImpl
 
batchSize - Variable in class com.mongodb.MongoIterableImpl
 
batchSize(int) - Method in class com.mongodb.MongoIterableImpl
 
batchSize - Variable in class com.mongodb.operation.AggregateOperation
 
batchSize(Integer) - Method in class com.mongodb.operation.AggregateOperation
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
batchSize - Variable in class com.mongodb.operation.ChangeStreamOperation
 
batchSize(Integer) - Method in class com.mongodb.operation.ChangeStreamOperation
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.operation.FindOperation
 
batchSize(int) - Method in class com.mongodb.operation.FindOperation
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.operation.ListCollectionsOperation
 
batchSize(int) - Method in class com.mongodb.operation.ListCollectionsOperation
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.operation.ListIndexesOperation
 
batchSize(int) - Method in class com.mongodb.operation.ListIndexesOperation
Sets the number of documents to return per batch.
batchSize - Variable in class com.mongodb.operation.ParallelCollectionScanOperation
 
batchSize(int) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
The batch size to use for each cursor.
batchSize - Variable in class com.mongodb.operation.QueryBatchCursor
 
batchSize - Variable in class com.mongodb.ParallelScanOptions
 
batchSize - Variable in class com.mongodb.ParallelScanOptions.Builder
 
batchSize(int) - Method in class com.mongodb.ParallelScanOptions.Builder
The batch size to use for each cursor.
batchType - Variable in class com.mongodb.operation.BulkWriteBatch
 
beforeFields(BsonWriter, EncoderContext, DBObject) - Method in class com.mongodb.DBObjectCodec
 
beforeFields(BsonWriter, EncoderContext, BsonDocument) - Method in class org.bson.codecs.BsonDocumentCodec
 
beforeFields(BsonWriter, EncoderContext, Map<String, Object>) - Method in class org.bson.codecs.DocumentCodec
 
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.
BIG_INT_ONE - Static variable in class org.bson.types.Decimal128
 
BIG_INT_TEN - Static variable in class org.bson.types.Decimal128
 
BIG_INT_ZERO - Static variable in class org.bson.types.Decimal128
 
BigDecimalCodec - Class in org.bson.codecs
Encodes and decodes BigDecimal objects.
BigDecimalCodec() - Constructor for class org.bson.codecs.BigDecimalCodec
 
bigDecimalValue() - Method in class org.bson.types.Decimal128
Gets a BigDecimal that is equivalent to this Decimal128.
bigDecimalValueNoNegativeZeroCheck() - Method in class org.bson.types.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
 
binaryConverter - Variable in class org.bson.json.JsonWriterSettings
 
binaryConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
binaryConverter(Converter<BsonBinary>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Binary values to JSON.
BinarySerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.BinarySerializer
Deprecated.
 
BinarySerializerBase(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.BinarySerializerBase
Deprecated.
 
binaryWriterSettings - Variable in class org.bson.BsonBinaryWriter
 
binding - Variable in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
binding - Variable in class com.mongodb.operation.ChangeStreamBatchCursor
 
bits - Variable in class com.mongodb.bulk.IndexRequest
 
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 - Variable in class com.mongodb.client.model.IndexOptions
 
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 - Variable in class com.mongodb.async.client.FlatteningSingleResultCallbackSubscription
 
block - Variable in class com.mongodb.async.client.SingleResultCallbackSubscription
 
Block<T> - Interface in com.mongodb
An interface for applying some logic against the given parameter.
bodyByteBuffer - Variable in class com.mongodb.connection.ResponseBuffers
 
bodyByteBufferStartPosition - Variable in class com.mongodb.connection.ResponseBuffers
 
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
 
booleanConverter - Variable in class org.bson.json.JsonWriterSettings
 
booleanConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
booleanConverter(Converter<Boolean>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Boolean values to JSON.
boundaries - Variable in class com.mongodb.client.model.Aggregates.BucketStage
 
BOX - Static variable in class com.mongodb.QueryOperators
 
boxType(Class<S>) - Method in class org.bson.codecs.pojo.TypeData
 
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.
BSON_DOCUMENT_CODEC - Static variable in class com.mongodb.client.model.changestream.ChangeStreamDocumentCodec
 
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() - Constructor for class org.bson.codecs.BsonArrayCodec
Creates a new instance with a default codec registry that uses the BsonValueCodecProvider.
BsonArrayCodec(CodecRegistry) - Constructor for class org.bson.codecs.BsonArrayCodec
Construct an instance with the given registry
BsonArrayWrapper<T> - Class in com.mongodb.operation
 
BsonArrayWrapper(List<T>) - Constructor for class com.mongodb.operation.BsonArrayWrapper
 
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
BsonBinarySubType(byte) - Constructor for enum org.bson.BsonBinarySubType
 
bsonBinaryWriter - Variable in class com.mongodb.connection.LevelCountingBsonWriter
 
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.
bsonCallback - Variable in class org.bson.BSONCallbackAdapter
 
BSONCallbackAdapter - Class in org.bson
 
BSONCallbackAdapter(BsonWriterSettings, BSONCallback) - Constructor for class org.bson.BSONCallbackAdapter
Initializes a new instance of the BsonWriter class.
BSONCallbackAdapter.Context - Class in org.bson
 
BsonContextType - Enum in org.bson
Used by BsonReader and BsonWriter implementations to represent the current context.
BsonContextType() - Constructor for enum org.bson.BsonContextType
 
BsonCreator - Annotation Type in org.bson.codecs.pojo.annotations
An annotation that configures a constructor or method as the Creator for the Pojo.
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.
BsonDiscriminator - Annotation Type in org.bson.codecs.pojo.annotations
An annotation that configures the discriminator key and value for a class.
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.
BsonDocument.SerializationProxy - Class in org.bson
 
bsonDocumentCodec - Variable in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
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.
bsonDocumentCodec - Variable in class org.bson.codecs.BsonDocumentWrapperCodec
 
BsonDocumentMarkableIterator(Iterator<T>) - Constructor for class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
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.BsonDocumentMarkableIterator<T> - Class in org.bson
 
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,
BsonDocumentWrapperHelper - Class in com.mongodb.operation
 
BsonDocumentWrapperHelper() - Constructor for class com.mongodb.operation.BsonDocumentWrapperHelper
 
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.
BsonDocumentWriter.Context - Class in org.bson
 
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
BsonId - Annotation Type in org.bson.codecs.pojo.annotations
An annotation that configures the property as the id property for a ClassModel.
BsonIgnore - Annotation Type in org.bson.codecs.pojo.annotations
An annotation that configures a property to be ignored when reading and writing to BSON
bsonInput - Variable in class org.bson.BsonBinaryReader
 
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.
BsonInvalidOperationException(String, Throwable) - 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 - Variable in class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
bsonOutput - Variable in class com.mongodb.connection.SplittablePayloadBsonWriter
 
bsonOutput - Variable in class org.bson.BsonBinaryWriter
 
BsonOutput - Interface in org.bson.io
An output stream that is optimized for writing BSON values directly to the underlying stream.
BsonProperty - Annotation Type in org.bson.codecs.pojo.annotations
An annotation that configures a property.
BsonReader - Interface in org.bson
An interface for reading a logical BSON document using a pull-oriented API.
BsonReaderMark - Interface in org.bson
Represents a bookmark that can be used to reset a BsonReader to its state at the time the mark was created.
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(long) - Constructor for class org.bson.BsonTimestamp
Construct a new instance for the given value, which combines the time in seconds and the increment as a single long value.
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
 
BSONTimestampSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.BSONTimestampSerializer
Deprecated.
 
BsonType - Enum in org.bson
Enumeration of all the BSON types currently supported.
BsonType(int) - Constructor for enum org.bson.BsonType
 
bsonTypeClassMap - Variable in class com.mongodb.DBObjectCodecProvider
 
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.
bsonTypeClassMap - Variable in class org.bson.codecs.BsonTypeCodecMap
 
bsonTypeClassMap - Variable in class org.bson.codecs.DocumentCodecProvider
 
bsonTypeClassMap - Variable in class org.bson.codecs.IterableCodecProvider
 
bsonTypeClassMap - Variable in class org.bson.codecs.MapCodecProvider
 
bsonTypeCodecMap - Variable in class com.mongodb.DBObjectCodec
 
bsonTypeCodecMap - Variable in class org.bson.codecs.BsonDocumentCodec
 
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.
bsonTypeCodecMap - Variable in class org.bson.codecs.DocumentCodec
 
bsonTypeCodecMap - Variable in class org.bson.codecs.IterableCodec
 
bsonTypeCodecMap - Variable in class org.bson.codecs.MapCodec
 
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.
BsonValue() - Constructor for class org.bson.BsonValue
Construct a new instance.
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 - Variable in class org.bson.BasicBSONEncoder
 
BsonWriter - Interface in org.bson
An interface for writing a logical BSON document using a push-oriented API.
BsonWriterHelper - Class in com.mongodb.connection
 
BsonWriterHelper() - Constructor for class com.mongodb.connection.BsonWriterHelper
 
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
 
BucketAutoStage(TExpression, int, BucketAutoOptions) - Constructor for class com.mongodb.client.model.Aggregates.BucketAutoStage
 
BucketGranularity - Enum in com.mongodb.client.model
Granularity values for automatic bucketing.
BucketGranularity() - Constructor for enum com.mongodb.client.model.BucketGranularity
 
BucketGranularity(String) - Constructor for enum com.mongodb.client.model.BucketGranularity
 
bucketName - Variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
bucketName - Variable in class com.mongodb.client.gridfs.GridFSBucketImpl
 
bucketName - Variable in class com.mongodb.gridfs.GridFS
 
BucketOptions - Class in com.mongodb.client.model
The options for a $bucket aggregation pipeline stage
BucketOptions() - Constructor for class com.mongodb.client.model.BucketOptions
 
buckets - Variable in class com.mongodb.client.model.Aggregates.BucketAutoStage
 
bucketSize - Variable in class com.mongodb.bulk.IndexRequest
 
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 - Variable in class com.mongodb.client.model.IndexOptions
 
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
BucketStage(TExpression, List<TBoundary>, BucketOptions) - Constructor for class com.mongodb.client.model.Aggregates.BucketStage
 
buf - Variable in class org.bson.ByteBufNIO
 
buffer - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
buffer - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
buffer - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
buffer - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
buffer - Variable in class com.mongodb.connection.CompositeByteBuf.Component
 
buffer - Variable in class com.mongodb.connection.SendMessageCallback
 
buffer - Variable in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
buffer - Variable in class com.mongodb.gridfs.GridFSInputFile
 
buffer - Variable in class org.bson.io.BasicOutputBuffer
 
buffer - Variable in class org.bson.io.ByteBufferBsonInput
 
buffer - Variable in class org.bson.json.JsonBuffer
 
buffer - Variable in class org.bson.json.JsonScanner
 
BUFFER_SIZE - Static variable in class com.mongodb.connection.Compressor
 
BufferExposingByteArrayOutputStream(int) - Constructor for class com.mongodb.connection.Compressor.BufferExposingByteArrayOutputStream
 
BufferExposingByteArrayOutputStream(int) - Constructor for class com.mongodb.DBDecoderAdapter.BufferExposingByteArrayOutputStream
 
bufferIndex - Variable in class com.mongodb.connection.ByteBufferBsonOutput.BufferPositionPair
 
bufferList - Variable in class com.mongodb.connection.ByteBufferBsonOutput
 
bufferOffset - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
bufferOffset - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
bufferOffset - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
bufferOffset - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
BufferPositionPair(int, int) - Constructor for class com.mongodb.connection.ByteBufferBsonOutput.BufferPositionPair
 
bufferProvider - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream
 
bufferProvider - Variable in class com.mongodb.connection.AsynchronousSocketChannelStreamFactory
 
BufferProvider - Interface in com.mongodb.connection
A provider of instances of ByteBuf.
bufferProvider - Variable in class com.mongodb.connection.ByteBufferBsonOutput
 
bufferProvider - Variable in class com.mongodb.connection.SocketChannelStream
 
bufferProvider - Variable in class com.mongodb.connection.SocketStream
 
bufferProvider - Variable in class com.mongodb.connection.SocketStreamFactory
 
bufferProvider - Variable in class com.mongodb.DBDecoderAdapter
 
bufferProvider - Variable in class com.mongodb.Mongo
 
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.ClientSessionOptions.Builder
Build the session options instance.
build() - Method in class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory.Builder
Build an instance of AsynchronousSocketChannelStreamFactoryFactory.
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.MessageSettings.Builder
Build it.
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.
build() - Method in class org.bson.codecs.pojo.ClassModelBuilder
Creates a new ClassModel instance based on the mapping data provided.
build() - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Creates the PojoCodecProvider with the classes or packages that configured and registered.
build() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Creates the PropertyModel.
build() - Method in class org.bson.codecs.pojo.TypeData.Builder
 
build() - Method in class org.bson.codecs.pojo.TypeParameterMap.Builder
 
build() - Method in class org.bson.json.JsonWriterSettings.Builder
Build a JsonWriterSettings instance.
build() - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
Build a JsonWriterSettings instance.
buildCompressors(String, Integer) - Method in class com.mongodb.ConnectionString
 
builder() - Static method in class com.mongodb.AggregationOptions
Creates a new Builder for AggregationOptions.
Builder() - Constructor for class com.mongodb.AggregationOptions.Builder
 
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() - Constructor for class com.mongodb.async.client.MongoClientSettings.Builder
 
Builder(MongoClientSettings) - Constructor for class com.mongodb.async.client.MongoClientSettings.Builder
Creates a Builder 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() - Constructor for class com.mongodb.client.model.Collation.Builder
 
Builder(Collation) - Constructor for class com.mongodb.client.model.Collation.Builder
 
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() - Constructor for class com.mongodb.client.MongoDriverInformation.Builder
 
Builder(MongoDriverInformation) - Constructor for class com.mongodb.client.MongoDriverInformation.Builder
 
builder() - Static method in class com.mongodb.ClientSessionOptions
Gets an instance of a builder
Builder() - Constructor for class com.mongodb.ClientSessionOptions.Builder
 
builder() - Static method in class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory
Gets a builder for an instance of AsynchronousSocketChannelStreamFactoryFactory.
Builder() - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory.Builder
 
builder() - Static method in class com.mongodb.connection.ClusterSettings
Get a builder for this class.
builder(ClusterSettings) - Static method in class com.mongodb.connection.ClusterSettings
Creates a builder instance.
Builder() - Constructor for class com.mongodb.connection.ClusterSettings.Builder
 
Builder(ClusterSettings) - Constructor for class com.mongodb.connection.ClusterSettings.Builder
 
builder() - Static method in class com.mongodb.connection.ConnectionPoolSettings
Gets a Builder for creating a new ConnectionPoolSettings instance.
builder(ConnectionPoolSettings) - 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(ConnectionPoolSettings) - Constructor for class com.mongodb.connection.ConnectionPoolSettings.Builder
 
builder() - Static method in class com.mongodb.connection.MessageSettings
Gets the builder
Builder() - Constructor for class com.mongodb.connection.MessageSettings.Builder
 
builder() - Static method in class com.mongodb.connection.netty.NettyStreamFactoryFactory
Gets a builder for an instance of NettyStreamFactoryFactory.
Builder() - Constructor for class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
 
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(ServerSettings) - Static method in class com.mongodb.connection.ServerSettings
Creates a builder instance.
Builder() - Constructor for class com.mongodb.connection.ServerSettings.Builder
 
Builder(ServerSettings) - 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 - Variable in class com.mongodb.MongoClientURI
 
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() - Constructor for class org.bson.codecs.DecoderContext.Builder
 
builder() - Static method in class org.bson.codecs.EncoderContext
Create a builder.
Builder() - Constructor for class org.bson.codecs.EncoderContext.Builder
 
builder(Class<S>) - Static method in class org.bson.codecs.pojo.ClassModel
Creates a new Class Model builder instance using reflection.
builder() - Static method in class org.bson.codecs.pojo.PojoCodecProvider
Creates a Builder so classes or packages can be registered and configured before creating an immutable CodecProvider.
Builder() - Constructor for class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
builder() - Static method in class org.bson.codecs.pojo.PropertyModel
builder(Class<T>) - Static method in class org.bson.codecs.pojo.TypeData
Creates a new builder for ClassTypeData
Builder(Class<T>) - Constructor for class org.bson.codecs.pojo.TypeData.Builder
 
builder() - Static method in class org.bson.codecs.pojo.TypeParameterMap
Creates a new builder for the TypeParameterMap
Builder() - Constructor for class org.bson.codecs.pojo.TypeParameterMap.Builder
 
builder() - Static method in class org.bson.json.JsonWriterSettings
Create a builder for JsonWriterSettings, which are immutable.
Builder() - Constructor for class org.bson.json.JsonWriterSettings.Builder
 
builder() - Static method in class org.bson.json.StrictCharacterStreamJsonWriterSettings
Create a builder for StrictCharacterStreamJsonWriterSettings, which are immutable.
Builder() - Constructor for class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
 
builder() - Static method in class org.bson.util.CopyOnWriteMap
Get a CopyOnWriteMap.Builder for a CopyOnWriteMap instance.
Builder() - Constructor for class org.bson.util.CopyOnWriteMap.Builder
 
BuildersHelper - Class in com.mongodb.client.model
 
BuildersHelper() - Constructor for class com.mongodb.client.model.BuildersHelper
 
buildReadPreference(String, List<TagSet>, long) - Method in class com.mongodb.ConnectionString
 
buildWriteConcern(Boolean, String, Integer, Boolean, Boolean) - Method in class com.mongodb.ConnectionString
 
BulkUpdateRequestBuilder - Class in com.mongodb
A builder for a single update request.
BulkUpdateRequestBuilder(BulkWriteOperation, DBObject, boolean, Encoder<DBObject>, Encoder<DBObject>, Collation, List<? extends DBObject>) - Constructor for class com.mongodb.BulkUpdateRequestBuilder
 
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(ClientSession, 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(ClientSession, 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>>, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
bulkWrite(List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
bulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
bulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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.
bulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>) - Method in interface com.mongodb.client.MongoCollection
Executes a mix of inserts, updates, replaces, and deletes.
bulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions) - Method in interface com.mongodb.client.MongoCollection
Executes a mix of inserts, updates, replaces, and deletes.
bulkWrite(List<? extends WriteModel<? extends TDocument>>) - Method in class com.mongodb.MongoCollectionImpl
 
bulkWrite(List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
bulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>) - Method in class com.mongodb.MongoCollectionImpl
 
bulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
BulkWriteBatch - Class in com.mongodb.operation
 
BulkWriteBatch(MongoNamespace, ConnectionDescription, boolean, WriteConcern, Boolean, boolean, BulkWriteBatchCombiner, List<BulkWriteBatch.WriteRequestWithIndex>, SessionContext) - Constructor for class com.mongodb.operation.BulkWriteBatch
 
BulkWriteBatch(MongoNamespace, ConnectionDescription, boolean, WriteConcern, Boolean, boolean, BulkWriteBatchCombiner, IndexMap, WriteRequest.Type, BsonDocument, SplittablePayload, List<BulkWriteBatch.WriteRequestWithIndex>, SessionContext) - Constructor for class com.mongodb.operation.BulkWriteBatch
 
BulkWriteBatch.WriteRequestEncoder - Class in com.mongodb.operation
 
BulkWriteBatch.WriteRequestWithIndex - Class in com.mongodb.operation
 
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.
bulkWriteBatchCombiner - Variable in class com.mongodb.operation.BulkWriteBatch
 
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.
BulkWriteException(BulkWriteResult, List<BulkWriteError>, WriteConcernError, ServerAddress) - Constructor for exception com.mongodb.BulkWriteException
Constructs a new instance.
BulkWriteHelper - Class in com.mongodb
 
BulkWriteHelper() - Constructor for class com.mongodb.BulkWriteHelper
 
bulkWriteOperation - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
BulkWriteOperation - Class in com.mongodb
A bulk write operation.
BulkWriteOperation(boolean, DBCollection) - Constructor for class com.mongodb.BulkWriteOperation
 
bulkWriteOperation - Variable in class com.mongodb.BulkWriteRequestBuilder
 
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.
BulkWriteRequestBuilder(BulkWriteOperation, DBObject, Encoder<DBObject>, Encoder<DBObject>) - Constructor for class com.mongodb.BulkWriteRequestBuilder
 
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.
BY_CHARACTER - Static variable in enum org.bson.codecs.PatternCodec.RegexFlag
 
bypassDocumentValidation - Variable in class com.mongodb.AggregateIterableImpl
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.AggregateIterableImpl
 
bypassDocumentValidation - Variable in class com.mongodb.AggregationOptions.Builder
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.AggregationOptions.Builder
Sets whether to bypass document validation.
bypassDocumentValidation - Variable in class com.mongodb.AggregationOptions
 
bypassDocumentValidation(Boolean) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
bypassDocumentValidation(Boolean) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
bypassDocumentValidation - Variable in class com.mongodb.BulkWriteOperation
 
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 - Variable in class com.mongodb.client.model.BulkWriteOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.BulkWriteOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the bypassDocumentValidation
bypassDocumentValidation - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.client.model.InsertManyOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.InsertManyOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.client.model.InsertOneOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.InsertOneOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.client.model.UpdateOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.client.model.UpdateOptions
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.InsertOptions
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.InsertOptions
Sets whether to bypass document validation.
bypassDocumentValidation - Variable in class com.mongodb.MapReduceCommand
 
bypassDocumentValidation - Variable in class com.mongodb.MapReduceIterableImpl
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.MapReduceIterableImpl
 
bypassDocumentValidation - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.operation.BaseWriteOperation
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.BaseWriteOperation
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.operation.BulkWriteBatch
 
bypassDocumentValidation - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
bypassDocumentValidation(Boolean) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the bypass document level validation flag.
bypassDocumentValidation - Variable in class com.mongodb.operation.MixedBulkWriteOperation
 
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
 
ByteArraySerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.ByteArraySerializer
Deprecated.
 
byteArrayToString(byte[]) - Static method in class org.bson.internal.Base64
 
byteBuf - Variable in class com.mongodb.connection.ByteBufBsonDocument
 
ByteBuf - Interface in org.bson
An interface wrapper around a java.nio.ByteBuffer which additionally is Closeable, so that pooled byte buffers know how.
ByteBufBsonDocument - Class in com.mongodb.connection
 
ByteBufBsonDocument(ByteBuf) - Constructor for class com.mongodb.connection.ByteBufBsonDocument
 
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.
ByteBufferBsonOutput.BufferPositionPair - Class in com.mongodb.connection
 
ByteBufInputStream(ByteBuf) - Constructor for class com.mongodb.connection.Compressor.ByteBufInputStream
 
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.
byteBufReference - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream.BasicCompletionHandler
 
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
 
bytes - Variable in class org.bson.BsonDocument.SerializationProxy
 
bytes - Variable in class org.bson.LazyBSONObject
 
bytes - Variable in class org.bson.RawBsonDocument
 
bytes - Variable in class org.bson.RawBsonDocument.SerializationProxy
 
Bytes.OptionHolder - Class in com.mongodb
 
BYTES_IN_INTEGER - Static variable in class org.bson.LazyBSONDecoder
 
BYTES_PER_ENCODED_BLOCK - Static variable in class org.bson.internal.Base64
 
BYTES_PER_UNENCODED_BLOCK - Static variable in class org.bson.internal.Base64
 

C

cache - Variable in class org.bson.util.ClassMap
 
cachedBsonType - Variable in class org.bson.LazyBSONList.LazyBSONListIterator
 
cachedCodec - Variable in class org.bson.codecs.pojo.PropertyModel
 
cachedCodec(Codec<T>) - Method in class org.bson.codecs.pojo.PropertyModel
 
cachedValues - Variable in class org.bson.codecs.pojo.InstanceCreatorImpl
 
call(AsyncConnection, Throwable) - Method in interface com.mongodb.operation.OperationHelper.AsyncCallableWithConnection
 
call(AsyncConnectionSource, AsyncConnection, Throwable) - Method in interface com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionAndSource
 
call(Connection) - Method in interface com.mongodb.operation.OperationHelper.CallableWithConnection
 
call(ConnectionSource, Connection) - Method in interface com.mongodb.operation.OperationHelper.CallableWithConnectionAndSource
 
callable - Variable in class com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionAndSourceCallback
 
callable - Variable in class com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionCallback
 
callback - Variable in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
callback - Variable in class com.mongodb.connection.CommandResultCallback
 
callback - Variable in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
callback - Variable in class com.mongodb.connection.InternalStreamConnection.MessageHeaderCallback
 
callback - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
callback - Variable in class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
callback - Variable in class com.mongodb.connection.SaslAuthenticator.Continuator
 
callback - Variable in class com.mongodb.connection.SendMessageCallback
 
callback - Variable in class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
callback - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.CommandResultSingleResultCallback
 
callback - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.QueryResultSingleResultCallback
 
callback - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
callback - Variable in class com.mongodb.operation.CommandOperationHelper.TransformingResultCallback
 
callback - Variable in class com.mongodb.operation.FindOperation.ExplainResultCallback
 
callback - Variable in class org.bson.BSONCallbackAdapter.Context
 
callback - Variable in class org.bson.LazyBSONObject
 
callbackClosedException(SingleResultCallback<T>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
callbackClosedException(SingleResultCallback<T>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
callbackIsReadingException(SingleResultCallback<T>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
callbackIsWritingException(SingleResultCallback<T>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
callCallback(ResponseBuffers, Throwable) - Method in class com.mongodb.connection.CommandResultBaseCallback
 
callCallback(T, Throwable) - Method in class com.mongodb.connection.CommandResultBaseCallback
 
callCallback(BsonDocument, Throwable) - Method in class com.mongodb.connection.CommandResultCallback
 
callCallback(ResponseBuffers, Throwable) - Method in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
callCallback(ResponseBuffers, Throwable) - Method in class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
callCallback(ResponseBuffers, Throwable) - Method in class com.mongodb.connection.ResponseCallback
 
callGetLastError() - Method in class com.mongodb.WriteConcern
Deprecated.
canonicalAddress - Variable in class com.mongodb.connection.ServerDescription.Builder
 
canonicalAddress(String) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the canonical host name and port of this server.
canonicalAddress - Variable in class com.mongodb.connection.ServerDescription
 
canonicalize(Object) - Static method in class org.bson.BasicBSONObject
 
CANONICALIZE_HOST_NAME_DEFAULT_VALUE - Static variable in class com.mongodb.connection.GSSAPIAuthenticator
 
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.
canonicalizeBSONObject(BSONObject) - Static method in class org.bson.BasicBSONObject
 
canonicalizeList(List<Object>) - Static method in class org.bson.BasicBSONObject
 
canonicalizeMap(Map<String, Object>) - Static method in class org.bson.BasicBSONObject
 
canRetryWrite(ServerDescription, ConnectionDescription) - Static method in class com.mongodb.operation.OperationHelper
 
capacity() - Method in class com.mongodb.connection.CompositeByteBuf
 
capacity() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
capacity() - Method in interface org.bson.ByteBuf
Returns this buffer's capacity.
capacity() - Method in class org.bson.ByteBufNIO
 
capped - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
capped(boolean) - Method in class com.mongodb.client.model.CreateCollectionOptions
sets whether the collection is capped.
capped - Variable in class com.mongodb.operation.CreateCollectionOperation
 
capped(boolean) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets whether the collection is capped.
caseFirst - Variable in class com.mongodb.client.model.Collation.Builder
 
caseFirst - Variable in class com.mongodb.client.model.Collation
 
caseLevel - Variable in class com.mongodb.client.model.Collation.Builder
 
caseLevel(Boolean) - Method in class com.mongodb.client.model.Collation.Builder
Sets the case level value
caseLevel - Variable in class com.mongodb.client.model.Collation
 
caseSensitive - Variable in class com.mongodb.client.model.TextSearchOptions
 
caseSensitive(Boolean) - Method in class com.mongodb.client.model.TextSearchOptions
Set the case-sensitive flag for the text search
casNext(ConcurrentLinkedDeque.Node<E>, ConcurrentLinkedDeque.Node<E>) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
compareAndSet next link
causallyConsistent - Variable in class com.mongodb.ClientSessionOptions.Builder
 
causallyConsistent(boolean) - Method in class com.mongodb.ClientSessionOptions.Builder
Sets whether operations using the session should causally consistent with each other.
causallyConsistent - Variable in class com.mongodb.ClientSessionOptions
 
CENTER - Static variable in class com.mongodb.QueryOperators
 
CENTER_SPHERE - Static variable in class com.mongodb.QueryOperators
 
ChangeEvent<T> - Class in com.mongodb.connection
Represents some sort of change in the system
ChangeEvent(T, T) - Constructor for class com.mongodb.connection.ChangeEvent
 
ChangeListener<T> - Interface in com.mongodb.connection
Listener for ChangeEvents - classes that implement this will be informed if classes of type T are changed.
ChangeStreamBatchCursor<T> - Class in com.mongodb.operation
 
ChangeStreamBatchCursor(ChangeStreamOperation<T>, BatchCursor<RawBsonDocument>, ReadBinding) - Constructor for class com.mongodb.operation.ChangeStreamBatchCursor
 
ChangeStreamDocument<TDocument> - Class in com.mongodb.client.model.changestream
Represents the $changeStream aggregation output document.
ChangeStreamDocument(BsonDocument, MongoNamespace, TDocument, BsonDocument, OperationType, UpdateDescription) - Constructor for class com.mongodb.client.model.changestream.ChangeStreamDocument
Creates a new instance
ChangeStreamDocumentCodec<TResult> - Class in com.mongodb.client.model.changestream
 
ChangeStreamDocumentCodec(Class<TResult>, CodecRegistry) - Constructor for class com.mongodb.client.model.changestream.ChangeStreamDocumentCodec
 
ChangeStreamIterable<TResult> - Interface in com.mongodb.async.client
Iterable for change streams.
ChangeStreamIterable<TResult> - Interface in com.mongodb.client
Iterable for change streams.
ChangeStreamIterableImpl<TResult> - Class in com.mongodb.async.client
 
ChangeStreamIterableImpl(ClientSession, MongoNamespace, CodecRegistry, ReadPreference, ReadConcern, AsyncOperationExecutor, List<? extends Bson>, Class<TResult>) - Constructor for class com.mongodb.async.client.ChangeStreamIterableImpl
 
ChangeStreamIterableImpl<TResult> - Class in com.mongodb
 
ChangeStreamIterableImpl(ClientSession, MongoNamespace, CodecRegistry, ReadPreference, ReadConcern, OperationExecutor, List<? extends Bson>, Class<TResult>) - Constructor for class com.mongodb.ChangeStreamIterableImpl
 
changeStreamOperation - Variable in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
changeStreamOperation - Variable in class com.mongodb.operation.ChangeStreamBatchCursor
 
ChangeStreamOperation<T> - Class in com.mongodb.operation
An operation that executes an $changeStream aggregation.
ChangeStreamOperation(MongoNamespace, FullDocument, List<BsonDocument>, Decoder<T>) - Constructor for class com.mongodb.operation.ChangeStreamOperation
Construct a new instance.
channel - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream
 
channel - Variable in class com.mongodb.connection.netty.NettyStream
 
channelRead0(ChannelHandlerContext, ByteBuf) - Method in class com.mongodb.connection.netty.NettyStream.InboundBufferHandler
 
channelToInputStream(AsynchronousByteChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
Converts a AsynchronousByteChannel into a AsyncInputStream
channelToInputStream(AsynchronousFileChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
Converts a AsynchronousFileChannel into a AsyncInputStream
channelToOutputStream(AsynchronousByteChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
Converts a AsynchronousByteChannel into a AsyncOutputStream
channelToOutputStream(AsynchronousFileChannel) - Static method in class com.mongodb.async.client.gridfs.helpers.AsynchronousChannelHelper
Converts a AsynchronousFileChannel into a AsyncOutputStream
CharacterCodec - Class in org.bson.codecs
Encodes and decodes Character objects.
CharacterCodec() - Constructor for class org.bson.codecs.CharacterCodec
 
check(char) - Method in class com.mongodb.util.JSONParser
Checks the current character, making sure that it is the expected character.
checkAndCreateIndex(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSIndexCheck
 
checkAndCreateIndex(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
checkAndFetchResults(int, ByteBuffer, SingleResultCallback<Integer>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
checkBypassDocumentValidationIsSupported(ConnectionDescription, Boolean, WriteConcern) - Static method in class com.mongodb.operation.OperationHelper
 
checkChunksIndex(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
checkClosed() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
checkClosed() - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
checkClosed() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
checkClosed() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
checkCollectionNameValidity(String) - Static method in class com.mongodb.MongoNamespace
Check the validity of the given collection name.
checkCompleted() - Method in class com.mongodb.async.client.AbstractSubscription
 
checkCompleted() - Method in class com.mongodb.async.client.FlatteningSingleResultCallbackSubscription
 
checkCompleted() - Method in class com.mongodb.async.client.MongoIterableSubscription
 
checkCompleted() - Method in class com.mongodb.async.client.SingleResultCallbackSubscription
 
checkCreateIndex(ClientSession) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
checkDatabaseNameValidity(String) - Static method in class com.mongodb.MongoNamespace
Check the validity of the given database name.
checkDstIndex(int, int, int, int) - Method in class com.mongodb.connection.CompositeByteBuf
 
checkedDiscriminator - Variable in class org.bson.codecs.DecoderContext.Builder
 
checkedDiscriminator(boolean) - Method in class org.bson.codecs.DecoderContext.Builder
Sets the checkedDiscriminator
checkedDiscriminator - Variable in class org.bson.codecs.DecoderContext
 
checkedIndexes - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
checkedIndexes - Variable in class com.mongodb.client.gridfs.GridFSBucketImpl
 
checkedOutCount - Variable in class com.mongodb.management.ConnectionPoolStatistics
 
checkFilesIndex(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
checkForDuplicateKeyError(MongoCommandException) - Method in class com.mongodb.operation.CreateIndexesOperation
 
checkForDuplicates(String, String, Map<String, Integer>, String) - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
checkHasAnExecutable() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
checkIndex(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
checkIndex(int, int) - Method in class com.mongodb.connection.CompositeByteBuf
 
checkIteratorOrArray(DBCursor.IteratorOrArray) - Method in class com.mongodb.DBCursor
 
checkNotNull(Object) - Static method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Throws NullPointerException if argument is null.
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.
checkPreconditions(StrictCharacterStreamJsonWriter.State...) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
checkState(AbstractBsonWriter.State[]) - Method in class org.bson.AbstractBsonWriter
Checks if this writer's current state is in the list of given states.
checkState(StrictCharacterStreamJsonWriter.State...) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
ChildCodecRegistry<T> - Class in org.bson.codecs.configuration
 
ChildCodecRegistry(ProvidersCodecRegistry, Class<T>) - Constructor for class org.bson.codecs.configuration.ChildCodecRegistry
 
ChildCodecRegistry(ChildCodecRegistry<?>, Class<T>) - Constructor for class org.bson.codecs.configuration.ChildCodecRegistry
 
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.ReadPreference.PrimaryReadPreference
 
chooseForNonReplicaSet(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.ReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference.NearestReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference.PrimaryPreferredReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference.SecondaryPreferredReadPreference
 
chooseForReplicaSet(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference.SecondaryReadPreference
 
chunkIndex - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
chunkIndex - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
chunkIndex - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
chunkIndex - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
chunkNotFound(int) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
chunksCollection - Variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
chunksCollection - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
chunksCollection - Variable in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
chunksCollection - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
chunksCollection - Variable in class com.mongodb.client.gridfs.GridFSBucketImpl
 
chunksCollection - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
chunksCollection - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
chunksCollection - Variable in class com.mongodb.gridfs.GridFS
 
chunkSize - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
chunkSize - Variable in class com.mongodb.gridfs.GridFSFile
 
chunkSizeBytes - Variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
chunkSizeBytes - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
chunkSizeBytes - Variable in class com.mongodb.client.gridfs.GridFSBucketImpl
 
chunkSizeBytes - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
chunkSizeBytes - Variable in class com.mongodb.client.gridfs.model.GridFSUploadOptions
 
chunkSizeBytes(Integer) - Method in class com.mongodb.client.gridfs.model.GridFSUploadOptions
Sets the chunk size in bytes.
chunkSizeInBytes - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
clampAndRound(BigDecimal) - Method in class org.bson.types.Decimal128
 
CLASS_AND_PROPERTY_CONVENTION - Static variable in class org.bson.codecs.pojo.Conventions
The default class and property conventions Sets the discriminator key if not set to _t and the discriminator value if not set to the ClassModels simple type name. Configures the PropertyModels.
ClassAncestry - Class in org.bson.util
 
ClassAncestry() - Constructor for class org.bson.util.ClassAncestry
 
ClassMap<T> - Class in org.bson.util
Maps Class objects to values.
ClassMap() - Constructor for class org.bson.util.ClassMap
 
ClassMap.ComputeFunction - Class in org.bson.util
 
ClassMapBasedObjectSerializer - Class in com.mongodb.util
Objects of type ClassMapBasedObjectSerializer are constructed to perform instance specific object to JSON serialization schemes.
ClassMapBasedObjectSerializer() - Constructor for class com.mongodb.util.ClassMapBasedObjectSerializer
 
ClassModel<T> - Class in org.bson.codecs.pojo
This model represents the metadata for a class and all its properties.
ClassModel(Class<T>, Map<String, TypeParameterMap>, InstanceCreatorFactory<T>, Boolean, String, String, PropertyModel<?>, List<PropertyModel<?>>) - Constructor for class org.bson.codecs.pojo.ClassModel
 
classModel - Variable in class org.bson.codecs.pojo.LazyPojoCodec
 
classModel - Variable in class org.bson.codecs.pojo.PojoCodecImpl
 
ClassModelBuilder<T> - Class in org.bson.codecs.pojo
A builder for programmatically creating ClassModels.
ClassModelBuilder(Class<T>) - Constructor for class org.bson.codecs.pojo.ClassModelBuilder
 
classModels - Variable in class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
classModels - Variable in class org.bson.codecs.pojo.PojoCodecProvider
 
clazz - Variable in class com.mongodb.ReflectionDBObject.FieldInfo
 
clazz - Variable in class com.mongodb.ReflectionDBObject.JavaWrapper
 
clazz - Variable in class org.bson.codecs.configuration.LazyCodec
 
clazz - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
clazz - Variable in class org.bson.codecs.pojo.EnumPropertyCodecProvider.EnumCodec
 
clazzes - Variable in class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
CLDIterator() - Constructor for class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
cleanCursors() - Method in class com.mongodb.Mongo
 
cleanPropertyBuilders(ClassModelBuilder<?>) - Method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
clear() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
clear() - Method in class com.mongodb.connection.CompositeByteBuf
 
clear() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
clear() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Removes all of the elements from this deque.
clear() - Method in class com.mongodb.operation.BsonArrayWrapper
 
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.types.StringRangeSet
 
clear() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
clear() - Method in class org.bson.util.AbstractCopyOnWriteMap.EntrySet
 
clear() - Method in class org.bson.util.AbstractCopyOnWriteMap.KeySet
 
clear() - Method in class org.bson.util.AbstractCopyOnWriteMap.Values
 
clear() - Method in class org.bson.util.ClassMap
As per java.util.Map, removes all of the mappings from this map (optional operation).
clear() - Method in class org.bson.util.ComputingMap
 
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
 
CLIENT_METADATA_DOCUMENT - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
clientFirstMessageBare - Variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
clientMetadataDocument - Variable in class com.mongodb.connection.InternalStreamConnectionFactory
 
clientMetadataDocument - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer
 
clientMetadataDocumentTooLarge(BsonDocument) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
ClientMetadataHelper - Class in com.mongodb.connection
 
ClientMetadataHelper() - Constructor for class com.mongodb.connection.ClientMetadataHelper
 
clients - Variable in class com.mongodb.Mongo.Holder
 
clientSession - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
clientSession - Variable in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
clientSession - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
clientSession - Variable in class com.mongodb.async.client.MongoIterableImpl
 
clientSession - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
clientSession - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
clientSession - Variable in class com.mongodb.internal.session.ClientSessionContext
 
clientSession - Variable in class com.mongodb.MongoIterableImpl
 
ClientSession - Interface in com.mongodb.session
A client session.
ClientSessionBinding - Class in com.mongodb.async.client
 
ClientSessionBinding(ClientSession, boolean, AsyncReadWriteBinding) - Constructor for class com.mongodb.async.client.ClientSessionBinding
 
ClientSessionBinding - Class in com.mongodb
 
ClientSessionBinding(ClientSession, boolean, ReadWriteBinding) - Constructor for class com.mongodb.ClientSessionBinding
 
ClientSessionBinding.SessionBindingAsyncConnectionSource - Class in com.mongodb.async.client
 
ClientSessionBinding.SessionBindingConnectionSource - Class in com.mongodb
 
ClientSessionContext - Class in com.mongodb.internal.session
 
ClientSessionContext(ClientSession) - Constructor for class com.mongodb.internal.session.ClientSessionContext
 
clientSessionHelper - Variable in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
ClientSessionHelper - Class in com.mongodb.async.client
 
ClientSessionHelper(MongoClientImpl, ServerSessionPool) - Constructor for class com.mongodb.async.client.ClientSessionHelper
 
clientSessionHelper - Variable in class com.mongodb.async.client.MongoClientImpl
 
ClientSessionImpl - Class in com.mongodb.internal.session
 
ClientSessionImpl(ServerSessionPool, Object, ClientSessionOptions) - Constructor for class com.mongodb.internal.session.ClientSessionImpl
 
ClientSessionOptions - Class in com.mongodb
The options to apply to a ClientSession.
ClientSessionOptions(ClientSessionOptions.Builder) - Constructor for class com.mongodb.ClientSessionOptions
 
ClientSessionOptions.Builder - Class in com.mongodb
A builder for instances of ClientSession
clock - Variable in class com.mongodb.internal.session.ServerSessionPool
 
clone() - Method in class com.mongodb.connection.ByteBufBsonDocument
 
clone() - Method in class com.mongodb.operation.BsonArrayWrapper
 
clone() - Method in class org.bson.BsonArray
 
clone(BsonBinary) - Static method in class org.bson.BsonBinary
 
clone() - Method in class org.bson.BsonDocument
 
clone() - Method in class org.bson.BsonDocumentWrapper
 
clone(BsonJavaScriptWithScope) - Static method in class org.bson.BsonJavaScriptWithScope
 
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(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
close(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
close() - Method in class com.mongodb.async.client.MappingAsyncBatchCursor
 
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.async.client.MongoClientImpl
 
close() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
close() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
close() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
 
close() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
close() - Method in interface com.mongodb.client.MongoCursor
 
close() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
Closes the connection.
close() - Method in class com.mongodb.connection.BaseCluster
 
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.ClusterableServer
Closes the server.
close() - Method in interface com.mongodb.connection.ConnectionPool
 
close() - Method in class com.mongodb.connection.DefaultConnectionPool
 
close() - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
close(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory
 
close() - Method in class com.mongodb.connection.DefaultServer
 
close() - Method in class com.mongodb.connection.DefaultServerMonitor
 
close() - Method in interface com.mongodb.connection.InternalConnection
Closes the connection.
close() - Method in class com.mongodb.connection.InternalStreamConnection
 
close() - Method in class com.mongodb.connection.MultiServerCluster
 
close() - Method in class com.mongodb.connection.netty.NettyStream
 
close() - Method in class com.mongodb.connection.ResponseBuffers
 
close() - Method in interface com.mongodb.connection.ServerMonitor
 
close() - Method in class com.mongodb.connection.SingleServerCluster
 
close() - Method in class com.mongodb.connection.SocketChannelStream
 
close() - Method in class com.mongodb.connection.SocketStream
 
close() - Method in interface com.mongodb.connection.Stream
Closes the connection.
close() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
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.gridfs.GridFSInputFile.GridFSOutputStream
Processes/saves all data from InputStream and closes the potentially present OutputStream.
close() - Method in class com.mongodb.internal.connection.ConcurrentPool
Clears the pool of all objects.
close(T) - Method in class com.mongodb.internal.connection.ConcurrentPool
 
close(T) - Method in interface com.mongodb.internal.connection.ConcurrentPool.ItemFactory
 
close() - Method in interface com.mongodb.internal.connection.Pool
 
close() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
close() - Method in class com.mongodb.internal.session.ServerSessionPool
 
close() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
close(ServerSessionPool.ServerSessionImpl) - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionItemFactory
 
close() - Method in class com.mongodb.Mongo
Closes all resources associated with this instance, in particular any open network connections.
close() - Method in class com.mongodb.MongoBatchCursorAdapter
 
close() - Method in class com.mongodb.MongoCursorAdapter
 
close() - Method in class com.mongodb.MongoMappingCursor
 
close() - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
close() - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
close() - Method in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
close() - Method in interface com.mongodb.operation.BatchCursor
 
close() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
close() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
close() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
close() - Method in class com.mongodb.operation.QueryBatchCursor
 
close() - Method in interface com.mongodb.session.ClientSession
 
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
 
closeAndReadingLock - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
closeAndWritingLock - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
closed - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
closed - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
closed - Variable in class com.mongodb.BulkWriteOperation
 
closed - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
closed - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
closed - Variable in class com.mongodb.connection.ByteBufferBsonOutput
 
closed - Variable in class com.mongodb.connection.DefaultConnectionPool
 
closed - Variable in class com.mongodb.connection.ResponseCallback
 
closed - Variable in class com.mongodb.DBCursor
 
closed - Variable in class com.mongodb.internal.connection.ConcurrentPool
 
closed - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
closed - Variable in class com.mongodb.internal.session.ServerSessionPool
 
closed - Variable in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
closed - Variable in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
closed - Variable in class com.mongodb.operation.QueryBatchCursor
 
closed - Variable in class org.bson.AbstractBsonReader
 
closed - Variable in class org.bson.AbstractBsonWriter
 
closedSessionIdentifiers - Variable in class com.mongodb.internal.session.ServerSessionPool
 
closeLock - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
closeLock - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
closeSession(ServerSessionPool.ServerSessionImpl) - Method in class com.mongodb.internal.session.ServerSessionPool
 
closeSessionIfCountIsZero() - Method in class com.mongodb.async.client.ClientSessionBinding
 
closeSessionIfCountIsZero() - Method in class com.mongodb.ClientSessionBinding
 
closeStreamOnPersist - Variable in class com.mongodb.gridfs.GridFSInputFile
 
closing - Variable in class com.mongodb.internal.session.ServerSessionPool
 
cluster - Variable in class com.mongodb.async.client.MongoClientImpl
 
cluster - Variable in class com.mongodb.binding.AsyncClusterBinding
 
cluster - Variable in class com.mongodb.binding.ClusterBinding
 
cluster - Variable in class com.mongodb.binding.SingleServerBinding
 
Cluster - Interface in com.mongodb.connection
Represents a cluster of MongoDB servers.
cluster - Variable in class com.mongodb.internal.session.ServerSessionPool
 
cluster - Variable in class com.mongodb.Mongo
 
cluster - Variable in class com.mongodb.ReplicaSetStatus
 
CLUSTER_TIME_KEY - Static variable in class com.mongodb.connection.ClusterClock
 
CLUSTER_TIME_KEY - Static variable in class com.mongodb.internal.session.ClientSessionImpl
 
ClusterableServer - Interface in com.mongodb.connection
A logical connection to a MongoDB server that supports clustering along with other servers.
ClusterableServerFactory - Interface in com.mongodb.connection
 
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.
ClusterBinding.ClusterBindingConnectionSource - Class in com.mongodb.binding
 
ClusterBindingConnectionSource(ServerSelector) - Constructor for class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
clusterClock - Variable in class com.mongodb.connection.BaseCluster
 
ClusterClock - Class in com.mongodb.connection
 
ClusterClock() - Constructor for class com.mongodb.connection.ClusterClock
 
clusterClock - Variable in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
clusterClock - Variable in class com.mongodb.connection.DefaultServer
 
clusterClock - Variable in class com.mongodb.connection.DefaultServerMonitor
 
clusterClock - Variable in class com.mongodb.connection.DefaultServerMonitorFactory
 
ClusterClockAdvancingSessionContext - Class in com.mongodb.connection
 
ClusterClockAdvancingSessionContext(SessionContext, ClusterClock) - Constructor for class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
clusterClosed(ClusterClosedEvent) - Method in class com.mongodb.event.ClusterEventMulticaster
Deprecated.
 
clusterClosed(ClusterClosedEvent) - Method in interface com.mongodb.event.ClusterListener
Invoked when a cluster is closed.
clusterClosed(ClusterClosedEvent) - Method in class com.mongodb.event.ClusterListenerAdapter
 
clusterClosed(ClusterClosedEvent) - Method in class com.mongodb.internal.event.ClusterListenerMulticaster
 
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.
ClusterConnectionMode() - Constructor for enum com.mongodb.connection.ClusterConnectionMode
 
clusterConnectionMode - Variable in class com.mongodb.connection.CommandMessage
 
clusterConnectionMode - Variable in class com.mongodb.connection.CommandProtocolImpl
 
clusterConnectionMode - Variable in class com.mongodb.connection.DefaultServer
 
clusterConnectionMode - Variable in class com.mongodb.connection.DefaultServerConnection
 
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.
clusterDescription - Variable in exception com.mongodb.MongoIncompatibleDriverException
 
ClusterDescription.Predicate - Interface in com.mongodb.connection
 
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in class com.mongodb.event.ClusterEventMulticaster
Deprecated.
 
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in interface com.mongodb.event.ClusterListener
Invoked when a cluster description changes.
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in class com.mongodb.event.ClusterListenerAdapter
 
clusterDescriptionChanged(ClusterDescriptionChangedEvent) - Method in class com.mongodb.internal.event.ClusterListenerMulticaster
 
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
Deprecated.
register multiple cluster listeners instead
ClusterEventMulticaster(List<ClusterListener>) - Constructor for class com.mongodb.event.ClusterEventMulticaster
Deprecated.
Construct an instance with the given list of cluster listeners
ClusterFactory - Interface in com.mongodb.connection
Factory for Cluster implementations.
clusterId - Variable in class com.mongodb.connection.BaseCluster
 
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.
ClusterId(String, String) - Constructor for class com.mongodb.connection.ClusterId
 
clusterId - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
clusterId - Variable in class com.mongodb.connection.ServerId
 
clusterId - Variable in class com.mongodb.event.ClusterClosedEvent
 
clusterId - Variable in class com.mongodb.event.ClusterDescriptionChangedEvent
 
clusterId - Variable in class com.mongodb.event.ClusterOpeningEvent
 
clusterListener - Variable in class com.mongodb.connection.BaseCluster
 
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
 
ClusterListenerMulticaster - Class in com.mongodb.internal.event
 
ClusterListenerMulticaster(List<ClusterListener>) - Constructor for class com.mongodb.internal.event.ClusterListenerMulticaster
 
clusterListeners - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
clusterListeners - Variable in class com.mongodb.connection.ClusterSettings
 
clusterListeners - Variable in class com.mongodb.event.ClusterEventMulticaster
Deprecated.
 
clusterListeners - Variable in class com.mongodb.internal.event.ClusterListenerMulticaster
 
clusterListeners - Variable in class com.mongodb.MongoClientOptions.Builder
 
clusterListeners - Variable in class com.mongodb.MongoClientOptions
 
clusterOpening(ClusterOpeningEvent) - Method in class com.mongodb.event.ClusterEventMulticaster
Deprecated.
 
clusterOpening(ClusterOpeningEvent) - Method in interface com.mongodb.event.ClusterListener
Invoked when a cluster is opened.
clusterOpening(ClusterOpeningEvent) - Method in class com.mongodb.event.ClusterListenerAdapter
 
clusterOpening(ClusterOpeningEvent) - Method in class com.mongodb.internal.event.ClusterListenerMulticaster
 
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 - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
clusterSettings(ClusterSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the cluster settings.
clusterSettings - Variable in class com.mongodb.async.client.MongoClientSettings
 
clusterSettings - Variable in class com.mongodb.connection.ClusterDescription
 
ClusterSettings - Class in com.mongodb.connection
Settings for the cluster.
ClusterSettings(ClusterSettings.Builder) - Constructor for class com.mongodb.connection.ClusterSettings
 
clusterSettings - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
ClusterSettings.Builder - Class in com.mongodb.connection
A builder for the cluster settings.
clusterTime - Variable in class com.mongodb.connection.ClusterClock
 
clusterTime - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
ClusterType - Enum in com.mongodb.connection
An enumeration of all possible cluster types.
ClusterType() - Constructor for enum com.mongodb.connection.ClusterType
 
clusterType - Variable in class com.mongodb.connection.MultiServerCluster
 
code - Variable in class com.mongodb.bulk.WriteConcernError
 
code - Variable in class com.mongodb.BulkWriteError
 
code - Variable in exception com.mongodb.MongoException
 
code - Variable in class com.mongodb.WriteConcernError
 
code - Variable in class com.mongodb.WriteError
 
CODE - Static variable in class org.bson.BSON
 
code - Variable in class org.bson.BSONCallbackAdapter.Context
 
code - Variable in class org.bson.BsonJavaScript
 
code - Variable in class org.bson.BsonJavaScriptWithScope
 
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 - Variable in class org.bson.types.Code
 
CODE_W_SCOPE - Static variable in class org.bson.BSON
 
codec - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
codec - Variable in class com.mongodb.BulkWriteRequestBuilder
 
codec - Variable in class com.mongodb.ChangeStreamIterableImpl
 
codec - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocumentCodec
 
codec - Variable in class com.mongodb.InsertRequest
 
codec - Variable in class com.mongodb.RemoveRequest
 
codec - Variable in class com.mongodb.ReplaceRequest
 
codec - Variable in class com.mongodb.UpdateRequest
 
Codec<T> - Interface in org.bson.codecs
Implementations of this interface can both encode and decode values of type T.
codec - Variable in class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
codec - Variable in class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
codec - Variable in class org.bson.codecs.pojo.PropertyModel
 
codec - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
codec(Codec<T>) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Sets a custom codec for the property
CodecCache - Class in org.bson.codecs.configuration
 
CodecCache() - Constructor for class org.bson.codecs.configuration.CodecCache
 
codecCache - Variable in class org.bson.codecs.configuration.CodecCache
 
codecCache - Variable in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
codecCache - Variable in class org.bson.codecs.pojo.LazyPojoCodec
 
codecCache - Variable in class org.bson.codecs.pojo.PojoCodecImpl
 
codecClass - Variable in class org.bson.codecs.configuration.ChildCodecRegistry
 
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.
CodecConfigurationException(String, Throwable) - Constructor for exception org.bson.codecs.configuration.CodecConfigurationException
Construct a new instance and wraps a cause
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.
codecProviders - Variable in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
CodecRegistries - Class in org.bson.codecs.configuration
A helper class for creating and combining codecs, codec providers, and codec registries
CodecRegistries() - Constructor for class org.bson.codecs.configuration.CodecRegistries
 
codecRegistry - Variable in class com.mongodb.AggregateIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.FindIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.ListCollectionsIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.ListDatabasesIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.ListIndexesIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
codecRegistry - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
codecRegistry(CodecRegistry) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the codec registry
codecRegistry - Variable in class com.mongodb.async.client.MongoClientSettings
 
codecRegistry - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
codecRegistry - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
codecRegistry - Variable in class com.mongodb.ChangeStreamIterableImpl
 
codecRegistry - Variable in class com.mongodb.DBObjectCodec
 
codecRegistry - Variable in class com.mongodb.DistinctIterableImpl
 
codecRegistry - Variable in class com.mongodb.FindIterableImpl
 
codecRegistry - Variable in class com.mongodb.ListCollectionsIterableImpl
 
codecRegistry - Variable in class com.mongodb.ListDatabasesIterableImpl
 
codecRegistry - Variable in class com.mongodb.ListIndexesIterableImpl
 
codecRegistry - Variable in class com.mongodb.MapReduceIterableImpl
 
codecRegistry - Variable in class com.mongodb.MongoClientOptions.Builder
 
codecRegistry(CodecRegistry) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the codec registry
codecRegistry - Variable in class com.mongodb.MongoClientOptions
 
codecRegistry - Variable in class com.mongodb.MongoCollectionImpl
 
codecRegistry - Variable in class com.mongodb.MongoDatabaseImpl
 
codecRegistry - Variable in class org.bson.codecs.BsonArrayCodec
 
codecRegistry - Variable in class org.bson.codecs.BsonDocumentCodec
 
codecRegistry - Variable in class org.bson.codecs.BsonValueCodec
 
CodecRegistry - Interface in org.bson.codecs.configuration
A registry of Codec instances searchable by the class that the Codec can encode and decode.
codecRegistry - Variable in class org.bson.codecs.pojo.EnumPropertyCodecProvider
 
codecRegistry - Variable in class org.bson.codecs.pojo.FallbackPropertyCodecProvider
 
codecs - Variable in class com.mongodb.operation.CommandResultCodecProvider
 
codecs - Variable in class org.bson.codecs.BsonTypeCodecMap
 
codecs - Variable in class org.bson.codecs.BsonValueCodecProvider
 
codecs - Variable in class org.bson.codecs.ValueCodecProvider
 
codecsMap - Variable in class org.bson.codecs.configuration.MapOfCodecsProvider
 
CodeSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.CodeSerializer
Deprecated.
 
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
CodeWScopeSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.CodeWScopeSerializer
Deprecated.
 
collation - Variable in class com.mongodb.AggregateIterableImpl
 
collation(Collation) - Method in class com.mongodb.AggregateIterableImpl
 
collation - Variable in class com.mongodb.AggregationOptions.Builder
 
collation(Collation) - Method in class com.mongodb.AggregationOptions.Builder
Sets the collation
collation - Variable in class com.mongodb.AggregationOptions
 
collation(Collation) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the collation options
collation - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
collation(Collation) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
collation(Collation) - Method in interface com.mongodb.async.client.ChangeStreamIterable
Sets the collation options
collation - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
collation(Collation) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
collation(Collation) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the collation options
collation - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
collation(Collation) - Method in class com.mongodb.async.client.DistinctIterableImpl
 
collation(Collation) - Method in interface com.mongodb.async.client.FindIterable
Sets the collation options
collation(Collation) - Method in class com.mongodb.async.client.FindIterableImpl
 
collation(Collation) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the collation options
collation(Collation) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
collation(Collation) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the collation options
collation - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
collation(Collation) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
collation - Variable in class com.mongodb.bulk.DeleteRequest
 
collation(Collation) - Method in class com.mongodb.bulk.DeleteRequest
Sets the collation options
collation - Variable in class com.mongodb.bulk.IndexRequest
 
collation(Collation) - Method in class com.mongodb.bulk.IndexRequest
Sets the collation options
collation - Variable in class com.mongodb.bulk.UpdateRequest
 
collation(Collation) - Method in class com.mongodb.bulk.UpdateRequest
Sets the collation options
collation - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
collation(Collation) - Method in class com.mongodb.BulkUpdateRequestBuilder
Sets the collation
collation - Variable in class com.mongodb.BulkWriteRequestBuilder
 
collation(Collation) - Method in class com.mongodb.BulkWriteRequestBuilder
Sets the collation
collation - Variable in class com.mongodb.ChangeStreamIterableImpl
 
collation(Collation) - Method in class com.mongodb.ChangeStreamIterableImpl
 
collation(Collation) - Method in interface com.mongodb.client.AggregateIterable
Sets the collation options
collation(Collation) - Method in interface com.mongodb.client.ChangeStreamIterable
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 class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
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.Builder) - Constructor for class com.mongodb.client.model.Collation
 
collation - Variable in class com.mongodb.client.model.CountOptions
 
collation(Collation) - Method in class com.mongodb.client.model.CountOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
collation(Collation) - Method in class com.mongodb.client.model.CreateCollectionOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.CreateViewOptions
 
collation(Collation) - Method in class com.mongodb.client.model.CreateViewOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DBCollectionDistinctOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DBCollectionRemoveOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DBCreateViewOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DBCreateViewOptions
Sets the collation
collation - Variable in class com.mongodb.client.model.DeleteOptions
 
collation(Collation) - Method in class com.mongodb.client.model.DeleteOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.FindOneAndDeleteOptions
 
collation(Collation) - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
collation(Collation) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
collation(Collation) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.FindOptions
 
collation(Collation) - Method in class com.mongodb.client.model.FindOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.IndexOptions
 
collation(Collation) - Method in class com.mongodb.client.model.IndexOptions
Sets the collation options
collation - Variable in class com.mongodb.client.model.UpdateOptions
 
collation(Collation) - Method in class com.mongodb.client.model.UpdateOptions
Sets the collation options
collation - Variable in class com.mongodb.DistinctIterableImpl
 
collation(Collation) - Method in class com.mongodb.DistinctIterableImpl
 
collation(Collation) - Method in class com.mongodb.FindIterableImpl
 
collation - Variable in class com.mongodb.GroupCommand
 
collation - Variable in class com.mongodb.MapReduceCommand
 
collation - Variable in class com.mongodb.MapReduceIterableImpl
 
collation(Collation) - Method in class com.mongodb.MapReduceIterableImpl
 
collation - Variable in class com.mongodb.operation.AggregateExplainOperation
 
collation(Collation) - Method in class com.mongodb.operation.AggregateExplainOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.AggregateOperation
 
collation(Collation) - Method in class com.mongodb.operation.AggregateOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
collation(Collation) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.ChangeStreamOperation
 
collation(Collation) - Method in class com.mongodb.operation.ChangeStreamOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.CountOperation
 
collation(Collation) - Method in class com.mongodb.operation.CountOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.CreateCollectionOperation
 
collation(Collation) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.CreateViewOperation
 
collation(Collation) - Method in class com.mongodb.operation.CreateViewOperation
Sets the default collation for the view.
collation - Variable in class com.mongodb.operation.DistinctOperation
 
collation(Collation) - Method in class com.mongodb.operation.DistinctOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
collation(Collation) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
collation(Collation) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
collation(Collation) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.FindOperation
 
collation(Collation) - Method in class com.mongodb.operation.FindOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.GroupOperation
 
collation(Collation) - Method in class com.mongodb.operation.GroupOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
collation(Collation) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the collation options
collation - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
collation(Collation) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the collation options
collation - Variable in class com.mongodb.RemoveRequest
 
collation - Variable in class com.mongodb.ReplaceRequest
 
collation - Variable in class com.mongodb.UpdateRequest
 
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.
CollationAlternate(String) - Constructor for enum com.mongodb.client.model.CollationAlternate
 
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.
CollationCaseFirst(String) - Constructor for enum com.mongodb.client.model.CollationCaseFirst
 
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.
CollationMaxVariable(String) - Constructor for enum com.mongodb.client.model.CollationMaxVariable
 
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.
CollationStrength(int) - Constructor for enum com.mongodb.client.model.CollationStrength
 
CollectibleCodec<T> - Interface in org.bson.codecs
A Codec that generates complete BSON documents for storage in a MongoDB collection.
CollectibleDocumentFieldNameValidator - Class in com.mongodb.internal.validator
A field name validator for document that are meant for storage in MongoDB collections.
CollectibleDocumentFieldNameValidator() - Constructor for class com.mongodb.internal.validator.CollectibleDocumentFieldNameValidator
 
collection - Variable in class com.mongodb.BulkWriteOperation
 
collection - Variable in class com.mongodb.ConnectionString
 
collection - Variable in class com.mongodb.DBCursor
 
collection - Variable in class com.mongodb.DBDecoderAdapter
 
collection - Variable in class com.mongodb.MapReduceOutput
 
collectionCache - Variable in class com.mongodb.DB
 
CollectionCodec(Class<Collection<T>>, Codec<T>) - Constructor for class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
collectionExists(String) - Method in class com.mongodb.DB
Checks to see if a collection with a given name exists on a server.
collectionIsEmpty(ClientSession, MongoCollection<T>) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
collectionName(String) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the collectionName for the output of the MapReduce
collectionName - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
collectionName(String) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
collectionName(String) - Method in interface com.mongodb.client.MapReduceIterable
Sets the collectionName for the output of the MapReduce
collectionName - Variable in class com.mongodb.connection.RequestMessage
 
collectionName - Variable in class com.mongodb.DBRef
 
collectionName - Variable in class com.mongodb.GroupCommand
 
collectionName - Variable in class com.mongodb.MapReduceIterableImpl
 
collectionName(String) - Method in class com.mongodb.MapReduceIterableImpl
 
collectionName - Variable in class com.mongodb.MongoNamespace
 
collectionName - Variable in class com.mongodb.operation.CreateCollectionOperation
 
collectionName - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
CollectionPropertyCodecProvider - Class in org.bson.codecs.pojo
 
CollectionPropertyCodecProvider() - Constructor for class org.bson.codecs.pojo.CollectionPropertyCodecProvider
 
CollectionPropertyCodecProvider.CollectionCodec<T> - Class in org.bson.codecs.pojo
 
CollectionView() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
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.changestream - package com.mongodb.client.model.changestream
This package contains classes for the change stream api
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.internal - package com.mongodb.internal
 
com.mongodb.internal.async - package com.mongodb.internal.async
 
com.mongodb.internal.authentication - package com.mongodb.internal.authentication
 
com.mongodb.internal.connection - package com.mongodb.internal.connection
 
com.mongodb.internal.dns - package com.mongodb.internal.dns
 
com.mongodb.internal.event - package com.mongodb.internal.event
 
com.mongodb.internal.management.jmx - package com.mongodb.internal.management.jmx
 
com.mongodb.internal.session - package com.mongodb.internal.session
 
com.mongodb.internal.thread - package com.mongodb.internal.thread
 
com.mongodb.internal.validator - package com.mongodb.internal.validator
 
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.session - package com.mongodb.session
Contains classes related to sessions
com.mongodb.util - package com.mongodb.util
Contains classes that can be used everywhere in the driver, and have no specific domain.
combine(List<String>, BsonValue) - Static method in class com.mongodb.client.model.Projections
 
combine(Bson...) - Static method in class com.mongodb.client.model.Updates
Combine a list of updates into a single update.
combine(List<? extends Bson>) - Static method in class com.mongodb.client.model.Updates
Combine a list of updates into a single update.
combineOptionsMaps(Map<String, List<String>>, Map<String, List<String>>) - Method in class com.mongodb.ConnectionString
 
command - Variable in class com.mongodb.connection.CommandMessage
 
command - Variable in class com.mongodb.connection.CommandProtocolImpl
 
command(String, BsonDocument, boolean, FieldNameValidator, Decoder<T>) - Method in interface com.mongodb.connection.Connection
command(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext) - Method in interface com.mongodb.connection.Connection
Execute the command.
command(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext, boolean, SplittablePayload, FieldNameValidator) - Method in interface com.mongodb.connection.Connection
Executes the command, consuming as much of the SplittablePayload as possible.
command(String, BsonDocument, boolean, FieldNameValidator, Decoder<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
command(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext) - Method in class com.mongodb.connection.DefaultServerConnection
 
command(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext, boolean, SplittablePayload, FieldNameValidator) - Method in class com.mongodb.connection.DefaultServerConnection
 
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 - Variable in class com.mongodb.event.CommandStartedEvent
 
command - Variable in class com.mongodb.MapReduceOutput
 
command - Variable in class com.mongodb.operation.BulkWriteBatch
 
command - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
command - Variable in class com.mongodb.operation.CommandReadOperation
 
command - Variable in class com.mongodb.operation.CommandWriteOperation
 
COMMAND_COLLECTION_NAME - Static variable in class com.mongodb.MongoNamespace
 
COMMAND_NAME - Static variable in class com.mongodb.connection.GetMoreProtocol
 
COMMAND_NAME - Static variable in class com.mongodb.connection.KillCursorProtocol
 
commandAsync(String, BsonDocument, boolean, FieldNameValidator, Decoder<T>, SingleResultCallback<T>) - Method in interface com.mongodb.connection.AsyncConnection
commandAsync(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext, SingleResultCallback<T>) - Method in interface com.mongodb.connection.AsyncConnection
Execute the command.
commandAsync(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext, boolean, SplittablePayload, FieldNameValidator, SingleResultCallback<T>) - Method in interface com.mongodb.connection.AsyncConnection
Executes the command, consuming as much of the SplittablePayload as possible.
commandAsync(String, BsonDocument, boolean, FieldNameValidator, Decoder<T>, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
commandAsync(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
commandAsync(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, SessionContext, boolean, SplittablePayload, FieldNameValidator, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
commandCodec - Variable in class com.mongodb.DB
 
commandDocument - Variable in class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
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
Deprecated.
register multiple command listeners instead
CommandEventMulticaster(List<CommandListener>) - Constructor for class com.mongodb.event.CommandEventMulticaster
Deprecated.
Construct an instance with the given list of command listeners
CommandEventSender(CommandMessage, InternalStreamConnection.LazyCommandDocument) - Constructor for class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
commandFailed(CommandFailedEvent) - Method in class com.mongodb.event.CommandEventMulticaster
Deprecated.
 
commandFailed(CommandFailedEvent) - Method in interface com.mongodb.event.CommandListener
Listener for command failure events
commandFailed(CommandFailedEvent) - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
commandFailed(CommandFailedEvent) - Method in class com.mongodb.internal.event.CommandListenerMulticaster
 
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.
commandFieldNameValidator - Variable in class com.mongodb.connection.CommandMessage
 
commandFieldNameValidator - Variable in class com.mongodb.connection.CommandProtocolImpl
 
CommandHelper - Class in com.mongodb.connection
 
CommandHelper() - Constructor for class com.mongodb.connection.CommandHelper
 
commandListener - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
commandListener - Variable in class com.mongodb.connection.DefaultServer
 
commandListener - Variable in class com.mongodb.connection.GetMoreProtocol
 
commandListener - Variable in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
commandListener - Variable in class com.mongodb.connection.InternalStreamConnection
 
commandListener - Variable in class com.mongodb.connection.InternalStreamConnectionFactory
 
commandListener - Variable in class com.mongodb.connection.KillCursorProtocol
 
commandListener - Variable in class com.mongodb.connection.QueryProtocol
 
commandListener - Variable in class com.mongodb.connection.SendMessageCallback
 
commandListener - Variable in class com.mongodb.connection.WriteProtocol
 
CommandListener - Interface in com.mongodb.event
A listener for command events
CommandListenerMulticaster - Class in com.mongodb.event
Deprecated.
register multiple command listeners in the settings
CommandListenerMulticaster(List<CommandListener>) - Constructor for class com.mongodb.event.CommandListenerMulticaster
Deprecated.
Construct an instance with the given list of command listeners
CommandListenerMulticaster - Class in com.mongodb.internal.event
 
CommandListenerMulticaster(List<CommandListener>) - Constructor for class com.mongodb.internal.event.CommandListenerMulticaster
 
commandListeners - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
commandListeners - Variable in class com.mongodb.async.client.MongoClientSettings
 
commandListeners - Variable in class com.mongodb.event.CommandEventMulticaster
Deprecated.
 
commandListeners - Variable in class com.mongodb.internal.event.CommandListenerMulticaster
 
commandListeners - Variable in class com.mongodb.MongoClientOptions.Builder
 
commandListeners - Variable in class com.mongodb.MongoClientOptions
 
CommandMessage - Class in com.mongodb.connection
A command message that uses OP_MSG or OP_QUERY to send the command.
CommandMessage(MongoNamespace, BsonDocument, FieldNameValidator, ReadPreference, MessageSettings) - Constructor for class com.mongodb.connection.CommandMessage
 
CommandMessage(MongoNamespace, BsonDocument, FieldNameValidator, ReadPreference, MessageSettings, boolean, SplittablePayload, FieldNameValidator, ClusterConnectionMode) - Constructor for class com.mongodb.connection.CommandMessage
 
commandMessage - Variable in class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
commandName - Variable in class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
commandName - Variable in class com.mongodb.connection.SendMessageCallback
 
commandName - Variable in class com.mongodb.event.CommandEvent
 
CommandOperationHelper - Class in com.mongodb.operation
 
CommandOperationHelper() - Constructor for class com.mongodb.operation.CommandOperationHelper
 
CommandOperationHelper.CommandCreator - Interface in com.mongodb.operation
 
CommandOperationHelper.CommandProtocolExecutingCallback<D,R> - Class in com.mongodb.operation
 
CommandOperationHelper.CommandTransformer<T,R> - Interface in com.mongodb.operation
 
CommandOperationHelper.IdentityTransformer<T> - Class in com.mongodb.operation
 
CommandOperationHelper.TransformingResultCallback<T,R> - Class in com.mongodb.operation
 
CommandProtocol<T> - Interface in com.mongodb.connection
 
CommandProtocolExecutingCallback(String, BsonDocument, FieldNameValidator, Decoder<D>, ReadPreference, CommandOperationHelper.CommandTransformer<D, R>, SessionContext, SingleResultCallback<R>) - Constructor for class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
CommandProtocolImpl<T> - Class in com.mongodb.connection
 
CommandProtocolImpl(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>) - Constructor for class com.mongodb.connection.CommandProtocolImpl
 
CommandProtocolImpl(String, BsonDocument, FieldNameValidator, ReadPreference, Decoder<T>, boolean, SplittablePayload, FieldNameValidator, ClusterConnectionMode) - Constructor for class com.mongodb.connection.CommandProtocolImpl
 
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.
CommandResult(BsonDocument) - Constructor for class com.mongodb.CommandResult
 
CommandResult(BsonDocument, ServerAddress) - Constructor for class com.mongodb.CommandResult
 
CommandResultArrayCodec<T> - Class in com.mongodb.operation
 
CommandResultArrayCodec(CodecRegistry, Decoder<T>) - Constructor for class com.mongodb.operation.CommandResultArrayCodec
 
CommandResultBaseCallback<T> - Class in com.mongodb.connection
 
CommandResultBaseCallback(Decoder<T>, long, ServerAddress) - Constructor for class com.mongodb.connection.CommandResultBaseCallback
 
CommandResultCallback<T> - Class in com.mongodb.connection
 
CommandResultCallback(SingleResultCallback<T>, Decoder<T>, long, ServerAddress) - Constructor for class com.mongodb.connection.CommandResultCallback
 
CommandResultCodecProvider<P> - Class in com.mongodb.operation
 
CommandResultCodecProvider(Decoder<P>, List<String>) - Constructor for class com.mongodb.operation.CommandResultCodecProvider
 
commandResultDecoder - Variable in class com.mongodb.connection.CommandProtocolImpl
 
CommandResultDocumentCodec<T> - Class in com.mongodb.operation
 
CommandResultDocumentCodec(CodecRegistry, Decoder<T>, List<String>) - Constructor for class com.mongodb.operation.CommandResultDocumentCodec
 
CommandResultSingleResultCallback(AsyncConnection, ServerCursor, SingleResultCallback<List<T>>, boolean) - Constructor for class com.mongodb.operation.AsyncQueryBatchCursor.CommandResultSingleResultCallback
 
commandStarted(CommandStartedEvent) - Method in class com.mongodb.event.CommandEventMulticaster
Deprecated.
 
commandStarted(CommandStartedEvent) - Method in interface com.mongodb.event.CommandListener
Listener for command started events.
commandStarted(CommandStartedEvent) - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
commandStarted(CommandStartedEvent) - Method in class com.mongodb.internal.event.CommandListenerMulticaster
 
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
Deprecated.
 
commandSucceeded(CommandSucceededEvent) - Method in interface com.mongodb.event.CommandListener
Listener for command completed events
commandSucceeded(CommandSucceededEvent) - Method in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
commandSucceeded(CommandSucceededEvent) - Method in class com.mongodb.internal.event.CommandListenerMulticaster
 
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.
commandTransformer(ConnectionSource) - Method in class com.mongodb.operation.ListCollectionsOperation
 
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 - Variable in class com.mongodb.AggregateIterableImpl
 
comment(String) - Method in class com.mongodb.AggregateIterableImpl
 
comment(String) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the comment to the aggregation.
comment - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
comment(String) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
comment(String) - Method in interface com.mongodb.async.client.FindIterable
Sets the comment to the query.
comment(String) - Method in class com.mongodb.async.client.FindIterableImpl
 
comment(String) - Method in interface com.mongodb.client.AggregateIterable
Sets the comment to the aggregation.
comment(String) - Method in interface com.mongodb.client.FindIterable
Sets the comment to the query.
comment - Variable in class com.mongodb.client.model.FindOptions
 
comment(String) - Method in class com.mongodb.client.model.FindOptions
Sets the comment to the query.
comment(String) - Method in class com.mongodb.DBCursor
Adds a comment to the query to identify queries in the database profiler output.
comment(String) - Method in class com.mongodb.FindIterableImpl
 
comment - Variable in class com.mongodb.operation.AggregateOperation
 
comment(String) - Method in class com.mongodb.operation.AggregateOperation
Sets the comment to the aggregation.
comment - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
comment(String) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the comment to the aggregation.
comment - Variable in class com.mongodb.operation.FindOperation
 
comment(String) - Method in class com.mongodb.operation.FindOperation
Sets the comment to the query.
COMMENT - Static variable in class com.mongodb.QueryOperators
 
compare(long, long) - Static method in class org.bson.internal.UnsignedLongs
Equivalent of Long.compareUnsigned in Java 8.
compareLongs(long, long) - Static method in class org.bson.internal.UnsignedLongs
 
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
 
completeConnectionDescriptionInitialization(InternalConnection, ConnectionDescription) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
completeConnectionDescriptionInitializationAsync(InternalConnection, ConnectionDescription, SingleResultCallback<ConnectionDescription>) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
completed - Variable in class com.mongodb.async.client.FlatteningSingleResultCallbackSubscription
 
completed - Variable in class com.mongodb.async.client.MongoIterableSubscription
 
completed - Variable in class com.mongodb.async.client.SingleResultCallbackSubscription
 
completed(T) - Method in interface com.mongodb.connection.AsyncCompletionHandler
Invoked when an operation has completed.
completed(Integer, Object) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter.WriteCompletionHandler
 
completed(Integer, Void) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.BasicCompletionHandler
 
completed(Void, Object) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.OpenCompletionHandler
 
completed(T) - Method in class com.mongodb.connection.FutureAsyncCompletionHandler
 
completed(T) - Method in class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 
completedAuthentication() - Method in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
Component(ByteBuf, int) - Constructor for class com.mongodb.connection.CompositeByteBuf.Component
 
components - Variable in class com.mongodb.connection.CompositeByteBuf
 
CompositeByteBuf - Class in com.mongodb.connection
 
CompositeByteBuf(List<ByteBuf>) - Constructor for class com.mongodb.connection.CompositeByteBuf
 
CompositeByteBuf(CompositeByteBuf) - Constructor for class com.mongodb.connection.CompositeByteBuf
 
CompositeByteBuf.Component - Class in com.mongodb.connection
 
compositeSelector - Variable in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
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.
CompositeUpdate(List<? extends Bson>) - Constructor for class com.mongodb.client.model.Updates.CompositeUpdate
 
CompoundAuthenticator(InternalConnection, ConnectionDescription, SingleResultCallback<Void>) - Constructor for class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
CompoundDBObjectCodec - Class in com.mongodb
 
CompoundDBObjectCodec(Encoder<DBObject>, Decoder<DBObject>) - Constructor for class com.mongodb.CompoundDBObjectCodec
 
CompoundDBObjectCodec(Codec<DBObject>) - Constructor for class com.mongodb.CompoundDBObjectCodec
 
compoundIndex(Bson...) - Static method in class com.mongodb.client.model.Indexes
create a compound index specifications.
compoundIndex(List<? extends Bson>) - Static method in class com.mongodb.client.model.Indexes
compound multiple index specifications.
compoundIndex(List<String>, BsonValue) - Static method in class com.mongodb.client.model.Indexes
 
CompoundObjectSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.CompoundObjectSerializer
Deprecated.
 
CompoundSort(List<? extends Bson>) - Constructor for class com.mongodb.client.model.Sorts.CompoundSort
 
compress(List<ByteBuf>, BsonOutput) - Method in class com.mongodb.connection.Compressor
 
compress(List<ByteBuf>, BsonOutput) - Method in class com.mongodb.connection.SnappyCompressor
 
COMPRESSED_HEADER_LENGTH - Static variable in class com.mongodb.connection.CompressedHeader
The length of the reply header in the MongoDB wire protocol.
CompressedHeader - Class in com.mongodb.connection
 
CompressedHeader(ByteBuf, MessageHeader) - Constructor for class com.mongodb.connection.CompressedHeader
 
CompressedMessage - Class in com.mongodb.connection
 
CompressedMessage(OpCode, List<ByteBuf>, Compressor, MessageSettings) - Constructor for class com.mongodb.connection.CompressedMessage
 
compressor - Variable in class com.mongodb.connection.CompressedMessage
 
Compressor - Class in com.mongodb.connection
 
Compressor() - Constructor for class com.mongodb.connection.Compressor
 
Compressor.BufferExposingByteArrayOutputStream - Class in com.mongodb.connection
 
Compressor.ByteBufInputStream - Class in com.mongodb.connection
 
COMPRESSOR_KEYS - Static variable in class com.mongodb.ConnectionString
 
compressorId - Variable in class com.mongodb.connection.CompressedHeader
 
compressorList - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
compressorList(List<MongoCompressor>) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the compressors to use for compressing messages to the server.
compressorList - Variable in class com.mongodb.async.client.MongoClientSettings
 
compressorList - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
compressorList - Variable in class com.mongodb.connection.InternalStreamConnection
 
compressorList - Variable in class com.mongodb.connection.InternalStreamConnectionFactory
 
compressorList - Variable in class com.mongodb.ConnectionString
 
compressorList - Variable in class com.mongodb.MongoClientOptions.Builder
 
compressorList(List<MongoCompressor>) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the compressors to use for compressing messages to the server.
compressorList - Variable in class com.mongodb.MongoClientOptions
 
compressorMap - Variable in class com.mongodb.connection.InternalStreamConnection
 
compressors - Variable in class com.mongodb.connection.ConnectionDescription
 
computeAncestry(Class<?>) - Static method in class org.bson.util.ClassAncestry
Starting with children and going back to parents
computeAncestry(Class<T>, List<Class<?>>) - Static method in class org.bson.util.ClassAncestry
 
computeClientFinalMessage(byte[]) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
computeClientFirstMessage() - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
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.
ComputeFunction() - Constructor for class org.bson.util.ClassMap.ComputeFunction
 
ComputingMap<K,V> - Class in org.bson.util
 
ComputingMap(ConcurrentMap<K, V>, Function<K, V>) - Constructor for class org.bson.util.ComputingMap
 
ConcurrentLinkedDeque<E> - Class in com.mongodb.internal.connection
A concurrent linked-list implementation of a Deque (double-ended queue).
ConcurrentLinkedDeque() - Constructor for class com.mongodb.internal.connection.ConcurrentLinkedDeque
Constructs an empty deque.
ConcurrentLinkedDeque(Collection<? extends E>) - Constructor for class com.mongodb.internal.connection.ConcurrentLinkedDeque
Constructs a deque initially containing the elements of the given collection, added in traversal order of the collection's iterator.
ConcurrentLinkedDeque.CLDIterator - Class in com.mongodb.internal.connection
 
ConcurrentLinkedDeque.Node<E> - Class in com.mongodb.internal.connection
Linked Nodes.
ConcurrentLinkedDeque.RemovalReportingIterator<E> - Interface in com.mongodb.internal.connection
 
ConcurrentPool<T> - Class in com.mongodb.internal.connection
A concurrent pool implementation.
ConcurrentPool(int, ConcurrentPool.ItemFactory<T>) - Constructor for class com.mongodb.internal.connection.ConcurrentPool
Initializes a new pool of objects.
ConcurrentPool.ItemFactory<T> - Interface in com.mongodb.internal.connection
Factory for creating and closing pooled items.
ConcurrentPool.Prune - Enum in com.mongodb.internal.connection
 
condition - Variable in class com.mongodb.connection.DefaultServerMonitor
 
condition - Variable in class com.mongodb.GroupCommand
 
configureClassModelBuilder(ClassModelBuilder<T>, Class<T>) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
connect() - Method in class com.mongodb.connection.BaseCluster
 
connect() - Method in interface com.mongodb.connection.ClusterableServer
Attempt to connect to the server.
connect() - Method in class com.mongodb.connection.DefaultServer
 
connect() - Method in class com.mongodb.connection.DefaultServerMonitor
 
connect() - Method in class com.mongodb.connection.MultiServerCluster
 
connect() - Method in interface com.mongodb.connection.ServerMonitor
 
connect() - Method in class com.mongodb.connection.SingleServerCluster
 
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.
connectFromField - Variable in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
connection - Variable in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
connection - Variable in class com.mongodb.binding.SingleConnectionReadBinding
 
Connection - Interface in com.mongodb.connection
A synchronous connection to a MongoDB server with blocking operations.
connection - Variable in class com.mongodb.connection.SaslAuthenticator.Continuator
 
connection - Variable in class com.mongodb.connection.SendMessageCallback
 
connection - Variable in class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
connection - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.CommandResultSingleResultCallback
 
connection - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.QueryResultSingleResultCallback
 
connection - Variable in class com.mongodb.operation.OperationHelper.ConnectionReleasingWrappedCallback
 
CONNECTION_STRING - Static variable in class com.mongodb.client.jndi.MongoClientFactory
 
connectionAdded(ConnectionAddedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
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.internal.event.ConnectionPoolListenerMulticaster
 
connectionAdded(ConnectionAddedEvent) - Method in class com.mongodb.management.ConnectionPoolStatistics
 
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
Deprecated.
 
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.internal.event.ConnectionPoolListenerMulticaster
 
connectionCheckedIn(ConnectionCheckedInEvent) - Method in class com.mongodb.management.ConnectionPoolStatistics
 
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
Deprecated.
 
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.internal.event.ConnectionPoolListenerMulticaster
 
connectionCheckedOut(ConnectionCheckedOutEvent) - Method in class com.mongodb.management.ConnectionPoolStatistics
 
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 interface com.mongodb.event.ConnectionListener
Deprecated.
Publish a connection message closed event.
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.
ConnectionDescription(ConnectionId, ServerVersion, ServerType, int, int, int, List<String>) - Constructor for class com.mongodb.connection.ConnectionDescription
Construct an instance.
connectionDescription - Variable in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
connectionDescription - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
connectionDescription - Variable in class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
connectionDescription - Variable in class com.mongodb.event.CommandEvent
 
connectionDescription - Variable in class com.mongodb.operation.BulkWriteBatch
 
ConnectionFactory - Interface in com.mongodb.connection
 
connectionFactory - Variable in class com.mongodb.connection.DefaultServer
 
connectionId - Variable in class com.mongodb.connection.ConnectionDescription
 
ConnectionId - Class in com.mongodb.connection
An immutable connection identifier of a connection to a MongoDB server.
ConnectionId(ServerId) - Constructor for class com.mongodb.connection.ConnectionId
Construct an instance with the given server id.
ConnectionId(ServerId, int, Integer) - Constructor for class com.mongodb.connection.ConnectionId
 
connectionId - Variable in class com.mongodb.event.ConnectionAddedEvent
 
connectionId - Variable in class com.mongodb.event.ConnectionCheckedInEvent
 
connectionId - Variable in class com.mongodb.event.ConnectionCheckedOutEvent
 
connectionId - Variable in class com.mongodb.event.ConnectionClosedEvent
 
connectionId - Variable in class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
 
connectionId - Variable in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
 
connectionId - Variable in class com.mongodb.event.ConnectionOpenedEvent
 
connectionId - Variable in class com.mongodb.event.ConnectionRemovedEvent
 
connectionId - Variable in class com.mongodb.event.ServerHeartbeatFailedEvent
 
connectionId - Variable in class com.mongodb.event.ServerHeartbeatStartedEvent
 
connectionId - Variable in class com.mongodb.event.ServerHeartbeatSucceededEvent
 
connectionInitializer - Variable in class com.mongodb.connection.InternalStreamConnection
 
ConnectionListener - Interface in com.mongodb.event
Deprecated.
- No longer used
ConnectionMessageReceivedEvent - Class in com.mongodb.event
Deprecated.
- No longer used
ConnectionMessageReceivedEvent(ConnectionId, int, int) - Constructor for class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
Constructs a new instance of the event.
ConnectionMessagesSentEvent - Class in com.mongodb.event
Deprecated.
- No longer used
ConnectionMessagesSentEvent(ConnectionId, int, int) - Constructor for class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
Constructs a new instance of the event.
connectionMode - Variable in class com.mongodb.connection.ClusterDescription
 
connectionOpened(ConnectionOpenedEvent) - Method in interface com.mongodb.event.ConnectionListener
Deprecated.
Publish a connection opened event.
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
ConnectionPool - Interface in com.mongodb.connection
 
connectionPool - Variable in class com.mongodb.connection.DefaultServer
 
connectionPool - Variable in class com.mongodb.connection.DefaultServerMonitor
 
connectionPool - Variable in class com.mongodb.connection.DefaultServerMonitorFactory
 
connectionPoolClosed(ConnectionPoolClosedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
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.internal.event.ConnectionPoolListenerMulticaster
 
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
Deprecated.
register multiple command listeners instead
ConnectionPoolEventMulticaster() - Constructor for class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
connectionPoolListener - Variable in class com.mongodb.connection.DefaultConnectionPool
 
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
 
ConnectionPoolListenerMulticaster - Class in com.mongodb.internal.event
 
ConnectionPoolListenerMulticaster(List<ConnectionPoolListener>) - Constructor for class com.mongodb.internal.event.ConnectionPoolListenerMulticaster
 
connectionPoolListeners - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
connectionPoolListeners - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
connectionPoolListeners - Variable in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
connectionPoolListeners - Variable in class com.mongodb.internal.event.ConnectionPoolListenerMulticaster
 
connectionPoolListeners - Variable in class com.mongodb.MongoClientOptions.Builder
 
connectionPoolOpened(ConnectionPoolOpenedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
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.internal.event.ConnectionPoolListenerMulticaster
 
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 - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
connectionPoolSettings(ConnectionPoolSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the connection pool settings.
connectionPoolSettings - Variable in class com.mongodb.async.client.MongoClientSettings
 
ConnectionPoolSettings - Class in com.mongodb.connection
All settings that relate to the pool of connections to a MongoDB server.
ConnectionPoolSettings(ConnectionPoolSettings.Builder) - Constructor for class com.mongodb.connection.ConnectionPoolSettings
 
connectionPoolSettings - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
connectionPoolSettings - Variable in class com.mongodb.MongoClientOptions
 
ConnectionPoolSettings.Builder - Class in com.mongodb.connection
A builder for creating ConnectionPoolSettings.
ConnectionPoolStatistics - Class in com.mongodb.management
An MBean implementation for connection pool statistics.
ConnectionPoolStatistics(ConnectionPoolOpenedEvent) - Constructor for class com.mongodb.management.ConnectionPoolStatistics
 
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) - 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) - Constructor for class com.mongodb.event.ConnectionPoolWaitQueueExitedEvent
Construct an instance.
ConnectionReleasingWrappedCallback(SingleResultCallback<T>, AsyncConnectionSource, AsyncConnection) - Constructor for class com.mongodb.operation.OperationHelper.ConnectionReleasingWrappedCallback
 
connectionRemoved(ConnectionRemovedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
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.internal.event.ConnectionPoolListenerMulticaster
 
connectionRemoved(ConnectionRemovedEvent) - Method in class com.mongodb.management.ConnectionPoolStatistics
 
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.
connectionSource - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
connectionSource - Variable in class com.mongodb.operation.QueryBatchCursor
 
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.
connectionString - Variable in class com.mongodb.ConnectionString
 
connectTimeout(int, TimeUnit) - Method in class com.mongodb.connection.SocketSettings.Builder
Sets the socket connect timeout.
connectTimeout - Variable in class com.mongodb.ConnectionString
 
connectTimeout - Variable in class com.mongodb.MongoClientOptions.Builder
 
connectTimeout(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the connection timeout.
connectTimeout - Variable in class com.mongodb.MongoClientOptions
 
connectTimeout - Variable in class com.mongodb.MongoOptions
Deprecated.
The connection timeout in milliseconds.
connectTimeoutMS - Variable in class com.mongodb.connection.SocketSettings.Builder
 
connectTimeoutMS - Variable in class com.mongodb.connection.SocketSettings
 
connectToField - Variable in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
CONSTANT_TIME - Static variable in class com.mongodb.connection.Time
 
constructInstanceAndProcessCachedValues() - Method in class org.bson.codecs.pojo.InstanceCreatorImpl
 
constructor - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
container - Variable in class org.bson.BsonDocumentWriter.Context
 
contains(Object) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns true if this deque contains at least one element e such that o.equals(e).
contains(Object) - Method in class com.mongodb.operation.BsonArrayWrapper
 
contains(Object) - Method in class org.bson.BsonArray
 
contains(Object) - Method in class org.bson.LazyBSONList
 
contains(Object) - Method in class org.bson.types.StringRangeSet
 
contains(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
containsAll(Collection<?>) - Method in class com.mongodb.operation.BsonArrayWrapper
 
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
 
containsAll(Collection<?>) - Method in class org.bson.types.StringRangeSet
 
containsAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
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(Object) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
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(Class<?>) - Method in class org.bson.codecs.configuration.CodecCache
 
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.
containsKey(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
containsKey(Object) - Method in class org.bson.util.ComputingMap
 
containsPayload() - Method in class com.mongodb.connection.CommandMessage
 
containsQuotableCharacter(String) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
containsValue(Object) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
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
 
containsValue(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
containsValue(Object) - Method in class org.bson.util.ComputingMap
 
contentType - Variable in class com.mongodb.gridfs.GridFSFile
 
context - Variable in class com.mongodb.connection.SslSettings.Builder
 
context(SSLContext) - Method in class com.mongodb.connection.SslSettings.Builder
Sets the SSLContext for use when SSL is enabled.
context - Variable in class com.mongodb.connection.SslSettings
 
context - Variable in class org.bson.AbstractBsonReader
 
Context(AbstractBsonReader.Context, BsonContextType) - Constructor for class org.bson.AbstractBsonReader.Context
Creates a new instance.
context - Variable in class org.bson.AbstractBsonWriter
 
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(BsonBinaryReader.Context, BsonContextType, int, int) - Constructor for class org.bson.BsonBinaryReader.Context
 
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(BSONCallbackAdapter.Context, BsonContextType) - Constructor for class org.bson.BSONCallbackAdapter.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 - Variable in class org.bson.BsonDocumentReader.Mark
 
Context(BsonValue, BsonContextType, BsonDocumentWriter.Context) - Constructor for class org.bson.BsonDocumentWriter.Context
 
Context() - Constructor for class org.bson.BsonDocumentWriter.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
Deprecated.
Context(JsonWriter.Context, BsonContextType) - Constructor for class org.bson.json.JsonWriter.Context
Creates a new context.
context - Variable in class org.bson.json.StrictCharacterStreamJsonWriter
 
contextType - Variable in class org.bson.AbstractBsonReader.Context
 
contextType - Variable in class org.bson.AbstractBsonReader.Mark
 
contextType - Variable in class org.bson.AbstractBsonWriter.Context
 
contextType - Variable in class org.bson.json.StrictCharacterStreamJsonWriter.StrictJsonContext
 
Continuator(SaslClient, BsonDocument, InternalConnection, SingleResultCallback<Void>) - Constructor for class com.mongodb.connection.SaslAuthenticator.Continuator
 
continueConversation(BsonDocument) - Method in class com.mongodb.connection.SaslAuthenticator.Continuator
 
continueOnError - Variable in class com.mongodb.InsertOptions
 
continueOnError(boolean) - Method in class com.mongodb.InsertOptions
Set whether documents will continue to be inserted after a failure to insert one.
Convention - Interface in org.bson.codecs.pojo
Defines a convention to be applied when mapping a class.
ConventionAnnotationImpl - Class in org.bson.codecs.pojo
 
ConventionAnnotationImpl() - Constructor for class org.bson.codecs.pojo.ConventionAnnotationImpl
 
ConventionDefaultsImpl - Class in org.bson.codecs.pojo
 
ConventionDefaultsImpl() - Constructor for class org.bson.codecs.pojo.ConventionDefaultsImpl
 
conventions - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
conventions(List<Convention>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Sets the conventions to apply to the model
Conventions - Class in org.bson.codecs.pojo
The default Conventions
Conventions() - Constructor for class org.bson.codecs.pojo.Conventions
 
conventions - Variable in class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
conventions(List<Convention>) - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Sets the conventions to use when creating ClassModels from classes or packages.
conventions - Variable in class org.bson.codecs.pojo.PojoCodecProvider
 
ConventionSetPrivateFieldImpl - Class in org.bson.codecs.pojo
 
ConventionSetPrivateFieldImpl() - Constructor for class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl
 
ConventionSetPrivateFieldImpl.PrivateProperyAccessor<T> - Class in org.bson.codecs.pojo
 
ConventionUseGettersAsSettersImpl - Class in org.bson.codecs.pojo
 
ConventionUseGettersAsSettersImpl() - Constructor for class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl
 
ConventionUseGettersAsSettersImpl.PrivateProperyAccessor<T> - Class in org.bson.codecs.pojo
 
convert(T, StrictJsonWriter) - Method in interface org.bson.json.Converter
Convert the given value to JSON using the JSON writer.
convert(BsonBinary, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonBinaryConverter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonDateTimeConverter
 
convert(Decimal128, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonDecimal128Converter
 
convert(Double, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonDoubleConverter
 
convert(Integer, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonInt32Converter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonInt64Converter
 
convert(BsonMaxKey, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonMaxKeyConverter
 
convert(BsonMinKey, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonMinKeyConverter
 
convert(ObjectId, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonObjectIdConverter
 
convert(BsonRegularExpression, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonRegularExpressionConverter
 
convert(BsonTimestamp, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonTimestampConverter
 
convert(BsonUndefined, StrictJsonWriter) - Method in class org.bson.json.ExtendedJsonUndefinedConverter
 
convert(Boolean, StrictJsonWriter) - Method in class org.bson.json.JsonBooleanConverter
 
convert(Double, StrictJsonWriter) - Method in class org.bson.json.JsonDoubleConverter
 
convert(Integer, StrictJsonWriter) - Method in class org.bson.json.JsonInt32Converter
 
convert(String, StrictJsonWriter) - Method in class org.bson.json.JsonJavaScriptConverter
 
convert(BsonNull, StrictJsonWriter) - Method in class org.bson.json.JsonNullConverter
 
convert(String, StrictJsonWriter) - Method in class org.bson.json.JsonStringConverter
 
convert(String, StrictJsonWriter) - Method in class org.bson.json.JsonSymbolConverter
 
convert(BsonBinary, StrictJsonWriter) - Method in class org.bson.json.LegacyExtendedJsonBinaryConverter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.LegacyExtendedJsonDateTimeConverter
 
convert(BsonRegularExpression, StrictJsonWriter) - Method in class org.bson.json.LegacyExtendedJsonRegularExpressionConverter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.RelaxedExtendedJsonDateTimeConverter
 
convert(Double, StrictJsonWriter) - Method in class org.bson.json.RelaxedExtendedJsonDoubleConverter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.RelaxedExtendedJsonInt64Converter
 
convert(BsonBinary, StrictJsonWriter) - Method in class org.bson.json.ShellBinaryConverter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.ShellDateTimeConverter
 
convert(Decimal128, StrictJsonWriter) - Method in class org.bson.json.ShellDecimal128Converter
 
convert(Long, StrictJsonWriter) - Method in class org.bson.json.ShellInt64Converter
 
convert(BsonMaxKey, StrictJsonWriter) - Method in class org.bson.json.ShellMaxKeyConverter
 
convert(BsonMinKey, StrictJsonWriter) - Method in class org.bson.json.ShellMinKeyConverter
 
convert(ObjectId, StrictJsonWriter) - Method in class org.bson.json.ShellObjectIdConverter
 
convert(BsonRegularExpression, StrictJsonWriter) - Method in class org.bson.json.ShellRegularExpressionConverter
 
convert(BsonTimestamp, StrictJsonWriter) - Method in class org.bson.json.ShellTimestampConverter
 
convert(BsonUndefined, StrictJsonWriter) - Method in class org.bson.json.ShellUndefinedConverter
 
convertBulkWriteException(MongoBulkWriteException) - Method in class com.mongodb.operation.BaseWriteOperation
 
Converter<T> - Interface in org.bson.json
A converter from a BSON value to JSON.
convertOptionsToType(DBObject, String, Class<T>) - Method in class com.mongodb.DBCollection
 
convertResults(List<RawBsonDocument>) - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
convertResultsCallback(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
convertToListOfLists(List<Double[]>) - Method in class com.mongodb.QueryBuilder
 
convertToType(Class<T>, Object, String) - Method in class com.mongodb.DBCollection
 
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.
coordinate - Variable in class com.mongodb.client.model.geojson.Point
 
CoordinateReferenceSystem - Class in com.mongodb.client.model.geojson
A GeoJSON Coordinate Reference System (CRS).
CoordinateReferenceSystem() - Constructor for class com.mongodb.client.model.geojson.CoordinateReferenceSystem
 
coordinateReferenceSystem - Variable in class com.mongodb.client.model.geojson.Geometry
 
CoordinateReferenceSystemType - Enum in com.mongodb.client.model.geojson
An enumeration of the GeoJSON coordinate reference system types.
CoordinateReferenceSystemType(String) - Constructor for enum com.mongodb.client.model.geojson.CoordinateReferenceSystemType
 
coordinates - Variable in class com.mongodb.client.model.geojson.LineString
 
coordinates - Variable in class com.mongodb.client.model.geojson.MultiLineString
 
coordinates - Variable in class com.mongodb.client.model.geojson.MultiPoint
 
coordinates - Variable in class com.mongodb.client.model.geojson.MultiPolygon
 
coordinates - Variable in class com.mongodb.client.model.geojson.Polygon
 
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(List<ByteBuf>, byte[]) - Method in class com.mongodb.connection.SnappyCompressor
 
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
 
copy(N) - Method in class org.bson.util.AbstractCopyOnWriteMap
Copy function, implemented by sub-classes.
copy() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
copy(N) - Method in class org.bson.util.CopyOnWriteMap
 
copy(N) - Method in class org.bson.util.CopyOnWriteMap.Hash
 
copy(N) - Method in class org.bson.util.CopyOnWriteMap.Linked
 
copyClusterDescription(ClusterDescription, List<ServerDescription>) - Static method in class com.mongodb.TaggableReadPreference
 
CopyOnWriteMap<K,V> - Class in org.bson.util
A thread-safe variant of Map in which all mutative operations (the "destructive" operations described by Map put, remove and so on) are implemented by making a fresh copy of the underlying map.
CopyOnWriteMap(Map<? extends K, ? extends V>) - Constructor for class org.bson.util.CopyOnWriteMap
Deprecated.
since 0.0.12 use the versions that explicitly specify View.Type
CopyOnWriteMap() - Constructor for class org.bson.util.CopyOnWriteMap
Deprecated.
since 0.0.12 use the versions that explicitly specify View.Type
CopyOnWriteMap(Map<? extends K, ? extends V>, AbstractCopyOnWriteMap.View.Type) - Constructor for class org.bson.util.CopyOnWriteMap
Create a new CopyOnWriteMap with the supplied Map to initialize the values.
CopyOnWriteMap(AbstractCopyOnWriteMap.View.Type) - Constructor for class org.bson.util.CopyOnWriteMap
Create a new empty CopyOnWriteMap.
CopyOnWriteMap.Builder<K,V> - Class in org.bson.util
Build a CopyOnWriteMap and specify all the options.
CopyOnWriteMap.Hash<K,V> - Class in org.bson.util
Uses HashMap instances as its internal storage.
CopyOnWriteMap.Linked<K,V> - Class in org.bson.util
Uses LinkedHashMap instances as its internal storage.
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(ClientSession, SingleResultCallback<Long>) - Method in interface com.mongodb.async.client.MongoCollection
Counts the number of documents in the collection.
count(ClientSession, 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(ClientSession, 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(SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
count(Bson, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
count(Bson, CountOptions, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
count(ClientSession, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
count(ClientSession, Bson, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
count(ClientSession, Bson, CountOptions, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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(ClientSession) - Method in interface com.mongodb.client.MongoCollection
Counts the number of documents in the collection.
count(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Counts the number of documents in the collection according to the given options.
count(ClientSession, 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.
count - Variable in class com.mongodb.internal.connection.IndexMap.RangeBased
 
count() - Method in class com.mongodb.MongoCollectionImpl
 
count(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
count(Bson, CountOptions) - Method in class com.mongodb.MongoCollectionImpl
 
count(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
count(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
count(ClientSession, Bson, CountOptions) - Method in class com.mongodb.MongoCollectionImpl
 
count - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
count - Variable in class com.mongodb.operation.QueryBatchCursor
 
counter - Variable in class org.bson.types.ObjectId
 
countOccurrences(String, String) - Method in class com.mongodb.ConnectionString
 
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(MongoClientSettings, MongoDriverInformation, String) - Static method in class com.mongodb.async.client.MongoClients
 
create(MongoClientSettings, MongoDriverInformation) - Static method in class com.mongodb.async.client.NettyMongoClients
 
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(ServerAddress, ServerListener, ClusterClock) - Method in interface com.mongodb.connection.ClusterableServerFactory
 
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(InternalConnection, ProtocolExecutor, ClusterConnectionMode) - Method in interface com.mongodb.connection.ConnectionFactory
 
create(ServerAddress, ServerListener, ClusterClock) - Method in class com.mongodb.connection.DefaultClusterableServerFactory
 
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
create(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, ClusterListener, ConnectionPoolListener, ConnectionListener, CommandListener, String, MongoDriverInformation) - Method in class com.mongodb.connection.DefaultClusterFactory
create(InternalConnection, ProtocolExecutor, ClusterConnectionMode) - Method in class com.mongodb.connection.DefaultConnectionFactory
 
create(boolean) - Method in class com.mongodb.connection.DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory
 
create(ChangeListener<ServerDescription>) - Method in class com.mongodb.connection.DefaultServerMonitorFactory
 
create(ServerId) - Method in interface com.mongodb.connection.InternalConnectionFactory
 
create(ServerId) - Method in class com.mongodb.connection.InternalStreamConnectionFactory
 
create(ServerAddress) - Method in class com.mongodb.connection.netty.NettyStreamFactory
 
create(SocketSettings, SslSettings) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
create(ChangeListener<ServerDescription>) - Method in interface com.mongodb.connection.ServerMonitorFactory
 
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(boolean) - Method in interface com.mongodb.internal.connection.ConcurrentPool.ItemFactory
 
create() - Static method in class com.mongodb.internal.connection.IndexMap
Create an empty index map.
create(int, int) - Static method in class com.mongodb.internal.connection.IndexMap
Create an index map that maps the integers 0..count to startIndex..startIndex + count.
create(boolean) - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionItemFactory
 
create(ServerDescription, ConnectionDescription) - Method in interface com.mongodb.operation.CommandOperationHelper.CommandCreator
 
create(Decoder<P>, String) - Static method in class com.mongodb.operation.CommandResultDocumentCodec
 
create(Decoder<P>, List<String>) - Static method in class com.mongodb.operation.CommandResultDocumentCodec
 
create() - Method in class com.mongodb.util.JSONCallback
Deprecated.
 
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.
create() - Method in interface org.bson.codecs.pojo.InstanceCreatorFactory
 
create() - Method in class org.bson.codecs.pojo.InstanceCreatorFactoryImpl
 
create(Function<K, V>) - Static method in class org.bson.util.ComputingMap
 
createAggregateIterable(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createAggregateIterable(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
createAggregateOperation() - Method in class com.mongodb.operation.ChangeStreamOperation
 
createAggregateToCollectionOperation(List<BsonDocument>) - Method in class com.mongodb.AggregateIterableImpl
 
createAggregateToCollectionOperation(List<BsonDocument>) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
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.
createAsync(InternalConnection, ProtocolExecutor, ClusterConnectionMode) - Method in interface com.mongodb.connection.ConnectionFactory
 
createAsync(InternalConnection, ProtocolExecutor, ClusterConnectionMode) - Method in class com.mongodb.connection.DefaultConnectionFactory
 
createAuthenticationHash(String, char[]) - Static method in class com.mongodb.internal.authentication.NativeAuthenticationHelper
Creates a hash of the given user name and password, which is the hex encoding of MD5( <userName> + ":mongo:" + <password> ).
createAuthenticator(ConnectionDescription) - Method in class com.mongodb.connection.DefaultAuthenticator
 
createAuthenticator(MongoCredential) - Method in class com.mongodb.connection.InternalStreamConnectionFactory
 
createBitUpdateDocument(String, String, int) - Static method in class com.mongodb.client.model.Updates
 
createBitUpdateDocument(String, String, long) - Static method in class com.mongodb.client.model.Updates
 
createBitUpdateDocument(String, String, BsonValue) - Static method in class com.mongodb.client.model.Updates
 
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
 
createBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.AggregateIterableImpl
 
createBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
createBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
createBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.ChangeStreamIterableImpl
 
createBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.MongoDatabaseImpl
 
createBsonReader(ResponseBuffers) - Static method in class com.mongodb.connection.ProtocolHelper
 
createBulkWriteBatch(MongoNamespace, ServerDescription, ConnectionDescription, boolean, WriteConcern, Boolean, boolean, List<? extends WriteRequest>, SessionContext) - Static method in class com.mongodb.operation.BulkWriteBatch
 
createChangeStreamIterable(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createChangeStreamIterable(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
createChangeStreamOperation(Codec<S>) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
createChangeStreamOperation(Codec<S>) - Method in class com.mongodb.ChangeStreamIterableImpl
 
createChunk(Object, int, byte[]) - Method in class com.mongodb.gridfs.GridFSInputFile
Creates a new chunk of this file.
createClassModel(Class<T>, List<Convention>) - Static method in class org.bson.codecs.pojo.PojoCodecProvider
 
createClientMetadataDocument(String) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
createClientMetadataDocument(String, MongoDriverInformation) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
createClientMetadataDocument(String, MongoDriverInformation, BsonDocument) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
createClientSession(ClientSessionOptions, SingleResultCallback<ClientSession>) - Method in class com.mongodb.async.client.ClientSessionHelper
 
createClientSession(ClientSessionOptions) - Method in class com.mongodb.async.client.ClientSessionHelper
 
createClientSession(ClientSessionOptions) - Method in class com.mongodb.Mongo
 
createCluster(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, CommandListener, String, MongoDriverInformation) - Method in class com.mongodb.connection.DefaultClusterFactory
createCluster(ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, CommandListener, String, MongoDriverInformation, List<MongoCompressor>) - Method in class com.mongodb.connection.DefaultClusterFactory
Creates a cluster with the given settings.
createCluster(MongoClientURI, MongoDriverInformation) - Static method in class com.mongodb.Mongo
 
createCluster(List<ServerAddress>, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Static method in class com.mongodb.Mongo
 
createCluster(ServerAddress, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Static method in class com.mongodb.Mongo
 
createCluster(ClusterSettings, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Static method in class com.mongodb.Mongo
 
createCodec(Class<TFullDocument>, CodecRegistry) - Static method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Creates the codec for the specific ChangeStreamOutput type
createCollationFromOptions(DBObject) - Static method in class com.mongodb.DBObjectCollationHelper
 
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(ClientSession, String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new collection with the given name.
createCollection(ClientSession, String, CreateCollectionOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new collection with the selected options
createCollection(String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createCollection(String, CreateCollectionOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createCollection(ClientSession, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createCollection(ClientSession, String, CreateCollectionOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
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(ClientSession, String) - Method in interface com.mongodb.client.MongoDatabase
Create a new collection with the given name.
createCollection(ClientSession, 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.
createCollection(String) - Method in class com.mongodb.MongoDatabaseImpl
 
createCollection(String, CreateCollectionOptions) - Method in class com.mongodb.MongoDatabaseImpl
 
createCollection(ClientSession, String) - Method in class com.mongodb.MongoDatabaseImpl
 
createCollection(ClientSession, String, CreateCollectionOptions) - Method in class com.mongodb.MongoDatabaseImpl
 
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
 
createCommandCallback(AsyncWriteBinding, AsyncConnectionSource, AsyncConnection, String, ReadPreference, BsonDocument, FieldNameValidator, Decoder<T>, CommandOperationHelper.CommandTransformer<T, R>, SingleResultCallback<R>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
createCommandDecoder() - Method in class com.mongodb.operation.DistinctOperation
 
createCommandDecoder() - Method in class com.mongodb.operation.ListCollectionsOperation
 
createCommandDecoder() - Method in class com.mongodb.operation.ListIndexesOperation
 
createCompressor(MongoCompressor) - Method in class com.mongodb.connection.InternalStreamConnection
 
createCompressorMap(List<MongoCompressor>) - Method in class com.mongodb.connection.InternalStreamConnection
 
createCompressors(Map<String, List<String>>) - Method in class com.mongodb.ConnectionString
 
createConnectionDescription(ConnectionId, BsonDocument, BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
createConnectionDescriptionCallback(InternalConnection, SingleResultCallback<ConnectionDescription>) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
createCredential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance with an unspecified mechanism.
createCredentials(Map<String, List<String>>, String, char[]) - Method in class com.mongodb.ConnectionString
 
createCursorCleaningService() - Method in class com.mongodb.Mongo
 
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).
createDefaultBsonTypeClassMap() - Static method in class com.mongodb.DBObjectCodec
 
createDistinctIterable(ClientSession, String, Bson, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createDistinctIterable(ClientSession, String, Bson, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
createDnsDirContext() - Static method in class com.mongodb.internal.dns.DnsResolver
 
createEmptyAsyncBatchCursor(MongoNamespace, ServerAddress) - Static method in class com.mongodb.operation.OperationHelper
 
createEmptyBatchCursor(MongoNamespace, Decoder<T>, ServerAddress, int) - Static method in class com.mongodb.operation.OperationHelper
 
createExceptionForIncompatibleServerVersion() - Method in class com.mongodb.operation.CreateViewOperation
 
createExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.CountOperation
 
createExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
 
createExplainableOperation(ExplainVerbosity) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
createExplainableQueryOperation() - Method in class com.mongodb.operation.FindOperation
 
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.
createFilter(String, BsonValue) - Method in class com.mongodb.client.model.Filters.NotFilter
 
createFindIterable(ClientSession, Bson) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
createFindIterable(ClientSession, Bson, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createFindIterable(ClientSession, Bson) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
createFindIterable(ClientSession, Bson, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
createFindOperation() - Method in class com.mongodb.async.client.FindIterableImpl
 
createFindOperation() - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
createFromLegacyFormat(int, int, int) - Static method in class org.bson.types.ObjectId
Creates an ObjectId using time, machine and inc values.
createGridFSDownloadStream(ClientSession, GridFSFindIterable) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
createGridFSDownloadStream(ClientSession, GridFSFile) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
createGridFSFindIterable(ClientSession, Bson) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
createGridFSFindIterable(ClientSession, String, GridFSDownloadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
createGridFSFindIterable(ClientSession, Bson) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
createGridFSUploadStream(ClientSession, BsonValue, String, GridFSUploadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
createGridFSUploadStream(ClientSession, BsonValue, String, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
createGSSAPICredential(String) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the GSSAPI SASL mechanism.
createIncompatibleException(ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
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(ClientSession, Bson, SingleResultCallback<String>) - Method in interface com.mongodb.async.client.MongoCollection
Creates an index.
createIndex(ClientSession, Bson, IndexOptions, SingleResultCallback<String>) - Method in interface com.mongodb.async.client.MongoCollection
Creates an index.
createIndex(Bson, SingleResultCallback<String>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndex(Bson, IndexOptions, SingleResultCallback<String>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndex(ClientSession, Bson, SingleResultCallback<String>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndex(ClientSession, Bson, IndexOptions, SingleResultCallback<String>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndex(ClientSession, MongoCollection<T>, Document, IndexOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
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(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Create an index with the given keys.
createIndex(ClientSession, 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.
createIndex(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
createIndex(Bson, IndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
createIndex(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
createIndex(ClientSession, Bson, IndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
createIndexes(List<IndexModel>, SingleResultCallback<List<String>>) - Method in interface com.mongodb.async.client.MongoCollection
Create multiple indexes.
createIndexes(List<IndexModel>, CreateIndexOptions, SingleResultCallback<List<String>>) - Method in interface com.mongodb.async.client.MongoCollection
Create multiple indexes.
createIndexes(ClientSession, List<IndexModel>, SingleResultCallback<List<String>>) - Method in interface com.mongodb.async.client.MongoCollection
Create multiple indexes.
createIndexes(ClientSession, List<IndexModel>, CreateIndexOptions, SingleResultCallback<List<String>>) - Method in interface com.mongodb.async.client.MongoCollection
Create multiple indexes.
createIndexes(List<IndexModel>, SingleResultCallback<List<String>>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndexes(List<IndexModel>, CreateIndexOptions, SingleResultCallback<List<String>>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndexes(ClientSession, List<IndexModel>, SingleResultCallback<List<String>>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndexes(ClientSession, List<IndexModel>, CreateIndexOptions, SingleResultCallback<List<String>>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createIndexes(List<IndexModel>) - Method in interface com.mongodb.client.MongoCollection
Create multiple indexes.
createIndexes(List<IndexModel>, CreateIndexOptions) - Method in interface com.mongodb.client.MongoCollection
Create multiple indexes.
createIndexes(ClientSession, List<IndexModel>) - Method in interface com.mongodb.client.MongoCollection
Create multiple indexes.
createIndexes(ClientSession, List<IndexModel>, CreateIndexOptions) - Method in interface com.mongodb.client.MongoCollection
Create multiple indexes.
createIndexes(List<IndexModel>) - Method in class com.mongodb.MongoCollectionImpl
 
createIndexes(List<IndexModel>, CreateIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
createIndexes(ClientSession, List<IndexModel>) - Method in class com.mongodb.MongoCollectionImpl
 
createIndexes(ClientSession, List<IndexModel>, CreateIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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.
createIndexOperation(DBObject, DBObject) - Method in class com.mongodb.DBCollection
 
CreateIndexOptions - Class in com.mongodb.client.model
The options to apply to the command when creating indexes.
CreateIndexOptions() - Constructor for class com.mongodb.client.model.CreateIndexOptions
 
createInternalException(Class<? extends DBObject>, Throwable) - Method in class com.mongodb.DBCollectionObjectFactory
 
createIsMasterCommand() - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
createLegacyOptions() - Static method in class com.mongodb.Mongo
 
createList(ResponseBuffers) - Static method in class com.mongodb.connection.ByteBufBsonDocument
 
createList(ByteBufferBsonOutput, int) - Static method in class com.mongodb.connection.ByteBufBsonDocument
 
createList() - Method in class com.mongodb.util.JSONCallback
Deprecated.
 
createList() - Method in class org.bson.BasicBSONCallback
Factory method for creating a new BSON List.
createListCollectionNamesIterable(ClientSession) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createListCollectionNamesIterable(ClientSession) - Method in class com.mongodb.MongoDatabaseImpl
 
createListCollectionsIterable(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createListCollectionsIterable(ClientSession, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
createListDatabaseNamesIterable(ClientSession) - Method in class com.mongodb.async.client.MongoClientImpl
 
createListDatabaseNamesIterable(ClientSession) - Method in class com.mongodb.MongoClient
 
createListDatabasesIterable(ClientSession, Class<T>) - Method in class com.mongodb.async.client.MongoClientImpl
 
createListDatabasesIterable(ClientSession, Class<T>) - Method in class com.mongodb.MongoClient
 
createListIndexesIterable(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createListIndexesIterable(ClientSession, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
createMachineIdentifier() - Static method in class org.bson.types.ObjectId
 
createMaintenanceTask() - Method in class com.mongodb.connection.DefaultConnectionPool
 
createMaintenanceTimer() - Method in class com.mongodb.connection.DefaultConnectionPool
 
createMapReduceInlineOperation() - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
createMapReduceIterable(ClientSession, String, String, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
createMapReduceIterable(ClientSession, String, String, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
createMapReduceToCollectionOperation() - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
createMapReduceToCollectionOperation() - Method in class com.mongodb.MapReduceIterableImpl
 
createMessageSettingsBuilder(MessageSettings) - Static method in class com.mongodb.connection.BsonWriterHelper
 
createMongoClient(MongoClientSettings, MongoDriverInformation, StreamFactory, StreamFactory, Closeable) - Static method in class com.mongodb.async.client.MongoClients
 
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.
createMongoX509Credential() - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the MongoDB X.509 protocol where the distinguished subject name of the client certificate acts as the userName.
createNamespace() - Method in class com.mongodb.operation.ListCollectionsOperation
 
createNearFilterDocument(String, double, double, Double, Double, String) - Static method in class com.mongodb.client.model.Filters
 
createNew(int) - Method in class com.mongodb.internal.connection.PowerOfTwoBufferPool
 
createNewAndReleasePermitIfFailure(boolean) - Method in class com.mongodb.internal.connection.ConcurrentPool
 
createNewServerSessionIdentifier() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionItemFactory
 
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.
createOne(ByteBufferBsonOutput, int) - Static method in class com.mongodb.connection.ByteBufBsonDocument
 
createOperationExecutor() - Method in class com.mongodb.Mongo
 
createPlainCredential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the PLAIN SASL mechanism.
createProcessIdentifier() - Static method in class org.bson.types.ObjectId
 
createPropertyModelBuilder(PropertyMetadata<T>) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
createQueryMessage(ConnectionDescription) - Method in class com.mongodb.connection.QueryProtocol
 
createQueryOperation() - Method in class com.mongodb.FindIterableImpl
 
createQueryResult(BsonDocument, ConnectionDescription) - Method in class com.mongodb.operation.AggregateOperation
 
createQueryResult(BsonDocument, ConnectionDescription) - Method in class com.mongodb.operation.DistinctOperation
 
createQueryResult(BsonDocument, ConnectionDescription) - Method in class com.mongodb.operation.GroupOperation
 
createQueryResult(BsonDocument, ConnectionDescription) - Method in class com.mongodb.operation.ListDatabasesOperation
 
createQueryResult(BsonDocument, ConnectionDescription) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
createQueryResult(BsonDocument, ServerAddress) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
createReader() - Method in class org.bson.RawBsonDocument
 
createReadPreference(Map<String, List<String>>) - Method in class com.mongodb.ConnectionString
 
createRequestMessage(MessageSettings) - Method in class com.mongodb.connection.DeleteProtocol
 
createRequestMessage(MessageSettings) - Method in class com.mongodb.connection.InsertProtocol
 
createRequestMessage(MessageSettings) - Method in class com.mongodb.connection.UpdateProtocol
 
createRequestMessage(MessageSettings) - Method in class com.mongodb.connection.WriteProtocol
Create the initial request message for the write.
createResult() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
createSaslClient(ServerAddress) - Method in class com.mongodb.connection.GSSAPIAuthenticator
 
createSaslClient(ServerAddress) - Method in class com.mongodb.connection.PlainAuthenticator
 
createSaslClient(ServerAddress) - Method in class com.mongodb.connection.SaslAuthenticator
 
createSaslClient(ServerAddress) - Method in class com.mongodb.connection.ScramSha1Authenticator
 
createSaslContinueDocument(BsonInt32, byte[]) - Method in class com.mongodb.connection.SaslAuthenticator
 
createSaslStartCommandDocument(byte[]) - Method in class com.mongodb.connection.SaslAuthenticator
 
createScramSha1Credential(String, String, char[]) - Static method in class com.mongodb.MongoCredential
Creates a MongoCredential instance for the SCRAM-SHA-1 SASL mechanism.
createServer(ServerAddress, ServerListener) - Method in class com.mongodb.connection.BaseCluster
 
createServerDescription(ServerAddress, BsonDocument, ServerVersion, long) - Static method in class com.mongodb.connection.DescriptionHelper
 
createServerListener(ServerSettings, ServerListener) - Static method in class com.mongodb.internal.event.EventListenerHelper
 
createSnappyCompressor() - Static method in class com.mongodb.MongoCompressor
Create an instance for snappy compression.
createSpecialException(BsonDocument, ServerAddress, String) - Static method in class com.mongodb.connection.ProtocolHelper
 
createStatistics(BsonDocument) - Static method in class com.mongodb.operation.MapReduceHelper
 
createTimeoutException(ServerSelector, ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
createTimeoutException() - Method in class com.mongodb.connection.DefaultConnectionPool
 
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(ClientSession, 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(ClientSession, 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>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createView(String, String, List<? extends Bson>, CreateViewOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createView(ClientSession, String, String, List<? extends Bson>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
createView(ClientSession, String, String, List<? extends Bson>, CreateViewOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
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(ClientSession, 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(ClientSession, 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.
createView(String, String, List<? extends Bson>) - Method in class com.mongodb.MongoDatabaseImpl
 
createView(String, String, List<? extends Bson>, CreateViewOptions) - Method in class com.mongodb.MongoDatabaseImpl
 
createView(ClientSession, String, String, List<? extends Bson>) - Method in class com.mongodb.MongoDatabaseImpl
 
createView(ClientSession, String, String, List<? extends Bson>, CreateViewOptions) - Method in class com.mongodb.MongoDatabaseImpl
 
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
 
createWaitQueueFullException() - Method in class com.mongodb.connection.BaseCluster
 
createWaitQueueFullException() - Method in class com.mongodb.connection.DefaultConnectionPool
 
createWriteConcern(Map<String, List<String>>) - Method in class com.mongodb.ConnectionString
 
createWriteConcernError(BsonDocument) - Static method in class com.mongodb.operation.FindAndModifyHelper
 
createWriteConcernError(BsonDocument, ServerAddress) - Static method in class com.mongodb.operation.WriteConcernHelper
 
createWriteConcernError(BsonDocument) - Static method in class com.mongodb.operation.WriteConcernHelper
 
createWriteConcernException(MongoWriteConcernException) - Static method in class com.mongodb.DBCollection
 
createWriteConcernResult(BsonDocument) - Static method in class com.mongodb.operation.FindAndModifyHelper
 
createWriteResult(BsonDocument) - Static method in class com.mongodb.connection.ProtocolHelper
 
createZlibCompressor() - Static method in class com.mongodb.MongoCompressor
Create an instance for zlib compression.
CreatorExecutable<T> - Class in org.bson.codecs.pojo
 
CreatorExecutable(Class<T>, Constructor<T>) - Constructor for class org.bson.codecs.pojo.CreatorExecutable
 
CreatorExecutable(Class<T>, Method) - Constructor for class org.bson.codecs.pojo.CreatorExecutable
 
CreatorExecutable(Class<T>, Constructor<T>, Method) - Constructor for class org.bson.codecs.pojo.CreatorExecutable
 
creatorExecutable - Variable in class org.bson.codecs.pojo.InstanceCreatorFactoryImpl
 
creatorExecutable - Variable in class org.bson.codecs.pojo.InstanceCreatorImpl
 
credential(MongoCredential) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the credential.
credential - Variable in class com.mongodb.connection.Authenticator
 
credential - Variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
credential - Variable in class com.mongodb.ConnectionString
 
credential - Variable in exception com.mongodb.MongoSecurityException
 
credential - Variable in class com.mongodb.operation.CreateUserOperation
 
credential - Variable in class com.mongodb.operation.UpdateUserOperation
 
credentialList - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
credentialList(List<MongoCredential>) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
credentialList - Variable in class com.mongodb.async.client.MongoClientSettings
 
credentialList - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
credentialsList - Variable in class com.mongodb.Mongo
 
CRS_84 - Static variable in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
The urn:ogc:def:crs:OGC:1.3:CRS84 Coordinate Reference System
ctx - Variable in class com.mongodb.connection.netty.ReadTimeoutHandler.ReadTimeoutTask
 
cur() - Method in class org.bson.BasicBSONCallback
Gets the current value
curBatch - Variable in class com.mongodb.MongoBatchCursorAdapter
 
curBufferIndex - Variable in class com.mongodb.connection.ByteBufferBsonOutput
 
curIndex - Variable in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
curName() - Method in class org.bson.BasicBSONCallback
Gets the name of the current field
curPos - Variable in class com.mongodb.MongoBatchCursorAdapter
 
curr() - Method in class com.mongodb.DBCursor
Returns the element the cursor is at.
currentAuthenticatorIndex - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
currentBsonType - Variable in class org.bson.AbstractBsonReader
 
currentBsonType - Variable in class org.bson.AbstractBsonReader.Mark
 
currentBufferPosition - Variable in class com.mongodb.gridfs.GridFSInputFile
 
currentChunkId - Variable in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
currentChunkNumber - Variable in class com.mongodb.gridfs.GridFSInputFile
 
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.
currentName - Variable in class org.bson.AbstractBsonReader
 
currentName - Variable in class org.bson.AbstractBsonReader.Mark
 
currentName - Variable in class org.bson.AbstractBsonWriter.Mark
 
currentObject - Variable in class com.mongodb.DBCursor
 
currentObject(DBObject) - Method in class com.mongodb.DBCursor
 
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
 
currentPosition - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
currentPosition - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
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.
currentValue - Variable in class org.bson.BsonDocumentReader
 
currentValue - Variable in class org.bson.BsonDocumentReader.Mark
 
currentValue - Variable in class org.bson.json.JsonReader
 
currentValue - Variable in class org.bson.json.JsonReader.Mark
 
cursor - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
cursor - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
Cursor - Interface in com.mongodb
Interface for providing consistent behaviour between different Cursor implementations.
cursor - Variable in class com.mongodb.DBCursor
 
cursor - Variable in class com.mongodb.MongoCursorAdapter
 
CURSOR - Static variable in class com.mongodb.operation.AggregateOperation
 
cursor - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.CommandResultSingleResultCallback
 
cursor - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
CURSOR_NOT_FOUND_RESPONSE_FLAG - Static variable in class com.mongodb.connection.ReplyHeader
 
cursorCleaningService - Variable in class com.mongodb.Mongo
 
cursorDocumentToAsyncBatchCursor(BsonDocument, Decoder<T>, AsyncConnectionSource, AsyncConnection, int) - Static method in class com.mongodb.operation.OperationHelper
 
cursorDocumentToBatchCursor(BsonDocument, Decoder<T>, ConnectionSource, int) - Static method in class com.mongodb.operation.OperationHelper
 
cursorDocumentToQueryResult(BsonDocument, ServerAddress) - Static method in class com.mongodb.operation.OperationHelper
 
cursorDocumentToQueryResult(BsonDocument, ServerAddress, String) - Static method in class com.mongodb.operation.OperationHelper
 
cursorFinalizerEnabled - Variable in class com.mongodb.MongoClientOptions.Builder
 
cursorFinalizerEnabled(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Sets whether cursor finalizers are enabled.
cursorFinalizerEnabled - Variable in class com.mongodb.MongoClientOptions
 
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.
CursorHelper - Class in com.mongodb.operation
 
CursorHelper() - Constructor for class com.mongodb.operation.CursorHelper
 
cursorId - Variable in class com.mongodb.connection.GetMoreMessage
 
cursorId - Variable in class com.mongodb.connection.GetMoreProtocol
 
cursorId - Variable in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
cursorId - Variable in class com.mongodb.connection.QueryResult
 
cursorId - Variable in class com.mongodb.connection.ReplyHeader
 
cursorId - Variable in exception com.mongodb.MongoCursorNotFoundException
 
cursorLock - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
cursors - Variable in class com.mongodb.connection.KillCursorProtocol
 
cursors - Variable in class com.mongodb.connection.KillCursorsMessage
 
cursorType(CursorType) - Method in interface com.mongodb.async.client.FindIterable
Sets the cursor type.
cursorType(CursorType) - Method in class com.mongodb.async.client.FindIterableImpl
 
cursorType(CursorType) - Method in interface com.mongodb.client.FindIterable
Sets the cursor type.
cursorType - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
cursorType(CursorType) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the cursor type.
cursorType - Variable in class com.mongodb.client.model.FindOptions
 
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() - Constructor for enum com.mongodb.CursorType
 
cursorType(CursorType) - Method in class com.mongodb.FindIterableImpl
 
cursorType - Variable in class com.mongodb.operation.FindOperation
 
cursorType(CursorType) - Method in class com.mongodb.operation.FindOperation
Sets the cursor type.

D

DaemonThreadFactory - Class in com.mongodb.internal.thread
Custom thread factory for scheduled executor service that creates daemon threads.
DaemonThreadFactory(String) - Constructor for class com.mongodb.internal.thread.DaemonThreadFactory
 
data - Variable in class org.bson.BsonBinary
 
data - Variable in class org.bson.types.Binary
 
database - Variable in class com.mongodb.ConnectionString
 
database - Variable in class com.mongodb.DBCollection
 
database - Variable in class com.mongodb.gridfs.GridFS
 
database - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
databaseName - Variable in class com.mongodb.async.client.ListCollectionsIterableImpl
 
databaseName(String) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the name of the database to output into.
databaseName - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
databaseName(String) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
databaseName(String) - Method in interface com.mongodb.client.MapReduceIterable
Sets the name of the database to output into.
databaseName - Variable in class com.mongodb.DBRef
 
databaseName - Variable in class com.mongodb.event.CommandStartedEvent
 
databaseName - Variable in class com.mongodb.ListCollectionsIterableImpl
 
databaseName - Variable in class com.mongodb.MapReduceIterableImpl
 
databaseName(String) - Method in class com.mongodb.MapReduceIterableImpl
 
databaseName - Variable in class com.mongodb.MongoNamespace
 
databaseName - Variable in class com.mongodb.operation.CommandReadOperation
 
databaseName - Variable in class com.mongodb.operation.CommandWriteOperation
 
databaseName - Variable in class com.mongodb.operation.CreateCollectionOperation
 
databaseName - Variable in class com.mongodb.operation.CreateViewOperation
 
databaseName - Variable in class com.mongodb.operation.DropDatabaseOperation
 
databaseName - Variable in class com.mongodb.operation.DropUserOperation
 
databaseName - Variable in class com.mongodb.operation.ListCollectionsOperation
 
databaseName - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
databaseName(String) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the name of the database to output into.
databaseName - Variable in class com.mongodb.operation.UserExistsOperation
 
DATATYPE_CONVERTER_PARSE_DATE_TIME_METHOD - Static variable in class org.bson.json.DateTimeFormatter.JaxbDateTimeFormatter
 
DATATYPE_CONVERTER_PRINT_DATE_TIME_METHOD - Static variable in class org.bson.json.DateTimeFormatter.JaxbDateTimeFormatter
 
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
 
DateSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.DateSerializer
Deprecated.
 
dateTimeConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
dateTimeConverter(Converter<Long>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON DateTime values to JSON.
dateTimeConverter - Variable in class org.bson.json.JsonWriterSettings
 
DateTimeFormatter - Class in org.bson.json
 
DateTimeFormatter() - Constructor for class org.bson.json.DateTimeFormatter
 
DateTimeFormatter.FormatterImpl - Interface in org.bson.json
 
DateTimeFormatter.Java8DateTimeFormatter - Class in org.bson.json
 
DateTimeFormatter.JaxbDateTimeFormatter - Class in org.bson.json
 
dateToTimestampSeconds(Date) - Static method in class org.bson.types.ObjectId
 
DB - Class in com.mongodb
A thread-safe client view of a logical database in a MongoDB cluster.
DB(Mongo, String, OperationExecutor) - Constructor for class com.mongodb.DB
 
DB(Mongo, String) - Constructor for class com.mongodb.DB
Constructs a new instance of the DB.
db - Static variable in class com.mongodb.gridfs.CLI
 
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.
 
dbCache - Variable in class com.mongodb.Mongo
 
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(String, DB, OperationExecutor) - Constructor for class com.mongodb.DBCollection
Constructs new DBCollection instance.
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 distinct 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
DBCollectionObjectFactory - Class in com.mongodb
 
DBCollectionObjectFactory() - Constructor for class com.mongodb.DBCollectionObjectFactory
 
DBCollectionObjectFactory(Map<List<String>, Class<? extends DBObject>>, ReflectionDBObject.JavaWrapper) - Constructor for class com.mongodb.DBCollectionObjectFactory
 
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.
DBCursor(DBCollection, DBObject, DBCollectionFindOptions) - Constructor for class com.mongodb.DBCursor
 
DBCursor(DBCollection, DBObject, DBCollectionFindOptions, OperationExecutor, DBDecoderFactory, Decoder<DBObject>) - Constructor for class com.mongodb.DBCursor
 
DBCursor.IteratorOrArray - Enum in com.mongodb
 
DBCursor.OptionalFinalizer - Class in com.mongodb
 
DBDecoder - Interface in com.mongodb
An interface for decoders of BSON into instances of DBObject that belong to a DBCollection.
DBDecoderAdapter - Class in com.mongodb
 
DBDecoderAdapter(DBDecoder, DBCollection, BufferProvider) - Constructor for class com.mongodb.DBDecoderAdapter
 
DBDecoderAdapter.BufferExposingByteArrayOutputStream - Class in com.mongodb
 
DBDecoderFactory - Interface in com.mongodb
Creates concrete DBDecoder instances.
dbDecoderFactory - Variable in class com.mongodb.MongoClientOptions.Builder
 
dbDecoderFactory(DBDecoderFactory) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the decoder factory.
dbDecoderFactory - Variable in class com.mongodb.MongoClientOptions
 
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 - Variable in class com.mongodb.InsertOptions
 
dbEncoder(DBEncoder) - Method in class com.mongodb.InsertOptions
Set the encoder to use for the documents.
DBEncoderAdapter - Class in com.mongodb
 
DBEncoderAdapter(DBEncoder) - Constructor for class com.mongodb.DBEncoderAdapter
 
DBEncoderFactory - Interface in com.mongodb
Creates concrete DBEncoder instances.
dbEncoderFactory - Variable in class com.mongodb.MongoClientOptions.Builder
 
dbEncoderFactory(DBEncoderFactory) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the encoder factory.
dbEncoderFactory - Variable in class com.mongodb.MongoClientOptions
 
dbEncoderFactory - Variable in class com.mongodb.MongoOptions
Deprecated.
Override the encoding factory.
DBEncoderFactoryAdapter - Class in com.mongodb
 
DBEncoderFactoryAdapter(DBEncoderFactory) - Constructor for class com.mongodb.DBEncoderFactoryAdapter
 
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.
DBObjectCollationHelper - Class in com.mongodb
 
DBObjectCollationHelper() - Constructor for class com.mongodb.DBObjectCollationHelper
 
DBObjectFactory - Interface in com.mongodb
 
DBObjects - Class in com.mongodb
 
DBObjects() - Constructor for class com.mongodb.DBObjects
 
DBObjectSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.DBObjectSerializer
Deprecated.
 
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.
DBRefBaseSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.DBRefBaseSerializer
Deprecated.
 
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 class com.mongodb.diagnostics.logging.JULLogger
 
debug(String, Throwable) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
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.
debug(String) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
debug(String, Throwable) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
debug(String) - Method in class org.bson.diagnostics.JULLogger
 
debug(String, Throwable) - Method in class org.bson.diagnostics.JULLogger
 
debug(String) - Method in interface org.bson.diagnostics.Logger
Log a message at the DEBUG level.
debug(String, Throwable) - Method in interface org.bson.diagnostics.Logger
Log an exception (throwable) at the DEBUG level with an accompanying message.
debug(String) - Method in class org.bson.diagnostics.SLF4JLogger
 
debug(String, Throwable) - Method in class org.bson.diagnostics.SLF4JLogger
 
Decimal128 - Class in org.bson.types
A binary integer decimal representation of a 128-bit decimal value, supporting 34 decimal digits of significand and an exponent range of -6143 to +6144.
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.
Decimal128(long, long) - Constructor for class org.bson.types.Decimal128
 
Decimal128(BigDecimal, boolean) - Constructor for class org.bson.types.Decimal128
 
Decimal128Codec - Class in org.bson.codecs
Encodes and decodes Decimal128 objects.
Decimal128Codec() - Constructor for class org.bson.codecs.Decimal128Codec
 
decimal128Converter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
decimal128Converter(Converter<Decimal128>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Decimal128 values to JSON.
decimal128Converter - Variable in class org.bson.json.JsonWriterSettings
 
Decimal128Serializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.Decimal128Serializer
Deprecated.
 
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.
DECIMAL_FORMAT_SYMBOLS - Static variable in class com.mongodb.connection.ServerDescription
 
declaringClassName - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
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.changestream.ChangeStreamDocumentCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.changestream.OperationTypeCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.AbstractGeometryCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
decode(BsonReader, DecoderContext) - Method in class com.mongodb.CompoundDBObjectCodec
 
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.DBDecoderAdapter
 
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(BsonReader, DecoderContext) - Method in class com.mongodb.operation.CommandResultArrayCodec
 
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.BigDecimalCodec
 
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.configuration.LazyCodec
 
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.MapCodec
 
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.pojo.AutomaticPojoCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.pojo.EnumPropertyCodecProvider.EnumCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.pojo.LazyPojoCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
decode(BsonReader, DecoderContext) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
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(String) - Static method in class org.bson.internal.Base64
Decodes the given Base64-encoded string.
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.
decode(Decoder<T>) - Method in class org.bson.RawBsonDocument
Decode this into a document.
DECODE_TABLE - Static variable in class org.bson.internal.Base64
 
decodeBase64(String) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
decodeCoordinateReferenceSystem(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeCoordinateReferenceSystemProperties(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeCoordinates(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeDouble(BsonReader) - Static method in class org.bson.codecs.NumberCodecHelper
 
decodeGeometries(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeGeometry(BsonReader, Class<T>) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeGeometry(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeGeometryCollection(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeHex(String) - Static method in class org.bson.json.JsonReader
 
decodeHooks - Static variable in class org.bson.BSON
 
decodeInt(BsonReader) - Static method in class org.bson.codecs.NumberCodecHelper
 
decodeLineString(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeLong(BsonReader) - Static method in class org.bson.codecs.NumberCodecHelper
 
decodeMultiCoordinates(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeMultiLineString(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeMultiPoint(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeMultiPolygon(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeMultiPolygonCoordinates(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodePoint(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodePolygon(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodePolygonCoordinates(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodePosition(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
decodeProperties(BsonReader, DecoderContext, InstanceCreator<T>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
decodePropertyModel(BsonReader, DecoderContext, InstanceCreator<T>, String, PropertyModel<S>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
decoder - Variable in class com.mongodb.CompoundDBObjectCodec
 
decoder - Variable in class com.mongodb.connection.CommandResultBaseCallback
 
decoder - Variable in class com.mongodb.connection.CommandResultCallback
 
decoder - Variable in class com.mongodb.DBCursor
 
decoder - Variable in class com.mongodb.DBDecoderAdapter
 
decoder - Variable in class com.mongodb.operation.AggregateOperation
 
decoder - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
DECODER - Static variable in class com.mongodb.operation.BulkWriteBatch
 
decoder - Variable in class com.mongodb.operation.ChangeStreamOperation
 
decoder - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
decoder - Variable in class com.mongodb.operation.CommandReadOperation
 
decoder - Variable in class com.mongodb.operation.CommandResultArrayCodec
 
decoder - Variable in class com.mongodb.operation.CommandWriteOperation
 
decoder - Variable in class com.mongodb.operation.DistinctOperation
 
decoder - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
decoder - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
decoder - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
decoder - Variable in class com.mongodb.operation.FindOperation
 
decoder - Variable in class com.mongodb.operation.GroupOperation
 
decoder - Variable in class com.mongodb.operation.ListCollectionsOperation
 
decoder - Variable in class com.mongodb.operation.ListDatabasesOperation
 
decoder - Variable in class com.mongodb.operation.ListIndexesOperation
 
decoder - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
decoder - Variable in class com.mongodb.operation.ParallelCollectionScanOperation
 
decoder - Variable in class com.mongodb.operation.QueryBatchCursor
 
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(DecoderContext.Builder) - Constructor for class org.bson.codecs.DecoderContext
 
DecoderContext.Builder - Class in org.bson.codecs
A builder for DecoderContext instances.
decoderFactory - Variable in class com.mongodb.DBCollection
 
decoderFactory - Variable in class com.mongodb.DBCursor
 
decoderUuidRepresentation - Variable in class org.bson.codecs.UuidCodec
 
decodeUTF8(String) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
decodeWithChildContext(Decoder<T>, BsonReader) - Method in class org.bson.codecs.DecoderContext
Creates a child context and then deserializes using the reader.
decodingHooks - Static variable in class org.bson.BSON
 
DEFAULT - Static variable in class com.mongodb.ReadConcern
Use the servers default read concern.
DEFAULT_BSON_TYPE_CLASS_MAP - Static variable in class com.mongodb.DBObjectCodec
 
DEFAULT_BSON_TYPE_CLASS_MAP - Static variable in class org.bson.codecs.BsonValueCodecProvider
 
DEFAULT_BSON_TYPE_CLASS_MAP - Static variable in class org.bson.codecs.DocumentCodec
 
DEFAULT_BSON_TYPE_CLASS_MAP - Static variable in class org.bson.codecs.MapCodec
 
DEFAULT_BUCKET - Static variable in class com.mongodb.gridfs.GridFS
Bucket to use for the collection namespaces
DEFAULT_BUFFER_SIZE - Static variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
DEFAULT_CHUNKSIZE - Static variable in class com.mongodb.gridfs.GridFS
File's chunk size
DEFAULT_CHUNKSIZE_BYTES - Static variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
DEFAULT_CHUNKSIZE_BYTES - Static variable in class com.mongodb.client.gridfs.GridFSBucketImpl
 
DEFAULT_CODEC_REGISTRY - Static variable in class com.mongodb.async.client.MongoClients
 
DEFAULT_CODEC_REGISTRY - Static variable in class com.mongodb.MongoClient
 
DEFAULT_CONTEXT - Static variable in class org.bson.codecs.DecoderContext
 
DEFAULT_CONTEXT - Static variable in class org.bson.codecs.EncoderContext
 
DEFAULT_CONVENTIONS - Static variable in class org.bson.codecs.pojo.Conventions
The default conventions list
DEFAULT_MAX_BATCH_COUNT - Static variable in class com.mongodb.connection.MessageSettings
 
DEFAULT_MAX_DOCUMENT_SIZE - Static variable in class com.mongodb.connection.MessageSettings
 
DEFAULT_MAX_DOCUMENT_SIZE - Static variable in class com.mongodb.connection.ServerDescription
 
DEFAULT_MAX_MESSAGE_SIZE - Static variable in class com.mongodb.connection.ConnectionDescription
 
DEFAULT_MAX_MESSAGE_SIZE - Static variable in class com.mongodb.connection.MessageSettings
 
DEFAULT_MAX_WRITE_BATCH_SIZE - Static variable in class com.mongodb.connection.ConnectionDescription
 
DEFAULT_PROTOCOL - Static variable in class com.mongodb.connection.PlainAuthenticator
 
DEFAULT_REGISTRY - Static variable in class org.bson.codecs.BsonArrayCodec
 
DEFAULT_REGISTRY - Static variable in class org.bson.codecs.BsonDocumentCodec
 
DEFAULT_REGISTRY - Static variable in class org.bson.codecs.DocumentCodec
 
DEFAULT_REGISTRY - Static variable in class org.bson.codecs.MapCodec
 
DEFAULT_SOCKET_FACTORY - Static variable in class com.mongodb.MongoClientOptions
 
DEFAULT_SSL_SOCKET_FACTORY - Static variable in class com.mongodb.MongoClientOptions
 
DefaultAuthenticator - Class in com.mongodb.connection
 
DefaultAuthenticator(MongoCredential) - Constructor for class com.mongodb.connection.DefaultAuthenticator
 
defaultBucket - Variable in class com.mongodb.client.model.BucketOptions
 
defaultBucket(Object) - Method in class com.mongodb.client.model.BucketOptions
The name of the default bucket for values outside the defined buckets
DefaultClusterableServerFactory - Class in com.mongodb.connection
 
DefaultClusterableServerFactory(ClusterId, ClusterSettings, ServerSettings, ConnectionPoolSettings, StreamFactory, StreamFactory, List<MongoCredential>, CommandListener, String, MongoDriverInformation, List<MongoCompressor>) - Constructor for class com.mongodb.connection.DefaultClusterableServerFactory
 
DefaultClusterFactory - Class in com.mongodb.connection
The default factory for cluster implementations.
DefaultClusterFactory() - Constructor for class com.mongodb.connection.DefaultClusterFactory
 
DefaultConnectionFactory - Class in com.mongodb.connection
 
DefaultConnectionFactory() - Constructor for class com.mongodb.connection.DefaultConnectionFactory
 
DefaultConnectionPool - Class in com.mongodb.connection
 
DefaultConnectionPool(ServerId, InternalConnectionFactory, ConnectionPoolSettings) - Constructor for class com.mongodb.connection.DefaultConnectionPool
 
DefaultConnectionPool.PooledConnection - Class in com.mongodb.connection
 
DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory - Class in com.mongodb.connection
 
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 - Variable in class com.mongodb.bulk.IndexRequest
 
defaultLanguage(String) - Method in class com.mongodb.bulk.IndexRequest
Sets the language for the text index.
defaultLanguage - Variable in class com.mongodb.client.model.IndexOptions
 
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
DefaultRandomStringGenerator() - Constructor for class com.mongodb.connection.ScramSha1Authenticator.DefaultRandomStringGenerator
 
DefaultServer - Class in com.mongodb.connection
 
DefaultServer(ServerId, ClusterConnectionMode, ConnectionPool, ConnectionFactory, ServerMonitorFactory, ServerListener, CommandListener, ClusterClock) - Constructor for class com.mongodb.connection.DefaultServer
 
DefaultServer.DefaultServerProtocolExecutor - Class in com.mongodb.connection
 
DefaultServer.DefaultServerStateListener - Class in com.mongodb.connection
 
DefaultServerConnection - Class in com.mongodb.connection
 
DefaultServerConnection(InternalConnection, ProtocolExecutor, ClusterConnectionMode) - Constructor for class com.mongodb.connection.DefaultServerConnection
 
DefaultServerMonitor - Class in com.mongodb.connection
 
DefaultServerMonitor(ServerId, ServerSettings, ClusterClock, ChangeListener<ServerDescription>, InternalConnectionFactory, ConnectionPool) - Constructor for class com.mongodb.connection.DefaultServerMonitor
 
DefaultServerMonitor.ServerMonitorRunnable - Class in com.mongodb.connection
 
DefaultServerMonitorFactory - Class in com.mongodb.connection
 
DefaultServerMonitorFactory(ServerId, ServerSettings, ClusterClock, InternalConnectionFactory, ConnectionPool) - Constructor for class com.mongodb.connection.DefaultServerMonitorFactory
 
DefaultServerProtocolExecutor() - Constructor for class com.mongodb.connection.DefaultServer.DefaultServerProtocolExecutor
 
DefaultServerStateListener() - Constructor for class com.mongodb.connection.DefaultServer.DefaultServerStateListener
 
DefaultServerStateListener() - Constructor for class com.mongodb.connection.MultiServerCluster.DefaultServerStateListener
 
DefaultServerStateListener() - Constructor for class com.mongodb.connection.SingleServerCluster.DefaultServerStateListener
 
defaultValidator - Variable in class com.mongodb.internal.validator.MappedFieldNameValidator
 
delegate - Variable in class com.mongodb.diagnostics.logging.JULLogger
 
delegate - Variable in class com.mongodb.diagnostics.logging.SLF4JLogger
 
delegate - Variable in class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
delegate - Variable in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
delegate - Variable in class org.bson.diagnostics.JULLogger
 
delegate - Variable in class org.bson.diagnostics.SLF4JLogger
 
delegate - Variable in class org.bson.util.AbstractCopyOnWriteMap
 
delegate - Variable in class org.bson.util.AbstractCopyOnWriteMap.UnmodifiableIterator
 
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(ClientSession, 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(ClientSession, 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, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
delete(BsonValue, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
delete(ClientSession, ObjectId, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
delete(ClientSession, BsonValue, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
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(ClientSession, 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(ClientSession, 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(ObjectId) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
delete(BsonValue) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
delete(ClientSession, ObjectId) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
delete(ClientSession, BsonValue) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
delete(MongoNamespace, boolean, DeleteRequest) - Method in interface com.mongodb.connection.Connection
Delete the documents using the delete wire protocol and apply the write concern.
delete(MongoNamespace, boolean, DeleteRequest) - Method in class com.mongodb.connection.DefaultServerConnection
 
delete() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Tries to mark this node as deleted, failing if already deleted or if this node is header or trailer.
deleteAsync(MongoNamespace, boolean, DeleteRequest, SingleResultCallback<WriteConcernResult>) - Method in interface com.mongodb.connection.AsyncConnection
Delete the documents using the delete wire protocol and apply the write concern asynchronously.
deleteAsync(MongoNamespace, boolean, DeleteRequest, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.DefaultServerConnection
 
deletedCount - Variable in class com.mongodb.client.result.DeleteResult.AcknowledgedDeleteResult
 
deletedCount - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
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(ClientSession, Bson, SingleResultCallback<DeleteResult>) - Method in interface com.mongodb.async.client.MongoCollection
Removes all documents from the collection that match the given query filter.
deleteMany(ClientSession, 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, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
deleteMany(Bson, DeleteOptions, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
deleteMany(ClientSession, Bson, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
deleteMany(ClientSession, Bson, DeleteOptions, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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.
deleteMany(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Removes all documents from the collection that match the given query filter.
deleteMany(ClientSession, Bson, DeleteOptions) - Method in interface com.mongodb.client.MongoCollection
Removes all documents from the collection that match the given query filter.
deleteMany(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
deleteMany(Bson, DeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
deleteMany(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
deleteMany(ClientSession, Bson, DeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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.
DeleteMessage - Class in com.mongodb.connection
An OP_DELETE message.
DeleteMessage(String, DeleteRequest, MessageSettings) - Constructor for class com.mongodb.connection.DeleteMessage
 
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(ClientSession, 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(ClientSession, 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, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
deleteOne(Bson, DeleteOptions, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
deleteOne(ClientSession, Bson, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
deleteOne(ClientSession, Bson, DeleteOptions, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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.
deleteOne(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Removes at most one document from the collection that matches the given filter.
deleteOne(ClientSession, Bson, DeleteOptions) - Method in interface com.mongodb.client.MongoCollection
Removes at most one document from the collection that matches the given filter.
deleteOne(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
deleteOne(Bson, DeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
deleteOne(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
deleteOne(ClientSession, Bson, DeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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
DeleteOperation(MongoNamespace, boolean, WriteConcern, boolean, 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
 
DeleteProtocol - Class in com.mongodb.connection
An implementation of the MongoDB OP_DELETE wire protocol.
DeleteProtocol(MongoNamespace, boolean, DeleteRequest) - Constructor for class com.mongodb.connection.DeleteProtocol
 
DeleteRequest - Class in com.mongodb.bulk
A representation of a delete.
DeleteRequest(BsonDocument) - Constructor for class com.mongodb.bulk.DeleteRequest
Construct a new instance.
deleteRequest - Variable in class com.mongodb.connection.DeleteMessage
 
deleteRequest - Variable in class com.mongodb.connection.DeleteProtocol
 
deleteRequests - Variable in class com.mongodb.operation.DeleteOperation
 
DeleteResult - Class in com.mongodb.client.result
The result of a delete operation.
DeleteResult() - Constructor for class com.mongodb.client.result.DeleteResult
 
DeleteResult.AcknowledgedDeleteResult - Class in com.mongodb.client.result
 
DeleteResult.UnacknowledgedDeleteResult - Class in com.mongodb.client.result
 
depthField - Variable in class com.mongodb.client.model.GraphLookupOptions
 
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.
descendingIterator() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Not yet implemented.
description - Variable in class com.mongodb.connection.BaseCluster
 
description - Variable in class com.mongodb.connection.ClusterId
 
description - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
description(String) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the user defined description of the MongoClient.
description - Variable in class com.mongodb.connection.ClusterSettings
 
description - Variable in class com.mongodb.connection.DefaultServer
 
description - Variable in class com.mongodb.connection.InternalStreamConnection
 
description - Variable in class com.mongodb.connection.MultiServerCluster.ServerTuple
 
description - Variable in class com.mongodb.MongoClientOptions.Builder
 
description(String) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the description.
description - Variable in class com.mongodb.MongoClientOptions
 
description - Variable in class com.mongodb.MongoOptions
Deprecated.
The description for Mongo instances created with these options.
DescriptionHelper - Class in com.mongodb.connection
 
DescriptionHelper() - Constructor for class com.mongodb.connection.DescriptionHelper
 
deserializeBsonValue(BsonReader) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
deserializeBsonValue(BsonBinaryReader) - Method in class org.bson.RawBsonDocument
 
details - Variable in class com.mongodb.bulk.WriteConcernError
 
details - Variable in class com.mongodb.BulkWriteError
 
details - Variable in class com.mongodb.WriteConcernError
 
details - Variable in class com.mongodb.WriteError
 
diacriticSensitive - Variable in class com.mongodb.client.model.TextSearchOptions
 
diacriticSensitive(Boolean) - Method in class com.mongodb.client.model.TextSearchOptions
Set the diacritic-sensitive flag for the text search
disableReadTimeout() - Method in class com.mongodb.connection.netty.NettyStream
 
discardCursor() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
discardCursor() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
discriminator - Variable in class org.bson.codecs.pojo.ClassModel
 
discriminator - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
discriminator(String) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Sets the discriminator to be used when storing instances of the modeled type
discriminatorClassMap - Variable in class org.bson.codecs.pojo.DiscriminatorLookup
 
discriminatorEnabled - Variable in class org.bson.codecs.pojo.ClassModel
 
discriminatorEnabled - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
discriminatorEnabled - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
discriminatorEnabled(boolean) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Enables or disables the use of a discriminator when serializing
discriminatorKey - Variable in class org.bson.codecs.pojo.ClassModel
 
discriminatorKey - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
discriminatorKey(String) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Sets the discriminator key to be used when storing instances of the modeled type
DiscriminatorLookup - Class in org.bson.codecs.pojo
 
DiscriminatorLookup(Map<Class<?>, ClassModel<?>>, Set<String>) - Constructor for class org.bson.codecs.pojo.DiscriminatorLookup
 
discriminatorLookup - Variable in class org.bson.codecs.pojo.LazyPojoCodec
 
discriminatorLookup - Variable in class org.bson.codecs.pojo.PojoCodecImpl
 
discriminatorLookup - Variable in class org.bson.codecs.pojo.PojoCodecProvider
 
dispose() - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
disposeOfSaslClient(SaslClient) - Method in class com.mongodb.connection.SaslAuthenticator
 
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(ClientSession, String, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Gets the distinct values of the specified field name.
distinct(ClientSession, 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 class com.mongodb.async.client.MongoCollectionImpl
 
distinct(String, Bson, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
distinct(ClientSession, String, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
distinct(ClientSession, String, Bson, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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(ClientSession, String, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Gets the distinct values of the specified field name.
distinct(ClientSession, 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.
distinct(String, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
distinct(String, Bson, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
distinct(ClientSession, String, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
distinct(ClientSession, String, Bson, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
DistinctIterable<TResult> - Interface in com.mongodb.async.client
Iterable for distinct.
DistinctIterable<TResult> - Interface in com.mongodb.client
Iterable interface for distinct.
DistinctIterableImpl<TDocument,TResult> - Class in com.mongodb.async.client
 
DistinctIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, AsyncOperationExecutor, String, Bson) - Constructor for class com.mongodb.async.client.DistinctIterableImpl
 
DistinctIterableImpl<TDocument,TResult> - Class in com.mongodb
 
DistinctIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, OperationExecutor, String, Bson) - Constructor for class com.mongodb.DistinctIterableImpl
 
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.
divide(long, long) - Static method in class org.bson.internal.UnsignedLongs
 
DnsResolver - Class in com.mongodb.internal.dns
Utility class for resolving SRV and TXT records.
DnsResolver() - Constructor for class com.mongodb.internal.dns.DnsResolver
 
doAsSubject(PrivilegedAction<Void>) - Method in class com.mongodb.connection.SaslAuthenticator
 
doCallback(String, Object) - Method in class com.mongodb.util.JSONParser
 
document - Variable in class com.mongodb.bulk.InsertRequest
 
document - Variable in class com.mongodb.client.model.InsertOneModel
 
document - Variable in class com.mongodb.InsertRequest
 
document - Variable in class com.mongodb.ReplaceRequest
 
document - Variable in class org.bson.BsonDocumentWriter
 
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.
DOCUMENT_HEADROOM - Static variable in class com.mongodb.connection.BsonWriterHelper
 
DOCUMENT_HEADROOM - Static variable in class com.mongodb.connection.RequestMessage
 
documentAsMap - Variable in class org.bson.Document
 
documentClass - Variable in class com.mongodb.AggregateIterableImpl
 
documentClass - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
documentClass - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
documentClass - Variable in class com.mongodb.async.client.FindIterableImpl
 
documentClass - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
documentClass - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
documentClass - Variable in class com.mongodb.DistinctIterableImpl
 
documentClass - Variable in class com.mongodb.FindIterableImpl
 
documentClass - Variable in class com.mongodb.MapReduceIterableImpl
 
documentClass - Variable in class com.mongodb.MongoCollectionImpl
 
documentCodec - Variable in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
documentCodec - Variable in class org.bson.codecs.BsonJavaScriptWithScopeCodec
 
documentCodec - Variable in class org.bson.codecs.CodeWithScopeCodec
 
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.
DocumentCodec(CodecRegistry) - Constructor for class org.bson.codecs.DocumentCodec
Construct a new instance with the given registry.
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
 
DocumentHelper - Class in com.mongodb.operation
 
DocumentHelper() - Constructor for class com.mongodb.operation.DocumentHelper
 
documentIterator - Variable in class org.bson.BsonDocumentReader.Context
 
documentKey - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
documents - Variable in class com.mongodb.connection.ReplyMessage
 
documentToBsonDocument(TDocument) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
documentToBsonDocument(TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
DocumentToDBRefTransformer - Class in com.mongodb
A Document to DBRef Transformer.
DocumentToDBRefTransformer() - Constructor for class com.mongodb.DocumentToDBRefTransformer
 
documentToQueryResult(BsonDocument, ServerAddress) - Method in class com.mongodb.operation.FindOperation
 
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.
doMaintenance() - Method in class com.mongodb.connection.DefaultConnectionPool
Synchronously prune idle connections and ensure the minimum pool size.
done() - Method in class org.bson.BasicBSONEncoder
 
done() - Method in interface org.bson.BSONEncoder
Free the resources.
doPeekBinarySize() - Method in class org.bson.AbstractBsonReader
Handles the logic to peek at the binary size.
doPeekBinarySize() - Method in class org.bson.BsonBinaryReader
 
doPeekBinarySize() - Method in class org.bson.BsonDocumentReader
 
doPeekBinarySize() - Method in class org.bson.json.JsonReader
 
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
 
doubleConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
doubleConverter(Converter<Double>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Double values to JSON.
doubleConverter - Variable in class org.bson.json.JsonWriterSettings
 
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.
downloadToAsyncOutputStream(GridFSDownloadStream, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
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(ClientSession, 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(ClientSession, 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(ClientSession, 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(ClientSession, 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(String, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(String, AsyncOutputStream, GridFSDownloadOptions, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(ObjectId, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(BsonValue, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, ObjectId, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, BsonValue, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, String, AsyncOutputStream, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, String, AsyncOutputStream, GridFSDownloadOptions, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
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.
downloadToStream(ClientSession, 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(ClientSession, 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(ClientSession, 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(ClientSession, 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.
downloadToStream(ObjectId, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(BsonValue, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(String, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(String, OutputStream, GridFSDownloadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, ObjectId, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, BsonValue, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, String, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(ClientSession, String, OutputStream, GridFSDownloadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStream(GridFSDownloadStream, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
downloadToStreamByName(String, OutputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
downloadToStreamByName(String, OutputStream, GridFSDownloadByNameOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
downloadToStreamByName(String, OutputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
Deprecated.
downloadToStreamByName(String, OutputStream, GridFSDownloadByNameOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
Deprecated.
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
doWriteMinKey() - Method in class org.bson.BsonDocumentWriter
 
doWriteMinKey() - Method in class org.bson.json.JsonWriter
 
doWriteName(String) - Method in class org.bson.AbstractBsonWriter
Handles the logic of writing the element name.
doWriteName(String) - 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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
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.BSONCallbackAdapter
 
doWriteUndefined() - Method in class org.bson.BsonDocumentWriter
 
doWriteUndefined() - Method in class org.bson.json.JsonWriter
 
DRIVER_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
DRIVER_NAME_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
DRIVER_VERSION_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
driverInformation - Variable in class com.mongodb.client.MongoDriverInformation.Builder
 
driverName - Variable in class com.mongodb.client.MongoDriverInformation.Builder
 
driverName(String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
Sets the name
driverNames - Variable in class com.mongodb.client.MongoDriverInformation
 
driverPlatform - Variable in class com.mongodb.client.MongoDriverInformation.Builder
 
driverPlatform(String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
Sets the platform
driverPlatforms - Variable in class com.mongodb.client.MongoDriverInformation
 
driverVersion - Variable in class com.mongodb.client.MongoDriverInformation.Builder
 
driverVersion(String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
Sets the version
driverVersions - Variable in class com.mongodb.client.MongoDriverInformation
 
drop(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Drops the data associated with this bucket from the database.
drop(ClientSession, 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 class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
drop(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
drop(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops this collection from the Database.
drop(ClientSession, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops this collection from the Database.
drop(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
drop(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
drop(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Drops this database.
drop(ClientSession, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoDatabase
Drops this database.
drop(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
drop(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
drop() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Drops the data associated with this bucket from the database.
drop(ClientSession) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Drops the data associated with this bucket from the database.
drop() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
drop(ClientSession) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
drop() - Method in interface com.mongodb.client.MongoCollection
Drops this collection from the Database.
drop(ClientSession) - 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(ClientSession) - 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.
drop() - Method in class com.mongodb.MongoCollectionImpl
 
drop(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
drop() - Method in class com.mongodb.MongoDatabaseImpl
 
drop(ClientSession) - Method in class com.mongodb.MongoDatabaseImpl
 
DROP_DATABASE - Static variable in class com.mongodb.operation.DropDatabaseOperation
 
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 - Variable in class com.mongodb.bulk.IndexRequest
 
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(String, DropIndexOptions, 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(Bson, DropIndexOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(ClientSession, String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given its name.
dropIndex(ClientSession, String, DropIndexOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given its name.
dropIndex(ClientSession, Bson, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(ClientSession, Bson, DropIndexOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(String, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(Bson, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(Bson, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(ClientSession, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(ClientSession, String, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(ClientSession, Bson, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(ClientSession, Bson, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndex(String) - Method in interface com.mongodb.client.MongoCollection
Drops the index given its name.
dropIndex(String, DropIndexOptions) - 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(Bson, DropIndexOptions) - Method in interface com.mongodb.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(ClientSession, String) - Method in interface com.mongodb.client.MongoCollection
Drops the index given its name.
dropIndex(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Drops the index given the keys used to create it.
dropIndex(ClientSession, String, DropIndexOptions) - Method in interface com.mongodb.client.MongoCollection
Drops the index given its name.
dropIndex(ClientSession, Bson, DropIndexOptions) - 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.
dropIndex(String) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(String, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(Bson, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(ClientSession, String) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(ClientSession, String, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndex(ClientSession, Bson, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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(DropIndexOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes(ClientSession, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes(ClientSession, DropIndexOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndexes(DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndexes(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndexes(ClientSession, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
dropIndexes() - Method in interface com.mongodb.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes(ClientSession) - Method in interface com.mongodb.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes(DropIndexOptions) - Method in interface com.mongodb.client.MongoCollection
Drop all the indexes on this collection, except for the default on _id.
dropIndexes(ClientSession, DropIndexOptions) - 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.
dropIndexes() - Method in class com.mongodb.MongoCollectionImpl
 
dropIndexes(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndexes(DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
dropIndexes(ClientSession, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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.
DropIndexOptions - Class in com.mongodb.client.model
The options to apply to the command when dropping indexes.
DropIndexOptions() - Constructor for class com.mongodb.client.model.DropIndexOptions
 
dropTarget - Variable in class com.mongodb.client.model.RenameCollectionOptions
 
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 - Variable in class com.mongodb.operation.RenameCollectionOperation
 
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.
dumpBuffer(boolean) - Method in class com.mongodb.gridfs.GridFSInputFile
Dumps a new chunk into the chunks collection.
duplicate() - Method in class com.mongodb.connection.CompositeByteBuf
 
duplicate() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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
 
DUPLICATE_KEY_ERROR_CODES - Static variable in enum com.mongodb.ErrorCategory
 
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.
duration - Variable in class com.mongodb.operation.MapReduceStatistics
 

E

elapsedTimeNanos - Variable in class com.mongodb.event.CommandFailedEvent
 
elapsedTimeNanos - Variable in class com.mongodb.event.CommandSucceededEvent
 
elapsedTimeNanos - Variable in class com.mongodb.event.ServerHeartbeatFailedEvent
 
elapsedTimeNanos - Variable in class com.mongodb.event.ServerHeartbeatSucceededEvent
 
electionId - Variable in class com.mongodb.connection.ServerDescription.Builder
 
electionId(ObjectId) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the electionId reported by this server.
electionId - Variable in class com.mongodb.connection.ServerDescription
 
ELEM_MATCH - Static variable in class com.mongodb.QueryOperators
 
element() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
element - Variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
 
ElementExtendingBsonWriter - Class in com.mongodb.connection
 
ElementExtendingBsonWriter(BsonBinaryWriter, List<BsonElement>) - Constructor for class com.mongodb.connection.ElementExtendingBsonWriter
 
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
ElemMatchFilterProjection(String, Bson) - Constructor for class com.mongodb.client.model.Projections.ElemMatchFilterProjection
 
emitCount - Variable in class com.mongodb.operation.MapReduceStatistics
 
empty() - Static method in class org.bson.codecs.configuration.Optional
 
emptyAsyncCursor(AsyncConnectionSource) - Method in class com.mongodb.operation.ListCollectionsOperation
 
emptyAsyncCursor(AsyncConnectionSource) - Method in class com.mongodb.operation.ListIndexesOperation
 
EmptyBSONCallback - Class in org.bson
Convenience implementation of BSONCallback that throws UnsupportedOperationException for all methods.
EmptyBSONCallback() - Constructor for class org.bson.EmptyBSONCallback
 
enabled - Variable in class com.mongodb.connection.SslSettings.Builder
 
enabled(boolean) - Method in class com.mongodb.connection.SslSettings.Builder
Define whether SSL should be enabled.
enabled - Variable in class com.mongodb.connection.SslSettings
 
enableDiscriminator(boolean) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Enables or disables the use of a discriminator when serializing
enableHostNameVerification(SSLParameters) - Static method in class com.mongodb.internal.connection.SslHelper
Enable HTTP endpoint verification on the given SSL parameters.
enableSni(ServerAddress, SSLParameters) - Method in class com.mongodb.internal.connection.Java8SniSslHelper
 
enableSni(ServerAddress, SSLParameters) - Method in interface com.mongodb.internal.connection.SniSslHelper
Enable SNI.
enableSni(ServerAddress, SSLParameters) - Static method in class com.mongodb.internal.connection.SslHelper
Enable SNI if running on Java 8 or later.
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, ChangeStreamDocument<TResult>, EncoderContext) - Method in class com.mongodb.client.model.changestream.ChangeStreamDocumentCodec
 
encode(BsonWriter, OperationType, EncoderContext) - Method in class com.mongodb.client.model.changestream.OperationTypeCodec
 
encode(BsonWriter, T, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.AbstractGeometryCodec
 
encode(BsonWriter, NamedCoordinateReferenceSystem, EncoderContext) - Method in class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
encode(BsonWriter, DBObject, EncoderContext) - Method in class com.mongodb.CompoundDBObjectCodec
 
encode(BsonOutput, SessionContext) - Method in class com.mongodb.connection.RequestMessage
Encoded the message to the given output.
encode(BsonWriter, DBObject, EncoderContext) - Method in class com.mongodb.DBEncoderAdapter
 
encode(BsonWriter, DBObject, EncoderContext) - Method in class com.mongodb.DBEncoderFactoryAdapter
 
encode(BsonWriter, DBObject, EncoderContext) - Method in class com.mongodb.DBObjectCodec
 
encode(BsonWriter, DBRef, EncoderContext) - Method in class com.mongodb.DBRefCodec
 
encode(BsonWriter, WriteRequest, EncoderContext) - Method in class com.mongodb.operation.BulkWriteBatch.WriteRequestEncoder
 
encode(BSONObject) - Method in class org.bson.BasicBSONEncoder
 
encode() - Method in class org.bson.BasicBSONObject
 
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, BigDecimal, EncoderContext) - Method in class org.bson.codecs.BigDecimalCodec
 
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, T, EncoderContext) - Method in class org.bson.codecs.configuration.LazyCodec
 
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, Map<String, Object>, EncoderContext) - Method in class org.bson.codecs.MapCodec
 
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, T, EncoderContext) - Method in class org.bson.codecs.pojo.AutomaticPojoCodec
 
encode(BsonWriter, Collection<T>, EncoderContext) - Method in class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
encode(BsonWriter, T, EncoderContext) - Method in class org.bson.codecs.pojo.EnumPropertyCodecProvider.EnumCodec
 
encode(BsonWriter, T, EncoderContext) - Method in class org.bson.codecs.pojo.LazyPojoCodec
 
encode(BsonWriter, Map<String, T>, EncoderContext) - Method in class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
encode(BsonWriter, T, EncoderContext) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
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
 
encode(byte[]) - Static method in class org.bson.internal.Base64
Encodes the given byte array into a Base64-encoded string.
ENCODE_TABLE - Static variable in class org.bson.internal.Base64
This array is a lookup table that translates 6-bit positive integer index values into their "Base64 Alphabet" equivalents as specified in Table 1 of RFC 2045.
encodeArray(BsonWriter, Object) - Method in class com.mongodb.DBObjectCodec
 
encodeBase64(byte[]) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
encodeBsonObject(BsonWriter, BSONObject) - Method in class com.mongodb.DBObjectCodec
 
encodeByteArray(BsonWriter, byte[]) - Method in class com.mongodb.DBObjectCodec
 
encodeCodeWScope(BsonWriter, CodeWScope) - Method in class com.mongodb.DBObjectCodec
 
encodeCoordinateReferenceSystem(BsonWriter, Geometry, EncoderContext, CodecRegistry) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeDBRef(BsonWriter, DBRef) - Method in class com.mongodb.DBObjectCodec
 
encodeGeometry(BsonWriter, Geometry, EncoderContext, CodecRegistry) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeGeometryCollection(BsonWriter, GeometryCollection, EncoderContext, CodecRegistry) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeHooks - Static variable in class org.bson.BSON
 
encodeIterable(BsonWriter, Iterable) - Method in class com.mongodb.DBObjectCodec
 
encodeLinearRing(List<Position>, BsonWriter) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeLineString(BsonWriter, LineString) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeMap(BsonWriter, Map<String, Object>) - Method in class com.mongodb.DBObjectCodec
 
encodeMessage(RequestMessage, BsonOutput) - Static method in class com.mongodb.connection.ProtocolHelper
 
encodeMessageBodyWithMetadata(BsonOutput, SessionContext) - Method in class com.mongodb.connection.CommandMessage
 
encodeMessageBodyWithMetadata(BsonOutput, SessionContext) - Method in class com.mongodb.connection.CompressedMessage
 
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.DeleteMessage
 
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.GetMoreMessage
 
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.InsertMessage
 
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.KillCursorsMessage
 
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.LegacyMessage
 
encodeMessageBodyWithMetadata(BsonOutput, SessionContext) - Method in class com.mongodb.connection.LegacyMessage
 
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.QueryMessage
 
encodeMessageBodyWithMetadata(BsonOutput, SessionContext) - Method in class com.mongodb.connection.RequestMessage
Encode the message body to the given output.
encodeMessageBodyWithMetadata(BsonOutput) - Method in class com.mongodb.connection.UpdateMessage
 
encodeMessageWithMetadata(RequestMessage, BsonOutput) - Static method in class com.mongodb.connection.ProtocolHelper
 
encodeMultiLineString(BsonWriter, MultiLineString) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeMultiPoint(BsonWriter, MultiPoint) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeMultiPolygon(BsonWriter, MultiPolygon) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodePoint(BsonWriter, Point) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodePolygon(BsonWriter, Polygon) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodePolygonCoordinates(BsonWriter, PolygonCoordinates) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodePosition(BsonWriter, Position) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
encodeProperty(BsonWriter, T, EncoderContext, PropertyModel<S>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
encoder - Variable in class com.mongodb.client.model.DBCollectionRemoveOptions
 
encoder(DBEncoder) - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Sets the encoder
encoder - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
encoder(DBEncoder) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the encoder
encoder - Variable in class com.mongodb.CompoundDBObjectCodec
 
encoder - Variable in class com.mongodb.DBEncoderAdapter
 
encoder - Variable in class org.bson.BsonDocumentWrapper
 
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.
ENCODER_CONTEXT - Static variable in class com.mongodb.connection.BsonWriterHelper
 
encoderClass - Variable in class com.mongodb.client.model.geojson.codecs.AbstractGeometryCodec
 
encoderClass - Variable in class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
encoderClass - Variable in class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
EncoderContext - Class in org.bson.codecs
The context for encoding values to BSON.
EncoderContext(EncoderContext.Builder) - Constructor for class org.bson.codecs.EncoderContext
 
EncoderContext.Builder - Class in org.bson.codecs
A builder for EncoderContext instances.
encoderFactory - Variable in class com.mongodb.DBCollection
 
encoderFactory - Variable in class com.mongodb.DBEncoderFactoryAdapter
 
encoderUuidRepresentation - Variable in class org.bson.codecs.UuidCodec
 
encodeUTF8(byte[]) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
encodeValue(BsonDocumentWriter, TItem, CodecRegistry) - Static method in class com.mongodb.client.model.BuildersHelper
 
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.
encodingCollectibleDocument - Variable in class org.bson.codecs.EncoderContext.Builder
 
encodingCollectibleDocument - Variable in class org.bson.codecs.EncoderContext
 
encodingHooks - Static variable in class org.bson.BSON
 
encodingMetadata - Variable in class com.mongodb.connection.RequestMessage
 
EncodingMetadata(int) - Constructor for class com.mongodb.connection.RequestMessage.EncodingMetadata
 
END_SESSIONS_BATCH_SIZE - Static variable in class com.mongodb.internal.session.ServerSessionPool
 
endClosedSessions() - Method in class com.mongodb.internal.session.ServerSessionPool
 
endOffset - Variable in class com.mongodb.connection.CompositeByteBuf.Component
 
ensure(int) - Method in class org.bson.io.BasicOutputBuffer
 
ensureAccessible() - Method in class com.mongodb.connection.CompositeByteBuf
 
ensureAvailable(int) - Method in class org.bson.io.ByteBufferBsonInput
 
ensureExactRounding(BigDecimal, int) - Method in class org.bson.types.Decimal128
 
ensureMinSize(int, boolean) - Method in class com.mongodb.internal.connection.ConcurrentPool
 
ensureOpen() - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
ensureOpen() - Method in class org.bson.io.BasicOutputBuffer
 
ensureOpen() - Method in class org.bson.io.ByteBufferBsonInput
 
ensureServers(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
ensureValidValue(String) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
entrySet() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
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
 
entrySet() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
EntrySet() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.EntrySet
 
entrySet() - Method in class org.bson.util.AbstractCopyOnWriteMap.Immutable
 
entrySet - Variable in class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
entrySet() - Method in class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
entrySet() - Method in class org.bson.util.AbstractCopyOnWriteMap.View
 
entrySet() - Method in class org.bson.util.ComputingMap
 
EnumCodec(Class<T>) - Constructor for class org.bson.codecs.pojo.EnumPropertyCodecProvider.EnumCodec
 
EnumPropertyCodecProvider - Class in org.bson.codecs.pojo
 
EnumPropertyCodecProvider(CodecRegistry) - Constructor for class org.bson.codecs.pojo.EnumPropertyCodecProvider
 
EnumPropertyCodecProvider.EnumCodec<T extends java.lang.Enum<T>> - Class in org.bson.codecs.pojo
 
eof - Variable in class org.bson.json.JsonBuffer
 
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(TItem) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of _id field equals the specified value.
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.AcknowledgedBulkWriteResult
 
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.changestream.ChangeStreamDocument
 
equals(Object) - Method in class com.mongodb.client.model.changestream.UpdateDescription
 
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.client.result.DeleteResult.AcknowledgedDeleteResult
 
equals(Object) - Method in class com.mongodb.client.result.DeleteResult.UnacknowledgedDeleteResult
 
equals(Object) - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
equals(Object) - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
equals(Object) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
equals(Object) - Method in class com.mongodb.connection.ChangeEvent
 
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 class com.mongodb.DocumentToDBRefTransformer
 
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.MongoCompressor
 
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.operation.BsonArrayWrapper
 
equals(Object) - Method in class com.mongodb.operation.CommandResultCodecProvider
 
equals(Object) - Method in class com.mongodb.ReadConcern
 
equals(Object) - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
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.UnacknowledgedBulkWriteResult
 
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.BsonElement
 
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.configuration.ChildCodecRegistry
 
equals(Object) - Method in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
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.MapCodecProvider
 
equals(Object) - Method in class org.bson.codecs.pojo.ClassModel
 
equals(Object) - Method in class org.bson.codecs.pojo.PropertyModel
 
equals(Object) - Method in class org.bson.codecs.pojo.TypeData
 
equals(Object) - Method in class org.bson.codecs.pojo.TypeParameterMap
 
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
equals(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
equals(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
equals(Object, Object) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
equals(Object) - Method in class org.bson.util.ComputingMap
 
error - Variable in class com.mongodb.connection.FutureAsyncCompletionHandler
 
error(String) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
error(String, Throwable) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
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.
error(String) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
error(String, Throwable) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
error - Variable in exception com.mongodb.MongoWriteException
 
error(String) - Method in class org.bson.diagnostics.JULLogger
 
error(String, Throwable) - Method in class org.bson.diagnostics.JULLogger
 
error(String) - Method in interface org.bson.diagnostics.Logger
Log a message at the ERROR level.
error(String, Throwable) - Method in interface org.bson.diagnostics.Logger
Log an exception (throwable) at the ERROR level with an accompanying message.
error(String) - Method in class org.bson.diagnostics.SLF4JLogger
 
error(String, Throwable) - Method in class org.bson.diagnostics.SLF4JLogger
 
ErrorCategory - Enum in com.mongodb
A categorization of errors returned by a MongoDB server command.
ErrorCategory() - Constructor for enum com.mongodb.ErrorCategory
 
errorCode - Variable in exception org.bson.BSONException
 
errorHandlingCallback(SingleResultCallback<T>, Logger) - Static method in class com.mongodb.internal.async.ErrorHandlingResultCallback
 
ErrorHandlingResultCallback<T> - Class in com.mongodb.internal.async
This class is not part of the public API and may be removed or changed at any time.
ErrorHandlingResultCallback(SingleResultCallback<T>, Logger) - Constructor for class com.mongodb.internal.async.ErrorHandlingResultCallback
 
errorMessage - Variable in exception com.mongodb.MongoQueryException
 
errors - Variable in exception com.mongodb.MongoBulkWriteException
 
eval(String, Object...) - Method in class com.mongodb.DB
evaluateChallenge(byte[]) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
EventListenerHelper - Class in com.mongodb.internal.event
 
EventListenerHelper() - Constructor for class com.mongodb.internal.event.EventListenerHelper
 
eventLoopGroup - Variable in class com.mongodb.connection.netty.NettyStreamFactory
 
eventLoopGroup - Variable in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
 
eventLoopGroup(EventLoopGroup) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
Sets the event loop group.
eventLoopGroup - Variable in class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
exceedsLimits(MessageSettings, int, int, int) - Static method in class com.mongodb.connection.BsonWriterHelper
 
exception - Variable in class com.mongodb.connection.ServerDescription.Builder
 
exception(Throwable) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the exception thrown while attempting to determine the server description.
exception - Variable in class com.mongodb.connection.ServerDescription
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.mongodb.connection.netty.NettyStream.InboundBufferHandler
 
EXCEPTIONS - Static variable in class com.mongodb.internal.validator.CollectibleDocumentFieldNameValidator
 
exceptionTransformingCallback(SingleResultCallback<T>) - Static method in class com.mongodb.operation.FindOperation
 
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(AsyncReadOperation<T>, ReadPreference, SingleResultCallback<T>) - Method in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
execute(AsyncReadOperation<T>, ReadPreference, ClientSession, SingleResultCallback<T>) - Method in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
execute(AsyncWriteOperation<T>, SingleResultCallback<T>) - Method in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
execute(AsyncWriteOperation<T>, ClientSession, SingleResultCallback<T>) - Method in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
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(InternalConnection) - Method in interface com.mongodb.connection.CommandProtocol
 
execute(InternalConnection) - Method in class com.mongodb.connection.CommandProtocolImpl
 
execute(LegacyProtocol<T>, InternalConnection) - Method in class com.mongodb.connection.DefaultServer.DefaultServerProtocolExecutor
 
execute(CommandProtocol<T>, InternalConnection, SessionContext) - Method in class com.mongodb.connection.DefaultServer.DefaultServerProtocolExecutor
 
execute(InternalConnection) - Method in class com.mongodb.connection.DeleteProtocol
 
execute(InternalConnection) - Method in class com.mongodb.connection.GetMoreProtocol
 
execute(InternalConnection) - Method in class com.mongodb.connection.InsertProtocol
 
execute(InternalConnection) - Method in class com.mongodb.connection.KillCursorProtocol
 
execute(InternalConnection) - Method in interface com.mongodb.connection.LegacyProtocol
 
execute(LegacyProtocol<T>, InternalConnection) - Method in interface com.mongodb.connection.ProtocolExecutor
 
execute(CommandProtocol<T>, InternalConnection, SessionContext) - Method in interface com.mongodb.connection.ProtocolExecutor
 
execute(InternalConnection) - Method in class com.mongodb.connection.QueryProtocol
 
execute(InternalConnection) - Method in class com.mongodb.connection.UpdateProtocol
 
execute(InternalConnection) - Method in class com.mongodb.connection.WriteProtocol
 
execute(ReadBinding) - Method in class com.mongodb.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
execute() - Method in class com.mongodb.MongoIterableImpl
 
execute(ReadBinding) - Method in class com.mongodb.operation.AggregateExplainOperation
 
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(AsyncReadOperation<T>, ReadPreference, ClientSession, 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(AsyncWriteOperation<T>, ClientSession, SingleResultCallback<T>) - Method in interface com.mongodb.operation.AsyncOperationExecutor
Execute the write operation.
execute(WriteBinding) - Method in class com.mongodb.operation.BaseFindAndModifyOperation
 
execute(WriteBinding) - Method in class com.mongodb.operation.BaseWriteOperation
 
execute(ReadBinding) - Method in class com.mongodb.operation.ChangeStreamOperation
 
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(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.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
Deprecated.
Execute the read operation with the given read preference.
execute(WriteOperation<T>) - Method in interface com.mongodb.operation.OperationExecutor
Deprecated.
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
execute(ReadOperation<T>, ReadPreference) - Method in interface com.mongodb.OperationExecutor
Execute the read operation with the given read preference.
execute(WriteOperation<T>) - Method in interface com.mongodb.OperationExecutor
Execute the write operation.
execute(ReadOperation<T>, ReadPreference, ClientSession) - Method in interface com.mongodb.OperationExecutor
Execute the read operation with the given read preference.
execute(WriteOperation<T>, ClientSession) - Method in interface com.mongodb.OperationExecutor
Execute the write operation.
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.async.client.AggregateToCollectionThenFindOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<TResult>>) - Method in class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceWriteOperation
 
executeAsync(InternalConnection, SingleResultCallback<T>) - Method in interface com.mongodb.connection.CommandProtocol
 
executeAsync(InternalConnection, SingleResultCallback<T>) - Method in class com.mongodb.connection.CommandProtocolImpl
 
executeAsync(LegacyProtocol<T>, InternalConnection, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServer.DefaultServerProtocolExecutor
 
executeAsync(CommandProtocol<T>, InternalConnection, SessionContext, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServer.DefaultServerProtocolExecutor
 
executeAsync(InternalConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.DeleteProtocol
 
executeAsync(InternalConnection, SingleResultCallback<QueryResult<T>>) - Method in class com.mongodb.connection.GetMoreProtocol
 
executeAsync(InternalConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.InsertProtocol
 
executeAsync(InternalConnection, SingleResultCallback<Void>) - Method in class com.mongodb.connection.KillCursorProtocol
 
executeAsync(InternalConnection, SingleResultCallback<T>) - Method in interface com.mongodb.connection.LegacyProtocol
 
executeAsync(LegacyProtocol<T>, InternalConnection, SingleResultCallback<T>) - Method in interface com.mongodb.connection.ProtocolExecutor
 
executeAsync(CommandProtocol<T>, InternalConnection, SessionContext, SingleResultCallback<T>) - Method in interface com.mongodb.connection.ProtocolExecutor
 
executeAsync(InternalConnection, SingleResultCallback<QueryResult<T>>) - Method in class com.mongodb.connection.QueryProtocol
 
executeAsync(InternalConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.UpdateProtocol
 
executeAsync(InternalConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.WriteProtocol
 
executeAsync(RequestMessage, InternalConnection, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.WriteProtocol
 
executeAsync(AsyncReadBinding, SingleResultCallback<BsonDocument>) - Method in class com.mongodb.operation.AggregateExplainOperation
 
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<T>) - Method in class com.mongodb.operation.BaseFindAndModifyOperation
 
executeAsync(AsyncWriteBinding, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.operation.BaseWriteOperation
 
executeAsync(AsyncReadBinding, SingleResultCallback<AsyncBatchCursor<T>>) - Method in class com.mongodb.operation.ChangeStreamOperation
 
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(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
 
executeBatchesAsync(AsyncWriteBinding, AsyncConnection, BulkWriteBatch, boolean, OperationHelper.ConnectionReleasingWrappedCallback<BulkWriteResult>) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeBulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeBulkWrite(ClientSession, List<? extends WriteModel<? extends TDocument>>, BulkWriteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeBulkWriteBatch(WriteBinding, Connection, BulkWriteBatch) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeBulkWriteOperation(boolean, Boolean, List<WriteRequest>) - Method in class com.mongodb.DBCollection
 
executeBulkWriteOperation(boolean, Boolean, List<WriteRequest>, WriteConcern) - Method in class com.mongodb.DBCollection
 
executeCommand(ClientSession, Bson, ReadPreference, Class<TResult>, SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
executeCommand(String, BsonDocument, InternalConnection) - Static method in class com.mongodb.connection.CommandHelper
 
executeCommand(String, BsonDocument, ClusterClock, InternalConnection) - Static method in class com.mongodb.connection.CommandHelper
 
executeCommand(BsonDocument) - Method in class com.mongodb.DB
 
executeCommand(BsonDocument, ReadPreference) - Method in class com.mongodb.DB
 
executeCommand(ClientSession, Bson, ReadPreference, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
executeCommand(Connection, BulkWriteBatch, WriteBinding) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeCommandAsync(String, BsonDocument, InternalConnection, SingleResultCallback<BsonDocument>) - Static method in class com.mongodb.connection.CommandHelper
 
executeCommandAsync(AsyncWriteBinding, AsyncConnection, BulkWriteBatch, OperationHelper.ConnectionReleasingWrappedCallback<BulkWriteResult>, SingleResultCallback<BsonDocument>) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeCommandWithoutCheckingForFailure(String, BsonDocument, InternalConnection) - Static method in class com.mongodb.connection.CommandHelper
 
executeCount(ClientSession, Bson, CountOptions, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeCount(ClientSession, Bson, CountOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeCreateCollection(ClientSession, String, CreateCollectionOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
executeCreateCollection(ClientSession, String, CreateCollectionOptions) - Method in class com.mongodb.MongoDatabaseImpl
 
executeCreateIndexes(ClientSession, List<IndexModel>, CreateIndexOptions, SingleResultCallback<List<String>>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeCreateIndexes(ClientSession, List<IndexModel>, CreateIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeCreateView(ClientSession, String, String, List<? extends Bson>, CreateViewOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
executeCreateView(ClientSession, String, String, List<? extends Bson>, CreateViewOptions) - Method in class com.mongodb.MongoDatabaseImpl
 
executeDelete(ClientSession, BsonValue, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
executeDelete(ClientSession, Bson, DeleteOptions, boolean, SingleResultCallback<DeleteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeDelete(ClientSession, BsonValue) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
executeDelete(ClientSession, Bson, DeleteOptions, boolean) - Method in class com.mongodb.MongoCollectionImpl
 
executeDrop(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
executeDrop(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeDrop(ClientSession, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
executeDrop(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
executeDrop(ClientSession) - Method in class com.mongodb.MongoDatabaseImpl
 
executeDropIndex(ClientSession, Bson, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeDropIndex(ClientSession, String, DropIndexOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeDropIndex(ClientSession, String, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeDropIndex(ClientSession, Bson, DropIndexOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeFindOneAndDelete(ClientSession, Bson, FindOneAndDeleteOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeFindOneAndDelete(ClientSession, Bson, FindOneAndDeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeFindOneAndReplace(ClientSession, Bson, TDocument, FindOneAndReplaceOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeFindOneAndReplace(ClientSession, Bson, TDocument, FindOneAndReplaceOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeFindOneAndUpdate(ClientSession, Bson, Bson, FindOneAndUpdateOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeFindOneAndUpdate(ClientSession, Bson, Bson, FindOneAndUpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeInsertMany(ClientSession, List<? extends TDocument>, InsertManyOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeInsertMany(ClientSession, List<? extends TDocument>, InsertManyOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeInsertOne(ClientSession, TDocument, InsertOneOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeInsertOne(ClientSession, TDocument, InsertOneOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeLegacyBatches(Connection) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeLegacyBatchesAsync(AsyncConnection, List<? extends WriteRequest>, int, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
executeProtocol(LegacyProtocol<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
executeProtocol(CommandProtocol<T>, SessionContext) - Method in class com.mongodb.connection.DefaultServerConnection
 
executeProtocolAsync(LegacyProtocol<T>, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
executeProtocolAsync(CommandProtocol<T>, SessionContext, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
executeRename(ClientSession, BsonValue, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
executeRename(ClientSession, BsonValue, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
executeRenameCollection(ClientSession, MongoNamespace, RenameCollectionOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeRenameCollection(ClientSession, MongoNamespace, RenameCollectionOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeReplaceOne(ClientSession, Bson, TDocument, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeReplaceOne(ClientSession, Bson, TDocument, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
executeRetryableCommand(WriteBinding, String, ReadPreference, FieldNameValidator, Decoder<T>, CommandOperationHelper.CommandCreator, CommandOperationHelper.CommandTransformer<T, R>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeRetryableCommand(AsyncWriteBinding, String, ReadPreference, FieldNameValidator, Decoder<T>, CommandOperationHelper.CommandCreator, CommandOperationHelper.CommandTransformer<T, R>, SingleResultCallback<R>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeSingleWriteRequest(ClientSession, WriteRequest, Boolean, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeSingleWriteRequest(ClientSession, WriteRequest, Boolean) - Method in class com.mongodb.MongoCollectionImpl
 
executeUpdate(ClientSession, Bson, Bson, UpdateOptions, boolean, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
executeUpdate(ClientSession, Bson, Bson, UpdateOptions, boolean) - Method in class com.mongodb.MongoCollectionImpl
 
executeUploadFromStream(ClientSession, BsonValue, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
executeUploadFromStream(ClientSession, BsonValue, String, InputStream, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument, Decoder<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument, Decoder<D>, CommandOperationHelper.CommandTransformer<D, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument, Connection) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument, Connection, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(ReadBinding, String, BsonDocument, Decoder<BsonDocument>, Connection, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, Decoder<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, Decoder<D>, CommandOperationHelper.CommandTransformer<D, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, Connection, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, Decoder<BsonDocument>, Connection, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, FieldNameValidator, Decoder<BsonDocument>, Connection, CommandOperationHelper.CommandTransformer<BsonDocument, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, FieldNameValidator, Decoder<D>, CommandOperationHelper.CommandTransformer<D, T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(WriteBinding, String, BsonDocument, Connection) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(String, BsonDocument, Decoder<T>, ConnectionSource, ReadPreference) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(String, BsonDocument, FieldNameValidator, Decoder<T>, ConnectionSource, ReadPreference) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(String, BsonDocument, Decoder<T>, Connection, ReadPreference, SessionContext) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(String, BsonDocument, Decoder<D>, Connection, ReadPreference, CommandOperationHelper.CommandTransformer<D, T>, SessionContext) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocol(String, BsonDocument, FieldNameValidator, Decoder<D>, Connection, ReadPreference, CommandOperationHelper.CommandTransformer<D, T>, SessionContext) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncReadBinding, String, BsonDocument, SingleResultCallback<BsonDocument>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncReadBinding, String, BsonDocument, Decoder<T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncReadBinding, String, BsonDocument, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncReadBinding, String, BsonDocument, Decoder<D>, CommandOperationHelper.CommandTransformer<D, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncReadBinding, String, BsonDocument, AsyncConnection, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncReadBinding, String, BsonDocument, Decoder<BsonDocument>, AsyncConnection, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, SingleResultCallback<BsonDocument>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, Decoder<T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, Decoder<D>, CommandOperationHelper.CommandTransformer<D, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, Decoder<BsonDocument>, AsyncConnection, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, FieldNameValidator, Decoder<BsonDocument>, AsyncConnection, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, FieldNameValidator, Decoder<D>, CommandOperationHelper.CommandTransformer<D, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, AsyncConnection, SingleResultCallback<BsonDocument>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(AsyncWriteBinding, String, BsonDocument, AsyncConnection, CommandOperationHelper.CommandTransformer<BsonDocument, T>, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(String, BsonDocument, Decoder<D>, AsyncConnection, ReadPreference, CommandOperationHelper.CommandTransformer<D, T>, SessionContext, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWrappedCommandProtocolAsync(String, BsonDocument, FieldNameValidator, Decoder<D>, AsyncConnection, ReadPreference, CommandOperationHelper.CommandTransformer<D, T>, SessionContext, SingleResultCallback<T>) - Static method in class com.mongodb.operation.CommandOperationHelper
 
executeWriteOperation(BaseWriteOperation) - Method in class com.mongodb.DBCollection
 
EXECUTION_TIMEOUT_ERROR_CODES - Static variable in enum com.mongodb.ErrorCategory
 
executor - Variable in class com.mongodb.async.client.MongoClientImpl
 
executor - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
executor - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
executor - Variable in class com.mongodb.async.client.MongoIterableImpl
 
executor - Variable in class com.mongodb.DB
 
executor - Variable in class com.mongodb.DBCollection
 
executor - Variable in class com.mongodb.DBCursor
 
executor - Variable in class com.mongodb.MongoCollectionImpl
 
executor - Variable in class com.mongodb.MongoDatabaseImpl
 
executor - Variable in class com.mongodb.MongoIterableImpl
 
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
expireAfterSeconds - Variable in class com.mongodb.bulk.IndexRequest
 
expireAfterSeconds - Variable in class com.mongodb.client.model.IndexOptions
 
expired(long, long, long) - Method in class com.mongodb.connection.DefaultConnectionPool
 
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
 
EXPLAIN_COMMAND_NAME - Static variable in class com.mongodb.connection.QueryProtocol
 
explainAggregate(List<? extends DBObject>, AggregationOptions) - Method in class com.mongodb.DBCollection
Return the explain plan for the aggregation pipeline.
ExplainHelper - Class in com.mongodb.operation
 
ExplainHelper() - Constructor for class com.mongodb.operation.ExplainHelper
 
ExplainResultCallback(SingleResultCallback<BsonDocument>) - Constructor for class com.mongodb.operation.FindOperation.ExplainResultCallback
 
ExplainVerbosity - Enum in com.mongodb
An enumeration of the verbosity levels available for explaining query execution.
ExplainVerbosity() - Constructor for enum com.mongodb.ExplainVerbosity
 
EXPONENT_OFFSET - Static variable in class org.bson.types.Decimal128
 
ExponentiallyWeightedMovingAverage - Class in com.mongodb.connection
 
ExponentiallyWeightedMovingAverage(double) - Constructor for class com.mongodb.connection.ExponentiallyWeightedMovingAverage
 
expr(TExpression) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents that validate against the given JSON schema document.
expression - Variable in class com.mongodb.client.model.SimpleExpression
 
EXTENDED_JSON_BINARY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_DATE_TIME_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_DECIMAL_128_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_DOUBLE_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_INT_32_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_INT_64_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_MAX_KEY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_MIN_KEY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_OBJECT_ID_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_REGULAR_EXPRESSION_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_TIMESTAMP_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
EXTENDED_JSON_UNDEFINED_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
ExtendedJsonBinaryConverter - Class in org.bson.json
 
ExtendedJsonBinaryConverter() - Constructor for class org.bson.json.ExtendedJsonBinaryConverter
 
ExtendedJsonDateTimeConverter - Class in org.bson.json
 
ExtendedJsonDateTimeConverter() - Constructor for class org.bson.json.ExtendedJsonDateTimeConverter
 
ExtendedJsonDecimal128Converter - Class in org.bson.json
 
ExtendedJsonDecimal128Converter() - Constructor for class org.bson.json.ExtendedJsonDecimal128Converter
 
ExtendedJsonDoubleConverter - Class in org.bson.json
 
ExtendedJsonDoubleConverter() - Constructor for class org.bson.json.ExtendedJsonDoubleConverter
 
ExtendedJsonInt32Converter - Class in org.bson.json
 
ExtendedJsonInt32Converter() - Constructor for class org.bson.json.ExtendedJsonInt32Converter
 
ExtendedJsonInt64Converter - Class in org.bson.json
 
ExtendedJsonInt64Converter() - Constructor for class org.bson.json.ExtendedJsonInt64Converter
 
ExtendedJsonMaxKeyConverter - Class in org.bson.json
 
ExtendedJsonMaxKeyConverter() - Constructor for class org.bson.json.ExtendedJsonMaxKeyConverter
 
ExtendedJsonMinKeyConverter - Class in org.bson.json
 
ExtendedJsonMinKeyConverter() - Constructor for class org.bson.json.ExtendedJsonMinKeyConverter
 
ExtendedJsonObjectIdConverter - Class in org.bson.json
 
ExtendedJsonObjectIdConverter() - Constructor for class org.bson.json.ExtendedJsonObjectIdConverter
 
ExtendedJsonRegularExpressionConverter - Class in org.bson.json
 
ExtendedJsonRegularExpressionConverter() - Constructor for class org.bson.json.ExtendedJsonRegularExpressionConverter
 
ExtendedJsonTimestampConverter - Class in org.bson.json
 
ExtendedJsonTimestampConverter() - Constructor for class org.bson.json.ExtendedJsonTimestampConverter
 
ExtendedJsonUndefinedConverter - Class in org.bson.json
 
ExtendedJsonUndefinedConverter() - Constructor for class org.bson.json.ExtendedJsonUndefinedConverter
 
exterior - Variable in class com.mongodb.client.model.geojson.PolygonCoordinates
 
externalResourceCloser - Variable in class com.mongodb.async.client.MongoClientImpl
 
extra - Variable in class com.mongodb.gridfs.GridFSFile
 
extractErrorCode(BsonDocument) - Static method in exception com.mongodb.MongoCommandException
 
extractErrorCode(BsonDocument) - Static method in exception com.mongodb.WriteConcernException
For internal use only: extract the error code from the response to a write command.
extractErrorMessage(BsonDocument) - Static method in exception com.mongodb.MongoCommandException
 
extractErrorMessage(BsonDocument) - Static method in exception com.mongodb.WriteConcernException
For internal use only: extract the error message from the response to a write command.
extraElements - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
extraElements - Variable in class com.mongodb.connection.ElementExtendingBsonWriter
 

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
 
facets - Variable in class com.mongodb.client.model.Aggregates.FacetStage
 
FacetStage(List<Facet>) - Constructor for class com.mongodb.client.model.Aggregates.FacetStage
 
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.
failed(Throwable, Object) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter.WriteCompletionHandler
 
failed(Throwable, Void) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.BasicCompletionHandler
 
failed(Throwable, Object) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.OpenCompletionHandler
 
failed(Throwable) - Method in class com.mongodb.connection.FutureAsyncCompletionHandler
 
failed(Throwable) - Method in class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 
FALLBACK_CONVERTER - Static variable in class org.bson.json.RelaxedExtendedJsonDateTimeConverter
 
FALLBACK_CONVERTER - Static variable in class org.bson.json.RelaxedExtendedJsonDoubleConverter
 
FallbackPropertyCodecProvider - Class in org.bson.codecs.pojo
 
FallbackPropertyCodecProvider(PojoCodec<?>, CodecRegistry) - Constructor for class org.bson.codecs.pojo.FallbackPropertyCodecProvider
 
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
field - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
field(Field) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
FIELD_NAMES_WITH_RESULT - Static variable in class com.mongodb.operation.AggregateOperation
 
fieldAccumulators - Variable in class com.mongodb.client.model.Aggregates.GroupStage
 
FieldInfo(String, Class<? extends DBObject>) - Constructor for class com.mongodb.ReflectionDBObject.FieldInfo
 
fieldName - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
fieldName - Variable in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
fieldName - Variable in class com.mongodb.client.model.Filters.IterableOperatorFilter
 
fieldName - Variable in class com.mongodb.client.model.Filters.OperatorFilter
 
fieldName - Variable in class com.mongodb.client.model.Filters.SimpleEncodingFilter
 
fieldName - Variable in class com.mongodb.client.model.Filters.SimpleFilter
 
fieldName - Variable in class com.mongodb.client.model.Projections.ElemMatchFilterProjection
 
fieldName - Variable in class com.mongodb.client.model.Updates.PullAllUpdate
 
fieldName - Variable in class com.mongodb.client.model.Updates.SimpleUpdate
 
fieldName - Variable in class com.mongodb.client.model.Updates.WithEachUpdate
 
fieldName - Variable in class com.mongodb.DistinctIterableImpl
 
fieldName - Variable in class com.mongodb.operation.DistinctOperation
 
fieldNameToValidatorMap - Variable in class com.mongodb.internal.validator.MappedFieldNameValidator
 
fieldNameValidator - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
FieldNameValidator - Interface in org.bson
A field name validator, for use by BSON writers to validate field names as documents are encoded.
fieldNameValidatorStack - Variable in class org.bson.AbstractBsonWriter
 
fields - Variable in class com.mongodb.client.model.Aggregates.AddFieldsStage
 
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<? extends Bson>) - Static method in class com.mongodb.client.model.Projections
Creates a projection that combines the list of projections into a single one.
fields - Variable in class com.mongodb.connection.QueryMessage
 
fields - Variable in class com.mongodb.connection.QueryProtocol
 
fields - Variable in class com.mongodb.ReflectionDBObject.JavaWrapper
 
fieldsContainingPayload - Variable in class com.mongodb.operation.CommandResultCodecProvider
 
fieldsContainingPayload - Variable in class com.mongodb.operation.CommandResultDocumentCodec
 
FieldsProjection(List<? extends Bson>) - Constructor for class com.mongodb.client.model.Projections.FieldsProjection
 
fileId - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
fileId - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
fileId - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
fileInfo - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
fileInfo - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
fileInfoIterable - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
filename - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
filename - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
filename - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
filename - Variable in class com.mongodb.gridfs.GridFSFile
 
filesCollection - Variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
filesCollection - Variable in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
filesCollection - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
filesCollection - Variable in class com.mongodb.client.gridfs.GridFSBucketImpl
 
filesCollection - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
filesCollection - Variable in class com.mongodb.gridfs.GridFS
 
fillArray(int) - Method in class com.mongodb.DBCursor
 
filter(Bson) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
filter(Bson) - Method in class com.mongodb.async.client.DistinctIterableImpl
 
filter(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.async.client.FindIterableImpl
 
filter(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
filter(Bson) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the query filter to apply to the query.
filter(Bson) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
filter(Bson) - Method in interface com.mongodb.async.client.ListCollectionsIterable
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.async.client.ListCollectionsIterableImpl
 
filter(Bson) - Method in class com.mongodb.async.client.ListCollectionsIterableImpl
 
filter(Bson) - Method in interface com.mongodb.async.client.ListDatabasesIterable
Sets the query filter to apply to the returned database names.
filter - Variable in class com.mongodb.async.client.ListDatabasesIterableImpl
 
filter(Bson) - Method in class com.mongodb.async.client.ListDatabasesIterableImpl
 
filter(Bson) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
filter(Bson) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
filter - Variable in class com.mongodb.bulk.DeleteRequest
 
filter - Variable in class com.mongodb.bulk.UpdateRequest
 
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 class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
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.ListDatabasesIterable
Sets the query filter to apply to the returned database names.
filter(Bson) - Method in interface com.mongodb.client.MapReduceIterable
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.client.model.Aggregates.SortByCountStage
 
filter - Variable in class com.mongodb.client.model.DBCollectionDistinctOptions
 
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 - Variable in class com.mongodb.client.model.DeleteManyModel
 
filter - Variable in class com.mongodb.client.model.DeleteOneModel
 
filter - Variable in class com.mongodb.client.model.Filters.NotFilter
 
filter - Variable in class com.mongodb.client.model.Projections.ElemMatchFilterProjection
 
filter - Variable in class com.mongodb.client.model.ReplaceOneModel
 
filter - Variable in class com.mongodb.client.model.UpdateManyModel
 
filter - Variable in class com.mongodb.client.model.UpdateOneModel
 
filter - Variable in class com.mongodb.DBCursor
 
filter - Variable in class com.mongodb.DistinctIterableImpl
 
filter(Bson) - Method in class com.mongodb.DistinctIterableImpl
 
filter - Variable in class com.mongodb.FindIterableImpl
 
filter(Bson) - Method in class com.mongodb.FindIterableImpl
 
filter - Variable in class com.mongodb.ListCollectionsIterableImpl
 
filter(Bson) - Method in class com.mongodb.ListCollectionsIterableImpl
 
filter - Variable in class com.mongodb.ListDatabasesIterableImpl
 
filter(Bson) - Method in class com.mongodb.ListDatabasesIterableImpl
 
filter - Variable in class com.mongodb.MapReduceIterableImpl
 
filter(Bson) - Method in class com.mongodb.MapReduceIterableImpl
 
filter - Variable in class com.mongodb.operation.CountOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.CountOperation
Sets the filter to apply to the query.
filter - Variable in class com.mongodb.operation.DistinctOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.DistinctOperation
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets the filter to apply to the query.
filter - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the filter to apply to the query.
filter - Variable in class com.mongodb.operation.FindOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.operation.GroupOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.GroupOperation
Sets the optional query filter to determine which documents in the collection to process.
filter - Variable in class com.mongodb.operation.ListCollectionsOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.ListCollectionsOperation
Sets the query filter to apply to the query.
filter - Variable in class com.mongodb.operation.ListDatabasesOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.ListDatabasesOperation
Sets the query filter to apply to the returned database names.
filter - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
filter(BsonDocument) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the filter to apply to the query.
filter - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
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.
Filters() - Constructor for class com.mongodb.client.model.Filters
 
filters - Variable in class com.mongodb.client.model.Filters.AndFilter
 
filters - Variable in class com.mongodb.client.model.Filters.OrNorFilter
 
Filters.AndFilter - Class in com.mongodb.client.model
 
Filters.GeometryOperatorFilter<TItem> - Class in com.mongodb.client.model
 
Filters.IterableOperatorFilter<TItem> - Class in com.mongodb.client.model
 
Filters.NotFilter - Class in com.mongodb.client.model
 
Filters.OperatorFilter<TItem> - Class in com.mongodb.client.model
 
Filters.OrNorFilter - Class in com.mongodb.client.model
 
Filters.OrNorFilter.Operator - Enum in com.mongodb.client.model
 
Filters.SimpleEncodingFilter<TItem> - Class in com.mongodb.client.model
 
Filters.SimpleFilter - Class in com.mongodb.client.model
 
Filters.TextFilter - Class in com.mongodb.client.model
 
finalize() - Method in class com.mongodb.DBCursor.OptionalFinalizer
 
finalize - Variable in class com.mongodb.GroupCommand
 
finalize - Variable in class com.mongodb.MapReduceCommand
 
finalizeFunction(String) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the JavaScript function that follows the reduce method and modifies the output.
finalizeFunction - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
finalizeFunction(String) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
finalizeFunction(String) - Method in interface com.mongodb.client.MapReduceIterable
Sets the JavaScript function that follows the reduce method and modifies the output.
finalizeFunction - Variable in class com.mongodb.MapReduceIterableImpl
 
finalizeFunction(String) - Method in class com.mongodb.MapReduceIterableImpl
 
finalizeFunction - Variable in class com.mongodb.operation.GroupOperation
 
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 - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
finalizeFunction(BsonJavaScript) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the JavaScript function that follows the reduce method and modifies the output.
finalizeFunction - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
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(ClientSession) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Finds all documents in the files collection.
find(ClientSession, Bson) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Finds all documents in the collection that match the filter.
find() - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
find(Bson) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
find(ClientSession) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
find(ClientSession, Bson) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
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(ClientSession) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(ClientSession, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(ClientSession, Bson) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find(ClientSession, Bson, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Finds all documents in the collection.
find() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(Bson) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(Bson, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(ClientSession) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(ClientSession, Bson) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
find(ClientSession, Bson, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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(ClientSession) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Finds all documents in the files collection.
find(ClientSession, Bson) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Finds all documents in the collection that match the filter.
find() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
find(Bson) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
find(ClientSession) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
find(ClientSession, Bson) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
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(ClientSession) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(ClientSession, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(ClientSession, Bson, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Finds all documents in the collection.
find(BsonReader) - Method in interface com.mongodb.connection.AbstractByteBufBsonDocument.Finder
 
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.
find() - Method in class com.mongodb.MongoCollectionImpl
 
find(Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
find(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
find(Bson, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
find(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
find(ClientSession, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
find(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
find(ClientSession, Bson, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
FIND_COMMAND_NAME - Static variable in class com.mongodb.connection.QueryProtocol
 
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
FindAndDeleteOperation(MongoNamespace, WriteConcern, boolean, 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.
FindAndModifyHelper - Class in com.mongodb.operation
 
FindAndModifyHelper() - Constructor for class com.mongodb.operation.FindAndModifyHelper
 
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
FindAndReplaceOperation(MongoNamespace, WriteConcern, boolean, 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
FindAndUpdateOperation(MongoNamespace, WriteConcern, boolean, 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.
findComponent(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
findComponentIndex(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
findInDocument(AbstractByteBufBsonDocument.Finder<T>) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
findInDocument(AbstractByteBufBsonDocument.Finder<T>) - Method in class com.mongodb.connection.ByteBufBsonDocument
 
FindIterable<T> - Interface in com.mongodb.async.client
Iterable for find.
FindIterable<TResult> - Interface in com.mongodb.client
Iterable for find.
FindIterableImpl<TDocument,TResult> - Class in com.mongodb.async.client
 
FindIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, AsyncOperationExecutor, Bson, FindOptions) - Constructor for class com.mongodb.async.client.FindIterableImpl
 
FindIterableImpl<TDocument,TResult> - Class in com.mongodb
 
FindIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, OperationExecutor, Bson, FindOptions) - Constructor for class com.mongodb.FindIterableImpl
 
findMostUpToDateSecondary(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference
 
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(ClientSession, Bson, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(ClientSession, Bson, FindOneAndDeleteOptions, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(Bson, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndDelete(Bson, FindOneAndDeleteOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndDelete(ClientSession, Bson, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndDelete(ClientSession, Bson, FindOneAndDeleteOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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.
findOneAndDelete(ClientSession, Bson) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(ClientSession, Bson, FindOneAndDeleteOptions) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and remove it.
findOneAndDelete(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndDelete(Bson, FindOneAndDeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndDelete(ClientSession, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndDelete(ClientSession, Bson, FindOneAndDeleteOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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(ClientSession, Bson, TDocument, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(ClientSession, Bson, TDocument, FindOneAndReplaceOptions, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(Bson, TDocument, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndReplace(Bson, TDocument, FindOneAndReplaceOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndReplace(ClientSession, Bson, TDocument, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndReplace(ClientSession, Bson, TDocument, FindOneAndReplaceOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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.
findOneAndReplace(ClientSession, Bson, TDocument) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(ClientSession, Bson, TDocument, FindOneAndReplaceOptions) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and replace it.
findOneAndReplace(Bson, TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndReplace(Bson, TDocument, FindOneAndReplaceOptions) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndReplace(ClientSession, Bson, TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndReplace(ClientSession, Bson, TDocument, FindOneAndReplaceOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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(ClientSession, Bson, Bson, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(ClientSession, Bson, Bson, FindOneAndUpdateOptions, SingleResultCallback<TDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(Bson, Bson, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndUpdate(Bson, Bson, FindOneAndUpdateOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndUpdate(ClientSession, Bson, Bson, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
findOneAndUpdate(ClientSession, Bson, Bson, FindOneAndUpdateOptions, SingleResultCallback<TDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
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.
findOneAndUpdate(ClientSession, Bson, Bson) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(ClientSession, Bson, Bson, FindOneAndUpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Atomically find a document and update it.
findOneAndUpdate(Bson, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndUpdate(Bson, Bson, FindOneAndUpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndUpdate(ClientSession, Bson, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
findOneAndUpdate(ClientSession, Bson, Bson, FindOneAndUpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
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 - Variable in class com.mongodb.async.client.AggregateToCollectionThenFindOperation
 
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.
FindOperation.ExplainResultCallback - Class in com.mongodb.operation
 
findOptions - Variable in class com.mongodb.async.client.FindIterableImpl
 
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.
findOptions - Variable in class com.mongodb.DBCursor
 
findOptions - Variable in class com.mongodb.FindIterableImpl
 
findPredecessorOf(ConcurrentLinkedDeque.Node<E>) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns the apparent predecessor of target by searching forward for it, starting at this node, patching up pointers while traversing.
findPrimary(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference
 
findSendCompressor(ConnectionDescription) - Method in class com.mongodb.connection.InternalStreamConnection
 
findServerIncompatiblyNewerThanDriver() - Method in class com.mongodb.connection.ClusterDescription
Return a server in the cluster that is incompatibly newer than the driver.
findServerIncompatiblyOlderThanDriver() - Method in class com.mongodb.connection.ClusterDescription
Return a server in the cluster that is incompatibly older than the driver.
finishData() - Method in class com.mongodb.gridfs.GridFSInputFile
Marks the data as fully written.
fireChangeEvent(ClusterDescriptionChangedEvent) - Method in class com.mongodb.connection.BaseCluster
 
first(SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.FindIterableImpl
 
first(SingleResultCallback<GridFSFile>) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
first(SingleResultCallback<V>) - Method in class com.mongodb.async.client.MappingIterable
 
first(SingleResultCallback<TResult>) - Method in interface com.mongodb.async.client.MongoIterable
Helper to return the first item in the iterator or null.
first(SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.MongoIterableImpl
 
first() - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
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.
first() - Method in class com.mongodb.FindIterableImpl
 
first() - Method in class com.mongodb.MappingIterable
 
first() - Method in class com.mongodb.MongoIterableImpl
 
FIRST_BATCH - Static variable in class com.mongodb.operation.AggregateOperation
 
FIRST_BATCH - Static variable in class com.mongodb.operation.FindOperation
 
firstBatch - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
firstBatch - Variable in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
firstDocumentPosition - Variable in class com.mongodb.connection.RequestMessage.EncodingMetadata
 
FLAG_GLOBAL - Static variable in class org.bson.BSON
 
FLAG_LOOKUP - Static variable in class org.bson.BSON
 
flagChar - Variable in enum org.bson.codecs.PatternCodec.RegexFlag
 
FlatteningSingleResultCallbackSubscription<TResult> - Class in com.mongodb.async.client
 
FlatteningSingleResultCallbackSubscription(Block<SingleResultCallback<List<TResult>>>, Observer<? super TResult>) - Constructor for class com.mongodb.async.client.FlatteningSingleResultCallbackSubscription
 
flip() - Method in class com.mongodb.connection.CompositeByteBuf
 
flip() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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 com.mongodb.connection.LevelCountingBsonWriter
 
flush() - Method in class org.bson.BsonBinaryWriter
 
flush() - Method in class org.bson.BSONCallbackAdapter
 
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
 
flush() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
forEach(Block<? super GridFSFile>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
forEach(Block<? super V>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MappingIterable
 
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>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoIterableImpl
 
forEach(Block<? super GridFSFile>) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
forEach(Block<? super TResult>) - Method in interface com.mongodb.client.MongoIterable
Iterates over all documents in the view, applying the given block to each.
forEach(Block<? super V>) - Method in class com.mongodb.MappingIterable
 
forEach(Block<? super TResult>) - Method in class com.mongodb.MongoIterableImpl
 
format(long) - Static method in class org.bson.json.DateTimeFormatter
 
format(long) - Method in interface org.bson.json.DateTimeFormatter.FormatterImpl
 
format(long) - Method in class org.bson.json.DateTimeFormatter.Java8DateTimeFormatter
 
format(long) - Method in class org.bson.json.DateTimeFormatter.JaxbDateTimeFormatter
 
FORMATTER_IMPL - Static variable in class org.bson.json.DateTimeFormatter
 
forward() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns the next node containing a nondeleted user element.
from - Variable in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
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.
fromPreviousGeneration(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool
 
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.changestream.FullDocument
Returns the ChangeStreamFullDocument from the string value.
fromString(String) - Static method in enum com.mongodb.client.model.changestream.OperationType
Returns the ChangeStreamOperationType from the string 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
fs - Variable in class com.mongodb.gridfs.GridFSFile
 
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 - Variable in class com.mongodb.WriteConcern
 
fsync() - Method in class com.mongodb.WriteConcern
Deprecated.
FSYNC_SAFE - Static variable in class com.mongodb.WriteConcern
Deprecated.
FSYNC_UNLOCK_COMMAND - Static variable in class com.mongodb.operation.FsyncUnlockOperation
 
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
 
fullDocument(FullDocument) - Method in interface com.mongodb.async.client.ChangeStreamIterable
Sets the fullDocument value.
fullDocument - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
fullDocument(FullDocument) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
fullDocument - Variable in class com.mongodb.ChangeStreamIterableImpl
 
fullDocument(FullDocument) - Method in class com.mongodb.ChangeStreamIterableImpl
 
fullDocument(FullDocument) - Method in interface com.mongodb.client.ChangeStreamIterable
Sets the fullDocument value.
fullDocument - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
FullDocument - Enum in com.mongodb.client.model.changestream
Change Stream fullDocument configuration.
FullDocument(String) - Constructor for enum com.mongodb.client.model.changestream.FullDocument
 
fullDocument - Variable in class com.mongodb.operation.ChangeStreamOperation
 
fullName - Variable in class com.mongodb.MongoNamespace
 
Function<T,R> - Interface in com.mongodb
Apply a function to the input object yielding an appropriate result object.
function - Variable in class org.bson.util.ComputingMap
 
Function<A,B> - Interface in org.bson.util
 
FutureAsyncCompletionHandler<T> - Class in com.mongodb.connection
 
FutureAsyncCompletionHandler() - Constructor for class com.mongodb.connection.FutureAsyncCompletionHandler
 
FutureAsyncCompletionHandler() - Constructor for class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 

G

GENERAL_OPTIONS_KEYS - Static variable in class com.mongodb.ConnectionString
 
generate(int) - Method in class com.mongodb.connection.ScramSha1Authenticator.DefaultRandomStringGenerator
 
generate(int) - Method in interface com.mongodb.connection.ScramSha1Authenticator.RandomStringGenerator
 
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
 
generateIndexName(BsonDocument) - Static method in class com.mongodb.operation.IndexHelper
Convenience method to generate an index name from the set of fields it is over.
generation - Variable in class com.mongodb.connection.DefaultConnectionPool
 
generation - Variable in class com.mongodb.connection.UsageTrackingInternalConnection
 
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.
GeoJsonObjectType(String) - Constructor for enum com.mongodb.client.model.geojson.GeoJsonObjectType
 
geometries - Variable in class com.mongodb.client.model.geojson.GeometryCollection
 
geometry - Variable in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
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.
GeometryCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON Geometry.
GeometryCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.GeometryCodec
Construct a new instance
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.
GeometryDecoderHelper - Class in com.mongodb.client.model.geojson.codecs
 
GeometryDecoderHelper() - Constructor for class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
GeometryEncoderHelper - Class in com.mongodb.client.model.geojson.codecs
 
GeometryEncoderHelper() - Constructor for class com.mongodb.client.model.geojson.codecs.GeometryEncoderHelper
 
GeometryOperatorFilter(String, String, TItem) - Constructor for class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
GeometryOperatorFilter(String, String, TItem, Double, Double) - Constructor for class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
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() - Method in class com.mongodb.Bytes.OptionHolder
 
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(Object) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
get() - Method in class com.mongodb.connection.CompositeByteBuf
 
get(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
get(byte[]) - Method in class com.mongodb.connection.CompositeByteBuf
 
get(int, byte[]) - Method in class com.mongodb.connection.CompositeByteBuf
 
get(byte[], int, int) - Method in class com.mongodb.connection.CompositeByteBuf
 
get(int, byte[], int, int) - Method in class com.mongodb.connection.CompositeByteBuf
 
get() - Method in interface com.mongodb.connection.ConnectionPool
 
get(long, TimeUnit) - Method in interface com.mongodb.connection.ConnectionPool
 
get() - Method in class com.mongodb.connection.DefaultConnectionPool
 
get(long, TimeUnit) - Method in class com.mongodb.connection.DefaultConnectionPool
 
get(String) - Method in class com.mongodb.connection.FutureAsyncCompletionHandler
 
get() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
get(int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
get(byte[]) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
get(int, byte[]) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
get(byte[], int, int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
get(int, byte[], int, int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
get() - Method in class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 
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.internal.connection.ConcurrentPool
Gets an object from the pool.
get(long, TimeUnit) - Method in class com.mongodb.internal.connection.ConcurrentPool
Gets an object from the pool - will block if none are available
get() - Method in interface com.mongodb.internal.connection.Pool
 
get(long, TimeUnit) - Method in interface com.mongodb.internal.connection.Pool
 
get() - Method in class com.mongodb.internal.session.ServerSessionPool
 
get(int) - Method in class com.mongodb.operation.BsonArrayWrapper
 
get(Class<T>, CodecRegistry) - Method in class com.mongodb.operation.CommandResultCodecProvider
 
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 com.mongodb.util.JSONParser
Returns the current character.
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<U>) - Method in class org.bson.codecs.configuration.ChildCodecRegistry
 
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.configuration.MapOfCodecsProvider
 
get() - Method in class org.bson.codecs.configuration.Optional
 
get() - Method in class org.bson.codecs.configuration.Optional.Some
 
get(Class<T>) - Method in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
get(ChildCodecRegistry) - Method in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
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.MapCodecProvider
 
get(TypeWithTypeParameters<T>, PropertyCodecRegistry) - Method in class org.bson.codecs.pojo.CollectionPropertyCodecProvider
 
get(S) - Method in class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl.PrivateProperyAccessor
 
get(S) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 
get(TypeWithTypeParameters<T>, PropertyCodecRegistry) - Method in class org.bson.codecs.pojo.EnumPropertyCodecProvider
 
get(TypeWithTypeParameters<S>, PropertyCodecRegistry) - Method in class org.bson.codecs.pojo.FallbackPropertyCodecProvider
 
get(TypeWithTypeParameters<T>, PropertyCodecRegistry) - Method in class org.bson.codecs.pojo.MapPropertyCodecProvider
 
get(Class<T>, CodecRegistry) - Method in class org.bson.codecs.pojo.PojoCodecProvider
 
get(S) - Method in interface org.bson.codecs.pojo.PropertyAccessor
Gets the value for a given PropertyModel instance.
get(S) - Method in class org.bson.codecs.pojo.PropertyAccessorImpl
 
get(TypeWithTypeParameters<T>, PropertyCodecRegistry) - Method in interface org.bson.codecs.pojo.PropertyCodecProvider
Get a Codec using the given context, which includes, most importantly, the class and bound type parameters for which a Codec is required.
get(TypeWithTypeParameters<T>) - Method in interface org.bson.codecs.pojo.PropertyCodecRegistry
Gets a Codec for the given Class.
get(TypeWithTypeParameters<S>) - Method in class org.bson.codecs.pojo.PropertyCodecRegistryImpl
 
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, T) - Method in class org.bson.Document
Gets the value of the given key, casting it to Class<T> or returning the default value if null.
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.AbstractCopyOnWriteMap
 
get(AbstractCopyOnWriteMap<K, V, M>) - Method in enum org.bson.util.AbstractCopyOnWriteMap.View.Type
 
get(Object) - Method in class org.bson.util.ClassMap
Gets the value associated with either this Class or a superclass of this class.
get(Object) - Method in class org.bson.util.ComputingMap
 
get_id() - Method in class com.mongodb.ReflectionDBObject
Gets the _id
GET_PREFIX - Static variable in class org.bson.codecs.pojo.PropertyReflectionUtils
 
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.AsynchronousSocketChannelStream
 
getAddress() - Method in class com.mongodb.connection.netty.NettyStream
 
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 class com.mongodb.connection.SocketChannelStream
 
getAddress() - Method in class com.mongodb.connection.SocketStream
 
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.
getAggregateToCollectionOperation() - Method in class com.mongodb.async.client.AggregateToCollectionThenFindOperation
 
getAliases() - Method in class com.mongodb.client.gridfs.model.GridFSFile
Deprecated.
any aliases should be stored in the metadata document instead.
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
getAllocator() - Method in class com.mongodb.connection.netty.NettyStream
 
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.
getAllServerAddresses(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
getAlternate() - Method in class com.mongodb.client.model.Collation
Returns the collation alternate
getAncestry(Class<T>) - Static method in class org.bson.util.ClassAncestry
Walks superclass and interface graph, superclasses first, then interfaces, to compute an ancestry list.
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.
getAndSetWritingLock() - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
getAnnotations() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
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.
getArrayFilters() - Method in class com.mongodb.bulk.UpdateRequest
Returns the array filters option
getArrayFilters() - Method in class com.mongodb.BulkUpdateRequestBuilder
Gets the array filters to apply to the update operation
getArrayFilters() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the array filters option
getArrayFilters() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Returns the array filters option
getArrayFilters() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Returns the array filters option
getArrayFilters() - Method in class com.mongodb.client.model.UpdateOptions
Returns the array filters option
getArrayFilters() - Method in class com.mongodb.operation.FindAndUpdateOperation
Returns the array filters option
getArrayFilters() - Method in class com.mongodb.UpdateRequest
 
getAsWriteCommand(ByteBufferBsonOutput, int) - Method in class com.mongodb.connection.DeleteProtocol
 
getAsWriteCommand(ByteBufferBsonOutput, int) - Method in class com.mongodb.connection.InsertProtocol
 
getAsWriteCommand(ByteBufferBsonOutput, int) - Method in class com.mongodb.connection.UpdateProtocol
 
getAsWriteCommand(ByteBufferBsonOutput, int) - Method in class com.mongodb.connection.WriteProtocol
 
getAsync(SingleResultCallback<InternalConnection>) - Method in interface com.mongodb.connection.ConnectionPool
 
getAsync(SingleResultCallback<InternalConnection>) - Method in class com.mongodb.connection.DefaultConnectionPool
 
getAsyncClusterBindingConnectionSource(ServerSelector, SingleResultCallback<AsyncConnectionSource>) - Method in class com.mongodb.binding.AsyncClusterBinding
 
getAsyncGetter() - Method in class com.mongodb.connection.DefaultConnectionPool
 
getAuthCommand(String) - Method in class com.mongodb.connection.X509Authenticator
 
getAuthCommand(String, char[], String) - Static method in class com.mongodb.internal.authentication.NativeAuthenticationHelper
 
getAuthCommand(String, String, String) - Static method in class com.mongodb.internal.authentication.NativeAuthenticationHelper
 
getAuthenticationMechanism() - Method in class com.mongodb.MongoCredential
Gets the mechanism
getAvailableCount() - Method in class com.mongodb.internal.connection.ConcurrentPool
 
getAverage() - Method in class com.mongodb.connection.ExponentiallyWeightedMovingAverage
 
getBackwards() - Method in class com.mongodb.client.model.Collation
Returns the backwards value
getBaseCommandDocument(String) - Method in class com.mongodb.connection.WriteProtocol
 
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.async.client.MappingAsyncBatchCursor
 
getBatchSize() - Method in class com.mongodb.async.client.MongoIterableImpl
 
getBatchSize() - Method in class com.mongodb.async.client.MongoIterableSubscription
Returns the batchSize to be used with the cursor.
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.MongoIterableImpl
 
getBatchSize() - Method in class com.mongodb.operation.AggregateOperation
Gets the number of documents to return per batch.
getBatchSize() - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
getBatchSize() - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
getBatchSize() - Method in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
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.ChangeStreamBatchCursor
 
getBatchSize() - Method in class com.mongodb.operation.ChangeStreamOperation
Gets the number of documents to return per 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.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
getBatchSize() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
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.operation.QueryBatchCursor
 
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.
getBinaryConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Binary values to JSON.
getBinaryWriterSettings() - Method in class org.bson.BsonBinaryWriter
 
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.
getBodyByteBuffer() - Method in class com.mongodb.connection.ResponseBuffers
Returns a read-only buffer containing the response body.
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.
getBooleanConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Boolean values to JSON.
getBsonBinaryWriter() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
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.
getBsonReader() - Method in class org.bson.LazyBSONObject
 
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 class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getBucketName() - Method in interface com.mongodb.client.gridfs.GridFSBucket
The bucket name.
getBucketName() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
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 class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
getBuffer(int) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
getBuffer(int) - Method in interface com.mongodb.connection.BufferProvider
Gets a buffer with the givens capacity.
getBuffer(int) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
getBuffer(int) - Method in class com.mongodb.connection.InternalStreamConnection
 
getBuffer(int) - Method in class com.mongodb.connection.netty.NettyBufferProvider
 
getBuffer(int) - Method in class com.mongodb.connection.netty.NettyStream
 
getBuffer(int) - Method in class com.mongodb.connection.SocketChannelStream
 
getBuffer(int) - Method in class com.mongodb.connection.SocketStream
 
getBuffer(int) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
getBuffer(int) - Method in class com.mongodb.internal.connection.PowerOfTwoBufferPool
 
getBufferForInternalBytes() - Method in class org.bson.LazyBSONObject
 
getBufferFromChunk(Document, int) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
getBufferFromChunk(Document, int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
getBufferFromResultsQueue() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
getBufferPool() - Method in class com.mongodb.DB
 
getBufferPool() - Method in class com.mongodb.DBCollection
 
getBufferPosition() - Method in class org.bson.json.JsonScanner
 
getBufferPositionPair(int) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
getBufferProvider() - Method in class com.mongodb.Mongo
 
getBulkWriteException(WriteRequest.Type, BsonDocument, ServerAddress) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
getBulkWriteException(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
getBulkWriteResult(WriteRequest.Type, BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
getBulkWriteResult(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
getByCharacter(char) - Static method in enum org.bson.codecs.PatternCodec.RegexFlag
 
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.
getByteBufferAtIndex(int) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
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.
getBytes() - Method in class org.bson.types.Decimal128
 
getCachedCodec() - Method in class org.bson.codecs.pojo.PropertyModel
 
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 class com.mongodb.management.ConnectionPoolStatistics
 
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.
getChunk(int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
getChunk(int) - Method in class com.mongodb.gridfs.GridFSDBFile
 
getChunksCollection(MongoDatabase, String) - Static method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getChunksCollection(MongoDatabase, String) - Static method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
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 class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getChunkSizeBytes() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Sets the chunk size in bytes.
getChunkSizeBytes() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
getChunkSizeBytes() - Method in class com.mongodb.client.gridfs.model.GridFSUploadOptions
The number of bytes per chunk of this file.
getClassAncestryCache() - Static method in class org.bson.util.ClassAncestry
classAncestryCache
getClassForBsonType(BsonType) - Static method in class org.bson.codecs.BsonValueCodecProvider
Get the BsonValue subclass associated with the given BsonType.
getClassForName(String) - Method in class org.bson.codecs.pojo.DiscriminatorLookup
 
getClassForPath(List<String>) - Method in class com.mongodb.DBCollectionObjectFactory
 
getClassModel() - Method in class org.bson.codecs.pojo.AutomaticPojoCodec
 
getClassModel() - Method in class org.bson.codecs.pojo.LazyPojoCodec
 
getClassModel() - Method in class org.bson.codecs.pojo.PojoCodec
 
getClassModel() - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
getClientSession() - Method in class com.mongodb.async.client.MongoIterableImpl
 
getClientSession() - Method in class com.mongodb.internal.session.ClientSessionContext
 
getClientSession() - Method in class com.mongodb.MongoIterableImpl
 
getCluster() - Method in class com.mongodb.async.client.MongoClientImpl
 
getCluster() - Method in class com.mongodb.Mongo
 
getClusterDescription() - Method in class com.mongodb.Mongo
 
getClusterDescription() - Method in exception com.mongodb.MongoIncompatibleDriverException
The cluster description which was determined to be incompatible.
getClusterDescription() - Method in class com.mongodb.ReplicaSetStatus
 
getClusterId() - Method in class com.mongodb.connection.BaseCluster
 
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.
getClusterListener(ClusterSettings) - Static method in class com.mongodb.internal.event.EventListenerHelper
 
getClusterListeners() - Method in class com.mongodb.connection.ClusterSettings
Gets the cluster listeners.
getClusterListeners() - Method in class com.mongodb.event.ClusterEventMulticaster
Deprecated.
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.
getClusterSettings(ClusterSettings, ClusterListener) - Method in class com.mongodb.connection.DefaultClusterFactory
 
getClusterSettings(List<ServerAddress>, MongoClientOptions, ClusterConnectionMode) - Static method in class com.mongodb.Mongo
 
getClusterTime() - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
getClusterTime(ResponseBuffers) - Static method in class com.mongodb.connection.ProtocolHelper
 
getClusterTime(BsonDocument) - Static method in class com.mongodb.connection.ProtocolHelper
 
getClusterTime() - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
getClusterTime() - Method in class com.mongodb.internal.session.ClientSessionContext
 
getClusterTime() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
getClusterTime() - Method in interface com.mongodb.session.ClientSession
 
getClusterTime() - Method in interface com.mongodb.session.SessionContext
Gets the current cluster time for this session context.
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.
getCodec() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
getCodec(Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
getCodec(BsonValue) - Static method in class com.mongodb.connection.BsonWriterHelper
 
getCodec(BsonDocument) - Method in class com.mongodb.connection.RequestMessage
 
getCodec() - Method in class com.mongodb.MongoCollectionImpl
 
getCodec(BsonDocument) - Static method in class com.mongodb.operation.BulkWriteBatch
 
getCodec() - Method in class org.bson.codecs.pojo.PropertyModel
 
getCodec() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
getCodecClass() - Method in class org.bson.codecs.configuration.ChildCodecRegistry
 
getCodecFromDocument(BsonReader, boolean, String, CodecRegistry, DiscriminatorLookup, Codec<T>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
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 class com.mongodb.async.client.MongoCollectionImpl
 
getCodecRegistry() - Method in interface com.mongodb.async.client.MongoDatabase
Get the codec registry for the MongoDatabase.
getCodecRegistry() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
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 com.mongodb.MongoCollectionImpl
 
getCodecRegistry() - Method in class com.mongodb.MongoDatabaseImpl
 
getCodecRegistry() - Method in class org.bson.codecs.BsonDocumentCodec
Gets the CodecRegistry for this Codec.
getCodeSourcePath() - Static method in class com.mongodb.connection.ClientMetadataHelper
 
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.ChangeStreamOperation
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
getCollation() - Method in class com.mongodb.ReplaceRequest
 
getCollation() - Method in class com.mongodb.UpdateRequest
 
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 class com.mongodb.async.client.MongoDatabaseImpl
 
getCollection(String, Class<TDocument>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
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(String) - Method in class com.mongodb.MongoDatabaseImpl
 
getCollection(String, Class<TDocument>) - Method in class com.mongodb.MongoDatabaseImpl
 
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.connection.RequestMessage
Gets the collection name, which may be null for some message types
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.
getCollectionNameFullName(String) - Static method in class com.mongodb.MongoNamespace
 
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.
getCommand() - Method in class com.mongodb.operation.AggregateExplainOperation
 
getCommand(ConnectionDescription, SessionContext) - Method in class com.mongodb.operation.AggregateOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.AggregateToCollectionOperation
 
getCommand() - Method in class com.mongodb.operation.BulkWriteBatch
 
getCommand(SessionContext) - Method in class com.mongodb.operation.CountOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.CreateCollectionOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.CreateIndexesOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.CreateUserOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.CreateViewOperation
 
getCommand(SessionContext) - Method in class com.mongodb.operation.DistinctOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.DropCollectionOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.DropDatabaseOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.DropIndexOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.DropUserOperation
 
getCommand(SessionContext) - Method in class com.mongodb.operation.FindOperation
 
getCommand() - Method in class com.mongodb.operation.GroupOperation
 
getCommand() - Method in class com.mongodb.operation.ListCollectionsOperation
 
getCommand() - Method in class com.mongodb.operation.ListDatabasesOperation
 
getCommand() - Method in class com.mongodb.operation.ListIndexesOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
 
getCommand(SessionContext) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
getCommand(SessionContext) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.RenameCollectionOperation
 
getCommand(ConnectionDescription) - Method in class com.mongodb.operation.UpdateUserOperation
 
getCommand() - Method in class com.mongodb.operation.UserExistsOperation
 
getCommandCallback(AsyncWriteBinding, AsyncConnection, BulkWriteBatch, boolean, boolean, OperationHelper.ConnectionReleasingWrappedCallback<BulkWriteResult>) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
getCommandCodec() - Static method in class com.mongodb.MongoClient
 
getCommandCreator(SessionContext) - Method in class com.mongodb.operation.BaseFindAndModifyOperation
 
getCommandCreator(SessionContext) - Method in class com.mongodb.operation.FindAndDeleteOperation
 
getCommandCreator(SessionContext) - Method in class com.mongodb.operation.FindAndReplaceOperation
 
getCommandCreator(SessionContext) - Method in class com.mongodb.operation.FindAndUpdateOperation
 
getCommandDocument(ByteBufferBsonOutput) - Method in class com.mongodb.connection.CommandMessage
 
getCommandFailureException(BsonDocument, ServerAddress) - Static method in class com.mongodb.connection.ProtocolHelper
 
getCommandListener() - Method in class com.mongodb.connection.QueryProtocol
 
getCommandListener(List<CommandListener>) - Static method in class com.mongodb.internal.event.EventListenerHelper
 
getCommandListeners() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the list of added CommandListener.
getCommandListeners() - Method in class com.mongodb.event.CommandEventMulticaster
Deprecated.
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.
getCommandMessage(String, BsonDocument, InternalConnection) - Static method in class com.mongodb.connection.CommandHelper
 
getCommandMessage(InternalConnection) - Method in class com.mongodb.connection.CommandProtocolImpl
 
getCommandName() - Method in class com.mongodb.connection.CommandProtocolImpl
 
getCommandName(boolean) - Method in class com.mongodb.connection.QueryProtocol
 
getCommandName(RequestMessage) - Method in class com.mongodb.connection.WriteProtocol
 
getCommandName() - Method in class com.mongodb.event.CommandEvent
Gets the name of the command.
getCommandName(WriteRequest.Type) - Method in class com.mongodb.operation.BulkWriteBatch
 
getCommandReadPreference(DBObject, ReadPreference) - Method in class com.mongodb.DB
Determines the read preference that should be used for the given command.
getCommandToEncode() - Method in class com.mongodb.connection.CommandMessage
 
getComment() - Method in class com.mongodb.client.model.FindOptions
Returns the comment to send with the query.
getComment() - Method in class com.mongodb.operation.AggregateOperation
Returns the comment to send with the aggregate.
getComment() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Returns the comment to send with the aggregate.
getComment() - Method in class com.mongodb.operation.FindOperation
Returns the comment to send with the query.
getCompositeServerSelector(ServerSelector) - Method in class com.mongodb.connection.BaseCluster
 
getCompressedSize() - Method in class com.mongodb.connection.CompressedHeader
 
getCompressor(CompressedHeader) - Method in class com.mongodb.connection.InternalStreamConnection
 
getCompressorId() - Method in class com.mongodb.connection.CompressedHeader
 
getCompressorList() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the compressors to use for compressing messages to the server.
getCompressorList() - Method in class com.mongodb.ConnectionString
Gets the list of compressors.
getCompressorList() - Method in class com.mongodb.MongoClientOptions
Gets the compressors to use for compressing messages to the server.
getCompressors() - Method in class com.mongodb.connection.ConnectionDescription
Gets the compressors supported by this connection.
getCompressors(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getConnectedClusterDescription() - Method in class com.mongodb.Mongo
 
getConnectingServerDescription(Throwable) - Method in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
getConnectingServerDescription(ServerAddress) - Method in class com.mongodb.connection.MultiServerCluster
 
getConnection(SingleResultCallback<AsyncConnection>) - Method in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
getConnection(SingleResultCallback<AsyncConnection>) - Method in class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
getConnection(SingleResultCallback<AsyncConnection>) - Method in interface com.mongodb.binding.AsyncConnectionSource
Gets a connection from this source.
getConnection(SingleResultCallback<AsyncConnection>) - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource
 
getConnection() - Method in class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
getConnection() - Method in interface com.mongodb.binding.ConnectionSource
Gets a connection from this source.
getConnection() - Method in class com.mongodb.binding.SingleConnectionReadBinding.SingleConnectionSource
 
getConnection() - Method in class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
getConnection() - Method in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
getConnection() - Method in class com.mongodb.connection.DefaultServer
 
getConnection() - Method in interface com.mongodb.connection.Server
Gets a connection to this server.
getConnectionAsync(SingleResultCallback<AsyncConnection>) - Method in class com.mongodb.connection.DefaultServer
 
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
Deprecated.
Gets the identifier for this connection.
getConnectionId() - Method in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
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.
getConnectionPool() - Method in class com.mongodb.connection.DefaultServer
 
getConnectionPoolListener(ConnectionPoolSettings) - Static method in class com.mongodb.internal.event.EventListenerHelper
 
getConnectionPoolListeners() - Method in class com.mongodb.connection.ConnectionPoolSettings
Gets the list of added ConnectionPoolListener.
getConnectionPoolListeners() - Method in class com.mongodb.MongoClientOptions
Gets the list of added ConnectionPoolListener.
getConnectionPoolSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the settings for the connection provider in a settings object.
getConnectionPoolSettings(ConnectionPoolSettings, ConnectionPoolListener) - Method in class com.mongodb.connection.DefaultClusterFactory
 
getConnectionPoolSettings() - Method in class com.mongodb.MongoClientOptions
 
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 should be stored the metadata document instead.
getContentType() - Method in class com.mongodb.gridfs.GridFSFile
Gets the content type.
getContext() - Method in class com.mongodb.connection.SslSettings
Gets the SSLContext configured for use with SSL connections.
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.BSONCallbackAdapter
 
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
 
getConventions() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
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 class com.mongodb.async.client.ClientSessionBinding
 
getCount() - Method in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
getCount() - Method in class com.mongodb.binding.AbstractReferenceCounted
 
getCount() - Method in interface com.mongodb.binding.ReferenceCounted
Gets the current reference count, which starts at 0.
getCount() - Method in class com.mongodb.ClientSessionBinding
 
getCount() - Method in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
getCount() - Method in class com.mongodb.connection.AbstractReferenceCounted
 
getCount(BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
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() - Method in class com.mongodb.internal.connection.ConcurrentPool
 
getCount(BulkWriteResult) - Method in class com.mongodb.operation.BaseWriteOperation
 
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.
getCreateCollectionOperation(String, DBObject) - Method in class com.mongodb.DB
 
getCredential() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the credential list.
getCredential() - Method in class com.mongodb.connection.Authenticator
 
getCredential() - Method in class com.mongodb.ConnectionString
Gets the credentials in an immutable list.
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
getCredentialList() - Method in class com.mongodb.ConnectionString
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.Mongo
 
getCredentialsList() - Method in class com.mongodb.MongoClient
Gets the list of credentials that this client authenticates all connections with
getCurrent() - Method in class com.mongodb.connection.ClusterClock
 
getCurrentBsonType() - Method in class org.bson.AbstractBsonReader
 
getCurrentBsonType() - Method in interface org.bson.BsonReader
 
getCurrentByteBuffer() - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
getCurrentCounter() - Static method in class org.bson.types.ObjectId
Gets the current value of the auto-incrementing counter.
getCurrentDescription() - Method in class com.mongodb.connection.BaseCluster
 
getCurrentDescription() - Method in interface com.mongodb.connection.Cluster
Get the current description of this cluster.
getCurrentGlobalId() - Static method in class com.mongodb.connection.RequestMessage
Gets the next available unique message identifier.
getCurrentLevel() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
getCurrentName() - Method in class org.bson.AbstractBsonReader
 
getCurrentName() - Method in interface org.bson.BsonReader
Gets the most recently read name.
getCursor(int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
getCursor() - Method in class com.mongodb.connection.QueryResult
Gets the cursor.
getCursorDocument(BsonDocument) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
getCursorDocumentFromBatchSize(Integer) - Static method in class com.mongodb.operation.CursorHelper
 
getCursorDocuments(BsonDocument) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
getCursorFlag() - Method in class com.mongodb.connection.BaseQueryMessage
 
getCursorId() - Method in class com.mongodb.connection.GetMoreMessage
Gets the cursor to get more from.
getCursorId() - Method in class com.mongodb.connection.ReplyHeader
Gets the cursor ID that this response is a part of.
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 class com.mongodb.MongoCursorAdapter
 
getCursorId() - Method in exception com.mongodb.MongoCursorNotFoundException
Get the cursor id that wasn't found.
getCursorIdListAsString() - Method in class com.mongodb.connection.KillCursorProtocol
 
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 com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
getData() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
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(String) - Method in class com.mongodb.async.client.MongoClientImpl
 
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.BaseFindAndModifyOperation
 
getDatabaseName() - Method in class com.mongodb.operation.CreateViewOperation
Gets the database name
getDatabaseName() - Method in class com.mongodb.operation.FindAndDeleteOperation
 
getDatabaseName() - Method in class com.mongodb.operation.FindAndReplaceOperation
 
getDatabaseName() - Method in class com.mongodb.operation.FindAndUpdateOperation
 
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.
getDatatabaseNameFromFullName(String) - Static method in class com.mongodb.MongoNamespace
 
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.
getDateTimeConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON DateTime values to JSON.
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
 
getDbCollectionCountOptions() - Method in class com.mongodb.DBCursor
 
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.
getDecimal128Converter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Decimal128 values to JSON.
getDeclaringClassName() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getDecoder() - Method in class com.mongodb.CompoundDBObjectCodec
 
getDecoder() - Method in class com.mongodb.operation.BaseFindAndModifyOperation
 
getDecoder() - Method in class com.mongodb.operation.BulkWriteBatch
 
getDecoder() - Method in class com.mongodb.operation.ChangeStreamOperation
 
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
getDefaultBsonTypeClassMap() - Static method in class com.mongodb.DBObjectCodec
 
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.
getDefaultDBObjectCodec() - Method in class com.mongodb.DBCollection
 
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
getDelegate() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
getDelegate() - Method in class org.bson.util.AbstractCopyOnWriteMap.EntrySet
 
getDelegate() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
getDelegate() - Method in class org.bson.util.AbstractCopyOnWriteMap.KeySet
 
getDelegate() - Method in class org.bson.util.AbstractCopyOnWriteMap.Values
 
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.AcknowledgedDeleteResult
 
getDeletedCount() - Method in class com.mongodb.client.result.DeleteResult
Gets the number of documents deleted.
getDeletedCount() - Method in class com.mongodb.client.result.DeleteResult.UnacknowledgedDeleteResult
 
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 class com.mongodb.connection.BaseCluster
 
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 class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
getDescription() - Method in class com.mongodb.connection.DefaultServer
 
getDescription() - Method in class com.mongodb.connection.DefaultServerConnection
 
getDescription() - Method in interface com.mongodb.connection.InternalConnection
Gets the description of this connection.
getDescription() - Method in class com.mongodb.connection.InternalStreamConnection
 
getDescription() - Method in interface com.mongodb.connection.Server
Gets the description of this server.
getDescription() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
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
getDigest() - Static method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
getDiscriminator() - Method in class org.bson.codecs.pojo.ClassModel
Returns the discriminator key.
getDiscriminator() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
getDiscriminatorKey() - Method in class org.bson.codecs.pojo.ClassModel
Gets the value for the discriminator.
getDiscriminatorKey() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
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() - Method in class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
getDocument() - Method in class com.mongodb.InsertRequest
 
getDocument() - Method in class com.mongodb.ReplaceRequest
 
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 class com.mongodb.async.client.MongoCollectionImpl
 
getDocumentClass() - Method in interface com.mongodb.client.MongoCollection
Get the class of documents stored in this collection.
getDocumentClass() - Method in class com.mongodb.MongoCollectionImpl
 
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
 
getDocumentKey() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Returns a document containing just the _id of the changed document.
getDocumentMessageSettings(MessageSettings) - Static method in class com.mongodb.connection.BsonWriterHelper
 
getDocuments() - Method in class com.mongodb.connection.ReplyMessage
Gets the documents.
getDouble() - Method in class com.mongodb.connection.CompositeByteBuf
 
getDouble(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
getDouble() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
getDouble(int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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.
getDoubleConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Double values to JSON.
getDriverInformation(MongoDriverInformation) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
getDriverNames() - Method in class com.mongodb.client.MongoDriverInformation
Returns the driverNames
getDriverPlatforms() - Method in class com.mongodb.client.MongoDriverInformation
Returns the driverPlatforms
getDriverVersion() - Static method in class com.mongodb.connection.ClientMetadataHelper
 
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(BsonDocument) - Static method in class com.mongodb.operation.MapReduceHelper
 
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(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
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(BsonDocument) - Static method in class com.mongodb.operation.MapReduceHelper
 
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 com.mongodb.CompoundDBObjectCodec
 
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.changestream.ChangeStreamDocumentCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.changestream.OperationTypeCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.AbstractGeometryCodec
 
getEncoderClass() - Method in class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
getEncoderClass() - Method in class com.mongodb.CompoundDBObjectCodec
 
getEncoderClass() - Method in class com.mongodb.DBEncoderAdapter
 
getEncoderClass() - Method in class com.mongodb.DBEncoderFactoryAdapter
 
getEncoderClass() - Method in class com.mongodb.DBObjectCodec
 
getEncoderClass() - Method in class com.mongodb.DBRefCodec
 
getEncoderClass() - Method in class com.mongodb.operation.BulkWriteBatch.WriteRequestEncoder
 
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.BigDecimalCodec
 
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.configuration.LazyCodec
 
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.MapCodec
 
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.pojo.AutomaticPojoCodec
 
getEncoderClass() - Method in class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
getEncoderClass() - Method in class org.bson.codecs.pojo.EnumPropertyCodecProvider.EnumCodec
 
getEncoderClass() - Method in class org.bson.codecs.pojo.LazyPojoCodec
 
getEncoderClass() - Method in class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
getEncoderClass() - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
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.
getEncodingMetadata() - Method in class com.mongodb.connection.RequestMessage
Gets the encoding metadata from the last attempt to encode this message.
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.
getError() - Method in class com.mongodb.operation.BulkWriteBatch
 
getError(Class<?>, String) - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getError(Class<?>, boolean, String) - Static method in class org.bson.codecs.pojo.CreatorExecutable
 
getError(Exception) - Method in class org.bson.codecs.pojo.PropertyAccessorImpl
 
getErrorCode(BsonDocument) - Static method in class com.mongodb.connection.ProtocolHelper
 
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(BsonDocument, String) - Static method in class com.mongodb.connection.ProtocolHelper
 
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.
getExecutor() - Method in class com.mongodb.async.client.MongoIterableImpl
 
getExecutor() - Method in class com.mongodb.DB
 
getExecutor() - Method in class com.mongodb.DBCollection
 
getExecutor() - Method in class com.mongodb.MongoIterableImpl
 
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
getExponent() - Method in class org.bson.types.Decimal128
 
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 instead.
getExtraElements(SessionContext) - Method in class com.mongodb.connection.CommandMessage
 
getFastestRoundTripTimeNanos(List<ServerDescription>) - Method in class com.mongodb.selector.LatencyMinimizingServerSelector
 
getField(BsonReader, String) - Static method in class com.mongodb.connection.ProtocolHelper
 
getField() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getFieldNameValidator() - Method in class com.mongodb.operation.BaseFindAndModifyOperation
 
getFieldNameValidator() - Method in class com.mongodb.operation.BulkWriteBatch
 
getFieldNameValidator() - Method in class com.mongodb.operation.FindAndDeleteOperation
 
getFieldNameValidator() - Method in class com.mongodb.operation.FindAndReplaceOperation
 
getFieldNameValidator() - Method in class com.mongodb.operation.FindAndUpdateOperation
 
getFileByName(ClientSession, String, GridFSDownloadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
getFileId() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
Deprecated.
getFileId() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
Deprecated.
getFileInfoById(ClientSession, BsonValue) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
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(MongoDatabase, String) - Static method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getFilesCollection(MongoDatabase, String) - Static method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
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.ListDatabasesOperation
Gets the query filter to apply to the returned database names.
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.
getFindOperation() - Method in class com.mongodb.async.client.AggregateToCollectionThenFindOperation
 
getFirst() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
getFirstDocumentPosition() - Method in class com.mongodb.connection.RequestMessage.EncodingMetadata
 
getFirstKey() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
Gets the first key in this document, or null if the document is empty.
getFirstKey() - Method in class org.bson.BsonDocument
Gets the first key in the document.
getFirstKey() - Method in class org.bson.RawBsonDocument
 
getFirstWrappedMessageBuffer(List<ByteBuf>) - Static method in class com.mongodb.connection.CompressedMessage
 
getFsync() - Method in class com.mongodb.WriteConcern
Deprecated.
getFullDocument() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Returns the fullDocument
getFullDocument() - Method in class com.mongodb.operation.ChangeStreamOperation
Returns the fullDocument value, in 3.6
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.
getGeneration() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
Gets the generation of this connection.
getGenericType(Method) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
getGeometries() - Method in class com.mongodb.client.model.geojson.GeometryCollection
Gets the list of Geometry objects in this collection.
getGetter() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getGetterMethods() - Method in class org.bson.codecs.pojo.PropertyReflectionUtils.PropertyMethods
 
getGranularity() - Method in class com.mongodb.client.model.BucketAutoOptions
 
getGridFS() - Static method in class com.mongodb.gridfs.CLI
 
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(SingleResultCallback<GridFSFile>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
getGridFSFile() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
Gets the corresponding GridFSFile for the file being downloaded
getGridFSFile() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
getGroup() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
getGSSCredential(String) - Method in class com.mongodb.connection.GSSAPIAuthenticator
 
getHandlerAndClear() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.BaseCompletionHandler
 
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.
getHeartbeatSocketSettings() - Method in class com.mongodb.MongoClientOptions
 
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.client.model.FindOptions
Returns the hint for which index to use.
getHint() - Method in class com.mongodb.operation.AggregateExplainOperation
Returns the hint for which index to use.
getHint() - Method in class com.mongodb.operation.AggregateOperation
Returns the hint for which index to use.
getHint() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Returns the hint for which index to use.
getHint() - Method in class com.mongodb.operation.CountOperation
Gets the hint to apply.
getHint() - Method in class com.mongodb.operation.FindOperation
Returns the hint for which index to use.
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 class com.mongodb.management.ConnectionPoolStatistics
 
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
getHostName(ServerAddress) - Method in class com.mongodb.connection.GSSAPIAuthenticator
 
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.async.client.gridfs.GridFSUploadStreamImpl
 
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.GridFSUploadStreamImpl
 
getId() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The BsonValue id for this file.
getId() - Method in class com.mongodb.connection.Compressor
 
getId(InternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool
 
getId() - Method in class com.mongodb.connection.InternalStreamConnection
 
getId() - Method in class com.mongodb.connection.RequestMessage
Gets the message id.
getId() - Method in class com.mongodb.connection.SnappyCompressor
 
getId() - Method in class com.mongodb.connection.ZlibCompressor
 
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.
getIdentifier() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
getIdentifier() - Method in interface com.mongodb.session.ServerSession
 
getIdPropertyIndex() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getIdPropertyModel() - Method in class org.bson.codecs.pojo.ClassModel
Returns the PropertyModel mapped as the id property for this ClassModel
getIdPropertyName() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
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.
getIndentCharacters() - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings
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.
getIndex(IndexRequest) - Method in class com.mongodb.operation.CreateIndexesOperation
 
getIndexInfo() - Method in class com.mongodb.DBCollection
Return a list of the indexes for this collection.
getIndexNameFromIndexFields(DBObject) - Method in class com.mongodb.DBCollection
 
getIndexNames() - Method in class com.mongodb.operation.CreateIndexesOperation
Gets the index names.
getIndexNamespace() - Method in class com.mongodb.operation.ListIndexesOperation
 
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.
getInitialDescription() - Method in class com.mongodb.connection.SingleServerCluster
 
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(BsonDocument) - Static method in class com.mongodb.operation.MapReduceHelper
 
getInputCount() - Method in class com.mongodb.operation.MapReduceStatistics
Get the number of documents that were input into the map reduce operation
getInputStream(InputStream) - Method in class com.mongodb.connection.Compressor
 
getInputStream(InputStream) - Method in class com.mongodb.connection.SnappyCompressor
 
getInputStream(InputStream) - Method in class com.mongodb.connection.ZlibCompressor
 
getInputStream() - Method in class com.mongodb.gridfs.GridFSDBFile
Returns an InputStream from which data can be read.
getInsertedCount() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
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.
getInsertedCount() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
getInsertRequests() - Method in class com.mongodb.operation.InsertOperation
Gets the list of insert requests.
getInstance() - Method in class com.mongodb.BasicDBObjectFactory
 
getInstance(List<String>) - Method in class com.mongodb.BasicDBObjectFactory
 
getInstance() - Method in class com.mongodb.DBCollectionObjectFactory
 
getInstance(List<String>) - Method in class com.mongodb.DBCollectionObjectFactory
 
getInstance() - Method in interface com.mongodb.DBObjectFactory
 
getInstance(List<String>) - Method in interface com.mongodb.DBObjectFactory
 
getInstance() - Method in class org.bson.codecs.pojo.CollectionPropertyCodecProvider.CollectionCodec
 
getInstance() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getInstance(Object[]) - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getInstance() - Method in interface org.bson.codecs.pojo.InstanceCreator
Returns the new instance of the class.
getInstance() - Method in class org.bson.codecs.pojo.InstanceCreatorImpl
 
getInstance() - Method in class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
getInstanceCreator() - Method in class org.bson.codecs.pojo.ClassModel
 
getInstanceCreatorFactory() - Method in class org.bson.codecs.pojo.ClassModel
 
getInstanceCreatorFactory() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
getInt() - Method in class com.mongodb.connection.CompositeByteBuf
 
getInt(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
getInt() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
getInt(int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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.
getInt32Converter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Int32 values to JSON.
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.
getInt64Converter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Int64 values to JSON.
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.
getInternalBytes() - Method in class com.mongodb.connection.Compressor.BufferExposingByteArrayOutputStream
 
getInternalBytes() - Method in class com.mongodb.DBDecoderAdapter.BufferExposingByteArrayOutputStream
 
getInternalClass(String) - Method in class com.mongodb.DBCollection
Gets the internal class for the given path in the document hierarchy
getInternalClass(List<String>) - Method in class com.mongodb.ReflectionDBObject.JavaWrapper
 
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.
getInUseCount() - Method in class com.mongodb.internal.connection.ConcurrentPool
 
getInUseCount() - Method in class com.mongodb.internal.session.ServerSessionPool
 
getJ() - Method in class com.mongodb.WriteConcern
Deprecated.
getJavaScriptConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON JavaScript values to JSON.
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.
getLast() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
getLastError(MongoBulkWriteException) - Method in class com.mongodb.operation.BaseWriteOperation
 
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().
getLastUsedAt() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
Returns the time at which this connection was last used, or Long.MAX_VALUE if it has not yet been used.
getLastUsedAtMillis() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
getLastValue(Map<String, List<String>>, String) - Method in class com.mongodb.ConnectionString
 
getLastWriteDate(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getLastWriteDate() - Method in class com.mongodb.connection.ServerDescription
Gets the last write date.
getLegacy() - Static method in class com.mongodb.util.JSONSerializers
Deprecated.
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.
getLevel() - Method in class com.mongodb.ReadConcern
Gets the read concern level.
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() - Method in class com.mongodb.connection.DeleteProtocol
 
getLogger() - Method in class com.mongodb.connection.InsertProtocol
 
getLogger() - Method in class com.mongodb.connection.UpdateProtocol
 
getLogger() - Method in class com.mongodb.connection.WriteProtocol
Gets the logger.
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 '.'.
getLogicalSessionTimeoutMinutes() - Method in class com.mongodb.connection.ClusterDescription
Gets the logical session timeout in minutes, or null if at least one of the known servers does not support logical sessions.
getLogicalSessionTimeoutMinutes(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getLogicalSessionTimeoutMinutes() - Method in class com.mongodb.connection.ServerDescription
Gets the session timeout in minutes.
getLong() - Method in class com.mongodb.connection.CompositeByteBuf
 
getLong(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
getLong() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
getLong(int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
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.
getMapped() - Method in class com.mongodb.async.client.MappingIterable
 
getMapped() - Method in class com.mongodb.MappingIterable
 
getMappingCallback(SingleResultCallback<List<U>>) - Method in class com.mongodb.async.client.MappingAsyncBatchCursor
 
getMapReduceOutputCollection(MapReduceCommand) - Method in class com.mongodb.DBCollection
 
getMark() - Method in class org.bson.BsonBinaryReader
 
getMark() - Method in class org.bson.BsonDocumentReader
 
getMark() - Method in interface org.bson.BsonReader
Gets a mark representing the current state of the reader.
getMark() - Method in class org.bson.json.JsonReader
 
getMaster() - Method in class com.mongodb.ReplicaSetStatus
Gets the ServerAddress of the master server in this replica set.
getMatchedCount() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
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.AcknowledgedUpdateResult
 
getMatchedCount() - Method in class com.mongodb.client.result.UpdateResult
Gets the number of documents matched by the query.
getMatchedCount() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
getMatchedCount() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
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.FindOptions
Returns the exclusive upper bound for a specific index.
getMax() - Method in class com.mongodb.client.model.IndexOptions
Gets the upper inclusive boundary for the longitude and latitude values for 2d indexes..
getMax() - Method in class com.mongodb.operation.FindOperation
Returns the exclusive upper bound for a specific index.
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.AggregateOperation
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.ChangeStreamOperation
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.
getMaxBatchCount() - Method in class com.mongodb.connection.MessageSettings
Gets the maximum number of items in a batch allowed.
getMaxBsonObjectSize(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
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.MessageSettings
Gets the maximum document size allowed.
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.
getMaxKeyConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON MaxKey values to JSON.
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.
getMaxMessageSize() - Method in class com.mongodb.connection.MessageSettings
Gets the maximum message size allowed.
getMaxMessageSizeBytes(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getMaxScan() - Method in class com.mongodb.client.model.FindOptions
Returns the maximum number of documents or index keys to scan when executing the query.
getMaxScan() - Method in class com.mongodb.operation.FindOperation
Returns the maximum number of documents or index keys to scan when executing the query.
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 class com.mongodb.internal.connection.ConcurrentPool
 
getMaxSize() - Method in class com.mongodb.management.ConnectionPoolStatistics
 
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.CreateIndexOptions
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.DropIndexOptions
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.CreateIndexesOperation
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.DropIndexOperation
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.
getMaxTimeForCursor() - Method in class com.mongodb.operation.FindOperation
 
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.
getMaxWaitTimeNanos() - Method in class com.mongodb.connection.BaseCluster
 
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.
getMaxWriteBatchSize(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getMBean(ServerId) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
getMBeanObjectName(ServerId) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
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.
getMechanismName() - Method in class com.mongodb.connection.GSSAPIAuthenticator
 
getMechanismName() - Method in class com.mongodb.connection.PlainAuthenticator
 
getMechanismName() - Method in class com.mongodb.connection.SaslAuthenticator
 
getMechanismName() - Method in class com.mongodb.connection.ScramSha1Authenticator
 
getMechanismName() - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
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.
getMessageHeader() - Method in class com.mongodb.connection.CompressedHeader
 
getMessageLength() - Method in class com.mongodb.connection.MessageHeader
Gets the total size of the message in bytes.
getMessageLength() - Method in class com.mongodb.connection.ReplyHeader
Gets the total size of the message in bytes.
getMessageSettings(ConnectionDescription) - Static method in class com.mongodb.connection.ProtocolHelper
 
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.FindOptions
Returns the minimum inclusive lower bound for a specific index.
getMin() - Method in class com.mongodb.client.model.IndexOptions
Gets the lower inclusive boundary for the longitude and latitude values for 2d indexes..
getMin() - Method in class com.mongodb.operation.FindOperation
Returns the minimum inclusive lower bound for a specific index.
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.
getMinKeyConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON MinKey values to JSON.
getMinSize() - Method in class com.mongodb.connection.ConnectionPoolSettings
The minimum number of connections.
getMinSize() - Method in class com.mongodb.management.ConnectionPoolStatistics
 
getMinSize() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the minimum allowed size of the pool, including idle and in-use members.
getMinWaitTimeNanos() - Method in class com.mongodb.connection.BaseCluster
 
getMinWireVersion() - Method in class com.mongodb.connection.ServerDescription
The earliest version of the wire protocol that this MongoDB server is capable of using to communicate with clients.
getMixedBulkOperation() - Method in class com.mongodb.operation.BaseWriteOperation
 
getMode() - Method in class com.mongodb.connection.ClusterSettings
Gets the mode.
getModifiedCount() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
getModifiedCount() - Method in class com.mongodb.bulk.BulkWriteResult
Returns the number of documents modified by the write operation.
getModifiedCount() - Method in class com.mongodb.BulkWriteResult
Returns the number of documents modified by the write operation.
getModifiedCount() - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
getModifiedCount() - Method in class com.mongodb.client.result.UpdateResult
Gets the number of documents modified by the update.
getModifiedCount() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
getModifiedCount(WriteRequest.Type, BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
getModifiedCount(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
getModifiedCount() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
getModifiers() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets the query modifiers to apply to this operation.
getModifiers() - Method in class com.mongodb.client.model.FindOptions
Deprecated.
use the individual modifier methods instead.
getModifiers() - Method in class com.mongodb.operation.FindOperation
Gets the query modifiers to apply to this operation.
getMongo() - Method in class com.mongodb.DB
Gets the Mongo instance
getMongo() - Static method in class com.mongodb.gridfs.CLI
 
getMongoClientOptions() - Method in class com.mongodb.Mongo
 
getMongoClientOptions() - Method in class com.mongodb.MongoClient
Gets the options that this client uses to connect to server.
getMongoOptions() - Method in class com.mongodb.Mongo
Deprecated.
Please use MongoClient class to connect to server and corresponding MongoClient.getMongoClientOptions()
getMore(MongoNamespace, long, int, Decoder<T>) - Method in interface com.mongodb.connection.Connection
Get more result documents from a cursor.
getMore(MongoNamespace, long, int, Decoder<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
getMore(ServerCursor, SingleResultCallback<List<T>>, boolean) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
getMore(AsyncConnection, ServerCursor, SingleResultCallback<List<T>>, boolean) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
getMore() - Method in class com.mongodb.operation.QueryBatchCursor
 
getMoreAsync(MongoNamespace, long, int, Decoder<T>, SingleResultCallback<QueryResult<T>>) - Method in interface com.mongodb.connection.AsyncConnection
Get more result documents from a cursor asynchronously.
getMoreAsync(MongoNamespace, long, int, Decoder<T>, SingleResultCallback<QueryResult<T>>) - Method in class com.mongodb.connection.DefaultServerConnection
 
getMoreCursorDocumentToQueryResult(BsonDocument, ServerAddress) - Static method in class com.mongodb.operation.OperationHelper
 
GetMoreMessage - Class in com.mongodb.connection
An OP_GET_MORE message.
GetMoreMessage(String, long, int) - Constructor for class com.mongodb.connection.GetMoreMessage
 
GetMoreProtocol<T> - Class in com.mongodb.connection
An implementation of the OP_GET_MORE protocol.
GetMoreProtocol(MongoNamespace, long, int, Decoder<T>) - Constructor for class com.mongodb.connection.GetMoreProtocol
 
GetMoreProtocol.GetMoreResultCallback - Class in com.mongodb.connection
 
GetMoreResultCallback(SingleResultCallback<QueryResult<T>>, long, GetMoreMessage, ConnectionDescription, CommandListener, long) - Constructor for class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
getN() - Method in class com.mongodb.WriteResult
Gets the "n" field, which contains the number of documents affected in the write operation.
getName() - Method in interface com.mongodb.async.client.MongoDatabase
Gets the name of the database.
getName() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
getName() - Method in class com.mongodb.bulk.IndexRequest
Gets the name of the index.
getName() - Method in class com.mongodb.client.model.BsonField
Gets the field name
getName() - Method in class com.mongodb.client.model.Facet
 
getName() - Method in class com.mongodb.client.model.Field
 
getName() - Method in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
Gets the name of this Coordinate Reference System.
getName() - Method in class com.mongodb.client.model.IndexOptions
Gets the name of the index.
getName() - Method in interface com.mongodb.client.MongoDatabase
Gets the name of the database.
getName() - Method in class com.mongodb.connection.Compressor
 
getName() - Method in class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
getName() - Method in class com.mongodb.connection.SnappyCompressor
 
getName() - Method in class com.mongodb.connection.ZlibCompressor
 
getName() - Method in class com.mongodb.DB
Returns the name of this database.
getName() - Method in class com.mongodb.DBCollection
Get the name of a collection.
getName() - Method in class com.mongodb.diagnostics.logging.JULLogger
 
getName() - Method in interface com.mongodb.diagnostics.logging.Logger
Return the name of this Logger instance.
getName() - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
getName() - Method in class com.mongodb.MongoCompressor
Gets the name of the compressor.
getName() - Method in class com.mongodb.MongoDatabaseImpl
 
getName() - Method in class com.mongodb.ReadPreference
Gets the name of this read preference.
getName() - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
getName() - Method in class com.mongodb.ReplicaSetStatus
Get the name of the replica set.
getName() - Method in class com.mongodb.Tag
Gets the name of the replica set tag.
getName() - Method in class com.mongodb.TaggableReadPreference.NearestReadPreference
 
getName() - Method in class com.mongodb.TaggableReadPreference.PrimaryPreferredReadPreference
 
getName() - Method in class com.mongodb.TaggableReadPreference.SecondaryPreferredReadPreference
 
getName() - Method in class com.mongodb.TaggableReadPreference.SecondaryReadPreference
 
getName() - Method in class org.bson.AbstractBsonWriter
The name of the field being written.
getName() - Method in class org.bson.BSONCallbackAdapter
 
getName() - Method in class org.bson.BsonElement
Gets the name of the key/field.
getName() - Method in class org.bson.codecs.pojo.ClassModel
Returns the name of the class represented by this ClassModel
getName() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getName() - Method in class org.bson.codecs.pojo.PropertyModel
 
getName() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
getName() - Method in class org.bson.diagnostics.JULLogger
 
getName() - Method in interface org.bson.diagnostics.Logger
Return the name of this Logger instance.
getName() - Method in class org.bson.diagnostics.SLF4JLogger
 
getNameOnly() - Method in class com.mongodb.operation.ListDatabasesOperation
Gets the nameOnly flag that indicates whether the command should return just the database names or return the database names and size information.
getNamespace() - Method in interface com.mongodb.async.client.MongoCollection
Gets the namespace of this collection.
getNamespace() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
getNamespace() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Returns the namespace
getNamespace() - Method in interface com.mongodb.client.MongoCollection
Gets the namespace of this collection.
getNamespace() - Method in class com.mongodb.connection.QueryResult
Gets the namespace.
getNamespace() - Method in class com.mongodb.connection.RequestMessage
Gets the collection namespace to send the message to.
getNamespace() - Method in class com.mongodb.connection.WriteProtocol
Gets the namespace.
getNamespace() - Method in class com.mongodb.DBCollection
 
getNamespace() - Method in class com.mongodb.MongoCollectionImpl
 
getNamespace() - Method in class com.mongodb.operation.BaseWriteOperation
Gets the namespace of the collection to write to.
getNamespace() - Method in class com.mongodb.operation.ChangeStreamOperation
 
getNamespace() - Method in class com.mongodb.operation.FindAndDeleteOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.FindOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.GroupOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.ListCollectionsOperation
 
getNamespace() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the namespace.
getNamespace() - Method in class com.mongodb.operation.MixedBulkWriteOperation
Gets the namespace of the collection to write to.
getNamespace() - Method in class org.bson.BsonDbPointer
Gets the namespace.
getNegotiatedProperty(String) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
getNestedTypeData(TypeData.Builder<T>, Type) - Static method in class org.bson.codecs.pojo.TypeData
 
getNewDescription() - Method in class com.mongodb.event.ClusterDescriptionChangedEvent
Gets the new cluster description.
getNewDescription() - Method in class com.mongodb.event.ServerDescriptionChangedEvent
Gets the new server description.
getNewLineCharacters() - Method in class org.bson.json.JsonWriterSettings
The new line character(s) to use if indent mode is enabled.
getNewLineCharacters() - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings
The new line character(s) to use if indent mode is enabled.
getNewServerDescriptionList() - Method in class com.mongodb.connection.MultiServerCluster
 
getNewValue() - Method in class com.mongodb.connection.ChangeEvent
Returns the value after the event was fired
getNext() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Gets next link (which is actually the value held as atomic reference).
getNextBatch() - Method in class com.mongodb.operation.BulkWriteBatch
 
getNextElement() - Method in class org.bson.BsonDocumentReader.Context
 
getNextInBatch() - Method in class com.mongodb.MongoBatchCursorAdapter
 
getNextSplit() - Method in class com.mongodb.connection.SplittablePayload
 
getNextState() - Method in class org.bson.AbstractBsonReader
Returns the next State to transition to, based on the AbstractBsonReader.Context of this reader.
getNextState() - Method in class org.bson.AbstractBsonWriter
Returns the next valid state for this writer.
getNextValue() - Method in class org.bson.BsonDocumentReader.Context
 
getNonceCommand() - Static method in class com.mongodb.internal.authentication.NativeAuthenticationHelper
 
getNormalization() - Method in class com.mongodb.client.model.Collation
Returns the normalization value
getNullConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Null values to JSON.
getNumber(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonNumber, or throws if not.
getNumber(Object, BsonNumber) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getNumberReturned() - Method in class com.mongodb.connection.ReplyHeader
Gets the number of documents to expect in the body of this reply.
getNumberToReturn() - Method in class com.mongodb.connection.QueryProtocol
 
getNumberToReturn(int, int, int) - Static method in class com.mongodb.operation.CursorHelper
Gets the limit of the number of documents in the OP_REPLY response to the get more request.
getNumCursors() - Method in class com.mongodb.operation.ParallelCollectionScanOperation
Gets the number of cursors requested.
getNumCursors() - Method in class com.mongodb.ParallelScanOptions
Gets the number of cursors requested.
getNumericOrdering() - Method in class com.mongodb.client.model.Collation
Returns the numeric ordering, if true will order numbers based on numerical order and not collation order.
getObjectClass() - Method in class com.mongodb.DBCollection
Gets the default class for objects in the collection
getObjectCodec() - Method in class com.mongodb.DBCollection
 
getObjectFactory() - Method in class com.mongodb.DBCollection
 
getObjectId() - Method in interface com.mongodb.async.client.gridfs.GridFSUploadStream
Gets the ObjectId for the file to be uploaded Throws a MongoGridFSException if the file id is not an ObjectId.
getObjectId() - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
getObjectId() - Method in class com.mongodb.client.gridfs.GridFSUploadStream
Gets the ObjectId for the file to be uploaded or throws an error if an alternative BsonType has been used for the id.
getObjectId() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
getObjectId() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The ObjectId for this file.
getObjectId(String) - Method in class org.bson.BasicBSONObject
Returns the object id or null if not set.
getObjectId(String, ObjectId) - Method in class org.bson.BasicBSONObject
Returns the object id or def if not set.
getObjectId(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonObjectId, or throws if not.
getObjectId(Object, BsonObjectId) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getObjectId(Object) - Method in class org.bson.Document
Gets the value of the given key as an ObjectId.
getObjectIdConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON ObjectId values to JSON.
getObjectInstance(Object, Name, Context, Hashtable<?, ?>) - Method in class com.mongodb.client.jndi.MongoClientFactory
This implementation will create instances of MongoClient based on a connection string conforming to the format specified in MongoClientURI.
getOffset() - Method in class org.bson.LazyBSONObject
Gets the offset into the raw bytes representing the start of the document
getOpCode(MessageSettings) - Static method in class com.mongodb.connection.CommandMessage
 
getOpCode() - Method in class com.mongodb.connection.MessageHeader
Gets the opcode
getOpCode() - Method in class com.mongodb.connection.RequestMessage
Gets the op code of the message.
getOpen() - Method in class com.mongodb.connection.FutureAsyncCompletionHandler
 
getOpenedAt() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
Returns the time at which this connection was opened, or Long.MAX_VALUE if it has not yet been opened.
getOperatingSystemType(String) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
getOperation() - Method in class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
getOperation() - Method in class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceWriteOperation
 
getOperation() - Method in class com.mongodb.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
getOperationTime() - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
getOperationTime(ResponseBuffers) - Static method in class com.mongodb.connection.ProtocolHelper
 
getOperationTime() - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
getOperationTime() - Method in class com.mongodb.internal.session.ClientSessionContext
 
getOperationTime() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
getOperationTime() - Method in interface com.mongodb.session.ClientSession
Gets the operation time of the last operation executed in this session.
getOperationTime() - Method in interface com.mongodb.session.SessionContext
Gets the current operation time for this session context
getOperationType() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Returns the operationType
getOpMsgFlagBits() - Method in class com.mongodb.connection.CommandMessage
 
getOpMsgFlagBits() - Method in class com.mongodb.connection.ReplyHeader
 
getOpMsgResponseExpectedFlagBit() - Method in class com.mongodb.connection.CommandMessage
 
getOpQueryFlagBits() - Method in class com.mongodb.connection.CommandMessage
 
getOpQuerySlaveOkFlagBit() - Method in class com.mongodb.connection.CommandMessage
 
getOptionHolder() - Method in class com.mongodb.DB
 
getOptionHolder() - Method in class com.mongodb.Mongo
 
getOptions() - Method in class com.mongodb.client.model.DeleteManyModel
Gets the options to apply.
getOptions() - Method in class com.mongodb.client.model.DeleteOneModel
Gets the options to apply.
getOptions() - Method in class com.mongodb.client.model.IndexModel
Gets the index options.
getOptions() - Method in class com.mongodb.client.model.ReplaceOneModel
Gets the options to apply.
getOptions() - Method in class com.mongodb.client.model.UpdateManyModel
Gets the options to apply.
getOptions() - Method in class com.mongodb.client.model.UpdateOneModel
Gets the options to apply.
getOptions() - Method in class com.mongodb.DB
Gets the query options
getOptions() - Method in class com.mongodb.DBCollection
Gets the default query options
getOptions() - Method in class com.mongodb.DBCursor
Gets the query options.
getOptions() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
getOptions() - Method in class com.mongodb.Mongo
Deprecated.
Get options instead from instances of DBCursor
getOptions() - Method in class com.mongodb.MongoClientURI
Gets the options
getOptions() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the options.
getOptions() - Method in interface com.mongodb.session.ClientSession
Get the options for this session.
getOptions() - Method in class org.bson.BsonRegularExpression
Gets the options for the regular expression
getOptionsAsInt(BsonRegularExpression) - Static method in class org.bson.codecs.PatternCodec
 
getOptionsAsString(Pattern) - Static method in class org.bson.codecs.PatternCodec
 
getOrCreateProperty(String, String, Map<String, PropertyMetadata<?>>, TypeData<T>, Map<String, TypeParameterMap>, TypeData<S>, List<String>, Type, PojoBuilderHelper.PropertyTypeCheck) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
getOriginalOpcode() - Method in class com.mongodb.connection.CompressedHeader
 
getOriginator() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
getOriginator() - Method in interface com.mongodb.session.ClientSession
Gets the originator for the session.
getOrThrow(Class<T>) - Method in class org.bson.codecs.configuration.CodecCache
 
getOutCollection(List<BsonDocument>) - Method in class com.mongodb.AggregateIterableImpl
 
getOutCollection(List<BsonDocument>) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
getOutput() - Method in class com.mongodb.client.model.BucketAutoOptions
 
getOutput() - Method in class com.mongodb.client.model.BucketOptions
 
getOutputBuffer() - Method in class org.bson.BasicBSONEncoder
Gets the buffer the BSON is being encoded into.
getOutputCollection() - Method in class com.mongodb.MapReduceOutput
Gets the collection that holds the results (Will return null if results are Inline).
getOutputCount() - Method in class com.mongodb.MapReduceOutput
Get the number of documents generated as a result of this map reduce
getOutputCount(BsonDocument) - Static method in class com.mongodb.operation.MapReduceHelper
 
getOutputCount() - Method in class com.mongodb.operation.MapReduceStatistics
Get the number of documents generated as a result of this map reduce
getOutputDB() - Method in class com.mongodb.MapReduceCommand
Gets the (optional) database name where the output collection should reside
getOutputMode() - Method in class com.mongodb.AggregationOptions
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
getOutputMode() - Method in class org.bson.json.JsonWriterSettings
The output mode to use.
getOutputStream(OutputStream) - Method in class com.mongodb.connection.Compressor
 
getOutputStream(OutputStream) - Method in class com.mongodb.connection.ZlibCompressor
 
getOutputStream() - Method in class com.mongodb.gridfs.GridFSInputFile
After retrieving this OutputStream, this object will be capable of accepting successively written data to the output stream.
getOutputTarget() - Method in class com.mongodb.MapReduceCommand
Gets the output target (name of collection to save to) This value is nullable only if OutputType is set to INLINE
getOutputType() - Method in class com.mongodb.MapReduceCommand
Gets the OutputType for this instance.
getParameterGenericTypes() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getParameterTypes() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getParentContext() - Method in class org.bson.AbstractBsonReader.Context
Returns the parent context.
getParentContext() - Method in class org.bson.AbstractBsonReader.Mark
 
getParentContext() - Method in class org.bson.AbstractBsonWriter.Context
Returns the parent context.
getParentContext() - Method in class org.bson.BsonBinaryReader.Context
 
getParentContext() - Method in class org.bson.BsonBinaryWriter.Context
 
getParentContext() - Method in class org.bson.BSONCallbackAdapter.Context
 
getParentContext() - Method in class org.bson.json.JsonReader.Context
 
getParentContext() - Method in class org.bson.json.JsonWriter.Context
 
getPartialFilterExpression() - Method in class com.mongodb.bulk.IndexRequest
Get the filter expression for the documents to be included in the index or null if not set
getPartialFilterExpression() - Method in class com.mongodb.client.model.IndexOptions
Get the filter expression for the documents to be included in the index or null if not set
getPassives() - Method in class com.mongodb.connection.ServerDescription
Gets the passive members of the replica set.
getPassword() - Method in class com.mongodb.ConnectionString
Gets the password
getPassword() - Method in class com.mongodb.MongoClientURI
Gets the password
getPassword() - Method in class com.mongodb.MongoCredential
Gets the password.
getPassword() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the password.
getPattern() - Method in class org.bson.BsonRegularExpression
Gets the regex pattern.
getPayload() - Method in class com.mongodb.connection.SplittablePayload
 
getPayload() - Method in class com.mongodb.operation.BulkWriteBatch
 
getPayloadArrayFieldNameValidator() - Method in class com.mongodb.connection.CommandMessage
 
getPayloadMessageSettings(SplittablePayload.Type, MessageSettings) - Static method in class com.mongodb.connection.BsonWriterHelper
 
getPayloadName() - Method in class com.mongodb.connection.SplittablePayload
 
getPayloadType() - Method in class com.mongodb.connection.SplittablePayload
 
getPayloadType(WriteRequest.Type) - Method in class com.mongodb.operation.BulkWriteBatch
 
getPipeline() - Method in class com.mongodb.client.model.Facet
 
getPipeline() - Method in class com.mongodb.operation.AggregateOperation
Gets the aggregation pipeline.
getPipeline() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Gets the aggregation pipeline.
getPipeline() - Method in class com.mongodb.operation.ChangeStreamOperation
Gets the aggregation pipeline.
getPipeline() - Method in class com.mongodb.operation.CreateViewOperation
Gets the pipeline that defines the view.
getPojoCodec() - Method in class org.bson.codecs.pojo.LazyPojoCodec
 
getPojoCodec(Class<T>, CodecRegistry) - Method in class org.bson.codecs.pojo.PojoCodecProvider
 
getPool() - Method in class com.mongodb.connection.DefaultConnectionPool
 
getPooledConnection(long, TimeUnit) - Method in class com.mongodb.connection.DefaultConnectionPool
 
getPort() - Method in class com.mongodb.management.ConnectionPoolStatistics
 
getPort() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the port that this connection pool is connecting to.
getPort() - Method in class com.mongodb.ServerAddress
Gets the port number
getPosition() - Method in class com.mongodb.client.model.geojson.Point
Gets the position of this point.
getPosition() - Method in class com.mongodb.client.model.PushOptions
Gets the position at which to add the pushed values in the array.
getPosition() - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
getPosition() - Method in class com.mongodb.connection.SplittablePayload
 
getPosition() - Method in class org.bson.io.BasicOutputBuffer
 
getPosition() - Method in interface org.bson.io.BsonInput
Gets the current position in the stream
getPosition() - Method in interface org.bson.io.BsonOutput
Gets the current position in the stream.
getPosition() - Method in class org.bson.io.ByteBufferBsonInput
 
getPosition() - Method in class org.bson.json.JsonBuffer
 
getPrev() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Gets prev link.
getPreviousDescription() - Method in class com.mongodb.event.ClusterDescriptionChangedEvent
Gets the previous cluster description.
getPreviousDescription() - Method in class com.mongodb.event.ServerDescriptionChangedEvent
Gets the previous server description.
getPreviousValue() - Method in class com.mongodb.connection.ChangeEvent
Returns the value before this change event was fired.
getPrimaries() - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getPrimary() - Method in class com.mongodb.connection.ServerDescription
Gets the address of the current primary in the replica set
getProcessIdentifier() - Method in class org.bson.types.ObjectId
Gets the process identifier.
getProjection() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the projection
getProjection() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.client.model.FindOptions
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.operation.FindAndDeleteOperation
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets a document describing the fields to return for all matching documents.
getProjection() - Method in class com.mongodb.operation.FindOperation
Gets a document describing the fields to return for all matching documents.
getProperties() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getProperty(String, T) - Method in class com.mongodb.MongoCompressor
Gets the property with the given key.
getProperty(String) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Gets a property by the property name.
getPropertyAccessor() - Method in class org.bson.codecs.pojo.PropertyModel
 
getPropertyAccessor() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Returns the PropertyAccessor
getPropertyMetadata() - Method in class org.bson.codecs.pojo.PropertyAccessorImpl
 
getPropertyMethods(Class<?>) - Static method in class org.bson.codecs.pojo.PropertyReflectionUtils
 
getPropertyModel(String) - Method in class org.bson.codecs.pojo.ClassModel
Gets a PropertyModel by the property name.
getPropertyModelBuilders() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
getPropertyModelByWriteName(ClassModel<T>, String) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
getPropertyModels() - Method in class org.bson.codecs.pojo.ClassModel
Returns all the properties on this model
getPropertyNameToTypeParameterMap() - Method in class org.bson.codecs.pojo.ClassModel
 
getPropertyNameToTypeParameterMap() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
getPropertySerialization() - Method in class org.bson.codecs.pojo.PropertyModel
 
getPropertySerialization() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
getPropertyToClassParamIndexMap() - Method in class org.bson.codecs.pojo.TypeParameterMap
Returns a mapping of property type parameter index to the class type parameter index.
getQuery() - Method in class com.mongodb.DBCursor
Gets the query.
getQuery() - Method in class com.mongodb.MapReduceCommand
Gets the query to run for this MapReduce job
getQuery() - Method in class com.mongodb.RemoveRequest
 
getQuery() - Method in class com.mongodb.ReplaceRequest
 
getQuery() - Method in class com.mongodb.UpdateRequest
 
getQueryFailureException(BsonDocument, ServerAddress) - Static method in class com.mongodb.connection.ProtocolHelper
 
getQueryOperation(Decoder<DBObject>) - Method in class com.mongodb.DBCursor
 
getRandom() - Method in class com.mongodb.connection.BaseCluster
 
getRandomServer(List<ServerDescription>) - Method in class com.mongodb.connection.BaseCluster
 
getRead() - Method in class com.mongodb.connection.FutureAsyncCompletionHandler
 
getReadAnnotations() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getReadAnnotations() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Returns the read annotations, to be applied when serializing to BSON
getReadConcern() - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Get the read concern for the GridFSBucket.
getReadConcern() - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getReadConcern() - Method in class com.mongodb.async.client.MongoClientSettings
The read concern to use.
getReadConcern() - Method in interface com.mongodb.async.client.MongoCollection
Get the read concern for the MongoCollection.
getReadConcern() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
getReadConcern() - Method in interface com.mongodb.async.client.MongoDatabase
Get the read concern for the MongoDatabase.
getReadConcern() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
getReadConcern() - Method in class com.mongodb.async.client.MongoIterableImpl
 
getReadConcern() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Get the read concern for the GridFSBucket.
getReadConcern() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
getReadConcern() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Returns the readConcern
getReadConcern() - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Returns the readConcern
getReadConcern() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Returns the readConcern
getReadConcern() - Method in interface com.mongodb.client.MongoCollection
Get the read concern for the MongoCollection.
getReadConcern() - Method in interface com.mongodb.client.MongoDatabase
Get the read concern for the MongoDatabase.
getReadConcern() - Method in class com.mongodb.ConnectionString
Gets the read concern specified in the connection string.
getReadConcern() - Method in class com.mongodb.DB
Get the read concern for this database.
getReadConcern() - Method in class com.mongodb.DBCollection
Get the read concern for this collection.
getReadConcern() - Method in class com.mongodb.DBCursor
Get the read concern for this collection.
getReadConcern() - Method in class com.mongodb.Mongo
Gets the read concern
getReadConcern() - Method in class com.mongodb.MongoClientOptions
The read concern to use.
getReadConcern() - Method in class com.mongodb.MongoCollectionImpl
 
getReadConcern() - Method in class com.mongodb.MongoDatabaseImpl
 
getReadConcern() - Method in class com.mongodb.MongoIterableImpl
 
getReadConcern() - Method in class com.mongodb.operation.AggregateOperation
Gets the read concern
getReadConcern() - Method in class com.mongodb.operation.ChangeStreamOperation
Gets the read concern
getReadConcern() - Method in class com.mongodb.operation.CountOperation
Gets the read concern
getReadConcern() - Method in class com.mongodb.operation.DistinctOperation
Gets the read concern
getReadConcern() - Method in class com.mongodb.operation.FindOperation
Gets the read concern
getReadConcern() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the read concern
getReadConcern() - Method in class com.mongodb.operation.ParallelCollectionScanOperation
Gets the read concern
getReadConcernLevel(ReadConcern, SessionContext) - Static method in class com.mongodb.operation.ReadConcernHelper
 
getReadConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in class com.mongodb.async.client.ClientSessionBinding
 
getReadConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in class com.mongodb.binding.AsyncClusterBinding
 
getReadConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in interface com.mongodb.binding.AsyncReadBinding
Returns a connection source to a server that satisfies the specified read preference.
getReadConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
getReadConnectionSource() - Method in class com.mongodb.binding.ClusterBinding
 
getReadConnectionSource() - Method in interface com.mongodb.binding.ReadBinding
Returns a connection source to a server that satisfies the specified read preference.
getReadConnectionSource() - Method in class com.mongodb.binding.SingleConnectionReadBinding
 
getReadConnectionSource() - Method in class com.mongodb.binding.SingleServerBinding
 
getReadConnectionSource() - Method in class com.mongodb.ClientSessionBinding
 
getReadingLock() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
getReadName() - Method in class org.bson.codecs.pojo.PropertyModel
 
getReadName() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
getReadPreference() - Method in class com.mongodb.async.client.ClientSessionBinding
 
getReadPreference() - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Get the read preference for the GridFSBucket.
getReadPreference() - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getReadPreference() - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
getReadPreference() - Method in class com.mongodb.async.client.MongoClientSettings
The read preference to use for queries, map-reduce, aggregation, and count.
getReadPreference() - Method in interface com.mongodb.async.client.MongoCollection
Get the read preference for the MongoCollection.
getReadPreference() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
getReadPreference() - Method in interface com.mongodb.async.client.MongoDatabase
Get the read preference for the MongoDatabase.
getReadPreference() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
getReadPreference() - Method in class com.mongodb.async.client.MongoIterableImpl
 
getReadPreference() - Method in class com.mongodb.binding.AsyncClusterBinding
 
getReadPreference() - Method in interface com.mongodb.binding.AsyncReadBinding
The read preference that all connection sources returned by this instance will satisfy.
getReadPreference() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
getReadPreference() - Method in class com.mongodb.binding.ClusterBinding
 
getReadPreference() - Method in interface com.mongodb.binding.ReadBinding
The read preference that all connection sources returned by this instance will satisfy.
getReadPreference() - Method in class com.mongodb.binding.SingleConnectionReadBinding
 
getReadPreference() - Method in class com.mongodb.binding.SingleServerBinding
 
getReadPreference() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Get the read preference for the GridFSBucket.
getReadPreference() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
getReadPreference() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Returns the readPreference
getReadPreference() - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Returns the readPreference
getReadPreference() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Returns the readPreference
getReadPreference() - Method in interface com.mongodb.client.MongoCollection
Get the read preference for the MongoCollection.
getReadPreference() - Method in interface com.mongodb.client.MongoDatabase
Get the read preference for the MongoDatabase.
getReadPreference() - Method in class com.mongodb.ClientSessionBinding
 
getReadPreference() - Method in class com.mongodb.ConnectionString
Gets the read preference specified in the connection string.
getReadPreference() - Method in class com.mongodb.DB
Gets the read preference for this database.
getReadPreference() - Method in class com.mongodb.DBCollection
Gets the ReadPreference.
getReadPreference() - Method in class com.mongodb.DBCursor
Gets the default read preference.
getReadPreference() - Method in class com.mongodb.MapReduceCommand
Gets the read preference
getReadPreference() - Method in class com.mongodb.MapReduceIterableImpl
 
getReadPreference() - Method in class com.mongodb.Mongo
Gets the default read preference
getReadPreference() - Method in class com.mongodb.MongoClientOptions
The read preference to use for queries, map-reduce, aggregation, and count.
getReadPreference() - Method in class com.mongodb.MongoCollectionImpl
 
getReadPreference() - Method in class com.mongodb.MongoDatabaseImpl
 
getReadPreference() - Method in class com.mongodb.MongoIterableImpl
 
getReadPreference() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the read preference.
getReadPreference() - Method in class com.mongodb.ParallelScanOptions
Gets the read preference to use.
getReadPreference() - Method in class com.mongodb.selector.ReadPreferenceServerSelector
Gets the read preference.
getReadPreferenceForCursor() - Method in class com.mongodb.DBCursor
 
getReadPreferenceFromSlaveOk(boolean) - Method in class com.mongodb.connection.DefaultServerConnection
 
getReadTimeout(TimeUnit) - Method in class com.mongodb.connection.SocketSettings
Gets the timeout for socket reads.
getReadWriteBinding(ReadPreference, ClientSession, boolean) - Method in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
getReasonForClosing(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory
 
getReceiveBufferSize() - Method in class com.mongodb.connection.SocketSettings
Gets the receive buffer size.
getReduce() - Method in class com.mongodb.MapReduceCommand
Gets the reduce function, as a JS String
getReduceFunction() - Method in class com.mongodb.operation.GroupOperation
Gets the aggregation function that operates on the documents during the grouping operation.
getReduceFunction() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the JavaScript function that "reduces" to a single object all the values associated with a particular key.
getReduceFunction() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the JavaScript function that "reduces" to a single object all the values associated with a particular key.
getReferenceCount() - Method in class com.mongodb.connection.CompositeByteBuf
 
getReferenceCount() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
getReferenceCount() - Method in interface org.bson.ByteBuf
Gets the current reference count, which starts at 0.
getReferenceCount() - Method in class org.bson.ByteBufNIO
 
getRegistry() - Static method in class com.mongodb.client.model.geojson.Geometry
 
getRegularExpression(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonRegularExpression, or throws if not.
getRegularExpression(Object, BsonRegularExpression) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getRegularExpressionConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON RegularExpression values to JSON.
getRemainingTime() - Method in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
getRemovedCount() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
getRemovedCount() - Method in class com.mongodb.BulkWriteResult
Returns the number of documents removed by the write operation.
getRemovedCount() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
getRemovedFields() - Method in class com.mongodb.client.model.changestream.UpdateDescription
Returns the removedFields
getReplacement() - Method in class com.mongodb.client.model.ReplaceOneModel
Gets the document which will replace the document matching the query filter.
getReplacement() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the document which will replace the document matching the query filter.
getReplicaSetStatus() - Method in class com.mongodb.Mongo
Get the status of the replica set cluster.
getReply() - Method in class com.mongodb.event.ServerHeartbeatSucceededEvent
Gets the reply to the isMaster command executed for this heartbeat.
getReplyHeader() - Method in class com.mongodb.connection.ReplyMessage
Gets the reply header.
getReplyHeader() - Method in class com.mongodb.connection.ResponseBuffers
Gets the reply header.
getRequested() - Method in class com.mongodb.async.client.AbstractSubscription
 
getRequestId() - Method in class com.mongodb.connection.MessageHeader
This is a client or database-generated identifier that uniquely identifies this message.
getRequestId() - Method in class com.mongodb.connection.ReplyHeader
This is a client or database-generated identifier that uniquely identifies this message.
getRequestId() - Method in class com.mongodb.connection.ResponseCallback
 
getRequestId() - Method in class com.mongodb.event.CommandEvent
Gets the request identifier
getRequestId() - Method in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
Gets the request id of the message that was sent.
getRequests() - Method in class com.mongodb.operation.CreateIndexesOperation
Gets the index requests.
getRequiredClusterType() - Method in class com.mongodb.connection.ClusterSettings
Get
getRequiredReplicaSetName() - Method in class com.mongodb.connection.ClusterSettings
Gets the required replica set name.
getRequiredReplicaSetName() - Method in class com.mongodb.ConnectionString
Gets the required replica set name specified in the connection string.
getRequiredReplicaSetName() - Method in class com.mongodb.MongoClientOptions
Gets the required replica set name.
getRequiredReplicaSetName() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the required replica set name that this client should be connecting to.
getResponse() - Method in class com.mongodb.event.CommandSucceededEvent
Gets the response document.
getResponse() - Method in exception com.mongodb.MongoCommandException
For internal use only.
getResponse() - Method in exception com.mongodb.WriteConcernException
Gets the response to the write operation.
getResponseAsJson(BsonDocument) - Static method in exception com.mongodb.MongoCommandException
 
getResponseDocument(ResponseBuffers, int, Decoder<T>) - Static method in class com.mongodb.connection.InternalStreamConnection
 
getResponseDocument() - Method in class com.mongodb.connection.WriteProtocol
 
getResponseFlags() - Method in class com.mongodb.connection.ReplyHeader
Gets additional information about the response.
getResponseTo() - Method in class com.mongodb.connection.MessageHeader
Along with the requestID field in queries, clients can use this to associate query responses with the originating query.
getResponseTo() - Method in class com.mongodb.connection.ReplyHeader
Along with the requestID field in queries, clients can use this to associate query responses with the originating query.
getResponseTo() - Method in class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
The responseTo identifier of the message.
getRestrictSearchWithMatch() - Method in class com.mongodb.client.model.GraphLookupOptions
 
getResult() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Gets the combined result.
getResult() - Method in class com.mongodb.operation.BulkWriteBatch
 
getResults() - Method in class com.mongodb.connection.QueryResult
Gets the results.
getResumeToken() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Returns the resumeToken
getResumeToken() - Method in class com.mongodb.operation.ChangeStreamOperation
Returns the logical starting point for the new change stream.
getRetryWrites() - Method in class com.mongodb.async.client.MongoClientSettings
Returns true if writes should be retried if they fail due to a network error.
getRetryWrites() - Method in class com.mongodb.ConnectionString
Returns true if writes should be retried if they fail due to a network error.
getRetryWrites() - Method in class com.mongodb.MongoClientOptions
Returns true if writes should be retried if they fail due to a network error.
getRetryWrites() - Method in class com.mongodb.operation.BulkWriteBatch
 
getRetryWrites() - Method in class com.mongodb.operation.MixedBulkWriteOperation
Returns true if writes should be retried if they fail due to a network error.
getReturnDocument() - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Gets the ReturnDocument value indicating whether to return the document before it was replaced or after
getReturnDocument() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Gets the ReturnDocument value indicating whether to return the document before it was updated / inserted or after
getRevision() - Method in class com.mongodb.client.gridfs.model.GridFSDownloadByNameOptions
Deprecated.
Gets the revision to download identifier
getRevision() - Method in class com.mongodb.client.gridfs.model.GridFSDownloadOptions
Gets the revision to download identifier
getRoleName(MongoCredential, boolean) - Static method in class com.mongodb.operation.UserOperationHelper
 
getRoot() - Method in class org.bson.LazyBSONCallback
 
getRoundTripFormattedInMilliseconds() - Method in class com.mongodb.connection.ServerDescription
 
getRoundTripTimeNanos() - Method in class com.mongodb.connection.ServerDescription
Get the time it took to make the round trip for requesting this information from the server in nanoseconds.
getScope() - Method in class com.mongodb.MapReduceCommand
Gets the (optional) JavaScript scope
getScope() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the global variables that are accessible in the map, reduce and finalize functions.
getScope() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the global variables that are accessible in the map, reduce and finalize functions.
getScope() - Method in class org.bson.BsonJavaScriptWithScope
Get the scope.
getScope() - Method in class org.bson.types.CodeWithScope
Gets the scope, which is is a mapping from identifiers to values, representing the scope in which the code should be evaluated.
getScope() - Method in class org.bson.types.CodeWScope
Gets the scope for this JavaScript
getSecondaries() - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getSecondaries(TagSet) - Method in class com.mongodb.connection.ClusterDescription
Deprecated.
Replace with a filter on ServerDescription in the caller
getSendBufferSize() - Method in class com.mongodb.connection.SocketSettings
Gets the send buffer size.
getServer(ServerAddress) - Method in class com.mongodb.connection.BaseCluster
Return the server at the given address.
getServer(ServerAddress) - Method in class com.mongodb.connection.MultiServerCluster
 
getServer(ServerAddress) - Method in class com.mongodb.connection.SingleServerCluster
 
getServerAddress() - Method in interface com.mongodb.client.MongoCursor
Returns the server address
getServerAddress() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
getServerAddress() - Method in class com.mongodb.connection.ConnectionDescription
Gets the server address.
getServerAddress() - Method in class com.mongodb.connection.InternalStreamConnection
 
getServerAddress() - Method in class com.mongodb.connection.ResponseCallback
 
getServerAddress() - Method in interface com.mongodb.Cursor
Gets the address of the server that data is pulled from.
getServerAddress() - Method in class com.mongodb.DBCursor
 
getServerAddress() - Method in class com.mongodb.MongoBatchCursorAdapter
 
getServerAddress() - Method in exception com.mongodb.MongoBulkWriteException
The address of the server which performed the bulk write operation.
getServerAddress() - Method in class com.mongodb.MongoCursorAdapter
 
getServerAddress() - Method in exception com.mongodb.MongoCursorNotFoundException
The server address where the cursor is.
getServerAddress() - Method in class com.mongodb.MongoMappingCursor
 
getServerAddress() - Method in exception com.mongodb.MongoServerException
Gets the address of the server.
getServerAddress() - Method in exception com.mongodb.MongoSocketException
Gets the server address for this exception.
getServerAddress() - Method in interface com.mongodb.operation.BatchCursor
Returns the server address
getServerAddress() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
getServerAddress() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
getServerAddress() - Method in class com.mongodb.operation.QueryBatchCursor
 
getServerAddress() - Method in class com.mongodb.selector.ServerAddressSelector
Gets the server address.
getServerAddressList() - Method in class com.mongodb.Mongo
Gets the list of server addresses currently seen by this client.
getServerCursor() - Method in interface com.mongodb.client.MongoCursor
Returns the server cursor, which can be null if the no cursor was created or if the cursor has been exhausted or killed.
getServerCursor() - Method in class com.mongodb.MongoBatchCursorAdapter
 
getServerCursor() - Method in class com.mongodb.MongoMappingCursor
 
getServerCursor() - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
getServerCursor() - Method in interface com.mongodb.operation.BatchCursor
Returns the server cursor
getServerCursor() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
getServerCursor() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
getServerCursor() - Method in class com.mongodb.operation.QueryBatchCursor
 
getServerDescription() - Method in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
getServerDescription() - Method in class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
getServerDescription() - Method in interface com.mongodb.binding.AsyncConnectionSource
Gets the current description of this source.
getServerDescription() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource
 
getServerDescription() - Method in class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
getServerDescription() - Method in interface com.mongodb.binding.ConnectionSource
Gets the current description of this source.
getServerDescription() - Method in class com.mongodb.binding.SingleConnectionReadBinding.SingleConnectionSource
 
getServerDescription() - Method in class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
getServerDescription() - Method in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
getServerDescriptionListToConsiderForSessionSupport(ClusterDescription) - Method in class com.mongodb.async.client.ClientSessionHelper
 
getServerDescriptionListToConsiderForSessionSupport(ClusterDescription) - Method in class com.mongodb.Mongo
 
getServerDescriptions() - Method in class com.mongodb.connection.ClusterDescription
Returns an unmodifiable list of the server descriptions in this cluster description.
getServerFactory() - Method in class com.mongodb.connection.BaseCluster
 
getServerId() - Method in class com.mongodb.connection.ConnectionId
Gets the server id.
getServerId() - Method in class com.mongodb.event.ConnectionPoolClosedEvent
Gets the server id
getServerId() - Method in class com.mongodb.event.ConnectionPoolOpenedEvent
Gets the server id
getServerId() - Method in class com.mongodb.event.ConnectionPoolWaitQueueEnteredEvent
Gets the server id.
getServerId() - Method in class com.mongodb.event.ConnectionPoolWaitQueueExitedEvent
Gets the server id.
getServerId() - Method in class com.mongodb.event.ServerClosedEvent
Gets the serverId.
getServerId() - Method in class com.mongodb.event.ServerDescriptionChangedEvent
Gets the serverId.
getServerId() - Method in class com.mongodb.event.ServerOpeningEvent
Gets the serverId.
getServerListeners() - Method in class com.mongodb.connection.ServerSettings
Gets the server listeners.
getServerListeners() - Method in class com.mongodb.event.ServerEventMulticaster
Deprecated.
Gets the server listeners.
getServerListeners() - Method in class com.mongodb.MongoClientOptions
Gets the list of added ServerListener.
getServerMonitorListener(ServerSettings) - Static method in class com.mongodb.internal.event.EventListenerHelper
 
getServerMonitorListeners() - Method in class com.mongodb.connection.ServerSettings
Gets the server monitor listeners.
getServerMonitorListeners() - Method in class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
Gets the server monitor listeners.
getServerMonitorListeners() - Method in class com.mongodb.MongoClientOptions
Gets the list of added ServerMonitorListener.
getServersByPredicate(ClusterDescription.Predicate) - Method in class com.mongodb.connection.ClusterDescription
 
getServerSelectionTimeout(TimeUnit) - Method in class com.mongodb.connection.ClusterSettings
Gets the timeout to apply when selecting a server.
getServerSelectionTimeout() - Method in class com.mongodb.ConnectionString
 
getServerSelectionTimeout() - Method in class com.mongodb.MongoClientOptions
Gets the server selection timeout in milliseconds, which defines how long the driver will wait for server selection to succeed before throwing an exception.
getServerSelector() - Method in class com.mongodb.connection.ClusterSettings
Gets the ServerSelector that will be uses as the final server selector that is applied in calls to Cluster.selectServer.
getServerSelector(MongoClientOptions) - Static method in class com.mongodb.Mongo
 
getServerSelector() - Method in class com.mongodb.MongoClientOptions
Gets the server selector.
getServerSession() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
getServerSession() - Method in interface com.mongodb.session.ClientSession
 
getServerSessionPool() - Method in class com.mongodb.async.client.MongoClientImpl
 
getServerSessionPool() - Method in class com.mongodb.Mongo
 
getServerSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the server-specific settings wrapped in a settings object.
getServerSettings() - Method in class com.mongodb.connection.ClusterDescription
Gets the server settings, which may be null if not provided.
getServerSettings() - Method in class com.mongodb.MongoClientOptions
 
getServersWithAcceptableLatencyDifference(List<ServerDescription>, long) - Method in class com.mongodb.selector.LatencyMinimizingServerSelector
 
getServerType() - Method in class com.mongodb.connection.ConnectionDescription
Gets the server type.
getServerType(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getServerType() - Method in class com.mongodb.connection.MessageSettings
 
getServerValue() - Method in class com.mongodb.connection.ConnectionId
Gets the server generated id value for the connection or null if not set.
getServerVersion() - Method in class com.mongodb.connection.ConnectionDescription
Gets the version of the server.
getServerVersion() - Method in class com.mongodb.connection.MessageSettings
 
getSessionContext() - Method in class com.mongodb.async.client.ClientSessionBinding
 
getSessionContext() - Method in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
getSessionContext() - Method in class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
getSessionContext() - Method in class com.mongodb.binding.AsyncClusterBinding
 
getSessionContext() - Method in interface com.mongodb.binding.AsyncConnectionSource
Gets the session context for this source
getSessionContext() - Method in interface com.mongodb.binding.AsyncReadBinding
Gets the session context for this binding.
getSessionContext() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource
 
getSessionContext() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
getSessionContext() - Method in interface com.mongodb.binding.AsyncWriteBinding
Gets the session context for this binding.
getSessionContext() - Method in class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
getSessionContext() - Method in class com.mongodb.binding.ClusterBinding
 
getSessionContext() - Method in interface com.mongodb.binding.ConnectionSource
Gets the session context for this source
getSessionContext() - Method in interface com.mongodb.binding.ReadBinding
Gets the session context for this binding.
getSessionContext() - Method in class com.mongodb.binding.SingleConnectionReadBinding
 
getSessionContext() - Method in class com.mongodb.binding.SingleConnectionReadBinding.SingleConnectionSource
 
getSessionContext() - Method in class com.mongodb.binding.SingleServerBinding
 
getSessionContext() - Method in class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
getSessionContext() - Method in interface com.mongodb.binding.WriteBinding
Gets the session context for this binding.
getSessionContext() - Method in class com.mongodb.ClientSessionBinding
 
getSessionContext() - Method in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
getSessionId() - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
getSessionId() - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
getSessionId() - Method in class com.mongodb.internal.session.ClientSessionContext
 
getSessionId() - Method in interface com.mongodb.session.SessionContext
Gets the session identifier if this context has a session backing it.
getSetName() - Method in class com.mongodb.connection.ServerDescription
Gets the name of the replica set
getSetter() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getSetterMethods() - Method in class org.bson.codecs.pojo.PropertyReflectionUtils.PropertyMethods
 
getSettings() - Method in interface com.mongodb.async.client.MongoClient
Gets the settings that this client uses to connect to server.
getSettings() - Method in class com.mongodb.async.client.MongoClientImpl
 
getSettings() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
getSettings() - Method in class com.mongodb.connection.BaseCluster
 
getSettings() - Method in interface com.mongodb.connection.Cluster
Gets the cluster settings with which this cluster was created.
getSettings() - Method in interface com.mongodb.connection.ClusterableServerFactory
 
getSettings() - Method in class com.mongodb.connection.DefaultClusterableServerFactory
 
getSettings() - Method in class com.mongodb.connection.netty.NettyStream
 
getSettings() - Method in class com.mongodb.connection.RequestMessage
Gets the message settings.
getSettings() - Method in class com.mongodb.connection.SocketChannelStream
Get the settings for this socket.
getSettings() - Method in class com.mongodb.connection.SocketStream
Get the settings for this socket.
getSettings() - Method in class com.mongodb.event.ConnectionPoolOpenedEvent
Gets the connection pool settings.
getSetVersion(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getSetVersion() - Method in class com.mongodb.connection.ServerDescription
The replica set setVersion reported by this MongoDB server.
getShort(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
getShortDescription() - Method in class com.mongodb.connection.ClusterDescription
Returns a short, pretty description for this ClusterDescription.
getShortDescription() - Method in class com.mongodb.connection.ClusterSettings
Returns a short, pretty description for these ClusterSettings.
getShortDescription() - Method in class com.mongodb.connection.ServerDescription
Returns a short, pretty description for this ServerDescription.
getSingleServerClusterMode(MongoClientOptions) - Static method in class com.mongodb.Mongo
 
getSister(String) - Method in class com.mongodb.DBAddress
Deprecated.
Creates a DBAddress pointing to a different database on the same server.
getSisterDB(String) - Method in class com.mongodb.DB
Gets another database on same server
getSize() - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
getSize() - Method in class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
Gets the size of the received message.
getSize() - Method in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
Gets the size of the sent message.
getSize() - Method in class com.mongodb.management.ConnectionPoolStatistics
 
getSize() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the current size of the pool, including idle and and in-use members.
getSize() - Method in class org.bson.io.BasicOutputBuffer
 
getSize() - Method in interface org.bson.io.BsonOutput
Gets the current size of the stream in number of bytes.
getSizeInBytes() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets the maximum size in bytes of a capped collection.
getSizeInBytes() - Method in class com.mongodb.connection.ByteBufBsonDocument
 
getSizeInBytes() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the maximum size of the collection in bytes.
getSkip() - Method in class com.mongodb.client.model.CountOptions
Gets the number of documents to skip.
getSkip() - Method in class com.mongodb.client.model.DBCollectionCountOptions
Gets the number of documents to skip.
getSkip() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets the number of documents to skip.
getSkip() - Method in class com.mongodb.client.model.FindOptions
Gets the number of documents to skip.
getSkip() - Method in class com.mongodb.operation.CountOperation
Gets the number of documents to skip.
getSkip() - Method in class com.mongodb.operation.FindOperation
Gets the number of documents to skip.
getSlaveOk(boolean) - Method in class com.mongodb.connection.DefaultServerConnection
 
getSlice() - Method in class com.mongodb.client.model.PushOptions
Gets the slice value, which is the limit on the number of array elements allowed.
getSocketAddress() - Method in class com.mongodb.ServerAddress
Gets the underlying socket address
getSocketChannelClass() - Method in class com.mongodb.connection.netty.NettyStream
 
getSocketFactory() - Method in class com.mongodb.MongoClientOptions
The socket factory for creating sockets to the mongo server.
getSocketFactory() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the socket factory for creating sockets to mongod.
getSocketSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the connection-specific settings wrapped in a settings object.
getSocketSettings() - Method in class com.mongodb.MongoClientOptions
 
getSocketTimeout() - Method in class com.mongodb.ConnectionString
Gets the socket timeout specified in the connection string.
getSocketTimeout() - Method in class com.mongodb.MongoClientOptions
The socket timeout in milliseconds.
getSocketTimeout() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the socket timeout in milliseconds.
getSort() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the sort
getSort() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.client.model.FindOptions
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.client.model.PushOptions
Gets the sort direction for sorting array elements that are not documents.
getSort() - Method in class com.mongodb.MapReduceCommand
Gets the (optional) sort specification object
getSort() - Method in class com.mongodb.operation.FindAndDeleteOperation
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.operation.FindAndReplaceOperation
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.operation.FindOperation
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the sort criteria to apply to the query.
getSort() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the sort criteria to apply to the query.
getSortDocument() - Method in class com.mongodb.client.model.PushOptions
Gets the sort direction for sorting array elements that are documents.
getSource() - Method in class com.mongodb.MongoCredential
Gets the source of the user name, typically the name of the database where the user is defined.
getSpecializedClassModel(ClassModel<S>, PropertyModel<V>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
getSpecializedPropertyModel(PropertyModel<V>, TypeParameterMap, List<TypeData<?>>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
getSphereVersion() - Method in class com.mongodb.bulk.IndexRequest
Gets the 2dsphere index version number.
getSphereVersion() - Method in class com.mongodb.client.model.IndexOptions
Gets the 2dsphere index version number.
getSslContext() - Method in class com.mongodb.connection.netty.NettyStream
 
getSslContext() - Method in class com.mongodb.connection.SocketStreamFactory
 
getSslContext() - Method in class com.mongodb.MongoClientOptions
Returns the SSLContext.
getSslEnabled() - Method in class com.mongodb.ConnectionString
Gets the SSL enabled value specified in the connection string.
getSslInvalidHostnameAllowed() - Method in class com.mongodb.ConnectionString
Gets the SSL invalidHostnameAllowed value specified in the connection string.
getSslSettings() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the SSL settings.
getSslSettings() - Method in class com.mongodb.connection.netty.NettyStream
 
getSslSettings() - Method in class com.mongodb.MongoClientOptions
 
getStalenessOfSecondaryRelativeToPrimary(ServerDescription, ServerDescription, long) - Method in class com.mongodb.TaggableReadPreference
 
getStartingFrom() - Method in class com.mongodb.connection.ReplyHeader
Returns the position in the cursor that is the start point of this reply.
getState() - Method in class com.mongodb.connection.ServerDescription
Gets the current state of the connection to the server.
getState() - Method in class org.bson.AbstractBsonReader
 
getState() - Method in class org.bson.AbstractBsonWriter
Gets the current state of this writer.
getStatistics(ConnectionId) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
getStatistics(ServerId) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
getStatistics() - Method in interface com.mongodb.operation.MapReduceAsyncBatchCursor
Get the statistics for this map-reduce operation
getStatistics() - Method in interface com.mongodb.operation.MapReduceBatchCursor
Get the statistics for this map-reduce operation
getStatistics() - Method in class com.mongodb.operation.MapReduceInlineResultsAsyncCursor
 
getStatistics() - Method in class com.mongodb.operation.MapReduceInlineResultsCursor
 
getStats() - Method in class com.mongodb.DB
Helper method for calling a 'dbStats' command.
getStats() - Method in class com.mongodb.DBCollection
The collStats command returns a variety of storage statistics for a given collection
getStorageEngine() - Method in class com.mongodb.bulk.IndexRequest
Gets the storage engine options document for this index.
getStorageEngine() - Method in class com.mongodb.client.model.IndexOptionDefaults
Gets the default storage engine options document for indexes.
getStorageEngine() - Method in class com.mongodb.client.model.IndexOptions
Gets the storage engine options document for this index.
getStorageEngineOptions() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets the storage engine options document for the collection.
getStorageEngineOptions() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the storage engine options document for this collection.
getStreamFactory(StreamFactoryFactory, SocketSettings, SslSettings, String) - Static method in class com.mongodb.async.client.MongoClients
 
getStreamFactoryFactory() - Method in class com.mongodb.async.client.MongoClientSettings
Gets the factory to use to create a StreamFactory.
getStreamType(String) - Static method in class com.mongodb.async.client.MongoClients
 
getStreamType() - Method in class com.mongodb.ConnectionString
Gets the stream type value specified in the connection string.
getStrength() - Method in class com.mongodb.client.model.Collation
Returns the collation strength
getStrict() - Static method in class com.mongodb.util.JSONSerializers
Deprecated.
Returns an ObjectSerializer that conforms to the strict JSON format defined in extended JSON.
getString(BsonDocument, String) - Static method in class com.mongodb.connection.DescriptionHelper
 
getString(String) - Method in class org.bson.BasicBSONObject
Returns the value of a field as a string
getString(String, String) - Method in class org.bson.BasicBSONObject
Returns the value of a field as a string
getString(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonString, or throws if not.
getString(Object, BsonString) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getString(Object) - Method in class org.bson.Document
Gets the value of the given key as a String.
getStringConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON String values to JSON.
getSubject() - Method in class com.mongodb.connection.SaslAuthenticator
 
getSymbol() - Method in class org.bson.BsonSymbol
Gets the symbol value
getSymbol() - Method in class org.bson.types.Symbol
Gets the symbol.
getSymbolConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Symbol values to JSON.
getTags(String) - Method in class com.mongodb.ConnectionString
 
getTagSet() - Method in class com.mongodb.connection.ServerDescription
A set of all tags assigned to this member.
getTagSetFromDocument(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getTagSetList() - Method in class com.mongodb.TaggableReadPreference
Gets the list of tag sets as a list of TagSet instances.
getter - Variable in class com.mongodb.ReflectionDBObject.FieldInfo
 
getter - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
getterMethods - Variable in class org.bson.codecs.pojo.PropertyReflectionUtils.PropertyMethods
 
getTextVersion() - Method in class com.mongodb.bulk.IndexRequest
The text index version number.
getTextVersion() - Method in class com.mongodb.client.model.IndexOptions
The text index version number.
getThreadsAllowedToBlockForConnectionMultiplier() - Method in class com.mongodb.ConnectionString
Gets the multiplier for the number of threads allowed to block waiting for a connection specified in the connection string.
getThreadsAllowedToBlockForConnectionMultiplier() - Method in class com.mongodb.MongoClientOptions
This multiplier, multiplied with the connectionsPerHost setting, gives the maximum number of threads that may be waiting for a connection to become available from the pool.
getThreadsAllowedToBlockForConnectionMultiplier() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the multiplier which, when multiplied with the connectionsPerHost setting, gives the maximum number of threads that may be waiting for a connection to become available from the pool.
getThrowable() - Method in class com.mongodb.event.CommandFailedEvent
Gets the throwable cause of the failure
getThrowable() - Method in class com.mongodb.event.ServerHeartbeatFailedEvent
Gets the exceptions that caused the failure
getTime() - Method in class org.bson.BsonTimestamp
Gets the time in seconds since epoch.
getTime() - Method in class org.bson.types.BSONTimestamp
Gets the time in seconds since epoch
getTime() - Method in class org.bson.types.ObjectId
Deprecated.
Use #getDate instead
getTimeSecond() - Method in class org.bson.types.ObjectId
Deprecated.
Use #getTimestamp instead
getTimestamp(Object) - Method in class org.bson.BsonDocument
Gets the value of the key if it is a BsonTimestamp, or throws if not.
getTimestamp(Object, BsonTimestamp) - Method in class org.bson.BsonDocument
If the document does not contain the given key, return the given default value.
getTimestamp() - Method in class org.bson.types.ObjectId
Gets the timestamp (number of seconds since the Unix epoch).
getTimestampConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Timestamp values to JSON.
getTransactionNumber() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
getType() - Method in class com.mongodb.bulk.DeleteRequest
 
getType() - Method in class com.mongodb.bulk.InsertRequest
 
getType() - Method in class com.mongodb.bulk.UpdateRequest
 
getType() - Method in class com.mongodb.bulk.WriteRequest
Gets the type of the write.
getType(Object) - Static method in class com.mongodb.Bytes
Gets the type byte for a given object.
getType() - Method in class com.mongodb.client.model.geojson.CoordinateReferenceSystem
Gets the type of this Coordinate Reference System.
getType() - Method in class com.mongodb.client.model.geojson.Geometry
Gets the GeoJSON object type.
getType() - Method in class com.mongodb.client.model.geojson.GeometryCollection
 
getType() - Method in class com.mongodb.client.model.geojson.LineString
 
getType() - Method in class com.mongodb.client.model.geojson.MultiLineString
 
getType() - Method in class com.mongodb.client.model.geojson.MultiPoint
 
getType() - Method in class com.mongodb.client.model.geojson.MultiPolygon
 
getType() - Method in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
 
getType() - Method in class com.mongodb.client.model.geojson.Point
 
getType() - Method in class com.mongodb.client.model.geojson.Polygon
 
getType() - Method in class com.mongodb.connection.ClusterDescription
Gets the specific type of this cluster
getType() - Method in class com.mongodb.connection.ServerDescription
Gets the type of the server, for example whether it's a standalone or in a replica set.
getType() - Method in class com.mongodb.operation.BaseWriteOperation
 
getType() - Method in class com.mongodb.operation.BulkWriteBatch.WriteRequestWithIndex
 
getType() - Method in class com.mongodb.operation.DeleteOperation
 
getType() - Method in class com.mongodb.operation.InsertOperation
 
getType() - Method in class com.mongodb.operation.UpdateOperation
 
getType() - Method in class org.bson.BsonBinary
Gets the type of this Binary.
getType() - Method in class org.bson.codecs.pojo.ClassModel
 
getType() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
getType() - Method in class org.bson.codecs.pojo.CreatorExecutable
 
getType() - Method in class org.bson.codecs.pojo.TypeData
 
getType() - Method in interface org.bson.codecs.pojo.TypeWithTypeParameters
 
getType() - Method in class org.bson.json.JsonToken
 
getType() - Method in class org.bson.types.Binary
Get the binary sub type as a byte.
getTypeData() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getTypeData() - Method in class org.bson.codecs.pojo.PropertyModel
 
getTypeData() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
getTypeName() - Method in enum com.mongodb.client.model.geojson.CoordinateReferenceSystemType
Gets the GeoJSON-defined name for the type.
getTypeName() - Method in enum com.mongodb.client.model.geojson.GeoJsonObjectType
Gets the GeoJSON-defined name for the object type.
getTypeParameterMap(List<String>, Type) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
getTypeParameterMap() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getTypeParameters() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getTypeParameters() - Method in class org.bson.codecs.pojo.TypeData
 
getTypeParameters() - Method in interface org.bson.codecs.pojo.TypeWithTypeParameters
 
getUnacknowledgedWriteException() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
getUnacknowledgedWriteException() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
getUncompressedSize() - Method in class com.mongodb.connection.CompressedHeader
 
getUncompressedSize(List<ByteBuf>) - Method in class com.mongodb.connection.SnappyCompressor
 
getUndefinedConverter() - Method in class org.bson.json.JsonWriterSettings
A converter from BSON Undefined values to JSON.
getUnwrapped() - Method in class org.bson.BsonDocumentWrapper
 
getUpdate() - Method in class com.mongodb.bulk.UpdateRequest
Gets the update.
getUpdate() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the update
getUpdate() - Method in class com.mongodb.client.model.UpdateManyModel
Gets the document specifying the updates to apply to the matching document.
getUpdate() - Method in class com.mongodb.client.model.UpdateOneModel
Gets the document specifying the updates to apply to the matching document.
getUpdate() - Method in class com.mongodb.operation.FindAndUpdateOperation
Gets the document containing update operators
getUpdate() - Method in class com.mongodb.UpdateRequest
 
getUpdateDescription() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
Returns the updateDescription
getUpdatedExisting(BulkWriteResult) - Method in class com.mongodb.operation.BaseWriteOperation
 
getUpdatedFields() - Method in class com.mongodb.client.model.changestream.UpdateDescription
Returns the updatedFields
getUpdateRequests() - Method in class com.mongodb.operation.UpdateOperation
Gets the list of update requests.
getUploadDate() - Method in class com.mongodb.client.gridfs.model.GridFSFile
The date and time this file was added to GridFS
getUploadDate() - Method in class com.mongodb.gridfs.GridFSFile
Gets the upload date.
getUpsertedId(BulkWriteUpsert, Decoder<DBObject>) - Static method in class com.mongodb.BulkWriteHelper
 
getUpsertedId() - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
getUpsertedId() - Method in class com.mongodb.client.result.UpdateResult
If the replace resulted in an inserted document, gets the _id of the inserted document, otherwise null.
getUpsertedId() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
getUpsertedId() - Method in class com.mongodb.WriteConcernResult
Returns the value of _id if this write resulted in an upsert.
getUpsertedId() - Method in class com.mongodb.WriteResult
Gets the _id value of an upserted document that resulted from this write.
getUpsertedItems(BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
getUpsertedItems(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
getUpserts() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
getUpserts() - Method in class com.mongodb.bulk.BulkWriteResult
Gets an unmodifiable list of upserted items, or the empty list if there were none.
getUpserts() - Method in class com.mongodb.BulkWriteResult
Gets an unmodifiable list of upserted items, or the empty list if there were none.
getUpserts() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
getURI() - Method in class com.mongodb.ConnectionString
Deprecated.
getURI() - Method in class com.mongodb.MongoClientURI
Get the unparsed URI.
getUseCursor() - Method in class com.mongodb.operation.AggregateOperation
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
getUsedDatabases() - Method in class com.mongodb.Mongo
Returns the list of databases used by the driver since this Mongo instance was created.
getUsername() - Method in class com.mongodb.ConnectionString
Gets the username
getUsername() - Method in class com.mongodb.MongoClientURI
Gets the username
getUserName() - Method in class com.mongodb.MongoCredential
Gets the user name
getUsername() - Method in class com.mongodb.MongoURI
Deprecated.
Gets the username.
getValidationAction() - Method in class com.mongodb.client.model.ValidationOptions
getValidationAction() - Method in class com.mongodb.operation.CreateCollectionOperation
getValidationLevel() - Method in class com.mongodb.client.model.ValidationOptions
Gets the ValidationLevel that determines how strictly MongoDB applies the validation rules to existing documents during an insert or update.
getValidationLevel() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the ValidationLevel that determines how strictly MongoDB applies the validation rules to existing documents during an insert or update.
getValidationOptions() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets the validation options for documents being inserted or updated in a collection
getValidator() - Method in class com.mongodb.client.model.ValidationOptions
Gets the validation rules if set or null.
getValidator() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the validation rules for inserting or updating documents
getValidatorForField(String) - Method in class com.mongodb.internal.validator.CollectibleDocumentFieldNameValidator
 
getValidatorForField(String) - Method in class com.mongodb.internal.validator.MappedFieldNameValidator
 
getValidatorForField(String) - Method in class com.mongodb.internal.validator.NoOpFieldNameValidator
 
getValidatorForField(String) - Method in class com.mongodb.internal.validator.UpdateFieldNameValidator
 
getValidatorForField(String) - Method in interface org.bson.FieldNameValidator
Gets a new validator to use for the value of the field with the given name.
getValidatorForField(String) - Method in class org.bson.NoOpFieldNameValidator
 
getValue() - Method in class com.mongodb.client.model.BsonField
Gets the field value
getValue() - Method in enum com.mongodb.client.model.BucketGranularity
Returns the display as defined in the preferred number article
getValue() - Method in enum com.mongodb.client.model.changestream.FullDocument
 
getValue() - Method in enum com.mongodb.client.model.changestream.OperationType
 
getValue() - Method in enum com.mongodb.client.model.CollationAlternate
 
getValue() - Method in enum com.mongodb.client.model.CollationCaseFirst
 
getValue() - Method in enum com.mongodb.client.model.CollationMaxVariable
 
getValue() - Method in class com.mongodb.client.model.Field
 
getValue() - Method in enum com.mongodb.client.model.MapReduceAction
 
getValue() - Method in enum com.mongodb.client.model.ValidationAction
 
getValue() - Method in enum com.mongodb.client.model.ValidationLevel
 
getValue() - Method in class com.mongodb.connection.ClusterId
Gets the value of the identifier.
getValue() - Method in enum com.mongodb.connection.OpCode
 
getValue() - Method in enum com.mongodb.ReadConcernLevel
 
getValue() - Method in class com.mongodb.Tag
Gets the value of the replica set tag.
getValue() - Method in enum org.bson.BsonBinarySubType
Gets the byte representation of this subtype.
getValue() - Method in class org.bson.BsonBoolean
Gets the boolean value.
getValue() - Method in class org.bson.BsonDateTime
Gets the DateTime value as a long
getValue() - Method in class org.bson.BsonDecimal128
Gets the Decimal128 value.
getValue() - Method in class org.bson.BsonDouble
Gets the double value.
getValue() - Method in class org.bson.BsonElement
Gets the value of this element.
getValue() - Method in class org.bson.BsonInt32
Gets the integer value.
getValue() - Method in class org.bson.BsonInt64
Gets the long value.
getValue() - Method in class org.bson.BsonObjectId
Get the ObjectId value.
getValue() - Method in class org.bson.BsonString
Gets the String value.
getValue() - Method in class org.bson.BsonTimestamp
Gets the value of the timestamp.
getValue() - Method in enum org.bson.BsonType
Get the int value of this BSON type.
getValue() - Method in class org.bson.json.JsonToken
 
getValue(Class<T>) - Method in class org.bson.json.JsonToken
 
getValues() - Method in class com.mongodb.client.model.geojson.Position
Gets the values of this position
getValues() - Method in class com.mongodb.operation.BsonArrayWrapper
 
getValues() - Method in class org.bson.BsonArray
Gets the values in this array as a list of BsonValue objects.
getVerbosityAsString(ExplainVerbosity) - Static method in class com.mongodb.operation.ExplainHelper
 
getVersion() - Method in class com.mongodb.bulk.IndexRequest
Gets the index version number.
getVersion() - Method in class com.mongodb.client.model.IndexOptions
Gets the index version number.
getVersion(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
getVersion() - Method in class com.mongodb.connection.ServerDescription
Gets the server version
getVersionList() - Method in class com.mongodb.connection.ServerVersion
Gets the version list.
getViewName() - Method in class com.mongodb.operation.CreateViewOperation
Gets the name of the view to create.
getViewOn() - Method in class com.mongodb.operation.CreateViewOperation
Gets the name of the collection or view that backs this view.
getW() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the "w" value, (number of writes), of the global WriteConcern.
getW() - Method in class com.mongodb.WriteConcern
Gets the w value as an integer.
getWaitQueueSize() - Method in class com.mongodb.management.ConnectionPoolStatistics
 
getWaitQueueSize() - Method in interface com.mongodb.management.ConnectionPoolStatisticsMBean
Gets the size of the wait queue for a connection from this pool.
getWeights() - Method in class com.mongodb.bulk.IndexRequest
Gets the weighting object for use with a text index
getWeights() - Method in class com.mongodb.client.model.IndexOptions
Gets the weighting object for use with a text index
getWObject() - Method in class com.mongodb.WriteConcern
Gets the w value.
getWorkerGroup() - Method in class com.mongodb.connection.netty.NettyStream
 
getWrapped() - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
getWrapped() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
getWrapped() - Method in class org.bson.codecs.configuration.LazyCodec
 
getWrappedArray() - Method in class com.mongodb.operation.BsonArrayWrapper
Get the wrapped array.
getWrappedDocument() - Method in class org.bson.BsonDocumentWrapper
Get the wrapped document.
getWrappedMessageRequestId(List<ByteBuf>) - Static method in class com.mongodb.connection.CompressedMessage
 
getWrappedMessageSize(List<ByteBuf>) - Static method in class com.mongodb.connection.CompressedMessage
 
getWrapper() - Method in class com.mongodb.ReflectionDBObject
 
getWrapper(Class) - Static method in class com.mongodb.ReflectionDBObject
Returns an existing Wrapper instance associated with a class, or creates a new one.
getWrapperIfReflectionObject(Class) - Static method in class com.mongodb.ReflectionDBObject
Returns the wrapper if this object can be assigned from this class.
getWrite() - Method in class com.mongodb.connection.FutureAsyncCompletionHandler
 
getWriteAnnotations() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
getWriteAnnotations() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Returns the write annotations, to be applied when deserializing from BSON
getWriteConcern() - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Get the write concern for the GridFSBucket.
getWriteConcern() - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
getWriteConcern() - Method in class com.mongodb.async.client.MongoClientSettings
The write concern to use.
getWriteConcern() - Method in interface com.mongodb.async.client.MongoCollection
Get the write concern for the MongoCollection.
getWriteConcern() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
getWriteConcern() - Method in interface com.mongodb.async.client.MongoDatabase
Get the write concern for the MongoDatabase.
getWriteConcern() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
getWriteConcern() - Method in interface com.mongodb.client.gridfs.GridFSBucket
Get the write concern for the GridFSBucket.
getWriteConcern() - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
getWriteConcern() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the writeConcern
getWriteConcern() - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
The write concern to use for the insertion.
getWriteConcern() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
The write concern to use for the insertion.
getWriteConcern() - Method in interface com.mongodb.client.MongoCollection
Get the write concern for the MongoCollection.
getWriteConcern() - Method in interface com.mongodb.client.MongoDatabase
Get the write concern for the MongoDatabase.
getWriteConcern() - Method in class com.mongodb.ConnectionString
Gets the write concern specified in the connection string.
getWriteConcern() - Method in class com.mongodb.DB
Gets the write concern for this database.
getWriteConcern() - Method in class com.mongodb.DBCollection
Get the WriteConcern for this collection.
getWriteConcern() - Method in class com.mongodb.InsertOptions
The write concern to use for the insertion.
getWriteConcern() - Method in class com.mongodb.Mongo
Gets the write concern
getWriteConcern() - Method in class com.mongodb.MongoClientOptions
The write concern to use.
getWriteConcern() - Method in class com.mongodb.MongoCollectionImpl
 
getWriteConcern() - Method in class com.mongodb.MongoDatabaseImpl
 
getWriteConcern() - Method in class com.mongodb.MongoOptions
Deprecated.
Helper method to return the appropriate WriteConcern instance based on the current related options settings.
getWriteConcern() - Method in class com.mongodb.operation.AggregateToCollectionOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.BaseWriteOperation
Gets the write concern to apply
getWriteConcern() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.CreateIndexesOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.CreateViewOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.DropCollectionOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.DropDatabaseOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.DropIndexOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.FindAndDeleteOperation
Get the write concern for this operation
getWriteConcern() - Method in class com.mongodb.operation.FindAndReplaceOperation
Get the write concern for this operation
getWriteConcern() - Method in class com.mongodb.operation.FindAndUpdateOperation
Get the write concern for this operation
getWriteConcern() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the write concern.
getWriteConcern() - Method in class com.mongodb.operation.MixedBulkWriteOperation
Gets the write concern to apply
getWriteConcern() - Method in class com.mongodb.operation.RenameCollectionOperation
Gets the write concern.
getWriteConcernError() - Method in exception com.mongodb.BulkWriteException
The write concern error, which may be null (in which case the list of errors will not be empty).
getWriteConcernError(BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
getWriteConcernError() - Method in exception com.mongodb.MongoBulkWriteException
The write concern error, which may be null (in which case the list of errors will not be empty).
getWriteConcernError() - Method in exception com.mongodb.MongoWriteConcernException
Gets the write concern error.
getWriteConcernError(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
getWriteConcernResult() - Method in exception com.mongodb.WriteConcernException
Gets the write result.
getWriteConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in class com.mongodb.async.client.ClientSessionBinding
 
getWriteConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in class com.mongodb.binding.AsyncClusterBinding
 
getWriteConnectionSource(SingleResultCallback<AsyncConnectionSource>) - Method in interface com.mongodb.binding.AsyncWriteBinding
Supply a connection source to a server that can be written to
getWriteConnectionSource() - Method in class com.mongodb.binding.ClusterBinding
 
getWriteConnectionSource() - Method in class com.mongodb.binding.SingleServerBinding
 
getWriteConnectionSource() - Method in interface com.mongodb.binding.WriteBinding
Supply a connection source to a server that can be written to
getWriteConnectionSource() - Method in class com.mongodb.ClientSessionBinding
 
getWriteErrors() - Method in exception com.mongodb.BulkWriteException
The list of errors, which will not be null, but may be empty (if the write concern error is not null).
getWriteErrors(BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
getWriteErrors() - Method in exception com.mongodb.MongoBulkWriteException
The list of errors, which will not be null, but may be empty (if the write concern error is not null).
getWriteErrors(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
getWriteName() - Method in class org.bson.codecs.pojo.PropertyModel
 
getWriteName() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
getWriter() - Method in class org.bson.json.JsonWriter
Gets the Writer.
getWriter() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
getWriteRequests() - Method in class com.mongodb.operation.BaseWriteOperation
 
getWriteRequests() - Method in class com.mongodb.operation.DeleteOperation
 
getWriteRequests() - Method in class com.mongodb.operation.InsertOperation
 
getWriteRequests() - Method in class com.mongodb.operation.MixedBulkWriteOperation
Gets the list of write requests to execute.
getWriteRequests() - Method in class com.mongodb.operation.UpdateOperation
 
getWriteResult() - Method in exception com.mongodb.BulkWriteException
The result of all successfully processed write operations.
getWriteResult(BsonDocument, ServerAddress) - Static method in class com.mongodb.connection.ProtocolHelper
 
getWriteResult() - Method in exception com.mongodb.MongoBulkWriteException
The result of all successfully processed write operations.
getWriteResult() - Method in exception com.mongodb.MongoWriteConcernException
Gets the write result.
getWString() - Method in class com.mongodb.WriteConcern
Gets the w parameter as a String.
getWtimeout() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the "wtimeout" value of the global WriteConcern.
getWTimeout(TimeUnit) - Method in class com.mongodb.WriteConcern
Gets the wTimeout in the given time unit.
getWtimeout() - Method in class com.mongodb.WriteConcern
GLOBAL_FLAG - Static variable in class org.bson.codecs.PatternCodec
 
gotBinary(String, byte, byte[]) - Method in class org.bson.BasicBSONCallback
 
gotBinary(String, byte, byte[]) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.BINARY value.
gotBinary(String, byte, byte[]) - Method in class org.bson.EmptyBSONCallback
 
gotBinary(String, byte, byte[]) - Method in class org.bson.LazyBSONCallback
 
gotBinaryArray(String, byte[]) - Method in class org.bson.BasicBSONCallback
Deprecated.
gotBinaryArray(String, byte[]) - Method in interface org.bson.BSONCallback
Deprecated. 
gotBinaryArray(String, byte[]) - Method in class org.bson.EmptyBSONCallback
Deprecated.
gotBoolean(String, boolean) - Method in class org.bson.BasicBSONCallback
 
gotBoolean(String, boolean) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.BOOLEAN value.
gotBoolean(String, boolean) - Method in class org.bson.EmptyBSONCallback
 
gotCode(String, String) - Method in class org.bson.BasicBSONCallback
 
gotCode(String, String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.JAVASCRIPT value.
gotCode(String, String) - Method in class org.bson.EmptyBSONCallback
 
gotCodeWScope(String, String, Object) - Method in class org.bson.BasicBSONCallback
 
gotCodeWScope(String, String, Object) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.JAVASCRIPT_WITH_SCOPE value.
gotCodeWScope(String, String, Object) - Method in class org.bson.EmptyBSONCallback
 
gotDate(String, long) - Method in class org.bson.BasicBSONCallback
 
gotDate(String, long) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.DATE_TIME value.
gotDate(String, long) - Method in class org.bson.EmptyBSONCallback
 
gotDBRef(String, String, ObjectId) - Method in class com.mongodb.DefaultDBCallback
 
gotDBRef(String, String, ObjectId) - Method in class org.bson.BasicBSONCallback
 
gotDBRef(String, String, ObjectId) - Method in interface org.bson.BSONCallback
Invoked when BSONDecoder encountered a BsonType.DB_POINTER type field in a byte sequence.
gotDBRef(String, String, ObjectId) - Method in class org.bson.EmptyBSONCallback
 
gotDecimal128(String, Decimal128) - Method in class org.bson.BasicBSONCallback
 
gotDecimal128(String, Decimal128) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.DECIMAL128 value.
gotDecimal128(String, Decimal128) - Method in class org.bson.EmptyBSONCallback
 
gotDouble(String, double) - Method in class org.bson.BasicBSONCallback
 
gotDouble(String, double) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.DOUBLE value.
gotDouble(String, double) - Method in class org.bson.EmptyBSONCallback
 
gotInt(String, int) - Method in class org.bson.BasicBSONCallback
 
gotInt(String, int) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.INT32 value.
gotInt(String, int) - Method in class org.bson.EmptyBSONCallback
 
gotLong(String, long) - Method in class org.bson.BasicBSONCallback
 
gotLong(String, long) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.INT64 value.
gotLong(String, long) - Method in class org.bson.EmptyBSONCallback
 
gotMaxKey(String) - Method in class org.bson.BasicBSONCallback
 
gotMaxKey(String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.MAX_KEY value.
gotMaxKey(String) - Method in class org.bson.EmptyBSONCallback
 
gotMinKey(String) - Method in class org.bson.BasicBSONCallback
 
gotMinKey(String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.MIN_KEY value.
gotMinKey(String) - Method in class org.bson.EmptyBSONCallback
 
gotNull(String) - Method in class org.bson.BasicBSONCallback
 
gotNull(String) - Method in interface org.bson.BSONCallback
Called when reading a BSON field that exists but has a null value.
gotNull(String) - Method in class org.bson.EmptyBSONCallback
 
gotObjectId(String, ObjectId) - Method in class org.bson.BasicBSONCallback
 
gotObjectId(String, ObjectId) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.OBJECT_ID value.
gotObjectId(String, ObjectId) - Method in class org.bson.EmptyBSONCallback
 
gotRegex(String, String, String) - Method in class org.bson.BasicBSONCallback
 
gotRegex(String, String, String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.REGULAR_EXPRESSION value.
gotRegex(String, String, String) - Method in class org.bson.EmptyBSONCallback
 
gotString(String, String) - Method in class org.bson.BasicBSONCallback
 
gotString(String, String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.STRING value.
gotString(String, String) - Method in class org.bson.EmptyBSONCallback
 
gotSymbol(String, String) - Method in class org.bson.BasicBSONCallback
 
gotSymbol(String, String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.SYMBOL value.
gotSymbol(String, String) - Method in class org.bson.EmptyBSONCallback
 
gotTimestamp(String, int, int) - Method in class org.bson.BasicBSONCallback
 
gotTimestamp(String, int, int) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.TIMESTAMP value.
gotTimestamp(String, int, int) - Method in class org.bson.EmptyBSONCallback
 
gotUndefined(String) - Method in class org.bson.BasicBSONCallback
 
gotUndefined(String) - Method in interface org.bson.BSONCallback
Called when reading a field with a BsonType.UNDEFINED value.
gotUndefined(String) - Method in class org.bson.EmptyBSONCallback
 
gotUUID(String, long, long) - Method in class org.bson.BasicBSONCallback
 
gotUUID(String, long, long) - Method in interface org.bson.BSONCallback
Called when reading a field with a UUID value.
gotUUID(String, long, long) - Method in class org.bson.EmptyBSONCallback
 
granularity - Variable in class com.mongodb.client.model.BucketAutoOptions
 
granularity(BucketGranularity) - Method in class com.mongodb.client.model.BucketAutoOptions
Specifies the granularity of the bucket definitions.
graphLookup(String, TExpression, String, String, String) - Static method in class com.mongodb.client.model.Aggregates
Creates a graphLookup pipeline stage for the specified filter
graphLookup(String, TExpression, String, String, String, GraphLookupOptions) - Static method in class com.mongodb.client.model.Aggregates
Creates a graphLookup pipeline stage for the specified filter
GraphLookupOptions - Class in com.mongodb.client.model
The options for a graphLookup aggregation pipeline stage
GraphLookupOptions() - Constructor for class com.mongodb.client.model.GraphLookupOptions
 
GraphLookupStage(String, TExpression, String, String, String, GraphLookupOptions) - Constructor for class com.mongodb.client.model.Aggregates.GraphLookupStage
 
greaterOf(BsonDocument) - Method in class com.mongodb.connection.ClusterClock
 
greaterOf(BsonDocument) - Method in class com.mongodb.internal.session.ClientSessionImpl
 
greaterOf(BsonTimestamp) - Method in class com.mongodb.internal.session.ClientSessionImpl
 
greaterThan(Object) - Method in class com.mongodb.QueryBuilder
Equivalent to the $gt operator
greaterThanEquals(Object) - Method in class com.mongodb.QueryBuilder
Equivalent to the $gte operator
gridFS - Static variable in class com.mongodb.gridfs.CLI
 
GridFS - Class in com.mongodb.gridfs
Implementation of GridFS - a specification for storing and retrieving files that exceed the BSON-document size limit of 16MB.
GridFS(DB) - Constructor for class com.mongodb.gridfs.GridFS
Creates a GridFS instance for the default bucket "fs" in the given database.
GridFS(DB, String) - Constructor for class com.mongodb.gridfs.GridFS
Creates a GridFS instance for the specified bucket in the given database.
GridFSBucket - Interface in com.mongodb.async.client.gridfs
Represents a GridFS Bucket
GridFSBucket - Interface in com.mongodb.client.gridfs
Represents a GridFS Bucket
GridFSBucketImpl - Class in com.mongodb.async.client.gridfs
 
GridFSBucketImpl(MongoDatabase) - Constructor for class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
GridFSBucketImpl(MongoDatabase, String) - Constructor for class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
GridFSBucketImpl(String, int, MongoCollection<GridFSFile>, MongoCollection<Document>) - Constructor for class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
GridFSBucketImpl - Class in com.mongodb.client.gridfs
 
GridFSBucketImpl(MongoDatabase) - Constructor for class com.mongodb.client.gridfs.GridFSBucketImpl
 
GridFSBucketImpl(MongoDatabase, String) - Constructor for class com.mongodb.client.gridfs.GridFSBucketImpl
 
GridFSBucketImpl(String, int, MongoCollection<GridFSFile>, MongoCollection<Document>) - Constructor for class com.mongodb.client.gridfs.GridFSBucketImpl
 
GridFSBuckets - Class in com.mongodb.async.client.gridfs
A factory for GridFSBucket instances.
GridFSBuckets() - Constructor for class com.mongodb.async.client.gridfs.GridFSBuckets
 
GridFSBuckets - Class in com.mongodb.client.gridfs
A factory for GridFSBucket instances.
GridFSBuckets() - Constructor for class com.mongodb.client.gridfs.GridFSBuckets
 
GridFSDBFile - Class in com.mongodb.gridfs
This class enables retrieving a GridFS file metadata and content.
GridFSDBFile() - Constructor for class com.mongodb.gridfs.GridFSDBFile
 
GridFSDBFile.GridFSInputStream - Class in com.mongodb.gridfs
 
GridFSDownloadByNameOptions - Class in com.mongodb.client.gridfs.model
Deprecated.
GridFSDownloadByNameOptions() - Constructor for class com.mongodb.client.gridfs.model.GridFSDownloadByNameOptions
Deprecated.
Download the most recent version of the file.
GridFSDownloadOptions - Class in com.mongodb.client.gridfs.model
The GridFS download by name options
GridFSDownloadOptions() - Constructor for class com.mongodb.client.gridfs.model.GridFSDownloadOptions
Download the most recent version of the file.
GridFSDownloadStream - Interface in com.mongodb.async.client.gridfs
A GridFS InputStream for downloading data from GridFS
GridFSDownloadStream - Class in com.mongodb.client.gridfs
A GridFS InputStream for downloading data from GridFS
GridFSDownloadStream() - Constructor for class com.mongodb.client.gridfs.GridFSDownloadStream
 
GridFSDownloadStreamImpl - Class in com.mongodb.async.client.gridfs
 
GridFSDownloadStreamImpl(ClientSession, GridFSFindIterable, MongoCollection<Document>) - Constructor for class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
GridFSDownloadStreamImpl - Class in com.mongodb.client.gridfs
 
GridFSDownloadStreamImpl(ClientSession, GridFSFile, MongoCollection<Document>) - Constructor for class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
GridFSFile - Class in com.mongodb.client.gridfs.model
The GridFSFile
GridFSFile(BsonValue, String, long, int, Date, String, Document) - Constructor for class com.mongodb.client.gridfs.model.GridFSFile
Creates a new GridFSFile
GridFSFile(BsonValue, String, long, int, Date, String, Document, Document) - Constructor for class com.mongodb.client.gridfs.model.GridFSFile
Creates a legacy implementation of the GridFSFile
GridFSFile - Class in com.mongodb.gridfs
The abstract class representing a GridFS file.
GridFSFile() - Constructor for class com.mongodb.gridfs.GridFSFile
 
GridFSFileCodec - Class in com.mongodb.client.gridfs.codecs
A codec for GridFS Files
GridFSFileCodec(CodecRegistry) - Constructor for class com.mongodb.client.gridfs.codecs.GridFSFileCodec
Create a new instance
GridFSFileCodecProvider - Class in com.mongodb.client.gridfs.codecs
A provider of codecs for GridFSFiles.
GridFSFileCodecProvider() - Constructor for class com.mongodb.client.gridfs.codecs.GridFSFileCodecProvider
 
GridFSFindIterable - Interface in com.mongodb.async.client.gridfs
Iterable for the GridFS Files Collection.
GridFSFindIterable - Interface in com.mongodb.client.gridfs
Iterable for the GridFS Files Collection.
GridFSFindIterableImpl - Class in com.mongodb.async.client.gridfs
 
GridFSFindIterableImpl(FindIterable<GridFSFile>) - Constructor for class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
GridFSFindIterableImpl - Class in com.mongodb.client.gridfs
 
GridFSFindIterableImpl(FindIterable<GridFSFile>) - Constructor for class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
GridFSIndexCheck - Interface in com.mongodb.async.client.gridfs
 
GridFSIndexCheckImpl - Class in com.mongodb.async.client.gridfs
 
GridFSIndexCheckImpl(ClientSession, MongoCollection<GridFSFile>, MongoCollection<Document>) - Constructor for class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
GridFSInputFile - Class in com.mongodb.gridfs
This class represents a GridFS file to be written to the database.
GridFSInputFile(GridFS, InputStream, String, boolean) - Constructor for class com.mongodb.gridfs.GridFSInputFile
Default constructor setting the GridFS file name and providing an input stream containing data to be written to the file.
GridFSInputFile(GridFS, InputStream, String) - Constructor for class com.mongodb.gridfs.GridFSInputFile
Default constructor setting the GridFS file name and providing an input stream containing data to be written to the file.
GridFSInputFile(GridFS, String) - Constructor for class com.mongodb.gridfs.GridFSInputFile
Constructor that only provides a file name, but does not rely on the presence of an InputStream.
GridFSInputFile(GridFS) - Constructor for class com.mongodb.gridfs.GridFSInputFile
Minimal constructor that does not rely on the presence of an InputStream.
GridFSInputFile.GridFSOutputStream - Class in com.mongodb.gridfs
An output stream implementation that can be used to successively write to a GridFS file.
GridFSInputStream() - Constructor for class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
GridFSOutputStream() - Constructor for class com.mongodb.gridfs.GridFSInputFile.GridFSOutputStream
 
GridFSUploadOptions - Class in com.mongodb.client.gridfs.model
GridFS upload options Customizable options used when uploading files into GridFS
GridFSUploadOptions() - Constructor for class com.mongodb.client.gridfs.model.GridFSUploadOptions
Construct a new instance.
GridFSUploadStream - Interface in com.mongodb.async.client.gridfs
A GridFS OutputStream for uploading data into GridFS
GridFSUploadStream - Class in com.mongodb.client.gridfs
A GridFS OutputStream for uploading data into GridFS
GridFSUploadStream() - Constructor for class com.mongodb.client.gridfs.GridFSUploadStream
 
GridFSUploadStreamImpl - Class in com.mongodb.async.client.gridfs
 
GridFSUploadStreamImpl(ClientSession, MongoCollection<GridFSFile>, MongoCollection<Document>, BsonValue, String, int, Document, GridFSIndexCheck) - Constructor for class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
GridFSUploadStreamImpl - Class in com.mongodb.client.gridfs
 
GridFSUploadStreamImpl(ClientSession, MongoCollection<GridFSFile>, MongoCollection<Document>, BsonValue, String, int, Document) - Constructor for class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
group(TExpression, BsonField...) - Static method in class com.mongodb.client.model.Aggregates
Creates a $group pipeline stage for the specified filter
group(TExpression, List<BsonField>) - Static method in class com.mongodb.client.model.Aggregates
Creates a $group pipeline stage for the specified filter
group - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream
 
group - Variable in class com.mongodb.connection.AsynchronousSocketChannelStreamFactory
 
group - Variable in class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory.Builder
 
group(AsynchronousChannelGroup) - Method in class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory.Builder
Sets the AsynchronousChannelGroup
group - Variable in class com.mongodb.connection.AsynchronousSocketChannelStreamFactoryFactory
 
group(DBObject, DBObject, DBObject, String) - Method in class com.mongodb.DBCollection
Group documents in a collection by the specified key and performs simple aggregation functions such as computing counts and sums.
group(DBObject, DBObject, DBObject, String, String) - Method in class com.mongodb.DBCollection
Group documents in a collection by the specified key and performs simple aggregation functions such as computing counts and sums.
group(DBObject, DBObject, DBObject, String, String, ReadPreference) - Method in class com.mongodb.DBCollection
Group documents in a collection by the specified key and performs simple aggregation functions such as computing counts and sums.
group(GroupCommand) - Method in class com.mongodb.DBCollection
Group documents in a collection by the specified key and performs simple aggregation functions such as computing counts and sums.
group(GroupCommand, ReadPreference) - Method in class com.mongodb.DBCollection
Group documents in a collection by the specified key and performs simple aggregation functions such as computing counts and sums.
groupBy - Variable in class com.mongodb.client.model.Aggregates.BucketAutoStage
 
groupBy - Variable in class com.mongodb.client.model.Aggregates.BucketStage
 
GroupCommand - Class in com.mongodb
This class groups the argument for a group operation and can build the underlying command object
GroupCommand(DBCollection, DBObject, DBObject, DBObject, String, String) - Constructor for class com.mongodb.GroupCommand
Creates a new group command.
GroupCommand(DBCollection, DBObject, DBObject, DBObject, String, String, Collation) - Constructor for class com.mongodb.GroupCommand
Creates a new group command.
GroupCommand(DBCollection, String, DBObject, DBObject, String, String) - Constructor for class com.mongodb.GroupCommand
Creates a new group command.
GroupCommand(DBCollection, String, DBObject, DBObject, String, String, Collation) - Constructor for class com.mongodb.GroupCommand
Creates a new group command.
GroupOperation<T> - Class in com.mongodb.operation
Groups documents in a collection by the specified key and performs simple aggregation functions, such as computing counts and sums.
GroupOperation(MongoNamespace, BsonJavaScript, BsonDocument, Decoder<T>) - Constructor for class com.mongodb.operation.GroupOperation
Create an operation that will perform a Group on a given collection.
GroupStage(TExpression, List<BsonField>) - Constructor for class com.mongodb.client.model.Aggregates.GroupStage
 
GS2_HEADER - Static variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
GSSAPI_MECHANISM - Static variable in class com.mongodb.MongoCredential
The GSSAPI mechanism.
GSSAPI_MECHANISM_NAME - Static variable in class com.mongodb.connection.GSSAPIAuthenticator
 
GSSAPI_OID - Static variable in class com.mongodb.connection.GSSAPIAuthenticator
 
GSSAPIAuthenticator - Class in com.mongodb.connection
 
GSSAPIAuthenticator(MongoCredential) - Constructor for class com.mongodb.connection.GSSAPIAuthenticator
 
gt(String, TItem) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the given field is greater than the specified value.
GT - Static variable in class com.mongodb.QueryOperators
 
gte(String, TItem) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the given field is greater than or equal to the specified value.
GTE - Static variable in class com.mongodb.QueryOperators
 

H

h(byte[]) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
handleGetMoreQueryResult(AsyncConnection, SingleResultCallback<List<T>>, QueryResult<T>, boolean) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
handler - Variable in class com.mongodb.connection.netty.NettyStream.PendingReader
 
handleReadResponse(ByteBuf, Throwable) - Method in class com.mongodb.connection.netty.NettyStream
 
handleReplicaSetMemberChanged(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
handlerReference - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream.BaseCompletionHandler
 
handleServerSelectionRequest(BaseCluster.ServerSelectionRequest, CountDownLatch, ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
handleShardRouterChanged(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
handleStandAloneChanged(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
handleThrowable(Throwable) - Method in class com.mongodb.connection.DefaultServer
 
hasAnotherBatch() - Method in class com.mongodb.operation.BulkWriteBatch
 
hasAnotherSplit() - Method in class com.mongodb.connection.SplittablePayload
 
hasBytesAvailable(int) - Method in class com.mongodb.connection.netty.NettyStream
 
hasCheckedDiscriminator() - Method in class org.bson.codecs.DecoderContext.Builder
 
hasCheckedDiscriminator() - Method in class org.bson.codecs.DecoderContext
 
hasCycles(Class<U>) - Method in class org.bson.codecs.configuration.ChildCodecRegistry
 
hasDecodeHooks() - Static method in class org.bson.BSON
Gets whether any decoding transformers have been registered for any classes.
hasElements - Variable in class org.bson.json.StrictCharacterStreamJsonWriter.StrictJsonContext
 
hasEncodeHooks() - Static method in class org.bson.BSON
Gets whether any encoding transformers have been registered for any classes.
hasError(BsonDocument) - Static method in class com.mongodb.connection.WriteCommandResultHelper
 
hasError(BsonDocument) - Method in class com.mongodb.operation.BulkWriteBatch
 
hasErrorCode() - Method in exception org.bson.BSONException
Returns if the error code is set (i.e., not null).
hasErrors() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
Gets whether there are errors in the combined result.
hasErrors() - Method in class com.mongodb.operation.BulkWriteBatch
 
hasFileInfo() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
Hash(Map<? extends K, ? extends V>, AbstractCopyOnWriteMap.View.Type) - Constructor for class org.bson.util.CopyOnWriteMap.Hash
 
HashBased(int, int) - Constructor for class com.mongodb.internal.connection.IndexMap.HashBased
 
hashCode() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
hashCode() - Method in class com.mongodb.bulk.BulkWriteError
 
hashCode() - Method in class com.mongodb.bulk.BulkWriteUpsert
 
hashCode() - Method in class com.mongodb.bulk.WriteConcernError
 
hashCode() - Method in class com.mongodb.BulkWriteError
 
hashCode() - Method in exception com.mongodb.BulkWriteException
 
hashCode() - Method in class com.mongodb.BulkWriteUpsert
 
hashCode() - Method in class com.mongodb.client.gridfs.model.GridFSFile
 
hashCode() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
hashCode() - Method in class com.mongodb.client.model.changestream.UpdateDescription
 
hashCode() - Method in class com.mongodb.client.model.Collation
 
hashCode() - Method in class com.mongodb.client.model.Field
 
hashCode() - Method in class com.mongodb.client.model.geojson.Geometry
 
hashCode() - Method in class com.mongodb.client.model.geojson.GeometryCollection
 
hashCode() - Method in class com.mongodb.client.model.geojson.LineString
 
hashCode() - Method in class com.mongodb.client.model.geojson.MultiLineString
 
hashCode() - Method in class com.mongodb.client.model.geojson.MultiPoint
 
hashCode() - Method in class com.mongodb.client.model.geojson.MultiPolygon
 
hashCode() - Method in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
 
hashCode() - Method in class com.mongodb.client.model.geojson.Point
 
hashCode() - Method in class com.mongodb.client.model.geojson.Polygon
 
hashCode() - Method in class com.mongodb.client.model.geojson.PolygonCoordinates
 
hashCode() - Method in class com.mongodb.client.model.geojson.Position
 
hashCode() - Method in class com.mongodb.client.result.DeleteResult.AcknowledgedDeleteResult
 
hashCode() - Method in class com.mongodb.client.result.DeleteResult.UnacknowledgedDeleteResult
 
hashCode() - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
hashCode() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
hashCode() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
hashCode() - Method in class com.mongodb.connection.ChangeEvent
 
hashCode() - Method in class com.mongodb.connection.ClusterDescription
 
hashCode() - Method in class com.mongodb.connection.ClusterId
 
hashCode() - Method in class com.mongodb.connection.ClusterSettings
 
hashCode() - Method in class com.mongodb.connection.ConnectionDescription
 
hashCode() - Method in class com.mongodb.connection.ConnectionId
 
hashCode() - Method in class com.mongodb.connection.ConnectionPoolSettings
 
hashCode() - Method in class com.mongodb.connection.ServerDescription
 
hashCode() - Method in class com.mongodb.connection.ServerId
 
hashCode() - Method in class com.mongodb.connection.ServerSettings
 
hashCode() - Method in class com.mongodb.connection.ServerVersion
 
hashCode() - Method in class com.mongodb.connection.SocketSettings
 
hashCode() - Method in class com.mongodb.connection.SslSettings
 
hashCode() - Method in class com.mongodb.ConnectionString
 
hashCode() - Method in class com.mongodb.DBAddress
Deprecated.
 
hashCode() - Method in class com.mongodb.DBObjectCodecProvider
 
hashCode() - Method in class com.mongodb.DBRef
 
hashCode() - Method in class com.mongodb.DBRefCodecProvider
 
hashCode() - Method in class com.mongodb.DocumentToDBRefTransformer
 
hashCode() - Method in exception com.mongodb.MongoBulkWriteException
 
hashCode() - Method in class com.mongodb.MongoClientOptions
 
hashCode() - Method in class com.mongodb.MongoClientURI
 
hashCode() - Method in class com.mongodb.MongoCompressor
 
hashCode() - Method in class com.mongodb.MongoCredential
 
hashCode() - Method in class com.mongodb.MongoNamespace
 
hashCode() - Method in class com.mongodb.MongoOptions
Deprecated.
 
hashCode() - Method in class com.mongodb.operation.BsonArrayWrapper
 
hashCode() - Method in class com.mongodb.operation.CommandResultCodecProvider
 
hashCode() - Method in class com.mongodb.ReadConcern
 
hashCode() - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
hashCode() - Method in class com.mongodb.ServerAddress
 
hashCode() - Method in class com.mongodb.ServerCursor
 
hashCode() - Method in class com.mongodb.Tag
 
hashCode() - Method in class com.mongodb.TaggableReadPreference
 
hashCode() - Method in class com.mongodb.TagSet
 
hashCode() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
hashCode() - Method in class com.mongodb.WriteConcern
 
hashCode() - Method in class com.mongodb.WriteConcernError
 
hashCode() - Method in class com.mongodb.WriteError
 
hashCode() - Method in class org.bson.BasicBSONObject
 
hashCode() - Method in class org.bson.BsonArray
 
hashCode() - Method in class org.bson.BsonBinary
 
hashCode() - Method in class org.bson.BsonBoolean
 
hashCode() - Method in class org.bson.BsonDateTime
 
hashCode() - Method in class org.bson.BsonDbPointer
 
hashCode() - Method in class org.bson.BsonDecimal128
 
hashCode() - Method in class org.bson.BsonDocument
 
hashCode() - Method in class org.bson.BsonDocumentWrapper
 
hashCode() - Method in class org.bson.BsonDouble
 
hashCode() - Method in class org.bson.BsonElement
 
hashCode() - Method in class org.bson.BsonInt32
 
hashCode() - Method in class org.bson.BsonInt64
 
hashCode() - Method in class org.bson.BsonJavaScript
 
hashCode() - Method in class org.bson.BsonJavaScriptWithScope
 
hashCode() - Method in class org.bson.BsonMaxKey
 
hashCode() - Method in class org.bson.BsonMinKey
 
hashCode() - Method in class org.bson.BsonNull
 
hashCode() - Method in class org.bson.BsonObjectId
 
hashCode() - Method in class org.bson.BsonRegularExpression
 
hashCode() - Method in class org.bson.BsonString
 
hashCode() - Method in class org.bson.BsonSymbol
 
hashCode() - Method in class org.bson.BsonTimestamp
 
hashCode() - Method in class org.bson.BsonUndefined
 
hashCode() - Method in class org.bson.codecs.BsonTypeClassMap
 
hashCode() - Method in class org.bson.codecs.configuration.ChildCodecRegistry
 
hashCode() - Method in class org.bson.codecs.configuration.ProvidersCodecRegistry
 
hashCode() - Method in class org.bson.codecs.DocumentCodecProvider
 
hashCode() - Method in class org.bson.codecs.IterableCodecProvider
 
hashCode() - Method in class org.bson.codecs.MapCodecProvider
 
hashCode() - Method in class org.bson.codecs.pojo.ClassModel
 
hashCode() - Method in class org.bson.codecs.pojo.PropertyModel
 
hashCode() - Method in class org.bson.codecs.pojo.TypeData
 
hashCode() - Method in class org.bson.codecs.pojo.TypeParameterMap
 
hashCode() - Method in class org.bson.codecs.ValueCodecProvider
 
hashCode() - Method in class org.bson.Document
 
hashCode() - Method in class org.bson.LazyBSONObject
 
hashCode() - Method in class org.bson.RawBsonDocument
 
hashCode() - Method in class org.bson.types.Binary
 
hashCode() - Method in class org.bson.types.BSONTimestamp
 
hashCode() - Method in class org.bson.types.Code
 
hashCode() - Method in class org.bson.types.CodeWithScope
 
hashCode() - Method in class org.bson.types.CodeWScope
 
hashCode() - Method in class org.bson.types.Decimal128
 
hashCode() - Method in class org.bson.types.MaxKey
 
hashCode() - Method in class org.bson.types.MinKey
 
hashCode() - Method in class org.bson.types.ObjectId
 
hashCode() - Method in class org.bson.types.Symbol
 
hashCode() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
hashCode() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
hashCode() - Method in class org.bson.util.ComputingMap
 
hashed(String) - Static method in class com.mongodb.client.model.Indexes
Create an index key for a hashed index on the given field.
hasIndex(MongoCollection<T>, Document, SingleResultCallback<Boolean>) - Method in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
hasIndex(ClientSession, MongoCollection<T>, Document) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
hasInitialResponse() - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
hasNext() - Method in interface com.mongodb.client.MongoCursor
 
hasNext() - Method in class com.mongodb.DBCursor
Checks if there is another object available.
hasNext() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
hasNext() - Method in class com.mongodb.MongoBatchCursorAdapter
 
hasNext() - Method in class com.mongodb.MongoCursorAdapter
 
hasNext() - Method in class com.mongodb.MongoMappingCursor
 
hasNext() - Method in interface com.mongodb.operation.BatchCursor
Returns true if another batch of results exists.
hasNext() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
hasNext() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
hasNext() - Method in class com.mongodb.operation.QueryBatchCursor
 
hasNext() - Method in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
hasNext() - Method in class org.bson.LazyBSONList.LazyBSONListIterator
 
hasNext() - Method in class org.bson.util.AbstractCopyOnWriteMap.UnmodifiableIterator
 
hasPrimary() - Method in class com.mongodb.connection.MultiServerCluster
 
hasReadableServer(ReadPreference) - Method in class com.mongodb.connection.ClusterDescription
Returns true if this cluster has at least one server that satisfies the given read preference.
hasRemaining() - Method in class com.mongodb.connection.CompositeByteBuf
 
hasRemaining() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
hasRemaining() - Method in interface org.bson.ByteBuf
States whether there are any elements between the current position and the limit.
hasRemaining() - Method in class org.bson.ByteBufNIO
 
hasRemaining() - Method in interface org.bson.io.BsonInput
Returns true if there are more bytes left in the stream.
hasRemaining() - Method in class org.bson.io.ByteBufferBsonInput
 
hasResultsToProcess() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
hasSession() - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
hasSession() - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
hasSession() - Method in class com.mongodb.internal.session.ClientSessionContext
 
hasSession() - Method in interface com.mongodb.session.SessionContext
Returns true if there is a true server session associated with this context.
hasTags(TagSet) - Method in class com.mongodb.connection.ServerDescription
Returns true if the server has the given tags.
hasTypeParameters - Variable in class org.bson.codecs.pojo.ClassModel
 
hasTypeParameters() - Method in class org.bson.codecs.pojo.ClassModel
 
hasTypeParameters() - Method in class org.bson.codecs.pojo.TypeParameterMap
 
hasWritableServer() - Method in class com.mongodb.connection.ClusterDescription
Returns true if this cluster has at least one server that can be used for write operations.
hasWriteConcernError(BsonDocument) - Static method in class com.mongodb.operation.WriteConcernHelper
 
hasWriteConcernErrors() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
hasWriteError(BsonDocument) - Static method in class com.mongodb.connection.ProtocolHelper
 
hasWriteErrors() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
header - Variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque
List header.
heartbeatConnectTimeout - Variable in class com.mongodb.MongoClientOptions.Builder
 
heartbeatConnectTimeout(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the connect timeout for connections used for the cluster heartbeat.
heartbeatConnectTimeout - Variable in class com.mongodb.MongoClientOptions
 
heartbeatFrequency(long, TimeUnit) - Method in class com.mongodb.connection.ServerSettings.Builder
Sets the frequency that the cluster monitor attempts to reach each server.
heartbeatFrequency - Variable in class com.mongodb.ConnectionString
 
heartbeatFrequency - Variable in class com.mongodb.MongoClientOptions.Builder
 
heartbeatFrequency(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the heartbeat frequency.
heartbeatFrequency - Variable in class com.mongodb.MongoClientOptions
 
heartbeatFrequencyMS - Variable in class com.mongodb.connection.ServerSettings.Builder
 
heartbeatFrequencyMS - Variable in class com.mongodb.connection.ServerSettings
 
heartbeatSocketSettings - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
heartbeatSocketSettings(SocketSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the heartbeat socket settings.
heartbeatSocketSettings - Variable in class com.mongodb.async.client.MongoClientSettings
 
heartbeatSocketSettings - Variable in class com.mongodb.MongoClientOptions
 
heartbeatSocketTimeout - Variable in class com.mongodb.MongoClientOptions.Builder
 
heartbeatSocketTimeout(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the socket timeout for connections used for the cluster heartbeat.
heartbeatSocketTimeout - Variable in class com.mongodb.MongoClientOptions
 
heartbeatStreamFactory - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
HEX_CHARS - Static variable in class org.bson.types.ObjectId
 
hexMD5(byte[]) - Static method in class com.mongodb.internal.HexUtils
Produce hex representation of the MD5 digest of a byte array.
hexMD5(ByteBuffer, int, int) - Static method in class com.mongodb.internal.HexUtils
Produce hex representation of the MD5 digest of a byte array.
hexMD5(byte[]) - Static method in class com.mongodb.util.Util
Produce hex representation of the MD5 digest of a byte array.
hexMD5(ByteBuffer, int, int) - Static method in class com.mongodb.util.Util
Produce hex representation of the MD5 digest of a byte array.
HexUtils - Class in com.mongodb.internal
This class is not part of the public API and may be removed or changed at any time.
HexUtils() - Constructor for class com.mongodb.internal.HexUtils
 
hi(String, byte[], int) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
high - Variable in class org.bson.types.Decimal128
 
hint - Variable in class com.mongodb.AggregateIterableImpl
 
hint(Bson) - Method in class com.mongodb.AggregateIterableImpl
 
hint(Bson) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the hint for which index to use.
hint - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
hint(Bson) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
hint(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets the hint for which index to use.
hint(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
hint(Bson) - Method in interface com.mongodb.client.AggregateIterable
Sets the hint for which index to use.
hint(Bson) - Method in interface com.mongodb.client.FindIterable
Sets the hint for which index to use.
hint - Variable in class com.mongodb.client.model.CountOptions
 
hint(Bson) - Method in class com.mongodb.client.model.CountOptions
Sets the hint to apply.
hint - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
hint(DBObject) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the hint to apply.
hint - Variable in class com.mongodb.client.model.FindOptions
 
hint(Bson) - Method in class com.mongodb.client.model.FindOptions
Sets the hint for which index to use.
hint(DBObject) - Method in class com.mongodb.DBCursor
Informs the database of indexed fields of the collection in order to improve performance.
hint(String) - Method in class com.mongodb.DBCursor
Informs the database of an indexed field of the collection in order to improve performance.
hint(Bson) - Method in class com.mongodb.FindIterableImpl
 
hint - Variable in class com.mongodb.operation.AggregateExplainOperation
 
hint(BsonDocument) - Method in class com.mongodb.operation.AggregateExplainOperation
Sets the hint for which index to use.
hint - Variable in class com.mongodb.operation.AggregateOperation
 
hint(BsonDocument) - Method in class com.mongodb.operation.AggregateOperation
Sets the hint for which index to use.
hint - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
hint(BsonDocument) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the hint for which index to use.
hint - Variable in class com.mongodb.operation.CountOperation
 
hint(BsonValue) - Method in class com.mongodb.operation.CountOperation
Sets the hint to apply.
hint - Variable in class com.mongodb.operation.FindOperation
 
hint(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets the hint for which index to use.
HINT - Static variable in class com.mongodb.QueryOperators
 
hintFields - Variable in class com.mongodb.DBCollection
 
hintString - Variable in class com.mongodb.client.model.CountOptions
 
hintString(String) - Method in class com.mongodb.client.model.CountOptions
Sets the hint to apply.
hintString - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
hintString(String) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the hint to apply.
hmac(byte[], String) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
Holder() - Constructor for class com.mongodb.Mongo.Holder
 
holes - Variable in class com.mongodb.client.model.geojson.PolygonCoordinates
 
host - Static variable in class com.mongodb.gridfs.CLI
 
host - Variable in class com.mongodb.ServerAddress
 
hosts - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
hosts(List<ServerAddress>) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the hosts for the cluster.
hosts - Variable in class com.mongodb.connection.ClusterSettings
 
hosts - Variable in class com.mongodb.connection.ServerDescription.Builder
 
hosts(Set<String>) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets all members of the replica set that are neither hidden, passive, nor arbiters.
hosts - Variable in class com.mongodb.connection.ServerDescription
 
hosts - Variable in class com.mongodb.ConnectionString
 

I

id - Variable in class com.mongodb.bulk.BulkWriteUpsert
 
id - Variable in class com.mongodb.BulkWriteUpsert
 
id - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
id - Variable in class com.mongodb.client.model.Aggregates.GroupStage
 
id - Variable in class com.mongodb.connection.RequestMessage
 
id - Variable in class com.mongodb.DBRef
 
id - Variable in class com.mongodb.gridfs.GridFSFile
 
id - Variable in class com.mongodb.ServerCursor
 
id - Variable in class org.bson.BsonDbPointer
 
ID_FIELD_NAME - Static variable in class com.mongodb.BulkWriteOperation
 
ID_FIELD_NAME - Static variable in class com.mongodb.DBCollection
 
ID_FIELD_NAME - Static variable in class com.mongodb.DBObjectCodec
 
ID_FIELD_NAME - Static variable in class org.bson.codecs.BsonDocumentCodec
 
ID_FIELD_NAME - Static variable in class org.bson.codecs.DocumentCodec
 
ID_PROPERTY_NAME - Static variable in class org.bson.codecs.pojo.ClassModelBuilder
 
identifier - Variable in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
IdentityTransformer() - Constructor for class com.mongodb.operation.CommandOperationHelper.IdentityTransformer
 
idGenerator - Variable in class com.mongodb.DBObjectCodec
 
idGenerator - Variable in class org.bson.codecs.DocumentCodec
 
IdGenerator - Interface in org.bson.codecs
Classes that implement this interface define a way to create IDs for MongoDB documents.
IDLE_WRITE_PERIOD_MS - Static variable in class com.mongodb.TaggableReadPreference
 
idProperty - Variable in class org.bson.codecs.pojo.ClassModel
 
idPropertyIndex - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
idPropertyName - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
idPropertyName(String) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Designates a property as the _id property for this type.
IGNORE_FIELDS - Static variable in class com.mongodb.ReflectionDBObject
 
Immutable - Annotation Type in com.mongodb.annotations
The class to which this annotation is applied is immutable.
Immutable() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.Immutable
 
in(String, TItem...) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of a field equals any value in the list of specified values.
in(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 equals any value in the list of specified values.
in(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $in operand
IN - Static variable in class com.mongodb.QueryOperators
 
InboundBufferHandler() - Constructor for class com.mongodb.connection.netty.NettyStream.InboundBufferHandler
 
inc(String, Number) - Static method in class com.mongodb.client.model.Updates
Creates an update that increments the value of the field with the given name by the given value.
inc - Variable in class org.bson.types.BSONTimestamp
 
include(String...) - Static method in class com.mongodb.client.model.Projections
Creates a projection that includes all of the given fields.
include(List<String>) - Static method in class com.mongodb.client.model.Projections
Creates a projection that includes all of the given fields.
includeArrayIndex - Variable in class com.mongodb.client.model.UnwindOptions
 
includeArrayIndex(String) - Method in class com.mongodb.client.model.UnwindOptions
Sets the field to be used to store the array index of the unwound item
incrementGenerationOnSocketException(InternalConnection, Throwable) - Method in class com.mongodb.connection.DefaultConnectionPool
If there was a socket exception that wasn't some form of interrupted read, increment the generation count so that any connections created prior will be discarded.
INCREMENTING_ID - Static variable in class com.mongodb.connection.ConnectionId
 
indent - Variable in class org.bson.json.JsonWriterSettings.Builder
 
indent(boolean) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets whether indentation is enabled, which defaults to false.
indent - Variable in class org.bson.json.JsonWriterSettings
 
indent - Variable in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
 
indent(boolean) - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
Sets whether indentation is enabled.
indent - Variable in class org.bson.json.StrictCharacterStreamJsonWriterSettings
 
indentation - Variable in class org.bson.json.StrictCharacterStreamJsonWriter.StrictJsonContext
 
indentCharacters - Variable in class org.bson.json.JsonWriterSettings.Builder
 
indentCharacters(String) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the indent character string to use when indentation is enabled, which defaults to two spaces.
indentCharacters - Variable in class org.bson.json.JsonWriterSettings
 
indentCharacters - Variable in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
 
indentCharacters(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
Sets the indent character string to use when indentation is enabled.
indentCharacters - Variable in class org.bson.json.StrictCharacterStreamJsonWriterSettings
 
index - Variable in class com.mongodb.bulk.BulkWriteError
 
index - Variable in class com.mongodb.bulk.BulkWriteUpsert
 
index - Variable in class com.mongodb.BulkWriteError
 
index - Variable in class com.mongodb.BulkWriteUpsert
 
index - Variable in class com.mongodb.operation.BulkWriteBatch.WriteRequestWithIndex
 
index - Variable in class org.bson.BsonBinaryWriter.Context
 
index - Variable in class org.bson.BSONCallbackAdapter.Context
 
indexCheck - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
Indexes - Class in com.mongodb.client.model
A factory for defining index keys.
Indexes() - Constructor for class com.mongodb.client.model.Indexes
 
IndexHelper - Class in com.mongodb.operation
 
IndexHelper() - Constructor for class com.mongodb.operation.IndexHelper
 
IndexMap - Class in com.mongodb.internal.connection
Efficiently maps each integer in a set to another integer in a set, useful for merging bulk write errors when a bulk write must be split into multiple batches.
IndexMap() - Constructor for class com.mongodb.internal.connection.IndexMap
 
indexMap - Variable in class com.mongodb.internal.connection.IndexMap.HashBased
 
indexMap - Variable in class com.mongodb.operation.BulkWriteBatch
 
IndexMap.HashBased - Class in com.mongodb.internal.connection
 
IndexMap.RangeBased - Class in com.mongodb.internal.connection
 
IndexModel - Class in com.mongodb.client.model
A model describing the creation of a single index.
IndexModel(Bson) - Constructor for class com.mongodb.client.model.IndexModel
Construct an instance with the given keys.
IndexModel(Bson, IndexOptions) - Constructor for class com.mongodb.client.model.IndexModel
Construct an instance with the given keys and options.
indexName - Variable in class com.mongodb.operation.DropIndexOperation
 
indexOf(Object) - Method in class com.mongodb.operation.BsonArrayWrapper
 
indexOf(Object) - Method in class org.bson.BsonArray
 
indexOf(Object) - Method in class org.bson.LazyBSONList
 
indexOptionDefaults - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
indexOptionDefaults(IndexOptionDefaults) - Method in class com.mongodb.client.model.CreateCollectionOptions
Sets the index option defaults for the collection.
IndexOptionDefaults - Class in com.mongodb.client.model
The default options for a collection to apply on the creation of indexes.
IndexOptionDefaults() - Constructor for class com.mongodb.client.model.IndexOptionDefaults
 
indexOptionDefaults - Variable in class com.mongodb.operation.CreateCollectionOperation
 
indexOptionDefaults(BsonDocument) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the index option defaults document for the collection.
IndexOptions - Class in com.mongodb.client.model
The options to apply to the creation of an index.
IndexOptions() - Constructor for class com.mongodb.client.model.IndexOptions
 
IndexRequest - Class in com.mongodb.bulk
The settings to apply to the creation of an index.
IndexRequest(BsonDocument) - Constructor for class com.mongodb.bulk.IndexRequest
Construct a new instance with the given keys
INFINITY_MASK - Static variable in class org.bson.types.Decimal128
 
info(String) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
info(String, Throwable) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
info(String) - Method in interface com.mongodb.diagnostics.logging.Logger
Log a message at the INFO level.
info(String, Throwable) - Method in interface com.mongodb.diagnostics.logging.Logger
Log an exception (throwable) at the INFO level with an accompanying message.
info(String) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
info(String, Throwable) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
info(String) - Method in class org.bson.diagnostics.JULLogger
 
info(String, Throwable) - Method in class org.bson.diagnostics.JULLogger
 
info(String) - Method in interface org.bson.diagnostics.Logger
Log a message at the INFO level.
info(String, Throwable) - Method in interface org.bson.diagnostics.Logger
Log an exception (throwable) at the INFO level with an accompanying message.
info(String) - Method in class org.bson.diagnostics.SLF4JLogger
 
info(String, Throwable) - Method in class org.bson.diagnostics.SLF4JLogger
 
initFromCommandResult(BsonDocument) - Method in class com.mongodb.operation.QueryBatchCursor
 
initFromQueryResult(QueryResult<T>) - Method in class com.mongodb.operation.QueryBatchCursor
 
initial - Variable in class com.mongodb.GroupCommand
 
initial - Variable in class com.mongodb.operation.GroupOperation
 
INITIAL_BUFFER_SIZE - Static variable in class com.mongodb.connection.ByteBufferBsonOutput
 
INITIAL_SHIFT - Static variable in class com.mongodb.connection.ByteBufferBsonOutput
 
initialize(InternalConnection) - Method in interface com.mongodb.connection.InternalConnectionInitializer
 
initialize(InternalConnection) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
initialize(Socket, ServerAddress, SocketSettings, SslSettings) - Static method in class com.mongodb.connection.SocketStreamHelper
 
initializeAsync(InternalConnection, SingleResultCallback<ConnectionDescription>) - Method in interface com.mongodb.connection.InternalConnectionInitializer
 
initializeAsync(InternalConnection, SingleResultCallback<ConnectionDescription>) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
initializeConnectionDescription(InternalConnection) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
initializeConnectionDescriptionAsync(InternalConnection, SingleResultCallback<ConnectionDescription>) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer
 
initializeCursor(FindOperation<DBObject>) - Method in class com.mongodb.DBCursor
 
initializeDecimalFormatSymbols() - Static method in class com.mongodb.connection.ServerDescription
Initialize the character used for decimal separator
initializeOrderedBulkOperation() - Method in class com.mongodb.DBCollection
Creates a builder for an ordered bulk write operation, consisting of an ordered collection of write requests, which can be any combination of inserts, updates, replaces, or removes.
initializeUnorderedBulkOperation() - Method in class com.mongodb.DBCollection
Creates a builder for an unordered bulk operation, consisting of an unordered collection of write requests, which can be any combination of inserts, updates, replaces, or removes.
initialValues - Variable in class org.bson.util.CopyOnWriteMap.Builder
 
injectGridFSInstance(Object) - Method in class com.mongodb.gridfs.GridFS
 
inline - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
inline - Variable in class com.mongodb.MapReduceIterableImpl
 
inlineResults - Variable in class com.mongodb.MapReduceOutput
 
inputCount - Variable in class com.mongodb.operation.MapReduceStatistics
 
inputStream - Variable in class com.mongodb.connection.SocketStream
 
inputStream - Variable in class com.mongodb.gridfs.GridFSInputFile
 
insert(DBObject) - Method in class com.mongodb.BulkWriteOperation
Add an insert request to the bulk operation
insert(MongoNamespace, boolean, InsertRequest) - Method in interface com.mongodb.connection.Connection
Insert the documents using the insert wire protocol and apply the write concern.
insert(MongoNamespace, boolean, InsertRequest) - Method in class com.mongodb.connection.DefaultServerConnection
 
insert(DBObject, WriteConcern) - Method in class com.mongodb.DBCollection
Insert a document into a collection.
insert(DBObject...) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(WriteConcern, DBObject...) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(DBObject[], WriteConcern) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(List<? extends DBObject>) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(List<? extends DBObject>, WriteConcern) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(DBObject[], WriteConcern, DBEncoder) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(List<? extends DBObject>, WriteConcern, DBEncoder) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(List<? extends DBObject>, InsertOptions) - Method in class com.mongodb.DBCollection
Insert documents into a collection.
insert(List<InsertRequest>, WriteConcern, boolean, Boolean) - Method in class com.mongodb.DBCollection
 
insertAsync(MongoNamespace, boolean, InsertRequest, SingleResultCallback<WriteConcernResult>) - Method in interface com.mongodb.connection.AsyncConnection
Insert the documents using the insert wire protocol and apply the write concern asynchronously.
insertAsync(MongoNamespace, boolean, InsertRequest, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.DefaultServerConnection
 
insertedCount - Variable in class com.mongodb.AcknowledgedBulkWriteResult
 
insertedCount - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
insertMany(List<? extends TDocument>, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts one or more documents.
insertMany(List<? extends TDocument>, InsertManyOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts one or more documents.
insertMany(ClientSession, List<? extends TDocument>, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts one or more documents.
insertMany(ClientSession, List<? extends TDocument>, InsertManyOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts one or more documents.
insertMany(List<? extends TDocument>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertMany(List<? extends TDocument>, InsertManyOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertMany(ClientSession, List<? extends TDocument>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertMany(ClientSession, List<? extends TDocument>, InsertManyOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertMany(List<? extends TDocument>) - Method in interface com.mongodb.client.MongoCollection
Inserts one or more documents.
insertMany(List<? extends TDocument>, InsertManyOptions) - Method in interface com.mongodb.client.MongoCollection
Inserts one or more documents.
insertMany(ClientSession, List<? extends TDocument>) - Method in interface com.mongodb.client.MongoCollection
Inserts one or more documents.
insertMany(ClientSession, List<? extends TDocument>, InsertManyOptions) - Method in interface com.mongodb.client.MongoCollection
Inserts one or more documents.
insertMany(List<? extends TDocument>) - Method in class com.mongodb.MongoCollectionImpl
 
insertMany(List<? extends TDocument>, InsertManyOptions) - Method in class com.mongodb.MongoCollectionImpl
 
insertMany(ClientSession, List<? extends TDocument>) - Method in class com.mongodb.MongoCollectionImpl
 
insertMany(ClientSession, List<? extends TDocument>, InsertManyOptions) - Method in class com.mongodb.MongoCollectionImpl
 
InsertManyOptions - Class in com.mongodb.client.model
The options to apply to an operation that inserts multiple documents into a collection.
InsertManyOptions() - Constructor for class com.mongodb.client.model.InsertManyOptions
 
InsertMessage - Class in com.mongodb.connection
An insert message.
InsertMessage(String, InsertRequest, MessageSettings) - Constructor for class com.mongodb.connection.InsertMessage
 
insertOne(TDocument, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts the provided document.
insertOne(TDocument, InsertOneOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts the provided document.
insertOne(ClientSession, TDocument, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts the provided document.
insertOne(ClientSession, TDocument, InsertOneOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Inserts the provided document.
insertOne(TDocument, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertOne(TDocument, InsertOneOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertOne(ClientSession, TDocument, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertOne(ClientSession, TDocument, InsertOneOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
insertOne(TDocument) - Method in interface com.mongodb.client.MongoCollection
Inserts the provided document.
insertOne(TDocument, InsertOneOptions) - Method in interface com.mongodb.client.MongoCollection
Inserts the provided document.
insertOne(ClientSession, TDocument) - Method in interface com.mongodb.client.MongoCollection
Inserts the provided document.
insertOne(ClientSession, TDocument, InsertOneOptions) - Method in interface com.mongodb.client.MongoCollection
Inserts the provided document.
insertOne(TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
insertOne(TDocument, InsertOneOptions) - Method in class com.mongodb.MongoCollectionImpl
 
insertOne(ClientSession, TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
insertOne(ClientSession, TDocument, InsertOneOptions) - Method in class com.mongodb.MongoCollectionImpl
 
InsertOneModel<T> - Class in com.mongodb.client.model
A model describing an insert of a single document.
InsertOneModel(T) - Constructor for class com.mongodb.client.model.InsertOneModel
Construct a new instance.
InsertOneOptions - Class in com.mongodb.client.model
The options to apply to an operation that inserts a single document into a collection.
InsertOneOptions() - Constructor for class com.mongodb.client.model.InsertOneOptions
 
InsertOperation - Class in com.mongodb.operation
An operation that inserts one or more documents into a collection.
InsertOperation(MongoNamespace, boolean, WriteConcern, List<InsertRequest>) - Constructor for class com.mongodb.operation.InsertOperation
InsertOperation(MongoNamespace, boolean, WriteConcern, boolean, List<InsertRequest>) - Constructor for class com.mongodb.operation.InsertOperation
Construct an instance.
InsertOptions - Class in com.mongodb
Options related to insertion of documents into MongoDB.
InsertOptions() - Constructor for class com.mongodb.InsertOptions
 
InsertProtocol - Class in com.mongodb.connection
An implementation of the insert wire protocol.
InsertProtocol(MongoNamespace, boolean, InsertRequest) - Constructor for class com.mongodb.connection.InsertProtocol
 
InsertRequest - Class in com.mongodb.bulk
A representation of a document to insert.
InsertRequest(BsonDocument) - Constructor for class com.mongodb.bulk.InsertRequest
Construct an instance with the given document.
insertRequest - Variable in class com.mongodb.connection.InsertMessage
 
insertRequest - Variable in class com.mongodb.connection.InsertProtocol
 
InsertRequest - Class in com.mongodb
 
InsertRequest(DBObject, Encoder<DBObject>) - Constructor for class com.mongodb.InsertRequest
 
insertRequests - Variable in class com.mongodb.operation.InsertOperation
 
INSTANCE - Static variable in class com.mongodb.internal.connection.NoOpSessionContext
A singleton instance of a NoOpSessionContext
INSTANCE - Static variable in class com.mongodb.Mongo.Holder
 
InstanceCreator<T> - Interface in org.bson.codecs.pojo
Provides access for setting data and the creation of a class instances.
instanceCreatorFactory - Variable in class org.bson.codecs.pojo.ClassModel
 
instanceCreatorFactory - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
instanceCreatorFactory(InstanceCreatorFactory<T>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Sets the InstanceCreatorFactory for the ClassModel
InstanceCreatorFactory<T> - Interface in org.bson.codecs.pojo
The factory for creating InstanceCreator instances
InstanceCreatorFactoryImpl<T> - Class in org.bson.codecs.pojo
 
InstanceCreatorFactoryImpl(CreatorExecutable<T>) - Constructor for class org.bson.codecs.pojo.InstanceCreatorFactoryImpl
 
InstanceCreatorImpl<T> - Class in org.bson.codecs.pojo
 
InstanceCreatorImpl(CreatorExecutable<T>) - Constructor for class org.bson.codecs.pojo.InstanceCreatorImpl
 
int0(int) - Static method in class org.bson.types.ObjectId
 
int1(int) - Static method in class org.bson.types.ObjectId
 
int2(int) - Static method in class org.bson.types.ObjectId
 
int3(int) - Static method in class org.bson.types.ObjectId
 
int32Converter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
int32Converter(Converter<Integer>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Int32 values to JSON.
int32Converter - Variable in class org.bson.json.JsonWriterSettings
 
int64Converter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
int64Converter(Converter<Long>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Int64 values to JSON.
int64Converter - Variable in class org.bson.json.JsonWriterSettings
 
IntegerCodec - Class in org.bson.codecs
Encodes and decodes Integer objects.
IntegerCodec() - Constructor for class org.bson.codecs.IntegerCodec
 
InternalConnection - Interface in com.mongodb.connection
 
internalConnection - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
internalConnectionFactory - Variable in class com.mongodb.connection.DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory
 
internalConnectionFactory - Variable in class com.mongodb.connection.DefaultServerMonitor
 
internalConnectionFactory - Variable in class com.mongodb.connection.DefaultServerMonitorFactory
 
InternalConnectionFactory - Interface in com.mongodb.connection
 
InternalConnectionInitializer - Interface in com.mongodb.connection
 
InternalStreamConnection - Class in com.mongodb.connection
 
InternalStreamConnection(ServerId, StreamFactory, List<MongoCompressor>, CommandListener, InternalConnectionInitializer) - Constructor for class com.mongodb.connection.InternalStreamConnection
 
InternalStreamConnection.CommandEventSender - Class in com.mongodb.connection
 
InternalStreamConnection.LazyCommandDocument - Class in com.mongodb.connection
 
InternalStreamConnection.MessageHeaderCallback - Class in com.mongodb.connection
 
InternalStreamConnection.MessageHeaderCallback.MessageCallback - Class in com.mongodb.connection
 
InternalStreamConnectionFactory - Class in com.mongodb.connection
 
InternalStreamConnectionFactory(StreamFactory, List<MongoCredential>, String, MongoDriverInformation, List<MongoCompressor>, CommandListener) - Constructor for class com.mongodb.connection.InternalStreamConnectionFactory
 
InternalStreamConnectionInitializer - Class in com.mongodb.connection
 
InternalStreamConnectionInitializer(List<Authenticator>, BsonDocument, List<MongoCompressor>) - Constructor for class com.mongodb.connection.InternalStreamConnectionInitializer
 
InternalStreamConnectionInitializer.CompoundAuthenticator - Class in com.mongodb.connection
 
into(A, SingleResultCallback<A>) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
into(A, SingleResultCallback<A>) - Method in class com.mongodb.async.client.MappingIterable
 
into(A, SingleResultCallback<A>) - Method in interface com.mongodb.async.client.MongoIterable
Iterates over all the documents, adding each to the given target.
into(A, SingleResultCallback<A>) - Method in class com.mongodb.async.client.MongoIterableImpl
 
into(A) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
into(A) - Method in interface com.mongodb.client.MongoIterable
Iterates over all the documents, adding each to the given target.
into(A) - Method in class com.mongodb.MappingIterable
 
into(A) - Method in class com.mongodb.MongoIterableImpl
 
intRepresentation - Variable in enum com.mongodb.client.model.CollationStrength
 
intRepresentation - Variable in enum com.mongodb.operation.OrderBy
 
intToString(int) - Method in class org.bson.types.StringRangeSet
 
intValue() - Method in class org.bson.BsonDecimal128
 
intValue() - Method in class org.bson.BsonDouble
 
intValue() - Method in class org.bson.BsonInt32
 
intValue() - Method in class org.bson.BsonInt64
 
intValue() - Method in class org.bson.BsonNumber
Returns the value of the specified number as an int, which may involve rounding or truncation.
invalidate() - Method in interface com.mongodb.connection.ClusterableServer
Invalidate the description of this server.
invalidate() - Method in interface com.mongodb.connection.ConnectionPool
 
invalidate() - Method in class com.mongodb.connection.DefaultConnectionPool
 
invalidate() - Method in class com.mongodb.connection.DefaultServer
 
invalidateOldPrimaries(ServerAddress) - Method in class com.mongodb.connection.MultiServerCluster
 
invalidConversion(Class<T>, Number) - Static method in class org.bson.codecs.NumberCodecHelper
 
invalidHostNameAllowed - Variable in class com.mongodb.connection.SslSettings.Builder
 
invalidHostNameAllowed(boolean) - Method in class com.mongodb.connection.SslSettings.Builder
Define whether invalid host names should be allowed.
invalidHostNameAllowed - Variable in class com.mongodb.connection.SslSettings
 
is(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the find({key:value})
IS_PREFIX - Static variable in class org.bson.codecs.pojo.PropertyReflectionUtils
 
isAcknowledged() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
isAcknowledged() - Method in class com.mongodb.BulkWriteResult
Returns true if the write was acknowledged.
isAcknowledged() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
isAcknowledged() - Method in class com.mongodb.WriteConcern
Returns true if this write concern indicates that write operations must be acknowledged.
isAlwaysUseMBeans() - Method in class com.mongodb.MongoClientOptions
Gets whether JMX beans registered by the driver should always be MBeans, regardless of whether the VM is Java 6 or greater.
isAlwaysUseMBeans() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets whether JMX beans registered by the driver should always be MBeans, regardless of whether the VM is Java 6 or greater.
isArray(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonArray, returns false if the document does not contain the key.
isArray() - Method in class org.bson.BsonValue
Returns true if this is a BsonArray, false otherwise.
isAssignableFrom(Class<?>) - Method in class org.bson.codecs.pojo.TypeData
 
isAutoIndex() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets if auto-index is enabled
isAutoIndex() - Method in class com.mongodb.operation.CreateCollectionOperation
The auto index value.
isAwaitData() - Method in class com.mongodb.connection.BaseQueryMessage
Returns true if the cursor should await for data.
isAwaitData() - Method in class com.mongodb.connection.QueryProtocol
Returns true if the cursor should await for data.
isAwaitData() - Method in class com.mongodb.operation.FindOperation
 
isBackground() - Method in class com.mongodb.bulk.IndexRequest
Create the index in the background
isBackground() - Method in class com.mongodb.client.model.IndexOptions
Create the index in the background
isBinary(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonBinary, returns false if the document does not contain the key.
isBinary() - Method in class org.bson.BsonValue
Returns true if this is a BsonBinary, false otherwise.
isBoolean(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonBoolean, returns false if the document does not contain the key.
isBoolean() - Method in class org.bson.BsonValue
Returns true if this is a BsonBoolean, false otherwise.
isCapped() - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets whether the collection is capped.
isCapped() - Method in class com.mongodb.DBCollection
Checks whether this collection is capped
isCapped() - Method in class com.mongodb.operation.CreateCollectionOperation
Gets whether the collection is capped.
isCausallyConsistent() - Method in class com.mongodb.ClientSessionOptions
Whether operations using the session should causally consistent with each other.
isCausallyConsistent() - Method in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
isCausallyConsistent() - Method in class com.mongodb.internal.connection.NoOpSessionContext
 
isCausallyConsistent() - Method in class com.mongodb.internal.session.ClientSessionContext
 
isCausallyConsistent() - Method in class com.mongodb.internal.session.ClientSessionImpl
 
isCausallyConsistent() - Method in interface com.mongodb.session.ClientSession
Returns true if operations in this session must be causally consistent
isCausallyConsistent() - Method in interface com.mongodb.session.SessionContext
Gets whether this context is associated with a causally consistent session.
isClosed() - Method in interface com.mongodb.async.AsyncBatchCursor
Return true if the AsyncBatchCursor has been closed
isClosed() - Method in class com.mongodb.async.client.MappingAsyncBatchCursor
 
isClosed - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream
 
isClosed() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
isClosed - Variable in class com.mongodb.connection.BaseCluster
 
isClosed() - Method in class com.mongodb.connection.BaseCluster
 
isClosed() - Method in interface com.mongodb.connection.Cluster
Whether all the servers in the cluster are closed or not.
isClosed() - Method in interface com.mongodb.connection.ClusterableServer
Returns true if the server is closed, false otherwise.
isClosed - Variable in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
isClosed() - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
isClosed - Variable in class com.mongodb.connection.DefaultServer
 
isClosed() - Method in class com.mongodb.connection.DefaultServer
 
isClosed - Variable in class com.mongodb.connection.DefaultServerMonitor
 
isClosed() - Method in interface com.mongodb.connection.InternalConnection
Returns the closed state of the connection
isClosed - Variable in class com.mongodb.connection.InternalStreamConnection
 
isClosed() - Method in class com.mongodb.connection.InternalStreamConnection
 
isClosed - Variable in class com.mongodb.connection.netty.NettyStream
 
isClosed() - Method in class com.mongodb.connection.netty.NettyStream
 
isClosed - Variable in class com.mongodb.connection.ResponseBuffers
 
isClosed - Variable in class com.mongodb.connection.SocketChannelStream
 
isClosed() - Method in class com.mongodb.connection.SocketChannelStream
 
isClosed - Variable in class com.mongodb.connection.SocketStream
 
isClosed() - Method in class com.mongodb.connection.SocketStream
 
isClosed() - Method in interface com.mongodb.connection.Stream
Returns the closed state of the connection
isClosed() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
isClosed() - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
isClosed() - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
isClosed - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
isClosed() - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
isClosed() - Method in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
isClosed() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
isClosed() - Method in interface com.mongodb.session.ServerSession
Whether the server session is closed.
isClosed() - Method in class org.bson.AbstractBsonReader
Return true if the reader has been closed.
isClosed() - Method in class org.bson.AbstractBsonWriter
Returns whether this writer has been closed.
isCommandOk(BsonDocument) - Static method in class com.mongodb.connection.CommandHelper
 
isCommandOk(BsonDocument) - Static method in class com.mongodb.connection.ProtocolHelper
 
isCommandOk(BsonReader) - Static method in class com.mongodb.connection.ProtocolHelper
 
isCommandOk(ResponseBuffers) - Static method in class com.mongodb.connection.ProtocolHelper
 
isCommandOk(BsonValue) - Static method in class com.mongodb.connection.ProtocolHelper
 
isCompatibleWithDriver() - Method in class com.mongodb.connection.ClusterDescription
Return whether all servers in the cluster are compatible with the driver.
isCompatibleWithDriver() - Method in class com.mongodb.connection.ServerDescription
Return whether the server is compatible with the driver.
isComplete() - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
isConstant - Static variable in class com.mongodb.connection.Time
 
isContainer() - Method in enum org.bson.BsonType
Returns whether this type is some sort of containing type, e.g.
isContinueOnError() - Method in class com.mongodb.InsertOptions
Whether documents will continue to be inserted after a failure to insert one (most commonly due to a duplicate key error).
isCursorFinalizerEnabled() - Method in class com.mongodb.DBCursor
 
isCursorFinalizerEnabled() - Method in class com.mongodb.MongoClientOptions
Gets whether there is a a finalize method created that cleans up instances of DBCursor that the client does not close.
isCursorFinalizerEnabled() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets whether there is a a finalize method created that cleans up instances of DBCursor that the client does not close.
isCursorNotFound() - Method in class com.mongodb.connection.ReplyHeader
Gets whether this query was performed with a cursor ID that was not valid on the server.
isDateTime(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonDateTime, returns false if the document does not contain the key.
isDateTime() - Method in class org.bson.BsonValue
Returns true if this is a BsonDateTime, false otherwise.
isDBPointer() - Method in class org.bson.BsonValue
Returns true if this is a BsonDbPointer, false otherwise.
isDebugEnabled() - Method in class com.mongodb.diagnostics.logging.JULLogger
 
isDebugEnabled() - Method in interface com.mongodb.diagnostics.logging.Logger
Is the logger instance enabled for the DEBUG level?
isDebugEnabled() - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
isDebugEnabled() - Method in class org.bson.diagnostics.JULLogger
 
isDebugEnabled() - Method in interface org.bson.diagnostics.Logger
Is the logger instance enabled for the DEBUG level?
isDebugEnabled() - Method in class org.bson.diagnostics.SLF4JLogger
 
isDecimal128(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonDecimal128, returns false if the document does not contain the key.
isDecimal128() - Method in class org.bson.BsonValue
Returns true if this is a BsonDecimal128, false otherwise.
isDefined() - Method in class org.bson.codecs.configuration.Optional
 
isDeleted() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns true if this node is followed by a marker node, meaning that this node is deleted.
isDeserializable() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
isDirectConnectionToNonShardRouter() - Method in class com.mongodb.connection.CommandMessage
 
isDiscriminatorEnabled() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
isDocument(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonDocument, returns false if the document does not contain the key.
isDocument() - Method in class org.bson.BsonValue
Returns true if this is a BsonDocument, false otherwise.
isDouble(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonDouble, returns false if the document does not contain the key.
isDouble() - Method in class org.bson.BsonValue
Returns true if this is a BsonDouble, false otherwise.
isDropTarget() - Method in class com.mongodb.client.model.RenameCollectionOptions
Gets if mongod should drop the target of renameCollection prior to renaming the collection.
isDropTarget() - Method in class com.mongodb.operation.RenameCollectionOperation
Gets if mongod should drop the target of renameCollection prior to renaming the collection.
isEmpty() - Method in class com.mongodb.BasicDBObjectBuilder
Returns true if no key/value was inserted into the top level document.
isEmpty() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
isEmpty() - Method in class com.mongodb.connection.SplittablePayload
 
isEmpty() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns true if this collection contains no elements.
isEmpty() - Method in class com.mongodb.operation.BsonArrayWrapper
 
isEmpty() - Method in class org.bson.BsonArray
 
isEmpty() - Method in class org.bson.BsonDocument
 
isEmpty() - Method in class org.bson.BsonDocumentWrapper
 
isEmpty() - Method in class org.bson.codecs.configuration.Optional
 
isEmpty() - Method in class org.bson.codecs.configuration.Optional.Some
 
isEmpty() - Method in class org.bson.Document
 
isEmpty() - Method in class org.bson.LazyBSONObject
Gets whether this is an empty BSONObject.
isEmpty() - Method in class org.bson.RawBsonDocument
 
isEmpty() - Method in class org.bson.types.StringRangeSet
 
isEmpty() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
isEmpty() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
isEmpty() - Method in class org.bson.util.ClassMap
As per java.util.Map, returns true if this map contains no key-value mappings.
isEmpty() - Method in class org.bson.util.ComputingMap
 
isEnabled() - Method in class com.mongodb.connection.SslSettings
Returns whether SSL is enabled.
isEnabled(Level) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
isEnabled(Level) - Method in class org.bson.diagnostics.JULLogger
 
isEncodingCollectibleDocument(boolean) - Method in class org.bson.codecs.EncoderContext.Builder
Set to true if the the value to be encoded is a document that will be put in a MongoDB collection.
isEncodingCollectibleDocument() - Method in class org.bson.codecs.EncoderContext
Returns true if the the value to be encoded is a document that will be put in a MongoDB collection.
isErrorEnabled() - Method in class com.mongodb.diagnostics.logging.JULLogger
 
isErrorEnabled() - Method in interface com.mongodb.diagnostics.logging.Logger
Is the logger instance enabled for the ERROR level?
isErrorEnabled() - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
isErrorEnabled() - Method in class org.bson.diagnostics.JULLogger
 
isErrorEnabled() - Method in interface org.bson.diagnostics.Logger
Is the logger instance enabled for the ERROR level?
isErrorEnabled() - Method in class org.bson.diagnostics.SLF4JLogger
 
isExplain() - Method in class com.mongodb.operation.FindOperation
 
isExplainEvent - Variable in class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
isFinite() - Method in class org.bson.types.Decimal128
Returns true if this Decimal128 is finite.
isFsync() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the "fsync" value of the global WriteConcern.
isGetter(Method) - Static method in class org.bson.codecs.pojo.PropertyReflectionUtils
 
isHeader() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns true if this is a header node.
isIncompatiblyNewerThanDriver() - Method in class com.mongodb.connection.ServerDescription
Return whether the server is compatible with the driver.
isIncompatiblyOlderThanDriver() - Method in class com.mongodb.connection.ServerDescription
Return whether the server is compatible with the driver.
isIndent() - Method in class org.bson.json.JsonWriterSettings
The indentation mode.
isIndent() - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings
The indentation mode.
isInfinite() - Method in class org.bson.types.Decimal128
Returns true if this Decimal128 is infinite.
isInfoEnabled() - Method in class com.mongodb.diagnostics.logging.JULLogger
 
isInfoEnabled() - Method in interface com.mongodb.diagnostics.logging.Logger
Is the logger instance enabled for the INFO level?
isInfoEnabled() - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
isInfoEnabled() - Method in class org.bson.diagnostics.JULLogger
 
isInfoEnabled() - Method in interface org.bson.diagnostics.Logger
Is the logger instance enabled for the INFO level?
isInfoEnabled() - Method in class org.bson.diagnostics.SLF4JLogger
 
isInline(ConnectionDescription) - Method in class com.mongodb.operation.AggregateOperation
 
isInt32(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonInt32, returns false if the document does not contain the key.
isInt32() - Method in class org.bson.BsonValue
Returns true if this is a BsonInt32, false otherwise.
isInt64(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonInt64, returns false if the document does not contain the key.
isInt64() - Method in class org.bson.BsonValue
Returns true if this is a BsonInt64, false otherwise.
isInvalidHostNameAllowed() - Method in class com.mongodb.connection.SslSettings
Returns whether invalid host names should be allowed.
isJ() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the "j" value of the global WriteConcern.
isJavaScript() - Method in class org.bson.BsonValue
Returns true if this is a BsonJavaScript, false otherwise.
isJavaScriptWithScope() - Method in class org.bson.BsonValue
Returns true if this is a BsonJavaScriptWithScope, false otherwise.
isJsMode() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets the flag that specifies whether to convert intermediate data into BSON format between the execution of the map and reduce functions.
isJsMode() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets the flag that specifies whether to convert intermediate data into BSON format between the execution of the map and reduce functions.
isKeepAlive() - Method in class com.mongodb.connection.SocketSettings
Deprecated.
configuring keep-alive has been deprecated. It now defaults to true and disabling it is not recommended.
isLocked() - Method in class com.mongodb.Mongo
Returns true if the database is locked (read-only), false otherwise.
isMapOrCollection(Class<T>) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl
 
isMarker() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns true if this is a marker node.
isMaster(ServerAddress) - Method in class com.mongodb.ReplicaSetStatus
Checks to see if a given server is the primary server in this replica set.
isModifiedCountAvailable() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
isModifiedCountAvailable() - Method in class com.mongodb.bulk.BulkWriteResult
Returns true if the server was able to provide a count of modified documents.
isModifiedCountAvailable() - Method in class com.mongodb.BulkWriteResult
Returns true if the server was able to provide a count of modified documents.
isModifiedCountAvailable() - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
isModifiedCountAvailable() - Method in class com.mongodb.client.result.UpdateResult
Gets a value indicating whether the modified count is available.
isModifiedCountAvailable() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
isModifiedCountAvailable() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
isMulti - Variable in class com.mongodb.bulk.DeleteRequest
 
isMulti() - Method in class com.mongodb.bulk.DeleteRequest
Gets whether all documents matching the query filter will be removed.
isMulti - Variable in class com.mongodb.bulk.UpdateRequest
 
isMulti() - Method in class com.mongodb.bulk.UpdateRequest
Gets whether this update will update all documents matching the filter.
isMulti() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Gets whether all documents matching the query filter will be removed.
isMulti() - Method in class com.mongodb.RemoveRequest
 
isMulti() - Method in class com.mongodb.UpdateRequest
 
isNamespaceError(Throwable) - Static method in class com.mongodb.operation.CommandOperationHelper
 
isNaN() - Method in class org.bson.types.Decimal128
Returns true if this Decimal128 is Not-A-Number (NaN).
isNegative() - Method in class org.bson.types.Decimal128
Returns true if this Decimal128 is negative.
isNetty(String) - Static method in class com.mongodb.async.client.MongoClients
 
isNio2(String) - Static method in class com.mongodb.async.client.MongoClients
 
isNoCursorTimeout() - Method in class com.mongodb.client.model.DBCollectionFindOptions
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
isNoCursorTimeout() - Method in class com.mongodb.client.model.FindOptions
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
isNoCursorTimeout() - Method in class com.mongodb.connection.BaseQueryMessage
Returns true if cursor timeout has been turned off.
isNoCursorTimeout() - Method in class com.mongodb.connection.QueryProtocol
Returns true if cursor timeout has been turned off.
isNoCursorTimeout() - Method in class com.mongodb.operation.FindOperation
Returns true if cursor timeout has been turned off.
isNonAtomic() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
True if the post-processing step will prevent MongoDB from locking the database.
isNotAlreadyPrimary(ServerAddress) - Method in class com.mongodb.connection.MultiServerCluster
 
isNull(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonNull, returns false if the document does not contain the key.
isNull() - Method in class org.bson.BsonValue
Returns true if this is a BsonNull, false otherwise.
isNumber(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonNumber, returns false if the document does not contain the key.
isNumber() - Method in class org.bson.BsonValue
Returns true if this is a BsonNumber, false otherwise.
isObjectId(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonObjectId, returns false if the document does not contain the key.
isObjectId() - Method in class org.bson.BsonValue
Returns true if this is an BsonObjectId, false otherwise.
isOk() - Method in class com.mongodb.connection.ServerDescription
The isOK() result from requesting this information from the server
isOplogReplay() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Users should not set this under normal circumstances.
isOplogReplay() - Method in class com.mongodb.client.model.FindOptions
Users should not set this under normal circumstances.
isOplogReplay() - Method in class com.mongodb.connection.BaseQueryMessage
Internal replication use only.
isOplogReplay() - Method in class com.mongodb.connection.QueryProtocol
Internal replication use only.
isOplogReplay() - Method in class com.mongodb.operation.FindOperation
Internal replication use only.
isOrdered() - Method in class com.mongodb.BulkWriteOperation
Returns true if this is building an ordered bulk write request.
isOrdered() - Method in class com.mongodb.client.model.BulkWriteOptions
If true, then when a write fails, return without performing the remaining writes.
isOrdered() - Method in class com.mongodb.client.model.InsertManyOptions
Gets whether the documents should be inserted in the order provided, stopping on the first failed insertion.
isOrdered() - Method in class com.mongodb.connection.WriteProtocol
Gets whether the writes are ordered.
isOrdered() - Method in class com.mongodb.operation.BaseWriteOperation
Gets whether the writes are ordered.
isOrdered() - Method in class com.mongodb.operation.MixedBulkWriteOperation
Gets whether the writes are ordered.
isPartial() - Method in class com.mongodb.client.model.DBCollectionFindOptions
Get partial results from a sharded cluster if one or more shards are unreachable (instead of throwing an error).
isPartial() - Method in class com.mongodb.client.model.FindOptions
Get partial results from a sharded cluster if one or more shards are unreachable (instead of throwing an error).
isPartial() - Method in class com.mongodb.connection.BaseQueryMessage
Returns true if can get partial results from a mongos if some shards are down.
isPartial() - Method in class com.mongodb.connection.QueryProtocol
Returns true if can get partial results from a mongos if some shards are down.
isPartial - Variable in class com.mongodb.LazyDBList
 
isPartial - Variable in class com.mongodb.LazyDBObject
 
isPartial() - Method in class com.mongodb.operation.FindOperation
Returns true if can get partial results from a mongos if some shards are down.
isPartialObject() - Method in class com.mongodb.BasicDBList
 
isPartialObject - Variable in class com.mongodb.BasicDBObject
 
isPartialObject() - Method in class com.mongodb.BasicDBObject
Whether BasicDBObject.markAsPartialObject() was ever called only matters if you are going to upsert and do not want to risk losing fields.
isPartialObject() - Method in interface com.mongodb.DBObject
Whether DBObject.markAsPartialObject() was ever called only matters if you are going to upsert and do not want to risk losing fields.
isPartialObject() - Method in class com.mongodb.gridfs.GridFSFile
 
isPartialObject() - Method in class com.mongodb.LazyDBList
 
isPartialObject() - Method in class com.mongodb.LazyDBObject
 
isPartialObject() - Method in class com.mongodb.ReflectionDBObject
 
isPreserveNullAndEmptyArrays() - Method in class com.mongodb.client.model.UnwindOptions
If true the unwind stage will include documents that have null values or empty arrays
isPrimary() - Method in class com.mongodb.connection.ServerDescription
Returns whether this can be treated as a primary server.
isProcessing - Variable in class com.mongodb.async.client.AbstractSubscription
 
isPublicAndNotStaticOrTransient(int) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
isQueryFailure() - Method in class com.mongodb.connection.ReplyHeader
Gets whether the query failed or not.
isReadable() - Method in class org.bson.codecs.pojo.PropertyModel
Property is readable.
isReadable() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Property is readable.
isReading - Variable in class com.mongodb.async.client.MongoIterableSubscription
 
isReadOnly() - Method in class com.mongodb.operation.CreateUserOperation
Returns true if the user is a readOnly user.
isReadOnly() - Method in class com.mongodb.operation.UpdateUserOperation
Returns true if the user is a readOnly user.
isReflectionDBObject(Class<? extends DBObject>) - Method in class com.mongodb.DBCollectionObjectFactory
 
isRegularExpression() - Method in class org.bson.BsonValue
Returns true if this is a BsonRegularExpression, false otherwise.
isRemove() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the remove
isReplicaSetMember(BsonDocument) - Static method in class com.mongodb.connection.DescriptionHelper
 
isReplicaSetMember() - Method in class com.mongodb.connection.ServerDescription
Gets whether this server is a replica set member.
isResponseExpected() - Method in class com.mongodb.connection.CommandMessage
 
isRetryable(WriteRequest) - Static method in class com.mongodb.operation.BulkWriteBatch
 
isRetryableException(Throwable) - Static method in class com.mongodb.operation.CommandOperationHelper
 
isRetryableWrite(boolean, WriteConcern, ServerDescription, ConnectionDescription) - Static method in class com.mongodb.operation.OperationHelper
 
isReturnKey() - Method in class com.mongodb.client.model.FindOptions
Returns the returnKey.
isReturnKey() - Method in class com.mongodb.operation.FindOperation
Returns the returnKey.
isReturnOriginal() - Method in class com.mongodb.operation.FindAndReplaceOperation
When false, returns the replaced document rather than the original.
isReturnOriginal() - Method in class com.mongodb.operation.FindAndUpdateOperation
When false, returns the updated document rather than the original.
isSafe() - Method in class com.mongodb.MongoOptions
Deprecated.
Returns whether the driver will use a WriteConcern of WriteConcern.ACKNOWLEDGED for all operations.
isSecondary() - Method in class com.mongodb.connection.ServerDescription
Returns whether this can be treated as a secondary server.
isSerializable() - Method in class org.bson.codecs.pojo.PropertyMetadata
 
isServerDefault() - Method in class com.mongodb.ReadConcern
 
isServerDefault() - Method in class com.mongodb.WriteConcern
Gets whether this write concern indicates that the server's default write concern will be used.
isServerVersionAtLeastThreeDotSix(MessageSettings) - Static method in class com.mongodb.connection.CommandMessage
 
isSetter(Method) - Static method in class org.bson.codecs.pojo.PropertyReflectionUtils
 
isSharded() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
True if the output database is sharded
isShardRouter() - Method in class com.mongodb.connection.ServerDescription
Gets whether this is a server that is the entry point to a sharded instance of MongoDB.
isShowRecordId() - Method in class com.mongodb.client.model.FindOptions
Returns the showRecordId.
isShowRecordId() - Method in class com.mongodb.operation.FindOperation
Returns the showRecordId.
isSlaveOk() - Method in class com.mongodb.connection.BaseQueryMessage
Returns true if set to allowed to query non-primary replica set members.
isSlaveOk() - Method in class com.mongodb.connection.CommandMessage
 
isSlaveOk() - Method in class com.mongodb.connection.QueryProtocol
Returns true if set to allowed to query non-primary replica set members.
isSlaveOk() - Method in class com.mongodb.operation.FindOperation
Returns true if set to allowed to query non-primary replica set members.
isSlaveOk() - Method in class com.mongodb.ReadPreference
True if this read preference allows reading from a secondary member of a replica set.
isSlaveOk() - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
isSlaveOk() - Method in class com.mongodb.TaggableReadPreference
 
isSnapshot() - Method in class com.mongodb.client.model.FindOptions
Returns the snapshot.
isSnapshot() - Method in class com.mongodb.operation.FindOperation
Returns the snapshot.
isSocketKeepAlive() - Method in class com.mongodb.MongoClientOptions
Deprecated.
configuring keep-alive has been deprecated. It now defaults to true and disabling it is not recommended.
isSocketKeepAlive() - Method in class com.mongodb.MongoOptions
Deprecated.
Gets the flag that controls the socket keep alive feature that keeps a connection alive through firewalls.
isSparse() - Method in class com.mongodb.bulk.IndexRequest
If true, the index only references documents with the specified field
isSparse() - Method in class com.mongodb.client.model.IndexOptions
If true, the index only references documents with the specified field
isSpecial() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns true if this is a header, trailer, or marker node.
isSslEnabled() - Method in class com.mongodb.MongoClientOptions
Whether to use SSL.
isSslInvalidHostNameAllowed() - Method in class com.mongodb.MongoClientOptions
Returns whether invalid host names should be allowed if SSL is enabled.
isStackEmpty() - Method in class org.bson.BasicBSONCallback
Returns whether this is the top level or not
isStalePrimary(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
isStandAlone() - Method in class com.mongodb.connection.ServerDescription
Gets whether this is part of a replica set/sharded system, or is a single server.
isString(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonString, returns false if the document does not contain the key.
isString() - Method in class org.bson.BsonValue
Returns true if this is a BsonString, false otherwise.
isSymbol() - Method in class org.bson.BsonValue
Returns true if this is a BsonSymbol, false otherwise.
isTailable() - Method in enum com.mongodb.CursorType
True if the cursor type is tailable.
isTailableCursor() - Method in class com.mongodb.connection.BaseQueryMessage
Gets whether the cursor is configured to be a tailable cursor.
isTailableCursor() - Method in class com.mongodb.connection.QueryProtocol
Gets whether the cursor is configured to be a tailable cursor.
isTailableCursor() - Method in class com.mongodb.operation.FindOperation
 
isTerminated - Variable in class com.mongodb.async.client.AbstractSubscription
 
isTerminated() - Method in class com.mongodb.async.client.AbstractSubscription
 
isTimestamp(Object) - Method in class org.bson.BsonDocument
Returns true if the value of the key is a BsonTimestamp, returns false if the document does not contain the key.
isTimestamp() - Method in class org.bson.BsonValue
Returns true if this is a BsonTimestamp, false otherwise.
isTopLevelDocument() - Method in class org.bson.BasicBSONEncoder
 
isTraceEnabled() - Method in class com.mongodb.diagnostics.logging.JULLogger
 
isTraceEnabled() - Method in interface com.mongodb.diagnostics.logging.Logger
Is the logger instance enabled for the TRACE level?
isTraceEnabled() - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
isTraceEnabled() - Method in class org.bson.diagnostics.JULLogger
 
isTraceEnabled() - Method in interface org.bson.diagnostics.Logger
Is the logger instance enabled for the TRACE level?
isTraceEnabled() - Method in class org.bson.diagnostics.SLF4JLogger
 
isTrailer() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns true if this is a trailer node.
isTrue(String, boolean) - Static method in class com.mongodb.assertions.Assertions
Throw IllegalStateException if the condition if false.
isTrue(String, boolean, SingleResultCallback<?>) - Static method in class com.mongodb.assertions.Assertions
Throw IllegalStateException if the condition if false.
isTrue(String, boolean) - Static method in class org.bson.assertions.Assertions
Throw IllegalStateException if the condition if false.
isTrueArgument(String, boolean) - Static method in class com.mongodb.assertions.Assertions
Throw IllegalArgumentException if the condition if false.
isTrueArgument(String, boolean) - Static method in class org.bson.assertions.Assertions
Throw IllegalArgumentException if the condition if false.
isUnique() - Method in class com.mongodb.bulk.IndexRequest
Gets if the index should be unique.
isUnique() - Method in class com.mongodb.client.model.IndexOptions
Gets if the index should be unique.
isUnsubscribed - Variable in class com.mongodb.async.client.AbstractSubscription
 
isUnsubscribed() - Method in class com.mongodb.async.client.AbstractSubscription
 
isUnsubscribed() - Method in interface com.mongodb.async.client.Subscription
Indicates whether this Subscription is currently unsubscribed.
isUnwrapped() - Method in class org.bson.BsonDocumentWrapper
Determine whether the document has been unwrapped already.
isUpdateOfExisting() - Method in class com.mongodb.WriteConcernResult
Returns true if the write was an update of an existing document.
isUpdateOfExisting() - Method in class com.mongodb.WriteResult
Returns true if this write resulted in an update of an existing document.
isUpsert - Variable in class com.mongodb.bulk.UpdateRequest
 
isUpsert() - Method in class com.mongodb.bulk.UpdateRequest
Gets whether this update will insert a new document if no documents match the filter.
isUpsert() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the upsert
isUpsert() - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Returns true if a new document should be inserted if there are no matches to the query filter.
isUpsert() - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Returns true if a new document should be inserted if there are no matches to the query filter.
isUpsert() - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Returns true if a new document should be inserted if there are no matches to the query filter.
isUpsert() - Method in class com.mongodb.client.model.UpdateOptions
Returns true if a new document should be inserted if there are no matches to the query filter.
isUpsert() - Method in class com.mongodb.operation.FindAndReplaceOperation
Returns true if a new document should be inserted if there are no matches to the query filter.
isUpsert() - Method in class com.mongodb.operation.FindAndUpdateOperation
Returns true if a new document should be inserted if there are no matches to the query filter.
isUpsert() - Method in class com.mongodb.ReplaceRequest
 
isUpsert() - Method in class com.mongodb.UpdateRequest
 
isUsePowerOf2Sizes() - Method in class com.mongodb.client.model.CreateCollectionOptions
Deprecated.
As of MongoDB 3.0, power of 2 sizes is ignored by the MongoDB server
isUsePowerOf2Sizes() - Method in class com.mongodb.operation.CreateCollectionOperation
Deprecated.
As of MongoDB 3.0, power of 2 sizes is ignored by the MongoDB server
isUuid(byte) - Static method in enum org.bson.BsonBinarySubType
Returns true if the given value is a UUID subtype
isValid(String) - Static method in class org.bson.types.ObjectId
Checks if a string could be an ObjectId.
isVerbose() - Method in class com.mongodb.MapReduceCommand
Gets the verbosity of the MapReduce job.
isVerbose() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Gets whether to include the timing information in the result information.
isVerbose() - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Gets whether to include the timing information in the result information.
isWarnEnabled() - Method in class com.mongodb.diagnostics.logging.JULLogger
 
isWarnEnabled() - Method in interface com.mongodb.diagnostics.logging.Logger
Is the logger instance enabled for the WARN level?
isWarnEnabled() - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
isWarnEnabled() - Method in class org.bson.diagnostics.JULLogger
 
isWarnEnabled() - Method in interface org.bson.diagnostics.Logger
Is the logger instance enabled for the WARN level?
isWarnEnabled() - Method in class org.bson.diagnostics.SLF4JLogger
 
isWritable() - Method in class org.bson.codecs.pojo.PropertyModel
Property is writable.
isWritable() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Property is writable.
isWriting - Variable in class com.mongodb.connection.netty.NettyByteBuf
 
itcount() - Method in class com.mongodb.DBCursor
For testing only! Iterates cursor and counts objects
itemFactory - Variable in class com.mongodb.internal.connection.ConcurrentPool
 
iterable - Variable in class com.mongodb.async.client.MappingIterable
 
iterable - Variable in class com.mongodb.MappingIterable
 
IterableCodec - Class in org.bson.codecs
Encodes and decodes Iterable objects.
IterableCodec(CodecRegistry, BsonTypeClassMap) - Constructor for class org.bson.codecs.IterableCodec
Construct a new instance with the given CodecRegistry and BsonTypeClassMap.
IterableCodec(CodecRegistry, BsonTypeClassMap, Transformer) - Constructor for class org.bson.codecs.IterableCodec
Construct a new instance with the given CodecRegistry and BsonTypeClassMap.
IterableCodecProvider - Class in org.bson.codecs
A CodecProvider for classes than implement the Iterable interface.
IterableCodecProvider() - Constructor for class org.bson.codecs.IterableCodecProvider
Construct a new instance with a default BsonTypeClassMap and no Transformer.
IterableCodecProvider(Transformer) - Constructor for class org.bson.codecs.IterableCodecProvider
Construct a new instance with a default BsonTypeClassMap and the given Transformer.
IterableCodecProvider(BsonTypeClassMap) - Constructor for class org.bson.codecs.IterableCodecProvider
Construct a new instance with the given instance of BsonTypeClassMap and no Transformer.
IterableCodecProvider(BsonTypeClassMap, Transformer) - Constructor for class org.bson.codecs.IterableCodecProvider
Construct a new instance with the given instance of BsonTypeClassMap and Transformer.
IterableOperatorFilter(String, String, Iterable<TItem>) - Constructor for class com.mongodb.client.model.Filters.IterableOperatorFilter
 
IterableSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.IterableSerializer
Deprecated.
 
iterator() - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
iterator() - Method in interface com.mongodb.client.MongoIterable
 
iterator() - Method in class com.mongodb.DBCursor
Creates a copy of this cursor object that can be iterated.
iterator() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns an iterator over the elements in this deque in proper sequence.
iterator() - Method in class com.mongodb.MappingIterable
 
iterator() - Method in class com.mongodb.MongoIterableImpl
 
iterator() - Method in class com.mongodb.operation.BsonArrayWrapper
 
iterator() - Method in class com.mongodb.TagSet
 
iterator() - Method in class org.bson.BsonArray
 
iterator() - Method in class org.bson.LazyBSONList
 
iterator() - Method in class org.bson.types.StringRangeSet
 
iterator() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
iteratorOrArray - Variable in class com.mongodb.DBCursor
 
IteratorOrArray() - Constructor for enum com.mongodb.DBCursor.IteratorOrArray
 

J

j - Variable in class com.mongodb.MongoOptions
Deprecated.
The "j" value of the global WriteConcern.
Java8DateTimeFormatter() - Constructor for class org.bson.json.DateTimeFormatter.Java8DateTimeFormatter
 
Java8SniSslHelper - Class in com.mongodb.internal.connection
 
Java8SniSslHelper() - Constructor for class com.mongodb.internal.connection.Java8SniSslHelper
 
JAVA_SASL_CLIENT_PROPERTIES_KEY - Static variable in class com.mongodb.MongoCredential
Mechanism property key for overriding the SaslClient properties for GSSAPI authentication.
JAVA_SUBJECT_KEY - Static variable in class com.mongodb.MongoCredential
Mechanism property key for overriding the Subject under which GSSAPI authentication executes.
javaFlag - Variable in enum org.bson.codecs.PatternCodec.RegexFlag
 
javaScriptConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
javaScriptConverter(Converter<String>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON JavaScript values to JSON.
javaScriptConverter - Variable in class org.bson.json.JsonWriterSettings
 
JavaWrapper(Class) - Constructor for class com.mongodb.ReflectionDBObject.JavaWrapper
 
JaxbDateTimeFormatter() - Constructor for class org.bson.json.DateTimeFormatter.JaxbDateTimeFormatter
 
JMXConnectionPoolListener - Class in com.mongodb.management
A connection pool listener that manages a set of JMX MBeans, one for each connection pool.
JMXConnectionPoolListener() - Constructor for class com.mongodb.management.JMXConnectionPoolListener
 
JMXMBeanServer - Class in com.mongodb.internal.management.jmx
This class is NOT part of the public API.
JMXMBeanServer() - Constructor for class com.mongodb.internal.management.jmx.JMXMBeanServer
 
join(String, Collection<?>) - Static method in class org.bson.StringUtils
 
journal - Variable in class com.mongodb.WriteConcern
 
JOURNAL_SAFE - Static variable in class com.mongodb.WriteConcern
Deprecated.
JOURNALED - Static variable in class com.mongodb.WriteConcern
Write operations wait for the server to group commit to the journal file on disk.
jsMode(boolean) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the flag that specifies whether to convert intermediate data into BSON format between the execution of the map and reduce functions.
jsMode - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
jsMode(boolean) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
jsMode(boolean) - Method in interface com.mongodb.client.MapReduceIterable
Sets the flag that specifies whether to convert intermediate data into BSON format between the execution of the map and reduce functions.
jsMode - Variable in class com.mongodb.MapReduceCommand
 
jsMode - Variable in class com.mongodb.MapReduceIterableImpl
 
jsMode(boolean) - Method in class com.mongodb.MapReduceIterableImpl
 
jsMode - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
jsMode(boolean) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the flag that specifies whether to convert intermediate data into BSON format between the execution of the map and reduce functions.
jsMode - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
jsMode(boolean) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the flag that specifies whether to convert intermediate data into BSON format between the execution of the map and reduce functions.
JSON - Class in com.mongodb.util
Deprecated.
This class has been superseded by to toJson and parse methods on BasicDBObject
JSON() - Constructor for class com.mongodb.util.JSON
Deprecated.
 
JSON_BOOLEAN_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
JSON_DOUBLE_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
JSON_INT_32_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
JSON_NULL_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
JSON_STRING_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
JSON_SYMBOL_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
JsonBooleanConverter - Class in org.bson.json
 
JsonBooleanConverter() - Constructor for class org.bson.json.JsonBooleanConverter
 
JsonBuffer - Class in org.bson.json
 
JsonBuffer(String) - Constructor for class org.bson.json.JsonBuffer
 
JSONCallback - Class in com.mongodb.util
Deprecated.
This class has been superseded by to toJson and parse methods on BasicDBObject
JSONCallback() - Constructor for class com.mongodb.util.JSONCallback
Deprecated.
 
JsonContextType() - Constructor for enum org.bson.json.StrictCharacterStreamJsonWriter.JsonContextType
 
JsonDoubleConverter - Class in org.bson.json
 
JsonDoubleConverter() - Constructor for class org.bson.json.JsonDoubleConverter
 
JsonInt32Converter - Class in org.bson.json
 
JsonInt32Converter() - Constructor for class org.bson.json.JsonInt32Converter
 
JsonJavaScriptConverter - Class in org.bson.json
 
JsonJavaScriptConverter() - Constructor for class org.bson.json.JsonJavaScriptConverter
 
JsonMode - Enum in org.bson.json
An enumeration of the supported output modes of JSONWriter.
JsonMode() - Constructor for enum org.bson.json.JsonMode
 
JsonNullConverter - Class in org.bson.json
 
JsonNullConverter() - Constructor for class org.bson.json.JsonNullConverter
 
JSONParseException - Exception in com.mongodb.util
Exception that is thrown when invalid JSON is encountered by the parser.
JSONParseException(String, int) - Constructor for exception com.mongodb.util.JSONParseException
Creates a new instance.
JSONParseException(String, int, Throwable) - Constructor for exception com.mongodb.util.JSONParseException
Creates a new instance.
JsonParseException - Exception in org.bson.json
JSONParseException indicates some exception happened during JSON processing.
JsonParseException() - Constructor for exception org.bson.json.JsonParseException
Constructs a new runtime exception with null as its detail message.
JsonParseException(String) - Constructor for exception org.bson.json.JsonParseException
Constructs a new runtime exception with the specified detail message.
JsonParseException(String, Object...) - Constructor for exception org.bson.json.JsonParseException
Constructs a new runtime exception with string formatted using specified pattern and arguments.
JsonParseException(Throwable) - Constructor for exception org.bson.json.JsonParseException
Create a JSONParseException with the given Throwable cause.
JSONParser - Class in com.mongodb.util
Parser for JSON objects.
JSONParser(String) - Constructor for class com.mongodb.util.JSONParser
 
JSONParser(String, BSONCallback) - Constructor for class com.mongodb.util.JSONParser
 
JsonReader - Class in org.bson.json
Reads a JSON in one of the following modes: Strict mode that conforms to the JSON RFC specifications. JavaScript mode that that most JavaScript interpreters can process Shell mode that the mongo shell can process.
JsonReader(String) - Constructor for class org.bson.json.JsonReader
Constructs a new instance with the given JSON string.
JsonReader.Context - Class in org.bson.json
 
JsonReader.Mark - Class in org.bson.json
 
JsonScanner - Class in org.bson.json
Parses the string representation of a JSON object into a set of JsonToken-derived objects.
JsonScanner(JsonBuffer) - Constructor for class org.bson.json.JsonScanner
 
JsonScanner(String) - Constructor for class org.bson.json.JsonScanner
 
JsonScanner.NumberState - Enum in org.bson.json
 
JsonScanner.RegularExpressionState - Enum in org.bson.json
 
jsonSchema(Bson) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents that validate against the given JSON schema document.
JSONSerializers - Class in com.mongodb.util
Deprecated.
This class has been superseded by to toJson and parse methods on BasicDBObject
JSONSerializers() - Constructor for class com.mongodb.util.JSONSerializers
Deprecated.
 
JSONSerializers.BinarySerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.BinarySerializerBase - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.BSONTimestampSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.ByteArraySerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.CodeSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.CodeWScopeSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.CompoundObjectSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.DateSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.DBObjectSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.DBRefBaseSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.Decimal128Serializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.IterableSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.LegacyBinarySerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.LegacyBSONTimestampSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.LegacyDateSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.MapSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.MaxKeySerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.MinKeySerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.ObjectArraySerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.ObjectIdSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.PatternSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.StringSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.SymbolSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.ToStringSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.UndefinedSerializer - Class in com.mongodb.util
Deprecated.
 
JSONSerializers.UuidSerializer - Class in com.mongodb.util
Deprecated.
 
jsonString - Variable in exception com.mongodb.util.JSONParseException
 
JsonStringConverter - Class in org.bson.json
 
JsonStringConverter() - Constructor for class org.bson.json.JsonStringConverter
 
JsonSymbolConverter - Class in org.bson.json
 
JsonSymbolConverter() - Constructor for class org.bson.json.JsonSymbolConverter
 
JsonToken - Class in org.bson.json
A JSON token.
JsonToken(JsonTokenType, Object) - Constructor for class org.bson.json.JsonToken
 
JsonTokenType - Enum in org.bson.json
 
JsonTokenType() - Constructor for enum org.bson.json.JsonTokenType
 
JsonWriter - Class in org.bson.json
A BsonWriter implementation that outputs a JSON representation of BSON.
JsonWriter(Writer) - Constructor for class org.bson.json.JsonWriter
Creates a new instance which uses writer to write JSON to.
JsonWriter(Writer, JsonWriterSettings) - Constructor for class org.bson.json.JsonWriter
Creates a new instance which uses writer to write JSON to and uses the given settings.
JsonWriter.Context - Class in org.bson.json
The context for the writer, inheriting all the values from AbstractBsonWriter.Context, and additionally providing settings for the indentation level and whether there are any child elements at this level.
JsonWriterSettings - Class in org.bson.json
Settings to control the behavior of a JSONWriter instance.
JsonWriterSettings() - Constructor for class org.bson.json.JsonWriterSettings
Deprecated.
Prefer JsonWriterSettings.builder(), but note that the default output mode is different for that method
JsonWriterSettings(JsonMode) - Constructor for class org.bson.json.JsonWriterSettings
Deprecated.
JsonWriterSettings(boolean) - Constructor for class org.bson.json.JsonWriterSettings
Deprecated.
JsonWriterSettings(JsonMode, boolean) - Constructor for class org.bson.json.JsonWriterSettings
Deprecated.
JsonWriterSettings(JsonMode, String) - Constructor for class org.bson.json.JsonWriterSettings
Deprecated.
JsonWriterSettings(JsonMode, String, String) - Constructor for class org.bson.json.JsonWriterSettings
Deprecated.
JsonWriterSettings(JsonWriterSettings.Builder) - Constructor for class org.bson.json.JsonWriterSettings
 
JsonWriterSettings.Builder - Class in org.bson.json
A builder for JsonWriterSettings
JULLogger - Class in com.mongodb.diagnostics.logging
 
JULLogger(String) - Constructor for class com.mongodb.diagnostics.logging.JULLogger
 
JULLogger - Class in org.bson.diagnostics
 
JULLogger(String) - Constructor for class org.bson.diagnostics.JULLogger
 

K

keepAlive - Variable in class com.mongodb.connection.SocketSettings.Builder
 
keepAlive(boolean) - Method in class com.mongodb.connection.SocketSettings.Builder
Deprecated.
configuring keep-alive has been deprecated. It now defaults to true and disabling it is not recommended.
keepAlive - Variable in class com.mongodb.connection.SocketSettings
 
key - Variable in class com.mongodb.operation.GroupOperation
 
key(BsonDocument) - Method in class com.mongodb.operation.GroupOperation
Sets the document containing the field or fields to group.
keyf - Variable in class com.mongodb.GroupCommand
 
keyFunction - Variable in class com.mongodb.operation.GroupOperation
 
keyFunction(BsonJavaScript) - Method in class com.mongodb.operation.GroupOperation
Sets the function that creates a "key object" for use as the grouping key.
keys - Variable in class com.mongodb.bulk.IndexRequest
 
keys - Variable in class com.mongodb.client.model.IndexModel
 
keys - Variable in class com.mongodb.GroupCommand
 
keys - Variable in class com.mongodb.ReflectionDBObject.JavaWrapper
 
keys() - Method in class org.bson.codecs.BsonTypeClassMap
 
keySet() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
keySet() - Method in class com.mongodb.gridfs.GridFSFile
 
keySet() - Method in class com.mongodb.ReflectionDBObject.JavaWrapper
Gets all the fields on this object.
keySet() - Method in class com.mongodb.ReflectionDBObject
 
keySet() - Method in class org.bson.BsonDocument
 
keySet() - Method in class org.bson.BsonDocumentWrapper
 
keySet() - Method in interface org.bson.BSONObject
Returns this object's fields' names
keySet() - Method in class org.bson.Document
 
keySet() - Method in class org.bson.LazyBSONObject
 
keySet() - Method in class org.bson.RawBsonDocument
 
keySet() - Method in class org.bson.types.BasicBSONList
 
keySet() - Method in class org.bson.util.AbstractCopyOnWriteMap.Immutable
 
keySet() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
KeySet() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.KeySet
 
keySet - Variable in class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
keySet() - Method in class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
keySet() - Method in class org.bson.util.AbstractCopyOnWriteMap.View
 
keySet() - Method in class org.bson.util.ComputingMap
 
keysIntersect(BsonDocument, BsonDocument) - Method in class com.mongodb.client.model.Filters.AndFilter
 
killCursor(List<Long>) - Method in interface com.mongodb.connection.Connection
killCursor(MongoNamespace, List<Long>) - Method in interface com.mongodb.connection.Connection
Kills the given list of cursors.
killCursor(List<Long>) - Method in class com.mongodb.connection.DefaultServerConnection
 
killCursor(MongoNamespace, List<Long>) - Method in class com.mongodb.connection.DefaultServerConnection
 
killCursor(AsyncConnection) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
killCursor() - Method in class com.mongodb.operation.QueryBatchCursor
 
killCursor(Connection) - Method in class com.mongodb.operation.QueryBatchCursor
 
killCursorAsync(List<Long>, SingleResultCallback<Void>) - Method in interface com.mongodb.connection.AsyncConnection
killCursorAsync(MongoNamespace, List<Long>, SingleResultCallback<Void>) - Method in interface com.mongodb.connection.AsyncConnection
Asynchronously Kills the given list of cursors.
killCursorAsync(List<Long>, SingleResultCallback<Void>) - Method in class com.mongodb.connection.DefaultServerConnection
 
killCursorAsync(MongoNamespace, List<Long>, SingleResultCallback<Void>) - Method in class com.mongodb.connection.DefaultServerConnection
 
killCursorAsynchronouslyAndReleaseConnectionAndSource(AsyncConnection, ServerCursor) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
killCursorOnClose() - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
KillCursorProtocol - Class in com.mongodb.connection
An implementation of the OP_KILL_CURSOR protocol.
KillCursorProtocol(MongoNamespace, List<Long>) - Constructor for class com.mongodb.connection.KillCursorProtocol
 
KillCursorsMessage - Class in com.mongodb.connection
An OP_KILL_CURSOR message.
KillCursorsMessage(List<Long>) - Constructor for class com.mongodb.connection.KillCursorsMessage
 

L

language - Variable in class com.mongodb.client.model.TextSearchOptions
 
language(String) - Method in class com.mongodb.client.model.TextSearchOptions
Set the language for the text search
LANGUAGE - Static variable in class com.mongodb.QueryOperators
 
languageOverride - Variable in class com.mongodb.bulk.IndexRequest
 
languageOverride(String) - Method in class com.mongodb.bulk.IndexRequest
Sets the name of the field that contains the language string.
languageOverride - Variable in class com.mongodb.client.model.IndexOptions
 
languageOverride(String) - Method in class com.mongodb.client.model.IndexOptions
Sets the name of the field that contains the language string.
last(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 last member of the group.
last - Variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
LAST_MS_OF_YEAR_9999 - Static variable in class org.bson.json.RelaxedExtendedJsonDateTimeConverter
 
lastIndexOf(Object) - Method in class com.mongodb.operation.BsonArrayWrapper
 
lastIndexOf(Object) - Method in class org.bson.BsonArray
 
lastIndexOf(Object) - Method in class org.bson.LazyBSONList
 
lastUpdateTimeNanos - Variable in class com.mongodb.connection.ServerDescription.Builder
 
lastUpdateTimeNanos(long) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the last update time for this description, which is simply the time that the server description was created.
lastUpdateTimeNanos - Variable in class com.mongodb.connection.ServerDescription
 
lastUsedAt - Variable in class com.mongodb.connection.UsageTrackingInternalConnection
 
lastUsedAtMillis - Variable in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
lastWriteDate - Variable in class com.mongodb.connection.ServerDescription.Builder
 
lastWriteDate(Date) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the lastWriteDate reported by this server
lastWriteDate - Variable in class com.mongodb.connection.ServerDescription
 
latch - Variable in class com.mongodb.connection.FutureAsyncCompletionHandler
 
latch - Variable in class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 
LatencyMinimizingServerSelector - Class in com.mongodb.selector
A server selector that accepts only servers within the given ping-time latency difference from the faster of the servers.
LatencyMinimizingServerSelector(long, TimeUnit) - Constructor for class com.mongodb.selector.LatencyMinimizingServerSelector
 
LazyBSONCallback - Class in org.bson
A BSONCallback for creation of LazyBSONObject and LazyBSONList instances.
LazyBSONCallback() - Constructor for class org.bson.LazyBSONCallback
 
LazyBSONDecoder - Class in org.bson
A decoder for LazyBSONObject instances.
LazyBSONDecoder() - Constructor for class org.bson.LazyBSONDecoder
 
LazyBSONList - Class in org.bson
A LazyBSONObject representing a BSON array.
LazyBSONList(byte[], LazyBSONCallback) - Constructor for class org.bson.LazyBSONList
Construct an instance with the given raw bytes and offset.
LazyBSONList(byte[], int, LazyBSONCallback) - Constructor for class org.bson.LazyBSONList
Construct an instance with the given raw bytes and offset.
LazyBSONList.LazyBSONListIterator - Class in org.bson
An iterator over the values in a LazyBsonList.
LazyBSONListIterator() - Constructor for class org.bson.LazyBSONList.LazyBSONListIterator
Construct an instance
LazyBSONObject - Class in org.bson
An immutable BSONObject backed by a byte buffer that lazily provides keys and values on request.
LazyBSONObject(byte[], LazyBSONCallback) - Constructor for class org.bson.LazyBSONObject
Construct an instance.
LazyBSONObject(byte[], int, LazyBSONCallback) - Constructor for class org.bson.LazyBSONObject
Construct an instance.
LazyCodec<T> - Class in org.bson.codecs.configuration
 
LazyCodec(CodecRegistry, Class<T>) - Constructor for class org.bson.codecs.configuration.LazyCodec
 
lazyCommandDocument - Variable in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
LazyCommandDocument(CommandMessage, ByteBufferBsonOutput) - Constructor for class com.mongodb.connection.InternalStreamConnection.LazyCommandDocument
 
LazyDBCallback - Class in com.mongodb
A BSONCallback for the creation of LazyDBObject and LazyDBList instances.
LazyDBCallback(DBCollection) - Constructor for class com.mongodb.LazyDBCallback
Construct an instance.
LazyDBDecoder - Class in com.mongodb
A decoder for LazyDBObject instances.
LazyDBDecoder() - Constructor for class com.mongodb.LazyDBDecoder
 
LazyDBEncoder - Class in com.mongodb
Encoder that only knows how to encode BSONObject instances of type LazyDBObject.
LazyDBEncoder() - Constructor for class com.mongodb.LazyDBEncoder
 
LazyDBList - Class in com.mongodb
A LazyDBObject representing a BSON array.
LazyDBList(byte[], LazyBSONCallback) - Constructor for class com.mongodb.LazyDBList
Construct an instance with the given raw bytes and offset.
LazyDBList(byte[], int, LazyBSONCallback) - Constructor for class com.mongodb.LazyDBList
Construct an instance with the given raw bytes and offset.
LazyDBObject - Class in com.mongodb
An immutable DBObject backed by a byte buffer that lazily provides keys and values on request.
LazyDBObject(byte[], LazyBSONCallback) - Constructor for class com.mongodb.LazyDBObject
Construct an instance.
LazyDBObject(byte[], int, LazyBSONCallback) - Constructor for class com.mongodb.LazyDBObject
Construct an instance.
LazyPojoCodec<T> - Class in org.bson.codecs.pojo
 
LazyPojoCodec(ClassModel<T>, CodecRegistry, PropertyCodecRegistry, DiscriminatorLookup, ConcurrentMap<ClassModel<?>, Codec<?>>) - Constructor for class org.bson.codecs.pojo.LazyPojoCodec
 
LEGACY_EXTENDED_JSON_BINARY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
LEGACY_EXTENDED_JSON_DATE_TIME_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
LEGACY_EXTENDED_JSON_REGULAR_EXPRESSION_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
LegacyBinarySerializer() - Constructor for class com.mongodb.util.JSONSerializers.LegacyBinarySerializer
Deprecated.
 
LegacyBSONTimestampSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.LegacyBSONTimestampSerializer
Deprecated.
 
LegacyDateSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.LegacyDateSerializer
Deprecated.
 
legacyDefaults() - Method in class com.mongodb.MongoClientOptions.Builder
Sets defaults to be what they are in MongoOptions.
LegacyExtendedJsonBinaryConverter - Class in org.bson.json
 
LegacyExtendedJsonBinaryConverter() - Constructor for class org.bson.json.LegacyExtendedJsonBinaryConverter
 
LegacyExtendedJsonDateTimeConverter - Class in org.bson.json
 
LegacyExtendedJsonDateTimeConverter() - Constructor for class org.bson.json.LegacyExtendedJsonDateTimeConverter
 
LegacyExtendedJsonRegularExpressionConverter - Class in org.bson.json
 
LegacyExtendedJsonRegularExpressionConverter() - Constructor for class org.bson.json.LegacyExtendedJsonRegularExpressionConverter
 
LegacyMessage - Class in com.mongodb.connection
 
LegacyMessage(String, OpCode, MessageSettings) - Constructor for class com.mongodb.connection.LegacyMessage
 
LegacyMessage(OpCode, MessageSettings) - Constructor for class com.mongodb.connection.LegacyMessage
 
LegacyProtocol<T> - Interface in com.mongodb.connection
 
legacyToBytes(int, int, int) - Static method in class org.bson.types.ObjectId
 
length - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
length - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
length - Variable in class com.mongodb.connection.CompositeByteBuf.Component
 
length() - Method in class com.mongodb.DBCursor
Pulls back all items into an array and returns the number of objects.
length - Variable in class com.mongodb.gridfs.GridFSFile
 
length - Variable in class org.bson.RawBsonDocument
 
length() - Method in class org.bson.types.Binary
Get the length of the data.
lengthInBytes - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
lengthInBytes - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
lessThan(Object) - Method in class com.mongodb.QueryBuilder
Equivalent to the $lt operand
lessThanEquals(Object) - Method in class com.mongodb.QueryBuilder
Equivalent to the $lte operand
level - Variable in class com.mongodb.connection.LevelCountingBsonWriter
 
level - Variable in class com.mongodb.connection.ZlibCompressor
 
LEVEL - Static variable in class com.mongodb.MongoCompressor
The property key for defining the compression level.
level - Variable in class com.mongodb.ReadConcern
 
LevelCountingBsonWriter - Class in com.mongodb.connection
 
LevelCountingBsonWriter(BsonBinaryWriter) - Constructor for class com.mongodb.connection.LevelCountingBsonWriter
 
limit(int) - Method in interface com.mongodb.async.client.FindIterable
Sets the limit to apply.
limit(int) - Method in class com.mongodb.async.client.FindIterableImpl
 
limit(int) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the limit to apply.
limit(int) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
limit(int) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the limit to apply.
limit - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
limit(int) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
limit(int) - Method in interface com.mongodb.client.FindIterable
Sets the limit to apply.
limit(int) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the limit to apply.
limit(int) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
limit(int) - Method in interface com.mongodb.client.MapReduceIterable
Sets the limit to apply.
limit(int) - Static method in class com.mongodb.client.model.Aggregates
Creates a $limit pipeline stage for the specified filter
limit - Variable in class com.mongodb.client.model.CountOptions
 
limit(int) - Method in class com.mongodb.client.model.CountOptions
Sets the limit to apply.
limit - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
limit(int) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the limit to apply.
limit(long) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the limit to apply.
limit - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
limit(int) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the limit to apply.
limit - Variable in class com.mongodb.client.model.FindOptions
 
limit(int) - Method in class com.mongodb.client.model.FindOptions
Sets the limit to apply.
limit - Variable in class com.mongodb.connection.CompositeByteBuf
 
limit() - Method in class com.mongodb.connection.CompositeByteBuf
 
limit(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
limit() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
limit(int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
limit - Variable in class com.mongodb.connection.QueryProtocol
 
limit(int) - Method in class com.mongodb.DBCursor
Limits the number of elements returned.
limit(int) - Method in class com.mongodb.FindIterableImpl
 
limit - Variable in class com.mongodb.MapReduceCommand
 
limit - Variable in class com.mongodb.MapReduceIterableImpl
 
limit(int) - Method in class com.mongodb.MapReduceIterableImpl
 
limit - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
limit - Variable in class com.mongodb.operation.CountOperation
 
limit(long) - Method in class com.mongodb.operation.CountOperation
Sets the limit to apply.
limit - Variable in class com.mongodb.operation.FindOperation
 
limit(int) - Method in class com.mongodb.operation.FindOperation
Sets the limit to apply.
limit - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
limit(int) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the limit to apply.
limit - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
limit(int) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the limit to apply.
limit - Variable in class com.mongodb.operation.QueryBatchCursor
 
limit() - Method in interface org.bson.ByteBuf
Returns this buffer's limit.
limit(int) - Method in interface org.bson.ByteBuf
Sets this buffer's limit.
limit() - Method in class org.bson.ByteBufNIO
 
limit(int) - Method in class org.bson.ByteBufNIO
 
limitReached() - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
limitReached() - Method in class com.mongodb.operation.QueryBatchCursor
 
LINEARIZABLE - Static variable in class com.mongodb.ReadConcern
The linearizable read concern.
LineString - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON LineString.
LineString(List<Position>) - Constructor for class com.mongodb.client.model.geojson.LineString
Construct an instance with the given coordinates.
LineString(CoordinateReferenceSystem, List<Position>) - Constructor for class com.mongodb.client.model.geojson.LineString
Construct an instance with the given coordinates and coordinate reference system.
LineStringCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON LineString.
LineStringCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.LineStringCodec
Construct a new instance
Linked(Map<? extends K, ? extends V>, AbstractCopyOnWriteMap.View.Type) - Constructor for class org.bson.util.CopyOnWriteMap.Linked
 
listCollectionNames() - Method in interface com.mongodb.async.client.MongoDatabase
Gets the names of all the collections in this database.
listCollectionNames(ClientSession) - Method in interface com.mongodb.async.client.MongoDatabase
Gets the names of all the collections in this database.
listCollectionNames() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
listCollectionNames(ClientSession) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
listCollectionNames() - Method in interface com.mongodb.client.MongoDatabase
Gets the names of all the collections in this database.
listCollectionNames(ClientSession) - Method in interface com.mongodb.client.MongoDatabase
Gets the names of all the collections in this database.
listCollectionNames() - Method in class com.mongodb.MongoDatabaseImpl
 
listCollectionNames(ClientSession) - Method in class com.mongodb.MongoDatabaseImpl
 
listCollections() - Method in interface com.mongodb.async.client.MongoDatabase
Finds all the collections in this database.
listCollections(Class<TResult>) - Method in interface com.mongodb.async.client.MongoDatabase
Finds all the collections in this database.
listCollections(ClientSession) - Method in interface com.mongodb.async.client.MongoDatabase
Finds all the collections in this database.
listCollections(ClientSession, Class<TResult>) - Method in interface com.mongodb.async.client.MongoDatabase
Finds all the collections in this database.
listCollections() - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
listCollections(Class<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
listCollections(ClientSession) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
listCollections(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
listCollections() - Method in interface com.mongodb.client.MongoDatabase
Finds all the collections in this database.
listCollections(Class<TResult>) - Method in interface com.mongodb.client.MongoDatabase
Finds all the collections in this database.
listCollections(ClientSession) - Method in interface com.mongodb.client.MongoDatabase
Finds all the collections in this database.
listCollections(ClientSession, Class<TResult>) - Method in interface com.mongodb.client.MongoDatabase
Finds all the collections in this database.
listCollections() - Method in class com.mongodb.MongoDatabaseImpl
 
listCollections(Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
listCollections(ClientSession) - Method in class com.mongodb.MongoDatabaseImpl
 
listCollections(ClientSession, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
ListCollectionsIterable<TResult> - Interface in com.mongodb.async.client
Iterable for ListCollections.
ListCollectionsIterable<TResult> - Interface in com.mongodb.client
Iterable for ListCollections.
ListCollectionsIterableImpl<TResult> - Class in com.mongodb.async.client
 
ListCollectionsIterableImpl(ClientSession, String, Class<TResult>, CodecRegistry, ReadPreference, AsyncOperationExecutor) - Constructor for class com.mongodb.async.client.ListCollectionsIterableImpl
 
ListCollectionsIterableImpl<TResult> - Class in com.mongodb
 
ListCollectionsIterableImpl(ClientSession, String, Class<TResult>, CodecRegistry, ReadPreference, OperationExecutor) - Constructor for class com.mongodb.ListCollectionsIterableImpl
 
ListCollectionsOperation<T> - Class in com.mongodb.operation
An operation that provides a cursor allowing iteration through the metadata of all the collections in a database.
ListCollectionsOperation(String, Decoder<T>) - Constructor for class com.mongodb.operation.ListCollectionsOperation
Construct a new instance.
ListCollectionsOperation.ProjectingAsyncBatchCursor - Class in com.mongodb.operation
 
ListCollectionsOperation.ProjectingBatchCursor - Class in com.mongodb.operation
 
listDatabaseNames() - Method in interface com.mongodb.async.client.MongoClient
Get a list of the database names
listDatabaseNames(ClientSession) - Method in interface com.mongodb.async.client.MongoClient
Get a list of the database names
listDatabaseNames() - Method in class com.mongodb.async.client.MongoClientImpl
 
listDatabaseNames(ClientSession) - Method in class com.mongodb.async.client.MongoClientImpl
 
listDatabaseNames() - Method in class com.mongodb.MongoClient
Get a list of the database names
listDatabaseNames(ClientSession) - Method in class com.mongodb.MongoClient
Get a list of the database names
listDatabases() - Method in interface com.mongodb.async.client.MongoClient
Gets the list of databases
listDatabases(ClientSession) - Method in interface com.mongodb.async.client.MongoClient
Gets the list of databases
listDatabases(Class<TResult>) - Method in interface com.mongodb.async.client.MongoClient
Gets the list of databases
listDatabases(ClientSession, Class<TResult>) - Method in interface com.mongodb.async.client.MongoClient
Gets the list of databases
listDatabases() - Method in class com.mongodb.async.client.MongoClientImpl
 
listDatabases(ClientSession) - Method in class com.mongodb.async.client.MongoClientImpl
 
listDatabases(Class<T>) - Method in class com.mongodb.async.client.MongoClientImpl
 
listDatabases(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoClientImpl
 
listDatabases() - Method in class com.mongodb.MongoClient
Gets the list of databases
listDatabases(Class<T>) - Method in class com.mongodb.MongoClient
Gets the list of databases
listDatabases(ClientSession) - Method in class com.mongodb.MongoClient
Gets the list of databases
listDatabases(ClientSession, Class<T>) - Method in class com.mongodb.MongoClient
Gets the list of databases
ListDatabasesIterable<T> - Interface in com.mongodb.async.client
Iterable for ListDatabases.
ListDatabasesIterable<TResult> - Interface in com.mongodb.client
Iterable for ListDatabases.
ListDatabasesIterableImpl<TResult> - Class in com.mongodb.async.client
 
ListDatabasesIterableImpl(ClientSession, Class<TResult>, CodecRegistry, ReadPreference, AsyncOperationExecutor) - Constructor for class com.mongodb.async.client.ListDatabasesIterableImpl
 
ListDatabasesIterableImpl<TResult> - Class in com.mongodb
 
ListDatabasesIterableImpl(ClientSession, Class<TResult>, CodecRegistry, ReadPreference, OperationExecutor) - Constructor for class com.mongodb.ListDatabasesIterableImpl
 
ListDatabasesOperation<T> - Class in com.mongodb.operation
An operation that provides a cursor allowing iteration through the metadata of all the databases for a MongoClient.
ListDatabasesOperation(Decoder<T>) - Constructor for class com.mongodb.operation.ListDatabasesOperation
Construct a new instance.
listIndexes() - Method in interface com.mongodb.async.client.MongoCollection
Get all the indexes in this collection.
listIndexes(Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Get all the indexes in this collection.
listIndexes(ClientSession) - Method in interface com.mongodb.async.client.MongoCollection
Get all the indexes in this collection.
listIndexes(ClientSession, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Get all the indexes in this collection.
listIndexes() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
listIndexes(Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
listIndexes(ClientSession) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
listIndexes(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
listIndexes() - Method in interface com.mongodb.client.MongoCollection
Get all the indexes in this collection.
listIndexes(Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Get all the indexes in this collection.
listIndexes(ClientSession) - Method in interface com.mongodb.client.MongoCollection
Get all the indexes in this collection.
listIndexes(ClientSession, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Get all the indexes in this collection.
listIndexes() - Method in class com.mongodb.MongoCollectionImpl
 
listIndexes(Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
listIndexes(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
listIndexes(ClientSession, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
ListIndexesIterable<TResult> - Interface in com.mongodb.async.client
Iterable for ListIndexes.
ListIndexesIterable<TResult> - Interface in com.mongodb.client
Iterable for ListIndexes.
ListIndexesIterableImpl<TResult> - Class in com.mongodb.async.client
 
ListIndexesIterableImpl(ClientSession, MongoNamespace, Class<TResult>, CodecRegistry, ReadPreference, AsyncOperationExecutor) - Constructor for class com.mongodb.async.client.ListIndexesIterableImpl
 
ListIndexesIterableImpl<TResult> - Class in com.mongodb
 
ListIndexesIterableImpl(ClientSession, MongoNamespace, Class<TResult>, CodecRegistry, ReadPreference, OperationExecutor) - Constructor for class com.mongodb.ListIndexesIterableImpl
 
ListIndexesOperation<T> - Class in com.mongodb.operation
An operation that lists the indexes that have been created on a collection.
ListIndexesOperation(MongoNamespace, Decoder<T>) - Constructor for class com.mongodb.operation.ListIndexesOperation
Construct a new instance.
listIterator() - Method in class com.mongodb.operation.BsonArrayWrapper
 
listIterator(int) - Method in class com.mongodb.operation.BsonArrayWrapper
 
listIterator() - Method in class org.bson.BsonArray
 
listIterator(int) - Method in class org.bson.BsonArray
 
listIterator() - Method in class org.bson.LazyBSONList
 
listIterator(int) - Method in class org.bson.LazyBSONList
 
listToBsonString(List<String>) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
listToSet(BsonArray) - Static method in class com.mongodb.connection.DescriptionHelper
 
liveViews() - Method in class org.bson.util.CopyOnWriteMap.Builder
Views are live (reflecting concurrent updates) and mutator methods are supported.
loadDateTimeFormatter(String) - Static method in class org.bson.json.DateTimeFormatter
 
LOCAL - Static variable in class com.mongodb.ReadConcern
The local read concern.
locale - Variable in class com.mongodb.client.model.Collation.Builder
 
locale(String) - Method in class com.mongodb.client.model.Collation.Builder
Sets the locale
locale - Variable in class com.mongodb.client.model.Collation
 
localThreshold - Variable in class com.mongodb.ConnectionString
 
localThreshold - Variable in class com.mongodb.MongoClientOptions.Builder
 
localThreshold(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the local threshold.
localThreshold - Variable in class com.mongodb.MongoClientOptions
 
localValue - Variable in class com.mongodb.connection.ConnectionId
 
lock - Variable in class com.mongodb.connection.DefaultServerMonitor
 
lock - Variable in class org.bson.util.AbstractCopyOnWriteMap
 
log(Level, String) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
log(Level, String, Throwable) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
log(Level, String) - Method in class org.bson.diagnostics.JULLogger
 
log(Level, String, Throwable) - Method in class org.bson.diagnostics.JULLogger
 
log2(int) - Static method in class com.mongodb.internal.connection.PowerOfTwoBufferPool
 
LOGGER - Static variable in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
LOGGER - Static variable in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
LOGGER - Static variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
LOGGER - Static variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
LOGGER - Static variable in class com.mongodb.async.client.MongoClientImpl
 
LOGGER - Static variable in class com.mongodb.async.client.MongoCollectionImpl
 
LOGGER - Static variable in class com.mongodb.client.jndi.MongoClientFactory
 
LOGGER - Static variable in class com.mongodb.connection.BaseCluster
 
LOGGER - Static variable in class com.mongodb.connection.CommandProtocolImpl
 
LOGGER - Static variable in class com.mongodb.connection.CommandResultBaseCallback
 
LOGGER - Static variable in class com.mongodb.connection.CommandResultCallback
 
LOGGER - Static variable in class com.mongodb.connection.DefaultConnectionPool
 
LOGGER - Static variable in class com.mongodb.connection.DefaultServer
 
LOGGER - Static variable in class com.mongodb.connection.DefaultServerConnection
 
LOGGER - Static variable in class com.mongodb.connection.DefaultServerMonitor
 
LOGGER - Static variable in class com.mongodb.connection.DeleteProtocol
 
LOGGER - Static variable in class com.mongodb.connection.GetMoreProtocol
 
LOGGER - Static variable in class com.mongodb.connection.InsertProtocol
 
LOGGER - Static variable in class com.mongodb.connection.InternalStreamConnection
 
LOGGER - Static variable in class com.mongodb.connection.KillCursorProtocol
 
LOGGER - Static variable in class com.mongodb.connection.MultiServerCluster
 
LOGGER - Static variable in class com.mongodb.connection.QueryProtocol
 
LOGGER - Static variable in class com.mongodb.connection.SingleServerCluster
 
LOGGER - Static variable in class com.mongodb.connection.UpdateProtocol
 
LOGGER - Static variable in class com.mongodb.connection.UsageTrackingInternalConnection
 
LOGGER - Static variable in class com.mongodb.ConnectionString
 
Logger - Interface in com.mongodb.diagnostics.logging
This class is not part of the public API.
LOGGER - Static variable in class com.mongodb.event.ClusterEventMulticaster
Deprecated.
 
LOGGER - Static variable in class com.mongodb.event.CommandEventMulticaster
Deprecated.
 
LOGGER - Static variable in class com.mongodb.event.ServerEventMulticaster
Deprecated.
 
LOGGER - Static variable in class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
 
logger - Variable in class com.mongodb.internal.async.ErrorHandlingResultCallback
 
LOGGER - Static variable in class com.mongodb.internal.event.ClusterListenerMulticaster
 
LOGGER - Static variable in class com.mongodb.internal.event.CommandListenerMulticaster
 
LOGGER - Static variable in class com.mongodb.internal.event.ConnectionPoolListenerMulticaster
 
LOGGER - Static variable in class com.mongodb.internal.event.ServerListenerMulticaster
 
LOGGER - Static variable in class com.mongodb.internal.event.ServerMonitorListenerMulticaster
 
LOGGER - Static variable in class com.mongodb.internal.management.jmx.JMXMBeanServer
 
LOGGER - Static variable in class com.mongodb.operation.OperationHelper
 
LOGGER - Static variable in class org.bson.codecs.pojo.PojoCodecImpl
 
Logger - Interface in org.bson.diagnostics
This class is not part of the public API.
LOGGER - Static variable in class org.bson.types.ObjectId
 
Loggers - Class in com.mongodb.diagnostics.logging
This class is not part of the public API.
Loggers() - Constructor for class com.mongodb.diagnostics.logging.Loggers
 
Loggers - Class in org.bson.diagnostics
This class is not part of the public API.
Loggers() - Constructor for class org.bson.diagnostics.Loggers
 
logicalSessionTimeoutMinutes - Variable in class com.mongodb.connection.ServerDescription.Builder
 
logicalSessionTimeoutMinutes(Integer) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the session timeout in minutes.
logicalSessionTimeoutMinutes - Variable in class com.mongodb.connection.ServerDescription
 
logServerSelectionFailure(ServerSelector, ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
logStateChange(ServerDescription, ServerDescription) - Method in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
LongCodec - Class in org.bson.codecs
Encodes and decodes Long objects.
LongCodec() - Constructor for class org.bson.codecs.LongCodec
 
longValue() - Method in class org.bson.BsonDecimal128
 
longValue() - Method in class org.bson.BsonDouble
 
longValue() - Method in class org.bson.BsonInt32
 
longValue() - Method in class org.bson.BsonInt64
 
longValue() - Method in class org.bson.BsonNumber
Returns the value of the specified number as an long, which may involve rounding or truncation.
lookup(String, String, String, String) - Static method in class com.mongodb.client.model.Aggregates
Creates a $lookup pipeline stage for the specified filter
lookup(String) - Method in class org.bson.codecs.pojo.DiscriminatorLookup
 
LOOKUP_TABLE - Static variable in enum org.bson.BsonType
 
lookupServerDescription(InternalConnection) - Method in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
lookupSuitableHints(DBObject, List<DBObject>) - Static method in class com.mongodb.DBCursor
 
loopCursor(AsyncBatchCursor<TResult>, Block<? super TResult>, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoIterableImpl
 
low - Variable in class org.bson.types.Decimal128
 
LOW_ORDER_THREE_BYTES - Static variable in class org.bson.types.ObjectId
 
lt(String, TItem) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the given field is less than the specified value.
LT - Static variable in class com.mongodb.QueryOperators
 
lte(String, TItem) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the given field is less than or equal to the specified value.
LTE - Static variable in class com.mongodb.QueryOperators
 

M

M_BEAN_SERVER - Static variable in class com.mongodb.management.MBeanServerFactory
 
MACHINE_IDENTIFIER - Static variable in class org.bson.types.ObjectId
 
machineIdentifier - Variable in class org.bson.types.ObjectId
 
main(String[]) - Static method in class com.mongodb.gridfs.CLI
 
maintenanceFrequency(long, TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The time period between runs of the maintenance job.
maintenanceFrequencyMS - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maintenanceFrequencyMS - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maintenanceInitialDelay(long, TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The period of time to wait before running the first maintenance job on the connection pool.
maintenanceInitialDelayMS - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maintenanceInitialDelayMS - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maintenanceTask - Variable in class com.mongodb.connection.DefaultConnectionPool
 
MAJORITY - Static variable in class com.mongodb.ReadConcern
The majority read concern.
MAJORITY - Static variable in class com.mongodb.WriteConcern
Exceptions are raised for network issues, and server errors; waits on a majority of servers for the write operation.
Majority() - Constructor for class com.mongodb.WriteConcern.Majority
Deprecated.
Create a new Majority WriteConcern.
Majority(int, boolean, boolean) - Constructor for class com.mongodb.WriteConcern.Majority
Deprecated.
Create a new WriteConcern with the given configuration.
majorityWriteConcern(int, boolean, boolean) - Static method in class com.mongodb.WriteConcern
makeInt(byte, byte, byte, byte) - Static method in class org.bson.types.ObjectId
 
makeTimeConstant() - Static method in class com.mongodb.connection.Time
 
makeTimeMove() - Static method in class com.mongodb.connection.Time
 
manufactureGetLastErrorResponse(MongoBulkWriteException) - Method in class com.mongodb.operation.BaseWriteOperation
 
map(Function<GridFSFile, U>) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
map(Function<V, W>) - Method in class com.mongodb.async.client.MappingIterable
 
map(Function<TResult, U>) - Method in interface com.mongodb.async.client.MongoIterable
Maps this iterable from the source document type to the target document type.
map(Function<TResult, U>) - Method in class com.mongodb.async.client.MongoIterableImpl
 
map(Function<GridFSFile, U>) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
map(Function<TResult, U>) - Method in interface com.mongodb.client.MongoIterable
Maps this iterable from the source document type to the target document type.
map(int) - Method in class com.mongodb.internal.connection.IndexMap.HashBased
 
map(int) - Method in class com.mongodb.internal.connection.IndexMap
Return the index that the specified index is mapped to.
map(int) - Method in class com.mongodb.internal.connection.IndexMap.RangeBased
 
map - Variable in class com.mongodb.management.JMXConnectionPoolListener
 
map(Function<V, W>) - Method in class com.mongodb.MappingIterable
 
map - Variable in class com.mongodb.MapReduceCommand
 
map(Function<TResult, U>) - Method in class com.mongodb.MongoIterableImpl
 
map - Variable in class org.bson.BsonDocument
 
map - Variable in class org.bson.codecs.BsonTypeClassMap
 
map - Variable in class org.bson.util.ClassMap
 
map - Variable in class org.bson.util.ComputingMap
 
MapCodec - Class in org.bson.codecs
A Codec for Map instances.
MapCodec() - Constructor for class org.bson.codecs.MapCodec
Construct a new instance with a default CodecRegistry
MapCodec(CodecRegistry) - Constructor for class org.bson.codecs.MapCodec
Construct a new instance with the given registry
MapCodec(CodecRegistry, BsonTypeClassMap) - Constructor for class org.bson.codecs.MapCodec
Construct a new instance with the given registry and BSON type class map.
MapCodec(CodecRegistry, BsonTypeClassMap, Transformer) - Constructor for class org.bson.codecs.MapCodec
Construct a new instance with the given registry and BSON type class map.
MapCodec(Class<Map<String, T>>, Codec<T>) - Constructor for class org.bson.codecs.pojo.MapPropertyCodecProvider.MapCodec
 
MapCodecProvider - Class in org.bson.codecs
A CodecProvider for the Map class and all the default Codec implementations on which it depends.
MapCodecProvider() - Constructor for class org.bson.codecs.MapCodecProvider
Construct a new instance with a default BsonTypeClassMap.
MapCodecProvider(BsonTypeClassMap) - Constructor for class org.bson.codecs.MapCodecProvider
Construct a new instance with the given instance of BsonTypeClassMap.
MapCodecProvider(Transformer) - Constructor for class org.bson.codecs.MapCodecProvider
Construct a new instance with a default BsonTypeClassMap and the given Transformer.
MapCodecProvider(BsonTypeClassMap, Transformer) - Constructor for class org.bson.codecs.MapCodecProvider
Construct a new instance with the given instance of BsonTypeClassMap.
mapFunction - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
mapFunction - Variable in class com.mongodb.MapReduceIterableImpl
 
mapFunction - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
mapFunction - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
MapOfCodecsProvider - Class in org.bson.codecs.configuration
 
MapOfCodecsProvider(List<? extends Codec<?>>) - Constructor for class org.bson.codecs.configuration.MapOfCodecsProvider
 
MappedFieldNameValidator - Class in com.mongodb.internal.validator
A field name validator that serves as a root validator for a map of validators that are applied to child fields.
MappedFieldNameValidator(FieldNameValidator, Map<String, FieldNameValidator>) - Constructor for class com.mongodb.internal.validator.MappedFieldNameValidator
The default validator will be use to validate all fields whose names are not contained int the fieldNameToValidator map.
mapper - Variable in class com.mongodb.async.client.MappingAsyncBatchCursor
 
mapper - Variable in class com.mongodb.async.client.MappingIterable
 
mapper - Variable in class com.mongodb.MappingIterable
 
mapper - Variable in class com.mongodb.MongoMappingCursor
 
MappingAsyncBatchCursor<T,U> - Class in com.mongodb.async.client
 
MappingAsyncBatchCursor(AsyncBatchCursor<T>, Function<T, U>) - Constructor for class com.mongodb.async.client.MappingAsyncBatchCursor
 
MappingIterable<U,V> - Class in com.mongodb.async.client
 
MappingIterable(MongoIterable<U>, Function<U, V>) - Constructor for class com.mongodb.async.client.MappingIterable
 
MappingIterable<U,V> - Class in com.mongodb
 
MappingIterable(MongoIterable<U>, Function<U, V>) - Constructor for class com.mongodb.MappingIterable
 
MapPropertyCodecProvider - Class in org.bson.codecs.pojo
 
MapPropertyCodecProvider() - Constructor for class org.bson.codecs.pojo.MapPropertyCodecProvider
 
MapPropertyCodecProvider.MapCodec<T> - Class in org.bson.codecs.pojo
 
mapReduce(String, String) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(String, String, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(ClientSession, String, String) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(ClientSession, String, String, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(String, String) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
mapReduce(String, String, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
mapReduce(ClientSession, String, String) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
mapReduce(ClientSession, String, String, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
mapReduce(String, String) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(String, String, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(ClientSession, String, String) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(ClientSession, String, String, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Aggregates documents according to the specified map-reduce function.
mapReduce(String, String, String, DBObject) - Method in class com.mongodb.DBCollection
Allows you to run map-reduce aggregation operations over a collection.
mapReduce(String, String, String, MapReduceCommand.OutputType, DBObject) - Method in class com.mongodb.DBCollection
Allows you to run map-reduce aggregation operations over a collection and saves to a named collection.
mapReduce(String, String, String, MapReduceCommand.OutputType, DBObject, ReadPreference) - Method in class com.mongodb.DBCollection
Allows you to run map-reduce aggregation operations over a collection and saves to a named collection.
mapReduce(MapReduceCommand) - Method in class com.mongodb.DBCollection
Allows you to run map-reduce aggregation operations over a collection.
mapReduce - Variable in class com.mongodb.MapReduceCommand
 
mapReduce(String, String) - Method in class com.mongodb.MongoCollectionImpl
 
mapReduce(String, String, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
mapReduce(ClientSession, String, String) - Method in class com.mongodb.MongoCollectionImpl
 
mapReduce(ClientSession, String, String, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
MapReduceAction - Enum in com.mongodb.client.model
The map reduce to collection actions.
MapReduceAction(String) - Constructor for enum com.mongodb.client.model.MapReduceAction
 
MapReduceAsyncBatchCursor<T> - Interface in com.mongodb.operation
Represents the future results of a map-reduce operation as a cursor.
MapReduceBatchCursor<T> - Interface in com.mongodb.operation
Represents the results of a map-reduce operation as a cursor.
MapReduceCommand - Class in com.mongodb
This class groups the argument for a map/reduce operation and can build the underlying command object
MapReduceCommand(DBCollection, String, String, String, MapReduceCommand.OutputType, DBObject) - Constructor for class com.mongodb.MapReduceCommand
Represents the command for a map reduce operation Runs the command in REPLACE output type to a named collection
MapReduceCommand.OutputType - Enum in com.mongodb
Represents the different options available for outputting the results of a map-reduce operation.
MapReduceHelper - Class in com.mongodb.operation
 
MapReduceHelper() - Constructor for class com.mongodb.operation.MapReduceHelper
 
MapReduceInlineResultsAsyncCursor<T> - Class in com.mongodb.operation
Cursor representation of the results of an inline map-reduce operation.
MapReduceInlineResultsAsyncCursor(QueryResult<T>, MapReduceStatistics) - Constructor for class com.mongodb.operation.MapReduceInlineResultsAsyncCursor
 
MapReduceInlineResultsCursor<T> - Class in com.mongodb.operation
Cursor representation of the results of an inline map-reduce operation.
MapReduceInlineResultsCursor(QueryResult<T>, Decoder<T>, ConnectionSource, MapReduceStatistics) - Constructor for class com.mongodb.operation.MapReduceInlineResultsCursor
 
MapReduceIterable<TResult> - Interface in com.mongodb.async.client
Iterable for map reduce.
MapReduceIterable<TResult> - Interface in com.mongodb.client
Iterable for map-reduce.
MapReduceIterableImpl<TDocument,TResult> - Class in com.mongodb.async.client
 
MapReduceIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, WriteConcern, AsyncOperationExecutor, String, String) - Constructor for class com.mongodb.async.client.MapReduceIterableImpl
 
MapReduceIterableImpl<TDocument,TResult> - Class in com.mongodb
 
MapReduceIterableImpl(ClientSession, MongoNamespace, Class<TDocument>, Class<TResult>, CodecRegistry, ReadPreference, ReadConcern, WriteConcern, OperationExecutor, String, String) - Constructor for class com.mongodb.MapReduceIterableImpl
 
MapReduceIterableImpl.WrappedMapReduceReadOperation<TResult> - Class in com.mongodb.async.client
 
MapReduceIterableImpl.WrappedMapReduceReadOperation<TResult> - Class in com.mongodb
 
MapReduceIterableImpl.WrappedMapReduceWriteOperation - Class in com.mongodb.async.client
 
MapReduceOutput - Class in com.mongodb
Represents the result of a map/reduce operation.
MapReduceOutput(DBObject, MapReduceBatchCursor<DBObject>) - Constructor for class com.mongodb.MapReduceOutput
Constructor for use with inline map reduce.
MapReduceOutput(DBObject, DBCursor, MapReduceStatistics, DBCollection) - Constructor for class com.mongodb.MapReduceOutput
Constructor for use when the map reduce output was put into a collection
mapReduceStatistics - Variable in class com.mongodb.MapReduceOutput
 
MapReduceStatistics - Class in com.mongodb.operation
Common statistics returned by running all types of map-reduce operations.
MapReduceStatistics(int, int, int, int) - Constructor for class com.mongodb.operation.MapReduceStatistics
Construct a new instance.
MapReduceToCollectionOperation - Class in com.mongodb.operation
Operation that runs a Map Reduce against a MongoDB instance.
MapReduceToCollectionOperation(MongoNamespace, BsonJavaScript, BsonJavaScript, String) - Constructor for class com.mongodb.operation.MapReduceToCollectionOperation
Construct a MapReduceOperation with all the criteria it needs to execute
MapReduceToCollectionOperation(MongoNamespace, BsonJavaScript, BsonJavaScript, String, WriteConcern) - Constructor for class com.mongodb.operation.MapReduceToCollectionOperation
Construct a MapReduceOperation with all the criteria it needs to execute
MapReduceWithInlineResultsOperation<T> - Class in com.mongodb.operation
Operation that runs a Map Reduce against a MongoDB instance.
MapReduceWithInlineResultsOperation(MongoNamespace, BsonJavaScript, BsonJavaScript, Decoder<T>) - Constructor for class com.mongodb.operation.MapReduceWithInlineResultsOperation
Construct a MapReduceOperation with all the criteria it needs to execute.
MapSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.MapSerializer
Deprecated.
 
mark() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
Marks the current position in this input stream.
mark() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
mark(int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
Mark() - Constructor for class org.bson.AbstractBsonReader.Mark
 
Mark() - Constructor for class org.bson.AbstractBsonWriter.Mark
Creates a new snapshopt of the current state.
mark - Variable in class org.bson.BsonBinaryReader
 
mark() - Method in class org.bson.BsonBinaryReader
Deprecated.
Mark() - Constructor for class org.bson.BsonBinaryReader.Mark
 
mark - Variable in class org.bson.BsonBinaryWriter
 
mark() - Method in class org.bson.BsonBinaryWriter
Create a snapshot of this writer's context at a point in time.
Mark() - Constructor for class org.bson.BsonBinaryWriter.Mark
Creates a new instance storing the current position of the BsonOutput.
mark() - Method in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
mark() - Method in class org.bson.BsonDocumentReader.Context
 
mark - Variable in class org.bson.BsonDocumentReader
 
mark() - Method in class org.bson.BsonDocumentReader
Deprecated.
Mark() - Constructor for class org.bson.BsonDocumentReader.Mark
 
mark() - Method in interface org.bson.BsonReader
Deprecated.
mark(int) - Method in interface org.bson.io.BsonInput
Marks the current position in the stream.
mark - Variable in class org.bson.io.ByteBufferBsonInput
 
mark(int) - Method in class org.bson.io.ByteBufferBsonInput
 
mark - Variable in class org.bson.json.JsonReader
 
mark() - Method in class org.bson.json.JsonReader
Deprecated.
Mark() - Constructor for class org.bson.json.JsonReader.Mark
 
markAsPartialObject() - Method in class com.mongodb.BasicDBList
 
markAsPartialObject() - Method in class com.mongodb.BasicDBObject
If this object was retrieved with only some fields (using a field filter) this method will be called to mark it as such.
markAsPartialObject() - Method in interface com.mongodb.DBObject
If this object was retrieved with only some fields (using a field filter) this method will be called to mark it as such.
markAsPartialObject() - Method in class com.mongodb.gridfs.GridFSFile
 
markAsPartialObject() - Method in class com.mongodb.LazyDBList
 
markAsPartialObject() - Method in class com.mongodb.LazyDBObject
 
markAsPartialObject() - Method in class com.mongodb.ReflectionDBObject
ReflectionDBObjects can't be partial.
markedContext - Variable in class org.bson.AbstractBsonWriter.Mark
 
markedState - Variable in class org.bson.AbstractBsonWriter.Mark
 
marking - Variable in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
markIterator - Variable in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
markPosition - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
markSupported() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
match(Bson) - Static method in class com.mongodb.client.model.Aggregates
Creates a $match pipeline stage for the specified filter
matchedCount - Variable in class com.mongodb.AcknowledgedBulkWriteResult
 
matchedCount - Variable in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
matchedCount - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
max(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets the exclusive upper bound for a specific index.
max(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
max - Variable in class com.mongodb.bulk.IndexRequest
 
max(Double) - Method in class com.mongodb.bulk.IndexRequest
Sets the upper inclusive boundary for the longitude and latitude values for 2d indexes..
max(Bson) - Method in interface com.mongodb.client.FindIterable
Sets the exclusive upper bound for a specific index.
max(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the maximum of the values of the given expression when applied to all members of the group.
max - Variable in class com.mongodb.client.model.FindOptions
 
max(Bson) - Method in class com.mongodb.client.model.FindOptions
Sets the exclusive upper bound for a specific index.
max - Variable in class com.mongodb.client.model.IndexOptions
 
max(Double) - Method in class com.mongodb.client.model.IndexOptions
Sets the upper inclusive boundary for the longitude and latitude values for 2d indexes..
max(String, TItem) - Static method in class com.mongodb.client.model.Updates
Creates an update that sets the value of the field to the given value if the given value is greater than the current value of the field.
max(DBObject) - Method in class com.mongodb.DBCursor
Specifies an exclusive upper limit for the index to use in a query.
max(Bson) - Method in class com.mongodb.FindIterableImpl
 
max - Variable in class com.mongodb.operation.FindOperation
 
max(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets the exclusive upper bound for a specific index.
MAX - Static variable in class com.mongodb.QueryOperators
 
MAX_BIT_LENGTH - Static variable in class org.bson.types.Decimal128
 
MAX_BUFFER_SIZE - Static variable in class com.mongodb.connection.ByteBufferBsonOutput
 
MAX_CHUNKSIZE - Static variable in class com.mongodb.gridfs.GridFS
Deprecated.
You can calculate max chunkSize with a similar formula Mongo.getMaxBsonObjectSize() - 500*1000. Please ensure that you left enough space for metadata (500kb is enough).
MAX_DISTANCE - Static variable in class com.mongodb.QueryOperators
 
MAX_DRIVER_WIRE_VERSION - Static variable in class com.mongodb.connection.ServerDescription
 
MAX_EXPONENT - Static variable in class org.bson.types.Decimal128
 
MAX_SAFE_DIGITS - Static variable in class org.bson.internal.UnsignedLongs
 
MAX_SCAN - Static variable in class com.mongodb.QueryOperators
 
MAX_SHIFT - Static variable in class com.mongodb.connection.ByteBufferBsonOutput
 
MAX_VALUE - Static variable in class org.bson.internal.UnsignedLongs
 
MAX_VALUE_DIVS - Static variable in class org.bson.internal.UnsignedLongs
 
MAX_VALUE_MODS - Static variable in class org.bson.internal.UnsignedLongs
 
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.AggregateIterableImpl
 
maxAwaitTime(long, TimeUnit) - Method in interface com.mongodb.async.client.AggregateIterable
The maximum amount of time for the server to wait on new documents to satisfy a $changeStream aggregation.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
maxAwaitTime(long, TimeUnit) - Method in interface com.mongodb.async.client.ChangeStreamIterable
Sets the maximum await execution time on the server for this operation.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
maxAwaitTime(long, TimeUnit) - Method in interface com.mongodb.async.client.FindIterable
The maximum amount of time for the server to wait on new documents to satisfy a tailable cursor query.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.async.client.FindIterableImpl
 
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.ChangeStreamIterableImpl
 
maxAwaitTime(long, TimeUnit) - Method in interface com.mongodb.client.AggregateIterable
The maximum amount of time for the server to wait on new documents to satisfy a $changeStream aggregation.
maxAwaitTime(long, TimeUnit) - Method in interface com.mongodb.client.ChangeStreamIterable
Sets the maximum await execution time on the server for this operation.
maxAwaitTime(long, TimeUnit) - Method in interface com.mongodb.client.FindIterable
The maximum amount of time for the server to wait on new documents to satisfy a tailable cursor query.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the maximum await execution time on the server for this operation.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.client.model.FindOptions
Sets the maximum await execution time on the server for this operation.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.FindIterableImpl
 
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.operation.AggregateOperation
Sets the maximum await execution time on the server for this operation.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.operation.ChangeStreamOperation
Sets the maximum await execution time on the server for this operation.
maxAwaitTime(long, TimeUnit) - Method in class com.mongodb.operation.FindOperation
Sets the maximum await execution time on the server for this operation.
maxAwaitTimeMS - Variable in class com.mongodb.AggregateIterableImpl
 
maxAwaitTimeMS - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
maxAwaitTimeMS - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
maxAwaitTimeMS - Variable in class com.mongodb.ChangeStreamIterableImpl
 
maxAwaitTimeMS - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
maxAwaitTimeMS - Variable in class com.mongodb.client.model.FindOptions
 
maxAwaitTimeMS - Variable in class com.mongodb.operation.AggregateOperation
 
maxAwaitTimeMS - Variable in class com.mongodb.operation.ChangeStreamOperation
 
maxAwaitTimeMS - Variable in class com.mongodb.operation.FindOperation
 
maxBatchCount - Variable in class com.mongodb.connection.ConnectionDescription
 
maxBatchCount - Variable in class com.mongodb.connection.MessageSettings.Builder
 
maxBatchCount(int) - Method in class com.mongodb.connection.MessageSettings.Builder
Sets the maximum number of items in a batch allowed.
maxBatchCount - Variable in class com.mongodb.connection.MessageSettings
 
maxConnectionIdleTime(long, TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The maximum idle time of a pooled connection.
maxConnectionIdleTime - Variable in class com.mongodb.ConnectionString
 
maxConnectionIdleTime - Variable in class com.mongodb.MongoClientOptions.Builder
 
maxConnectionIdleTime(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the maximum idle time for a pooled connection.
maxConnectionIdleTime - Variable in class com.mongodb.MongoClientOptions
 
maxConnectionIdleTimeMS - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maxConnectionIdleTimeMS - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maxConnectionLifeTime(long, TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The maximum time a pooled connection can live for.
maxConnectionLifeTime - Variable in class com.mongodb.ConnectionString
 
maxConnectionLifeTime - Variable in class com.mongodb.MongoClientOptions.Builder
 
maxConnectionLifeTime(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the maximum life time for a pooled connection.
maxConnectionLifeTime - Variable in class com.mongodb.MongoClientOptions
 
maxConnectionLifeTimeMS - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maxConnectionLifeTimeMS - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maxConnectionPoolSize - Variable in class com.mongodb.ConnectionString
 
maxConnectionsPerHost - Variable in class com.mongodb.MongoClientOptions.Builder
 
maxConnectionsPerHost - Variable in class com.mongodb.MongoClientOptions
 
maxDepth - Variable in class com.mongodb.client.model.GraphLookupOptions
 
maxDepth(Integer) - Method in class com.mongodb.client.model.GraphLookupOptions
Specifies a maximum recursive depth for the $graphLookup.
maxDistance - Variable in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
maxDocuments - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
maxDocuments(long) - Method in class com.mongodb.client.model.CreateCollectionOptions
Sets the maximum number of documents allowed in a capped collection.
maxDocuments - Variable in class com.mongodb.operation.CreateCollectionOperation
 
maxDocuments(long) - Method in class com.mongodb.operation.CreateCollectionOperation
Set the maximum number of documents in the collection.
maxDocumentSize - Variable in class com.mongodb.connection.ConnectionDescription
 
maxDocumentSize - Variable in class com.mongodb.connection.MessageSettings.Builder
 
maxDocumentSize(int) - Method in class com.mongodb.connection.MessageSettings.Builder
Sets the maximum document size allowed.
maxDocumentSize - Variable in class com.mongodb.connection.MessageSettings
 
maxDocumentSize - Variable in class com.mongodb.connection.ServerDescription.Builder
 
maxDocumentSize(int) - Method in class com.mongodb.connection.ServerDescription.Builder
The maximum permitted size of a BSON object in bytes for this mongod process.
maxDocumentSize - Variable in class com.mongodb.connection.ServerDescription
 
maxDocumentSize - Variable in class org.bson.BsonBinaryWriterSettings
 
maxDocumentSizeStack - Variable in class org.bson.BsonBinaryWriter
 
maxElectionId - Variable in class com.mongodb.connection.MultiServerCluster
 
MAXIMUM_CLIENT_METADATA_ENCODED_SIZE - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
MAXKEY - Static variable in class org.bson.BSON
 
MaxKey - Class in org.bson.types
Represent the maximum key value regardless of the key's type
MaxKey() - Constructor for class org.bson.types.MaxKey
 
MaxKeyCodec - Class in org.bson.codecs
Encodes and decodes instances of type MaxKey.
MaxKeyCodec() - Constructor for class org.bson.codecs.MaxKeyCodec
 
maxKeyConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
maxKeyConverter(Converter<BsonMaxKey>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON MaxKey values to JSON.
maxKeyConverter - Variable in class org.bson.json.JsonWriterSettings
 
MaxKeySerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.MaxKeySerializer
Deprecated.
 
maxMessageSize - Variable in class com.mongodb.connection.ConnectionDescription
 
maxMessageSize - Variable in class com.mongodb.connection.MessageSettings.Builder
 
maxMessageSize(int) - Method in class com.mongodb.connection.MessageSettings.Builder
Sets the maximum message size allowed.
maxMessageSize - Variable in class com.mongodb.connection.MessageSettings
 
maxScan(long) - Method in interface com.mongodb.async.client.FindIterable
Sets the maximum number of documents or index keys to scan when executing the query.
maxScan(long) - Method in class com.mongodb.async.client.FindIterableImpl
 
maxScan(long) - Method in interface com.mongodb.client.FindIterable
Sets the maximum number of documents or index keys to scan when executing the query.
maxScan - Variable in class com.mongodb.client.model.FindOptions
 
maxScan(long) - Method in class com.mongodb.client.model.FindOptions
Sets the maximum number of documents or index keys to scan when executing the query.
maxScan(int) - Method in class com.mongodb.DBCursor
Limits the number of documents a cursor will return for a query.
maxScan(long) - Method in class com.mongodb.FindIterableImpl
 
maxScan - Variable in class com.mongodb.operation.FindOperation
 
maxScan(long) - Method in class com.mongodb.operation.FindOperation
Sets the maximum number of documents or index keys to scan when executing the query.
maxSerializationDepth - Variable in class org.bson.BsonWriterSettings
 
maxSetVersion - Variable in class com.mongodb.connection.MultiServerCluster
 
maxSize - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maxSize(int) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The maximum number of connections allowed.
maxSize - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maxSize - Variable in class com.mongodb.internal.connection.ConcurrentPool
 
maxStalenessMS - Variable in class com.mongodb.TaggableReadPreference
 
maxTime(long, TimeUnit) - Method in class com.mongodb.AggregateIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.AggregationOptions.Builder
Sets the maximum execution time for the aggregation command.
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.AggregateIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.DistinctIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.DistinctIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.FindIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.FindIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.ListCollectionsIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.ListCollectionsIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.ListDatabasesIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.ListDatabasesIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.ListIndexesIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.ListIndexesIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.AggregateIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.DistinctIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.FindIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.ListCollectionsIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.ListDatabasesIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.ListIndexesIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in interface com.mongodb.client.MapReduceIterable
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.CountOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.CreateIndexOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.DropIndexOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.client.model.FindOptions
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.DBCursor
Set the maximum execution time for operations on this cursor.
maxTime(long, TimeUnit) - Method in class com.mongodb.DistinctIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.FindIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.ListCollectionsIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.ListDatabasesIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.ListIndexesIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.MapReduceIterableImpl
 
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.AggregateExplainOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.AggregateOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.AggregateToCollectionOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.CountOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.CreateIndexesOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.DistinctOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.DropIndexOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.FindOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.ListCollectionsOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.ListDatabasesOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.ListIndexesOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the maximum execution time on the server for this operation.
maxTime(long, TimeUnit) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the maximum execution time on the server for this operation.
maxTimeMS - Variable in class com.mongodb.AggregateIterableImpl
 
maxTimeMS - Variable in class com.mongodb.AggregationOptions.Builder
 
maxTimeMS - Variable in class com.mongodb.AggregationOptions
 
maxTimeMS - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
maxTimeMS - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
maxTimeMS - Variable in class com.mongodb.async.client.ListCollectionsIterableImpl
 
maxTimeMS - Variable in class com.mongodb.async.client.ListDatabasesIterableImpl
 
maxTimeMS - Variable in class com.mongodb.async.client.ListIndexesIterableImpl
 
maxTimeMS - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
maxTimeMS - Variable in class com.mongodb.client.model.CountOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.CreateIndexOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.DropIndexOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.FindOneAndDeleteOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
maxTimeMS - Variable in class com.mongodb.client.model.FindOptions
 
maxTimeMS - Variable in class com.mongodb.DistinctIterableImpl
 
maxTimeMS - Variable in class com.mongodb.ListCollectionsIterableImpl
 
maxTimeMS - Variable in class com.mongodb.ListDatabasesIterableImpl
 
maxTimeMS - Variable in class com.mongodb.ListIndexesIterableImpl
 
maxTimeMS - Variable in class com.mongodb.MapReduceCommand
 
maxTimeMS - Variable in class com.mongodb.MapReduceIterableImpl
 
maxTimeMS - Variable in class com.mongodb.operation.AggregateExplainOperation
 
maxTimeMS - Variable in class com.mongodb.operation.AggregateOperation
 
maxTimeMS - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
maxTimeMS - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
maxTimeMS - Variable in class com.mongodb.operation.CountOperation
 
maxTimeMS - Variable in class com.mongodb.operation.CreateIndexesOperation
 
maxTimeMS - Variable in class com.mongodb.operation.DistinctOperation
 
maxTimeMS - Variable in class com.mongodb.operation.DropIndexOperation
 
maxTimeMS - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
maxTimeMS - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
maxTimeMS - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
maxTimeMS - Variable in class com.mongodb.operation.FindOperation
 
maxTimeMS - Variable in class com.mongodb.operation.ListCollectionsOperation
 
maxTimeMS - Variable in class com.mongodb.operation.ListDatabasesOperation
 
maxTimeMS - Variable in class com.mongodb.operation.ListIndexesOperation
 
maxTimeMS - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
maxTimeMS - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
maxTimeMS - Variable in class com.mongodb.operation.QueryBatchCursor
 
maxVariable - Variable in class com.mongodb.client.model.Collation.Builder
 
maxVariable - Variable in class com.mongodb.client.model.Collation
 
maxWaitQueueSize - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
maxWaitQueueSize(int) - Method in class com.mongodb.connection.ClusterSettings.Builder
This is the maximum number of concurrent operations allowed to wait for a server to become available.
maxWaitQueueSize - Variable in class com.mongodb.connection.ClusterSettings
 
maxWaitQueueSize - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maxWaitQueueSize(int) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
This is the maximum number of waiters for a connection to become available from the pool.
maxWaitQueueSize - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maxWaitTime(long, TimeUnit) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The maximum time that a thread may wait for a connection to become available.
maxWaitTime - Variable in class com.mongodb.ConnectionString
 
maxWaitTime - Variable in class com.mongodb.MongoClientOptions.Builder
 
maxWaitTime(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the maximum time that a thread will block waiting for a connection.
maxWaitTime - Variable in class com.mongodb.MongoClientOptions
 
maxWaitTime - Variable in class com.mongodb.MongoOptions
Deprecated.
The maximum wait time in milliseconds that a thread may wait for a connection to become available.
maxWaitTimeMS - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
maxWaitTimeMS - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
maxWaitTimeNanos - Variable in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
maxWireVersion - Variable in class com.mongodb.connection.ServerDescription.Builder
 
maxWireVersion(int) - Method in class com.mongodb.connection.ServerDescription.Builder
The latest version of the wire protocol that this MongoDB server is capable of using to communicate with clients.
maxWireVersion - Variable in class com.mongodb.connection.ServerDescription
 
MBeanServer - Interface in com.mongodb.management
This class is NOT part of the public API.
MBeanServerFactory - Class in com.mongodb.management
This class is NOT part of the public API.
MBeanServerFactory() - Constructor for class com.mongodb.management.MBeanServerFactory
 
md5 - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
md5 - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
md5 - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
md5 - Variable in class com.mongodb.gridfs.GridFSFile
 
mechanism - Variable in class com.mongodb.MongoCredential
 
mechanismName - Variable in enum com.mongodb.AuthenticationMechanism
 
mechanismProperties - Variable in class com.mongodb.MongoCredential
 
mergeUpserts(List<BulkWriteUpsert>, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
mergeWriteConcernError(WriteConcernError) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
mergeWriteErrors(List<BulkWriteError>, IndexMap) - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
message - Variable in class com.mongodb.bulk.WriteConcernError
 
message - Variable in class com.mongodb.BulkWriteError
 
message - Variable in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
message - Variable in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
message - Variable in class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
message - Variable in class com.mongodb.connection.SendMessageCallback
 
message - Variable in class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
message - Variable in class com.mongodb.WriteConcernError
 
message - Variable in class com.mongodb.WriteError
 
MESSAGE_HEADER_LENGTH - Static variable in class com.mongodb.connection.MessageHeader
The length of the standard message header in the MongoDB wire protocol.
MESSAGE_PROLOGUE_LENGTH - Static variable in class com.mongodb.connection.RequestMessage
 
MessageCallback(MessageHeader) - Constructor for class com.mongodb.connection.InternalStreamConnection.MessageHeaderCallback.MessageCallback
 
messageDigester - Variable in class com.mongodb.gridfs.GridFSInputFile
 
messageHeader - Variable in class com.mongodb.connection.CompressedHeader
 
messageHeader - Variable in class com.mongodb.connection.InternalStreamConnection.MessageHeaderCallback.MessageCallback
 
MessageHeader - Class in com.mongodb.connection
 
MessageHeader(ByteBuf, int) - Constructor for class com.mongodb.connection.MessageHeader
 
MessageHeaderCallback(SingleResultCallback<ResponseBuffers>) - Constructor for class com.mongodb.connection.InternalStreamConnection.MessageHeaderCallback
 
messageLength - Variable in class com.mongodb.connection.MessageHeader
 
messageLength - Variable in class com.mongodb.connection.ReplyHeader
 
messageReceived(ConnectionMessageReceivedEvent) - Method in interface com.mongodb.event.ConnectionListener
Deprecated.
Publish a connection message received event.
MessageSettings - Class in com.mongodb.connection
The message settings
MessageSettings(MessageSettings.Builder) - Constructor for class com.mongodb.connection.MessageSettings
 
MessageSettings.Builder - Class in com.mongodb.connection
A MessageSettings builder.
messagesSent(ConnectionMessagesSentEvent) - Method in interface com.mongodb.event.ConnectionListener
Deprecated.
Publish a connection messages sent event.
messageStartPosition - Variable in class com.mongodb.connection.SplittablePayloadBsonWriter
 
META_OPERATOR_TO_COMMAND_FIELD_MAP - Static variable in class com.mongodb.connection.QueryProtocol
 
META_OPERATOR_TO_COMMAND_FIELD_MAP - Static variable in class com.mongodb.operation.FindOperation
 
metadata - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
metadata - Variable in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
metadata - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
metadata - Variable in class com.mongodb.client.gridfs.model.GridFSUploadOptions
 
metadata(Document) - Method in class com.mongodb.client.gridfs.model.GridFSUploadOptions
Sets metadata to stored alongside the filename in the files collection
metaTextScore(String) - Static method in class com.mongodb.client.model.Projections
Creates a projection to the given field name of the textScore, for use with text queries.
metaTextScore(String) - Static method in class com.mongodb.client.model.Sorts
Create a sort specification for the text score meta projection on the given field.
method - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
millis() - Method in interface com.mongodb.internal.session.ServerSessionPool.Clock
 
min(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets the minimum inclusive lower bound for a specific index.
min(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
min - Variable in class com.mongodb.bulk.IndexRequest
 
min(Double) - Method in class com.mongodb.bulk.IndexRequest
Sets the lower inclusive boundary for the longitude and latitude values for 2d indexes..
min(Bson) - Method in interface com.mongodb.client.FindIterable
Sets the minimum inclusive lower bound for a specific index.
min(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the minimum of the values of the given expression when applied to all members of the group.
min - Variable in class com.mongodb.client.model.FindOptions
 
min(Bson) - Method in class com.mongodb.client.model.FindOptions
Sets the minimum inclusive lower bound for a specific index.
min - Variable in class com.mongodb.client.model.IndexOptions
 
min(Double) - Method in class com.mongodb.client.model.IndexOptions
Sets the lower inclusive boundary for the longitude and latitude values for 2d indexes..
min(String, TItem) - Static method in class com.mongodb.client.model.Updates
Creates an update that sets the value of the field to the given value if the given value is less than the current value of the field.
min(DBObject) - Method in class com.mongodb.DBCursor
Specifies an inclusive lower limit for the index to use in a query.
min(Bson) - Method in class com.mongodb.FindIterableImpl
 
min - Variable in class com.mongodb.operation.FindOperation
 
min(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets the minimum inclusive lower bound for a specific index.
MIN - Static variable in class com.mongodb.QueryOperators
 
MIN_BSON_DOCUMENT_SIZE - Static variable in class org.bson.RawBsonDocument
 
MIN_DRIVER_SERVER_VERSION - Static variable in class com.mongodb.connection.ServerDescription
 
MIN_DRIVER_WIRE_VERSION - Static variable in class com.mongodb.connection.ServerDescription
 
MIN_EXPONENT - Static variable in class org.bson.types.Decimal128
 
minConnectionPoolSize - Variable in class com.mongodb.ConnectionString
 
minConnectionsPerHost - Variable in class com.mongodb.MongoClientOptions.Builder
 
minConnectionsPerHost(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the minimum number of connections per host.
minConnectionsPerHost - Variable in class com.mongodb.MongoClientOptions
 
minDistance - Variable in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
minHeartbeatFrequency(long, TimeUnit) - Method in class com.mongodb.connection.ServerSettings.Builder
Sets the minimum heartbeat frequency.
minHeartbeatFrequency - Variable in class com.mongodb.MongoClientOptions.Builder
 
minHeartbeatFrequency(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the minimum heartbeat frequency.
minHeartbeatFrequency - Variable in class com.mongodb.MongoClientOptions
 
minHeartbeatFrequencyMS - Variable in class com.mongodb.connection.ServerSettings.Builder
 
minHeartbeatFrequencyMS - Variable in class com.mongodb.connection.ServerSettings
 
MINKEY - Static variable in class org.bson.BSON
 
MinKey - Class in org.bson.types
Represent the minimum key value regardless of the key's type
MinKey() - Constructor for class org.bson.types.MinKey
 
MinKeyCodec - Class in org.bson.codecs
Encodes and decodes instances of type MinKey.
MinKeyCodec() - Constructor for class org.bson.codecs.MinKeyCodec
 
minKeyConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
minKeyConverter(Converter<BsonMinKey>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON MinKey values to JSON.
minKeyConverter - Variable in class org.bson.json.JsonWriterSettings
 
MinKeySerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.MinKeySerializer
Deprecated.
 
minSize - Variable in class com.mongodb.connection.ConnectionPoolSettings.Builder
 
minSize(int) - Method in class com.mongodb.connection.ConnectionPoolSettings.Builder
The minimum number of connections.
minSize - Variable in class com.mongodb.connection.ConnectionPoolSettings
 
minWireVersion - Variable in class com.mongodb.connection.ServerDescription.Builder
 
minWireVersion(int) - Method in class com.mongodb.connection.ServerDescription.Builder
The earliest version of the wire protocol that this MongoDB server is capable of using to communicate with clients.
minWireVersion - Variable in class com.mongodb.connection.ServerDescription
 
MixedBulkWriteOperation - Class in com.mongodb.operation
An operation to execute a series of write operations in bulk.
MixedBulkWriteOperation(MongoNamespace, List<? extends WriteRequest>, boolean, WriteConcern) - Constructor for class com.mongodb.operation.MixedBulkWriteOperation
MixedBulkWriteOperation(MongoNamespace, List<? extends WriteRequest>, boolean, WriteConcern, boolean) - Constructor for class com.mongodb.operation.MixedBulkWriteOperation
Construct a new instance.
mod(String, long, long) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of a field divided by a divisor has the specified remainder (i.e.
mod(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $mod operand
MOD - Static variable in class com.mongodb.QueryOperators
 
mode - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
mode(ClusterConnectionMode) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the mode for this cluster.
mode - Variable in class com.mongodb.connection.ClusterSettings
 
modifiedCount - Variable in class com.mongodb.AcknowledgedBulkWriteResult
 
modifiedCount - Variable in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
modifiedCount - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
modifiers(Bson) - Method in interface com.mongodb.async.client.FindIterable
Deprecated.
use the individual setters instead
modifiers(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
modifiers(Bson) - Method in interface com.mongodb.client.FindIterable
Deprecated.
use the individual setters instead
modifiers - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
modifiers(DBObject) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the query modifiers to apply to this operation.
modifiers - Variable in class com.mongodb.client.model.FindOptions
 
modifiers(Bson) - Method in class com.mongodb.client.model.FindOptions
Deprecated.
use the individual modifier methods instead.
modifiers(Bson) - Method in class com.mongodb.FindIterableImpl
 
modifiers - Variable in class com.mongodb.operation.FindOperation
 
modifiers(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Deprecated.
use the individual setters instead
mongo - Variable in class com.mongodb.DB
 
mongo - Variable in class com.mongodb.DBCursor.OptionalFinalizer
 
mongo - Static variable in class com.mongodb.gridfs.CLI
 
Mongo - Class in com.mongodb
A database connection with internal connection pooling.
Mongo() - Constructor for class com.mongodb.Mongo
Deprecated.
Mongo(String) - Constructor for class com.mongodb.Mongo
Deprecated.
Mongo(String, MongoOptions) - Constructor for class com.mongodb.Mongo
Mongo(String, int) - Constructor for class com.mongodb.Mongo
Deprecated.
Mongo(ServerAddress) - Constructor for class com.mongodb.Mongo
Mongo(ServerAddress, MongoOptions) - Constructor for class com.mongodb.Mongo
Mongo(ServerAddress, ServerAddress) - Constructor for class com.mongodb.Mongo
Deprecated.
Mongo(ServerAddress, ServerAddress, MongoOptions) - Constructor for class com.mongodb.Mongo
Mongo(List<ServerAddress>) - Constructor for class com.mongodb.Mongo
Mongo(List<ServerAddress>, MongoOptions) - Constructor for class com.mongodb.Mongo
Mongo(MongoURI) - Constructor for class com.mongodb.Mongo
Mongo(List<ServerAddress>, MongoClientOptions) - Constructor for class com.mongodb.Mongo
 
Mongo(ServerAddress, MongoClientOptions) - Constructor for class com.mongodb.Mongo
 
Mongo(ServerAddress, List<MongoCredential>, MongoClientOptions) - Constructor for class com.mongodb.Mongo
 
Mongo(ServerAddress, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Constructor for class com.mongodb.Mongo
 
Mongo(List<ServerAddress>, List<MongoCredential>, MongoClientOptions) - Constructor for class com.mongodb.Mongo
 
Mongo(List<ServerAddress>, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Constructor for class com.mongodb.Mongo
 
Mongo(MongoClientURI) - Constructor for class com.mongodb.Mongo
 
Mongo(MongoClientURI, MongoDriverInformation) - Constructor for class com.mongodb.Mongo
 
Mongo(Cluster, MongoClientOptions, List<MongoCredential>) - Constructor for class com.mongodb.Mongo
 
Mongo.Holder - Class in com.mongodb
Mongo.Holder can be used as a static place to hold several instances of Mongo.
Mongo.ServerCursorAndNamespace - Class in com.mongodb
 
MongoBatchCursorAdapter<T> - Class in com.mongodb
 
MongoBatchCursorAdapter(BatchCursor<T>) - Constructor for class com.mongodb.MongoBatchCursorAdapter
 
MongoBulkWriteException - Exception in com.mongodb
An exception that represents all errors associated with a bulk write operation.
MongoBulkWriteException(BulkWriteResult, List<BulkWriteError>, WriteConcernError, ServerAddress) - Constructor for exception com.mongodb.MongoBulkWriteException
Constructs a new instance.
MongoChangeStreamException - Exception in com.mongodb
An exception indicating that a failure occurred when running a $changeStream.
MongoChangeStreamException(String) - Constructor for exception com.mongodb.MongoChangeStreamException
Constructs a new instance.
mongoClient - Variable in class com.mongodb.async.client.AsyncOperationExecutorImpl
 
mongoClient - Variable in class com.mongodb.async.client.ClientSessionHelper
 
MongoClient - Interface in com.mongodb.async.client
A client-side representation of a MongoDB cluster.
MongoClient - Class in com.mongodb
A MongoDB client with internal connection pooling.
MongoClient() - Constructor for class com.mongodb.MongoClient
Creates an instance based on a (single) mongodb node (localhost, default port).
MongoClient(String) - Constructor for class com.mongodb.MongoClient
Creates a Mongo instance based on a (single) mongodb node.
MongoClient(String, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
Creates a Mongo instance based on a (single) mongodb node (default port).
MongoClient(String, int) - Constructor for class com.mongodb.MongoClient
Creates a Mongo instance based on a (single) mongodb node.
MongoClient(ServerAddress) - Constructor for class com.mongodb.MongoClient
Creates a Mongo instance based on a (single) mongodb node
MongoClient(ServerAddress, List<MongoCredential>) - Constructor for class com.mongodb.MongoClient
MongoClient(ServerAddress, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
Creates a Mongo instance based on a (single) mongo node using a given ServerAddress and default options.
MongoClient(ServerAddress, List<MongoCredential>, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
MongoClient(ServerAddress, MongoCredential, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
Creates a Mongo instance based on a (single) mongo node using a given server address, credential, and options
MongoClient(List<ServerAddress>) - Constructor for class com.mongodb.MongoClient
Creates an instance based on a list of replica set members or mongos servers.
MongoClient(List<ServerAddress>, List<MongoCredential>) - Constructor for class com.mongodb.MongoClient
MongoClient(List<ServerAddress>, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
Construct an instance based on a list of replica set members or mongos servers.
MongoClient(List<ServerAddress>, List<MongoCredential>, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
MongoClient(List<ServerAddress>, MongoCredential, MongoClientOptions) - Constructor for class com.mongodb.MongoClient
Creates an instance based on a list of replica set members or mongos servers.
MongoClient(MongoClientURI) - Constructor for class com.mongodb.MongoClient
Creates a Mongo described by a URI.
MongoClient(MongoClientURI, MongoDriverInformation) - Constructor for class com.mongodb.MongoClient
Creates a Mongo described by a URI.
MongoClient(ServerAddress, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Constructor for class com.mongodb.MongoClient
MongoClient(ServerAddress, MongoCredential, MongoClientOptions, MongoDriverInformation) - Constructor for class com.mongodb.MongoClient
Creates a MongoClient to a single node using a given ServerAddress.
MongoClient(List<ServerAddress>, List<MongoCredential>, MongoClientOptions, MongoDriverInformation) - Constructor for class com.mongodb.MongoClient
MongoClient(List<ServerAddress>, MongoCredential, MongoClientOptions, MongoDriverInformation) - Constructor for class com.mongodb.MongoClient
Creates a MongoClient
MongoClientException - Exception in com.mongodb
A base class for exceptions indicating a failure condition with the MongoClient.
MongoClientException(String) - Constructor for exception com.mongodb.MongoClientException
Constructs a new instance.
MongoClientException(String, Throwable) - Constructor for exception com.mongodb.MongoClientException
Constructs a new instance.
MongoClientFactory - Class in com.mongodb.client.jndi
An ObjectFactory for MongoClient instances.
MongoClientFactory() - Constructor for class com.mongodb.client.jndi.MongoClientFactory
 
MongoClientImpl - Class in com.mongodb.async.client
 
MongoClientImpl(MongoClientSettings, Cluster, Closeable) - Constructor for class com.mongodb.async.client.MongoClientImpl
 
MongoClientImpl(MongoClientSettings, Cluster, AsyncOperationExecutor) - Constructor for class com.mongodb.async.client.MongoClientImpl
 
MongoClientImpl(MongoClientSettings, Cluster, AsyncOperationExecutor, Closeable) - Constructor for class com.mongodb.async.client.MongoClientImpl
 
MongoClientOptions - Class in com.mongodb
Various settings to control the behavior of a MongoClient.
MongoClientOptions(MongoClientOptions.Builder) - Constructor for class com.mongodb.MongoClientOptions
 
MongoClientOptions.Builder - Class in com.mongodb
A builder for MongoClientOptions so that MongoClientOptions can be immutable, and to support easier construction through chaining.
MongoClients - Class in com.mongodb.async.client
A factory for MongoClient instances.
MongoClients() - Constructor for class com.mongodb.async.client.MongoClients
 
MongoClientSettings - Class in com.mongodb.async.client
Various settings to control the behavior of a MongoClient.
MongoClientSettings(MongoClientSettings.Builder) - Constructor for class com.mongodb.async.client.MongoClientSettings
 
MongoClientSettings.Builder - Class in com.mongodb.async.client
A builder for MongoClientSettings so that MongoClientSettings can be immutable, and to support easier construction through chaining.
MongoClientURI - Class in com.mongodb
Represents a URI which can be used to create a MongoClient instance.
MongoClientURI(String) - Constructor for class com.mongodb.MongoClientURI
Creates a MongoURI from the given string.
MongoClientURI(String, MongoClientOptions.Builder) - Constructor for class com.mongodb.MongoClientURI
Creates a MongoURI from the given URI string, and MongoClientOptions.Builder.
MongoCollection<TDocument> - Interface in com.mongodb.async.client
The MongoCollection interface.
MongoCollection<TDocument> - Interface in com.mongodb.client
The MongoCollection interface.
MongoCollectionImpl<TDocument> - Class in com.mongodb.async.client
 
MongoCollectionImpl(MongoNamespace, Class<TDocument>, CodecRegistry, ReadPreference, WriteConcern, boolean, ReadConcern, AsyncOperationExecutor) - Constructor for class com.mongodb.async.client.MongoCollectionImpl
 
MongoCollectionImpl<TDocument> - Class in com.mongodb
 
MongoCollectionImpl(MongoNamespace, Class<TDocument>, CodecRegistry, ReadPreference, WriteConcern, boolean, ReadConcern, OperationExecutor) - Constructor for class com.mongodb.MongoCollectionImpl
 
MongoCommandException - Exception in com.mongodb
An exception indicating that a command sent to a MongoDB server returned a failure.
MongoCommandException(BsonDocument, ServerAddress) - Constructor for exception com.mongodb.MongoCommandException
Construct a new instance with the CommandResult from a failed command
MongoCompressor - Class in com.mongodb
Metadata describing a compressor to use for sending and receiving messages to a MongoDB server.
MongoCompressor(String) - Constructor for class com.mongodb.MongoCompressor
 
MongoCompressor(MongoCompressor, String, T) - Constructor for class com.mongodb.MongoCompressor
 
MongoConfigurationException - Exception in com.mongodb
An exception indicating a configuration error in the client.
MongoConfigurationException(String) - Constructor for exception com.mongodb.MongoConfigurationException
Construct an instance with the given message.
MongoConfigurationException(String, Throwable) - Constructor for exception com.mongodb.MongoConfigurationException
Construct an instance with the given message and cause.
MongoCredential - Class in com.mongodb
Represents credentials to authenticate to a mongo server,as well as the source of the credentials and the authentication mechanism to use.
MongoCredential(AuthenticationMechanism, String, String, char[]) - Constructor for class com.mongodb.MongoCredential
Constructs a new instance using the given mechanism, userName, source, and password
MongoCredential(MongoCredential, String, T) - Constructor for class com.mongodb.MongoCredential
Constructs a new instance using the given credential plus an additional mechanism property.
MongoCursor<TResult> - Interface in com.mongodb.client
The Mongo Cursor interface implementing the iterator protocol.
MongoCursorAdapter - Class in com.mongodb
 
MongoCursorAdapter(MongoCursor<DBObject>) - Constructor for class com.mongodb.MongoCursorAdapter
 
MongoCursorNotFoundException - Exception in com.mongodb
Subclass of MongoException representing a cursor-not-found exception.
MongoCursorNotFoundException(long, ServerAddress) - Constructor for exception com.mongodb.MongoCursorNotFoundException
Construct a new instance.
MongoDatabase - Interface in com.mongodb.async.client
The MongoDatabase interface.
MongoDatabase - Interface in com.mongodb.client
The MongoDatabase interface.
MongoDatabaseImpl - Class in com.mongodb.async.client
 
MongoDatabaseImpl(String, CodecRegistry, ReadPreference, WriteConcern, boolean, ReadConcern, AsyncOperationExecutor) - Constructor for class com.mongodb.async.client.MongoDatabaseImpl
 
MongoDatabaseImpl - Class in com.mongodb
 
MongoDatabaseImpl(String, CodecRegistry, ReadPreference, WriteConcern, boolean, ReadConcern, OperationExecutor) - Constructor for class com.mongodb.MongoDatabaseImpl
 
MONGODB_CR_MECHANISM - Static variable in class com.mongodb.MongoCredential
The MongoDB Challenge Response mechanism.
MONGODB_PREFIX - Static variable in class com.mongodb.ConnectionString
 
MONGODB_PREFIX - Static variable in class com.mongodb.MongoURI
Deprecated.
The prefix for mongodb URIs.
MONGODB_SRV_PREFIX - Static variable in class com.mongodb.ConnectionString
 
MONGODB_X509_MECHANISM - Static variable in class com.mongodb.MongoCredential
The MongoDB X.509
MongoDriverInformation - Class in com.mongodb.client
The MongoDriverInformation class allows driver and library authors to add extra information about their library.
MongoDriverInformation(List<String>, List<String>, List<String>) - Constructor for class com.mongodb.client.MongoDriverInformation
 
mongoDriverInformation - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
MongoDriverInformation.Builder - Class in com.mongodb.client
 
MongoException - Exception in com.mongodb
Top level Exception for all Exceptions, server-side or client-side, that come from the driver.
MongoException(String) - Constructor for exception com.mongodb.MongoException
 
MongoException(int, String) - Constructor for exception com.mongodb.MongoException
 
MongoException(String, Throwable) - Constructor for exception com.mongodb.MongoException
 
MongoException(int, String, Throwable) - Constructor for exception com.mongodb.MongoException
 
MongoExecutionTimeoutException - Exception in com.mongodb
Exception indicating that the execution of the current operation timed out as a result of the maximum operation time being exceeded.
MongoExecutionTimeoutException(int, String) - Constructor for exception com.mongodb.MongoExecutionTimeoutException
Construct a new instance.
MongoGridFSException - Exception in com.mongodb
An exception indicating that a failure occurred in GridFS.
MongoGridFSException(String) - Constructor for exception com.mongodb.MongoGridFSException
Constructs a new instance.
MongoGridFSException(String, Throwable) - Constructor for exception com.mongodb.MongoGridFSException
Constructs a new instance.
MongoIncompatibleDriverException - Exception in com.mongodb
An exception indicating that this version of the driver is not compatible with at least one of the servers that it is currently connected to.
MongoIncompatibleDriverException(String, ClusterDescription) - Constructor for exception com.mongodb.MongoIncompatibleDriverException
Construct a new instance.
MongoInternalException - Exception in com.mongodb
A Mongo exception internal to the driver, not carrying any error code.
MongoInternalException(String) - Constructor for exception com.mongodb.MongoInternalException
 
MongoInternalException(String, Throwable) - Constructor for exception com.mongodb.MongoInternalException
 
MongoInterruptedException - Exception in com.mongodb
A non-checked exception indicating that the driver has been interrupted by a call to Thread.interrupt.
MongoInterruptedException(String, Exception) - Constructor for exception com.mongodb.MongoInterruptedException
Construct a new instance.
MongoIterable<TResult> - Interface in com.mongodb.async.client
Operations that allow asynchronous iteration over a collection view.
mongoIterable - Variable in class com.mongodb.async.client.MongoIterableSubscription
 
MongoIterable<TResult> - Interface in com.mongodb.client
The MongoIterable is the results from an operation, such as a query.
MongoIterableImpl<TResult> - Class in com.mongodb.async.client
 
MongoIterableImpl(ClientSession, AsyncOperationExecutor, ReadConcern, ReadPreference) - Constructor for class com.mongodb.async.client.MongoIterableImpl
 
MongoIterableImpl<TResult> - Class in com.mongodb
 
MongoIterableImpl(ClientSession, OperationExecutor, ReadConcern, ReadPreference) - Constructor for class com.mongodb.MongoIterableImpl
 
MongoIterableSubscription<TResult> - Class in com.mongodb.async.client
 
MongoIterableSubscription(MongoIterable<TResult>, Observer<? super TResult>) - Constructor for class com.mongodb.async.client.MongoIterableSubscription
 
MongoMappingCursor<T,U> - Class in com.mongodb
 
MongoMappingCursor(MongoCursor<T>, Function<T, U>) - Constructor for class com.mongodb.MongoMappingCursor
 
MongoNamespace - Class in com.mongodb
A MongoDB namespace, which includes a database name and collection name.
MongoNamespace(String) - Constructor for class com.mongodb.MongoNamespace
Construct an instance for the given full name.
MongoNamespace(String, String) - Constructor for class com.mongodb.MongoNamespace
Construct an instance from the given database name and collection name.
MongoNodeIsRecoveringException - Exception in com.mongodb
An exception indicating that the server is a member of a replica set but is in recovery mode, and therefore refused to execute the operation.
MongoNodeIsRecoveringException(ServerAddress) - Constructor for exception com.mongodb.MongoNodeIsRecoveringException
Construct an instance.
MongoNotPrimaryException - Exception in com.mongodb
An exception indicating that the server is a member of a replica set but is not the primary, and therefore refused to execute either a write operation or a read operation that required a primary.
MongoNotPrimaryException(ServerAddress) - Constructor for exception com.mongodb.MongoNotPrimaryException
Construct an instance.
MongoOptions - Class in com.mongodb
Deprecated.
Please use MongoClientOptions instead.
MongoOptions() - Constructor for class com.mongodb.MongoOptions
Deprecated.
MongoOptions(MongoClientOptions) - Constructor for class com.mongodb.MongoOptions
Deprecated.
MongoQueryException - Exception in com.mongodb
An exception indicating that a query operation failed on the server.
MongoQueryException(ServerAddress, int, String) - Constructor for exception com.mongodb.MongoQueryException
Construct an instance.
MongoSecurityException - Exception in com.mongodb
This exception is thrown when there is an error reported by the underlying client authentication mechanism.
MongoSecurityException(MongoCredential, String, Throwable) - Constructor for exception com.mongodb.MongoSecurityException
Construct an instance
MongoSecurityException(MongoCredential, String) - Constructor for exception com.mongodb.MongoSecurityException
Construct an instance
MongoServerException - Exception in com.mongodb
An exception indicating that some error has been raised by a MongoDB server in response to an operation.
MongoServerException(String, ServerAddress) - Constructor for exception com.mongodb.MongoServerException
Construct a new instance.
MongoServerException(int, String, ServerAddress) - Constructor for exception com.mongodb.MongoServerException
Construct a new instance.
MongoSocketClosedException - Exception in com.mongodb
This exception is thrown when trying to read or write from a closed socket.
MongoSocketClosedException(String, ServerAddress) - Constructor for exception com.mongodb.MongoSocketClosedException
Construct an instance.
MongoSocketException - Exception in com.mongodb
Subclass of MongoException representing a network-related exception
MongoSocketException(String, ServerAddress, Throwable) - Constructor for exception com.mongodb.MongoSocketException
 
MongoSocketException(String, ServerAddress) - Constructor for exception com.mongodb.MongoSocketException
Construct a new instance.
MongoSocketOpenException - Exception in com.mongodb
This exception is thrown when there is an exception opening a Socket.
MongoSocketOpenException(String, ServerAddress, Throwable) - Constructor for exception com.mongodb.MongoSocketOpenException
Construct an instance.
MongoSocketReadException - Exception in com.mongodb
This exception is thrown when there is an exception reading a response from a Socket.
MongoSocketReadException(String, ServerAddress) - Constructor for exception com.mongodb.MongoSocketReadException
Construct a new instance.
MongoSocketReadException(String, ServerAddress, Throwable) - Constructor for exception com.mongodb.MongoSocketReadException
Construct a new instance.
MongoSocketReadTimeoutException - Exception in com.mongodb
This exception is thrown when there is a timeout reading a response from the socket.
MongoSocketReadTimeoutException(String, ServerAddress, Throwable) - Constructor for exception com.mongodb.MongoSocketReadTimeoutException
Construct a new instance
MongoSocketWriteException - Exception in com.mongodb
This exception is thrown when there is an exception writing a response to a Socket.
MongoSocketWriteException(String, ServerAddress, Throwable) - Constructor for exception com.mongodb.MongoSocketWriteException
Construct a new instance.
MongoTimeoutException - Exception in com.mongodb
An exception indicating that the driver has timed out waiting for either a server or a connection to become available.
MongoTimeoutException(String) - Constructor for exception com.mongodb.MongoTimeoutException
Construct a new instance.
MongoURI - Class in com.mongodb
Deprecated.
Replaced by MongoClientURI
MongoURI(String) - Constructor for class com.mongodb.MongoURI
Deprecated.
MongoURI(MongoClientURI) - Constructor for class com.mongodb.MongoURI
Deprecated.
MongoWaitQueueFullException - Exception in com.mongodb
An exception indicating that the queue for waiting for a pooled connection is full.
MongoWaitQueueFullException(String) - Constructor for exception com.mongodb.MongoWaitQueueFullException
Constructs a new instance with the given message.
MongoWriteConcernException - Exception in com.mongodb
An exception indicating a failure to apply the write concern to the requested write operation
MongoWriteConcernException(WriteConcernError, ServerAddress) - Constructor for exception com.mongodb.MongoWriteConcernException
Construct an instance.
MongoWriteConcernException(WriteConcernError, WriteConcernResult, ServerAddress) - Constructor for exception com.mongodb.MongoWriteConcernException
Construct an instance.
MongoWriteException - Exception in com.mongodb
An exception indicating the failure of a write operation.
MongoWriteException(WriteError, ServerAddress) - Constructor for exception com.mongodb.MongoWriteException
Construct an instance
monitor - Variable in class com.mongodb.connection.DefaultServerMonitor
 
monitorThread - Variable in class com.mongodb.connection.DefaultServerMonitor
 
mul(String, Number) - Static method in class com.mongodb.client.model.Updates
Creates an update that multiplies the value of the field with the given name by the given number.
multi(boolean) - Method in class com.mongodb.bulk.DeleteRequest
Sets whether all documents matching the query filter will be removed.
multi(boolean) - Method in class com.mongodb.bulk.UpdateRequest
Sets whether this will update all documents matching the query filter.
multi - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
multi(boolean) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets whether all documents matching the query filter will be removed.
multi - Variable in class com.mongodb.RemoveRequest
 
multi - Variable in class com.mongodb.UpdateRequest
 
MultiLineString - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON MultiLineString.
MultiLineString(List<List<Position>>) - Constructor for class com.mongodb.client.model.geojson.MultiLineString
Construct an instance with the given coordinates.
MultiLineString(CoordinateReferenceSystem, List<List<Position>>) - Constructor for class com.mongodb.client.model.geojson.MultiLineString
Construct an instance with the given coordinates and coordinate reference system.
MultiLineStringCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON MultiLineString.
MultiLineStringCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.MultiLineStringCodec
Constructs an instance.
MultiPoint - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON MultiPoint.
MultiPoint(List<Position>) - Constructor for class com.mongodb.client.model.geojson.MultiPoint
Construct an instance with the given coordinates.
MultiPoint(CoordinateReferenceSystem, List<Position>) - Constructor for class com.mongodb.client.model.geojson.MultiPoint
Construct an instance with the given coordinates and coordinate reference system.
MultiPointCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON MultiPoint.
MultiPointCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.MultiPointCodec
Constructs an instance.
MultiPolygon - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON MultiPolygon.
MultiPolygon(List<PolygonCoordinates>) - Constructor for class com.mongodb.client.model.geojson.MultiPolygon
Construct an instance.
MultiPolygon(CoordinateReferenceSystem, List<PolygonCoordinates>) - Constructor for class com.mongodb.client.model.geojson.MultiPolygon
Construct an instance.
MultiPolygonCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON MultiPolygon.
MultiPolygonCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.MultiPolygonCodec
Constructs an instance.
MultiServerCluster - Class in com.mongodb.connection
This class needs to be final because we are leaking a reference to "this" from the constructor
MultiServerCluster(ClusterId, ClusterSettings, ClusterableServerFactory) - Constructor for class com.mongodb.connection.MultiServerCluster
 
MultiServerCluster.DefaultServerStateListener - Class in com.mongodb.connection
 
MultiServerCluster.ServerTuple - Class in com.mongodb.connection
 
Mutable() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
mutateCollection(S, Collection) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 
mutateMap(S, Map) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 

N

n - Variable in class com.mongodb.WriteResult
 
name - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
name - Variable in class com.mongodb.bulk.IndexRequest
 
name(String) - Method in class com.mongodb.bulk.IndexRequest
Sets the name of the index.
name - Variable in class com.mongodb.client.model.Aggregates.SimplePipelineStage
 
name - Variable in class com.mongodb.client.model.BsonField
 
name - Variable in class com.mongodb.client.model.Facet
 
name - Variable in class com.mongodb.client.model.Field
 
name - Variable in enum com.mongodb.client.model.Filters.OrNorFilter.Operator
 
name - Variable in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
 
name - Variable in class com.mongodb.client.model.IndexOptions
 
name(String) - Method in class com.mongodb.client.model.IndexOptions
Sets the name of the index.
name - Variable in class com.mongodb.client.model.SimpleExpression
 
name - Variable in class com.mongodb.DB
 
name - Variable in class com.mongodb.DBCollection
 
name - Variable in class com.mongodb.MongoCompressor
 
name - Variable in class com.mongodb.MongoDatabaseImpl
 
name - Variable in class com.mongodb.ReflectionDBObject.FieldInfo
 
name - Variable in class com.mongodb.ReflectionDBObject.JavaWrapper
 
name - Variable in class com.mongodb.Tag
 
name - Variable in class org.bson.AbstractBsonWriter.Context
 
name - Variable in class org.bson.BSONCallbackAdapter.Context
 
name - Variable in class org.bson.BsonElement
 
name - Variable in class org.bson.codecs.pojo.ClassModel
 
name - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
name - Variable in class org.bson.codecs.pojo.PropertyModel
 
name - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
NAMED_CONCERNS - Static variable in class com.mongodb.WriteConcern
 
NamedCoordinateReferenceSystem - Class in com.mongodb.client.model.geojson
A GeoJSON named Coordinate Reference System.
NamedCoordinateReferenceSystem(String) - Constructor for class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
Construct an instance
NamedCoordinateReferenceSystemCodec - Class in com.mongodb.client.model.geojson.codecs
Codec for a GeoJson Coordinate Reference System of type name.
NamedCoordinateReferenceSystemCodec() - Constructor for class com.mongodb.client.model.geojson.codecs.NamedCoordinateReferenceSystemCodec
 
nameMatches(String, String...) - Static method in class com.mongodb.connection.ClientMetadataHelper
 
nameOnly(Boolean) - Method in interface com.mongodb.async.client.ListDatabasesIterable
Sets the nameOnly flag that indicates whether the command should return just the database names or return the database names and size information.
nameOnly - Variable in class com.mongodb.async.client.ListDatabasesIterableImpl
 
nameOnly(Boolean) - Method in class com.mongodb.async.client.ListDatabasesIterableImpl
 
nameOnly(Boolean) - Method in interface com.mongodb.client.ListDatabasesIterable
Sets the nameOnly flag that indicates whether the command should return just the database names or return the database names and size information.
nameOnly - Variable in class com.mongodb.ListDatabasesIterableImpl
 
nameOnly(Boolean) - Method in class com.mongodb.ListDatabasesIterableImpl
 
nameOnly - Variable in class com.mongodb.operation.ListDatabasesOperation
 
nameOnly(Boolean) - Method in class com.mongodb.operation.ListDatabasesOperation
Sets the nameOnly flag that indicates whether the command should return just the database names or return the database names and size information.
namePrefix - Variable in class com.mongodb.internal.thread.DaemonThreadFactory
 
namespace - Variable in class com.mongodb.AggregateIterableImpl
 
namespace - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
namespace - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
namespace - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
namespace - Variable in class com.mongodb.async.client.FindIterableImpl
 
namespace - Variable in class com.mongodb.async.client.ListIndexesIterableImpl
 
namespace - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
namespace - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
namespace - Variable in class com.mongodb.ChangeStreamIterableImpl
 
namespace - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
namespace - Variable in class com.mongodb.connection.CommandMessage
 
namespace - Variable in class com.mongodb.connection.CommandProtocolImpl
 
namespace - Variable in class com.mongodb.connection.GetMoreProtocol
 
namespace - Variable in class com.mongodb.connection.KillCursorProtocol
 
namespace - Variable in class com.mongodb.connection.QueryProtocol
 
namespace - Variable in class com.mongodb.connection.QueryResult
 
namespace - Variable in class com.mongodb.connection.WriteProtocol
 
namespace - Variable in class com.mongodb.DBCursor.OptionalFinalizer
 
namespace - Variable in class com.mongodb.DistinctIterableImpl
 
namespace - Variable in class com.mongodb.FindIterableImpl
 
namespace - Variable in class com.mongodb.ListIndexesIterableImpl
 
namespace - Variable in class com.mongodb.MapReduceIterableImpl
 
namespace - Variable in class com.mongodb.Mongo.ServerCursorAndNamespace
 
namespace - Variable in class com.mongodb.MongoCollectionImpl
 
namespace - Variable in class com.mongodb.operation.AggregateExplainOperation
 
namespace - Variable in class com.mongodb.operation.AggregateOperation
 
namespace - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
namespace - Variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
namespace - Variable in class com.mongodb.operation.BaseWriteOperation
 
namespace - Variable in class com.mongodb.operation.BulkWriteBatch
 
namespace - Variable in class com.mongodb.operation.ChangeStreamOperation
 
namespace - Variable in class com.mongodb.operation.CountOperation
 
namespace - Variable in class com.mongodb.operation.CreateIndexesOperation
 
namespace - Variable in class com.mongodb.operation.DistinctOperation
 
namespace - Variable in class com.mongodb.operation.DropCollectionOperation
 
namespace - Variable in class com.mongodb.operation.DropIndexOperation
 
namespace - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
namespace - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
namespace - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
namespace - Variable in class com.mongodb.operation.FindOperation
 
namespace - Variable in class com.mongodb.operation.GroupOperation
 
namespace - Variable in class com.mongodb.operation.ListIndexesOperation
 
namespace - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
namespace - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
namespace - Variable in class com.mongodb.operation.MixedBulkWriteOperation
 
namespace - Variable in class com.mongodb.operation.ParallelCollectionScanOperation
 
namespace - Variable in class com.mongodb.operation.QueryBatchCursor
 
namespace - Variable in class org.bson.BsonDbPointer
 
nameStack - Variable in class org.bson.BasicBSONCallback
 
NaN - Static variable in class org.bson.types.Decimal128
A constant holding a Not-a-Number (NaN) value of type Decimal128.
NaN_MASK - Static variable in class org.bson.types.Decimal128
 
NaN_STRINGS - Static variable in class org.bson.types.Decimal128
 
nanoTime() - Static method in class com.mongodb.connection.Time
 
NativeAuthenticationHelper - Class in com.mongodb.internal.authentication
Utility class for working with MongoDB native authentication.
NativeAuthenticationHelper() - Constructor for class com.mongodb.internal.authentication.NativeAuthenticationHelper
 
NativeAuthenticator - Class in com.mongodb.connection
 
NativeAuthenticator(MongoCredential) - Constructor for class com.mongodb.connection.NativeAuthenticator
 
ne(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 does not equal the specified value.
NE - Static variable in class com.mongodb.QueryOperators
 
near(String, Point, Double, Double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that is near the specified GeoJSON point.
near(String, Bson, Double, Double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that is near the specified GeoJSON point.
near(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 geospatial data that is near the specified point.
near(double, double) - Method in class com.mongodb.QueryBuilder
Equivalent of the $near operand
near(double, double, double) - Method in class com.mongodb.QueryBuilder
Equivalent of the $near operand
NEAR - Static variable in class com.mongodb.QueryOperators
 
NEAR_SPHERE - Static variable in class com.mongodb.QueryOperators
 
NEAREST - Static variable in class com.mongodb.ReadPreference
 
nearest() - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a primary or a secondary.
nearest(long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a primary or a secondary that is less stale than the given maximum.
nearest(TagSet) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary or a secondary with the given set of tags.
nearest(TagSet, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary or a secondary with the given set of tags that is less stale than the given maximum.
nearest(List<TagSet>) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary or a secondary with one of the given sets of tags.
nearest(List<TagSet>, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary or a secondary with one of the given sets of tags that is less stale than the given maximum.
NearestReadPreference() - Constructor for class com.mongodb.TaggableReadPreference.NearestReadPreference
 
NearestReadPreference(List<TagSet>, Long, TimeUnit) - Constructor for class com.mongodb.TaggableReadPreference.NearestReadPreference
 
nearSphere(String, Point, Double, Double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that is near the specified GeoJSON point using spherical geometry.
nearSphere(String, Bson, Double, Double) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents containing a field with geospatial data that is near the specified GeoJSON point using spherical geometry.
nearSphere(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 geospatial data that is near the specified point using spherical geometry.
nearSphere(double, double) - Method in class com.mongodb.QueryBuilder
Equivalent of the $nearSphere operand
nearSphere(double, double, double) - Method in class com.mongodb.QueryBuilder
Equivalent of the $nearSphere operand
NEGATIVE_INFINITY - Static variable in class org.bson.types.Decimal128
A constant holding the negative infinity of type Decimal128.
NEGATIVE_INFINITY_STRINGS - Static variable in class org.bson.types.Decimal128
 
NEGATIVE_NaN - Static variable in class org.bson.types.Decimal128
A constant holding a negative Not-a-Number (-NaN) value of type Decimal128.
NEGATIVE_NaN_STRINGS - Static variable in class org.bson.types.Decimal128
 
NEGATIVE_ZERO - Static variable in class org.bson.types.Decimal128
A constant holding a negative zero value of type Decimal128.
nestedTypeParameters(List<TypeData<?>>) - Static method in class org.bson.codecs.pojo.TypeData
 
NettyBufferProvider - Class in com.mongodb.connection.netty
 
NettyBufferProvider() - Constructor for class com.mongodb.connection.netty.NettyBufferProvider
 
NettyBufferProvider(ByteBufAllocator) - Constructor for class com.mongodb.connection.netty.NettyBufferProvider
 
NettyByteBuf - Class in com.mongodb.connection.netty
 
NettyByteBuf(ByteBuf) - Constructor for class com.mongodb.connection.netty.NettyByteBuf
 
NettyByteBuf(ByteBuf, boolean) - Constructor for class com.mongodb.connection.netty.NettyByteBuf
 
NettyMongoClients - Class in com.mongodb.async.client
 
NettyMongoClients() - Constructor for class com.mongodb.async.client.NettyMongoClients
 
NettyStream - Class in com.mongodb.connection.netty
A Stream implementation based on Netty 4.0.
NettyStream(ServerAddress, SocketSettings, SslSettings, EventLoopGroup, Class<? extends SocketChannel>, ByteBufAllocator) - Constructor for class com.mongodb.connection.netty.NettyStream
 
NettyStream.FutureAsyncCompletionHandler<T> - Class in com.mongodb.connection.netty
 
NettyStream.InboundBufferHandler - Class in com.mongodb.connection.netty
 
NettyStream.PendingReader - Class in com.mongodb.connection.netty
 
NettyStreamFactory - Class in com.mongodb.connection.netty
A StreamFactory for Streams based on Netty 4.x.
NettyStreamFactory(SocketSettings, SslSettings, EventLoopGroup, Class<? extends SocketChannel>, ByteBufAllocator) - Constructor for class com.mongodb.connection.netty.NettyStreamFactory
Construct a new instance of the factory.
NettyStreamFactory(SocketSettings, SslSettings, EventLoopGroup, ByteBufAllocator) - Constructor for class com.mongodb.connection.netty.NettyStreamFactory
Construct a new instance of the factory.
NettyStreamFactory(SocketSettings, SslSettings, EventLoopGroup) - Constructor for class com.mongodb.connection.netty.NettyStreamFactory
Construct a new instance of the factory.
NettyStreamFactory(SocketSettings, SslSettings) - Constructor for class com.mongodb.connection.netty.NettyStreamFactory
Construct a new instance of the factory with a default allocator, nio event loop group and nio socket channel.
NettyStreamFactoryFactory - Class in com.mongodb.connection.netty
A StreamFactoryFactory implementation for Netty-based streams.
NettyStreamFactoryFactory() - Constructor for class com.mongodb.connection.netty.NettyStreamFactoryFactory
Deprecated.
Use NettyStreamFactoryFactory.builder() instead to construct the NettyStreamFactoryFactory.
NettyStreamFactoryFactory(EventLoopGroup, ByteBufAllocator) - Constructor for class com.mongodb.connection.netty.NettyStreamFactoryFactory
Deprecated.
Use NettyStreamFactoryFactory.builder() instead to construct the NettyStreamFactoryFactory.
NettyStreamFactoryFactory(NettyStreamFactoryFactory.Builder) - Constructor for class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
NettyStreamFactoryFactory.Builder - Class in com.mongodb.connection.netty
A builder for an instance of NettyStreamFactoryFactory.
newDescription - Variable in class com.mongodb.event.ClusterDescriptionChangedEvent
 
newDescription - Variable in class com.mongodb.event.ServerDescriptionChangedEvent
 
newHashMap() - Method in class org.bson.util.CopyOnWriteMap.Builder
 
newHashMap() - Static method in class org.bson.util.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying HashMap.
newHashMap(Map<? extends K, ? extends V>) - Static method in class org.bson.util.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying HashMap using the supplied map as the initial values.
newInstance - Variable in class org.bson.codecs.pojo.InstanceCreatorImpl
 
newInstance(Method) - Static method in class org.bson.codecs.pojo.TypeData
 
newInstance(Field) - Static method in class org.bson.codecs.pojo.TypeData
 
newInstance(Type, Class<T>) - Static method in class org.bson.codecs.pojo.TypeData
 
newLineCharacters - Variable in class org.bson.json.JsonWriterSettings.Builder
 
newLineCharacters(String) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the new line character string to use when indentation is enabled, which defaults to System.getProperty("line.separator").
newLineCharacters - Variable in class org.bson.json.JsonWriterSettings
 
newLineCharacters - Variable in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
 
newLineCharacters(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriterSettings.Builder
Sets the new line character string to use when indentation is enabled.
newLineCharacters - Variable in class org.bson.json.StrictCharacterStreamJsonWriterSettings
 
newLinkedMap() - Method in class org.bson.util.CopyOnWriteMap.Builder
 
newLinkedMap() - Static method in class org.bson.util.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying LinkedHashMap.
newLinkedMap(Map<? extends K, ? extends V>) - Static method in class org.bson.util.CopyOnWriteMap
Creates a new CopyOnWriteMap with an underlying LinkedHashMap using the supplied map as the initial values.
newNamespace - Variable in class com.mongodb.operation.RenameCollectionOperation
 
newThread(Runnable) - Method in class com.mongodb.internal.thread.DaemonThreadFactory
 
newValue - Variable in class com.mongodb.connection.ChangeEvent
 
next(SingleResultCallback<List<T>>) - Method in interface com.mongodb.async.AsyncBatchCursor
Returns the next batch of results.
next(SingleResultCallback<List<U>>) - Method in class com.mongodb.async.client.MappingAsyncBatchCursor
 
next() - Method in interface com.mongodb.client.MongoCursor
 
next() - Method in class com.mongodb.DBCursor
Returns the object the cursor is at and moves the cursor ahead by one.
next - Variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
next() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
next() - Method in class com.mongodb.MongoBatchCursorAdapter
 
next() - Method in class com.mongodb.MongoCursorAdapter
 
next() - Method in class com.mongodb.MongoMappingCursor
 
next(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
next(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
next(SingleResultCallback<List<T>>, boolean) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
next(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
next() - Method in interface com.mongodb.operation.BatchCursor
Returns the next batch of results.
next() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
next(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
next() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
next() - Method in class com.mongodb.operation.QueryBatchCursor
 
next() - Method in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
next() - Method in class org.bson.LazyBSONList.LazyBSONListIterator
 
next() - Method in class org.bson.util.AbstractCopyOnWriteMap.UnmodifiableIterator
 
NEXT_COUNTER - Static variable in class org.bson.types.ObjectId
 
nextBatch - Variable in class com.mongodb.operation.QueryBatchCursor
 
nextInternal() - Method in class com.mongodb.DBCursor
 
nextNonmarker() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns next node, ignoring deletion marker.
nextToken() - Method in class org.bson.json.JsonScanner
Finds and returns the next complete token from this scanner.
nin(String, TItem...) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of a field does not equal any of the specified values or does not exist.
nin(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 does not equal any of the specified values or does not exist.
NIN - Static variable in class com.mongodb.QueryOperators
 
NO_CONVENTIONS - Static variable in class org.bson.codecs.pojo.Conventions
An empty conventions list
NO_OP_CLUSTER_LISTENER - Static variable in class com.mongodb.internal.event.EventListenerHelper
 
NO_OP_CONNECTION_POOL_LISTENER - Static variable in class com.mongodb.internal.event.EventListenerHelper
 
NO_OP_FIELD_NAME_VALIDATOR - Static variable in class com.mongodb.operation.AsyncQueryBatchCursor
 
NO_OP_FIELD_NAME_VALIDATOR - Static variable in class com.mongodb.operation.BulkWriteBatch
 
NO_OP_FIELD_NAME_VALIDATOR - Static variable in class com.mongodb.operation.MixedBulkWriteOperation
 
NO_OP_FIELD_NAME_VALIDATOR - Static variable in class com.mongodb.operation.QueryBatchCursor
 
NO_OP_SERVER_LISTENER - Static variable in class com.mongodb.internal.event.EventListenerHelper
 
NO_OP_SERVER_MONITOR_LISTENER - Static variable in class com.mongodb.internal.event.EventListenerHelper
 
noCursorTimeout(boolean) - Method in interface com.mongodb.async.client.FindIterable
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
noCursorTimeout(boolean) - Method in class com.mongodb.async.client.FindIterableImpl
 
noCursorTimeout(boolean) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
noCursorTimeout(boolean) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
noCursorTimeout(boolean) - Method in interface com.mongodb.client.FindIterable
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
noCursorTimeout(boolean) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
noCursorTimeout(boolean) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
noCursorTimeout - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
noCursorTimeout(boolean) - Method in class com.mongodb.client.model.DBCollectionFindOptions
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
noCursorTimeout - Variable in class com.mongodb.client.model.FindOptions
 
noCursorTimeout(boolean) - Method in class com.mongodb.client.model.FindOptions
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
noCursorTimeout - Variable in class com.mongodb.connection.BaseQueryMessage
 
noCursorTimeout(boolean) - Method in class com.mongodb.connection.BaseQueryMessage
Sets if the cursor timeout should be turned off.
noCursorTimeout - Variable in class com.mongodb.connection.QueryProtocol
 
noCursorTimeout(boolean) - Method in class com.mongodb.connection.QueryProtocol
Sets if the cursor timeout should be turned off.
noCursorTimeout(boolean) - Method in class com.mongodb.FindIterableImpl
 
noCursorTimeout - Variable in class com.mongodb.operation.FindOperation
 
noCursorTimeout(boolean) - Method in class com.mongodb.operation.FindOperation
Sets if the cursor timeout should be turned off.
Node(E, ConcurrentLinkedDeque.Node<E>, ConcurrentLinkedDeque.Node<E>) - Constructor for class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Creates a node with given contents.
Node(ConcurrentLinkedDeque.Node<E>) - Constructor for class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Creates a marker node with given successor.
nonAtomic(boolean) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets if the post-processing step will prevent MongoDB from locking the database.
nonAtomic - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
nonAtomic(boolean) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
nonAtomic(boolean) - Method in interface com.mongodb.client.MapReduceIterable
Sets if the post-processing step will prevent MongoDB from locking the database.
nonAtomic - Variable in class com.mongodb.MapReduceIterableImpl
 
nonAtomic(boolean) - Method in class com.mongodb.MapReduceIterableImpl
 
nonAtomic - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
nonAtomic(boolean) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets if the post-processing step will prevent MongoDB from locking the database.
NONE - Static variable in class org.bson.codecs.configuration.Optional
 
NoOpFieldNameValidator - Class in com.mongodb.internal.validator
A field name validator that treats all fields as valid.
NoOpFieldNameValidator() - Constructor for class com.mongodb.internal.validator.NoOpFieldNameValidator
 
NoOpFieldNameValidator - Class in org.bson
 
NoOpFieldNameValidator() - Constructor for class org.bson.NoOpFieldNameValidator
 
NoOpSessionContext - Class in com.mongodb.internal.connection
A SessionContext implementation that does nothing and reports that it has no session.
NoOpSessionContext() - Constructor for class com.mongodb.internal.connection.NoOpSessionContext
 
nor(Bson...) - Static method in class com.mongodb.client.model.Filters
Creates a filter that performs a logical NOR operation on all the specified filters.
nor(Iterable<Bson>) - Static method in class com.mongodb.client.model.Filters
Creates a filter that performs a logical NOR operation on all the specified filters.
NOR - Static variable in class com.mongodb.QueryOperators
 
NORMAL - Static variable in class com.mongodb.WriteConcern
Deprecated.
normalization - Variable in class com.mongodb.client.model.Collation.Builder
 
normalization(Boolean) - Method in class com.mongodb.client.model.Collation.Builder
Sets the normalization value
normalization - Variable in class com.mongodb.client.model.Collation
 
not(Bson) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents that do not match the passed in filter.
not() - Method in class com.mongodb.QueryBuilder
Equivalent to $not meta operator.
NOT - Static variable in class com.mongodb.QueryOperators
 
notEquals(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $ne operand
NotFilter(Bson) - Constructor for class com.mongodb.client.model.Filters.NotFilter
 
notFound() - Method in interface com.mongodb.connection.AbstractByteBufBsonDocument.Finder
 
notifyWaitQueueHandler(BaseCluster.ServerSelectionRequest) - Method in class com.mongodb.connection.BaseCluster
 
notIn(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $nin operand
notNull(String, T) - Static method in class com.mongodb.assertions.Assertions
Throw IllegalArgumentException if the value is null.
notNull(String, T, SingleResultCallback<?>) - Static method in class com.mongodb.assertions.Assertions
Throw IllegalArgumentException if the value is null.
notNull(String, T) - Static method in class org.bson.assertions.Assertions
Throw IllegalArgumentException if the value is null.
notStaticOrTransient(int) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
NotThreadSafe - Annotation Type in com.mongodb.annotations
The class to which this annotation is applied is not thread-safe.
NULL - Static variable in class org.bson.BSON
 
nullConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
nullConverter(Converter<BsonNull>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Null values to JSON.
nullConverter - Variable in class org.bson.json.JsonWriterSettings
 
NullMBeanServer - Class in com.mongodb.management
This class is NOT part of the public API.
NullMBeanServer() - Constructor for class com.mongodb.management.NullMBeanServer
 
NullObject() - Constructor for class com.mongodb.QueryBuilder.NullObject
 
NUMBER - Static variable in class org.bson.BSON
 
NUMBER_INT - Static variable in class org.bson.BSON
 
NUMBER_LONG - Static variable in class org.bson.BSON
 
NumberCodecHelper - Class in org.bson.codecs
 
NumberCodecHelper() - Constructor for class org.bson.codecs.NumberCodecHelper
 
numberOfChunks - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
numberOfChunks - Variable in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
numberOfChunks - Variable in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
numberReturned - Variable in class com.mongodb.connection.ReplyHeader
 
NumberState() - Constructor for enum org.bson.json.JsonScanner.NumberState
 
numberToReturn - Variable in class com.mongodb.connection.BaseQueryMessage
 
numberToReturn - Variable in class com.mongodb.connection.GetMoreMessage
 
numberToReturn - Variable in class com.mongodb.connection.GetMoreProtocol
 
numberToReturn - Variable in class com.mongodb.connection.QueryProtocol
 
numBytes - Variable in class com.mongodb.connection.netty.NettyStream.PendingReader
 
numChunks() - Method in class com.mongodb.gridfs.GridFSFile
Returns the number of chunks that store the file data.
numCursors - Variable in class com.mongodb.operation.ParallelCollectionScanOperation
 
numCursors - Variable in class com.mongodb.ParallelScanOptions.Builder
 
numCursors(int) - Method in class com.mongodb.ParallelScanOptions.Builder
Set the requested number of cursors to iterate in parallel.
numCursors - Variable in class com.mongodb.ParallelScanOptions
 
numericOrdering - Variable in class com.mongodb.client.model.Collation.Builder
 
numericOrdering(Boolean) - Method in class com.mongodb.client.model.Collation.Builder
Sets the numeric ordering
numericOrdering - Variable in class com.mongodb.client.model.Collation
 
numSeen - Variable in class com.mongodb.DBCursor
 
numSeen() - Method in class com.mongodb.DBCursor
Returns the number of objects through which the cursor has iterated.

O

OBEDIENT_COMMANDS - Static variable in class com.mongodb.DB
 
OBJECT - Static variable in class org.bson.BSON
 
ObjectArraySerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.ObjectArraySerializer
Deprecated.
 
objectCodec - Variable in class com.mongodb.DBCollection
 
objectDone() - Method in class com.mongodb.DefaultDBCallback
 
objectDone() - Method in class com.mongodb.util.JSONCallback
Deprecated.
 
objectDone() - Method in class org.bson.BasicBSONCallback
 
objectDone() - Method in interface org.bson.BSONCallback
Called at the end of the document/array, and returns this object.
objectDone() - Method in class org.bson.EmptyBSONCallback
 
objectFactory - Variable in class com.mongodb.DBCollection
 
objectFactory - Variable in class com.mongodb.DBObjectCodec
 
objectFactory - Variable in class com.mongodb.DefaultDBCallback
 
ObjectId - Class in org.bson.types
A globally unique identifier for objects.
ObjectId() - Constructor for class org.bson.types.ObjectId
Create a new object id.
ObjectId(Date) - Constructor for class org.bson.types.ObjectId
Constructs a new instance using the given date.
ObjectId(Date, int) - Constructor for class org.bson.types.ObjectId
Constructs a new instances using the given date and counter.
ObjectId(Date, int, short, int) - Constructor for class org.bson.types.ObjectId
Constructs a new instances using the given date, machine identifier, process identifier, and counter.
ObjectId(int, int, short, int) - Constructor for class org.bson.types.ObjectId
Creates an ObjectId using the given time, machine identifier, process identifier, and counter.
ObjectId(int, int, short, int, boolean) - Constructor for class org.bson.types.ObjectId
 
ObjectId(String) - Constructor for class org.bson.types.ObjectId
Constructs a new instance from a 24-byte hexadecimal string representation.
ObjectId(byte[]) - Constructor for class org.bson.types.ObjectId
Constructs a new instance from the given byte array
ObjectId(int, int, int) - Constructor for class org.bson.types.ObjectId
Creates an ObjectId
ObjectId(ByteBuffer) - Constructor for class org.bson.types.ObjectId
Constructs a new instance from the given ByteBuffer
ObjectIdCodec - Class in org.bson.codecs
A Codec for ObjectId instances.
ObjectIdCodec() - Constructor for class org.bson.codecs.ObjectIdCodec
 
objectIdConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
objectIdConverter(Converter<ObjectId>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON ObjectId values to JSON.
objectIdConverter - Variable in class org.bson.json.JsonWriterSettings
 
ObjectIdGenerator - Class in org.bson.codecs
Creates new ObjectId instances as IDs for MongoDB Documents.
ObjectIdGenerator() - Constructor for class org.bson.codecs.ObjectIdGenerator
 
ObjectIdSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.ObjectIdSerializer
Deprecated.
 
ObjectSerializer - Interface in com.mongodb.util
Interface describing methods for serializing an object to a string.
objectStart(String) - Method in class com.mongodb.util.JSONCallback
Deprecated.
 
objectStart() - Method in class org.bson.BasicBSONCallback
 
objectStart(String) - Method in class org.bson.BasicBSONCallback
 
objectStart() - Method in interface org.bson.BSONCallback
Signals the start of a BSON document, which usually maps onto some Java object.
objectStart(String) - Method in interface org.bson.BSONCallback
Signals the start of a BSON document, which usually maps onto some Java object.
objectStart() - Method in class org.bson.EmptyBSONCallback
 
objectStart(String) - Method in class org.bson.EmptyBSONCallback
 
Observable<TResult> - Interface in com.mongodb.async.client
A Observable represents a MongoDB operation.
Observables - Class in com.mongodb.async.client
Observable helpers.
Observables() - Constructor for class com.mongodb.async.client.Observables
 
observe(MongoIterable<TResult>) - Static method in class com.mongodb.async.client.Observables
Convert a MongoIterable into an Observable.
observe(Block<SingleResultCallback<TResult>>) - Static method in class com.mongodb.async.client.Observables
Allows the conversion of SingleResultCallback based operations into an Observable
observeAndFlatten(Block<SingleResultCallback<List<TResult>>>) - Static method in class com.mongodb.async.client.Observables
Allows the conversion of SingleResultCallback based operations and flattens the results in an Observable.
observer - Variable in class com.mongodb.async.client.AbstractSubscription
 
Observer<TResult> - Interface in com.mongodb.async.client
Provides a mechanism for receiving push-based notifications.
of(T) - Static method in class org.bson.codecs.configuration.Optional
 
offer(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Inserts the specified element at the tail of this queue.
offerFirst(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Inserts the specified element at the front of this deque.
offerLast(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Inserts the specified element at the end of this deque.
offset - Variable in class com.mongodb.connection.CompositeByteBuf.Component
 
offset - Variable in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
offset - Variable in class org.bson.LazyBSONObject
 
offset - Variable in class org.bson.RawBsonDocument
 
OID - Static variable in class org.bson.BSON
 
ok() - Method in class com.mongodb.CommandResult
Gets the "ok" field, which is whether this command executed correctly or not.
ok - Variable in class com.mongodb.connection.ServerDescription.Builder
 
ok(boolean) - Method in class com.mongodb.connection.ServerDescription.Builder
The isOK() result from requesting this information from MongoDB
ok - Variable in class com.mongodb.connection.ServerDescription
 
ok() - Method in class com.mongodb.ReflectionDBObject.FieldInfo
 
onChange(ServerDescriptionChangedEvent) - Method in class com.mongodb.connection.MultiServerCluster
 
onComplete() - Method in class com.mongodb.async.client.AbstractSubscription
 
onComplete() - Method in interface com.mongodb.async.client.Observer
Notifies the Subscriber that the Observable has finished sending push-based notifications.
one() - Method in class com.mongodb.DBCursor
Returns the first document that matches the query.
ONE_BYTE_ASCII_STRINGS - Static variable in class org.bson.io.ByteBufferBsonInput
 
onError(Throwable) - Method in class com.mongodb.async.client.AbstractSubscription
 
onError(Throwable) - Method in interface com.mongodb.async.client.Observer
Notifies the Observer that the Observable has experienced an error condition.
onNext(TResult) - Method in class com.mongodb.async.client.AbstractSubscription
 
onNext(TResult) - Method in interface com.mongodb.async.client.Observer
Provides the Observer with a new item to observe.
onResult(T, Throwable) - Method in interface com.mongodb.async.SingleResultCallback
Called when the operation completes.
onResult(Server, Throwable) - Method in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
onResult(ByteBuf, Throwable) - Method in class com.mongodb.connection.InternalStreamConnection.MessageHeaderCallback.MessageCallback
 
onResult(ByteBuf, Throwable) - Method in class com.mongodb.connection.InternalStreamConnection.MessageHeaderCallback
 
onResult(Void, Throwable) - Method in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
onResult(ResponseBuffers, Throwable) - Method in class com.mongodb.connection.ResponseCallback
 
onResult(BsonDocument, Throwable) - Method in class com.mongodb.connection.SaslAuthenticator.Continuator
 
onResult(Void, Throwable) - Method in class com.mongodb.connection.SendMessageCallback
 
onResult(Void, Throwable) - Method in class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
onResult(T, Throwable) - Method in class com.mongodb.internal.async.ErrorHandlingResultCallback
 
onResult(BsonDocument, Throwable) - Method in class com.mongodb.operation.AsyncQueryBatchCursor.CommandResultSingleResultCallback
 
onResult(QueryResult<T>, Throwable) - Method in class com.mongodb.operation.AsyncQueryBatchCursor.QueryResultSingleResultCallback
 
onResult(AsyncConnectionSource, Throwable) - Method in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
onResult(T, Throwable) - Method in class com.mongodb.operation.CommandOperationHelper.TransformingResultCallback
 
onResult(AsyncBatchCursor<BsonDocument>, Throwable) - Method in class com.mongodb.operation.FindOperation.ExplainResultCallback
 
onResult(AsyncConnectionSource, Throwable) - Method in class com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionAndSourceCallback
 
onResult(AsyncConnectionSource, Throwable) - Method in class com.mongodb.operation.OperationHelper.AsyncCallableWithConnectionCallback
 
onResult(T, Throwable) - Method in class com.mongodb.operation.OperationHelper.ConnectionReleasingWrappedCallback
 
onResult(T, Throwable) - Method in class com.mongodb.operation.OperationHelper.ReferenceCountedReleasingWrappedCallback
 
onSubscribe(Subscription) - Method in interface com.mongodb.async.client.Observer
Invoked on subscription to an Observable.
opCode - Variable in class com.mongodb.connection.MessageHeader
 
OpCode - Enum in com.mongodb.connection
 
OpCode(int) - Constructor for enum com.mongodb.connection.OpCode
 
opCode - Variable in class com.mongodb.connection.RequestMessage
 
open() - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
open() - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
open() - Method in interface com.mongodb.connection.InternalConnection
Opens the connection so its ready for use
open() - Method in class com.mongodb.connection.InternalStreamConnection
 
open() - Method in class com.mongodb.connection.netty.NettyStream
 
open() - Method in class com.mongodb.connection.SocketChannelStream
 
open() - Method in class com.mongodb.connection.SocketStream
 
open() - Method in interface com.mongodb.connection.Stream
Open the stream.
open() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
openAsync(AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
openAsync(DefaultConnectionPool.PooledConnection, SingleResultCallback<InternalConnection>) - Method in class com.mongodb.connection.DefaultConnectionPool
 
openAsync(SingleResultCallback<Void>) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
openAsync(SingleResultCallback<Void>) - Method in interface com.mongodb.connection.InternalConnection
Opens the connection so its ready for use
openAsync(SingleResultCallback<Void>) - Method in class com.mongodb.connection.InternalStreamConnection
 
openAsync(AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.netty.NettyStream
 
openAsync(AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.SocketChannelStream
 
openAsync(AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.SocketStream
 
openAsync(AsyncCompletionHandler<Void>) - Method in interface com.mongodb.connection.Stream
Open the stream asynchronously.
openAsync(SingleResultCallback<Void>) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
OpenCompletionHandler(AsyncCompletionHandler<Void>) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStream.OpenCompletionHandler
 
openDownloadStream(ObjectId) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncInputStream from which the application can read the contents of the stored file specified by id.
openDownloadStream(BsonValue) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncInputStream from which the application can read the contents of the stored file specified by id.
openDownloadStream(String) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the latest version of the stored file specified by the filename.
openDownloadStream(String, GridFSDownloadOptions) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by filename and the revision in options.
openDownloadStream(ClientSession, ObjectId) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncInputStream from which the application can read the contents of the stored file specified by id.
openDownloadStream(ClientSession, BsonValue) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncInputStream from which the application can read the contents of the stored file specified by id.
openDownloadStream(ClientSession, String) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the latest version of the stored file specified by the filename.
openDownloadStream(ClientSession, String, GridFSDownloadOptions) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by filename and the revision in options.
openDownloadStream(ObjectId) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(BsonValue) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(String) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(String, GridFSDownloadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, ObjectId) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, BsonValue) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, String) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, String, GridFSDownloadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ObjectId) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by id.
openDownloadStream(BsonValue) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by id.
openDownloadStream(String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the latest version of the stored file specified by the filename.
openDownloadStream(String, GridFSDownloadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by filename and the revision in options.
openDownloadStream(ClientSession, ObjectId) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by id.
openDownloadStream(ClientSession, BsonValue) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by id.
openDownloadStream(ClientSession, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the latest version of the stored file specified by the filename.
openDownloadStream(ClientSession, String, GridFSDownloadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream from which the application can read the contents of the stored file specified by filename and the revision in options.
openDownloadStream(ObjectId) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(BsonValue) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(String, GridFSDownloadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, ObjectId) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, BsonValue) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStream(ClientSession, String, GridFSDownloadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openDownloadStreamByName(String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Deprecated.
openDownloadStreamByName(String, GridFSDownloadByNameOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
openDownloadStreamByName(String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
Deprecated.
openDownloadStreamByName(String, GridFSDownloadByNameOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
Deprecated.
opened() - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
opened() - Method in interface com.mongodb.connection.InternalConnection
Returns if the connection has been opened
opened - Variable in class com.mongodb.connection.InternalStreamConnection
 
opened() - Method in class com.mongodb.connection.InternalStreamConnection
 
opened() - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
openedAt - Variable in class com.mongodb.connection.UsageTrackingInternalConnection
 
openUploadStream(String) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(String, GridFSUploadOptions) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(BsonValue, String) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(BsonValue, String, GridFSUploadOptions) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(ClientSession, String) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(ClientSession, String, GridFSUploadOptions) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(ClientSession, BsonValue, String) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(ClientSession, BsonValue, String, GridFSUploadOptions) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Opens a AsyncOutputStream that the application can write the contents of the file to.
openUploadStream(String) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(String, GridFSUploadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(BsonValue, String) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(BsonValue, String, GridFSUploadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, String) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, String, GridFSUploadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, BsonValue, String) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, BsonValue, String, GridFSUploadOptions) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
openUploadStream(String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(String, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(BsonValue, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(BsonValue, String, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(ClientSession, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(ClientSession, String, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(ClientSession, BsonValue, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(ClientSession, ObjectId, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(ClientSession, BsonValue, String, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Opens a Stream that the application can write the contents of the file to.
openUploadStream(String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(String, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(BsonValue, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(BsonValue, String, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, String, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, ObjectId, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, BsonValue, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
openUploadStream(ClientSession, BsonValue, String, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
operation - Variable in class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
operation - Variable in class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceWriteOperation
 
operation - Variable in class com.mongodb.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
OPERATION_TYPE_CODEC - Static variable in class com.mongodb.client.model.changestream.ChangeStreamDocumentCodec
 
OperationExecutor - Interface in com.mongodb.operation
Deprecated.
there is no replacement for this interface
OperationExecutor - Interface in com.mongodb
An interface describing the execution of a read or a write operation.
OperationHelper - Class in com.mongodb.operation
 
OperationHelper() - Constructor for class com.mongodb.operation.OperationHelper
 
OperationHelper.AsyncCallableWithConnection - Interface in com.mongodb.operation
 
OperationHelper.AsyncCallableWithConnectionAndSource - Interface in com.mongodb.operation
 
OperationHelper.AsyncCallableWithConnectionAndSourceCallback - Class in com.mongodb.operation
 
OperationHelper.AsyncCallableWithConnectionCallback - Class in com.mongodb.operation
 
OperationHelper.CallableWithConnection<T> - Interface in com.mongodb.operation
 
OperationHelper.CallableWithConnectionAndSource<T> - Interface in com.mongodb.operation
 
OperationHelper.ConnectionReleasingWrappedCallback<T> - Class in com.mongodb.operation
 
OperationHelper.ReferenceCountedReleasingWrappedCallback<T> - Class in com.mongodb.operation
 
operationTime - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
operationType - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
OperationType - Enum in com.mongodb.client.model.changestream
The $changeStream operation type.
OperationType(String) - Constructor for enum com.mongodb.client.model.changestream.OperationType
 
OperationTypeCodec - Class in com.mongodb.client.model.changestream
 
OperationTypeCodec() - Constructor for class com.mongodb.client.model.changestream.OperationTypeCodec
 
operator - Variable in class com.mongodb.client.model.Filters.OrNorFilter
 
Operator(String, String) - Constructor for enum com.mongodb.client.model.Filters.OrNorFilter.Operator
 
operator - Variable in class com.mongodb.client.model.Updates.SimpleUpdate
 
operator - Variable in class com.mongodb.client.model.Updates.WithEachUpdate
 
OperatorFilter(String, String, TItem) - Constructor for class com.mongodb.client.model.Filters.OperatorFilter
 
operatorFilterToString(String, String, Object) - Static method in class com.mongodb.client.model.Filters
 
operatorName - Variable in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
operatorName - Variable in class com.mongodb.client.model.Filters.IterableOperatorFilter
 
operatorName - Variable in class com.mongodb.client.model.Filters.OperatorFilter
 
oplogReplay(boolean) - Method in interface com.mongodb.async.client.FindIterable
Users should not set this under normal circumstances.
oplogReplay(boolean) - Method in class com.mongodb.async.client.FindIterableImpl
 
oplogReplay(boolean) - Method in interface com.mongodb.client.FindIterable
Users should not set this under normal circumstances.
oplogReplay - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
oplogReplay(boolean) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Users should not set this under normal circumstances.
oplogReplay - Variable in class com.mongodb.client.model.FindOptions
 
oplogReplay(boolean) - Method in class com.mongodb.client.model.FindOptions
Users should not set this under normal circumstances.
oplogReplay - Variable in class com.mongodb.connection.BaseQueryMessage
 
oplogReplay(boolean) - Method in class com.mongodb.connection.BaseQueryMessage
Internal replication use only.
oplogReplay - Variable in class com.mongodb.connection.QueryProtocol
 
oplogReplay(boolean) - Method in class com.mongodb.connection.QueryProtocol
Internal replication use only.
oplogReplay(boolean) - Method in class com.mongodb.FindIterableImpl
 
oplogReplay - Variable in class com.mongodb.operation.FindOperation
 
oplogReplay(boolean) - Method in class com.mongodb.operation.FindOperation
Internal replication use only.
opMsgFlagBits - Variable in class com.mongodb.connection.ReplyHeader
 
Optional<T> - Class in org.bson.codecs.configuration
 
Optional() - Constructor for class org.bson.codecs.configuration.Optional
 
Optional.Some<T> - Class in org.bson.codecs.configuration
 
optionalFinalizer - Variable in class com.mongodb.DBCursor
 
OptionalFinalizer(Mongo, MongoNamespace) - Constructor for class com.mongodb.DBCursor.OptionalFinalizer
 
OptionHolder(Bytes.OptionHolder) - Constructor for class com.mongodb.Bytes.OptionHolder
 
optionHolder - Variable in class com.mongodb.DB
 
optionHolder - Variable in class com.mongodb.DBCollection
 
optionHolder - Variable in class com.mongodb.Mongo
 
options - Variable in class com.mongodb.client.model.Aggregates.BucketAutoStage
 
options - Variable in class com.mongodb.client.model.Aggregates.BucketStage
 
options - Variable in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
options - Variable in class com.mongodb.client.model.DeleteManyModel
 
options - Variable in class com.mongodb.client.model.DeleteOneModel
 
options - Variable in class com.mongodb.client.model.IndexModel
 
options - Variable in class com.mongodb.client.model.ReplaceOneModel
 
options - Variable in class com.mongodb.client.model.UpdateManyModel
 
options - Variable in class com.mongodb.client.model.UpdateOneModel
 
options - Variable in class com.mongodb.client.model.Updates.PushUpdate
 
options - Variable in class com.mongodb.DBCursor
 
options - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
options - Variable in class com.mongodb.Mongo
 
options - Variable in class com.mongodb.MongoURI
Deprecated.
 
options - Variable in class org.bson.BsonRegularExpression
 
or(Iterable<Bson>) - Static method in class com.mongodb.client.model.Filters
Creates a filter that preforms a logical OR of the provided list of filters.
or(Bson...) - Static method in class com.mongodb.client.model.Filters
Creates a filter that preforms a logical OR of the provided list of filters.
or(DBObject...) - Method in class com.mongodb.QueryBuilder
Equivalent to an $or operand
OR - Static variable in class com.mongodb.QueryOperators
 
ORDER - Static variable in class com.mongodb.Bytes
Little-endian
order(ByteOrder) - Method in class com.mongodb.connection.CompositeByteBuf
 
order(ByteOrder) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
order(ByteOrder) - Method in interface org.bson.ByteBuf
Modifies this buffer's byte order.
order(ByteOrder) - Method in class org.bson.ByteBufNIO
 
ORDER_BY - Static variable in class com.mongodb.QueryOperators
 
orderBy(Bson...) - Static method in class com.mongodb.client.model.Sorts
Combine multiple sort specifications.
orderBy(List<? extends Bson>) - Static method in class com.mongodb.client.model.Sorts
Combine multiple sort specifications.
orderBy(List<String>, BsonValue) - Static method in class com.mongodb.client.model.Sorts
 
OrderBy - Enum in com.mongodb.operation
Enumeration of possible index orders
OrderBy(int) - Constructor for enum com.mongodb.operation.OrderBy
 
ordered - Variable in class com.mongodb.BulkWriteOperation
 
ordered - Variable in class com.mongodb.client.model.BulkWriteOptions
 
ordered(boolean) - Method in class com.mongodb.client.model.BulkWriteOptions
If true, then when a write fails, return without performing the remaining writes.
ordered - Variable in class com.mongodb.client.model.InsertManyOptions
 
ordered(boolean) - Method in class com.mongodb.client.model.InsertManyOptions
Sets whether the server should insert the documents in the order provided.
ordered - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
ordered - Variable in class com.mongodb.connection.WriteProtocol
 
ordered - Variable in class com.mongodb.operation.BaseWriteOperation
 
ordered - Variable in class com.mongodb.operation.BulkWriteBatch
 
ordered - Variable in class com.mongodb.operation.MixedBulkWriteOperation
 
org.bson - package org.bson
Contains the base BSON classes.
org.bson.assertions - package org.bson.assertions
This package contains design by contract assertions
org.bson.codecs - package org.bson.codecs
This package contains all the default BSON codecs.
org.bson.codecs.configuration - package org.bson.codecs.configuration
This package contains codec configurations and the codec registry helper
org.bson.codecs.pojo - package org.bson.codecs.pojo
This package contains classes specific to mapping user POJOs.
org.bson.codecs.pojo.annotations - package org.bson.codecs.pojo.annotations
This package defines various annotations used by the driver provided when used in conjunction with the Conventions.ANNOTATION_CONVENTION.
org.bson.conversions - package org.bson.conversions
This package contains the Bson interface
org.bson.diagnostics - package org.bson.diagnostics
Contains the classes for visibility of the BSON layer, for example Logging.
org.bson.internal - package org.bson.internal
 
org.bson.io - package org.bson.io
Contains classes implementing I/O operations used by BSON objects.
org.bson.json - package org.bson.json
JSON serialization and deserialization.
org.bson.types - package org.bson.types
Contains classes implementing various BSON types.
org.bson.util - package org.bson.util
Contains helper classes for working with the BSON protocol.
originalNamespace - Variable in class com.mongodb.operation.RenameCollectionOperation
 
originalOpcode - Variable in class com.mongodb.connection.CompressedHeader
 
originalSelector - Variable in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
originator - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
OrNorFilter(Filters.OrNorFilter.Operator, Iterable<Bson>) - Constructor for class com.mongodb.client.model.Filters.OrNorFilter
 
orphanedCursors - Variable in class com.mongodb.Mongo
 
OS_ARCHITECTURE_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
OS_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
OS_NAME_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
OS_TYPE_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
OS_VERSION_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
out(String) - Static method in class com.mongodb.client.model.Aggregates
Creates a $out pipeline stage for the specified filter
output - Variable in class com.mongodb.client.model.BucketAutoOptions
 
output(BsonField...) - Method in class com.mongodb.client.model.BucketAutoOptions
The definition of the output document in each bucket
output(List<BsonField>) - Method in class com.mongodb.client.model.BucketAutoOptions
The definition of the output document in each bucket
output - Variable in class com.mongodb.client.model.BucketOptions
 
output(BsonField...) - Method in class com.mongodb.client.model.BucketOptions
The definition of the output document in each bucket
output(List<BsonField>) - Method in class com.mongodb.client.model.BucketOptions
The definition of the output document in each bucket
outputBuffer - Variable in class org.bson.BasicBSONEncoder
 
OutputBuffer - Class in org.bson.io
An abstract base class for classes implementing BsonOutput.
OutputBuffer() - Constructor for class org.bson.io.OutputBuffer
 
outputCollection - Variable in class com.mongodb.MapReduceCommand
 
outputCount - Variable in class com.mongodb.operation.MapReduceStatistics
 
outputDB - Variable in class com.mongodb.MapReduceCommand
 
outputMode - Variable in class com.mongodb.AggregationOptions.Builder
 
outputMode(AggregationOptions.OutputMode) - Method in class com.mongodb.AggregationOptions.Builder
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
outputMode - Variable in class com.mongodb.AggregationOptions
 
OutputMode() - Constructor for enum com.mongodb.AggregationOptions.OutputMode
Deprecated.
 
outputMode - Variable in class org.bson.json.JsonWriterSettings.Builder
 
outputMode(JsonMode) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the output mode, which defaults to JsonMode.RELAXED.
outputMode - Variable in class org.bson.json.JsonWriterSettings
 
outputStream - Variable in class com.mongodb.connection.SocketStream
 
outputStream - Variable in class com.mongodb.gridfs.GridFSInputFile
 
outputType - Variable in class com.mongodb.MapReduceCommand
 
OutputType() - Constructor for enum com.mongodb.MapReduceCommand.OutputType
 
overflowInParse(long, int, int) - Static method in class org.bson.internal.UnsignedLongs
 
ownsSession - Variable in class com.mongodb.async.client.ClientSessionBinding
 
ownsSession - Variable in class com.mongodb.ClientSessionBinding
 

P

packages - Variable in class org.bson.codecs.pojo.DiscriminatorLookup
 
packages - Variable in class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
packages - Variable in class org.bson.codecs.pojo.PojoCodecProvider
 
PAD - Static variable in class org.bson.internal.Base64
padding char
ParallelCollectionScanOperation<T> - Class in com.mongodb.operation
Return a list of cursors over the collection that can be used to scan it in parallel.
ParallelCollectionScanOperation(MongoNamespace, int, Decoder<T>) - Constructor for class com.mongodb.operation.ParallelCollectionScanOperation
Construct a new instance.
ParallelCollectionScanOptions - Class in com.mongodb.client.model
Deprecated.
this is an unused class and there should be no reason to use it
ParallelCollectionScanOptions() - Constructor for class com.mongodb.client.model.ParallelCollectionScanOptions
Deprecated.
 
parallelScan(ParallelScanOptions) - Method in class com.mongodb.DBCollection
Return a list of cursors over the collection that can be used to scan it in parallel.
ParallelScanOptions - Class in com.mongodb
The options to use for a parallel collection scan.
ParallelScanOptions(ParallelScanOptions.Builder) - Constructor for class com.mongodb.ParallelScanOptions
 
ParallelScanOptions.Builder - Class in com.mongodb
A builder for the options
parameterGenericTypes - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
parameterTypes - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
params - Variable in class org.bson.codecs.pojo.InstanceCreatorImpl
 
parent - Variable in class org.bson.codecs.configuration.ChildCodecRegistry
 
parentContext - Variable in class org.bson.AbstractBsonReader.Context
 
parentContext - Variable in class org.bson.AbstractBsonReader.Mark
 
parentContext - Variable in class org.bson.AbstractBsonWriter.Context
 
parentContext - Variable in class org.bson.json.StrictCharacterStreamJsonWriter.StrictJsonContext
 
parse(String) - Static method in class com.mongodb.BasicDBObject
Parses a string in MongoDB Extended JSON format to a BasicDBObject.
parse(String, Decoder<BasicDBObject>) - Static method in class com.mongodb.BasicDBObject
Parses a string in MongoDB Extended JSON format to a BasicDBObject.
parse(String) - Static method in class com.mongodb.util.JSON
Deprecated.
Parses a JSON string and returns a corresponding Java object.
parse(String, BSONCallback) - Static method in class com.mongodb.util.JSON
Deprecated.
Parses a JSON string and constructs a corresponding Java object by calling the methods of a BSONCallback during parsing.
parse() - Method in class com.mongodb.util.JSONParser
Parse an unknown type.
parse(String) - Method in class com.mongodb.util.JSONParser
Parse an unknown type.
parse(String) - Static method in class org.bson.BsonArray
Parses a string in MongoDB Extended JSON format to a BsonArray
parse(String) - Static method in class org.bson.BsonDocument
Parses a string in MongoDB Extended JSON format to a BsonDocument
parse(String) - Static method in class org.bson.Document
Parses a string in MongoDB Extended JSON format to a Document
parse(String, Decoder<Document>) - Static method in class org.bson.Document
Parses a string in MongoDB Extended JSON format to a Document
parse(String) - Static method in class org.bson.internal.UnsignedLongs
Equivalent to Long.parseUnsignedLong in Java 8.
parse(String) - Method in interface org.bson.json.DateTimeFormatter.FormatterImpl
 
parse(String) - Method in class org.bson.json.DateTimeFormatter.Java8DateTimeFormatter
 
parse(String) - Method in class org.bson.json.DateTimeFormatter.JaxbDateTimeFormatter
 
parse(String) - Static method in class org.bson.json.DateTimeFormatter
 
parse(String) - Static method in class org.bson.RawBsonDocument
Parses a string in MongoDB Extended JSON format to a RawBsonDocument
parse(String) - Static method in class org.bson.types.Decimal128
Returns a Decimal128 value representing the given String.
parseArray() - Method in class com.mongodb.util.JSONParser
Parses the next array.
parseArray(String) - Method in class com.mongodb.util.JSONParser
Parses the next array.
parseBoolean(String, String) - Method in class com.mongodb.ConnectionString
 
parseExponent() - Method in class com.mongodb.util.JSONParser
Advances the pointer through the exponent.
parseFraction() - Method in class com.mongodb.util.JSONParser
Advances the pointed through .digits.
parseHexString(String) - Static method in class org.bson.types.ObjectId
 
parseHosts(List<String>, boolean) - Method in class com.mongodb.ConnectionString
 
parseInteger(String, String) - Method in class com.mongodb.ConnectionString
 
parseNumber() - Method in class com.mongodb.util.JSONParser
Parses a number.
parseObject() - Method in class com.mongodb.util.JSONParser
Parses an object for the form {} and { members }.
parseObject(String) - Method in class com.mongodb.util.JSONParser
Parses an object for the form {} and { members }.
parseOptions(String) - Method in class com.mongodb.ConnectionString
 
parseServerResponse(String) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
The server provides back key value pairs using an = sign and delimited by a command.
parseString(boolean) - Method in class com.mongodb.util.JSONParser
Parses a string.
partial(boolean) - Method in interface com.mongodb.async.client.FindIterable
Get partial results from a sharded cluster if one or more shards are unreachable (instead of throwing an error).
partial(boolean) - Method in class com.mongodb.async.client.FindIterableImpl
 
partial(boolean) - Method in interface com.mongodb.client.FindIterable
Get partial results from a sharded cluster if one or more shards are unreachable (instead of throwing an error).
partial - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
partial(boolean) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Get partial results from a sharded cluster if one or more shards are unreachable (instead of throwing an error).
partial - Variable in class com.mongodb.client.model.FindOptions
 
partial(boolean) - Method in class com.mongodb.client.model.FindOptions
Get partial results from a sharded cluster if one or more shards are unreachable (instead of throwing an error).
partial - Variable in class com.mongodb.connection.BaseQueryMessage
 
partial(boolean) - Method in class com.mongodb.connection.BaseQueryMessage
Sets if partial results from a mongos if some shards are down are allowed
partial - Variable in class com.mongodb.connection.QueryProtocol
 
partial(boolean) - Method in class com.mongodb.connection.QueryProtocol
Sets if partial results from a mongos if some shards are down are allowed
partial(boolean) - Method in class com.mongodb.FindIterableImpl
 
partial - Variable in class com.mongodb.operation.FindOperation
 
partial(boolean) - Method in class com.mongodb.operation.FindOperation
Sets if partial results from a mongos if some shards are down are allowed
partialFilterExpression - Variable in class com.mongodb.bulk.IndexRequest
 
partialFilterExpression(BsonDocument) - Method in class com.mongodb.bulk.IndexRequest
Sets the filter expression for the documents to be included in the index
partialFilterExpression - Variable in class com.mongodb.client.model.IndexOptions
 
partialFilterExpression(Bson) - Method in class com.mongodb.client.model.IndexOptions
Sets the filter expression for the documents to be included in the index
passives - Variable in class com.mongodb.connection.ServerDescription.Builder
 
passives(Set<String>) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the passive members of the replica set.
passives - Variable in class com.mongodb.connection.ServerDescription
 
password - Variable in class com.mongodb.MongoCredential
 
pastMaxIdleTime(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool
 
pastMaxLifeTime(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool
 
pathToClassMap - Variable in class com.mongodb.DBCollectionObjectFactory
 
pattern - Variable in class org.bson.BsonRegularExpression
 
PatternCodec - Class in org.bson.codecs
A codec for Pattern instances.
PatternCodec() - Constructor for class org.bson.codecs.PatternCodec
 
PatternCodec.RegexFlag - Enum in org.bson.codecs
 
PatternSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.PatternSerializer
Deprecated.
 
payload - Variable in class com.mongodb.connection.CommandMessage
 
payload - Variable in class com.mongodb.connection.CommandProtocolImpl
 
payload - Variable in class com.mongodb.connection.SplittablePayload
 
payload - Variable in class com.mongodb.connection.SplittablePayloadBsonWriter
 
payload - Variable in class com.mongodb.operation.BulkWriteBatch
 
payloadDecoder - Variable in class com.mongodb.operation.CommandResultCodecProvider
 
payloadDecoder - Variable in class com.mongodb.operation.CommandResultDocumentCodec
 
payloadFieldNameValidator - Variable in class com.mongodb.connection.CommandMessage
 
payloadFieldNameValidator - Variable in class com.mongodb.connection.CommandProtocolImpl
 
payloadType - Variable in class com.mongodb.connection.SplittablePayload
 
peek() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
peekBinarySize() - Method in class org.bson.AbstractBsonReader
 
peekBinarySize() - Method in interface org.bson.BsonReader
Peeks the size of the binary data that the reader is positioned at.
peekBinarySubType() - Method in class org.bson.AbstractBsonReader
 
peekBinarySubType() - Method in interface org.bson.BsonReader
Peeks the subtype of the binary data that the reader is positioned at.
peekFirst() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
peekLast() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
pendingException - Variable in class com.mongodb.connection.netty.NettyStream
 
pendingInboundBuffers - Variable in class com.mongodb.connection.netty.NettyStream
 
pendingReader - Variable in class com.mongodb.connection.netty.NettyStream
 
PendingReader(int, AsyncCompletionHandler<ByteBuf>) - Constructor for class com.mongodb.connection.netty.NettyStream.PendingReader
 
permits - Variable in class com.mongodb.internal.connection.ConcurrentPool
 
phase - Variable in class com.mongodb.connection.BaseCluster
 
phase - Variable in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
pipe(OutputStream) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
pipe(BsonReader) - Method in class com.mongodb.connection.ElementExtendingBsonWriter
 
pipe(BsonReader) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
pipe(BsonReader) - Method in class org.bson.AbstractBsonWriter
 
pipe(BsonReader, List<BsonElement>) - Method in class org.bson.AbstractBsonWriter
Reads a single document from the given BsonReader and writes it to this, appending the given extra elements to the document.
pipe(BsonReader) - Method in class org.bson.BsonBinaryWriter
 
pipe(BsonReader, List<BsonElement>) - Method in class org.bson.BsonBinaryWriter
 
pipe(BsonReader) - Method in interface org.bson.BsonWriter
Reads a single document from a BsonReader and writes it to this.
pipe(OutputStream) - Method in class org.bson.io.BasicOutputBuffer
 
pipe(OutputStream) - Method in class org.bson.io.OutputBuffer
Pipe the contents of this output buffer into the given output stream
pipe(OutputStream) - Method in class org.bson.LazyBSONObject
Pipe the raw bytes into the given output stream.
pipeArray(BsonReader) - Method in class org.bson.AbstractBsonWriter
 
pipeArray(BsonArray) - Method in class org.bson.AbstractBsonWriter
 
pipeDocument(BsonReader, List<BsonElement>) - Method in class org.bson.AbstractBsonWriter
 
pipeDocument(BsonDocument) - Method in class org.bson.AbstractBsonWriter
 
pipeDocument(BsonReader, List<BsonElement>) - Method in class org.bson.BsonBinaryWriter
 
pipeExtraElements(List<BsonElement>) - Method in class org.bson.AbstractBsonWriter
Pipe a list of extra element to this writer
pipeJavascriptWithScope(BsonReader) - Method in class org.bson.AbstractBsonWriter
 
pipeJavascriptWithScope(BsonJavaScriptWithScope) - Method in class org.bson.AbstractBsonWriter
 
pipeline - Variable in class com.mongodb.AggregateIterableImpl
 
pipeline - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
pipeline - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
pipeline - Variable in class com.mongodb.ChangeStreamIterableImpl
 
pipeline - Variable in class com.mongodb.client.model.Facet
 
pipeline - Variable in class com.mongodb.operation.AggregateExplainOperation
 
pipeline - Variable in class com.mongodb.operation.AggregateOperation
 
pipeline - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
pipeline - Variable in class com.mongodb.operation.ChangeStreamOperation
 
pipeline - Variable in class com.mongodb.operation.CreateViewOperation
 
pipeOneBuffer(AsyncWritableByteChannel, ByteBuf, AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
pipeValue(BsonReader) - Method in class org.bson.AbstractBsonWriter
 
pipeValue(BsonValue) - Method in class org.bson.AbstractBsonWriter
 
PLAIN_MECHANISM - Static variable in class com.mongodb.MongoCredential
The PLAIN mechanism.
PlainAuthenticator - Class in com.mongodb.connection
 
PlainAuthenticator(MongoCredential) - Constructor for class com.mongodb.connection.PlainAuthenticator
 
PLATFORM_FIELD - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
Point - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON Point.
Point(Position) - Constructor for class com.mongodb.client.model.geojson.Point
Construct an instance with the given coordinate.
Point(CoordinateReferenceSystem, Position) - Constructor for class com.mongodb.client.model.geojson.Point
Construct an instance with the given coordinate and coordinate reference system.
PointCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON point.
PointCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.PointCodec
Constructs an instance.
PojoBuilderHelper - Class in org.bson.codecs.pojo
 
PojoBuilderHelper() - Constructor for class org.bson.codecs.pojo.PojoBuilderHelper
 
PojoBuilderHelper.PropertyTypeCheck - Enum in org.bson.codecs.pojo
 
pojoCodec - Variable in class org.bson.codecs.pojo.AutomaticPojoCodec
 
pojoCodec - Variable in class org.bson.codecs.pojo.FallbackPropertyCodecProvider
 
pojoCodec - Variable in class org.bson.codecs.pojo.LazyPojoCodec
 
PojoCodec<T> - Class in org.bson.codecs.pojo
 
PojoCodec() - Constructor for class org.bson.codecs.pojo.PojoCodec
 
PojoCodecImpl<T> - Class in org.bson.codecs.pojo
 
PojoCodecImpl(ClassModel<T>, CodecRegistry, List<PropertyCodecProvider>, DiscriminatorLookup) - Constructor for class org.bson.codecs.pojo.PojoCodecImpl
 
PojoCodecImpl(ClassModel<T>, CodecRegistry, PropertyCodecRegistry, DiscriminatorLookup, ConcurrentMap<ClassModel<?>, Codec<?>>, boolean) - Constructor for class org.bson.codecs.pojo.PojoCodecImpl
 
PojoCodecProvider - Class in org.bson.codecs.pojo
Provides Codecs for registered POJOs via the ClassModel abstractions.
PojoCodecProvider(boolean, Map<Class<?>, ClassModel<?>>, Set<String>, List<Convention>, List<PropertyCodecProvider>) - Constructor for class org.bson.codecs.pojo.PojoCodecProvider
 
PojoCodecProvider.Builder - Class in org.bson.codecs.pojo
A Builder for the PojoCodecProvider
poll() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
pollFirst() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
pollLast() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
Polygon - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON Polygon.
Polygon(List<Position>, List<Position>...) - Constructor for class com.mongodb.client.model.geojson.Polygon
Construct an instance with the given coordinates.
Polygon(PolygonCoordinates) - Constructor for class com.mongodb.client.model.geojson.Polygon
Construct an instance with the given coordinates.
Polygon(CoordinateReferenceSystem, PolygonCoordinates) - Constructor for class com.mongodb.client.model.geojson.Polygon
Construct an instance with the given coordinates and coordinate reference system.
POLYGON - Static variable in class com.mongodb.QueryOperators
 
PolygonCodec - Class in com.mongodb.client.model.geojson.codecs
A Codec for a GeoJSON polygon.
PolygonCodec(CodecRegistry) - Constructor for class com.mongodb.client.model.geojson.codecs.PolygonCodec
Constructs an instance.
PolygonCoordinates - Class in com.mongodb.client.model.geojson
Coordinates for a GeoJSON Polygon.
PolygonCoordinates(List<Position>, List<Position>...) - Constructor for class com.mongodb.client.model.geojson.PolygonCoordinates
Construct an instance.
pool - Variable in class com.mongodb.connection.DefaultConnectionPool
 
Pool<T> - Interface in com.mongodb.internal.connection
 
POOL_NUMBER - Static variable in class com.mongodb.internal.thread.DaemonThreadFactory
 
PooledByteBufNIO(ByteBuffer) - Constructor for class com.mongodb.internal.connection.PowerOfTwoBufferPool.PooledByteBufNIO
 
PooledConnection(UsageTrackingInternalConnection) - Constructor for class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
pop() - Method in class com.mongodb.BasicDBObjectBuilder
Pops the active object, which means that the parent object becomes active
pop() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
popContext(int) - Method in class org.bson.BsonBinaryReader.Context
 
popFirst(String) - Static method in class com.mongodb.client.model.Updates
Creates an update that pops the first element of an array that is the value of the field with the given name.
popLast(String) - Static method in class com.mongodb.client.model.Updates
Creates an update that pops the last element of an array that is the value of the field with the given name.
popMaxDocumentSize() - Method in class org.bson.BsonBinaryWriter
Reset the maximum document size to its previous value.
popToken() - Method in class org.bson.json.JsonReader
 
port - Variable in class com.mongodb.ServerAddress
 
pos - Variable in exception com.mongodb.util.JSONParseException
 
pos - Variable in class com.mongodb.util.JSONParser
 
Position - Class in com.mongodb.client.model.geojson
A representation of a GeoJSON Position.
Position(List<Double>) - Constructor for class com.mongodb.client.model.geojson.Position
Construct an instance.
Position(double, double, double...) - Constructor for class com.mongodb.client.model.geojson.Position
Construct an instance.
position - Variable in class com.mongodb.client.model.PushOptions
 
position(Integer) - Method in class com.mongodb.client.model.PushOptions
Sets the position at which to add the pushed values in the array.
position - Variable in class com.mongodb.connection.ByteBufferBsonOutput.BufferPositionPair
 
position - Variable in class com.mongodb.connection.ByteBufferBsonOutput
 
position - Variable in class com.mongodb.connection.CompositeByteBuf
 
position() - Method in class com.mongodb.connection.CompositeByteBuf
 
position(int) - Method in class com.mongodb.connection.CompositeByteBuf
 
position(int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
position() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
position - Variable in class com.mongodb.connection.SplittablePayload
 
position - Variable in class org.bson.BsonBinaryWriter.Mark
 
position(int) - Method in interface org.bson.ByteBuf
Sets this buffer's position.
position() - Method in interface org.bson.ByteBuf
Returns this buffer's position.
position(int) - Method in class org.bson.ByteBufNIO
 
position() - Method in class org.bson.ByteBufNIO
 
position - Variable in class org.bson.io.BasicOutputBuffer
 
position - Variable in class org.bson.json.JsonBuffer
 
position - Variable in class org.bson.json.JsonReader.Mark
 
POSITIVE_INFINITY - Static variable in class org.bson.types.Decimal128
A constant holding the positive infinity of type Decimal128.
POSITIVE_INFINITY_STRINGS - Static variable in class org.bson.types.Decimal128
 
POSITIVE_ZERO - Static variable in class org.bson.types.Decimal128
A constant holding a postive zero value of type Decimal128.
postTerminate() - Method in class com.mongodb.async.client.AbstractSubscription
 
postTerminate() - Method in class com.mongodb.async.client.MongoIterableSubscription
 
PowerOfTwoBufferPool - Class in com.mongodb.internal.connection
Power-of-two buffer pool implementation.
PowerOfTwoBufferPool() - Constructor for class com.mongodb.internal.connection.PowerOfTwoBufferPool
Construct an instance with a highest power of two of 24.
PowerOfTwoBufferPool(int) - Constructor for class com.mongodb.internal.connection.PowerOfTwoBufferPool
Construct an instance.
PowerOfTwoBufferPool.PooledByteBufNIO - Class in com.mongodb.internal.connection
 
powerOfTwoToPoolMap - Variable in class com.mongodb.internal.connection.PowerOfTwoBufferPool
 
predecessor() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns the previous non-deleted node, patching up pointers as needed.
PREFIX - Static variable in class com.mongodb.diagnostics.logging.Loggers
The prefix for all logger names.
PREFIX - Static variable in class org.bson.diagnostics.Loggers
The prefix for all logger names.
preparePipeline(List<? extends DBObject>) - Method in class com.mongodb.DBCollection
 
prepend(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Tries to insert a node holding element as predecessor, failing if no live predecessor can be found to link to.
prependToList(List<String>, String) - Method in class com.mongodb.client.MongoDriverInformation.Builder
 
prepUserName(String) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
preserveNullAndEmptyArrays - Variable in class com.mongodb.client.model.UnwindOptions
 
preserveNullAndEmptyArrays(Boolean) - Method in class com.mongodb.client.model.UnwindOptions
Sets true if the unwind stage should include documents that have null values or empty arrays
prev - Variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
 
previousDescription - Variable in class com.mongodb.event.ClusterDescriptionChangedEvent
 
previousDescription - Variable in class com.mongodb.event.ServerDescriptionChangedEvent
 
previousValue - Variable in class com.mongodb.connection.ChangeEvent
 
preWriteValue() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
primary - Variable in class com.mongodb.connection.ServerDescription.Builder
 
primary(String) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the address of the current primary in the replica set
primary - Variable in class com.mongodb.connection.ServerDescription
 
PRIMARY - Static variable in class com.mongodb.ReadPreference
 
primary() - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces read to the primary.
PRIMARY_PREFERRED - Static variable in class com.mongodb.ReadPreference
 
primaryPreferred() - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary if available, otherwise to a secondary.
primaryPreferred(long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary if available, otherwise to a secondary.
primaryPreferred(TagSet) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary if available, otherwise to a secondary with the given set of tags.
primaryPreferred(TagSet, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary if available, otherwise to a secondary with the given set of tags that is less stale than the given maximum.
primaryPreferred(List<TagSet>) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary if available, otherwise to a secondary with one of the given sets of tags.
primaryPreferred(List<TagSet>, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to the primary if available, otherwise to a secondary with one of the given sets of tags that is less stale than the given maximum.
PrimaryPreferredReadPreference() - Constructor for class com.mongodb.TaggableReadPreference.PrimaryPreferredReadPreference
 
PrimaryPreferredReadPreference(List<TagSet>, Long, TimeUnit) - Constructor for class com.mongodb.TaggableReadPreference.PrimaryPreferredReadPreference
 
PrimaryReadPreference() - Constructor for class com.mongodb.ReadPreference.PrimaryReadPreference
 
PrimaryServerSelector - Class in com.mongodb.selector
Deprecated.
Use either ReadPreferenceServerSelector or WritableServerSelector, depending on your requirements
PrimaryServerSelector() - Constructor for class com.mongodb.selector.PrimaryServerSelector
Deprecated.
 
PRIMITIVE_CLASS_MAP - Static variable in class org.bson.codecs.pojo.TypeData
 
printUsage() - Static method in class com.mongodb.gridfs.CLI
Dumps usage info to stdout
PrivateProperyAccessor(PropertyAccessorImpl<T>) - Constructor for class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl.PrivateProperyAccessor
 
PrivateProperyAccessor(PropertyAccessorImpl<T>) - Constructor for class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 
PROCESS_IDENTIFIER - Static variable in class org.bson.types.ObjectId
 
processClassAnnotation(ClassModelBuilder<?>, Annotation) - Method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
processCreatorAnnotation(ClassModelBuilder<T>) - Method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
processIdentifier - Variable in class org.bson.types.ObjectId
 
processPropertyAnnotations(ClassModelBuilder<?>, PropertyModelBuilder<?>) - Method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
processResults(int, ByteBuffer, SingleResultCallback<Integer>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
processResultsQueue() - Method in class com.mongodb.async.client.AbstractSubscription
 
project(Bson) - Static method in class com.mongodb.client.model.Aggregates
Creates a $project pipeline stage for the specified projection
projectFromFullNamespaceToCollectionName(List<BsonDocument>) - Method in class com.mongodb.operation.ListCollectionsOperation
 
ProjectingAsyncBatchCursor(AsyncBatchCursor<BsonDocument>) - Constructor for class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
ProjectingBatchCursor(BatchCursor<BsonDocument>) - Constructor for class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
projection(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets a document describing the fields to return for all matching documents.
projection(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
PROJECTION - Static variable in class com.mongodb.async.client.gridfs.GridFSIndexCheckImpl
 
projection(Bson) - Method in interface com.mongodb.client.FindIterable
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
projection(DBObject) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the projection
projection - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
projection(DBObject) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.client.model.FindOneAndDeleteOptions
 
projection(Bson) - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
projection(Bson) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
projection(Bson) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.client.model.FindOptions
 
projection(Bson) - Method in class com.mongodb.client.model.FindOptions
Sets a document describing the fields to return for all matching documents.
projection(Bson) - Method in class com.mongodb.FindIterableImpl
 
projection - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
projection(BsonDocument) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
projection(BsonDocument) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
projection(BsonDocument) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets a document describing the fields to return for all matching documents.
projection - Variable in class com.mongodb.operation.FindOperation
 
projection(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets a document describing the fields to return for all matching documents.
Projections - Class in com.mongodb.client.model
A factory for projections.
Projections() - Constructor for class com.mongodb.client.model.Projections
 
projections - Variable in class com.mongodb.client.model.Projections.FieldsProjection
 
Projections.ElemMatchFilterProjection - Class in com.mongodb.client.model
 
Projections.FieldsProjection - Class in com.mongodb.client.model
 
promoteRenderableToDollarForm(BsonDocument, Map.Entry<String, BsonValue>) - Method in class com.mongodb.client.model.Filters.AndFilter
 
properties - Variable in class com.mongodb.MongoCompressor
 
properties - Variable in class org.bson.codecs.pojo.CreatorExecutable
 
properties - Variable in class org.bson.codecs.pojo.InstanceCreatorImpl
 
PropertyAccessor<T> - Interface in org.bson.codecs.pojo
Provides access for getting and setting property data.
propertyAccessor - Variable in class org.bson.codecs.pojo.PropertyModel
 
propertyAccessor - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
propertyAccessor(PropertyAccessor<T>) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
PropertyAccessorImpl<T> - Class in org.bson.codecs.pojo
 
PropertyAccessorImpl(PropertyMetadata<T>) - Constructor for class org.bson.codecs.pojo.PropertyAccessorImpl
 
PropertyCodecProvider - Interface in org.bson.codecs.pojo
A variant of CodecProvider that generates codecs for PojoCodec.
propertyCodecProviders - Variable in class org.bson.codecs.pojo.PojoCodecProvider.Builder
 
propertyCodecProviders - Variable in class org.bson.codecs.pojo.PojoCodecProvider
 
propertyCodecProviders - Variable in class org.bson.codecs.pojo.PropertyCodecRegistryImpl
 
propertyCodecRegistry - Variable in class org.bson.codecs.pojo.LazyPojoCodec
 
propertyCodecRegistry - Variable in class org.bson.codecs.pojo.PojoCodecImpl
 
PropertyCodecRegistry - Interface in org.bson.codecs.pojo
A variant of CodecRegistry that generates codecs for PojoCodec.
PropertyCodecRegistryImpl - Class in org.bson.codecs.pojo
 
PropertyCodecRegistryImpl(PojoCodec<?>, CodecRegistry, List<PropertyCodecProvider>) - Constructor for class org.bson.codecs.pojo.PropertyCodecRegistryImpl
 
propertyMetadata - Variable in class org.bson.codecs.pojo.PropertyAccessorImpl
 
PropertyMetadata<T> - Class in org.bson.codecs.pojo
 
PropertyMetadata(String, String, TypeData<T>) - Constructor for class org.bson.codecs.pojo.PropertyMetadata
 
PropertyMethods(Collection<Method>, Collection<Method>) - Constructor for class org.bson.codecs.pojo.PropertyReflectionUtils.PropertyMethods
 
PropertyModel<T> - Class in org.bson.codecs.pojo
Represents a property on a class and stores various metadata such as generic parameters
PropertyModel(String, String, String, TypeData<T>, Codec<T>, PropertySerialization<T>, Boolean, PropertyAccessor<T>) - Constructor for class org.bson.codecs.pojo.PropertyModel
 
PropertyModelBuilder<T> - Class in org.bson.codecs.pojo
A builder for programmatically creating PropertyModels.
PropertyModelBuilder() - Constructor for class org.bson.codecs.pojo.PropertyModelBuilder
 
propertyModelBuilders - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
propertyModels - Variable in class org.bson.codecs.pojo.ClassModel
 
PropertyModelSerializationImpl<T> - Class in org.bson.codecs.pojo
 
PropertyModelSerializationImpl() - Constructor for class org.bson.codecs.pojo.PropertyModelSerializationImpl
 
propertyName(String) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
propertyNameToTypeParameterMap - Variable in class org.bson.codecs.pojo.ClassModel
 
propertyNameToTypeParameterMap - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
propertyNameToTypeParameterMap(Map<String, TypeParameterMap>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
PropertyReflectionUtils - Class in org.bson.codecs.pojo
 
PropertyReflectionUtils() - Constructor for class org.bson.codecs.pojo.PropertyReflectionUtils
 
PropertyReflectionUtils.PropertyMethods - Class in org.bson.codecs.pojo
 
propertySerialization - Variable in class org.bson.codecs.pojo.PropertyModel
 
propertySerialization - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
propertySerialization(PropertySerialization<T>) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Sets the PropertySerialization checker
PropertySerialization<T> - Interface in org.bson.codecs.pojo
An interface allowing a PropertyModel to determine if a value should be serialized.
propertyToClassParamIndexMap - Variable in class org.bson.codecs.pojo.TypeParameterMap.Builder
 
propertyToClassParamIndexMap - Variable in class org.bson.codecs.pojo.TypeParameterMap
 
PropertyTypeCheck() - Constructor for enum org.bson.codecs.pojo.PojoBuilderHelper.PropertyTypeCheck
 
PROTOCOL_EVENT_LOGGER - Static variable in class com.mongodb.connection.ProtocolHelper
 
protocolExecutor - Variable in class com.mongodb.connection.DefaultServerConnection
 
ProtocolExecutor - Interface in com.mongodb.connection
 
ProtocolHelper - Class in com.mongodb.connection
 
ProtocolHelper() - Constructor for class com.mongodb.connection.ProtocolHelper
 
providerFromRegistry(CodecRegistry) - Static method in class org.bson.codecs.configuration.CodecRegistries
 
ProvidersCodecRegistry - Class in org.bson.codecs.configuration
 
ProvidersCodecRegistry(List<? extends CodecProvider>) - Constructor for class org.bson.codecs.configuration.ProvidersCodecRegistry
 
proxied - Variable in class com.mongodb.connection.netty.NettyByteBuf
 
proxied - Variable in class com.mongodb.MongoClientURI
 
proxied - Variable in class com.mongodb.MongoMappingCursor
 
proxied - Variable in class com.mongodb.MongoURI
Deprecated.
 
prune() - Method in class com.mongodb.internal.connection.ConcurrentPool
 
Prune() - Constructor for enum com.mongodb.internal.connection.ConcurrentPool.Prune
 
publishDescription(ServerDescription) - Method in class com.mongodb.connection.SingleServerCluster
 
pull(String, TItem) - Static method in class com.mongodb.client.model.Updates
Creates an update that removes all instances of the given value from the array value of the field with the given name.
pullAll(String, List<TItem>) - Static method in class com.mongodb.client.model.Updates
Creates an update that removes all instances of the given values from the array value of the field with the given name.
PullAllUpdate(String, List<TItem>) - Constructor for class com.mongodb.client.model.Updates.PullAllUpdate
 
pullByFilter(Bson) - Static method in class com.mongodb.client.model.Updates
Creates an update that removes from an array all elements that match the given filter.
push(String) - Method in class com.mongodb.BasicDBObjectBuilder
Creates an new empty object and inserts it into the current object with the given key.
push(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing an array of all values that results from applying an expression to each document in a group of documents that share the same group by key.
push(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.
push(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
pushEach(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.
pushEach(String, List<TItem>, PushOptions) - 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, applying the given options for positioning the pushed values, and then slicing and/or sorting the array.
pushedToken - Variable in class org.bson.json.JsonReader.Mark
 
pushedToken - Variable in class org.bson.json.JsonReader
 
pushMaxDocumentSize(int) - Method in class org.bson.BsonBinaryWriter
Sets a maximum size for documents from this point.
PushOptions - Class in com.mongodb.client.model
The options to apply to a $push update operator.
PushOptions() - Constructor for class com.mongodb.client.model.PushOptions
 
pushToken(JsonToken) - Method in class org.bson.json.JsonReader
 
PushUpdate(String, List<TItem>, PushOptions) - Constructor for class com.mongodb.client.model.Updates.PushUpdate
 
put(String, BsonValue) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
put(int, byte) - Method in class com.mongodb.connection.CompositeByteBuf
 
put(byte[], int, int) - Method in class com.mongodb.connection.CompositeByteBuf
 
put(byte) - Method in class com.mongodb.connection.CompositeByteBuf
 
put(int, byte) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
put(byte[], int, int) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
put(byte) - Method in class com.mongodb.connection.netty.NettyByteBuf
 
put(String, Object) - Method in class com.mongodb.gridfs.GridFSFile
 
put(String) - Method in class com.mongodb.QueryBuilder
Adds a new key to the query if not present yet.
put(String, Object) - Method in class com.mongodb.ReflectionDBObject
 
put(String, BsonValue) - Method in class org.bson.BsonDocument
 
put(String, BsonValue) - Method in class org.bson.BsonDocumentWrapper
 
put(String, Object) - Method in interface org.bson.BSONObject
Sets a name/value pair in this object.
put(int, byte) - Method in interface org.bson.ByteBuf
Absolute put method (optional operation).
put(byte[], int, int) - Method in interface org.bson.ByteBuf
Relative bulk put method  (optional operation).
put(byte) - Method in interface org.bson.ByteBuf
Relative put method (optional operation).
put(int, byte) - Method in class org.bson.ByteBufNIO
 
put(byte[], int, int) - Method in class org.bson.ByteBufNIO
 
put(byte) - Method in class org.bson.ByteBufNIO
 
put(Class<?>, Codec<?>) - Method in class org.bson.codecs.configuration.CodecCache
 
put(String, Object) - Method in class org.bson.Document
 
put(String, Object) - Method in class org.bson.LazyBSONObject
Always throws UnsupportedOperationException.
put(String, BsonValue) - Method in class org.bson.RawBsonDocument
 
put(String, Object) - Method in class org.bson.types.BasicBSONList
Puts a value at an index.
put(int, Object) - Method in class org.bson.types.BasicBSONList
Puts a value at an index.
put(K, V) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
put(Class<?>, T) - Method in class org.bson.util.ClassMap
As per java.util.Map, associates the specified value with the specified key in this map.
put(K, V) - Method in class org.bson.util.ComputingMap
 
putAll(Map<? extends String, ? extends BsonValue>) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
putAll(BSONObject) - Method in class com.mongodb.gridfs.GridFSFile
 
putAll(Map) - Method in class com.mongodb.gridfs.GridFSFile
 
putAll(Map) - Method in class com.mongodb.ReflectionDBObject
 
putAll(BSONObject) - Method in class com.mongodb.ReflectionDBObject
 
putAll(Map) - Method in class org.bson.BasicBSONObject
 
putAll(BSONObject) - Method in class org.bson.BasicBSONObject
 
putAll(Map<? extends String, ? extends BsonValue>) - Method in class org.bson.BsonDocument
 
putAll(Map<? extends String, ? extends BsonValue>) - Method in class org.bson.BsonDocumentWrapper
 
putAll(BSONObject) - Method in interface org.bson.BSONObject
Sets all key/value pairs from an object into this object
putAll(Map) - Method in interface org.bson.BSONObject
Sets all key/value pairs from a map into this object
putAll(Map<? extends String, ?>) - Method in class org.bson.Document
 
putAll(BSONObject) - Method in class org.bson.LazyBSONObject
Always throws UnsupportedOperationException.
putAll(Map) - Method in class org.bson.LazyBSONObject
Always throws UnsupportedOperationException.
putAll(Map<? extends String, ? extends BsonValue>) - Method in class org.bson.RawBsonDocument
 
putAll(Map) - Method in class org.bson.types.BasicBSONList
 
putAll(BSONObject) - Method in class org.bson.types.BasicBSONList
 
putAll(Map<? extends K, ? extends V>) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.bson.util.ComputingMap
 
putArray(String, Object) - Method in class org.bson.BasicBSONEncoder
Encodes an array field.
putBinary(String, byte[]) - Method in class org.bson.BasicBSONEncoder
Encodes a byte array field
putBinary(String, Binary) - Method in class org.bson.BasicBSONEncoder
Encodes a Binary field
putBoolean(String, Boolean) - Method in class org.bson.BasicBSONEncoder
Encodes a field with a Boolean or boolean value
putCode(String, Code) - Method in class org.bson.BasicBSONEncoder
Encodes a field to a BsonType.JAVASCRIPT value.
putCodeWScope(String, CodeWScope) - Method in class org.bson.BasicBSONEncoder
Encodes a field to a BsonType.JAVASCRIPT_WITH_SCOPE value.
putDate(String, Date) - Method in class org.bson.BasicBSONEncoder
Encodes a field with data and time value.
putDBRef(String, DBRef) - Method in class com.mongodb.DefaultDBEncoder
Deals with encoding database references.
putDecimal128(String, Decimal128) - Method in class org.bson.BasicBSONEncoder
Encodes a Decimal128 field.
putIfAbsent(K, V) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
putIfAbsent(K, V) - Method in class org.bson.util.ComputingMap
 
putIfNotNull(BsonDocument, String, BsonValue) - Static method in class com.mongodb.operation.DocumentHelper
 
putIfNotZero(BsonDocument, String, int) - Static method in class com.mongodb.operation.DocumentHelper
 
putIfNotZero(BsonDocument, String, long) - Static method in class com.mongodb.operation.DocumentHelper
 
putIfTrue(BsonDocument, String, boolean) - Static method in class com.mongodb.operation.DocumentHelper
 
putIterable(String, Iterable) - Method in class org.bson.BasicBSONEncoder
Encodes an Iterable, for example List values
putMap(String, Map) - Method in class org.bson.BasicBSONEncoder
Encodes a map, as a BSON document
putMaxKey(String) - Method in class org.bson.BasicBSONEncoder
Encodes a field to a BsonType.MAX_KEY value.
putMinKey(String) - Method in class org.bson.BasicBSONEncoder
Encodes a field to a BsonType.MIN_KEY value.
putName(String) - Method in class org.bson.BasicBSONEncoder
Writes a field name
putNull(String) - Method in class org.bson.BasicBSONEncoder
Encodes a null value
putNumber(String, Number) - Method in class org.bson.BasicBSONEncoder
Encodes any number field.
putObject(BSONObject) - Method in class org.bson.BasicBSONEncoder
Encodes a BSONObject.
putObject(String, BSONObject) - Method in class org.bson.BasicBSONEncoder
Encodes any BSONObject, as a document
putObject(BSONObject) - Method in interface org.bson.BSONEncoder
Encoder and write a document into underlying buffer.
putObjectId(String, ObjectId) - Method in class org.bson.BasicBSONEncoder
Encodes an ObjectId field to a BsonType.OBJECT_ID.
putPattern(String, Pattern) - Method in class org.bson.BasicBSONEncoder
Encodes a Pattern field to a BsonType.REGULAR_EXPRESSION.
putSpecial(String, Object) - Method in class com.mongodb.DefaultDBEncoder
 
putSpecial(String, Object) - Method in class org.bson.BasicBSONEncoder
Special values are not encoded into documents.
putString(String, String) - Method in class org.bson.BasicBSONEncoder
Encodes a String field
putSymbol(String, Symbol) - Method in class org.bson.BasicBSONEncoder
Encodes a Symbol field
putTimestamp(String, BSONTimestamp) - Method in class org.bson.BasicBSONEncoder
Encodes a BSON timestamp
putToByteBuffer(ByteBuffer) - Method in class org.bson.types.ObjectId
Convert to bytes and put those bytes to the provided ByteBuffer.
putUndefined(String) - Method in class org.bson.BasicBSONEncoder
Encodes an undefined value
putUUID(String, UUID) - Method in class org.bson.BasicBSONEncoder
Encodes a field with a UUID value.

Q

query - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
query - Variable in class com.mongodb.BulkWriteRequestBuilder
 
query(MongoNamespace, BsonDocument, BsonDocument, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>) - Method in interface com.mongodb.connection.Connection
query(MongoNamespace, BsonDocument, BsonDocument, int, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>) - Method in interface com.mongodb.connection.Connection
Execute the query.
query(MongoNamespace, BsonDocument, BsonDocument, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
query(MongoNamespace, BsonDocument, BsonDocument, int, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>) - Method in class com.mongodb.connection.DefaultServerConnection
 
query - Variable in class com.mongodb.MapReduceCommand
 
query - Variable in class com.mongodb.RemoveRequest
 
query - Variable in class com.mongodb.ReplaceRequest
 
query - Variable in class com.mongodb.UpdateRequest
 
QUERY_FAILURE_RESPONSE_FLAG - Static variable in class com.mongodb.connection.ReplyHeader
 
queryAsync(MongoNamespace, BsonDocument, BsonDocument, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>, SingleResultCallback<QueryResult<T>>) - Method in interface com.mongodb.connection.AsyncConnection
queryAsync(MongoNamespace, BsonDocument, BsonDocument, int, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>, SingleResultCallback<QueryResult<T>>) - Method in interface com.mongodb.connection.AsyncConnection
Execute the query asynchronously.
queryAsync(MongoNamespace, BsonDocument, BsonDocument, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>, SingleResultCallback<QueryResult<T>>) - Method in class com.mongodb.connection.DefaultServerConnection
 
queryAsync(MongoNamespace, BsonDocument, BsonDocument, int, int, int, boolean, boolean, boolean, boolean, boolean, boolean, Decoder<T>, SingleResultCallback<QueryResult<T>>) - Method in class com.mongodb.connection.DefaultServerConnection
 
QueryBatchCursor<T> - Class in com.mongodb.operation
 
QueryBatchCursor(QueryResult<T>, int, int, Decoder<T>) - Constructor for class com.mongodb.operation.QueryBatchCursor
 
QueryBatchCursor(QueryResult<T>, int, int, Decoder<T>, ConnectionSource) - Constructor for class com.mongodb.operation.QueryBatchCursor
 
QueryBatchCursor(QueryResult<T>, int, int, long, Decoder<T>, ConnectionSource, Connection) - Constructor for class com.mongodb.operation.QueryBatchCursor
 
QueryBuilder - Class in com.mongodb
Utility for creating DBObject queries
QueryBuilder() - Constructor for class com.mongodb.QueryBuilder
Creates a builder with an empty query
QueryBuilder.NullObject - Class in com.mongodb
 
QueryBuilder.QueryBuilderException - Exception in com.mongodb
 
QueryBuilderException(String) - Constructor for exception com.mongodb.QueryBuilder.QueryBuilderException
 
queryCodec - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
queryDocument - Variable in class com.mongodb.connection.QueryMessage
 
queryDocument - Variable in class com.mongodb.connection.QueryProtocol
 
QueryHelper - Class in com.mongodb.operation
 
QueryHelper() - Constructor for class com.mongodb.operation.QueryHelper
 
QueryMessage - Class in com.mongodb.connection
An OP_QUERY message for an actual query (not a command).
QueryMessage(String, int, int, BsonDocument, BsonDocument, MessageSettings) - Constructor for class com.mongodb.connection.QueryMessage
 
QueryOperators - Class in com.mongodb
MongoDB keywords for various query operations.
QueryOperators() - Constructor for class com.mongodb.QueryOperators
 
QUERYOPTION_AWAITDATA - Static variable in class com.mongodb.Bytes
Use with TailableCursor.
QUERYOPTION_EXHAUST - Static variable in class com.mongodb.Bytes
Stream the data down full blast in multiple "more" packages, on the assumption that the client will fully read all data queried.
QUERYOPTION_NOTIMEOUT - Static variable in class com.mongodb.Bytes
The server normally times out idle cursors after an inactivity period (10 minutes) to prevent excess memory use.
QUERYOPTION_OPLOGREPLAY - Static variable in class com.mongodb.Bytes
Internal replication use only - driver should not set
QUERYOPTION_PARTIAL - Static variable in class com.mongodb.Bytes
Use with sharding (mongos).
QUERYOPTION_SLAVEOK - Static variable in class com.mongodb.Bytes
When turned on, read queries will be directed to slave servers instead of the primary server.
QUERYOPTION_TAILABLE - Static variable in class com.mongodb.Bytes
Tailable means cursor is not closed when the last data is retrieved.
QueryProtocol<T> - Class in com.mongodb.connection
An implementation of the MongoDB OP_QUERY wire protocol.
QueryProtocol(MongoNamespace, int, int, BsonDocument, BsonDocument, Decoder<T>) - Constructor for class com.mongodb.connection.QueryProtocol
 
QueryProtocol(MongoNamespace, int, int, int, BsonDocument, BsonDocument, Decoder<T>) - Constructor for class com.mongodb.connection.QueryProtocol
 
QueryProtocol.QueryResultCallback - Class in com.mongodb.connection
 
QueryResult<T> - Class in com.mongodb.connection
A batch of query results.
QueryResult(MongoNamespace, List<T>, long, ServerAddress) - Constructor for class com.mongodb.connection.QueryResult
Construct an instance.
QueryResult(MongoNamespace, ReplyMessage<T>, ServerAddress) - Constructor for class com.mongodb.connection.QueryResult
Construct an instance.
QueryResultCallback(SingleResultCallback<QueryResult<T>>, int, long, QueryMessage, boolean, ConnectionDescription) - Constructor for class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
QueryResultSingleResultCallback(AsyncConnection, SingleResultCallback<List<T>>, boolean) - Constructor for class com.mongodb.operation.AsyncQueryBatchCursor.QueryResultSingleResultCallback
 
queryUnlock(Connection) - Method in class com.mongodb.operation.FsyncUnlockOperation
 

R

random - Variable in class com.mongodb.connection.BaseCluster
 
RANDOM_LENGTH - Static variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
randomStringGenerator - Variable in class com.mongodb.connection.ScramSha1Authenticator
 
randomStringGenerator - Variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
RangeBased() - Constructor for class com.mongodb.internal.connection.IndexMap.RangeBased
 
RangeBased(int, int) - Constructor for class com.mongodb.internal.connection.IndexMap.RangeBased
 
RAW_BSON_DOCUMENT_CODEC - Static variable in class com.mongodb.operation.ChangeStreamOperation
 
RawBsonDocument - Class in org.bson
An immutable BSON document that is represented using only the raw bytes.
RawBsonDocument(byte[]) - Constructor for class org.bson.RawBsonDocument
Constructs a new instance with the given byte array.
RawBsonDocument(byte[], int, int) - Constructor for class org.bson.RawBsonDocument
Constructs a new instance with the given byte array, offset, and length.
RawBsonDocument(T, Codec<T>) - Constructor for class org.bson.RawBsonDocument
Construct a new instance from the given document and codec for the document type.
RawBsonDocument.SerializationProxy - Class in org.bson
 
RawBsonDocumentCodec - Class in org.bson.codecs
A simple BSONDocumentBuffer codec.
RawBsonDocumentCodec() - Constructor for class org.bson.codecs.RawBsonDocumentCodec
Constructs a new instance.
read(ByteBuffer, SingleResultCallback<Integer>) - Method in interface com.mongodb.async.client.gridfs.AsyncInputStream
Reads a sequence of bytes from this stream into the given buffer.
read(ByteBuffer, SingleResultCallback<Integer>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
read() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
read(byte[]) - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
read(byte[], int, int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
read() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
read(byte[]) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
read(byte[], int, int) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
read(int) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
read(byte[], int, int) - Method in class com.mongodb.connection.Compressor.ByteBufInputStream
 
read() - Method in class com.mongodb.connection.Compressor.ByteBufInputStream
 
read(int) - Method in class com.mongodb.connection.netty.NettyStream
 
read(int) - Method in class com.mongodb.connection.SocketChannelStream
 
read(int) - Method in class com.mongodb.connection.SocketStream
 
read(int) - Method in interface com.mongodb.connection.Stream
Read from the stream, blocking until the requested number of bytes have been read.
read() - Method in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
read(byte[]) - Method in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
read(byte[], int, int) - Method in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
 
read(char) - Method in class com.mongodb.util.JSONParser
Read the current character, making sure that it is the expected character.
read() - Method in class com.mongodb.util.JSONParser
 
read() - Method in class org.bson.json.JsonBuffer
 
READ_HANDLER_NAME - Static variable in class com.mongodb.connection.netty.NettyStream
 
READ_PREFERENCE_KEYS - Static variable in class com.mongodb.ConnectionString
 
readAndWriteInputStream(AsyncInputStream, GridFSUploadStream, ByteBuffer, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
readAndWriteOutputStream(AsyncOutputStream, GridFSDownloadStream, ByteBuffer, long, SingleResultCallback<Long>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
readAnnotations - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
readAnnotations - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
readAnnotations(List<Annotation>) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Sets the read annotations, to be applied when serializing to BSON
readArray(BsonReader, DecoderContext, List<String>) - Method in class com.mongodb.DBObjectCodec
 
readArray(BsonBinaryReader) - Method in class org.bson.LazyBSONObject
 
readAsync(int, AsyncCompletionHandler<ByteBuf>) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
readAsync(int, SingleResultCallback<ByteBuf>) - Method in class com.mongodb.connection.InternalStreamConnection
 
readAsync(int, AsyncCompletionHandler<ByteBuf>) - Method in class com.mongodb.connection.netty.NettyStream
 
readAsync(int, AsyncCompletionHandler<ByteBuf>) - Method in class com.mongodb.connection.SocketChannelStream
 
readAsync(int, AsyncCompletionHandler<ByteBuf>) - Method in class com.mongodb.connection.SocketStream
 
readAsync(int, AsyncCompletionHandler<ByteBuf>) - Method in interface com.mongodb.connection.Stream
Read from the stream, asynchronously.
readBinary(BsonReader, DecoderContext) - Method in class com.mongodb.DBObjectCodec
 
readBinaryData() - Method in class org.bson.AbstractBsonReader
 
readBinaryData(String) - Method in class org.bson.AbstractBsonReader
 
readBinaryData() - Method in interface org.bson.BsonReader
Reads BSON Binary data from the reader.
readBinaryData(String) - Method in interface org.bson.BsonReader
Reads a BSON Binary data element from the reader.
readBinarySubtypeFromExtendedJson() - Method in class org.bson.json.JsonReader
 
ReadBinding - Interface in com.mongodb.binding
A factory of connection sources to servers that can be read from and that satisfy the specified read preference.
readBoolean() - Method in class org.bson.AbstractBsonReader
 
readBoolean(String) - Method in class org.bson.AbstractBsonReader
 
readBoolean() - Method in interface org.bson.BsonReader
Reads a BSON Boolean from the reader.
readBoolean(String) - Method in interface org.bson.BsonReader
Reads a BSON Boolean element from the reader.
readBsonType() - Method in class org.bson.AbstractBsonReader
 
readBsonType() - Method in class org.bson.BsonBinaryReader
 
readBsonType() - Method in class org.bson.BsonDocumentReader
 
readBsonType() - Method in interface org.bson.BsonReader
Reads a BSONType from the reader.
readBsonType() - Method in class org.bson.json.JsonReader
 
readByte() - Method in interface org.bson.io.BsonInput
Reads a single byte from the stream
readByte() - Method in class org.bson.io.ByteBufferBsonInput
 
readBytes(byte[]) - Method in interface org.bson.io.BsonInput
Reads the specified number of bytes into the given byte array.
readBytes(byte[], int, int) - Method in interface org.bson.io.BsonInput
Reads the specified number of bytes into the given byte array starting at the specified offset.
readBytes(byte[]) - Method in class org.bson.io.ByteBufferBsonInput
 
readBytes(byte[], int, int) - Method in class org.bson.io.ByteBufferBsonInput
 
readCodeWScope(BsonReader, DecoderContext, List<String>) - Method in class com.mongodb.DBObjectCodec
 
readConcern - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
readConcern(ReadConcern) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the read concern.
readConcern - Variable in class com.mongodb.async.client.MongoClientSettings
 
readConcern - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
readConcern - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
readConcern - Variable in class com.mongodb.async.client.MongoIterableImpl
 
readConcern - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
readConcern(ReadConcern) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the readConcern
readConcern - Variable in class com.mongodb.client.model.DBCollectionDistinctOptions
 
readConcern(ReadConcern) - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Sets the readConcern
readConcern - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
readConcern(ReadConcern) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the readConcern
readConcern - Variable in class com.mongodb.ConnectionString
 
readConcern - Variable in class com.mongodb.DB
 
readConcern - Variable in class com.mongodb.DBCollection
 
readConcern - Variable in class com.mongodb.Mongo
 
readConcern - Variable in class com.mongodb.MongoClientOptions.Builder
 
readConcern(ReadConcern) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the read concern.
readConcern - Variable in class com.mongodb.MongoClientOptions
 
readConcern - Variable in class com.mongodb.MongoCollectionImpl
 
readConcern - Variable in class com.mongodb.MongoDatabaseImpl
 
readConcern - Variable in class com.mongodb.MongoIterableImpl
 
readConcern - Variable in class com.mongodb.operation.AggregateOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.AggregateOperation
Sets the read concern
readConcern - Variable in class com.mongodb.operation.ChangeStreamOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.ChangeStreamOperation
Sets the read concern
readConcern - Variable in class com.mongodb.operation.CountOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.CountOperation
Sets the read concern
readConcern - Variable in class com.mongodb.operation.DistinctOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.DistinctOperation
Sets the read concern
readConcern - Variable in class com.mongodb.operation.FindOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.FindOperation
Sets the read concern
readConcern - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the read concern
readConcern - Variable in class com.mongodb.operation.ParallelCollectionScanOperation
 
readConcern(ReadConcern) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
Sets the read concern
ReadConcern - Class in com.mongodb
A read concern allows clients to choose a level of isolation for their reads.
ReadConcern(ReadConcernLevel) - Constructor for class com.mongodb.ReadConcern
Construct a new read concern
ReadConcern() - Constructor for class com.mongodb.ReadConcern
 
ReadConcernHelper - Class in com.mongodb.operation
 
ReadConcernHelper() - Constructor for class com.mongodb.operation.ReadConcernHelper
 
ReadConcernLevel - Enum in com.mongodb
A read concern level allows clients to choose a level of isolation for their reads.
ReadConcernLevel(String) - Constructor for enum com.mongodb.ReadConcernLevel
 
readCString() - Method in interface org.bson.io.BsonInput
Reads a BSON CString value from the stream.
readCString() - Method in class org.bson.io.ByteBufferBsonInput
 
readDateTime() - Method in class org.bson.AbstractBsonReader
 
readDateTime(String) - Method in class org.bson.AbstractBsonReader
 
readDateTime() - Method in interface org.bson.BsonReader
Reads a BSON DateTime from the reader.
readDateTime(String) - Method in interface org.bson.BsonReader
Reads a BSON DateTime element from the reader.
readDBPointer() - Method in class org.bson.AbstractBsonReader
 
readDBPointer(String) - Method in class org.bson.AbstractBsonReader
 
readDBPointer() - Method in interface org.bson.BsonReader
Reads a BSON DBPointer from the reader.
readDBPointer(String) - Method in interface org.bson.BsonReader
Reads a BSON DBPointer element from the reader.
readDbPointerIdFromExtendedJson() - Method in class org.bson.json.JsonReader
 
readDecimal128() - Method in class org.bson.AbstractBsonReader
 
readDecimal128(String) - Method in class org.bson.AbstractBsonReader
 
readDecimal128() - Method in interface org.bson.BsonReader
Reads a BSON Decimal128 from the reader.
readDecimal128(String) - Method in interface org.bson.BsonReader
Reads a BSON Decimal128 element from the reader.
readDocument(BsonReader, DecoderContext, List<String>) - Method in class com.mongodb.DBObjectCodec
 
readDocument(BsonBinaryReader) - Method in class org.bson.LazyBSONObject
 
readDouble() - Method in class org.bson.AbstractBsonReader
 
readDouble(String) - Method in class org.bson.AbstractBsonReader
 
readDouble() - Method in interface org.bson.BsonReader
Reads a BSON Double from the reader.
readDouble(String) - Method in interface org.bson.BsonReader
Reads a BSON Double element from the reader.
readDouble() - Method in interface org.bson.io.BsonInput
Reads a BSON Double value from the stream.
readDouble() - Method in class org.bson.io.ByteBufferBsonInput
 
readEndArray() - Method in class org.bson.AbstractBsonReader
 
readEndArray() - Method in interface org.bson.BsonReader
Reads the end of a BSON array from the reader.
readEndDocument() - Method in class org.bson.AbstractBsonReader
 
readEndDocument() - Method in interface org.bson.BsonReader
Reads the end of a BSON document from the reader.
reader - Variable in class org.bson.LazyBSONList.LazyBSONListIterator
 
readFully(InputStream) - Method in class org.bson.BasicBSONDecoder
 
readFully(InputStream, byte[]) - Static method in class org.bson.io.Bits
Reads bytes from the input stream and puts them into the given byte buffer.
readFully(InputStream, byte[], int) - Static method in class org.bson.io.Bits
Reads bytes from the input stream and puts them into the given byte buffer.
readFully(InputStream, byte[], int, int) - Static method in class org.bson.io.Bits
Reads bytes from the input stream and puts them into the given byte buffer.
readHex() - Method in class com.mongodb.util.JSONParser
Read the current character, making sure that it is a hexidecimal character.
reading - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
readInt(InputStream) - Static method in class org.bson.io.Bits
Reads and returns a single integer value from the input stream.
readInt(InputStream, byte[]) - Static method in class org.bson.io.Bits
Reads and returns a single integer value from the input stream.
readInt(byte[]) - Static method in class org.bson.io.Bits
Reads and returns a single integer value from the buffer.
readInt(byte[], int) - Static method in class org.bson.io.Bits
Reads and returns a single integer value from the buffer.
readInt32() - Method in class org.bson.AbstractBsonReader
 
readInt32(String) - Method in class org.bson.AbstractBsonReader
 
readInt32() - Method in interface org.bson.BsonReader
Reads a BSON Int32 from the reader.
readInt32(String) - Method in interface org.bson.BsonReader
Reads a BSON Int32 element from the reader.
readInt32() - Method in interface org.bson.io.BsonInput
Reads a BSON Int32 value from the stream.
readInt32() - Method in class org.bson.io.ByteBufferBsonInput
 
readInt64() - Method in class org.bson.AbstractBsonReader
 
readInt64(String) - Method in class org.bson.AbstractBsonReader
 
readInt64() - Method in interface org.bson.BsonReader
Reads a BSON Int64 from the reader.
readInt64(String) - Method in interface org.bson.BsonReader
Reads a BSON Int64 element from the reader.
readInt64() - Method in interface org.bson.io.BsonInput
Reads a BSON Int64 value from the stream.
readInt64() - Method in class org.bson.io.ByteBufferBsonInput
 
readIntBE(byte[], int) - Static method in class org.bson.io.Bits
Reads and returns a single big-endian integer value
readIntFromExtendedJson() - Method in class org.bson.json.JsonReader
 
readJavaScript() - Method in class org.bson.AbstractBsonReader
 
readJavaScript(String) - Method in class org.bson.AbstractBsonReader
 
readJavaScript() - Method in interface org.bson.BsonReader
Reads a BSON JavaScript from the reader.
readJavaScript(String) - Method in interface org.bson.BsonReader
Reads a BSON JavaScript element from the reader.
readJavaScriptWithScope() - Method in class org.bson.AbstractBsonReader
 
readJavaScriptWithScope(String) - Method in class org.bson.AbstractBsonReader
 
readJavaScriptWithScope() - Method in interface org.bson.BsonReader
Reads a BSON JavaScript with scope from the reader (call readStartDocument next to read the scope).
readJavaScriptWithScope(String) - Method in interface org.bson.BsonReader
Reads a BSON JavaScript with scope element from the reader (call readStartDocument next to read the scope).
readJavaScriptWithScopeDocument(BsonBinaryReader) - Method in class org.bson.LazyBSONObject
 
readList(BsonReader, DecoderContext) - Method in class org.bson.codecs.DocumentCodec
 
readLong(InputStream) - Static method in class org.bson.io.Bits
Reads and returns a single long value from the input stream.
readLong(InputStream, byte[]) - Static method in class org.bson.io.Bits
Reads and returns a single long value from the input stream.
readLong(byte[]) - Static method in class org.bson.io.Bits
Reads and returns a single long value from the buffer.
readLong(byte[], int) - Static method in class org.bson.io.Bits
Reads and returns a single long value from the buffer.
readLongFromArrayBigEndian(byte[], int) - Static method in class org.bson.codecs.UuidCodec
 
readMaxKey() - Method in class org.bson.AbstractBsonReader
 
readMaxKey(String) - Method in class org.bson.AbstractBsonReader
 
readMaxKey() - Method in interface org.bson.BsonReader
Reads a BSON MaxKey from the reader.
readMaxKey(String) - Method in interface org.bson.BsonReader
Reads a BSON MaxKey element from the reader.
readMinKey() - Method in class org.bson.AbstractBsonReader
 
readMinKey(String) - Method in class org.bson.AbstractBsonReader
 
readMinKey() - Method in interface org.bson.BsonReader
Reads a BSON MinKey from the reader.
readMinKey(String) - Method in interface org.bson.BsonReader
Reads a BSON MinKey element from the reader.
readName() - Method in class org.bson.AbstractBsonReader
 
readName(String) - Method in class org.bson.AbstractBsonReader
 
readName() - Method in interface org.bson.BsonReader
Reads the name of an element from the reader.
readName(String) - Method in interface org.bson.BsonReader
Reads the name of an element from the reader.
readName - Variable in class org.bson.codecs.pojo.PropertyModel
 
readName - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
readName(String) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Sets the readName, the key for this property when deserializing the data from BSON.
readNull() - Method in class org.bson.AbstractBsonReader
 
readNull(String) - Method in class org.bson.AbstractBsonReader
 
readNull() - Method in interface org.bson.BsonReader
Reads a BSON null from the reader.
readNull(String) - Method in interface org.bson.BsonReader
Reads a BSON null element from the reader.
readObject(ObjectInputStream) - Method in class com.mongodb.connection.ByteBufBsonDocument
 
readObject(InputStream) - Method in class com.mongodb.LazyDBDecoder
 
readObject(byte[]) - Method in class org.bson.BasicBSONDecoder
 
readObject(InputStream) - Method in class org.bson.BasicBSONDecoder
 
readObject(byte[]) - Method in interface org.bson.BSONDecoder
Read a single BSON object from the given bytes.
readObject(InputStream) - Method in interface org.bson.BSONDecoder
Read a single BSON object from the given input stream.
readObject(ObjectInputStream) - Method in class org.bson.BsonDocument
 
readObject(ObjectInputStream) - Method in class org.bson.BsonDocumentWrapper
 
readObject(byte[]) - Method in class org.bson.LazyBSONDecoder
 
readObject(InputStream) - Method in class org.bson.LazyBSONDecoder
 
readObject(ObjectInputStream) - Method in class org.bson.RawBsonDocument
 
readObjectId() - Method in class org.bson.AbstractBsonReader
 
readObjectId(String) - Method in class org.bson.AbstractBsonReader
 
readObjectId() - Method in interface org.bson.BsonReader
Reads a BSON ObjectId from the reader.
readObjectId(String) - Method in interface org.bson.BsonReader
Reads a BSON ObjectId element from the reader.
readObjectId() - Method in interface org.bson.io.BsonInput
Reads a BSON ObjectId value from the stream.
readObjectId() - Method in class org.bson.io.ByteBufferBsonInput
 
readOnly - Variable in class com.mongodb.operation.CreateUserOperation
 
readOnly - Variable in class com.mongodb.operation.UpdateUserOperation
 
ReadOperation<T> - Interface in com.mongodb.operation
An operation that reads from a MongoDB server.
readPreference - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
readPreference(ReadPreference) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the read preference.
readPreference - Variable in class com.mongodb.async.client.MongoClientSettings
 
readPreference - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
readPreference - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
readPreference - Variable in class com.mongodb.async.client.MongoIterableImpl
 
readPreference - Variable in class com.mongodb.binding.AsyncClusterBinding
 
readPreference - Variable in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
readPreference - Variable in class com.mongodb.binding.ClusterBinding
 
readPreference - Variable in class com.mongodb.binding.SingleConnectionReadBinding
 
readPreference - Variable in class com.mongodb.binding.SingleServerBinding
 
readPreference - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
readPreference(ReadPreference) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the readPreference
readPreference - Variable in class com.mongodb.client.model.DBCollectionDistinctOptions
 
readPreference(ReadPreference) - Method in class com.mongodb.client.model.DBCollectionDistinctOptions
Sets the readPreference
readPreference - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
readPreference(ReadPreference) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the readPreference
readPreference - Variable in class com.mongodb.connection.CommandMessage
 
readPreference - Variable in class com.mongodb.connection.CommandProtocolImpl
 
readPreference - Variable in class com.mongodb.ConnectionString
 
readPreference - Variable in class com.mongodb.DB
 
readPreference - Variable in class com.mongodb.DBCollection
 
readPreference - Variable in class com.mongodb.MapReduceCommand
 
readPreference - Variable in class com.mongodb.Mongo
 
readPreference - Variable in class com.mongodb.MongoClientOptions.Builder
 
readPreference(ReadPreference) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the read preference.
readPreference - Variable in class com.mongodb.MongoClientOptions
 
readPreference - Variable in class com.mongodb.MongoCollectionImpl
 
readPreference - Variable in class com.mongodb.MongoDatabaseImpl
 
readPreference - Variable in class com.mongodb.MongoIterableImpl
 
readPreference - Variable in class com.mongodb.MongoOptions
Deprecated.
Specifies the read preference.
readPreference - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
readPreference - Variable in class com.mongodb.ParallelScanOptions.Builder
 
readPreference(ReadPreference) - Method in class com.mongodb.ParallelScanOptions.Builder
The read preference to use.
readPreference - Variable in class com.mongodb.ParallelScanOptions
 
ReadPreference - Class in com.mongodb
A class that represents preferred replica set members to which a query or command can be sent.
ReadPreference() - Constructor for class com.mongodb.ReadPreference
 
readPreference - Variable in class com.mongodb.selector.ReadPreferenceServerSelector
 
ReadPreference.PrimaryReadPreference - Class in com.mongodb
Preference to read from primary only.
ReadPreferenceServerSelector - Class in com.mongodb.selector
A server selector that chooses based on a read preference.
ReadPreferenceServerSelector(ReadPreference) - Constructor for class com.mongodb.selector.ReadPreferenceServerSelector
Gets the read preference.
readRegularExpression() - Method in class org.bson.AbstractBsonReader
 
readRegularExpression(String) - Method in class org.bson.AbstractBsonReader
 
readRegularExpression() - Method in interface org.bson.BsonReader
Reads a BSON regular expression from the reader.
readRegularExpression(String) - Method in interface org.bson.BsonReader
Reads a BSON regular expression element from the reader.
readResolve() - Method in class org.bson.BsonDocument.SerializationProxy
 
readResolve() - Method in class org.bson.RawBsonDocument.SerializationProxy
 
readSize() - Method in class org.bson.BsonBinaryReader
 
readStartArray() - Method in class org.bson.AbstractBsonReader
 
readStartArray() - Method in interface org.bson.BsonReader
Reads the start of a BSON array.
readStartDocument() - Method in class org.bson.AbstractBsonReader
 
readStartDocument() - Method in interface org.bson.BsonReader
Reads the start of a BSON document.
readString() - Method in class org.bson.AbstractBsonReader
 
readString(String) - Method in class org.bson.AbstractBsonReader
 
readString() - Method in interface org.bson.BsonReader
Reads a BSON String from the reader.
readString(String) - Method in interface org.bson.BsonReader
Reads a BSON string element from the reader.
readString() - Method in interface org.bson.io.BsonInput
Reads a BSON String value from the stream.
readString() - Method in class org.bson.io.ByteBufferBsonInput
 
readString(int) - Method in class org.bson.io.ByteBufferBsonInput
 
readStringFromExtendedJson() - Method in class org.bson.json.JsonReader
 
readSymbol() - Method in class org.bson.AbstractBsonReader
 
readSymbol(String) - Method in class org.bson.AbstractBsonReader
 
readSymbol() - Method in interface org.bson.BsonReader
Reads a BSON symbol from the reader.
readSymbol(String) - Method in interface org.bson.BsonReader
Reads a BSON symbol element from the reader.
readTimeout - Variable in class com.mongodb.connection.netty.ReadTimeoutHandler
 
readTimeout(int, TimeUnit) - Method in class com.mongodb.connection.SocketSettings.Builder
Sets the socket read timeout.
ReadTimeoutHandler - Class in com.mongodb.connection.netty
ReadTimeoutHandler(long) - Constructor for class com.mongodb.connection.netty.ReadTimeoutHandler
 
ReadTimeoutHandler.ReadTimeoutTask - Class in com.mongodb.connection.netty
 
readTimeoutMS - Variable in class com.mongodb.connection.SocketSettings.Builder
 
readTimeoutMS - Variable in class com.mongodb.connection.SocketSettings
 
ReadTimeoutTask(ChannelHandlerContext) - Constructor for class com.mongodb.connection.netty.ReadTimeoutHandler.ReadTimeoutTask
 
readTimestamp() - Method in class org.bson.AbstractBsonReader
 
readTimestamp(String) - Method in class org.bson.AbstractBsonReader
 
readTimestamp() - Method in interface org.bson.BsonReader
Reads a BSON timestamp from the reader.
readTimestamp(String) - Method in interface org.bson.BsonReader
Reads a BSON timestamp element from the reader.
readUndefined() - Method in class org.bson.AbstractBsonReader
 
readUndefined(String) - Method in class org.bson.AbstractBsonReader
 
readUndefined() - Method in interface org.bson.BsonReader
Reads a BSON undefined from the reader.
readUndefined(String) - Method in interface org.bson.BsonReader
Reads a BSON undefined element from the reader.
readUntilNullByte() - Method in class org.bson.io.ByteBufferBsonInput
 
readValue(BsonReader, DecoderContext, String, List<String>) - Method in class com.mongodb.DBObjectCodec
 
readValue(BsonReader, DecoderContext) - Method in class com.mongodb.operation.CommandResultArrayCodec
 
readValue(BsonReader, DecoderContext) - Method in class com.mongodb.operation.CommandResultDocumentCodec
 
readValue(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonArrayCodec
This method may be overridden to change the behavior of reading the current value from the given BsonReader.
readValue(BsonReader, DecoderContext) - Method in class org.bson.codecs.BsonDocumentCodec
This method may be overridden to change the behavior of reading the current value from the given BsonReader.
readValue(BsonReader, DecoderContext) - Method in class org.bson.codecs.DocumentCodec
 
readValue(BsonReader, DecoderContext) - Method in class org.bson.codecs.IterableCodec
 
readValue(BsonReader, DecoderContext) - Method in class org.bson.codecs.MapCodec
 
readValue(BsonBinaryReader) - Method in class org.bson.LazyBSONObject
 
ReadWriteBinding - Interface in com.mongodb.binding
A factory of connection sources to servers that can be read from or written to.
receiveBufferSize - Variable in class com.mongodb.connection.SocketSettings.Builder
 
receiveBufferSize(int) - Method in class com.mongodb.connection.SocketSettings.Builder
Sets the receive buffer size.
receiveBufferSize - Variable in class com.mongodb.connection.SocketSettings
 
receiveCommandMessageResponse(CommandMessage, Decoder<T>, InternalStreamConnection.CommandEventSender, SessionContext) - Method in class com.mongodb.connection.InternalStreamConnection
 
receiveMessage(int) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
receiveMessage(int) - Method in interface com.mongodb.connection.InternalConnection
Receive a response to a sent message from the server.
receiveMessage(int) - Method in class com.mongodb.connection.InternalStreamConnection
 
receiveMessage(int) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
receiveMessageAsync(int, SingleResultCallback<ResponseBuffers>) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
receiveMessageAsync(int, SingleResultCallback<ResponseBuffers>) - Method in interface com.mongodb.connection.InternalConnection
Asynchronously receive a response to a sent message from the server.
receiveMessageAsync(int, SingleResultCallback<ResponseBuffers>) - Method in class com.mongodb.connection.InternalStreamConnection
 
receiveMessageAsync(int, SingleResultCallback<ResponseBuffers>) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
receiveMessageCallback - Variable in class com.mongodb.connection.SendMessageCallback
 
receiveResponseBuffers() - Method in class com.mongodb.connection.InternalStreamConnection
 
reduce - Variable in class com.mongodb.GroupCommand
 
reduce - Variable in class com.mongodb.MapReduceCommand
 
reduceFunction - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
reduceFunction - Variable in class com.mongodb.MapReduceIterableImpl
 
reduceFunction - Variable in class com.mongodb.operation.GroupOperation
 
reduceFunction - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
reduceFunction - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
REF - Static variable in class org.bson.BSON
 
referenceCount - Variable in class com.mongodb.binding.AbstractReferenceCounted
 
referenceCount - Variable in class com.mongodb.connection.AbstractReferenceCounted
 
referenceCount - Variable in class com.mongodb.connection.CompositeByteBuf
 
referenceCount - Variable in class org.bson.ByteBufNIO
 
ReferenceCounted - Interface in com.mongodb.binding
An interface for reference-counted objects.
referenceCounted - Variable in class com.mongodb.operation.OperationHelper.ReferenceCountedReleasingWrappedCallback
 
ReferenceCountedReleasingWrappedCallback(SingleResultCallback<T>, List<? extends ReferenceCounted>) - Constructor for class com.mongodb.operation.OperationHelper.ReferenceCountedReleasingWrappedCallback
 
ReflectionDBObject - Class in com.mongodb
This class enables to map simple Class fields to a BSON object fields
ReflectionDBObject() - Constructor for class com.mongodb.ReflectionDBObject
 
ReflectionDBObject.FieldInfo - Class in com.mongodb
 
ReflectionDBObject.JavaWrapper - Class in com.mongodb
Represents a wrapper around the DBObject to interface with the Class fields
regex(String, String) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the field matches the given regular expression pattern with the given options applied.
regex(String, String, String) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the field matches the given regular expression pattern with the given options applied.
regex(String, Pattern) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the field matches the given regular expression pattern with the given options applied.
regex(Pattern) - Method in class com.mongodb.QueryBuilder
Passes a regular expression for a query
REGEX - Static variable in class org.bson.BSON
 
regexFlag(char) - Static method in class org.bson.BSON
Converts a regular expression modifier from the database into Java regular expression flags.
RegexFlag(int, char, String) - Constructor for enum org.bson.codecs.PatternCodec.RegexFlag
 
regexFlags(String) - Static method in class org.bson.BSON
Converts a sequence of regular expression modifiers from the database into Java regular expression flags.
regexFlags(int) - Static method in class org.bson.BSON
Converts Java regular expression flags into regular expression modifiers from the database.
register(Class<?>...) - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Registers a classes with the builder for inclusion in the Provider.
register(ClassModel<?>...) - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Registers classModels for inclusion in the Provider.
register(String...) - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Registers the packages of the given classes with the builder for inclusion in the Provider.
register(PropertyCodecProvider...) - Method in class org.bson.codecs.pojo.PojoCodecProvider.Builder
Registers codec providers that receive the type parameters of properties for instances encoded and decoded by a PojoCodec handled by this provider.
registerMBean(Object, String) - Method in class com.mongodb.internal.management.jmx.JMXMBeanServer
 
registerMBean(Object, String) - Method in interface com.mongodb.management.MBeanServer
Register the given mBean with the given name.
registerMBean(Object, String) - Method in class com.mongodb.management.NullMBeanServer
 
registry - Variable in class com.mongodb.client.model.geojson.codecs.AbstractGeometryCodec
 
REGISTRY - Static variable in class com.mongodb.client.model.geojson.Geometry
 
REGISTRY - Static variable in class com.mongodb.connection.AbstractByteBufBsonDocument
 
REGISTRY - Static variable in class com.mongodb.connection.BsonWriterHelper
 
REGISTRY - Static variable in class com.mongodb.connection.ProtocolHelper
 
REGISTRY - Static variable in class com.mongodb.connection.RequestMessage
 
registry - Variable in class com.mongodb.DBRefCodec
 
REGISTRY - Static variable in class com.mongodb.operation.BulkWriteBatch
 
registry - Variable in class org.bson.codecs.configuration.ChildCodecRegistry
 
registry - Variable in class org.bson.codecs.configuration.LazyCodec
 
registry - Variable in class org.bson.codecs.DocumentCodec
 
registry - Variable in class org.bson.codecs.IterableCodec
 
registry - Variable in class org.bson.codecs.MapCodec
 
registry - Variable in class org.bson.codecs.pojo.LazyPojoCodec
 
registry - Variable in class org.bson.codecs.pojo.PojoCodecImpl
 
REGISTRY - Static variable in class org.bson.RawBsonDocument
 
regularExpressionConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
regularExpressionConverter(Converter<BsonRegularExpression>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Regular Expression values to JSON.
regularExpressionConverter - Variable in class org.bson.json.JsonWriterSettings
 
RegularExpressionState() - Constructor for enum org.bson.json.JsonScanner.RegularExpressionState
 
RELAXED_EXTENDED_JSON_DATE_TIME_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
RELAXED_EXTENDED_JSON_DOUBLE_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
RELAXED_JSON_INT_64_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
RelaxedExtendedJsonDateTimeConverter - Class in org.bson.json
 
RelaxedExtendedJsonDateTimeConverter() - Constructor for class org.bson.json.RelaxedExtendedJsonDateTimeConverter
 
RelaxedExtendedJsonDoubleConverter - Class in org.bson.json
 
RelaxedExtendedJsonDoubleConverter() - Constructor for class org.bson.json.RelaxedExtendedJsonDoubleConverter
 
RelaxedExtendedJsonInt64Converter - Class in org.bson.json
 
RelaxedExtendedJsonInt64Converter() - Constructor for class org.bson.json.RelaxedExtendedJsonInt64Converter
 
release() - Method in class com.mongodb.async.client.ClientSessionBinding
 
release() - Method in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
release() - Method in class com.mongodb.binding.AbstractReferenceCounted
 
release() - Method in class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
release() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource
 
release() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
release() - Method in class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
release() - Method in interface com.mongodb.binding.ReferenceCounted
Release a reference to this object.
release() - Method in class com.mongodb.binding.SingleConnectionReadBinding
 
release() - Method in class com.mongodb.binding.SingleConnectionReadBinding.SingleConnectionSource
 
release() - Method in class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
release() - Method in class com.mongodb.ClientSessionBinding
 
release() - Method in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
release() - Method in class com.mongodb.connection.AbstractReferenceCounted
 
release() - Method in class com.mongodb.connection.CompositeByteBuf
 
release() - Method in class com.mongodb.connection.DefaultServerConnection
 
release() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
release(T) - Method in class com.mongodb.internal.connection.ConcurrentPool
Return an instance of T to the pool.
release(T, boolean) - Method in class com.mongodb.internal.connection.ConcurrentPool
call done when you are done with an object from the pool if there is room and the object is ok will get added
release(T) - Method in interface com.mongodb.internal.connection.Pool
 
release(T, boolean) - Method in interface com.mongodb.internal.connection.Pool
 
release() - Method in class com.mongodb.internal.connection.PowerOfTwoBufferPool.PooledByteBufNIO
 
release(ByteBuffer) - Method in class com.mongodb.internal.connection.PowerOfTwoBufferPool
 
release(ServerSession) - Method in class com.mongodb.internal.session.ServerSessionPool
 
release() - Method in interface org.bson.ByteBuf
Release a reference to this object.
release() - Method in class org.bson.ByteBufNIO
 
releaseConnectionAndGetWrapped() - Method in class com.mongodb.operation.OperationHelper.ConnectionReleasingWrappedCallback
 
releasePermit() - Method in class com.mongodb.internal.connection.ConcurrentPool
 
releaseReadingLock() - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
releaseWritingLock() - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
releasingCallback(SingleResultCallback<T>, AsyncConnectionSource) - Static method in class com.mongodb.operation.OperationHelper
 
releasingCallback(SingleResultCallback<T>, AsyncConnection) - Static method in class com.mongodb.operation.OperationHelper
 
releasingCallback(SingleResultCallback<T>, AsyncConnectionSource, AsyncConnection) - Static method in class com.mongodb.operation.OperationHelper
 
releasingCallback(SingleResultCallback<T>, AsyncReadBinding, AsyncConnectionSource, AsyncConnection) - Static method in class com.mongodb.operation.OperationHelper
 
remainder(long, long) - Static method in class org.bson.internal.UnsignedLongs
 
remaining() - Method in class com.mongodb.connection.CompositeByteBuf
 
remaining() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
remaining() - Method in interface org.bson.ByteBuf
Returns the number of elements between the current position and the limit.
remaining() - Method in class org.bson.ByteBufNIO
 
remove() - Method in class com.mongodb.BulkWriteRequestBuilder
Adds a request to remove all documents in the collection that match the query with which this builder was created.
remove - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
remove(boolean) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the remove
remove(Object) - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
remove(DBObject) - Method in class com.mongodb.DBCollection
Remove documents from a collection.
remove(DBObject, WriteConcern) - Method in class com.mongodb.DBCollection
Remove documents from a collection.
remove(DBObject, WriteConcern, DBEncoder) - Method in class com.mongodb.DBCollection
Remove documents from a collection.
remove(DBObject, DBCollectionRemoveOptions) - Method in class com.mongodb.DBCollection
Remove documents from a collection.
remove() - Method in class com.mongodb.DBCursor
 
remove(ConnectionPoolListener) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
Removes the given connection pool listener from the list of listeners to invoke on connection pool events.
remove(ObjectId) - Method in class com.mongodb.gridfs.GridFS
Removes the file matching the given id.
remove(String) - Method in class com.mongodb.gridfs.GridFS
Removes all files matching the given filename.
remove(DBObject) - Method in class com.mongodb.gridfs.GridFS
Removes all files matching the given query.
remove() - Method in class com.mongodb.gridfs.GridFSDBFile
Removes file from GridFS i.e.
remove() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
remove() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
remove(Object) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Removes the first element e such that o.equals(e), if such an element exists in this deque.
remove() - Method in class com.mongodb.MongoBatchCursorAdapter
 
remove() - Method in class com.mongodb.MongoCursorAdapter
 
remove() - Method in class com.mongodb.MongoMappingCursor
 
remove(Object) - Method in class com.mongodb.operation.BsonArrayWrapper
 
remove(int) - Method in class com.mongodb.operation.BsonArrayWrapper
 
remove() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
remove() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
remove() - Method in class com.mongodb.operation.QueryBatchCursor
 
remove(Object) - Method in class org.bson.BsonArray
 
remove(int) - Method in class org.bson.BsonArray
 
remove(Object) - Method in class org.bson.BsonDocument
 
remove() - Method in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
remove(Object) - Method in class org.bson.BsonDocumentWrapper
 
remove(Object) - Method in class org.bson.Document
 
remove() - Method in class org.bson.LazyBSONList.LazyBSONListIterator
 
remove(Object) - Method in class org.bson.LazyBSONList
 
remove(int) - Method in class org.bson.LazyBSONList
 
remove(Object) - Method in class org.bson.RawBsonDocument
 
remove(Object) - Method in class org.bson.types.StringRangeSet
 
remove(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap.EntrySet
 
remove(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap.KeySet
 
remove(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
remove(Object, Object) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
remove() - Method in class org.bson.util.AbstractCopyOnWriteMap.UnmodifiableIterator
 
remove(Object) - Method in class org.bson.util.AbstractCopyOnWriteMap.Values
 
remove(Object) - Method in class org.bson.util.ClassMap
As per java.util.Map, removes the mapping for a key from this map if it is present
remove(Object, Object) - Method in class org.bson.util.ComputingMap
 
remove(Object) - Method in class org.bson.util.ComputingMap
 
removeAll(Collection<?>) - Method in class com.mongodb.operation.BsonArrayWrapper
 
removeAll(Collection<?>) - Method in class org.bson.BsonArray
 
removeAll(Collection) - Method in class org.bson.LazyBSONList
 
removeAll(Collection<?>) - Method in class org.bson.types.StringRangeSet
 
removeAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.EntrySet
 
removeAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.KeySet
 
removeAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.Values
 
removedCount - Variable in class com.mongodb.AcknowledgedBulkWriteResult
 
removeDecodingHook(Class<?>, Transformer) - Static method in class org.bson.BSON
Remove a specific encoding hook for a specific class.
removeDecodingHooks(Class<?>) - Static method in class org.bson.BSON
Remove all decoding hooks for a specific class.
removedFields - Variable in class com.mongodb.client.model.changestream.UpdateDescription
 
removeEncodingHook(Class<?>, Transformer) - Static method in class org.bson.BSON
Remove a specific encoding hook for a specific class.
removeEncodingHooks(Class<?>) - Static method in class org.bson.BSON
Remove all encoding hooks for a specific class.
removeExtraHosts(ServerDescription) - Method in class com.mongodb.connection.MultiServerCluster
 
removeField(String) - Method in class com.mongodb.gridfs.GridFSFile
 
removeField(String) - Method in class com.mongodb.ReflectionDBObject
This operation is not supported.
removeField(String) - Method in class org.bson.BasicBSONObject
Deletes a field from this object.
removeField(String) - Method in interface org.bson.BSONObject
Removes a field with a given name from this object.
removeField(String) - Method in class org.bson.LazyBSONObject
Always throws UnsupportedOperationException.
removeField(String) - Method in class org.bson.types.BasicBSONList
 
removeFirst() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
removeFirstOccurrence(Object) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Removes the first element e such that o.equals(e), if such an element exists in this deque.
removeLast() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
removeLastOccurrence(Object) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Removes the last element e such that o.equals(e), if such an element exists in this deque.
removeOne() - Method in class com.mongodb.BulkWriteRequestBuilder
Adds a request to remove one document in the collection that matches the query with which this builder was created.
removeProperty(String) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Remove a property from the builder
RemoveRequest - Class in com.mongodb
 
RemoveRequest(DBObject, boolean, Encoder<DBObject>, Collation) - Constructor for class com.mongodb.RemoveRequest
 
removeServer(ServerAddress) - Method in class com.mongodb.connection.MultiServerCluster
 
removeTimeout(ChannelHandlerContext) - Method in class com.mongodb.connection.netty.ReadTimeoutHandler
 
removeUser(String) - Method in class com.mongodb.DB
Deprecated.
Use DB.command to call the dropUser command
rename(ObjectId, String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(BsonValue, String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(ClientSession, ObjectId, String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(ClientSession, BsonValue, String, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(ObjectId, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
rename(BsonValue, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
rename(ClientSession, ObjectId, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
rename(ClientSession, BsonValue, String, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
rename(ObjectId, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(BsonValue, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(ClientSession, ObjectId, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(ClientSession, BsonValue, String) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Renames the stored file with the specified id.
rename(ObjectId, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
rename(BsonValue, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
rename(ClientSession, ObjectId, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
rename(ClientSession, BsonValue, String) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
rename(String, String) - Static method in class com.mongodb.client.model.Updates
Creates an update that renames a field.
rename(String) - Method in class com.mongodb.DBCollection
Change the name of an existing collection.
rename(String, boolean) - Method in class com.mongodb.DBCollection
Change the name of an existing collection.
renameCollection(MongoNamespace, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(MongoNamespace, RenameCollectionOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(ClientSession, MongoNamespace, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(ClientSession, MongoNamespace, RenameCollectionOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(MongoNamespace, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
renameCollection(MongoNamespace, RenameCollectionOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
renameCollection(ClientSession, MongoNamespace, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
renameCollection(ClientSession, MongoNamespace, RenameCollectionOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
renameCollection(MongoNamespace) - Method in interface com.mongodb.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(MongoNamespace, RenameCollectionOptions) - Method in interface com.mongodb.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(ClientSession, MongoNamespace) - Method in interface com.mongodb.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(ClientSession, MongoNamespace, RenameCollectionOptions) - Method in interface com.mongodb.client.MongoCollection
Rename the collection with oldCollectionName to the newCollectionName.
renameCollection(MongoNamespace) - Method in class com.mongodb.MongoCollectionImpl
 
renameCollection(MongoNamespace, RenameCollectionOptions) - Method in class com.mongodb.MongoCollectionImpl
 
renameCollection(ClientSession, MongoNamespace) - Method in class com.mongodb.MongoCollectionImpl
 
renameCollection(ClientSession, MongoNamespace, RenameCollectionOptions) - Method in class com.mongodb.MongoCollectionImpl
 
RenameCollectionOperation - Class in com.mongodb.operation
An operation that renames the given collection to the new name.
RenameCollectionOperation(MongoNamespace, MongoNamespace) - Constructor for class com.mongodb.operation.RenameCollectionOperation
RenameCollectionOperation(MongoNamespace, MongoNamespace, WriteConcern) - Constructor for class com.mongodb.operation.RenameCollectionOperation
 
RenameCollectionOptions - Class in com.mongodb.client.model
The options to apply when renaming a collection.
RenameCollectionOptions() - Constructor for class com.mongodb.client.model.RenameCollectionOptions
 
replace(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Tries to insert a node holding element to replace this node.
replace(K, V, V) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
replace(K, V) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
replace(K, V, V) - Method in class org.bson.util.ComputingMap
 
replace(K, V) - Method in class org.bson.util.ComputingMap
 
replacement - Variable in class com.mongodb.client.model.ReplaceOneModel
 
replacement - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
replacementCodec - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
replacementCodec - Variable in class com.mongodb.BulkWriteRequestBuilder
 
replacementCodec - Variable in class com.mongodb.ReplaceRequest
 
replaceOne(Bson, TDocument, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(Bson, TDocument, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(ClientSession, Bson, TDocument, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(ClientSession, Bson, TDocument, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(Bson, TDocument, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
replaceOne(Bson, TDocument, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
replaceOne(ClientSession, Bson, TDocument, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
replaceOne(ClientSession, Bson, TDocument, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
replaceOne(DBObject) - Method in class com.mongodb.BulkUpdateRequestBuilder
Adds a request to replace one document in the collection that matches the query with which this builder was created.
replaceOne(DBObject) - Method in class com.mongodb.BulkWriteRequestBuilder
Adds a request to replace one document in the collection that matches the query with which this builder was created.
replaceOne(Bson, TDocument) - Method in interface com.mongodb.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(Bson, TDocument, UpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(ClientSession, Bson, TDocument) - Method in interface com.mongodb.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(ClientSession, Bson, TDocument, UpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Replace a document in the collection according to the specified arguments.
replaceOne(Bson, TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
replaceOne(Bson, TDocument, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
replaceOne(ClientSession, Bson, TDocument) - Method in class com.mongodb.MongoCollectionImpl
 
replaceOne(ClientSession, Bson, TDocument, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
ReplaceOneModel<T> - Class in com.mongodb.client.model
A model describing the replacement of at most one document that matches the query filter.
ReplaceOneModel(Bson, T) - Constructor for class com.mongodb.client.model.ReplaceOneModel
Construct a new instance.
ReplaceOneModel(Bson, T, UpdateOptions) - Constructor for class com.mongodb.client.model.ReplaceOneModel
Construct a new instance.
replaceOrInsert(DBObject, Object, WriteConcern) - Method in class com.mongodb.DBCollection
 
ReplaceRequest - Class in com.mongodb
 
ReplaceRequest(DBObject, DBObject, boolean, Encoder<DBObject>, Encoder<DBObject>, Collation) - Constructor for class com.mongodb.ReplaceRequest
 
replaceRoot(TExpression) - Static method in class com.mongodb.client.model.Aggregates
Creates a $replaceRoot pipeline stage
ReplaceRootStage(TExpression) - Constructor for class com.mongodb.client.model.Aggregates.ReplaceRootStage
 
REPLICA_ACKNOWLEDGED - Static variable in class com.mongodb.WriteConcern
Deprecated.
Prefer WriteConcern#W2
REPLICAS_SAFE - Static variable in class com.mongodb.WriteConcern
Deprecated.
replicaSetName - Variable in class com.mongodb.connection.MultiServerCluster
 
ReplicaSetStatus - Class in com.mongodb
Keeps replica set status.
ReplicaSetStatus(Cluster) - Constructor for class com.mongodb.ReplicaSetStatus
 
reply - Variable in class com.mongodb.event.ServerHeartbeatSucceededEvent
 
REPLY_HEADER_LENGTH - Static variable in class com.mongodb.connection.ReplyHeader
The length of the OP_REPLY header in the MongoDB wire protocol.
ReplyHeader - Class in com.mongodb.connection
Contains the details of a reply from a MongoDB server.
ReplyHeader(ByteBuf, MessageHeader) - Constructor for class com.mongodb.connection.ReplyHeader
 
ReplyHeader(ByteBuf, CompressedHeader) - Constructor for class com.mongodb.connection.ReplyHeader
 
ReplyHeader(int, int, MessageHeader, ByteBuf) - Constructor for class com.mongodb.connection.ReplyHeader
 
replyHeader - Variable in class com.mongodb.connection.ReplyMessage
 
replyHeader - Variable in class com.mongodb.connection.ResponseBuffers
 
ReplyMessage<T> - Class in com.mongodb.connection
An OP_REPLY message.
ReplyMessage(ResponseBuffers, Decoder<T>, long) - Constructor for class com.mongodb.connection.ReplyMessage
 
ReplyMessage(ReplyHeader, long) - Constructor for class com.mongodb.connection.ReplyMessage
 
reportingRemove() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.CLDIterator
 
reportingRemove() - Method in interface com.mongodb.internal.connection.ConcurrentLinkedDeque.RemovalReportingIterator
Removes from the underlying collection the last element returned by this iterator and reports whether the current element was removed by the call.
request(long) - Method in class com.mongodb.async.client.AbstractSubscription
 
request(long) - Method in interface com.mongodb.async.client.Subscription
No operation will be sent to MongoDB from the Observable until demand is signaled via this method.
REQUEST_ID - Static variable in class com.mongodb.connection.RequestMessage
 
requested - Variable in class com.mongodb.async.client.AbstractSubscription
 
requestedCompressors - Variable in class com.mongodb.connection.InternalStreamConnectionInitializer
 
requestedData - Variable in class com.mongodb.async.client.AbstractSubscription
 
requestId - Variable in class com.mongodb.connection.MessageHeader
 
requestId - Variable in class com.mongodb.connection.ReplyHeader
 
requestId - Variable in class com.mongodb.connection.ResponseCallback
 
requestId - Variable in class com.mongodb.connection.SendMessageCallback
 
requestId - Variable in class com.mongodb.event.CommandEvent
 
requestId - Variable in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
 
requestInitialData() - Method in class com.mongodb.async.client.AbstractSubscription
 
requestInitialData() - Method in class com.mongodb.async.client.FlatteningSingleResultCallbackSubscription
 
requestInitialData() - Method in class com.mongodb.async.client.MongoIterableSubscription
 
requestInitialData() - Method in class com.mongodb.async.client.SingleResultCallbackSubscription
 
RequestMessage - Class in com.mongodb.connection
Abstract base class for all MongoDB Wire Protocol request messages.
RequestMessage(OpCode, MessageSettings) - Constructor for class com.mongodb.connection.RequestMessage
 
RequestMessage(OpCode, int, MessageSettings) - Constructor for class com.mongodb.connection.RequestMessage
 
RequestMessage(String, OpCode, MessageSettings) - Constructor for class com.mongodb.connection.RequestMessage
 
RequestMessage(String, OpCode, int, MessageSettings) - Constructor for class com.mongodb.connection.RequestMessage
 
RequestMessage.EncodingMetadata - Class in com.mongodb.connection
 
requestMoreData() - Method in class com.mongodb.async.client.AbstractSubscription
 
requestMoreData() - Method in class com.mongodb.async.client.MongoIterableSubscription
 
requests - Variable in class com.mongodb.BulkWriteOperation
 
requests - Variable in class com.mongodb.operation.CreateIndexesOperation
 
requiredClusterType - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
requiredClusterType(ClusterType) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the required cluster type for the cluster.
requiredClusterType - Variable in class com.mongodb.connection.ClusterSettings
 
requiredReplicaSetName - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
requiredReplicaSetName(String) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the required replica set name for the cluster.
requiredReplicaSetName - Variable in class com.mongodb.connection.ClusterSettings
 
requiredReplicaSetName - Variable in class com.mongodb.ConnectionString
 
requiredReplicaSetName - Variable in class com.mongodb.MongoClientOptions.Builder
 
requiredReplicaSetName(String) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the required replica set name for the cluster.
requiredReplicaSetName - Variable in class com.mongodb.MongoClientOptions
 
requiredReplicaSetName - Variable in class com.mongodb.MongoOptions
Deprecated.
 
requireOpMsgResponse() - Method in class com.mongodb.connection.CommandMessage
 
reset() - Method in class com.mongodb.Bytes.OptionHolder
 
reset() - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
reset() - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
reset() - Method in class com.mongodb.connection.ExponentiallyWeightedMovingAverage
 
reset() - Method in class com.mongodb.connection.ResponseBuffers
 
reset() - Method in class com.mongodb.MongoOptions
Deprecated.
Reset all settings to the default.
reset() - Method in class org.bson.AbstractBsonReader.Mark
 
reset() - Method in class org.bson.AbstractBsonWriter.Mark
Resets the AbstractBsonWriter instance that contains this Mark to the state the writer was in when the Mark was created.
reset() - Method in class org.bson.BasicBSONCallback
 
reset() - Method in class org.bson.BsonBinaryReader.Mark
 
reset() - Method in class org.bson.BsonBinaryReader
 
reset() - Method in class org.bson.BsonBinaryWriter.Mark
 
reset() - Method in class org.bson.BsonBinaryWriter
Resets this writer to the last BsonBinaryWriter.mark() saved.
reset() - Method in interface org.bson.BSONCallback
Resets the callback, clearing all state.
reset() - Method in class org.bson.BsonDocumentReader.BsonDocumentMarkableIterator
 
reset() - Method in class org.bson.BsonDocumentReader.Context
 
reset() - Method in class org.bson.BsonDocumentReader.Mark
 
reset() - Method in class org.bson.BsonDocumentReader
 
reset() - Method in interface org.bson.BsonReader
Go back to the state at the last mark and removes the mark
reset() - Method in interface org.bson.BsonReaderMark
Reset the BsonReader to its state at the time the mark was created.
reset() - Method in class org.bson.EmptyBSONCallback
 
reset() - Method in interface org.bson.io.BsonInput
Resets the stream to the current mark.
reset() - Method in class org.bson.io.ByteBufferBsonInput
 
reset() - Method in class org.bson.json.JsonReader.Mark
 
reset() - Method in class org.bson.json.JsonReader
 
reset() - Method in class org.bson.LazyBSONCallback
 
resetOptions() - Method in class com.mongodb.DB
Resets the query options.
resetOptions() - Method in class com.mongodb.DBCollection
Resets the default query options
resetOptions() - Method in class com.mongodb.DBCursor
Resets the query options.
resetOptions() - Method in class com.mongodb.Mongo
Deprecated.
Reset options instead on instances of DBCursor
resolveAdditionalQueryParametersFromTxtRecords(String) - Static method in class com.mongodb.internal.dns.DnsResolver
 
resolveHostFromSrvRecords(String) - Static method in class com.mongodb.internal.dns.DnsResolver
 
response - Variable in class com.mongodb.CommandResult
 
response - Variable in class com.mongodb.event.CommandSucceededEvent
 
response - Variable in exception com.mongodb.MongoCommandException
 
response - Variable in exception com.mongodb.WriteConcernException
 
ResponseBuffers - Class in com.mongodb.connection
 
ResponseBuffers(ReplyHeader, ByteBuf) - Constructor for class com.mongodb.connection.ResponseBuffers
 
ResponseCallback - Class in com.mongodb.connection
 
ResponseCallback(long, ServerAddress) - Constructor for class com.mongodb.connection.ResponseCallback
 
responseExpected - Variable in class com.mongodb.connection.CommandMessage
 
responseExpected - Variable in class com.mongodb.connection.CommandProtocolImpl
 
responseFlags - Variable in class com.mongodb.connection.ReplyHeader
 
responseTo - Variable in class com.mongodb.connection.MessageHeader
 
responseTo - Variable in class com.mongodb.connection.ReplyHeader
 
responseTo - Variable in class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
 
restrictSearchWithMatch - Variable in class com.mongodb.client.model.GraphLookupOptions
 
restrictSearchWithMatch(Bson) - Method in class com.mongodb.client.model.GraphLookupOptions
A document specifying additional conditions for the recursive search
result - Variable in class com.mongodb.connection.FutureAsyncCompletionHandler
 
RESULT - Static variable in class com.mongodb.operation.AggregateOperation
 
resultClass - Variable in class com.mongodb.AggregateIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.DistinctIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.FindIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.ListCollectionsIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.ListDatabasesIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.ListIndexesIterableImpl
 
resultClass - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
resultClass - Variable in class com.mongodb.DistinctIterableImpl
 
resultClass - Variable in class com.mongodb.FindIterableImpl
 
resultClass - Variable in class com.mongodb.ListCollectionsIterableImpl
 
resultClass - Variable in class com.mongodb.ListDatabasesIterableImpl
 
resultClass - Variable in class com.mongodb.ListIndexesIterableImpl
 
resultClass - Variable in class com.mongodb.MapReduceIterableImpl
 
resultDecoder - Variable in class com.mongodb.connection.GetMoreProtocol
 
resultDecoder - Variable in class com.mongodb.connection.QueryProtocol
 
RESULTFLAG_AWAITCAPABLE - Static variable in class com.mongodb.Bytes
Set when the server supports the AwaitData Query option.
RESULTFLAG_CURSORNOTFOUND - Static variable in class com.mongodb.Bytes
Set when getMore is called but the cursor id is not valid at the server.
RESULTFLAG_ERRSET - Static variable in class com.mongodb.Bytes
Set when query failed.
RESULTFLAG_SHARDCONFIGSTALE - Static variable in class com.mongodb.Bytes
Drivers should ignore this.
results - Variable in class com.mongodb.AggregationOutput
Deprecated.
 
results() - Method in class com.mongodb.AggregationOutput
Deprecated.
Returns the results of the aggregation.
results - Variable in class com.mongodb.connection.QueryResult
 
results() - Method in class com.mongodb.MapReduceOutput
Returns an iterable containing the results of the operation.
resultsFromCollection - Variable in class com.mongodb.MapReduceOutput
 
resultsQueue - Variable in class com.mongodb.async.client.AbstractSubscription
 
resultsQueue - Variable in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
resumeableOperation(AsyncChangeStreamBatchCursor.AsyncBlock, SingleResultCallback<List<RawBsonDocument>>) - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
resumeableOperation(Function<BatchCursor<RawBsonDocument>, R>) - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
resumeAfter(BsonDocument) - Method in interface com.mongodb.async.client.ChangeStreamIterable
Sets the logical starting point for the new change stream.
resumeAfter(BsonDocument) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
resumeAfter(BsonDocument) - Method in class com.mongodb.ChangeStreamIterableImpl
 
resumeAfter(BsonDocument) - Method in interface com.mongodb.client.ChangeStreamIterable
Sets the logical starting point for the new change stream.
resumeAfter(BsonDocument) - Method in class com.mongodb.operation.ChangeStreamOperation
Sets the logical starting point for the new change stream.
resumeToken - Variable in class com.mongodb.async.client.ChangeStreamIterableImpl
 
resumeToken - Variable in class com.mongodb.ChangeStreamIterableImpl
 
resumeToken - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
resumeToken - Variable in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
resumeToken - Variable in class com.mongodb.operation.ChangeStreamBatchCursor
 
resumeToken - Variable in class com.mongodb.operation.ChangeStreamOperation
 
retain() - Method in class com.mongodb.async.client.ClientSessionBinding
 
retain() - Method in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
retain() - Method in class com.mongodb.binding.AbstractReferenceCounted
 
retain() - Method in class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
retain() - Method in class com.mongodb.binding.AsyncClusterBinding
 
retain() - Method in interface com.mongodb.binding.AsyncConnectionSource
 
retain() - Method in interface com.mongodb.binding.AsyncReadBinding
 
retain() - Method in interface com.mongodb.binding.AsyncReadWriteBinding
 
retain() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding.AsyncSingleConnectionSource
 
retain() - Method in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
retain() - Method in interface com.mongodb.binding.AsyncWriteBinding
 
retain() - Method in class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
retain() - Method in class com.mongodb.binding.ClusterBinding
 
retain() - Method in interface com.mongodb.binding.ConnectionSource
 
retain() - Method in interface com.mongodb.binding.ReadBinding
 
retain() - Method in interface com.mongodb.binding.ReadWriteBinding
 
retain() - Method in interface com.mongodb.binding.ReferenceCounted
Retain an additional reference to this object.
retain() - Method in class com.mongodb.binding.SingleConnectionReadBinding
 
retain() - Method in class com.mongodb.binding.SingleConnectionReadBinding.SingleConnectionSource
 
retain() - Method in class com.mongodb.binding.SingleServerBinding
 
retain() - Method in class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
retain() - Method in interface com.mongodb.binding.WriteBinding
 
retain() - Method in class com.mongodb.ClientSessionBinding
 
retain() - Method in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
retain() - Method in class com.mongodb.connection.AbstractReferenceCounted
 
retain() - Method in interface com.mongodb.connection.AsyncConnection
 
retain() - Method in class com.mongodb.connection.CompositeByteBuf
 
retain() - Method in interface com.mongodb.connection.Connection
 
retain() - Method in class com.mongodb.connection.DefaultServerConnection
 
retain() - Method in class com.mongodb.connection.netty.NettyByteBuf
 
retain() - Method in interface org.bson.ByteBuf
Retain an additional reference to this object.
retain() - Method in class org.bson.ByteBufNIO
 
retainAll(Collection<?>) - Method in class com.mongodb.operation.BsonArrayWrapper
 
retainAll(Collection<?>) - Method in class org.bson.BsonArray
 
retainAll(Collection) - Method in class org.bson.LazyBSONList
 
retainAll(Collection<?>) - Method in class org.bson.types.StringRangeSet
 
retainAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.EntrySet
 
retainAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.KeySet
 
retainAll(Collection<?>) - Method in class org.bson.util.AbstractCopyOnWriteMap.Values
 
rethrowIfNotNamespaceError(MongoCommandException) - Static method in class com.mongodb.operation.CommandOperationHelper
 
rethrowIfNotNamespaceError(MongoCommandException, T) - Static method in class com.mongodb.operation.CommandOperationHelper
 
retryExecuteBatches(WriteBinding, BulkWriteBatch, MongoException) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
retryExecuteBatchesAsync(AsyncWriteBinding, BulkWriteBatch, Throwable, SingleResultCallback<BulkWriteResult>) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
retryOperation(AsyncChangeStreamBatchCursor.AsyncBlock, SingleResultCallback<List<RawBsonDocument>>) - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
retryWrites - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
retryWrites(boolean) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets whether writes should be retried if they fail due to a network error.
retryWrites - Variable in class com.mongodb.async.client.MongoClientSettings
 
retryWrites - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
retryWrites - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
retryWrites - Variable in class com.mongodb.ConnectionString
 
retryWrites - Variable in class com.mongodb.DBCollection
 
retryWrites - Variable in class com.mongodb.MongoClientOptions.Builder
 
retryWrites(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Sets whether writes should be retried if they fail due to a network error.
retryWrites - Variable in class com.mongodb.MongoClientOptions
 
retryWrites - Variable in class com.mongodb.MongoCollectionImpl
 
retryWrites - Variable in class com.mongodb.MongoDatabaseImpl
 
retryWrites - Variable in class com.mongodb.operation.BaseWriteOperation
 
retryWrites - Variable in class com.mongodb.operation.BulkWriteBatch
 
retryWrites - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
retryWrites - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
retryWrites - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
retryWrites - Variable in class com.mongodb.operation.MixedBulkWriteOperation
 
RETURN_KEY - Static variable in class com.mongodb.QueryOperators
 
returnDocument - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
returnDocument(ReturnDocument) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Set whether to return the document before it was replaced or after
returnDocument - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
returnDocument(ReturnDocument) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Set whether to return the document before it was updated / inserted or after
ReturnDocument - Enum in com.mongodb.client.model
Indicates which document to return, the original document before change or the document after the change
ReturnDocument() - Constructor for enum com.mongodb.client.model.ReturnDocument
 
returnKey(boolean) - Method in interface com.mongodb.async.client.FindIterable
Sets the returnKey.
returnKey(boolean) - Method in class com.mongodb.async.client.FindIterableImpl
 
returnKey(boolean) - Method in interface com.mongodb.client.FindIterable
Sets the returnKey.
returnKey - Variable in class com.mongodb.client.model.FindOptions
 
returnKey(boolean) - Method in class com.mongodb.client.model.FindOptions
Sets the returnKey.
returnKey() - Method in class com.mongodb.DBCursor
Forces the cursor to only return fields included in the index.
returnKey(boolean) - Method in class com.mongodb.FindIterableImpl
 
returnKey - Variable in class com.mongodb.operation.FindOperation
 
returnKey(boolean) - Method in class com.mongodb.operation.FindOperation
Sets the returnKey.
returnNew - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
returnNew() - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Returns the returnNew
returnNew(boolean) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the returnNew
returnOriginal - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
returnOriginal(boolean) - Method in class com.mongodb.operation.FindAndReplaceOperation
Set to false to return the replaced document rather than the original.
returnOriginal - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
returnOriginal(boolean) - Method in class com.mongodb.operation.FindAndUpdateOperation
Set to false if the updated document rather than the original should be returned.
reverseByteArray(byte[], int, int) - Static method in class org.bson.codecs.UuidCodecHelper
 
revision - Variable in class com.mongodb.client.gridfs.model.GridFSDownloadByNameOptions
Deprecated.
 
revision(int) - Method in class com.mongodb.client.gridfs.model.GridFSDownloadByNameOptions
Deprecated.
Set the revision of the file to retrieve.
revision - Variable in class com.mongodb.client.gridfs.model.GridFSDownloadOptions
 
revision(int) - Method in class com.mongodb.client.gridfs.model.GridFSDownloadOptions
Set the revision of the file to retrieve.
root - Variable in class org.bson.BasicBSONCallback
 
root - Variable in class org.bson.LazyBSONCallback
 
roundTripTime(long, TimeUnit) - Method in class com.mongodb.connection.ServerDescription.Builder
Set the time it took to make the round trip for requesting this information from the server
roundTripTimeNanos - Variable in class com.mongodb.connection.ServerDescription.Builder
 
roundTripTimeNanos - Variable in class com.mongodb.connection.ServerDescription
 
roundUpToNextHighestPowerOfTwo(int) - Static method in class com.mongodb.internal.connection.PowerOfTwoBufferPool
 
rPrefix - Variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
run() - Method in class com.mongodb.connection.BaseCluster.WaitQueueHandler
 
run() - Method in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
run() - Method in class com.mongodb.connection.netty.ReadTimeoutHandler.ReadTimeoutTask
 
runCommand(Bson, SingleResultCallback<Document>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(Bson, ReadPreference, SingleResultCallback<Document>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(Bson, Class<TResult>, SingleResultCallback<TResult>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(Bson, ReadPreference, Class<TResult>, SingleResultCallback<TResult>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(ClientSession, Bson, SingleResultCallback<Document>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(ClientSession, Bson, ReadPreference, SingleResultCallback<Document>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(ClientSession, Bson, Class<TResult>, SingleResultCallback<TResult>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(ClientSession, Bson, ReadPreference, Class<TResult>, SingleResultCallback<TResult>) - Method in interface com.mongodb.async.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(Bson, SingleResultCallback<Document>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(Bson, ReadPreference, SingleResultCallback<Document>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(Bson, Class<TResult>, SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(Bson, ReadPreference, Class<TResult>, SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, SingleResultCallback<Document>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, ReadPreference, SingleResultCallback<Document>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, Class<TResult>, SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, ReadPreference, Class<TResult>, SingleResultCallback<TResult>) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
runCommand(Bson) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(Bson, ReadPreference) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(Bson, Class<TResult>) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(Bson, ReadPreference, Class<TResult>) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(ClientSession, Bson) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(ClientSession, Bson, ReadPreference) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(ClientSession, Bson, Class<TResult>) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with a read preference of ReadPreference.primary().
runCommand(ClientSession, Bson, ReadPreference, Class<TResult>) - Method in interface com.mongodb.client.MongoDatabase
Executes the given command in the context of the current database with the given read preference.
runCommand(Bson) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(Bson, ReadPreference) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(Bson, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(Bson, ReadPreference, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(ClientSession, Bson) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, ReadPreference) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 
runCommand(ClientSession, Bson, ReadPreference, Class<TResult>) - Method in class com.mongodb.MongoDatabaseImpl
 

S

s - Variable in class com.mongodb.util.JSONParser
 
safe - Variable in class com.mongodb.MongoOptions
Deprecated.
If true the driver will use a WriteConcern of WriteConcern.SAFE for all operations.
SAFE - Static variable in class com.mongodb.WriteConcern
Deprecated.
sameHost(String) - Method in class com.mongodb.ServerAddress
Deprecated.
use the ServerAddress.equals(Object) method instead
sameParentDomain(List<String>, String) - Static method in class com.mongodb.internal.dns.DnsResolver
 
sample(int) - Static method in class com.mongodb.client.model.Aggregates
Creates a $sample pipeline stage with the specified sample size
SaslAuthenticator - Class in com.mongodb.connection
 
SaslAuthenticator(MongoCredential) - Constructor for class com.mongodb.connection.SaslAuthenticator
 
SaslAuthenticator.Continuator - Class in com.mongodb.connection
 
saslClient - Variable in class com.mongodb.connection.SaslAuthenticator.Continuator
 
saslStartDocument - Variable in class com.mongodb.connection.SaslAuthenticator.Continuator
 
save(DBObject) - Method in class com.mongodb.DBCollection
Update an existing document or insert a document depending on the parameter.
save(DBObject, WriteConcern) - Method in class com.mongodb.DBCollection
Update an existing document or insert a document depending on the parameter.
save() - Method in class com.mongodb.gridfs.GridFSFile
Saves the file entry to the files collection
save() - Method in class com.mongodb.gridfs.GridFSInputFile
Calls GridFSInputFile.save(long) with the existing chunk size.
save(long) - Method in class com.mongodb.gridfs.GridFSInputFile
This method first calls saveChunks(long) if the file data has not been saved yet.
saveChunks() - Method in class com.mongodb.gridfs.GridFSInputFile
Saves all data into chunks from configured InputStream input stream to GridFS.
saveChunks(long) - Method in class com.mongodb.gridfs.GridFSInputFile
Saves all data into chunks from configured InputStream input stream to GridFS.
savedChunks - Variable in class com.mongodb.gridfs.GridFSInputFile
 
scanner - Variable in class org.bson.json.JsonReader
 
scanNumber(char) - Method in class org.bson.json.JsonScanner
Reads number token from source.
scanRegularExpression() - Method in class org.bson.json.JsonScanner
Reads RegularExpressionToken from source.
scanString(char) - Method in class org.bson.json.JsonScanner
Reads StringToken from source.
scanUnquotedString() - Method in class org.bson.json.JsonScanner
Reads StringToken from source.
scheduleReadTimeout() - Method in class com.mongodb.connection.netty.NettyStream
 
scheduleTimeout(ChannelHandlerContext) - Method in class com.mongodb.connection.netty.ReadTimeoutHandler
 
scope(Bson) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the global variables that are accessible in the map, reduce and finalize functions.
scope - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
scope(Bson) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
scope(Bson) - Method in interface com.mongodb.client.MapReduceIterable
Sets the global variables that are accessible in the map, reduce and finalize functions.
scope - Variable in class com.mongodb.MapReduceCommand
 
scope - Variable in class com.mongodb.MapReduceIterableImpl
 
scope(Bson) - Method in class com.mongodb.MapReduceIterableImpl
 
scope - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
scope(BsonDocument) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the global variables that are accessible in the map, reduce and finalize functions.
scope - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
scope(BsonDocument) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the global variables that are accessible in the map, reduce and finalize functions.
scope - Variable in class org.bson.BsonJavaScriptWithScope
 
scope - Variable in class org.bson.types.CodeWithScope
 
scope - Variable in class org.bson.types.CodeWScope
 
SCRAM_SHA_1_MECHANISM - Static variable in class com.mongodb.MongoCredential
The SCRAM-SHA-1 Mechanism.
ScramSha1Authenticator - Class in com.mongodb.connection
 
ScramSha1Authenticator(MongoCredential) - Constructor for class com.mongodb.connection.ScramSha1Authenticator
 
ScramSha1Authenticator(MongoCredential, ScramSha1Authenticator.RandomStringGenerator) - Constructor for class com.mongodb.connection.ScramSha1Authenticator
 
ScramSha1Authenticator.DefaultRandomStringGenerator - Class in com.mongodb.connection
 
ScramSha1Authenticator.RandomStringGenerator - Interface in com.mongodb.connection
 
ScramSha1Authenticator.ScramSha1SaslClient - Class in com.mongodb.connection
 
ScramSha1SaslClient(MongoCredential, ScramSha1Authenticator.RandomStringGenerator) - Constructor for class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
screenNullResult(E) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns element unless it is null, in which case throws NoSuchElementException.
search - Variable in class com.mongodb.client.model.Filters.TextFilter
 
SEARCH - Static variable in class com.mongodb.QueryOperators
 
searchPackages(String) - Method in class org.bson.codecs.pojo.DiscriminatorLookup
 
SECONDARY - Static variable in class com.mongodb.ReadPreference
 
secondary() - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary.
secondary(long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary that is less stale than the given maximum.
secondary(TagSet) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with the given set of tags.
secondary(TagSet, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with the given set of tags that is less stale than the given maximum.
secondary(List<TagSet>) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with one of the given sets of tags.
secondary(List<TagSet>, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with one of the given sets of tags that is less stale than the given maximum.
SECONDARY_PREFERRED - Static variable in class com.mongodb.ReadPreference
 
secondaryPreferred() - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary if one is available, otherwise to the primary.
secondaryPreferred(long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary that is less stale than the given maximumm if one is available, otherwise to the primary.
secondaryPreferred(TagSet) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with the given set of tags, or the primary is none are available.
secondaryPreferred(TagSet, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with the given set of tags that is less stale than the given maximum, or the primary is none are available.
secondaryPreferred(List<TagSet>) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with one of the given sets of tags.
secondaryPreferred(List<TagSet>, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Gets a read preference that forces reads to a secondary with one of the given sets of tags that is less stale than the given maximum.
SecondaryPreferredReadPreference() - Constructor for class com.mongodb.TaggableReadPreference.SecondaryPreferredReadPreference
 
SecondaryPreferredReadPreference(List<TagSet>, Long, TimeUnit) - Constructor for class com.mongodb.TaggableReadPreference.SecondaryPreferredReadPreference
 
SecondaryReadPreference() - Constructor for class com.mongodb.TaggableReadPreference.SecondaryReadPreference
 
SecondaryReadPreference(List<TagSet>, Long, TimeUnit) - Constructor for class com.mongodb.TaggableReadPreference.SecondaryReadPreference
 
SECURITY_SENSITIVE_COMMANDS - Static variable in class com.mongodb.connection.InternalStreamConnection
 
select(ClusterDescription) - Method in class com.mongodb.selector.CompositeServerSelector
 
select(ClusterDescription) - Method in class com.mongodb.selector.LatencyMinimizingServerSelector
 
select(ClusterDescription) - Method in class com.mongodb.selector.PrimaryServerSelector
Deprecated.
 
select(ClusterDescription) - Method in class com.mongodb.selector.ReadPreferenceServerSelector
 
select(ClusterDescription) - Method in class com.mongodb.selector.ServerAddressSelector
 
select(ClusterDescription) - Method in interface com.mongodb.selector.ServerSelector
Select a list of server descriptions from the given cluster description according to some criteria.
select(ClusterDescription) - Method in class com.mongodb.selector.WritableServerSelector
 
selectFreshServers(ClusterDescription, List<ServerDescription>) - Method in class com.mongodb.TaggableReadPreference
 
selectRandomServer(ServerSelector, ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
selectServer(ServerSelector) - Method in class com.mongodb.connection.BaseCluster
 
selectServer(ServerSelector) - Method in interface com.mongodb.connection.Cluster
Get a MongoDB server that matches the criteria defined by the serverSelector
selectServerAsync(ServerSelector, SingleResultCallback<Server>) - Method in class com.mongodb.connection.BaseCluster
 
selectServerAsync(ServerSelector, SingleResultCallback<Server>) - Method in interface com.mongodb.connection.Cluster
Asynchronously gets a MongoDB server that matches the criteria defined by the serverSelector.
sendAndReceive(String, BsonDocument, ClusterClock, InternalConnection) - Static method in class com.mongodb.connection.CommandHelper
 
sendAndReceive(CommandMessage, Decoder<T>, SessionContext) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
sendAndReceive(CommandMessage, Decoder<T>, SessionContext) - Method in interface com.mongodb.connection.InternalConnection
Send a command message to the server.
sendAndReceive(CommandMessage, Decoder<T>, SessionContext) - Method in class com.mongodb.connection.InternalStreamConnection
 
sendAndReceive(CommandMessage, Decoder<T>, SessionContext) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
sendAndReceiveAsync(CommandMessage, Decoder<T>, SessionContext, SingleResultCallback<T>) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
sendAndReceiveAsync(CommandMessage, Decoder<T>, SessionContext, SingleResultCallback<T>) - Method in interface com.mongodb.connection.InternalConnection
Send a command message to the server.
sendAndReceiveAsync(CommandMessage, Decoder<T>, SessionContext, SingleResultCallback<T>) - Method in class com.mongodb.connection.InternalStreamConnection
 
sendAndReceiveAsync(CommandMessage, Decoder<T>, SessionContext, SingleResultCallback<T>) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
sendBufferSize - Variable in class com.mongodb.connection.SocketSettings.Builder
 
sendBufferSize(int) - Method in class com.mongodb.connection.SocketSettings.Builder
Sets the send buffer size.
sendBufferSize - Variable in class com.mongodb.connection.SocketSettings
 
sendCommandFailedEvent(RequestMessage, String, ConnectionDescription, long, Throwable, CommandListener) - Static method in class com.mongodb.connection.ProtocolHelper
 
sendCommandMessage(CommandMessage, InternalStreamConnection.LazyCommandDocument, ByteBufferBsonOutput, SessionContext) - Method in class com.mongodb.connection.InternalStreamConnection
 
sendCommandMessageAsync(int, Decoder<T>, SessionContext, SingleResultCallback<T>, ByteBufferBsonOutput, InternalStreamConnection.CommandEventSender, boolean) - Method in class com.mongodb.connection.InternalStreamConnection
 
sendCommandStartedEvent(RequestMessage, String, String, BsonDocument, ConnectionDescription, CommandListener) - Static method in class com.mongodb.connection.ProtocolHelper
 
sendCommandSucceededEvent(RequestMessage, String, BsonDocument, ConnectionDescription, long, CommandListener) - Static method in class com.mongodb.connection.ProtocolHelper
 
sendCompressor - Variable in class com.mongodb.connection.InternalStreamConnection
 
sendFailedEvent(Throwable) - Method in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
sendFailedEvent(InternalConnection, RequestMessage, boolean, Throwable, long) - Method in class com.mongodb.connection.WriteProtocol
 
sendMessage(List<ByteBuf>, int) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
sendMessage(GetMoreMessage, InternalConnection) - Method in class com.mongodb.connection.GetMoreProtocol
 
sendMessage(List<ByteBuf>, int) - Method in interface com.mongodb.connection.InternalConnection
Send a message to the server.
sendMessage(List<ByteBuf>, int) - Method in class com.mongodb.connection.InternalStreamConnection
 
sendMessage(List<ByteBuf>, int) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
sendMessageAsync(List<ByteBuf>, int, SingleResultCallback<Void>) - Method in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
sendMessageAsync(List<ByteBuf>, int, SingleResultCallback<Void>) - Method in interface com.mongodb.connection.InternalConnection
Asynchronously send a message to the server.
sendMessageAsync(List<ByteBuf>, int, SingleResultCallback<Void>) - Method in class com.mongodb.connection.InternalStreamConnection
 
sendMessageAsync(List<ByteBuf>, int, SingleResultCallback<Void>) - Method in class com.mongodb.connection.UsageTrackingInternalConnection
 
SendMessageCallback<T> - Class in com.mongodb.connection
 
SendMessageCallback(InternalConnection, OutputBuffer, RequestMessage, String, long, CommandListener, SingleResultCallback<T>, SingleResultCallback<ResponseBuffers>) - Constructor for class com.mongodb.connection.SendMessageCallback
 
SendMessageCallback(InternalConnection, OutputBuffer, RequestMessage, int, String, long, CommandListener, SingleResultCallback<T>, SingleResultCallback<ResponseBuffers>) - Constructor for class com.mongodb.connection.SendMessageCallback
 
sendQueryStartedEvent(InternalConnection, QueryMessage, ByteBufferBsonOutput, RequestMessage.EncodingMetadata) - Method in class com.mongodb.connection.QueryProtocol
 
sendQuerySucceededEvent(ConnectionDescription, long, QueryMessage, boolean, ResponseBuffers, QueryResult<T>) - Method in class com.mongodb.connection.QueryProtocol
 
sendSaslContinue(BsonInt32, byte[], InternalConnection) - Method in class com.mongodb.connection.SaslAuthenticator
 
sendSaslContinueAsync(BsonInt32, byte[], InternalConnection, SingleResultCallback<BsonDocument>) - Method in class com.mongodb.connection.SaslAuthenticator
 
sendSaslStart(byte[], InternalConnection) - Method in class com.mongodb.connection.SaslAuthenticator
 
sendSaslStartAsync(byte[], InternalConnection, SingleResultCallback<BsonDocument>) - Method in class com.mongodb.connection.SaslAuthenticator
 
sendStartedEvent() - Method in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
sendStartedEvent(InternalConnection, RequestMessage, RequestMessage.EncodingMetadata, ByteBufferBsonOutput) - Method in class com.mongodb.connection.WriteProtocol
 
sendSucceededEvent(ResponseBuffers) - Method in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
sendSucceededEvent(InternalConnection, RequestMessage, long) - Method in class com.mongodb.connection.WriteProtocol
 
sendSucceededEvent(InternalConnection, RequestMessage, BsonDocument, long) - Method in class com.mongodb.connection.WriteProtocol
 
sendSucceededEventForOneWayCommand() - Method in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
SEPARATOR - Static variable in class com.mongodb.connection.ClientMetadataHelper
 
serializationDepth - Variable in class org.bson.AbstractBsonWriter.Mark
 
serializationDepth - Variable in class org.bson.AbstractBsonWriter
 
SerializationProxy(BsonDocument) - Constructor for class org.bson.BsonDocument.SerializationProxy
 
SerializationProxy(byte[], int, int) - Constructor for class org.bson.RawBsonDocument.SerializationProxy
 
serialize(Object) - Method in class com.mongodb.util.AbstractObjectSerializer
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.ClassMapBasedObjectSerializer
 
serialize(Object) - Static method in class com.mongodb.util.JSON
Deprecated.
Serializes an object into its JSON form.
serialize(Object, StringBuilder) - Static method in class com.mongodb.util.JSON
Deprecated.
Serializes an object into its JSON form.
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.BinarySerializer
Deprecated.
 
serialize(byte[], byte, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.BinarySerializerBase
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.BSONTimestampSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.ByteArraySerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.CodeSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.CodeWScopeSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.DateSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.DBObjectSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.DBRefBaseSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.Decimal128Serializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.IterableSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.LegacyBinarySerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.LegacyBSONTimestampSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.LegacyDateSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.MapSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.MaxKeySerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.MinKeySerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.ObjectArraySerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.ObjectIdSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.PatternSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.StringSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.SymbolSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.ToStringSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.UndefinedSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in class com.mongodb.util.JSONSerializers.UuidSerializer
Deprecated.
 
serialize(Object, StringBuilder) - Method in interface com.mongodb.util.ObjectSerializer
Serializes obj into buf.
serialize(Object) - Method in interface com.mongodb.util.ObjectSerializer
Serializes obj.
serializer - Variable in class com.mongodb.util.JSONSerializers.CompoundObjectSerializer
Deprecated.
 
serialVersionUID - Static variable in class com.mongodb.BasicDBList
 
serialVersionUID - Static variable in class com.mongodb.BasicDBObject
 
serialVersionUID - Static variable in exception com.mongodb.BulkWriteException
 
serialVersionUID - Static variable in class com.mongodb.CommandResult
 
serialVersionUID - Static variable in class com.mongodb.connection.AbstractByteBufBsonDocument
 
serialVersionUID - Static variable in class com.mongodb.connection.ByteBufBsonDocument
 
serialVersionUID - Static variable in class com.mongodb.DBAddress
Deprecated.
 
serialVersionUID - Static variable in class com.mongodb.DBRef
 
serialVersionUID - Static variable in exception com.mongodb.DuplicateKeyException
 
serialVersionUID - Static variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
 
serialVersionUID - Static variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque
 
serialVersionUID - Static variable in exception com.mongodb.MongoBulkWriteException
 
serialVersionUID - Static variable in exception com.mongodb.MongoChangeStreamException
 
serialVersionUID - Static variable in exception com.mongodb.MongoClientException
 
serialVersionUID - Static variable in exception com.mongodb.MongoCommandException
 
serialVersionUID - Static variable in exception com.mongodb.MongoConfigurationException
 
serialVersionUID - Static variable in exception com.mongodb.MongoCursorNotFoundException
 
serialVersionUID - Static variable in exception com.mongodb.MongoException
 
serialVersionUID - Static variable in exception com.mongodb.MongoExecutionTimeoutException
 
serialVersionUID - Static variable in exception com.mongodb.MongoGridFSException
 
serialVersionUID - Static variable in exception com.mongodb.MongoIncompatibleDriverException
 
serialVersionUID - Static variable in exception com.mongodb.MongoInternalException
 
serialVersionUID - Static variable in exception com.mongodb.MongoInterruptedException
 
serialVersionUID - Static variable in exception com.mongodb.MongoNodeIsRecoveringException
 
serialVersionUID - Static variable in exception com.mongodb.MongoNotPrimaryException
 
serialVersionUID - Static variable in exception com.mongodb.MongoQueryException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSecurityException
 
serialVersionUID - Static variable in exception com.mongodb.MongoServerException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSocketClosedException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSocketException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSocketOpenException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSocketReadException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSocketReadTimeoutException
 
serialVersionUID - Static variable in exception com.mongodb.MongoSocketWriteException
 
serialVersionUID - Static variable in exception com.mongodb.MongoTimeoutException
 
serialVersionUID - Static variable in exception com.mongodb.MongoWaitQueueFullException
 
serialVersionUID - Static variable in exception com.mongodb.MongoWriteConcernException
 
serialVersionUID - Static variable in exception com.mongodb.MongoWriteException
 
serialVersionUID - Static variable in class com.mongodb.ServerAddress
 
serialVersionUID - Static variable in class com.mongodb.ServerCursor
 
serialVersionUID - Static variable in exception com.mongodb.util.JSONParseException
 
serialVersionUID - Static variable in class com.mongodb.WriteConcern.Majority
Deprecated.
 
serialVersionUID - Static variable in class com.mongodb.WriteConcern
 
serialVersionUID - Static variable in exception com.mongodb.WriteConcernException
 
serialVersionUID - Static variable in class org.bson.BasicBSONObject
 
serialVersionUID - Static variable in class org.bson.BsonDocument.SerializationProxy
 
serialVersionUID - Static variable in class org.bson.BsonDocument
 
serialVersionUID - Static variable in class org.bson.BsonDocumentWrapper
 
serialVersionUID - Static variable in exception org.bson.BSONException
 
serialVersionUID - Static variable in exception org.bson.BsonInvalidOperationException
 
serialVersionUID - Static variable in exception org.bson.BsonSerializationException
 
serialVersionUID - Static variable in exception org.bson.codecs.configuration.CodecConfigurationException
 
serialVersionUID - Static variable in class org.bson.Document
 
serialVersionUID - Static variable in exception org.bson.json.JsonParseException
 
serialVersionUID - Static variable in class org.bson.RawBsonDocument.SerializationProxy
 
serialVersionUID - Static variable in class org.bson.RawBsonDocument
 
serialVersionUID - Static variable in class org.bson.types.BasicBSONList
 
serialVersionUID - Static variable in class org.bson.types.Binary
 
serialVersionUID - Static variable in class org.bson.types.BSONTimestamp
 
serialVersionUID - Static variable in class org.bson.types.Code
 
serialVersionUID - Static variable in class org.bson.types.CodeWithScope
 
serialVersionUID - Static variable in class org.bson.types.CodeWScope
 
serialVersionUID - Static variable in class org.bson.types.Decimal128
 
serialVersionUID - Static variable in class org.bson.types.MaxKey
 
serialVersionUID - Static variable in class org.bson.types.MinKey
 
serialVersionUID - Static variable in class org.bson.types.ObjectId
 
serialVersionUID - Static variable in class org.bson.types.Symbol
 
serialVersionUID - Static variable in class org.bson.util.CopyOnWriteMap.Hash
 
serialVersionUID - Static variable in class org.bson.util.CopyOnWriteMap.Linked
 
serialVersionUID - Static variable in class org.bson.util.CopyOnWriteMap
 
server - Variable in class com.mongodb.binding.AsyncClusterBinding.AsyncClusterBindingConnectionSource
 
server - Variable in class com.mongodb.binding.ClusterBinding.ClusterBindingConnectionSource
 
server - Variable in class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
server - Variable in class com.mongodb.connection.MultiServerCluster.ServerTuple
 
Server - Interface in com.mongodb.connection
A logical connection to a MongoDB server.
server - Variable in class com.mongodb.connection.SingleServerCluster
 
server - Variable in class com.mongodb.internal.management.jmx.JMXMBeanServer
 
serverAddress - Variable in class com.mongodb.binding.SingleServerBinding
 
serverAddress - Variable in exception com.mongodb.BulkWriteException
 
serverAddress - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream
 
serverAddress - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
serverAddress - Variable in class com.mongodb.connection.QueryResult
 
serverAddress - Variable in class com.mongodb.connection.ResponseCallback
 
serverAddress - Variable in class com.mongodb.management.ConnectionPoolStatistics
 
serverAddress - Variable in exception com.mongodb.MongoBulkWriteException
 
serverAddress - Variable in exception com.mongodb.MongoCursorNotFoundException
 
serverAddress - Variable in exception com.mongodb.MongoServerException
 
serverAddress - Variable in exception com.mongodb.MongoSocketException
 
serverAddress - Variable in class com.mongodb.operation.CommandOperationHelper.TransformingResultCallback
 
serverAddress - Variable in class com.mongodb.operation.QueryBatchCursor
 
serverAddress - Variable in class com.mongodb.selector.ServerAddressSelector
 
ServerAddress - Class in com.mongodb
Represents the location of a Mongo server - i.e.
ServerAddress() - Constructor for class com.mongodb.ServerAddress
Creates a ServerAddress with default host and port
ServerAddress(String) - Constructor for class com.mongodb.ServerAddress
Creates a ServerAddress with default port
ServerAddress(InetAddress) - Constructor for class com.mongodb.ServerAddress
Creates a ServerAddress with default port
ServerAddress(InetAddress, int) - Constructor for class com.mongodb.ServerAddress
Creates a ServerAddress
ServerAddress(InetSocketAddress) - Constructor for class com.mongodb.ServerAddress
Creates a ServerAddress
ServerAddress(String, int) - Constructor for class com.mongodb.ServerAddress
Creates a ServerAddress
ServerAddressSelector - Class in com.mongodb.selector
A server selector that chooses a server that matches the server address.
ServerAddressSelector(ServerAddress) - Constructor for class com.mongodb.selector.ServerAddressSelector
Constructs a new instance.
serverClosed(ServerClosedEvent) - Method in class com.mongodb.event.ServerEventMulticaster
Deprecated.
 
serverClosed(ServerClosedEvent) - Method in interface com.mongodb.event.ServerListener
Listener for server closed events.
serverClosed(ServerClosedEvent) - Method in class com.mongodb.event.ServerListenerAdapter
 
serverClosed(ServerClosedEvent) - Method in class com.mongodb.internal.event.ServerListenerMulticaster
 
ServerClosedEvent - Class in com.mongodb.event
A server opening event.
ServerClosedEvent(ServerId) - Constructor for class com.mongodb.event.ServerClosedEvent
Construct an instance.
ServerConnectionState - Enum in com.mongodb.connection
Enum of the current state of attempting to connect to a server.
ServerConnectionState() - Constructor for enum com.mongodb.connection.ServerConnectionState
 
serverCursor - Variable in class com.mongodb.DBCursor.OptionalFinalizer
 
serverCursor - Variable in class com.mongodb.Mongo.ServerCursorAndNamespace
 
serverCursor - Variable in class com.mongodb.operation.QueryBatchCursor
 
ServerCursor - Class in com.mongodb
A class representing a cursor id associated with a server address (host/port) Since cursor ids are only useful in the context of a single MongoDB server process, you need both values to do a getMore on the cursor.
ServerCursor(long, ServerAddress) - Constructor for class com.mongodb.ServerCursor
Construct an instance.
ServerCursorAndNamespace(ServerCursor, MongoNamespace) - Constructor for class com.mongodb.Mongo.ServerCursorAndNamespace
 
serverDescription - Variable in class com.mongodb.binding.AsyncSingleConnectionReadBinding
 
serverDescription - Variable in class com.mongodb.binding.SingleConnectionReadBinding
 
ServerDescription - Class in com.mongodb.connection
Immutable snapshot state of a server.
ServerDescription(ServerDescription.Builder) - Constructor for class com.mongodb.connection.ServerDescription
 
ServerDescription.Builder - Class in com.mongodb.connection
A builder for creating ServerDescription.
serverDescriptionChanged(ServerDescriptionChangedEvent) - Method in class com.mongodb.connection.MultiServerCluster.DefaultServerStateListener
 
serverDescriptionChanged(ServerDescriptionChangedEvent) - Method in class com.mongodb.connection.SingleServerCluster.DefaultServerStateListener
 
serverDescriptionChanged(ServerDescriptionChangedEvent) - Method in class com.mongodb.event.ServerEventMulticaster
Deprecated.
 
serverDescriptionChanged(ServerDescriptionChangedEvent) - Method in interface com.mongodb.event.ServerListener
Listener for server description changed events.
serverDescriptionChanged(ServerDescriptionChangedEvent) - Method in class com.mongodb.event.ServerListenerAdapter
 
serverDescriptionChanged(ServerDescriptionChangedEvent) - Method in class com.mongodb.internal.event.ServerListenerMulticaster
 
ServerDescriptionChangedEvent - Class in com.mongodb.event
An event for changes to the description of a server.
ServerDescriptionChangedEvent(ServerId, ServerDescription, ServerDescription) - Constructor for class com.mongodb.event.ServerDescriptionChangedEvent
Construct an instance.
serverDescriptions - Variable in class com.mongodb.connection.ClusterDescription
 
ServerEventMulticaster - Class in com.mongodb.event
Deprecated.
register multiple server listeners instead
ServerEventMulticaster(List<ServerListener>) - Constructor for class com.mongodb.event.ServerEventMulticaster
Deprecated.
Construct an instance with the given list of server listeners
serverFactory - Variable in class com.mongodb.connection.BaseCluster
 
serverHearbeatStarted(ServerHeartbeatStartedEvent) - Method in class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
 
serverHearbeatStarted(ServerHeartbeatStartedEvent) - Method in interface com.mongodb.event.ServerMonitorListener
Listener for server heartbeat started events.
serverHearbeatStarted(ServerHeartbeatStartedEvent) - Method in class com.mongodb.event.ServerMonitorListenerAdapter
 
serverHearbeatStarted(ServerHeartbeatStartedEvent) - Method in class com.mongodb.internal.event.ServerMonitorListenerMulticaster
 
serverHeartbeatFailed(ServerHeartbeatFailedEvent) - Method in class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
 
serverHeartbeatFailed(ServerHeartbeatFailedEvent) - Method in interface com.mongodb.event.ServerMonitorListener
Listener for server heartbeat failed events.
serverHeartbeatFailed(ServerHeartbeatFailedEvent) - Method in class com.mongodb.event.ServerMonitorListenerAdapter
 
serverHeartbeatFailed(ServerHeartbeatFailedEvent) - Method in class com.mongodb.internal.event.ServerMonitorListenerMulticaster
 
ServerHeartbeatFailedEvent - Class in com.mongodb.event
An event for server heartbeat failures.
ServerHeartbeatFailedEvent(ConnectionId, long, Throwable) - Constructor for class com.mongodb.event.ServerHeartbeatFailedEvent
Construct an instance.
ServerHeartbeatStartedEvent - Class in com.mongodb.event
An event for the start of a server heartbeat.
ServerHeartbeatStartedEvent(ConnectionId) - Constructor for class com.mongodb.event.ServerHeartbeatStartedEvent
Construct an instance.
serverHeartbeatSucceeded(ServerHeartbeatSucceededEvent) - Method in class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
 
serverHeartbeatSucceeded(ServerHeartbeatSucceededEvent) - Method in interface com.mongodb.event.ServerMonitorListener
Listener for server heartbeat succeeded events.
serverHeartbeatSucceeded(ServerHeartbeatSucceededEvent) - Method in class com.mongodb.event.ServerMonitorListenerAdapter
 
serverHeartbeatSucceeded(ServerHeartbeatSucceededEvent) - Method in class com.mongodb.internal.event.ServerMonitorListenerMulticaster
 
ServerHeartbeatSucceededEvent - Class in com.mongodb.event
An event for successful completion of a server heartbeat.
ServerHeartbeatSucceededEvent(ConnectionId, BsonDocument, long) - Constructor for class com.mongodb.event.ServerHeartbeatSucceededEvent
Construct an instance.
serverId - Variable in class com.mongodb.connection.ConnectionId
 
serverId - Variable in class com.mongodb.connection.DefaultConnectionPool
 
serverId - Variable in class com.mongodb.connection.DefaultServer
 
serverId - Variable in class com.mongodb.connection.DefaultServerMonitor
 
serverId - Variable in class com.mongodb.connection.DefaultServerMonitorFactory
 
serverId - Variable in class com.mongodb.connection.InternalStreamConnection
 
ServerId - Class in com.mongodb.connection
A client-generated identifier that uniquely identifies a MongoDB server.
ServerId(ClusterId, ServerAddress) - Constructor for class com.mongodb.connection.ServerId
Construct an instance.
serverId - Variable in class com.mongodb.event.ConnectionPoolClosedEvent
 
serverId - Variable in class com.mongodb.event.ConnectionPoolOpenedEvent
 
serverId - Variable in class com.mongodb.event.ConnectionPoolWaitQueueEnteredEvent
 
serverId - Variable in class com.mongodb.event.ConnectionPoolWaitQueueExitedEvent
 
serverId - Variable in class com.mongodb.event.ServerClosedEvent
 
serverId - Variable in class com.mongodb.event.ServerDescriptionChangedEvent
 
serverId - Variable in class com.mongodb.event.ServerOpeningEvent
 
serverIsAtLeastVersion(ConnectionDescription, ServerVersion) - Static method in class com.mongodb.operation.OperationHelper
 
serverIsAtLeastVersionThreeDotFour(ConnectionDescription) - Static method in class com.mongodb.operation.OperationHelper
 
serverIsAtLeastVersionThreeDotSix(ConnectionDescription) - Static method in class com.mongodb.operation.OperationHelper
 
serverIsAtLeastVersionThreeDotTwo(ConnectionDescription) - Static method in class com.mongodb.operation.OperationHelper
 
serverIsAtLeastVersionThreeDotZero(ConnectionDescription) - Static method in class com.mongodb.operation.OperationHelper
 
serverListener - Variable in class com.mongodb.connection.DefaultServer
 
ServerListener - Interface in com.mongodb.event
A listener for server-related events
ServerListenerAdapter - Class in com.mongodb.event
An adapter for server listener implementations, for clients that want to listen for a subset of server events.
ServerListenerAdapter() - Constructor for class com.mongodb.event.ServerListenerAdapter
 
ServerListenerMulticaster - Class in com.mongodb.internal.event
 
ServerListenerMulticaster(List<ServerListener>) - Constructor for class com.mongodb.internal.event.ServerListenerMulticaster
 
serverListeners - Variable in class com.mongodb.connection.ServerSettings.Builder
 
serverListeners - Variable in class com.mongodb.connection.ServerSettings
 
serverListeners - Variable in class com.mongodb.event.ServerEventMulticaster
Deprecated.
 
serverListeners - Variable in class com.mongodb.internal.event.ServerListenerMulticaster
 
serverListeners - Variable in class com.mongodb.MongoClientOptions.Builder
 
serverMonitor - Variable in class com.mongodb.connection.DefaultServer
 
ServerMonitor - Interface in com.mongodb.connection
 
ServerMonitorEventMulticaster - Class in com.mongodb.event
Deprecated.
register multiple server monitor listeners instead
ServerMonitorEventMulticaster(List<ServerMonitorListener>) - Constructor for class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
Construct an instance with the given list of server monitor listeners
ServerMonitorFactory - Interface in com.mongodb.connection
 
serverMonitorListener - Variable in class com.mongodb.connection.DefaultServerMonitor
 
ServerMonitorListener - Interface in com.mongodb.event
A listener for server monitor-related events
ServerMonitorListenerAdapter - Class in com.mongodb.event
An adapter for server monitor listener implementations, for clients that want to listen for a subset of server monitor-related events.
ServerMonitorListenerAdapter() - Constructor for class com.mongodb.event.ServerMonitorListenerAdapter
 
ServerMonitorListenerMulticaster - Class in com.mongodb.internal.event
 
ServerMonitorListenerMulticaster(List<ServerMonitorListener>) - Constructor for class com.mongodb.internal.event.ServerMonitorListenerMulticaster
 
serverMonitorListeners - Variable in class com.mongodb.connection.ServerSettings.Builder
 
serverMonitorListeners - Variable in class com.mongodb.connection.ServerSettings
 
serverMonitorListeners - Variable in class com.mongodb.event.ServerMonitorEventMulticaster
Deprecated.
 
serverMonitorListeners - Variable in class com.mongodb.internal.event.ServerMonitorListenerMulticaster
 
serverMonitorListeners - Variable in class com.mongodb.MongoClientOptions.Builder
 
ServerMonitorRunnable() - Constructor for class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
serverOpening(ServerOpeningEvent) - Method in class com.mongodb.event.ServerEventMulticaster
Deprecated.
 
serverOpening(ServerOpeningEvent) - Method in interface com.mongodb.event.ServerListener
Listener for server opening events.
serverOpening(ServerOpeningEvent) - Method in class com.mongodb.event.ServerListenerAdapter
 
serverOpening(ServerOpeningEvent) - Method in class com.mongodb.internal.event.ServerListenerMulticaster
 
ServerOpeningEvent - Class in com.mongodb.event
A server opening event.
ServerOpeningEvent(ServerId) - Constructor for class com.mongodb.event.ServerOpeningEvent
Construct an instance.
serversAreAllThreeDotFour(ClusterDescription) - Method in class com.mongodb.TaggableReadPreference
 
ServerSelectionRequest(ServerSelector, ServerSelector, long, SingleResultCallback<Server>) - Constructor for class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
serverSelectionTimeout(long, TimeUnit) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the timeout to apply when selecting a server.
serverSelectionTimeout - Variable in class com.mongodb.ConnectionString
 
serverSelectionTimeout - Variable in class com.mongodb.MongoClientOptions.Builder
 
serverSelectionTimeout(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the server selection timeout in milliseconds, which defines how long the driver will wait for server selection to succeed before throwing an exception.
serverSelectionTimeout - Variable in class com.mongodb.MongoClientOptions
 
serverSelectionTimeoutMS - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
serverSelectionTimeoutMS - Variable in class com.mongodb.connection.ClusterSettings
 
serverSelector - Variable in class com.mongodb.connection.ClusterSettings.Builder
 
serverSelector(ServerSelector) - Method in class com.mongodb.connection.ClusterSettings.Builder
Sets the final server selector for the cluster to apply before selecting a server
serverSelector - Variable in class com.mongodb.connection.ClusterSettings
 
serverSelector - Variable in class com.mongodb.MongoClientOptions.Builder
 
serverSelector(ServerSelector) - Method in class com.mongodb.MongoClientOptions.Builder
Sets a server selector that augments the normal server selection rules applied by the driver when determining which server to send an operation to.
serverSelector - Variable in class com.mongodb.MongoClientOptions
 
ServerSelector - Interface in com.mongodb.selector
An interface for selecting a server from a cluster according to some preference.
serverSelectors - Variable in class com.mongodb.selector.CompositeServerSelector
 
serverSession - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
ServerSession - Interface in com.mongodb.session
A MongoDB server session.
ServerSessionImpl(BsonBinary) - Constructor for class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
ServerSessionItemFactory() - Constructor for class com.mongodb.internal.session.ServerSessionPool.ServerSessionItemFactory
 
serverSessionPool - Variable in class com.mongodb.async.client.ClientSessionHelper
 
serverSessionPool - Variable in class com.mongodb.async.client.MongoClientImpl
 
serverSessionPool - Variable in class com.mongodb.internal.session.ClientSessionImpl
 
ServerSessionPool - Class in com.mongodb.internal.session
 
ServerSessionPool(Cluster) - Constructor for class com.mongodb.internal.session.ServerSessionPool
 
ServerSessionPool(Cluster, ServerSessionPool.Clock) - Constructor for class com.mongodb.internal.session.ServerSessionPool
 
serverSessionPool - Variable in class com.mongodb.internal.session.ServerSessionPool
 
serverSessionPool - Variable in class com.mongodb.Mongo
 
ServerSessionPool.Clock - Interface in com.mongodb.internal.session
 
ServerSessionPool.ServerSessionImpl - Class in com.mongodb.internal.session
 
ServerSessionPool.ServerSessionItemFactory - Class in com.mongodb.internal.session
 
serverSettings - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
serverSettings(ServerSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the server settings.
serverSettings - Variable in class com.mongodb.async.client.MongoClientSettings
 
serverSettings - Variable in class com.mongodb.connection.ClusterDescription
 
serverSettings - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
serverSettings - Variable in class com.mongodb.connection.DefaultServerMonitor
 
ServerSettings - Class in com.mongodb.connection
Settings relating to monitoring of each server.
ServerSettings(ServerSettings.Builder) - Constructor for class com.mongodb.connection.ServerSettings
 
serverSettings - Variable in class com.mongodb.MongoClientOptions
 
ServerSettings.Builder - Class in com.mongodb.connection
A builder for the settings.
serverSignature - Variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
serverStateListener - Variable in class com.mongodb.connection.DefaultServer
 
serverStateListener - Variable in class com.mongodb.connection.DefaultServerMonitor
 
ServerTuple(ClusterableServer, ServerDescription) - Constructor for class com.mongodb.connection.MultiServerCluster.ServerTuple
 
serverType - Variable in class com.mongodb.connection.ConnectionDescription
 
serverType - Variable in class com.mongodb.connection.MessageSettings.Builder
 
serverType(ServerType) - Method in class com.mongodb.connection.MessageSettings.Builder
 
serverType - Variable in class com.mongodb.connection.MessageSettings
 
ServerType - Enum in com.mongodb.connection
The type of the server.
ServerType() - Constructor for enum com.mongodb.connection.ServerType
 
serverValue - Variable in class com.mongodb.connection.ConnectionId
 
serverVersion - Variable in class com.mongodb.connection.ConnectionDescription
 
serverVersion - Variable in class com.mongodb.connection.MessageSettings.Builder
 
serverVersion(ServerVersion) - Method in class com.mongodb.connection.MessageSettings.Builder
 
serverVersion - Variable in class com.mongodb.connection.MessageSettings
 
ServerVersion - Class in com.mongodb.connection
Holds an array of three integers representing the server version, e.g.
ServerVersion() - Constructor for class com.mongodb.connection.ServerVersion
Creates a server version which will compare as less than all other valid versions
ServerVersion(List<Integer>) - Constructor for class com.mongodb.connection.ServerVersion
Constructs a new instance with the given version list of integers.
ServerVersion(int, int) - Constructor for class com.mongodb.connection.ServerVersion
Constructs a new instance with the given major and minor versions and a patch version of 0.
SERVICE_NAME_DEFAULT_VALUE - Static variable in class com.mongodb.connection.GSSAPIAuthenticator
 
SERVICE_NAME_KEY - Static variable in class com.mongodb.MongoCredential
Mechanism property key for overriding the service name for GSSAPI authentication.
session - Variable in class com.mongodb.async.client.ClientSessionBinding
 
session - Variable in class com.mongodb.ClientSessionBinding
 
SessionBindingAsyncConnectionSource(AsyncConnectionSource) - Constructor for class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
SessionBindingConnectionSource(ConnectionSource) - Constructor for class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
sessionContext - Variable in class com.mongodb.async.client.ClientSessionBinding
 
sessionContext - Variable in class com.mongodb.ClientSessionBinding
 
sessionContext(SessionContext) - Method in interface com.mongodb.connection.CommandProtocol
 
sessionContext - Variable in class com.mongodb.connection.CommandProtocolImpl
 
sessionContext(SessionContext) - Method in class com.mongodb.connection.CommandProtocolImpl
 
sessionContext - Variable in class com.mongodb.operation.BulkWriteBatch
 
sessionContext - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
SessionContext - Interface in com.mongodb.session
The session context.
set(int) - Method in class com.mongodb.Bytes.OptionHolder
 
set(String, TItem) - Static method in class com.mongodb.client.model.Updates
Creates an update that sets the value of the field with the given name to the given value.
set(int, BsonValue) - Method in class com.mongodb.operation.BsonArrayWrapper
 
set(ReflectionDBObject, String, Object) - Method in class com.mongodb.ReflectionDBObject.JavaWrapper
Adds or sets the given field to the given value on the document.
set(OutputBuffer) - Method in class org.bson.BasicBSONEncoder
 
set(int, BsonValue) - Method in class org.bson.BsonArray
 
set(OutputBuffer) - Method in interface org.bson.BSONEncoder
Sets the buffer to wrich the result of encoding will be written.
set(S, T) - Method in class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl.PrivateProperyAccessor
 
set(S, T) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 
set(S, PropertyModel<S>) - Method in interface org.bson.codecs.pojo.InstanceCreator
Sets a value for the given PropertyModel
set(S, PropertyModel<S>) - Method in class org.bson.codecs.pojo.InstanceCreatorImpl
 
set(S, T) - Method in interface org.bson.codecs.pojo.PropertyAccessor
Sets a value on the given PropertyModel
set(S, T) - Method in class org.bson.codecs.pojo.PropertyAccessorImpl
 
set(int, Object) - Method in class org.bson.LazyBSONList
 
set(M) - Method in class org.bson.util.AbstractCopyOnWriteMap
 
set_id(Object) - Method in class com.mongodb.ReflectionDBObject
Sets the _id
SET_PREFIX - Static variable in class org.bson.codecs.pojo.PropertyReflectionUtils
 
SET_PRIVATE_FIELDS_CONVENTION - Static variable in class org.bson.codecs.pojo.Conventions
A convention that enables private fields to be set using reflection.
setAlwaysUseMBeans(boolean) - Method 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.
setBatchSize(int) - Method in interface com.mongodb.async.AsyncBatchCursor
Sets the batch size to use when requesting the next batch.
setBatchSize(int) - Method in class com.mongodb.async.client.MappingAsyncBatchCursor
 
setBatchSize(int) - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
setBatchSize(int) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
setBatchSize(int) - Method in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
setBatchSize(int) - Method in interface com.mongodb.operation.BatchCursor
Sets the batch size to use when requesting the next batch.
setBatchSize(int) - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
setBatchSize(int) - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
setBatchSize(int) - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
setBatchSize(int) - Method in class com.mongodb.operation.QueryBatchCursor
 
setBufferPosition(int) - Method in class org.bson.json.JsonScanner
 
setBypassDocumentValidation(Boolean) - Method in class com.mongodb.BulkWriteOperation
Sets whether to bypass document validation.
setBypassDocumentValidation(Boolean) - Method in class com.mongodb.MapReduceCommand
Sets whether to bypass document validation.
setChunkSize(long) - Method in class com.mongodb.gridfs.GridFSInputFile
Set the chunk size.
setCollation(Collation) - Method in class com.mongodb.DBCursor
Sets the collation options
setCollation(Collation) - Method in class com.mongodb.MapReduceCommand
Sets the collation options
setCommandListener(CommandListener) - Method in class com.mongodb.connection.GetMoreProtocol
 
setCommandListener(CommandListener) - Method in class com.mongodb.connection.KillCursorProtocol
 
setCommandListener(CommandListener) - Method in interface com.mongodb.connection.LegacyProtocol
 
setCommandListener(CommandListener) - Method in class com.mongodb.connection.QueryProtocol
 
setCommandListener(CommandListener) - Method in class com.mongodb.connection.WriteProtocol
 
setConnectionsPerHost(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the maximum number of connections allowed per host for this Mongo instance.
setConnectTimeout(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the connection timeout in milliseconds.
setContentType(String) - Method in class com.mongodb.gridfs.GridFSInputFile
Sets the content type (MIME type) on the GridFS entry.
setContext(AbstractBsonReader.Context) - Method in class org.bson.AbstractBsonReader
Set the context, which will indicate which state the reader is in, for example which part of a document it's currently reading.
setContext(AbstractBsonWriter.Context) - Method in class org.bson.AbstractBsonWriter
Set the context, which will indicate which state the writer is in, for example which part of a document it's currently writing.
setCurrentBsonType(BsonType) - Method in class org.bson.AbstractBsonReader
Sets the type of the current value being read.
setCurrentName(String) - Method in class org.bson.AbstractBsonReader
Sets the field name for the key/value pair being read.
setCursorFinalizerEnabled(boolean) - Method 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.
setDBDecoderFactory(DBDecoderFactory) - Method in class com.mongodb.DBCollection
Set a custom decoder factory for this collection.
setDbDecoderFactory(DBDecoderFactory) - Method in class com.mongodb.MongoOptions
Deprecated.
Override the DBCallback factory.
setDBEncoderFactory(DBEncoderFactory) - Method in class com.mongodb.DBCollection
Set a custom encoder factory for this collection.
setDbEncoderFactory(DBEncoderFactory) - Method in class com.mongodb.MongoOptions
Deprecated.
Override the encoding factory.
setDecoderFactory(DBDecoderFactory) - Method in class com.mongodb.DBCursor
Sets the factory that will be used create a DBDecoder that will be used to decode BSON documents into DBObject instances.
setDescription(String) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the description for Mongo instances created with these options.
setError(Exception) - Method in class org.bson.codecs.pojo.PropertyAccessorImpl
 
setFilename(String) - Method in class com.mongodb.gridfs.GridFSInputFile
Sets the file name on the GridFS entry.
setFinalize(String) - Method in class com.mongodb.MapReduceCommand
Sets the Finalize JS Function
setFsync(boolean) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the "fsync" value of the global WriteConcern.
setGetter(Method) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
setGridFS(GridFS) - Method in class com.mongodb.gridfs.GridFSFile
Sets the GridFS associated with this file.
setHintFields(List<? extends DBObject>) - Method in class com.mongodb.DBCollection
Override MongoDB's default index selection and query optimization process.
setId(Object) - Method in class com.mongodb.gridfs.GridFSInputFile
Sets the ID of this GridFS file.
setInternalClass(String, Class<? extends DBObject>) - Method in class com.mongodb.DBCollection
Sets the internal class for the given path in the document hierarchy
setJ(boolean) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the "j" value of the global WriteConcern.
setJsMode(Boolean) - Method in class com.mongodb.MapReduceCommand
Sets the (optional) JavaScript Mode
setLimit(int) - Method in class com.mongodb.MapReduceCommand
Sets the (optional) limit on input
setMaxTime(long, TimeUnit) - Method in class com.mongodb.MapReduceCommand
Sets the max execution time for this command, in the given time unit.
setMaxWaitTime(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the maximum wait time in milliseconds that a thread may wait for a connection to become available.
setMetaData(DBObject) - Method in class com.mongodb.gridfs.GridFSFile
Gets the file metadata.
setName - Variable in class com.mongodb.connection.ServerDescription.Builder
 
setName(String) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the name of the replica set
setName - Variable in class com.mongodb.connection.ServerDescription
 
setNext(ConcurrentLinkedDeque.Node<E>) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Sets next link.
setNextState() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
setObjectClass(Class<? extends DBObject>) - Method in class com.mongodb.DBCollection
Sets a default class for objects in this collection; null resets the class to nothing.
setObjectFactory(DBCollectionObjectFactory) - Method in class com.mongodb.DBCollection
 
setOnInsert(String, TItem) - Static method in class com.mongodb.client.model.Updates
Creates an update that sets the value of the field with the given name to the given value, but only if the update is an upsert that results in an insert of a document.
setOptions(int) - Method in class com.mongodb.DB
Sets the query options, overwriting previous value.
setOptions(int) - Method in class com.mongodb.DBCollection
Sets the default query options, overwriting previous value.
setOptions(int) - Method in class com.mongodb.DBCursor
Sets the query option - see Bytes.QUERYOPTION_* for list.
setOptions(int) - Method in class com.mongodb.Mongo
Deprecated.
Set options on instances of DBCursor
setOutputDB(String) - Method in class com.mongodb.MapReduceCommand
Sets the (optional) database name where the output collection should reside
setPosition(int) - Method in class com.mongodb.connection.SplittablePayload
Sets the current position in the payload
setPosition(int) - Method in class org.bson.json.JsonBuffer
 
setPrev(ConcurrentLinkedDeque.Node<E>) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Sets prev link.
setPropertyAccessor(PropertyModelBuilder<T>) - Method in class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl
 
setPropertyAccessor(PropertyModelBuilder<T>) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl
 
setPropertyValue(PropertyModel<S>, Object) - Method in class org.bson.codecs.pojo.InstanceCreatorImpl
 
setReadConcern(ReadConcern) - Method in class com.mongodb.DB
Sets the read concern for this database.
setReadConcern(ReadConcern) - Method in class com.mongodb.DBCollection
Sets the read concern for this collection.
setReadConcern(ReadConcern) - Method in class com.mongodb.DBCursor
Sets the read concern for this collection.
setReadPreference(ReadPreference) - Method in class com.mongodb.DB
Sets the read preference for this database.
setReadPreference(ReadPreference) - Method in class com.mongodb.DBCollection
Sets the ReadPreference for this collection.
setReadPreference(ReadPreference) - Method in class com.mongodb.DBCursor
Sets the read preference for this cursor.
setReadPreference(ReadPreference) - Method in class com.mongodb.MapReduceCommand
Sets the read preference for this command.
setReadPreference(ReadPreference) - Method in class com.mongodb.Mongo
Deprecated.
Set the default read preference with either MongoClientURI or MongoClientOptions
setReadPreference(ReadPreference) - Method in class com.mongodb.MongoOptions
Deprecated.
Specifies the read preference.
setRoot(Object) - Method in class org.bson.BasicBSONCallback
Sets the root document for this position
setRoot(Object) - Method in class org.bson.LazyBSONCallback
 
setSafe(boolean) - Method in class com.mongodb.MongoOptions
Deprecated.
If true the driver will use a WriteConcern of WriteConcern.SAFE for all operations.
setScope(Map<String, Object>) - Method in class com.mongodb.MapReduceCommand
Sets the (optional) JavaScript scope
setServerCursor(ServerCursor) - Method in class com.mongodb.DBCursor.OptionalFinalizer
 
setServerCursorOnFinalizer(ServerCursor) - Method in class com.mongodb.DBCursor
 
setSetter(Method) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
setSocketFactory(SocketFactory) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the socket factory for creating sockets to mongod.
setSocketKeepAlive(boolean) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the flag that controls the socket keep alive feature that keeps a connection alive through firewalls Socket.setKeepAlive(boolean) Default is false.
setSocketTimeout(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the socket timeout in milliseconds It is used for I/O socket read and write operations (int) Default is 0 and means no timeout.
setSort(DBObject) - Method in class com.mongodb.MapReduceCommand
Sets the (optional) sort specification object
setState(AbstractBsonReader.State) - Method in class org.bson.AbstractBsonReader
Sets the new current state of this reader.
setState(AbstractBsonWriter.State) - Method in class org.bson.AbstractBsonWriter
Sets the current state of the writer.
setStateOnEnd() - Method in class org.bson.AbstractBsonReader
 
setter - Variable in class com.mongodb.ReflectionDBObject.FieldInfo
 
setter - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
setterMethods - Variable in class org.bson.codecs.pojo.PropertyReflectionUtils.PropertyMethods
 
setThreadsAllowedToBlockForConnectionMultiplier(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the multiplier which, when multiplied with the connectionsPerHost setting, gives the maximum number of threads that may be waiting for a connection to become available from the pool.
settings - Variable in class com.mongodb.async.client.MongoClientImpl
 
settings - Variable in class com.mongodb.connection.AsynchronousSocketChannelStream
 
settings - Variable in class com.mongodb.connection.AsynchronousSocketChannelStreamFactory
 
settings - Variable in class com.mongodb.connection.BaseCluster
 
settings - Variable in class com.mongodb.connection.DefaultConnectionPool
 
settings - Variable in class com.mongodb.connection.DefaultServerMonitorFactory
 
settings - Variable in class com.mongodb.connection.netty.NettyStream
 
settings - Variable in class com.mongodb.connection.netty.NettyStreamFactory
 
settings - Variable in class com.mongodb.connection.RequestMessage
 
settings - Variable in class com.mongodb.connection.SocketChannelStream
 
settings - Variable in class com.mongodb.connection.SocketStream
 
settings - Variable in class com.mongodb.connection.SocketStreamFactory
 
settings - Variable in class com.mongodb.connection.SplittablePayloadBsonWriter
 
settings - Variable in class com.mongodb.event.ConnectionPoolOpenedEvent
 
settings - Variable in class com.mongodb.management.ConnectionPoolStatistics
 
settings - Variable in class org.bson.AbstractBsonWriter
 
settings - Variable in class org.bson.json.JsonWriter
 
settings - Variable in class org.bson.json.StrictCharacterStreamJsonWriter
 
setVerbose(Boolean) - Method in class com.mongodb.MapReduceCommand
Sets the verbosity of the MapReduce job, defaults to 'true'
setVersion - Variable in class com.mongodb.connection.ServerDescription.Builder
 
setVersion(Integer) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the setVersion reported by this server.
setVersion - Variable in class com.mongodb.connection.ServerDescription
 
setW(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the "w" value, (number of writes), of the global WriteConcern.
setWriteConcern(WriteConcern) - Method in class com.mongodb.DB
Sets the write concern for this database.
setWriteConcern(WriteConcern) - Method in class com.mongodb.DBCollection
Set the WriteConcern for this collection.
setWriteConcern(WriteConcern) - Method in class com.mongodb.Mongo
Deprecated.
Set the default write concern with either MongoClientURI or MongoClientOptions
setWriteConcern(WriteConcern) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the write concern.
setWtimeout(int) - Method in class com.mongodb.MongoOptions
Deprecated.
Sets the "wtimeout" value of the global WriteConcern.
sharded(boolean) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets if the output database is sharded
sharded - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
sharded(boolean) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
sharded(boolean) - Method in interface com.mongodb.client.MapReduceIterable
Sets if the output database is sharded
sharded - Variable in class com.mongodb.MapReduceIterableImpl
 
sharded(boolean) - Method in class com.mongodb.MapReduceIterableImpl
 
sharded - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
sharded(boolean) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets if the output database is sharded
SHELL_BINARY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_DATE_TIME_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_DECIMAL_128_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_INT_64_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_MAX_KEY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_MIN_KEY_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_OBJECT_ID_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_REGULAR_EXPRESSION_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_TIMESTAMP_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
SHELL_UNDEFINED_CONVERTER - Static variable in class org.bson.json.JsonWriterSettings
 
ShellBinaryConverter - Class in org.bson.json
 
ShellBinaryConverter() - Constructor for class org.bson.json.ShellBinaryConverter
 
ShellDateTimeConverter - Class in org.bson.json
 
ShellDateTimeConverter() - Constructor for class org.bson.json.ShellDateTimeConverter
 
ShellDecimal128Converter - Class in org.bson.json
 
ShellDecimal128Converter() - Constructor for class org.bson.json.ShellDecimal128Converter
 
ShellInt64Converter - Class in org.bson.json
 
ShellInt64Converter() - Constructor for class org.bson.json.ShellInt64Converter
 
ShellMaxKeyConverter - Class in org.bson.json
 
ShellMaxKeyConverter() - Constructor for class org.bson.json.ShellMaxKeyConverter
 
ShellMinKeyConverter - Class in org.bson.json
 
ShellMinKeyConverter() - Constructor for class org.bson.json.ShellMinKeyConverter
 
ShellObjectIdConverter - Class in org.bson.json
 
ShellObjectIdConverter() - Constructor for class org.bson.json.ShellObjectIdConverter
 
ShellRegularExpressionConverter - Class in org.bson.json
 
ShellRegularExpressionConverter() - Constructor for class org.bson.json.ShellRegularExpressionConverter
 
ShellTimestampConverter - Class in org.bson.json
 
ShellTimestampConverter() - Constructor for class org.bson.json.ShellTimestampConverter
 
ShellUndefinedConverter - Class in org.bson.json
 
ShellUndefinedConverter() - Constructor for class org.bson.json.ShellUndefinedConverter
 
short0(short) - Static method in class org.bson.types.ObjectId
 
short1(short) - Static method in class org.bson.types.ObjectId
 
ShortCodec - Class in org.bson.codecs
Encodes and decodes Short objects.
ShortCodec() - Constructor for class org.bson.codecs.ShortCodec
 
shouldAcknowledge(BulkWriteBatch, WriteConcern) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
shouldAddAfterClusterTime(SessionContext) - Static method in class com.mongodb.operation.ReadConcernHelper
 
shouldEnsureMinSize() - Method in class com.mongodb.connection.DefaultConnectionPool
 
shouldLogStageChange(ServerDescription, ServerDescription) - Static method in class com.mongodb.connection.DefaultServerMonitor
 
shouldProcessBatch() - Method in class com.mongodb.operation.BulkWriteBatch
 
shouldPrune() - Method in class com.mongodb.connection.DefaultConnectionPool
 
shouldPrune(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool
 
shouldPrune(UsageTrackingInternalConnection) - Method in class com.mongodb.connection.DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory
 
shouldPrune(T) - Method in interface com.mongodb.internal.connection.ConcurrentPool.ItemFactory
 
shouldPrune(ServerSessionPool.ServerSessionImpl) - Method in class com.mongodb.internal.session.ServerSessionPool.ServerSessionItemFactory
 
shouldPrune(ServerSessionPool.ServerSessionImpl) - Method in class com.mongodb.internal.session.ServerSessionPool
 
shouldSerialize(T) - Method in class org.bson.codecs.pojo.PropertyModel
Returns true if the value should be serialized.
shouldSerialize(T) - Method in class org.bson.codecs.pojo.PropertyModelSerializationImpl
 
shouldSerialize(T) - Method in interface org.bson.codecs.pojo.PropertySerialization
Determines if a value should be serialized
shouldSpecialize(ClassModel<T>) - Static method in class org.bson.codecs.pojo.PojoCodecImpl
 
shouldStopSendingMoreBatches() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
True if ordered and has write errors.
shouldUseSLF4J() - Static method in class com.mongodb.diagnostics.logging.Loggers
 
shouldUseSLF4J() - Static method in class org.bson.diagnostics.Loggers
 
SHOW_DISK_LOC - Static variable in class com.mongodb.QueryOperators
 
showDiskLoc() - Method in class com.mongodb.DBCursor
Modifies the documents returned to include references to the on-disk location of each document.
showRecordId(boolean) - Method in interface com.mongodb.async.client.FindIterable
Sets the showRecordId.
showRecordId(boolean) - Method in class com.mongodb.async.client.FindIterableImpl
 
showRecordId(boolean) - Method in interface com.mongodb.client.FindIterable
Sets the showRecordId.
showRecordId - Variable in class com.mongodb.client.model.FindOptions
 
showRecordId(boolean) - Method in class com.mongodb.client.model.FindOptions
Sets the showRecordId.
showRecordId(boolean) - Method in class com.mongodb.FindIterableImpl
 
showRecordId - Variable in class com.mongodb.operation.FindOperation
 
showRecordId(boolean) - Method in class com.mongodb.operation.FindOperation
Sets the showRecordId.
shutdownAsyncGetter() - Method in class com.mongodb.connection.DefaultConnectionPool
 
SIGN_BIT_MASK - Static variable in class org.bson.types.Decimal128
 
SimpleEncodingFilter(String, TItem) - Constructor for class com.mongodb.client.model.Filters.SimpleEncodingFilter
 
SimpleExpression<TExpression> - Class in com.mongodb.client.model
 
SimpleExpression(String, TExpression) - Constructor for class com.mongodb.client.model.SimpleExpression
 
SimpleFilter(String, BsonValue) - Constructor for class com.mongodb.client.model.Filters.SimpleFilter
 
SimplePipelineStage(String, Bson) - Constructor for class com.mongodb.client.model.Aggregates.SimplePipelineStage
 
SimpleUpdate(String, TItem, String) - Constructor for class com.mongodb.client.model.Updates.SimpleUpdate
 
SingleConnectionReadBinding - Class in com.mongodb.binding
A read binding that is bound to a single connection.
SingleConnectionReadBinding(ReadPreference, ServerDescription, Connection) - Constructor for class com.mongodb.binding.SingleConnectionReadBinding
Construct an instance.
SingleConnectionReadBinding.SingleConnectionSource - Class in com.mongodb.binding
 
SingleConnectionSource() - Constructor for class com.mongodb.binding.SingleConnectionReadBinding.SingleConnectionSource
 
SingleResultCallback<T> - Interface in com.mongodb.async
An interface to describe the completion of an asynchronous operation.
SingleResultCallbackSubscription<TResult> - Class in com.mongodb.async.client
 
SingleResultCallbackSubscription(Block<SingleResultCallback<TResult>>, Observer<? super TResult>) - Constructor for class com.mongodb.async.client.SingleResultCallbackSubscription
 
SingleServerBinding - Class in com.mongodb.binding
A simple binding where all connection sources are bound to the server specified in the constructor.
SingleServerBinding(Cluster, ServerAddress) - Constructor for class com.mongodb.binding.SingleServerBinding
Creates an instance, defaulting to ReadPreference.primary() for reads.
SingleServerBinding(Cluster, ServerAddress, ReadPreference) - Constructor for class com.mongodb.binding.SingleServerBinding
Creates an instance.
SingleServerBinding.SingleServerBindingConnectionSource - Class in com.mongodb.binding
 
SingleServerBindingConnectionSource() - Constructor for class com.mongodb.binding.SingleServerBinding.SingleServerBindingConnectionSource
 
SingleServerCluster - Class in com.mongodb.connection
This class needs to be final because we are leaking a reference to "this" from the constructor
SingleServerCluster(ClusterId, ClusterSettings, ClusterableServerFactory) - Constructor for class com.mongodb.connection.SingleServerCluster
 
SingleServerCluster.DefaultServerStateListener - Class in com.mongodb.connection
 
singleton() - Static method in class com.mongodb.Mongo.Holder
Get the only instance of Holder.
SIX_BIT_MASK - Static variable in class org.bson.internal.Base64
Mask used to extract 6 bits, used when encoding
size(String, int) - 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 of the specified size.
size() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
size() - Method in class com.mongodb.DBCursor
Counts the number of objects matching the query this does take limit/skip into consideration
size - Variable in class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
 
size - Variable in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
 
size() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns the number of elements in this deque.
size - Variable in class com.mongodb.management.ConnectionPoolStatistics
 
size() - Method in class com.mongodb.operation.BsonArrayWrapper
 
size(Object) - Method in class com.mongodb.QueryBuilder
Equivalent of the $size operand
SIZE - Static variable in class com.mongodb.QueryOperators
 
size() - Method in class org.bson.BsonArray
 
size - Variable in class org.bson.BsonBinaryReader.Context
 
size - Variable in class org.bson.BsonBinaryReader.Mark
 
size() - Method in class org.bson.BsonDocument
 
size() - Method in class org.bson.BsonDocumentWrapper
 
size() - Method in class org.bson.Document
 
size() - Method in class org.bson.io.OutputBuffer
Gets the output size in bytes.
size() - Method in class org.bson.LazyBSONList
 
size() - Method in class org.bson.RawBsonDocument
 
size - Variable in class org.bson.types.StringRangeSet
 
size() - Method in class org.bson.types.StringRangeSet
 
size() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
size() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
size() - Method in class org.bson.util.ClassMap
As per java.util.Map, returns the number of key-value mappings in this map.
size() - Method in class org.bson.util.ComputingMap
 
sizeInBytes - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
sizeInBytes(long) - Method in class com.mongodb.client.model.CreateCollectionOptions
Gets the maximum size of in bytes of a capped collection.
sizeInBytes - Variable in class com.mongodb.operation.CreateCollectionOperation
 
sizeInBytes(long) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the maximum size of the collection in bytes.
sizeMaintenanceTimer - Variable in class com.mongodb.connection.DefaultConnectionPool
 
skip(int) - Method in interface com.mongodb.async.client.FindIterable
Sets the number of documents to skip.
skip(int) - Method in class com.mongodb.async.client.FindIterableImpl
 
skip(int) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the number of documents to skip.
skip(int) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
skip(int) - Method in interface com.mongodb.client.FindIterable
Sets the number of documents to skip.
skip(long) - Method in class com.mongodb.client.gridfs.GridFSDownloadStream
 
skip(long) - Method in class com.mongodb.client.gridfs.GridFSDownloadStreamImpl
 
skip(int) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the number of documents to skip.
skip(int) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
skip(int) - Static method in class com.mongodb.client.model.Aggregates
Creates a $skip pipeline stage
skip - Variable in class com.mongodb.client.model.CountOptions
 
skip(int) - Method in class com.mongodb.client.model.CountOptions
Sets the number of documents to skip.
skip - Variable in class com.mongodb.client.model.DBCollectionCountOptions
 
skip(int) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the number of documents to skip.
skip(long) - Method in class com.mongodb.client.model.DBCollectionCountOptions
Sets the number of documents to skip.
skip - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
skip(int) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the number of documents to skip.
skip - Variable in class com.mongodb.client.model.FindOptions
 
skip(int) - Method in class com.mongodb.client.model.FindOptions
Sets the number of documents to skip.
skip - Variable in class com.mongodb.connection.BaseQueryMessage
 
skip - Variable in class com.mongodb.connection.QueryProtocol
 
skip(int) - Method in class com.mongodb.DBCursor
Discards a given number of elements at the beginning of the cursor.
skip(int) - Method in class com.mongodb.FindIterableImpl
 
skip(long) - Method in class com.mongodb.gridfs.GridFSDBFile.GridFSInputStream
Will smartly skip over chunks without fetching them if possible.
skip - Variable in class com.mongodb.operation.CountOperation
 
skip(long) - Method in class com.mongodb.operation.CountOperation
Sets the number of documents to skip.
skip - Variable in class com.mongodb.operation.FindOperation
 
skip(int) - Method in class com.mongodb.operation.FindOperation
Sets the number of documents to skip.
skip(int) - Method in interface org.bson.io.BsonInput
Skips the specified number of bytes in the stream.
skip(int) - Method in class org.bson.io.ByteBufferBsonInput
 
skipCString() - Method in interface org.bson.io.BsonInput
Skips a BSON CString value from the stream.
skipCString() - Method in class org.bson.io.ByteBufferBsonInput
 
skipField(EncoderContext, String) - Method in class com.mongodb.DBObjectCodec
 
skipField(EncoderContext, String) - Method in class org.bson.codecs.BsonDocumentCodec
 
skipField(EncoderContext, String) - Method in class org.bson.codecs.DocumentCodec
 
skipName() - Method in class org.bson.AbstractBsonReader
 
skipName() - Method in interface org.bson.BsonReader
Skips the name (reader must be positioned on a name).
skipValue() - Method in class org.bson.AbstractBsonReader
 
skipValue() - Method in interface org.bson.BsonReader
Skips the value (reader must be positioned on a value).
skipWS() - Method in class com.mongodb.util.JSONParser
Advances the position in the string past any whitespace.
slaveOk - Variable in class com.mongodb.connection.BaseQueryMessage
 
slaveOk(boolean) - Method in class com.mongodb.connection.BaseQueryMessage
Sets if allowed to query non-primary replica set members.
slaveOk - Variable in class com.mongodb.connection.QueryProtocol
 
slaveOk(boolean) - Method in class com.mongodb.connection.QueryProtocol
Sets if allowed to query non-primary replica set members.
slaveOk() - Method in class com.mongodb.DB
Deprecated.
Replaced with ReadPreference.secondaryPreferred()
slaveOk() - Method in class com.mongodb.DBCollection
Deprecated.
slaveOk() - Method in class com.mongodb.DBCursor
Deprecated.
slaveOk() - Method in class com.mongodb.Mongo
Deprecated.
Replaced with ReadPreference.secondaryPreferred()
slaveOk - Variable in class com.mongodb.operation.FindOperation
 
slaveOk(boolean) - Method in class com.mongodb.operation.FindOperation
Sets if allowed to query non-primary replica set members.
SLF4JLogger - Class in com.mongodb.diagnostics.logging
 
SLF4JLogger(String) - Constructor for class com.mongodb.diagnostics.logging.SLF4JLogger
 
SLF4JLogger - Class in org.bson.diagnostics
 
SLF4JLogger(String) - Constructor for class org.bson.diagnostics.SLF4JLogger
 
slice(String, int) - Static method in class com.mongodb.client.model.Projections
Creates a projection to the given field name of a slice of the array value of that field.
slice(String, int, int) - Static method in class com.mongodb.client.model.Projections
Creates a projection to the given field name of a slice of the array value of that field.
slice - Variable in class com.mongodb.client.model.PushOptions
 
slice(Integer) - Method in class com.mongodb.client.model.PushOptions
Sets the limit on the number of array elements allowed.
SMALLEST_MAX_STALENESS_MS - Static variable in class com.mongodb.TaggableReadPreference
 
SnappyCompressor - Class in com.mongodb.connection
 
SnappyCompressor() - Constructor for class com.mongodb.connection.SnappyCompressor
 
snapshot(boolean) - Method in interface com.mongodb.async.client.FindIterable
Sets the snapshot.
snapshot(boolean) - Method in class com.mongodb.async.client.FindIterableImpl
 
snapshot(boolean) - Method in interface com.mongodb.client.FindIterable
Sets the snapshot.
snapshot - Variable in class com.mongodb.client.model.FindOptions
 
snapshot(boolean) - Method in class com.mongodb.client.model.FindOptions
Sets the snapshot.
snapshot() - Method in class com.mongodb.DBCursor
Use snapshot mode for the query.
snapshot(boolean) - Method in class com.mongodb.FindIterableImpl
 
snapshot - Variable in class com.mongodb.operation.FindOperation
 
snapshot(boolean) - Method in class com.mongodb.operation.FindOperation
Sets the snapshot.
SNAPSHOT - Static variable in class com.mongodb.QueryOperators
 
SNI_SSL_HELPER - Static variable in class com.mongodb.internal.connection.SslHelper
 
SniSslHelper - Interface in com.mongodb.internal.connection
 
socket - Variable in class com.mongodb.connection.SocketStream
 
socketChannel - Variable in class com.mongodb.connection.SocketChannelStream
 
socketChannelClass - Variable in class com.mongodb.connection.netty.NettyStream
 
socketChannelClass - Variable in class com.mongodb.connection.netty.NettyStreamFactory
 
socketChannelClass - Variable in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
 
socketChannelClass(Class<? extends SocketChannel>) - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory.Builder
Sets the socket channel class
socketChannelClass - Variable in class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
SocketChannelStream - Class in com.mongodb.connection
 
SocketChannelStream(ServerAddress, SocketSettings, SslSettings, BufferProvider) - Constructor for class com.mongodb.connection.SocketChannelStream
 
socketFactory - Variable in class com.mongodb.connection.SocketStream
 
socketFactory - Variable in class com.mongodb.connection.SocketStreamFactory
 
socketFactory - Variable in class com.mongodb.MongoClientOptions.Builder
 
socketFactory(SocketFactory) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the socket factory.
socketFactory - Variable in class com.mongodb.MongoClientOptions
 
socketFactory - Variable in class com.mongodb.MongoOptions
Deprecated.
Sets the socket factory for creating sockets to mongod Default is SocketFactory.getDefault()
socketKeepAlive - Variable in class com.mongodb.MongoClientOptions.Builder
 
socketKeepAlive(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Deprecated.
configuring keep-alive has been deprecated. It now defaults to true and disabling it is not recommended.
socketKeepAlive - Variable in class com.mongodb.MongoClientOptions
 
socketKeepAlive - Variable in class com.mongodb.MongoOptions
Deprecated.
This flag controls the socket keep alive feature that keeps a connection alive through firewalls Socket.setKeepAlive(boolean) Default is false.
socketSettings - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
socketSettings(SocketSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the socket settings.
socketSettings - Variable in class com.mongodb.async.client.MongoClientSettings
 
SocketSettings - Class in com.mongodb.connection
An immutable class representing socket settings used for connections to a MongoDB server.
SocketSettings(SocketSettings.Builder) - Constructor for class com.mongodb.connection.SocketSettings
 
socketSettings - Variable in class com.mongodb.MongoClientOptions
 
SocketSettings.Builder - Class in com.mongodb.connection
A builder for an instance of SocketSettings.
SocketStream - Class in com.mongodb.connection
 
SocketStream(ServerAddress, SocketSettings, SslSettings, SocketFactory, BufferProvider) - Constructor for class com.mongodb.connection.SocketStream
 
SocketStreamFactory - Class in com.mongodb.connection
Factory for creating instances of SocketStream.
SocketStreamFactory(SocketSettings, SslSettings) - Constructor for class com.mongodb.connection.SocketStreamFactory
Creates a new factory with the given settings for connecting to servers and the given SSL settings
SocketStreamFactory(SocketSettings, SslSettings, SocketFactory) - Constructor for class com.mongodb.connection.SocketStreamFactory
Creates a new factory with the given settings for connecting to servers and a factory for creating connections.
SocketStreamHelper - Class in com.mongodb.connection
 
SocketStreamHelper() - Constructor for class com.mongodb.connection.SocketStreamHelper
 
socketTimeout - Variable in class com.mongodb.ConnectionString
 
socketTimeout - Variable in class com.mongodb.MongoClientOptions.Builder
 
socketTimeout(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the socket timeout.
socketTimeout - Variable in class com.mongodb.MongoClientOptions
 
socketTimeout - Variable in class com.mongodb.MongoOptions
Deprecated.
The socket timeout in milliseconds It is used for I/O socket read and write operations Socket.setSoTimeout(int) Default is 0 and means no timeout.
Some(T) - Constructor for class org.bson.codecs.configuration.Optional.Some
 
sort(Bson) - Method in interface com.mongodb.async.client.FindIterable
Sets the sort criteria to apply to the query.
sort(Bson) - Method in class com.mongodb.async.client.FindIterableImpl
 
sort(Bson) - Method in interface com.mongodb.async.client.gridfs.GridFSFindIterable
Sets the sort criteria to apply to the query.
sort(Bson) - Method in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
sort(Bson) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
sort(Bson) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
sort(Bson) - Method in interface com.mongodb.client.FindIterable
Sets the sort criteria to apply to the query.
sort(Bson) - Method in interface com.mongodb.client.gridfs.GridFSFindIterable
Sets the sort criteria to apply to the query.
sort(Bson) - Method in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
sort(Bson) - Method in interface com.mongodb.client.MapReduceIterable
Sets the sort criteria to apply to the query.
sort(Bson) - Static method in class com.mongodb.client.model.Aggregates
Creates a $sort pipeline stage for the specified sort specification
sort - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
sort(DBObject) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the sort
sort - Variable in class com.mongodb.client.model.DBCollectionFindOptions
 
sort(DBObject) - Method in class com.mongodb.client.model.DBCollectionFindOptions
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.client.model.FindOneAndDeleteOptions
 
sort(Bson) - Method in class com.mongodb.client.model.FindOneAndDeleteOptions
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
sort(Bson) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
sort(Bson) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.client.model.FindOptions
 
sort(Bson) - Method in class com.mongodb.client.model.FindOptions
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.client.model.PushOptions
 
sort(Integer) - Method in class com.mongodb.client.model.PushOptions
Sets the sort direction for sorting array elements that are not documents.
sort(DBObject) - Method in class com.mongodb.DBCursor
Sorts this cursor's elements.
sort(Bson) - Method in class com.mongodb.FindIterableImpl
 
sort - Variable in class com.mongodb.MapReduceCommand
 
sort - Variable in class com.mongodb.MapReduceIterableImpl
 
sort(Bson) - Method in class com.mongodb.MapReduceIterableImpl
 
sort - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
sort(BsonDocument) - Method in class com.mongodb.operation.FindAndDeleteOperation
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
sort(BsonDocument) - Method in class com.mongodb.operation.FindAndReplaceOperation
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
sort(BsonDocument) - Method in class com.mongodb.operation.FindAndUpdateOperation
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.operation.FindOperation
 
sort(BsonDocument) - Method in class com.mongodb.operation.FindOperation
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
sort(BsonDocument) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets the sort criteria to apply to the query.
sort - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
sort(BsonDocument) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets the sort criteria to apply to the query.
sortByCount(TExpression) - Static method in class com.mongodb.client.model.Aggregates
Creates a $sortByCount pipeline stage for the specified filter
SortByCountStage(TExpression) - Constructor for class com.mongodb.client.model.Aggregates.SortByCountStage
 
sortDocument - Variable in class com.mongodb.client.model.PushOptions
 
sortDocument(Bson) - Method in class com.mongodb.client.model.PushOptions
Sets the sort direction for sorting array elements that are documents.
sortOptionCharacters(String) - Method in class org.bson.BsonRegularExpression
 
Sorts - Class in com.mongodb.client.model
A factory for sort specifications.
Sorts() - Constructor for class com.mongodb.client.model.Sorts
 
sorts - Variable in class com.mongodb.client.model.Sorts.CompoundSort
 
Sorts.CompoundSort - Class in com.mongodb.client.model
 
source - Variable in class com.mongodb.connection.Compressor.ByteBufInputStream
 
source - Variable in class com.mongodb.MongoCredential
 
source - Variable in class com.mongodb.operation.OperationHelper.ConnectionReleasingWrappedCallback
 
sparse - Variable in class com.mongodb.bulk.IndexRequest
 
sparse(boolean) - Method in class com.mongodb.bulk.IndexRequest
Should the index only references documents with the specified field
sparse - Variable in class com.mongodb.client.model.IndexOptions
 
sparse(boolean) - Method in class com.mongodb.client.model.IndexOptions
Should the index only references documents with the specified field
specialize() - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
specialized - Variable in class org.bson.codecs.pojo.PojoCodecImpl
 
specializePojoCodec(PropertyModel<S>, Codec<S>) - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
specializePropertyModelBuilder(PropertyModelBuilder<V>, PropertyMetadata<V>) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
sphereVersion - Variable in class com.mongodb.bulk.IndexRequest
 
sphereVersion(Integer) - Method in class com.mongodb.bulk.IndexRequest
Sets the 2dsphere index version number.
sphereVersion - Variable in class com.mongodb.client.model.IndexOptions
 
sphereVersion(Integer) - Method in class com.mongodb.client.model.IndexOptions
Sets the 2dsphere index version number.
SplittablePayload - Class in com.mongodb.connection
A Splittable payload for write commands.
SplittablePayload(SplittablePayload.Type, List<BsonDocument>) - Constructor for class com.mongodb.connection.SplittablePayload
Create a new instance
SplittablePayload.Type - Enum in com.mongodb.connection
The type of the payload.
SplittablePayloadBsonWriter - Class in com.mongodb.connection
 
SplittablePayloadBsonWriter(BsonBinaryWriter, BsonOutput, int, MessageSettings, SplittablePayload) - Constructor for class com.mongodb.connection.SplittablePayloadBsonWriter
 
sslContext - Variable in class com.mongodb.MongoClientOptions.Builder
 
sslContext(SSLContext) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the SSLContext to be used with SSL is enabled.
sslContext - Variable in class com.mongodb.MongoClientOptions
 
sslEnabled - Variable in class com.mongodb.ConnectionString
 
sslEnabled - Variable in class com.mongodb.MongoClientOptions.Builder
 
sslEnabled(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Sets whether to use SSL.
sslEnabled - Variable in class com.mongodb.MongoClientOptions
 
SslHelper - Class in com.mongodb.internal.connection
This class should not be considered a part of the public API.
SslHelper() - Constructor for class com.mongodb.internal.connection.SslHelper
 
sslInvalidHostnameAllowed - Variable in class com.mongodb.ConnectionString
 
sslInvalidHostNameAllowed - Variable in class com.mongodb.MongoClientOptions.Builder
 
sslInvalidHostNameAllowed(boolean) - Method in class com.mongodb.MongoClientOptions.Builder
Define whether invalid host names should be allowed.
sslInvalidHostNameAllowed - Variable in class com.mongodb.MongoClientOptions
 
sslSettings - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
sslSettings(SslSettings) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the socket settings.
sslSettings - Variable in class com.mongodb.async.client.MongoClientSettings
 
sslSettings - Variable in class com.mongodb.connection.netty.NettyStream
 
sslSettings - Variable in class com.mongodb.connection.netty.NettyStreamFactory
 
sslSettings - Variable in class com.mongodb.connection.SocketChannelStream
 
sslSettings - Variable in class com.mongodb.connection.SocketStream
 
sslSettings - Variable in class com.mongodb.connection.SocketStreamFactory
 
SslSettings - Class in com.mongodb.connection
Settings for connecting to MongoDB via SSL.
SslSettings(SslSettings.Builder) - Constructor for class com.mongodb.connection.SslSettings
 
sslSettings - Variable in class com.mongodb.MongoClientOptions
 
SslSettings.Builder - Class in com.mongodb.connection
A builder for creating SSLSettings.
stableViews() - Method in class org.bson.util.CopyOnWriteMap.Builder
Views are stable (fixed in time) and unmodifiable.
stack - Variable in class org.bson.BasicBSONCallback
 
start() - Static method in class com.mongodb.BasicDBObjectBuilder
Creates a builder intialized with an empty document.
start(String, Object) - Static method in class com.mongodb.BasicDBObjectBuilder
Creates a builder initialized with the given key/value.
start(Map) - Static method in class com.mongodb.BasicDBObjectBuilder
Creates an object builder from an existing map of key value pairs.
start() - Method in class com.mongodb.connection.DefaultServerMonitor
 
start() - Method in class com.mongodb.connection.InternalStreamConnectionInitializer.CompoundAuthenticator
 
start() - Method in class com.mongodb.connection.SaslAuthenticator.Continuator
 
start() - Method in interface com.mongodb.connection.ServerMonitor
 
start() - Static method in class com.mongodb.QueryBuilder
Returns a new QueryBuilder.
start(String) - Static method in class com.mongodb.QueryBuilder
Creates a new query with a document key
startIndex - Variable in class com.mongodb.internal.connection.IndexMap.RangeBased
 
startingFrom - Variable in class com.mongodb.connection.ReplyHeader
 
startPosition - Variable in class org.bson.BsonBinaryReader.Context
 
startPosition - Variable in class org.bson.BsonBinaryReader.Mark
 
startPosition - Variable in class org.bson.BsonBinaryWriter.Context
 
startSession(ClientSessionOptions, SingleResultCallback<ClientSession>) - Method in interface com.mongodb.async.client.MongoClient
Creates a client session.
startSession(ClientSessionOptions, SingleResultCallback<ClientSession>) - Method in class com.mongodb.async.client.MongoClientImpl
 
startSession(ClientSessionOptions) - Method in class com.mongodb.MongoClient
Creates a client session.
startTimeNanos - Variable in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
startTimeNanos - Variable in class com.mongodb.connection.GetMoreProtocol.GetMoreResultCallback
 
startTimeNanos - Variable in class com.mongodb.connection.InternalStreamConnection.CommandEventSender
 
startTimeNanos - Variable in class com.mongodb.connection.QueryProtocol.QueryResultCallback
 
startTimeNanos - Variable in class com.mongodb.connection.SendMessageCallback
 
startTimeNanos - Variable in class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
startWith - Variable in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
state - Variable in class com.mongodb.connection.ServerDescription.Builder
 
state(ServerConnectionState) - Method in class com.mongodb.connection.ServerDescription.Builder
The current state of the connection to the server.
state - Variable in class com.mongodb.connection.ServerDescription
 
state - Variable in class org.bson.AbstractBsonReader.Mark
 
state - Variable in class org.bson.AbstractBsonReader
 
State() - Constructor for enum org.bson.AbstractBsonReader.State
 
state - Variable in class org.bson.AbstractBsonWriter
 
State() - Constructor for enum org.bson.AbstractBsonWriter.State
 
state - Variable in class org.bson.json.StrictCharacterStreamJsonWriter
 
State() - Constructor for enum org.bson.json.StrictCharacterStreamJsonWriter.State
 
stateChanged(ChangeEvent<T>) - Method in interface com.mongodb.connection.ChangeListener
A ChangeEvent has been fired to notify listeners that T has changed.
stateChanged(ChangeEvent<ServerDescription>) - Method in class com.mongodb.connection.DefaultServer.DefaultServerStateListener
 
stateNotNull(String, V) - Static method in class org.bson.codecs.pojo.PojoBuilderHelper
 
statistics - Variable in class com.mongodb.operation.MapReduceInlineResultsAsyncCursor
 
statistics - Variable in class com.mongodb.operation.MapReduceInlineResultsCursor
 
stdDevPop(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the sample standard deviation of the values of the given expression when applied to all members of the group.
stdDevSamp(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the sample standard deviation of the values of the given expression when applied to all members of the group.
step - Variable in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
stopWaitQueueHandler() - Method in class com.mongodb.connection.BaseCluster
 
storageEngine - Variable in class com.mongodb.bulk.IndexRequest
 
storageEngine(BsonDocument) - Method in class com.mongodb.bulk.IndexRequest
Sets the storage engine options document for this index.
storageEngine - Variable in class com.mongodb.client.model.IndexOptionDefaults
 
storageEngine(Bson) - Method in class com.mongodb.client.model.IndexOptionDefaults
Sets the default storage engine options document for indexes.
storageEngine - Variable in class com.mongodb.client.model.IndexOptions
 
storageEngine(Bson) - Method in class com.mongodb.client.model.IndexOptions
Sets the storage engine options document for this index.
storageEngineOptions - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
storageEngineOptions(Bson) - Method in class com.mongodb.client.model.CreateCollectionOptions
Sets the storage engine options document defaults for the collection
storageEngineOptions - Variable in class com.mongodb.operation.CreateCollectionOperation
 
storageEngineOptions(BsonDocument) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the storage engine options document for this collection.
stream - Variable in class com.mongodb.connection.InternalStreamConnection
 
Stream - Interface in com.mongodb.connection
A full duplex stream of bytes.
streamFactory - Variable in class com.mongodb.connection.DefaultClusterableServerFactory
 
streamFactory - Variable in class com.mongodb.connection.InternalStreamConnection
 
streamFactory - Variable in class com.mongodb.connection.InternalStreamConnectionFactory
 
StreamFactory - Interface in com.mongodb.connection
A factory for streams.
streamFactoryFactory - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
streamFactoryFactory(StreamFactoryFactory) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the factory to use to create a StreamFactory.
streamFactoryFactory - Variable in class com.mongodb.async.client.MongoClientSettings
 
StreamFactoryFactory - Interface in com.mongodb.connection
A factory of StreamFactory instances.
streamType - Variable in class com.mongodb.ConnectionString
 
strength - Variable in class com.mongodb.client.model.Collation.Builder
 
strength - Variable in class com.mongodb.client.model.Collation
 
StrictCharacterStreamJsonWriter - Class in org.bson.json
A class that writes JSON texts as a character stream via a provided Writer.
StrictCharacterStreamJsonWriter(Writer, StrictCharacterStreamJsonWriterSettings) - Constructor for class org.bson.json.StrictCharacterStreamJsonWriter
Construct an instance.
StrictCharacterStreamJsonWriter.JsonContextType - Enum in org.bson.json
 
StrictCharacterStreamJsonWriter.State - Enum in org.bson.json
 
StrictCharacterStreamJsonWriter.StrictJsonContext - Class in org.bson.json
 
StrictCharacterStreamJsonWriterSettings - Class in org.bson.json
Settings to control the behavior of a JSONWriter instance.
StrictCharacterStreamJsonWriterSettings(StrictCharacterStreamJsonWriterSettings.Builder) - Constructor for class org.bson.json.StrictCharacterStreamJsonWriterSettings
 
StrictCharacterStreamJsonWriterSettings.Builder - Class in org.bson.json
A builder for StrictCharacterStreamJsonWriterSettings
StrictJsonContext(StrictCharacterStreamJsonWriter.StrictJsonContext, StrictCharacterStreamJsonWriter.JsonContextType, String) - Constructor for class org.bson.json.StrictCharacterStreamJsonWriter.StrictJsonContext
 
strictJsonWriter - Variable in class org.bson.json.JsonWriter
 
StrictJsonWriter - Interface in org.bson.json
An interface for creating JSON texts that largely conform to RFC 7159.
string(StringBuilder, String) - Static method in class com.mongodb.util.JSON
Deprecated.
 
STRING - Static variable in class org.bson.BSON
 
StringCodec - Class in org.bson.codecs
Encodes and decodes String objects.
StringCodec() - Constructor for class org.bson.codecs.StringCodec
 
stringConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
stringConverter(Converter<String>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON String values to JSON.
stringConverter - Variable in class org.bson.json.JsonWriterSettings
 
StringRangeSet - Class in org.bson.types
 
StringRangeSet(int) - Constructor for class org.bson.types.StringRangeSet
 
STRINGS - Static variable in class org.bson.types.StringRangeSet
 
StringSerializer() - Constructor for class com.mongodb.util.JSONSerializers.StringSerializer
Deprecated.
 
StringUtils - Class in org.bson
 
StringUtils() - Constructor for class org.bson.StringUtils
 
stringValue - Variable in class com.mongodb.connection.ConnectionId
 
subList(int, int) - Method in class com.mongodb.operation.BsonArrayWrapper
 
subList(int, int) - Method in class org.bson.BsonArray
 
subList(int, int) - Method in class org.bson.LazyBSONList
 
subscribe(Observer<? super TResult>) - Method in interface com.mongodb.async.client.Observable
Request Observable to start streaming data.
Subscription - Interface in com.mongodb.async.client
A Subscription represents a one-to-one lifecycle of a Observer subscribing to an Observable.
substring(int) - Method in class org.bson.json.JsonBuffer
 
substring(int, int) - Method in class org.bson.json.JsonBuffer
 
successor() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque.Node
Returns the next non-deleted node, swinging next pointer around any encountered deleted nodes, and also patching up successor's prev link to point back to this.
sum(String, TExpression) - Static method in class com.mongodb.client.model.Accumulators
Gets a field name for a $group operation representing the sum of the values of the given expression when applied to all members of the group.
SYMBOL - Static variable in class org.bson.BSON
 
symbol - Variable in class org.bson.BsonSymbol
 
Symbol - Class in org.bson.types
Class to hold an instance of the BSON symbol type.
Symbol(String) - Constructor for class org.bson.types.Symbol
Construct a new instance with the given symbol.
symbol - Variable in class org.bson.types.Symbol
 
SymbolCodec - Class in org.bson.codecs
A codec for BSON symbol type.
SymbolCodec() - Constructor for class org.bson.codecs.SymbolCodec
 
symbolConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
symbolConverter(Converter<String>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Symbol values to JSON.
symbolConverter - Variable in class org.bson.json.JsonWriterSettings
 
SymbolSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.SymbolSerializer
Deprecated.
 

T

t - Variable in class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 
Tag - Class in com.mongodb
A replica set tag.
Tag(String, String) - Constructor for class com.mongodb.Tag
Construct a new instance.
TaggableReadPreference - Class in com.mongodb
Abstract class for all preference which can be combined with tags
TaggableReadPreference() - Constructor for class com.mongodb.TaggableReadPreference
 
TaggableReadPreference(List<TagSet>, Long, TimeUnit) - Constructor for class com.mongodb.TaggableReadPreference
 
TaggableReadPreference.NearestReadPreference - Class in com.mongodb
Read from nearest node respective of tags.
TaggableReadPreference.PrimaryPreferredReadPreference - Class in com.mongodb
Read from primary if available, otherwise a secondary.
TaggableReadPreference.SecondaryPreferredReadPreference - Class in com.mongodb
Read from secondary if available, otherwise from primary, irrespective of tags.
TaggableReadPreference.SecondaryReadPreference - Class in com.mongodb
Read from secondary
tagSet - Variable in class com.mongodb.connection.ServerDescription.Builder
 
tagSet(TagSet) - Method in class com.mongodb.connection.ServerDescription.Builder
A set of any tags assigned to this member.
tagSet - Variable in class com.mongodb.connection.ServerDescription
 
TagSet - Class in com.mongodb
An immutable set of tags, used to select members of a replica set to use for read operations.
TagSet() - Constructor for class com.mongodb.TagSet
An empty set of tags.
TagSet(Tag) - Constructor for class com.mongodb.TagSet
A set of tags contain the single given tag
TagSet(List<Tag>) - Constructor for class com.mongodb.TagSet
A set of tags containing the given list of tags.
tagSetList - Variable in class com.mongodb.TaggableReadPreference
 
tagsListToBsonArray() - Method in class com.mongodb.TaggableReadPreference
 
tailableCursor - Variable in class com.mongodb.connection.BaseQueryMessage
 
tailableCursor(boolean) - Method in class com.mongodb.connection.BaseQueryMessage
Sets whether the cursor should be a tailable cursor.
tailableCursor - Variable in class com.mongodb.connection.QueryProtocol
 
tailableCursor(boolean) - Method in class com.mongodb.connection.QueryProtocol
Sets whether the cursor should be a tailable cursor.
takeWritingLock(SingleResultCallback<T>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
terminalAction() - Method in class com.mongodb.async.client.AbstractSubscription
 
text(String) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents matching the given search term.
text(String, String) - Static method in class com.mongodb.client.model.Filters
text(String, TextSearchOptions) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents matching the given the search term with the given text search options.
text(String) - Static method in class com.mongodb.client.model.Indexes
Create an index key for a text index on the given field.
text(String) - Method in class com.mongodb.QueryBuilder
Equivalent to a $text operand.
text(String, String) - Method in class com.mongodb.QueryBuilder
Equivalent to a $text operand.
TEXT - Static variable in class com.mongodb.QueryOperators
 
TextFilter(String, TextSearchOptions) - Constructor for class com.mongodb.client.model.Filters.TextFilter
 
textSearchOptions - Variable in class com.mongodb.client.model.Filters.TextFilter
 
TextSearchOptions - Class in com.mongodb.client.model
Text search options for the Filters.text(String, TextSearchOptions) helper
TextSearchOptions() - Constructor for class com.mongodb.client.model.TextSearchOptions
 
textVersion - Variable in class com.mongodb.bulk.IndexRequest
 
textVersion(Integer) - Method in class com.mongodb.bulk.IndexRequest
Set the text index version number.
textVersion - Variable in class com.mongodb.client.model.IndexOptions
 
textVersion(Integer) - Method in class com.mongodb.client.model.IndexOptions
Set the text index version number.
threadNumber - Variable in class com.mongodb.internal.thread.DaemonThreadFactory
 
ThreadSafe - Annotation Type in com.mongodb.annotations
The class to which this annotation is applied is thread-safe.
threadsAllowedToBlockForConnectionMultiplier - Variable in class com.mongodb.ConnectionString
 
threadsAllowedToBlockForConnectionMultiplier - Variable in class com.mongodb.MongoClientOptions.Builder
 
threadsAllowedToBlockForConnectionMultiplier(int) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the multiplier for number of threads allowed to block waiting for a connection.
threadsAllowedToBlockForConnectionMultiplier - Variable in class com.mongodb.MongoClientOptions
 
threadsAllowedToBlockForConnectionMultiplier - Variable in class com.mongodb.MongoOptions
Deprecated.
This multiplier, multiplied with the connectionsPerHost setting, gives the maximum number of threads that may be waiting for a connection to become available from the pool.
throwable - Variable in class com.mongodb.connection.netty.NettyStream.FutureAsyncCompletionHandler
 
throwable - Variable in class com.mongodb.event.CommandFailedEvent
 
throwable - Variable in class com.mongodb.event.ServerHeartbeatFailedEvent
 
throwBSONException(IOException) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
throwCodecConfigurationException(String, Exception) - Method in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 
throwIfIncompatible(ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
throwIfInvalidType(BsonType) - Method in class org.bson.BsonValue
 
throwIfKeyAbsent(Object) - Method in class org.bson.BsonDocument
 
throwIfUnacknowledged(String) - Method in class com.mongodb.WriteResult
 
throwInvalidContextType(String, BsonContextType, BsonContextType...) - Method in class org.bson.AbstractBsonReader
Throws an InvalidOperationException when the method called is not valid for the current ContextType.
throwInvalidContextType(String, BsonContextType, BsonContextType...) - Method in class org.bson.AbstractBsonWriter
Throws an InvalidOperationException when the method called is not valid for the current ContextType.
throwInvalidState(String, AbstractBsonReader.State...) - Method in class org.bson.AbstractBsonReader
Throws an InvalidOperationException when the method called is not valid for the current state.
throwInvalidState(String, AbstractBsonWriter.State...) - Method in class org.bson.AbstractBsonWriter
Throws a BsonInvalidOperationException when the method called is not valid for the current state.
throwOnError() - Method in class com.mongodb.CommandResult
Throws a CommandFailureException if the command failed.
throwOnError() - Method in class com.mongodb.connection.BulkWriteBatchCombiner
 
throwOnWriteConcernError(BsonDocument, ServerAddress) - Static method in class com.mongodb.operation.WriteConcernHelper
 
throwWriteException(BsonDocument, ServerAddress) - Static method in class com.mongodb.connection.ProtocolHelper
 
Time - Class in com.mongodb.connection
 
Time() - Constructor for class com.mongodb.connection.Time
 
time - Variable in class org.bson.types.BSONTimestamp
 
timedOut() - Method in class com.mongodb.connection.BaseCluster.ServerSelectionRequest
 
timeout - Variable in class com.mongodb.connection.netty.ReadTimeoutHandler
 
TIMESTAMP - Static variable in class org.bson.BSON
 
timestamp - Variable in class org.bson.types.ObjectId
 
timestampConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
timestampConverter(Converter<BsonTimestamp>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Timestamp values to JSON.
timestampConverter - Variable in class org.bson.json.JsonWriterSettings
 
toArray() - Method in class com.mongodb.DBCursor
Converts this cursor to an array.
toArray(int) - Method in class com.mongodb.DBCursor
Converts this cursor to an array.
toArray() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns an array containing all of the elements in this deque, in proper sequence (from first to last element).
toArray(T[]) - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns an array containing all of the elements in this deque, in proper sequence (from first to last element); the runtime type of the returned array is that of the specified array.
toArray() - Method in class com.mongodb.operation.BsonArrayWrapper
 
toArray(T[]) - Method in class com.mongodb.operation.BsonArrayWrapper
 
toArray() - Method in class org.bson.BsonArray
 
toArray(T[]) - Method in class org.bson.BsonArray
 
toArray() - Method in class org.bson.LazyBSONList
 
toArray(Object[]) - Method in class org.bson.LazyBSONList
 
toArray() - Method in class org.bson.types.StringRangeSet
 
toArray(T[]) - Method in class org.bson.types.StringRangeSet
 
toArray() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
toArray(T[]) - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
toArrayList() - Method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Creates an array list and fills it with elements of this list.
toAsyncInputStream(byte[]) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
Converts a byte[] into a AsyncInputStream
toAsyncInputStream(ByteBuffer) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
Converts a ByteBuffer into a AsyncInputStream
toAsyncInputStream(InputStream) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
Converts a InputStream into a AsyncInputStream
toAsyncOutputStream(byte[]) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
Converts a byte[] into a AsyncOutputStream
toAsyncOutputStream(ByteBuffer) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
Converts a ByteBuffer into a AsyncOutputStream
toAsyncOutputStream(OutputStream) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
Converts a OutputStream into a AsyncOutputStream
toBsonDocument(Bson) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
toBsonDocument(Bson) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.BasicDBObject
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.AddFieldsStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.BucketAutoStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.BucketStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.FacetStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.GroupStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.ReplaceRootStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.SimplePipelineStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Aggregates.SortByCountStage
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.AndFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.IterableOperatorFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.NotFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.OperatorFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.OrNorFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.SimpleEncodingFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.SimpleFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Filters.TextFilter
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Projections.ElemMatchFilterProjection
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Projections.FieldsProjection
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.SimpleExpression
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Sorts.CompoundSort
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Updates.CompositeUpdate
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Updates.PullAllUpdate
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Updates.SimpleUpdate
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Updates.WithEachUpdate
 
toBsonDocument() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
toBsonDocument() - Method in class com.mongodb.connection.ByteBufBsonDocument
 
toBsonDocument(Bson) - Method in class com.mongodb.MongoCollectionImpl
 
toBsonDocument(Bson) - Method in class com.mongodb.MongoDatabaseImpl
 
toBsonDocument(Class<C>, CodecRegistry) - Method in class org.bson.BsonDocument
 
toBsonDocument(Class<TDocument>, CodecRegistry) - Method in interface org.bson.conversions.Bson
Render the filter into a BsonDocument.
toBsonDocument(Class<C>, CodecRegistry) - Method in class org.bson.Document
 
toBsonDocument() - Method in class org.bson.RawBsonDocument
 
toBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
toBsonDocumentList(List<? extends Bson>) - Method in class com.mongodb.MongoCollectionImpl
 
toBsonDocumentOrNull(Bson, CodecRegistry) - Method in class com.mongodb.async.client.MongoIterableImpl
 
toBsonDocumentOrNull(Bson, Class<T>, CodecRegistry) - Method in class com.mongodb.async.client.MongoIterableImpl
 
toBsonDocumentOrNull(Bson, CodecRegistry) - Method in class com.mongodb.MongoIterableImpl
 
toBsonDocumentOrNull(Bson, Class<T>, CodecRegistry) - Method in class com.mongodb.MongoIterableImpl
 
toByteArray() - Method in class org.bson.io.OutputBuffer
Gets a copy of the buffered bytes.
toByteArray() - Method in class org.bson.types.ObjectId
Convert to a byte array.
toClientOptions() - Method in class com.mongodb.MongoOptions
Deprecated.
 
toClientURI() - Method in class com.mongodb.MongoURI
Deprecated.
 
toCollection() - Method in class com.mongodb.AggregateIterableImpl
 
toCollection(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.AggregateIterable
Aggregates documents according to the specified aggregation pipeline, which must end with a $out stage.
toCollection(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.AggregateIterableImpl
 
toCollection(SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.MapReduceIterable
Aggregates documents to a collection according to the specified map-reduce function with the given options, which must specify a non-inline result.
toCollection(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
toCollection() - Method in interface com.mongodb.client.AggregateIterable
Aggregates documents according to the specified aggregation pipeline, which must end with a $out stage.
toCollection() - Method in interface com.mongodb.client.MapReduceIterable
Aggregates documents to a collection according to the specified map-reduce function with the given options, which must specify a non-inline result.
toCollection() - Method in class com.mongodb.MapReduceIterableImpl
 
toDBList(BatchCursor<DBObject>) - Static method in class com.mongodb.DBCollection
 
toDBObject(BsonDocument) - Static method in class com.mongodb.DBObjects
 
toDBObject() - Method in class com.mongodb.GroupCommand
Turns this group command into the DBObject format of the command.
toDBObject() - Method in class com.mongodb.MapReduceCommand
Turns this command into a DBObject representation of this map reduce command.
toDocument(BsonDocument) - Static method in class com.mongodb.operation.BsonDocumentWrapperHelper
 
toDocument() - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
toDocument() - Method in class com.mongodb.ReadPreference
Gets a document representing this read preference in the wire protocol.
toDocument() - Method in class com.mongodb.TaggableReadPreference
 
toDocument(TagSet) - Method in class com.mongodb.TaggableReadPreference
 
toEncoder(DBEncoder) - Method in class com.mongodb.DBCollection
 
toHex(byte[]) - Static method in class com.mongodb.internal.HexUtils
Converts the given byte buffer to a hexadecimal string using Integer.toHexString(int).
toHex(byte[]) - Static method in class com.mongodb.util.Util
Converts the given byte buffer to a hexadecimal string using Integer.toHexString(int).
toHexString() - Method in class org.bson.types.ObjectId
Converts this instance into a 24-byte hexadecimal string representation.
toInt(Object) - Method in class org.bson.BasicBSONObject
 
toInt(Object) - Static method in class org.bson.BSON
Provides an integer representation of Boolean or Number.
toJson() - Method in class com.mongodb.BasicDBObject
Gets a JSON representation of this document using the JsonMode.STRICT output mode, and otherwise the default settings of JsonWriterSettings.Builder and DBObjectCodec.
toJson(JsonWriterSettings) - Method in class com.mongodb.BasicDBObject
Gets a JSON representation of this document
toJson(Encoder<BasicDBObject>) - Method in class com.mongodb.BasicDBObject
Gets a JSON representation of this document
toJson(JsonWriterSettings, Encoder<BasicDBObject>) - Method in class com.mongodb.BasicDBObject
Gets a JSON representation of this document
toJson() - Method in class com.mongodb.client.model.geojson.Geometry
Converts to GeoJSON representation
toJson() - Method in class com.mongodb.connection.ByteBufBsonDocument
 
toJson(JsonWriterSettings) - Method in class com.mongodb.connection.ByteBufBsonDocument
 
toJson() - Method in class org.bson.BsonDocument
Gets a JSON representation of this document using the JsonMode.STRICT output mode, and otherwise the default settings of JsonWriterSettings.Builder.
toJson(JsonWriterSettings) - Method in class org.bson.BsonDocument
Gets a JSON representation of this document using the given JsonWriterSettings.
toJson() - Method in class org.bson.Document
Gets a JSON representation of this document using the JsonMode.STRICT output mode, and otherwise the default settings of JsonWriterSettings.Builder and DocumentCodec.
toJson(JsonWriterSettings) - Method in class org.bson.Document
Gets a JSON representation of this document
toJson(Encoder<Document>) - Method in class org.bson.Document
Gets a JSON representation of this document
toJson(JsonWriterSettings, Encoder<Document>) - Method in class org.bson.Document
Gets a JSON representation of this document
toJson() - Method in class org.bson.RawBsonDocument
 
toJson(JsonWriterSettings) - Method in class org.bson.RawBsonDocument
 
toKey(MongoClientURI) - Method in class com.mongodb.Mongo.Holder
 
toList(BsonDocument, String) - Static method in class com.mongodb.operation.BsonDocumentWrapperHelper
 
toMap() - Method in class com.mongodb.gridfs.GridFSFile
 
toMap() - Method in class com.mongodb.ReflectionDBObject
 
toMap() - Method in class org.bson.BasicBSONObject
Converts a DBObject to a map.
toMap() - Method in interface org.bson.BSONObject
Returns a map representing this BSONObject.
toMap() - Method in class org.bson.LazyBSONObject
 
toMap() - Method in class org.bson.types.BasicBSONList
 
toNew(DBCollection) - Method in class com.mongodb.InsertRequest
 
toNew(DBCollection) - Method in class com.mongodb.RemoveRequest
 
toNew(DBCollection) - Method in class com.mongodb.ReplaceRequest
 
toNew(DBCollection) - Method in class com.mongodb.UpdateRequest
 
toNew(DBCollection) - Method in class com.mongodb.WriteRequest
 
toOperation(MongoNamespace, DBObjectCodec) - Method in class com.mongodb.GroupCommand
 
toPropertyName(Method) - Static method in class org.bson.codecs.pojo.PropertyReflectionUtils
 
toString() - Method in class com.mongodb.AcknowledgedBulkWriteResult
 
toString() - Method in class com.mongodb.AggregationOptions
 
toString() - Method in enum com.mongodb.AuthenticationMechanism
 
toString() - Method in class com.mongodb.BasicDBList
Returns a JSON serialization of this object
toString() - Method in class com.mongodb.BasicDBObject
Returns a JSON serialization of this object
toString() - Method in class com.mongodb.bulk.BulkWriteError
 
toString() - Method in class com.mongodb.bulk.BulkWriteUpsert
 
toString() - Method in class com.mongodb.bulk.WriteConcernError
 
toString() - Method in class com.mongodb.BulkWriteError
 
toString() - Method in class com.mongodb.BulkWriteUpsert
 
toString() - Method in class com.mongodb.client.gridfs.model.GridFSFile
 
toString() - Method in class com.mongodb.client.model.Aggregates.AddFieldsStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.BucketAutoStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.BucketStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.FacetStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.GraphLookupStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.GroupStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.ReplaceRootStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.SimplePipelineStage
 
toString() - Method in class com.mongodb.client.model.Aggregates.SortByCountStage
 
toString() - Method in class com.mongodb.client.model.BsonField
 
toString() - Method in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
toString() - Method in enum com.mongodb.client.model.changestream.OperationType
 
toString() - Method in class com.mongodb.client.model.changestream.UpdateDescription
 
toString() - Method in class com.mongodb.client.model.Collation
 
toString() - Method in class com.mongodb.client.model.Filters.AndFilter
 
toString() - Method in class com.mongodb.client.model.Filters.GeometryOperatorFilter
 
toString() - Method in class com.mongodb.client.model.Filters.IterableOperatorFilter
 
toString() - Method in class com.mongodb.client.model.Filters.NotFilter
 
toString() - Method in class com.mongodb.client.model.Filters.OperatorFilter
 
toString() - Method in class com.mongodb.client.model.Filters.OrNorFilter
 
toString() - Method in class com.mongodb.client.model.Filters.SimpleEncodingFilter
 
toString() - Method in class com.mongodb.client.model.Filters.SimpleFilter
 
toString() - Method in class com.mongodb.client.model.Filters.TextFilter
 
toString() - Method in class com.mongodb.client.model.FindOptions
 
toString() - Method in class com.mongodb.client.model.geojson.GeometryCollection
 
toString() - Method in class com.mongodb.client.model.geojson.LineString
 
toString() - Method in class com.mongodb.client.model.geojson.MultiLineString
 
toString() - Method in class com.mongodb.client.model.geojson.MultiPoint
 
toString() - Method in class com.mongodb.client.model.geojson.MultiPolygon
 
toString() - Method in class com.mongodb.client.model.geojson.NamedCoordinateReferenceSystem
 
toString() - Method in class com.mongodb.client.model.geojson.Point
 
toString() - Method in class com.mongodb.client.model.geojson.Polygon
 
toString() - Method in class com.mongodb.client.model.geojson.PolygonCoordinates
 
toString() - Method in class com.mongodb.client.model.geojson.Position
 
toString() - Method in class com.mongodb.client.model.GraphLookupOptions
 
toString() - Method in class com.mongodb.client.model.Projections.ElemMatchFilterProjection
 
toString() - Method in class com.mongodb.client.model.Projections.FieldsProjection
 
toString() - Method in class com.mongodb.client.model.PushOptions
 
toString() - Method in class com.mongodb.client.model.SimpleExpression
 
toString() - Method in class com.mongodb.client.model.Sorts.CompoundSort
 
toString() - Method in class com.mongodb.client.model.TextSearchOptions
 
toString() - Method in class com.mongodb.client.model.Updates.CompositeUpdate
 
toString() - Method in class com.mongodb.client.model.Updates.PullAllUpdate
 
toString() - Method in class com.mongodb.client.model.Updates.SimpleUpdate
 
toString() - Method in class com.mongodb.client.model.Updates.WithEachUpdate
 
toString() - Method in class com.mongodb.client.result.DeleteResult.AcknowledgedDeleteResult
 
toString() - Method in class com.mongodb.client.result.DeleteResult.UnacknowledgedDeleteResult
 
toString() - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
toString() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
toString() - Method in class com.mongodb.connection.ChangeEvent
 
toString() - Method in class com.mongodb.connection.ClusterDescription
 
toString() - Method in class com.mongodb.connection.ClusterId
 
toString() - Method in class com.mongodb.connection.ClusterSettings
 
toString() - Method in class com.mongodb.connection.ConnectionId
 
toString() - Method in class com.mongodb.connection.ConnectionPoolSettings
 
toString() - Method in class com.mongodb.connection.netty.NettyStreamFactoryFactory
 
toString() - Method in class com.mongodb.connection.ServerDescription
 
toString() - Method in class com.mongodb.connection.ServerId
 
toString() - Method in class com.mongodb.connection.ServerSettings
 
toString() - Method in class com.mongodb.connection.ServerVersion
 
toString() - Method in class com.mongodb.connection.SocketSettings
 
toString() - Method in class com.mongodb.connection.SslSettings
 
toString() - Method in class com.mongodb.ConnectionString
 
toString() - Method in class com.mongodb.DB
 
toString() - Method in class com.mongodb.DBAddress
Deprecated.
Gets a String representation of address as host:port/databaseName.
toString() - Method in class com.mongodb.DBCollection
 
toString() - Method in class com.mongodb.DBCursor
 
toString() - Method in class com.mongodb.DBRef
 
toString() - Method in class com.mongodb.DefaultDBDecoder
 
toString() - Method in class com.mongodb.DefaultDBEncoder
 
toString() - Method in class com.mongodb.event.ClusterClosedEvent
 
toString() - Method in class com.mongodb.event.ClusterDescriptionChangedEvent
 
toString() - Method in class com.mongodb.event.ClusterOpeningEvent
 
toString() - Method in class com.mongodb.event.ConnectionAddedEvent
 
toString() - Method in class com.mongodb.event.ConnectionCheckedInEvent
 
toString() - Method in class com.mongodb.event.ConnectionCheckedOutEvent
 
toString() - Method in class com.mongodb.event.ConnectionClosedEvent
 
toString() - Method in class com.mongodb.event.ConnectionMessageReceivedEvent
Deprecated.
 
toString() - Method in class com.mongodb.event.ConnectionMessagesSentEvent
Deprecated.
 
toString() - Method in class com.mongodb.event.ConnectionOpenedEvent
 
toString() - Method in class com.mongodb.event.ConnectionPoolClosedEvent
 
toString() - Method in class com.mongodb.event.ConnectionPoolOpenedEvent
 
toString() - Method in class com.mongodb.event.ConnectionPoolWaitQueueEnteredEvent
 
toString() - Method in class com.mongodb.event.ConnectionPoolWaitQueueExitedEvent
 
toString() - Method in class com.mongodb.event.ConnectionRemovedEvent
 
toString() - Method in class com.mongodb.event.ServerClosedEvent
 
toString() - Method in class com.mongodb.event.ServerDescriptionChangedEvent
 
toString() - Method in class com.mongodb.event.ServerHeartbeatFailedEvent
 
toString() - Method in class com.mongodb.event.ServerHeartbeatStartedEvent
 
toString() - Method in class com.mongodb.event.ServerHeartbeatSucceededEvent
 
toString() - Method in class com.mongodb.event.ServerOpeningEvent
 
toString() - Method in class com.mongodb.gridfs.GridFSFile
 
toString() - Method in class com.mongodb.internal.connection.ConcurrentPool
 
toString() - Method in class com.mongodb.MapReduceCommand
 
toString() - Method in class com.mongodb.MapReduceOutput
 
toString() - Method in class com.mongodb.Mongo
 
toString() - Method in class com.mongodb.MongoClientOptions
 
toString() - Method in class com.mongodb.MongoClientURI
 
toString() - Method in class com.mongodb.MongoCompressor
 
toString() - Method in class com.mongodb.MongoCredential
 
toString() - Method in class com.mongodb.MongoNamespace
Returns the standard MongoDB representation of a namespace, which is &lt;database&gt;.&lt;collection&gt;.
toString() - Method in class com.mongodb.MongoOptions
Deprecated.
 
toString() - Method in class com.mongodb.MongoURI
Deprecated.
 
toString() - Method in class com.mongodb.operation.AggregateOperation
 
toString() - Method in class com.mongodb.operation.BsonArrayWrapper
 
toString() - Method in class com.mongodb.ReadPreference.PrimaryReadPreference
 
toString() - Method in class com.mongodb.ReplicaSetStatus
 
toString() - Method in class com.mongodb.selector.CompositeServerSelector
 
toString() - Method in class com.mongodb.selector.LatencyMinimizingServerSelector
 
toString() - Method in class com.mongodb.selector.PrimaryServerSelector
Deprecated.
 
toString() - Method in class com.mongodb.selector.ReadPreferenceServerSelector
 
toString() - Method in class com.mongodb.selector.ServerAddressSelector
 
toString() - Method in class com.mongodb.selector.WritableServerSelector
 
toString() - Method in class com.mongodb.ServerAddress
 
toString() - Method in class com.mongodb.ServerCursor
 
toString() - Method in class com.mongodb.Tag
 
toString() - Method in class com.mongodb.TaggableReadPreference
 
toString() - Method in class com.mongodb.TagSet
 
toString() - Method in class com.mongodb.UnacknowledgedBulkWriteResult
 
toString() - Method in class com.mongodb.WriteConcern
 
toString() - Method in class com.mongodb.WriteConcernError
 
toString() - Method in class com.mongodb.WriteError
 
toString() - Method in class com.mongodb.WriteResult
 
toString() - Method in class org.bson.BasicBSONObject
Returns a JSON serialization of this object
toString() - Method in class org.bson.BsonArray
 
toString() - Method in class org.bson.BsonBinary
 
toString() - Method in class org.bson.BsonBoolean
 
toString() - Method in class org.bson.BsonDateTime
 
toString() - Method in class org.bson.BsonDbPointer
 
toString() - Method in class org.bson.BsonDecimal128
 
toString() - Method in class org.bson.BsonDocument
 
toString() - Method in class org.bson.BsonDocumentWrapper
 
toString() - Method in class org.bson.BsonDouble
 
toString() - Method in class org.bson.BsonInt32
 
toString() - Method in class org.bson.BsonInt64
 
toString() - Method in class org.bson.BsonJavaScript
 
toString() - Method in class org.bson.BsonJavaScriptWithScope
 
toString() - Method in class org.bson.BsonMaxKey
 
toString() - Method in class org.bson.BsonMinKey
 
toString() - Method in class org.bson.BsonNull
 
toString() - Method in class org.bson.BsonObjectId
 
toString() - Method in class org.bson.BsonRegularExpression
 
toString() - Method in class org.bson.BsonString
 
toString() - Method in class org.bson.BsonSymbol
 
toString() - Method in class org.bson.BsonTimestamp
 
toString() - Method in class org.bson.codecs.configuration.Optional.Some
 
toString() - Method in class org.bson.codecs.configuration.Optional
 
toString() - Method in class org.bson.codecs.pojo.ClassModel
 
toString() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
toString() - Method in class org.bson.codecs.pojo.PojoCodecImpl
 
toString() - Method in class org.bson.codecs.pojo.PropertyModel
 
toString() - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
toString() - Method in class org.bson.codecs.pojo.TypeData
 
toString() - Method in class org.bson.codecs.pojo.TypeParameterMap
 
toString() - Method in class org.bson.Document
 
toString(long) - Static method in class org.bson.internal.UnsignedLongs
Equivalent to Long.toUnsignedString in Java 8.
toString() - Method in class org.bson.io.OutputBuffer
 
toString() - Method in class org.bson.LazyBSONObject
Returns a JSON serialization of this object
toString() - Method in class org.bson.types.BSONTimestamp
 
toString() - Method in class org.bson.types.Code
 
toString() - Method in class org.bson.types.Decimal128
Returns the String representation of the Decimal128 value.
toString() - Method in class org.bson.types.MaxKey
 
toString() - Method in class org.bson.types.MinKey
 
toString() - Method in class org.bson.types.ObjectId
 
toString() - Method in class org.bson.types.Symbol
 
toString() - Method in class org.bson.util.AbstractCopyOnWriteMap.CollectionView
 
toString() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
toStringMongod() - Method in class org.bson.types.ObjectId
Deprecated.
toStringName - Variable in enum com.mongodb.client.model.Filters.OrNorFilter.Operator
 
ToStringSerializer() - Constructor for class com.mongodb.util.JSONSerializers.ToStringSerializer
Deprecated.
 
toStringWithBigDecimal() - Method in class org.bson.types.Decimal128
 
TOTAL_COMPRESSED_HEADER_LENGTH - Static variable in class com.mongodb.connection.CompressedHeader
The length of the OP_COMPRESSED header plus the length of the standard message header
TOTAL_REPLY_HEADER_LENGTH - Static variable in class com.mongodb.connection.ReplyHeader
The length of the OP_REPLY header plus the length of the standard message header
totalBytes - Variable in class com.mongodb.gridfs.GridFSInputFile
 
toUnsignedLong(int) - Method in class org.bson.json.ExtendedJsonTimestampConverter
 
toUpdateResult(BulkWriteResult) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
toUpdateResult(BulkWriteResult) - Method in class com.mongodb.MongoCollectionImpl
 
trace(String) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
trace(String, Throwable) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
trace(String) - Method in interface com.mongodb.diagnostics.logging.Logger
Log a message at the TRACE level.
trace(String, Throwable) - Method in interface com.mongodb.diagnostics.logging.Logger
Log an exception (throwable) at the TRACE level with an accompanying message.
trace(String) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
trace(String, Throwable) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
trace(String) - Method in class org.bson.diagnostics.JULLogger
 
trace(String, Throwable) - Method in class org.bson.diagnostics.JULLogger
 
trace(String) - Method in interface org.bson.diagnostics.Logger
Log a message at the TRACE level.
trace(String, Throwable) - Method in interface org.bson.diagnostics.Logger
Log an exception (throwable) at the TRACE level with an accompanying message.
trace(String) - Method in class org.bson.diagnostics.SLF4JLogger
 
trace(String, Throwable) - Method in class org.bson.diagnostics.SLF4JLogger
 
trailer - Variable in class com.mongodb.internal.connection.ConcurrentLinkedDeque
List trailer.
transactionNumber - Variable in class com.mongodb.internal.session.ServerSessionPool.ServerSessionImpl
 
transferDataFromByteBuffers(ByteBuffer, ByteBuffer, SingleResultCallback<Integer>) - Static method in class com.mongodb.async.client.gridfs.helpers.AsyncStreamHelper
 
transform(Object) - Method in class com.mongodb.DocumentToDBRefTransformer
 
transform(Object) - Method in interface org.bson.Transformer
Turns the objectToTransform into some other Object.
transformer(ConnectionSource, Connection) - Method in class com.mongodb.operation.AggregateOperation
 
transformer - Variable in class com.mongodb.operation.CommandOperationHelper.CommandProtocolExecutingCallback
 
transformer - Variable in class com.mongodb.operation.CommandOperationHelper.TransformingResultCallback
 
transformer() - Method in class com.mongodb.operation.CountOperation
 
transformer(ConnectionSource, Connection) - Method in class com.mongodb.operation.DistinctOperation
 
transformer() - Static method in class com.mongodb.operation.FindAndModifyHelper
 
transformer(ConnectionSource, Connection) - Method in class com.mongodb.operation.FindOperation
 
transformer(ConnectionSource, Connection) - Method in class com.mongodb.operation.GroupOperation
 
transformer(ConnectionSource, Connection) - Method in class com.mongodb.operation.ListDatabasesOperation
 
transformer(ConnectionSource) - Method in class com.mongodb.operation.ListIndexesOperation
 
transformer() - Method in class com.mongodb.operation.MapReduceToCollectionOperation
 
transformer(ConnectionSource, Connection) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
transformer(ConnectionSource) - Method in class com.mongodb.operation.ParallelCollectionScanOperation
 
transformer() - Method in class com.mongodb.operation.UserExistsOperation
 
Transformer - Interface in org.bson
Transforms objects that can be converted to BSON into other Java types, and vice versa.
TransformingResultCallback(CommandOperationHelper.CommandTransformer<T, R>, ServerAddress, SingleResultCallback<R>) - Constructor for class com.mongodb.operation.CommandOperationHelper.TransformingResultCallback
 
translateBulkWriteException(MongoBulkWriteException, Decoder<DBObject>) - Static method in class com.mongodb.BulkWriteHelper
 
translateBulkWriteResult(WriteRequest, BulkWriteResult) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
translateBulkWriteResult(BulkWriteResult, Decoder<DBObject>) - Static method in class com.mongodb.BulkWriteHelper
 
translateBulkWriteResult(WriteRequest, BulkWriteResult) - Method in class com.mongodb.MongoCollectionImpl
 
translateBulkWriteResult(BulkWriteResult) - Method in class com.mongodb.operation.BaseWriteOperation
 
translateBulkWriteUpserts(List<BulkWriteUpsert>, Decoder<DBObject>) - Static method in class com.mongodb.BulkWriteHelper
 
translateCommandException(MongoCommandException, ServerCursor) - Static method in class com.mongodb.operation.QueryHelper
 
translateException(Throwable) - Method in class com.mongodb.operation.CreateIndexesOperation
 
translateExceptionToString() - Method in class com.mongodb.connection.ServerDescription
 
translateOptions(Map<String, List<String>>) - Method in class com.mongodb.ConnectionString
 
translateReadException(Throwable) - Method in class com.mongodb.connection.InternalStreamConnection
 
translateThrowable(Throwable) - Method in class com.mongodb.connection.NativeAuthenticator
 
translateThrowable(Throwable) - Method in class com.mongodb.connection.X509Authenticator
 
translateUserCommandException(MongoCommandException) - Static method in class com.mongodb.operation.UserOperationHelper
 
translateWriteConcernError(WriteConcernError) - Static method in class com.mongodb.BulkWriteHelper
 
translateWriteErrors(List<BulkWriteError>) - Static method in class com.mongodb.BulkWriteHelper
 
translateWriteException(Throwable) - Method in class com.mongodb.connection.InternalStreamConnection
 
translateWriteRequestsToNew(List<WriteRequest>) - Method in class com.mongodb.DBCollection
 
translateWriteResult(WriteConcernResult) - Method in class com.mongodb.DBCollection
 
translateWriteResult(int, boolean, BsonValue) - Method in class com.mongodb.DBCollection
 
TRUE - Static variable in class org.bson.BsonBoolean
 
truncateToPosition(int) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
truncateToPosition(int) - Method in class org.bson.io.BasicOutputBuffer
 
truncateToPosition(int) - Method in interface org.bson.io.BsonOutput
Truncates this stream to the new position.
truncateToPosition(int) - Method in class org.bson.io.OutputBuffer
 
tryGetReadingLock(SingleResultCallback<A>) - Method in class com.mongodb.async.client.gridfs.GridFSDownloadStreamImpl
 
tryHasNext() - Method in class com.mongodb.operation.QueryBatchCursor
 
tryNext(SingleResultCallback<List<T>>) - Method in interface com.mongodb.async.AsyncBatchCursor
A special next() case that returns the next batch if available or null.
tryNext(SingleResultCallback<List<U>>) - Method in class com.mongodb.async.client.MappingAsyncBatchCursor
 
tryNext() - Method in interface com.mongodb.client.MongoCursor
A special next() case that returns the next element in the iteration if available or null.
tryNext() - Method in class com.mongodb.DBCursor
Non blocking check for tailable cursors to see if another object is available.
tryNext() - Method in class com.mongodb.MongoBatchCursorAdapter
 
tryNext() - Method in class com.mongodb.MongoMappingCursor
 
tryNext(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
tryNext - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.CommandResultSingleResultCallback
 
tryNext - Variable in class com.mongodb.operation.AsyncQueryBatchCursor.QueryResultSingleResultCallback
 
tryNext(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncQueryBatchCursor
 
tryNext(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.AsyncSingleBatchQueryCursor
 
tryNext() - Method in interface com.mongodb.operation.BatchCursor
A special next() case that returns the next batch if available or null.
tryNext() - Method in class com.mongodb.operation.ChangeStreamBatchCursor
 
tryNext(SingleResultCallback<List<T>>) - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingAsyncBatchCursor
 
tryNext() - Method in class com.mongodb.operation.ListCollectionsOperation.ProjectingBatchCursor
 
tryNext() - Method in class com.mongodb.operation.QueryBatchCursor
 
tryProcessResultsQueue() - Method in class com.mongodb.async.client.AbstractSubscription
 
tryRequestInitialData() - Method in class com.mongodb.async.client.AbstractSubscription
 
tryToExpandToGenericType(Class<?>, PropertyModelBuilder<T>, Type) - Static method in class org.bson.codecs.pojo.ConventionAnnotationImpl
 
twoHighestCombinationBitsAreSet() - Method in class org.bson.types.Decimal128
 
Type() - Constructor for enum com.mongodb.bulk.WriteRequest.Type
 
type(String, BsonType) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the field is of the specified BSON type.
type(String, String) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents where the value of the field is of the specified BSON type.
type - Variable in class com.mongodb.connection.ClusterDescription
 
type - Variable in class com.mongodb.connection.ServerDescription.Builder
 
type(ServerType) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the type of the server, for example whether it's a standalone or in a replica set.
type - Variable in class com.mongodb.connection.ServerDescription
 
Type() - Constructor for enum com.mongodb.connection.SplittablePayload.Type
 
TYPE - Static variable in class com.mongodb.QueryOperators
 
type - Variable in class org.bson.BsonBinary
 
type - Variable in class org.bson.codecs.pojo.ClassModel
 
type - Variable in class org.bson.codecs.pojo.ClassModelBuilder
 
type(Class<T>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
Sets the type of the model
type - Variable in class org.bson.codecs.pojo.TypeData.Builder
 
type - Variable in class org.bson.codecs.pojo.TypeData
 
type - Variable in class org.bson.json.JsonToken
 
type - Variable in class org.bson.types.Binary
 
Type() - Constructor for enum org.bson.util.AbstractCopyOnWriteMap.View.Type
 
typeData - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
typeData - Variable in class org.bson.codecs.pojo.PropertyModel
 
typeData - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
typeData(TypeData<T>) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
 
TypeData<T> - Class in org.bson.codecs.pojo
 
TypeData(Class<T>, List<TypeData<?>>) - Constructor for class org.bson.codecs.pojo.TypeData
 
TypeData.Builder<T> - Class in org.bson.codecs.pojo
A builder for TypeData
typeName - Variable in enum com.mongodb.client.model.geojson.CoordinateReferenceSystemType
 
typeName - Variable in enum com.mongodb.client.model.geojson.GeoJsonObjectType
 
typeParameterInfo(TypeParameterMap, TypeData<S>) - Method in class org.bson.codecs.pojo.PropertyMetadata
 
typeParameterMap - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
TypeParameterMap - Class in org.bson.codecs.pojo
Maps the index of a class's generic parameter type index to a property's.
TypeParameterMap(Map<Integer, Integer>) - Constructor for class org.bson.codecs.pojo.TypeParameterMap
 
TypeParameterMap.Builder - Class in org.bson.codecs.pojo
A builder for mapping field type parameter indices to the class type parameter indices
typeParameters - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
typeParameters - Variable in class org.bson.codecs.pojo.TypeData.Builder
 
typeParameters - Variable in class org.bson.codecs.pojo.TypeData
 
TypeWithTypeParameters<T> - Interface in org.bson.codecs.pojo
A combination of a type and its type parameters.

U

unacknowledged() - Static method in class com.mongodb.bulk.BulkWriteResult
Create an unacknowledged BulkWriteResult
unacknowledged() - Static method in class com.mongodb.client.result.DeleteResult
Create an unacknowledged DeleteResult
unacknowledged() - Static method in class com.mongodb.client.result.UpdateResult
Create an unacknowledged UpdateResult
UNACKNOWLEDGED - Static variable in class com.mongodb.WriteConcern
Write operations that use this write concern will return as soon as the message is written to the socket.
unacknowledged() - Static method in class com.mongodb.WriteConcernResult
Create an unacknowledged WriteConcernResult
unacknowledged() - Static method in class com.mongodb.WriteResult
Gets an instance representing an unacknowledged write.
UnacknowledgedBulkWriteResult - Class in com.mongodb
 
UnacknowledgedBulkWriteResult() - Constructor for class com.mongodb.UnacknowledgedBulkWriteResult
 
UnacknowledgedDeleteResult() - Constructor for class com.mongodb.client.result.DeleteResult.UnacknowledgedDeleteResult
 
UnacknowledgedUpdateResult() - Constructor for class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
UnacknowledgedWriteResultCallback(SingleResultCallback<WriteConcernResult>, RequestMessage, OutputBuffer, InternalConnection, long) - Constructor for class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
uncompress(ByteBuf, ByteBuf) - Method in class com.mongodb.connection.Compressor
 
uncompressedSize - Variable in class com.mongodb.connection.CompressedHeader
 
UNDEFINED - Static variable in class org.bson.BSON
 
undefinedConverter - Variable in class org.bson.json.JsonWriterSettings.Builder
 
undefinedConverter(Converter<BsonUndefined>) - Method in class org.bson.json.JsonWriterSettings.Builder
Sets the converter from BSON Undefined values to JSON.
undefinedConverter - Variable in class org.bson.json.JsonWriterSettings
 
UndefinedSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.UndefinedSerializer
Deprecated.
 
underlying - Variable in class com.mongodb.async.client.gridfs.GridFSFindIterableImpl
 
underlying - Variable in class com.mongodb.client.gridfs.GridFSFindIterableImpl
 
unique - Variable in class com.mongodb.bulk.IndexRequest
 
unique(boolean) - Method in class com.mongodb.bulk.IndexRequest
Should the index should be unique.
unique - Variable in class com.mongodb.client.model.IndexOptions
 
unique(boolean) - Method in class com.mongodb.client.model.IndexOptions
Should the index should be unique.
UNIQUE_DOCS - Static variable in class com.mongodb.QueryOperators
 
unlock() - Method in class com.mongodb.Mongo
Unlocks the database, allowing the write operations to go through.
UnmodifiableIterator(Iterator<T>) - Constructor for class org.bson.util.AbstractCopyOnWriteMap.UnmodifiableIterator
 
unprocessed - Variable in class com.mongodb.operation.BulkWriteBatch
 
unread(int) - Method in class org.bson.json.JsonBuffer
 
unregisterMBean(String) - Method in class com.mongodb.internal.management.jmx.JMXMBeanServer
 
unregisterMBean(String) - Method in interface com.mongodb.management.MBeanServer
Unregister the MBean with the given name.
unregisterMBean(String) - Method in class com.mongodb.management.NullMBeanServer
 
unset(String) - Static method in class com.mongodb.client.model.Updates
Creates an update that deletes the field with the given name.
UnsignedLongs - Class in org.bson.internal
Utilities for treating long values as unsigned.
UnsignedLongs() - Constructor for class org.bson.internal.UnsignedLongs
 
unsubscribe() - Method in class com.mongodb.async.client.AbstractSubscription
 
unsubscribe() - Method in interface com.mongodb.async.client.Subscription
Request the Observable to stop sending data and clean up resources.
unsupported - Variable in enum org.bson.codecs.PatternCodec.RegexFlag
 
unwind(String) - Static method in class com.mongodb.client.model.Aggregates
Creates a $unwind pipeline stage for the specified field name, which must be prefixed by a '$' sign.
unwind(String, UnwindOptions) - Static method in class com.mongodb.client.model.Aggregates
Creates a $unwind pipeline stage for the specified field name, which must be prefixed by a '$' sign.
UnwindOptions - Class in com.mongodb.client.model
The options for an unwind aggregation pipeline stage
UnwindOptions() - Constructor for class com.mongodb.client.model.UnwindOptions
 
unwrap(byte[], int, int) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
unwrapped - Variable in class org.bson.BsonDocumentWrapper
 
update - Variable in class com.mongodb.bulk.UpdateRequest
 
update(DBObject) - Method in class com.mongodb.BulkUpdateRequestBuilder
Adds a request to update all documents in the collection that match the query with which this builder was created.
update(DBObject) - Method in class com.mongodb.BulkWriteRequestBuilder
Adds a request to update all documents in the collection that match the query with which this builder was created.
update - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
update(DBObject) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the update
update - Variable in class com.mongodb.client.model.UpdateManyModel
 
update - Variable in class com.mongodb.client.model.UpdateOneModel
 
update(MongoNamespace, boolean, UpdateRequest) - Method in interface com.mongodb.connection.Connection
Update the documents using the update wire protocol and apply the write concern.
update(MongoNamespace, boolean, UpdateRequest) - Method in class com.mongodb.connection.DefaultServerConnection
 
update(DBObject, DBObject, boolean, boolean, WriteConcern) - Method in class com.mongodb.DBCollection
Modify an existing document or documents in collection.
update(DBObject, DBObject, boolean, boolean, WriteConcern, DBEncoder) - Method in class com.mongodb.DBCollection
Modify an existing document or documents in collection.
update(DBObject, DBObject, boolean, boolean, WriteConcern, Boolean, DBEncoder) - Method in class com.mongodb.DBCollection
Modify an existing document or documents in collection.
update(DBObject, DBObject, boolean, boolean) - Method in class com.mongodb.DBCollection
Modify an existing document or documents in collection.
update(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Modify an existing document.
update(DBObject, DBObject, DBCollectionUpdateOptions) - Method in class com.mongodb.DBCollection
Modify an existing document or documents in collection.
update(Class<? extends DBObject>) - Method in class com.mongodb.DBCollectionObjectFactory
 
update(Class<? extends DBObject>, List<String>) - Method in class com.mongodb.DBCollectionObjectFactory
 
update - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
update - Variable in class com.mongodb.UpdateRequest
 
updateAsync(MongoNamespace, boolean, UpdateRequest, SingleResultCallback<WriteConcernResult>) - Method in interface com.mongodb.connection.AsyncConnection
Update the documents using the update wire protocol and apply the write concern asynchronously.
updateAsync(MongoNamespace, boolean, UpdateRequest, SingleResultCallback<WriteConcernResult>) - Method in class com.mongodb.connection.DefaultServerConnection
 
updateDescription - Variable in class com.mongodb.client.model.changestream.ChangeStreamDocument
 
UpdateDescription - Class in com.mongodb.client.model.changestream
The update description for changed fields in a $changeStream operation.
UpdateDescription(List<String>, BsonDocument) - Constructor for class com.mongodb.client.model.changestream.UpdateDescription
Creates a new instance
updateDescription(ClusterDescription) - Method in class com.mongodb.connection.BaseCluster
 
updateDescription() - Method in class com.mongodb.connection.MultiServerCluster
 
updatedFields - Variable in class com.mongodb.client.model.changestream.UpdateDescription
 
UpdateFieldNameValidator - Class in com.mongodb.internal.validator
A field name validator for update documents.
UpdateFieldNameValidator() - Constructor for class com.mongodb.internal.validator.UpdateFieldNameValidator
 
updateMany(Bson, Bson, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(ClientSession, Bson, Bson, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(ClientSession, Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(Bson, Bson, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateMany(Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateMany(ClientSession, Bson, Bson, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateMany(ClientSession, Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateMany(Bson, Bson) - Method in interface com.mongodb.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(Bson, Bson, UpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(ClientSession, Bson, Bson) - Method in interface com.mongodb.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(ClientSession, Bson, Bson, UpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Update all documents in the collection according to the specified arguments.
updateMany(Bson, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
updateMany(Bson, Bson, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
updateMany(ClientSession, Bson, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
updateMany(ClientSession, Bson, Bson, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
UpdateManyModel<T> - Class in com.mongodb.client.model
A model describing an update to all documents that matches the query filter.
UpdateManyModel(Bson, Bson) - Constructor for class com.mongodb.client.model.UpdateManyModel
Construct a new instance.
UpdateManyModel(Bson, Bson, UpdateOptions) - Constructor for class com.mongodb.client.model.UpdateManyModel
Construct a new instance.
UpdateMessage - Class in com.mongodb.connection
An OP_UPDATE message.
UpdateMessage(String, UpdateRequest, MessageSettings) - Constructor for class com.mongodb.connection.UpdateMessage
 
updateMulti(DBObject, DBObject) - Method in class com.mongodb.DBCollection
Modify documents in collection.
updateOfExisting - Variable in class com.mongodb.WriteResult
 
updateOne(Bson, Bson, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(ClientSession, Bson, Bson, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(ClientSession, Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in interface com.mongodb.async.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(Bson, Bson, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateOne(Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateOne(ClientSession, Bson, Bson, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateOne(ClientSession, Bson, Bson, UpdateOptions, SingleResultCallback<UpdateResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
updateOne(DBObject) - Method in class com.mongodb.BulkUpdateRequestBuilder
Adds a request to update one document in the collection that matches the query with which this builder was created.
updateOne(DBObject) - Method in class com.mongodb.BulkWriteRequestBuilder
Adds a request to update one document in the collection that matches the query with which this builder was created.
updateOne(Bson, Bson) - Method in interface com.mongodb.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(Bson, Bson, UpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(ClientSession, Bson, Bson) - Method in interface com.mongodb.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(ClientSession, Bson, Bson, UpdateOptions) - Method in interface com.mongodb.client.MongoCollection
Update a single document in the collection according to the specified arguments.
updateOne(Bson, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
updateOne(Bson, Bson, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
updateOne(ClientSession, Bson, Bson) - Method in class com.mongodb.MongoCollectionImpl
 
updateOne(ClientSession, Bson, Bson, UpdateOptions) - Method in class com.mongodb.MongoCollectionImpl
 
UpdateOneModel<T> - Class in com.mongodb.client.model
A model describing an update to at most one document that matches the query filter.
UpdateOneModel(Bson, Bson) - Constructor for class com.mongodb.client.model.UpdateOneModel
Construct a new instance.
UpdateOneModel(Bson, Bson, UpdateOptions) - Constructor for class com.mongodb.client.model.UpdateOneModel
Construct a new instance.
UpdateOperation - Class in com.mongodb.operation
An operation that updates a document in a collection.
UpdateOperation(MongoNamespace, boolean, WriteConcern, List<UpdateRequest>) - Constructor for class com.mongodb.operation.UpdateOperation
UpdateOperation(MongoNamespace, boolean, WriteConcern, boolean, List<UpdateRequest>) - Constructor for class com.mongodb.operation.UpdateOperation
Construct an instance.
UpdateOptions - Class in com.mongodb.client.model
The options to apply when updating documents.
UpdateOptions() - Constructor for class com.mongodb.client.model.UpdateOptions
 
updatePathToClassMap(Class<? extends DBObject>, List<String>) - Method in class com.mongodb.DBCollectionObjectFactory
 
UpdateProtocol - Class in com.mongodb.connection
An implementation of the MongoDB OP_UPDATE wire protocol.
UpdateProtocol(MongoNamespace, boolean, UpdateRequest) - Constructor for class com.mongodb.connection.UpdateProtocol
 
UpdateRequest - Class in com.mongodb.bulk
An update to one or more documents.
UpdateRequest(BsonDocument, BsonDocument, WriteRequest.Type) - Constructor for class com.mongodb.bulk.UpdateRequest
Construct a new instance.
updateRequest - Variable in class com.mongodb.connection.UpdateMessage
 
updateRequest - Variable in class com.mongodb.connection.UpdateProtocol
 
UpdateRequest - Class in com.mongodb
 
UpdateRequest(DBObject, DBObject, boolean, boolean, Encoder<DBObject>, Collation, List<? extends DBObject>) - Constructor for class com.mongodb.UpdateRequest
 
UpdateResult - Class in com.mongodb.client.result
The result of an update operation.
UpdateResult() - Constructor for class com.mongodb.client.result.UpdateResult
 
UpdateResult.AcknowledgedUpdateResult - Class in com.mongodb.client.result
 
UpdateResult.UnacknowledgedUpdateResult - Class in com.mongodb.client.result
 
Updates - Class in com.mongodb.client.model
A factory for document updates.
Updates() - Constructor for class com.mongodb.client.model.Updates
 
updates - Variable in class com.mongodb.client.model.Updates.CompositeUpdate
 
updates - Variable in class com.mongodb.operation.UpdateOperation
 
Updates.CompositeUpdate - Class in com.mongodb.client.model
 
Updates.PullAllUpdate<TItem> - Class in com.mongodb.client.model
 
Updates.PushUpdate<TItem> - Class in com.mongodb.client.model
 
Updates.SimpleUpdate<TItem> - Class in com.mongodb.client.model
 
Updates.WithEachUpdate<TItem> - Class in com.mongodb.client.model
 
updateSessionContext(SessionContext, ResponseBuffers) - Method in class com.mongodb.connection.InternalStreamConnection
 
updateType - Variable in class com.mongodb.bulk.UpdateRequest
 
UpdateUserOperation - Class in com.mongodb.operation
An operation that updates a user.
UpdateUserOperation(MongoCredential, boolean) - Constructor for class com.mongodb.operation.UpdateUserOperation
UpdateUserOperation(MongoCredential, boolean, WriteConcern) - Constructor for class com.mongodb.operation.UpdateUserOperation
Construct a new instance.
uploadDate - Variable in class com.mongodb.client.gridfs.model.GridFSFile
 
uploadDate - Variable in class com.mongodb.gridfs.GridFSFile
 
uploadFromStream(String, AsyncInputStream, SingleResultCallback<ObjectId>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<ObjectId>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(BsonValue, String, AsyncInputStream, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(BsonValue, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(ClientSession, String, AsyncInputStream, SingleResultCallback<ObjectId>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(ClientSession, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<ObjectId>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(ClientSession, BsonValue, String, AsyncInputStream, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(ClientSession, BsonValue, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<Void>) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Uploads the contents of the given AsyncInputStream to a GridFS bucket.
uploadFromStream(String, AsyncInputStream, SingleResultCallback<ObjectId>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<ObjectId>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(BsonValue, String, AsyncInputStream, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(BsonValue, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, String, AsyncInputStream, SingleResultCallback<ObjectId>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<ObjectId>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, BsonValue, String, AsyncInputStream, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, BsonValue, String, AsyncInputStream, GridFSUploadOptions, SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
uploadFromStream(String, InputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(String, InputStream, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(BsonValue, String, InputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(BsonValue, String, InputStream, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(ClientSession, String, InputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(ClientSession, String, InputStream, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(ClientSession, BsonValue, String, InputStream) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(ClientSession, BsonValue, String, InputStream, GridFSUploadOptions) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Uploads the contents of the given InputStream to a GridFS bucket.
uploadFromStream(String, InputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(String, InputStream, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(BsonValue, String, InputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(BsonValue, String, InputStream, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, String, InputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, String, InputStream, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, BsonValue, String, InputStream) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
uploadFromStream(ClientSession, BsonValue, String, InputStream, GridFSUploadOptions) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
upsert(boolean) - Method in class com.mongodb.bulk.UpdateRequest
Sets whether this update will insert a new document if no documents match the filter.
upsert - Variable in class com.mongodb.BulkUpdateRequestBuilder
 
upsert() - Method in class com.mongodb.BulkWriteRequestBuilder
Specifies that the request being built should be an upsert.
upsert - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
upsert(boolean) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the upsert
upsert - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
upsert(boolean) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Set to true if a new document should be inserted if there are no matches to the query filter.
upsert - Variable in class com.mongodb.client.model.FindOneAndReplaceOptions
 
upsert(boolean) - Method in class com.mongodb.client.model.FindOneAndReplaceOptions
Set to true if a new document should be inserted if there are no matches to the query filter.
upsert - Variable in class com.mongodb.client.model.FindOneAndUpdateOptions
 
upsert(boolean) - Method in class com.mongodb.client.model.FindOneAndUpdateOptions
Set to true if a new document should be inserted if there are no matches to the query filter.
upsert - Variable in class com.mongodb.client.model.UpdateOptions
 
upsert(boolean) - Method in class com.mongodb.client.model.UpdateOptions
Set to true if a new document should be inserted if there are no matches to the query filter.
upsert - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
upsert(boolean) - Method in class com.mongodb.operation.FindAndReplaceOperation
Set to true if a new document should be inserted if there are no matches to the query filter.
upsert - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
upsert(boolean) - Method in class com.mongodb.operation.FindAndUpdateOperation
Set to true if a new document should be inserted if there are no matches to the query filter.
upsert - Variable in class com.mongodb.ReplaceRequest
 
upsert - Variable in class com.mongodb.UpdateRequest
 
upsertedId - Variable in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
upsertedId - Variable in class com.mongodb.WriteResult
 
upserts - Variable in class com.mongodb.AcknowledgedBulkWriteResult
 
urldecode(String) - Method in class com.mongodb.ConnectionString
 
urldecode(String, boolean) - Method in class com.mongodb.ConnectionString
 
usable(ConcurrentLinkedDeque.Node<?>) - Static method in class com.mongodb.internal.connection.ConcurrentLinkedDeque
Returns true if given reference is non-null and isn't a header, trailer, or marker.
UsageTrackingInternalConnection - Class in com.mongodb.connection
A connection that tracks when it was opened and when it was last used.
UsageTrackingInternalConnection(InternalConnection, int) - Constructor for class com.mongodb.connection.UsageTrackingInternalConnection
 
UsageTrackingInternalConnectionItemFactory(InternalConnectionFactory) - Constructor for class com.mongodb.connection.DefaultConnectionPool.UsageTrackingInternalConnectionItemFactory
 
USE_GETTERS_FOR_SETTERS - Static variable in class org.bson.codecs.pojo.Conventions
A convention that uses getter methods as setters for collections and maps if there is no setter.
USE_SLF4J - Static variable in class com.mongodb.diagnostics.logging.Loggers
 
USE_SLF4J - Static variable in class org.bson.diagnostics.Loggers
 
useCursor - Variable in class com.mongodb.AggregateIterableImpl
 
useCursor(Boolean) - Method in class com.mongodb.AggregateIterableImpl
Deprecated.
useCursor(Boolean) - Method in interface com.mongodb.async.client.AggregateIterable
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
useCursor - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
useCursor(Boolean) - Method in class com.mongodb.async.client.AggregateIterableImpl
Deprecated.
useCursor(Boolean) - Method in interface com.mongodb.client.AggregateIterable
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
useCursor - Variable in class com.mongodb.operation.AggregateOperation
 
useCursor(Boolean) - Method in class com.mongodb.operation.AggregateOperation
Deprecated.
There is no replacement for this. Applications can assume that the driver will use a cursor for server versions that support it (>= 2.6). The driver will ignore this as of MongoDB 3.6, which does not support inline results for the aggregate command.
useDiscriminator() - Method in class org.bson.codecs.pojo.ClassModel
 
useDiscriminator() - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
useDiscriminator - Variable in class org.bson.codecs.pojo.PropertyModel
 
useDiscriminator() - Method in class org.bson.codecs.pojo.PropertyModel
 
useOpMsg() - Method in class com.mongodb.connection.CommandMessage
 
usePowerOf2Sizes - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
usePowerOf2Sizes(Boolean) - Method in class com.mongodb.client.model.CreateCollectionOptions
Deprecated.
As of MongoDB 3.0, power of 2 sizes is ignored by the MongoDB server
usePowerOf2Sizes - Variable in class com.mongodb.operation.CreateCollectionOperation
 
usePowerOf2Sizes(Boolean) - Method in class com.mongodb.operation.CreateCollectionOperation
Deprecated.
As of MongoDB 3.0, power of 2 sizes is ignored by the MongoDB server
userCommandCallback(SingleResultCallback<Void>) - Static method in class com.mongodb.operation.UserOperationHelper
 
UserExistsOperation - Class in com.mongodb.operation
An operation that determines if a user exists.
UserExistsOperation(String, String) - Constructor for class com.mongodb.operation.UserExistsOperation
Construct a new instance.
userName - Variable in class com.mongodb.MongoCredential
 
userName - Variable in class com.mongodb.operation.DropUserOperation
 
userName - Variable in class com.mongodb.operation.UserExistsOperation
 
UserOperationHelper - Class in com.mongodb.operation
 
UserOperationHelper() - Constructor for class com.mongodb.operation.UserOperationHelper
 
UTF8_CHARSET - Static variable in class org.bson.io.ByteBufferBsonInput
 
UTF_8 - Static variable in class com.mongodb.ConnectionString
 
UTF_8_CHARSET - Static variable in class com.mongodb.internal.authentication.NativeAuthenticationHelper
 
Util - Class in com.mongodb.util
General utilities that are useful throughout the driver.
Util() - Constructor for class com.mongodb.util.Util
 
UuidCodec - Class in org.bson.codecs
Encodes and decodes UUID objects.
UuidCodec(UuidRepresentation) - Constructor for class org.bson.codecs.UuidCodec
The default UUIDRepresentation is JAVA_LEGACY to be compatible with existing documents
UuidCodec() - Constructor for class org.bson.codecs.UuidCodec
The constructor for UUIDCodec, default is JAVA_LEGACY
UuidCodecHelper - Class in org.bson.codecs
 
UuidCodecHelper() - Constructor for class org.bson.codecs.UuidCodecHelper
 
UuidCodecProvider - Class in org.bson.codecs
A CodecProvider for UUID Codecs with custom UUID representations
UuidCodecProvider(UuidRepresentation) - Constructor for class org.bson.codecs.UuidCodecProvider
Set the UUIDRepresentation to be used in the codec default is JAVA_LEGACY to be compatible with existing documents
uuidRepresentation - Variable in class org.bson.codecs.UuidCodecProvider
 
UuidRepresentation - Enum in org.bson
The representation to use when converting a UUID to a BSON binary value.
UuidRepresentation() - Constructor for enum org.bson.UuidRepresentation
 
UuidSerializer(ObjectSerializer) - Constructor for class com.mongodb.util.JSONSerializers.UuidSerializer
Deprecated.
 

V

VALID_ACTIONS - Static variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
VALID_FIELDS - Static variable in class com.mongodb.client.gridfs.codecs.GridFSFileCodec
 
VALID_FIELDS - Static variable in class com.mongodb.gridfs.GridFSFile
 
VALID_SPHERE_INDEX_VERSIONS - Static variable in class com.mongodb.bulk.IndexRequest
 
VALID_TEXT_INDEX_VERSIONS - Static variable in class com.mongodb.bulk.IndexRequest
 
validate() - Method in class com.mongodb.gridfs.GridFSFile
Verifies that the MD5 matches between the database and the local file.
validate(String) - Method in class com.mongodb.internal.validator.CollectibleDocumentFieldNameValidator
 
validate(String) - Method in class com.mongodb.internal.validator.MappedFieldNameValidator
 
validate(String) - Method in class com.mongodb.internal.validator.NoOpFieldNameValidator
 
validate(String) - Method in class com.mongodb.internal.validator.UpdateFieldNameValidator
 
validate(String) - Method in interface org.bson.FieldNameValidator
Returns true if the field name is valid, false otherwise.
validate(String) - Method in class org.bson.NoOpFieldNameValidator
 
validateCollation(Connection, Collation) - Static method in class com.mongodb.operation.OperationHelper
 
validateCollation(ConnectionDescription, Collation) - Static method in class com.mongodb.operation.OperationHelper
 
validateCollation(AsyncConnection, Collation, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
validateCollation(AsyncConnectionSource, AsyncConnection, Collation, OperationHelper.AsyncCallableWithConnectionAndSource) - Static method in class com.mongodb.operation.OperationHelper
 
validateCollationAndWriteConcern(ConnectionDescription, Collation, WriteConcern) - Static method in class com.mongodb.operation.OperationHelper
 
validateIndexRequestCollations(Connection, List<IndexRequest>) - Static method in class com.mongodb.operation.OperationHelper
 
validateIndexRequestCollations(AsyncConnection, List<IndexRequest>, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
validateIsArray(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
validateIsDocument(BsonReader) - Static method in class com.mongodb.client.model.geojson.codecs.GeometryDecoderHelper
 
validatePort(String, String) - Method in class com.mongodb.ConnectionString
 
validatePropertyModels(String, List<PropertyModel<?>>) - Method in class org.bson.codecs.pojo.ClassModelBuilder
 
validateReadConcern(Connection, ReadConcern) - Static method in class com.mongodb.operation.OperationHelper
 
validateReadConcern(AsyncConnection, ReadConcern, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
validateReadConcern(AsyncConnectionSource, AsyncConnection, ReadConcern, OperationHelper.AsyncCallableWithConnectionAndSource) - Static method in class com.mongodb.operation.OperationHelper
 
validateReadConcernAndCollation(Connection, ReadConcern, Collation) - Static method in class com.mongodb.operation.OperationHelper
 
validateReadConcernAndCollation(AsyncConnection, ReadConcern, Collation, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
validateReadConcernAndCollation(AsyncConnectionSource, AsyncConnection, ReadConcern, Collation, OperationHelper.AsyncCallableWithConnectionAndSource) - Static method in class com.mongodb.operation.OperationHelper
 
validateSize(int) - Method in class org.bson.BsonBinaryWriter
 
validateUserName(ConnectionDescription) - Method in class com.mongodb.connection.X509Authenticator
 
validateWriteRequestCollations(ConnectionDescription, List<? extends WriteRequest>, WriteConcern) - Static method in class com.mongodb.operation.OperationHelper
 
validateWriteRequests(ConnectionDescription, Boolean, List<? extends WriteRequest>, WriteConcern) - Static method in class com.mongodb.operation.OperationHelper
 
validateWriteRequests(AsyncConnection, Boolean, List<? extends WriteRequest>, WriteConcern, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
validateWriteRequestsAndReleaseConnectionIfError(Connection) - Method in class com.mongodb.operation.MixedBulkWriteOperation
 
ValidationAction - Enum in com.mongodb.client.model
Determines whether to error on invalid documents or just warn about the violations but allow invalid documents.
ValidationAction(String) - Constructor for enum com.mongodb.client.model.ValidationAction
 
validationAction - Variable in class com.mongodb.client.model.ValidationOptions
 
validationAction(ValidationAction) - Method in class com.mongodb.client.model.ValidationOptions
Sets the ValidationAction that determines whether to error on invalid documents or just warn about the violations but allow invalid documents.
validationAction - Variable in class com.mongodb.operation.CreateCollectionOperation
 
validationAction(ValidationAction) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the ValidationAction that determines whether to error on invalid documents or just warn about the violations but allow invalid documents.
ValidationLevel - Enum in com.mongodb.client.model
Determines how strictly MongoDB applies the validation rules to existing documents during an insert or update.
ValidationLevel(String) - Constructor for enum com.mongodb.client.model.ValidationLevel
 
validationLevel - Variable in class com.mongodb.client.model.ValidationOptions
 
validationLevel(ValidationLevel) - Method in class com.mongodb.client.model.ValidationOptions
Sets the validation level that determines how strictly MongoDB applies the validation rules to existing documents during an insert or update.
validationLevel - Variable in class com.mongodb.operation.CreateCollectionOperation
 
validationLevel(ValidationLevel) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the validation level that determines how strictly MongoDB applies the validation rules to existing documents during an insert or update.
validationOptions - Variable in class com.mongodb.client.model.CreateCollectionOptions
 
validationOptions(ValidationOptions) - Method in class com.mongodb.client.model.CreateCollectionOptions
Sets the validation options for documents being inserted or updated in a collection
ValidationOptions - Class in com.mongodb.client.model
Validation options for documents being inserted or updated in a collection
ValidationOptions() - Constructor for class com.mongodb.client.model.ValidationOptions
 
validator - Variable in class com.mongodb.client.model.ValidationOptions
 
validator(Bson) - Method in class com.mongodb.client.model.ValidationOptions
Sets the validation rules for all
validator - Variable in class com.mongodb.operation.CreateCollectionOperation
 
validator(BsonDocument) - Method in class com.mongodb.operation.CreateCollectionOperation
Sets the validation rules for inserting or updating documents
value - Variable in class com.mongodb.client.model.Aggregates.ReplaceRootStage
 
value - Variable in class com.mongodb.client.model.Aggregates.SimplePipelineStage
 
value - Variable in class com.mongodb.client.model.BsonField
 
value - Variable in enum com.mongodb.client.model.BucketGranularity
 
value - Variable in enum com.mongodb.client.model.changestream.FullDocument
 
value - Variable in enum com.mongodb.client.model.changestream.OperationType
 
value - Variable in enum com.mongodb.client.model.CollationAlternate
 
value - Variable in enum com.mongodb.client.model.CollationCaseFirst
 
value - Variable in enum com.mongodb.client.model.CollationMaxVariable
 
value - Variable in class com.mongodb.client.model.Field
 
value - Variable in class com.mongodb.client.model.Filters.OperatorFilter
 
value - Variable in class com.mongodb.client.model.Filters.SimpleEncodingFilter
 
value - Variable in class com.mongodb.client.model.Filters.SimpleFilter
 
value - Variable in enum com.mongodb.client.model.MapReduceAction
 
value - Variable in class com.mongodb.client.model.Updates.SimpleUpdate
 
value - Variable in enum com.mongodb.client.model.ValidationAction
 
value - Variable in enum com.mongodb.client.model.ValidationLevel
 
value - Variable in class com.mongodb.connection.ClusterId
 
value - Variable in enum com.mongodb.connection.OpCode
 
value - Variable in enum com.mongodb.ReadConcernLevel
 
value - Variable in class com.mongodb.Tag
 
value - Variable in enum org.bson.BsonBinarySubType
 
value - Variable in class org.bson.BsonBoolean
 
value - Variable in class org.bson.BsonDateTime
 
value - Variable in class org.bson.BsonDecimal128
 
value - Variable in class org.bson.BsonDouble
 
value - Variable in class org.bson.BsonElement
 
value - Variable in class org.bson.BsonInt32
 
value - Variable in class org.bson.BsonInt64
 
VALUE - Static variable in class org.bson.BsonNull
 
value - Variable in class org.bson.BsonObjectId
 
value - Variable in class org.bson.BsonString
 
value - Variable in class org.bson.BsonTimestamp
 
value - Variable in enum org.bson.BsonType
 
value - Variable in class org.bson.codecs.configuration.Optional.Some
 
value - Variable in class org.bson.json.JsonToken
 
ValueCodecProvider - Class in org.bson.codecs
A Codec provider for dynamically-typed value classes.
ValueCodecProvider() - Constructor for class org.bson.codecs.ValueCodecProvider
A provider of Codecs for simple value types.
valueOf(String) - Static method in enum com.mongodb.AggregationOptions.OutputMode
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.AuthenticationMechanism
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.bulk.WriteRequest.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.BucketGranularity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.changestream.FullDocument
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.changestream.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.CollationAlternate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.CollationCaseFirst
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.CollationMaxVariable
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.CollationStrength
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.Filters.OrNorFilter.Operator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.geojson.CoordinateReferenceSystemType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.geojson.GeoJsonObjectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.MapReduceAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.ReturnDocument
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.ValidationAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.client.model.ValidationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.connection.ClusterConnectionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.connection.ClusterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.connection.OpCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.connection.ServerConnectionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.connection.ServerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.connection.SplittablePayload.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.CursorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.DBCursor.IteratorOrArray
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.ErrorCategory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.ExplainVerbosity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.internal.connection.ConcurrentPool.Prune
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.MapReduceCommand.OutputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.operation.OrderBy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.mongodb.ReadConcernLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class com.mongodb.ReadPreference
Creates a read preference from the given read preference name.
valueOf(String, List<TagSet>) - Static method in class com.mongodb.ReadPreference
Creates a taggable read preference from the given read preference name and list of tag sets.
valueOf(String, List<TagSet>, long, TimeUnit) - Static method in class com.mongodb.ReadPreference
Creates a taggable read preference from the given read preference name, list of tag sets, and max allowable staleness of secondaries.
valueOf(String, List<TagSet>, Long, TimeUnit) - Static method in class com.mongodb.ReadPreference
 
valueOf(String) - Static method in class com.mongodb.WriteConcern
Gets the WriteConcern constants by name (matching is done case insensitively).
valueOf(String) - Static method in enum org.bson.AbstractBsonReader.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.AbstractBsonWriter.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.BsonBinarySubType
Returns the enum constant of this type with the specified name.
valueOf(boolean) - Static method in class org.bson.BsonBoolean
Returns a BsonBoolean instance representing the specified boolean value.
valueOf(String) - Static method in enum org.bson.BsonContextType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.BsonType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.codecs.PatternCodec.RegexFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.codecs.pojo.PojoBuilderHelper.PropertyTypeCheck
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.json.JsonMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.json.JsonScanner.NumberState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.json.JsonScanner.RegularExpressionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.json.JsonTokenType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.json.StrictCharacterStreamJsonWriter.JsonContextType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.json.StrictCharacterStreamJsonWriter.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.util.AbstractCopyOnWriteMap.View.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.bson.UuidRepresentation
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.mongodb.AggregationOptions.OutputMode
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.AuthenticationMechanism
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.bulk.WriteRequest.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.BucketGranularity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.changestream.FullDocument
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.changestream.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.CollationAlternate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.CollationCaseFirst
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.CollationMaxVariable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.CollationStrength
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.mongodb.client.model.Filters.IterableOperatorFilter
 
values() - Static method in enum com.mongodb.client.model.Filters.OrNorFilter.Operator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.geojson.CoordinateReferenceSystemType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.geojson.GeoJsonObjectType
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.mongodb.client.model.geojson.Position
 
values() - Static method in enum com.mongodb.client.model.MapReduceAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.ReturnDocument
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class com.mongodb.client.model.Updates.PullAllUpdate
 
values - Variable in class com.mongodb.client.model.Updates.WithEachUpdate
 
values() - Static method in enum com.mongodb.client.model.ValidationAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.client.model.ValidationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
values() - Static method in enum com.mongodb.connection.ClusterConnectionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.connection.ClusterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.connection.OpCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.connection.ServerConnectionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.connection.ServerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.connection.SplittablePayload.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.CursorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.DBCursor.IteratorOrArray
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.ErrorCategory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.ExplainVerbosity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.internal.connection.ConcurrentPool.Prune
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.MapReduceCommand.OutputType
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in class com.mongodb.operation.DistinctOperation
 
values() - Static method in enum com.mongodb.operation.OrderBy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.mongodb.ReadConcernLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.AbstractBsonReader.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.AbstractBsonWriter.State
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.bson.BsonArray
 
values() - Static method in enum org.bson.BsonBinarySubType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.BsonContextType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.bson.BsonDocument
 
values() - Method in class org.bson.BsonDocumentWrapper
 
values() - Static method in enum org.bson.BsonType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.codecs.PatternCodec.RegexFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.codecs.pojo.PojoBuilderHelper.PropertyTypeCheck
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.bson.Document
 
values() - Static method in enum org.bson.json.JsonMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.json.JsonScanner.NumberState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.json.JsonScanner.RegularExpressionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.json.JsonTokenType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.json.StrictCharacterStreamJsonWriter.JsonContextType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.bson.json.StrictCharacterStreamJsonWriter.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.bson.RawBsonDocument
 
values() - Method in class org.bson.util.AbstractCopyOnWriteMap.Immutable
 
values - Variable in class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
values() - Method in class org.bson.util.AbstractCopyOnWriteMap.Mutable
 
values() - Method in class org.bson.util.AbstractCopyOnWriteMap
 
Values() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.Values
 
values() - Static method in enum org.bson.util.AbstractCopyOnWriteMap.View.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.bson.util.AbstractCopyOnWriteMap.View
 
values() - Method in class org.bson.util.ComputingMap
 
values() - Static method in enum org.bson.UuidRepresentation
Returns an array containing the constants of this enum type, in the order they are declared.
valueTransformer - Variable in class org.bson.codecs.DocumentCodec
 
valueTransformer - Variable in class org.bson.codecs.DocumentCodecProvider
 
valueTransformer - Variable in class org.bson.codecs.IterableCodec
 
valueTransformer - Variable in class org.bson.codecs.IterableCodecProvider
 
valueTransformer - Variable in class org.bson.codecs.MapCodec
 
valueTransformer - Variable in class org.bson.codecs.MapCodecProvider
 
verbose(boolean) - Method in interface com.mongodb.async.client.MapReduceIterable
Sets whether to include the timing information in the result information.
verbose - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
verbose(boolean) - Method in class com.mongodb.async.client.MapReduceIterableImpl
 
verbose(boolean) - Method in interface com.mongodb.client.MapReduceIterable
Sets whether to include the timing information in the result information.
verbose - Variable in class com.mongodb.MapReduceCommand
 
verbose - Variable in class com.mongodb.MapReduceIterableImpl
 
verbose(boolean) - Method in class com.mongodb.MapReduceIterableImpl
 
verbose - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
verbose(boolean) - Method in class com.mongodb.operation.MapReduceToCollectionOperation
Sets whether to include the timing information in the result information.
verbose - Variable in class com.mongodb.operation.MapReduceWithInlineResultsOperation
 
verbose(boolean) - Method in class com.mongodb.operation.MapReduceWithInlineResultsOperation
Sets whether to include the timing information in the result information.
verifyBSONType(String, BsonType) - Method in class org.bson.AbstractBsonReader
Verifies the current state and BSONType of the reader.
verifyForDBRef(DBObject) - Method in class com.mongodb.DBObjectCodec
 
verifyName(String) - Method in class org.bson.AbstractBsonReader
Verifies the name of the current element.
verifyString(String) - Method in class org.bson.json.JsonReader
 
verifyToken(JsonTokenType) - Method in class org.bson.json.JsonReader
 
verifyToken(JsonTokenType, Object) - Method in class org.bson.json.JsonReader
 
version - Variable in class com.mongodb.bulk.IndexRequest
 
version(Integer) - Method in class com.mongodb.bulk.IndexRequest
Sets the index version number.
version - Variable in class com.mongodb.client.model.IndexOptions
 
version(Integer) - Method in class com.mongodb.client.model.IndexOptions
Sets the index version number.
version - Variable in class com.mongodb.connection.ServerDescription.Builder
 
version(ServerVersion) - Method in class com.mongodb.connection.ServerDescription.Builder
Sets the server version
version - Variable in class com.mongodb.connection.ServerDescription
 
versionList - Variable in class com.mongodb.connection.ServerVersion
 
view - Variable in class org.bson.util.AbstractCopyOnWriteMap
 
View() - Constructor for class org.bson.util.AbstractCopyOnWriteMap.View
 
viewName - Variable in class com.mongodb.operation.CreateViewOperation
 
viewOn - Variable in class com.mongodb.operation.CreateViewOperation
 
viewType - Variable in class org.bson.util.CopyOnWriteMap.Builder
 
visitBinDataConstructor() - Method in class org.bson.json.JsonReader
 
visitBinDataExtendedJson(String) - Method in class org.bson.json.JsonReader
 
visitDateTimeConstructor() - Method in class org.bson.json.JsonReader
 
visitDateTimeConstructorWithOutNew() - Method in class org.bson.json.JsonReader
 
visitDateTimeExtendedJson() - Method in class org.bson.json.JsonReader
 
visitDBPointerConstructor() - Method in class org.bson.json.JsonReader
 
visitDbPointerExtendedJson() - Method in class org.bson.json.JsonReader
 
visitEmptyConstructor() - Method in class org.bson.json.JsonReader
 
visitExtendedJSON() - Method in class org.bson.json.JsonReader
 
visitHexDataConstructor() - Method in class org.bson.json.JsonReader
 
visitISODateTimeConstructor() - Method in class org.bson.json.JsonReader
 
visitJavaScriptExtendedJson() - Method in class org.bson.json.JsonReader
 
visitLegacyBinaryExtendedJson(String) - Method in class org.bson.json.JsonReader
 
visitMaxKeyExtendedJson() - Method in class org.bson.json.JsonReader
 
visitMinKeyExtendedJson() - Method in class org.bson.json.JsonReader
 
visitNew() - Method in class org.bson.json.JsonReader
 
visitNewRegularExpressionExtendedJson() - Method in class org.bson.json.JsonReader
 
visitNumberDecimalConstructor() - Method in class org.bson.json.JsonReader
 
visitNumberDecimalExtendedJson() - Method in class org.bson.json.JsonReader
 
visitNumberDoubleExtendedJson() - Method in class org.bson.json.JsonReader
 
visitNumberIntConstructor() - Method in class org.bson.json.JsonReader
 
visitNumberIntExtendedJson() - Method in class org.bson.json.JsonReader
 
visitNumberLongConstructor() - Method in class org.bson.json.JsonReader
 
visitNumberLongExtendedJson() - Method in class org.bson.json.JsonReader
 
visitObjectIdConstructor() - Method in class org.bson.json.JsonReader
 
visitObjectIdExtendedJson() - Method in class org.bson.json.JsonReader
 
visitRegularExpressionConstructor() - Method in class org.bson.json.JsonReader
 
visitRegularExpressionExtendedJson(String) - Method in class org.bson.json.JsonReader
 
visitSymbolExtendedJson() - Method in class org.bson.json.JsonReader
 
visitTimestampConstructor() - Method in class org.bson.json.JsonReader
 
visitTimestampExtendedJson() - Method in class org.bson.json.JsonReader
 
visitUndefinedExtendedJson() - Method in class org.bson.json.JsonReader
 
visitUUIDConstructor(String) - Method in class org.bson.json.JsonReader
 

W

w - Variable in class com.mongodb.MongoOptions
Deprecated.
The "w" value, (number of writes), of the global WriteConcern.
w - Variable in class com.mongodb.WriteConcern
 
W1 - Static variable in class com.mongodb.WriteConcern
Write operations that use this write concern will wait for acknowledgement from a single member.
W2 - Static variable in class com.mongodb.WriteConcern
Write operations that use this write concern will wait for acknowledgement from two members.
W3 - Static variable in class com.mongodb.WriteConcern
Write operations that use this write concern will wait for acknowledgement from three members.
waitForNext() - Method in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
waitForSignalOrTimeout() - Method in class com.mongodb.connection.DefaultServerMonitor.ServerMonitorRunnable
 
waitQueue - Variable in class com.mongodb.connection.BaseCluster
 
waitQueueEntered(ConnectionPoolWaitQueueEnteredEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
waitQueueEntered(ConnectionPoolWaitQueueEnteredEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection pool's wait queue is entered.
waitQueueEntered(ConnectionPoolWaitQueueEnteredEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
waitQueueEntered(ConnectionPoolWaitQueueEnteredEvent) - Method in class com.mongodb.internal.event.ConnectionPoolListenerMulticaster
 
waitQueueEntered(ConnectionPoolWaitQueueEnteredEvent) - Method in class com.mongodb.management.ConnectionPoolStatistics
 
waitQueueEntered(ConnectionPoolWaitQueueEnteredEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
waitQueueExited(ConnectionPoolWaitQueueExitedEvent) - Method in class com.mongodb.event.ConnectionPoolEventMulticaster
Deprecated.
 
waitQueueExited(ConnectionPoolWaitQueueExitedEvent) - Method in interface com.mongodb.event.ConnectionPoolListener
Invoked when a connection pools wait queue is exited.
waitQueueExited(ConnectionPoolWaitQueueExitedEvent) - Method in class com.mongodb.event.ConnectionPoolListenerAdapter
 
waitQueueExited(ConnectionPoolWaitQueueExitedEvent) - Method in class com.mongodb.internal.event.ConnectionPoolListenerMulticaster
 
waitQueueExited(ConnectionPoolWaitQueueExitedEvent) - Method in class com.mongodb.management.ConnectionPoolStatistics
 
waitQueueExited(ConnectionPoolWaitQueueExitedEvent) - Method in class com.mongodb.management.JMXConnectionPoolListener
 
waitQueueHandler - Variable in class com.mongodb.connection.BaseCluster
 
WaitQueueHandler() - Constructor for class com.mongodb.connection.BaseCluster.WaitQueueHandler
 
waitQueueSize - Variable in class com.mongodb.connection.BaseCluster
 
waitQueueSize - Variable in class com.mongodb.connection.DefaultConnectionPool
 
waitQueueSize - Variable in class com.mongodb.management.ConnectionPoolStatistics
 
warn(String) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
warn(String, Throwable) - Method in class com.mongodb.diagnostics.logging.JULLogger
 
warn(String) - Method in interface com.mongodb.diagnostics.logging.Logger
Log a message at the WARN level.
warn(String, Throwable) - Method in interface com.mongodb.diagnostics.logging.Logger
Log an exception (throwable) at the WARN level with an accompanying message.
warn(String) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
warn(String, Throwable) - Method in class com.mongodb.diagnostics.logging.SLF4JLogger
 
warn(String) - Method in class org.bson.diagnostics.JULLogger
 
warn(String, Throwable) - Method in class org.bson.diagnostics.JULLogger
 
warn(String) - Method in interface org.bson.diagnostics.Logger
Log a message at the WARN level.
warn(String, Throwable) - Method in interface org.bson.diagnostics.Logger
Log an exception (throwable) at the WARN level with an accompanying message.
warn(String) - Method in class org.bson.diagnostics.SLF4JLogger
 
warn(String, Throwable) - Method in class org.bson.diagnostics.SLF4JLogger
 
warnOnUnsupportedOptions(Map<String, List<String>>) - Method in class com.mongodb.ConnectionString
 
wasAcknowledged() - Method in class com.mongodb.bulk.BulkWriteResult
Returns true if the write was acknowledged.
wasAcknowledged() - Method in class com.mongodb.client.result.DeleteResult.AcknowledgedDeleteResult
 
wasAcknowledged() - Method in class com.mongodb.client.result.DeleteResult.UnacknowledgedDeleteResult
 
wasAcknowledged() - Method in class com.mongodb.client.result.DeleteResult
Returns true if the write was acknowledged.
wasAcknowledged() - Method in class com.mongodb.client.result.UpdateResult.AcknowledgedUpdateResult
 
wasAcknowledged() - Method in class com.mongodb.client.result.UpdateResult.UnacknowledgedUpdateResult
 
wasAcknowledged() - Method in class com.mongodb.client.result.UpdateResult
Returns true if the write was acknowledged.
wasAcknowledged() - Method in class com.mongodb.WriteConcernResult
Returns true if the write was acknowledged.
wasAcknowledged() - Method in class com.mongodb.WriteResult
Returns true if the write was acknowledged.
watch() - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(List<? extends Bson>) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(List<? extends Bson>, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession, List<? extends Bson>) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession, List<? extends Bson>, Class<TResult>) - Method in interface com.mongodb.async.client.MongoCollection
Creates a change stream for this collection.
watch() - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(List<? extends Bson>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(ClientSession) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(ClientSession, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(ClientSession, List<? extends Bson>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
watch() - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(List<? extends Bson>) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(List<? extends Bson>, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession, List<? extends Bson>) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch(ClientSession, List<? extends Bson>, Class<TResult>) - Method in interface com.mongodb.client.MongoCollection
Creates a change stream for this collection.
watch() - Method in class com.mongodb.MongoCollectionImpl
 
watch(Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
watch(List<? extends Bson>) - Method in class com.mongodb.MongoCollectionImpl
 
watch(List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
watch(ClientSession) - Method in class com.mongodb.MongoCollectionImpl
 
watch(ClientSession, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
watch(ClientSession, List<? extends Bson>) - Method in class com.mongodb.MongoCollectionImpl
 
watch(ClientSession, List<? extends Bson>, Class<TResult>) - Method in class com.mongodb.MongoCollectionImpl
 
weights - Variable in class com.mongodb.bulk.IndexRequest
 
weights(BsonDocument) - Method in class com.mongodb.bulk.IndexRequest
Sets the weighting object for use with a text index.
weights - Variable in class com.mongodb.client.model.IndexOptions
 
weights(Bson) - Method in class com.mongodb.client.model.IndexOptions
Sets the weighting object for use with a text index.
where(String) - Static method in class com.mongodb.client.model.Filters
Creates a filter that matches all documents for which the given expression is true.
WHERE - Static variable in class com.mongodb.QueryOperators
 
withChunkSizeBytes(int) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a new chunk size in bytes.
withChunkSizeBytes(int) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
withChunkSizeBytes(int) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a new chunk size in bytes.
withChunkSizeBytes(int) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
withClientSession(ClientSession, SingleResultCallback<ClientSession>) - Method in class com.mongodb.async.client.ClientSessionHelper
 
withCodecRegistry(CodecRegistry) - Method in interface com.mongodb.async.client.MongoCollection
Create a new MongoCollection instance with a different codec registry.
withCodecRegistry(CodecRegistry) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
withCodecRegistry(CodecRegistry) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new MongoDatabase instance with a different codec registry.
withCodecRegistry(CodecRegistry) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
withCodecRegistry(CodecRegistry) - Method in interface com.mongodb.client.MongoCollection
Create a new MongoCollection instance with a different codec registry.
withCodecRegistry(CodecRegistry) - Method in interface com.mongodb.client.MongoDatabase
Create a new MongoDatabase instance with a different codec registry.
withCodecRegistry(CodecRegistry) - Method in class com.mongodb.MongoCollectionImpl
 
withCodecRegistry(CodecRegistry) - Method in class com.mongodb.MongoDatabaseImpl
 
withConnection(ReadBinding, OperationHelper.CallableWithConnection<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withConnection(ReadBinding, OperationHelper.CallableWithConnectionAndSource<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withConnection(WriteBinding, OperationHelper.CallableWithConnection<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withConnection(AsyncWriteBinding, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
withConnection(AsyncWriteBinding, OperationHelper.AsyncCallableWithConnectionAndSource) - Static method in class com.mongodb.operation.OperationHelper
 
withConnection(AsyncReadBinding, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
withConnection(AsyncReadBinding, OperationHelper.AsyncCallableWithConnectionAndSource) - Static method in class com.mongodb.operation.OperationHelper
 
withConnectionId(ConnectionId) - Method in class com.mongodb.connection.ConnectionDescription
 
withConnectionSource(ConnectionSource, OperationHelper.CallableWithConnection<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withConnectionSource(ConnectionSource, OperationHelper.CallableWithConnectionAndSource<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withConnectionSource(AsyncConnectionSource, OperationHelper.AsyncCallableWithConnection) - Static method in class com.mongodb.operation.OperationHelper
 
withConnectionSource(AsyncConnectionSource, OperationHelper.AsyncCallableWithConnectionAndSource) - Static method in class com.mongodb.operation.OperationHelper
 
withDocumentClass(Class<TDocument>) - Method in interface com.mongodb.async.client.ChangeStreamIterable
Returns a MongoIterable containing the results of the change stream based on the document class provided.
withDocumentClass(Class<TDocument>) - Method in class com.mongodb.async.client.ChangeStreamIterableImpl
 
withDocumentClass(Class<NewTDocument>) - Method in interface com.mongodb.async.client.MongoCollection
Create a new MongoCollection instance with a different default class to cast any documents returned from the database into..
withDocumentClass(Class<NewTDocument>) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
withDocumentClass(Class<TDocument>) - Method in class com.mongodb.ChangeStreamIterableImpl
 
withDocumentClass(Class<TDocument>) - Method in interface com.mongodb.client.ChangeStreamIterable
Returns a MongoIterable containing the results of the change stream based on the document class provided.
withDocumentClass(Class<NewTDocument>) - Method in interface com.mongodb.client.MongoCollection
Create a new MongoCollection instance with a different default class to cast any documents returned from the database into..
withDocumentClass(Class<NewTDocument>) - Method in class com.mongodb.MongoCollectionImpl
 
WithEachUpdate(String, List<TItem>, String) - Constructor for class com.mongodb.client.model.Updates.WithEachUpdate
 
withFsync(boolean) - Method in class com.mongodb.WriteConcern
WITHIN - Static variable in class com.mongodb.QueryOperators
 
withinBox(double, double, double, double) - Method in class com.mongodb.QueryBuilder
Equivalent to a $within operand, based on a bounding box using represented by two corners
withinCenter(double, double, double) - Method in class com.mongodb.QueryBuilder
Equivalent of the $within operand, used for geospatial operation
withinCenterSphere(double, double, double) - Method in class com.mongodb.QueryBuilder
Equivalent of the $centerSphere operand mostly intended for queries up to a few hundred miles or km.
withinPolygon(List<Double[]>) - Method in class com.mongodb.QueryBuilder
Equivalent to a $within operand, based on a bounding polygon represented by an array of points
withJ(boolean) - Method in class com.mongodb.WriteConcern
withJournal(Boolean) - Method in class com.mongodb.WriteConcern
Constructs a new WriteConcern from the current one and the specified journal value
withLimitAndBatchSize - Variable in class com.mongodb.connection.QueryProtocol
 
withMechanismProperty(String, T) - Method in class com.mongodb.MongoCredential
Creates a new MongoCredential as a copy of this instance, with the specified mechanism property added.
withProperty(String, T) - Method in class com.mongodb.MongoCompressor
Creates a new compressor from this compressor with the given property added to it.
withReadConcern(ReadConcern) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Create a new MongoDatabase instance with a different read concern.
withReadConcern(ReadConcern) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
withReadConcern(ReadConcern) - Method in interface com.mongodb.async.client.MongoCollection
Create a new MongoCollection instance with a different read concern.
withReadConcern(ReadConcern) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
withReadConcern(ReadConcern) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new MongoDatabase instance with a different read concern.
withReadConcern(ReadConcern) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
withReadConcern(ReadConcern) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a different read concern.
withReadConcern(ReadConcern) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
withReadConcern(ReadConcern) - Method in interface com.mongodb.client.MongoCollection
Create a new MongoCollection instance with a different read concern.
withReadConcern(ReadConcern) - Method in interface com.mongodb.client.MongoDatabase
Create a new MongoDatabase instance with a different read concern.
withReadConcern(ReadConcern) - Method in class com.mongodb.MongoCollectionImpl
 
withReadConcern(ReadConcern) - Method in class com.mongodb.MongoDatabaseImpl
 
withReadPreference(ReadPreference) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a different read preference.
withReadPreference(ReadPreference) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
withReadPreference(ReadPreference) - Method in interface com.mongodb.async.client.MongoCollection
Create a new MongoCollection instance with a different read preference.
withReadPreference(ReadPreference) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
withReadPreference(ReadPreference) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new MongoDatabase instance with a different read preference.
withReadPreference(ReadPreference) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
withReadPreference(ReadPreference) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a different read preference.
withReadPreference(ReadPreference) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
withReadPreference(ReadPreference) - Method in interface com.mongodb.client.MongoCollection
Create a new MongoCollection instance with a different read preference.
withReadPreference(ReadPreference) - Method in interface com.mongodb.client.MongoDatabase
Create a new MongoDatabase instance with a different read preference.
withReadPreference(ReadPreference) - Method in class com.mongodb.MongoCollectionImpl
 
withReadPreference(ReadPreference) - Method in class com.mongodb.MongoDatabaseImpl
 
withReleasableConnection(WriteBinding, OperationHelper.CallableWithConnectionAndSource<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withReleasableConnection(WriteBinding, MongoException, OperationHelper.CallableWithConnectionAndSource<T>) - Static method in class com.mongodb.operation.OperationHelper
 
withServerValue(int) - Method in class com.mongodb.connection.ConnectionId
 
withW(int) - Method in class com.mongodb.WriteConcern
Constructs a new WriteConcern from the current one and the specified integer-based value for w
withW(String) - Method in class com.mongodb.WriteConcern
Constructs a new WriteConcern from the current one and the specified tag-set based value for w
withWriteConcern(WriteConcern) - Method in interface com.mongodb.async.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a different write concern.
withWriteConcern(WriteConcern) - Method in class com.mongodb.async.client.gridfs.GridFSBucketImpl
 
withWriteConcern(WriteConcern) - Method in interface com.mongodb.async.client.MongoCollection
Create a new MongoCollection instance with a different write concern.
withWriteConcern(WriteConcern) - Method in class com.mongodb.async.client.MongoCollectionImpl
 
withWriteConcern(WriteConcern) - Method in interface com.mongodb.async.client.MongoDatabase
Create a new MongoDatabase instance with a different write concern.
withWriteConcern(WriteConcern) - Method in class com.mongodb.async.client.MongoDatabaseImpl
 
withWriteConcern(WriteConcern) - Method in interface com.mongodb.client.gridfs.GridFSBucket
Create a new GridFSBucket instance with a different write concern.
withWriteConcern(WriteConcern) - Method in class com.mongodb.client.gridfs.GridFSBucketImpl
 
withWriteConcern(WriteConcern) - Method in interface com.mongodb.client.MongoCollection
Create a new MongoCollection instance with a different write concern.
withWriteConcern(WriteConcern) - Method in interface com.mongodb.client.MongoDatabase
Create a new MongoDatabase instance with a different write concern.
withWriteConcern(WriteConcern) - Method in class com.mongodb.MongoCollectionImpl
 
withWriteConcern(WriteConcern) - Method in class com.mongodb.MongoDatabaseImpl
 
withWTimeout(long, TimeUnit) - Method in class com.mongodb.WriteConcern
Constructs a new WriteConcern from the current one and the specified wTimeout in the given time unit.
workerGroup - Variable in class com.mongodb.connection.netty.NettyStream
 
wrap(byte[], int, int) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 
wrap(DBObject) - Method in class com.mongodb.DB
 
wrap(DBObject, DBEncoder) - Method in class com.mongodb.DB
 
wrap(DBObject) - Method in class com.mongodb.DBCollection
 
wrap(DBObject, DBEncoder) - Method in class com.mongodb.DBCollection
 
wrap(DBObject, Encoder<DBObject>) - Method in class com.mongodb.DBCollection
 
wrapAllowNull(DBObject) - Method in class com.mongodb.DBCollection
 
wrapAllowNull(List<? extends DBObject>, DBEncoder) - Method in class com.mongodb.DBCollection
 
wrapAllowNull(List<? extends DBObject>, Encoder<DBObject>) - Method in class com.mongodb.DBCollection
 
wrapException(Throwable) - Method in class com.mongodb.connection.SaslAuthenticator
 
wrapInExplainIfNecessary(BsonDocument) - Method in class com.mongodb.operation.FindOperation
 
wrapped - Variable in class com.mongodb.async.client.ClientSessionBinding.SessionBindingAsyncConnectionSource
 
wrapped - Variable in class com.mongodb.async.client.ClientSessionBinding
 
wrapped - Variable in class com.mongodb.ClientSessionBinding.SessionBindingConnectionSource
 
wrapped - Variable in class com.mongodb.ClientSessionBinding
 
wrapped - Variable in class com.mongodb.connection.ClusterClockAdvancingSessionContext
 
wrapped - Variable in class com.mongodb.connection.DefaultConnectionPool.PooledConnection
 
wrapped - Variable in class com.mongodb.connection.DefaultServerConnection
 
wrapped - Variable in class com.mongodb.connection.UsageTrackingInternalConnection
 
wrapped - Variable in class com.mongodb.event.CommandListenerMulticaster
Deprecated.
 
wrapped - Variable in class com.mongodb.internal.async.ErrorHandlingResultCallback
 
wrapped - Variable in class com.mongodb.operation.AsyncChangeStreamBatchCursor
 
wrapped - Variable in class com.mongodb.operation.ChangeStreamBatchCursor
 
wrapped - Variable in class com.mongodb.operation.OperationHelper.ConnectionReleasingWrappedCallback
 
wrapped - Variable in class com.mongodb.operation.OperationHelper.ReferenceCountedReleasingWrappedCallback
 
wrapped - Variable in class com.mongodb.TagSet
 
wrapped - Variable in class org.bson.codecs.configuration.LazyCodec
 
wrapped - Variable in class org.bson.codecs.pojo.ConventionSetPrivateFieldImpl.PrivateProperyAccessor
 
wrapped - Variable in class org.bson.codecs.pojo.ConventionUseGettersAsSettersImpl.PrivateProperyAccessor
 
wrappedArray - Variable in class com.mongodb.operation.BsonArrayWrapper
 
wrappedDocument - Variable in class org.bson.BsonDocumentWrapper
 
WrappedMapReduceReadOperation(MapReduceWithInlineResultsOperation<TResult>) - Constructor for class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
WrappedMapReduceReadOperation(MapReduceWithInlineResultsOperation<TResult>) - Constructor for class com.mongodb.MapReduceIterableImpl.WrappedMapReduceReadOperation
 
WrappedMapReduceWriteOperation(MapReduceToCollectionOperation) - Constructor for class com.mongodb.async.client.MapReduceIterableImpl.WrappedMapReduceWriteOperation
 
wrappedMessageBuffers - Variable in class com.mongodb.connection.CompressedMessage
 
wrappedOpcode - Variable in class com.mongodb.connection.CompressedMessage
 
wrapper - Variable in class com.mongodb.DBCollectionObjectFactory
 
WritableServerSelector - Class in com.mongodb.selector
A server selector that chooses servers that are writable.
WritableServerSelector() - Constructor for class com.mongodb.selector.WritableServerSelector
 
write(ByteBuffer, SingleResultCallback<Integer>) - Method in interface com.mongodb.async.client.gridfs.AsyncOutputStream
Writes a sequence of bytes from the given buffer into this stream.
write(ByteBuffer, SingleResultCallback<Integer>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
write(int, ByteBuffer, SingleResultCallback<Integer>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
write(int) - Method in class com.mongodb.client.gridfs.GridFSUploadStream
 
write(byte[]) - Method in class com.mongodb.client.gridfs.GridFSUploadStream
 
write(byte[], int, int) - Method in class com.mongodb.client.gridfs.GridFSUploadStream
 
write(int) - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
write(byte[]) - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
write(byte[], int, int) - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
write(ByteBuffer, AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter
 
write(List<ByteBuf>) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
write(ByteBuffer, AsyncCompletionHandler<Void>) - Method in interface com.mongodb.connection.AsyncWritableByteChannel
Writes a sequence of bytes to this channel from the given buffer.
write(int, int) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
write(List<ByteBuf>) - Method in class com.mongodb.connection.netty.NettyStream
 
write(List<ByteBuf>) - Method in class com.mongodb.connection.SocketChannelStream
 
write(List<ByteBuf>) - Method in class com.mongodb.connection.SocketStream
 
write(List<ByteBuf>) - Method in interface com.mongodb.connection.Stream
Write each buffer in the list to the stream in order, blocking until all are completely written.
write(int) - Method in class com.mongodb.gridfs.GridFSInputFile.GridFSOutputStream
 
write(byte[], int, int) - Method in class com.mongodb.gridfs.GridFSInputFile.GridFSOutputStream
 
write(BsonValue) - Method in class org.bson.BsonDocumentWriter
 
write(byte[]) - Method in class org.bson.io.BasicOutputBuffer
 
write(int, int) - Method in class org.bson.io.BasicOutputBuffer
 
write(byte[]) - Method in class org.bson.io.OutputBuffer
 
write(byte[], int, int) - Method in class org.bson.io.OutputBuffer
 
write(int) - Method in class org.bson.io.OutputBuffer
 
write(int, int) - Method in class org.bson.io.OutputBuffer
Write the specified byte at the specified position.
write(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
write(char) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
WRITE_CONCERN_KEYS - Static variable in class com.mongodb.ConnectionString
 
WRITE_REQUEST_ENCODER - Static variable in class com.mongodb.operation.BulkWriteBatch
 
writeAdditionalFields(BsonDocumentWriter, Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Updates.PushUpdate
 
writeAdditionalFields(BsonDocumentWriter, Class<TDocument>, CodecRegistry) - Method in class com.mongodb.client.model.Updates.WithEachUpdate
 
writeAnnotations - Variable in class org.bson.codecs.pojo.PropertyMetadata
 
writeAnnotations - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
writeAnnotations(List<Annotation>) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Sets the writeAnnotations, to be applied when deserializing from BSON
writeAsync(List<ByteBuf>, AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.AsynchronousSocketChannelStream
 
writeAsync(List<ByteBuf>, SingleResultCallback<Void>) - Method in class com.mongodb.connection.InternalStreamConnection
 
writeAsync(List<ByteBuf>, AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.netty.NettyStream
 
writeAsync(List<ByteBuf>, AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.SocketChannelStream
 
writeAsync(List<ByteBuf>, AsyncCompletionHandler<Void>) - Method in class com.mongodb.connection.SocketStream
 
writeAsync(List<ByteBuf>, AsyncCompletionHandler<Void>) - Method in interface com.mongodb.connection.Stream
Write each buffer in the list to the stream in order, asynchronously.
writeBinaryData(String, BsonBinary) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeBinaryData(BsonBinary) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeBinaryData(String, BsonBinary) - Method in class org.bson.AbstractBsonWriter
 
writeBinaryData(BsonBinary) - Method in class org.bson.AbstractBsonWriter
 
writeBinaryData(BsonBinary) - Method in interface org.bson.BsonWriter
Writes a BSON Binary data element to the writer.
writeBinaryData(String, BsonBinary) - Method in interface org.bson.BsonWriter
Writes a BSON Binary data element to the writer.
WriteBinding - Interface in com.mongodb.binding
A factory of connection sources to servers that can be written to, e.g, a standalone, a mongos, or a replica set primary.
writeBoolean(String, boolean) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeBoolean(boolean) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeBoolean(String, boolean) - Method in class org.bson.AbstractBsonWriter
 
writeBoolean(boolean) - Method in class org.bson.AbstractBsonWriter
 
writeBoolean(boolean) - Method in interface org.bson.BsonWriter
Writes a BSON Boolean to the writer.
writeBoolean(String, boolean) - Method in interface org.bson.BsonWriter
Writes a BSON Boolean element to the writer.
writeBoolean(String, boolean) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeBoolean(boolean) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeBoolean(boolean) - Method in interface org.bson.json.StrictJsonWriter
Writes a boolean to the writer.
writeBoolean(String, boolean) - Method in interface org.bson.json.StrictJsonWriter
Writes a a member with a boolean value to the writer.
writeBucketOutput(CodecRegistry, BsonDocumentWriter, List<BsonField>) - Static method in class com.mongodb.client.model.Aggregates
 
writeByte(int) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
writeByte(int) - Method in class org.bson.io.BasicOutputBuffer
 
writeByte(int) - Method in interface org.bson.io.BsonOutput
Write a single byte to the stream.
writeBytes(byte[], int, int) - Method in class com.mongodb.connection.ByteBufferBsonOutput
 
writeBytes(byte[], int, int) - Method in class org.bson.io.BasicOutputBuffer
 
writeBytes(byte[]) - Method in interface org.bson.io.BsonOutput
Writes all the bytes in the byte array to the stream.
writeBytes(byte[], int, int) - Method in interface org.bson.io.BsonOutput
Writes length bytes from the byte array, starting at offset.
writeBytes(byte[]) - Method in class org.bson.io.OutputBuffer
 
writeCharacters(String, boolean) - Method in class org.bson.io.OutputBuffer
 
writeChunk(SingleResultCallback<Void>) - Method in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
writeChunk() - Method in class com.mongodb.client.gridfs.GridFSUploadStreamImpl
 
WriteCommandResultHelper - Class in com.mongodb.connection
 
WriteCommandResultHelper() - Constructor for class com.mongodb.connection.WriteCommandResultHelper
 
WriteCompletionHandler(AsyncCompletionHandler<Void>) - Constructor for class com.mongodb.connection.AsynchronousSocketChannelStream.AsyncWritableByteChannelAdapter.WriteCompletionHandler
 
writeConcern - Variable in class com.mongodb.AggregateIterableImpl
 
writeConcern - Variable in class com.mongodb.async.client.AggregateIterableImpl
 
writeConcern - Variable in class com.mongodb.async.client.MapReduceIterableImpl
 
writeConcern - Variable in class com.mongodb.async.client.MongoClientSettings.Builder
 
writeConcern(WriteConcern) - Method in class com.mongodb.async.client.MongoClientSettings.Builder
Sets the write concern.
writeConcern - Variable in class com.mongodb.async.client.MongoClientSettings
 
writeConcern - Variable in class com.mongodb.async.client.MongoCollectionImpl
 
writeConcern - Variable in class com.mongodb.async.client.MongoDatabaseImpl
 
writeConcern - Variable in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
 
writeConcern(WriteConcern) - Method in class com.mongodb.client.model.DBCollectionFindAndModifyOptions
Sets the writeConcern
writeConcern - Variable in class com.mongodb.client.model.DBCollectionRemoveOptions
 
writeConcern(WriteConcern) - Method in class com.mongodb.client.model.DBCollectionRemoveOptions
Sets the write concern
writeConcern - Variable in class com.mongodb.client.model.DBCollectionUpdateOptions
 
writeConcern(WriteConcern) - Method in class com.mongodb.client.model.DBCollectionUpdateOptions
Sets the write concern
writeConcern - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
writeConcern - Variable in class com.mongodb.ConnectionString
 
writeConcern - Variable in class com.mongodb.DB
 
writeConcern - Variable in class com.mongodb.DBCollection
 
writeConcern - Variable in class com.mongodb.InsertOptions
 
writeConcern(WriteConcern) - Method in class com.mongodb.InsertOptions
Set the write concern to use for the insert.
writeConcern - Variable in class com.mongodb.MapReduceIterableImpl
 
writeConcern - Variable in class com.mongodb.Mongo
 
writeConcern - Variable in class com.mongodb.MongoClientOptions.Builder
 
writeConcern(WriteConcern) - Method in class com.mongodb.MongoClientOptions.Builder
Sets the write concern.
writeConcern - Variable in class com.mongodb.MongoClientOptions
 
writeConcern - Variable in class com.mongodb.MongoCollectionImpl
 
writeConcern - Variable in class com.mongodb.MongoDatabaseImpl
 
writeConcern - Variable in class com.mongodb.MongoOptions
Deprecated.
Sets the write concern.
writeConcern - Variable in class com.mongodb.operation.AggregateToCollectionOperation
 
writeConcern - Variable in class com.mongodb.operation.BaseWriteOperation
 
writeConcern - Variable in class com.mongodb.operation.BulkWriteBatch
 
writeConcern - Variable in class com.mongodb.operation.CreateCollectionOperation
 
writeConcern - Variable in class com.mongodb.operation.CreateIndexesOperation
 
writeConcern - Variable in class com.mongodb.operation.CreateUserOperation
 
writeConcern - Variable in class com.mongodb.operation.CreateViewOperation
 
writeConcern - Variable in class com.mongodb.operation.DropCollectionOperation
 
writeConcern - Variable in class com.mongodb.operation.DropDatabaseOperation
 
writeConcern - Variable in class com.mongodb.operation.DropIndexOperation
 
writeConcern - Variable in class com.mongodb.operation.DropUserOperation
 
writeConcern - Variable in class com.mongodb.operation.FindAndDeleteOperation
 
writeConcern - Variable in class com.mongodb.operation.FindAndReplaceOperation
 
writeConcern - Variable in class com.mongodb.operation.FindAndUpdateOperation
 
writeConcern - Variable in class com.mongodb.operation.MapReduceToCollectionOperation
 
writeConcern - Variable in class com.mongodb.operation.MixedBulkWriteOperation
 
writeConcern - Variable in class com.mongodb.operation.RenameCollectionOperation
 
writeConcern - Variable in class com.mongodb.operation.UpdateUserOperation
 
WriteConcern - Class in com.mongodb
Controls the acknowledgment of write operations with various options.
WriteConcern() - Constructor for class com.mongodb.WriteConcern
Deprecated.
WriteConcern(int) - Constructor for class com.mongodb.WriteConcern
Construct an instance with the given integer-based value for w.
WriteConcern(String) - Constructor for class com.mongodb.WriteConcern
Construct an instance with the given tag set-based value for w.
WriteConcern(int, int) - Constructor for class com.mongodb.WriteConcern
Constructs an instance with the given integer-based value for w and the given value for wTimeoutMS.
WriteConcern(boolean) - Constructor for class com.mongodb.WriteConcern
WriteConcern(int, int, boolean) - Constructor for class com.mongodb.WriteConcern
WriteConcern(int, int, boolean, boolean) - Constructor for class com.mongodb.WriteConcern
WriteConcern(String, int, boolean, boolean) - Constructor for class com.mongodb.WriteConcern
WriteConcern(Object, Integer, Boolean, Boolean) - Constructor for class com.mongodb.WriteConcern
 
WriteConcern.Majority - Class in com.mongodb
WriteConcernError - Class in com.mongodb.bulk
An error representing a failure by the server to apply the requested write concern to the bulk operation.
WriteConcernError(int, String, BsonDocument) - Constructor for class com.mongodb.bulk.WriteConcernError
Constructs a new instance.
writeConcernError - Variable in exception com.mongodb.BulkWriteException
 
writeConcernError - Variable in exception com.mongodb.MongoBulkWriteException
 
writeConcernError - Variable in exception com.mongodb.MongoWriteConcernException
 
WriteConcernError - Class in com.mongodb
An error representing a failure by the server to apply the requested write concern to the bulk operation.
WriteConcernError(int, String, DBObject) - Constructor for class com.mongodb.WriteConcernError
Constructs a new instance.
writeConcernErrors - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
writeConcernErrorTransformer() - Static method in class com.mongodb.operation.WriteConcernHelper
 
WriteConcernException - Exception in com.mongodb
An exception representing an error reported due to a write failure.
WriteConcernException(BsonDocument, ServerAddress, WriteConcernResult) - Constructor for exception com.mongodb.WriteConcernException
Construct a new instance.
WriteConcernHelper - Class in com.mongodb.operation
 
WriteConcernHelper() - Constructor for class com.mongodb.operation.WriteConcernHelper
 
writeConcernResult - Variable in exception com.mongodb.MongoWriteConcernException
 
writeConcernResult - Variable in exception com.mongodb.WriteConcernException
 
WriteConcernResult - Class in com.mongodb
The result of a successful write operation.
WriteConcernResult() - Constructor for class com.mongodb.WriteConcernResult
 
writeCString(String) - Method in interface org.bson.io.BsonOutput
Writes a BSON CString to the stream.
writeCString(String) - Method in class org.bson.io.OutputBuffer
 
writeCurrentName() - Method in class org.bson.BsonBinaryWriter
 
writeDateTime(String, long) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDateTime(long) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDateTime(String, long) - Method in class org.bson.AbstractBsonWriter
 
writeDateTime(long) - Method in class org.bson.AbstractBsonWriter
 
writeDateTime(long) - Method in interface org.bson.BsonWriter
Writes a BSON DateTime to the writer.
writeDateTime(String, long) - Method in interface org.bson.BsonWriter
Writes a BSON DateTime element to the writer.
writeDBPointer(String, BsonDbPointer) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDBPointer(BsonDbPointer) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDBPointer(String, BsonDbPointer) - Method in class org.bson.AbstractBsonWriter
 
writeDBPointer(BsonDbPointer) - Method in class org.bson.AbstractBsonWriter
 
writeDBPointer(BsonDbPointer) - Method in interface org.bson.BsonWriter
Writes a BSON DBPointer to the writer.
writeDBPointer(String, BsonDbPointer) - Method in interface org.bson.BsonWriter
Writes a BSON DBPointer element to the writer.
writeDecimal128(Decimal128) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDecimal128(String, Decimal128) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDecimal128(Decimal128) - Method in class org.bson.AbstractBsonWriter
 
writeDecimal128(String, Decimal128) - Method in class org.bson.AbstractBsonWriter
 
writeDecimal128(Decimal128) - Method in interface org.bson.BsonWriter
Writes a BSON Decimal128 to the writer.
writeDecimal128(String, Decimal128) - Method in interface org.bson.BsonWriter
Writes a BSON Decimal128 element to the writer.
writeDocument(BsonWriter, BsonOutput, MessageSettings, BsonDocument, int, int) - Static method in class com.mongodb.connection.BsonWriterHelper
 
writeDouble(String, double) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDouble(double) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeDouble(String, double) - Method in class org.bson.AbstractBsonWriter
 
writeDouble(double) - Method in class org.bson.AbstractBsonWriter
 
writeDouble(double) - Method in interface org.bson.BsonWriter
Writes a BSON Double to the writer.
writeDouble(String, double) - Method in interface org.bson.BsonWriter
Writes a BSON Double element to the writer.
writeDouble(double) - Method in interface org.bson.io.BsonOutput
Writes a BSON double to the stream.
writeDouble(double) - Method in class org.bson.io.OutputBuffer
 
writeElements(BsonWriter, List<BsonElement>) - Static method in class com.mongodb.connection.BsonWriterHelper
 
writeEndArray() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeEndArray() - Method in class org.bson.AbstractBsonWriter
 
writeEndArray() - Method in interface org.bson.BsonWriter
Writes the end of a BSON array to the writer.
writeEndArray() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeEndArray() - Method in interface org.bson.json.StrictJsonWriter
Writes the end of a JSON array to the writer.
writeEndDocument() - Method in class com.mongodb.connection.ElementExtendingBsonWriter
 
writeEndDocument() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeEndDocument() - Method in class com.mongodb.connection.SplittablePayloadBsonWriter
 
writeEndDocument() - Method in class org.bson.AbstractBsonWriter
 
writeEndDocument() - Method in interface org.bson.BsonWriter
Writes the end of a BSON document to the writer.
writeEndObject() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeEndObject() - Method in interface org.bson.json.StrictJsonWriter
Writes the end of a JSON object to the writer.
WriteError - Class in com.mongodb
Represents the details of a write error , e.g.
WriteError(int, String, BsonDocument) - Constructor for class com.mongodb.WriteError
Constructs a new instance.
WriteError(WriteError) - Constructor for class com.mongodb.WriteError
Construct an instance that is a shallow copy of the given instance.
writeErrors - Variable in exception com.mongodb.BulkWriteException
 
writeErrors - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
writeGetMore(BsonOutput) - Method in class com.mongodb.connection.GetMoreMessage
 
writeInsertPrologue(BsonOutput) - Method in class com.mongodb.connection.InsertMessage
 
writeInt(int) - Method in class org.bson.io.OutputBuffer
Writes the given integer value to the buffer.
writeInt32(String, int) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeInt32(int) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeInt32(String, int) - Method in class org.bson.AbstractBsonWriter
 
writeInt32(int) - Method in class org.bson.AbstractBsonWriter
 
writeInt32(int) - Method in interface org.bson.BsonWriter
Writes a BSON Int32 to the writer.
writeInt32(String, int) - Method in interface org.bson.BsonWriter
Writes a BSON Int32 element to the writer.
writeInt32(int) - Method in interface org.bson.io.BsonOutput
Writes a 32-bit BSON integer to the stream.
writeInt32(int, int) - Method in interface org.bson.io.BsonOutput
Writes a 32-bit BSON integer to the stream at the given position.
writeInt32(int) - Method in class org.bson.io.OutputBuffer
 
writeInt32(int, int) - Method in class org.bson.io.OutputBuffer
 
writeInt64(String, long) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeInt64(long) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeInt64(String, long) - Method in class org.bson.AbstractBsonWriter
 
writeInt64(long) - Method in class org.bson.AbstractBsonWriter
 
writeInt64(long) - Method in interface org.bson.BsonWriter
Writes a BSON Int64 to the writer.
writeInt64(String, long) - Method in interface org.bson.BsonWriter
Writes a BSON Int64 element to the writer.
writeInt64(long) - Method in interface org.bson.io.BsonOutput
Writes a 64-bit BSON integer to the stream.
writeInt64(long) - Method in class org.bson.io.OutputBuffer
 
writeIterable(BsonWriter, Iterable<Object>, EncoderContext) - Method in class org.bson.codecs.DocumentCodec
 
writeJavaScript(String, String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeJavaScript(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeJavaScript(String, String) - Method in class org.bson.AbstractBsonWriter
 
writeJavaScript(String) - Method in class org.bson.AbstractBsonWriter
 
writeJavaScript(String) - Method in interface org.bson.BsonWriter
Writes a BSON JavaScript to the writer.
writeJavaScript(String, String) - Method in interface org.bson.BsonWriter
Writes a BSON JavaScript element to the writer.
writeJavaScriptWithScope(String, String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeJavaScriptWithScope(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeJavaScriptWithScope(String, String) - Method in class org.bson.AbstractBsonWriter
 
writeJavaScriptWithScope(String) - Method in class org.bson.AbstractBsonWriter
 
writeJavaScriptWithScope(String) - Method in interface org.bson.BsonWriter
Writes a BSON JavaScript to the writer (call WriteStartDocument to start writing the scope).
writeJavaScriptWithScope(String, String) - Method in interface org.bson.BsonWriter
Writes a BSON JavaScript element to the writer (call WriteStartDocument to start writing the scope).
writeKillCursorsPrologue(int, BsonOutput) - Method in class com.mongodb.connection.KillCursorsMessage
 
writeLong(long) - Method in class org.bson.io.OutputBuffer
Writes the given long value to the buffer.
writeLongToArrayBigEndian(byte[], int, long) - Static method in class org.bson.codecs.UuidCodec
 
writeLongToArrayLittleEndian(byte[], int, long) - Static method in class org.bson.BasicBSONEncoder
 
writeMap(BsonWriter, Map<String, Object>, EncoderContext) - Method in class org.bson.codecs.DocumentCodec
 
writeMaxKey(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeMaxKey() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeMaxKey(String) - Method in class org.bson.AbstractBsonWriter
 
writeMaxKey() - Method in class org.bson.AbstractBsonWriter
 
writeMaxKey() - Method in interface org.bson.BsonWriter
Writes a BSON MaxKey to the writer.
writeMaxKey(String) - Method in interface org.bson.BsonWriter
Writes a BSON MaxKey element to the writer.
writeMessagePrologue(BsonOutput) - Method in class com.mongodb.connection.RequestMessage
Writes the message prologue to the given output.
writeMinKey(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeMinKey() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeMinKey(String) - Method in class org.bson.AbstractBsonWriter
 
writeMinKey() - Method in class org.bson.AbstractBsonWriter
 
writeMinKey() - Method in interface org.bson.BsonWriter
Writes a BSON MinKey to the writer.
writeMinKey(String) - Method in interface org.bson.BsonWriter
Writes a BSON MinKey element to the writer.
WriteModel<T> - Class in com.mongodb.client.model
A base class for models that can be used in a bulk write operations.
WriteModel() - Constructor for class com.mongodb.client.model.WriteModel
 
writeName(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeName(String) - Method in class org.bson.AbstractBsonWriter
 
writeName(String) - Method in interface org.bson.BsonWriter
Writes the name of an element to the writer.
writeName - Variable in class org.bson.codecs.pojo.PropertyModel
 
writeName - Variable in class org.bson.codecs.pojo.PropertyModelBuilder
 
writeName(String) - Method in class org.bson.codecs.pojo.PropertyModelBuilder
Sets the writeName, the key for this property when serializing the data into BSON.
writeName(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeName(String) - Method in interface org.bson.json.StrictJsonWriter
Writes the name of a member to the writer.
writeNull(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeNull() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeNull(String) - Method in class org.bson.AbstractBsonWriter
 
writeNull() - Method in class org.bson.AbstractBsonWriter
 
writeNull() - Method in interface org.bson.BsonWriter
Writes a BSON null to the writer.
writeNull(String) - Method in interface org.bson.BsonWriter
Writes a BSON null element to the writer.
writeNull(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeNull() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeNull() - Method in interface org.bson.json.StrictJsonWriter
Writes a null value to the writer.
writeNull(String) - Method in interface org.bson.json.StrictJsonWriter
Writes a member with a null value to the writer.
writeNumber(String, String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeNumber(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeNumber(String) - Method in interface org.bson.json.StrictJsonWriter
Writes a number to the writer.
writeNumber(String, String) - Method in interface org.bson.json.StrictJsonWriter
Writes a member with a numeric value to the writer.
writeObject(OutputBuffer, BSONObject) - Method in interface com.mongodb.DBEncoder
Encode the BSONObject.
writeObject(OutputBuffer, BSONObject) - Method in class com.mongodb.DefaultDBEncoder
 
writeObject(OutputBuffer, BSONObject) - Method in class com.mongodb.LazyDBEncoder
 
writeObjectId(String, ObjectId) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeObjectId(ObjectId) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeObjectId(String, ObjectId) - Method in class org.bson.AbstractBsonWriter
 
writeObjectId(ObjectId) - Method in class org.bson.AbstractBsonWriter
 
writeObjectId(ObjectId) - Method in interface org.bson.BsonWriter
Writes a BSON ObjectId to the writer.
writeObjectId(String, ObjectId) - Method in interface org.bson.BsonWriter
Writes a BSON ObjectId element to the writer.
writeObjectId(ObjectId) - Method in interface org.bson.io.BsonOutput
Writes a BSON ObjectId to the stream.
writeObjectId(ObjectId) - Method in class org.bson.io.OutputBuffer
 
WriteOperation<T> - Interface in com.mongodb.operation
An operation which writes to a MongoDB server.
writePayload(BsonWriter, BsonOutput, MessageSettings, int, SplittablePayload) - Static method in class com.mongodb.connection.BsonWriterHelper
 
writePayloadArray(BsonWriter, BsonOutput, MessageSettings, int, SplittablePayload) - Static method in class com.mongodb.connection.BsonWriterHelper
 
WriteProtocol - Class in com.mongodb.connection
Base class for legacy wire protocol messages that perform unacknowledged writes.
WriteProtocol(MongoNamespace, boolean) - Constructor for class com.mongodb.connection.WriteProtocol
 
WriteProtocol.UnacknowledgedWriteResultCallback - Class in com.mongodb.connection
 
writeQueryPrologue(BsonOutput) - Method in class com.mongodb.connection.BaseQueryMessage
Write the query prologue to the given BSON output.
writer - Variable in class com.mongodb.connection.SplittablePayloadBsonWriter
 
writer - Variable in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeRaw(String, String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeRaw(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeRaw(String) - Method in interface org.bson.json.StrictJsonWriter
Writes a raw value without quoting or escaping.
writeRaw(String, String) - Method in interface org.bson.json.StrictJsonWriter
Writes a member with a raw value without quoting or escaping.
writeRegularExpression(String, BsonRegularExpression) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeRegularExpression(BsonRegularExpression) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeRegularExpression(String, BsonRegularExpression) - Method in class org.bson.AbstractBsonWriter
 
writeRegularExpression(BsonRegularExpression) - Method in class org.bson.AbstractBsonWriter
 
writeRegularExpression(BsonRegularExpression) - Method in interface org.bson.BsonWriter
Writes a BSON regular expression to the writer.
writeRegularExpression(String, BsonRegularExpression) - Method in interface org.bson.BsonWriter
Writes a BSON regular expression element to the writer.
writeReplace() - Method in class com.mongodb.connection.AbstractByteBufBsonDocument
 
writeReplace() - Method in class org.bson.BsonDocument
 
writeReplace() - Method in class org.bson.BsonDocumentWrapper
 
writeReplace() - Method in class org.bson.RawBsonDocument
 
WriteRequest - Class in com.mongodb.bulk
An abstract base class for a write request.
WriteRequest() - Constructor for class com.mongodb.bulk.WriteRequest
 
writeRequest - Variable in class com.mongodb.operation.BulkWriteBatch.WriteRequestWithIndex
 
WriteRequest - Class in com.mongodb
 
WriteRequest() - Constructor for class com.mongodb.WriteRequest
 
WriteRequest.Type - Enum in com.mongodb.bulk
The type of write.
WriteRequestEncoder() - Constructor for class com.mongodb.operation.BulkWriteBatch.WriteRequestEncoder
 
writeRequests - Variable in class com.mongodb.operation.MixedBulkWriteOperation
 
WriteRequestWithIndex(WriteRequest, int) - Constructor for class com.mongodb.operation.BulkWriteBatch.WriteRequestWithIndex
 
writeResult - Variable in exception com.mongodb.BulkWriteException
 
writeResult - Variable in exception com.mongodb.MongoBulkWriteException
 
WriteResult - Class in com.mongodb
This class lets you access the results of the previous acknowledged write.
WriteResult(int, boolean, Object) - Constructor for class com.mongodb.WriteResult
Construct a new instance.
WriteResult() - Constructor for class com.mongodb.WriteResult
 
writeStartArray(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeStartArray() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeStartArray(String) - Method in class org.bson.AbstractBsonWriter
 
writeStartArray() - Method in class org.bson.AbstractBsonWriter
 
writeStartArray() - Method in interface org.bson.BsonWriter
Writes the start of a BSON array to the writer.
writeStartArray(String) - Method in interface org.bson.BsonWriter
Writes the start of a BSON array element to the writer.
writeStartArray(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeStartArray() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeStartArray() - Method in interface org.bson.json.StrictJsonWriter
Writes the start of a array to the writer.
writeStartArray(String) - Method in interface org.bson.json.StrictJsonWriter
Writes the start of JSON array member to the writer.
writeStartDocument(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeStartDocument() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeStartDocument() - Method in class com.mongodb.connection.SplittablePayloadBsonWriter
 
writeStartDocument(String) - Method in class org.bson.AbstractBsonWriter
 
writeStartDocument() - Method in class org.bson.AbstractBsonWriter
 
writeStartDocument() - Method in interface org.bson.BsonWriter
Writes the start of a BSON document to the writer.
writeStartDocument(String) - Method in interface org.bson.BsonWriter
Writes the start of a BSON document element to the writer.
writeStartObject(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeStartObject() - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeStartObject() - Method in interface org.bson.json.StrictJsonWriter
Writes the start of a JSON object to the writer.
writeStartObject(String) - Method in interface org.bson.json.StrictJsonWriter
Writes the start of a JSON object member to the writer.
writeString(String, String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeString(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeString(String, String) - Method in class org.bson.AbstractBsonWriter
 
writeString(String) - Method in class org.bson.AbstractBsonWriter
 
writeString(String) - Method in interface org.bson.BsonWriter
Writes a BSON String to the writer.
writeString(String, String) - Method in interface org.bson.BsonWriter
Writes a BSON String element to the writer.
writeString(String) - Method in interface org.bson.io.BsonOutput
Writes a BSON String to the stream.
writeString(String) - Method in class org.bson.io.OutputBuffer
 
writeString(String, String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeString(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeString(String) - Method in interface org.bson.json.StrictJsonWriter
Writes a String to the writer.
writeString(String, String) - Method in interface org.bson.json.StrictJsonWriter
Writes a member with a string value to the writer.
writeStringHelper(String) - Method in class org.bson.json.StrictCharacterStreamJsonWriter
 
writeSymbol(String, String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeSymbol(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeSymbol(String, String) - Method in class org.bson.AbstractBsonWriter
 
writeSymbol(String) - Method in class org.bson.AbstractBsonWriter
 
writeSymbol(String) - Method in interface org.bson.BsonWriter
Writes a BSON Symbol to the writer.
writeSymbol(String, String) - Method in interface org.bson.BsonWriter
Writes a BSON Symbol element to the writer.
writeTimestamp(String, BsonTimestamp) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeTimestamp(BsonTimestamp) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeTimestamp(String, BsonTimestamp) - Method in class org.bson.AbstractBsonWriter
 
writeTimestamp(BsonTimestamp) - Method in class org.bson.AbstractBsonWriter
 
writeTimestamp(BsonTimestamp) - Method in interface org.bson.BsonWriter
Writes a BSON Timestamp to the writer.
writeTimestamp(String, BsonTimestamp) - Method in interface org.bson.BsonWriter
Writes a BSON Timestamp element to the writer.
writeTo(String) - Method in class com.mongodb.gridfs.GridFSDBFile
Writes the file's data to a file on disk.
writeTo(File) - Method in class com.mongodb.gridfs.GridFSDBFile
Writes the file's data to a file on disk.
writeTo(OutputStream) - Method in class com.mongodb.gridfs.GridFSDBFile
Writes the file's data to an OutputStream.
writeUndefined(String) - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeUndefined() - Method in class com.mongodb.connection.LevelCountingBsonWriter
 
writeUndefined(String) - Method in class org.bson.AbstractBsonWriter
 
writeUndefined() - Method in class org.bson.AbstractBsonWriter
 
writeUndefined() - Method in interface org.bson.BsonWriter
Writes a BSON undefined to the writer.
writeUndefined(String) - Method in interface org.bson.BsonWriter
Writes a BSON undefined element to the writer.
writeUpserts - Variable in class com.mongodb.connection.BulkWriteBatchCombiner
 
writeValue(BsonWriter, EncoderContext, Object) - Method in class com.mongodb.DBObjectCodec
 
writeValue(BsonWriter, EncoderContext, BsonValue) - Method in class org.bson.codecs.BsonDocumentCodec
 
writeValue(BsonWriter, EncoderContext, Object) - Method in class org.bson.codecs.DocumentCodec
 
writeValue(BsonWriter, EncoderContext, Object) - Method in class org.bson.codecs.IterableCodec
 
writeValue(BsonWriter, EncoderContext, Object) - Method in class org.bson.codecs.MapCodec
 
writing - Variable in class com.mongodb.async.client.gridfs.GridFSUploadStreamImpl
 
writtenBuffer - Variable in class com.mongodb.connection.WriteProtocol.UnacknowledgedWriteResultCallback
 
wtimeout - Variable in class com.mongodb.MongoOptions
Deprecated.
The "wtimeout" value of the global WriteConcern.
wTimeoutMS - Variable in class com.mongodb.WriteConcern
 

X

X509Authenticator - Class in com.mongodb.connection
 
X509Authenticator(MongoCredential) - Constructor for class com.mongodb.connection.X509Authenticator
 
xor(byte[], byte[]) - Method in class com.mongodb.connection.ScramSha1Authenticator.ScramSha1SaslClient
 

Z

ZlibCompressor - Class in com.mongodb.connection
 
ZlibCompressor(MongoCompressor) - Constructor for class com.mongodb.connection.ZlibCompressor
 

_

_ancestryCache - Static variable in class org.bson.util.ClassAncestry
 
_callback - Variable in class com.mongodb.util.JSONParser
 
_check(String, String) - Static method in class com.mongodb.DBAddress
Deprecated.
 
_cur() - Method in class com.mongodb.BasicDBObjectBuilder
 
_currentKey - Variable in class com.mongodb.QueryBuilder
 
_db - Variable in class com.mongodb.DBAddress
Deprecated.
 
_fixName(String) - Static method in class com.mongodb.DBAddress
Deprecated.
 
_getDBSection(String) - Static method in class com.mongodb.DBAddress
Deprecated.
 
_getHostSection(String) - Static method in class com.mongodb.DBAddress
Deprecated.
 
_getInt(String) - Method in class org.bson.types.BasicBSONList
 
_getInt(String, boolean) - Method in class org.bson.types.BasicBSONList
 
_hasNot - Variable in class com.mongodb.QueryBuilder
 
_hasOptions - Variable in class com.mongodb.Bytes.OptionHolder
 
_id - Variable in class com.mongodb.ReflectionDBObject
 
_isPartialObject - Variable in class com.mongodb.BasicDBList
 
_lastArray - Variable in class com.mongodb.util.JSONCallback
Deprecated.
 
_msDateFormat - Static variable in class com.mongodb.util.JSONCallback
Deprecated.
 
_options - Variable in class com.mongodb.Bytes.OptionHolder
 
_parent - Variable in class com.mongodb.Bytes.OptionHolder
 
_put(String, Object) - Method in class org.bson.BasicBSONCallback
Puts a new value into the document.
_putObjectField(String, Object) - Method in class org.bson.BasicBSONEncoder
Encodes any Object type
_query - Variable in class com.mongodb.QueryBuilder
 
_readStream2Buffer() - Method in class com.mongodb.gridfs.GridFSInputFile
Reads a buffer full from the InputStream.
_secDateFormat - Static variable in class com.mongodb.util.JSONCallback
Deprecated.
 
_serializers - Variable in class com.mongodb.util.ClassMapBasedObjectSerializer
 
_stack - Variable in class com.mongodb.BasicDBObjectBuilder
 
_wrapper - Variable in class com.mongodb.ReflectionDBObject
 
_wrappers - Static variable in class com.mongodb.ReflectionDBObject
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
Skip navigation links