Server IP : 162.213.251.212 / Your IP : 18.191.185.51 [ Web Server : LiteSpeed System : Linux business55.web-hosting.com 4.18.0-553.lve.el8.x86_64 #1 SMP Mon May 27 15:27:34 UTC 2024 x86_64 User : allssztx ( 535) PHP Version : 8.1.31 Disable Function : NONE Domains : 1 Domains MySQL : OFF | cURL : ON | WGET : ON | Perl : ON | Python : ON | Sudo : OFF | Pkexec : OFF Directory : /proc/self/root/home/allssztx/needapair.com/node_modules/mongodb/src/ |
Upload File : |
import { Admin } from './admin'; import { OrderedBulkOperation } from './bulk/ordered'; import { UnorderedBulkOperation } from './bulk/unordered'; import { ChangeStream } from './change_stream'; import { Collection } from './collection'; import { AbstractCursor } from './cursor/abstract_cursor'; import { AggregationCursor } from './cursor/aggregation_cursor'; import { FindCursor } from './cursor/find_cursor'; import { ListCollectionsCursor } from './cursor/list_collections_cursor'; import { ListIndexesCursor } from './cursor/list_indexes_cursor'; import type { RunCommandCursor } from './cursor/run_command_cursor'; import { Db } from './db'; import { GridFSBucket } from './gridfs'; import { GridFSBucketReadStream } from './gridfs/download'; import { GridFSBucketWriteStream } from './gridfs/upload'; import { MongoClient } from './mongo_client'; import { CancellationToken } from './mongo_types'; import { ClientSession } from './sessions'; /** @public */ export { BSON } from './bson'; export { Binary, BSONRegExp, BSONSymbol, BSONType, Code, DBRef, Decimal128, Double, Int32, Long, MaxKey, MinKey, ObjectId, Timestamp, UUID } from './bson'; export { AnyBulkWriteOperation, BulkWriteOptions, MongoBulkWriteError } from './bulk/common'; export { ClientEncryption } from './client-side-encryption/client_encryption'; export { ChangeStreamCursor } from './cursor/change_stream_cursor'; export { MongoAPIError, MongoAWSError, MongoAzureError, MongoBatchReExecutionError, MongoChangeStreamError, MongoClientBulkWriteCursorError, MongoClientBulkWriteError, MongoClientBulkWriteExecutionError, MongoCompatibilityError, MongoCursorExhaustedError, MongoCursorInUseError, MongoDecompressionError, MongoDriverError, MongoError, MongoExpiredSessionError, MongoGCPError, MongoGridFSChunkError, MongoGridFSStreamError, MongoInvalidArgumentError, MongoKerberosError, MongoMissingCredentialsError, MongoMissingDependencyError, MongoNetworkError, MongoNetworkTimeoutError, MongoNotConnectedError, MongoOIDCError, MongoParseError, MongoRuntimeError, MongoServerClosedError, MongoServerError, MongoServerSelectionError, MongoSystemError, MongoTailableCursorError, MongoTopologyClosedError, MongoTransactionError, MongoUnexpectedServerResponseError, MongoWriteConcernError, WriteConcernErrorResult } from './error'; export { configureExplicitResourceManagement } from './resource_management'; export { AbstractCursor, // Actual driver classes exported Admin, AggregationCursor, CancellationToken, ChangeStream, ClientSession, Collection, Db, FindCursor, GridFSBucket, GridFSBucketReadStream, GridFSBucketWriteStream, ListCollectionsCursor, ListIndexesCursor, MongoClient, OrderedBulkOperation, RunCommandCursor, UnorderedBulkOperation }; // enums export { BatchType } from './bulk/common'; export { AutoEncryptionLoggerLevel } from './client-side-encryption/auto_encrypter'; export { GSSAPICanonicalizationValue } from './cmap/auth/gssapi'; export { AuthMechanism } from './cmap/auth/providers'; export { Compressor } from './cmap/wire_protocol/compression'; export { CURSOR_FLAGS } from './cursor/abstract_cursor'; export { MongoErrorLabel } from './error'; export { ExplainVerbosity } from './explain'; export { ServerApiVersion } from './mongo_client'; export { ReturnDocument } from './operations/find_and_modify'; export { ProfilingLevel } from './operations/set_profiling_level'; export { ReadConcernLevel } from './read_concern'; export { ReadPreferenceMode } from './read_preference'; export { ServerType, TopologyType } from './sdam/common'; // Helper classes export { ReadConcern } from './read_concern'; export { ReadPreference } from './read_preference'; export { WriteConcern } from './write_concern'; // events export { CommandFailedEvent, CommandStartedEvent, CommandSucceededEvent } from './cmap/command_monitoring_events'; export { ConnectionCheckedInEvent, ConnectionCheckedOutEvent, ConnectionCheckOutFailedEvent, ConnectionCheckOutStartedEvent, ConnectionClosedEvent, ConnectionCreatedEvent, ConnectionPoolClearedEvent, ConnectionPoolClosedEvent, ConnectionPoolCreatedEvent, ConnectionPoolMonitoringEvent, ConnectionPoolReadyEvent, ConnectionReadyEvent } from './cmap/connection_pool_events'; export { ServerClosedEvent, ServerDescriptionChangedEvent, ServerHeartbeatFailedEvent, ServerHeartbeatStartedEvent, ServerHeartbeatSucceededEvent, ServerOpeningEvent, TopologyClosedEvent, TopologyDescriptionChangedEvent, TopologyOpeningEvent } from './sdam/events'; export { ServerSelectionEvent, ServerSelectionFailedEvent, ServerSelectionStartedEvent, ServerSelectionSucceededEvent, WaitingForSuitableServerEvent } from './sdam/server_selection_events'; export { SrvPollingEvent } from './sdam/srv_polling'; // type only exports below, these are removed from emitted JS export type { AdminPrivate } from './admin'; export type { BSONElement, BSONSerializeOptions, Document } from './bson'; export type { deserialize, serialize } from './bson'; export type { BulkResult, BulkWriteOperationError, BulkWriteResult, DeleteManyModel, DeleteOneModel, InsertOneModel, ReplaceOneModel, UpdateManyModel, UpdateOneModel, WriteConcernError, WriteError } from './bulk/common'; export type { Batch, BulkOperationBase, BulkOperationPrivate, FindOperators, WriteConcernErrorData } from './bulk/common'; export type { ChangeStreamCollModDocument, ChangeStreamCreateDocument, ChangeStreamCreateIndexDocument, ChangeStreamDeleteDocument, ChangeStreamDocument, ChangeStreamDocumentCollectionUUID, ChangeStreamDocumentCommon, ChangeStreamDocumentKey, ChangeStreamDocumentOperationDescription, ChangeStreamDropDatabaseDocument, ChangeStreamDropDocument, ChangeStreamDropIndexDocument, ChangeStreamEvents, ChangeStreamInsertDocument, ChangeStreamInvalidateDocument, ChangeStreamNameSpace, ChangeStreamOptions, ChangeStreamRefineCollectionShardKeyDocument, ChangeStreamRenameDocument, ChangeStreamReplaceDocument, ChangeStreamReshardCollectionDocument, ChangeStreamShardCollectionDocument, ChangeStreamSplitEvent, ChangeStreamUpdateDocument, OperationTime, ResumeOptions, ResumeToken, UpdateDescription } from './change_stream'; export type { AutoEncrypter } from './client-side-encryption/auto_encrypter'; export type { AutoEncryptionOptions } from './client-side-encryption/auto_encrypter'; export type { AutoEncryptionExtraOptions } from './client-side-encryption/auto_encrypter'; export type { AWSEncryptionKeyOptions, AzureEncryptionKeyOptions, ClientEncryptionCreateDataKeyProviderOptions, ClientEncryptionEncryptOptions, ClientEncryptionOptions, ClientEncryptionRewrapManyDataKeyProviderOptions, ClientEncryptionRewrapManyDataKeyResult, DataKey, GCPEncryptionKeyOptions, KMIPEncryptionKeyOptions, RangeOptions } from './client-side-encryption/client_encryption'; export { MongoCryptAzureKMSRequestError, MongoCryptCreateDataKeyError, MongoCryptCreateEncryptedCollectionError, MongoCryptError, MongoCryptInvalidArgumentError, MongoCryptKMSRequestNetworkTimeoutError } from './client-side-encryption/errors'; export type { MongocryptdManager } from './client-side-encryption/mongocryptd_manager'; export type { AWSKMSProviderConfiguration, AzureKMSProviderConfiguration, ClientEncryptionDataKeyProvider, GCPKMSProviderConfiguration, KMIPKMSProviderConfiguration, KMSProviders, LocalKMSProviderConfiguration } from './client-side-encryption/providers/index'; export type { ClientEncryptionSocketOptions, ClientEncryptionTlsOptions, CSFLEKMSTlsOptions, StateMachineExecutable } from './client-side-encryption/state_machine'; export type { AuthContext, AuthProvider } from './cmap/auth/auth_provider'; export type { AuthMechanismProperties, MongoCredentials, MongoCredentialsOptions } from './cmap/auth/mongo_credentials'; export type { IdPInfo, IdPServerResponse, OIDCCallbackFunction, OIDCCallbackParams, OIDCResponse } from './cmap/auth/mongodb_oidc'; export type { Workflow } from './cmap/auth/mongodb_oidc'; export type { TokenCache } from './cmap/auth/mongodb_oidc/token_cache'; export type { MessageHeader, OpCompressedRequest, OpMsgOptions, OpMsgRequest, OpMsgResponse, OpQueryOptions, OpQueryRequest, OpReply, WriteProtocolMessageType } from './cmap/commands'; export type { HandshakeDocument } from './cmap/connect'; export type { LEGAL_TCP_SOCKET_OPTIONS, LEGAL_TLS_SOCKET_OPTIONS, Stream } from './cmap/connect'; export type { CommandOptions, Connection, ConnectionEvents, ConnectionOptions, ProxyOptions } from './cmap/connection'; export type { CloseOptions, ConnectionPool, ConnectionPoolEvents, ConnectionPoolOptions, PoolState, WaitQueueMember, WithConnectionCallback } from './cmap/connection_pool'; export type { ClientMetadata, ClientMetadataOptions } from './cmap/handshake/client_metadata'; export type { ConnectionPoolMetrics } from './cmap/metrics'; export type { StreamDescription, StreamDescriptionOptions } from './cmap/stream_description'; export type { CompressorName } from './cmap/wire_protocol/compression'; export type { JSTypeOf, OnDemandDocument, OnDemandDocumentDeserializeOptions } from './cmap/wire_protocol/on_demand/document'; export type { CursorResponse, MongoDBResponse, MongoDBResponseConstructor } from './cmap/wire_protocol/responses'; export type { CollectionOptions, CollectionPrivate, CountDocumentsOptions, ModifyResult } from './collection'; export type { COMMAND_FAILED, COMMAND_STARTED, COMMAND_SUCCEEDED, CONNECTION_CHECK_OUT_FAILED, CONNECTION_CHECK_OUT_STARTED, CONNECTION_CHECKED_IN, CONNECTION_CHECKED_OUT, CONNECTION_CLOSED, CONNECTION_CREATED, CONNECTION_POOL_CLEARED, CONNECTION_POOL_CLOSED, CONNECTION_POOL_CREATED, CONNECTION_POOL_READY, CONNECTION_READY, MONGO_CLIENT_EVENTS, SERVER_CLOSED, SERVER_DESCRIPTION_CHANGED, SERVER_HEARTBEAT_FAILED, SERVER_HEARTBEAT_STARTED, SERVER_HEARTBEAT_SUCCEEDED, SERVER_OPENING, SERVER_SELECTION_FAILED, SERVER_SELECTION_STARTED, SERVER_SELECTION_SUCCEEDED, TOPOLOGY_CLOSED, TOPOLOGY_DESCRIPTION_CHANGED, TOPOLOGY_OPENING, WAITING_FOR_SUITABLE_SERVER } from './constants'; export type { AbstractCursorEvents, AbstractCursorOptions, CursorFlag, CursorStreamOptions } from './cursor/abstract_cursor'; export type { InitialCursorResponse, InternalAbstractCursorOptions } from './cursor/abstract_cursor'; export type { AggregationCursorOptions } from './cursor/aggregation_cursor'; export type { ChangeStreamCursorOptions } from './cursor/change_stream_cursor'; export type { ListSearchIndexesCursor, ListSearchIndexesOptions } from './cursor/list_search_indexes_cursor'; export type { RunCursorCommandOptions } from './cursor/run_command_cursor'; export type { DbOptions, DbPrivate } from './db'; export type { Encrypter, EncrypterOptions } from './encrypter'; export type { AnyError, ErrorDescription, MongoNetworkErrorOptions } from './error'; export type { Explain, ExplainCommandOptions, ExplainOptions, ExplainVerbosityLike } from './explain'; export type { GridFSBucketReadStreamOptions, GridFSBucketReadStreamOptionsWithRevision, GridFSBucketReadStreamPrivate, GridFSFile } from './gridfs/download'; export type { GridFSBucketEvents, GridFSBucketOptions, GridFSBucketPrivate } from './gridfs/index'; export type { GridFSBucketWriteStreamOptions, GridFSChunk } from './gridfs/upload'; export type { Auth, DriverInfo, MongoClientEvents, MongoClientOptions, MongoClientPrivate, MongoOptions, PkFactory, ServerApi, SupportedNodeConnectionOptions, SupportedSocketOptions, SupportedTLSConnectionOptions, SupportedTLSSocketOptions, WithSessionCallback } from './mongo_client'; export { MongoClientAuthProviders } from './mongo_client_auth_providers'; export type { Log, LogComponentSeveritiesClientOptions, LogConvertible, Loggable, LoggableCommandFailedEvent, LoggableCommandSucceededEvent, LoggableEvent, LoggableServerHeartbeatFailedEvent, LoggableServerHeartbeatStartedEvent, LoggableServerHeartbeatSucceededEvent, MongoDBLogWritable, MongoLoggableComponent, MongoLogger, MongoLoggerEnvOptions, MongoLoggerMongoClientOptions, MongoLoggerOptions, SeverityLevel } from './mongo_logger'; export type { CommonEvents, EventsDescription, GenericListener, TypedEventEmitter } from './mongo_types'; export type { AcceptedFields, AddToSetOperators, AlternativeType, ArrayElement, ArrayOperator, BitwiseFilter, BSONTypeAlias, Condition, EnhancedOmit, Filter, FilterOperations, FilterOperators, Flatten, InferIdType, IntegerType, IsAny, Join, KeysOfAType, KeysOfOtherType, MatchKeysAndValues, NestedPaths, NestedPathsOfType, NonObjectIdLikeDocument, NotAcceptedFields, NumericType, OneOrMore, OnlyFieldsOfType, OptionalId, OptionalUnlessRequiredId, PropertyType, PullAllOperator, PullOperator, PushOperator, RegExpOrString, RootFilterOperators, SchemaMember, SetFields, StrictFilter, StrictMatchKeysAndValues, StrictUpdateFilter, UpdateFilter, WithId, WithoutId } from './mongo_types'; export type { AggregateOperation, AggregateOptions, DB_AGGREGATE_COLLECTION } from './operations/aggregate'; export type { AnyClientBulkWriteModel, ClientBulkWriteError, ClientBulkWriteModel, ClientBulkWriteOptions, ClientBulkWriteResult, ClientDeleteManyModel, ClientDeleteOneModel, ClientDeleteResult, ClientInsertOneModel, ClientInsertOneResult, ClientReplaceOneModel, ClientUpdateManyModel, ClientUpdateOneModel, ClientUpdateResult, ClientWriteModel } from './operations/client_bulk_write/common'; export type { CollationOptions, CommandOperation, CommandOperationOptions, OperationParent } from './operations/command'; export type { CountOptions } from './operations/count'; export type { ClusteredCollectionOptions, CreateCollectionOptions, TimeSeriesCollectionOptions } from './operations/create_collection'; export type { DeleteOptions, DeleteResult, DeleteStatement } from './operations/delete'; export type { DistinctOptions } from './operations/distinct'; export type { DropCollectionOptions, DropDatabaseOptions } from './operations/drop'; export type { EstimatedDocumentCountOptions } from './operations/estimated_document_count'; export type { FindOptions } from './operations/find'; export type { FindOneAndDeleteOptions, FindOneAndReplaceOptions, FindOneAndUpdateOptions } from './operations/find_and_modify'; export type { IndexInformationOptions } from './operations/indexes'; export type { CreateIndexesOptions, DropIndexesOptions, IndexDescription, IndexDescriptionCompact, IndexDescriptionInfo, IndexDirection, IndexSpecification, ListIndexesOptions } from './operations/indexes'; export type { InsertManyResult, InsertOneOptions, InsertOneResult } from './operations/insert'; export type { CollectionInfo, ListCollectionsOptions } from './operations/list_collections'; export type { ListDatabasesOptions, ListDatabasesResult } from './operations/list_databases'; export type { AbstractOperation, Hint, OperationOptions } from './operations/operation'; export type { ProfilingLevelOptions } from './operations/profiling_level'; export type { RemoveUserOptions } from './operations/remove_user'; export type { RenameOptions } from './operations/rename'; export type { RunCommandOptions } from './operations/run_command'; export type { SearchIndexDescription } from './operations/search_indexes/create'; export type { SetProfilingLevelOptions } from './operations/set_profiling_level'; export type { DbStatsOptions } from './operations/stats'; export type { ReplaceOptions, UpdateOptions, UpdateResult, UpdateStatement } from './operations/update'; export type { ValidateCollectionOptions } from './operations/validate_collection'; export type { ReadConcernLike } from './read_concern'; export type { HedgeOptions, ReadPreferenceFromOptions, ReadPreferenceLike, ReadPreferenceLikeOptions, ReadPreferenceOptions } from './read_preference'; export type { AsyncDisposable } from './resource_management'; export type { ClusterTime, TimerQueue } from './sdam/common'; export type { Monitor, MonitorEvents, MonitorInterval, MonitorIntervalOptions, MonitorOptions, MonitorPrivate, RTTPinger, RTTPingerOptions, RTTSampler, ServerMonitoringMode } from './sdam/monitor'; export type { Server, ServerEvents, ServerOptions, ServerPrivate } from './sdam/server'; export type { ServerDescription, ServerDescriptionOptions, TagSet, TopologyVersion } from './sdam/server_description'; export type { ServerSelector } from './sdam/server_selection'; export type { SrvPoller, SrvPollerEvents, SrvPollerOptions } from './sdam/srv_polling'; export type { ConnectOptions, SelectServerOptions, ServerCapabilities, ServerSelectionCallback, ServerSelectionRequest, Topology, TopologyEvents, TopologyOptions, TopologyPrivate } from './sdam/topology'; export type { TopologyDescription, TopologyDescriptionOptions } from './sdam/topology_description'; export type { ClientSessionEvents, ClientSessionOptions, EndSessionOptions, ServerSession, ServerSessionId, ServerSessionPool, WithTransactionCallback } from './sessions'; export type { Sort, SortDirection, SortDirectionForCmd, SortForCmd } from './sort'; export type { Timeout } from './timeout'; export type { Transaction, TransactionOptions, TxnState } from './transactions'; export type { BufferPool, Callback, EventEmitterWithState, HostAddress, List, MongoDBCollectionNamespace, MongoDBNamespace } from './utils'; export type { W, WriteConcernOptions, WriteConcernSettings } from './write_concern';