A B C D E F G H I J K L M N O P Q R S T U V W Y _ 

A

abort() - Method in class net.ravendb.client.document.BulkInsertOperation
 
abort() - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
abort() - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
 
abort() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
abort() - Method in class net.ravendb.client.document.ShardedBulkInsertOperation
 
AbstractAuthenticator - Class in net.ravendb.abstractions.oauth
 
AbstractAuthenticator() - Constructor for class net.ravendb.abstractions.oauth.AbstractAuthenticator
 
AbstractCommonApiForIndexesAndTransformers - Class in net.ravendb.client.indexes
 
AbstractCommonApiForIndexesAndTransformers() - Constructor for class net.ravendb.client.indexes.AbstractCommonApiForIndexesAndTransformers
 
AbstractDocumentQuery<T,TSelf extends AbstractDocumentQuery<T,TSelf>> - Class in net.ravendb.client.document
A query against a Raven index
AbstractDocumentQuery(Class<T>, InMemoryDocumentSessionOperations, IDatabaseCommands, String, String[], String[], List<IDocumentQueryListener>, boolean) - Constructor for class net.ravendb.client.document.AbstractDocumentQuery
 
AbstractDocumentQuery(AbstractDocumentQuery<T, TSelf>) - Constructor for class net.ravendb.client.document.AbstractDocumentQuery
 
AbstractIndexCreationTask - Class in net.ravendb.client.indexes
Base class for creating indexes
AbstractIndexCreationTask() - Constructor for class net.ravendb.client.indexes.AbstractIndexCreationTask
 
AbstractMultiMapIndexCreationTask - Class in net.ravendb.client.indexes
Allow to create indexes with multiple maps Note we don't provide support for addMapForAll - all child classes must be manually listed using addMap.
AbstractMultiMapIndexCreationTask() - Constructor for class net.ravendb.client.indexes.AbstractMultiMapIndexCreationTask
 
AbstractScriptedIndexCreationTask - Class in net.ravendb.client.indexes
 
AbstractScriptedIndexCreationTask() - Constructor for class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
AbstractTransformerCreationTask - Class in net.ravendb.client.indexes
Base class for creating transformers The naming convention is that underscores in the inherited class names are replaced by slashed For example: Posts_ByName will be saved to Posts/ByName
AbstractTransformerCreationTask() - Constructor for class net.ravendb.client.indexes.AbstractTransformerCreationTask
 
Action0 - Interface in net.ravendb.abstractions.closure
Represents typed action with no arguments
Action1<X> - Interface in net.ravendb.abstractions.closure
Represents typed action with 1 argument
Action2<X,Y> - Interface in net.ravendb.abstractions.closure
Represents typed action with 2 arguments
Action3<X,Y,Z> - Interface in net.ravendb.abstractions.closure
Represents typed action with 3 arguments
add(T) - Method in class net.ravendb.abstractions.data.EnumSet
 
add(RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
add(String, Object) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
add(String, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
add(T) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
add(T) - Method in class net.ravendb.client.util.IdentityHashSet
 
addAfterAcknowledgmentHandler(EventHandler<Subscription.LastProcessedEtagEventArgs>) - Method in class net.ravendb.client.document.Subscription
 
addAfterBatchHandler(EventHandler<Subscription.DocumentProcessedEventArgs>) - Method in class net.ravendb.client.document.Subscription
 
addAfterDisposeEventHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.document.DocumentStore
Called after dispose is completed
addAfterDisposeEventHandler(EventHandler<VoidArgs>) - Method in interface net.ravendb.client.IDisposalNotification
Called after dispose is completed
addAfterDisposeEventHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
addAll(Collection<? extends T>) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
addAll(Collection<? extends T>) - Method in class net.ravendb.client.util.IdentityHashSet
 
addBeforeAcknowledgmentHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.document.Subscription
 
addBeforeBatchHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.document.Subscription
 
addChanges(List<DocumentsChanges>, DocumentsChanges.ChangeType) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
addChanges(List<DocumentsChanges>, String, RavenJToken, RavenJToken, String) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
addChanges(List<DocumentsChanges>, RavenJToken, RavenJToken, String) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
addConfigureRequestEventHandler(EventHandler<WebRequestEventArgs>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
addConnectionStatusChanged(EventHandler<VoidArgs>) - Method in interface net.ravendb.client.changes.IConnectableChanges
 
addConnectionStatusChanged(EventHandler<VoidArgs>) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
addConnectionStatusChanged(EventHandler<VoidArgs>) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
addFailoverStatusChanged(EventHandler<ReplicationInformer.FailoverStatusChangedEventArgs>) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
addFailoverStatusChanged(EventHandler<ReplicationInformer.FailoverStatusChangedEventArgs>) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
addFailoverStatusChanged(EventHandler<ReplicationInformer.FailoverStatusChangedEventArgs>) - Method in class net.ravendb.client.connection.ServerClient
 
addField(String) - Method in class net.ravendb.client.RavenQueryHighlightings
 
addForCloning(String, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
addForCloning(String, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
addForCloning(String, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
addForDatabase(String, ReplicationDestination...) - Method in class net.ravendb.abstractions.data.FailoverServers
 
addForDefaultDatabase(ReplicationDestination...) - Method in class net.ravendb.abstractions.data.FailoverServers
 
addLazyCountOperation(ILazyOperation) - Method in class net.ravendb.client.document.DocumentSession
 
addLazyCountOperation(ILazyOperation, List<IDatabaseCommands>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
addLazyOperation(ILazyOperation, Action1<T>) - Method in class net.ravendb.client.document.DocumentSession
 
addLazyOperation(ILazyOperation, Action1<T>, List<IDatabaseCommands>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
addLogRequestEventHandler(EventHandler<RequestResultArgs>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
addMap(String) - Method in class net.ravendb.client.indexes.AbstractMultiMapIndexCreationTask
 
addOnBeforeEntityInsert(BulkInsertOperation.BeforeEntityInsert) - Method in class net.ravendb.client.document.BulkInsertOperation
 
addOnError(ShardingErrorHandle<IDatabaseCommands>) - Method in interface net.ravendb.client.shard.IShardAccessStrategy
 
addOnError(ShardingErrorHandle<IDatabaseCommands>) - Method in class net.ravendb.client.shard.ParallelShardAccessStrategy
 
addOnError(ShardingErrorHandle<IDatabaseCommands>) - Method in class net.ravendb.client.shard.SequentialShardAccessStrategy
 
addOperationHeader(String, String) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
addOperationHeaders(Map<String, String>) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
Adds the operation headers.
addOperationHeaders(Map<String, String>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
addOperationHeadersMultiMap(Map<String, List<String>>) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
Adds the operation headers.
addOrder(String, boolean) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Adds an ordering for a specific field to the query
addOrder(String, boolean, Class<?>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Adds an ordering for a specific field to the query and specifies the type of field for sorting purposes
addOrder(Expression<?>, boolean) - Method in class net.ravendb.client.document.DocumentQuery
 
addOrder(String, boolean) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Adds an ordering for a specific field to the query
addOrder(String, boolean, Class<?>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Adds an ordering for a specific field to the query and specifies the type of field for sorting purposes
addOrder(String, boolean) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds an ordering for a specific field to the query
addOrder(Expression<?>, boolean) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds an ordering for a specific field to the query
addOrder(String, boolean, Class<?>) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds an ordering for a specific field to the query and specifies the type of field for sorting purposes
addRanges(BooleanExpression...) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
addReplicationStatusHeaders(String, String, IDocumentStoreReplicationInformer, FailoverBehaviorSet, ServerClient.HandleReplicationStatusChangesCallback) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
addRootType(Class<T>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
addRootType(Class<T>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
 
addSessionCreatedInternal(Action1<InMemoryDocumentSessionOperations>) - Method in class net.ravendb.client.DocumentStoreBase
 
addTransformerParameter(String, RavenJToken) - Method in class net.ravendb.client.document.RavenLoadConfiguration
 
addTransformerParameter(String, RavenJToken) - Method in interface net.ravendb.client.ILoadConfiguration
Adds transformer parameter that will be passed to transformer on server-side.
addTransformerParameter(String, RavenJToken) - Method in interface net.ravendb.client.linq.IRavenQueryable
Inputs a key and value to the query (accessible by the transformer)
addTransformerParameter(String, Object) - Method in interface net.ravendb.client.linq.IRavenQueryable
Inputs a key and value to the query (accessible by the transformer)
addTransformerParameter(String, RavenJToken) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Adds input to this query via a key/value pair
addTransformerParameter(String, RavenJToken) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
addTransformerParameter(String, Object) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
addTransformerParameter(String, RavenJToken) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
addTransformerParameter(String, RavenJToken) - Method in class net.ravendb.client.LoadConfigurationFactory
 
addTransformerParameter(String, Object) - Method in class net.ravendb.client.LoadConfigurationFactory
 
AdminMemoryStatistics - Class in net.ravendb.abstractions.data
 
AdminMemoryStatistics() - Constructor for class net.ravendb.abstractions.data.AdminMemoryStatistics
 
adminRequest - Variable in class net.ravendb.client.connection.AdminServerClient
 
AdminRequestCreator - Class in net.ravendb.client.connection
 
AdminRequestCreator(Function2<String, HttpMethods, HttpJsonRequest>, Function2<String, HttpMethods, HttpJsonRequest>, Function3<String, String, HttpMethods, HttpJsonRequest>) - Constructor for class net.ravendb.client.connection.AdminRequestCreator
 
AdminServerClient - Class in net.ravendb.client.connection
 
AdminServerClient(ServerClient) - Constructor for class net.ravendb.client.connection.AdminServerClient
 
AdminStatistics - Class in net.ravendb.abstractions.data
Server-wide statistics that contain memory usage and loaded resources information.
AdminStatistics() - Constructor for class net.ravendb.abstractions.data.AdminStatistics
 
adminStats() - Method in class net.ravendb.client.connection.AdminRequestCreator
 
adminStats(String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
advanced() - Method in class net.ravendb.client.document.DocumentSession
Get the accessor for advanced operations Note: Those operations are rarely needed, and have been moved to a separate property to avoid cluttering the API
advanced() - Method in interface net.ravendb.client.IDocumentSession
Get the accessor for advanced operations Those operations are rarely needed, and have been moved to a separate property to avoid cluttering the API
advanced() - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
afterConversionToDocument(String, Object, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.listeners.IDocumentConversionListener
Called after having converted an entity to a document and metadata
afterConversionToEntity(String, RavenJObject, RavenJObject, Object) - Method in interface net.ravendb.client.listeners.IDocumentConversionListener
Called before converting a document and metadata to an entity
afterExecute(IDatabaseCommands, DocumentConvention) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
afterExecute(IDatabaseCommands, DocumentConvention) - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
afterExecute(IDatabaseCommands, String, ScriptedIndexResults) - Static method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
afterQueryExecuted(Action1<QueryResult>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Callback to get the results of the query
afterQueryExecuted(Action1<QueryResult>) - Method in interface net.ravendb.client.IDocumentQueryBase
Called externally to raise the after query executed callback
afterQueryExecuted(Action1<QueryResult>) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Callback to get the results of the query
afterQueryExecuted(QueryResult) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
afterQueryExecuted(Action1<QueryResult>) - Method in class net.ravendb.client.linq.RavenQueryProvider
Callback to get the results of the query
afterQueryExecutedCallback - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
afterSessionCreated(InMemoryDocumentSessionOperations) - Method in class net.ravendb.client.document.DocumentStore
 
afterSessionCreated(InMemoryDocumentSessionOperations) - Method in class net.ravendb.client.DocumentStoreBase
 
afterStore(String, Object, RavenJObject) - Method in interface net.ravendb.client.listeners.IDocumentStoreListener
Invoked after the store request is sent to the server.
afterStreamExecuted(Function1<Reference<RavenJObject>, Boolean>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Callback to get the results of the stream
afterStreamExecuted(Function1<Reference<RavenJObject>, Boolean>) - Method in interface net.ravendb.client.IDocumentQueryBase
Callback to get the results of the stream
afterStreamExecuted(Action1<RavenJObject>) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Callback to get the results of the stream
afterStreamExecuted(Action1<RavenJObject>) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
afterStreamExecutedCallback - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
aggregateBy(String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
aggregateBy(String, String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
aggregateBy(Path<?>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
aggregateBy(Path<?>, String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
aggregateBy(String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using aggregation
aggregateBy(String, String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using aggregation with a specific display name
aggregateBy(Path<?>) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using aggregation
aggregateBy(Path<?>, String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using aggregation with a specific display name
AggregateException - Exception in net.ravendb.abstractions.exceptions
 
AggregateException(Exception[]) - Constructor for exception net.ravendb.abstractions.exceptions.AggregateException
 
AggregateException(String, Exception[]) - Constructor for exception net.ravendb.abstractions.exceptions.AggregateException
 
AggregationQuery - Class in net.ravendb.client.linq
 
AggregationQuery() - Constructor for class net.ravendb.client.linq.AggregationQuery
 
AggregationQueryDsl - Class in net.ravendb.client.linq
 
AggregationQueryDsl() - Constructor for class net.ravendb.client.linq.AggregationQueryDsl
 
aggressivelyCache() - Method in class net.ravendb.client.DocumentStoreBase
Setup the context for aggressive caching.
aggressivelyCache() - Method in interface net.ravendb.client.IDocumentStore
Setup the context for aggressive caching.
aggressivelyCacheFor(long) - Method in class net.ravendb.client.document.DocumentStore
Setup the context for aggressive caching.
aggressivelyCacheFor(long) - Method in interface net.ravendb.client.IDocumentStore
Setup the context for aggressive caching.
aggressivelyCacheFor(long) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Setup the context for aggressive caching.
ALL_FIELDS - Static variable in class net.ravendb.abstractions.data.Constants
 
ALLOW_BUNDLES_CHANGE - Static variable in class net.ravendb.abstractions.data.Constants
 
allowMultipleIndexEntriesForSameDocumentToResultTransformer - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
alwaysFalse() - Static method in class net.ravendb.abstractions.closure.Functions
 
alwaysFalse() - Static method in class net.ravendb.abstractions.closure.Predicates
 
alwaysTrue() - Static method in class net.ravendb.abstractions.closure.Functions
 
alwaysTrue() - Static method in class net.ravendb.abstractions.closure.Predicates
 
analyze(Path<?>, String) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be analyzed
analyze(String, String) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be analyzed
analyzers - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
analyzersStrings - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
and(Predicate<T>, Predicate<T>) - Static method in class net.ravendb.abstractions.closure.Predicates
 
andAggregateOn(Path<?>) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
andAggregateOn(Path<?>, String) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
andAggregateOn(String) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
andAggregateOn(String, String) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
andAlso() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Add an AND to the query
andAlso() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Add an AND to the query
andAlso() - Method in interface net.ravendb.client.IDocumentQueryBase
Add an AND to the query
ANY - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
any() - Method in class net.ravendb.client.document.DocumentQuery
 
any() - Method in interface net.ravendb.client.IDocumentQuery
Returns if any entry matches query
any(Iterator<T>) - Static method in class net.ravendb.client.linq.EnumerableUtils
 
any() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Performs any query.
any() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
any(BooleanExpression) - Method in class net.ravendb.querydsl.RavenArray
 
any() - Method in class net.ravendb.querydsl.RavenList
Deprecated.
any(BooleanExpression) - Method in class net.ravendb.querydsl.RavenList
 
ANY_RESULT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
APIKeyName - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
appendQueryString(StringBuilder) - Method in class net.ravendb.abstractions.data.IndexQuery
 
appendQueryString(StringBuilder, boolean, boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
 
apply() - Method in interface net.ravendb.abstractions.closure.Action0
 
apply(X) - Method in interface net.ravendb.abstractions.closure.Action1
 
apply(X, Y) - Method in interface net.ravendb.abstractions.closure.Action2
 
apply(X, Y, Z) - Method in interface net.ravendb.abstractions.closure.Action3
 
apply() - Method in class net.ravendb.abstractions.closure.Delegates.Delegate0
 
apply(X) - Method in class net.ravendb.abstractions.closure.Delegates.Delegate1
 
apply(X, Y) - Method in class net.ravendb.abstractions.closure.Delegates.Delegate2
 
apply(X, Y, Z) - Method in class net.ravendb.abstractions.closure.Delegates.Delegate3
 
apply() - Method in interface net.ravendb.abstractions.closure.Function0
Applies function
apply(F) - Method in interface net.ravendb.abstractions.closure.Function1
Applies function
apply(F, G) - Method in interface net.ravendb.abstractions.closure.Function2
Applies function
apply(F, G, H) - Method in interface net.ravendb.abstractions.closure.Function3
Applies function
apply(F, G, H, I) - Method in interface net.ravendb.abstractions.closure.Function4
Applies function
apply(S) - Method in class net.ravendb.abstractions.closure.Functions.AlwaysFalse
 
apply(S) - Method in class net.ravendb.abstractions.closure.Functions.AlwaysTrue
 
apply(S) - Method in class net.ravendb.abstractions.closure.Functions.StaticFunction1
 
apply(T) - Method in class net.ravendb.abstractions.closure.Predicates.AndPredicate
 
apply(T) - Method in class net.ravendb.abstractions.closure.Predicates.False
 
apply(T) - Method in class net.ravendb.abstractions.closure.Predicates.True
 
apply(Map<String, String>, String, String) - Method in class net.ravendb.client.connection.ServerClient.HandleReplicationStatusChangesCallback
 
apply(String, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.document.BulkInsertOperation.BeforeEntityInsert
 
apply() - Method in class net.ravendb.client.document.DocumentSession.DisableAllCachingCallback
 
apply(String) - Method in class net.ravendb.client.document.DocumentStore.ReplicationInformerGetter
 
apply(Class<?>, List<IDatabaseCommands>, ShardRequestData, Function2<IDatabaseCommands, Integer, T>) - Method in interface net.ravendb.client.shard.IShardAccessStrategy
Applies the specified action to all shard sessions.
apply(Class<?>, List<IDatabaseCommands>, ShardRequestData, Function2<IDatabaseCommands, Integer, T>) - Method in class net.ravendb.client.shard.ParallelShardAccessStrategy
 
apply(Class<?>, List<IDatabaseCommands>, ShardRequestData, Function2<IDatabaseCommands, Integer, T>) - Method in class net.ravendb.client.shard.SequentialShardAccessStrategy
Applies the specified action for all shard sessions.
apply(IndexQuery, List<Object>) - Method in interface net.ravendb.client.shard.ShardReduceFunction
 
as(Class<TResult>) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Project using a different type
as(Class<S>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
assertInitialized() - Method in class net.ravendb.client.DocumentStoreBase
 
assertNoDuplicateIdsInResults(List<QueryOperation>) - Static method in class net.ravendb.client.shard.ShardedDocumentQuery
 
assertNoNonUniqueInstance(Object, String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
assertNotFailingResponse(CloseableHttpResponse) - Static method in class net.ravendb.client.extensions.HttpJsonRequestExtension
 
assertValidConfiguration() - Method in class net.ravendb.client.document.DocumentStore
validate the configuration for the document store
assertValidName(String) - Static method in class net.ravendb.client.extensions.MultiDatabase
 
associateCurrentOBjectWith(Object) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
AtomicDictionary<T> - Class in net.ravendb.abstractions.util
 
AtomicDictionary(Comparator<String>) - Constructor for class net.ravendb.abstractions.util.AtomicDictionary
 
AtomicDictionary() - Constructor for class net.ravendb.abstractions.util.AtomicDictionary
 
Attachment - Class in net.ravendb.abstractions.data
Deprecated.
Use RavenFS instead.
Attachment(boolean, byte[], int, RavenJObject, Etag, String) - Constructor for class net.ravendb.abstractions.data.Attachment
Deprecated.
 
AttachmentInformation - Class in net.ravendb.abstractions.data
Deprecated.
Use RavenFS instead.
AttachmentInformation() - Constructor for class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
 
AutoResetEvent - Class in net.ravendb.abstractions.util
 
AutoResetEvent(boolean) - Constructor for class net.ravendb.abstractions.util.AutoResetEvent
 
averageOn(Path<?>) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 

B

BadRequestException - Exception in net.ravendb.abstractions.exceptions
 
BadRequestException() - Constructor for exception net.ravendb.abstractions.exceptions.BadRequestException
 
BadRequestException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.BadRequestException
 
BadRequestException(String) - Constructor for exception net.ravendb.abstractions.exceptions.BadRequestException
 
BadRequestException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.BadRequestException
 
base62Random() - Static method in class net.ravendb.abstractions.util.Base62Util
 
Base62Util - Class in net.ravendb.abstractions.util
 
Base62Util() - Constructor for class net.ravendb.abstractions.util.Base62Util
 
baseCapacity - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
BaseShardedDocumentSession<TDatabaseCommands> - Class in net.ravendb.client.shard
 
BaseShardedDocumentSession(String, ShardedDocumentStore, DocumentSessionListeners, UUID, ShardStrategy, Map<String, TDatabaseCommands>) - Constructor for class net.ravendb.client.shard.BaseShardedDocumentSession
 
BaseShardedDocumentSession.DbCmdsListComparer<TDatabaseCommands> - Class in net.ravendb.client.shard
 
BaseShardedDocumentSession.DbCmdsListComparer() - Constructor for class net.ravendb.client.shard.BaseShardedDocumentSession.DbCmdsListComparer
 
BaseShardedDocumentSession.IdToLoad<TDatabaseCommands> - Class in net.ravendb.client.shard
 
BaseShardedDocumentSession.IdToLoad(String, List<TDatabaseCommands>) - Constructor for class net.ravendb.client.shard.BaseShardedDocumentSession.IdToLoad
 
BasicAuthenticator - Class in net.ravendb.abstractions.oauth
 
BasicAuthenticator(CloseableHttpClient, boolean) - Constructor for class net.ravendb.abstractions.oauth.BasicAuthenticator
 
batch(List<ICommandData>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends multiple operations in a single request, reducing the number of remote calls and allowing several operations to share same transaction
batch(List<ICommandData>) - Method in class net.ravendb.client.connection.ServerClient
 
BatchResult - Class in net.ravendb.abstractions.data
The result of a single operation inside a batch
BatchResult() - Constructor for class net.ravendb.abstractions.data.BatchResult
 
BatchType - Enum in net.ravendb.abstractions.data
 
beforeConversionToDocument(String, Object, RavenJObject) - Method in interface net.ravendb.client.listeners.IDocumentConversionListener
Called before converting an entity to a document and metadata
beforeConversionToEntity(String, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.listeners.IDocumentConversionListener
Called before converting a document and metadata to an entity
beforeDelete(String, Object, RavenJObject) - Method in interface net.ravendb.client.listeners.IDocumentDeleteListener
Invoked before the delete request is sent to the server.
beforeQueryExecuted(IDocumentQueryCustomization) - Method in interface net.ravendb.client.listeners.IDocumentQueryListener
Allow to customize a query globally
beforeQueryExecution(Action1<IndexQuery>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
beforeQueryExecution(Action1<IndexQuery>) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
beforeQueryExecution(Action1<IndexQuery>) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Allow you to modify the index query before it is executed
beforeQueryExecution(Action1<IndexQuery>) - Method in interface net.ravendb.client.IDocumentQueryBase
Allows you to modify the index query before it is sent to the server
beforeQueryExecution(Action1<IndexQuery>) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Allow you to modify the index query before it is executed
beforeQueryExecutionAction - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
beforeStore(String, Object, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.listeners.IDocumentStoreListener
Invoked before the store request is sent to the server.
BomUtils - Class in net.ravendb.abstractions.util
 
BomUtils() - Constructor for class net.ravendb.abstractions.util.BomUtils
 
boost(Double) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Specifies a boost weight to the last where clause.
boost(Double) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Specifies a boost weight to the last where clause.
boost(Double) - Method in interface net.ravendb.client.IDocumentQueryBase
Specifies a boost weight to the last where clause.
BoostedValue - Class in net.ravendb.abstractions.data
 
BoostedValue() - Constructor for class net.ravendb.abstractions.data.BoostedValue
 
boundingBoxIndex() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.CartesianSpatialOptionsFactory
 
boundingBoxIndex() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
boundingBoxIndex(SpatialOptions.SpatialUnits) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
buffer - Variable in class net.ravendb.client.connection.ObservableLineStream
 
BuildNumber - Class in net.ravendb.abstractions.data
 
BuildNumber() - Constructor for class net.ravendb.abstractions.data.BuildNumber
 
bulkInsert() - Method in class net.ravendb.client.document.DocumentStore
 
bulkInsert(String) - Method in class net.ravendb.client.document.DocumentStore
 
bulkInsert(String, BulkInsertOptions) - Method in class net.ravendb.client.document.DocumentStore
 
bulkInsert() - Method in interface net.ravendb.client.IDocumentStore
Performs bulk insert
bulkInsert(String) - Method in interface net.ravendb.client.IDocumentStore
Performs bulk insert
bulkInsert(String, BulkInsertOptions) - Method in interface net.ravendb.client.IDocumentStore
Performs bulk insert
bulkInsert() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Deprecated.
bulkInsert(String) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Cannot use BulkInsert using sharded store, use shardedBulkInsert, instead
bulkInsert(String, BulkInsertOptions) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Cannot use BulkInsert using sharded store, use shardedBulkInsert, instead
BulkInsertChangeNotification - Class in net.ravendb.abstractions.data
 
BulkInsertChangeNotification() - Constructor for class net.ravendb.abstractions.data.BulkInsertChangeNotification
 
BulkInsertOperation - Class in net.ravendb.client.document
 
BulkInsertOperation(String, IDocumentStore, DocumentSessionListeners, BulkInsertOptions, IDatabaseChanges) - Constructor for class net.ravendb.client.document.BulkInsertOperation
 
BulkInsertOperation.BeforeEntityInsert - Interface in net.ravendb.client.document
 
BulkInsertOptions - Class in net.ravendb.abstractions.data
Options used during BulkInsert execution.
BulkInsertOptions() - Constructor for class net.ravendb.abstractions.data.BulkInsertOptions
 
BulkOperationOptions - Class in net.ravendb.abstractions.data
Holds different settings options for base operations.
BulkOperationOptions() - Constructor for class net.ravendb.abstractions.data.BulkOperationOptions
 
bytesToLong(byte[]) - Static method in class net.ravendb.abstractions.data.Etag
 
bytesToString(byte[]) - Static method in class net.ravendb.abstractions.connection.OAuthHelper
 

C

cachedJsonDocs - Variable in class net.ravendb.client.document.EntityToJson
 
CachedRequest - Class in net.ravendb.client.connection
 
CachedRequest() - Constructor for class net.ravendb.client.connection.CachedRequest
 
CachedRequest(RavenJToken, Date, Map<String, String>, String, boolean) - Constructor for class net.ravendb.client.connection.CachedRequest
 
CachedRequestOp - Class in net.ravendb.client.connection
 
CachedRequestOp() - Constructor for class net.ravendb.client.connection.CachedRequestOp
 
CachedRequestOp(CachedRequest, boolean) - Constructor for class net.ravendb.client.connection.CachedRequestOp
 
cacheResponse(String, RavenJToken, Map<String, String>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
calculateDuration() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
cancel() - Method in class net.ravendb.client.utils.CancellationTokenSource
 
cancelAfter(long) - Method in class net.ravendb.client.utils.CancellationTokenSource
 
cancelAfterDate - Variable in class net.ravendb.client.utils.CancellationTokenSource
 
CancellationTokenSource - Class in net.ravendb.client.utils
 
CancellationTokenSource() - Constructor for class net.ravendb.client.utils.CancellationTokenSource
 
CancellationTokenSource.CancellationToken - Class in net.ravendb.client.utils
 
CancellationTokenSource.CancellationToken() - Constructor for class net.ravendb.client.utils.CancellationTokenSource.CancellationToken
 
canConvertFrom(Class<?>) - Method in class net.ravendb.client.converters.Int32Converter
 
canConvertFrom(Class<?>) - Method in class net.ravendb.client.converters.Int64Converter
 
canConvertFrom(Class<?>) - Method in interface net.ravendb.client.converters.ITypeConverter
Returns whether this converter can convert an object of the given type to the type of this converter.
canConvertFrom(Class<?>) - Method in class net.ravendb.client.converters.UUIDConverter
 
canFullyCache(HttpJsonRequestFactory, HttpJsonRequest, String) - Method in class net.ravendb.client.connection.MultiGetOperation
 
canTransform(Expression<?>) - Method in interface net.ravendb.client.document.CustomQueryExpressionTranslator
 
capacity - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
capitalize(String) - Static method in class net.ravendb.client.util.Inflector
 
Challenge - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
ChallengeSalt - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
ChallengeSaltLength - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
ChallengeTimestamp - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
changes() - Method in class net.ravendb.client.document.DocumentStore
Subscribe to change notifications from the server
changes(String) - Method in class net.ravendb.client.document.DocumentStore
Subscribe to change notifications from the server
changes() - Method in interface net.ravendb.client.IDocumentStore
Subscribe to change notifications from the server
changes(String) - Method in interface net.ravendb.client.IDocumentStore
Subscribe to change notifications from the server
changes() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Subscribe to change notifications from the server
changes(String) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Subscribe to change notifications from the server
changes - Variable in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
checkIfIdAlreadyIncluded(String[], Tuple<String, Class<?>>[]) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
checkOAuthDeps() - Static method in class net.ravendb.client.utils.RequirementsChecker
JCE + Bouncy Castle is required for OAuth requests
ChunkedBulkInsertOptions - Class in net.ravendb.abstractions.data
Options for the chunked bulk insert operation
ChunkedBulkInsertOptions() - Constructor for class net.ravendb.abstractions.data.ChunkedBulkInsertOptions
 
ChunkedRemoteBulkInsertOperation - Class in net.ravendb.client.document
 
ChunkedRemoteBulkInsertOperation(BulkInsertOptions, ServerClient, IDatabaseChanges) - Constructor for class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
clazz - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
CleanCloseable - Interface in net.ravendb.abstractions.basic
 
cleanSleep(int) - Static method in class net.ravendb.abstractions.util.TimeUtils
 
clear() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
clear() - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
clear() - Method in class net.ravendb.client.connection.profiling.ConcurrentLruSet
 
clear() - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
clear() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Clears this instance.
clear() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Clears this instance.
clear() - Method in class net.ravendb.client.util.IdentityHashSet
 
clearHalf() - Method in class net.ravendb.client.connection.profiling.ConcurrentLruSet
 
clearReplicationInformationFromLocalCache(String) - Static method in class net.ravendb.client.connection.ReplicationInformerLocalCache
 
clearReplicationInformationLocalCache(T) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
Clears the replication information local cache.
clearReplicationInformationLocalCache(ServerClient) - Method in class net.ravendb.client.connection.ReplicationInformer
 
clearReplicationInformationLocalCache(T) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
clearSortHints(IDatabaseCommands) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
clientSideHeartbeat() - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
clientVersion - Static variable in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
clone() - Method in class net.ravendb.abstractions.data.EnumSet
 
clone() - Method in class net.ravendb.abstractions.data.Etag
 
clone() - Method in class net.ravendb.abstractions.data.HighlightedField
 
clone() - Method in class net.ravendb.abstractions.data.IndexQuery
 
clone() - Method in class net.ravendb.abstractions.data.SortedField
 
clone() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
 
clone() - Method in class net.ravendb.abstractions.util.NetDateFormat
 
clone() - Method in class net.ravendb.client.document.DocumentConvention
Clone the current conventions to a new instance
cloneToken() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
cloneToken() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
cloneToken() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
Clones this object
cloneToken() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
cloneTokenImpl(RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
close() - Method in interface net.ravendb.abstractions.basic.CleanCloseable
 
close() - Method in interface net.ravendb.abstractions.basic.CloseableIterator
 
close() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
close() - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
close() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
close() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
close() - Method in class net.ravendb.client.connection.ObservableLineStream
 
close() - Method in class net.ravendb.client.connection.RavenJObjectIterator
 
close() - Method in class net.ravendb.client.connection.ReplicationInformer
 
close() - Method in class net.ravendb.client.document.BulkInsertOperation
 
close() - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
close() - Method in class net.ravendb.client.document.DefaultRavenContractResolver.ClearExtensionData
 
close() - Method in class net.ravendb.client.document.DocumentStore
 
close() - Method in class net.ravendb.client.document.DocumentSubscriptions
 
close() - Method in class net.ravendb.client.document.EntityToJson.DisposeCachedJsonDocs
 
close() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Performs application-defined tasks associated with freeing, releasing, or resetting unmanaged resources.
close() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
close() - Method in class net.ravendb.client.document.ReplicationBehavior
 
close() - Method in class net.ravendb.client.document.ShardedBulkInsertOperation
 
close() - Method in class net.ravendb.client.document.Subscription
 
close() - Method in class net.ravendb.client.shard.ParallelShardAccessStrategy
 
close() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
close() - Method in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
close() - Method in class net.ravendb.client.util.SimpleCache
 
close(CleanCloseable) - Static method in class net.ravendb.client.utils.Closer
 
CloseableIterator<T> - Interface in net.ravendb.abstractions.basic
 
Closer - Class in net.ravendb.client.utils
 
Closer() - Constructor for class net.ravendb.client.utils.Closer
 
closeSubclause() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Simplified method for closing a clause within the query
closeSubclause() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Simplified method for closing a clause within the query
closeSubclause() - Method in interface net.ravendb.client.IDocumentQueryBase
Simplified method for closing a clause within the query
coalesce(T...) - Static method in class net.ravendb.client.utils.Lang
 
CollectionUtils - Class in net.ravendb.abstractions.basic
 
CollectionUtils() - Constructor for class net.ravendb.abstractions.basic.CollectionUtils
 
combine(Action1<X>, Action1<X>) - Static method in class net.ravendb.abstractions.closure.Delegates
 
combine(Function1<X, Y>, Function1<X, Y>) - Static method in class net.ravendb.abstractions.closure.Delegates
 
CommonsLoggingLogWrapper - Class in net.ravendb.abstractions.logging.providers
 
CommonsLoggingLogWrapper(Log) - Constructor for class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
CommonsLoggingProvider - Class in net.ravendb.abstractions.logging.providers
 
CommonsLoggingProvider() - Constructor for class net.ravendb.abstractions.logging.providers.CommonsLoggingProvider
 
compactDatabase(String) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
compactDatabase(String) - Method in class net.ravendb.client.connection.AdminServerClient
 
compactDatabase(String) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Sends an async command to compact a database.
compare(RavenJToken, RavenJToken, List<DocumentsChanges>) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenComparator
 
compare(RavenJToken, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenComparator
 
compare(List<TDatabaseCommands>, List<TDatabaseCommands>) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession.DbCmdsListComparer
 
compareDifferentLengthRavenJObjectData(Collection<DocumentsChanges>, RavenJObject, RavenJObject, String) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
compareRavenJArrayData(Collection<DocumentsChanges>, RavenJArray, RavenJArray, String) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
compareTo(Etag) - Method in class net.ravendb.abstractions.data.Etag
 
complete(Class<T>) - Method in class net.ravendb.client.document.sessionoperations.LoadOperation
 
complete(Class<T>, MultiLoadResult) - Method in class net.ravendb.client.document.sessionoperations.LoadTransformerOperation
 
complete(Class<T>) - Method in class net.ravendb.client.document.sessionoperations.MultiLoadOperation
 
complete(Class<T>) - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
compute16(byte[]) - Method in class net.ravendb.client.utils.encryptors.DefaultEncryptor.DefaultHashEncryptor
 
compute16(byte[]) - Method in class net.ravendb.client.utils.encryptors.FipsEncryptor.FipsHashEncryptor
 
compute16(byte[]) - Method in interface net.ravendb.client.utils.encryptors.IHashEncryptor
 
compute20(byte[]) - Method in class net.ravendb.client.utils.encryptors.DefaultEncryptor.DefaultHashEncryptor
 
compute20(byte[]) - Method in class net.ravendb.client.utils.encryptors.FipsEncryptor.FipsHashEncryptor
 
compute20(byte[]) - Method in interface net.ravendb.client.utils.encryptors.IHashEncryptor
 
computeHash(String, byte[], Integer) - Method in class net.ravendb.client.utils.encryptors.HashEncryptorBase
 
computeServerTotal() - Method in class net.ravendb.client.document.ResponseTimeInformation
 
ConcurrencyException - Exception in net.ravendb.abstractions.exceptions
 
ConcurrencyException(Etag, Etag, String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.ConcurrencyException
 
ConcurrentLruSet<T> - Class in net.ravendb.client.connection.profiling
 
ConcurrentLruSet(int, Action1<T>) - Constructor for class net.ravendb.client.connection.profiling.ConcurrentLruSet
 
ConcurrentSet<T> - Class in net.ravendb.client.connection.profiling
 
ConcurrentSet() - Constructor for class net.ravendb.client.connection.profiling.ConcurrentSet
 
config() - Method in class net.ravendb.client.document.JsonSerializer
 
configure(RavenLoadConfiguration) - Method in class net.ravendb.client.LoadConfigurationFactory
 
configureCaching(String, Action2<String, String>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
configureRequest(Object, WebRequestEventArgs) - Method in class net.ravendb.abstractions.oauth.AbstractAuthenticator
 
configureRequest(Object, WebRequestEventArgs) - Method in class net.ravendb.abstractions.oauth.SecuredAuthenticator
 
configureRequest(IHoldProfilingInformation, WebRequestEventArgs) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
ConflictException - Exception in net.ravendb.client.exceptions
 
ConflictException(boolean) - Constructor for exception net.ravendb.client.exceptions.ConflictException
 
ConflictException(String, boolean) - Constructor for exception net.ravendb.client.exceptions.ConflictException
 
ConflictException(String, Exception, boolean) - Constructor for exception net.ravendb.client.exceptions.ConflictException
 
ConflictsResolver - Class in net.ravendb.abstractions.json
 
ConflictsResolver(RavenJObject...) - Constructor for class net.ravendb.abstractions.json.ConflictsResolver
 
ConflictsResolver(RavenJObject[], boolean) - Constructor for class net.ravendb.abstractions.json.ConflictsResolver
 
ConflictsResolver.ArrayWithWarning - Class in net.ravendb.abstractions.json
 
ConflictsResolver.ArrayWithWarning(RavenJArray) - Constructor for class net.ravendb.abstractions.json.ConflictsResolver.ArrayWithWarning
 
ConflictsResolver.Conflicted - Class in net.ravendb.abstractions.json
 
ConflictsResolver.Conflicted() - Constructor for class net.ravendb.abstractions.json.ConflictsResolver.Conflicted
 
ConflictsResolver.MergeChunk - Class in net.ravendb.abstractions.json
 
ConflictsResolver.MergeChunk() - Constructor for class net.ravendb.abstractions.json.ConflictsResolver.MergeChunk
 
ConflictsResolver.MergeResult - Class in net.ravendb.abstractions.json
 
ConflictsResolver.MergeResult() - Constructor for class net.ravendb.abstractions.json.ConflictsResolver.MergeResult
 
connectionId - Variable in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
ConnectionStringParser<T extends RavenConnectionStringOptions> - Class in net.ravendb.abstractions.data
 
ConsistencyOptions - Enum in net.ravendb.client.document
The consistency options for all queries, fore more details about the consistency options, see: http://www.allthingsdistributed.com/2008/12/eventually_consistent.html Note that this option impact only queries, since we have Strong Consistency model for the documents
Constants - Class in net.ravendb.abstractions.data
 
Constants() - Constructor for class net.ravendb.abstractions.data.Constants
 
construct(S, int) - Static method in class net.ravendb.abstractions.data.EnumSet
 
construct(S, String) - Static method in class net.ravendb.abstractions.data.EnumSet
 
consumeContent() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
Deprecated.
consumeContent() - Method in class net.ravendb.java.http.client.GzipHttpEntity
Deprecated. 
contains(T) - Method in class net.ravendb.abstractions.data.EnumSet
 
contains(Object) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
contains(Object) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
 
contains(Object) - Method in class net.ravendb.client.util.IdentityHashSet
 
CONTAINS_ALL - Static variable in class net.ravendb.abstractions.LinqOps.Ops
 
CONTAINS_ANY - Static variable in class net.ravendb.abstractions.LinqOps.Ops
 
containsAll(Collection<?>) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
containsAll(String, Collection<Object>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
containsAll(Expression<?>, Collection<Object>) - Method in class net.ravendb.client.document.DocumentQuery
Performs a query matching ALL of the provided values against the given field (AND)
containsAll(String, Collection<Object>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Performs a query matching ALL of the provided values against the given field (AND)
containsAll(String, Collection<Object>) - Method in interface net.ravendb.client.IDocumentQueryBase
Performs a query matching ALL of the provided values against the given field (AND)
containsAll(Expression<?>, Collection<Object>) - Method in interface net.ravendb.client.IDocumentQueryBase
Performs a query matching ALL of the provided values against the given field (AND)
containsAll(Collection<?>) - Method in class net.ravendb.client.util.IdentityHashSet
 
containsAll(Collection<E>) - Method in class net.ravendb.querydsl.RavenArray
 
containsAll(Collection<E>) - Method in class net.ravendb.querydsl.RavenList
 
containsAny(String, Collection<Object>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
containsAny(Expression<?>, Collection<Object>) - Method in class net.ravendb.client.document.DocumentQuery
Performs a query matching ANY of the provided values against the given field (OR)
containsAny(String, Collection<Object>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Performs a query matching ANY of the provided values against the given field (OR)
containsAny(String, Collection<Object>) - Method in interface net.ravendb.client.IDocumentQueryBase
Performs a query matching ANY of the provided values against the given field (OR)
containsAny(Expression<?>, Collection<Object>) - Method in interface net.ravendb.client.IDocumentQueryBase
Performs a query matching ANY of the provided values against the given field (OR)
containsAny(Collection<E>) - Method in class net.ravendb.querydsl.RavenArray
 
containsAny(Collection<E>) - Method in class net.ravendb.querydsl.RavenList
 
containsKey(Object) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
containsKey(String) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
containsValue(Object) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
Convention - Class in net.ravendb.client.document
 
Convention() - Constructor for class net.ravendb.client.document.Convention
 
conventions - Variable in class net.ravendb.client.changes.RemoteChangesClientBase
 
conventions - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
conventions - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
conventions - Variable in class net.ravendb.client.DocumentStoreBase
 
conventions - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
convert(Class<U>, RavenJToken) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
convert(Class<U>, Iterable<RavenJToken>) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
convert(Class<U>, RavenJToken, boolean) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
convertEntityToJson(String, Object, RavenJObject) - Method in class net.ravendb.client.document.EntityToJson
 
convertFrom(String, Object, boolean) - Method in class net.ravendb.client.converters.Int32Converter
 
convertFrom(String, Object, boolean) - Method in class net.ravendb.client.converters.Int64Converter
 
convertFrom(String, Object, boolean) - Method in interface net.ravendb.client.converters.ITypeConverter
Converts the given object to the type of this converter.
convertFrom(String, Object, boolean) - Method in class net.ravendb.client.converters.UUIDConverter
 
convertTo(String) - Method in class net.ravendb.client.converters.Int32Converter
 
convertTo(String) - Method in class net.ravendb.client.converters.Int64Converter
 
convertTo(String) - Method in interface net.ravendb.client.converters.ITypeConverter
Converts the given value object to the specified type, using the specified context and culture information.
convertTo(String) - Method in class net.ravendb.client.converters.UUIDConverter
 
convertToEntity(Class<?>, String, RavenJObject, RavenJObject, boolean) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Converts the json document to an entity.
copyCurrentEvent(JsonParser) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
copyCurrentStructure(JsonParser) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
copyHeaders(HttpRequest, HttpRequest) - Static method in class net.ravendb.abstractions.connection.HttpRequestHelper
 
COUNT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
count() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Performs count query.
count(BooleanExpression) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Performs count query - each result must match specified predicate.
count() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
count(BooleanExpression) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
counters - Variable in class net.ravendb.client.changes.RemoteChangesClientBase
 
CountingStream - Class in net.ravendb.abstractions.connection
 
CountingStream(InputStream) - Constructor for class net.ravendb.abstractions.connection.CountingStream
 
countLazily() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Register the query as a lazy-count query in the session and return a lazy instance that will evaluate the query only when needed
countLazily() - Method in interface net.ravendb.client.IDocumentQuery
Register the query as a lazy-count query in the session and return a lazy instance that will evaluate the query only when needed.
countLazily(Class<T>, Expression<?>) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
countLazily() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
countLazily(Class<T>, Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProvider
Register the query as a lazy-count query in the session and return a lazy Register the query as a lazy-count query in the session and return a lazy
countLazily() - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
countLazily() - Method in class net.ravendb.client.shard.ShardedDocumentQuery
Register the query as a lazy-count query in the session and return a lazy instance that will evaluate the query only when needed
countOn(Path<?>) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
create(T, S) - Static method in class net.ravendb.abstractions.basic.Tuple
 
create(OperationState, ItemTypeSet, boolean, int) - Static method in class net.ravendb.abstractions.smuggler.ExportOptions
 
create(String, HttpJsonRequestFactory) - Method in interface net.ravendb.client.delegates.ReplicationInformerFactory
 
create(Class<?>, SubscriptionCriteria) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
create(Class<?>, SubscriptionCriteria, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
create(SubscriptionCriteria) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
create(SubscriptionCriteria, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
create() - Method in interface net.ravendb.client.document.dtc.ITransactionRecoveryStorage
 
create() - Method in class net.ravendb.client.document.dtc.VolatileOnlyTransactionRecoveryStorage
 
create(Class<?>, SubscriptionCriteria) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It creates a data subscription in a database.
create(Class<?>, SubscriptionCriteria, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It creates a data subscription in a database.
create(SubscriptionCriteria) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It creates a data subscription in a database.
create(SubscriptionCriteria, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It creates a data subscription in a database.
create(Action1<T>) - Static method in class net.ravendb.client.utils.Observers
 
createAsymmetrical(byte[], byte[]) - Method in class net.ravendb.client.utils.encryptors.DefaultEncryptor
 
createAsymmetrical(byte[], byte[]) - Method in class net.ravendb.client.utils.encryptors.FipsEncryptor
 
createAsymmetrical(byte[], byte[]) - Method in interface net.ravendb.client.utils.encryptors.IEncryptor
 
createConfiguration(RoundEnvironment) - Method in class net.ravendb.querydsl.RavenDBAnnotationProcessor
 
createDatabase(DatabaseDocument, Reference<RavenJObject>) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
createDatabase(DatabaseDocument) - Method in class net.ravendb.client.connection.AdminServerClient
 
createDatabase(DatabaseDocument) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Creates a database
createDatabaseChanges(String) - Method in class net.ravendb.client.document.DocumentStore
 
createDatabaseDocument(String) - Static method in class net.ravendb.client.extensions.MultiDatabase
 
createDefaultJsonSerializer() - Static method in class net.ravendb.abstractions.extensions.JsonExtensions
 
createDynamicIndexName(Class) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
createEncryptor() - Method in class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
createEncryptor() - Method in interface net.ravendb.client.utils.encryptors.ISymmetricalEncryptor
 
createFile(String, Action1<InputStream>) - Method in interface net.ravendb.client.document.dtc.ITransactionRecoveryStorageContext
 
createFile(String, Action1<InputStream>) - Method in class net.ravendb.client.document.dtc.VolatileOnlyTransactionRecoveryStorage
 
createHash() - Method in class net.ravendb.client.utils.encryptors.DefaultEncryptor
 
createHash() - Method in class net.ravendb.client.utils.encryptors.FipsEncryptor
 
createHash() - Method in interface net.ravendb.client.utils.encryptors.IEncryptor
 
createHttpJsonRequest(CreateHttpJsonRequestParams) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
CreateHttpJsonRequestParams - Class in net.ravendb.client.connection
 
CreateHttpJsonRequestParams(IHoldProfilingInformation, String, HttpMethods, RavenJObject, OperationCredentials, Convention) - Constructor for class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
CreateHttpJsonRequestParams(IHoldProfilingInformation, String, HttpMethods, RavenJObject, OperationCredentials, Convention, Long) - Constructor for class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
createIndexDefinition() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
createIndexDefinition() - Method in class net.ravendb.client.indexes.AbstractMultiMapIndexCreationTask
 
createIndexDefinition() - Method in class net.ravendb.client.indexes.RavenDocumentsByEntityName
 
createIndexesToAdd(List<AbstractIndexCreationTask>, DocumentConvention) - Static method in class net.ravendb.client.indexes.IndexCreation
 
createProfilingInformation(UUID) - Static method in class net.ravendb.client.connection.profiling.ProfilingInformation
Create a new instance of profiling information and provide additional context information
createPutEntityCommand(Object, DocumentMetadata) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Creates the put entity command.
createQuery(Expression<?>) - Method in interface net.ravendb.client.linq.IQueryProvider
 
createQuery(Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
createRavenQueryInspector() - Method in class net.ravendb.client.document.DocumentSession
 
createRavenQueryInspector() - Method in interface net.ravendb.client.linq.IDocumentQueryGenerator
Generates a query inspector
createRavenQueryInspector() - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
createReplicationAwareRequest(String, String, HttpMethods) - Method in class net.ravendb.client.connection.ServerClient
 
createReplicationAwareRequest(String, String, HttpMethods, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
createRequest(HttpMethods, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Internal use
createRequest(HttpMethods, String, boolean, boolean, Long) - Method in interface net.ravendb.client.connection.IDatabaseCommands
 
createRequest(HttpMethods, String) - Method in class net.ravendb.client.connection.ServerClient
 
createRequest(HttpMethods, String, boolean, boolean, Long) - Method in class net.ravendb.client.connection.ServerClient
 
createRequest() - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
createRequest() - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
createRequest() - Method in class net.ravendb.client.document.LazyFacetsOperation
 
createRestoreRequest() - Method in class net.ravendb.client.connection.AdminRequestCreator
 
createSaveChangesBatchPerShardFromDeferredCommands() - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
createSerializer() - Method in class net.ravendb.client.document.DocumentConvention
 
createSnapshot() - Method in class net.ravendb.abstractions.data.QueryResult
Creates a snapshot of the query results
createSnapshot() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
createSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
createSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
createSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
createSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
createSymmetrical(int) - Method in class net.ravendb.client.utils.encryptors.DefaultEncryptor
 
createSymmetrical(int) - Method in class net.ravendb.client.utils.encryptors.FipsEncryptor
 
createSymmetrical(int) - Method in interface net.ravendb.client.utils.encryptors.IEncryptor
 
createTransformerDefinition() - Method in class net.ravendb.client.indexes.AbstractTransformerCreationTask
Creates the Transformer definition.
current - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase.RangeValue
 
currentExtensionData - Variable in class net.ravendb.client.document.DefaultRavenContractResolver
 
currentOauthToken - Variable in class net.ravendb.abstractions.oauth.AbstractAuthenticator
 
currentSessionId - Static variable in class net.ravendb.client.document.DocumentStore
 
CUSTOM_BUILD_VERSION - Static variable in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
CUSTOM_SORT_FIELD_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
customize(IDocumentQueryCustomization) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
customize(DocumentQueryCustomizationFactory) - Method in interface net.ravendb.client.linq.IRavenQueryable
Customizes the query using the specified action
customize(DocumentQueryCustomizationFactory) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Customizes the query using the specified action
customize(DocumentQueryCustomizationFactory) - Method in class net.ravendb.client.linq.RavenQueryInspector
Customizes the query using the specified action
customize(DocumentQueryCustomizationFactory) - Method in class net.ravendb.client.linq.RavenQueryProvider
Customizes the query using the specified action
CustomQueryExpressionTranslator - Interface in net.ravendb.client.document
 
customSortUsing(String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
customSortUsing(String, boolean) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
customSortUsing(String) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
customSortUsing(String, boolean) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
customSortUsing(String) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
customSortUsing(String, boolean) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
customSortUsing(String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
 
customSortUsing(String, boolean) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Sort using custom sorter on the server
customSortUsing(String, boolean) - Method in interface net.ravendb.client.IDocumentQueryBase
Order the search results randomly
customSortUsing(String) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Sort using custom sorter on the server
customSortUsing(String, boolean) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Sort using custom sorter on the server
cutoff - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The cutoff date to use for detecting staleness in the index
cutoffEtag - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 

D

DatabaseBackupRequest - Class in net.ravendb.abstractions.data
 
DatabaseBackupRequest() - Constructor for class net.ravendb.abstractions.data.DatabaseBackupRequest
 
databaseCommandsFor(String) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
databaseCommandsGenerator - Variable in class net.ravendb.client.document.DocumentStore
 
DatabaseConnectionState - Class in net.ravendb.client.changes
 
DatabaseConnectionState(Action0, Action1<DatabaseConnectionState>) - Constructor for class net.ravendb.client.changes.DatabaseConnectionState
 
DatabaseDocument - Class in net.ravendb.abstractions.data
 
DatabaseDocument() - Constructor for class net.ravendb.abstractions.data.DatabaseDocument
 
DatabaseMetrics - Class in net.ravendb.abstractions.data
 
DatabaseMetrics() - Constructor for class net.ravendb.abstractions.data.DatabaseMetrics
 
DatabaseMetrics.HistogramData - Class in net.ravendb.abstractions.data
 
DatabaseMetrics.HistogramData() - Constructor for class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
DatabaseMetrics.MeterData - Class in net.ravendb.abstractions.data
 
DatabaseMetrics.MeterData() - Constructor for class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
databaseName - Variable in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
DatabaseRestoreRequest - Class in net.ravendb.abstractions.data
 
DatabaseRestoreRequest() - Constructor for class net.ravendb.abstractions.data.DatabaseRestoreRequest
 
databases(String, int, int) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
DatabaseStatistics - Class in net.ravendb.abstractions.data
 
DatabaseStatistics() - Constructor for class net.ravendb.abstractions.data.DatabaseStatistics
 
DataSubscriptionChangeNotification - Class in net.ravendb.abstractions.data
 
DataSubscriptionChangeNotification() - Constructor for class net.ravendb.abstractions.data.DataSubscriptionChangeNotification
 
DataSubscriptionChangeTypes - Enum in net.ravendb.abstractions.data
 
dbName - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
debug(String) - Method in interface net.ravendb.abstractions.logging.ILog
 
debug(String, Object...) - Method in interface net.ravendb.abstractions.logging.ILog
 
debug(String) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
debug(String, Object...) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
debugException(String, Throwable) - Method in interface net.ravendb.abstractions.logging.ILog
 
debugException(String, Throwable) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
dec() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
dec() - Method in interface net.ravendb.client.changes.IChangesConnectionState
 
deepEquals(RavenJToken, List<DocumentsChanges>) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
deepEquals(RavenJToken, RavenJToken, List<DocumentsChanges>) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
 
deepEquals(RavenJToken, RavenJToken) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
 
deepEquals(RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
deepEquals(RavenJToken, List<DocumentsChanges>) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
deepEquals(RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
deepHashCode(RavenJToken) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
 
deepHashCode() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
deepHashCode() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
DEFAULT_ACCURACY - Static variable in class net.ravendb.abstractions.data.SuggestionQuery
 
DEFAULT_BOOST - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_BOOST_FACTOR - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_DISTANCE - Static variable in class net.ravendb.abstractions.data.SuggestionQuery
 
DEFAULT_GEOHASH_LEVEL - Static variable in class net.ravendb.abstractions.indexing.SpatialOptions
 
DEFAULT_MAX_SUGGESTIONS - Static variable in class net.ravendb.abstractions.data.SuggestionQuery
 
DEFAULT_MAXIMUM_DOCUMENT_FREQUENCY - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_MAXIMUM_NUMBER_OF_TOKENS_PARSED - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_MAXIMUM_QUERY_TERMS - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_MAXIMUM_WORD_LENGTH - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_MINIMUM_DOCUMENT_FREQUENCY - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_MINIMUM_TERM_FREQUENCY - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_MINIMUM_WORD_LENGTH - Static variable in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
DEFAULT_QUAD_TREE_LEVEL - Static variable in class net.ravendb.abstractions.indexing.SpatialOptions
 
DEFAULT_SPATIAL_DISTANCE_ERROR_PCT - Static variable in class net.ravendb.abstractions.data.Constants
 
DEFAULT_SPATIAL_FIELD_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
DefaultEncryptor - Class in net.ravendb.client.utils.encryptors
 
DefaultEncryptor() - Constructor for class net.ravendb.client.utils.encryptors.DefaultEncryptor
 
DefaultEncryptor.DefaultHashEncryptor - Class in net.ravendb.client.utils.encryptors
 
DefaultEncryptor.DefaultHashEncryptor() - Constructor for class net.ravendb.client.utils.encryptors.DefaultEncryptor.DefaultHashEncryptor
 
defaultField - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
defaultFindFullDocumentKeyFromNonStringIdentifier(Object, Class<?>, boolean) - Method in class net.ravendb.client.document.DocumentConvention
Find the full document name assuming that we are using the standard conventions for generating a document key
defaultMergeQueryResults(IndexQuery, List<QueryResult>) - Method in class net.ravendb.client.shard.ShardStrategy
Merge the query results from all the shards into a single query results object by simply concatenating all of the values
defaultOperator - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
defaultOptions() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
defaultOptions(SpatialOptions.SpatialUnits) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
Defines a Geohash Prefix Tree index using a default Max Tree Level SpatialOptions
DefaultRavenContractResolver - Class in net.ravendb.client.document
 
DefaultRavenContractResolver() - Constructor for class net.ravendb.client.document.DefaultRavenContractResolver
 
DefaultRavenContractResolver.ClearExtensionData - Class in net.ravendb.client.document
 
DefaultRavenContractResolver.ClearExtensionData() - Constructor for class net.ravendb.client.document.DefaultRavenContractResolver.ClearExtensionData
 
DefaultShardResolutionStrategy - Class in net.ravendb.client.shard
 
DefaultShardResolutionStrategy(Collection<String>, ShardStrategy) - Constructor for class net.ravendb.client.shard.DefaultShardResolutionStrategy
 
defaultTransformTypeTagNameToDocumentKeyPrefix(String) - Static method in class net.ravendb.client.document.DocumentConvention
 
defaultTypeTagName(Class<?>) - Static method in class net.ravendb.client.document.DocumentConvention
Get the default tag name for the specified type.
defer(ICommandData...) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Defer commands to be executed on saveChanges()
defer(ICommandData...) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Defer commands to be executed on saveChanges()
defer(ICommandData...) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
deferredCommandsByShard - Variable in class net.ravendb.client.shard.BaseShardedDocumentSession
 
delegate - Variable in class net.ravendb.client.document.LazySessionOperations
 
delegate - Variable in class net.ravendb.client.document.LazyShardSessionOperations
 
delegate0() - Static method in class net.ravendb.abstractions.closure.Delegates
 
delegate1() - Static method in class net.ravendb.abstractions.closure.Delegates
 
delegate2() - Static method in class net.ravendb.abstractions.closure.Delegates
 
delegate3() - Static method in class net.ravendb.abstractions.closure.Delegates
 
Delegates - Class in net.ravendb.abstractions.closure
 
Delegates() - Constructor for class net.ravendb.abstractions.closure.Delegates
 
Delegates.Delegate0 - Class in net.ravendb.abstractions.closure
 
Delegates.Delegate0() - Constructor for class net.ravendb.abstractions.closure.Delegates.Delegate0
 
Delegates.Delegate1<X> - Class in net.ravendb.abstractions.closure
 
Delegates.Delegate1() - Constructor for class net.ravendb.abstractions.closure.Delegates.Delegate1
 
Delegates.Delegate2<X,Y> - Class in net.ravendb.abstractions.closure
 
Delegates.Delegate2() - Constructor for class net.ravendb.abstractions.closure.Delegates.Delegate2
 
Delegates.Delegate3<X,Y,Z> - Class in net.ravendb.abstractions.closure
 
Delegates.Delegate3() - Constructor for class net.ravendb.abstractions.closure.Delegates.Delegate3
 
delete(String, Etag) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deletes the document with the specified key
delete(String, Etag) - Method in class net.ravendb.client.connection.ServerClient
 
delete(long) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
delete(long, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
delete(T) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Marks the specified entity for deletion.
delete(Class<T>, Number) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Marks the specified entity for deletion.
delete(Class<T>, UUID) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Marks the specified entity for deletion.
delete(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Marks the specified entity for deletion.
delete(long) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It deletes a subscription.
delete(long, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It deletes a subscription.
delete(T) - Method in interface net.ravendb.client.IDocumentSession
Marks the specified entity for deletion.
delete(Class<T>, Number) - Method in interface net.ravendb.client.IDocumentSession
Marks the specified entity for deletion.
delete(Class<T>, UUID) - Method in interface net.ravendb.client.IDocumentSession
Marks the specified entity for deletion.
delete(String) - Method in interface net.ravendb.client.IDocumentSession
Marks the specified entity for deletion.
deleteAttachment(String, Etag) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
Use RavenFS instead.
deleteAttachment(String, Etag) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
deleteByIndex(String, IndexQuery, BulkOperationOptions) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a set based deletes using the specified index
deleteByIndex(String, IndexQuery) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a set based deletes using the specified index
deleteByIndex(String, IndexQuery) - Method in class net.ravendb.client.connection.ServerClient
 
deleteByIndex(String, IndexQuery, BulkOperationOptions) - Method in class net.ravendb.client.connection.ServerClient
 
DeleteCommandData - Class in net.ravendb.abstractions.commands
A single batch operation for a document DELETE
DeleteCommandData(String, Etag) - Constructor for class net.ravendb.abstractions.commands.DeleteCommandData
 
DeleteCommandData() - Constructor for class net.ravendb.abstractions.commands.DeleteCommandData
 
deleteDatabase(String, boolean) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
deleteDatabase(String) - Method in class net.ravendb.client.connection.AdminServerClient
 
deleteDatabase(String, boolean) - Method in class net.ravendb.client.connection.AdminServerClient
 
deleteDatabase(String) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Used to delete a database from a server, with a possibility to remove all the data from hard drive.
deleteDatabase(String, boolean) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Used to delete a database from a server, with a possibility to remove all the data from hard drive.
deletedEntities - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
deleteFile(String) - Method in interface net.ravendb.client.document.dtc.ITransactionRecoveryStorageContext
 
deleteFile(String) - Method in class net.ravendb.client.document.dtc.VolatileOnlyTransactionRecoveryStorage
 
deleteIndex(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deletes the specified index
deleteIndex(String) - Method in class net.ravendb.client.connection.ServerClient
 
deleteTransformer(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deletes the specified transformer
deleteTransformer(String) - Method in class net.ravendb.client.connection.ServerClient
 
deserialize(JsonParser, DeserializationContext) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.RavenEnumDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.RavenJTokenDeserializer
 
deserialize(String, Class<T>) - Method in class net.ravendb.client.document.JsonSerializer
 
deserialize(RavenJToken, Class<T>) - Method in class net.ravendb.client.document.JsonSerializer
 
deserialize(Class<T>, RavenJObject) - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
deserializeAttachements(RavenJToken, boolean) - Static method in class net.ravendb.client.connection.SerializationHelper
Java only
deserializeJsonDocument(String, RavenJToken, Map<String, String>, int) - Static method in class net.ravendb.client.connection.SerializationHelper
 
deserializeJsonDocumentMetadata(String, Map<String, String>, int) - Static method in class net.ravendb.client.connection.SerializationHelper
 
deserializeObject(RavenJArray, Class<T>, String) - Static method in class net.ravendb.imports.json.JsonConvert
This method gets RavenJArray, extracts propertyName from each object and maps to targetClass
deserializeObject(Class<T>, String) - Static method in class net.ravendb.imports.json.JsonConvert
 
dictionaryToString(Map<String, String>) - Static method in class net.ravendb.abstractions.connection.OAuthHelper
 
DictionaryWithParentSnapshot - Class in net.ravendb.abstractions.json.linq
 
DictionaryWithParentSnapshot(Comparator<String>) - Constructor for class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
DictionaryWithParentSnapshot(DictionaryWithParentSnapshot) - Constructor for class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
directBatch(List<ICommandData>, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directDelete(OperationMetadata, String, Etag) - Method in class net.ravendb.client.connection.ServerClient
 
directDeleteAttachment(String, Etag, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
directDeleteByIndex(OperationMetadata, String, IndexQuery, BulkOperationOptions) - Method in class net.ravendb.client.connection.ServerClient
 
directDeleteIndex(String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directDeleteTransformer(String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directGet(OperationMetadata, String) - Method in class net.ravendb.client.connection.ServerClient
 
directGet(String[], OperationMetadata, String[], String, Map<String, RavenJToken>, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
directGetAttachment(HttpMethods, String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
directGetAttachmentHeadersStartingWith(HttpMethods, String, int, int, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
directGetAttachments(int, Etag, int, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
directGetFacets(OperationMetadata, String, IndexQuery, String, int, Integer) - Method in class net.ravendb.client.connection.ServerClient
 
directGetFacets(OperationMetadata, String, IndexQuery, String, int, Integer, HttpMethods) - Method in class net.ravendb.client.connection.ServerClient
 
directGetIndex(String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directGetIndexes(int, int, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directGetIndexNames(int, int, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directGetReplicationDestinations(OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directGetTerms(OperationMetadata, String, String, String, int) - Method in class net.ravendb.client.connection.ServerClient
 
directGetTransformer(String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directGetTransformers(OperationMetadata, int, int) - Method in class net.ravendb.client.connection.ServerClient
 
directHead(OperationMetadata, String) - Method in class net.ravendb.client.connection.ServerClient
 
directIndexHasChanged(String, IndexDefinition, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directMultiGetInternal(OperationMetadata, GetRequest[], Reference<OperationMetadata>) - Method in class net.ravendb.client.connection.ServerClient
 
directNextIdentityFor(String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directPut(RavenJObject, String, Etag, RavenJObject, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directPutAttachment(String, RavenJObject, Etag, InputStream, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
directPutIndex(String, IndexDefinition, boolean, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directPutTransformer(String, OperationMetadata, TransformerDefinition) - Method in class net.ravendb.client.connection.ServerClient
 
directQueryAsGet(String, IndexQuery, OperationMetadata, String[], boolean, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
directQueryAsPost(String, IndexQuery, OperationMetadata, String[], boolean, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
directResetIndex(String, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directSetIndexLock(String, IndexLockMode, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directSetIndexPriority(String, IndexStats.IndexingPriority, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directStartsWith(OperationMetadata, String, String, int, int, boolean, String, RavenPagingInformation, String, Map<String, RavenJToken>, String) - Method in class net.ravendb.client.connection.ServerClient
 
directStreamDocs(OperationMetadata, Etag, String, String, int, int, String, RavenPagingInformation, String) - Method in class net.ravendb.client.connection.ServerClient
 
directStreamQuery(OperationMetadata, String, IndexQuery, Reference<QueryHeaderInformation>) - Method in class net.ravendb.client.connection.ServerClient
 
directSuggest(String, SuggestionQuery, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
directUpdateAttachmentMetadata(String, RavenJObject, Etag, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
directUpdateByIndexImpl(OperationMetadata, String, IndexQuery, BulkOperationOptions, String, HttpMethods) - Method in class net.ravendb.client.connection.ServerClient
 
disable(JsonGenerator.Feature) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
disableAggressiveCaching() - Method in class net.ravendb.client.document.DocumentStore
Setup the context for no aggressive caching This is mainly useful for internal use inside RavenDB, when we are executing queries that have been marked with WaitForNonStaleResults, we temporarily disable aggressive caching.
disableAggressiveCaching() - Method in interface net.ravendb.client.IDocumentStore
Setup the context for no aggressive caching This is mainly useful for internal use inside RavenDB, when we are executing queries that has been marked with WaitForNonStaleResults, we temporarily disable aggressive caching.
disableAggressiveCaching() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Setup the context for no aggressive caching This is mainly useful for internal use inside RavenDB, when we are executing queries that has been marked with WaitForNonStaleResults, we temporarily disable aggressive caching.
disableAllCaching() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Disable all caching within the given scope
disableAllCaching() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
disableAllCaching() - Method in class net.ravendb.client.connection.ServerClient
 
disableAllCaching - Variable in class net.ravendb.client.document.sessionoperations.MultiLoadOperation
 
disableCaching - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Determine if query results should be cached.
disableEntitiesTracking - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Determines if entities should be tracked and kept in memory
disableInMemoryIndexing - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
disjoint(Object) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
 
dispose() - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
DISTANCE_FIELD_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
distanceErrorPct - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
DISTINCT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
distinct - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
distinct() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
distinct() - Method in class net.ravendb.client.document.DocumentQuery
 
distinct() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
 
distinct() - Method in interface net.ravendb.client.IDocumentQueryBase
Apply distinct operation to this query
distinct() - Method in interface net.ravendb.client.linq.IRavenQueryable
Returns distinct results
distinct() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
doc(String, String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
docs(String, int, int) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
docsCount - Variable in class net.ravendb.abstractions.data.IndexStats
 
DOCUMENT_ID_FIELD_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
DocumentChangeNotification - Class in net.ravendb.abstractions.data
 
DocumentChangeNotification() - Constructor for class net.ravendb.abstractions.data.DocumentChangeNotification
 
DocumentChangeTypes - Enum in net.ravendb.abstractions.data
 
DocumentConvention - Class in net.ravendb.client.document
Note: we removed logic related to applyReduceFunction because we don't support map/reduce on shards we also don't support contractResolver - Jackson customization can be performed via JsonExtensions#getDefaultObjectMapper() instance
DocumentConvention() - Constructor for class net.ravendb.client.document.DocumentConvention
 
DocumentConvention.TryConvertValueForQueryDelegate<T> - Interface in net.ravendb.client.document
 
DocumentDoesNotExistsException - Exception in net.ravendb.abstractions.exceptions
 
DocumentDoesNotExistsException() - Constructor for exception net.ravendb.abstractions.exceptions.DocumentDoesNotExistsException
 
DocumentDoesNotExistsException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.DocumentDoesNotExistsException
 
DocumentDoesNotExistsException(String) - Constructor for exception net.ravendb.abstractions.exceptions.DocumentDoesNotExistsException
 
DocumentDoesNotExistsException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.DocumentDoesNotExistsException
 
DocumentHelpers - Class in net.ravendb.abstractions.util
 
DocumentHelpers() - Constructor for class net.ravendb.abstractions.util.DocumentHelpers
 
DocumentKeyFinder - Interface in net.ravendb.client.delegates
 
DocumentKeyGenerator - Interface in net.ravendb.client.document
 
DocumentMetadata - Class in net.ravendb.client.document
Metadata held about an entity by the session
DocumentMetadata() - Constructor for class net.ravendb.client.document.DocumentMetadata
 
DocumentQuery<T> - Class in net.ravendb.client.document
A query against a Raven index
DocumentQuery(Class<T>, InMemoryDocumentSessionOperations, IDatabaseCommands, String, String[], String[], List<IDocumentQueryListener>, boolean) - Constructor for class net.ravendb.client.document.DocumentQuery
Initializes a new instance of the DocumentQuery class.
DocumentQuery(DocumentQuery<T>) - Constructor for class net.ravendb.client.document.DocumentQuery
Initializes a new instance of the DocumentQuery class.
documentQuery(Class<T>, Class<TIndexCreator>) - Method in class net.ravendb.client.document.DocumentSession
Queries the index specified by using lucene syntax.
documentQuery(Class<T>, String) - Method in class net.ravendb.client.document.DocumentSession
 
documentQuery(Class<T>, String, boolean) - Method in class net.ravendb.client.document.DocumentSession
Query the specified index using Lucene syntax
documentQuery(Class<T>) - Method in class net.ravendb.client.document.DocumentSession
Dynamically query RavenDB using Lucene syntax
documentQuery(Class<T>, Class<S>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Queries the index specified by using lucene syntax.
documentQuery(Class<T>, String, boolean) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Query the specified index using Lucene syntax
documentQuery(Class<T>, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Query the specified index using Lucene syntax
documentQuery(Class<T>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Dynamically query RavenDB using Lucene syntax
documentQuery(Class<T>, String, boolean) - Method in interface net.ravendb.client.linq.IDocumentQueryGenerator
Create a new query for
documentQuery(Class<T>, Class<TIndexCreator>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
documentQuery(Class<T>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
documentQuery(Class<T>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
documentQuery(Class<T>, String, boolean) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
DocumentQueryCustomization - Class in net.ravendb.client.document
 
DocumentQueryCustomization(DocumentQuery<?>) - Constructor for class net.ravendb.client.document.DocumentQueryCustomization
 
DocumentQueryCustomizationFactory - Class in net.ravendb.client.document
Allows query customization
DocumentQueryCustomizationFactory() - Constructor for class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
DocumentQueryCustomizationFactory(Set<Action1<IDocumentQueryCustomization>>, Action1<IDocumentQueryCustomization>) - Constructor for class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
DocumentsChanges - Class in net.ravendb.abstractions.data
 
DocumentsChanges() - Constructor for class net.ravendb.abstractions.data.DocumentsChanges
 
DocumentsChanges.ChangeType - Enum in net.ravendb.abstractions.data
 
DocumentSession - Class in net.ravendb.client.document
Implements Unit of Work for accessing the RavenDB server
DocumentSession(String, DocumentStore, DocumentSessionListeners, UUID, IDatabaseCommands) - Constructor for class net.ravendb.client.document.DocumentSession
Initializes a new instance of the DocumentSession class.
DocumentSession.DisableAllCachingCallback - Class in net.ravendb.client.document
 
DocumentSession.DisableAllCachingCallback() - Constructor for class net.ravendb.client.document.DocumentSession.DisableAllCachingCallback
 
DocumentSessionListeners - Class in net.ravendb.client.document
Holder for all the listeners for the session
DocumentSessionListeners() - Constructor for class net.ravendb.client.document.DocumentSessionListeners
 
documentsSubscription - Variable in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
DocumentStore - Class in net.ravendb.client.document
Manages access to RavenDB and open sessions to work with RavenDB.
DocumentStore() - Constructor for class net.ravendb.client.document.DocumentStore
 
DocumentStore(String) - Constructor for class net.ravendb.client.document.DocumentStore
 
DocumentStore(String, String) - Constructor for class net.ravendb.client.document.DocumentStore
 
DocumentStore.ReplicationInformerGetter - Class in net.ravendb.client.document
 
DocumentStore.ReplicationInformerGetter() - Constructor for class net.ravendb.client.document.DocumentStore.ReplicationInformerGetter
 
DocumentStoreBase - Class in net.ravendb.client
Contains implementation of some IDocumentStore operations shared by DocumentStore implementations
DocumentStoreBase() - Constructor for class net.ravendb.client.DocumentStoreBase
 
DocumentSubscriptions - Class in net.ravendb.client.document
 
DocumentSubscriptions(IDocumentStore) - Constructor for class net.ravendb.client.document.DocumentSubscriptions
 
DocumentSubscriptions.ErrorAndUrl - Class in net.ravendb.client.document
 
DocumentSubscriptions.ErrorAndUrl() - Constructor for class net.ravendb.client.document.DocumentSubscriptions.ErrorAndUrl
 
doOAuthRequest(String, String) - Method in class net.ravendb.abstractions.oauth.AbstractAuthenticator
 
doOAuthRequest(String, String) - Method in class net.ravendb.abstractions.oauth.BasicAuthenticator
 
doOAuthRequest(String, String) - Method in class net.ravendb.abstractions.oauth.SecuredAuthenticator
 
DUMMY_CHAR - Static variable in class net.ravendb.client.utils.UrlUtils
 
DynamicAggregationQuery<T> - Class in net.ravendb.client.linq
 
DynamicAggregationQuery(IRavenQueryable<T>, Path<?>) - Constructor for class net.ravendb.client.linq.DynamicAggregationQuery
 
DynamicAggregationQuery(IRavenQueryable<T>, Path<?>, String) - Constructor for class net.ravendb.client.linq.DynamicAggregationQuery
 
DynamicAggregationQuery(IRavenQueryable<T>, String) - Constructor for class net.ravendb.client.linq.DynamicAggregationQuery
 
DynamicAggregationQuery(IRavenQueryable<T>, String, String) - Constructor for class net.ravendb.client.linq.DynamicAggregationQuery
 

E

eagerly() - Method in class net.ravendb.client.document.DocumentSession
Access the eager operations
eagerly() - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Access the eager operations
eagerly() - Method in class net.ravendb.client.shard.ShardedDocumentSession
Access the eager operations
EARTH_MEAN_RADIUS_KM - Static variable in class net.ravendb.abstractions.data.Constants
The International Union of Geodesy and Geophysics says the Earth's mean radius in KM is: [1] http://en.wikipedia.org/wiki/Earth_radius
EMPTY - Static variable in class net.ravendb.abstractions.basic.EventArgs
 
empty() - Static method in class net.ravendb.abstractions.data.Etag
 
EMPTY_STRING - Static variable in class net.ravendb.abstractions.data.Constants
 
EMPTY_STRING_NOT_ANALYZED - Static variable in class net.ravendb.abstractions.data.Constants
 
EMPTY_UUID - Static variable in class net.ravendb.abstractions.data.Constants
 
enable(JsonGenerator.Feature) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
encrypt(byte[]) - Method in class net.ravendb.client.utils.encryptors.FipsAsymmetricalEncryptor
 
encrypt(byte[]) - Method in interface net.ravendb.client.utils.encryptors.IAsymmetricalEncryptor
 
encryptAsymmetric(byte[], byte[], String) - Static method in class net.ravendb.abstractions.connection.OAuthHelper
 
EncryptedData - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
Encryptor - Class in net.ravendb.client.utils.encryptors
 
Encryptor() - Constructor for class net.ravendb.client.utils.encryptors.Encryptor
 
ensureCannotBeChangeAndEnableShapshotting() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
ensureCannotBeChangeAndEnableShapshotting() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
ensureCannotBeChangeAndEnableShapshotting() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
ensureCannotBeChangeAndEnableShapshotting() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
ensureDatabaseExists(String, boolean) - Method in class net.ravendb.client.connection.AdminServerClient
 
ensureDatabaseExists(String) - Method in class net.ravendb.client.connection.AdminServerClient
 
ensureDatabaseExists(String) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Ensures that the database exists, creating it if needed
ensureDatabaseExists(String, boolean) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Ensures that the database exists, creating it if needed
ensureNotClosed() - Method in class net.ravendb.client.DocumentStoreBase
 
ensureNotReadVetoed(RavenJObject) - Static method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
ensureSnapshot() - Method in class net.ravendb.abstractions.data.QueryResult
Ensures that the query results can be used in snapshots
ensureSnapshot() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
ensureSnapshot(String) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
ensureSnapshot(String) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
enterContext() - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
enterContext() - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
enterContext() - Method in class net.ravendb.client.document.LazyFacetsOperation
 
enterLoadContext() - Method in class net.ravendb.client.document.sessionoperations.LoadOperation
 
enterMultiLoadContext() - Method in class net.ravendb.client.document.sessionoperations.MultiLoadOperation
 
enterQueryContext() - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
entitiesAndMetadata - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
entitiesByKey - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
entitiesToJsonCachingScope() - Method in class net.ravendb.client.document.EntityToJson
All calls to convert an entity to a json object would be cache This is used inside the SaveChanges() action, where we need to access the entities json in several disparate places.
entityChanged(Object, DocumentMetadata) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
entityChanged(Object, DocumentMetadata, Map<String, List<DocumentsChanges>>) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Determines if the entity have changed.
EntityToJson - Class in net.ravendb.client.document
 
EntityToJson(IDocumentStore, DocumentSessionListeners) - Constructor for class net.ravendb.client.document.EntityToJson
 
entityToJson - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
EntityToJson.DisposeCachedJsonDocs - Class in net.ravendb.client.document
 
EntityToJson.DisposeCachedJsonDocs() - Constructor for class net.ravendb.client.document.EntityToJson.DisposeCachedJsonDocs
 
entrySet() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
EnumerableUtils - Class in net.ravendb.client.linq
 
EnumerableUtils() - Constructor for class net.ravendb.client.linq.EnumerableUtils
 
EnumSet<T extends Enum<T>,S extends EnumSet<T,S>> - Class in net.ravendb.abstractions.data
 
EnumSet(Class<T>, List<? extends Enum<T>>) - Constructor for class net.ravendb.abstractions.data.EnumSet
 
EnumSet(Class<T>) - Constructor for class net.ravendb.abstractions.data.EnumSet
 
EQ_NOT_IGNORE_CASE - Static variable in class net.ravendb.abstractions.LinqOps.Ops
 
equals(Object) - Method in class net.ravendb.abstractions.basic.Tuple
 
equals(Object) - Method in class net.ravendb.abstractions.data.DocumentsChanges
 
equals(Object) - Method in class net.ravendb.abstractions.data.EnumSet
 
equals(Object) - Method in class net.ravendb.abstractions.data.Etag
 
equals(Object) - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
 
equals(Object) - Method in class net.ravendb.abstractions.data.ScriptedPatchRequest
 
equals(Object) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
equals(Object) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
equals(Object) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
equals(Object) - Method in class net.ravendb.abstractions.indexing.SuggestionOptions
 
equals(Object) - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
 
equals(Object) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
equals(Object) - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
equals(Object) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
equalsNotIgnoreCase(Expression<String>) - Method in class net.ravendb.querydsl.RavenString
Compares this StringExpression to another StringExpression, NOT ignoring case considerations.
equalsNotIgnoreCase(String) - Method in class net.ravendb.querydsl.RavenString
Compares this StringExpression to another StringExpression, NOT ignoring case considerations.
error(String, Object...) - Method in interface net.ravendb.abstractions.logging.ILog
 
error(String, Object...) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
error(Exception) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
error(Exception) - Method in interface net.ravendb.client.changes.IChangesConnectionState
 
error(Exception) - Method in class net.ravendb.client.changes.TaskedObservable
 
errorException(String, Throwable) - Method in interface net.ravendb.abstractions.logging.ILog
 
errorException(String, Throwable) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
ErrorResponseException - Exception in net.ravendb.abstractions.connection
 
ErrorResponseException(ErrorResponseException, String) - Constructor for exception net.ravendb.abstractions.connection.ErrorResponseException
 
ErrorResponseException(CloseableHttpResponse, String) - Constructor for exception net.ravendb.abstractions.connection.ErrorResponseException
 
ErrorResponseException(CloseableHttpResponse, String, Throwable) - Constructor for exception net.ravendb.abstractions.connection.ErrorResponseException
 
ErrorResponseException(CloseableHttpResponse, String, String) - Constructor for exception net.ravendb.abstractions.connection.ErrorResponseException
 
escape(String) - Static method in class net.ravendb.abstractions.util.RavenQuery
Escapes Lucene operators and quotes phrases
escape(String, boolean, boolean) - Static method in class net.ravendb.abstractions.util.RavenQuery
Escapes Lucene operators and quotes phrases http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Escaping%20Special%20Characters
escapeDataString(String) - Static method in class net.ravendb.client.utils.UrlUtils
 
escapeField(String) - Static method in class net.ravendb.abstractions.util.RavenQuery
Escapes Lucene field
escapeLongDataString(String) - Static method in class net.ravendb.abstractions.util.EscapingHelper
 
EscapeQueryOptions - Enum in net.ravendb.client
 
escapeUriString(String) - Static method in class net.ravendb.client.utils.UrlUtils
 
EscapingHelper - Class in net.ravendb.abstractions.util
 
EsentStorageStats - Class in net.ravendb.abstractions.data
 
EsentStorageStats() - Constructor for class net.ravendb.abstractions.data.EsentStorageStats
 
establishConnection() - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
Etag - Class in net.ravendb.abstractions.data
 
Etag() - Constructor for class net.ravendb.abstractions.data.Etag
 
Etag(String) - Constructor for class net.ravendb.abstractions.data.Etag
 
Etag(UuidType, long, long) - Constructor for class net.ravendb.abstractions.data.Etag
 
etagHeaderToEtag(String) - Static method in class net.ravendb.client.connection.HttpExtensions
 
evaluate(RavenJToken, boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJPath
 
evaluate(RavenJToken, boolean, boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJPath
 
EventArgs - Class in net.ravendb.abstractions.basic
Parent class for all EventArgs
EventArgs() - Constructor for class net.ravendb.abstractions.basic.EventArgs
 
EventHandler<T extends EventArgs> - Interface in net.ravendb.abstractions.basic
 
EventHelper - Class in net.ravendb.abstractions.basic
 
EventHelper() - Constructor for class net.ravendb.abstractions.basic.EventHelper
 
evict(T) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Evicts the specified entity from the session.
evict(T) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Evicts the specified entity from the session.
evictCacheOldItems - Variable in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
EvictItemsFromCacheBasedOnChanges - Class in net.ravendb.client.util
 
EvictItemsFromCacheBasedOnChanges(String, IDatabaseChanges, Action1<String>) - Constructor for class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
EvictItemsFromCacheBasedOnChanges.DocumentChangeObserver - Class in net.ravendb.client.util
 
EvictItemsFromCacheBasedOnChanges.DocumentChangeObserver() - Constructor for class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges.DocumentChangeObserver
 
EvictItemsFromCacheBasedOnChanges.IndexChangeObserver - Class in net.ravendb.client.util
 
EvictItemsFromCacheBasedOnChanges.IndexChangeObserver() - Constructor for class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges.IndexChangeObserver
 
except(Iterable<T>, Iterable<T>) - Static method in class net.ravendb.abstractions.basic.CollectionUtils
 
ExceptionEventArgs - Class in net.ravendb.abstractions.basic
 
ExceptionEventArgs(Exception) - Constructor for class net.ravendb.abstractions.basic.ExceptionEventArgs
 
ExceptionExtensions - Class in net.ravendb.abstractions.extensions
 
ExceptionExtensions() - Constructor for class net.ravendb.abstractions.extensions.ExceptionExtensions
 
execute(IDocumentStore) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Executes the index creation against the specified document store.
execute(IDatabaseCommands, DocumentConvention) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Executes the index creation against the specified document database using the specified conventions
execute(IDocumentStore) - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
execute(IDatabaseCommands) - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
execute(IDocumentStore) - Method in class net.ravendb.client.indexes.AbstractTransformerCreationTask
 
execute(IDatabaseCommands, DocumentConvention) - Method in class net.ravendb.client.indexes.AbstractTransformerCreationTask
 
execute(Expression<?>) - Method in interface net.ravendb.client.linq.IQueryProvider
 
execute(Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
execute(Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
executeActualQuery() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
executeActualQuery() - Method in class net.ravendb.client.shard.ShardedDocumentQuery
 
executeAllPendingLazyOperations() - Method in interface net.ravendb.client.document.batches.IEagerSessionOperations
Execute all the lazy requests pending within this session
executeAllPendingLazyOperations() - Method in class net.ravendb.client.document.DocumentSession
 
executeAllPendingLazyOperations() - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
executeBeforeQueryListeners() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
executeEmbedded(IDatabaseCommands) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
executeGetRequest(String) - Method in class net.ravendb.client.connection.ServerClient
 
executeIndex(AbstractIndexCreationTask) - Method in class net.ravendb.client.DocumentStoreBase
Executes index creation.
executeIndex(AbstractIndexCreationTask) - Method in interface net.ravendb.client.IDocumentStore
Executes the index creation.
executeIndex(AbstractIndexCreationTask) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Executes the index creation against each of the shards.
executeIndexes(List<AbstractIndexCreationTask>) - Method in class net.ravendb.client.DocumentStoreBase
 
executeIndexes(List<AbstractIndexCreationTask>) - Method in interface net.ravendb.client.IDocumentStore
 
executeIndexes(List<AbstractIndexCreationTask>) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
executeRawRequest(RemoteBulkInsertOperation.BulkInsertEntity) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
executeRawResponse(String) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
executeRawResponse() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
executeRawResponseInternal(HttpEntity) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
executeRequest() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
executeTransformer(AbstractTransformerCreationTask) - Method in class net.ravendb.client.DocumentStoreBase
 
executeTransformer(AbstractTransformerCreationTask) - Method in interface net.ravendb.client.IDocumentStore
executes the transformer creation
executeTransformer(AbstractTransformerCreationTask) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Executes the transformer creation
executeWithReplication(HttpMethods, String, OperationCredentials, int, int, Function1<OperationMetadata, S>) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
executeWithReplication(HttpMethods, String, OperationCredentials, int, int, Function1<OperationMetadata, S>) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
executeWithReplication(HttpMethods, Function1<OperationMetadata, S>) - Method in class net.ravendb.client.connection.ServerClient
 
expireItemsFromCache(String) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
explainScores() - Method in class net.ravendb.client.document.DocumentQuery
 
explainScores() - Method in interface net.ravendb.client.IDocumentQueryBase
Adds explanations of scores calculated for queried documents to the query result
explicitlyVersion(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Version this entity when it is saved.
explicitlyVersion(Object) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Version this entity when it is saved.
ExportOptions - Class in net.ravendb.abstractions.smuggler
 
ExpressionExtensions - Class in net.ravendb.abstractions.extensions
 
ExpressionExtensions() - Constructor for class net.ravendb.abstractions.extensions.ExpressionExtensions
 
ExpressionInfo - Class in net.ravendb.client.linq
This class represents a node in an expression, usually a member - but in the case of dynamic queries the path to a member
ExpressionInfo(String, Class<?>, boolean) - Constructor for class net.ravendb.client.linq.ExpressionInfo
 
Extensions - Class in net.ravendb.abstractions.json.linq
 
Extensions() - Constructor for class net.ravendb.abstractions.json.linq.Extensions
 
extractHeaders(Header[]) - Static method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 

F

Facet - Class in net.ravendb.abstractions.data
 
Facet() - Constructor for class net.ravendb.abstractions.data.Facet
 
FacetAggregation - Enum in net.ravendb.abstractions.data
 
FacetAggregationSet - Class in net.ravendb.abstractions.data
 
FacetAggregationSet() - Constructor for class net.ravendb.abstractions.data.FacetAggregationSet
 
FacetAggregationSet(FacetAggregation...) - Constructor for class net.ravendb.abstractions.data.FacetAggregationSet
 
FacetMode - Enum in net.ravendb.abstractions.data
 
FacetQuery - Class in net.ravendb.abstractions.data
 
FacetQuery() - Constructor for class net.ravendb.abstractions.data.FacetQuery
 
FacetResult - Class in net.ravendb.abstractions.data
 
FacetResult() - Constructor for class net.ravendb.abstractions.data.FacetResult
 
FacetResults - Class in net.ravendb.abstractions.data
 
FacetResults() - Constructor for class net.ravendb.abstractions.data.FacetResults
 
FacetSetup - Class in net.ravendb.abstractions.data
 
FacetSetup() - Constructor for class net.ravendb.abstractions.data.FacetSetup
 
FacetSetup(String, List<Facet>) - Constructor for class net.ravendb.abstractions.data.FacetSetup
 
FacetTermSortMode - Enum in net.ravendb.abstractions.data
 
FacetValue - Class in net.ravendb.abstractions.data
 
FacetValue() - Constructor for class net.ravendb.abstractions.data.FacetValue
 
FailoverBehavior - Enum in net.ravendb.client.document
 
FailoverBehaviorSet - Class in net.ravendb.client.document
 
FailoverBehaviorSet(FailoverBehavior...) - Constructor for class net.ravendb.client.document.FailoverBehaviorSet
 
FailoverBehaviorSet() - Constructor for class net.ravendb.client.document.FailoverBehaviorSet
 
FailoverServers - Class in net.ravendb.abstractions.data
 
FailoverServers() - Constructor for class net.ravendb.abstractions.data.FailoverServers
 
failoverServers - Variable in class net.ravendb.client.DocumentStoreBase
 
failoverStatusChanged - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
failureCounts - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
fatalException(String, Throwable) - Method in interface net.ravendb.abstractions.logging.ILog
 
fatalException(String, Throwable) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
fetchConcurrencyException(ErrorResponseException) - Method in class net.ravendb.client.connection.ServerClient
 
FieldHighlightings - Class in net.ravendb.client
Query highlightings for the documents.
FieldHighlightings(String) - Constructor for class net.ravendb.client.FieldHighlightings
 
FieldIndexing - Enum in net.ravendb.abstractions.indexing
Options for indexing a field
fieldName - Variable in class net.ravendb.abstractions.indexing.SpatialOptions.SpatialSort
 
fieldsToFetch - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The list of fields to project directly from the index on the server
fieldsToFetch(List<String>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
FieldStorage - Enum in net.ravendb.abstractions.indexing
Specifies whether and how a field should be stored.
FieldTermVector - Enum in net.ravendb.abstractions.indexing
Specifies whether to include term vectors for a field
FileSystemMetrics - Class in net.ravendb.abstractions.data
 
FileSystemMetrics() - Constructor for class net.ravendb.abstractions.data.FileSystemMetrics
 
FileSystemStats - Class in net.ravendb.abstractions.data
 
FileSystemStats() - Constructor for class net.ravendb.abstractions.data.FileSystemStats
 
fill(int, int, int) - Method in class net.ravendb.client.RavenPagingInformation
 
filter - Variable in class net.ravendb.client.changes.TaskedObservable
 
filterHeadersAttachment(Map<String, String>) - Static method in class net.ravendb.abstractions.extensions.MetadataExtensions
Deprecated.
filterHeadersToObject(RavenJObject, Set<String>, Set<String>) - Static method in class net.ravendb.abstractions.extensions.MetadataExtensions
Filters headers from unwanted headers
filterHeadersToObject(RavenJObject) - Static method in class net.ravendb.abstractions.extensions.MetadataExtensions
 
filterHeadersToObject(Map<String, String>) - Static method in class net.ravendb.abstractions.extensions.MetadataExtensions
Filters the headers from unwanted headers
find(Object, Class<?>, Boolean) - Method in interface net.ravendb.client.delegates.DocumentKeyFinder
 
find(Field) - Method in interface net.ravendb.client.delegates.IdentityPropertyFinder
 
find(String) - Method in interface net.ravendb.client.delegates.IdentityPropertyNameFinder
 
find(Object, String) - Method in interface net.ravendb.client.delegates.IdValuePartFinder
 
find(String, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.delegates.JavaClassFinder
 
find(Class<?>) - Method in interface net.ravendb.client.delegates.JavaClassNameFinder
 
find(Class<?>, String, String, String) - Method in interface net.ravendb.client.delegates.PropertyNameFinder
 
find(Class<?>) - Method in interface net.ravendb.client.document.TypeTagNameFinder
 
findEnumValue(Enum<?>) - Method in class net.ravendb.abstractions.basic.SharpAwareJacksonAnnotationIntrospector
 
findIdentifier(String, IDatabaseCommands, Object) - Method in interface net.ravendb.client.delegates.IdConvention
 
FipsAsymmetricalEncryptor - Class in net.ravendb.client.utils.encryptors
 
FipsAsymmetricalEncryptor() - Constructor for class net.ravendb.client.utils.encryptors.FipsAsymmetricalEncryptor
 
FipsEncryptor - Class in net.ravendb.client.utils.encryptors
 
FipsEncryptor() - Constructor for class net.ravendb.client.utils.encryptors.FipsEncryptor
 
FipsEncryptor.FipsHashEncryptor - Class in net.ravendb.client.utils.encryptors
 
FipsEncryptor.FipsHashEncryptor() - Constructor for class net.ravendb.client.utils.encryptors.FipsEncryptor.FipsHashEncryptor
 
FipsSymmetricalEncryptor - Class in net.ravendb.client.utils.encryptors
 
FipsSymmetricalEncryptor() - Constructor for class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
FIRST - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
first() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
first() - Method in class net.ravendb.client.document.DocumentQuery
 
first() - Method in interface net.ravendb.client.IDocumentQuery
Returns first result
first() - Method in interface net.ravendb.client.IDocumentQueryBase
Returns first element or throws if sequence is empty.
first(Iterator<T>) - Static method in class net.ravendb.client.linq.EnumerableUtils
 
first() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Returns only first entry from result.
first(BooleanExpression) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Returns only first entry from result which suffices specified predicate.
first() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
first(BooleanExpression) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
FIRST_OR_DEFAULT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
firstOrDefault(Collection<? extends T>, Function1<T, Boolean>) - Static method in class net.ravendb.abstractions.basic.CollectionUtils
 
firstOrDefault(Function1<T, Boolean>) - Method in class net.ravendb.client.connection.profiling.ConcurrentLruSet
 
firstOrDefault() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
firstOrDefault() - Method in class net.ravendb.client.document.DocumentQuery
 
firstOrDefault() - Method in interface net.ravendb.client.IDocumentQuery
Returns first result
firstOrDefault() - Method in interface net.ravendb.client.IDocumentQueryBase
Returns first element or default value for type if sequence is empty.
firstOrDefault(Iterator<T>) - Static method in class net.ravendb.client.linq.EnumerableUtils
 
firstOrDefault() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Returns first entry from result or default value if none found.
firstOrDefault(BooleanExpression) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Returns first entry from result which suffices specified predicate or default value if none found.
firstOrDefault() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
firstOrDefault(BooleanExpression) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
firstTime - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
flush() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
forAllDataSubscriptions() - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all data subscriptions.
forAllDataSubscriptions() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forAllDataSubscriptions() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forAllDocuments() - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all documents.
forAllDocuments() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forAllDocuments() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forAllIndexes() - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all indexes.
forAllIndexes() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forAllIndexes() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forAllReplicationConflicts() - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to all replication conflicts.
forAllReplicationConflicts() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forAllReplicationConflicts() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forAllTransformers() - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all transformers.
forAllTransformers() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forAllTransformers() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forBulkInsert(UUID) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to all bulk insert operation changes that belong to a operation with given Id.
forBulkInsert() - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to all bulk insert operation changes
forBulkInsert() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forBulkInsert(UUID) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forBulkInsert() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forBulkInsert(UUID) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forceCheck(String, boolean) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
forceCheck(String, boolean) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
forceReadFromMaster() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Force the database commands to read directly from the master, unless there has been a failover.
forceReadFromMaster() - Method in class net.ravendb.client.connection.ServerClient
 
forceResult(QueryResult) - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
forceServerCheckOfCachedItemsForDatabase(String) - Method in class net.ravendb.client.util.SimpleCache
 
forClass(Class<S>) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Change the result type for the query provider
forClass(Class<S>) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
forDatabase(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Create a new instance of IDatabaseCommands that will interacts with the specified database
forDatabase(String, String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
forDatabase(String) - Method in class net.ravendb.client.connection.ServerClient
 
forDataSubscription(long) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for a specified data subscription.
forDataSubscription(long) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDataSubscription(long) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forDocument(String) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for specified document only.
forDocument(String) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDocument(String) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forDocumentsInCollection(String) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all documents that belong to specified collection (Raven-Entity-Name).
forDocumentsInCollection(Class<?>) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all documents that belong to specified collection (Raven-Entity-Name).
forDocumentsInCollection(String) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDocumentsInCollection(Class<?>) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDocumentsInCollection(String) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forDocumentsInCollection(Class<?>) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forDocumentsOfType(String) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all documents that belong to specified type (Raven-Clr-Type).
forDocumentsOfType(Class<?>) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all documents that belong to specified type (Raven-Clr-Type).
forDocumentsOfType(String) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDocumentsOfType(Class<?>) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDocumentsOfType(String) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forDocumentsOfType(Class<?>) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forDocumentsStartingWith(String) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for all documents that Id starts with given prefix.
forDocumentsStartingWith(String) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forDocumentsStartingWith(String) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
forIndex(String) - Method in interface net.ravendb.client.changes.IDatabaseChanges
Subscribe to changes for specified index only.
forIndex(String) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
forIndex(String) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
format(Date, StringBuffer, FieldPosition) - Method in class net.ravendb.abstractions.util.NetDateFormat
 
format(Date) - Static method in class net.ravendb.abstractions.util.NetISO8601Utils
Format a date into 'yyyy-MM-ddThh:mm:ssZ' (GMT timezone, no milliseconds precision)
format(Date, boolean) - Static method in class net.ravendb.abstractions.util.NetISO8601Utils
Format a date into 'yyyy-MM-ddThh:mm:ss[.sss]Z' (GMT timezone)
format(Date, boolean, TimeZone) - Static method in class net.ravendb.abstractions.util.NetISO8601Utils
Format date into yyyy-MM-ddThh:mm:ss[.sss][Z|[+-]hh:mm]
formatString(long) - Static method in class net.ravendb.client.utils.TimeSpan
 
forSystemDatabase() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates a new instance of IDatabaseCommands that will interacts with the default database.
forSystemDatabase() - Method in class net.ravendb.client.connection.ServerClient
 
fromConnectionString(Class<S>, String) - Static method in class net.ravendb.abstractions.data.ConnectionStringParser
 
fromJson(RavenJObject) - Static method in class net.ravendb.abstractions.data.PatchRequest
Create an instance from a json object
fromJson(RavenJObject) - Static method in class net.ravendb.abstractions.data.ScriptedPatchRequest
 
fromLegacy() - Static method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory
 
fromLegacy(SpatialOptions.SpatialSearchStrategy) - Static method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory
 
fromLegacy(SpatialOptions.SpatialSearchStrategy, int) - Static method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory
 
fromObject(Object) - Static method in class net.ravendb.abstractions.json.linq.RavenJObject
Creates a RavenJObject from an object.
fromObject(Object, JsonSerializer) - Static method in class net.ravendb.abstractions.json.linq.RavenJObject
Creates a RavenJObject from an object.
fromObject(Object) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
Creates a RavenJToken from an object.
fromObjectInternal(Object, JsonSerializer) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
 
fromResponseMessage(CloseableHttpResponse) - Static method in exception net.ravendb.abstractions.connection.ErrorResponseException
 
fromResponseMessage(CloseableHttpResponse, boolean) - Static method in exception net.ravendb.abstractions.connection.ErrorResponseException
 
fromValue(String, Class<T>) - Static method in class net.ravendb.abstractions.basic.SharpEnum
 
Function0<T> - Interface in net.ravendb.abstractions.closure
Function with no arguments, which returns object of type
Function1<F,T> - Interface in net.ravendb.abstractions.closure
 
Function2<F,G,T> - Interface in net.ravendb.abstractions.closure
 
Function3<F,G,H,T> - Interface in net.ravendb.abstractions.closure
 
Function4<F,G,H,I,T> - Interface in net.ravendb.abstractions.closure
 
Functions - Class in net.ravendb.abstractions.closure
 
Functions() - Constructor for class net.ravendb.abstractions.closure.Functions
 
Functions.AlwaysFalse<S> - Class in net.ravendb.abstractions.closure
 
Functions.AlwaysFalse() - Constructor for class net.ravendb.abstractions.closure.Functions.AlwaysFalse
 
Functions.AlwaysTrue<S> - Class in net.ravendb.abstractions.closure
 
Functions.AlwaysTrue() - Constructor for class net.ravendb.abstractions.closure.Functions.AlwaysTrue
 
Functions.StaticFunction1<S,T> - Class in net.ravendb.abstractions.closure
Function that takes 1 parameter and returns always the same value
Functions.StaticFunction1(T) - Constructor for class net.ravendb.abstractions.closure.Functions.StaticFunction1
 
FutureBatchStats - Class in net.ravendb.abstractions.data
 
FutureBatchStats() - Constructor for class net.ravendb.abstractions.data.FutureBatchStats
 
fuzzy(Double) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Specifies a fuzziness factor to the single word term in the last where clause http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Fuzzy%20Searches
fuzzy(Double) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Specifies a fuzziness factor to the single word term in the last where clause http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Fuzzy%20Searches
fuzzy(Double) - Method in interface net.ravendb.client.IDocumentQueryBase
Specifies a fuzziness factor to the single word term in the last where clause http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Fuzzy%20Searches

G

generate(String, IDatabaseCommands, Object) - Method in interface net.ravendb.client.document.DocumentKeyGenerator
Generates document key
generateDocumentKey(String, IDatabaseCommands, Object) - Method in class net.ravendb.client.document.DocumentConvention
Generates the document key.
generateDocumentKey(IDatabaseCommands, DocumentConvention, Object) - Method in class net.ravendb.client.document.HiLoKeyGenerator
Generates the document key.
generateDocumentKey(String, IDatabaseCommands, DocumentConvention, Object) - Method in class net.ravendb.client.document.MultiDatabaseHiLoGenerator
 
generateDocumentKey(IDatabaseCommands, DocumentConvention, Object) - Method in class net.ravendb.client.document.MultiTypeHiLoKeyGenerator
Generates the document key.
generateDocumentKey(IDatabaseCommands, DocumentConvention, Object) - Method in class net.ravendb.client.shard.ShardedHiloKeyGenerator
 
generateDocumentKeyForStorage(Object) - Method in class net.ravendb.client.document.GenerateEntityIdOnTheClient
 
generateDocumentKeysOnStore - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
generateDocumentKeyUsingIdentity(DocumentConvention, Object) - Static method in class net.ravendb.client.document.DocumentConvention
Generates the document key using identity.
GenerateEntityIdOnTheClient - Class in net.ravendb.client.document
 
GenerateEntityIdOnTheClient(DocumentConvention, Function1<Object, String>) - Constructor for class net.ravendb.client.document.GenerateEntityIdOnTheClient
 
generateIndexQuery(String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Generates the index query.
generateIV() - Method in class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
generateIV() - Method in interface net.ravendb.client.utils.encryptors.ISymmetricalEncryptor
 
generateKey(Object) - Method in class net.ravendb.client.document.DocumentSession
 
generateKey(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
generateKey(Object) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
generateKey() - Method in class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
generateKey() - Method in interface net.ravendb.client.utils.encryptors.ISymmetricalEncryptor
 
generateQueryWithinRadiusOf(String, double, double, double) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
generateQueryWithinRadiusOf(String, double, double, double, double) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
generateQueryWithinRadiusOf(String, double, double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Filter matches to be inside the specified radius
generateShardIdFor(Object, Object) - Method in class net.ravendb.client.shard.DefaultShardResolutionStrategy
Generate a shard id for the specified entity
generateShardIdFor(Object, Object) - Method in interface net.ravendb.client.shard.IShardResolutionStrategy
Generate a shard id for the specified entity
generateSpatialQueryData(String, String, SpatialOptions.SpatialRelation) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
generateSpatialQueryData(String, String, SpatialOptions.SpatialRelation, double) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
generateSpatialQueryData(String, String, SpatialOptions.SpatialRelation, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
generateSpatialQueryData(String, SpatialCriteria) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
generateSpatialQueryData(String, SpatialCriteria, double) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
geohashPrefixTreeIndex(int) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
geohashPrefixTreeIndex(int, SpatialOptions.SpatialUnits) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
GeoJsonWktConverter - Class in net.ravendb.abstractions.spatial
 
GeoJsonWktConverter() - Constructor for class net.ravendb.abstractions.spatial.GeoJsonWktConverter
 
get(Object) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
get(int) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
Gets the RavenJToken at the specified index.
get(String) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
get(String) - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
get(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieve a single document for a specified key.
get(String[], String[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents with the specified ids, optionally specifying includes to fetch along and also optionally the transformer.
get(String[], String[], String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents with the specified ids, optionally specifying includes to fetch along and also optionally the transformer.
get(String[], String[], String, Map<String, RavenJToken>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents with the specified ids, optionally specifying includes to fetch along and also optionally the transformer.
get(String[], String[], String, Map<String, RavenJToken>, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents with the specified ids, optionally specifying includes to fetch along and also optionally the transformer.
get(String) - Method in class net.ravendb.client.connection.ServerClient
 
get(String[], String[]) - Method in class net.ravendb.client.connection.ServerClient
 
get(String[], String[], String) - Method in class net.ravendb.client.connection.ServerClient
 
get(String[], String[], String, Map<String, RavenJToken>) - Method in class net.ravendb.client.connection.ServerClient
 
get(String[], String[], String, Map<String, RavenJToken>, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
get(String) - Method in class net.ravendb.client.util.SimpleCache
 
getAccuracy() - Method in class net.ravendb.abstractions.data.SuggestionQuery
Suggestion accuracy.
getAccuracy() - Method in class net.ravendb.abstractions.indexing.SuggestionOptions
Suggestion accuracy.
getAckEtag() - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
getAcknowledgmentTimeout() - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
getAction() - Method in class net.ravendb.abstractions.data.IndexingError
 
getActiveSyncs() - Method in class net.ravendb.abstractions.data.FileSystemStats
 
getActiveTransactions() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getActualEtag() - Method in exception net.ravendb.abstractions.exceptions.ConcurrencyException
Actual Etag.
getAdditionalData() - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Additional command data.
getAdditionalData() - Method in interface net.ravendb.abstractions.commands.ICommandData
Additional command data.
getAdditionalData() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Additional command data.
getAdditionalData() - Method in class net.ravendb.abstractions.commands.PutCommandData
Additional command data.
getAdditionalData() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Additional command data.
getAdditionalData() - Method in class net.ravendb.abstractions.data.BatchResult
Additional operation data.
getAdditionalInformation() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
Any additional information that might be required
getAdditionalQuery() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
An additional query that the matching documents need to also match to be returned.
getAdmin() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Admin operations for current database
getAdmin() - Method in class net.ravendb.client.connection.ServerClient
 
getAggregation() - Method in class net.ravendb.abstractions.data.Facet
Flags indicating type of facet aggregation.
getAggregation(FacetAggregation) - Method in class net.ravendb.abstractions.data.FacetValue
 
getAggregation() - Method in class net.ravendb.client.linq.AggregationQuery
 
getAggregationField() - Method in class net.ravendb.abstractions.data.Facet
Field on which aggregation will be performed.
getAggregationType() - Method in class net.ravendb.abstractions.data.Facet
Type of field on which aggregation will be performed.
getAggregationType() - Method in class net.ravendb.client.linq.AggregationQuery
 
getAggregrationField() - Method in class net.ravendb.client.linq.AggregationQuery
 
getAggressiveCacheDuration() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
getAllocatedDataFileSizeInBytes() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getAllPositions() - Method in class net.ravendb.abstractions.data.PatchRequest
Only valid for collections.
getAnalyzers() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field analyzer settings.
getAnalyzers() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getAnalyzersStrings() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getApiKey() - Method in class net.ravendb.abstractions.connection.OperationCredentials
 
getApiKey() - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
getApiKey() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getApiKey() - Method in class net.ravendb.client.document.DocumentStore
 
getApproximateTaskCount() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates how many tasks (approximately) are running currently in database.
getAt() - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
getAt() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
When the request completed
getAttachment(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
Use RavenFS instead.
getAttachment(String) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
getAttachmentHeadersStartingWith(String, int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
Use RavenFS instead.
getAttachmentHeadersStartingWith(String, int, int) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
getAttachments(int, Etag, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
Use RavenFS instead.
getAttachments(int, Etag, int) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
getAttributes() - Method in class net.ravendb.abstractions.data.LicensingStatus
 
getAuthenticationScheme() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getAverage() - Method in class net.ravendb.abstractions.data.FacetValue
Stores average value if FacetAggregation.Average was set.
getBackupLocation() - Method in class net.ravendb.abstractions.data.DatabaseBackupRequest
Path to directory where backup should lie (must be accessible from server).
getBackupLocation() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to directory where backup lies.
getBatchOptions() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
getBatchSize() - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Number of documents to send in each bulk insert batch.
getBelongsToAnyCollection() - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
getBoost() - Method in class net.ravendb.abstractions.data.BoostedValue
Boost factor.
getBoost() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Boost terms in query based on score.
getBoostFactor() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Boost factor when boosting based on score.
getBuildNumber() - Method in class net.ravendb.client.connection.AdminServerClient
 
getBuildNumber() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Gets the build number
getBuildNumber() - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Gets the build number
getBuildNumber() - Method in class net.ravendb.client.connection.ServerClient
 
getBuildVersion() - Method in class net.ravendb.abstractions.data.BuildNumber
 
getBulkInsertOperation(BulkInsertOptions, IDatabaseChanges) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Get the low level bulk insert operation
getBulkInsertOperation(BulkInsertOptions, IDatabaseChanges) - Method in class net.ravendb.client.connection.ServerClient
 
getBulkInsertOperation(BulkInsertOptions, IDatabaseCommands, IDatabaseChanges) - Method in class net.ravendb.client.document.BulkInsertOperation
 
getCachedJsonDocs() - Method in class net.ravendb.client.document.EntityToJson
 
getCachedRequest() - Method in class net.ravendb.client.connection.CachedRequestOp
 
getCachedRequestDetails() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getCanDelete() - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
getCanMerge() - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
getCartesian() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory
 
getChange() - Method in class net.ravendb.abstractions.data.DocumentsChanges
Type of change that occurred.
getChanges() - Method in class net.ravendb.abstractions.data.Etag
 
getChangesToSavePerShard(SaveChangesData) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
getCheckDestination() - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
getChunkedBulkInsertOptions() - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Represents options of the chunked functionality of the bulk insert operation, which allows opening new connection for each chunk by amount of documents and total size.
getClazz() - Method in class net.ravendb.client.linq.ExpressionInfo
 
getClientAliveNotificationInterval() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
getClientConfiguration() - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
getClientVisibleUrl() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getCode() - Method in enum net.ravendb.abstractions.data.IndexStats.IndexingPriority
 
getCodec() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
getCollection() - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
getCollectionName() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Document collection name.
getCommands() - Method in class net.ravendb.client.connection.AdminServerClient
 
getCommands() - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Gets DatabaseCommands
getCommands() - Method in class net.ravendb.client.document.SaveChangesData
 
getCommandsToOperateOn(ShardRequestData) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
getCompleted() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getConflictedVersionIds() - Method in exception net.ravendb.client.exceptions.ConflictException
 
getConflictListeners() - Method in class net.ravendb.client.document.DocumentSessionListeners
 
getConflicts() - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Array of conflict document Ids.
getConnectionId() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
getConnectionStringOptions() - Method in class net.ravendb.abstractions.data.ConnectionStringParser
 
getContent() - Method in class net.ravendb.abstractions.data.GetRequest
 
getContent() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
getContent() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
getContent() - Method in class net.ravendb.java.http.client.RavenGzipDecompressingEntity
 
getContentEncoding() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
getContentEncoding() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
getContentEncoding() - Method in class net.ravendb.java.http.client.RavenGzipDecompressingEntity
 
getContentLength() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
getContentLength() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
getContentLength() - Method in class net.ravendb.java.http.client.RavenGzipDecompressingEntity
 
getContentType() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
getContentType() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
getContext() - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
getConvention() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getConventions() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the conventions used by this session This instance is shared among all sessions, changes to the DocumentConvention should be done via the IDocumentStore instance, not on a single session.
getConventions() - Method in class net.ravendb.client.DocumentStoreBase
 
getConventions() - Method in interface net.ravendb.client.IDocumentSessionImpl
 
getConventions() - Method in interface net.ravendb.client.IDocumentStore
Gets the conventions.
getConventions() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Gets the conventions that should be used when index definition is created.
getConventions() - Method in class net.ravendb.client.indexes.AbstractTransformerCreationTask
 
getConventions() - Method in interface net.ravendb.client.linq.IDocumentQueryGenerator
Gets the conventions associated with this query
getConventions() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
getConventions() - Method in class net.ravendb.client.shard.ShardStrategy
 
getConversionListeners() - Method in class net.ravendb.client.document.DocumentSessionListeners
 
getCount() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
getCount() - Method in class net.ravendb.abstractions.data.FacetValue
Stores count value if FacetAggregation.Count was set.
getCount() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
getCounter() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getCountOfAttachments() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Deprecated.
Use RavenFS instead.
getCountOfAttachments() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Deprecated.
Use RavenFS instead.
getCountOfDocuments() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of documents in database.
getCountOfDocuments() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Total count of documents in database.
getCountOfIndexes() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of indexes in database.
getCountOfIndexesExcludingDisabledAndAbandoned() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of indexes in database excluding disabled and abandoned
getCountOfResultTransformers() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of transformers in database.
getCountOfStaleIndexesExcludingDisabledAndAbandoned() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of stale indexes excluding disabled and abandoned
getCreatedTimestamp() - Method in class net.ravendb.abstractions.data.IndexStats
Date of index creation.
getCredentials() - Method in class net.ravendb.abstractions.connection.WebRequestEventArgs
 
getCredentials() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getCredentials() - Method in class net.ravendb.client.connection.OperationMetadata
 
getCriteria() - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
getCurrent() - Static method in class net.ravendb.client.utils.encryptors.Encryptor
 
getCurrentCacheSize() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
The number of currently held requests in the cache
getCurrentClassLogger() - Static method in class net.ravendb.abstractions.logging.LogManager
 
getCurrentNumberOfItemsToIndexInSingleBatch() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Current value of items that will be processed by index (map) in single batch.
getCurrentNumberOfItemsToReduceInSingleBatch() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Current value of items that will be processed by index (reduce) in single batch.
getCurrentNumberOfParallelTasks() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
The concurrency level that RavenDB is currently using
getCurrentOAuthToken() - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
getCurrentPath() - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
getCurrentQueryResults() - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
getCurrentSize() - Method in class net.ravendb.client.util.SimpleCache
 
getCurrentToken() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
getCustomizedQuery() - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getCustomizeQuery() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getCustomizeQuery() - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getCustomQueryStringVariables() - Method in class net.ravendb.abstractions.data.IndexQuery
 
getCustomQueryStringVariables() - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Gets the custom query string variables.
getCutoff() - Method in class net.ravendb.abstractions.data.IndexQuery
Used to calculate index staleness.
getCutoffEtag() - Method in class net.ravendb.abstractions.data.IndexQuery
Gets or sets the cutoff etag.
getData() - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Returning the content of an attachment.
getData() - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeChunk
 
getData() - Method in class net.ravendb.client.connection.CachedRequest
 
getDataAsJson() - Method in class net.ravendb.abstractions.data.JsonDocument
Document data or projection as json.
getDatabase() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getDatabase() - Method in class net.ravendb.client.connection.CachedRequest
 
getDatabase() - Method in class net.ravendb.client.document.OpenSessionOptions
 
getDatabaseCacheSizeInMB() - Method in class net.ravendb.abstractions.data.AdminMemoryStatistics
Size of database cache in megabytes.
getDatabaseCommands() - Method in interface net.ravendb.client.connection.IRavenQueryInspector
Grant access to the database commands
getDatabaseCommands() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Grant access to the database commands
getDatabaseCommands() - Method in class net.ravendb.client.document.BulkInsertOperation
 
getDatabaseCommands() - Method in class net.ravendb.client.document.DocumentSession
Gets the database commands.
getDatabaseCommands() - Method in class net.ravendb.client.document.DocumentStore
 
getDatabaseCommands() - Method in class net.ravendb.client.document.ShardedBulkInsertOperation
 
getDatabaseCommands() - Method in interface net.ravendb.client.IDocumentStore
Gets the database commands.
getDatabaseCommands() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getDatabaseCommands() - Method in class net.ravendb.client.shard.ShardedDocumentQuery
 
getDatabaseCommands() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Gets the database commands.
getDatabaseConfiguration(String) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
getDatabaseConfiguration() - Method in class net.ravendb.client.connection.AdminServerClient
 
getDatabaseConfiguration() - Method in interface net.ravendb.client.connection.IAdminDatabaseCommands
Gets configuration for current database.
getDatabaseDocument() - Method in class net.ravendb.abstractions.data.DatabaseBackupRequest
DatabaseDocument that will be inserted with backup.
getDatabaseId() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Database identifier.
getDatabaseLocation() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to the directory of a new database.
getDatabaseName() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates what should be the name of database after restore.
getDatabaseName() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getDatabaseName(String) - Static method in class net.ravendb.client.extensions.MultiDatabase
 
getDatabaseName() - Method in interface net.ravendb.client.ITransactionalDocumentSession
 
getDatabaseName() - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
getDatabaseNames(int) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
getDatabaseNames(int, int) - Method in class net.ravendb.client.connection.AdminRequestCreator
Gets the list of databases from the server
getDatabaseNames(int) - Method in class net.ravendb.client.connection.AdminServerClient
 
getDatabaseNames(int, int) - Method in class net.ravendb.client.connection.AdminServerClient
 
getDatabaseNames(int) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Returns the names of all tenant databases on the RavenDB server
getDatabaseNames(int, int) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Returns the names of all tenant databases on the RavenDB server
getDatabaseTransactionVersionSizeInMB() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Transaction version size in megabytes for database.
getDatabaseTransactionVersionSizeInMB() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Transaction version size in megabytes for database.
getDatabaseUrl(String, String) - Static method in class net.ravendb.client.extensions.MultiDatabase
 
getDebugActions() - Method in class net.ravendb.abstractions.data.PatchResultData
Additional debugging information (if requested).
getDefault() - Static method in class net.ravendb.abstractions.json.linq.RavenJTokenComparator
 
getDefaultDatabase() - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
getDefaultDatabase() - Method in class net.ravendb.client.document.DocumentStore
 
getDefaultField() - Method in class net.ravendb.abstractions.data.IndexQuery
Default field to use when querying directly on the Lucene query
getDefaultLocale() - Static method in class net.ravendb.abstractions.data.Constants
 
getDefaultOperator() - Method in class net.ravendb.abstractions.data.IndexQuery
Changes the default operator mode we use for queries.
getDefaultQueryingConsistency() - Method in class net.ravendb.client.document.DocumentConvention
The consistency options used when querying the database by default
getDefaultSortOption(String) - Method in class net.ravendb.client.document.DocumentConvention
 
getDefaultSortOption(Class<?>) - Method in class net.ravendb.client.document.DocumentConvention
 
getDeferredCommandsCount() - Method in class net.ravendb.client.document.SaveChangesData
 
getDefinition() - Method in class net.ravendb.abstractions.data.IndexToAdd
Definition of an index
getDelayTimeInMiliSec() - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
getDelayTimeInMiliSec() - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getDeleted() - Method in class net.ravendb.abstractions.data.BatchResult
Indicates if the document was deleted (null if not DELETE operation) Value: - true - if the document was deleted - false - if it did not exist.
getDeleteListeners() - Method in class net.ravendb.client.document.DocumentSessionListeners
 
getDeleteScript() - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Script that will be evaluated for each document deleted from the index.
getDeleteScript() - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
getDescription() - Method in enum net.ravendb.abstractions.replication.ReplicationDestination.TransitiveReplicationOptions
 
getDestinations() - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
getDestinationUrl() - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
getDestionationUrl() - Method in class net.ravendb.abstractions.replication.ReplicatedEtagInfo
 
getDetails() - Method in class net.ravendb.abstractions.data.LicensingStatus
 
getDisabled() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getDisableHttpCaching() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
getDisplayName() - Method in class net.ravendb.abstractions.data.Facet
Display name of facet.
getDisplayName() - Method in class net.ravendb.client.linq.AggregationQuery
 
getDistance() - Method in class net.ravendb.abstractions.data.SuggestionQuery
String distance algorithm to use.
getDistance() - Method in class net.ravendb.abstractions.indexing.SuggestionOptions
String distance algorithm to use.
getDistanceErrorPercentage() - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
A measure of acceptable error of the shape as a fraction.
getDocsCount() - Method in class net.ravendb.abstractions.data.IndexStats
Total number of entries in this index.
getDocsWritesPerSecond() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getDocument() - Method in class net.ravendb.abstractions.commands.PutCommandData
RavenJObject representing the document.
getDocument() - Method in class net.ravendb.abstractions.data.IndexingError
 
getDocument() - Method in class net.ravendb.abstractions.data.PatchResultData
Patched document.
getDocument() - Method in class net.ravendb.abstractions.data.StreamResult
Document deserialized to T.
getDocument() - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeResult
 
getDocumentConvention() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Gets the document convention from the query session
getDocumentConvention() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Gets the document convention from the query session
getDocumentConvention() - Method in interface net.ravendb.client.IDocumentQueryBase
Gets the document convention from the query session
getDocumentEtag() - Method in class net.ravendb.abstractions.replication.ReplicatedEtagInfo
 
getDocumentId() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The document id to use as the basis for comparison
getDocumentId(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the document id.
getDocumentId(Object) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets the document id for the specified entity.
getDocumentKeyFromId(DocumentConvention, long) - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
getDocumentKeyGenerator() - Method in class net.ravendb.client.document.DocumentConvention
Gets the document key generator.
getDocumentMetadataValue(T, Reference<String>, JsonDocument) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getDocumentQueryFor(Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
getDocuments(int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves multiple documents.
getDocuments(int, int, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves multiple documents.
getDocuments(Etag, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves multiple documents.
getDocuments(Etag, int, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves multiple documents.
getDocuments(int, int) - Method in class net.ravendb.client.connection.ServerClient
 
getDocuments(int, int, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
getDocuments(Etag, int) - Method in class net.ravendb.client.connection.ServerClient
 
getDocuments(Etag, int, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
getDocumentsProcessed() - Method in class net.ravendb.client.document.Subscription.DocumentProcessedEventArgs
 
getDocumentStore() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getDocumentStore() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
The document store associated with this session
getDocumentUrl(Object) - Method in class net.ravendb.client.document.DocumentSession
Gets the document URL for the specified entity.
getDocumentUrl(Object) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Returns full document url for a given entity
getDocumentUrl(Object) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
getDomain() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getDslFacets(List<AggregationQueryDsl>) - Static method in class net.ravendb.client.linq.AggregationQueryDsl
 
getDuration() - Method in class net.ravendb.abstractions.data.FutureBatchStats
Indicates how much time it took to prepare future batch.
getDuration() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getDuration() - Method in class net.ravendb.client.document.ResponseTimeInformation.ResponseTimeItem
 
getDurationBreakdown() - Method in class net.ravendb.client.document.ResponseTimeInformation
 
getDurationMiliseconds() - Method in class net.ravendb.abstractions.data.QueryResult
The duration of actually executing the query server side -1 is returned in case the query results retrieved from cache
getDurationMiliseconds() - Method in class net.ravendb.client.RavenQueryStatistics
 
getDurationMilleseconds() - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
getDurationMilliseconds() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getDurationMilliseconds() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
How long this request took
getDynamicIndexName(Class<?>) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
getDynamicTagName(Object) - Method in class net.ravendb.client.document.DocumentConvention
 
getElementType() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getElementType() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Returns element type
getElementType() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getEntities() - Method in class net.ravendb.client.document.SaveChangesData
 
getEntitySerializer() - Method in class net.ravendb.querydsl.RavenDefaultConfiguration
 
getEntityToJson() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getEntityType() - Method in class net.ravendb.client.shard.ShardRequestData
 
getError() - Method in class net.ravendb.abstractions.data.IndexingError
 
getError() - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
getError() - Method in class net.ravendb.client.connection.ServerClient.ErrorObjectProtoTransformer
 
getError() - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
getError() - Method in class net.ravendb.client.document.DocumentSubscriptions.ErrorAndUrl
 
getError() - Method in class net.ravendb.client.exceptions.ServerRequestError
 
getErrors() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Array of indexing errors that occurred in database.
getEsentStats() - Method in class net.ravendb.abstractions.data.StorageStats
 
getEtag() - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Current document etag, used for concurrency checks (null to skip check)
getEtag() - Method in interface net.ravendb.abstractions.commands.ICommandData
Current document etag, used for concurrency checks (null to skip check).
getEtag() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Current document etag, used for concurrency checks (null to skip check)
getEtag() - Method in class net.ravendb.abstractions.commands.PutCommandData
Current document etag, used for concurrency checks (null to skip check).
getEtag() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Current document etag, used for concurrency checks (null to skip check).
getEtag() - Method in exception net.ravendb.abstractions.connection.ErrorResponseException
 
getEtag() - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Current attachment etag, used for concurrency checks (null to skip check).
getEtag() - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
Current attachment etag.
getEtag() - Method in class net.ravendb.abstractions.data.BatchResult
Etag generated by the operation (null if not applicable).
getEtag() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Document etag.
getEtag() - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Current document etag, used for concurrency checks (null to skip check)
getEtag() - Method in class net.ravendb.abstractions.data.IndexChangeNotification
Gets etag
getEtag() - Method in class net.ravendb.abstractions.data.JsonDocument
Current document etag.
getEtag() - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Current document etag.
getEtag() - Method in class net.ravendb.abstractions.data.PutResult
Etag of the document after PUT operation.
getEtag() - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Current conflict document Etag.
getEtag() - Method in class net.ravendb.abstractions.data.StreamResult
Document etag.
getEtag() - Method in class net.ravendb.client.document.DocumentMetadata
 
getEtag() - Method in exception net.ravendb.client.exceptions.ConflictException
 
getEtagFor(T) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the ETag for the specified entity.
getEtagFor(T) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets the ETag for the specified entity.
getEtagHeader(HttpJsonRequest) - Static method in class net.ravendb.client.connection.HttpExtensions
 
getEtagHeader(HttpResponse) - Static method in class net.ravendb.client.connection.HttpExtensions
 
getEtagHeader(GetResponse) - Static method in class net.ravendb.client.connection.HttpExtensions
 
getException() - Method in class net.ravendb.abstractions.basic.ExceptionEventArgs
 
getException() - Method in class net.ravendb.abstractions.data.LogItem
 
getExpectedEtag() - Method in exception net.ravendb.abstractions.exceptions.ConcurrencyException
Expected Etag.
getExpression() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Expression created via DSL
getExpression() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getExternalState() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getExternalState() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Allow extensions to provide additional state per session
getFacets() - Method in class net.ravendb.abstractions.data.FacetQuery
List of facets (mutually exclusive with FacetSetupDoc).
getFacets() - Method in class net.ravendb.abstractions.data.FacetSetup
List of facets.
getFacets(String, IndexQuery, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Using the given Index, calculate the facets as per the specified doc with the given start and pageSize
getFacets(String, IndexQuery, String, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Using the given Index, calculate the facets as per the specified doc with the given start and pageSize
getFacets(String, IndexQuery, String, int, Integer) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Using the given Index, calculate the facets as per the specified doc with the given start and pageSize
getFacets(String, IndexQuery, List<Facet>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Using the given Index, calculate the facets as per the specified doc with the given start and pageSize
getFacets(String, IndexQuery, List<Facet>, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Using the given Index, calculate the facets as per the specified doc with the given start and pageSize
getFacets(String, IndexQuery, List<Facet>, int, Integer) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Using the given Index, calculate the facets as per the specified doc with the given start and pageSize
getFacets(String, int, Integer) - Method in interface net.ravendb.client.connection.IRavenQueryInspector
Get the facets as per the specified facet document with the given start and pageSize
getFacets(List<Facet>, int, Integer) - Method in interface net.ravendb.client.connection.IRavenQueryInspector
Get the facet results as per the specified facets with the given start and pageSize
getFacets(String, IndexQuery, String) - Method in class net.ravendb.client.connection.ServerClient
 
getFacets(String, IndexQuery, String, int) - Method in class net.ravendb.client.connection.ServerClient
 
getFacets(String, IndexQuery, String, int, Integer) - Method in class net.ravendb.client.connection.ServerClient
 
getFacets(String, IndexQuery, List<Facet>) - Method in class net.ravendb.client.connection.ServerClient
 
getFacets(String, IndexQuery, List<Facet>, int) - Method in class net.ravendb.client.connection.ServerClient
 
getFacets(String, IndexQuery, List<Facet>, int, Integer) - Method in class net.ravendb.client.connection.ServerClient
 
getFacets(String, int, Integer) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getFacets(List<Facet>, int, Integer) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getFacets(String, int, Integer) - Method in interface net.ravendb.client.IDocumentQuery
Get the facets as per the specified doc with the given start and pageSize
getFacets(List<Facet>, int, Integer) - Method in interface net.ravendb.client.IDocumentQuery
Get the facets as per the specified facets with the given start and pageSize
getFacets(List<AggregationQuery>) - Static method in class net.ravendb.client.linq.AggregationQuery
 
getFacets(String, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getFacets(List<Facet>, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getFacets(String, int, Integer) - Method in class net.ravendb.client.shard.ShardedRavenQueryInspector
 
getFacets(List<Facet>, int, Integer) - Method in class net.ravendb.client.shard.ShardedRavenQueryInspector
 
getFacetSetupDoc() - Method in class net.ravendb.abstractions.data.FacetQuery
Id of a facet setup document that can be found in database containing facets (mutually exclusive with Facets).
getFailing() - Method in class net.ravendb.client.connection.ReplicationInformer.FailoverStatusChangedEventArgs
 
getFailoverBehavior() - Method in class net.ravendb.abstractions.replication.ReplicationClientConfiguration
 
getFailoverBehavior() - Method in class net.ravendb.client.document.Convention
How should we behave in a replicated environment when we can't reach the primary node and need to failover to secondary node(s).
getFailoverBehaviorWithoutFlags() - Method in class net.ravendb.client.document.Convention
 
getFailoverServers() - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
getFailoverServers() - Method in interface net.ravendb.client.connection.IDocumentStoreReplicationInformer
 
getFailoverServers() - Method in class net.ravendb.client.connection.ReplicationInformer
 
getFailoverServers() - Method in class net.ravendb.client.DocumentStoreBase
 
getFailureCount() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getFailureCount(String) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
Get the current failure count for the url
getFailureCount(String) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getFailureCountInternal() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getFailureLastCheck(String) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
Get failure last check time for the url
getFailureLastCheck(String) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getField() - Method in class net.ravendb.abstractions.data.HighlightedField
 
getField() - Method in class net.ravendb.abstractions.data.SortedField
Index field name for sorting.
getField() - Method in class net.ravendb.abstractions.data.SuggestionQuery
Field to be used in conjunction with the index.
getFieldName() - Method in class net.ravendb.abstractions.data.DocumentsChanges
Name of field on which the change occurred.
getFieldName() - Method in class net.ravendb.client.FieldHighlightings
The field name.
getFieldName() - Method in class net.ravendb.client.WhereParams
 
getFieldNewType() - Method in class net.ravendb.abstractions.data.DocumentsChanges
Current field type.
getFieldNewValue() - Method in class net.ravendb.abstractions.data.DocumentsChanges
Current field value.
getFieldOldType() - Method in class net.ravendb.abstractions.data.DocumentsChanges
Previous field type.
getFieldOldValue() - Method in class net.ravendb.abstractions.data.DocumentsChanges
Previous field value.
getFields() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The fields to compare
getFields() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
List of queryable fields in index.
getFieldsToFetch() - Method in class net.ravendb.abstractions.data.IndexQuery
Array of fields that will be fetched.
getFieldsToFetch() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getFieldsToFetch() - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getFieldsToFetch() - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
getFieldsToRename() - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getFieldsToRename() - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
getFieldTypeForIdentifier() - Method in class net.ravendb.client.WhereParams
 
getFiftennMinuteRate() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
getFileCount() - Method in class net.ravendb.abstractions.data.FileSystemStats
 
getFileETag() - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
getFileName() - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
getFileNames(String) - Method in interface net.ravendb.client.document.dtc.ITransactionRecoveryStorageContext
 
getFileNames(String) - Method in class net.ravendb.client.document.dtc.VolatileOnlyTransactionRecoveryStorage
 
getFilePath() - Method in class net.ravendb.abstractions.smuggler.OperationState
 
getFilesWritesPerSecond() - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
getFindFullDocumentKeyFromNonStringIdentifier() - Method in class net.ravendb.client.document.DocumentConvention
Gets the function to find the full document key based on the type of a document and the value type identifier (just the numeric part of the id).
getFindIdentityProperty() - Method in class net.ravendb.client.document.Convention
Gets the function to find the identity property.
getFindIdentityPropertyNameFromEntityName() - Method in class net.ravendb.client.document.DocumentConvention
Get the function to get the identity property name from the entity name
getFindIdValuePartForValueTypeConversion() - Method in class net.ravendb.client.document.DocumentConvention
When RavenDB needs to convert between a string id to a value type like int or uuid, it calls this to perform the actual work
getFindJavaClass() - Method in class net.ravendb.client.document.DocumentConvention
Gets the function to find the java class of a document.
getFindJavaClassName() - Method in class net.ravendb.client.document.DocumentConvention
Gets the function to find the java class name from a java class
getFindPropertyNameForDynamicIndex() - Method in class net.ravendb.client.document.DocumentConvention
Gets the function to find the indexed property name given the indexed document type, the index name, the current path and the property path.
getFindPropertyNameForIndex() - Method in class net.ravendb.client.document.DocumentConvention
Gets the function to find the indexed property name given the indexed document type, the index name, the current path and the property path.
getFindTypeTagName() - Method in class net.ravendb.client.document.DocumentConvention
Gets the function to find the type tag.
getFirstFailureInCycleTimestamp() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getFiveMinuteRate() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
getFlags() - Method in class net.ravendb.abstractions.data.VoronActiveTransaction
 
getForDatabase(String) - Method in class net.ravendb.abstractions.data.FailoverServers
 
getForDefaultDatabase() - Method in class net.ravendb.abstractions.data.FailoverServers
 
getForEntityName() - Method in class net.ravendb.abstractions.data.IndexStats
List of all entity names (collections) for which this index is working.
getFragmentCount() - Method in class net.ravendb.abstractions.data.HighlightedField
 
getFragmentLength() - Method in class net.ravendb.abstractions.data.HighlightedField
 
getFragments(String) - Method in class net.ravendb.client.FieldHighlightings
Returns the list of document's field highlighting fragments.
getFragmentsField() - Method in class net.ravendb.abstractions.data.HighlightedField
 
getFreePagesOverhead() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getFullNameWithoutVersionInformation(Class<?>) - Static method in class net.ravendb.client.document.ReflectionUtil
Note: we can't fetch generic types information in Java - hence we are limited to simple getName on class object
getGauges() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getGenerateEntityIdOnTheClient() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getGeography() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory
 
getGlobalAdmin() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Admin operations performed against system database, like create/delete database
getGlobalAdmin() - Method in class net.ravendb.client.connection.ServerClient
 
getHandleForbiddenResponse() - Method in class net.ravendb.client.document.Convention
Handles forbidden responses
getHandleUnauthorizedResponse() - Method in class net.ravendb.client.document.Convention
Handles unauthenticated responses, usually by authenticating against the oauth server
getHeaders() - Method in class net.ravendb.abstractions.data.GetRequest
Request headers.
getHeaders() - Method in class net.ravendb.abstractions.data.GetResponse
Response headers.
getHeaders() - Method in class net.ravendb.client.connection.CachedRequest
 
getHighlightedFields() - Method in class net.ravendb.abstractions.data.IndexQuery
Array of fields containing highlighting information.
getHighlighterKeyName() - Method in class net.ravendb.abstractions.data.IndexQuery
Gets highligter key name.
getHighlighterPostTags() - Method in class net.ravendb.abstractions.data.IndexQuery
Array of highlighter post tags that will be applied to highlighting results.
getHighlighterPreTags() - Method in class net.ravendb.abstractions.data.IndexQuery
Array of highlighter pre tags that will be applied to highlighting results.
getHighlightings() - Method in class net.ravendb.abstractions.data.QueryResult
Highlighter results (if requested).
getHighlightings() - Method in class net.ravendb.client.FieldHighlightings
 
getHiLoDocumentKey() - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
getHits() - Method in class net.ravendb.abstractions.data.FacetValue
Number of terms that are covered by this facet.
getHolder(String) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getHttpClient() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
getHttpResult() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
The HTTP result for this request
getHumane() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getId() - Method in class net.ravendb.abstractions.data.DatabaseDocument
The ID of a database.
getId() - Method in class net.ravendb.abstractions.data.DataSubscriptionChangeNotification
Subscription identifier for which a notification was created
getId() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Identifier of document for which notification was created.
getId() - Method in class net.ravendb.abstractions.data.FacetSetup
Id of a facet setup document.
getId() - Method in class net.ravendb.abstractions.data.IndexingError
 
getId() - Method in class net.ravendb.abstractions.data.IndexStats
Index identifier.
getId() - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Identifier of a document/attachment on which replication conflict occurred.
getId() - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Identifier for ScriptedIndexResults document.
getId() - Method in class net.ravendb.abstractions.data.VoronActiveTransaction
 
getId() - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
getId() - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
getId(Object) - Method in class net.ravendb.client.document.BulkInsertOperation
 
getId() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getIdentifier() - Method in class net.ravendb.client.document.DocumentStore
 
getIdentifier() - Method in interface net.ravendb.client.IDocumentStore
Gets the identifier
getIdentifier() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
getIdentityPartsSeparator() - Method in class net.ravendb.client.document.DocumentConvention
Gets the identity parts separator used by the HiLo generators
getIdentityProperty(Class<?>) - Method in class net.ravendb.client.document.Convention
Gets the identity property.
getIdentityTypeConvertors() - Method in class net.ravendb.client.document.DocumentConvention
A list of type converters that can be used to translate the document key (string) to whatever type it is that is used on the entity, if the type isn't already a string
getIdsThatNeedLoading(Class<T>, String[], String[], String) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
getIgnoredClient() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getIncludeRemainingTerms() - Method in class net.ravendb.abstractions.data.Facet
Indicates if remaining terms should be included in results.
getIncludes() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Array of paths under which document Ids can be found.
getIncludes() - Method in class net.ravendb.abstractions.data.MultiLoadResult
Included documents.
getIncludes() - Method in class net.ravendb.abstractions.data.QueryResult
Gets the document included in the result.
getIndex() - Method in class net.ravendb.abstractions.data.IndexingError
 
getIndex() - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
getIndex(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves an index definition from a database.
getIndex(String) - Method in class net.ravendb.client.connection.ServerClient
 
getIndexAndTransformerReplicationMode() - Method in class net.ravendb.client.document.DocumentConvention
 
getIndexDefinitionProperty() - Method in exception net.ravendb.abstractions.exceptions.IndexCompilationException
Indicates which property caused error (Maps, Reduce).
getIndexDefinitionProperty() - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
getIndexedPerSecond() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getIndexes() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Statistics for each index in database.
getIndexes() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field indexing settings.
getIndexes(int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves multiple index definitions from a database
getIndexes(int, int) - Method in class net.ravendb.client.connection.ServerClient
 
getIndexes() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getIndexesLocation() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to directory where indexes lies (if null, then default location will be assumed).
getIndexesStrings() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getIndexesToAdd() - Method in class net.ravendb.abstractions.data.SideBySideIndexes
 
getIndexEtag() - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
getIndexEtag() - Method in class net.ravendb.abstractions.data.QueryResult
The last etag indexed by the index.
getIndexEtag() - Method in class net.ravendb.client.RavenQueryStatistics
 
getIndexHash() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Provide a cached version of the index hash code, which is used when generating the index etag.
getIndexId() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index identifier (internal).
getIndexId() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
Transformer identifier (internal).
getIndexingAttempts() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many times database tried to index documents (map) using this index.
getIndexingErrors() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many indexing attempts failed.
getIndexingLag() - Method in class net.ravendb.abstractions.data.IndexStats
Shows the difference between last document etag available in database and last indexed etag.
getIndexingStatus() - Method in class net.ravendb.client.connection.AdminServerClient
 
getIndexingStatus() - Method in interface net.ravendb.client.connection.IAdminDatabaseCommands
Get the indexing status
getIndexingSuccesses() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many indexing attempts succeeded.
getIndexMergeSuggestions() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves all suggestions for an index merging
getIndexMergeSuggestions() - Method in class net.ravendb.client.connection.ServerClient
 
getIndexName() - Method in class net.ravendb.abstractions.data.FacetQuery
Index name to run facet query on.
getIndexName() - Method in class net.ravendb.abstractions.data.IndexingError
 
getIndexName() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The name of the index to use for this operation
getIndexName() - Method in class net.ravendb.abstractions.data.QueryResult
The index used to answer this query
getIndexName() - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
getIndexName() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Generates index name from type name replacing all _ with / e.g.
getIndexName() - Method in class net.ravendb.client.indexes.RavenDocumentsByEntityName
 
getIndexName() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getIndexName() - Method in class net.ravendb.client.linq.RavenQueryProvider
Gets the name of the index.
getIndexName() - Method in class net.ravendb.client.RavenQueryStatistics
 
getIndexName() - Method in class net.ravendb.client.shard.ShardRequestData
 
getIndexNames(int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves multiple index names from a database.
getIndexNames(int, int) - Method in class net.ravendb.client.connection.ServerClient
 
getIndexQueried() - Method in interface net.ravendb.client.connection.IRavenQueryInspector
Get the name of the index being queried
getIndexQueried() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Get the name of the index being queried
getIndexQueried() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Get the name of the index being queried
getIndexQueried() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getIndexQuery() - Method in interface net.ravendb.client.connection.IRavenQueryInspector
Get the index query for this query
getIndexQuery() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getIndexQuery() - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
getIndexQuery() - Method in interface net.ravendb.client.IDocumentQuery
Create the index query object for this query
getIndexQuery() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getIndexQueryUrl(String, String, String) - Method in class net.ravendb.abstractions.data.IndexQuery
 
getIndexQueryUrl(String, String, String, boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
 
getIndexQueryUrl(String, String, String, boolean, boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Gets the index query URL.
getIndexScript() - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Script that will be evaluated for each indexed document.
getIndexScript() - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
getIndexStateEtag() - Method in class net.ravendb.abstractions.data.FacetResults
 
getIndexStorageHumaneSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size of a index storage in a more human readable format.
getIndexStorageSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size of a index storage in bytes.
getIndexTimestamp() - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
getIndexTimestamp() - Method in class net.ravendb.abstractions.data.QueryResult
The last time the index was updated.
getIndexTimestamp() - Method in class net.ravendb.client.RavenQueryStatistics
 
getIndexToReplace() - Method in class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
getInMemoryIndexingQueueSize() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates how many elements are currently kept in queue for all indexing prefetchers available.
getInner() - Method in exception net.ravendb.abstractions.exceptions.AggregateException
 
getInnerClass() - Method in class net.ravendb.abstractions.data.EnumSet
 
getInputCount() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getIs64Bit() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates if process is 64-bit
getIsOnRam() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates if index is in-memory only.
getItem1() - Method in class net.ravendb.abstractions.basic.Tuple
 
getItem2() - Method in class net.ravendb.abstractions.basic.Tuple
 
getItemsCount() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getItemType() - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Type of conflict that occurred (None, DocumentReplicationConflict, AttachmentReplicationConflict).
getIV() - Method in class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
getIV() - Method in interface net.ravendb.client.utils.encryptors.ISymmetricalEncryptor
 
getJavaClass(String, RavenJObject, RavenJObject) - Method in class net.ravendb.client.document.DocumentConvention
Get the java class (if exists) from the document
getJavaClassName(Class<?>) - Method in class net.ravendb.client.document.DocumentConvention
Get the java class name to be stored in the entity metadata
getJournalsLocation() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to directory where journals lies (if null, then default location will be assumed).
getJsonContractResolver() - Method in class net.ravendb.client.document.DocumentConvention
 
getJsonDocument(String) - Method in class net.ravendb.client.document.DocumentSession
Get the json document by key from the store
getJsonDocument(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Get the json document by key from the store
getJsonDocument(String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
getJsonRequestFactory() - Method in class net.ravendb.client.connection.ServerClient
 
getJsonRequestFactory() - Method in class net.ravendb.client.document.DocumentStore
 
getJsonRequestFactory() - Method in interface net.ravendb.client.IDocumentStore
Get the HttpJsonRequestFactory for this store
getJsonRequestFactory() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
getKey() - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Key of a document to delete.
getKey() - Method in interface net.ravendb.abstractions.commands.ICommandData
Key of a document.
getKey() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Key of a document to patch.
getKey() - Method in class net.ravendb.abstractions.commands.PutCommandData
Key of a document.
getKey() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Key of a document to patch.
getKey() - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Key of an attachment.
getKey() - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
Key of an attachment.
getKey() - Method in class net.ravendb.abstractions.data.BatchResult
Key of a document.
getKey() - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Key of a document.
getKey() - Method in class net.ravendb.abstractions.data.JsonDocument
Key for the document
getKey() - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Key for the document
getKey() - Method in class net.ravendb.abstractions.data.PutResult
Key of the document that was PUT.
getKey() - Method in class net.ravendb.abstractions.data.StreamResult
Document key.
getKey() - Method in class net.ravendb.client.document.DocumentMetadata
 
getKey() - Method in class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
getKey() - Method in interface net.ravendb.client.utils.encryptors.ISymmetricalEncryptor
 
getKeys() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
getKeys() - Method in class net.ravendb.client.shard.ShardRequestData
 
getKeySize() - Method in class net.ravendb.client.utils.encryptors.FipsSymmetricalEncryptor
 
getKeySize() - Method in interface net.ravendb.client.utils.encryptors.ISymmetricalEncryptor
 
getKeyStartsWith() - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
getLastActivity() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Time of last activity on this database.
getLastAttachmentDeleteEtag() - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
getLastAttachmentEtag() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Deprecated.
Use RavenFS instead.
getLastAttachmentEtag() - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
getLastCheck() - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
getLastDocDeleteEtag() - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
getLastDocEtag() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Last document etag in database.
getLastDocsEtag() - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
getLastEqualityTerm() - Method in interface net.ravendb.client.connection.IRavenQueryInspector
The last term that we asked the query to use equals on
getLastEqualityTerm() - Method in class net.ravendb.client.document.AbstractDocumentQuery
The last term that we asked the query to use equals on
getLastEqualityTerm() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
The last term that we asked the query to use equals on
getLastEqualityTerm() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getLastError() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastEtagCheckedForReplication() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastEtagHolder() - Method in class net.ravendb.client.DocumentStoreBase
 
getLastFailureTimestamp() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastHeartbeatReceived() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastIndexedEtag() - Method in class net.ravendb.abstractions.data.IndexStats
This value represents etag of last document indexed (using map) by this index.
getLastIndexedTimestamp() - Method in class net.ravendb.abstractions.data.IndexStats
Time of last indexing for this index.
getLastIndexingTime() - Method in class net.ravendb.abstractions.data.IndexStats
Time of last indexing (map or reduce) for this index.
getLastModified() - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Last modified date for the document
getLastModified() - Method in class net.ravendb.abstractions.data.JsonDocument
Last modified date for the document
getLastModified() - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Last modified date for the document
getLastProcessedEtag() - Method in class net.ravendb.client.document.Subscription.LastProcessedEtagEventArgs
 
getLastQueryTime() - Method in class net.ravendb.abstractions.data.QueryResult
The timestamp of the last time the index was queried
getLastQueryTime() - Method in class net.ravendb.client.RavenQueryStatistics
 
getLastQueryTimestamp() - Method in class net.ravendb.abstractions.data.IndexStats
Time of last query for this index.
getLastReducedEtag() - Method in class net.ravendb.abstractions.data.IndexStats
This value represents etag of last document indexed (using reduce) by this index.
getLastReducedTimestamp() - Method in class net.ravendb.abstractions.data.IndexStats
Time of last reduce for this index.
getLastReplicatedAttachmentEtag() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastReplicatedEtag() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastReplicatedLastModified() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastStats() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastSubscriberException() - Method in class net.ravendb.client.document.Subscription
The last exception thrown by one of subscribers.
getLastSuccessTimestamp() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getLastWrittenEtag() - Method in class net.ravendb.client.DocumentStoreBase
Gets the etag of the last document written by any session belonging to this document store
getLastWrittenEtag() - Method in interface net.ravendb.client.IDocumentStore
Gets the etag of the last document written by any session belonging to this document store
getLastWrittenEtag() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Gets the etag of the last document written by any session belonging to this
getLastWrittenEtag() - Method in class net.ravendb.client.util.GlobalLastEtagHolder
 
getLastWrittenEtag() - Method in interface net.ravendb.client.util.ILastEtagHolder
 
getLevel() - Method in class net.ravendb.abstractions.data.LogItem
 
getLicenseStatus() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Gets the license status
getLicenseStatus() - Method in class net.ravendb.client.connection.ServerClient
 
getListeners() - Method in class net.ravendb.client.document.EntityToJson
 
getListeners() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getListeners() - Method in class net.ravendb.client.DocumentStoreBase
 
getListeners() - Method in interface net.ravendb.client.IDocumentStore
 
getLoadDocumentCount() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getLoadDocumentDurationMs() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getLoadedDatabases() - Method in class net.ravendb.abstractions.data.AdminStatistics
List of loaded databases with their statistics.
getLoadedFileSystems() - Method in class net.ravendb.abstractions.data.AdminStatistics
List of loaded filesystems with their statistics.
getLocalChanges() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
getLockMode() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates current lock mode: - Unlock - all index definition changes acceptable - LockedIgnore - all index definition changes will be ignored, only log entry will be created - LockedError - all index definition changes will raise exception
getLockMode() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index lock mode: - Unlock - all index definition changes acceptable - LockedIgnore - all index definition changes will be ignored, only log entry will be created - LockedError - all index definition changes will raise exception
getLockMode() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
 
getLockMode() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getLogger(String) - Method in interface net.ravendb.abstractions.logging.ILogManager
 
getLogger(String) - Static method in class net.ravendb.abstractions.logging.LogManager
 
getLogger(String) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingProvider
 
getLoggerName() - Method in class net.ravendb.abstractions.data.LogItem
 
getLogs(boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Gets the Logs
getLogs(boolean) - Method in class net.ravendb.client.connection.ServerClient
 
getManagedMemorySizeInMB() - Method in class net.ravendb.abstractions.data.AdminMemoryStatistics
Size (in megabytes) of managed memory held by server.
getMap() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
getMap() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getMapGroupFields() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Values for the the mapping group fields to use as the basis for comparison
getMaps() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
getMax() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getMax() - Method in class net.ravendb.abstractions.data.FacetValue
Stores maximum value if FacetAggregation.Max was set.
getMaxChunkVolumeInBytes() - Method in class net.ravendb.abstractions.data.ChunkedBulkInsertOptions
Max volume of all the documents could be sent in each bulk insert sub operation (Default: 8MB)
getMaxDocCount() - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
getMaxDocumentsPerChunk() - Method in class net.ravendb.abstractions.data.ChunkedBulkInsertOptions
Number of documents to send in each bulk insert sub operation (Default: 2048)
getMaxFromDocument(JsonDocument, long) - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
getMaximumDocumentFrequency() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words which occur in more than this many documents.
getMaximumDocumentFrequencyPercentage() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words which occur in more than this percentage of documents.
getMaximumNumberOfTokensParsed() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
getMaximumQueryTerms() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
A Query with no more than this many terms.
getMaximumWordLength() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words greater than this length or if 0 then this has no effect.
getMaxIndexOutputsPerDocument() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index specific setting that limits the number of map outputs that an index is allowed to create for a one source document.
getMaxIndexOutputsPerDocument() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Index specific setting that limits the number of map outputs that an index is allowed to create for a one source document.
getMaxIndexOutputsPerDocument() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getMaxLengthOfQueryUsingGetUrl() - Method in class net.ravendb.client.document.DocumentConvention
 
getMaxNumberOfAttachmentsToExport() - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
getMaxNumberOfCachedRequests() - Method in class net.ravendb.client.document.DocumentStore
 
getMaxNumberOfDocumentsToExport() - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
getMaxNumberOfRequestsPerSession() - Method in class net.ravendb.client.document.DocumentConvention
Gets the default max number of requests per session.
getMaxNumberOfRequestsPerSession() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the max number of requests per session.
getMaxNumberOfRequestsPerSession() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets the max number of requests per session.
getMaxOpsPerSec() - Method in class net.ravendb.abstractions.data.BulkOperationOptions
Limits the amount of base operation per second allowed.
getMaxResults() - Method in class net.ravendb.abstractions.data.Facet
Maximum number of results to return.
getMaxSize() - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
getMaxSuggestions() - Method in class net.ravendb.abstractions.data.SuggestionQuery
Maximum number of suggestions to return.
getMaxTreeLevel() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getMaxX() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getMaxX() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
getMaxY() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getMaxY() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
getMaybeProperty() - Method in class net.ravendb.client.linq.ExpressionInfo
 
getMaybeProperty() - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
getMean() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getMeanRate() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
getMember(Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
Gets member info for the specified expression and the path to that expression
getMemberExpression(Expression<?>) - Method in class net.ravendb.client.linq.LinqPathProvider
 
getMemberQueryPath(Expression<?>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getMemberQueryPathForOrderBy(Expression<?>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getMemberQueryPaths(Expression<?>...) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getMemberQueryPathsForOrderBy(Expression<?>...) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
getMemberType() - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
getMemory() - Method in class net.ravendb.abstractions.data.AdminStatistics
Current memory statistics.
getMergedArray() - Method in class net.ravendb.abstractions.json.ConflictsResolver.ArrayWithWarning
 
getMergedIndex() - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
getMergeQueryResults() - Method in class net.ravendb.client.shard.ShardStrategy
Merge the query results from all the shards into a single query results object
getMessage() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Notification message.
getMessage() - Method in class net.ravendb.abstractions.data.LicensingStatus
 
getMessage() - Method in class net.ravendb.abstractions.data.LogItem
 
getMessage() - Method in class net.ravendb.client.connection.ServerClient.ErrorObjectProtoTransformer
 
getMessage() - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
getMetadata() - Method in class net.ravendb.abstractions.commands.DeleteCommandData
RavenJObject representing document's metadata.
getMetadata() - Method in interface net.ravendb.abstractions.commands.ICommandData
RavenJObject representing document's metadata.
getMetadata() - Method in class net.ravendb.abstractions.commands.PatchCommandData
RavenJObject representing document's metadata.
getMetadata() - Method in class net.ravendb.abstractions.commands.PutCommandData
RavenJObject representing document's metadata.
getMetadata() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
RavenJObject representing document's metadata.
getMetadata() - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
RavenJObject representing attachment's metadata.
getMetadata() - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
RavenJObject representing attachment's metadata.
getMetadata() - Method in class net.ravendb.abstractions.data.BatchResult
Updated metadata of a document.
getMetadata() - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
RavenJObject representing document's metadata.
getMetadata() - Method in class net.ravendb.abstractions.data.JsonDocument
Metadata for the document
getMetadata() - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Metadata for the document
getMetadata() - Method in class net.ravendb.abstractions.data.StreamResult
Document metadata.
getMetadata() - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeResult
 
getMetadata() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getMetadata() - Method in class net.ravendb.client.document.DocumentMetadata
 
getMetadataFor(T) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the metadata for the specified entity.
getMetadataFor(T) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets the metadata for the specified entity.
getMethod() - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Returns operation method.
getMethod() - Method in interface net.ravendb.abstractions.commands.ICommandData
Returns operation method.
getMethod() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Returns operation method.
getMethod() - Method in class net.ravendb.abstractions.commands.PutCommandData
Returns operation method.
getMethod() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Returns operation method.
getMethod() - Method in class net.ravendb.abstractions.data.BatchResult
Method used by the operation (PUT,DELETE,PATCH).
getMethod() - Method in class net.ravendb.abstractions.data.GetRequest
 
getMethod() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getMethod() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getMethod() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
The request method
getMethod() - Method in class net.ravendb.java.http.client.HttpEval
 
getMethod() - Method in class net.ravendb.java.http.client.HttpReset
 
getMetrics() - Method in class net.ravendb.abstractions.data.FileSystemStats
 
getMetrics() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Database metrics.
getMetricType() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getMetricType() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
getMin() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getMin() - Method in class net.ravendb.abstractions.data.FacetValue
Stores minimum value if FacetAggregation.Min was set.
getMinimalQueryString() - Method in class net.ravendb.abstractions.data.IndexQuery
 
getMinimumDocumentFrequency() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words which do not occur in at least this many documents.
getMinimumEtagBeforeReplace() - Method in class net.ravendb.abstractions.data.SideBySideIndexes
 
getMinimumEtagBeforeReplace() - Method in class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
getMinimumTermFrequency() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore terms with less than this frequency in the source doc.
getMinimumWordLength() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words less than this length or if 0 then this has no effect.
getMinX() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getMinX() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
getMinY() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getMinY() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
getMissingDictionary() - Method in class net.ravendb.client.document.EntityToJson
 
getMode() - Method in class net.ravendb.abstractions.data.Facet
Mode of a facet (Default, Ranges).
getModifyDocumentId() - Method in class net.ravendb.client.shard.ShardStrategy
 
getMostRecentAttachmentEtag() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
Deprecated.
getMostRecentDocumentEtag() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
 
getMultiFacets(FacetQuery[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a multiple faceted queries in a single request and calculates the facet results for each of them
getMultiFacets(FacetQuery[]) - Method in class net.ravendb.client.connection.ServerClient
 
getName() - Method in class net.ravendb.abstractions.data.Facet
Name of facet.
getName() - Method in class net.ravendb.abstractions.data.FileSystemStats
 
getName() - Method in class net.ravendb.abstractions.data.IndexChangeNotification
Name of index for which notification was created
getName() - Method in class net.ravendb.abstractions.data.IndexStats
Index name.
getName() - Method in class net.ravendb.abstractions.data.IndexToAdd
The name of an index that will be added
getName() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Name of database.
getName() - Method in class net.ravendb.abstractions.data.PatchRequest
Property/field name to patch.
getName() - Method in class net.ravendb.abstractions.data.TransformerChangeNotification
Name of transformer for which notification was created
getName() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
This is the means by which the outside world refers to this index definition
getName() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
Transformer name.
getName() - Method in class net.ravendb.client.linq.AggregationQuery
 
getNested() - Method in class net.ravendb.abstractions.data.PatchRequest
Gets the nested operations to perform.
getNewField() - Method in class net.ravendb.client.linq.RenamedField
 
getNextPageStart() - Method in class net.ravendb.client.RavenPagingInformation
 
getNextWriteTransactionId() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getNonAuthoritativeInformation() - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Indicates whether this document is non authoritative (modified by uncommitted transaction).
getNonAuthoritativeInformation() - Method in class net.ravendb.abstractions.data.JsonDocument
Indicates whether this document is non authoritative (modified by uncommitted transaction).
getNonAuthoritativeInformation() - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Indicates whether this document is non authoritative (modified by uncommitted transaction).
getNonAuthoritativeInformationTimeout() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the timeout to wait for authoritative information if encountered non authoritative document.
getNonAuthoritativeInformationTimeout() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets the timeout to wait for authoritative information if encountered non authoritative document.
getNull() - Static method in class net.ravendb.abstractions.json.linq.RavenJValue
 
getNumberOfEntitiesInUnitOfWork() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the number of entities held in memory to manage Unit of Work
getNumberOfExportedAttachments() - Method in class net.ravendb.abstractions.smuggler.OperationState
 
getNumberOfExportedDocuments() - Method in class net.ravendb.abstractions.smuggler.OperationState
 
getNumberOfReadBytes() - Method in class net.ravendb.abstractions.connection.CountingStream
 
getNumberOfRequests() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
getNumberOfRequests() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets the number of requests for this session If the NumberOfRequests rise above MaxNumberOfRequestsPerSession, an exception will be thrown.
getNumOfCachedRequests() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
getNumOfCacheResets() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
getOnBulkInsertChangeNotification() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOnDataSubscriptionNotification() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOnDocumentChangeNotification() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOneMinuteRate() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
getOnError() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOnIndexChangeNotification() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOnReplicationConflictNotification() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOnTransformerChangeNotification() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
getOperation() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getOperationId() - Method in class net.ravendb.abstractions.data.BulkInsertChangeNotification
BulkInsert operation Id.
getOperationId() - Method in class net.ravendb.client.document.BulkInsertOperation
 
getOperationId() - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
getOperationId() - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
 
getOperationId() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
getOperationsHeaders() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Gets the operations headers
getOperationsHeaders() - Method in class net.ravendb.client.connection.ServerClient
 
getOperationStatus(long) - Method in class net.ravendb.client.connection.ServerClient
 
getOperationType() - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Operation type on which conflict occurred (Put, Delete).
getOrAdd(String, Function1<String, T>) - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
getOrGenerateDocumentKey(Object) - Method in class net.ravendb.client.document.GenerateEntityIdOnTheClient
Tries to get the identity.
getOriginalField() - Method in class net.ravendb.client.linq.RenamedField
 
getOriginalMetadata() - Method in class net.ravendb.client.document.DocumentMetadata
 
getOriginalQueryType() - Method in interface net.ravendb.client.linq.IRavenQueryable
Holds the original query type only when TransformWith is invoked otherwise null.
getOriginalQueryType() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getOriginalQueryType() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getOriginalQueryType() - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getOriginalValue() - Method in class net.ravendb.client.document.DocumentMetadata
 
getOutputContext() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
getOutputCount() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getOwner() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getPageSize() - Method in class net.ravendb.abstractions.data.FacetQuery
Page size for facet query results.
getPageSize() - Method in class net.ravendb.abstractions.data.IndexQuery
Maximum number of records that will be retrieved.
getPageSize() - Method in class net.ravendb.client.RavenPagingInformation
 
getPageStart() - Method in class net.ravendb.abstractions.data.FacetQuery
Page start for facet query results.
getPassword() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getPatch() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
ScriptedPatchRequest (using JavaScript) that is used to patch the document.
getPatches() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Array of patches that will be applied to the document
getPatchesIfMissing() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Array of patches to apply to a default document if the document is missing
getPatchIfMissing() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
ScriptedPatchRequest (using JavaScript) that is used to patch a default document if the document is missing.
getPatchResult() - Method in class net.ravendb.abstractions.data.BatchResult
Result of a PATCH operation.
getPatchResult() - Method in class net.ravendb.abstractions.data.PatchResultData
Result of patch operation: - DocumentDoesNotExists - document does not exists, operation was a no-op, - Patched - document was properly patched, - Tested - document was properly tested, - Skipped - document was not patched, because skipPatchIfEtagMismatch was set and the etag did not match, - NotModified - neither document body not metadata was changed during patch operation
getPath() - Method in class net.ravendb.client.linq.ExpressionInfo
 
getPath(Expression<?>) - Method in class net.ravendb.client.linq.LinqPathProvider
 
getPath() - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
getPendingSyncs() - Method in class net.ravendb.abstractions.data.FileSystemStats
 
getPercentiles() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getPerformance() - Method in class net.ravendb.abstractions.data.IndexStats
Performance statistics for this index.
getPosition() - Method in class net.ravendb.abstractions.data.PatchRequest
Only valid for collection types.
getPostedData() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
The data posted to the server
getPrefetches() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Information about future indexing batches.
getPrefetchingUser() - Method in class net.ravendb.abstractions.data.FutureBatchStats
Indicates what prefetching user (indexer, replicator, sql replicator) calculated the future batch.
getPrevVal() - Method in class net.ravendb.abstractions.data.PatchRequest
Gets the previous value, which is compared against the current value to verify a change isn't overwriting new values.
getPrimaryCredentials() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Primary credentials for access.
getPrimaryCredentials() - Method in class net.ravendb.client.connection.ServerClient
 
getPriority() - Method in class net.ravendb.abstractions.data.IndexStats
Index priority (Normal, Disabled, Idle, Abandoned, Error)
getPriority() - Method in class net.ravendb.abstractions.data.IndexToAdd
Priority of an index
getPriority() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
index can have a priority that controls how much power of the indexing process it is allowed to consume.
getProblematicText() - Method in exception net.ravendb.abstractions.exceptions.IndexCompilationException
Value of a problematic property.
getProblematicText() - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
getProductVersion() - Method in class net.ravendb.abstractions.data.BuildNumber
 
getProfilingInformation() - Method in interface net.ravendb.client.connection.profiling.IHoldProfilingInformation
The profiling information
getProfilingInformation() - Method in class net.ravendb.client.connection.ServerClient
 
getProfilingInformationFor(UUID) - Method in class net.ravendb.client.DocumentStoreBase
Get the profiling information for the given id
getProjectionFields() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Gets the fields for projection
getProjectionFields() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Gets the fields for projection
getProperties() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
getPropertiesMatch() - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
getPropertiesNotMatch() - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
getProvider() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Query provider.
getProvider() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getPullingRequestTimeout() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
getQuery() - Method in class net.ravendb.abstractions.data.FacetQuery
Query that should be ran on index.
getQuery() - Method in class net.ravendb.abstractions.data.GetRequest
Query information e.g.
getQuery() - Method in class net.ravendb.abstractions.data.IndexQuery
Actual query that will be performed (Lucene syntax).
getQuery() - Method in class net.ravendb.client.shard.ShardRequestData
 
getQueryGenerator() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getQueryGenerator() - Method in class net.ravendb.client.linq.RavenQueryProvider
Get the query generator
getQueryListeners() - Method in class net.ravendb.client.document.DocumentSessionListeners
 
getQueryProviderProcessor(Class<S>) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getQueryResult() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Gets the query result Execute the query the first time that this is called.
getQueryResult() - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
getQueryResult() - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
getQueryResult() - Method in class net.ravendb.client.document.LazyFacetsOperation
 
getQueryResult() - Method in interface net.ravendb.client.IDocumentQuery
Gets the query result.
getQueryShape() - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Shape in WKT format.
getQueryShapeFromLatLon(double, double, double) - Static method in class net.ravendb.abstractions.data.SpatialIndexQuery
 
getQueryString() - Method in class net.ravendb.abstractions.data.IndexQuery
 
getRadiusUnitOverride() - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Overrides the units defined in the spatial index
getRange() - Method in class net.ravendb.abstractions.data.FacetValue
Name of range for which facet value applies.
getRange() - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
getRanges() - Method in class net.ravendb.abstractions.data.Facet
List of facet ranges.
getRanges() - Method in class net.ravendb.client.linq.AggregationQueryDsl
 
getReadStripingBase(boolean) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
getReadStripingBase(boolean) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getReadTime() - Method in class net.ravendb.client.connection.CachedRequest
 
getReduce() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index reduce function
getReduce() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getReducedPerSecond() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getReduceIndexingAttempts() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many times database tried to index documents (reduce) using this index.
getReduceIndexingErrors() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many reducing attempts failed.
getReduceIndexingSuccesses() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many reducing attempts succeeded.
getRegisteredConflictListeners() - Method in class net.ravendb.client.DocumentStoreBase
Gets a read-only collection of the registered conflict listeners.
getRegisteredConversionListeners() - Method in class net.ravendb.client.DocumentStoreBase
Gets a read-only collection of the registered conversion listeners.
getRegisteredDeleteListeners() - Method in class net.ravendb.client.DocumentStoreBase
Gets a read-only collection of the registered delete listeners.
getRegisteredQueryListeners() - Method in class net.ravendb.client.DocumentStoreBase
Gets a read-only collection of the registered query listeners.
getRegisteredStoreListeners() - Method in class net.ravendb.client.DocumentStoreBase
Gets a read-only collection of the registered store listeners.
getRelation() - Method in class net.ravendb.client.spatial.SpatialCriteria
 
getRemainingHits() - Method in class net.ravendb.abstractions.data.FacetResult
The number of remaining hits outside of those covered by the Values terms.
getRemainingTerms() - Method in class net.ravendb.abstractions.data.FacetResult
A list of remaining terms in term sort order for terms that are outside of the MaxResults count.
getRemainingTermsCount() - Method in class net.ravendb.abstractions.data.FacetResult
The number of remaining terms outside of those covered by the Values terms.
getReplaceTimeUtc() - Method in class net.ravendb.abstractions.data.SideBySideIndexes
 
getReplaceTimeUtc() - Method in class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
getReplication() - Method in class net.ravendb.client.document.DocumentStore
 
getReplicationBatchSizeHistogram() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getReplicationBatchSizeMeter() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getReplicationDestinations() - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
getReplicationDestinations() - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getReplicationDestinationsUrls() - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
getReplicationDestinationsUrls() - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getReplicationDurationHistogram() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getReplicationDurationMeter() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getReplicationInfo() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Get replication info
getReplicationInfo() - Method in class net.ravendb.client.connection.ServerClient
 
getReplicationInformer() - Method in class net.ravendb.client.connection.ServerClient
 
getReplicationInformerFactory() - Method in class net.ravendb.client.document.DocumentConvention
This is called to provide replication behavior for the client.
getReplicationInformerForDatabase() - Method in class net.ravendb.client.document.DocumentStore
 
getReplicationInformerForDatabase(String) - Method in class net.ravendb.client.document.DocumentStore
 
getReport() - Method in class net.ravendb.client.document.BulkInsertOperation
 
getReport() - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
getReport() - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
 
getReport() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
getRequest() - Method in class net.ravendb.abstractions.connection.WebRequestEventArgs
 
GetRequest - Class in net.ravendb.abstractions.data
 
GetRequest() - Constructor for class net.ravendb.abstractions.data.GetRequest
 
GetRequest(String) - Constructor for class net.ravendb.abstractions.data.GetRequest
 
GetRequest(String, String) - Constructor for class net.ravendb.abstractions.data.GetRequest
 
getRequestDuration() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getRequests() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getRequests() - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
getRequests() - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
getRequestsDuration() - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
getRequestsPerSecond() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getRequestsPerSecond() - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
getRequestTimeout() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
getRequestUri() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
 
getRequestUri() - Method in class net.ravendb.client.connection.MultiGetOperation
 
getResponse() - Method in exception net.ravendb.abstractions.connection.ErrorResponseException
 
GetResponse - Class in net.ravendb.abstractions.data
 
GetResponse() - Constructor for class net.ravendb.abstractions.data.GetResponse
 
getResponse() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getResponseHeaders() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getResponseStatusCode() - Method in exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionException
 
getResponseStatusCode() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getResponseString() - Method in exception net.ravendb.abstractions.connection.ErrorResponseException
 
getRestarts() - Method in class net.ravendb.abstractions.data.Etag
 
getRestoreStartTimeout() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Maximum number of seconds to wait for restore to start (only one restore can run simultaneously).
getResult() - Method in class net.ravendb.abstractions.data.GetResponse
Response result as JSON.
getResult() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
The result of this request
getResult() - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
getResult() - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
getResult() - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
getResult() - Method in class net.ravendb.client.document.LazyFacetsOperation
 
getResultEtag() - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
getResultEtag() - Method in class net.ravendb.abstractions.data.QueryResult
The ETag value for this index current state, which include what docs were indexed, what document were deleted, etc.
getResultEtag() - Method in class net.ravendb.client.RavenQueryStatistics
 
getResults() - Method in class net.ravendb.abstractions.data.FacetResults
A list of results for the facet.
getResults() - Method in class net.ravendb.abstractions.data.MultiLoadResult
Loaded documents.
getResults() - Method in class net.ravendb.abstractions.data.QueryResult
Gets the document resulting from this query.
getResultSize() - Method in class net.ravendb.abstractions.data.QueryResult
The size of the request which were sent from the server.
getResultSize() - Method in class net.ravendb.client.RavenQueryStatistics
The size of the request which were sent from the server.
getResultsTransformer() - Method in class net.ravendb.abstractions.data.IndexQuery
Name of transformer to use on query results.
getResultsTransformer() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Transformer to use on the query results.
getResultTranformer() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getResultTranformer() - Method in class net.ravendb.client.linq.RavenQueryProvider
Gets the results transformer to use
getRetries() - Method in class net.ravendb.abstractions.data.FutureBatchStats
Number of retries till the future batch calculation succeeded.
getRootDatabaseUrl(String) - Static method in class net.ravendb.client.extensions.MultiDatabase
 
getRootPages() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getRoughSize(RavenJToken) - Static method in class net.ravendb.abstractions.util.DocumentHelpers
Gets rough size of RavenJToken in bytes
getScoreExplanations() - Method in class net.ravendb.abstractions.data.QueryResult
Explanations of document scores (if requested).
getScoreExplanations() - Method in class net.ravendb.client.RavenQueryStatistics
 
getScript() - Method in class net.ravendb.abstractions.data.ScriptedPatchRequest
JavaScript function to use to patch a document
getSecuredSettings() - Method in class net.ravendb.abstractions.data.DatabaseDocument
Database settings (secured).
getSelf() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
 
getServerCheckUrl(String) - Method in class net.ravendb.client.connection.ReplicationInformer
 
getServerCheckUrl(String) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
getServerHash(String) - Static method in class net.ravendb.client.connection.ServerHash
 
getServerName() - Method in class net.ravendb.abstractions.data.AdminStatistics
Name of a server.
getSession() - Method in interface net.ravendb.client.connection.IRavenQueryInspector
The query session
getSession() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Gets the session associated with this document query
getSession() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
getSettings() - Method in class net.ravendb.abstractions.data.DatabaseDocument
Database settings (unsecured).
getShape() - Method in class net.ravendb.client.spatial.SpatialCriteria
 
getShardAccessStrategy() - Method in class net.ravendb.client.shard.ShardStrategy
 
getShardResolutionStrategy() - Method in class net.ravendb.client.shard.ShardStrategy
 
getShards() - Method in class net.ravendb.client.shard.ShardStrategy
 
getShardsToOperateOn(ShardRequestData) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
getShardStrategy() - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
getShardStrategy() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
getSharedOperationsHeaders() - Method in class net.ravendb.client.DocumentStoreBase
 
getSharedOperationsHeaders() - Method in interface net.ravendb.client.IDocumentStore
Gets the shared operations headers.
getSharedOperationsHeaders() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
getShouldCacheRequest() - Method in class net.ravendb.client.document.Convention
Whatever or not RavenDB should cache the request to the specified url.
getSize() - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Attachment size in bytes.
getSize() - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
Attachment size in bytes.
getSize() - Method in class net.ravendb.abstractions.data.FutureBatchStats
Number of documents in batch.
getSize() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getSkippedResults() - Method in class net.ravendb.abstractions.data.IndexQuery
For internal use only.
getSkippedResults() - Method in class net.ravendb.abstractions.data.QueryResult
Gets the skipped results
getSkippedResults() - Method in class net.ravendb.client.RavenQueryStatistics
 
getSnapshot() - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
getSortedFields() - Method in class net.ravendb.abstractions.data.IndexQuery
Array of fields containing sorting information.
getSortHints() - Method in class net.ravendb.abstractions.data.IndexQuery
For internal use only.
getSortOptions() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field sorting settings.
getSortOptions() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getSortOptionsStrings() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getSource() - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
getSpatialFieldName() - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
 
getSpatialIndexes() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field spatial settings.
getSpatialIndexes() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getSpatialIndexesStrings() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getSpatialRelation() - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Spatial relation (Within, Contains, Disjoint, Intersects, Nearby)
getStaleIndexes() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
List of stale index names in database.
getStaleIndexMaps() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getStaleIndexReduces() - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
getStaleTimeout() - Method in class net.ravendb.abstractions.data.BulkOperationOptions
If AllowStale is set to false and index is stale, then this is the maximum timeout to wait for index to become non-stale.
getStart() - Method in class net.ravendb.abstractions.data.IndexQuery
Number of records that should be skipped.
getStart() - Method in class net.ravendb.client.RavenPagingInformation
 
getStarted() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getStartEtag() - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
getStartEtags() - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
getStatistics() - Method in class net.ravendb.client.connection.AdminServerClient
 
getStatistics() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieve the statistics for the database
getStatistics() - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Gets server-wide statistics.
getStatistics() - Method in class net.ravendb.client.connection.ServerClient
 
getStats() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
 
getStatus() - Method in class net.ravendb.abstractions.data.GetResponse
Response HTTP status code.
getStatus() - Method in class net.ravendb.abstractions.data.LicensingStatus
 
getStatus() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
The request status
getStatusCode() - Method in exception net.ravendb.abstractions.connection.ErrorResponseException
 
getStdev() - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
getStopWordsDocumentId() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The document id containing the custom stop words
getStorageEngine() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Storage engine used by database (esent, voron).
getStorageStats() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Database storage statistics.
getStoreIdentifier() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets the store identifier for this session.
getStoreIdentifier() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets a value indicating whether the session should use optimistic concurrency.
getStoreListeners() - Method in class net.ravendb.client.document.DocumentSessionListeners
 
getStores() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field storage settings.
getStores() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getStoresStrings() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getStrategy() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
getStrategy() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getSubscriptionConnectionException() - Method in class net.ravendb.client.document.Subscription
The last subscription connection exception.
getSubscriptionId() - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
getSubscriptions(int, int) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
getSubscriptions(int, int, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
getSubscriptions(int, int) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It downloads a list of all existing subscriptions in a database.
getSubscriptions(int, int, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It downloads a list of all existing subscriptions in a database.
getSuggestions() - Method in class net.ravendb.abstractions.data.SuggestionQueryResult
Suggestions based on the term and dictionary.
getSuggestions() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field suggestion settings.
getSuggestions() - Method in class net.ravendb.abstractions.indexing.IndexMergeResults
 
getSuggestions() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getSum() - Method in class net.ravendb.abstractions.data.FacetValue
Stores sum of all values if FacetAggregation.Sum was set.
getSupportedClass() - Method in interface net.ravendb.client.document.DocumentConvention.TryConvertValueForQueryDelegate
 
getSurpassingIndex() - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
getTag() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
getTask() - Method in class net.ravendb.client.connection.ObservableLineStream
 
getTempIndexScore() - Method in class net.ravendb.abstractions.data.JsonDocument
The ranking of this result in the current query
getTerm() - Method in class net.ravendb.abstractions.data.SuggestionQuery
Term is what the user likely entered, and will used as the basis of the suggestions.
getTerms(String, String, String, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Get the all terms stored in the index for the specified field You can page through the results by use fromValue parameter as the starting point for the next query
getTerms(String, String, String, int) - Method in class net.ravendb.client.connection.ServerClient
 
getTermSortMode() - Method in class net.ravendb.abstractions.data.Facet
Indicates how terms should be sorted.
getTermVectors() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field term vector settings.
getTermVectors() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getTermVectorsStrings() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
getTime() - Method in class net.ravendb.client.connection.CachedRequest
 
getTimeOfLastClientActivity() - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
getTimeOfSendingLastBatch() - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
getTimeout() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getTimeout() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getTimestamp() - Method in class net.ravendb.abstractions.data.FutureBatchStats
Time when future batch was created.
getTimestamp() - Method in class net.ravendb.abstractions.data.IndexingError
 
getTimeStamp() - Method in class net.ravendb.abstractions.data.LogItem
 
getTimestamp() - Method in class net.ravendb.client.RavenQueryStatistics
 
getTimeToWaitBeforeConnectionRetry() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
getTimingsInMilliseconds() - Method in class net.ravendb.abstractions.data.QueryResult
Detailed timings for various parts of a query (Lucene search, loading documents, transforming results) - if requested.
getTimingsInMilliseconds() - Method in class net.ravendb.client.RavenQueryStatistics
 
getToken() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
getToken() - Method in class net.ravendb.client.util.SingleAuthTokenRetriever
 
getToken() - Method in class net.ravendb.client.utils.CancellationTokenSource
 
getTotalClientDuration() - Method in class net.ravendb.client.document.ResponseTimeInformation
 
getTotalDatabaseHumaneSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Total database size in a more human readable format.
getTotalDatabaseSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Total database size in bytes.
getTotalNumberOfRequests() - Method in class net.ravendb.abstractions.data.AdminStatistics
Total number of requests received since server startup.
getTotalProcessMemorySizeInMB() - Method in class net.ravendb.abstractions.data.AdminMemoryStatistics
Total size of memory held by server.
getTotalResults() - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
getTotalResults() - Method in class net.ravendb.abstractions.data.QueryResult
Gets the total results for this query
getTotalResults() - Method in class net.ravendb.client.RavenQueryStatistics
 
getTotalServerDuration() - Method in class net.ravendb.client.document.ResponseTimeInformation
 
getTotalSize() - Method in class net.ravendb.abstractions.data.IndexQuery
For internal use only.
getTotalSize() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
getTouchCount() - Method in class net.ravendb.abstractions.data.IndexStats
 
getTransactionalStorageAllocatedSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (allocated) of a transactional storage in bytes.
getTransactionalStorageAllocatedSizeHumaneSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (allocated) of a transactional storage in a more human readable format.
getTransactionalStorageUsedSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (used) of a transactional storage in bytes.
getTransactionalStorageUsedSizeHumaneSize() - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (used) of a transactional storage in a more human readable format.
getTransactionRecoveryStorage() - Method in class net.ravendb.client.DocumentStoreBase
 
getTransformer(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Gets the transformer definition for the specified name
getTransformer(String) - Method in class net.ravendb.client.connection.ServerClient
 
getTransformerName() - Method in class net.ravendb.client.indexes.AbstractTransformerCreationTask
Generates transformer name from type name replacing all _ with / e.g.
getTransformerParameters() - Method in class net.ravendb.abstractions.data.IndexQuery
Parameters that will be passed to transformer (if specified).
getTransformerParameters() - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Parameters that will be passed to transformer.
getTransformerParameters() - Method in class net.ravendb.client.document.RavenLoadConfiguration
 
getTransformerParameters() - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
getTransformerParameters() - Method in class net.ravendb.client.linq.RavenQueryProvider
 
getTransformers(int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Gets the transformers from the server
getTransformers(int, int) - Method in class net.ravendb.client.connection.ServerClient
 
getTransformResults() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
Projection function.
getTransformTypeTagNameToDocumentKeyPrefix() - Method in class net.ravendb.client.document.DocumentConvention
Translate the type tag name to the document key prefix
getTransitiveReplicationBehavior() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getType() - Method in class net.ravendb.abstractions.data.DataSubscriptionChangeNotification
Type of subscription change
getType() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Type of change that occurred on document.
getType() - Method in class net.ravendb.abstractions.data.IndexChangeNotification
Type of change that occurred on index.
getType() - Method in class net.ravendb.abstractions.data.PatchRequest
Type of patch operation.
getType() - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
getType() - Method in class net.ravendb.abstractions.data.TransformerChangeNotification
Type of change that occurred on transformer.
getType() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
getType() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getType() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
Gets the node type for this RavenJArray
getType() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
getType() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
Gets the node type for this RavenJToken
getType() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
Gets the node type for this RavenJToken
getTypeName() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Document type name.
getTypeTagName(Class<?>) - Method in class net.ravendb.client.document.DocumentConvention
Gets the name of the type tag.
getUnallocatedPagesAtEndOfFile() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getUnits() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
getUnmergables() - Method in class net.ravendb.abstractions.indexing.IndexMergeResults
 
getUptime() - Method in class net.ravendb.abstractions.data.AdminStatistics
Server uptime.
getUrl() - Method in class net.ravendb.abstractions.data.GetRequest
Request url (relative).
getUrl() - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
getUrl() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getUrl() - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
getUrl() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
getUrl() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
getUrl() - Method in class net.ravendb.client.connection.OperationMetadata
 
getUrl() - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
The request Url
getUrl() - Method in class net.ravendb.client.connection.ReplicationInformer.FailoverStatusChangedEventArgs
 
getUrl() - Method in class net.ravendb.client.connection.ServerClient
 
getUrl() - Method in class net.ravendb.client.document.DocumentSubscriptions.ErrorAndUrl
 
getUrl() - Method in class net.ravendb.client.document.ResponseTimeInformation.ResponseTimeItem
 
getUrl() - Method in class net.ravendb.client.DocumentStoreBase
 
getUrl() - Method in class net.ravendb.client.exceptions.ServerRequestError
 
getUrl() - Method in interface net.ravendb.client.IDocumentStore
Gets the URL.
getUrl() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
getUrlAndQuery() - Method in class net.ravendb.abstractions.data.GetRequest
Concatenated Url and Query.
getUsedDataFileSizeInBytes() - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
getUsername() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
getValue() - Method in class net.ravendb.abstractions.basic.Lazy
 
getValue() - Method in class net.ravendb.abstractions.data.BoostedValue
 
getValue() - Method in enum net.ravendb.abstractions.data.DataSubscriptionChangeTypes
 
getValue() - Method in enum net.ravendb.abstractions.data.DocumentChangeTypes
 
getValue() - Method in class net.ravendb.abstractions.data.EnumSet
 
getValue() - Method in enum net.ravendb.abstractions.data.FacetAggregation
 
getValue() - Method in enum net.ravendb.abstractions.data.IndexChangeTypes
 
getValue() - Method in enum net.ravendb.abstractions.data.MetricType
 
getValue() - Method in class net.ravendb.abstractions.data.PatchRequest
New value.
getValue() - Method in enum net.ravendb.abstractions.data.PrefetchingUser
 
getValue() - Method in enum net.ravendb.abstractions.data.ReplicationConflictTypes
 
getValue() - Method in enum net.ravendb.abstractions.data.ReplicationOperationTypes
 
getValue() - Method in enum net.ravendb.abstractions.data.TransformerChangeTypes
 
getValue() - Method in enum net.ravendb.abstractions.data.UuidType
 
getValue() - Method in enum net.ravendb.abstractions.indexing.SortOptions
 
getValue() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
Gets the underlying token value.
getValue() - Method in enum net.ravendb.abstractions.smuggler.ItemType
 
getValue() - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
getValue() - Method in enum net.ravendb.client.document.FailoverBehavior
 
getValue() - Method in enum net.ravendb.client.document.IndexAndTransformerReplicationMode
 
getValue() - Method in enum net.ravendb.client.SearchOptions
 
getValue() - Method in class net.ravendb.client.WhereParams
 
getValueFromExpression(Expression<?>, Class<?>) - Method in class net.ravendb.client.linq.LinqPathProvider
 
getValueFromExpressionWithoutConversion(Expression<?>, Reference<Object>) - Static method in class net.ravendb.client.linq.LinqPathProvider
 
getValueMethod - Variable in class net.ravendb.abstractions.data.EnumSet
 
getValues() - Method in class net.ravendb.abstractions.data.FacetResult
The facet terms and hits up to a limit of MaxResults items (as specified in the facet setup document), sorted in TermSortMode order (as indicated in the facet setup document).
getValues() - Method in class net.ravendb.abstractions.data.ScriptedPatchRequest
Additional arguments passed to JavaScript function from Script.
getValues() - Method in class net.ravendb.abstractions.json.ConflictsResolver.Conflicted
 
getVoronStats() - Method in class net.ravendb.abstractions.data.StorageStats
 
getWaitingTimeSinceLastBatchCompleted() - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
getWasDisposed() - Method in class net.ravendb.client.DocumentStoreBase
 
getWasDisposed() - Method in interface net.ravendb.client.IDisposalNotification
Whatever the instance has been disposed
getWriteTimeoutMiliseconds() - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Maximum timeout in milliseconds to wait for document write.
GlobalLastEtagHolder - Class in net.ravendb.client.util
 
GlobalLastEtagHolder() - Constructor for class net.ravendb.client.util.GlobalLastEtagHolder
 
groupByFields - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Fields to group on
GzipHttpEntity - Class in net.ravendb.java.http.client
 
GzipHttpEntity(HttpEntity) - Constructor for class net.ravendb.java.http.client.GzipHttpEntity
 

H

handle(Object, T) - Method in interface net.ravendb.abstractions.basic.EventHandler
Handle event
handle(HttpResponse) - Method in interface net.ravendb.client.delegates.HttpResponseHandler
 
handle(HttpResponse, OperationCredentials) - Method in interface net.ravendb.client.delegates.HttpResponseWithMetaHandler
 
handleCachingResponse(GetResponse[], HttpJsonRequestFactory) - Method in class net.ravendb.client.connection.MultiGetOperation
 
handleEmbeddedResponse(Object) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
handleEmbeddedResponse(Object) - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
handleForbiddenResponse(HttpResponse) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
handleForbiddenResponse(HttpResponse) - Method in class net.ravendb.client.document.Convention
 
handleGetDocumentResult(MultiLoadResult) - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
handleInternalMetadata(RavenJObject) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
handlePropertyRenames(Path<?>, String) - Static method in class net.ravendb.client.linq.LinqPathProvider
 
handleReplicationStatusChanges(Map<String, String>, String, String) - Method in class net.ravendb.client.connection.ServerClient
 
handleResponse(GetResponse) - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
handleResponse(GetResponse) - Method in class net.ravendb.client.document.LazyFacetsOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
handleResponses(GetResponse[], ShardStrategy) - Method in class net.ravendb.client.document.LazyFacetsOperation
 
handleUnauthorizedResponse(HttpResponse, OperationCredentials) - Method in class net.ravendb.client.document.Convention
 
handleUnknownProperty(DeserializationContext, JsonDeserializer<?>, Object, String) - Method in class net.ravendb.client.document.DefaultRavenContractResolver
 
hasChanged(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Determines whether the specified entity has changed.
hasChanged(Object) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Determines whether the specified entity has changed.
hasChanges() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets a value indicating whether any of the entities tracked by the session has changes.
hasChanges() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets a value indicating whether any of the entities tracked by the session has changes.
hash(String) - Static method in class net.ravendb.abstractions.connection.OAuthHelper
 
hashCode() - Method in class net.ravendb.abstractions.basic.Tuple
 
hashCode() - Method in class net.ravendb.abstractions.data.DocumentsChanges
 
hashCode() - Method in class net.ravendb.abstractions.data.EnumSet
 
hashCode() - Method in class net.ravendb.abstractions.data.Etag
 
hashCode() - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
 
hashCode() - Method in class net.ravendb.abstractions.data.ScriptedPatchRequest
 
hashCode() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
hashCode() - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
hashCode() - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
hashCode() - Method in class net.ravendb.abstractions.indexing.SuggestionOptions
 
hashCode() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
 
hashCode() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
hashCode() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
hashCode() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
hashCode() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
HashEncryptorBase - Class in net.ravendb.client.utils.encryptors
 
HashEncryptorBase() - Constructor for class net.ravendb.client.utils.encryptors.HashEncryptorBase
 
hasJsonRequestFactory() - Method in class net.ravendb.client.document.DocumentStore
 
hasJsonRequestFactory() - Method in class net.ravendb.client.DocumentStoreBase
 
hasJsonRequestFactory() - Method in interface net.ravendb.client.IDocumentStore
Whatever this instance has json request factory available
hasJsonRequestFactory() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Whatever this instance has json request factory available
hasNext() - Method in class net.ravendb.client.connection.RavenJObjectIterator
 
head(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves the document metadata for the specified document key.
head(String) - Method in class net.ravendb.client.connection.ServerClient
 
headAttachment(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
headAttachment(String) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
HEADERS_TO_IGNORE_CLIENT - Static variable in class net.ravendb.abstractions.extensions.MetadataExtensions
 
HEADERS_TO_IGNORE_FOR_CLIENT - Static variable in class net.ravendb.abstractions.extensions.MetadataExtensions
 
highlight(String, int, int, String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
highlight(String, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
highlight(String, String, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
highlight(Expression<?>, int, int, ListPath<?, ?>) - Method in class net.ravendb.client.document.DocumentQuery
 
highlight(Expression<?>, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.DocumentQuery
 
highlight(Expression<?>, Expression<?>, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.DocumentQuery
 
highlight(String, int, int, String) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
highlight(String, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
highlight(String, String, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
highlight(String, int, int, String) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Adds matches highlighting for the specified field.
highlight(String, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Adds matches highlighting for the specified field.
highlight(String, String, int, int, Reference<FieldHighlightings>) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Adds matches highlighting for the specified field.
highlight(String, int, int, String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Adds matches highlighting for the specified field.
highlight(String, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Adds matches highlighting for the specified field.
highlight(String, String, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Adds matches highlighting for the specified field on a Map/Reduce Index.
highlight(String, int, int, String) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds matches highlighting for the specified field.
highlight(String, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds matches highlighting for the specified field.
highlight(String, String, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds matches highlighting for the specified field.
highlight(Expression<?>, int, int, ListPath<?, ?>) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds matches highlighting for the specified field.
highlight(Expression<?>, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds matches highlighting for the specified field.
highlight(Expression<?>, Expression<?>, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.IDocumentQueryBase
Adds matches highlighting for the specified field on a Map/Reduce Index.
highlight(String, int, int, String) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Adds matches highlighting for the specified field.
highlight(String, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Adds matches highlighting for the specified field.
highlight(String, String, int, int, Reference<FieldHighlightings>) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Adds matches highlighting for the specified field.
HighlightedField - Class in net.ravendb.abstractions.data
 
HighlightedField(String, int, int, String) - Constructor for class net.ravendb.abstractions.data.HighlightedField
 
highlightedFields - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The fields to highlight
highlighterKeyName - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Highlighter key
highlighterPostTags - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Highlighter post tags
highlighterPreTags - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Highlighter pre tags
highlightings - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Holds the query highlightings
HiLoKeyGenerator - Class in net.ravendb.client.document
Generate hilo numbers against a RavenDB document
HiLoKeyGenerator(String, long) - Constructor for class net.ravendb.client.document.HiLoKeyGenerator
Initializes a new instance of the HiLoKeyGenerator class.
HiLoKeyGeneratorBase - Class in net.ravendb.client.document
 
HiLoKeyGeneratorBase(String, long) - Constructor for class net.ravendb.client.document.HiLoKeyGeneratorBase
 
HiLoKeyGeneratorBase.RangeValue - Class in net.ravendb.client.document
 
HiLoKeyGeneratorBase.RangeValue(long, long) - Constructor for class net.ravendb.client.document.HiLoKeyGeneratorBase.RangeValue
 
HttpContentExtentions - Class in net.ravendb.client.connection
 
HttpContentExtentions() - Constructor for class net.ravendb.client.connection.HttpContentExtentions
 
HttpEval - Class in net.ravendb.java.http.client
Http EVAL method
HttpEval() - Constructor for class net.ravendb.java.http.client.HttpEval
 
HttpEval(URI) - Constructor for class net.ravendb.java.http.client.HttpEval
 
HttpEval(String) - Constructor for class net.ravendb.java.http.client.HttpEval
 
HttpExtensions - Class in net.ravendb.client.connection
 
HttpExtensions() - Constructor for class net.ravendb.client.connection.HttpExtensions
 
HttpJsonRequest - Class in net.ravendb.client.connection.implementation
 
HttpJsonRequest(CreateHttpJsonRequestParams, HttpJsonRequestFactory) - Constructor for class net.ravendb.client.connection.implementation.HttpJsonRequest
 
HttpJsonRequestExtension - Class in net.ravendb.client.extensions
 
HttpJsonRequestExtension() - Constructor for class net.ravendb.client.extensions.HttpJsonRequestExtension
 
HttpJsonRequestFactory - Class in net.ravendb.client.connection.implementation
Create the HTTP Json Requests to the RavenDB Server and manages the http cache
HttpJsonRequestFactory(int) - Constructor for class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
HttpJsonRequestFactory(int, boolean) - Constructor for class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
HttpMethods - Enum in net.ravendb.abstractions.data
 
HttpRequestHelper - Class in net.ravendb.abstractions.connection
 
HttpRequestHelper() - Constructor for class net.ravendb.abstractions.connection.HttpRequestHelper
 
HttpReset - Class in net.ravendb.java.http.client
Http RESET method
HttpReset() - Constructor for class net.ravendb.java.http.client.HttpReset
 
HttpReset(URI) - Constructor for class net.ravendb.java.http.client.HttpReset
 
HttpReset(String) - Constructor for class net.ravendb.java.http.client.HttpReset
 
HttpResponseHandler - Interface in net.ravendb.client.delegates
 
HttpResponseWithMetaHandler - Interface in net.ravendb.client.delegates
 

I

IAbstractDocumentQuery<T> - Interface in net.ravendb.client.document
Mostly used by the linq provider
IAdminDatabaseCommands - Interface in net.ravendb.client.connection
 
IAdvancedDocumentSessionOperations - Interface in net.ravendb.client
Advanced session operations
IAsymmetricalEncryptor - Interface in net.ravendb.client.utils.encryptors
 
IChangesConnectionState - Interface in net.ravendb.client.changes
 
ICommandData - Interface in net.ravendb.abstractions.commands
A single operation inside the batch.
IConnectableChanges - Interface in net.ravendb.client.changes
 
id - Variable in class net.ravendb.client.shard.BaseShardedDocumentSession.IdToLoad
 
ID_PREFIX - Static variable in class net.ravendb.abstractions.data.ScriptedIndexResults
 
IDatabaseChanges - Interface in net.ravendb.client.changes
 
IDatabaseCommands - Interface in net.ravendb.client.connection
 
IdConvention - Interface in net.ravendb.client.delegates
 
IdentityHashSet<T> - Class in net.ravendb.client.util
 
IdentityHashSet() - Constructor for class net.ravendb.client.util.IdentityHashSet
 
identityPartsSeparator - Variable in class net.ravendb.client.document.Convention
 
IdentityPropertyFinder - Interface in net.ravendb.client.delegates
 
IdentityPropertyNameFinder - Interface in net.ravendb.client.delegates
 
IDisposalNotification - Interface in net.ravendb.client
Provide a way for interested party to tell whatever implementers have been disposed
IDocumentConflictListener - Interface in net.ravendb.client.listeners
Hooks for users that allows you to handle document replication conflicts
IDocumentConversionListener - Interface in net.ravendb.client.listeners
Extended hook for users to provide additional logic for converting to / from entities to document/metadata pairs.
IDocumentDeleteListener - Interface in net.ravendb.client.listeners
Hook for users to provide additional logic on delete operations
IDocumentQuery<T> - Interface in net.ravendb.client
A query against a Raven index
IDocumentQueryBase<T,TSelf extends IDocumentQueryBase<T,TSelf>> - Interface in net.ravendb.client
A query against a Raven index
IDocumentQueryCustomization - Interface in net.ravendb.client
Customize the document query
IDocumentQueryGenerator - Interface in net.ravendb.client.linq
Generate a new document query
IDocumentQueryListener - Interface in net.ravendb.client.listeners
Hook for users to modify all queries globally
IDocumentSession - Interface in net.ravendb.client
Interface for document session
IDocumentSessionImpl - Interface in net.ravendb.client
Interface for document session which holds the internal operations
IDocumentStore - Interface in net.ravendb.client
Interface for managing access to RavenDB and open sessions.
IDocumentStoreListener - Interface in net.ravendb.client.listeners
Hook for users to provide additional logic on store operations
IDocumentStoreReplicationInformer - Interface in net.ravendb.client.connection
 
IdValuePartFinder - Interface in net.ravendb.client.delegates
 
IEagerSessionOperations - Interface in net.ravendb.client.document.batches
Allow to perform eager operations on the session
IEncryptor - Interface in net.ravendb.client.utils.encryptors
 
IGlobalAdminDatabaseCommands - Interface in net.ravendb.client.connection
 
ignoreChangesFor(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
ignoreChangesFor(Object) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Mark the entity as one that should be ignore for change tracking purposes, it still takes part in the session, but is ignored for saveChanges.
IHashEncryptor - Interface in net.ravendb.client.utils.encryptors
 
IHoldProfilingInformation - Interface in net.ravendb.client.connection.profiling
Interface for getting profiling information about the actions of the system within a given context, usually the context is database commands
IJsonDocumentMetadata - Interface in net.ravendb.abstractions.data
Interface that is used purely internally
ILastEtagHolder - Interface in net.ravendb.client.util
 
ILazyLoaderWithInclude - Interface in net.ravendb.client.document.batches
Fluent interface for specifying include paths for loading documents lazily NOTE: Java version does not contain method load that skips class parameter - since we can't track type in method signature based on Path object
ILazyOperation - Interface in net.ravendb.client.document.batches
 
ILazySessionOperations - Interface in net.ravendb.client.document.batches
Specify interface for lazy operation for the session
ILoadConfiguration - Interface in net.ravendb.client
 
ILoaderWithInclude - Interface in net.ravendb.client.document
Fluent interface for specifying include paths for loading documents
ILog - Interface in net.ravendb.abstractions.logging
 
ILogManager - Interface in net.ravendb.abstractions.logging
 
ILowLevelBulkInsertOperation - Interface in net.ravendb.client.document
 
IMetricsData - Interface in net.ravendb.abstractions.data
 
importParameters(byte[], byte[]) - Method in class net.ravendb.client.utils.encryptors.FipsAsymmetricalEncryptor
 
importParameters(byte[], byte[]) - Method in interface net.ravendb.client.utils.encryptors.IAsymmetricalEncryptor
 
inc() - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
inc() - Method in interface net.ravendb.client.changes.IChangesConnectionState
 
include(RavenJObject, String, Action1<String>) - Static method in class net.ravendb.abstractions.util.IncludesUtil
 
include(String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
include(Class<?>, Path<?>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
include(Path<?>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
include(String) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Begin a load while including the specified path
include(Path<?>) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Begin a load while including the specified path
include(String) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Begin a load while including the specified path
include(Path<?>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Begin a load while including the specified path
include(String) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
Includes the specified path.
include(Path<?>) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
Includes the specified path.
include(Path<?>) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
include(String) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
include(Class<?>, Path<?>) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
include(Path<?>) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Includes the specified path in the query, loading the document specified in that path
include(String) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Includes the specified path in the query, loading the document specified in that path
include(Class<?>, Path<?>) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Includes the specified path in the query, loading the document specified in that path
include(String) - Method in class net.ravendb.client.document.DocumentSession
Begin a load while including the specified path
include(Expression<?>) - Method in class net.ravendb.client.document.DocumentSession
Begin a load while including the specified path
include(Class<?>, Expression<?>) - Method in class net.ravendb.client.document.DocumentSession
Begin a load while including the specified path
include(Path<?>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Includes the specified path in the query, loading the document specified in that path
include(String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Includes the specified path in the query, loading the document specified in that path
include(Class<?>, Path<?>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Includes the specified path in the query, loading the document specified in that path
include(String) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Includes the specified path.
include(Expression<?>) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Includes the specified path.
include(Class<?>, Expression<?>) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Includes the specified path.
include(Path<?>) - Method in class net.ravendb.client.document.LazySessionOperations
Begin a load while including the specified path
include(String) - Method in class net.ravendb.client.document.LazySessionOperations
Begin a load while including the specified path
include(Path<?>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Begin a load while including the specified path
include(String) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Begin a load while including the specified path
include(Class<?>, Expression<?>) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
include(String) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
Includes the specified path.
include(String, Class<?>) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
include(Expression<?>) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
Includes the specified path
include(String) - Method in interface net.ravendb.client.IDocumentQueryBase
Includes the specified path in the query, loading the document specified in that path
include(Path<?>) - Method in interface net.ravendb.client.IDocumentQueryBase
Includes the specified path in the query, loading the document specified in that path
include(Path<?>) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Includes the specified path in the query, loading the document specified in that path
include(String) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Includes the specified path in the query, loading the document specified in that path
include(Class<?>, Path<?>) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Includes the specified path in the query, loading the document specified in that path
include(String) - Method in interface net.ravendb.client.IDocumentSession
Begin a load while including the specified path
include(Expression<?>) - Method in interface net.ravendb.client.IDocumentSession
Begin a load while including the specified path
include(Class<?>, Expression<?>) - Method in interface net.ravendb.client.IDocumentSession
Begin a load while include the specified path
include(Path<?>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
include(Path<?>) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
include(String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
include(Expression<?>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
include(Class<?>, Expression<?>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
includedDocumentsByKey - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
includes - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The paths to include when loading the query
IncludesUtil - Class in net.ravendb.abstractions.util
 
IncludesUtil() - Constructor for class net.ravendb.abstractions.util.IncludesUtil
 
increment() - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
incrementBy(int) - Method in class net.ravendb.abstractions.data.Etag
 
incrementCachedRequests() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
incrementRequestCount() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
index(Path<?>, FieldIndexing) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be indexed
index(String, FieldIndexing) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be indexed
INDEX_REPLACE_PREFIX - Static variable in class net.ravendb.abstractions.data.Constants
 
IndexAndTransformerReplicationMode - Enum in net.ravendb.client.document
 
IndexChangeNotification - Class in net.ravendb.abstractions.data
 
IndexChangeNotification() - Constructor for class net.ravendb.abstractions.data.IndexChangeNotification
 
IndexChangeTypes - Enum in net.ravendb.abstractions.data
 
IndexCompilationException - Exception in net.ravendb.abstractions.exceptions
 
IndexCompilationException() - Constructor for exception net.ravendb.abstractions.exceptions.IndexCompilationException
 
IndexCompilationException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.IndexCompilationException
 
IndexCompilationException(String) - Constructor for exception net.ravendb.abstractions.exceptions.IndexCompilationException
 
IndexCompilationException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.IndexCompilationException
 
IndexCreation - Class in net.ravendb.client.indexes
 
IndexCreation() - Constructor for class net.ravendb.client.indexes.IndexCreation
 
IndexDefinition - Class in net.ravendb.abstractions.indexing
 
IndexDefinition() - Constructor for class net.ravendb.abstractions.indexing.IndexDefinition
Initializes a new instance of the IndexDefinition class.
IndexDefinition(String) - Constructor for class net.ravendb.abstractions.indexing.IndexDefinition
 
indexDefinition(String, String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
IndexDefinitionBuilder - Class in net.ravendb.client.indexes
 
IndexDefinitionBuilder() - Constructor for class net.ravendb.client.indexes.IndexDefinitionBuilder
 
IndexDefinitionBuilder(String) - Constructor for class net.ravendb.client.indexes.IndexDefinitionBuilder
 
indexes(String, String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
indexes - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
indexesStrings - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
indexesSubscriptions - Variable in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges
 
indexHasChanged(String, IndexDefinition) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Lets you check if the given index definition differs from the one on a server.
indexHasChanged(String, IndexDefinition) - Method in class net.ravendb.client.connection.ServerClient
 
IndexingError - Class in net.ravendb.abstractions.data
 
IndexingError() - Constructor for class net.ravendb.abstractions.data.IndexingError
 
indexingStatus(String) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
IndexLockMode - Enum in net.ravendb.abstractions.indexing
 
IndexMergeResults - Class in net.ravendb.abstractions.indexing
 
IndexMergeResults() - Constructor for class net.ravendb.abstractions.indexing.IndexMergeResults
 
indexName - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The index to query
indexName - Variable in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
indexNames(String, int, int) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
IndexQuery - Class in net.ravendb.abstractions.data
All the information required to query a Raven index
IndexQuery() - Constructor for class net.ravendb.abstractions.data.IndexQuery
Initializes a new instance of the IndexQuery class.
IndexQuery(String) - Constructor for class net.ravendb.abstractions.data.IndexQuery
 
IndexReplaceDocument - Class in net.ravendb.abstractions.indexing
 
IndexReplaceDocument() - Constructor for class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
indexSortOptions - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
indexSortOptionsStrings - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
IndexStats - Class in net.ravendb.abstractions.data
 
IndexStats() - Constructor for class net.ravendb.abstractions.data.IndexStats
 
IndexStats.IndexingPerformanceStats - Class in net.ravendb.abstractions.data
 
IndexStats.IndexingPerformanceStats() - Constructor for class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
IndexStats.IndexingPriority - Enum in net.ravendb.abstractions.data
 
indexSuggestions - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
IndexToAdd - Class in net.ravendb.abstractions.data
 
IndexToAdd() - Constructor for class net.ravendb.abstractions.data.IndexToAdd
 
Inflector - Class in net.ravendb.client.util
Class responsible for pluralizing words
info(String) - Method in interface net.ravendb.abstractions.logging.ILog
 
info(String, Object...) - Method in interface net.ravendb.abstractions.logging.ILog
 
info(String) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
info(String, Object...) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
infoException(String, Throwable) - Method in interface net.ravendb.abstractions.logging.ILog
 
infoException(String, Throwable) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
init(Class<T>, IRavenQueryProvider, RavenQueryStatistics, RavenQueryHighlightings, String, Expression<?>, InMemoryDocumentSessionOperations, IDatabaseCommands, boolean) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
initialize() - Method in class net.ravendb.client.document.DocumentStore
 
initialize() - Method in interface net.ravendb.client.IDocumentStore
Initializes this instance.
initialize() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Initializes this instance.
initialize(boolean) - Static method in class net.ravendb.client.utils.encryptors.Encryptor
 
initialized - Variable in class net.ravendb.client.DocumentStoreBase
 
initializeEncryptor() - Method in class net.ravendb.client.DocumentStoreBase
 
initializeInternal() - Method in class net.ravendb.client.document.DocumentStore
Initialize the document store access method to RavenDB
initializeProfiling() - Method in class net.ravendb.client.document.DocumentStore
 
initializeProfiling() - Method in interface net.ravendb.client.IDocumentStore
 
initializeProfiling() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
initializeQueryOperation() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
initializeSecurity(Convention, HttpJsonRequestFactory, String) - Static method in class net.ravendb.client.extensions.SecurityExtensions
 
initSync() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
initSync() - Method in class net.ravendb.client.shard.ShardedDocumentQuery
 
InMemoryDocumentSessionOperations - Class in net.ravendb.client.document
Abstract implementation for in memory session operations
InMemoryDocumentSessionOperations(String, DocumentStoreBase, DocumentSessionListeners, UUID) - Constructor for class net.ravendb.client.document.InMemoryDocumentSessionOperations
Initializes a new instance of the InMemoryDocumentSessionOperations class.
innerClass - Variable in class net.ravendb.abstractions.data.EnumSet
 
innerServerClient - Variable in class net.ravendb.client.connection.AdminServerClient
 
innerSetClass - Variable in class net.ravendb.abstractions.data.EnumSet
 
insert(int, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
Inserts an item to the List at the specified index.
Int32Converter - Class in net.ravendb.client.converters
 
Int32Converter() - Constructor for class net.ravendb.client.converters.Int32Converter
 
Int64Converter - Class in net.ravendb.client.converters
 
Int64Converter() - Constructor for class net.ravendb.client.converters.Int64Converter
 
INTERSECT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
intersect() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
intersect() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
 
intersect() - Method in interface net.ravendb.client.IDocumentQueryBase
Partition the query so we can intersect different parts of the query across different index entries.
intersect() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
intersect() - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
INTERSECT_SEPARATOR - Static variable in class net.ravendb.abstractions.data.Constants
 
intersects(Object) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
 
introImports(CodeWriter, SerializerConfig, EntityType) - Method in class net.ravendb.querydsl.RavenEntitySerializer
 
invalidEtag() - Static method in class net.ravendb.abstractions.data.Etag
 
invoke(List<EventHandler<T>>, Object, T) - Static method in class net.ravendb.abstractions.basic.EventHelper
Helper used for invoking event on list of delegates
invoke(List<Action1<T>>, T) - Static method in class net.ravendb.abstractions.basic.EventHelper
 
invokeAfterQueryExecuted(QueryResult) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Called externally to raise the after query executed callback
invokeAfterQueryExecuted(QueryResult) - Method in interface net.ravendb.client.IDocumentQueryBase
Called externally to raise the after query executed callback
invokeAfterStreamExecuted(Reference<RavenJObject>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Called externally to raise the after stream executed callback
invokeAfterStreamExecuted(Reference<RavenJObject>) - Method in interface net.ravendb.client.IDocumentQueryBase
Called externally to raise the after query executed callback
IObservable<T> - Interface in net.ravendb.client.changes
 
IObserver<T> - Interface in net.ravendb.client.changes
 
IOrderedQueryable<T> - Interface in net.ravendb.client.linq
 
IQueryProvider - Interface in net.ravendb.client.linq
 
IRavenQueryable<T> - Interface in net.ravendb.client.linq
An implementation of IOrderedQueryable with Raven specific operation
IRavenQueryInspector - Interface in net.ravendb.client.connection
Provide access to the underlying IDocumentQuery
IRavenQueryProvider - Interface in net.ravendb.client.linq
Extension for the built-in IQueryProvider allowing for Raven specific operations
IReliableSubscriptions - Interface in net.ravendb.client.document
 
IReplicationInformerBase<T> - Interface in net.ravendb.client.connection
 
isAborted() - Method in class net.ravendb.client.document.BulkInsertOperation
 
isAborted() - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
isAborted() - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
 
isAborted() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
isAborted() - Method in class net.ravendb.client.document.ShardedBulkInsertOperation
 
isAcceptable(QueryResult) - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
isAcceptGzipContent() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
isAcceptGzipContent() - Method in class net.ravendb.client.document.DocumentConvention
 
isAllowMultipleIndexEntriesForSameDocumentToResultTransformer() - Method in class net.ravendb.abstractions.data.IndexQuery
If set to true, this property will send multiple index entries from the same document (assuming the index project them) to the result transformer function.
isAllowNonAuthoritativeInformation() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets a value indicating whether non authoritative information is allowed.
isAllowNonAuthoritativeInformation() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets a value indicating whether non authoritative information is allowed.
isAllowQueriesOnId() - Method in class net.ravendb.client.document.DocumentConvention
Whatever to allow queries on document id.
isAllowStale() - Method in class net.ravendb.abstractions.data.BulkOperationOptions
Indicates whether operations are allowed on stale indexes.
isAllowWildcards() - Method in class net.ravendb.client.WhereParams
 
isAnalyzed() - Method in class net.ravendb.client.WhereParams
 
isAvoidCachingRequest() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
isCancellationRequested() - Method in class net.ravendb.client.utils.CancellationTokenSource.CancellationToken
 
isCheckReferencesInIndexes() - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Indicates if referenced documents should be checked in indexes.
isChunked() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
isChunked() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
isClosed() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
isCommercial() - Method in class net.ravendb.abstractions.data.LicensingStatus
 
isCompiled() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Internal use only.
isConnected() - Method in interface net.ravendb.client.changes.IConnectableChanges
 
isConnected() - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
isConnected() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
isConnectionClosed() - Method in class net.ravendb.client.document.Subscription
It determines if the subscription is closed.
isDebugEnabled() - Method in interface net.ravendb.abstractions.logging.ILog
 
isDebugEnabled() - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
isDebugMode() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Indicates in the operation should be run in debug mode.
isDebugOptionGetIndexEntires() - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever we should get the raw index entries.
isDefaultUseOptimisticConcurrency() - Method in class net.ravendb.client.document.DocumentConvention
 
isDefrag() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates if defragmentation should take place after restore.
isDeleted(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Returns whatever a document with the specified id is deleted or known to be missing
isDescending() - Method in class net.ravendb.abstractions.data.SortedField
Gets or sets a value indicating whether this SortedField is descending.
isDisableAuthentication() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
isDisableCaching() - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever we should disable caching of query results
isDisableCapacityChanges() - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
isDisabled() - Method in class net.ravendb.abstractions.data.DatabaseDocument
Indicates if database is disabled or not.
isDisableEntitiesTracking() - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
isDisableInMemoryIndexing() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Prevent index from being kept in memory.
isDisableInMemoryIndexing() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
isDisableInMemoryIndexing() - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
isDisableProfiling() - Method in class net.ravendb.client.document.DocumentConvention
Disable all profiling support
isDisableReplicationDestinations() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates if all replication destinations should disabled after restore (only when Replication bundle is activated).
isDisableRequestCompression() - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
isDisableRequestCompression() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
isDistinct() - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever we should apply distinct operation to the query on the server side.
isDistinct() - Method in class net.ravendb.client.document.DocumentQuery
 
isDistinct() - Method in interface net.ravendb.client.IDocumentQuery
Whatever we should apply distinct operation to the query on the server side
isEmpty() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
isEmpty() - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
isEmpty() - Method in class net.ravendb.client.util.IdentityHashSet
 
isEnableBasicAuthenticationOverUnsecuredHttpEvenThoughPasswordsWouldBeSentOverTheWireInClearTextToBeStolenByHackers() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
isEnabled(JsonGenerator.Feature) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
isEntityType(Class<?>) - Static method in class net.ravendb.client.util.Types
 
isError() - Method in class net.ravendb.abstractions.data.LicensingStatus
 
isErroredBecauseOfSubscriber() - Method in class net.ravendb.client.document.Subscription
 
isExpect100Continue() - Method in interface net.ravendb.client.connection.profiling.IHoldProfilingInformation
Is expect 100 continue?
isExpect100Continue() - Method in class net.ravendb.client.connection.ServerClient
 
isExplainScores() - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever a query result should contains an explanation about how docs scored against query
isExportAttachments() - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
isExportDeletions() - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
isExportDocuments() - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
isForceCheck() - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
isForceConcurrencyCheck() - Method in class net.ravendb.client.document.DocumentMetadata
 
isForceReadFromMaster() - Method in class net.ravendb.client.document.OpenSessionOptions
 
isForceRetry() - Method in class net.ravendb.abstractions.data.GetResponse
Indicates if request should be retried (forced).
isForceServerCheck() - Method in class net.ravendb.client.connection.CachedRequest
 
isForPreviousPage(int, int) - Method in class net.ravendb.client.RavenPagingInformation
 
isGenerateNewDatabaseId() - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates if restored database should have new Id generated.
IShardAccessStrategy - Interface in net.ravendb.client.shard
Apply an operation to all the shard session
IShardResolutionStrategy - Interface in net.ravendb.client.shard
Implementers of this interface provide a way to decide which shards will be queried for a specified operation
isHttpStatus(Exception, int...) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
isHttpStatus(Exception, int...) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
isIgnoreChanges() - Method in class net.ravendb.client.document.DocumentMetadata
If set to true, the session will ignore this document when SaveChanges() is called, and won't perform and change tracking
isIgnoreSubscribersErrors() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
isInFailoverMode() - Method in class net.ravendb.client.connection.ServerClient
 
isInvalidDestinationsDocument(JsonDocument) - Static method in class net.ravendb.client.connection.ReplicationInformerBase
 
isLastPage() - Method in class net.ravendb.client.RavenPagingInformation
 
isLoaded(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Returns whatever a document with the specified id is loaded in the current session
isLoaded(String) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Returns whatever a document with the specified id is loaded in the current session
isMapReduce() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates if it is a MapReduce index.
isMapReduce() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Gets a value indicating whether this instance is map reduce index definition
isMapReduce - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
isMapReduce() - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Gets a value indicating whether this instance is map reduce index definition
isMapReduce() - Method in class net.ravendb.client.indexes.RavenDocumentsByEntityName
 
isMetadata() - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeChunk
 
isNestedPath() - Method in class net.ravendb.client.linq.ExpressionInfo
 
isNestedPath() - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
isNestedPath() - Method in class net.ravendb.client.WhereParams
 
isNonAuthoritativeInformation() - Method in class net.ravendb.abstractions.data.QueryResult
Indicates whether any of the documents returned by this query are non authoritative (modified by uncommitted transaction).
isNonAuthoritativeInformation() - Method in class net.ravendb.client.RavenQueryStatistics
Gets a value indicating whether any of the documents returned by this query are non authoritative (modified by uncommitted transaction).
isOverwriteExisting() - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Indicates in existing documents should be overwritten.
isPageSizeSet() - Method in class net.ravendb.abstractions.data.IndexQuery
 
isPopularity() - Method in class net.ravendb.abstractions.data.SuggestionQuery
Whatever to return the terms in order of popularity
isPreserveDocumentPropertiesNotFoundOnModel() - Method in class net.ravendb.client.document.DocumentConvention
 
isRepeatable() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
isRepeatable() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
isRequestHasErrors() - Method in class net.ravendb.abstractions.data.GetResponse
Method used to check if request has errors.
isRequiresRetry() - Method in interface net.ravendb.client.document.batches.ILazyOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
isRequiresRetry() - Method in class net.ravendb.client.document.LazyFacetsOperation
 
isRetrieveDetails() - Method in class net.ravendb.abstractions.data.BulkOperationOptions
Determines whether operation details about each document should be returned by server.
isRetryOnconcurrencyExceptions() - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Indicates if patcher should retry applying the scripts when concurrency exception occurs.
isRetryOnconcurrencyExceptions() - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
isSaveEnumsAsIntegers() - Method in class net.ravendb.client.document.Convention
Saves Enums as integers and instruct the Linq provider to query enums as integer values.
isServerDown(Exception, Reference<Boolean>) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
isServerDown(Exception, Reference<Boolean>) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
isSetForDatabase(String) - Method in class net.ravendb.abstractions.data.FailoverServers
 
isSetForDefaultDatabase() - Method in class net.ravendb.abstractions.data.FailoverServers
 
isShouldAggressiveCacheTrackChanges() - Method in class net.ravendb.client.document.DocumentConvention
Whatever or not RavenDB should in the aggressive cache mode use Changes API to track changes and rebuild the cache.
isShouldCacheRequest() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
isShouldSaveChangesForceAggressiveCacheCheck() - Method in class net.ravendb.client.document.DocumentConvention
Whatever or not RavenDB should in the aggressive cache mode should force the aggressive cache to check with the server after we called SaveChanges() on a non empty data set.
isShowTimings() - Method in class net.ravendb.abstractions.data.IndexQuery
 
isSideBySideIndex() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
isSignalled() - Method in class net.ravendb.abstractions.util.AutoResetEvent
 
isSignalled() - Method in class net.ravendb.abstractions.util.ManualResetEvent
 
isSkipIndexReplication() - Method in class net.ravendb.abstractions.replication.ReplicationDestination
Gets flag that controls whether index is replicated to the node or not
isSkipOverwriteIfUnchanged() - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Determines whether should skip to overwrite a document when it is updated by exactly the same document (by comparing a content and metadata as well).
isSkipPatchIfEtagMismatch() - Method in class net.ravendb.abstractions.commands.PatchCommandData
If set to true, _and_ the Etag is specified then the behavior of the patch in the case of etag mismatch is different.
isSkipServerCheck() - Method in class net.ravendb.client.connection.CachedRequestOp
 
isSkipServerCheck() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
isSnapshot() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
isSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
isSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
isSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
isSnapshot() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
isSpatialQuery - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
isStale() - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
isStale() - Method in class net.ravendb.abstractions.data.QueryResult
Gets a value indicating whether the index is stale.
isStale() - Method in class net.ravendb.client.RavenQueryStatistics
 
isStreaming() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
isStreaming() - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
isSuccess() - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
isSupportsDtc() - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates if database supports DTC transactions.
isTestIndex() - Method in class net.ravendb.abstractions.data.IndexStats
Indicates if this is a test index (works on a limited data set - for testing purposes only)
isTextIndex() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
isUseOptimisticConcurrency() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Gets a value indicating whether the session should use optimistic concurrency.
isUseOptimisticConcurrency() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Gets a value indicating whether the session should use optimistic concurrency.
isUseParallelMultiGet() - Method in class net.ravendb.client.document.DocumentConvention
Instruct RavenDB to parallel Multi Get processing when handling lazy requests
isValueCreated() - Method in class net.ravendb.abstractions.basic.Lazy
 
isValueType(Class<?>) - Static method in class net.ravendb.abstractions.util.ValueTypeUtils
 
isWaitForNonStaleResults() - Method in class net.ravendb.abstractions.data.IndexQuery
CAUTION.
isWaitForNonStaleResultsAsOfNow() - Method in class net.ravendb.abstractions.data.IndexQuery
Used to calculate index staleness.
isWarnEnabled() - Method in interface net.ravendb.abstractions.logging.ILog
 
isWarnEnabled() - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
isWasTimeout() - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
ISymmetricalEncryptor - Interface in net.ravendb.client.utils.encryptors
 
ISyncAdvancedSessionOperation - Interface in net.ravendb.client
Advanced synchronous session operations
ItemType - Enum in net.ravendb.abstractions.smuggler
 
ItemTypeSet - Class in net.ravendb.abstractions.smuggler
 
ItemTypeSet() - Constructor for class net.ravendb.abstractions.smuggler.ItemTypeSet
 
ItemTypeSet(ItemType...) - Constructor for class net.ravendb.abstractions.smuggler.ItemTypeSet
 
iterator() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
iterator() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
iterator() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
iterator() - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
iterator() - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
iterator() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
iterator() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
 
iterator() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
iterator() - Method in class net.ravendb.client.util.IdentityHashSet
 
ITransactionalDocumentSession - Interface in net.ravendb.client
 
ITransactionRecoveryStorage - Interface in net.ravendb.client.document.dtc
 
ITransactionRecoveryStorageContext - Interface in net.ravendb.client.document.dtc
 
ITypeConverter - Interface in net.ravendb.client.converters
Interface for performing type conversions.

J

JavaClassFinder - Interface in net.ravendb.client.delegates
 
JavaClassNameFinder - Interface in net.ravendb.client.delegates
 
join(DocumentQueryCustomizationFactory, DocumentQueryCustomizationFactory) - Static method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
JsonConvert - Class in net.ravendb.imports.json
 
JsonConvert() - Constructor for class net.ravendb.imports.json.JsonConvert
 
JsonDocument - Class in net.ravendb.abstractions.data
A document representation: - Data / Projection - Etag - Metadata
JsonDocument(RavenJObject, RavenJObject, String, Boolean, Etag, Date) - Constructor for class net.ravendb.abstractions.data.JsonDocument
 
JsonDocumentMetadata - Class in net.ravendb.abstractions.data
 
JsonDocumentMetadata() - Constructor for class net.ravendb.abstractions.data.JsonDocumentMetadata
 
JsonExtensions - Class in net.ravendb.abstractions.extensions
 
JsonExtensions() - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions
 
JsonExtensions.DotNetNamingStrategy - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.DotNetNamingStrategy() - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.DotNetNamingStrategy
 
JsonExtensions.EtagDeserializer - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.RavenEnumDeserializer<T extends Enum<?>> - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.RavenEnumDeserializer(Class<T>) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenEnumDeserializer
 
JsonExtensions.RavenEnumSerializer - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.RavenEnumSerializer(Class<? extends Enum<?>>) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenEnumSerializer
 
JsonExtensions.RavenEnumSetSerializer - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.RavenEnumSetSerializer(Class<? extends Enum<?>>) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenEnumSetSerializer
 
JsonExtensions.RavenJTokenDeserializer<T extends RavenJToken> - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.RavenJTokenDeserializer(Class<T>) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenJTokenDeserializer
 
JsonExtensions.RavenJTokenSerializer<T extends RavenJToken> - Class in net.ravendb.abstractions.extensions
 
JsonExtensions.RavenJTokenSerializer(Class<?>, boolean) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenJTokenSerializer
 
JsonExtensions.RavenJTokenSerializer(Class<T>) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenJTokenSerializer
 
JsonExtensions.RavenJTokenSerializer(JavaType) - Constructor for class net.ravendb.abstractions.extensions.JsonExtensions.RavenJTokenSerializer
 
JsonReaderException - Exception in net.ravendb.abstractions.exceptions
 
JsonReaderException() - Constructor for exception net.ravendb.abstractions.exceptions.JsonReaderException
 
JsonReaderException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.JsonReaderException
 
JsonReaderException(String) - Constructor for exception net.ravendb.abstractions.exceptions.JsonReaderException
 
JsonReaderException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.JsonReaderException
 
jsonRequestFactory - Variable in class net.ravendb.client.connection.ServerClient
 
jsonRequestFactory - Variable in class net.ravendb.client.document.DocumentStore
 
JsonSerializer - Class in net.ravendb.client.document
 
JsonSerializer() - Constructor for class net.ravendb.client.document.JsonSerializer
 
JsonSerializer(DocumentConvention) - Constructor for class net.ravendb.client.document.JsonSerializer
 
JsonWriterException - Exception in net.ravendb.abstractions.exceptions
 
JsonWriterException() - Constructor for exception net.ravendb.abstractions.exceptions.JsonWriterException
 
JsonWriterException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.JsonWriterException
 
JsonWriterException(String) - Constructor for exception net.ravendb.abstractions.exceptions.JsonWriterException
 
JsonWriterException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.JsonWriterException
 
JTokenExtensions - Class in net.ravendb.abstractions.json
 
JTokenExtensions() - Constructor for class net.ravendb.abstractions.json.JTokenExtensions
 
JTokenType - Enum in net.ravendb.abstractions.json.linq
Specified the type of token.

K

keys() - Method in class net.ravendb.querydsl.RavenMap
 
keySet() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
knownMissingIds - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 

L

Lang - Class in net.ravendb.client.utils
 
Lang() - Constructor for class net.ravendb.client.utils.Lang
 
LAST_MODIFIED - Static variable in class net.ravendb.abstractions.data.Constants
 
lastEquality - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
lastEtagLocker - Variable in class net.ravendb.client.util.GlobalLastEtagHolder
 
LastEtagsInfo - Class in net.ravendb.abstractions.smuggler
 
LastEtagsInfo() - Constructor for class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
lastReplicatedEtagFor(String, String, String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
lastReplicationUpdate - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
lastRequestedUtc1 - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
lastRequestedUtc2 - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
lastServerPrefix - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
latitude - Variable in class net.ravendb.abstractions.indexing.SpatialOptions.SpatialSort
 
lazily() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Register the query as a lazy query in the session and return a lazy instance that will evaluate the query only when needed
lazily(Action1<List<T>>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Register the query as a lazy query in the session and return a lazy instance that will evaluate the query only when needed
lazily() - Method in class net.ravendb.client.document.DocumentSession
Access the lazy operations
lazily() - Method in interface net.ravendb.client.IDocumentQuery
Register the query as a lazy query in the session and return a lazy instance that will evaluate the query only when needed
lazily(Action1<List<T>>) - Method in interface net.ravendb.client.IDocumentQuery
Register the query as a lazy query in the session and return a lazy instance that will evaluate the query only when needed.
lazily() - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Access the lazy operations
lazily(Class<T>, Expression<?>, Action1<List<T>>) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Convert the Linq query to a lazy Lucene query and provide a function to execute when it is being evaluate
lazily() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
lazily(Action1<List<T>>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
lazily(Class<S>, Expression<?>, Action1<List<S>>) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
lazily() - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
lazily(Action1<List<T>>) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
lazily(Action1<List<T>>) - Method in class net.ravendb.client.shard.ShardedDocumentQuery
Register the query as a lazy query in the session and return a lazy instance that will evaluate the query only when needed
lazily() - Method in class net.ravendb.client.shard.ShardedDocumentSession
Access the lazy operations
Lazy<T> - Class in net.ravendb.abstractions.basic
 
Lazy(Function0<T>) - Constructor for class net.ravendb.abstractions.basic.Lazy
 
LazyFacetsOperation - Class in net.ravendb.client.document
 
LazyFacetsOperation(String, String, IndexQuery) - Constructor for class net.ravendb.client.document.LazyFacetsOperation
 
LazyFacetsOperation(String, String, IndexQuery, int) - Constructor for class net.ravendb.client.document.LazyFacetsOperation
 
LazyFacetsOperation(String, String, IndexQuery, int, Integer) - Constructor for class net.ravendb.client.document.LazyFacetsOperation
 
LazyFacetsOperation(String, List<Facet>, IndexQuery) - Constructor for class net.ravendb.client.document.LazyFacetsOperation
 
LazyFacetsOperation(String, List<Facet>, IndexQuery, int) - Constructor for class net.ravendb.client.document.LazyFacetsOperation
 
LazyFacetsOperation(String, List<Facet>, IndexQuery, int, Integer) - Constructor for class net.ravendb.client.document.LazyFacetsOperation
 
lazyLoadInternal(Class<T>, String[], Tuple<String, Class<?>>[], Action1<T[]>) - Method in class net.ravendb.client.document.DocumentSession
Register to lazily load documents and include
lazyLoadInternal(Class<T>, String[], Tuple<String, Class<?>>[], Action1<T[]>) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
lazyLoadInternal(Class<T>, String[], Tuple<String, Class<?>>[], Action1<T[]>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
LazyLoadOperation<T> - Class in net.ravendb.client.document.batches
 
LazyLoadOperation(Class<T>, String, LoadOperation) - Constructor for class net.ravendb.client.document.batches.LazyLoadOperation
 
LazyMoreLikeThisOperation<T> - Class in net.ravendb.client.document.batches
 
LazyMoreLikeThisOperation(Class<T>, MultiLoadOperation, MoreLikeThisQuery) - Constructor for class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
LazyMultiLoaderWithInclude - Class in net.ravendb.client.document.batches
 
LazyMultiLoaderWithInclude(IDocumentSessionImpl) - Constructor for class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
Initializes a new instance of the LazyMultiLoaderWithInclude class.
LazyMultiLoadOperation<T> - Class in net.ravendb.client.document.batches
 
LazyMultiLoadOperation(Class<T>, MultiLoadOperation, String[], Tuple<String, Class<?>>[], String) - Constructor for class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
LazyQueryOperation<T> - Class in net.ravendb.client.document.batches
 
LazyQueryOperation(Class<T>, QueryOperation, Action1<QueryResult>, Set<String>, Map<String, String>) - Constructor for class net.ravendb.client.document.batches.LazyQueryOperation
 
LazySessionOperations - Class in net.ravendb.client.document
 
LazySessionOperations(DocumentSession) - Constructor for class net.ravendb.client.document.LazySessionOperations
 
LazyShardSessionOperations - Class in net.ravendb.client.document
 
LazyShardSessionOperations(ShardedDocumentSession) - Constructor for class net.ravendb.client.document.LazyShardSessionOperations
 
LazyStartsWithOperation<T> - Class in net.ravendb.client.document.batches
 
LazyStartsWithOperation(Class<T>, String, String, String, int, int, InMemoryDocumentSessionOperations, RavenPagingInformation, String) - Constructor for class net.ravendb.client.document.batches.LazyStartsWithOperation
 
LazySuggestOperation - Class in net.ravendb.client.document.batches
 
LazySuggestOperation(String, SuggestionQuery) - Constructor for class net.ravendb.client.document.batches.LazySuggestOperation
 
LazyTransformerLoadOperation<T> - Class in net.ravendb.client.document.batches
 
LazyTransformerLoadOperation(Class<T>, String[], String, Map<String, RavenJToken>, LoadTransformerOperation, boolean) - Constructor for class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
LicensingStatus - Class in net.ravendb.abstractions.data
 
LicensingStatus() - Constructor for class net.ravendb.abstractions.data.LicensingStatus
 
LinqExtensionsQueryable<T> - Interface in net.ravendb.client
 
LinqOps - Class in net.ravendb.abstractions
Linq Operations
LinqOps() - Constructor for class net.ravendb.abstractions.LinqOps
 
LinqOps.Ops - Class in net.ravendb.abstractions
 
LinqOps.Ops() - Constructor for class net.ravendb.abstractions.LinqOps.Ops
 
LinqOps.Query - Class in net.ravendb.abstractions
 
LinqOps.Query() - Constructor for class net.ravendb.abstractions.LinqOps.Query
 
LinqPathProvider - Class in net.ravendb.client.linq
 
LinqPathProvider(Convention) - Constructor for class net.ravendb.client.linq.LinqPathProvider
 
LinqPathProvider.Result - Class in net.ravendb.client.linq
 
LinqPathProvider.Result() - Constructor for class net.ravendb.client.linq.LinqPathProvider.Result
 
load(JsonParser) - Static method in class net.ravendb.abstractions.json.linq.RavenJArray
 
load(JsonParser) - Static method in class net.ravendb.abstractions.json.linq.RavenJObject
 
load(JsonParser) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
 
load(Class<TResult>, String...) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entities with the specified ids.
load(Class<TResult>, Collection<String>) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entities with the specified ids.
load(Class<TResult>, String) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entity with the specified id.
load(Class<TResult>, Number) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, Number...) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID...) - Method in interface net.ravendb.client.document.batches.ILazyLoaderWithInclude
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, String[]) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified ids.
load(Class<TResult>, String[], Action1<TResult[]>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified ids and a function to call when it is evaluated
load(Class<TResult>, Collection<String>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified ids.
load(Class<TResult>, Collection<String>, Action1<TResult[]>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified ids and a function to call when it is evaluated
load(Class<TResult>, String) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified id.
load(Class<TResult>, String, Action1<TResult>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified id and a function to call when it is evaluated
load(Class<TResult>, Number) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, Number, Action1<TResult>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID, Action1<TResult>) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, Number...) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID...) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, Action1<TResult[]>, Number...) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, Action1<TResult[]>, UUID...) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Performs a load that will use the specified results transformer against the specified id
load(Class<TTransformer>, Class<TResult>, String[], LoadConfigurationFactory) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Performs a load that will use the specified results transformer against the specified id
load(Class<TResult>, String...) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<TResult>, Collection<String>) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<TResult>, String) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<TResult>, Number) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<TResult>, UUID) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<TResult>, Number...) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<TResult>, UUID...) - Method in class net.ravendb.client.document.batches.LazyMultiLoaderWithInclude
 
load(Class<T>, String) - Method in class net.ravendb.client.document.DocumentSession
Loads the specified entity with the specified id.
load(Class<T>, Collection<String>) - Method in class net.ravendb.client.document.DocumentSession
Loads the specified entities with the specified ids.
load(Class<T>, String...) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<T>, Number) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<T>, UUID) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<T>, Number...) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<T>, UUID...) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TTransformer>, Class<TResult>, String) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TTransformer>, Class<TResult>, String...) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TTransformer>, Class<TResult>, List<String>, LoadConfigurationFactory) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TResult>, String, String) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TResult>, String, String, LoadConfigurationFactory) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TResult>, String, Collection<String>) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TResult>, String, Collection<String>, LoadConfigurationFactory) - Method in class net.ravendb.client.document.DocumentSession
 
load(Class<TResult>, String...) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified ids.
load(Class<TResult>, Collection<String>) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified ids.
load(Class<TResult>, String) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified id.
load(Class<TResult>, Number) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, UUID...) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TResult>, Number...) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Performs a load that will use the specified results transformer against the specified id
load(Class<TTransformer>, Class<TResult>, String[], LoadConfigurationFactory) - Method in interface net.ravendb.client.document.ILoaderWithInclude
Performs a load that will use the specified results transformer against the specified id
load(Class<T>, String[]) - Method in class net.ravendb.client.document.LazySessionOperations
Loads the specified ids.
load(Class<TResult>, String[], Action1<TResult[]>) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, Collection<String>) - Method in class net.ravendb.client.document.LazySessionOperations
Loads the specified ids.
load(Class<T>, String) - Method in class net.ravendb.client.document.LazySessionOperations
Loads the specified id.
load(Class<TResult>, Collection<String>, Action1<TResult[]>) - Method in class net.ravendb.client.document.LazySessionOperations
Loads the specified ids and a function to call when it is evaluated
load(Class<T>, String, Action1<T>) - Method in class net.ravendb.client.document.LazySessionOperations
Loads the specified id and a function to call when it is evaluated
load(Class<T>, Number, Action1<T>) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, UUID, Action1<T>) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, Number...) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, UUID...) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<TResult>, Action1<TResult[]>, Number...) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<TResult>, Action1<TResult[]>, UUID...) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<TTransformer>, Class<TResult>, String[], LoadConfigurationFactory) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, Number) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, UUID) - Method in class net.ravendb.client.document.LazySessionOperations
 
load(Class<T>, String[]) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Loads the specified ids.
load(Class<TResult>, String[], Action1<TResult[]>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<T>, Collection<String>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Loads the specified ids.
load(Class<T>, String) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Loads the specified id.
load(Class<TResult>, Collection<String>, Action1<TResult[]>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Loads the specified ids and a function to call when it is evaluated
load(Class<T>, String, Action1<T>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
Loads the specified id and a function to call when it is evaluated
load(Class<T>, Number, Action1<T>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<T>, UUID, Action1<T>) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<T>, Number...) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<T>, UUID...) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<TResult>, Action1<TResult[]>, Number...) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<TResult>, Action1<TResult[]>, UUID...) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<TTransformer>, Class<TResult>, String[], LoadConfigurationFactory) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<T>, Number) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<T>, UUID) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
load(Class<TResult>, String...) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TResult>, Collection<String>) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TResult>, String) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TResult>, Number) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TResult>, UUID) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TResult>, UUID...) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TResult>, Number...) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<TTransformer>, Class<TResult>, String[], LoadConfigurationFactory) - Method in class net.ravendb.client.document.MultiLoaderWithInclude
 
load(Class<T>, String) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entity with the specified id.
load(Class<T>, String...) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entities with the specified ids.
load(Class<T>, Collection<String>) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entities with the specified ids.
load(Class<T>, Number) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<T>, UUID) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entity with the specified id after applying conventions on the provided id to get the real document id.
load(Class<T>, Number...) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<T>, UUID...) - Method in interface net.ravendb.client.IDocumentSession
Loads the specified entities with the specified id after applying conventions on the provided id to get the real document id.
load(Class<TTransformer>, Class<TResult>, String) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TTransformer>, Class<TResult>, String...) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TTransformer>, Class<TResult>, List<String>, LoadConfigurationFactory) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TResult>, String, String) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TResult>, String, String, LoadConfigurationFactory) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TResult>, String, Collection<String>) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TResult>, String, Collection<String>, LoadConfigurationFactory) - Method in interface net.ravendb.client.IDocumentSession
Performs a load that will use the specified results transformer against the specified id
load(Class<TTransformer>, Class<TResult>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TTransformer>, Class<TResult>, String, LoadConfigurationFactory) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<T>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<T>, Collection<String>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
Loads the specified entities with the specified ids.
load(Class<T>, String...) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<T>, Number) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<T>, UUID) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<T>, Number...) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<T>, UUID...) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TTransformer>, Class<TResult>, List<String>, LoadConfigurationFactory) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TResult>, String, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TResult>, String, String, LoadConfigurationFactory) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TResult>, String, Collection<String>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TResult>, String, Collection<String>, LoadConfigurationFactory) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
load(Class<TTransformer>, Class<TResult>, String...) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
LoadConfigurationFactory - Class in net.ravendb.client
 
LoadConfigurationFactory() - Constructor for class net.ravendb.client.LoadConfigurationFactory
 
LoadConfigurationFactory(Set<Action1<ILoadConfiguration>>, Action1<ILoadConfiguration>) - Constructor for class net.ravendb.client.LoadConfigurationFactory
 
LoadedDatabaseStatistics - Class in net.ravendb.abstractions.data
 
LoadedDatabaseStatistics() - Constructor for class net.ravendb.abstractions.data.LoadedDatabaseStatistics
 
loadInternal(Class<T>, String[], String) - Method in class net.ravendb.client.document.DocumentSession
 
loadInternal(Class<T>, String[], String, Map<String, RavenJToken>) - Method in class net.ravendb.client.document.DocumentSession
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[], String) - Method in class net.ravendb.client.document.DocumentSession
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[], String, Map<String, RavenJToken>) - Method in class net.ravendb.client.document.DocumentSession
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[]) - Method in class net.ravendb.client.document.DocumentSession
 
loadInternal(Class<T>, String[]) - Method in class net.ravendb.client.document.DocumentSession
 
loadInternal(Class<T>, String[]) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[]) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
loadInternal(Class<T>, String[], String) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
loadInternal(Class<T>, String[], String, Map<String, RavenJToken>) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[], String) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[], String, Map<String, RavenJToken>) - Method in interface net.ravendb.client.IDocumentSessionImpl
 
loadInternal(Class<T>, String[], String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadInternal(Class<T>, String[], String, Map<String, RavenJToken>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[], String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[], String, Map<String, RavenJToken>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadInternal(Class<T>, String[]) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadInternal(Class<T>, String[], Tuple<String, Class<?>>[]) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
LoadOperation - Class in net.ravendb.client.document.sessionoperations
 
LoadOperation(InMemoryDocumentSessionOperations, Function0<CleanCloseable>, String) - Constructor for class net.ravendb.client.document.sessionoperations.LoadOperation
 
loadStartingWith(Class<TResult>, String) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Load documents with the specified key prefix
loadStartingWith(Class<TResult>, String, String) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Load documents with the specified key prefix
loadStartingWith(Class<TResult>, String, String, int) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Load documents with the specified key prefix
loadStartingWith(Class<TResult>, String, String, int, int) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Load documents with the specified key prefix
loadStartingWith(Class<TResult>, String, String, int, int, String) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Load documents with the specified key prefix
loadStartingWith(Class<TResult>, String, String, int, int, String, RavenPagingInformation) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads multiple entities that contain common prefix.
loadStartingWith(Class<TResult>, String, String, int, int, String, RavenPagingInformation, String) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String, String, int) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String, String, int, int) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String, String, int, int, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String, String, int, int, String, RavenPagingInformation, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation, LoadConfigurationFactory) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation, LoadConfigurationFactory, String) - Method in class net.ravendb.client.document.DocumentSession
 
loadStartingWith(Class<T>, String) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<T>, String, String) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<T>, String, String, int) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<T>, String, String, int, int) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<TResult>, String, String, int, int, String) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<TResult>, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<TResult>, String, String, int, int, String, RavenPagingInformation, String) - Method in class net.ravendb.client.document.LazySessionOperations
 
loadStartingWith(Class<T>, String) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<T>, String, String) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<T>, String, String, int) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<T>, String, String, int, int) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<TResult>, String, String, int, int, String) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<TResult>, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<TResult>, String, String, int, int, String, RavenPagingInformation, String) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
loadStartingWith(Class<T>, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String, String, int) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String, String, int, int) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String, String, int, int, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String, String, int, int, String, RavenPagingInformation) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<T>, String, String, int, int, String, RavenPagingInformation, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads multiple entities that contain common prefix.
loadStartingWith(Class<TResult>, Class<TTransformer>, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation, LoadConfigurationFactory) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation, LoadConfigurationFactory, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Loads documents with the specified key prefix and applies the specified results transformer against the results
loadStartingWith(Class<T>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<T>, String, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<T>, String, String, int) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<T>, String, String, int, int) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<T>, String, String, int, int, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<T>, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<T>, String, String, int, int, String, RavenPagingInformation, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation, LoadConfigurationFactory) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
loadStartingWith(Class<TResult>, Class<TTransformer>, String, String, int, int, String, RavenPagingInformation, LoadConfigurationFactory, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
LoadTransformerOperation - Class in net.ravendb.client.document.sessionoperations
 
LoadTransformerOperation(InMemoryDocumentSessionOperations, String, String[]) - Constructor for class net.ravendb.client.document.sessionoperations.LoadTransformerOperation
 
localConnectionState - Variable in class net.ravendb.client.changes.TaskedObservable
 
log(LogLevel, String) - Method in interface net.ravendb.abstractions.logging.ILog
 
log(LogLevel, String, Exception) - Method in interface net.ravendb.abstractions.logging.ILog
 
log(LogLevel, String) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
log(LogLevel, String, Exception) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
log - Static variable in class net.ravendb.client.connection.ReplicationInformerBase
 
log - Static variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
logBatch(SaveChangesData) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
logger - Static variable in class net.ravendb.client.changes.RemoteChangesClientBase
 
logger - Static variable in class net.ravendb.client.document.Subscription
 
LogItem - Class in net.ravendb.abstractions.data
 
LogItem() - Constructor for class net.ravendb.abstractions.data.LogItem
 
LogLevel - Enum in net.ravendb.abstractions.logging
 
LogManager - Class in net.ravendb.abstractions.logging
 
LogManager() - Constructor for class net.ravendb.abstractions.logging.LogManager
 
logOnConnectionStatusChanged(Object, EventArgs) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
logOperation() - Method in class net.ravendb.client.document.sessionoperations.LoadOperation
 
logOperation() - Method in class net.ravendb.client.document.sessionoperations.MultiLoadOperation
 
logQuery() - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
LONG_COUNT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
longCount() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Performs count query.
longCount(BooleanExpression) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Performs count query - each result must match specified predicate.
longCount() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
longCount(BooleanExpression) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
longitude - Variable in class net.ravendb.abstractions.indexing.SpatialOptions.SpatialSort
 

M

makePoint(double, double) - Method in class net.ravendb.abstractions.spatial.ShapeConverter
 
ManualResetEvent - Class in net.ravendb.abstractions.util
 
ManualResetEvent(boolean) - Constructor for class net.ravendb.abstractions.util.ManualResetEvent
 
map - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
markReadOnly(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Mark the entity as read only, change tracking won't apply to such an entity.
markReadOnly(Object) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Mark the entity as read only, change tracking won't apply to such an entity.
max - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase.RangeValue
 
maxIndexOutputsPerDocument - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
maxOn(Path<?>) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
MergeQueryResultsFunc - Interface in net.ravendb.client.shard
 
MergeSuggestions - Class in net.ravendb.abstractions.indexing
 
MergeSuggestions() - Constructor for class net.ravendb.abstractions.indexing.MergeSuggestions
 
METADATA - Static variable in class net.ravendb.abstractions.data.Constants
 
METADATA_ETAG_FIELD - Static variable in class net.ravendb.abstractions.data.Constants
 
MetadataExtensions - Class in net.ravendb.abstractions.extensions
Extensions for handling metadata
MetadataExtensions() - Constructor for class net.ravendb.abstractions.extensions.MetadataExtensions
 
metadataShardIdFor(Object) - Method in class net.ravendb.client.shard.DefaultShardResolutionStrategy
The shard id for the server that contains the metadata (such as the HiLo documents) for the given entity
metadataShardIdFor(Object) - Method in interface net.ravendb.client.shard.IShardResolutionStrategy
The shard id for the server that contains the metadata (such as the HiLo documents) for the given entity
METHOD_NAME - Static variable in class net.ravendb.java.http.client.HttpEval
 
METHOD_NAME - Static variable in class net.ravendb.java.http.client.HttpReset
 
MetricType - Enum in net.ravendb.abstractions.data
 
MILES_TO_KM - Static variable in class net.ravendb.abstractions.data.Constants
 
min - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase.RangeValue
 
MINIMUM_SERVER_VERSION - Static variable in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
minOn(Path<?>) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
modifyCapacityIfRequired() - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
ModifyDocumentIdFunc - Interface in net.ravendb.client.shard
 
modifyObjectId(String, Object, RavenJObject) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
moreLikeThis(MoreLikeThisQuery) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Return a list of documents that based on the MoreLikeThisQuery.
moreLikeThis(MoreLikeThisQuery) - Method in class net.ravendb.client.connection.ServerClient
 
moreLikeThis(Class<TResult>, MoreLikeThisQuery) - Method in interface net.ravendb.client.document.batches.ILazySessionOperations
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, String) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, MoreLikeThisQuery) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<T>, String, String) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, Class<? extends AbstractTransformerCreationTask>, String) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, Class<? extends AbstractTransformerCreationTask>, MoreLikeThisQuery) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<T>, String, String, String) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<T>, String, String, MoreLikeThisQuery) - Method in class net.ravendb.client.document.DocumentSession
 
moreLikeThis(Class<TResult>, MoreLikeThisQuery) - Method in class net.ravendb.client.document.LazySessionOperations
 
moreLikeThis(Class<TResult>, MoreLikeThisQuery) - Method in class net.ravendb.client.document.LazyShardSessionOperations
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, MoreLikeThisQuery) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, String, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, Class<? extends AbstractTransformerCreationTask>, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, Class<? extends AbstractTransformerCreationTask>, MoreLikeThisQuery) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, String, String, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, String, String, MoreLikeThisQuery) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, MoreLikeThisQuery) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
moreLikeThis(Class<T>, String, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, Class<? extends AbstractTransformerCreationTask>, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
moreLikeThis(Class<T>, Class<? extends AbstractIndexCreationTask>, Class<? extends AbstractTransformerCreationTask>, MoreLikeThisQuery) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
moreLikeThis(Class<T>, String, String, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
moreLikeThis(Class<T>, String, String, MoreLikeThisQuery) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
MoreLikeThisQuery - Class in net.ravendb.abstractions.data
 
MoreLikeThisQuery() - Constructor for class net.ravendb.abstractions.data.MoreLikeThisQuery
 
MultiDatabase - Class in net.ravendb.client.extensions
Methods to create multitenant databases
MultiDatabase() - Constructor for class net.ravendb.client.extensions.MultiDatabase
 
MultiDatabaseHiLoGenerator - Class in net.ravendb.client.document
 
MultiDatabaseHiLoGenerator(int) - Constructor for class net.ravendb.client.document.MultiDatabaseHiLoGenerator
 
multiFacetedSearch(FacetQuery...) - Method in class net.ravendb.client.document.DocumentSession
 
multiFacetedSearch(FacetQuery...) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Sends a multiple faceted queries in a single request and calculates the facet results for each of them
multiFacetedSearch(FacetQuery...) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
multiGet(GetRequest[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a single POST request containing multiple nested GET requests
multiGet(GetRequest[]) - Method in class net.ravendb.client.connection.ServerClient
 
MultiGetOperation - Class in net.ravendb.client.connection
 
MultiGetOperation(IHoldProfilingInformation, DocumentConvention, String, GetRequest[]) - Constructor for class net.ravendb.client.connection.MultiGetOperation
 
MultiLoaderWithInclude - Class in net.ravendb.client.document
Fluent implementation for specifying include paths for loading documents
MultiLoaderWithInclude(IDocumentSessionImpl) - Constructor for class net.ravendb.client.document.MultiLoaderWithInclude
 
MultiLoadOperation - Class in net.ravendb.client.document.sessionoperations
 
MultiLoadOperation(InMemoryDocumentSessionOperations, Function0<CleanCloseable>, String[], Tuple<String, Class<?>>[]) - Constructor for class net.ravendb.client.document.sessionoperations.MultiLoadOperation
 
MultiLoadResult - Class in net.ravendb.abstractions.data
 
MultiLoadResult() - Constructor for class net.ravendb.abstractions.data.MultiLoadResult
 
MultiTypeHiLoKeyGenerator - Class in net.ravendb.client.document
Generate a hilo key for each given type
MultiTypeHiLoKeyGenerator(int) - Constructor for class net.ravendb.client.document.MultiTypeHiLoKeyGenerator
Initializes a new instance of the MultiTypeHiLoKeyGenerator class.

N

nameForConstructorParameter(MapperConfig<?>, AnnotatedParameter, String) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.DotNetNamingStrategy
 
nameForField(MapperConfig<?>, AnnotatedField, String) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.DotNetNamingStrategy
 
nameForGetterMethod(MapperConfig<?>, AnnotatedMethod, String) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.DotNetNamingStrategy
 
nameForSetterMethod(MapperConfig<?>, AnnotatedMethod, String) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.DotNetNamingStrategy
 
negate - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Whatever to negate the next operation
negateNext() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Negate the next operation
negateNext() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Negate the next operation
negateNext() - Method in interface net.ravendb.client.IDocumentQueryBase
Negate the next operation
net.ravendb.abstractions - package net.ravendb.abstractions
 
net.ravendb.abstractions.basic - package net.ravendb.abstractions.basic
 
net.ravendb.abstractions.closure - package net.ravendb.abstractions.closure
 
net.ravendb.abstractions.commands - package net.ravendb.abstractions.commands
 
net.ravendb.abstractions.connection - package net.ravendb.abstractions.connection
 
net.ravendb.abstractions.data - package net.ravendb.abstractions.data
 
net.ravendb.abstractions.exceptions - package net.ravendb.abstractions.exceptions
 
net.ravendb.abstractions.exceptions.subscriptions - package net.ravendb.abstractions.exceptions.subscriptions
 
net.ravendb.abstractions.extensions - package net.ravendb.abstractions.extensions
 
net.ravendb.abstractions.indexing - package net.ravendb.abstractions.indexing
 
net.ravendb.abstractions.json - package net.ravendb.abstractions.json
 
net.ravendb.abstractions.json.linq - package net.ravendb.abstractions.json.linq
 
net.ravendb.abstractions.logging - package net.ravendb.abstractions.logging
 
net.ravendb.abstractions.logging.providers - package net.ravendb.abstractions.logging.providers
 
net.ravendb.abstractions.oauth - package net.ravendb.abstractions.oauth
 
net.ravendb.abstractions.replication - package net.ravendb.abstractions.replication
 
net.ravendb.abstractions.smuggler - package net.ravendb.abstractions.smuggler
 
net.ravendb.abstractions.spatial - package net.ravendb.abstractions.spatial
 
net.ravendb.abstractions.util - package net.ravendb.abstractions.util
 
net.ravendb.client - package net.ravendb.client
 
net.ravendb.client.changes - package net.ravendb.client.changes
 
net.ravendb.client.connection - package net.ravendb.client.connection
 
net.ravendb.client.connection.implementation - package net.ravendb.client.connection.implementation
 
net.ravendb.client.connection.profiling - package net.ravendb.client.connection.profiling
 
net.ravendb.client.converters - package net.ravendb.client.converters
 
net.ravendb.client.delegates - package net.ravendb.client.delegates
 
net.ravendb.client.document - package net.ravendb.client.document
 
net.ravendb.client.document.batches - package net.ravendb.client.document.batches
 
net.ravendb.client.document.dtc - package net.ravendb.client.document.dtc
 
net.ravendb.client.document.sessionoperations - package net.ravendb.client.document.sessionoperations
 
net.ravendb.client.exceptions - package net.ravendb.client.exceptions
 
net.ravendb.client.extensions - package net.ravendb.client.extensions
 
net.ravendb.client.indexes - package net.ravendb.client.indexes
 
net.ravendb.client.linq - package net.ravendb.client.linq
 
net.ravendb.client.listeners - package net.ravendb.client.listeners
 
net.ravendb.client.shard - package net.ravendb.client.shard
 
net.ravendb.client.spatial - package net.ravendb.client.spatial
 
net.ravendb.client.util - package net.ravendb.client.util
 
net.ravendb.client.utils - package net.ravendb.client.utils
 
net.ravendb.client.utils.encryptors - package net.ravendb.client.utils.encryptors
 
net.ravendb.imports.json - package net.ravendb.imports.json
 
net.ravendb.java.http.client - package net.ravendb.java.http.client
 
net.ravendb.querydsl - package net.ravendb.querydsl
 
NetDateFormat - Class in net.ravendb.abstractions.util
Provides support for 7 characters in date fraction.
NetDateFormat() - Constructor for class net.ravendb.abstractions.util.NetDateFormat
 
NetISO8601Utils - Class in net.ravendb.abstractions.util
Based on ISO8601
NetISO8601Utils() - Constructor for class net.ravendb.abstractions.util.NetISO8601Utils
 
next() - Method in class net.ravendb.client.connection.RavenJObjectIterator
 
NEXT_PAGE_START - Static variable in class net.ravendb.abstractions.data.Constants
 
nextId(IDatabaseCommands) - Method in class net.ravendb.client.document.HiLoKeyGenerator
Create the next id (numeric)
nextIdentityFor(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Generate the next identity value from the server
nextIdentityFor(String) - Method in class net.ravendb.client.connection.ServerClient
 
noCaching() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
noCaching() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
noCaching() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Disables caching for query results.
noCaching() - Method in interface net.ravendb.client.IDocumentQueryBase
Disables caching for query results.
noCaching() - Method in interface net.ravendb.client.IDocumentQueryCustomization
Disables caching for query results.
NonAuthoritativeInformationException - Exception in net.ravendb.client.exceptions
 
NonAuthoritativeInformationException() - Constructor for exception net.ravendb.client.exceptions.NonAuthoritativeInformationException
 
NonAuthoritativeInformationException(String, Throwable) - Constructor for exception net.ravendb.client.exceptions.NonAuthoritativeInformationException
 
NonAuthoritativeInformationException(String) - Constructor for exception net.ravendb.client.exceptions.NonAuthoritativeInformationException
 
NonAuthoritativeInformationException(Throwable) - Constructor for exception net.ravendb.client.exceptions.NonAuthoritativeInformationException
 
NonUniqueObjectException - Exception in net.ravendb.client.exceptions
This exception is thrown when a separate instance of an entity is added to the session when a different entity with the same key already exists within the session.
NonUniqueObjectException() - Constructor for exception net.ravendb.client.exceptions.NonUniqueObjectException
 
NonUniqueObjectException(String, Throwable) - Constructor for exception net.ravendb.client.exceptions.NonUniqueObjectException
 
NonUniqueObjectException(String) - Constructor for exception net.ravendb.client.exceptions.NonUniqueObjectException
 
NonUniqueObjectException(Throwable) - Constructor for exception net.ravendb.client.exceptions.NonUniqueObjectException
 
not() - Method in class net.ravendb.client.document.DocumentQuery
 
not() - Method in interface net.ravendb.client.IDocumentQueryBase
Negate the next operation
notifySubscribers(String, RavenJObject, Iterable<Map.Entry<String, DatabaseConnectionState>>) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
notifySubscribers(String, RavenJObject, Iterable<Map.Entry<String, DatabaseConnectionState>>) - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
noTracking() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
noTracking() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
noTracking() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Disables tracking for queried entities by Raven's Unit of Work.
noTracking() - Method in interface net.ravendb.client.IDocumentQueryBase
Disables tracking for queried entities by Raven's Unit of Work.
noTracking() - Method in interface net.ravendb.client.IDocumentQueryCustomization
Disables tracking for queried entities by Raven's Unit of Work.
NULL_VALUE - Static variable in class net.ravendb.abstractions.data.Constants
 
NULL_VALUE_NOT_ANALYZED - Static variable in class net.ravendb.abstractions.data.Constants
 
numberToString(int) - Static method in class net.ravendb.abstractions.indexing.NumberUtil
Translate a number to an indexable string
numberToString(long) - Static method in class net.ravendb.abstractions.indexing.NumberUtil
Translate a number to an indexable string
numberToString(float) - Static method in class net.ravendb.abstractions.indexing.NumberUtil
Translate a number to an indexable string
numberToString(double) - Static method in class net.ravendb.abstractions.indexing.NumberUtil
Translate a number to an indexable string
NumberUtil - Class in net.ravendb.abstractions.indexing
Helper function for numeric to indexed string and vice versa
NumberUtil() - Constructor for class net.ravendb.abstractions.indexing.NumberUtil
 
numOfCachedRequests - Variable in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
numOfCacheResets - Variable in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 

O

OAuthHelper - Class in net.ravendb.abstractions.connection
 
OAuthHelper() - Constructor for class net.ravendb.abstractions.connection.OAuthHelper
 
OAuthHelper.Keys - Class in net.ravendb.abstractions.connection
 
OAuthHelper.Keys() - Constructor for class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
ObservableLineStream - Class in net.ravendb.client.connection
 
ObservableLineStream(InputStream, Action0) - Constructor for class net.ravendb.client.connection.ObservableLineStream
 
ObserverAdapter<T> - Class in net.ravendb.client.changes
 
ObserverAdapter() - Constructor for class net.ravendb.client.changes.ObserverAdapter
 
Observers - Class in net.ravendb.client.utils
 
Observers() - Constructor for class net.ravendb.client.utils.Observers
 
Observers.ActionBasedObserver<T> - Class in net.ravendb.client.utils
 
Observers.ActionBasedObserver(Action1<T>) - Constructor for class net.ravendb.client.utils.Observers.ActionBasedObserver
 
of(FacetAggregation...) - Static method in class net.ravendb.abstractions.data.FacetAggregationSet
 
of(ItemType...) - Static method in class net.ravendb.abstractions.smuggler.ItemTypeSet
 
of(FailoverBehavior...) - Static method in class net.ravendb.client.document.FailoverBehaviorSet
 
of(SearchOptions...) - Static method in class net.ravendb.client.SearchOptionsSet
 
onCompleted() - Method in interface net.ravendb.client.changes.IObserver
 
onCompleted() - Method in class net.ravendb.client.changes.ObserverAdapter
 
onCompleted() - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
onCompleted() - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
onCompleted() - Method in class net.ravendb.client.utils.Observers.ActionBasedObserver
 
onContextCreated - Static variable in class net.ravendb.client.connection.profiling.ProfilingInformation
A hook that allows extensions to provide additional information about the created context
onError(Exception) - Method in interface net.ravendb.client.changes.IObserver
 
onError(Exception) - Method in class net.ravendb.client.changes.ObserverAdapter
 
onError(Exception) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
onError(Exception) - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
onError(Exception) - Method in class net.ravendb.client.utils.Observers.ActionBasedObserver
 
onEvaluateLazy - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
onEvaluateLazy - Variable in class net.ravendb.client.shard.BaseShardedDocumentSession
 
onLogRequest(IHoldProfilingInformation, RequestResultArgs) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
onNext(T) - Method in interface net.ravendb.client.changes.IObserver
 
onNext(String) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
onNext(BulkInsertChangeNotification) - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
onNext(DocumentChangeNotification) - Method in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges.DocumentChangeObserver
 
onNext(IndexChangeNotification) - Method in class net.ravendb.client.util.EvictItemsFromCacheBasedOnChanges.IndexChangeObserver
 
onNext(T) - Method in class net.ravendb.client.utils.Observers.ActionBasedObserver
 
open(Class<T>, long, SubscriptionConnectionOptions) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
open(Class<T>, long, SubscriptionConnectionOptions, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
open(long, SubscriptionConnectionOptions) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
open(long, SubscriptionConnectionOptions, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
open(Class<T>, long, SubscriptionConnectionOptions) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It opens a subscription and starts pulling documents since a last processed document for that subscription (in document's Etag order).
open(Class<T>, long, SubscriptionConnectionOptions, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It opens a subscription and starts pulling documents since a last processed document for that subscription (in document's Etag order).
open(long, SubscriptionConnectionOptions) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It opens a subscription and starts pulling documents since a last processed document for that subscription (in document's Etag order).
open(long, SubscriptionConnectionOptions, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It opens a subscription and starts pulling documents since a last processed document for that subscription (in document's Etag order).
openRead(String) - Method in interface net.ravendb.client.document.dtc.ITransactionRecoveryStorageContext
 
openRead(String) - Method in class net.ravendb.client.document.dtc.VolatileOnlyTransactionRecoveryStorage
 
openSession() - Method in class net.ravendb.client.document.DocumentStore
Opens the session.
openSession(String) - Method in class net.ravendb.client.document.DocumentStore
Opens the session for a particular database
openSession(OpenSessionOptions) - Method in class net.ravendb.client.document.DocumentStore
 
openSession() - Method in interface net.ravendb.client.IDocumentStore
Opens the session.
openSession(String) - Method in interface net.ravendb.client.IDocumentStore
Opens the session for a particular database
openSession(OpenSessionOptions) - Method in interface net.ravendb.client.IDocumentStore
Opens the session with the specified options.
openSession() - Method in class net.ravendb.client.shard.ShardedDocumentStore
Opens the session.
openSession(String) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Opens the session for a particular database
openSession(OpenSessionOptions) - Method in class net.ravendb.client.shard.ShardedDocumentStore
Opens the session with the specified options.
OpenSessionOptions - Class in net.ravendb.client.document
 
OpenSessionOptions() - Constructor for class net.ravendb.client.document.OpenSessionOptions
 
openSubclause() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Simplified method for opening a new clause within the query
openSubclause() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Simplified method for opening a new clause within the query
openSubclause() - Method in interface net.ravendb.client.IDocumentQueryBase
Simplified method for opening a new clause within the query
Operation - Class in net.ravendb.client.connection
 
Operation(ServerClient, long) - Constructor for class net.ravendb.client.connection.Operation
 
Operation(Function1<Long, RavenJToken>, long) - Constructor for class net.ravendb.client.connection.Operation
 
Operation(long, RavenJToken) - Constructor for class net.ravendb.client.connection.Operation
 
operation - Variable in class net.ravendb.client.document.BulkInsertOperation
 
OperationCancelledException - Exception in net.ravendb.abstractions.exceptions
 
OperationCancelledException() - Constructor for exception net.ravendb.abstractions.exceptions.OperationCancelledException
 
OperationCancelledException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.OperationCancelledException
 
OperationCancelledException(String) - Constructor for exception net.ravendb.abstractions.exceptions.OperationCancelledException
 
OperationCancelledException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.OperationCancelledException
 
OperationCredentials - Class in net.ravendb.abstractions.connection
 
OperationCredentials() - Constructor for class net.ravendb.abstractions.connection.OperationCredentials
 
OperationCredentials(OperationCredentials) - Constructor for class net.ravendb.abstractions.connection.OperationCredentials
 
OperationCredentials(String) - Constructor for class net.ravendb.abstractions.connection.OperationCredentials
 
OperationMetadata - Class in net.ravendb.client.connection
 
OperationMetadata(String) - Constructor for class net.ravendb.client.connection.OperationMetadata
 
OperationMetadata(String, OperationCredentials) - Constructor for class net.ravendb.client.connection.OperationMetadata
 
OperationMetadata(OperationMetadata) - Constructor for class net.ravendb.client.connection.OperationMetadata
 
operationsHeaders - Variable in class net.ravendb.client.connection.ServerClient
 
OperationState - Class in net.ravendb.abstractions.smuggler
 
OperationState() - Constructor for class net.ravendb.abstractions.smuggler.OperationState
 
ORDER_BY - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
ORDER_BY_SCORE - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
orderBy(String...) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by ascending.
orderBy(Expression<?>...) - Method in class net.ravendb.client.document.DocumentQuery
 
orderBy(String...) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by ascending.
orderBy(String...) - Method in interface net.ravendb.client.IDocumentQueryBase
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by ascending.
orderBy(Expression<?>...) - Method in interface net.ravendb.client.IDocumentQueryBase
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by ascending.
orderBy(OrderSpecifier<?>...) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Changes order of result elements
orderBy(OrderSpecifier<?>...) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
orderByDescending(String...) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by descending.
orderByDescending(Expression<?>...) - Method in class net.ravendb.client.document.DocumentQuery
 
orderByDescending(String...) - Method in interface net.ravendb.client.IDocumentQueryBase
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by descending.
orderByDescending(Expression<?>...) - Method in interface net.ravendb.client.IDocumentQueryBase
Order the results by the specified fields The fields are the names of the fields to sort, defaulting to sorting by descending.
orderByDistance(SpatialOptions.SpatialSort) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
orderByFields - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The fields to order the results by
orderByScore() - Method in class net.ravendb.client.document.DocumentQuery
 
orderByScore() - Method in interface net.ravendb.client.IDocumentQueryBase
Adds an ordering by score for a specific field to the query
orderByScore() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
orderByScore() - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
orderByScoreDescending() - Method in class net.ravendb.client.document.DocumentQuery
 
orderByScoreDescending() - Method in interface net.ravendb.client.IDocumentQueryBase
Adds an ordering by score for a specific field to the query
orElse() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Add an OR to the query
orElse() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Add an OR to the query
orElse() - Method in interface net.ravendb.client.IDocumentQueryBase
Add an OR to the query
outro(EntityType, CodeWriter) - Method in class net.ravendb.querydsl.RavenEntitySerializer
 

P

pageSize - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The page size to use when querying the index
ParallelShardAccessStrategy - Class in net.ravendb.client.shard
ParallelShardAccessStrategy NOTE: Remember to close this instance!
ParallelShardAccessStrategy() - Constructor for class net.ravendb.client.shard.ParallelShardAccessStrategy
 
parse() - Method in class net.ravendb.abstractions.data.ConnectionStringParser
 
parse(byte[]) - Static method in class net.ravendb.abstractions.data.Etag
 
parse(String) - Static method in class net.ravendb.abstractions.data.Etag
 
parse(BooleanExpression) - Static method in class net.ravendb.abstractions.data.Facet
 
parse(String) - Static method in class net.ravendb.abstractions.json.linq.RavenJArray
Load a RavenJArray from a string that contains JSON.
parse(String) - Static method in class net.ravendb.abstractions.json.linq.RavenJObject
Loads RavenJObject from a string that contains JSON.
parse(String) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
Load a RavenJToken from a string that contains JSON.
parse(String, ParsePosition) - Method in class net.ravendb.abstractions.util.NetDateFormat
 
parse(String) - Static method in class net.ravendb.abstractions.util.NetISO8601Utils
Parse a date from ISO-8601 formatted string.
parseBytes(String) - Static method in class net.ravendb.abstractions.connection.OAuthHelper
 
parseConnectionString(String) - Method in class net.ravendb.client.document.DocumentStore
Set document store settings based on a given connection string.
parseDictionary(String) - Static method in class net.ravendb.abstractions.connection.OAuthHelper
 
patch(String, PatchRequest[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document, ignoring the document's Etag and if the document is missing
patch(String, PatchRequest[], boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document, ignoring the document's Etag
patch(String, ScriptedPatchRequest) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document, ignoring the document's Etag and if the document is missing
patch(String, ScriptedPatchRequest, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document, ignoring the document's Etag
patch(String, PatchRequest[], Etag) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document
patch(String, PatchRequest[], PatchRequest[], RavenJObject) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document which may or may not currently exist
patch(String, ScriptedPatchRequest, Etag) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document
patch(String, ScriptedPatchRequest, ScriptedPatchRequest, RavenJObject) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sends a patch request for a specific document which may or may not currently exist
patch(String, PatchRequest[]) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, PatchRequest[], boolean) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, ScriptedPatchRequest) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, ScriptedPatchRequest, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, PatchRequest[], Etag) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, PatchRequest[], PatchRequest[], RavenJObject) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, ScriptedPatchRequest, Etag) - Method in class net.ravendb.client.connection.ServerClient
 
patch(String, ScriptedPatchRequest, ScriptedPatchRequest, RavenJObject) - Method in class net.ravendb.client.connection.ServerClient
 
PatchCommandData - Class in net.ravendb.abstractions.commands
 
PatchCommandData() - Constructor for class net.ravendb.abstractions.commands.PatchCommandData
 
PatchCommandType - Enum in net.ravendb.abstractions.data
 
PatchRequest - Class in net.ravendb.abstractions.data
A patch request for a specified document
PatchRequest() - Constructor for class net.ravendb.abstractions.data.PatchRequest
 
PatchRequest(PatchCommandType, String, RavenJToken) - Constructor for class net.ravendb.abstractions.data.PatchRequest
 
PatchResult - Enum in net.ravendb.abstractions.data
 
PatchResultData - Class in net.ravendb.abstractions.data
 
PatchResultData() - Constructor for class net.ravendb.abstractions.data.PatchResultData
 
pendingLazyOperations - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
pendingLazyOperations - Variable in class net.ravendb.client.shard.BaseShardedDocumentSession
 
pluralize(String) - Static method in class net.ravendb.client.util.Inflector
 
posInBuffer - Variable in class net.ravendb.client.connection.ObservableLineStream
 
potentialShardsFor(ShardRequestData) - Method in class net.ravendb.client.shard.DefaultShardResolutionStrategy
Selects the shard ids appropriate for the specified data.
potentialShardsFor(ShardRequestData) - Method in interface net.ravendb.client.shard.IShardResolutionStrategy
Selects the shard ids appropriate for the specified data.
Predicate<T> - Interface in net.ravendb.abstractions.closure
 
Predicates - Class in net.ravendb.abstractions.closure
 
Predicates() - Constructor for class net.ravendb.abstractions.closure.Predicates
 
Predicates.AndPredicate<T> - Class in net.ravendb.abstractions.closure
 
Predicates.AndPredicate(Predicate<T>, Predicate<T>) - Constructor for class net.ravendb.abstractions.closure.Predicates.AndPredicate
 
Predicates.False<T> - Class in net.ravendb.abstractions.closure
 
Predicates.False() - Constructor for class net.ravendb.abstractions.closure.Predicates.False
 
Predicates.True<T> - Class in net.ravendb.abstractions.closure
 
Predicates.True() - Constructor for class net.ravendb.abstractions.closure.Predicates.True
 
PrefetchingUser - Enum in net.ravendb.abstractions.data
 
PREFIXES_IN_HEADERS_TO_IGNORE_CLIENT - Static variable in class net.ravendb.abstractions.extensions.MetadataExtensions
 
prepareForSaveChanges() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Prepares for save changes.
preparingForCachingRequest(HttpJsonRequestFactory) - Method in class net.ravendb.client.connection.MultiGetOperation
 
process(HttpResponse, HttpContext) - Method in class net.ravendb.java.http.client.RavenResponseContentEncoding
Handles the following Content-Encodings by using the appropriate decompressor to wrap the response Entity: gzip - see GzipDecompressingEntity deflate - see DeflateDecompressingEntity identity - no action needed
processConnectionStringOption(String, String) - Method in class net.ravendb.abstractions.data.ConnectionStringParser
Parse the connection string option
ProfilingContext - Class in net.ravendb.client.connection.profiling
 
ProfilingContext() - Constructor for class net.ravendb.client.connection.profiling.ProfilingContext
 
profilingContext - Variable in class net.ravendb.client.DocumentStoreBase
 
ProfilingInformation - Class in net.ravendb.client.connection.profiling
Information about a particular session
projectionFields - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The list of fields to project directly from the results
projectionToInstance(RavenJObject, Class<?>) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
propertyMatch(String, RavenJToken) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
propertyMatch(Expression<TValue>, TValue) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
PropertyNameFinder - Interface in net.ravendb.client.delegates
 
propertyNotMatch(String, RavenJToken) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
propertyNotMatch(Expression<TValue>, TValue) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
proximity(int) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Specifies a proximity distance for the phrase in the last where clause http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Proximity%20 Searches
proximity(int) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Specifies a proximity distance for the phrase in the last where clause http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Proximity%20Searches
proximity(int) - Method in interface net.ravendb.client.IDocumentQueryBase
Specifies a proximity distance for the phrase in the last where clause http://lucene.apache.org/java/2_4_0/queryparsersyntax.html#Proximity%20Searches
push(T) - Method in class net.ravendb.client.connection.profiling.ConcurrentLruSet
 
put(String, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
put(String, Etag, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Puts the document in the database with the specified key.
put(String, Etag, RavenJObject, RavenJObject) - Method in class net.ravendb.client.connection.ServerClient
 
putAll(Map<? extends String, ? extends RavenJToken>) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
putAttachment(String, Etag, InputStream, RavenJObject) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
Use RavenFS instead.
putAttachment(String, Etag, InputStream, RavenJObject) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
PutCommandData - Class in net.ravendb.abstractions.commands
A single batch operation for a document PUT
PutCommandData() - Constructor for class net.ravendb.abstractions.commands.PutCommandData
 
PutCommandData(String, Etag, RavenJObject, RavenJObject) - Constructor for class net.ravendb.abstractions.commands.PutCommandData
 
putIndex(String, IndexDefinition) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates an index with the specified name, based on an index definition
putIndex(String, IndexDefinition, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates an index with the specified name, based on an index definition
putIndex(String, IndexDefinition, boolean, Reference<Operation>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates an index with the specified name, based on an index definition
putIndex(String, IndexDefinitionBuilder) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates an index with the specified name, based on an index definition that is created by the supplied IndexDefinitionBuilder
putIndex(String, IndexDefinitionBuilder, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates an index with the specified name, based on an index definition that is created by the supplied IndexDefinitionBuilder
putIndex(String, IndexDefinitionBuilder) - Method in class net.ravendb.client.connection.ServerClient
 
putIndex(String, IndexDefinitionBuilder, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
putIndex(String, IndexDefinition, boolean, Reference<Operation>) - Method in class net.ravendb.client.connection.ServerClient
 
putIndex(String, IndexDefinition) - Method in class net.ravendb.client.connection.ServerClient
 
putIndex(String, IndexDefinition, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
putIndexes(IndexToAdd[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates multiple indexes with the specified name, using given index definitions and priorities
putIndexes(IndexToAdd[]) - Method in class net.ravendb.client.connection.ServerClient
 
PutResult - Class in net.ravendb.abstractions.data
 
PutResult(String, Etag) - Constructor for class net.ravendb.abstractions.data.PutResult
 
putSideBySideIndexes(IndexToAdd[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates multiple side by side indexes with the specified name, using given index definitions and priorities
putSideBySideIndexes(IndexToAdd[], Etag, Date) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates multiple side by side indexes with the specified name, using given index definitions and priorities
putSideBySideIndexes(IndexToAdd[]) - Method in class net.ravendb.client.connection.ServerClient
 
putSideBySideIndexes(IndexToAdd[], Etag, Date) - Method in class net.ravendb.client.connection.ServerClient
 
putTransformer(String, TransformerDefinition) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Creates a transformer with the specified name, based on an transformer definition
putTransformer(String, TransformerDefinition) - Method in class net.ravendb.client.connection.ServerClient
 

Q

quadPrefixTreeIndex(int, SpatialOptionsFactory.SpatialBounds) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.CartesianSpatialOptionsFactory
 
quadPrefixTreeIndex(int) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
quadPrefixTreeIndex(int, SpatialOptions.SpatialUnits) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
queries(String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
query(String, IndexQuery) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Queries the specified index in the Raven-flavored Lucene query syntax
query(String, IndexQuery, String[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Queries the specified index in the Raven-flavored Lucene query syntax
query(String, IndexQuery, String[], boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Queries the specified index in the Raven-flavored Lucene query syntax
query(String, IndexQuery, String[], boolean, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Queries the specified index in the Raven-flavored Lucene query syntax
query(String, IndexQuery) - Method in class net.ravendb.client.connection.ServerClient
 
query(String, IndexQuery, String[]) - Method in class net.ravendb.client.connection.ServerClient
 
query(String, IndexQuery, String[], boolean) - Method in class net.ravendb.client.connection.ServerClient
 
query(String, IndexQuery, String[], boolean, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
query(Class<T>, String) - Method in class net.ravendb.client.document.DocumentSession
Queries the specified index.
query(Class<T>, String, boolean) - Method in class net.ravendb.client.document.DocumentSession
Queries the specified index.
query(Class<T>, Class<? extends AbstractIndexCreationTask>) - Method in class net.ravendb.client.document.DocumentSession
Queries the index specified by tIndexCreator using Linq.
query(Class<T>, Class<? extends AbstractIndexCreationTask>, ShardReduceFunction) - Method in class net.ravendb.client.document.DocumentSession
 
query(Class<T>) - Method in class net.ravendb.client.document.DocumentSession
Query RavenDB dynamically using
query(Class<T>, String) - Method in interface net.ravendb.client.IDocumentSession
Queries the specified index.
query(Class<T>, String, boolean) - Method in interface net.ravendb.client.IDocumentSession
Queries the specified index.
query(Class<T>) - Method in interface net.ravendb.client.IDocumentSession
Dynamically queries RavenDB.
query(Class<T>, Class<? extends AbstractIndexCreationTask>) - Method in interface net.ravendb.client.IDocumentSession
Queries the index specified by indexCreator.
query(Class<T>, Class<? extends AbstractIndexCreationTask>, ShardReduceFunction) - Method in interface net.ravendb.client.IDocumentSession
Queries the index specified by indexCreator.
query(Class<T>, String) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
query(Class<T>, String, boolean) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
query(Class<T>) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
query(Class<T>, Class<? extends AbstractIndexCreationTask>) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
query(Class<T>, Class<? extends AbstractIndexCreationTask>, ShardReduceFunction) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
QUERY_OPERATORS_PREFIX - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
queryGenerator - Variable in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
QueryHeaderInformation - Class in net.ravendb.abstractions.data
 
QueryHeaderInformation() - Constructor for class net.ravendb.abstractions.data.QueryHeaderInformation
 
queryListeners - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The query listeners for this query
queryOperation - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
QueryOperation - Class in net.ravendb.client.document.sessionoperations
 
QueryOperation(InMemoryDocumentSessionOperations, String, IndexQuery, String[], boolean, long, ShardReduceFunction, Set<String>, boolean) - Constructor for class net.ravendb.client.document.sessionoperations.QueryOperation
 
QueryOperator - Enum in net.ravendb.abstractions.data
 
QueryResult - Class in net.ravendb.abstractions.data
 
QueryResult() - Constructor for class net.ravendb.abstractions.data.QueryResult
Initializes a new instance of the QueryResult class.
queryShape - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
queryStats - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Holds the query stats
queryText - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The query to use
QueryValueConvertionType - Enum in net.ravendb.client.document
 

R

random() - Static method in class net.ravendb.abstractions.data.Etag
 
RANDOM_FIELD_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
randomOrdering() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Order the search results randomly
randomOrdering(String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Order the search results randomly using the specified seed this is useful if you want to have repeatable random queries
randomOrdering() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
randomOrdering(String) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
randomOrdering() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Order the search results randomly
randomOrdering(String) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Order the search results randomly using the specified seed this is useful if you want to have repeatable random queries
randomOrdering() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Order the search results randomly
randomOrdering(String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Order the search results randomly using the specified seed this is useful if you want to have repeatable random queries
randomOrdering() - Method in interface net.ravendb.client.IDocumentQueryBase
Order the search results randomly
randomOrdering(String) - Method in interface net.ravendb.client.IDocumentQueryBase
Order the search results randomly using the specified seed this is useful if you want to have repeatable random queries
randomOrdering() - Method in interface net.ravendb.client.IDocumentQueryCustomization
Order the search results randomly
randomOrdering(String) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Order the search results randomly using the specified seed this is useful if you want to have repeatable random queries
RAVEN_CLIENT_PRIMARY_SERVER_LAST_CHECK - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_CLIENT_PRIMARY_SERVER_URL - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_CREATE_VERSION - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_DOCUMENT_DOES_NOT_EXISTS - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_ENTITY_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_FORCE_PRIMARY_SERVER_CHECK - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_JAVA_CLASS - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_KEY_GENERATORS_HILO - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
RAVEN_KEY_SERVER_PREFIX - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
RAVEN_LAST_MODIFIED - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_LAST_MODIFIED_DATE_FORMAT - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_READ_ONLY - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_REPLICATION_CONFLICT - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_REPLICATION_DESTINATIONS - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_S_DATE_FORMAT - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_SERVER_BUILD - Static variable in class net.ravendb.abstractions.data.Constants
 
RAVEN_SHARD_ID - Static variable in class net.ravendb.abstractions.data.Constants
 
RavenArray<E> - Class in net.ravendb.querydsl
 
RavenArray(Class<? super E[]>, Path<?>, String) - Constructor for class net.ravendb.querydsl.RavenArray
 
RavenArray(Class<? super E[]>, PathMetadata<?>) - Constructor for class net.ravendb.querydsl.RavenArray
 
RavenArray(Class<? super E[]>, String) - Constructor for class net.ravendb.querydsl.RavenArray
 
RavenConnectionStringOptions - Class in net.ravendb.abstractions.data
 
RavenConnectionStringOptions() - Constructor for class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
RavenDBAnnotationProcessor - Class in net.ravendb.querydsl
 
RavenDBAnnotationProcessor() - Constructor for class net.ravendb.querydsl.RavenDBAnnotationProcessor
 
RavenDefaultConfiguration - Class in net.ravendb.querydsl
 
RavenDefaultConfiguration(RoundEnvironment, Map<String, String>, Collection<String>, Class<? extends Annotation>, Class<? extends Annotation>, Class<? extends Annotation>, Class<? extends Annotation>, Class<? extends Annotation>, Class<? extends Annotation>) - Constructor for class net.ravendb.querydsl.RavenDefaultConfiguration
 
RavenDocumentsByEntityName - Class in net.ravendb.client.indexes
Create an index that allows to tag entities by their entity name
RavenDocumentsByEntityName() - Constructor for class net.ravendb.client.indexes.RavenDocumentsByEntityName
 
RavenEntitySerializer - Class in net.ravendb.querydsl
 
RavenEntitySerializer(TypeMappings, Collection<String>) - Constructor for class net.ravendb.querydsl.RavenEntitySerializer
 
RavenGzipDecompressingEntity - Class in net.ravendb.java.http.client
 
RavenGzipDecompressingEntity(HttpEntity) - Constructor for class net.ravendb.java.http.client.RavenGzipDecompressingEntity
Creates a new GzipDecompressingEntity which will wrap the specified HttpEntity.
RavenJArray - Class in net.ravendb.abstractions.json.linq
Represents a JSON array.
RavenJArray() - Constructor for class net.ravendb.abstractions.json.linq.RavenJArray
Initializes a new instance of the RavenJArray class.
RavenJArray(Collection<?>) - Constructor for class net.ravendb.abstractions.json.linq.RavenJArray
 
RavenJArray(RavenJToken...) - Constructor for class net.ravendb.abstractions.json.linq.RavenJArray
Initializes a new instance of the RavenJArray class with the specified content.
RavenJObject - Class in net.ravendb.abstractions.json.linq
 
RavenJObject() - Constructor for class net.ravendb.abstractions.json.linq.RavenJObject
 
RavenJObject(Comparator<String>) - Constructor for class net.ravendb.abstractions.json.linq.RavenJObject
 
RavenJObject(DictionaryWithParentSnapshot) - Constructor for class net.ravendb.abstractions.json.linq.RavenJObject
 
RavenJObject(RavenJObject) - Constructor for class net.ravendb.abstractions.json.linq.RavenJObject
 
RavenJObjectIterator - Class in net.ravendb.client.connection
 
RavenJObjectIterator(CloseableHttpResponse, int, int, RavenPagingInformation, Function1<JsonParser, Boolean>) - Constructor for class net.ravendb.client.connection.RavenJObjectIterator
 
ravenJObjectsToJsonDocuments(Collection<RavenJObject>) - Static method in class net.ravendb.client.connection.SerializationHelper
Translate a collection of RavenJObject to JsonDocuments
ravenJObjectsToJsonDocuments(RavenJToken) - Static method in class net.ravendb.client.connection.SerializationHelper
 
ravenJObjectToJsonDocument(RavenJObject) - Static method in class net.ravendb.client.connection.SerializationHelper
 
RavenJPath - Class in net.ravendb.abstractions.json.linq
 
RavenJPath(String) - Constructor for class net.ravendb.abstractions.json.linq.RavenJPath
 
RavenJPathEvaluationException - Exception in net.ravendb.abstractions.exceptions
 
RavenJPathEvaluationException() - Constructor for exception net.ravendb.abstractions.exceptions.RavenJPathEvaluationException
 
RavenJPathEvaluationException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.RavenJPathEvaluationException
 
RavenJPathEvaluationException(String) - Constructor for exception net.ravendb.abstractions.exceptions.RavenJPathEvaluationException
 
RavenJPathEvaluationException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.RavenJPathEvaluationException
 
RavenJsonTextReader - Class in net.ravendb.abstractions.json
 
RavenJsonTextReader() - Constructor for class net.ravendb.abstractions.json.RavenJsonTextReader
 
RavenJToken - Class in net.ravendb.abstractions.json.linq
Represents an abstract JSON token.
RavenJToken() - Constructor for class net.ravendb.abstractions.json.linq.RavenJToken
 
RavenJTokenComparator - Class in net.ravendb.abstractions.json.linq
 
RavenJTokenWriter - Class in net.ravendb.abstractions.json.linq
 
RavenJTokenWriter() - Constructor for class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
RavenJValue - Class in net.ravendb.abstractions.json.linq
 
RavenJValue(Object, JTokenType) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
 
RavenJValue(int) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(long) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(double) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(float) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(Date) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(boolean) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(String) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(URI) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenJValue(Object) - Constructor for class net.ravendb.abstractions.json.linq.RavenJValue
Initializes a new instance of the RavenJValue class with the given value.
RavenList<E,Q extends com.mysema.query.types.expr.SimpleExpression<? super E>> - Class in net.ravendb.querydsl
Extends QueryDSL ListPath to use binary ANY instead of unary.
RavenList(Class<? super E>, Class<Q>, Path<?>, String) - Constructor for class net.ravendb.querydsl.RavenList
 
RavenList(Class<? super E>, Class<Q>, PathMetadata<?>, PathInits) - Constructor for class net.ravendb.querydsl.RavenList
 
RavenList(Class<? super E>, Class<Q>, PathMetadata<?>) - Constructor for class net.ravendb.querydsl.RavenList
 
RavenList(Class<? super E>, Class<Q>, String) - Constructor for class net.ravendb.querydsl.RavenList
 
RavenLoadConfiguration - Class in net.ravendb.client.document
 
RavenLoadConfiguration() - Constructor for class net.ravendb.client.document.RavenLoadConfiguration
 
RavenMap<K,V,Q extends com.mysema.query.types.expr.SimpleExpression<? super V>> - Class in net.ravendb.querydsl
 
RavenMap(Class<? super K>, Class<? super V>, Class<Q>, Path<?>, String) - Constructor for class net.ravendb.querydsl.RavenMap
 
RavenMap(Class<? super K>, Class<? super V>, Class<Q>, PathMetadata<?>) - Constructor for class net.ravendb.querydsl.RavenMap
 
RavenMap(Class<? super K>, Class<? super V>, Class<Q>, String) - Constructor for class net.ravendb.querydsl.RavenMap
 
RavenPagingInformation - Class in net.ravendb.client
 
RavenPagingInformation() - Constructor for class net.ravendb.client.RavenPagingInformation
 
RavenQuery - Class in net.ravendb.abstractions.util
Helper class that provide a way to escape query terms
RavenQuery() - Constructor for class net.ravendb.abstractions.util.RavenQuery
 
RavenQueryHighlightings - Class in net.ravendb.client
 
RavenQueryHighlightings() - Constructor for class net.ravendb.client.RavenQueryHighlightings
 
RavenQueryInspector<T> - Class in net.ravendb.client.linq
 
RavenQueryInspector() - Constructor for class net.ravendb.client.linq.RavenQueryInspector
 
RavenQueryProvider<T> - Class in net.ravendb.client.linq
 
RavenQueryProvider(Class<T>, IDocumentQueryGenerator, String, RavenQueryStatistics, RavenQueryHighlightings, IDatabaseCommands, boolean) - Constructor for class net.ravendb.client.linq.RavenQueryProvider
 
RavenQueryProviderProcessor<T> - Class in net.ravendb.client.linq
Process a Linq expression to a Lucene query
RavenQueryProviderProcessor(Class<T>, IDocumentQueryGenerator, DocumentQueryCustomizationFactory, Action1<QueryResult>, Action1<RavenJObject>, String, Set<String>, List<RenamedField>, boolean, String, Map<String, RavenJToken>, Class) - Constructor for class net.ravendb.client.linq.RavenQueryProviderProcessor
 
RavenQueryStatistics - Class in net.ravendb.client
Statistics about a raven query.
RavenQueryStatistics() - Constructor for class net.ravendb.client.RavenQueryStatistics
 
RavenResponseContentEncoding - Class in net.ravendb.java.http.client
 
RavenResponseContentEncoding() - Constructor for class net.ravendb.java.http.client.RavenResponseContentEncoding
 
RavenString - Class in net.ravendb.querydsl
Custom extensions for build-in StringPath
RavenString(Path<?>, String) - Constructor for class net.ravendb.querydsl.RavenString
 
RavenString(PathMetadata<?>) - Constructor for class net.ravendb.querydsl.RavenString
 
RavenString(String) - Constructor for class net.ravendb.querydsl.RavenString
 
RavenUrlExtensions - Class in net.ravendb.client.connection
 
RavenUrlExtensions() - Constructor for class net.ravendb.client.connection.RavenUrlExtensions
 
read() - Method in class net.ravendb.abstractions.connection.CountingStream
 
read() - Method in class net.ravendb.client.connection.ObservableLineStream
 
readFrom(JsonParser) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
 
readResponseBytes() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
readResponseJson() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
readStripingBase - Static variable in class net.ravendb.client.connection.ReplicationInformerBase
 
readStripingBase - Variable in class net.ravendb.client.connection.ServerClient
 
ReadVetoException - Exception in net.ravendb.abstractions.exceptions
 
ReadVetoException() - Constructor for exception net.ravendb.abstractions.exceptions.ReadVetoException
 
ReadVetoException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.ReadVetoException
 
ReadVetoException(String) - Constructor for exception net.ravendb.abstractions.exceptions.ReadVetoException
 
ReadVetoException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.ReadVetoException
 
recordAction(Object, RequestResultArgs) - Method in class net.ravendb.client.connection.profiling.ProfilingContext
Register the action as associated with the sender
reduce - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
Reference<T> - Class in net.ravendb.abstractions.basic
Models out parameters
Reference() - Constructor for class net.ravendb.abstractions.basic.Reference
Creates a new holder with a null value.
Reference(T) - Constructor for class net.ravendb.abstractions.basic.Reference
Create a new holder with the specified value.
ReflectionUtil - Class in net.ravendb.client.document
Helper class for reflection operations
ReflectionUtil() - Constructor for class net.ravendb.client.document.ReflectionUtil
 
refresh(T) - Method in class net.ravendb.client.document.DocumentSession
Refreshes the specified entity from Raven server.
refresh(T) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Updates entity with latest changes from server
refresh(T) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
refreshInternal(T, JsonDocument, DocumentMetadata) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
refreshReplicationInformation(T) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
Refreshes the replication information.
refreshReplicationInformation(ServerClient) - Method in class net.ravendb.client.connection.ReplicationInformer
 
refreshReplicationInformationTask - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
registerCustomQueryTranslator(CustomQueryExpressionTranslator) - Method in class net.ravendb.client.document.Convention
 
registerForExtensionData(Action3<Object, String, RavenJToken>) - Method in class net.ravendb.client.document.DefaultRavenContractResolver
 
registerIdConvention(Class<TEntity>, IdConvention) - Method in class net.ravendb.client.document.DocumentConvention
Register an id convention for a single type (and all of its derived types.
registerListener(IDocumentConversionListener) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
registerListener(IDocumentQueryListener) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
registerListener(IDocumentStoreListener) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
registerListener(IDocumentDeleteListener) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
registerListener(IDocumentConflictListener) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
registerListener(IDocumentConversionListener) - Method in class net.ravendb.client.DocumentStoreBase
Registers the conversion listener.
registerListener(IDocumentQueryListener) - Method in class net.ravendb.client.DocumentStoreBase
Registers the query listener.
registerListener(IDocumentStoreListener) - Method in class net.ravendb.client.DocumentStoreBase
Registers the store listener.
registerListener(IDocumentDeleteListener) - Method in class net.ravendb.client.DocumentStoreBase
Registers the delete listener.
registerListener(IDocumentConflictListener) - Method in class net.ravendb.client.DocumentStoreBase
Registers the conflict listener.
registerMissing(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
registerMissingIncludes(Collection<RavenJObject>, Collection<String>) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
registerModule(Module) - Method in class net.ravendb.client.document.JsonSerializer
 
registerQueryValueConverter(DocumentConvention.TryConvertValueForQueryDelegate<T>) - Method in class net.ravendb.client.document.DocumentConvention
 
registerQueryValueConverter(DocumentConvention.TryConvertValueForQueryDelegate<T>, SortOptions) - Method in class net.ravendb.client.document.DocumentConvention
 
registerQueryValueConverter(DocumentConvention.TryConvertValueForQueryDelegate<T>, SortOptions, boolean) - Method in class net.ravendb.client.document.DocumentConvention
 
relatesToShape(String, String, SpatialOptions.SpatialRelation) - Method in class net.ravendb.client.document.DocumentQuery
 
relatesToShape(String, String, SpatialOptions.SpatialRelation, double) - Method in class net.ravendb.client.document.DocumentQuery
 
relatesToShape(String, String, SpatialOptions.SpatialRelation) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
relatesToShape(String, String, SpatialOptions.SpatialRelation) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Filter matches based on a given shape - only documents with the shape defined in fieldName that have a relation rel with the given shapeWKT will be returned
relatesToShape(String, String, SpatialOptions.SpatialRelation) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter matches based on a given shape - only documents with the shape defined in fieldName that have a relation rel with the given shapeWKT will be returned
relatesToShape(String, String, SpatialOptions.SpatialRelation, double) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter matches based on a given shape - only documents with the shape defined in fieldName that have a relation rel with the given shapeWKT will be returned
relatesToShape(String, String, SpatialOptions.SpatialRelation) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Filter matches based on a given shape - only documents with the shape defined in fieldName that have a relation rel with the given shapeWKT will be returned
relatesToShape(Object, SpatialOptions.SpatialRelation) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
 
release(long) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
release(long, String) - Method in class net.ravendb.client.document.DocumentSubscriptions
 
release(long) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It releases a subscriptions by forcing a connected client to drop.
release(long, String) - Method in interface net.ravendb.client.document.IReliableSubscriptions
It releases a subscriptions by forcing a connected client to drop.
RELEVANT_HTTP_STATUS_CODE - Static variable in exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionClosedException
 
RELEVANT_HTTP_STATUS_CODE - Static variable in exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionDoesNotExistException
 
RELEVANT_HTTP_STATUS_CODE - Static variable in exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionInUseException
 
rememberEntityForDocumentKeyGeneration(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
RemoteBulkInsertOperation - Class in net.ravendb.client.document
 
RemoteBulkInsertOperation(BulkInsertOptions, ServerClient, IDatabaseChanges) - Constructor for class net.ravendb.client.document.RemoteBulkInsertOperation
 
RemoteBulkInsertOperation(BulkInsertOptions, ServerClient, IDatabaseChanges, UUID) - Constructor for class net.ravendb.client.document.RemoteBulkInsertOperation
 
RemoteBulkInsertOperation.BulkInsertEntity - Class in net.ravendb.client.document
 
RemoteBulkInsertOperation.BulkInsertEntity(BulkInsertOptions, CancellationTokenSource.CancellationToken) - Constructor for class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
RemoteChangesClientBase<TChangesApi extends IConnectableChanges,TConnectionState extends IChangesConnectionState> - Class in net.ravendb.client.changes
 
RemoteChangesClientBase(String, String, HttpJsonRequestFactory, Convention, IReplicationInformerBase, Action0) - Constructor for class net.ravendb.client.changes.RemoteChangesClientBase
 
RemoteDatabaseChanges - Class in net.ravendb.client.changes
 
RemoteDatabaseChanges(String, String, HttpJsonRequestFactory, DocumentConvention, IDocumentStoreReplicationInformer, Action0, Function4<String, Etag, String[], OperationMetadata, Boolean>) - Constructor for class net.ravendb.client.changes.RemoteDatabaseChanges
 
remove(T) - Method in class net.ravendb.abstractions.data.EnumSet
 
remove(Object) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
remove(RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
remove(String) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
remove(String) - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
remove(T) - Method in class net.ravendb.client.connection.profiling.ConcurrentLruSet
 
remove(Object) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
remove() - Method in class net.ravendb.client.connection.RavenJObjectIterator
 
remove(Object) - Method in class net.ravendb.client.util.IdentityHashSet
 
removeAfterAcknowledgmentHandler(EventHandler<Subscription.LastProcessedEtagEventArgs>) - Method in class net.ravendb.client.document.Subscription
 
removeAfterBatchHandler(EventHandler<Subscription.DocumentProcessedEventArgs>) - Method in class net.ravendb.client.document.Subscription
 
removeAfterDisposeEventHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.document.DocumentStore
Remove event handler
removeAfterDisposeEventHandler(EventHandler<VoidArgs>) - Method in interface net.ravendb.client.IDisposalNotification
Remove event handler
removeAfterDisposeEventHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
removeAll(Collection<?>) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
removeAll(Collection<?>) - Method in class net.ravendb.client.util.IdentityHashSet
 
removeAt(int) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
removeAuthorizationHeader() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
removeBeforeAcknowledgmentHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.document.Subscription
 
removeBeforeBatchHandler(EventHandler<VoidArgs>) - Method in class net.ravendb.client.document.Subscription
 
removeConfigureRequestEventHandler(EventHandler<WebRequestEventArgs>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
removeConnectionStatusChanges(EventHandler<VoidArgs>) - Method in interface net.ravendb.client.changes.IConnectableChanges
 
removeConnectionStatusChanges(EventHandler<VoidArgs>) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
removeConnectionStatusChanges(EventHandler<VoidArgs>) - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
removeDefaultValues() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Remove the default values that we don't actually need
removeFailoverStatusChanged(EventHandler<ReplicationInformer.FailoverStatusChangedEventArgs>) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
removeFailoverStatusChanged(EventHandler<ReplicationInformer.FailoverStatusChangedEventArgs>) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
removeFailoverStatusChanged(EventHandler<ReplicationInformer.FailoverStatusChangedEventArgs>) - Method in class net.ravendb.client.connection.ServerClient
 
removeLogRequestEventHandler(EventHandler<RequestResultArgs>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
removeOnBeforeEntityInsert(BulkInsertOperation.BeforeEntityInsert) - Method in class net.ravendb.client.document.BulkInsertOperation
 
removeOnError(ShardingErrorHandle<IDatabaseCommands>) - Method in interface net.ravendb.client.shard.IShardAccessStrategy
 
removeOnError(ShardingErrorHandle<IDatabaseCommands>) - Method in class net.ravendb.client.shard.ParallelShardAccessStrategy
 
removeOnError(ShardingErrorHandle<IDatabaseCommands>) - Method in class net.ravendb.client.shard.SequentialShardAccessStrategy
 
removeSessionCreatedInternal(Action1<InMemoryDocumentSessionOperations>) - Method in class net.ravendb.client.DocumentStoreBase
 
removeUTF8BOM(String) - Static method in class net.ravendb.abstractions.util.BomUtils
 
RenamedField - Class in net.ravendb.client.linq
 
RenamedField() - Constructor for class net.ravendb.client.linq.RenamedField
 
renameResults(QueryResult) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
renameSingleResult(Reference<RavenJObject>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
ReplicatedEtagInfo - Class in net.ravendb.abstractions.replication
 
ReplicatedEtagInfo() - Constructor for class net.ravendb.abstractions.replication.ReplicatedEtagInfo
 
ReplicationBehavior - Class in net.ravendb.client.document
 
ReplicationBehavior(DocumentStore) - Constructor for class net.ravendb.client.document.ReplicationBehavior
 
ReplicationClientConfiguration - Class in net.ravendb.abstractions.replication
 
ReplicationClientConfiguration() - Constructor for class net.ravendb.abstractions.replication.ReplicationClientConfiguration
 
ReplicationConflictNotification - Class in net.ravendb.abstractions.data
 
ReplicationConflictNotification() - Constructor for class net.ravendb.abstractions.data.ReplicationConflictNotification
 
ReplicationConflictTypes - Enum in net.ravendb.abstractions.data
 
ReplicationDestination - Class in net.ravendb.abstractions.replication
 
ReplicationDestination() - Constructor for class net.ravendb.abstractions.replication.ReplicationDestination
 
ReplicationDestination.TransitiveReplicationOptions - Enum in net.ravendb.abstractions.replication
 
replicationDestinations - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
ReplicationDocument - Class in net.ravendb.abstractions.replication
 
ReplicationDocument() - Constructor for class net.ravendb.abstractions.replication.ReplicationDocument
 
replicationInfo(String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
ReplicationInformer - Class in net.ravendb.client.connection
 
ReplicationInformer(Convention, HttpJsonRequestFactory) - Constructor for class net.ravendb.client.connection.ReplicationInformer
 
ReplicationInformer.FailoverStatusChangedEventArgs - Class in net.ravendb.client.connection
 
ReplicationInformer.FailoverStatusChangedEventArgs() - Constructor for class net.ravendb.client.connection.ReplicationInformer.FailoverStatusChangedEventArgs
 
ReplicationInformer.FailoverStatusChangedEventArgs(String, Boolean) - Constructor for class net.ravendb.client.connection.ReplicationInformer.FailoverStatusChangedEventArgs
 
ReplicationInformerBase<T> - Class in net.ravendb.client.connection
 
ReplicationInformerBase(Convention, HttpJsonRequestFactory, int) - Constructor for class net.ravendb.client.connection.ReplicationInformerBase
 
ReplicationInformerBase.FailureCounter - Class in net.ravendb.client.connection
 
ReplicationInformerBase.FailureCounter() - Constructor for class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
ReplicationInformerBase.OperationResult<T> - Class in net.ravendb.client.connection
 
ReplicationInformerBase.OperationResult(T, boolean, boolean, Exception) - Constructor for class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
ReplicationInformerBase.OperationResult(T, boolean) - Constructor for class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
ReplicationInformerBase.OperationResult() - Constructor for class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
ReplicationInformerFactory - Interface in net.ravendb.client.delegates
 
ReplicationInformerLocalCache - Class in net.ravendb.client.connection
 
ReplicationInformerLocalCache() - Constructor for class net.ravendb.client.connection.ReplicationInformerLocalCache
 
replicationLock - Variable in class net.ravendb.client.connection.ReplicationInformerBase
 
ReplicationOperationTypes - Enum in net.ravendb.abstractions.data
 
ReplicationStatistics - Class in net.ravendb.abstractions.replication
 
ReplicationStatistics() - Constructor for class net.ravendb.abstractions.replication.ReplicationStatistics
 
ReplicationStatistics.DestinationStats - Class in net.ravendb.abstractions.replication
 
ReplicationStatistics.DestinationStats() - Constructor for class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
RequestCachePolicy - Interface in net.ravendb.client.delegates
 
requestCount - Variable in class net.ravendb.client.connection.ServerClient
 
RequestResultArgs - Class in net.ravendb.client.connection.profiling
 
RequestResultArgs() - Constructor for class net.ravendb.client.connection.profiling.RequestResultArgs
 
RequestStatus - Enum in net.ravendb.client.connection.profiling
The status of the request
RequirementsChecker - Class in net.ravendb.client.utils
Class responsible for checking system requirements required by some of RavenDB client features
RequirementsChecker() - Constructor for class net.ravendb.client.utils.RequirementsChecker
 
reset() - Method in class net.ravendb.abstractions.util.AutoResetEvent
 
reset() - Method in class net.ravendb.abstractions.util.ManualResetEvent
 
reset() - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
resetCache(Integer) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
resetFailureCount(String) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
resetIndex(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Removes all indexing data from a server for a given index so the indexation can start from scratch for that index.
resetIndex(String) - Method in class net.ravendb.client.connection.ServerClient
 
resolve() - Method in class net.ravendb.abstractions.json.ConflictsResolver
 
resolve(int) - Method in class net.ravendb.abstractions.json.ConflictsResolver
 
Response - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
ResponseFormat - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
ResponseTimeInformation - Class in net.ravendb.client.document
 
ResponseTimeInformation() - Constructor for class net.ravendb.client.document.ResponseTimeInformation
 
ResponseTimeInformation.ResponseTimeItem - Class in net.ravendb.client.document
 
ResponseTimeInformation.ResponseTimeItem() - Constructor for class net.ravendb.client.document.ResponseTimeInformation.ResponseTimeItem
 
resultsTransformer - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The name of the results transformer to use after executing this query
retainAll(Collection<?>) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
retainAll(Collection<?>) - Method in class net.ravendb.client.util.IdentityHashSet
 
rootTypes - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
RSAExponent - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 
RSAModulus - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 

S

sanitize(String) - Method in class net.ravendb.abstractions.spatial.WktSanitizer
 
santizeRavenJObjects(Object) - Method in class net.ravendb.abstractions.spatial.GeoJsonWktConverter
 
saveChanges() - Method in class net.ravendb.client.document.DocumentSession
Saves all the changes to the Raven server.
saveChanges() - Method in interface net.ravendb.client.IDocumentSession
Saves all the changes to the Raven server.
saveChanges() - Method in class net.ravendb.client.shard.ShardedDocumentSession
Saves all the changes to the Raven server.
SaveChangesData - Class in net.ravendb.client.document
Data for a batch command to the server
SaveChangesData() - Constructor for class net.ravendb.client.document.SaveChangesData
 
ScriptedIndexResults - Class in net.ravendb.abstractions.data
 
ScriptedIndexResults() - Constructor for class net.ravendb.abstractions.data.ScriptedIndexResults
 
ScriptedPatchCommandData - Class in net.ravendb.abstractions.commands
A single batch operation for a document EVAL (using a Javascript)
ScriptedPatchCommandData() - Constructor for class net.ravendb.abstractions.commands.ScriptedPatchCommandData
 
ScriptedPatchRequest - Class in net.ravendb.abstractions.data
An advanced patch request for a specified document (using JavaScript)
ScriptedPatchRequest(String) - Constructor for class net.ravendb.abstractions.data.ScriptedPatchRequest
 
ScriptedPatchRequest(String, Map<String, Object>) - Constructor for class net.ravendb.abstractions.data.ScriptedPatchRequest
 
ScriptedPatchRequest() - Constructor for class net.ravendb.abstractions.data.ScriptedPatchRequest
 
SEARCH - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
search(String, String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
search(String, String, EscapeQueryOptions) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Perform a search for documents which fields that match the searchTerms.
search(Expression<?>, String) - Method in class net.ravendb.client.document.DocumentQuery
 
search(Expression<?>, String, EscapeQueryOptions) - Method in class net.ravendb.client.document.DocumentQuery
 
search(String, String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Perform a search for documents which fields that match the searchTerms.
search(String, String, EscapeQueryOptions) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Perform a search for documents which fields that match the searchTerms.
search(String, String) - Method in interface net.ravendb.client.IDocumentQueryBase
Perform a search for documents which fields that match the searchTerms.
search(String, String, EscapeQueryOptions) - Method in interface net.ravendb.client.IDocumentQueryBase
Perform a search for documents which fields that match the searchTerms.
search(Expression<?>, String) - Method in interface net.ravendb.client.IDocumentQueryBase
Perform a search for documents which fields that match the searchTerms.
search(Expression<?>, String, EscapeQueryOptions) - Method in interface net.ravendb.client.IDocumentQueryBase
Perform a search for documents which fields that match the searchTerms.
search(Path<?>, String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
search(Path<?>, String, double) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
search(Path<?>, String, double, SearchOptionsSet) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
search(Path<?>, String, SearchOptionsSet) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
search(Path<?>, String, EscapeQueryOptions) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
search(Path<?>, String, double, SearchOptionsSet, EscapeQueryOptions) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
search(Path<?>, String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Perform a search for documents which fields that match the searchTerms.
search(Path<?>, String, double) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
search(Path<?>, String, double, SearchOptionsSet) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
search(Path<?>, String, double, SearchOptionsSet, EscapeQueryOptions) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
search(Path<?>, String, EscapeQueryOptions) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
search(Path<?>, String, SearchOptionsSet) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
SearchOptions - Enum in net.ravendb.client
 
SearchOptionsSet - Class in net.ravendb.client
 
SearchOptionsSet() - Constructor for class net.ravendb.client.SearchOptionsSet
 
SearchOptionsSet(SearchOptions...) - Constructor for class net.ravendb.client.SearchOptionsSet
 
SecuredAuthenticator - Class in net.ravendb.abstractions.oauth
 
SecuredAuthenticator(HttpJsonRequestFactory) - Constructor for class net.ravendb.abstractions.oauth.SecuredAuthenticator
 
SecurityExtensions - Class in net.ravendb.client.extensions
 
SecurityExtensions() - Constructor for class net.ravendb.client.extensions.SecurityExtensions
 
seedIdentityFor(String, long) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Seeds the next identity value on the server
seedIdentityFor(String, long) - Method in class net.ravendb.client.connection.ServerClient
 
SELECT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
select(Class<TProjection>) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Projects results
select(Class<TProjection>, String...) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Projects results
select(Class<TProjection>, String[], String[]) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Projects results
select(Class<TProjection>, Path<?>...) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Projects results
select(Class<TProjection>, Path<?>[], Path<?>[]) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Projects results
select(Path<TProjection>) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Projects results based on projection path
select(Class<TProjection>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
select(Path<TProjection>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
select(Class<TProjection>, String...) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
select(Class<TProjection>, String[], String[]) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
select(Class<TProjection>, Path<?>...) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
select(Class<TProjection>, Path<?>[], Path<?>[]) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
select() - Method in class net.ravendb.querydsl.RavenArray
Deprecated.
select() - Method in class net.ravendb.querydsl.RavenList
 
selectFields(Class<TProjection>) - Method in class net.ravendb.client.document.DocumentQuery
Selects the projection fields directly from the index
selectFields(Class<TProjection>, String...) - Method in class net.ravendb.client.document.DocumentQuery
Selects the specified fields directly from the index
selectFields(Class<TProjection>, String[], String[]) - Method in class net.ravendb.client.document.DocumentQuery
Selects the specified fields directly from the index
selectFields(Class<TProjection>, String...) - Method in interface net.ravendb.client.IDocumentQuery
Selects the specified fields directly from the index if the are stored.
selectFields(Class<TProjection>, String[], String[]) - Method in interface net.ravendb.client.IDocumentQuery
Selects the specified fields directly from the index if the are stored.
selectFields(Class<TProjection>) - Method in interface net.ravendb.client.IDocumentQuery
Selects the specified fields directly from the index if the are stored.
selectFields(Class<TProjection>, String[], String[]) - Method in class net.ravendb.client.shard.ShardedDocumentQuery
 
selectToken(String) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectToken(String, boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectToken(String, boolean, boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectToken(RavenJPath) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectToken(RavenJPath, boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectToken(RavenJPath, boolean, boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectTokenWithRavenSyntaxReturningFlatStructure(RavenJToken, String) - Static method in class net.ravendb.abstractions.json.JTokenExtensions
 
selectTokenWithRavenSyntaxReturningFlatStructure(RavenJToken, String, boolean) - Static method in class net.ravendb.abstractions.json.JTokenExtensions
 
selectTokenWithRavenSyntaxReturningFlatStructure(String) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
selectTokenWithRavenSyntaxReturningSingleValue(String) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
send(DocumentChangeNotification) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
send(IndexChangeNotification) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
send(TransformerChangeNotification) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
send(ReplicationConflictNotification) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
send(BulkInsertChangeNotification) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
send(DataSubscriptionChangeNotification) - Method in class net.ravendb.client.changes.DatabaseConnectionState
 
send(String, String) - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
send(T) - Method in class net.ravendb.client.changes.TaskedObservable
 
SequentialShardAccessStrategy - Class in net.ravendb.client.shard
Apply an operation to all the shard session in sequence
SequentialShardAccessStrategy() - Constructor for class net.ravendb.client.shard.SequentialShardAccessStrategy
 
SerializationHelper - Class in net.ravendb.client.connection
 
SerializationHelper() - Constructor for class net.ravendb.client.connection.SerializationHelper
 
serialize(Enum<?>, JsonGenerator, SerializerProvider) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.RavenEnumSerializer
 
serialize(EnumSet, JsonGenerator, SerializerProvider) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.RavenEnumSetSerializer
 
serialize(T, JsonGenerator, SerializerProvider) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.RavenJTokenSerializer
 
serialize(RavenJTokenWriter, Object) - Method in class net.ravendb.client.document.JsonSerializer
 
serialize(EntityType, Property, Type, CodeWriter, String, String...) - Method in class net.ravendb.querydsl.RavenEntitySerializer
 
serializeAsString(Object) - Method in class net.ravendb.client.document.JsonSerializer
 
serializeFacetsToFacetsJsonString(List<Facet>) - Static method in class net.ravendb.client.connection.ServerClient
 
serializeObject(Object) - Static method in class net.ravendb.imports.json.JsonConvert
 
SerializeUsingValue - Annotation Type in net.ravendb.abstractions.basic
Marker annotation used - for serializing types using .NET enum conventions When enum is marked as flags and exists in EnumSet it must also contain method: int getValue() which returns int value used in flag
ServerClient - Class in net.ravendb.client.connection
 
ServerClient(String, DocumentConvention, OperationCredentials, HttpJsonRequestFactory, UUID, Function1<String, IDocumentStoreReplicationInformer>, String, IDocumentConflictListener[], boolean) - Constructor for class net.ravendb.client.connection.ServerClient
 
ServerClient.ErrorObjectProtoTransformer - Class in net.ravendb.client.connection
 
ServerClient.ErrorObjectProtoTransformer() - Constructor for class net.ravendb.client.connection.ServerClient.ErrorObjectProtoTransformer
 
ServerClient.HandleReplicationStatusChangesCallback - Class in net.ravendb.client.connection
 
ServerClient.HandleReplicationStatusChangesCallback() - Constructor for class net.ravendb.client.connection.ServerClient.HandleReplicationStatusChangesCallback
 
ServerClient.IndexErrorObjectProto - Class in net.ravendb.client.connection
 
ServerClient.IndexErrorObjectProto() - Constructor for class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
ServerHash - Class in net.ravendb.client.connection
 
ServerHash() - Constructor for class net.ravendb.client.connection.ServerHash
 
serverPull() - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
ServerRequestError - Class in net.ravendb.client.exceptions
 
ServerRequestError() - Constructor for class net.ravendb.client.exceptions.ServerRequestError
 
ServerVersionNotSuppportedException - Exception in net.ravendb.abstractions.exceptions
This exception is raised when server is not supported version.
ServerVersionNotSuppportedException() - Constructor for exception net.ravendb.abstractions.exceptions.ServerVersionNotSuppportedException
 
ServerVersionNotSuppportedException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.ServerVersionNotSuppportedException
 
ServerVersionNotSuppportedException(String) - Constructor for exception net.ravendb.abstractions.exceptions.ServerVersionNotSuppportedException
 
ServerVersionNotSuppportedException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.ServerVersionNotSuppportedException
 
set(int, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
Sets the RavenJToken at the specified index.
set(String, RavenJToken) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
set() - Method in class net.ravendb.abstractions.util.AutoResetEvent
 
set() - Method in class net.ravendb.abstractions.util.ManualResetEvent
 
set(String, CachedRequest) - Method in class net.ravendb.client.util.SimpleCache
 
setAcceptGzipContent(boolean) - Method in class net.ravendb.client.document.DocumentConvention
 
setAccuracy(Float) - Method in class net.ravendb.abstractions.data.SuggestionQuery
Suggestion accuracy.
setAccuracy(float) - Method in class net.ravendb.abstractions.indexing.SuggestionOptions
Suggestion accuracy.
setAckEtag(Etag) - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
setAcknowledgmentTimeout(Long) - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
setAction(String) - Method in class net.ravendb.abstractions.data.IndexingError
 
setActiveSyncs(List<SynchronizationDetails>) - Method in class net.ravendb.abstractions.data.FileSystemStats
 
setActiveTransactions(List<VoronActiveTransaction>) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setAdditionalData(RavenJObject) - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Additional command data.
setAdditionalData(RavenJObject) - Method in interface net.ravendb.abstractions.commands.ICommandData
Sets the additional metadata
setAdditionalData(RavenJObject) - Method in class net.ravendb.abstractions.commands.PatchCommandData
Additional command data.
setAdditionalData(RavenJObject) - Method in class net.ravendb.abstractions.commands.PutCommandData
Additional command data.
setAdditionalData(RavenJObject) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Additional command data.
setAdditionalData(RavenJObject) - Method in class net.ravendb.abstractions.data.BatchResult
Additional operation data.
setAdditionalInformation(Map<String, String>) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setAdditionalQuery(String) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
An additional query that the matching documents need to also match to be returned.
setAggregation(FacetAggregationSet) - Method in class net.ravendb.abstractions.data.Facet
Flags indicating type of facet aggregation.
setAggregation(FacetAggregationSet) - Method in class net.ravendb.client.linq.AggregationQuery
 
setAggregationField(String) - Method in class net.ravendb.abstractions.data.Facet
Field on which aggregation will be performed.
setAggregationType(String) - Method in class net.ravendb.abstractions.data.Facet
Type of field on which aggregation will be performed.
setAggregationType(String) - Method in class net.ravendb.client.linq.AggregationQuery
 
setAggregrationField(String) - Method in class net.ravendb.client.linq.AggregationQuery
 
setAggressiveCacheDuration(Long) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
setAllocatedDataFileSizeInBytes(long) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
If set to true, this property will send multiple index entries from the same document (assuming the index project them) to the result transformer function.
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
 
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in interface net.ravendb.client.IDocumentQueryBase
If set to true, this property will send multiple index entries from the same document (assuming the index project them) to the result transformer function.
setAllowMultipleIndexEntriesForSameDocumentToResultTransformer(boolean) - Method in interface net.ravendb.client.IDocumentQueryCustomization
If set to true, this property will send multiple index entries from the same document (assuming the index project them) to the result transformer function.
setAllowNonAuthoritativeInformation(boolean) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Sets a value indicating whether non authoritative information is allowed.
setAllowNonAuthoritativeInformation(boolean) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Sets a value indicating whether non authoritative information is allowed.
setAllowQueriesOnId(boolean) - Method in class net.ravendb.client.document.DocumentConvention
Whatever to allow queries on document id.
setAllowStale(boolean) - Method in class net.ravendb.abstractions.data.BulkOperationOptions
Indicates whether operations are allowed on stale indexes.
setAllowWildcards(boolean) - Method in class net.ravendb.client.WhereParams
Should the field allow wildcards
setAllPositions(Boolean) - Method in class net.ravendb.abstractions.data.PatchRequest
Only valid for collections.
setAnalyzed(boolean) - Method in class net.ravendb.client.WhereParams
Should the field be analyzed
setAnalyzers(Map<String, String>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field analyzer settings.
setAnalyzers(Map<Path<?>, String>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setAnalyzersStrings(Map<String, String>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setApiKey(String) - Method in class net.ravendb.abstractions.connection.OperationCredentials
 
setApiKey(String) - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
setApiKey(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setApiKey(String) - Method in class net.ravendb.client.document.DocumentStore
 
setApproximateTaskCount(long) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates how many tasks (approximately) are running currently in database.
setAt(Date) - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
setAt(Date) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setAttributes(Map<String, String>) - Method in class net.ravendb.abstractions.data.LicensingStatus
 
setAuthenticationScheme(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setAuthorization(HttpClient) - Method in class net.ravendb.abstractions.oauth.AbstractAuthenticator
 
setAverage(Double) - Method in class net.ravendb.abstractions.data.FacetValue
Stores average value if FacetAggregation.Average was set.
setAvoidCachingRequest(boolean) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setBackupLocation(String) - Method in class net.ravendb.abstractions.data.DatabaseBackupRequest
Path to directory where backup should lie (must be accessible from server).
setBackupLocation(String) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to directory where backup lies.
setBatchOptions(SubscriptionBatchOptions) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setBatchSize(int) - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Number of documents to send in each bulk insert batch.
setBelongsToAnyCollection(String...) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
setBoost(float) - Method in class net.ravendb.abstractions.data.BoostedValue
Boost factor.
setBoost(Boolean) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Boost terms in query based on score.
setBoostFactor(Float) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Boost factor when boosting based on score.
setBuildVersion(String) - Method in class net.ravendb.abstractions.data.BuildNumber
 
setCachedRequest(CachedRequest) - Method in class net.ravendb.client.connection.CachedRequestOp
 
setCachedRequestDetails(CachedRequest) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
setCanDelete(List<String>) - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
setCanMerge(List<String>) - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
setChange(DocumentsChanges.ChangeType) - Method in class net.ravendb.abstractions.data.DocumentsChanges
Type of change that occurred.
setCheckDestination(AtomicReference<Thread>) - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
setCheckReferencesInIndexes(boolean) - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Indicates if referenced documents should be checked in indexes.
setChunkedBulkInsertOptions(ChunkedBulkInsertOptions) - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Represents options of the chunked functionality of the bulk insert operation, which allows opening new connection for each chunk by amount of documents and total size.
setClazz(Class<?>) - Method in class net.ravendb.client.linq.ExpressionInfo
 
setClientAliveNotificationInterval(Integer) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setClientConfiguration(ReplicationClientConfiguration) - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
setClientVisibleUrl(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setCodec(ObjectCodec) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
setCollection(String) - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
setCollectionName(String) - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Document collection name.
setCommands(List<ICommandData>) - Method in class net.ravendb.client.document.SaveChangesData
 
setCompiled(boolean) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Internal use only.
setCompleted(Date) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setConflictedVersionIds(String[]) - Method in exception net.ravendb.client.exceptions.ConflictException
 
setConflictListeners(List<IDocumentConflictListener>) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
setConflicts(String[]) - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Array of conflict document Ids.
setConnectionId(String) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setConnectionStringOptions(T) - Method in class net.ravendb.abstractions.data.ConnectionStringParser
 
setConnectionStringSettings(RavenConnectionStringOptions) - Method in class net.ravendb.client.document.DocumentStore
Copy the relevant connection string settings
setContent(String) - Method in class net.ravendb.abstractions.data.GetRequest
 
setContentType(InputStreamEntity, Map<String, String>) - Static method in class net.ravendb.client.connection.HttpContentExtentions
 
setContext(Map<String, String>) - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
setConvention(Convention) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setConventions(DocumentConvention) - Method in class net.ravendb.client.DocumentStoreBase
 
setConventions(DocumentConvention) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Sets the conventions that should be used when index definition is created.
setConventions(DocumentConvention) - Method in class net.ravendb.client.indexes.AbstractTransformerCreationTask
 
setConventions(DocumentConvention) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
setConventions(DocumentConvention) - Method in class net.ravendb.client.shard.ShardStrategy
 
setConversionListeners(List<IDocumentConversionListener>) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
setCount(long) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
setCount(Integer) - Method in class net.ravendb.abstractions.data.FacetValue
Stores count value if FacetAggregation.Count was set.
setCounter(long) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
setCountOfAttachments(long) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Deprecated.
Use RavenFS instead.
setCountOfAttachments(long) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Deprecated.
Use RavenFS instead.
setCountOfDocuments(long) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of documents in database.
setCountOfDocuments(long) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Total count of documents in database.
setCountOfIndexes(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of indexes in database.
setCountOfIndexesExcludingDisabledAndAbandoned(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of indexes in database excluding disabled and abandoned
setCountOfResultTransformers(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of transformers in database.
setCountOfStaleIndexesExcludingDisabledAndAbandoned(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Total number of stale indexes excluding disabled and abandoned
setCreatedTimestamp(Date) - Method in class net.ravendb.abstractions.data.IndexStats
Date of index creation.
setCredentials(OperationCredentials) - Method in class net.ravendb.abstractions.connection.WebRequestEventArgs
 
setCredentials(OperationCredentials) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setCriteria(SubscriptionCriteria) - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
setCurrentNumberOfItemsToIndexInSingleBatch(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Current value of items that will be processed by index (map) in single batch.
setCurrentNumberOfItemsToReduceInSingleBatch(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Current value of items that will be processed by index (reduce) in single batch.
setCurrentNumberOfParallelTasks(int) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
The concurrency level that RavenDB is currently using
setCurrentOAuthToken(String) - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
setCutoff(Date) - Method in class net.ravendb.abstractions.data.IndexQuery
Used to calculate index staleness.
setCutoffEtag(Etag) - Method in class net.ravendb.abstractions.data.IndexQuery
Gets or sets the cutoff etag.
setData(byte[]) - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Setting the content of an attachment.
setData(String) - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeChunk
 
setData(RavenJToken) - Method in class net.ravendb.client.connection.CachedRequest
 
setDataAsJson(RavenJObject) - Method in class net.ravendb.abstractions.data.JsonDocument
Document data or projection as json.
setDatabase(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setDatabase(String) - Method in class net.ravendb.client.connection.CachedRequest
 
setDatabase(String) - Method in class net.ravendb.client.document.OpenSessionOptions
 
setDatabaseCacheSizeInMB(double) - Method in class net.ravendb.abstractions.data.AdminMemoryStatistics
Size of database cache in megabytes.
setDatabaseDocument(DatabaseDocument) - Method in class net.ravendb.abstractions.data.DatabaseBackupRequest
DatabaseDocument that will be inserted with backup.
setDatabaseId(UUID) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Database identifier.
setDatabaseLocation(String) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to the directory of a new database.
setDatabaseName(String) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates what should be the name of database after restore.
setDatabaseName(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
setDatabaseTransactionVersionSizeInMB(float) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Transaction version size in megabytes for database.
setDatabaseTransactionVersionSizeInMB(double) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Transaction version size in megabytes for database.
setDebugActions(RavenJObject) - Method in class net.ravendb.abstractions.data.PatchResultData
Additional debugging information (if requested).
setDebugMode(boolean) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Indicates in the operation should be run in debug mode.
setDebugOptionGetIndexEntires(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever we should get the raw index entries.
setDefaultDatabase(String) - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
setDefaultDatabase(String) - Method in class net.ravendb.client.document.DocumentStore
 
setDefaultField(String) - Method in class net.ravendb.abstractions.data.IndexQuery
Default field to use when querying directly on the Lucene query
setDefaultOperator(QueryOperator) - Method in class net.ravendb.abstractions.data.IndexQuery
Changes the default operator mode we use for queries.
setDefaultQueryingConsistency(ConsistencyOptions) - Method in class net.ravendb.client.document.DocumentConvention
The consistency options used when querying the database by default
setDefaultUseOptimisticConcurrency(boolean) - Method in class net.ravendb.client.document.DocumentConvention
 
setDeferredCommandsCount(int) - Method in class net.ravendb.client.document.SaveChangesData
 
setDefinition(IndexDefinition) - Method in class net.ravendb.abstractions.data.IndexToAdd
Definition of an index
setDefrag(boolean) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates if defragmentation should take place after restore.
setDelayTimeInMiliSec(int) - Method in interface net.ravendb.client.connection.IReplicationInformerBase
 
setDelayTimeInMiliSec(int) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
setDeleted(Boolean) - Method in class net.ravendb.abstractions.data.BatchResult
Indicates if the document was deleted (null if not DELETE operation) Value: - true - if the document was deleted - false - if it did not exist.
setDeleteListeners(List<IDocumentDeleteListener>) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
setDeleteScript(String) - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Script that will be evaluated for each document deleted from the index.
setDeleteScript(String) - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
setDescending(boolean) - Method in class net.ravendb.abstractions.data.SortedField
Gets or sets a value indicating whether this SortedField is descending.
setDestinations(List<ReplicationDestination>) - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
setDestinationUrl(String) - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
setDestionationUrl(String) - Method in class net.ravendb.abstractions.replication.ReplicatedEtagInfo
 
setDetails(String) - Method in class net.ravendb.abstractions.data.LicensingStatus
 
setDisableAuthentication(boolean) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setDisableCaching(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever we should disable caching of query results
setDisableCapacityChanges(boolean) - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
setDisabled(boolean) - Method in class net.ravendb.abstractions.data.DatabaseDocument
Indicates if database is disabled or not.
setDisabled(Boolean) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setDisableEntitiesTracking(boolean) - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
setDisableHttpCaching(Boolean) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
setDisableInMemoryIndexing(boolean) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Prevent index from being kept in memory.
setDisableInMemoryIndexing(boolean) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
setDisableInMemoryIndexing(boolean) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setDisableProfiling(boolean) - Method in class net.ravendb.client.document.DocumentConvention
Disable all profiling support
setDisableReplicationDestinations(boolean) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Indicates if all replication destinations should disabled after restore (only when Replication bundle is activated).
setDisableRequestCompression(boolean) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setDisableRequestCompression(boolean) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
setDisplayName(String) - Method in class net.ravendb.abstractions.data.Facet
Display name of facet.
setDisplayName(String) - Method in class net.ravendb.client.linq.AggregationQuery
 
setDistance(StringDistanceTypes) - Method in class net.ravendb.abstractions.data.SuggestionQuery
String distance algorithm to use.
setDistance(StringDistanceTypes) - Method in class net.ravendb.abstractions.indexing.SuggestionOptions
String distance algorithm to use.
setDistanceErrorPercentage(double) - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
A measure of acceptable error of the shape as a fraction.
setDistinct(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever we should apply distinct operation to the query on the server side.
setDocsCount(int) - Method in class net.ravendb.abstractions.data.IndexStats
Total number of entries in this index.
setDocsWritesPerSecond(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setDocument(RavenJObject) - Method in class net.ravendb.abstractions.commands.PutCommandData
RavenJObject representing the document.
setDocument(String) - Method in class net.ravendb.abstractions.data.IndexingError
 
setDocument(RavenJObject) - Method in class net.ravendb.abstractions.data.PatchResultData
Patched document.
setDocument(T) - Method in class net.ravendb.abstractions.data.StreamResult
Document deserialized to T.
setDocument(String) - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeResult
 
setDocumentEtag(Etag) - Method in class net.ravendb.abstractions.replication.ReplicatedEtagInfo
 
setDocumentId(String) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The document id to use as the basis for comparison
setDocumentKeyGenerator(DocumentKeyGenerator) - Method in class net.ravendb.client.document.DocumentConvention
Sets the document key generator.
setDomain(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setDuration(String) - Method in class net.ravendb.abstractions.data.FutureBatchStats
Indicates how much time it took to prepare future batch.
setDuration(String) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setDuration(Long) - Method in class net.ravendb.client.document.ResponseTimeInformation.ResponseTimeItem
 
setDurationBreakdown(List<ResponseTimeInformation.ResponseTimeItem>) - Method in class net.ravendb.client.document.ResponseTimeInformation
 
setDurationMiliseconds(long) - Method in class net.ravendb.abstractions.data.QueryResult
The duration of actually executing the query server side -1 is returned in case the query results retrieved from cache
setDurationMiliseconds(long) - Method in class net.ravendb.client.RavenQueryStatistics
The duration of the query _server side_
setDurationMilleseconds(double) - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
setDurationMilliseconds(double) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setDurationMilliseconds(double) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setEnableBasicAuthenticationOverUnsecuredHttpEvenThoughPasswordsWouldBeSentOverTheWireInClearTextToBeStolenByHackers(boolean) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
Advanced: Don't set this unless you know what you are doing! Enable using basic authentication using http By default, RavenDB only allows basic authentication over HTTPS, setting this property to true will instruct RavenDB to make unsecured calls (usually only good for testing / internal networks).
setEntities(List<Object>) - Method in class net.ravendb.client.document.SaveChangesData
 
setEntityType(Class) - Method in class net.ravendb.client.shard.ShardRequestData
 
setError(String) - Method in class net.ravendb.abstractions.data.IndexingError
 
setError(boolean) - Method in class net.ravendb.abstractions.data.LicensingStatus
 
setError(Exception) - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
setError(String) - Method in class net.ravendb.client.connection.ServerClient.ErrorObjectProtoTransformer
 
setError(String) - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
setError(String) - Method in class net.ravendb.client.document.DocumentSubscriptions.ErrorAndUrl
 
setError(String) - Method in class net.ravendb.client.exceptions.ServerRequestError
 
setErrors(IndexingError[]) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Array of indexing errors that occured in database.
setEsentStats(EsentStorageStats) - Method in class net.ravendb.abstractions.data.StorageStats
 
setEtag(Etag) - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Current document etag, used for concurrency checks (null to skip check)
setEtag(Etag) - Method in class net.ravendb.abstractions.commands.PatchCommandData
Current document etag, used for concurrency checks (null to skip check)
setEtag(Etag) - Method in class net.ravendb.abstractions.commands.PutCommandData
Current document etag, used for concurrency checks (null to skip check).
setEtag(Etag) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Current document etag, used for concurrency checks (null to skip check).
setEtag(Etag) - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Current attachment etag, used for concurrency checks (null to skip check).
setEtag(Etag) - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
Current attachment etag.
setEtag(Etag) - Method in class net.ravendb.abstractions.data.BatchResult
Etag generated by the operation (null if not applicable).
setEtag(Etag) - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Document etag.
setEtag(Etag) - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Current document etag, used for concurrency checks (null to skip check)
setEtag(Etag) - Method in class net.ravendb.abstractions.data.IndexChangeNotification
Sets etag
setEtag(Etag) - Method in class net.ravendb.abstractions.data.JsonDocument
Current document etag.
setEtag(Etag) - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Current document etag.
setEtag(Etag) - Method in class net.ravendb.abstractions.data.PutResult
Etag of the document after PUT operation.
setEtag(Etag) - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Current conflict document Etag.
setEtag(Etag) - Method in class net.ravendb.abstractions.data.StreamResult
Document etag.
setEtag(Etag) - Method in class net.ravendb.client.document.DocumentMetadata
 
setEtag(Etag) - Method in exception net.ravendb.client.exceptions.ConflictException
 
setException(Exception) - Method in class net.ravendb.abstractions.basic.ExceptionEventArgs
 
setException(String) - Method in class net.ravendb.abstractions.data.LogItem
 
setExpect100Continue(boolean) - Method in class net.ravendb.client.connection.ServerClient
 
setExplainScores(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Whatever a query result should contains an explanation about how docs scored against query
setExportAttachments(boolean) - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
setExportDeletions(boolean) - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
setExportDocuments(boolean) - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
setFacets(List<Facet>) - Method in class net.ravendb.abstractions.data.FacetQuery
List of facets (mutually exclusive with FacetSetupDoc).
setFacets(List<Facet>) - Method in class net.ravendb.abstractions.data.FacetSetup
List of facets.
setFacetSetupDoc(String) - Method in class net.ravendb.abstractions.data.FacetQuery
Id of a facet setup document that can be found in database containing facets (mutually exclusive with Facets).
setFailing(Boolean) - Method in class net.ravendb.client.connection.ReplicationInformer.FailoverStatusChangedEventArgs
 
setFailoverBehavior(FailoverBehavior) - Method in class net.ravendb.abstractions.replication.ReplicationClientConfiguration
 
setFailoverBehavior(FailoverBehaviorSet) - Method in class net.ravendb.client.document.Convention
How should we behave in a replicated environment when we can't reach the primary node and need to failover to secondary node(s).
setFailoverServers(FailoverServers) - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
setFailoverServers(ReplicationDestination[]) - Method in interface net.ravendb.client.connection.IDocumentStoreReplicationInformer
 
setFailoverServers(ReplicationDestination[]) - Method in class net.ravendb.client.connection.ReplicationInformer
 
setFailoverServers(FailoverServers) - Method in class net.ravendb.client.DocumentStoreBase
 
setFailureCountInternal(int) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setField(String) - Method in class net.ravendb.abstractions.data.SortedField
Index field name for sorting.
setField(String) - Method in class net.ravendb.abstractions.data.SuggestionQuery
Field to be used in conjunction with the index.
setFieldName(String) - Method in class net.ravendb.abstractions.data.DocumentsChanges
Name of field on which the change occurred.
setFieldName(String) - Method in class net.ravendb.client.WhereParams
 
setFieldNewType(String) - Method in class net.ravendb.abstractions.data.DocumentsChanges
Current field type.
setFieldNewValue(String) - Method in class net.ravendb.abstractions.data.DocumentsChanges
Current field value.
setFieldOldType(String) - Method in class net.ravendb.abstractions.data.DocumentsChanges
Previous field type.
setFieldOldValue(String) - Method in class net.ravendb.abstractions.data.DocumentsChanges
Previous field value.
setFields(String[]) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The fields to compare
setFields(List<String>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
List of queryable fields in index.
setFieldsToFetch(String[]) - Method in class net.ravendb.abstractions.data.IndexQuery
Array of fields that will be fetched.
setFieldsToFetch(Set<String>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
setFieldsToRename(List<RenamedField>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
Rename the fields from one name to another
setFieldTypeForIdentifier(Class<?>) - Method in class net.ravendb.client.WhereParams
 
setFiftennMinuteRate(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
setFileCount(Long) - Method in class net.ravendb.abstractions.data.FileSystemStats
 
setFileETag(UUID) - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
setFileName(String) - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
setFilePath(String) - Method in class net.ravendb.abstractions.smuggler.OperationState
 
setFilesWritesPerSecond(double) - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
setFindFullDocumentKeyFromNonStringIdentifier(DocumentKeyFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to find the full document key based on the type of a document and the value type identifier (just the numeric part of the id).
setFindIdentityProperty(IdentityPropertyFinder) - Method in class net.ravendb.client.document.Convention
Sets the function to find the identity property.
setFindIdentityPropertyNameFromEntityName(IdentityPropertyNameFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to get the identity property name from the entity name
setFindIdValuePartForValueTypeConversion(IdValuePartFinder) - Method in class net.ravendb.client.document.DocumentConvention
When RavenDB needs to convert between a string id to a value type like int or uuid, it calls this to perform the actual work
setFindJavaClass(JavaClassFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to find the java class of a document.
setFindJavaClassName(JavaClassNameFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to find the java class name from a java class
setFindPropertyNameForDynamicIndex(PropertyNameFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to find the indexed property name given the indexed document type, the index name, the current path and the property path.
setFindPropertyNameForIndex(PropertyNameFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to find the indexed property name given the indexed document type, the index name, the current path and the property path.
setFindTypeTagName(TypeTagNameFinder) - Method in class net.ravendb.client.document.DocumentConvention
Sets the function to find the type tag.
setFirstFailureInCycleTimestamp(Date) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setFiveMinuteRate(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
setFlags(String) - Method in class net.ravendb.abstractions.data.VoronActiveTransaction
 
setForceCheck(boolean) - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
setForceConcurrencyCheck(boolean) - Method in class net.ravendb.client.document.DocumentMetadata
 
setForceReadFromMaster(boolean) - Method in class net.ravendb.client.document.OpenSessionOptions
 
setForceRetry(boolean) - Method in class net.ravendb.abstractions.data.GetResponse
Indicates if request should be retried (forced).
setForceServerCheck(boolean) - Method in class net.ravendb.client.connection.CachedRequest
 
setForDatabases(Map<String, ReplicationDestination[]>) - Method in class net.ravendb.abstractions.data.FailoverServers
 
setForDefaultDatabase(Set<String>) - Method in class net.ravendb.abstractions.data.FailoverServers
 
setForEntityName(List<String>) - Method in class net.ravendb.abstractions.data.IndexStats
List of all entity names (collections) for which this index is working.
setFreePagesOverhead(long) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setGauges(Map<String, Map<String, String>>) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setGenerateNewDatabaseId(boolean) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Set if restored database should have new Id generated.
setHandleForbiddenResponse(HttpResponseHandler) - Method in class net.ravendb.client.document.Convention
Handles forbidden responses
setHandleUnauthorizedResponse(HttpResponseWithMetaHandler) - Method in class net.ravendb.client.document.Convention
Handles unauthenticated responses, usually by authenticating against the oauth server
setHeader(HttpUriRequest, String, String) - Static method in class net.ravendb.abstractions.oauth.AbstractAuthenticator
 
setHeaders(Map<String, String>) - Method in class net.ravendb.abstractions.data.GetRequest
Request headers.
setHeaders(Map<String, String>) - Method in class net.ravendb.abstractions.data.GetResponse
Response headers.
setHeaders(Map<String, String>) - Method in class net.ravendb.client.connection.CachedRequest
 
setHeaders(Map<String, String>) - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
setHighlightedFields(HighlightedField[]) - Method in class net.ravendb.abstractions.data.IndexQuery
Array of fields containing highlighting information.
setHighlighterKeyName(String) - Method in class net.ravendb.abstractions.data.IndexQuery
Sets highligter key name.
setHighlighterPostTags(String[]) - Method in class net.ravendb.abstractions.data.IndexQuery
Array of highlighter post tags that will be applied to highlighting results.
setHighlighterPreTags(String[]) - Method in class net.ravendb.abstractions.data.IndexQuery
Array of highlighter pre tags that will be applied to highlighting results.
setHighlighterTags(String, String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
setHighlighterTags(String[], String[]) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
setHighlighterTags(String, String) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
setHighlighterTags(String[], String[]) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
setHighlighterTags(String, String) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Sets the tags to highlight matches with.
setHighlighterTags(String[], String[]) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Sets the tags to highlight matches with.
setHighlighterTags(String, String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Sets the tags to highlight matches with.
setHighlighterTags(String[], String[]) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Sets the tags to highlight matches with.
setHighlighterTags(String, String) - Method in interface net.ravendb.client.IDocumentQueryBase
Sets the tags to highlight matches with.
setHighlighterTags(String[], String[]) - Method in interface net.ravendb.client.IDocumentQueryBase
Sets the tags to highlight matches with.
setHighlighterTags(String, String) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Sets the tags to highlight matches with.
setHighlighterTags(String[], String[]) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Sets the tags to highlight matches with.
setHighlightings(Map<String, Map<String, String[]>>) - Method in class net.ravendb.abstractions.data.QueryResult
Highlighter results (if requested).
setHits(int) - Method in class net.ravendb.abstractions.data.FacetValue
Number of terms that are covered by this facet.
setHttpResult(int) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setId(String) - Method in class net.ravendb.abstractions.data.DatabaseDocument
The ID of a database.
setId(long) - Method in class net.ravendb.abstractions.data.DataSubscriptionChangeNotification
Subscription identifier for which a notification was created
setId(String) - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Identifier of document for which notification was created.
setId(String) - Method in class net.ravendb.abstractions.data.FacetSetup
Id of a facet setup document.
setId(long) - Method in class net.ravendb.abstractions.data.IndexingError
 
setId(String) - Method in class net.ravendb.abstractions.data.IndexStats
Index identifier.
setId(String) - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Identifier of a document/attachment on which replication conflict occurred.
setId(String) - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Identifier for ScriptedIndexResults document.
setId(long) - Method in class net.ravendb.abstractions.data.VoronActiveTransaction
 
setId(String) - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
setId(UUID) - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
setIdentifier(String) - Method in class net.ravendb.client.document.DocumentStore
 
setIdentifier(String) - Method in interface net.ravendb.client.IDocumentStore
Sets the identifier
setIdentifier(String) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
setIdentityPartsSeparator(String) - Method in class net.ravendb.client.document.DocumentConvention
Sets the identity parts separator used by the HiLo generators
setIdentityTypeConvertors(List<ITypeConverter>) - Method in class net.ravendb.client.document.DocumentConvention
A list of type converters that can be used to translate the document key (string) to whatever type it is that is used on the entity, if the type isn't already a string
setIgnoreChanges(boolean) - Method in class net.ravendb.client.document.DocumentMetadata
If set to true, the session will ignore this document when SaveChanges() is called, and won't perform and change tracking
setIgnoredClient(Boolean) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setIgnoreSubscribersErrors(boolean) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setIncludeRemainingTerms(Boolean) - Method in class net.ravendb.abstractions.data.Facet
Indicates if remaining terms should be included in results.
setIncludes(String[]) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Array of paths under which document Ids can be found.
setIncludes(List<RavenJObject>) - Method in class net.ravendb.abstractions.data.MultiLoadResult
Included documents.
setIncludes(List<RavenJObject>) - Method in class net.ravendb.abstractions.data.QueryResult
Sets the document included in the result.
setIndex(int) - Method in class net.ravendb.abstractions.data.IndexingError
 
setIndex(String) - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
setIndexAndTransformerReplicationMode(EnumSet<IndexAndTransformerReplicationMode>) - Method in class net.ravendb.client.document.DocumentConvention
 
setIndexDefinitionProperty(String) - Method in exception net.ravendb.abstractions.exceptions.IndexCompilationException
Indicates which property caused error (Maps, Reduce).
setIndexDefinitionProperty(String) - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
setIndexedPerSecond(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setIndexes(IndexStats[]) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Statistics for each index in database.
setIndexes(Map<String, FieldIndexing>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field indexing settings.
setIndexes(Map<Path<?>, FieldIndexing>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setIndexesLocation(String) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to directory where indexes lies (if null, then default location will be assumed).
setIndexesStrings(Map<String, FieldIndexing>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setIndexesToAdd(IndexToAdd[]) - Method in class net.ravendb.abstractions.data.SideBySideIndexes
 
setIndexEtag(Etag) - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
setIndexEtag(Etag) - Method in class net.ravendb.abstractions.data.QueryResult
The last etag indexed by the index.
setIndexEtag(Etag) - Method in class net.ravendb.client.RavenQueryStatistics
The etag of the queried index
setIndexId(int) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index identifier (internal).
setIndexId(int) - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
Transformer identifier (internal).
setIndexingAttempts(int) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many times database tried to index documents (map) using this index.
setIndexingErrors(int) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many indexing attempts failed.
setIndexingLag(Integer) - Method in class net.ravendb.abstractions.data.IndexStats
Shows the difference between last document etag available in database and last indexed etag.
setIndexingSuccesses(int) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many indexing attempts succeeded.
setIndexLock(String, IndexLockMode) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sets the index lock mode
setIndexLock(String, IndexLockMode) - Method in class net.ravendb.client.connection.ServerClient
 
setIndexName(String) - Method in class net.ravendb.abstractions.data.FacetQuery
Index name to run facet query on.
setIndexName(String) - Method in class net.ravendb.abstractions.data.IndexingError
 
setIndexName(String) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The name of the index to use for this operation
setIndexName(String) - Method in class net.ravendb.abstractions.data.QueryResult
The index used to answer this query
setIndexName(String) - Method in class net.ravendb.client.RavenQueryStatistics
The name of the index queried
setIndexName(String) - Method in class net.ravendb.client.shard.ShardRequestData
 
setIndexPriority(String, IndexStats.IndexingPriority) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sets the index priority
setIndexPriority(String, IndexStats.IndexingPriority) - Method in class net.ravendb.client.connection.ServerClient
 
setIndexScript(String) - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Script that will be evaluated for each indexed document.
setIndexScript(String) - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
setIndexStateEtag(Etag) - Method in class net.ravendb.abstractions.data.FacetResults
 
setIndexStorageHumaneSize(String) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size of a index storage in a more human readable format.
setIndexStorageSize(long) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size of a index storage in bytes.
setIndexTimestamp(Date) - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
setIndexTimestamp(Date) - Method in class net.ravendb.abstractions.data.QueryResult
The last time the index was updated.
setIndexTimestamp(Date) - Method in class net.ravendb.client.RavenQueryStatistics
The timestamp of the queried index
setIndexToReplace(String) - Method in class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
setInMemoryIndexingQueueSize(int[]) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates how many elements are currently kept in queue for all indexing prefetchers available.
setInputCount(int) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setIs64Bit(Boolean) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates if process is 64-bit
setIsOnRam(String) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates if index is in-memory only.
setItem1(T) - Method in class net.ravendb.abstractions.basic.Tuple
 
setItem2(S) - Method in class net.ravendb.abstractions.basic.Tuple
 
setItemsCount(int) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setItemType(ReplicationConflictTypes) - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Type of conflict that occurred (None, DocumentReplicationConflict, AttachmentReplicationConflict).
setJournalsLocation(String) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Path to directory where journals lies (if null, then default location will be assumed).
setJsonContractResolver(DeserializationProblemHandler) - Method in class net.ravendb.client.document.DocumentConvention
 
setKey(String) - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Key of a document to delete.
setKey(String) - Method in class net.ravendb.abstractions.commands.PatchCommandData
Key of a document to patch.
setKey(String) - Method in class net.ravendb.abstractions.commands.PutCommandData
Key of a document.
setKey(String) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Key of a document to patch.
setKey(String) - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Key of an attachment.
setKey(String) - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
Key of an attachment.
setKey(String) - Method in class net.ravendb.abstractions.data.BatchResult
Key of a document.
setKey(String) - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Key of a document.
setKey(String) - Method in class net.ravendb.abstractions.data.JsonDocument
Key for the document
setKey(String) - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Key for the document
setKey(String) - Method in class net.ravendb.abstractions.data.PutResult
Key of the document that was PUT.
setKey(String) - Method in class net.ravendb.abstractions.data.StreamResult
Document key.
setKey(String) - Method in class net.ravendb.client.document.DocumentMetadata
 
setKeys(List<String>) - Method in class net.ravendb.client.shard.ShardRequestData
 
setKeyStartsWith(String) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
setLastActivity(Date) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Time of last activity on this database.
setLastAttachmentDeleteEtag(Etag) - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
setLastAttachmentEtag(Etag) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Deprecated.
Use RavenFS instead.
setLastAttachmentEtag(Etag) - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
setLastCheck(Date) - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
setLastDocDeleteEtag(Etag) - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
setLastDocEtag(Etag) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Last document etag in database.
setLastDocsEtag(Etag) - Method in class net.ravendb.abstractions.smuggler.LastEtagsInfo
 
setLastError(String) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastEtagCheckedForReplication(Etag) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastEtagHolder(ILastEtagHolder) - Method in class net.ravendb.client.DocumentStoreBase
 
setLastFailureTimestamp(Date) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastHeartbeatReceived(Date) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastIndexedEtag(Etag) - Method in class net.ravendb.abstractions.data.IndexStats
This value represents etag of last document indexed (using map) by this index.
setLastIndexedTimestamp(Date) - Method in class net.ravendb.abstractions.data.IndexStats
Time of last indexing for this index.
setLastIndexingTime(Date) - Method in class net.ravendb.abstractions.data.IndexStats
Time of last indexing (map or reduce) for this index.
setLastModified(Date) - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Last modified date for the document
setLastModified(Date) - Method in class net.ravendb.abstractions.data.JsonDocument
Last modified date for the document
setLastModified(Date) - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Last modified date for the document
setLastQueryTime(Date) - Method in class net.ravendb.abstractions.data.QueryResult
The timestamp of the last time the index was queried
setLastQueryTime(Date) - Method in class net.ravendb.client.RavenQueryStatistics
The timestamp of the last time the index was queried
setLastQueryTimestamp(Date) - Method in class net.ravendb.abstractions.data.IndexStats
Time of last query for this index.
setLastReducedEtag(Etag) - Method in class net.ravendb.abstractions.data.IndexStats
This value represents etag of last document indexed (using reduce) by this index.
setLastReducedTimestamp(Date) - Method in class net.ravendb.abstractions.data.IndexStats
Time of last reduce for this index.
setLastReplicatedAttachmentEtag(Etag) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastReplicatedEtag(Etag) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastReplicatedLastModified(Date) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastStats(RavenJArray) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLastSuccessTimestamp(Date) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setLevel(String) - Method in class net.ravendb.abstractions.data.LogItem
 
setListeners(DocumentSessionListeners) - Method in class net.ravendb.client.DocumentStoreBase
 
setListeners(DocumentSessionListeners) - Method in interface net.ravendb.client.IDocumentStore
 
setLoadDocumentCount(int) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setLoadDocumentDurationMs(long) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setLoadedDatabases(List<LoadedDatabaseStatistics>) - Method in class net.ravendb.abstractions.data.AdminStatistics
List of loaded databases with their statistics.
setLoadedFileSystems(List<FileSystemStats>) - Method in class net.ravendb.abstractions.data.AdminStatistics
List of loaded filesystems with their statistics.
setLockMode(IndexLockMode) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates current lock mode: - Unlock - all index definition changes acceptable - LockedIgnore - all index definition changes will be ignored, only log entry will be created - LockedError - all index definition changes will raise exception
setLockMode(IndexLockMode) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index lock mode: - Unlock - all index definition changes acceptable - LockedIgnore - all index definition changes will be ignored, only log entry will be created - LockedError - all index definition changes will raise exception
setLockMode(TransformerLockMode) - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
 
setLockMode(IndexLockMode) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setLoggerName(String) - Method in class net.ravendb.abstractions.data.LogItem
 
setManagedMemorySizeInMB(double) - Method in class net.ravendb.abstractions.data.AdminMemoryStatistics
Size (in megabytes) of managed memory held by server.
setMap(String) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
setMap(String) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setMapGroupFields(Map<String, String>) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Values for the the mapping group fields to use as the basis for comparison
setMapReduce(boolean) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates if it is a MapReduce index.
setMaps(Set<String>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
setMax(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
setMax(Double) - Method in class net.ravendb.abstractions.data.FacetValue
Stores maximum value if FacetAggregation.Max was set.
setMaxChunkVolumeInBytes(long) - Method in class net.ravendb.abstractions.data.ChunkedBulkInsertOptions
Max volume of all the documents could be sent in each bulk insert sub operation (Default: 8MB)
setMaxDocCount(int) - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
setMaxDocumentsPerChunk(int) - Method in class net.ravendb.abstractions.data.ChunkedBulkInsertOptions
Number of documents to send in each bulk insert sub operation (Default: 2048)
setMaximumDocumentFrequency(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words which occur in more than this many documents.
setMaximumDocumentFrequencyPercentage(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words which occur in more than this percentage of documents.
setMaximumNumberOfTokensParsed(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The maximum number of tokens to parse in each example doc field that is not stored with TermVector support.
setMaximumQueryTerms(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
A Query with no more than this many terms.
setMaximumWordLength(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words greater than this length or if 0 then this has no effect.
setMaxIndexOutputsPerDocument(Long) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index specific setting that limits the number of map outputs that an index is allowed to create for a one source document.
setMaxIndexOutputsPerDocument(Long) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Index specific setting that limits the number of map outputs that an index is allowed to create for a one source document.
setMaxIndexOutputsPerDocument(Long) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setMaxLengthOfQueryUsingGetUrl(int) - Method in class net.ravendb.client.document.DocumentConvention
 
setMaxNumberOfAttachmentsToExport(int) - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
setMaxNumberOfCachedRequests(int) - Method in class net.ravendb.client.document.DocumentStore
 
setMaxNumberOfDocumentsToExport(int) - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
setMaxNumberOfRequestsPerSession(int) - Method in class net.ravendb.client.document.DocumentConvention
Sets the default max number of requests per session.
setMaxNumberOfRequestsPerSession(int) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Sets the max number of requests per session.
setMaxNumberOfRequestsPerSession(int) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Sets the max number of requests per session.
setMaxOpsPerSec(Integer) - Method in class net.ravendb.abstractions.data.BulkOperationOptions
Limits the amount of base operation per second allowed.
setMaxResults(Integer) - Method in class net.ravendb.abstractions.data.Facet
Maximum number of results to return.
setMaxSize(Integer) - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
setMaxSuggestions(int) - Method in class net.ravendb.abstractions.data.SuggestionQuery
* Maximum number of suggestions to return.
setMaxTreeLevel(int) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setMaxX(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setMaxX(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
setMaxY(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setMaxY(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
setMaybeProperty(Field) - Method in class net.ravendb.client.linq.ExpressionInfo
 
setMaybeProperty(Field) - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
setMean(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
setMeanRate(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
setMemberType(Class<?>) - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
setMemory(AdminMemoryStatistics) - Method in class net.ravendb.abstractions.data.AdminStatistics
Current memory statistics.
setMergedIndex(IndexDefinition) - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
setMergeQueryResults(MergeQueryResultsFunc) - Method in class net.ravendb.client.shard.ShardStrategy
Merge the query results from all the shards into a single query results object
setMessage(String) - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Notification message.
setMessage(String) - Method in class net.ravendb.abstractions.data.LicensingStatus
 
setMessage(String) - Method in class net.ravendb.abstractions.data.LogItem
 
setMessage(String) - Method in class net.ravendb.client.connection.ServerClient.ErrorObjectProtoTransformer
 
setMessage(String) - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.commands.PatchCommandData
RavenJObject representing document's metadata.
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.commands.PutCommandData
RavenJObject representing document's metadata.
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
RavenJObject representing document's metadata.
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
RavenJObject representing attachment's metadata.
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
RavenJObject representing attachment's metadata.
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.data.BatchResult
Updated metadata of a document.
setMetadata(RavenJObject) - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
RavenJObject representing document's metadata.
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.data.JsonDocument
Metadata for the document
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Metadata for the document
setMetadata(RavenJObject) - Method in class net.ravendb.abstractions.data.StreamResult
Document metadata.
setMetadata(boolean) - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeChunk
 
setMetadata(String) - Method in class net.ravendb.abstractions.json.ConflictsResolver.MergeResult
 
setMetadata(RavenJObject) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setMetadata(RavenJObject) - Method in class net.ravendb.client.document.DocumentMetadata
 
setMethod(String) - Method in class net.ravendb.abstractions.data.BatchResult
Method used by the operation (PUT,DELETE,PATCH).
setMethod(HttpMethods) - Method in class net.ravendb.abstractions.data.GetRequest
 
setMethod(HttpMethods) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setMethod(HttpMethods) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setMetrics(FileSystemMetrics) - Method in class net.ravendb.abstractions.data.FileSystemStats
 
setMetrics(DatabaseMetrics) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Database metrics.
setMin(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
setMin(Double) - Method in class net.ravendb.abstractions.data.FacetValue
Stores minimum value if FacetAggregation.Min was set.
setMinimumDocumentFrequency(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words which do not occur in at least this many documents.
setMinimumEtagBeforeReplace(Etag) - Method in class net.ravendb.abstractions.data.SideBySideIndexes
 
setMinimumEtagBeforeReplace(Etag) - Method in class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
setMinimumTermFrequency(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore terms with less than this frequency in the source doc.
setMinimumWordLength(Integer) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Ignore words less than this length or if 0 then this has no effect.
setMinX(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setMinX(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
setMinY(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setMinY(double) - Method in class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
setMode(FacetMode) - Method in class net.ravendb.abstractions.data.Facet
Mode of a facet (Default, Ranges).
setModifyDocumentId(ModifyDocumentIdFunc) - Method in class net.ravendb.client.shard.ShardStrategy
 
setMostRecentAttachmentEtag(Etag) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
Deprecated.
setMostRecentDocumentEtag(Etag) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
 
setName(String) - Method in class net.ravendb.abstractions.data.Facet
Name of facet.
setName(Path<?>) - Method in class net.ravendb.abstractions.data.Facet
Name of facet.
setName(String) - Method in class net.ravendb.abstractions.data.FileSystemStats
 
setName(String) - Method in class net.ravendb.abstractions.data.IndexChangeNotification
Name of index for which notification was created
setName(String) - Method in class net.ravendb.abstractions.data.IndexStats
Index name.
setName(String) - Method in class net.ravendb.abstractions.data.IndexToAdd
The name of an index that will be added
setName(String) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Name of database.
setName(String) - Method in class net.ravendb.abstractions.data.PatchRequest
Property/field name to patch.
setName(String) - Method in class net.ravendb.abstractions.data.TransformerChangeNotification
Name of transformer for which notification was created
setName(String) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
This is the means by which the outside world refers to this index definition
setName(String) - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
Transformer name.
setName(String) - Method in class net.ravendb.client.linq.AggregationQuery
 
setNested(PatchRequest[]) - Method in class net.ravendb.abstractions.data.PatchRequest
Sets the nested operations to perform.
setNestedPath(boolean) - Method in class net.ravendb.client.linq.ExpressionInfo
 
setNestedPath(boolean) - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
setNestedPath(boolean) - Method in class net.ravendb.client.WhereParams
Is this a root property or not?
setNewField(String) - Method in class net.ravendb.client.linq.RenamedField
 
setNextWriteTransactionId(long) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setNonAuthoritativeInformation(Boolean) - Method in interface net.ravendb.abstractions.data.IJsonDocumentMetadata
Indicates whether this document is non authoritative (modified by uncommitted transaction).
setNonAuthoritativeInformation(Boolean) - Method in class net.ravendb.abstractions.data.JsonDocument
Indicates whether this document is non authoritative (modified by uncommitted transaction).
setNonAuthoritativeInformation(Boolean) - Method in class net.ravendb.abstractions.data.JsonDocumentMetadata
Indicates whether this document is non authoritative (modified by uncommitted transaction).
setNonAuthoritativeInformation(boolean) - Method in class net.ravendb.abstractions.data.QueryResult
Indicates whether any of the documents returned by this query are non authoritative (modified by uncommitted transaction).
setNonAuthoritativeInformation(boolean) - Method in class net.ravendb.client.RavenQueryStatistics
Sets a value indicating whether any of the documents returned by this query are non authoritative (modified by uncommitted transaction).
setNonAuthoritativeInformationTimeout(Long) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Sets the timeout to wait for authoritative information if encountered non authoritative document.
setNonAuthoritativeInformationTimeout(Long) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Sets the timeout to wait for authoritative information if encountered non authoritative document.
setNumberOfExportedAttachments(int) - Method in class net.ravendb.abstractions.smuggler.OperationState
 
setNumberOfExportedDocuments(int) - Method in class net.ravendb.abstractions.smuggler.OperationState
 
setNumOfCacheResets(int) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
setOneMinuteRate(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.MeterData
 
setOperation(String) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setOperationId(UUID) - Method in class net.ravendb.abstractions.data.BulkInsertChangeNotification
BulkInsert operation Id.
setOperationsHeaders(Map<String, String>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sets the operations headers
setOperationsHeaders(Map<String, String>) - Method in class net.ravendb.client.connection.ServerClient
 
setOperationType(ReplicationOperationTypes) - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
Operation type on which conflict occurred (Put, Delete).
setOriginalField(String) - Method in class net.ravendb.client.linq.RenamedField
 
setOriginalMetadata(RavenJObject) - Method in class net.ravendb.client.document.DocumentMetadata
 
setOriginalQueryType(Class) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
setOriginalQueryType(Class) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Sets the original query type incase of TransforWith usage.
setOriginalQueryType(Class) - Method in interface net.ravendb.client.linq.IRavenQueryable
Holds the original query type only when TransformWith is invoked otherwise null.
setOriginalQueryType(Class) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
 
setOriginalQueryType(Class) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
setOriginalQueryType(Class) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
setOriginalValue(RavenJObject) - Method in class net.ravendb.client.document.DocumentMetadata
 
setOutputCount(int) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setOverwriteExisting(boolean) - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Indicates in existing documents should be overwritten.
setOwner(IHoldProfilingInformation) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setPageSize(Integer) - Method in class net.ravendb.abstractions.data.FacetQuery
Page size for facet query results.
setPageSize(int) - Method in class net.ravendb.abstractions.data.IndexQuery
Maximum number of records that will be retrieved.
setPageStart(int) - Method in class net.ravendb.abstractions.data.FacetQuery
Page start for facet query results.
setPassword(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setPatch(ScriptedPatchRequest) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
ScriptedPatchRequest (using JavaScript) that is used to patch the document.
setPatches(PatchRequest[]) - Method in class net.ravendb.abstractions.commands.PatchCommandData
Array of patches that will be applied to the document
setPatchesIfMissing(PatchRequest[]) - Method in class net.ravendb.abstractions.commands.PatchCommandData
Array of patches to apply to a default document if the document is missing
setPatchIfMissing(ScriptedPatchRequest) - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
ScriptedPatchRequest (using JavaScript) that is used to patch a default document if the document is missing.
setPatchResult(PatchResult) - Method in class net.ravendb.abstractions.data.BatchResult
Result of a PATCH operation.
setPatchResult(PatchResult) - Method in class net.ravendb.abstractions.data.PatchResultData
Result of patch operation: - DocumentDoesNotExists - document does not exists, operation was a no-op, - Patched - document was properly patched, - Tested - document was properly tested, - Skipped - document was not patched, because skipPatchIfEtagMismatch was set and the etag did not match, - NotModified - neither document body not metadata was changed during patch operation
setPath(String) - Method in class net.ravendb.client.linq.ExpressionInfo
 
setPath(String) - Method in class net.ravendb.client.linq.LinqPathProvider.Result
 
setPendingSyncs(List<SynchronizationDetails>) - Method in class net.ravendb.abstractions.data.FileSystemStats
 
setPercentiles(Map<String, Double>) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
setPerformance(IndexStats.IndexingPerformanceStats[]) - Method in class net.ravendb.abstractions.data.IndexStats
Performance statistics for this index.
setPopularity(boolean) - Method in class net.ravendb.abstractions.data.SuggestionQuery
Whatever to return the terms in order of popularity
setPosition(Integer) - Method in class net.ravendb.abstractions.data.PatchRequest
Only valid for collection types.
setPostedData(String) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setPrefetches(FutureBatchStats[]) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Information about future indexing batches.
setPrefetchingUser(PrefetchingUser) - Method in class net.ravendb.abstractions.data.FutureBatchStats
Indicates what prefetching user (indexer, replicator, sql replicator) calculated the future batch.
setPreserveDocumentPropertiesNotFoundOnModel(boolean) - Method in class net.ravendb.client.document.DocumentConvention
Controls whatever properties on the object that weren't de-serialized to object properties will be preserved when saving the document again.
setPrevVal(RavenJToken) - Method in class net.ravendb.abstractions.data.PatchRequest
Sets the previous value, which is compared against the current value to verify a change isn't overwriting new values.
setPriority(IndexStats.IndexingPriority) - Method in class net.ravendb.abstractions.data.IndexStats
Index priority (Normal, Disabled, Idle, Abandoned, Error)
setPriority(IndexStats.IndexingPriority) - Method in class net.ravendb.abstractions.data.IndexToAdd
Priority of an index
setPriority(IndexStats.IndexingPriority) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
index can have a priority that controls how much power of the indexing process it is allowed to consume.
setProblematicText(String) - Method in exception net.ravendb.abstractions.exceptions.IndexCompilationException
Value of a problematic property.
setProblematicText(String) - Method in class net.ravendb.client.connection.ServerClient.IndexErrorObjectProto
 
setProductVersion(String) - Method in class net.ravendb.abstractions.data.BuildNumber
 
setPropertiesMatch(Map<String, RavenJToken>) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
setPropertiesNotMatch(Map<String, RavenJToken>) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
setPullingRequestTimeout(Long) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setQuery(IndexQuery) - Method in class net.ravendb.abstractions.data.FacetQuery
Query that should be ran on index.
setQuery(String) - Method in class net.ravendb.abstractions.data.GetRequest
Query information e.g.
setQuery(String) - Method in class net.ravendb.abstractions.data.IndexQuery
Actual query that will be performed (Lucene syntax).
setQuery(IndexQuery) - Method in class net.ravendb.client.shard.ShardRequestData
 
setQueryListeners(List<IDocumentQueryListener>) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazyMoreLikeThisOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazySuggestOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.batches.LazyTransformerLoadOperation
 
setQueryResult(QueryResult) - Method in class net.ravendb.client.document.LazyFacetsOperation
 
setQueryShape(String) - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Shape in WKT format.
setRadiusUnitOverride(SpatialOptions.SpatialUnits) - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Overrides the units defined in the spatial index
setRange(String) - Method in class net.ravendb.abstractions.data.FacetValue
Name of range for which facet value applies.
setRange(HiLoKeyGeneratorBase.RangeValue) - Method in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
setRanges(List<String>) - Method in class net.ravendb.abstractions.data.Facet
List of facet ranges.
setRanges(BooleanExpression...) - Method in class net.ravendb.abstractions.data.Facet
List of facet ranges.
setRanges(List<BooleanExpression>) - Method in class net.ravendb.client.linq.AggregationQueryDsl
 
setReadTime(long) - Method in class net.ravendb.client.connection.CachedRequest
 
setReduce(String) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index reduce function
setReduce(String) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setReducedPerSecond(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setReduceIndexingAttempts(Integer) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many times database tried to index documents (reduce) using this index.
setReduceIndexingErrors(Integer) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many reducing attempts failed.
setReduceIndexingSuccesses(Integer) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates how many reducing attempts succeeded.
setRelation(SpatialOptions.SpatialRelation) - Method in class net.ravendb.client.spatial.SpatialCriteria
 
setRemainingHits(int) - Method in class net.ravendb.abstractions.data.FacetResult
The number of remaining hits outside of those covered by the Values terms.
setRemainingTerms(List<String>) - Method in class net.ravendb.abstractions.data.FacetResult
A list of remaining terms in term sort order for terms that are outside of the MaxResults count.
setRemainingTermsCount(int) - Method in class net.ravendb.abstractions.data.FacetResult
The number of remaining terms outside of those covered by the Values terms.
setReplaceTimeUtc(Date) - Method in class net.ravendb.abstractions.data.SideBySideIndexes
 
setReplaceTimeUtc(Date) - Method in class net.ravendb.abstractions.indexing.IndexReplaceDocument
 
setReplicationBatchSizeHistogram(Map<String, DatabaseMetrics.HistogramData>) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setReplicationBatchSizeMeter(Map<String, DatabaseMetrics.MeterData>) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setReplicationDurationHistogram(Map<String, DatabaseMetrics.HistogramData>) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setReplicationDurationMeter(Map<String, DatabaseMetrics.MeterData>) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setReplicationInformerFactory(ReplicationInformerFactory) - Method in class net.ravendb.client.document.DocumentConvention
 
setReport(Action1<String>) - Method in class net.ravendb.client.document.BulkInsertOperation
 
setReport(Action1<String>) - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
setReport(Action1<String>) - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
Report of the progress of operation
setReport(Action1<String>) - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
setRequestDuration(DatabaseMetrics.HistogramData) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setRequests(DatabaseMetrics.MeterData) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setRequests(DatabaseMetrics.MeterData) - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
setRequests(List<RequestResultArgs>) - Method in class net.ravendb.client.connection.profiling.ProfilingInformation
 
setRequestsDuration(DatabaseMetrics.HistogramData) - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
setRequestsPerSecond(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setRequestsPerSecond(double) - Method in class net.ravendb.abstractions.data.FileSystemMetrics
 
setRequestsTimeoutFor(long) - Method in class net.ravendb.client.document.DocumentStore
Setup the WebRequest timeout for the session
setRequestsTimeoutFor(long) - Method in interface net.ravendb.client.IDocumentStore
Setup the WebRequest timeout for the session
setRequestsTimeoutFor(long) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
setRequestTimeout(Long) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
setRequiresRetry(boolean) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
setRequiresRetry(boolean) - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
setRequiresRetry(boolean) - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
setRequiresRetry(boolean) - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
setResponseHeaders(Map<String, String>) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
setResponseStatusCode(int) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
setRestoreStartTimeout(Integer) - Method in class net.ravendb.abstractions.data.DatabaseRestoreRequest
Maximum number of seconds to wait for restore to start (only one restore can run simultaneously).
setResult(RavenJToken) - Method in class net.ravendb.abstractions.data.GetResponse
Response result as JSON.
setResult(String) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setResult(T) - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
setResult(Object) - Method in class net.ravendb.client.document.batches.LazyLoadOperation
 
setResult(Object) - Method in class net.ravendb.client.document.batches.LazyMultiLoadOperation
 
setResult(Object) - Method in class net.ravendb.client.document.batches.LazyQueryOperation
 
setResult(Object) - Method in class net.ravendb.client.document.batches.LazyStartsWithOperation
 
setResult(JsonDocument) - Method in class net.ravendb.client.document.sessionoperations.LoadOperation
 
setResult(MultiLoadResult) - Method in class net.ravendb.client.document.sessionoperations.MultiLoadOperation
 
setResultEtag(Etag) - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
setResultEtag(Etag) - Method in class net.ravendb.abstractions.data.QueryResult
The ETag value for this index current state, which include what docs were indexed, what document were deleted, etc.
setResultEtag(Etag) - Method in class net.ravendb.client.RavenQueryStatistics
 
setResults(Map<String, FacetResult>) - Method in class net.ravendb.abstractions.data.FacetResults
A list of results for the facet.
setResults(List<RavenJObject>) - Method in class net.ravendb.abstractions.data.MultiLoadResult
Loaded documents.
setResults(List<RavenJObject>) - Method in class net.ravendb.abstractions.data.QueryResult
Sets the document resulting from this query.
setResultSize(long) - Method in class net.ravendb.abstractions.data.QueryResult
The size of the request which were sent from the server.
setResultSize(long) - Method in class net.ravendb.client.RavenQueryStatistics
 
setResultsTransformer(String) - Method in class net.ravendb.abstractions.data.IndexQuery
Name of transformer to use on query results.
setResultsTransformer(String) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Transformer to use on the query results.
setResultTransformer(String) - Method in class net.ravendb.client.document.DocumentQuery
 
setResultTransformer(Class<TTransformer>, Class<TTransformerResult>) - Method in class net.ravendb.client.document.DocumentQuery
 
setResultTransformer(Class<TTransformer>, Class<TTransformerResult>) - Method in interface net.ravendb.client.IDocumentQuery
Sets a transformer to use after executing a query
setResultTransformer(String) - Method in interface net.ravendb.client.IDocumentQueryBase
Sets a transformer to use after executing a query
setRetries(int) - Method in class net.ravendb.abstractions.data.FutureBatchStats
Number of retries till the future batch calculation succeeded.
setRetrieveDetails(boolean) - Method in class net.ravendb.abstractions.data.BulkOperationOptions
Determines whether operation details about each document should be returned by server.
setRetryOnconcurrencyExceptions(boolean) - Method in class net.ravendb.abstractions.data.ScriptedIndexResults
Indicates if patcher should retry applying the scripts when concurrency exception occurs.
setRetryOnconcurrencyExceptions(boolean) - Method in class net.ravendb.client.indexes.AbstractScriptedIndexCreationTask
 
setRootPages(long) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setSaveEnumsAsIntegers(boolean) - Method in class net.ravendb.client.document.Convention
Saves Enums as integers and instruct the Linq provider to query enums as integer values.
setScoreExplanations(Map<String, String>) - Method in class net.ravendb.abstractions.data.QueryResult
Explanations of document scores (if requested).
setScript(String) - Method in class net.ravendb.abstractions.data.ScriptedPatchRequest
JavaScript function to use to patch a document
setSecuredSettings(Map<String, String>) - Method in class net.ravendb.abstractions.data.DatabaseDocument
Database settings (secured).
setSelf(String) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
 
setServerName(String) - Method in class net.ravendb.abstractions.data.AdminStatistics
Name of a server.
setSettings(Map<String, String>) - Method in class net.ravendb.abstractions.data.DatabaseDocument
Database settings (unsecured).
setShape(Object) - Method in class net.ravendb.client.spatial.SpatialCriteria
 
setShardAccessStrategy(IShardAccessStrategy) - Method in class net.ravendb.client.shard.ShardStrategy
 
setShardResolutionStrategy(IShardResolutionStrategy) - Method in class net.ravendb.client.shard.ShardStrategy
 
setSharedOperationsHeaders(Map<String, String>) - Method in class net.ravendb.client.DocumentStoreBase
 
setSharedOperationsHeaders(Map<String, String>) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
setShouldAggressiveCacheTrackChanges(boolean) - Method in class net.ravendb.client.document.DocumentConvention
Whatever or not RavenDB should in the aggressive cache mode use Changes API to track changes and rebuild the cache.
setShouldCacheRequest(boolean) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
setShouldCacheRequest(RequestCachePolicy) - Method in class net.ravendb.client.document.Convention
 
setShouldSaveChangesForceAggressiveCacheCheck(boolean) - Method in class net.ravendb.client.document.DocumentConvention
Whatever or not RavenDB should in the aggressive cache mode should force the aggressive cache to check with the server after we called SaveChanges() on a non empty data set.
setShowTimings(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Indicates if detailed timings should be calculated for various query parts (Lucene search, loading documents, transforming results).
setSideBySideIndex(boolean) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
setSize(int) - Method in class net.ravendb.abstractions.data.Attachment
Deprecated.
Attachment size in bytes.
setSize(int) - Method in class net.ravendb.abstractions.data.AttachmentInformation
Deprecated.
Attachment size in bytes.
setSize(int) - Method in class net.ravendb.abstractions.data.FutureBatchStats
Number of documents in batch.
setSkipIndexReplication(boolean) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
Sets a flag that controls whether index is replicated to the node or not
setSkipOverwriteIfUnchanged(boolean) - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Determines whether should skip to overwrite a document when it is updated by exactly the same document (by comparing a content and metadata as well).
setSkipPatchIfEtagMismatch(boolean) - Method in class net.ravendb.abstractions.commands.PatchCommandData
If set to true, _and_ the Etag is specified then the behavior of the patch in the case of etag mismatch is different.
setSkippedResults(Reference<Integer>) - Method in class net.ravendb.abstractions.data.IndexQuery
For internal use only.
setSkippedResults(int) - Method in class net.ravendb.abstractions.data.QueryResult
Sets the skipped results
setSkippedResults(int) - Method in class net.ravendb.client.RavenQueryStatistics
Sets the skipped results
setSkipServerCheck(boolean) - Method in class net.ravendb.client.connection.CachedRequestOp
 
setSkipServerCheck(boolean) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
setSortedFields(SortedField[]) - Method in class net.ravendb.abstractions.data.IndexQuery
Array of fields containing sorting information.
setSortHints(Map<String, SortOptions>) - Method in class net.ravendb.abstractions.data.IndexQuery
For internal use only.
setSortOptions(Map<String, SortOptions>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field sorting settings.
setSortOptions(Map<Path<?>, SortOptions>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setSortOptionsStrings(Map<String, SortOptions>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setSource(String) - Method in class net.ravendb.abstractions.replication.ReplicationDocument
 
setSpatialFieldName(String) - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
 
setSpatialIndexes(Map<String, SpatialOptions>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field spatial settings.
setSpatialIndexes(Map<Path<?>, SpatialOptions>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setSpatialIndexesStrings(Map<String, SpatialOptions>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setSpatialRelation(SpatialOptions.SpatialRelation) - Method in class net.ravendb.abstractions.data.SpatialIndexQuery
Spatial relation (Within, Contains, Disjoint, Intersects, Nearby)
setStale(boolean) - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
setStale(boolean) - Method in class net.ravendb.abstractions.data.QueryResult
Sets a value indicating whether the index is stale.
setStale(boolean) - Method in class net.ravendb.client.RavenQueryStatistics
Whatever the query returned potentially stale results
setStaleIndexes(String[]) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
List of stale index names in database.
setStaleIndexMaps(DatabaseMetrics.HistogramData) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setStaleIndexReduces(DatabaseMetrics.HistogramData) - Method in class net.ravendb.abstractions.data.DatabaseMetrics
 
setStaleTimeout(Long) - Method in class net.ravendb.abstractions.data.BulkOperationOptions
If AllowStale is set to false and index is stale, then this is the maximum timeout to wait for index to become non-stale.
setStart(int) - Method in class net.ravendb.abstractions.data.IndexQuery
Number of records that should be skipped.
setStarted(Date) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setStartEtag(Etag) - Method in class net.ravendb.abstractions.data.SubscriptionCriteria
 
setStartEtags(LastEtagsInfo) - Method in class net.ravendb.abstractions.smuggler.ExportOptions
 
setStats(List<ReplicationStatistics.DestinationStats>) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics
 
setStatus(int) - Method in class net.ravendb.abstractions.data.GetResponse
Response HTTP status code.
setStatus(String) - Method in class net.ravendb.abstractions.data.LicensingStatus
 
setStatus(RequestStatus) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setStdev(double) - Method in class net.ravendb.abstractions.data.DatabaseMetrics.HistogramData
 
setStopWordsDocumentId(String) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
The document id containing the custom stop words
setStorageEngine(String) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Storage engine used by database (esent, voron).
setStorageStats(StorageStats) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Database storage statistics.
setStoreListeners(List<IDocumentStoreListener>) - Method in class net.ravendb.client.document.DocumentSessionListeners
 
setStores(Map<String, FieldStorage>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field storage settings.
setStores(Map<Path<?>, FieldStorage>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setStoresStrings(Map<String, FieldStorage>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setStrategy(SubscriptionOpeningStrategy) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setStrategy(SpatialOptions.SpatialSearchStrategy) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setSubscriptionId(Long) - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
setSuccess(boolean) - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
setSuggestions(String[]) - Method in class net.ravendb.abstractions.data.SuggestionQueryResult
Suggestions based on the term and dictionary.
setSuggestions(Map<String, SuggestionOptions>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field suggestion settings.
setSuggestions(List<MergeSuggestions>) - Method in class net.ravendb.abstractions.indexing.IndexMergeResults
 
setSuggestions(Map<Path<?>, SuggestionOptions>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setSum(Double) - Method in class net.ravendb.abstractions.data.FacetValue
Stores sum of all values if FacetAggregation.Sum was set.
setSupportsDtc(boolean) - Method in class net.ravendb.abstractions.data.DatabaseStatistics
Indicates if database supports DTC transactions.
setSurpassingIndex(String) - Method in class net.ravendb.abstractions.indexing.MergeSuggestions
 
setTag(Object) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
setTempIndexScore(Float) - Method in class net.ravendb.abstractions.data.JsonDocument
The ranking of this result in the current query
setTerm(String) - Method in class net.ravendb.abstractions.data.SuggestionQuery
Term is what the user likely entered, and will used as the basis of the suggestions.
setTermSortMode(FacetTermSortMode) - Method in class net.ravendb.abstractions.data.Facet
Indicates how terms should be sorted.
setTermVectors(Map<String, FieldTermVector>) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
Index field term vector settings.
setTermVectors(Map<Path<?>, FieldTermVector>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setTermVectorsStrings(Map<String, FieldTermVector>) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
setTestIndex(boolean) - Method in class net.ravendb.abstractions.data.IndexStats
Indicates if this is a test index (works on a limited data set - for testing purposes only)
setTextIndex(boolean) - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
setTime(Date) - Method in class net.ravendb.client.connection.CachedRequest
 
setTimeOfLastClientActivity(Date) - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
setTimeOfSendingLastBatch(Date) - Method in class net.ravendb.abstractions.data.SubscriptionConfig
 
setTimeout(Long) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
setTimeout(HttpRequestBase, long) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
setTimestamp(String) - Method in class net.ravendb.abstractions.data.FutureBatchStats
Time when future batch was created.
setTimestamp(Date) - Method in class net.ravendb.abstractions.data.IndexingError
 
setTimeStamp(Date) - Method in class net.ravendb.abstractions.data.LogItem
 
setTimestamp(Date) - Method in class net.ravendb.client.RavenQueryStatistics
The time when the query results were unstale.
setTimeToWaitBeforeConnectionRetry(Integer) - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
setTimingsInMilliseconds(Map<String, Double>) - Method in class net.ravendb.abstractions.data.QueryResult
Detailed timings for various parts of a query (Lucene search, loading documents, transforming results) - if requested.
setTimingsInMilliseconds(Map<String, Double>) - Method in class net.ravendb.client.RavenQueryStatistics
 
setTotalClientDuration(Long) - Method in class net.ravendb.client.document.ResponseTimeInformation
 
setTotalDatabaseHumaneSize(String) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Total database size in a more human readable format.
setTotalDatabaseSize(long) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Total database size in bytes.
setTotalNumberOfRequests(int) - Method in class net.ravendb.abstractions.data.AdminStatistics
Total number of requests received since server startup.
setTotalProcessMemorySizeInMB(double) - Method in class net.ravendb.abstractions.data.AdminMemoryStatistics
Total size of memory held by server.
setTotalResults(int) - Method in class net.ravendb.abstractions.data.QueryHeaderInformation
 
setTotalResults(int) - Method in class net.ravendb.abstractions.data.QueryResult
Sets the total results for this query
setTotalResults(int) - Method in class net.ravendb.client.RavenQueryStatistics
What was the total count of the results that matched the query
setTotalServerDuration(Long) - Method in class net.ravendb.client.document.ResponseTimeInformation
 
setTouchCount(int) - Method in class net.ravendb.abstractions.data.IndexStats
 
setTransactionalStorageAllocatedSize(long) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (allocated) of a transactional storage in bytes.
setTransactionalStorageAllocatedSizeHumaneSize(String) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (allocated) of a transactional storage in a more human readable format.
setTransactionalStorageUsedSize(long) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (used) of a transactional storage in bytes.
setTransactionalStorageUsedSizeHumaneSize(String) - Method in class net.ravendb.abstractions.data.LoadedDatabaseStatistics
Size (used) of a transactional storage in a more human readable format.
setTransactionRecoveryStorage(ITransactionRecoveryStorage) - Method in class net.ravendb.client.DocumentStoreBase
 
setTransformerLock(String, TransformerLockMode) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Sets the transformer's lock mode
setTransformerLock(String, TransformerLockMode) - Method in class net.ravendb.client.connection.ServerClient
 
setTransformerParameters(Map<String, RavenJToken>) - Method in class net.ravendb.abstractions.data.IndexQuery
Parameters that will be passed to transformer (if specified).
setTransformerParameters(Map<String, RavenJToken>) - Method in class net.ravendb.abstractions.data.MoreLikeThisQuery
Parameters that will be passed to transformer.
setTransformerParameters(Map<String, RavenJToken>) - Method in class net.ravendb.client.document.DocumentQuery
 
setTransformerParameters(Map<String, RavenJToken>) - Method in class net.ravendb.client.document.RavenLoadConfiguration
 
setTransformerParameters(Map<String, RavenJToken>) - Method in interface net.ravendb.client.IDocumentQuery
Get the facets as per the specified facets with the given start and pageSize
setTransformResults(String) - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
Projection function.
setTransformTypeTagNameToDocumentKeyPrefix(TypeTagNameToDocumentKeyPrefixTransformer) - Method in class net.ravendb.client.document.DocumentConvention
Translate the type tag name to the document key prefix
setTransitiveReplicationBehavior(ReplicationDestination.TransitiveReplicationOptions) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setType(DataSubscriptionChangeTypes) - Method in class net.ravendb.abstractions.data.DataSubscriptionChangeNotification
Type of subscription change
setType(DocumentChangeTypes) - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Type of change that occurred on document.
setType(IndexChangeTypes) - Method in class net.ravendb.abstractions.data.IndexChangeNotification
Type of change that occurred on index.
setType(PatchCommandType) - Method in class net.ravendb.abstractions.data.PatchRequest
Type of patch operation.
setType(SynchronizationType) - Method in class net.ravendb.abstractions.data.SynchronizationDetails
 
setType(TransformerChangeTypes) - Method in class net.ravendb.abstractions.data.TransformerChangeNotification
Type of change that occurred on transformer.
setType(SpatialOptions.SpatialFieldType) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setTypeName(String) - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
Document type name.
setUnallocatedPagesAtEndOfFile(long) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setUnits(SpatialOptions.SpatialUnits) - Method in class net.ravendb.abstractions.indexing.SpatialOptions
 
setUnmergables(Map<String, String>) - Method in class net.ravendb.abstractions.indexing.IndexMergeResults
 
setup(UuidType, long) - Method in class net.ravendb.abstractions.data.Etag
 
setUptime(String) - Method in class net.ravendb.abstractions.data.AdminStatistics
Server uptime.
setUrl(String) - Method in class net.ravendb.abstractions.data.GetRequest
Request url (relative).
setUrl(String) - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
setUrl(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setUrl(String) - Method in class net.ravendb.abstractions.replication.ReplicationStatistics.DestinationStats
 
setUrl(String) - Method in class net.ravendb.client.connection.profiling.RequestResultArgs
 
setUrl(String) - Method in class net.ravendb.client.connection.ReplicationInformer.FailoverStatusChangedEventArgs
 
setUrl(String) - Method in class net.ravendb.client.document.DocumentSubscriptions.ErrorAndUrl
 
setUrl(String) - Method in class net.ravendb.client.document.ResponseTimeInformation.ResponseTimeItem
 
setUrl(String) - Method in class net.ravendb.client.DocumentStoreBase
 
setUrl(String) - Method in class net.ravendb.client.exceptions.ServerRequestError
 
setUsedDataFileSizeInBytes(long) - Method in class net.ravendb.abstractions.data.VoronStorageStats
 
setUseOptimisticConcurrency(boolean) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Sets a value indicating whether the session should use optimistic concurrency.
setUseOptimisticConcurrency(boolean) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Sets a value indicating whether the session should use optimistic concurrency.
setUseParallelMultiGet(boolean) - Method in class net.ravendb.client.document.DocumentConvention
Instruct RavenDB to parallel Multi Get processing when handling lazy requests
setUsername(String) - Method in class net.ravendb.abstractions.replication.ReplicationDestination
 
setValue(Object) - Method in class net.ravendb.abstractions.data.BoostedValue
Boosted value.
setValue(long) - Method in class net.ravendb.abstractions.data.EnumSet
 
setValue(RavenJToken) - Method in class net.ravendb.abstractions.data.PatchRequest
New value.
setValue(Object) - Method in class net.ravendb.abstractions.json.linq.RavenJValue
Sets new value and type of RavenJValue.
setValue(AtomicLong) - Method in class net.ravendb.client.connection.ReplicationInformerBase.FailureCounter
 
setValue(Object) - Method in class net.ravendb.client.WhereParams
 
setValues(List<FacetValue>) - Method in class net.ravendb.abstractions.data.FacetResult
The facet terms and hits up to a limit of MaxResults items (as specified in the facet setup document), sorted in TermSortMode order (as indicated in the facet setup document).
setValues(Map<String, Object>) - Method in class net.ravendb.abstractions.data.ScriptedPatchRequest
Additional arguments passed to JavaScript function from Script.
setVoronStats(VoronStorageStats) - Method in class net.ravendb.abstractions.data.StorageStats
 
setWaitForNonStaleResults(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
CAUTION.
setWaitForNonStaleResultsAsOfNow(boolean) - Method in class net.ravendb.abstractions.data.IndexQuery
Used to calculate index staleness.
setWaitingTimeSinceLastBatchCompleted(String) - Method in class net.ravendb.abstractions.data.IndexStats.IndexingPerformanceStats
 
setWasDisposed(boolean) - Method in class net.ravendb.client.DocumentStoreBase
 
setWasTimeout(boolean) - Method in class net.ravendb.client.connection.ReplicationInformerBase.OperationResult
 
setWriteTimeoutMiliseconds(int) - Method in class net.ravendb.abstractions.data.BulkInsertOptions
Maximum timeout in milliseconds to wait for document write.
ShapeConverter - Class in net.ravendb.abstractions.spatial
Converts shape objects to strings, if they are not already a string
ShapeConverter() - Constructor for class net.ravendb.abstractions.spatial.ShapeConverter
 
shardDbCommands - Variable in class net.ravendb.client.shard.BaseShardedDocumentSession
 
shardedBulkInsert() - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
shardedBulkInsert(String) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
shardedBulkInsert(String, ShardedDocumentStore, BulkInsertOptions) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
ShardedBulkInsertOperation - Class in net.ravendb.client.document
 
ShardedBulkInsertOperation(String, ShardedDocumentStore, BulkInsertOptions) - Constructor for class net.ravendb.client.document.ShardedBulkInsertOperation
 
ShardedDatabaseChanges - Class in net.ravendb.client.shard
 
ShardedDatabaseChanges(IDatabaseChanges[]) - Constructor for class net.ravendb.client.shard.ShardedDatabaseChanges
 
ShardedDocumentQuery<T> - Class in net.ravendb.client.shard
 
ShardedDocumentQuery(Class<T>, InMemoryDocumentSessionOperations, Function1<ShardRequestData, List<Tuple<String, IDatabaseCommands>>>, ShardStrategy, String, String[], String[], List<IDocumentQueryListener>, boolean) - Constructor for class net.ravendb.client.shard.ShardedDocumentQuery
 
ShardedDocumentSession - Class in net.ravendb.client.shard
 
ShardedDocumentSession(String, ShardedDocumentStore, DocumentSessionListeners, UUID, ShardStrategy, Map<String, IDatabaseCommands>) - Constructor for class net.ravendb.client.shard.ShardedDocumentSession
Initializes a new instance of the ShardedDocumentSession class.
ShardedDocumentStore - Class in net.ravendb.client.shard
Implements a sharded document store Hiding most sharding details behind this and the ShardedDocumentSession gives you the ability to use sharding without really thinking about this too much
ShardedDocumentStore(ShardStrategy) - Constructor for class net.ravendb.client.shard.ShardedDocumentStore
Initializes a new instance of the ShardedDocumentStore class.
ShardedHiloKeyGenerator - Class in net.ravendb.client.shard
 
ShardedHiloKeyGenerator(ShardedDocumentStore, int) - Constructor for class net.ravendb.client.shard.ShardedHiloKeyGenerator
 
ShardedObservable<T> - Class in net.ravendb.client.shard
 
ShardedObservable(List<IObservable<T>>) - Constructor for class net.ravendb.client.shard.ShardedObservable
 
ShardedRavenQueryInspector<T> - Class in net.ravendb.client.shard
 
ShardedRavenQueryInspector(ShardStrategy, Collection<IDatabaseCommands>) - Constructor for class net.ravendb.client.shard.ShardedRavenQueryInspector
 
ShardFieldForQueryingFunc - Interface in net.ravendb.client.shard
 
shardIds - Variable in class net.ravendb.client.shard.DefaultShardResolutionStrategy
 
ShardingErrorHandle<TDatabaseCommands> - Interface in net.ravendb.client.shard
 
shardingOn(Path<TResult>) - Method in class net.ravendb.client.shard.DefaultShardResolutionStrategy
 
shardingOn(Path<TResult>, Function1<TResult, String>, Function1<String, String>) - Method in class net.ravendb.client.shard.DefaultShardResolutionStrategy
 
shardingOn(Class<T>) - Method in class net.ravendb.client.shard.ShardStrategy
Instructs the sharding strategy to shard the entityClazz instances based on round robin strategy.
shardingOn(Path<S>) - Method in class net.ravendb.client.shard.ShardStrategy
Instructs the sharding strategy to shard the T instances based on the property specified in shardingProperty
shardingOn(Path<S>, Function1<S, String>) - Method in class net.ravendb.client.shard.ShardStrategy
Instructs the sharding strategy to shard the T instances based on the property specified in shardingProperty
shardingOn(Path<S>, Function1<S, String>, Function1<String, String>) - Method in class net.ravendb.client.shard.ShardStrategy
Instructs the sharding strategy to shard the T instances based on the property specified in shardingProperty
ShardReduceFunction - Interface in net.ravendb.client.shard
 
ShardRequestData - Class in net.ravendb.client.shard
Information required to resolve the appropriate shard for an entity / entity and key
ShardRequestData(List<String>, Class<?>) - Constructor for class net.ravendb.client.shard.ShardRequestData
 
ShardRequestData() - Constructor for class net.ravendb.client.shard.ShardRequestData
 
shards - Variable in class net.ravendb.client.shard.BaseShardedDocumentSession.IdToLoad
 
ShardStrategy - Class in net.ravendb.client.shard
 
ShardStrategy(Map<String, IDocumentStore>) - Constructor for class net.ravendb.client.shard.ShardStrategy
 
SharpAwareJacksonAnnotationIntrospector - Class in net.ravendb.abstractions.basic
Performs custom enum serialization for enums annotated with UseSharpEnum In Java there is convention for enums values: THIS_IS_ENUM, in .NET we have: ThisIsEnum.
SharpAwareJacksonAnnotationIntrospector() - Constructor for class net.ravendb.abstractions.basic.SharpAwareJacksonAnnotationIntrospector
 
SharpEnum - Class in net.ravendb.abstractions.basic
Utility class for inter-language enum conversion
SharpEnum() - Constructor for class net.ravendb.abstractions.basic.SharpEnum
 
shouldCacheRequest(String) - Method in interface net.ravendb.client.delegates.RequestCachePolicy
 
shouldCacheRequest(String) - Method in class net.ravendb.client.document.Convention
Whatever or not RavenDB should cache the request to the specified url.
shouldExecuteUsing(OperationMetadata, OperationMetadata, int, HttpMethods, boolean, Exception) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
shouldExplainScores - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Determine if scores of query results should be explained
shouldQueryAgain(Exception) - Method in class net.ravendb.client.document.sessionoperations.QueryOperation
 
showQueryTimings - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Indicates if detailed timings should be calculated for various query parts (Lucene search, loading documents, transforming results).
showTimings() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
showTimings() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
showTimings() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
showTimings() - Method in interface net.ravendb.client.IDocumentQueryBase
Enables calculation of timings for various parts of a query (Lucene search, loading documents, transforming results).
showTimings() - Method in interface net.ravendb.client.IDocumentQueryCustomization
Enables calculation of timings for various parts of a query (Lucene search, loading documents, transforming results).
SIDE_BY_SIDE_INDEX_NAME_PREFIX - Static variable in class net.ravendb.abstractions.data.Constants
 
sideBySideExecute(IDocumentStore) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
sideBySideExecute(IDocumentStore, Etag, Date) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
sideBySideExecute(IDatabaseCommands, DocumentConvention, Etag, Date) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Executes the index creation using in side-by-side mode.
sideBySideExecuteIndex(AbstractIndexCreationTask) - Method in class net.ravendb.client.DocumentStoreBase
 
sideBySideExecuteIndex(AbstractIndexCreationTask, Etag, Date) - Method in class net.ravendb.client.DocumentStoreBase
 
sideBySideExecuteIndex(AbstractIndexCreationTask) - Method in interface net.ravendb.client.IDocumentStore
Executes the index creation in side-by-side mode.
sideBySideExecuteIndex(AbstractIndexCreationTask, Etag, Date) - Method in interface net.ravendb.client.IDocumentStore
Executes the index creation in side-by-side mode.
sideBySideExecuteIndex(AbstractIndexCreationTask, Etag, Date) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
sideBySideExecuteIndexes(List<AbstractIndexCreationTask>) - Method in class net.ravendb.client.DocumentStoreBase
 
sideBySideExecuteIndexes(List<AbstractIndexCreationTask>, Etag, Date) - Method in class net.ravendb.client.DocumentStoreBase
 
sideBySideExecuteIndexes(List<AbstractIndexCreationTask>) - Method in interface net.ravendb.client.IDocumentStore
 
sideBySideExecuteIndexes(List<AbstractIndexCreationTask>, Etag, Date) - Method in interface net.ravendb.client.IDocumentStore
 
sideBySideExecuteIndexes(List<AbstractIndexCreationTask>) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
sideBySideExecuteIndexes(List<AbstractIndexCreationTask>, Etag, Date) - Method in class net.ravendb.client.shard.ShardedDocumentStore
 
SideBySideIndexes - Class in net.ravendb.abstractions.data
 
SideBySideIndexes() - Constructor for class net.ravendb.abstractions.data.SideBySideIndexes
 
SimpleCache - Class in net.ravendb.client.util
 
SimpleCache(int) - Constructor for class net.ravendb.client.util.SimpleCache
 
SINGLE - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
single() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
single() - Method in class net.ravendb.client.document.DocumentQuery
 
single() - Method in interface net.ravendb.client.IDocumentQuery
Returns single result
single() - Method in interface net.ravendb.client.IDocumentQueryBase
Returns first element or throws if sequence is empty or contains more than one element.
single(Iterator<T>) - Static method in class net.ravendb.client.linq.EnumerableUtils
 
single() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Return value is based on result amount: 2 entries and over: throws exception 1 entry - return it 0 - throws
single(BooleanExpression) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Return value is based on result amount.
single() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
single(BooleanExpression) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
SINGLE_OR_DEFAULT - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
SingleAuthTokenRetriever - Class in net.ravendb.client.util
 
SingleAuthTokenRetriever(IHoldProfilingInformation, HttpJsonRequestFactory, Convention, Map<String, String>, OperationMetadata) - Constructor for class net.ravendb.client.util.SingleAuthTokenRetriever
 
singleOrDefault() - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
singleOrDefault() - Method in class net.ravendb.client.document.DocumentQuery
 
singleOrDefault() - Method in interface net.ravendb.client.IDocumentQuery
Returns single result
singleOrDefault() - Method in interface net.ravendb.client.IDocumentQueryBase
Returns first element or default value for given type if sequence is empty.
singleOrDefault(Iterator<T>) - Static method in class net.ravendb.client.linq.EnumerableUtils
 
singleOrDefault() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Return value is based on result amount.
singleOrDefault(BooleanExpression) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Return value is based on result amount.
singleOrDefault() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
singleOrDefault(BooleanExpression) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
singularize(String) - Static method in class net.ravendb.client.util.Inflector
 
size() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
size() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
size() - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
size() - Method in class net.ravendb.client.util.IdentityHashSet
 
SKIP - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
skip(int) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
skip(int) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Skips the specified count.
skip(int) - Method in interface net.ravendb.client.IDocumentQueryBase
Skips the specified count.
skip(int) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Skips specified number of records.
skip(int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
sort(Path<?>, SortOptions) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be sorted
sort(String, SortOptions) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be sorted
sortByDistance() - Method in class net.ravendb.client.document.DocumentQuery
 
sortByDistance(double, double) - Method in class net.ravendb.client.document.DocumentQuery
 
sortByDistance(double, double, String) - Method in class net.ravendb.client.document.DocumentQuery
 
sortByDistance() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
sortByDistance(double, double) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
sortByDistance(double, double, String) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
sortByDistance() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
When using spatial queries, instruct the query to sort by the distance from the origin point
sortByDistance(double, double) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
When using spatial queries, instruct the query to sort by the distance from the origin point
sortByDistance(double, double, String) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
When using spatial queries, instruct the query to sort by the distance from the origin point
sortByDistance() - Method in interface net.ravendb.client.IDocumentQueryBase
Sorts the query results by distance.
sortByDistance(double, double) - Method in interface net.ravendb.client.IDocumentQueryBase
Sorts the query results by distance.
sortByDistance(double, double, String) - Method in interface net.ravendb.client.IDocumentQueryBase
Sorts the query results by distance.
sortByDistance() - Method in interface net.ravendb.client.IDocumentQueryCustomization
When using spatial queries, instruct the query to sort by the distance from the origin point
sortByDistance(double, double) - Method in interface net.ravendb.client.IDocumentQueryCustomization
When using spatial queries, instruct the query to sort by the distance from the origin point
sortByDistance(double, double, String) - Method in interface net.ravendb.client.IDocumentQueryCustomization
When using spatial queries, instruct the query to sort by the distance from the origin point
sortByHints - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The types to sort the fields by (NULL if not specified)
SortedField - Class in net.ravendb.abstractions.data
Represent a field sort options
SortedField(String) - Constructor for class net.ravendb.abstractions.data.SortedField
Initializes a new instance of the SortedField class.
SortOptions - Enum in net.ravendb.abstractions.indexing
The sort options to use for a particular field
spatial(String, SpatialCriteria) - Method in class net.ravendb.client.document.DocumentQuery
 
spatial(Path<?>, SpatialCriteria) - Method in class net.ravendb.client.document.DocumentQuery
 
spatial(String, SpatialCriteria) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
spatial(String, SpatialCriteria) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
spatial(Path<?>, SpatialCriteria) - Method in interface net.ravendb.client.IDocumentQuery
Ability to use one factory to determine spatial shape that will be used in query.
spatial(String, SpatialCriteria) - Method in interface net.ravendb.client.IDocumentQuery
Ability to use one factory to determine spatial shape that will be used in query.
spatial(String, SpatialCriteria) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Ability to use one factory to determine spatial shape that will be used in query.
spatial(Path<?>, SpatialOptions) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be spatially indexed Note: using SpatialOptionsFactory might be very helpful!
spatial(String, SpatialOptions) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be spatially indexed Note: using SpatialOptionsFactory might be very helpful!
spatial(Path<?>, SpatialCriteria) - Method in interface net.ravendb.client.linq.IRavenQueryable
 
spatial(Path<?>, SpatialCriteria) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
SPATIAL_SHAPE_FIELD_NAME - Static variable in class net.ravendb.abstractions.data.Constants
 
SpatialCriteria - Class in net.ravendb.client.spatial
 
SpatialCriteria() - Constructor for class net.ravendb.client.spatial.SpatialCriteria
 
SpatialCriteriaFactory - Class in net.ravendb.client.spatial
 
SpatialCriteriaFactory() - Constructor for class net.ravendb.client.spatial.SpatialCriteriaFactory
 
spatialFieldName - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
spatialIndexes - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
spatialIndexesStrings - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
SpatialIndexQuery - Class in net.ravendb.abstractions.data
A query using spatial filtering
SpatialIndexQuery(IndexQuery) - Constructor for class net.ravendb.abstractions.data.SpatialIndexQuery
Initializes a new instance of the SpatialIndexQuery class.
SpatialIndexQuery() - Constructor for class net.ravendb.abstractions.data.SpatialIndexQuery
Initializes a new instance of the SpatialIndexQuery class.
SpatialOptions - Class in net.ravendb.abstractions.indexing
 
SpatialOptions() - Constructor for class net.ravendb.abstractions.indexing.SpatialOptions
 
SpatialOptions.SpatialFieldType - Enum in net.ravendb.abstractions.indexing
 
SpatialOptions.SpatialRelation - Enum in net.ravendb.abstractions.indexing
 
SpatialOptions.SpatialSearchStrategy - Enum in net.ravendb.abstractions.indexing
 
SpatialOptions.SpatialSort - Class in net.ravendb.abstractions.indexing
 
SpatialOptions.SpatialSort() - Constructor for class net.ravendb.abstractions.indexing.SpatialOptions.SpatialSort
 
SpatialOptions.SpatialUnits - Enum in net.ravendb.abstractions.indexing
 
SpatialOptionsFactory - Class in net.ravendb.abstractions.indexing
 
SpatialOptionsFactory() - Constructor for class net.ravendb.abstractions.indexing.SpatialOptionsFactory
 
SpatialOptionsFactory.CartesianSpatialOptionsFactory - Class in net.ravendb.abstractions.indexing
 
SpatialOptionsFactory.CartesianSpatialOptionsFactory() - Constructor for class net.ravendb.abstractions.indexing.SpatialOptionsFactory.CartesianSpatialOptionsFactory
 
SpatialOptionsFactory.GeographySpatialOptionsFactory - Class in net.ravendb.abstractions.indexing
 
SpatialOptionsFactory.GeographySpatialOptionsFactory() - Constructor for class net.ravendb.abstractions.indexing.SpatialOptionsFactory.GeographySpatialOptionsFactory
 
SpatialOptionsFactory.SpatialBounds - Class in net.ravendb.abstractions.indexing
 
SpatialOptionsFactory.SpatialBounds(double, double, double, double) - Constructor for class net.ravendb.abstractions.indexing.SpatialOptionsFactory.SpatialBounds
 
spatialRelation - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
spatialUnits - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
SpecialQueryType - Enum in net.ravendb.client.linq
Different query types
stableHashString(String) - Method in class net.ravendb.client.shard.ShardStrategy
 
start() - Method in class net.ravendb.client.connection.ObservableLineStream
 
start - Variable in class net.ravendb.client.document.AbstractDocumentQuery
which record to start reading from
startBackup(String, DatabaseDocument, String, boolean) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
startBackup(String, DatabaseDocument, boolean, String) - Method in class net.ravendb.client.connection.AdminServerClient
 
startBackup(String, DatabaseDocument, boolean, String) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Begins a backup operation
startIndexing(String, Integer) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
startIndexing() - Method in class net.ravendb.client.connection.AdminServerClient
 
startIndexing(Integer) - Method in class net.ravendb.client.connection.AdminServerClient
 
startIndexing() - Method in interface net.ravendb.client.connection.IAdminDatabaseCommands
Enables indexing
startIndexing(Integer) - Method in interface net.ravendb.client.connection.IAdminDatabaseCommands
Enables indexing
startRestore(DatabaseRestoreRequest) - Method in class net.ravendb.client.connection.AdminServerClient
 
startRestore(DatabaseRestoreRequest) - Method in interface net.ravendb.client.connection.IGlobalAdminDatabaseCommands
Begins a restore operation
startsWith(String, String, int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents for the specified key prefix.
startsWith(String, String, int, int, boolean) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents for the specified key prefix.
startsWith(String, String, int, int, boolean, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents for the specified key prefix.
startsWith(String, String, int, int, boolean, String, RavenPagingInformation) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents for the specified key prefix.
startsWith(String, String, int, int, boolean, String, RavenPagingInformation, String, Map<String, RavenJToken>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents for the specified key prefix.
startsWith(String, String, int, int, boolean, String, RavenPagingInformation, String, Map<String, RavenJToken>, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Retrieves documents for the specified key prefix.
startsWith(String, String, int, int) - Method in class net.ravendb.client.connection.ServerClient
 
startsWith(String, String, int, int, boolean) - Method in class net.ravendb.client.connection.ServerClient
 
startsWith(String, String, int, int, boolean, String) - Method in class net.ravendb.client.connection.ServerClient
 
startsWith(String, String, int, int, boolean, String, RavenPagingInformation) - Method in class net.ravendb.client.connection.ServerClient
 
startsWith(String, String, int, int, boolean, String, RavenPagingInformation, String, Map<String, RavenJToken>) - Method in class net.ravendb.client.connection.ServerClient
 
startsWith(String, String, int, int, boolean, String, RavenPagingInformation, String, Map<String, RavenJToken>, String) - Method in class net.ravendb.client.connection.ServerClient
 
statistics(Reference<RavenQueryStatistics>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Provide statistics about the query, such as total count of matching records
statistics(Reference<RavenQueryStatistics>) - Method in interface net.ravendb.client.IDocumentQueryBase
Provide statistics about the query, such as total count of matching records
statistics(Reference<RavenQueryStatistics>) - Method in interface net.ravendb.client.linq.IRavenQueryable
Provide statistics about the query, such as duration, total number of results, staleness information, etc.
statistics(Reference<RavenQueryStatistics>) - Method in class net.ravendb.client.linq.RavenQueryInspector
Provide statistics about the query, such as total count of matching records
stats(String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
stopIndexing(String) - Method in class net.ravendb.client.connection.AdminRequestCreator
 
stopIndexing() - Method in class net.ravendb.client.connection.AdminServerClient
 
stopIndexing() - Method in interface net.ravendb.client.connection.IAdminDatabaseCommands
Disables all indexing
storage - Variable in class net.ravendb.abstractions.data.EnumSet
 
StorageStats - Class in net.ravendb.abstractions.data
 
StorageStats() - Constructor for class net.ravendb.abstractions.data.StorageStats
 
store(Object) - Method in class net.ravendb.client.document.BulkInsertOperation
 
store(Object, String) - Method in class net.ravendb.client.document.BulkInsertOperation
 
store(RavenJObject, RavenJObject, String) - Method in class net.ravendb.client.document.BulkInsertOperation
 
store(RavenJObject, RavenJObject, String, Integer) - Method in class net.ravendb.client.document.BulkInsertOperation
 
store(Object) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Stores the specified entity in the session.
store(Object, Etag) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Stores the specified entity in the session.
store(Object, String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Stores the specified entity in the session, explicitly specifying its Id.
store(Object, Etag, String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Stores the specified entity in the session, explicitly specifying its Id.
store(Object) - Method in class net.ravendb.client.document.ShardedBulkInsertOperation
 
store(Object) - Method in interface net.ravendb.client.IDocumentSession
Stores entity in session, extracts Id from entity using Conventions or generates new one if it is not available.
store(Object, String) - Method in interface net.ravendb.client.IDocumentSession
Stores the specified dynamic entity, under the specified id.
store(Object, Etag) - Method in interface net.ravendb.client.IDocumentSession
Stores entity in session, extracts Id from entity using Conventions or generates new one if it is not available and forces concurrency check with given Etag
store(Object, Etag, String) - Method in interface net.ravendb.client.IDocumentSession
Stores the specified entity with the specified etag, under the specified id
store(Path<?>, FieldStorage) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be stored
store(String, FieldStorage) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be stored
storeAllFields(FieldStorage) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
storeEntityInUnitOfWork(String, Object, Etag, RavenJObject, boolean) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
storeEntityInUnitOfWork(String, Object, Etag, RavenJObject, boolean) - Method in class net.ravendb.client.shard.BaseShardedDocumentSession
 
stores - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
storesStrings - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
stream(IRavenQueryable<T>) - Method in class net.ravendb.client.document.DocumentSession
 
stream(IRavenQueryable<T>, Reference<QueryHeaderInformation>) - Method in class net.ravendb.client.document.DocumentSession
 
stream(IDocumentQuery<T>) - Method in class net.ravendb.client.document.DocumentSession
 
stream(IDocumentQuery<T>, Reference<QueryHeaderInformation>) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag, String) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag, String, String) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag, String, String, int) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag, String, String, int, int) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag, String, String, int, int, RavenPagingInformation) - Method in class net.ravendb.client.document.DocumentSession
 
stream(Class<T>, Etag, String, String, int, int, RavenPagingInformation, String) - Method in class net.ravendb.client.document.DocumentSession
 
stream(IRavenQueryable<T>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(IRavenQueryable<T>, Reference<QueryHeaderInformation>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(IDocumentQuery<T>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(IDocumentQuery<T>, Reference<QueryHeaderInformation>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag, String, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag, String, String, int) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag, String, String, int, int) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag, String, String, int, int, RavenPagingInformation) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(Class<T>, Etag, String, String, int, int, RavenPagingInformation, String) - Method in interface net.ravendb.client.ISyncAdvancedSessionOperation
Stream the results on the query to the client, converting them to Java types along the way.
stream(IRavenQueryable<T>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(IRavenQueryable<T>, Reference<QueryHeaderInformation>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(IDocumentQuery<T>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(IDocumentQuery<T>, Reference<QueryHeaderInformation>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag, String, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag, String, String, int) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag, String, String, int, int) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag, String, String, int, int, RavenPagingInformation) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
stream(Class<T>, Etag, String, String, int, int, RavenPagingInformation, String) - Method in class net.ravendb.client.shard.ShardedDocumentSession
 
streamDocs() - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String, String, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String, String, int, int) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String, String, int, int, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String, String, int, int, String, RavenPagingInformation) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs(Etag, String, String, int, int, String, RavenPagingInformation, String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Streams the documents by etag OR starts with the prefix and match the matches Will return *all* results, regardless of the number of items that might be returned.
streamDocs() - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String, String) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String, String, int) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String, String, int, int) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String, String, int, int, String) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String, String, int, int, String, RavenPagingInformation) - Method in class net.ravendb.client.connection.ServerClient
 
streamDocs(Etag, String, String, int, int, String, RavenPagingInformation, String) - Method in class net.ravendb.client.connection.ServerClient
 
streamExport(ExportOptions) - Method in class net.ravendb.client.connection.ServerClient
 
streamQuery(String, IndexQuery, Reference<QueryHeaderInformation>) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Queries the specified index in the Raven flavored Lucene query syntax.
streamQuery(String, IndexQuery, Reference<QueryHeaderInformation>) - Method in class net.ravendb.client.connection.ServerClient
 
StreamResult<T> - Class in net.ravendb.abstractions.data
 
StreamResult() - Constructor for class net.ravendb.abstractions.data.StreamResult
 
StringDistanceTypes - Enum in net.ravendb.abstractions.data
String distance algorithms used in suggestion query
stringToNumber(String) - Static method in class net.ravendb.abstractions.indexing.NumberUtil
Translate an indexable string to a number
subscribe(IObserver<T>) - Method in interface net.ravendb.client.changes.IObservable
 
subscribe(IObserver<T>) - Method in class net.ravendb.client.changes.TaskedObservable
 
subscribe(IObserver<String>) - Method in class net.ravendb.client.connection.ObservableLineStream
 
subscribe(IObserver<T>) - Method in class net.ravendb.client.document.Subscription
 
subscribe(IObserver<T>) - Method in class net.ravendb.client.shard.ShardedObservable
 
subscribeOnServer() - Method in class net.ravendb.client.changes.RemoteChangesClientBase
 
subscribeOnServer() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
subscribers - Variable in class net.ravendb.client.changes.TaskedObservable
 
Subscription<T> - Class in net.ravendb.client.document
 
Subscription.DocumentProcessedEventArgs - Class in net.ravendb.client.document
 
Subscription.DocumentProcessedEventArgs(int) - Constructor for class net.ravendb.client.document.Subscription.DocumentProcessedEventArgs
 
Subscription.LastProcessedEtagEventArgs - Class in net.ravendb.client.document
 
Subscription.LastProcessedEtagEventArgs(Etag) - Constructor for class net.ravendb.client.document.Subscription.LastProcessedEtagEventArgs
 
SubscriptionBatchOptions - Class in net.ravendb.abstractions.data
 
SubscriptionBatchOptions() - Constructor for class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
SubscriptionBatchOptions(Integer, int, Long) - Constructor for class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
SubscriptionClosedException - Exception in net.ravendb.abstractions.exceptions.subscriptions
 
SubscriptionClosedException() - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionClosedException
 
SubscriptionClosedException(String) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionClosedException
 
SubscriptionClosedException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionClosedException
 
SubscriptionConfig - Class in net.ravendb.abstractions.data
 
SubscriptionConfig() - Constructor for class net.ravendb.abstractions.data.SubscriptionConfig
 
SubscriptionConnectionOptions - Class in net.ravendb.abstractions.data
 
SubscriptionConnectionOptions() - Constructor for class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
SubscriptionConnectionOptions(SubscriptionBatchOptions) - Constructor for class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
SubscriptionCriteria - Class in net.ravendb.abstractions.data
 
SubscriptionCriteria() - Constructor for class net.ravendb.abstractions.data.SubscriptionCriteria
 
SubscriptionDoesNotExistException - Exception in net.ravendb.abstractions.exceptions.subscriptions
 
SubscriptionDoesNotExistException() - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionDoesNotExistException
 
SubscriptionDoesNotExistException(String) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionDoesNotExistException
 
SubscriptionDoesNotExistException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionDoesNotExistException
 
SubscriptionException - Exception in net.ravendb.abstractions.exceptions.subscriptions
 
SubscriptionException(int) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionException
 
SubscriptionException(String, int) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionException
 
SubscriptionException(String, Throwable, int) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionException
 
SubscriptionInUseException - Exception in net.ravendb.abstractions.exceptions.subscriptions
 
SubscriptionInUseException() - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionInUseException
 
SubscriptionInUseException(String) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionInUseException
 
SubscriptionInUseException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.subscriptions.SubscriptionInUseException
 
SubscriptionOpeningStrategy - Enum in net.ravendb.abstractions.data
Options for opening a subscription
subscriptions - Variable in class net.ravendb.client.DocumentStoreBase
 
subscriptions() - Method in class net.ravendb.client.DocumentStoreBase
 
subscriptions() - Method in interface net.ravendb.client.IDocumentStore
 
suggest(String, SuggestionQuery) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Returns a list of suggestions based on the specified suggestion query
suggest(String, SuggestionQuery) - Method in class net.ravendb.client.connection.ServerClient
 
suggest() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
suggest(SuggestionQuery) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
suggest() - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
suggest(SuggestionQuery) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
suggestion(Path<?>, SuggestionOptions) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be sorted
suggestion(Path<?>) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to be sorted
SuggestionOptions - Class in net.ravendb.abstractions.indexing
 
SuggestionOptions() - Constructor for class net.ravendb.abstractions.indexing.SuggestionOptions
 
SuggestionQuery - Class in net.ravendb.abstractions.data
 
SuggestionQuery() - Constructor for class net.ravendb.abstractions.data.SuggestionQuery
Create a new instance of SuggestionQuery
SuggestionQuery(String, String) - Constructor for class net.ravendb.abstractions.data.SuggestionQuery
 
SuggestionQueryResult - Class in net.ravendb.abstractions.data
The result of the suggestion query
SuggestionQueryResult() - Constructor for class net.ravendb.abstractions.data.SuggestionQueryResult
 
suggestLazy() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
suggestLazy(SuggestionQuery) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
suggestLazy() - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
suggestLazy(SuggestionQuery) - Method in interface net.ravendb.client.LinqExtensionsQueryable
 
sumOn(Path<?>) - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
SynchronizationDetails - Class in net.ravendb.abstractions.data
 
SynchronizationDetails() - Constructor for class net.ravendb.abstractions.data.SynchronizationDetails
 
SynchronizationType - Enum in net.ravendb.abstractions.data
 
SYSTEM_DATABASE - Static variable in class net.ravendb.abstractions.data.Constants
 

T

tag - Variable in class net.ravendb.client.document.HiLoKeyGeneratorBase
 
TAKE - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
take(int) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
take(int) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Takes the specified count.
take(int) - Method in interface net.ravendb.client.IDocumentQueryBase
Takes the specified count.
take(int) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Takes specified number of records.
take(int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
TaskedObservable<T,TConnectionState extends IChangesConnectionState> - Class in net.ravendb.client.changes
 
TaskedObservable(TConnectionState, Predicate<T>) - Constructor for class net.ravendb.client.changes.TaskedObservable
 
TEMPORARY_SCORE_VALUE - Static variable in class net.ravendb.abstractions.data.Constants
 
terms(String, String, String, String, int) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
termVector(Path<?>, FieldTermVector) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to have term vectors
termVector(String, FieldTermVector) - Method in class net.ravendb.client.indexes.AbstractIndexCreationTask
Register a field to have term vectors
termVectors - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
termVectorsStrings - Variable in class net.ravendb.client.indexes.AbstractIndexCreationTask
 
theDatabaseCommands - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The database commands to use
theListeners - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
theSession - Variable in class net.ravendb.client.document.AbstractDocumentQuery
The session for this query
theWaitForNonStaleResults - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Should we wait for non stale results
theWaitForNonStaleResultsAsOfNow - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Should we wait for non stale results as of now?
throwIfCancellationRequested() - Method in class net.ravendb.client.utils.CancellationTokenSource.CancellationToken
 
timeout - Variable in class net.ravendb.client.document.AbstractDocumentQuery
Timeout for this query
TimeSpan - Class in net.ravendb.client.utils
 
TimeSpan() - Constructor for class net.ravendb.client.utils.TimeSpan
 
TimeUtils - Class in net.ravendb.abstractions.util
 
TimeUtils() - Constructor for class net.ravendb.abstractions.util.TimeUtils
 
toArray() - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
toArray(S[]) - Method in class net.ravendb.client.connection.profiling.ConcurrentSet
 
toArray() - Method in class net.ravendb.client.util.IdentityHashSet
 
toArray(S[]) - Method in class net.ravendb.client.util.IdentityHashSet
 
toBase62(UUID) - Static method in class net.ravendb.abstractions.util.Base62Util
 
toByteArray() - Method in class net.ravendb.abstractions.data.Etag
 
toDocumentQuery(Class<T>, Expression<?>) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
Convert the linq query to a Lucene query
toDocumentQuery(Class<S>, Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProvider
Convert the expression to a Lucene query
toFacetQuery(List<Facet>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetQuery(List<Facet>, int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetQuery(List<Facet>, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetQuery(String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetQuery(String, int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetQuery(String, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetQuery(List<Facet>) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Transforms the query to the facet query that will allow you to execute multi faceted search
toFacetQuery(List<Facet>, int) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Transforms the query to the facet query that will allow you to execute multi faceted search
toFacetQuery(List<Facet>, int, Integer) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Transforms the query to the facet query that will allow you to execute multi faceted search
toFacetQuery(String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Transforms the query to the facet query that will allow you to execute multi faceted search
toFacetQuery(String, int) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Transforms the query to the facet query that will allow you to execute multi faceted search
toFacetQuery(String, int, Integer) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Transforms the query to the facet query that will allow you to execute multi faceted search
toFacets(String) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacets(String, int) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacets(String, int, Integer) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacets(List<Facet>) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacets(List<Facet>, int) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacets(List<Facet>, int, Integer) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacets(String) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacets(String, int) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacets(String, int, Integer) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacets(List<Facet>) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacets(List<Facet>, int) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacets(List<Facet>, int, Integer) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacets(List<Facet>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacets(List<Facet>, int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacets(List<Facet>, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacets(String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacets(String, int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacets(String, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacets(List<Facet>) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified list of facets
toFacets(List<Facet>, int) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified list of facets with the given start
toFacets(List<Facet>, int, Integer) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacets(String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified facet document
toFacets(String, int) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified facet document with the given start
toFacets(String, int, Integer) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacetsLazy(String) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacetsLazy(String, int) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacetsLazy(String, int, Integer) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacetsLazy(List<Facet>) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacetsLazy(List<Facet>, int) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacetsLazy(List<Facet>, int, Integer) - Method in class net.ravendb.client.document.DocumentQuery
 
toFacetsLazy(String) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacetsLazy(String, int) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacetsLazy(String, int, Integer) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified facet document with the given start and pageSize
toFacetsLazy(List<Facet>) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacetsLazy(List<Facet>, int) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacetsLazy(List<Facet>, int, Integer) - Method in interface net.ravendb.client.IDocumentQuery
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacetsLazy(List<Facet>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetsLazy(List<Facet>, int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetsLazy(List<Facet>, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetsLazy(String) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetsLazy(String, int) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetsLazy(String, int, Integer) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toFacetsLazy(List<Facet>) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified list of facets
toFacetsLazy(List<Facet>, int) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified list of facets with the given start
toFacetsLazy(List<Facet>, int, Integer) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified list of facets with the given start and pageSize
toFacetsLazy(String) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified facet document
toFacetsLazy(String, int) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified facet document with the given start
toFacetsLazy(String, int, Integer) - Method in interface net.ravendb.client.LinqExtensionsQueryable
Query the facets results for this query using the specified facet document with the given start and pageSize
toIndexDefinition(DocumentConvention) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
toIndexDefinition(DocumentConvention, boolean) - Method in class net.ravendb.client.indexes.IndexDefinitionBuilder
 
toJObject(Object) - Static method in class net.ravendb.abstractions.extensions.JsonExtensions
 
toJson() - Method in class net.ravendb.abstractions.commands.DeleteCommandData
Translates this instance to a Json object.
toJson() - Method in interface net.ravendb.abstractions.commands.ICommandData
Translates this instance to a Json object.
toJson() - Method in class net.ravendb.abstractions.commands.PatchCommandData
Translates this instance to a Json object.
toJson() - Method in class net.ravendb.abstractions.commands.PutCommandData
Translates this instance to a Json object.
toJson() - Method in class net.ravendb.abstractions.commands.ScriptedPatchCommandData
Translates this instance to a Json object.
toJson() - Method in class net.ravendb.abstractions.data.JsonDocument
Translate the json document to a RavenJObject
toJson(boolean) - Method in class net.ravendb.abstractions.data.JsonDocument
Translate the json document to a RavenJObject
toJson() - Method in class net.ravendb.abstractions.data.PatchRequest
Translates this instance to json
toJsonDocument(RavenJObject) - Static method in class net.ravendb.client.connection.SerializationHelper
 
toList() - Method in class net.ravendb.client.document.DocumentQuery
 
toList() - Method in interface net.ravendb.client.IDocumentQuery
Materialize query, executes request and returns with results
toList() - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
toList(Iterator<T>) - Static method in class net.ravendb.client.linq.EnumerableUtils
Extracts list from iterable
toList() - Method in interface net.ravendb.client.linq.IOrderedQueryable
Materialize query and returns results as list.
toList() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
toListLazy() - Method in class net.ravendb.client.linq.DynamicAggregationQuery
 
toProperty(Expression<?>) - Static method in class net.ravendb.abstractions.extensions.ExpressionExtensions
 
toPropertyPath(Expression<?>) - Static method in class net.ravendb.abstractions.extensions.ExpressionExtensions
 
toPropertyPath(Expression<?>, char) - Static method in class net.ravendb.abstractions.extensions.ExpressionExtensions
 
toPropertyPath(Expression<?>, char, char) - Static method in class net.ravendb.abstractions.extensions.ExpressionExtensions
 
toQueryResult(RavenJObject, Etag, String, long) - Static method in class net.ravendb.client.connection.SerializationHelper
 
toRavenObject() - Method in class net.ravendb.abstractions.data.SubscriptionBatchOptions
 
toRavenObject() - Method in class net.ravendb.abstractions.data.SubscriptionConnectionOptions
 
toString() - Method in class net.ravendb.abstractions.data.DocumentChangeNotification
 
toString() - Method in class net.ravendb.abstractions.data.Etag
 
toString() - Method in class net.ravendb.abstractions.data.FacetValue
 
toString() - Method in class net.ravendb.abstractions.data.HighlightedField
 
toString() - Method in class net.ravendb.abstractions.data.IndexChangeNotification
 
toString() - Method in class net.ravendb.abstractions.data.IndexingError
 
toString() - Method in class net.ravendb.abstractions.data.IndexQuery
 
toString() - Method in class net.ravendb.abstractions.data.IndexStats
 
toString() - Method in class net.ravendb.abstractions.data.JsonDocument
 
toString() - Method in class net.ravendb.abstractions.data.PutResult
 
toString() - Method in class net.ravendb.abstractions.data.RavenConnectionStringOptions
 
toString() - Method in class net.ravendb.abstractions.data.ReplicationConflictNotification
 
toString() - Method in class net.ravendb.abstractions.data.TransformerChangeNotification
 
toString() - Method in class net.ravendb.abstractions.indexing.IndexDefinition
 
toString() - Method in class net.ravendb.abstractions.indexing.TransformerDefinition
 
toString() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
toString(FormatSchema, Object[]) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
toString() - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
toString() - Method in class net.ravendb.abstractions.replication.ReplicatedEtagInfo
 
toString() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Returns a String that represents the query for this instance.
toString() - Method in class net.ravendb.client.document.DocumentQuery
 
toString() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
toString() - Method in class net.ravendb.client.linq.RavenQueryInspector
 
trackEntity(Class<?>, JsonDocument) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Tracks the entity inside the unit of work
trackEntity(Class<?>, String, RavenJObject, RavenJObject, boolean) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Tracks the entity.
trackIncludedDocument(JsonDocument) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
tranformer(String, String) - Static method in class net.ravendb.client.connection.RavenUrlExtensions
 
transform(String) - Method in interface net.ravendb.client.delegates.TypeTagNameToDocumentKeyPrefixTransformer
 
TransformCompilationException - Exception in net.ravendb.abstractions.exceptions
 
TransformCompilationException() - Constructor for exception net.ravendb.abstractions.exceptions.TransformCompilationException
 
TransformCompilationException(String, Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.TransformCompilationException
 
TransformCompilationException(String) - Constructor for exception net.ravendb.abstractions.exceptions.TransformCompilationException
 
TransformCompilationException(Throwable) - Constructor for exception net.ravendb.abstractions.exceptions.TransformCompilationException
 
TransformerChangeNotification - Class in net.ravendb.abstractions.data
 
TransformerChangeNotification() - Constructor for class net.ravendb.abstractions.data.TransformerChangeNotification
 
TransformerChangeTypes - Enum in net.ravendb.abstractions.data
 
TransformerDefinition - Class in net.ravendb.abstractions.indexing
 
TransformerDefinition() - Constructor for class net.ravendb.abstractions.indexing.TransformerDefinition
 
TransformerLockMode - Enum in net.ravendb.abstractions.indexing
 
transformerParameters - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
transformResults(ShardReduceFunction) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
transformResults(ShardReduceFunction) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
transformResults(ShardReduceFunction) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
 
transformResults(ShardReduceFunction) - Method in interface net.ravendb.client.IDocumentQueryCustomization
 
transformResults - Variable in class net.ravendb.client.indexes.AbstractTransformerCreationTask
 
transformResultsFunc - Variable in class net.ravendb.client.document.AbstractDocumentQuery
 
transformWith(String, Class<S>) - Method in interface net.ravendb.client.linq.IRavenQueryable
Specifies a result transformer to use on the results
transformWith(Class<? extends AbstractTransformerCreationTask>, Class<S>) - Method in interface net.ravendb.client.linq.IRavenQueryable
Specifies a result transformer to use on the results
transformWith(String) - Method in interface net.ravendb.client.linq.IRavenQueryProvider
The name of the transformer to use with this query
transformWith(Class<? extends AbstractTransformerCreationTask>, Class<S>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
transformWith(String, Class<S>) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
transformWith(String) - Method in class net.ravendb.client.linq.RavenQueryProvider
 
translate(Expression<?>) - Method in interface net.ravendb.client.document.CustomQueryExpressionTranslator
 
translateCustomQueryExpression(LinqPathProvider, Expression<?>) - Method in class net.ravendb.client.document.Convention
 
trimZeros(String) - Static method in class net.ravendb.abstractions.indexing.NumberUtil
Removes zeros from the end of the string but only from fractional part if string ends with dot after first operation, we remove dot as well.
tryConvert(RavenJObject, Reference<String>) - Method in class net.ravendb.abstractions.spatial.GeoJsonWktConverter
 
tryConvert(Object, Reference<String>) - Method in class net.ravendb.abstractions.spatial.ShapeConverter
 
tryConvertValue(String, T, QueryValueConvertionType, Reference<String>) - Method in interface net.ravendb.client.document.DocumentConvention.TryConvertValueForQueryDelegate
 
tryConvertValueForQuery(String, Object, QueryValueConvertionType, Reference<String>) - Method in class net.ravendb.client.document.DocumentConvention
 
tryGet(UUID) - Method in class net.ravendb.client.connection.profiling.ProfilingContext
Try to get a session matching the specified id.
tryGetIdFromInstance(Object, Reference<String>) - Method in class net.ravendb.client.document.GenerateEntityIdOnTheClient
Attempts to get the document key from an instance
tryGetSubscriptionException(Exception) - Static method in class net.ravendb.client.document.DocumentSubscriptions
 
tryGetValue(String, Reference<RavenJToken>) - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
tryGetValue(String, Reference<RavenJToken>) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
tryLoad(InputStream) - Static method in class net.ravendb.abstractions.json.linq.RavenJToken
Load a RavenJToken from a string that contains JSON.
tryLoadReplicationInformationFromLocalCache(String) - Static method in class net.ravendb.client.connection.ReplicationInformerLocalCache
 
tryOperation(Function1<OperationMetadata, S>, OperationMetadata, OperationMetadata, boolean) - Method in class net.ravendb.client.connection.ReplicationInformerBase
 
tryParse(String, Reference<Etag>) - Static method in class net.ravendb.abstractions.data.Etag
 
TryParse(String, Reference<HighlightedField>) - Static method in class net.ravendb.abstractions.data.HighlightedField
 
tryReadErrorResponseObject(Class<T>, ErrorResponseException) - Static method in class net.ravendb.abstractions.extensions.ExceptionExtensions
 
tryResolveConflict(String, List<JsonDocument>, Reference<JsonDocument>) - Method in interface net.ravendb.client.listeners.IDocumentConflictListener
 
tryResolveConflictByUsingRegisteredListeners(OperationMetadata, String, Etag, List<String>, OperationMetadata) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Tries to resolve conflict using registered listeners
tryResolveConflictByUsingRegisteredListeners(OperationMetadata, String, Etag, List<String>, OperationMetadata) - Method in class net.ravendb.client.connection.ServerClient
 
tryResolveConflictOrCreateConcurrencyException(GetResponse[], Function3<String, RavenJObject, Etag, ConflictException>) - Method in class net.ravendb.client.connection.MultiGetOperation
 
trySavingReplicationInformationToLocalCache(String, JsonDocument) - Static method in class net.ravendb.client.connection.ReplicationInformerLocalCache
 
trySetIdentity(Object, String) - Method in class net.ravendb.client.document.GenerateEntityIdOnTheClient
Tries to set the identity property
Tuple<T,S> - Class in net.ravendb.abstractions.basic
Represents tuple
Tuple(T, S) - Constructor for class net.ravendb.abstractions.basic.Tuple
 
Tuple() - Constructor for class net.ravendb.abstractions.basic.Tuple
 
Types - Class in net.ravendb.client.util
 
Types() - Constructor for class net.ravendb.client.util.Types
 
TypeTagNameFinder - Interface in net.ravendb.client.document
Finds type tag name based on class.
TypeTagNameToDocumentKeyPrefixTransformer - Interface in net.ravendb.client.delegates
 

U

UNCOMPRESSED - Static variable in class net.ravendb.java.http.client.RavenResponseContentEncoding
 
unescapeDataString(String) - Static method in class net.ravendb.client.utils.UrlUtils
 
unregisterMissing(String) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
unregisterMissing(String) - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Removes the specify documentId from the list of known missing ids.
update(QueryResult) - Method in class net.ravendb.client.FieldHighlightings
 
update(QueryResult) - Method in class net.ravendb.client.RavenQueryHighlightings
 
updateAttachmentMetadata(String, Etag, RavenJObject) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Deprecated.
Use RavenFS instead.
updateAttachmentMetadata(String, Etag, RavenJObject) - Method in class net.ravendb.client.connection.ServerClient
Deprecated.
updateBatchResults(List<BatchResult>, SaveChangesData) - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
Updates the batch results.
updateByIndex(String, IndexQuery, PatchRequest[]) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a set based update using the specified index
updateByIndex(String, IndexQuery, ScriptedPatchRequest) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a set based update using the specified index
updateByIndex(String, IndexQuery, PatchRequest[], BulkOperationOptions) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a set based update using the specified index
updateByIndex(String, IndexQuery, ScriptedPatchRequest, BulkOperationOptions) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Perform a set based update using the specified index
updateByIndex(String, IndexQuery, PatchRequest[]) - Method in class net.ravendb.client.connection.ServerClient
 
updateByIndex(String, IndexQuery, ScriptedPatchRequest) - Method in class net.ravendb.client.connection.ServerClient
 
updateByIndex(String, IndexQuery, PatchRequest[], BulkOperationOptions) - Method in class net.ravendb.client.connection.ServerClient
 
updateByIndex(String, IndexQuery, ScriptedPatchRequest, BulkOperationOptions) - Method in class net.ravendb.client.connection.ServerClient
 
updateCacheTime(HttpJsonRequest) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequestFactory
 
updateFrom(ReplicationClientConfiguration) - Method in class net.ravendb.client.document.Convention
 
updateHeaders(Map<String, String>) - Method in class net.ravendb.client.connection.CreateHttpJsonRequestParams
 
updateLastWrittenEtag(Etag) - Method in class net.ravendb.client.util.GlobalLastEtagHolder
 
updateLastWrittenEtag(Etag) - Method in interface net.ravendb.client.util.ILastEtagHolder
 
updateQueryStats(QueryResult) - Method in class net.ravendb.client.RavenQueryStatistics
 
updateReplicationInformationIfNeeded(ServerClient) - Method in interface net.ravendb.client.connection.IDocumentStoreReplicationInformer
Updates replication information if needed
updateReplicationInformationIfNeeded(ServerClient) - Method in class net.ravendb.client.connection.ReplicationInformer
 
updateStatsAndHighlightings(QueryResult) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
url - Variable in class net.ravendb.client.connection.ServerClient
 
url - Variable in class net.ravendb.client.DocumentStoreBase
 
urlFor(String) - Method in interface net.ravendb.client.connection.IDatabaseCommands
Get the full URL for the given document key
urlFor(String) - Method in class net.ravendb.client.connection.ServerClient
 
UrlUtils - Class in net.ravendb.client.utils
 
UrlUtils() - Constructor for class net.ravendb.client.utils.UrlUtils
 
useDefaultPrettyPrinter() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
useFips(boolean) - Method in class net.ravendb.client.document.DocumentStore
 
useFips - Variable in class net.ravendb.client.DocumentStoreBase
 
UseSharpEnum - Annotation Type in net.ravendb.abstractions.basic
Marker annotation used - for serializing types using .NET enum conventions
usesRangeType(Object) - Method in class net.ravendb.client.document.DocumentConvention
 
usingDefaultField(String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
usingDefaultField(String) - Method in interface net.ravendb.client.IDocumentQueryBase
Select the default field to use for this query
usingDefaultOperator(QueryOperator) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
usingDefaultOperator(QueryOperator) - Method in interface net.ravendb.client.IDocumentQueryBase
Select the default operator to use for this query
UTF8_BOM - Static variable in class net.ravendb.abstractions.util.BomUtils
 
UUIDConverter - Class in net.ravendb.client.converters
Convert string from / to UUID
UUIDConverter() - Constructor for class net.ravendb.client.converters.UUIDConverter
 
UuidType - Enum in net.ravendb.abstractions.data
 

V

validateThatWeCanUseToken(String) - Method in class net.ravendb.client.util.SingleAuthTokenRetriever
 
value - Variable in class net.ravendb.abstractions.basic.Reference
The value contained in the holder.
value(Enum<?>) - Static method in class net.ravendb.abstractions.basic.SharpEnum
 
value(Class<U>, Iterable<RavenJToken>) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
value(Class<U>, RavenJToken) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
value(Class<T>, Class<U>, Iterable<T>) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
value(Class<T>, String) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
value(Class<T>, String) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
value(Class<T>) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
valueOf(String) - Static method in enum net.ravendb.abstractions.data.BatchType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.DataSubscriptionChangeTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.DocumentChangeTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.DocumentsChanges.ChangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.FacetAggregation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.FacetMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.FacetTermSortMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.HttpMethods
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.IndexChangeTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.IndexStats.IndexingPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.MetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.PatchCommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.PatchResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.PrefetchingUser
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.QueryOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.ReplicationConflictTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.ReplicationOperationTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.StringDistanceTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.SubscriptionOpeningStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.SynchronizationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.TransformerChangeTypes
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.data.UuidType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.FieldIndexing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.FieldStorage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.FieldTermVector
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.IndexLockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.SortOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialFieldType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialRelation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialSearchStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialUnits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.indexing.TransformerLockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.json.linq.JTokenType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.logging.LogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.replication.ReplicationDestination.TransitiveReplicationOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.abstractions.smuggler.ItemType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.connection.profiling.RequestStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.document.ConsistencyOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.document.FailoverBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.document.IndexAndTransformerReplicationMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.document.QueryValueConvertionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.EscapeQueryOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.linq.SpecialQueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.ravendb.client.SearchOptions
Returns the enum constant of this type with the specified name.
values() - Static method in enum net.ravendb.abstractions.data.BatchType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.DataSubscriptionChangeTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.DocumentChangeTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.DocumentsChanges.ChangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.FacetAggregation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.FacetMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.FacetTermSortMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.HttpMethods
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.IndexChangeTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.IndexStats.IndexingPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.MetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.PatchCommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.PatchResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.PrefetchingUser
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.QueryOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.ReplicationConflictTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.ReplicationOperationTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.StringDistanceTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.SubscriptionOpeningStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.SynchronizationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.TransformerChangeTypes
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.data.UuidType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.FieldIndexing
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.FieldStorage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.FieldTermVector
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.IndexLockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.SortOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialFieldType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialRelation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialSearchStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.SpatialOptions.SpatialUnits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.indexing.TransformerLockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class net.ravendb.abstractions.json.linq.DictionaryWithParentSnapshot
 
values(Class<U>, Iterable<RavenJToken>) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
values(Iterable<RavenJToken>, String) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
values(Iterable<RavenJToken>) - Static method in class net.ravendb.abstractions.json.linq.Extensions
 
values() - Static method in enum net.ravendb.abstractions.json.linq.JTokenType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
values(Class<T>) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
values() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
values(Class<T>) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
values() - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
values(Class<T>) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
values() - Static method in enum net.ravendb.abstractions.logging.LogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.replication.ReplicationDestination.TransitiveReplicationOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.abstractions.smuggler.ItemType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
values() - Static method in enum net.ravendb.client.connection.profiling.RequestStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.document.ConsistencyOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.document.FailoverBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.document.IndexAndTransformerReplicationMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.document.QueryValueConvertionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.EscapeQueryOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.linq.SpecialQueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.ravendb.client.SearchOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class net.ravendb.querydsl.RavenMap
 
ValueTypeUtils - Class in net.ravendb.abstractions.util
 
ValueTypeUtils() - Constructor for class net.ravendb.abstractions.util.ValueTypeUtils
 
VERSION - Static variable in class net.ravendb.abstractions.data.Constants
 
visitExpression(Expression<?>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
Visits the expression and generate the lucene query
visitSearch(Operation<?>) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
visitStringEmpty(Expression<?>, boolean) - Method in class net.ravendb.client.linq.RavenQueryProviderProcessor
 
VoidArgs - Class in net.ravendb.abstractions.basic
 
VoidArgs() - Constructor for class net.ravendb.abstractions.basic.VoidArgs
 
VolatileOnlyTransactionRecoveryStorage - Class in net.ravendb.client.document.dtc
 
VolatileOnlyTransactionRecoveryStorage() - Constructor for class net.ravendb.client.document.dtc.VolatileOnlyTransactionRecoveryStorage
 
VoronActiveTransaction - Class in net.ravendb.abstractions.data
 
VoronActiveTransaction() - Constructor for class net.ravendb.abstractions.data.VoronActiveTransaction
 
VoronStorageStats - Class in net.ravendb.abstractions.data
 
VoronStorageStats() - Constructor for class net.ravendb.abstractions.data.VoronStorageStats
 

W

waitForAllPendingSubscriptions() - Method in interface net.ravendb.client.changes.IConnectableChanges
 
waitForAllPendingSubscriptions() - Method in class net.ravendb.client.changes.RemoteDatabaseChanges
 
waitForAllPendingSubscriptions() - Method in class net.ravendb.client.shard.ShardedDatabaseChanges
 
waitForCompletion() - Method in class net.ravendb.client.connection.Operation
 
waitForNonStaleResults(long) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
waitForNonStaleResults() - Method in class net.ravendb.client.document.AbstractDocumentQuery
EXPERT ONLY: Instructs the query to wait for non stale results.
waitForNonStaleResults() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResults(long) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResults() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
EXPERT ONLY: Instructs the query to wait for non stale results.
waitForNonStaleResults(long) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
EXPERT ONLY: Instructs the query to wait for non stale results for the specified wait timeout.
waitForNonStaleResults(long) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Instruct the query to wait for non stale result for the specified wait timeout.
waitForNonStaleResults() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
EXPERT ONLY: Instructs the query to wait for non stale results.
waitForNonStaleResults() - Method in interface net.ravendb.client.IDocumentQueryBase
EXPERT ONLY: Instructs the query to wait for non stale results.
waitForNonStaleResults(long) - Method in interface net.ravendb.client.IDocumentQueryBase
EXPERT ONLY: Instructs the query to wait for non stale results for the specified wait timeout.
waitForNonStaleResults() - Method in interface net.ravendb.client.IDocumentQueryCustomization
EXPERT ONLY: Instructs the query to wait for non stale results.
waitForNonStaleResults(long) - Method in interface net.ravendb.client.IDocumentQueryCustomization
EXPERT ONLY: Instructs the query to wait for non stale results for the specified wait timeout.
waitForNonStaleResultsAsOf(Date) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of the cutoff date.
waitForNonStaleResultsAsOf(Date, long) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of the cutoff date for the specified timeout
waitForNonStaleResultsAsOf(Etag) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of the cutoff etag.
waitForNonStaleResultsAsOf(Etag, long) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of the cutoff etag.
waitForNonStaleResultsAsOf(Date) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOf(Date, long) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOf(Etag) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOf(Etag, long) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOf(Date) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of the cutoff date.
waitForNonStaleResultsAsOf(Date, long) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of the cutoff date for the specified timeout
waitForNonStaleResultsAsOf(Etag) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of the cutoff etag.
waitForNonStaleResultsAsOf(Etag, long) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of the cutoff etag for the specified timeout.
waitForNonStaleResultsAsOf(Date) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Instructs the query to wait for non stale results as of the cutoff date.
waitForNonStaleResultsAsOf(Date, long) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Instructs the query to wait for non stale results as of the cutoff date for the specified timeout
waitForNonStaleResultsAsOf(Date) - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of the cutoff date.
waitForNonStaleResultsAsOf(Date, long) - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of the cutoff date for the specified timeout
waitForNonStaleResultsAsOf(Etag) - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of the cutoff etag.
waitForNonStaleResultsAsOf(Etag, long) - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of the cutoff etag for the specified timeout.
waitForNonStaleResultsAsOf(Date) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of the cutoff date.
waitForNonStaleResultsAsOf(Date, long) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of the cutoff date for the specified timeout
waitForNonStaleResultsAsOf(Etag) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of the cutoff etag.
waitForNonStaleResultsAsOf(Etag, long) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of the cutoff etag for the specified timeout.
waitForNonStaleResultsAsOfLastWrite() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite(long) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOfLastWrite(long) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOfLastWrite() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite(long) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite() - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite(long) - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite() - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfLastWrite(long) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of the last write made by any session belonging to the current document store.
waitForNonStaleResultsAsOfNow() - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of now.
waitForNonStaleResultsAsOfNow(long) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Instructs the query to wait for non stale results as of now for the specified timeout.
waitForNonStaleResultsAsOfNow() - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOfNow(long) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
waitForNonStaleResultsAsOfNow() - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of now.
waitForNonStaleResultsAsOfNow(long) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Instructs the query to wait for non stale results as of now for the specified timeout.
waitForNonStaleResultsAsOfNow() - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Instructs the query to wait for non stale results as of now.
waitForNonStaleResultsAsOfNow(long) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Instructs the query to wait for non stale results as of now for the specified timeout.
waitForNonStaleResultsAsOfNow() - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of now.
waitForNonStaleResultsAsOfNow(long) - Method in interface net.ravendb.client.IDocumentQueryBase
Instructs the query to wait for non stale results as of now for the specified timeout.
waitForNonStaleResultsAsOfNow() - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of now.
waitForNonStaleResultsAsOfNow(long) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Instructs the query to wait for non stale results as of now for the specified timeout.
waitForReplicationFromServer(String, String, String, Etag, ReplicatedEtagInfo[], int, CancellationTokenSource.CancellationToken) - Method in class net.ravendb.client.document.ReplicationBehavior
 
waitOne() - Method in class net.ravendb.abstractions.util.AutoResetEvent
 
waitOne(int, TimeUnit) - Method in class net.ravendb.abstractions.util.AutoResetEvent
 
waitOne() - Method in class net.ravendb.abstractions.util.ManualResetEvent
 
waitOne(int, TimeUnit) - Method in class net.ravendb.abstractions.util.ManualResetEvent
 
waitSync() - Method in class net.ravendb.client.document.ReplicationBehavior
 
waitSync(Etag, Long, String, int) - Method in class net.ravendb.client.document.ReplicationBehavior
 
warn(String) - Method in interface net.ravendb.abstractions.logging.ILog
 
warn(String, Object...) - Method in interface net.ravendb.abstractions.logging.ILog
 
warn(String) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
warn(String, Object...) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
warnException(String, Throwable) - Method in interface net.ravendb.abstractions.logging.ILog
 
warnException(String, Throwable) - Method in class net.ravendb.abstractions.logging.providers.CommonsLoggingLogWrapper
 
watchAllDataSubscriptions - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchAllDocs - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchAllIndexes - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchAllTransformers - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedBulkInserts - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedCollections - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedDataSubscriptions - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedDocs - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedIndexes - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedPrefixes - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
watchedTypes - Variable in class net.ravendb.client.changes.RemoteDatabaseChanges
 
WebRequestEventArgs - Class in net.ravendb.abstractions.connection
 
WebRequestEventArgs(HttpUriRequest) - Constructor for class net.ravendb.abstractions.connection.WebRequestEventArgs
 
WebRequestEventArgs(HttpUriRequest, OperationCredentials) - Constructor for class net.ravendb.abstractions.connection.WebRequestEventArgs
 
whatChanged() - Method in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
whatChanged() - Method in interface net.ravendb.client.IAdvancedDocumentSessionOperations
Returns all changes for each entity stored within session.
WHERE - Static variable in class net.ravendb.abstractions.LinqOps.Query
 
where(Predicate<T>) - Method in interface net.ravendb.client.changes.IObservable
 
where(Predicate<T>) - Method in class net.ravendb.client.changes.TaskedObservable
 
where(Predicate<String>) - Method in class net.ravendb.client.connection.ObservableLineStream
 
where(String) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
where(String) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Filter the results from the index using the specified where clause.
where(Predicate<T>) - Method in class net.ravendb.client.document.Subscription
 
where(String) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter the results from the index using the specified where clause.
where(Predicate) - Method in interface net.ravendb.client.linq.IOrderedQueryable
Filters a sequence of values based on a predicate.
where(Predicate) - Method in class net.ravendb.client.linq.RavenQueryInspector
 
where(Predicate<T>) - Method in class net.ravendb.client.shard.ShardedObservable
 
whereBetween(String, Object, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields where the value is between the specified start and end, exclusive
whereBetween(Expression<? super TValue>, TValue, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereBetween(String, Object, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields where the value is between the specified start and end, exclusive
whereBetween(String, Object, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is between the specified start and end, exclusive
whereBetween(Expression<? super TValue>, TValue, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is between the specified start and end, exclusive
whereBetweenOrEqual(String, Object, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields where the value is between the specified start and end, inclusive
whereBetweenOrEqual(Expression<? super TValue>, TValue, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereBetweenOrEqual(String, Object, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields where the value is between the specified start and end, inclusive
whereBetweenOrEqual(String, Object, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is between the specified start and end, inclusive
whereBetweenOrEqual(Expression<? super TValue>, TValue, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is between the specified start and end, inclusive
whereEndsWith(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields which ends with the specified value.
whereEndsWith(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereEndsWith(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields which ends with the specified value.
whereEndsWith(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields which ends with the specified value.
whereEndsWith(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields which ends with the specified value.
whereEquals(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches exact value
whereEquals(String, Object, boolean) - Method in class net.ravendb.client.document.AbstractDocumentQuery
 
whereEquals(WhereParams) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches exact value
whereEquals(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereEquals(Expression<? super TValue>, TValue, boolean) - Method in class net.ravendb.client.document.DocumentQuery
 
whereEquals(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches exact value Defaults to NotAnalyzed
whereEquals(String, Object, boolean) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches exact value Default to allow wildcard only if analyzed
whereEquals(WhereParams) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches exact value
whereEquals(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches exact value Defaults to NotAnalyzed
whereEquals(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches exact value Defaults to NotAnalyzed
whereEquals(String, Object, boolean) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches exact value Default to allow wildcards only if analyzed
whereEquals(Expression<? super TValue>, TValue, boolean) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches exact value Defaults to allow wildcards only if analyzed
whereEquals(WhereParams) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches exact value
whereGreaterThan(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields where the value is greater than the specified value
whereGreaterThan(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereGreaterThan(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields where the value is greater than the specified value
whereGreaterThan(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is greater than the specified value
whereGreaterThan(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is greater than the specified value
whereGreaterThanOrEqual(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields where the value is greater than or equal to the specified value
whereGreaterThanOrEqual(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereGreaterThanOrEqual(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields where the value is greater than or equal to the specified value
whereGreaterThanOrEqual(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is greater than or equal to the specified value
whereGreaterThanOrEqual(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is greater than or equal to the specified value
whereIn(String, Collection<?>) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Check that the field has one of the specified value
whereIn(Expression<? super TValue>, Collection<TValue>) - Method in class net.ravendb.client.document.DocumentQuery
 
whereIn(String, Collection<?>) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Check that the field has one of the specified value
whereIn(String, Collection<?>) - Method in interface net.ravendb.client.IDocumentQueryBase
Check that the field has one of the specified values
whereIn(Expression<? super TValue>, Collection<TValue>) - Method in interface net.ravendb.client.IDocumentQueryBase
Check that the field has one of the specified values
whereLessThan(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields where the value is less than the specified value
whereLessThan(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereLessThan(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields where the value is less than the specified value
whereLessThan(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is less than the specified value
whereLessThan(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is less than the specified value
whereLessThanOrEqual(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields where the value is less than or equal to the specified value
whereLessThanOrEqual(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereLessThanOrEqual(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields where the value is less than or equal to the specified value
whereLessThanOrEqual(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is less than or equal to the specified value
whereLessThanOrEqual(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields where the value is less than or equal to the specified value
WhereParams - Class in net.ravendb.client
Parameters for the Where Equals call
WhereParams() - Constructor for class net.ravendb.client.WhereParams
Create a new instance
whereStartsWith(String, Object) - Method in class net.ravendb.client.document.AbstractDocumentQuery
Matches fields which starts with the specified value.
whereStartsWith(Expression<? super TValue>, TValue) - Method in class net.ravendb.client.document.DocumentQuery
 
whereStartsWith(String, Object) - Method in interface net.ravendb.client.document.IAbstractDocumentQuery
Matches fields which starts with the specified value.
whereStartsWith(String, Object) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields which starts with the specified value.
whereStartsWith(Expression<? super TValue>, TValue) - Method in interface net.ravendb.client.IDocumentQueryBase
Matches fields which starts with the specified value.
withAllLocks() - Method in class net.ravendb.abstractions.util.AtomicDictionary
 
withApiKey(String) - Method in class net.ravendb.client.document.DocumentStore
 
withCaseInsensitivePropertyNames() - Method in class net.ravendb.abstractions.json.linq.RavenJObject
 
withConventions(DocumentConvention) - Method in class net.ravendb.client.DocumentStoreBase
 
within(Object) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
 
withinRadius(double, double, double) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
 
withinRadiusOf(double, double, double) - Method in class net.ravendb.client.document.DocumentQuery
 
withinRadiusOf(String, double, double, double) - Method in class net.ravendb.client.document.DocumentQuery
 
withinRadiusOf(double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.DocumentQuery
 
withinRadiusOf(String, double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.DocumentQuery
 
withinRadiusOf(double, double, double) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
withinRadiusOf(String, double, double, double) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
withinRadiusOf(double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
withinRadiusOf(String, double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.DocumentQueryCustomization
 
withinRadiusOf(double, double, double) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Filter matches to be inside the specified radius
withinRadiusOf(String, double, double, double) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Filter matches to be inside the specified radius
withinRadiusOf(double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Filter matches to be inside the specified radius
withinRadiusOf(String, double, double, double, SpatialOptions.SpatialUnits) - Method in class net.ravendb.client.document.DocumentQueryCustomizationFactory
Filter matches to be inside the specified radius
withinRadiusOf(double, double, double) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter matches to be inside the specified radius
withinRadiusOf(double, double, double, SpatialOptions.SpatialUnits) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter matches to be inside the specified radius
withinRadiusOf(String, double, double, double) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter matches to be inside the specified radius
withinRadiusOf(String, double, double, double, SpatialOptions.SpatialUnits) - Method in interface net.ravendb.client.IDocumentQueryBase
Filter matches to be inside the specified radius
withinRadiusOf(double, double, double) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Filter matches to be inside the specified radius.
withinRadiusOf(String, double, double, double) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Filter matches to be inside the specified radius
withinRadiusOf(double, double, double, SpatialOptions.SpatialUnits) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Filter matches to be inside the specified radius
withinRadiusOf(String, double, double, double, SpatialOptions.SpatialUnits) - Method in interface net.ravendb.client.IDocumentQueryCustomization
Filter matches to be inside the specified radius
withinRadiusOf(double, double, double) - Method in class net.ravendb.client.spatial.SpatialCriteriaFactory
Deprecated.
withLockFor(String) - Method in class net.ravendb.abstractions.util.AtomicDictionary
Usage: synchronized (withLockFor(key))
WktSanitizer - Class in net.ravendb.abstractions.spatial
 
WktSanitizer() - Constructor for class net.ravendb.abstractions.spatial.WktSanitizer
 
write(InputStream) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
write(String) - Method in class net.ravendb.client.connection.implementation.HttpJsonRequest
 
write(String, RavenJObject, RavenJObject) - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
write(String, RavenJObject, RavenJObject, Integer) - Method in class net.ravendb.client.document.ChunkedRemoteBulkInsertOperation
 
write(String, RavenJObject, RavenJObject) - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
 
write(String, RavenJObject, RavenJObject, Integer) - Method in interface net.ravendb.client.document.ILowLevelBulkInsertOperation
 
write(String, RavenJObject, RavenJObject) - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
write(String, RavenJObject, RavenJObject, Integer) - Method in class net.ravendb.client.document.RemoteBulkInsertOperation
 
writeBinary(Base64Variant, byte[], int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeBoolean(boolean) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeDataToRequest(HttpRequest, String, boolean) - Static method in class net.ravendb.abstractions.connection.HttpRequestHelper
 
writeEndArray() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeEndObject() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeFieldName(String) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNull() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(long) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(BigInteger) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(double) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(float) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(BigDecimal) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeNumber(String) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeObject(Object) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRaw(String) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRaw(String, int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRaw(char[], int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRaw(char) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRawUTF8String(byte[], int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRawValue(String) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRawValue(String, int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeRawValue(char[], int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeStartArray() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeStartObject() - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeString(String) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeString(char[], int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeTo(JsonGenerator) - Method in class net.ravendb.abstractions.json.linq.RavenJArray
 
writeTo(JsonGenerator) - Method in class net.ravendb.abstractions.json.linq.RavenJObject
Writes this token to a JsonGenerator
writeTo(JsonGenerator) - Method in class net.ravendb.abstractions.json.linq.RavenJToken
 
writeTo(JsonGenerator) - Method in class net.ravendb.abstractions.json.linq.RavenJValue
 
writeTo(OutputStream) - Method in class net.ravendb.client.document.RemoteBulkInsertOperation.BulkInsertEntity
 
writeTo(OutputStream) - Method in class net.ravendb.java.http.client.GzipHttpEntity
 
writeTo(OutputStream) - Method in class net.ravendb.java.http.client.RavenGzipDecompressingEntity
 
writeTree(JsonNode) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
writeUTF8String(byte[], int, int) - Method in class net.ravendb.abstractions.json.linq.RavenJTokenWriter
 
WWWAuthenticateHeaderKey - Static variable in class net.ravendb.abstractions.connection.OAuthHelper.Keys
 

Y

yieldStreamResults(CloseableHttpResponse) - Static method in class net.ravendb.client.connection.ServerClient
 
yieldStreamResults(CloseableHttpResponse, int, int, RavenPagingInformation, Function1<JsonParser, Boolean>) - Static method in class net.ravendb.client.connection.ServerClient
 

_

_databaseName - Variable in class net.ravendb.client.document.InMemoryDocumentSessionOperations
 
_deserialize(String, DeserializationContext) - Method in class net.ravendb.abstractions.extensions.JsonExtensions.EtagDeserializer
 
A B C D E F G H I J K L M N O P Q R S T U V W Y _ 

Copyright © 2016. All Rights Reserved.