Package

reactivemongo.api

commands

Permalink

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. All

Type Members

  1. sealed trait AbstractCommand extends AnyRef

    Permalink
  2. trait AggregationFramework[P <: SerializationPack] extends ImplicitCommandHelpers[P] with GroupAggregation[P]

    Permalink

    Implements the Aggregation Framework.

  3. trait BoxedAnyVal[A <: AnyVal] extends AnyRef

    Permalink
  4. case class Capped(size: Long, max: Option[Int] = None) extends Product with Serializable

    Permalink
  5. case class CollStats(scale: Option[Int] = None) extends CollectionCommand with CommandWithResult[CollStatsResult] with Product with Serializable

    Permalink
  6. 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

    Permalink

    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.

  7. trait CollectionCommand extends AbstractCommand

    Permalink
  8. case class CollectionNames(names: List[String]) extends Product with Serializable

    Permalink
  9. trait Command extends AbstractCommand

    Permalink
  10. trait CommandError extends Exception with NoStackTrace

    Permalink

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

  11. trait CommandWithPack[P <: SerializationPack] extends AnyRef

    Permalink
  12. trait CommandWithResult[R] extends AnyRef

    Permalink
  13. case class ConvertToCapped(capped: Capped) extends CollectionCommand with CommandWithResult[UnitBox.type] with Product with Serializable

    Permalink
  14. trait CountCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

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

    Permalink
  16. case class CreateIndexes(db: String, indexes: List[Index]) extends CollectionCommand with CommandWithResult[WriteResult] with Product with Serializable

    Permalink

    Creates the given indexes on the specified collection.

    Creates the given indexes on the specified collection.

    db

    the database name

    indexes

    the indexes to be created

  17. trait CreateUserCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Permalink
  18. trait CursorFetcher[P <: SerializationPack, +C[_] <: Cursor[_]] extends AnyRef

    Permalink

    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

  19. case class DBUserRole(name: String, db: String) extends UserRole with Product with Serializable

    Permalink

    db

    the name of the database

  20. 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

    Permalink
  21. trait DeleteCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Permalink
  22. trait DistinctCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Permalink

    The distinct command.

  23. case class DropCollectionResult(dropped: Boolean) extends Product with Serializable

    Permalink

    dropped

    true if the collection existed and was dropped

  24. case class DropIndexes(index: String) extends CollectionCommand with CommandWithResult[DropIndexesResult] with Product with Serializable

    Permalink
  25. case class DropIndexesResult(value: Int) extends BoxedAnyVal[Int] with Product with Serializable

    Permalink
  26. trait FindAndModifyCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

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

    Permalink

    wtimeout

    the time limit

  28. sealed trait GroupAggregation[P <: SerializationPack] extends AnyRef

    Permalink
  29. trait ImplicitCommandHelpers[P <: SerializationPack] extends AnyRef

    Permalink
  30. trait InsertCommand[P <: SerializationPack] extends ImplicitCommandHelpers[P]

    Permalink
  31. trait IsMasterCommand[P <: SerializationPack] extends AnyRef

    Permalink
  32. case class LastError(ok: Boolean, errmsg: Option[String], code: Option[Int], lastOp: Option[Long], n: Int, singleShard: Option[String], updatedExisting: Boolean, upserted: Option[BSONValue], wnote: Option[W], wtimeout: Boolean, waited: Option[Int], wtime: Option[Int], writeErrors: Seq[WriteError] = Nil, writeConcernError: Option[WriteConcernError] = None) extends Exception with DatabaseException with WriteResult with NoStackTrace with Product with Serializable

    Permalink
  33. case class ListIndexes(db: String) extends CollectionCommand with CommandWithResult[List[Index]] with Product with Serializable

    Permalink

    Lists the indexes of the specified collection.

    Lists the indexes of the specified collection.

    db

    the database name

  34. trait Mongo26WriteCommand extends AnyRef

    Permalink
  35. 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

    Permalink
  36. case class RenameCollection(fullyQualifiedCollectionName: String, fullyQualifiedTargetName: String, dropTarget: Boolean = false) extends Command with CommandWithResult[UnitBox.type] with Product with Serializable

    Permalink
  37. case class ReplSetMaintenance(enable: Boolean = true) extends Command with CommandWithResult[UnitBox.type] with Product with Serializable

    Permalink

    The replSetMaintenance command.

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

    enable

    if true the the member enters the RECOVERING state

  38. case class ReplSetMember(_id: Long, name: String, health: Int, state: Int, stateStr: String, uptime: Long, optime: Long, lastHeartbeat: Option[Long], lastHeartbeatRecv: Option[Long], lastHeartbeatMessage: Option[String], electionTime: Option[Long], self: Boolean, pingMs: Option[Long], syncingTo: Option[String], configVersion: Option[Int]) extends Product with Serializable

    Permalink

    Replica set member.

    Replica set member.

    name

    the member name (e.g. "host:port")

    health

    the health indicator for this member

    state

    the state code of the member

    stateStr

    the string representation of the state

    uptime

    the number of seconds that this member has been online

    optime

    information regarding the last operation from the operation log that this member has applied

    lastHeartbeat

    the time of the transmission time of last heartbeat received from this member

    lastHeartbeatRecv

    the time that the last heartbeat was received from this member

    lastHeartbeatMessage

    an optional message from the last heartbeat

    electionTime

    if the member is the primary, the time it was elected as

    self

    indicates which replica set member processed the replSetGetStatus command

    pingMs

    the number of milliseconds (ms) that a round-trip packet takes to travel between the remote member and the local instance (does not appear for the member that returns the rs.status() data)

    syncingTo

    the hostname of the member from which this instance is syncing (only present on the output of rs.status() on secondary and recovering members)

    configVersion

    the configuration version (since MongoDB 3.0)

  39. case class ReplSetStatus(name: String, time: Long, myState: Int, members: List[ReplSetMember]) extends Product with Serializable

    Permalink

    Result from the replSetGetStatus.

    Result from the replSetGetStatus.

    name

    the name of the replica set

    time

    the current server time

    members

    the list of the members of this replicate set

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

    Permalink

    collection

    the name of the collection against which the command is executed

    command

    the executed command

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

    Permalink

    response

    the response associated with the result

    numberToReturn

    the number of documents to return

    value

    the value parsed from the response

  42. case class ResultCursor(cursorId: Long, fullCollectionName: String) extends Product with Serializable

    Permalink

    cursorId

    the ID of the cursor

    fullCollectionName

    the namespace of the collection

  43. sealed trait ServerProcess extends AnyRef

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

    Permalink

    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

    See also

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

    ServerStatusResult

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

    Permalink

    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

    See also

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

    ServerStatusResult

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

    Permalink

    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.

    See also

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

    ServerStatusResult

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

    Permalink

    heapUsageBytes

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

    pageFaults

    the total number of page faults

    See also

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

    ServerStatusResult

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

    Permalink

    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

    See also

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

    ServerStatusResult

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

    Permalink

    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

    See also

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

    ServerStatusResult

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

    Permalink

    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

    See also

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

    ServerStatusJournaling

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

    Permalink

    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

    See also

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

    ServerStatusGlobalLock

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

    Permalink

    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

    See also

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

    ServerStatusResult

  53. 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

    Permalink

    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

    See also

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

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

    Permalink
  55. 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

    Permalink
  56. case class Upserted(index: Int, _id: BSONValue) extends Product with Serializable

    Permalink
  57. class UserRole extends AnyRef

    Permalink

  58. type WriteConcern = GetLastError

    Permalink
  59. case class WriteConcernError(code: Int, errmsg: String) extends Product with Serializable

    Permalink

    code

    the error code

    errmsg

    the error message

  60. case class WriteError(index: Int, code: Int, errmsg: String) extends Product with Serializable

    Permalink

    code

    the error code

    errmsg

    the error message

  61. sealed trait WriteResult extends AnyRef

    Permalink

Value Members

  1. object Command

    Permalink
  2. object CommandError extends Serializable

    Permalink
  3. object DropCollection extends CollectionCommand with CommandWithResult[DropCollectionResult]

    Permalink
  4. object DropDatabase extends Command with CommandWithResult[UnitBox.type]

    Permalink
  5. object EmptyCapped extends CollectionCommand with CommandWithResult[UnitBox.type]

    Permalink
  6. object GetLastError extends Serializable

    Permalink
  7. object ListCollectionNames extends Command with CommandWithResult[CollectionNames]

    Permalink

    List the names of DB collections.

  8. object MongodProcess extends ServerProcess with Product with Serializable

    Permalink
  9. object MongosProcess extends ServerProcess with Product with Serializable

    Permalink
  10. object MultiBulkWriteResult extends Serializable

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

    Permalink

    The command replSetGetStatus

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

    Permalink

    The command resync

  13. object ResyncResult extends BoxedAnyVal[Unit]

    Permalink
  14. object ServerProcess

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

    Permalink

    Server status

  16. object UnitBox extends BoxedAnyVal[Unit]

    Permalink
  17. object UserRole

    Permalink

    User role extractor

  18. val WriteConcern: GetLastError.type

    Permalink
  19. object WriteResult

    Permalink
  20. package bson

    Permalink

Deprecated Value Members

  1. object Drop extends CollectionCommand with CommandWithResult[UnitBox.type]

    Permalink
    Annotations
    @deprecated
    Deprecated

    (Since version 0.12.0) Use DropCollection

Inherited from AnyRef

Inherited from Any

Ungrouped