package commands

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. commands
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Package Members

  1. package bson

Type Members

  1. trait AggregationFramework[P <: SerializationPack] extends ImplicitCommandHelpers[P] with GroupAggregation[P] with SliceAggregation[P] with SortAggregation[P] with AggregationPipeline[P]

    Implements the Aggregation Framework.

    Implements the Aggregation Framework.

    See also

    PipelineOperator

  2. sealed trait AuthenticationRestriction extends AnyRef

    Authentication restriction for user (since MongoDB 3.6)

  3. trait BoxedAnyVal[A <: AnyVal] extends AnyRef
  4. trait CollectionCommand extends AbstractCommand
  5. trait Command extends AbstractCommand
  6. trait CommandError extends Exception with NoStackTrace

    Base definition for all the errors for the command execution errors.

  7. trait CommandWithPack[P <: SerializationPack] extends AnyRef
  8. trait CommandWithResult[R] extends AnyRef
  9. trait CursorFetcher[P <: SerializationPack, +C[_] <: Cursor[_]] extends AnyRef

    Fetches a cursor from MongoDB results.

    Fetches a cursor from MongoDB results.

    P

    the type of the serialization pack

    C

    the type of the cursor implementation

  10. class DBUserRole extends UserRole with Product2[String, String] with Serializable

  11. trait ImplicitCommandHelpers[P <: SerializationPack] extends AnyRef
  12. class LastError extends Exception with DatabaseException with WriteResult with NoStackTrace with Product14[Boolean, Option[String], Option[Int], Option[Long], Int, Option[String], Boolean, Option[BSONValue], Option[W], Boolean, Option[Int], Option[Int], Seq[WriteError], Option[WriteConcernError]] with Serializable
  13. class ReplSetMember extends Product15[Long, String, Int, Int, String, Long, Long, Option[Long], Option[Long], Option[String], Option[Long], Boolean, Option[Long], Option[String], Option[Int]] with Serializable

    Replica set member.

  14. class ReplSetStatus extends Product4[String, Long, Int, List[ReplSetMember]] with Serializable

    Result from the replSetGetStatus.

  15. class ResultCursor extends Product2[Long, String] with Serializable

  16. sealed trait ServerProcess extends AnyRef
  17. abstract class Upserted extends Product with Serializable
  18. class UserRole extends AnyRef

    User role

  19. class WriteConcernError extends Product2[Int, String] with Serializable

  20. class WriteError extends Product3[Int, Int, String] with Serializable

  21. sealed trait WriteResult extends AnyRef

Deprecated Type Members

  1. sealed trait AbstractCommand extends AnyRef
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Will be removed; See Command

  2. class Capped extends Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  3. class CollStats extends Product with Serializable with CollectionCommand with CommandWithResult[CollStatsResult]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  4. case class CollStatsResult(ns: String, count: Int, size: Double, averageObjectSize: Option[Double], storageSize: Double, numExtents: Option[Int], nindexes: Int, lastExtentSize: Option[Int], paddingFactor: Option[Double], systemFlags: Option[Int], userFlags: Option[Int], totalIndexSize: Int, sizePerIndex: List[(String, Int)], capped: Boolean, max: Option[Long], maxSize: Option[Double] = None) extends Product with Serializable

    Various information about a collection.

    Various information about a collection.

    ns

    The fully qualified collection name.

    count

    The number of documents in this collection.

    size

    The size in bytes (or in bytes / scale, if any).

    averageObjectSize

    The average object size in bytes (or in bytes / scale, if any).

    storageSize

    Preallocated space for the collection.

    numExtents

    Number of extents (contiguously allocated chunks of datafile space, only for mmapv1 storage engine).

    nindexes

    Number of indexes.

    lastExtentSize

    Size of the most recently created extent (only for mmapv1 storage engine).

    paddingFactor

    Padding can speed up updates if documents grow (only for mmapv1 storage engine).

    systemFlags

    System flags.

    userFlags

    User flags.

    capped

    States if this collection is capped.

    max

    The maximum number of documents of this collection, if capped.

    maxSize

    The maximum size in bytes (or in bytes / scale, if any) of this collection, if capped.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.19.8) Will be replaced by reactivemongo.api.CollStatsResult

  5. type Collation = api.Collation
    Annotations
    @deprecated
    Deprecated

    (Since version 0.19.8) Will be replaced by reactivemongo.api.Collation

  6. case class CollectionNames(names: List[String]) extends Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  7. class ConvertToCapped extends Product with Serializable with CollectionCommand with CommandWithResult[UnitBox.type]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  8. trait CountCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Use new reactivemongo.api.collections.CountOp

  9. case class Create(capped: Option[Capped] = None, autoIndexId: Boolean = true, flags: Int = 1) extends CollectionCommand with CommandWithResult[UnitBox.type] with Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  10. class CreateIndexes extends Product with Serializable with CollectionCommand with CommandWithResult[WriteResult]

    Creates the given indexes on the specified collection.

    Creates the given indexes on the specified collection.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  11. trait CreateUserCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  12. case class DefaultWriteResult(ok: Boolean, n: Int, writeErrors: Seq[WriteError], writeConcernError: Option[WriteConcernError], code: Option[Int], errmsg: Option[String]) extends WriteResult with Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  13. trait DeleteCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Implements the delete command.

    Implements the delete command.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Use the new delete operation

  14. class DropCollectionResult extends Product with Serializable

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  15. class DropIndexes extends Product with Serializable with CollectionCommand with CommandWithResult[DropIndexesResult]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  16. case class DropIndexesResult(value: Int) extends BoxedAnyVal[Int] with Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  17. trait FindAndModifyCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  18. case class GetLastError(w: W, j: Boolean, fsync: Boolean, wtimeout: Option[Int] = None) extends Command with api.WriteConcern with CommandWithResult[LastError] with Product with Serializable

    wtimeout

    the time limit

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Will be replaced by reactivemongo.api.commands.WriteConcern

  19. trait InsertCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Implements the insert command.

    Implements the insert command.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Use the new insert operation

  20. trait IsMasterCommand[P <: SerializationPack] extends AnyRef
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  21. class ListIndexes extends Product with Serializable with CollectionCommand with CommandWithResult[List[Index]]

    Lists the indexes of the specified collection.

    Lists the indexes of the specified collection.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  22. trait Mongo26WriteCommand extends AnyRef
    Annotations
    @deprecated
    Deprecated

    (Since version 0.12.7) Will be removed as EOL for 2.6

  23. case class MultiBulkWriteResult(ok: Boolean, n: Int, nModified: Int, upserted: Seq[Upserted], writeErrors: Seq[WriteError], writeConcernError: Option[WriteConcernError], code: Option[Int], errmsg: Option[String], totalN: Int) extends Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.19.8) Will be replaced by reactivemongo.api.MultiWriteResult

  24. case class RenameCollection(fullyQualifiedCollectionName: String, fullyQualifiedTargetName: String, dropTarget: Boolean = false) extends Command with CommandWithResult[UnitBox.type] with Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  25. class ReplSetMaintenance extends Product with Serializable with Command with CommandWithResult[UnitBox.type]

    The replSetMaintenance command.

    The replSetMaintenance command. It must be executed against the admin database.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  26. final case class ResolvedCollectionCommand[C <: CollectionCommand](collection: String, command: C) extends Command with Product with Serializable

    collection

    the name of the collection against which the command is executed

    command

    the executed command

    Annotations
    @deprecated
    Deprecated

    (Since version 0.20.3) Internal: will be made private

  27. case class ResponseResult[R](response: Response, numberToReturn: Int, value: R) extends Product with Serializable

    response

    the response associated with the result

    numberToReturn

    the number of documents to return

    value

    the value parsed from the response

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  28. case class ServerStatusAsserts(regular: Int, warning: Int, msg: Int, user: Int, rollovers: Int) extends Product with Serializable

    regular

    the number of regular assertions

    warning

    the number of warnings

    msg

    the number of message assertions

    user

    the number of user assertions

    rollovers

    the number of times that the rollovers counters have rolled over since the last time the MongoDB process started

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  29. case class ServerStatusBackgroundFlushing(flushes: Int, totalMs: Long, averageMs: Long, lastMs: Long, lastFinished: Long) extends Product with Serializable

    Only for the MMAPv1 storage engine.

    Only for the MMAPv1 storage engine.

    flushes

    the number of times the database has flushed all writes

    totalMs

    the total number of milliseconds (ms) that the mongod processes have spent writing

    averageMs

    the average time in milliseconds for each flush to disk

    lastMs

    the amount of time, in milliseconds, that the last flush operation took to complete

    lastFinished

    the timestamp of the last completed flush operation

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  30. case class ServerStatusConnections(current: Int, available: Int, totalCreated: Long) extends Product with Serializable

    current

    the number of incoming connections from clients to the database server

    available

    the number of unused incoming connections available

    totalCreated

    the count of all incoming connections created to the server.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  31. case class ServerStatusExtraInfo(heapUsageBytes: Int, pageFaults: Int) extends Product with Serializable

    heapUsageBytes

    the total size in bytes of heap space used by the database process

    pageFaults

    the total number of page faults

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  32. case class ServerStatusGlobalLock(totalTime: Int, currentQueue: ServerStatusLock, activeClients: ServerStatusLock) extends Product with Serializable

    totalTime

    the time, in microseconds, since the database last started and created the globalLock

    currentQueue

    the information concerning the number of operations queued because of a lock

    activeClients

    the information about the number of connected clients

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  33. case class ServerStatusJournaling(commits: Int, journaledMB: Double, writeToDataFilesMB: Double, compression: Double, commitsInWriteLock: Int, earlyCommits: Int, timeMs: ServerStatusJournalingTime) extends Product with Serializable

    Only for the MMAPv1 storage engine with the journaling enabled.

    Only for the MMAPv1 storage engine with the journaling enabled.

    commits

    the number of transactions written to the journal during the last journal group commit interval

    journaledMB

    the amount of data in megabytes (MB) written to journal

    writeToDataFilesMB

    the amount of data in megabytes (MB) written from journal

    compression

    the compression ratio of the data written to the journal

    commitsInWriteLock

    the count of the commits that occurred while a write lock was held

    earlyCommits

    the number of times MongoDB requested a commit

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  34. case class ServerStatusJournalingTime(dt: Long, prepLogBuffer: Long, writeToJournal: Long, writeToDataFiles: Long, remapPrivateView: Long, commits: Long, commitsInWriteLock: Long) extends Product with Serializable

    Only for the MMAPv1 storage engine with the journaling enabled.

    Only for the MMAPv1 storage engine with the journaling enabled.

    dt

    the amount of time in milliseconds, over which MongoDB collected this information

    prepLogBuffer

    the amount of time, in milliseconds, spent preparing to write to the journal

    writeToJournal

    the amount of time, in milliseconds, spent actually writing to the journal

    writeToDataFiles

    the amount of time, in milliseconds, spent writing to data files after journaling

    remapPrivateView

    the amount of time, in milliseconds, spent remapping copy-on-write memory mapped views

    commits

    the amount of time in milliseconds spent for commits

    commitsInWriteLock

    the amount of time, in milliseconds, spent for commits that occurred while a write lock was held

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusJournaling

    https://docs.mongodb.com/manual/reference/command/serverStatus/ ServerStatusJournaling

  35. case class ServerStatusLock(total: Int, readers: Int, writers: Int) extends Product with Serializable

    total

    the total number of operations queued waiting for the lock

    readers

    the number of operations that are currently queued and waiting for the read lock

    writers

    the number of operations that are currently queued and waiting for the write lock

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusGlobalLock

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  36. case class ServerStatusNetwork(bytesIn: Int, bytesOut: Int, numRequests: Int) extends Product with Serializable

    bytesIn

    the number of bytes that reflects the amount of network traffic received by this database

    bytesOut

    the number of bytes that reflects the amount of network traffic sent from this database

    numRequests

    the total number of distinct requests that the server has received

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    ServerStatusResult

    https://docs.mongodb.com/manual/reference/command/serverStatus/

  37. case class ServerStatusResult(host: String, version: String, process: ServerProcess, pid: Long, uptime: Long, uptimeMillis: Long, uptimeEstimate: Long, localTime: Long, advisoryHostFQDNs: List[String], asserts: ServerStatusAsserts, backgroundFlushing: Option[ServerStatusBackgroundFlushing], connections: ServerStatusConnections, dur: Option[ServerStatusJournaling], extraInfo: Option[ServerStatusExtraInfo], globalLock: ServerStatusGlobalLock, network: ServerStatusNetwork) extends Product with Serializable

    host

    the system hostname

    version

    the MongoDB version

    process

    the MongoDB process

    pid

    the process ID

    uptime

    the number of seconds this process has been active

    uptimeMillis

    same as uptime but with millisecond precision

    uptimeEstimate

    the uptime in seconds as calculated from MongoDB’s internal course-grained time keeping system

    localTime

    the UTC representation of the current server time

    advisoryHostFQDNs

    since MongoDB 3.2 (otherwise empty), the array of system fully qualified names

    asserts

    the statistics about the assertions raised by the MongoDB process since it starts

    backgroundFlushing

    the report on the periodic writes to disk (only for the MMAPv1 storage engine)

    connections

    the report about the status of the connection

    dur

    the report about the mongod instance’s journaling-related operations (only for the MMAPv1 storage engine with the journaling enabled)

    extraInfo

    the additional information regarding the underlying system

    globalLock

    the report about the database lock state

    network

    the report about the MongoDB network use

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

    See also

    @see https://docs.mongodb.com/manual/reference/command/serverStatus/

  38. trait UpdateCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Implements the update command.

    Implements the update command.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Use the new update operation

  39. case class UpdateWriteResult(ok: Boolean, n: Int, nModified: Int, upserted: Seq[Upserted], writeErrors: Seq[WriteError], writeConcernError: Option[WriteConcernError], code: Option[Int], errmsg: Option[String]) extends WriteResult with Product with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  40. type WriteConcern = GetLastError
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Will be replaced by reactivemongo.api.commands.WriteConcern

Value Members

  1. object AuthenticationRestriction
  2. object Capped extends AbstractFunction2[Long, Option[Int], Capped] with Serializable
  3. object CollStats extends AbstractFunction1[Option[Int], CollStats] with Serializable
  4. object Command
  5. object CommandError extends Serializable
  6. object ConvertToCapped extends AbstractFunction1[Capped, ConvertToCapped] with Serializable
  7. object DBUserRole extends AbstractFunction2[String, String, DBUserRole] with Serializable
  8. object DropCollectionResult extends AbstractFunction1[Boolean, DropCollectionResult] with Serializable
  9. object FindAndModifyCommand
  10. object LastError extends AbstractFunction14[Boolean, Option[String], Option[Int], Option[Long], Int, Option[String], Boolean, Option[BSONValue], Option[W], Boolean, Option[Int], Option[Int], Seq[WriteError], Option[WriteConcernError], LastError] with Serializable
  11. object MongodProcess extends ServerProcess with Product with Serializable
  12. object MongosProcess extends ServerProcess with Product with Serializable
  13. object ReplSetMember extends AbstractFunction15[Long, String, Int, Int, String, Long, Long, Option[Long], Option[Long], Option[String], Option[Long], Boolean, Option[Long], Option[String], Option[Int], ReplSetMember] with Serializable
  14. object ReplSetStatus extends AbstractFunction4[String, Long, Int, List[ReplSetMember], ReplSetStatus] with Serializable
  15. object ResultCursor extends AbstractFunction2[Long, String, ResultCursor] with Serializable
  16. object ResyncResult extends BoxedAnyVal[Unit]
  17. object ServerProcess
  18. object UnitBox extends BoxedAnyVal[Unit]
  19. object Upserted extends AbstractFunction2[Int, BSONValue, Upserted] with Serializable
  20. object UserRole

    User role extractor

  21. object WriteConcernError extends AbstractFunction2[Int, String, WriteConcernError] with Serializable
  22. object WriteError extends AbstractFunction3[Int, Int, String, WriteError] with Serializable
  23. object WriteResult

Deprecated Value Members

  1. val Collation: api.Collation.type
    Annotations
    @deprecated
    Deprecated

    (Since version 0.19.8) Will be replaced by reactivemongo.api.Collation

  2. val WriteConcern: GetLastError.type
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Will be replaced by reactivemongo.api.commands.WriteConcern

  3. object CreateIndexes extends AbstractFunction2[String, List[Index], CreateIndexes] with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  4. object DropCollection extends CollectionCommand with CommandWithResult[DropCollectionResult]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  5. object DropDatabase extends Command with CommandWithResult[UnitBox.type]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  6. object DropIndexes extends AbstractFunction1[String, DropIndexes] with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  7. object EmptyCapped extends CollectionCommand with CommandWithResult[UnitBox.type]
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  8. object GetLastError extends Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Will be replaced by reactivemongo.api.commands.WriteConcern

  9. object ListCollectionNames extends Command with CommandWithResult[CollectionNames]

    List the names of DB collections.

    List the names of DB collections.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  10. object ListIndexes extends AbstractFunction1[String, ListIndexes] with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  11. object MultiBulkWriteResult extends Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.19.8) Will be replaced by reactivemongo.api.MultiWriteResult

  12. object PingCommand extends Command with CommandWithResult[Boolean] with Product with Serializable

    The ping command.

    The ping command.

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  13. object ReplSetGetStatus extends Command with CommandWithResult[ReplSetStatus] with Product with Serializable

    The command replSetGetStatus

    The command replSetGetStatus

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  14. object ReplSetMaintenance extends AbstractFunction1[Boolean, ReplSetMaintenance] with Serializable
    Annotations
    @deprecated
    Deprecated

    (Since version 0.19.0) Internal: will be made private

  15. object Resync extends Command with CommandWithResult[ResyncResult.type]

    The command resync

    The command resync

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

  16. object ServerStatus extends Command with CommandWithResult[ServerStatusResult] with Product with Serializable

    Server status

    Server status

    Annotations
    @deprecated
    Deprecated

    (Since version 0.16.0) Internal: will be made private

Inherited from AnyRef

Inherited from Any

Ungrouped