Table of Contents

Class AggregateFluentBase<TResult>

Namespace
MongoDB.Driver
Assembly
MongoDB.Driver.dll

Base class for implementors of IAggregateFluent<TResult>.

public abstract class AggregateFluentBase<TResult> : IOrderedAggregateFluent<TResult>, IAggregateFluent<TResult>, IAsyncCursorSource<TResult>

Type Parameters

TResult

The type of the document.

Inheritance
AggregateFluentBase<TResult>
Implements
Inherited Members
Extension Methods

Properties

Database

Gets the database.

public virtual IMongoDatabase Database { get; }

Property Value

IMongoDatabase

Options

Gets the options.

public abstract AggregateOptions Options { get; }

Property Value

AggregateOptions

Stages

Gets the stages.

public abstract IList<IPipelineStageDefinition> Stages { get; }

Property Value

IList<IPipelineStageDefinition>

Methods

AppendStage<TNewResult>(PipelineStageDefinition<TResult, TNewResult>)

Appends the stage to the pipeline.

public abstract IAggregateFluent<TNewResult> AppendStage<TNewResult>(PipelineStageDefinition<TResult, TNewResult> stage)

Parameters

stage PipelineStageDefinition<TResult, TNewResult>

The stage.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the result of the stage.

As<TNewResult>(IBsonSerializer<TNewResult>)

Changes the result type of the pipeline.

public abstract IAggregateFluent<TNewResult> As<TNewResult>(IBsonSerializer<TNewResult> newResultSerializer)

Parameters

newResultSerializer IBsonSerializer<TNewResult>

The new result serializer.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the new result.

BucketAuto<TValue>(AggregateExpressionDefinition<TResult, TValue>, int, AggregateBucketAutoOptions)

Appends a $bucketAuto stage to the pipeline.

public virtual IAggregateFluent<AggregateBucketAutoResult<TValue>> BucketAuto<TValue>(AggregateExpressionDefinition<TResult, TValue> groupBy, int buckets, AggregateBucketAutoOptions options = null)

Parameters

groupBy AggregateExpressionDefinition<TResult, TValue>

The expression providing the value to group by.

buckets int

The number of buckets.

options AggregateBucketAutoOptions

The options (optional).

Returns

IAggregateFluent<AggregateBucketAutoResult<TValue>>

The fluent aggregate interface.

Type Parameters

TValue

The type of the value.

BucketAuto<TValue, TNewResult>(AggregateExpressionDefinition<TResult, TValue>, int, ProjectionDefinition<TResult, TNewResult>, AggregateBucketAutoOptions)

Appends a $bucketAuto stage to the pipeline with a custom projection.

public virtual IAggregateFluent<TNewResult> BucketAuto<TValue, TNewResult>(AggregateExpressionDefinition<TResult, TValue> groupBy, int buckets, ProjectionDefinition<TResult, TNewResult> output, AggregateBucketAutoOptions options = null)

Parameters

groupBy AggregateExpressionDefinition<TResult, TValue>

The expression providing the value to group by.

buckets int

The number of buckets.

output ProjectionDefinition<TResult, TNewResult>

The output projection.

options AggregateBucketAutoOptions

The options (optional).

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TValue

The type of the value.

TNewResult

The type of the new result.

Bucket<TValue>(AggregateExpressionDefinition<TResult, TValue>, IEnumerable<TValue>, AggregateBucketOptions<TValue>)

Appends a $bucket stage to the pipeline.

public virtual IAggregateFluent<AggregateBucketResult<TValue>> Bucket<TValue>(AggregateExpressionDefinition<TResult, TValue> groupBy, IEnumerable<TValue> boundaries, AggregateBucketOptions<TValue> options = null)

Parameters

groupBy AggregateExpressionDefinition<TResult, TValue>

The expression providing the value to group by.

boundaries IEnumerable<TValue>

The bucket boundaries.

options AggregateBucketOptions<TValue>

The options.

Returns

IAggregateFluent<AggregateBucketResult<TValue>>

The fluent aggregate interface.

Type Parameters

TValue

The type of the value.

Bucket<TValue, TNewResult>(AggregateExpressionDefinition<TResult, TValue>, IEnumerable<TValue>, ProjectionDefinition<TResult, TNewResult>, AggregateBucketOptions<TValue>)

Appends a $bucket stage to the pipeline with a custom projection.

public virtual IAggregateFluent<TNewResult> Bucket<TValue, TNewResult>(AggregateExpressionDefinition<TResult, TValue> groupBy, IEnumerable<TValue> boundaries, ProjectionDefinition<TResult, TNewResult> output, AggregateBucketOptions<TValue> options = null)

Parameters

groupBy AggregateExpressionDefinition<TResult, TValue>

The expression providing the value to group by.

boundaries IEnumerable<TValue>

The bucket boundaries.

output ProjectionDefinition<TResult, TNewResult>

The output projection.

options AggregateBucketOptions<TValue>

The options.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TValue

The type of the value.

TNewResult

The type of the new result.

ChangeStream(ChangeStreamStageOptions)

Appends a $changeStream stage to the pipeline. Normally you would prefer to use the Watch method of IMongoCollection<TDocument>. Only use this method if subsequent stages project away the resume token (the _id) or you don't want the resulting cursor to automatically resume.

public virtual IAggregateFluent<ChangeStreamDocument<TResult>> ChangeStream(ChangeStreamStageOptions options = null)

Parameters

options ChangeStreamStageOptions

The options.

Returns

IAggregateFluent<ChangeStreamDocument<TResult>>

The fluent aggregate interface.

Count()

Appends a count stage to the pipeline.

public virtual IAggregateFluent<AggregateCountResult> Count()

Returns

IAggregateFluent<AggregateCountResult>

The fluent aggregate interface.

Densify(FieldDefinition<TResult>, DensifyRange, params FieldDefinition<TResult>[])

Appends a $densify stage to the pipeline.

public virtual IAggregateFluent<TResult> Densify(FieldDefinition<TResult> field, DensifyRange range, params FieldDefinition<TResult>[] partitionByFields)

Parameters

field FieldDefinition<TResult>

The field.

range DensifyRange

The range.

partitionByFields FieldDefinition<TResult>[]

The fields to partition by.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

Densify(FieldDefinition<TResult>, DensifyRange, IEnumerable<FieldDefinition<TResult>>)

Appends a $densify stage to the pipeline.

public virtual IAggregateFluent<TResult> Densify(FieldDefinition<TResult> field, DensifyRange range, IEnumerable<FieldDefinition<TResult>> partitionByFields = null)

Parameters

field FieldDefinition<TResult>

The field.

range DensifyRange

The range.

partitionByFields IEnumerable<FieldDefinition<TResult>>

The fields to partition by.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

Facet<TNewResult>(IEnumerable<AggregateFacet<TResult>>, AggregateFacetOptions<TNewResult>)

Appends a $facet stage to the pipeline.

public virtual IAggregateFluent<TNewResult> Facet<TNewResult>(IEnumerable<AggregateFacet<TResult>> facets, AggregateFacetOptions<TNewResult> options = null)

Parameters

facets IEnumerable<AggregateFacet<TResult>>

The facets.

options AggregateFacetOptions<TNewResult>

The options.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the new result.

GraphLookup<TFrom, TConnectFrom, TConnectTo, TStartWith, TAsElement, TAs, TNewResult>(IMongoCollection<TFrom>, FieldDefinition<TFrom, TConnectFrom>, FieldDefinition<TFrom, TConnectTo>, AggregateExpressionDefinition<TResult, TStartWith>, FieldDefinition<TNewResult, TAs>, FieldDefinition<TAsElement, int>, AggregateGraphLookupOptions<TFrom, TAsElement, TNewResult>)

Appends a $graphLookup stage to the pipeline.

public virtual IAggregateFluent<TNewResult> GraphLookup<TFrom, TConnectFrom, TConnectTo, TStartWith, TAsElement, TAs, TNewResult>(IMongoCollection<TFrom> from, FieldDefinition<TFrom, TConnectFrom> connectFromField, FieldDefinition<TFrom, TConnectTo> connectToField, AggregateExpressionDefinition<TResult, TStartWith> startWith, FieldDefinition<TNewResult, TAs> @as, FieldDefinition<TAsElement, int> depthField, AggregateGraphLookupOptions<TFrom, TAsElement, TNewResult> options = null) where TAs : IEnumerable<TAsElement>

Parameters

from IMongoCollection<TFrom>

The from collection.

connectFromField FieldDefinition<TFrom, TConnectFrom>

The connect from field.

connectToField FieldDefinition<TFrom, TConnectTo>

The connect to field.

startWith AggregateExpressionDefinition<TResult, TStartWith>

The start with value.

as FieldDefinition<TNewResult, TAs>

The as field.

depthField FieldDefinition<TAsElement, int>

The depth field.

options AggregateGraphLookupOptions<TFrom, TAsElement, TNewResult>

The options.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TFrom

The type of the from documents.

TConnectFrom

The type of the connect from field (must be either TConnectTo or a type that implements IEnumerable{TConnectTo}).

TConnectTo

The type of the connect to field.

TStartWith

The type of the start with expression (must be either TConnectTo or a type that implements IEnumerable{TConnectTo}).

TAsElement

The type of the as field elements.

TAs

The type of the as field.

TNewResult

The type of the new result (must be same as TResult with an additional as field).

Group<TNewResult>(ProjectionDefinition<TResult, TNewResult>)

Appends a group stage to the pipeline.

public abstract IAggregateFluent<TNewResult> Group<TNewResult>(ProjectionDefinition<TResult, TNewResult> group)

Parameters

group ProjectionDefinition<TResult, TNewResult>

The group projection.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the result of the stage.

Limit(long)

Appends a limit stage to the pipeline.

public abstract IAggregateFluent<TResult> Limit(long limit)

Parameters

limit long

The limit.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

Lookup<TForeignDocument, TNewResult>(string, FieldDefinition<TResult>, FieldDefinition<TForeignDocument>, FieldDefinition<TNewResult>, AggregateLookupOptions<TForeignDocument, TNewResult>)

Appends a lookup stage to the pipeline.

public virtual IAggregateFluent<TNewResult> Lookup<TForeignDocument, TNewResult>(string foreignCollectionName, FieldDefinition<TResult> localField, FieldDefinition<TForeignDocument> foreignField, FieldDefinition<TNewResult> @as, AggregateLookupOptions<TForeignDocument, TNewResult> options)

Parameters

foreignCollectionName string

Name of the other collection.

localField FieldDefinition<TResult>

The local field.

foreignField FieldDefinition<TForeignDocument>

The foreign field.

as FieldDefinition<TNewResult>

The field in TNewResult to place the foreign results.

options AggregateLookupOptions<TForeignDocument, TNewResult>

The options.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TForeignDocument

The type of the foreign document.

TNewResult

The type of the new result.

Lookup<TForeignDocument, TAsElement, TAs, TNewResult>(IMongoCollection<TForeignDocument>, BsonDocument, PipelineDefinition<TForeignDocument, TAsElement>, FieldDefinition<TNewResult, TAs>, AggregateLookupOptions<TForeignDocument, TNewResult>)

Appends a lookup stage to the pipeline.

public virtual IAggregateFluent<TNewResult> Lookup<TForeignDocument, TAsElement, TAs, TNewResult>(IMongoCollection<TForeignDocument> foreignCollection, BsonDocument let, PipelineDefinition<TForeignDocument, TAsElement> lookupPipeline, FieldDefinition<TNewResult, TAs> @as, AggregateLookupOptions<TForeignDocument, TNewResult> options = null) where TAs : IEnumerable<TAsElement>

Parameters

foreignCollection IMongoCollection<TForeignDocument>

The foreign collection.

let BsonDocument

The "let" definition.

lookupPipeline PipelineDefinition<TForeignDocument, TAsElement>

The lookup pipeline.

as FieldDefinition<TNewResult, TAs>

The as field in TNewResult in which to place the results of the lookup pipeline.

options AggregateLookupOptions<TForeignDocument, TNewResult>

The options.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TForeignDocument

The type of the foreign collection documents.

TAsElement

The type of the as field elements.

TAs

The type of the as field.

TNewResult

The type of the new result.

Match(FilterDefinition<TResult>)

Appends a match stage to the pipeline.

public abstract IAggregateFluent<TResult> Match(FilterDefinition<TResult> filter)

Parameters

filter FilterDefinition<TResult>

The filter.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

MergeAsync<TOutput>(IMongoCollection<TOutput>, MergeStageOptions<TOutput>, CancellationToken)

Appends a merge stage to the pipeline and executes it, and then returns a cursor to read the contents of the output collection.

public virtual Task<IAsyncCursor<TOutput>> MergeAsync<TOutput>(IMongoCollection<TOutput> outputCollection, MergeStageOptions<TOutput> mergeOptions = null, CancellationToken cancellationToken = default)

Parameters

outputCollection IMongoCollection<TOutput>

The output collection.

mergeOptions MergeStageOptions<TOutput>

The merge options.

cancellationToken CancellationToken

The cancellation token.

Returns

Task<IAsyncCursor<TOutput>>

A cursor.

Type Parameters

TOutput

The type of output documents.

Merge<TOutput>(IMongoCollection<TOutput>, MergeStageOptions<TOutput>, CancellationToken)

Appends a merge stage to the pipeline and executes it, and then returns a cursor to read the contents of the output collection.

public virtual IAsyncCursor<TOutput> Merge<TOutput>(IMongoCollection<TOutput> outputCollection, MergeStageOptions<TOutput> mergeOptions = null, CancellationToken cancellationToken = default)

Parameters

outputCollection IMongoCollection<TOutput>

The output collection.

mergeOptions MergeStageOptions<TOutput>

The merge options.

cancellationToken CancellationToken

The cancellation token.

Returns

IAsyncCursor<TOutput>

A cursor.

Type Parameters

TOutput

The type of output documents.

OfType<TNewResult>(IBsonSerializer<TNewResult>)

Appends a match stage to the pipeline that matches derived documents and changes the result type to the derived type.

public abstract IAggregateFluent<TNewResult> OfType<TNewResult>(IBsonSerializer<TNewResult> newResultSerializer) where TNewResult : TResult

Parameters

newResultSerializer IBsonSerializer<TNewResult>

The new result serializer.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the derived documents.

Out(IMongoCollection<TResult>, CancellationToken)

Appends an out stage to the pipeline and executes it, and then returns a cursor to read the contents of the output collection.

public virtual IAsyncCursor<TResult> Out(IMongoCollection<TResult> outputCollection, CancellationToken cancellationToken)

Parameters

outputCollection IMongoCollection<TResult>

The output collection.

cancellationToken CancellationToken

The cancellation token.

Returns

IAsyncCursor<TResult>

A cursor.

Out(string, CancellationToken)

Appends an out stage to the pipeline and executes it, and then returns a cursor to read the contents of the output collection.

public virtual IAsyncCursor<TResult> Out(string collectionName, CancellationToken cancellationToken)

Parameters

collectionName string

Name of the collection.

cancellationToken CancellationToken

The cancellation token.

Returns

IAsyncCursor<TResult>

A cursor.

OutAsync(IMongoCollection<TResult>, CancellationToken)

Appends an out stage to the pipeline and executes it, and then returns a cursor to read the contents of the output collection.

public virtual Task<IAsyncCursor<TResult>> OutAsync(IMongoCollection<TResult> outputCollection, CancellationToken cancellationToken)

Parameters

outputCollection IMongoCollection<TResult>

The output collection.

cancellationToken CancellationToken

The cancellation token.

Returns

Task<IAsyncCursor<TResult>>

A Task whose result is a cursor.

OutAsync(string, CancellationToken)

Appends an out stage to the pipeline and executes it, and then returns a cursor to read the contents of the output collection.

public abstract Task<IAsyncCursor<TResult>> OutAsync(string collectionName, CancellationToken cancellationToken)

Parameters

collectionName string

Name of the collection.

cancellationToken CancellationToken

The cancellation token.

Returns

Task<IAsyncCursor<TResult>>

A Task whose result is a cursor.

Project<TNewResult>(ProjectionDefinition<TResult, TNewResult>)

Appends a project stage to the pipeline.

public abstract IAggregateFluent<TNewResult> Project<TNewResult>(ProjectionDefinition<TResult, TNewResult> projection)

Parameters

projection ProjectionDefinition<TResult, TNewResult>

The projection.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the result of the stage.

ReplaceRoot<TNewResult>(AggregateExpressionDefinition<TResult, TNewResult>)

Appends a $replaceRoot stage to the pipeline.

public virtual IAggregateFluent<TNewResult> ReplaceRoot<TNewResult>(AggregateExpressionDefinition<TResult, TNewResult> newRoot)

Parameters

newRoot AggregateExpressionDefinition<TResult, TNewResult>

The new root.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the new result.

ReplaceWith<TNewResult>(AggregateExpressionDefinition<TResult, TNewResult>)

Appends a $replaceWith stage to the pipeline.

public virtual IAggregateFluent<TNewResult> ReplaceWith<TNewResult>(AggregateExpressionDefinition<TResult, TNewResult> newRoot)

Parameters

newRoot AggregateExpressionDefinition<TResult, TNewResult>

The new root.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the new result.

Search(SearchDefinition<TResult>, SearchHighlightOptions<TResult>, string, SearchCountOptions, bool, bool)

Appends a $search stage to the pipeline.

public virtual IAggregateFluent<TResult> Search(SearchDefinition<TResult> searchDefinition, SearchHighlightOptions<TResult> highlight = null, string indexName = null, SearchCountOptions count = null, bool returnStoredSource = false, bool scoreDetails = false)

Parameters

searchDefinition SearchDefinition<TResult>

The search definition.

highlight SearchHighlightOptions<TResult>

The highlight options.

indexName string

The index name.

count SearchCountOptions

The count options.

returnStoredSource bool

Flag that specifies whether to perform a full document lookup on the backend database or return only stored source fields directly from Atlas Search.

scoreDetails bool

Flag that specifies whether to return a detailed breakdown of the score for each document in the result.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

Search(SearchDefinition<TResult>, SearchOptions<TResult>)

Appends a $search stage to the pipeline.

public virtual IAggregateFluent<TResult> Search(SearchDefinition<TResult> searchDefinition, SearchOptions<TResult> searchOptions)

Parameters

searchDefinition SearchDefinition<TResult>

The search definition.

searchOptions SearchOptions<TResult>

The search options.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

SearchMeta(SearchDefinition<TResult>, string, SearchCountOptions)

Appends a $searchMeta stage to the pipeline.

public virtual IAggregateFluent<SearchMetaResult> SearchMeta(SearchDefinition<TResult> searchDefinition, string indexName = null, SearchCountOptions count = null)

Parameters

searchDefinition SearchDefinition<TResult>

The search definition.

indexName string

The index name.

count SearchCountOptions

The count options.

Returns

IAggregateFluent<SearchMetaResult>

The fluent aggregate interface.

Set(SetFieldDefinitions<TResult>)

Appends a $set stage to the pipeline.

public virtual IAggregateFluent<TResult> Set(SetFieldDefinitions<TResult> fields)

Parameters

fields SetFieldDefinitions<TResult>

The fields to set.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

SetWindowFields<TWindowFields>(AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields>)

Appends a $setWindowFields to the pipeline.

public virtual IAggregateFluent<BsonDocument> SetWindowFields<TWindowFields>(AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields> output)

Parameters

output AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields>

The window fields definition.

Returns

IAggregateFluent<BsonDocument>

The fluent aggregate interface.

Type Parameters

TWindowFields

The type of the added window fields.

SetWindowFields<TPartitionBy, TWindowFields>(AggregateExpressionDefinition<TResult, TPartitionBy>, AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields>)

Appends a $setWindowFields to the pipeline.

public virtual IAggregateFluent<BsonDocument> SetWindowFields<TPartitionBy, TWindowFields>(AggregateExpressionDefinition<TResult, TPartitionBy> partitionBy, AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields> output)

Parameters

partitionBy AggregateExpressionDefinition<TResult, TPartitionBy>

The partitionBy definition.

output AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields>

The window fields definition.

Returns

IAggregateFluent<BsonDocument>

The fluent aggregate interface.

Type Parameters

TPartitionBy

The type of the value to partition by.

TWindowFields

The type of the added window fields.

SetWindowFields<TPartitionBy, TWindowFields>(AggregateExpressionDefinition<TResult, TPartitionBy>, SortDefinition<TResult>, AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields>)

Appends a $setWindowFields to the pipeline.

public virtual IAggregateFluent<BsonDocument> SetWindowFields<TPartitionBy, TWindowFields>(AggregateExpressionDefinition<TResult, TPartitionBy> partitionBy, SortDefinition<TResult> sortBy, AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields> output)

Parameters

partitionBy AggregateExpressionDefinition<TResult, TPartitionBy>

The partitionBy definition.

sortBy SortDefinition<TResult>

The sortBy definition.

output AggregateExpressionDefinition<ISetWindowFieldsPartition<TResult>, TWindowFields>

The window fields definition.

Returns

IAggregateFluent<BsonDocument>

The fluent aggregate interface.

Type Parameters

TPartitionBy

The type of the value to partition by.

TWindowFields

The type of the added window fields.

Skip(long)

Appends a skip stage to the pipeline.

public abstract IAggregateFluent<TResult> Skip(long skip)

Parameters

skip long

The number of documents to skip.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

Sort(SortDefinition<TResult>)

Appends a sort stage to the pipeline.

public abstract IAggregateFluent<TResult> Sort(SortDefinition<TResult> sort)

Parameters

sort SortDefinition<TResult>

The sort specification.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

SortByCount<TId>(AggregateExpressionDefinition<TResult, TId>)

Appends a sortByCount stage to the pipeline.

public virtual IAggregateFluent<AggregateSortByCountResult<TId>> SortByCount<TId>(AggregateExpressionDefinition<TResult, TId> id)

Parameters

id AggregateExpressionDefinition<TResult, TId>

The identifier.

Returns

IAggregateFluent<AggregateSortByCountResult<TId>>

The fluent aggregate interface.

Type Parameters

TId

The type of the identifier.

ThenBy(SortDefinition<TResult>)

Combines the current sort definition with an additional sort definition.

public virtual IOrderedAggregateFluent<TResult> ThenBy(SortDefinition<TResult> newSort)

Parameters

newSort SortDefinition<TResult>

The new sort.

Returns

IOrderedAggregateFluent<TResult>

The fluent aggregate interface.

ToCollection(CancellationToken)

Executes an aggregation pipeline that writes the results to a collection.

public virtual void ToCollection(CancellationToken cancellationToken)

Parameters

cancellationToken CancellationToken

The cancellation token.

ToCollectionAsync(CancellationToken)

Executes an aggregation pipeline that writes the results to a collection.

public virtual Task ToCollectionAsync(CancellationToken cancellationToken)

Parameters

cancellationToken CancellationToken

The cancellation token.

Returns

Task

A Task.

ToCursor(CancellationToken)

Executes the operation and returns a cursor to the results.

public virtual IAsyncCursor<TResult> ToCursor(CancellationToken cancellationToken)

Parameters

cancellationToken CancellationToken

The cancellation token.

Returns

IAsyncCursor<TResult>

A cursor.

ToCursorAsync(CancellationToken)

Executes the operation and returns a cursor to the results.

public abstract Task<IAsyncCursor<TResult>> ToCursorAsync(CancellationToken cancellationToken)

Parameters

cancellationToken CancellationToken

The cancellation token.

Returns

Task<IAsyncCursor<TResult>>

A Task whose result is a cursor.

UnionWith<TWith>(IMongoCollection<TWith>, PipelineDefinition<TWith, TResult>)

Appends an $unionWith stage to the pipeline.

public virtual IAggregateFluent<TResult> UnionWith<TWith>(IMongoCollection<TWith> withCollection, PipelineDefinition<TWith, TResult> withPipeline = null)

Parameters

withCollection IMongoCollection<TWith>

The with collection.

withPipeline PipelineDefinition<TWith, TResult>

The with pipeline.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.

Type Parameters

TWith

The type of the with collection documents.

Unwind<TNewResult>(FieldDefinition<TResult>, IBsonSerializer<TNewResult>)

Appends an unwind stage to the pipeline.

public abstract IAggregateFluent<TNewResult> Unwind<TNewResult>(FieldDefinition<TResult> field, IBsonSerializer<TNewResult> newResultSerializer)

Parameters

field FieldDefinition<TResult>

The field.

newResultSerializer IBsonSerializer<TNewResult>

The new result serializer.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the result of the stage.

Unwind<TNewResult>(FieldDefinition<TResult>, AggregateUnwindOptions<TNewResult>)

Appends an unwind stage to the pipeline.

public virtual IAggregateFluent<TNewResult> Unwind<TNewResult>(FieldDefinition<TResult> field, AggregateUnwindOptions<TNewResult> options)

Parameters

field FieldDefinition<TResult>

The field.

options AggregateUnwindOptions<TNewResult>

The options.

Returns

IAggregateFluent<TNewResult>

The fluent aggregate interface.

Type Parameters

TNewResult

The type of the new result.

VectorSearch(FieldDefinition<TResult>, QueryVector, int, VectorSearchOptions<TResult>)

Appends a vector search stage.

public virtual IAggregateFluent<TResult> VectorSearch(FieldDefinition<TResult> field, QueryVector queryVector, int limit, VectorSearchOptions<TResult> options = null)

Parameters

field FieldDefinition<TResult>

The field.

queryVector QueryVector

The query vector.

limit int

The limit.

options VectorSearchOptions<TResult>

The vector search options.

Returns

IAggregateFluent<TResult>

The fluent aggregate interface.