All Classes and Interfaces

Class
Description
Abstract implementation of a monitor for a particular transient action.
Extending the AActionMonitor to accept a action result which can be used for building result description.
MBean with the cache value.
A base implementation for an IActivePivotContentService that delegates its calls to an underlying service.
 
Abstract class which implement general behaviour for ActivePivot's continuous queries.
Base class for events impacting a single pivot.
The ground implementation of an IActivePivotQueryExecutor, implementing the basic behavior.
Base class for events impacting a single schema (and multiple of the underlying pivots).
This abstract class encapsulates the behavior of a stream which subscribes to an ActivePivot instance continuous queries.
Abstract class specialized for IStreamNode on IQuery on a IActivePivot.
A future that adapts the future value of an underlying future.
Abstract base class for all post processors.
Abstract implementation of an IAggregateCollector.
 
Abstract aggregate provider to be extended by every provider implementations.
Base implementation of an IAggregateProviderTransaction.
Base implementation of a IAggregateProviderVersion.
Base class for synchronous continuous handlers.
Abstract implementation of an IAggregatesContinuousQueryEngine.
Special aggregate retriever used during continuous query evaluation.
Special aggregate retriever used during continuous query evaluation for the measures that are specific to one query (e.g.
Abstract base implementation of an IAggregatesRetrieval.
Base implementation of an IAggregateStoreBinding that manages column-to-column bindings.
Abstract SQL generator for InternalAggregateTable.
Base class for implementing IAggregation classes.
Base class for aggregation binding implementations.
Aggregation Binding specialized for cloneable (object) aggregates like for instance vectors.
Base for aggregation functions.
Abstract implementation of a basic aggregation procedure for analysis hierarchies.
An Analysis Hierarchy is a hierarchy that is (at least partially) defined externally from the actual data in the cube, to offer an additional level of analysis that was not available through the traditional constructs of a cube.
Abstract implementation class for IAnalysisHierarchyDescriptionProvider.
Abstract configuration class for Copper analytic functions.
Condition tree visitor normalizing the AND logical nodes with leaf children of same field.
Extracts the value to search in a field when two conditions target the same fields.
This abstract class is the common function implementation definition shared by PeriodsToDateFunction, WTDFunction, MTDFunction, QTDFunction MTDFunction and YTDFunction.
Common implementation of an IApplicationManager.
Abstract vector feeder for array types.
A reader for array containing lists.
Basic implementation of IArrayCursor which delegates the calls to an IWritableArray.
Proxy to read and write undictionarized values from an underlying IArrayCursor.
Base class for array based vectors.
An implementation of an IVectorAllocator that allocates on-heap vectors that relies on standard java arrays.
An implementation of an IVectorAllocator that allocates on-heap vectors of doubles that relies on standard java arrays.
An implementation of an IVectorAllocator that allocates on-heap vectors of floats that relies on standard java arrays.
An implementation of an IVectorAllocator that allocates on-heap vectors of ints that relies on standard java arrays.
An implementation of an IVectorAllocator that allocates on-heap vectors of longs that relies on standard java arrays.
A reader for array stored on multiple column.
Base class for asynchronous continuous handlers.
An attached query that can be executed asynchronously using IAsyncAttachedQuery.executeAsync(CountedCompleter).
A Consumer which asynchronously processes the items submitted through AAsyncConsumer.accept(Object).
The basic abstract class for implementing a multiversion mechanism for a type of Object.
The base implementation of an IAgent that performs atomic state transitions.
AAttachedQuery
The audit stored in the database.
An health event that occurs within a thread that must be authenticated, and as such has a current user with roles.
Abstract ClientRequestFilter to handle authentication against remote servers, setting the HttpHeaders.AUTHORIZATION header.
 
This abstract class handle the problem of giving directly hierarchy and level ordinals or names.
A hierarchy which holds members from different epochs.
An iterator which only iterates on the members which exist at a specified epoch.
A predicate that check if a member exists for an epoch.
A hierarchy version for axis hierarchies.
A base iteration for leads iterations.
Iteration on the members of a level with reverse level order, excluding the current sibling from the siblings.
Default implementation of an AAxisMemberIteration that excludes the sibling.
Iteration on the members of a level with reverse level order, that includes the asked member in the siblings.
Implementation of an AAxisMemberIteration that includes the sibling, if we are at the given depth.
 
Parent abstract class representing an object that wraps a blob client.
Wrapper on an Azure Storage's directory.
Operation of finding all rows in toNode's store that reference/are-referenced-by rows in fromNode's store.
Runtime exception thrown when a reader requires a version at an epoch in the past and that version has already been abandoned by the multiversion holder.
Base array reader which read an array from multiple array readers.
A version that keeps a reference to its base.
Abstract post-processor with support for high performance dynamic aggregation.
Abstract basic implementation of a procedure, applied to only one hierarchy.
ClientRequestFilter to handle basic authentication against the remote content server, setting the HttpHeaders.AUTHORIZATION header.
Abstract class for entitlementsProvider which does not differentiate between roles and users.
 
 
Abstract base for a Continuous handler associated with one measure (aggregated measure or post processed measure).
Class representing a operator working with two arguments.
Abstract base class for IPostProcessor that retrieves its underlying aggregates at the exact location its computes a result for.
Abstract implementation of IAggregateCollector which directly writes into the base.
Bitmap index implementation using QfsBitmaps internally.
Abstract implementation of IBlockAllocator that does everything (caching, concurrent allocations...) except allocating/releasing memory.
Implementation of a vector that is based on blocks to retrieve its underlying data.
Basic implementation of an IVectorAllocator.
The base class for an IBroadcastMessage.
 
Base class for cell set implementations.
Abstract implementation of an append-only dictionary.
Abstract base class for hash based data structures.
A hash table that stores hashes in a chunk.
Hash table interface.
Large hash table, length maximum is 2^30 elements, (i.e.
Large hash table, length is 2^31 (about 2 billions), all slots in the table have a positive index.
Standard size hash table.
Very large hash table, length is 2^32 (about 4 billions), all slots in the table have a positive index.
Abstract base class for monitors.
Base class inherited by statistics providers.
A sub-location derived from a location pattern.
Abstract base class for transfer implementations.
A wrapper around an IVector that sets all values to their absolute value.
Bucketer post processor.
Bucket hierarchy.
Basic pool class for buffer-based vector.
The pool responsible for allocating BufferDoubleVectorBlocks.
The pool responsible for allocating BufferFloatVectorBlocks.
The pool responsible for allocating BufferIntegerVectorBlocks.
The pool responsible for allocating BufferLongVectorBlocks.
Base implementation of a block based on java.nio buffers.
Abstract implementation of IBuilder.
Schema that caches ReferencedTable aliases for consistent query generation.
Abstract class for the planned cached primitive nodes.
Abstract base class for calculated drillthrough column that compute values directly from underlying fields.
A composite Iterator that computes a Cartesian product of all values produced by the underlying iterators.
A listener wrapper to catch up with the current version, by running delta queries.
The cell plan executor is responsible for actually executing the calculations.
An IConcurrentDictionary where most of the regular operations are non-blocking.
Implementation of Christmas dictionary for primitive arrays (object[], int[], double[], etc.).
Christmas dictionary for double[].
Christmas dictionary for float[].
Christmas dictionary for int[].
Christmas dictionary for long[].
Christmas dictionary for Object[] or array of other types.
Chunk abstract base, with default implementation of typed read operations.
Base class for chunk allocators.
The vector allocator that is returned when retrieving it with AChunkAllocator.getVectorAllocator(IAllocationSettings).
A column based on underlying chunks.
ChunkOffset abstract base, with default implementation of typed scan operations.
A chunk storing primitive integers.
Base class for primitive integer chunks.
A record reader backed up by chunks for storing the data.
Abstract implementation for cloud CSV topics.
Abstract implementation of ICloudDirectory.
A channel factory for sources that have a notion of index to access elements of each record.
Examples of such sources: the
invalid reference
CsvSource
, a
invalid reference
JdbcSource
, etc.
If a field name cannot be found in the source, this channel factory will create an EmptyCalculator for this field.
Base abstract class to be extended by columnar translators.
Base abstract class for convenient column calculator implementations.
A Column of ChunkSet.
Base column store class.
A view over a single column of this store, exposed as a IColumn.
A view over a single column of this store, exposed as a IColumn.
Base implementation for the commit part of a remote transaction.
A task is responsible for executing some operations on a partition.
Task to execute ICompiledIncomingReferenceOperation on a target partition via multiple references.
Task to execute an own reference operation on a given partition.
Task to execute some content operations on a given partition.
Abstract class to generate Java classes.
Base implementation for an ICompositeActivePivotTransactionInfo.
Abstract base class for file information on a compressed archive.
Compressor of bytes using the lz77 standard.
Abstract implementation of IConcreteReference.
Adapter used for record flattening during structural transaction.
Abstract implementation of an IConcreteReferenceFactory.
Base implementation for a transaction on a Reference.
Implementation of a IConcreteReferenceVersion.
A channel that will download in parallel parts of an entity to speed up the global download speed.
Base class for conditions.
Abstract class used to easily implement an ITreeVisitor for ConditionTree.
Utility class used to print the content of a database.
Abstract implementation of IContentService which facilitate the monitoring.
A contextual and cancellable RecursiveBoundedTask.
Base class inherited by context value implementations.
Default implementation for IContextValueManager.
Base implementation to visit resolved expression with a context.
Generic implementation for continuous GAQ monitor.
A monitor for continuous handler under a context node.
Statistics collector for continuous handler node monitor.
Generic monitor for continuous query.
Define functions for statistics collector for a continuous query.
Generic implementation for timing of continuous query.
Abstract contribution task doing the contribution with a lock.
Abstract class for the Copper representation of Analysis hierarchies.
Abstract class for all ICopperFunction to force implementations to override Object.equals(Object) and Object.hashCode().
Abstract base for Join Hierarchies.
Level builder handling common attributes.
Abstract implementation of ICopperOperator that provides memoizing capability to compute only once the associated ICopperFunction.
Abstract class used to easily implement an ITreeVisitor for Copper.
A remote socket client has established a connection and sent a AcquaintanceMessage.
A message sent the first time a NettyTransporter is connecting to another one.
Abstract implementation of a DAO performing Create and Read actions.
Abstract implementation of a DAO performing Create, Read and Delete actions.
Statistics collector for crossed-stream continuous query monitor.
Abstract implementation of a DAO performing Create, Read, Update and Delete actions.
Abstract class representing a single error or warning listing.
Abstract class representing a single error or warning listing, whose position in the line can be determined.
Abstract class for events related to the parsing of a CSV file.
Abstract implementation for CSV topics.
Encapsulation for the pending state.
Enum used to signify the status when we need to create a data provider.
The default implementation of an IActiveCollector.
A custom MDX function that calls the PostProcessor with the given plugin key.
The function definition of ActiveMeasureFunction.
Helper class enabling starting the ActiveMonitor daemon once the distribution is stable.
The hibernate configuration for ActiveMonitor.
Spring configuration class defining services offered by ActiveMonitor extension for ActivePivot.
Registry contributor for the activemonitor pivot impl module.
Spring configuration class defining all REST services available in ActiveMonitor.
Class defining information about ActiveMonitor REST services.
Registry contributor for the activemonitor server impl module.
Spring configuration class defining the different services provided by ActiveMonitor.
Spring configuration class defining the beans related to WebSocket services.
Instance planning and performing retrievals into an ActivePivot.
The key that uniquely identifies an execution plan.
The base version of a MultiVersionActivePivot.
Helper class to manipulating conditions from ActivePivot descriptions.
This class is a container for IActivePivot instances running inside this schema.
A view of a Content service that helps one retrieve and store ActivePivot related classes from the content service.
Provides a smooth way to create a IActivePivotContentService.
 
 
Each time a user connect to ActivePivot server, the entitlements will be retrieved from the content service.
 
A utility class to help with the ActivePivot content service.
A default implementation of IActivePivotContext.
 
Event fired when a new continuous query is registered on a pivot.
Event fired when a continuous query is un-registered from a pivot.
Event fired when the definition of a continuous query on a pivot has been updated.
This class implements the IActivePivotDescription interface.
ActivePivot Discovery for SOAP webservices.
Base ActivePivot event.
An exception thrown by an ActivePivot instance.
Basic implementation of IActivePivotDataFeedHolder.
Utility to access predefined IActivePivotFeedingPolicys.
A Runnable that should be invoked periodically to detect a continuous inactivity on a collection of pivots.
This class implements the IActivePivotInstanceDescription interface.
An Object used for managing the pivot's transaction listeners and notifying them after a transaction is committed.
This class implements the IActivePivotManager interface.
Builder of ActivePivot Manager.
Full description of an IActivePivotManager structure.
Rebuilds an IActivePivotManager with a new description, maintaining the creation context.
The manager structure.
Internal utility.
The default MVC configurer for ActivePivot.
Event fired when a non-continuous query has finished executing successfully.
The base plugin responsible for executing attached queries on an IActivePivot.
Base class that registers Atoti vanilla implementations of an IActivePivotQueryExecutor.
Event fired when a non-continuous query has resulted in a failure for a reason that is not a timeout.
Cube query manager.
A helper object used to create and run queries on an ActivePivot.
Event fired when an ad-hoc query starts executing.
Default implementation for IActivePivotStreamIdentifier.
Implementation of a IRepositoryService over a remote server using the REST API defined by IRepositoryRestService.
Configuration importing REST services based on ActivePivot instances.
Class defining information about ActivePivot REST services.
Configuration class exposing REST services for ActivePivot.
ActivePivot Schema.
Builder of ActivePivot Manager.
This class implements the IActivePivotSchemaDescription interface.
An ActivePivotSchema that accepts IDistributedActivePivotInstanceDescription and is able to manage lifecycle of query cubes.
This class is a container for a distributed version of a pivot.
Plugin defining all the standard types of schemas.
Full description of an IActivePivotSchema.
Basic implementation of a IActivePivotSchemaSelectionSession.
Encapsulates all the statistics associated with an instance of IActivePivotSchema.
Implementation of an IActivePivotSchemaStructure.
A transaction on an ActivePivot Schema.
Transaction states.
Transaction Manager implementation that handles transactions at the ActivePivot schema level.
Implementation of an IActivePivotSchemaUpdater.
Pojo representing structural update by pivot.
Class optimizing a selection to reduce its scope to the minimal amount of tables.
 
Spring declaration of the ActivePivot Services.
Encapsulates all the statistics associated with an instance of IActivePivot.
Action to run to asynchronously attach a synchronous query to an ActivePivot.
A query to wrap a runnable action within the ActivePivot query engine.
A utility class that exposes a static method for running an pivot-dependent action while holding its query lock.
Abstract implementation of an ActivePivotSyncUtils.IAction.
Base implementation of an ActivePivotSyncUtils.AAbstractAction that synchronously executes the action.
An action that does not take any arguments and does not return any result.
A simple action that does not take any arguments.
An action to execute on the session associated with a target pivot.
A transaction on an ActivePivot.
Event fired when a transaction is successfully committed through IActivePivotSchemaTransactionManager.
An exception thrown when something goes wrong with a transaction on an ActivePivot component.
Implementation of the IActivePivotTransactionInfo interface.
Event fired when a transaction is rolled back.
Event fired when a transaction is started through the IActivePivotSchemaTransactionManager.
Base implementation of an IActivePivotVersion.
Helper class to simplify queries and location based operations on an ActivePivot instance.
The AP WebSocket config.
Configuration importing WS services based on ActivePivot instances.
Configuration for the XmlaService.
Property class for the XMLA REST controller.
ActivePivot XMLA controller handling XMLA operations and queries.
Record grouping arguments to pass to the constructor of ActivePivotXmlaController.
Annotation indicating a default plugin or extended plugin of the IRegistry.
Annotation indicating a default type of the IRegistry.
ActiveViam Checked Exception.
Similar to ActiveViamProperty, but for non-facing clients properties.
A subclass of ActiveViamRuntimeException that can register arbitrary values in order to use them in a subsequent catch block.
An enumeration of all the possible types of annotations.
Core properties used in ActiveViam products.
Log a warning message for every LegacyActiveViamProperty that is set.
Registry allowing only a set of predefined IActiveViamProperty.
This configuration allows to override the values of the ActiveViam properties with the Spring Environment.
A Spring configuration which imports all the REST services (Pivot, JWT, Content service, Datastore, Data export).
ActiveViam Runtime Exception.
Security Exception thrown within a ActiveViam component.
A Spring configuration which imports all the WS services.
Extended plugin for IFormField.IType converting Activiti FormType.
Configuration for having workflows running in ActiveMonitor.
Workflow Service using Activiti to trigger workflows upon configuration changes.
Base implementation of ICubeFormatterFactory that uses a Map<String, Map<String, String>> as dictionaries.
Basic implementation of ICubeHelper.
Base class for implementing the cursor.
Abstract implementation of a cursor factory.
Iterate on the elements of a cursor, following the java Iterator API.
This is the base class for custom properties, implementing the basic behavior shared by all custom properties.
Datastore Selection Listener transforming the content it receives into Database Listener notifications.
 
A partitioning that can be done on different fields.
 
The adaptive partitioning is never implied by anything.
 
 
Description of an adaptive partitioning.
 
Abstract for IDatabaseRetrieval implementations.
Abstract class for implementing IDatabaseRetrievalResult.
Basic abstract immutable implementation of an IDatabaseSchema listing the tables and joins.
Abstract implementation of IInternalDatabaseSchemaUpdater for Sql and Spark.
Simple abstract implementation of IDatabaseServiceConfiguration with fields for all getters.
An implementation of an ICustomProperty that is able to retrieve data from a database.
Abstract class to handle the supported and compatible versions of a database.
Abstract data contributor implementation able to handle cube transactions.
Abstract IDataCubeAdapter that contains base methods for the component constructors.
An abstract implementation of an IDistributedAgent to be used in a Data node.
Abstract class to extend when creating a IDataSourceBuilder.
 
Entity storing any information about the database.
DAO providing information about the application database.
AddCalculatedMember function.
Add dimension/hierarchy action.
This is a utility class to manipulate the additional measures of IGetAggregatesQuery.
Implementation of a IMeasuresProvider that is constructed from another IMeasuresProvider and adds additional measures.
Basic implementation of IAddReferenceAction.
 
Abstract implementation of IDatabaseService that does nothing except calling the next service.
Extension of ADynamicMonitoringWithAnnotations decorating an existing manitoring instance with annotated attributes and methods defined on the decorating instance.
This abstract class provides the basic implementation of IDefaultCellPropertiesHandler.
Proposes some default values for epoch management policy.
A vector wrapper that verifies its underlying vector implements IReleasableVector and delegate the call to ADelegateReadOnlyVector.acquireReference() and ADelegateReadOnlyVector.releaseReference() to its underlying vector.
An IStorePartitionView Object that relies on a delegate partition view.
A stream that delegates to an underlying stream.
 
A Delegating context.
Base class representing a node in a PlanningGraph.
 
Basic implementation of a description to which new imports can be added.
A cursor wrapped over an underlying cursor, with the dictionaries (if any) for each field.
Generic implementation for a proxy to read un-dictionarized values from an underlying IArrayReader containing dictionarized values.
Abstract implementation of the IDimension interface.
Component used to create the IMultiVersionDimension.
Abstract base class for native memory chunks.
Used to free the memory of native chunks.
Abstract class for an allocator that allocates chunks off-heap, using the given native memory allocator.
Abstract base class for native memory chunks.
Base class for primitive integer chunks.
Abstract class for the Spring configuration of an application based on DirectQuery.
Abstract class for a native allocator of vectors.
The pool responsible for the allocation of DoubleBlockVectors.
The pool responsible for the allocation of DirectFloatVectorBlocks.
The pool responsible for the allocation of DirectIntegerVectorBlocks.
The pool responsible for the allocation of DirectLongVectorBlocks.
A block that can store vectors using direct memory allocated an INativeMemoryAllocator.
An abstract implementation of an IDistributedAgent.
Implementation of a distributed health event with an epoch.
Default implementation for health event that need extra context in a distributed environment.
Implementation of a distributed health event with an epoch, hierarchy contributions and removals.
The base implementation for an IDistributedMessenger.
Abstract implementation of IDistributedSecurityManager.
Implementations of the IAdministrationService interface.
Administration Web Service exception thrown when a web method fails to execute.
Automatically loads the AdminUIResourceServerConfig.
Marker interface for a component providing the Spring resource containing the env.js file content for Atoti Admin UI.
Spring configuration for AdminUI web application.
Base class for DrilldownLevelFunctionDefinition, DrilldownLevelTopFunctionDefinition invalid input: '&' DrilldownLevelBottomFunctionDefinition.
Common implementation for DrillDownMemberTop and DrillDownMemberBottom.
The abstract drillthrough that allows the registration of the continuous queries.
Base class for mdx drillthrough execution.
Basic implementation of an UDAF measure.
Default implementation of an IAdvancedAggregatesRetriever.
Abstract post-processor with support for high performance dynamic aggregation.
This class implements general behavior for JMX monitored beans.
This class behaves like ADynamicMonitoring and parse JmxAttribute and JmxOperation annotations like AnnotationMBean.
Operand holder for IDynamicCondition.
 
Class fetching the time-travel information from an external database.
Abstract class for ActivePivot entitlements.
Reference on an object stored in the cloud.
Base implementation of a IAdvancedEpochManager.
Base implementation of IEventAlertAggregator providing default management of the events.
A base class for any entry in an eviction cache.
Abstract class for execution.
A primitive aggregates retrieval that provides methods to expand its result over a location scope.
Its expansion procedure makes sure that all the context values of the query is set on the thread performing the expansion in order that the filter (if any) is properly applied over the hierarchies of the cube.
 
 
Abstract class for the calculation of children and sibling function.
A ARecordingRegistrationAwareListener that can be replay its stored updates.
Implementation of the IMessageHandler to log the feed loading in an external file upon completion.
Immutable abstract description of an IDataTableField.
Builder of AFieldDescription.
Abstract implementation of an IPartitionContentFactory that creates content related to a defined set of fields.
Abstract implementation for output managers with a directory and file name.
Abstract implementation for CSV topics that are based on files that can be found on the current file system.
A facade to perform filtered iteration with the Iterator interface.
Abstract IPostProcessor which simply filters locations based on conditions on levels.
Implementation of a vector that is based on blocks to retrieve its underlying data.
A function that has a single fixed signature.
Base class for function definitions with a fixed signature (fully defined with constant number of parameters).
Abstract class for a fixed length integer array.
Base class for function implementation.
Base class for implementation of a function definition.
Common parent to all implementations of ITransactionContent.
Data transfer object for IAgentConnectionDetails.
Data transfer object for IAgentDescription.
Base exception for all Sink and source AgentException.
Component listening for agent connection and disconnection.
Default implementation of IAgentRestService.
Holder of the state of an agent, provides methods to change the state atomically.
An IAggregatedContributionHolder where additional contributions can be provided.
 
Measure representing a database field aggregated using an aggregation function.
Aggregated measure based on the standard aggregation of input values.
Factory for the AggregatedMeasure.
AggregatedMeasureDescription is the description class for an AggregatedMeasure.
Continuous handler associated with one measure (aggregated measure or post processed measure).
Record representing an Aggregated Selection.
The aggregation DTO is an association of a location and its aggregate.
 
Aggregate key to group tuple with common aggregate needs.
Explicit implementation of the IAggregateProviderBase extended plugin.
Build a multi-version aggregate provider from its definition and the contextual hierarchical mapping.
 
 
Definition of an aggregate storage.
 
AI-based optimizer that computes aggregate provider recommendations to cover the previously executed queries.
Record storing statistics about the query history on which the aggregate provider recommendations are based for a single cube.
Record storing statistics about the query history on which the aggregate provider recommendations are based for all the cubes of an application.
Selects the partitions of an aggregate provider that are necessary to handle a location, given the hierarchical mapping and the partitioning of this aggregate provider.
Properties to configure the AI-based aggregate provider recommendation.
POJO embedding all necessary statistics from an aggregate provider version.
A query equivalent to an SQL's GROUP BY.
 
Implementation of an IAggregateQueryResult.
Wraps an acceptor to merge all the results on the same partition and then call the wrapped acceptor with the merged results.
Acceptor which accepts one AggregateQueryResult per partition.
Metadata describing a AggregateQueryResult.
Thread-safe class gathering statistics on the processing of an aggregate query result.
 
A retrieval associated with an aggregate retrieval This class represents the common class for non empty retrievals.
Aggregate query ready to be run.
A cache for computed aggregates.
This class implements the IAggregatesCacheDescription interface.
A monitored component used to expose a pivot's aggregates cache as a monitored bean.
The statistics for an AggregatesCache.
Explicit implementation of the aggregates continuous handler plugin.
Explicit implementation of the IAggregatesContinuousQueryEngine extended plugin.
Statistics for an aggregates continuous query engine.
 
Pipeline to contribute into an aggregate provider.
An aggregates entry is simply a {range location, measure} pair that allows for querying.
Event corresponding to the update of a set of aggregates.
Component that writes values into a writer.
 
An Object used to create retrievals that will be contributed into an ExecutionPlan.
The result of the planning of a retrieval.
Basic implementation of an IAggregatesRetrievalDescription.
A transporter of AggregatesRetrievals.
Basic implementation of an IAggregatesLocationResult on top of an IIterableAggregatesRetrievalResult.
Requests the aggregates from the aggregate provider holder.
An IAggregateStore that can directly bind itself to a source for copying and aggregating data.
Singleton class compiler for aggregation bindings of tables.
A dictionary to attribute a unique index to a tuple of objects, based solely on the classes of those objects.
Specific implementation of a record format for Aggregate stores.
Helper class that joins / combines a list of IAggregateStore into a single consolidated result.
Abstract bootstrapper to create AggregateTableDescription corresponding to an aggregate provider.
A comparator between aggregate tables.
Immutable description of an aggregate table.
Describe the filer used to generate the aggregate table.
 
 
Utilities to handle filters on aggregate tables.
Optimizer for a UnifiedApiQuery to switch if possible to an equivalent query on an aggregate table.
Type of query.
Utility class for aggregate table manipulation.
Validator for AggregateTableDescription instances to ensure they are compatible with the providers they will feed.
 
 
Basic implementation of a context to provide when creating aggregation procedures.
Mask determining whether a CopperMeasureToAggregateAbove will be aggregated if any of the defined levels are present or if all are expressed.
Registry contributor for the aggregation module.
The utilities to convert an aggregation function to a window traversal.
A supplier for the reducer corresponding to an aggregation function.
Common aggregation manipulation utilities.
Common aggregation manipulation utilities.
Utils class for aggregation module.
 
Base implementation of an IGlobalAggregateProviderBase based on an AAggregateProviderBase.
Abstract implementation of an IGlobalAggregateProviderTransaction.
Base implementation of an IGlobalAggregateProviderVersion.
Implementation of an IGlobalHealthEventHandler that redirects all events to per-project handlers.
Abstract class providing the skeleton and base functions to compute the greatest common partitioning implied by two underlying partitionings.
Abstract implementation for aggregated runnable queries.
Base class for translator detecting the columns to parse from header lines.
The default implementation for a all health events.
Abstract class to help implement a content service on top of a Hibernate database.
Abstract implementation of the IHierarchy interface.
There are 2 different implementation of this abstract class which concerned measures and axis.
 
Abstract implementation for hierarchy descriptions.
Abstract base implementation for a memory quantifier for ActivePivot hierarchy members.
Base abstract implementation of an IHierarchyTransaction.
Initialize the cube formatters with the supported locale defined in the Content service.
The base data access object.
A visitor that represents the operation which retrieves the id of the partition in one partitioning that contains all the records of a partition of another partitioning.
 
Given a stream view, resolves the impacting table updates.
Holder for the content of a regular transaction on a partition.
Incremental refresh task in charge to compute the delta and to forward it to the resolved listener.
Plans a streams incremental refresh.
Factory which provides the refresh task for a stream view.
A IRecordHandler that process the records to add and the tuples to remove independently.
The abstract coordinates implementation.
Abstract compiled operation performing a disjunction of lookups on a set of fields that are uniquely indexed for a single point.
Aggregate storage using bitmaps to optimize query executions.
Only the leaf aggregates are materialized, the higher level aggregates are computed on the fly.
An abstract class for transactions specialized for the indexed aggregate providers.
Base class for a column calculator using the position of the column to produce.
A procedure used to expand a given location using the current hierarchies and the points stored in an indexed aggregates collector.
A filter visitor that can compile an ICubeFilter into a IBitmap.
The compiled ICubeFilter for a bitmap transaction.
Abstract compiled operation performing a disjunction of lookups on a set of indexed fields where the conditions on the indexed fields have multiple values.
Utility abstract factory counting instantiations that succeeded.
Base implementation of an IIntegerArray.
Internal immutable abstract description of an IDataTableField.
An IPointProcedure that periodically checks for interruption.
An IValuesProcedure that periodically checks for interruption.
Exposes the rest API for the AI-based recommendation tool that helps configure an atoti server.
The AI-based optimizer rest service config.
Abstract class to read a JDBC array into an Atoti IVector.
Abstract IJdbcConfiguration handling DriverManager logging.
Abstract implementation of a pool of JDBC connections.
Default Jdbc column calculator.
A JDBC store channel factory IStoreMessageChannelFactory which checks the types of the attributes.
Generates an result from a result set.
A JGroups-based distributed messenger that only handles membership in a cluster.
Abstract implementation for aggregation procedures performing join operations between a cube and a store of the database.
 
Abstract implementation of a JDBC reader which converts a JDBC String, representing a Json array, to an Atoti IVector.
 
Base class for a column calculator using a JSON representation of its input field.
Convert Entity attribute state (Java Object) into database column representation (JSON).
AActionResultMonitor for an mdx action.
AJsonMdxQueryMonitor with a drillthrough statement.
Base class for all the JSON parameter classes used with the rest content server.
Abstract base class for the Json query service.
The executor for a DRILLTHROUGH MDX statement, that returns the result as a JSON object.
The executor for a DRILLTHROUGH MDX statement for headers only, that gets the result from a HeadersOnlyDrillthroughExecutor and converts it to the corresponding list of JSON columns.
The executor for a SELECT MDX statement, that gets the result from a BasicSelectExecutor and converts it to the corresponding JSON object.
The executor for a SELECT MDX statement, that gets the result from a BasicSelectExecutor and converts it to the corresponding JSON object.
A query specialized for JIT aggregates retrieval for a given location.
A AJustInTimeQuery that returns no result.
 
A pool of connections to a Key-Value database, that handles creating, releasing, providing connections.
Abstract implementation of IKeyValueConnector.
Abstract root implementation for KPI formulas.
Abstract KPI function.
Monitoring streaming agent working with KPIs.
LeafLevels prefetcher aims to prefetch all leaf aggregates values on a dynamic aggregation context.
A leaf node of a ConditionTree.
A leaf node of a ConditionTree.
Basic implementation of an IAlertCache.
The data transfer object for an alert.
Monitoring bean for all alert services.
Implementation of executor applied to alerts.
The messages rest service.
Alert topic end point.
The service handling websockets interaction with alerts.
Abstract implementation of the ILevel interface.
Object to give an alias to a relative path to a field, starting from an arbitrary and unknown table.
Base implementation for IAliasedSet.
This property allows to define an alias for a member discriminator.
 
An ordered queue of version nodes, each keeps either strong or weak reference to a version.
Predicate which matches epochs in a branch before.
Predicate which returns true when the epoch was created before a given time.
Predicate on the branch of the epoch.
A predicate on the name of the epoch.
An abstract template for Linear Regression MDX functions.
The cache in which we will store our result, to avoid recomputing everything for each cell.
This decorator makes sure that the cache is cleared between MDX updates.
Abstract class for the Linear Regression functions that retrieve parameters of a Linear Regression (such as the β and α coefficients, or the fitness info).
The LinRegIntercept MDX function.
The LinRegR2 MDX function.
The LinRegSlope MDX function.
The LinRegVariance MDX function.
 
An implementation of ICanHaveComparator that keeps track of the alternates way a comparator can be defined.
A ISubCubeTree where all the members are excluded.
 
Allocation type describing where data was allocated.
Base class for procedures allowing recycling.
Objects whose behavior is Locale dependent.
Base location formatter.
Post processor with support for location shifting.
A custom JFR event that is also loggable.
Base implementation of an ILongArray.
Basic comparator for strings which sort them alphabetically.
When possible, implementations of the IReadableByteChannelHolder interface should be lazy and open the channel only when needed.
Mutable structure of a manager.
Mutable structure of a schema.
Transaction manager supporting data updates as well as altering the schema of a Datastore.
Copper measure that copies the underlying measure to the shared members of the given alternate hierarchy and consolidate them into their parents.
Copper measure that copies the underlying measure to the shared members of the given alternate hierarchy and consolidate them into their parents.
Post processor that copies the underlying measure to the shared members of the given alternate hierarchy and consolidate them into their parents.
Post processor that copies the underlying measure to the shared members of the given alternate hierarchy and consolidate them into their parents.
Event monitoring the alternate mapping shared members drilldown feeding.
Main implementation of IAlternateMappingFeeder.
Event monitoring the alternate mapping.
General behavior of a service that allows interactions with an IActivePivotManager instance.
A special delegate for map queries.
Base class to convert a IMapQuery into another query equivalent to it.
AActionResultMonitor for an mdx action.
Append only MAX aggregation function.
Max binding for the 'double' data type.
Max binding for the nullable 'double' data type.
Max binding for the 'float' data type.
Max binding for the nullable 'float' data type.
Max binding for the 'int' data type.
Max binding for the nullable 'int' data type.
Max binding for the 'long' data type.
Max binding for the nullable 'long' data type.
 
Abstract class for axes iterator based on MdxCellSet.
Abstract class which provide information on MDX result based on MdxCellSet.
Parses a compilation pattern, and tranform into int the type T using an IMdxCompilationBuilder.
An enum of all the keyword that can be used in compilation patterns.
A AFastForwardingRegistrationAwareListener specialized for listeners used by MDX continuous queries.
Abstract implementation of IMdxFixedMember.
Base class for mdx member.
Abstract member property implementation.
The base class for the member property functions that are based on an IMdxMemberProperty.
 
AActionResultMonitor for an mdx action.
AActionResultMonitor for an mdx action.
Abstract implementation of IMdxRegistrationDecorator.
The stream handling MDX continuous queries.
Base abstract implementation of IMdxStreamNode for a stream node handling.
Abstract implementation of the IMeasureMember interface.
Object representing a measure of the cube analyzed by a SmartAggregationEngine.
Abstract class implementing functionalities needed by the MDX functions MembersNameSearch invalid input: '&' MembersCaptionSearch.
Base class for IMemoryStatistic.
Class to override to associate a builder to a AMemoryStatistic.
Skeletal implementation of a message.
A task that sends asynchronously to several remote instances (data cubes) some messages; one by remote instance; (AMessageAction.createMessage(String) will determined the message to send).
Base abstract message channel.
Abstract message channel factory IStoreMessageChannelFactory for channels that convey data from a source towards a datastore.
Abstract implementation of ITaskPublisher leaving message creation to the actual implementation.
A message sent to only one instance; to be used with AMessageAction.
Append only MIN aggregation function.
Min binding for the 'double' data type.
Min binding for the nullable 'double' data type.
Min binding for the 'float' data type.
Min binding for the nullable 'float' data type.
Min binding for the 'int' data type.
Min binding for the nullable 'int' data type.
Min binding for the 'long' data type.
Min binding for the nullable 'long' data type.
 
Monitored Mbean.
Abstract class implementing all the extended agent logic.
Define a grouper for monitors.
 
Resolution of a query on multi row vector tables.
 
Base class for multi source aggregations.
Multi Source Aggregation Binding specialized for cloneable (object) aggregates, like, for instance, vectors.
Base for multi source aggregation functions.
Multi-source aggregation binding specialized for IVector.
Simple mutable implementation of a IMultiVersion.
Base implementation of a IMultiVersionAggregateProvider.
An Analysis Hierarchy is a hierarchy that is (at least partially) defined externally from the actual data in the cube, to offer an additional level of analysis that was not available through the traditional constructs of a cube.
A multi-version structure for hierarchies.
Abstract class for a reference storing for each row of its owner store the referenced row in the referenced store.
Base implementation of a IMultiVersionGlobalAggregateProvider.
A partitioned AMultiVersionGlobalAggregateProvider that relies on underlying providers to store and retrieve the aggregates.
The multi-versioned partitioned indexed aggregate provider (partitioned leaf or partitioned bitmap).
Abstract implementation of an IMultiVersionSecondaryRecordIndex.
Abstract class for a record index mapping all keys in a dictionary, and indexing key positions in a multi-version integer array.
Basic implementation of a IAnalysisAggregationProcedureDescription.
Standard factory creating an aggregation procedure.
Analysis hierarchy, internally the same implementation as an AxisHierarchy but constructed from an explicit list of analysis levels.
A hierarchy version for axis hierarchies.
Base for multi-version analysis hierarchies.
The description for an Analysis Hierarchy.
 
Explicit implementation of the IAnalysisHierarchy plugin.
Simple implementation of IAnalysisHierarchyBuilder.
Standard implementation of IAnalysisHierarchyInfo.
Dedicated transaction type for AMultiVersionAnalysisHierarchy.
Abstract implementation of post-processor that works for Window functions where aggregates are arranged along a hierarchy AnalyticFunctionPostProcessor.traversalHierarchyInfo.
The prefetcher associated to AnalyticFunctionPostProcessor.
JDBC reader for native arrays.
 
 
Logical AND combination of other conditions.
Logical AND combination of other conditions.
Compiled condition performing a logical AND on a list of conditions.
 
Logical AND combination of other conditions.
Compile condition for $and.
Condition tree visitor normalizing the AND logical nodes with constant leaf children of same field.
Condition tree visitor normalizing the AND logical nodes with dynamic leaf children of same field.
Logical AND combination of other conditions.
AND operand for constand and dymamic underlying operands.
Order conditions of an AND operand by ascending cost estimation (the more likely a condition is to return many results, the bigger its cost is).
Composite IPartitionSelector selecting the partitions that all its underlying IPartitionSelector have selected.
Base class processing the different ways of passing parameters to dynamic conditions.
Base class processing the different ways of passing parameters to dynamic conditions.
Base class processing the different ways of passing parameters to dynamic conditions.
Skeleton for NettyRequestMessage or NettyResponseMessage send with Netty.
AnnotationContributionProvider.
Provide MBeans by parsing annotations in target objects.
Create the notification tasks that will notify the listener of a continuous query when the view of that continuous query was updated.
 
An implementation of IUnresolvedPath that matches any path.
 
Abstract simple implementation of IRecordReader dedicated to underlying Objects types.
Abstract class for expression with ICompoundIdentifier i.e [smth].[smth].
Expression representing a dimension.
Expression representing a hierarchy.
Expression representing a level.
Expression representing a member.
 
 
 
Base class for the implementation of an operand.
Base class of an operator that can be used in the ArithmeticFormulaPostProcessor.
Base class for function definition with a signature like Function(arg1, arg2, [, arg3 [, arg4 [, arg5]]]).
A visitor represents the operation which retrieves the id of the partitions of a partitioning, that potentially contains the records in a partition of another partitioning.
Parent class for all ICompiledCondition that have sub conditions.
Base implementation of an IPartitionDictionaryFactory.
The base version of an aggregate provider that partitions its data.
 
A AGlobalAggregateProviderVersion that is partitioned into multiple sub-partitions.
Abstract implementation creating map of partition content from map of factories.
Abstract implementation of an IPartitionIndexFactory.
A visitor that represents the operation which checks if a partitioning is implied by another.
Generic implementation for a node in a hierarchical partitioning.
A factory of partitioning visitor that creates a visitor based on the type of the IPartitioning it is visiting.
Factory for calculator of partitionings greatest common partitioning.
Factory to create a visitor which retrieves the id of the partition in one partitioning that contains all the records of a partition of another partitioning.
Factory to create a visitor which retrieves the id of the partitions of a partitioning, that potentially contains the records in a partition of another partitioning.
Factory to create a visitor which checks if a partitioning is implied by another.
Generic implementation of partitioning which combines Cartesian partitioning (or Single partitioning) with another type of partitioning.
Define the standalone Cartesian partitioning.
A generic implementation of partitioning with multiple partitioning fields, each of which is associated with a partitioning function.
Common parent to all implementations of IPartitionTransactionContent.
Parent of all implementations of IPartitionTransactionContentReader.
This consumer is responsible for updating the references of one of the owner store's partitions and propagate the impacts.
Base implementation to visit passes.
Default implementation for IPatternFormatter.
Abstract implementation of IPatternMatcher that provide a getter for the pattern.
Simple implementation of IPatternMatcherFactory.
A matcher that will match any submitted string.
DTO providing the deployed versions for all APIs deployed in a application.
DTO represented all deployed APIs and their versions.
Base class for Pivot-based implementation of the discovery handler.
 
Contributions to the APM module.
Base class for a point aggregator.
A point location reader on top of a point location list.
Abstract base implementation of an IPostProcessedRetrieval based on an AAggregatesRetrieval.
Abstract class for partitioned APostProcessedRetrieval retrievals.
A merger used when there are partitions in the finer plan that do not correspond to partitions in the higher level plan.
A APostProcessedRetrieval that merges together the results from partitioned retrievals for the same measure and location.
A record block which can only append records to itself up to the fixed size.
Implementation of an append-only collection.
A whole application based on DirectQuery.
The builder for the application.
Helper class containing methods and elements to build DirectQuery applications.
Provides the application context.
Event fired when a node is accepted within a distributed application, and its contribution were successfully merged in the query cube.
Event fired when a node sees its candidacy to a specific distributed application rejected.
A pair containing a Datastore and an ActivePivot Manager.
Aggregation returning an approximation of the distinct cardinality of the input.
This class is used for retrieving external approximate count distinct results.
Approximate Distinct Count aggregation function.
Approximate Distinct Count Aggregation function history.
A boolean-valued function of one argument whose type is Type.VALUE.
Abstract prefetcher that eases the construction of the IAggregatesRetrievalDescription collection that must be returned by IPrefetcher.computePrefetches(ILocation, ICubeFilter).
Base abstract implementation of a IPrimitiveRetrieval.
A utility class for generating java files specialized for primitive Objects based on a template file.
Abstract class for partitioned APrimitiveAggregatesRetrieval retrievals.
A merger used when there are partitions in the finer plan that do not correspond to partitions in the higher level plan (because new partitions were created concurrently, in-between execution plan creations).
A APrimitiveAggregatesRetrieval that merges together the results from partitioned retrievals for the same measure and location.
Base class for properties.
The serializer Object used to replace a IProperty when serializing it.
Extension of AProxyMeasure for Aggregated Measures.
A proxy measure member that represents the definition of a measure but does not have any computation capacities.
Contain common logic for all operations sending records from a store partition to a view.
A message to be broadcast and executed on all instances.
AActionResultMonitor for an mdx action.
An abstract implementation of an IDistributedAgent to be used in a Query node.
Resolution of a single query part.
Provides base implementation for query performance evaluation.
Base class for implementing a query runner.
A completion sync for synchronous run.
Base implementation for datastore list query runners with a timeout configured.
AActionResultMonitor for an mdx action.
Base class for random access sets.
A special type of aggregate retrieval that creates a result by reducing one of its subtask results (e.g.
Abstract implementation of a DAO performing Read actions.
 
Abstract class defining methods to implement a Record format focusing only on read operations.
A vector that only supports read access.
Base abstract class for all IRecordBlock.
A FieldHandler is an object that knows, given a RecordFormat, how and where to perform read and write operations in the records or blocks of records it is being passed.
Handle primitive fields.
 
Handle object fields.
 
 
 
 
 
 
 
 
 
 
Handles string fields.
A ARegistrationAwareListener that stores the received updates while it is being initialized so that they can be replayed later on.
Base abstract class for implementing a IRecordReader.
A transaction holding the pending changes in a record set.
Abstract implementation of an IRecordSetVersion.
Common abstract implementation of IRecordStream to be used by all records stream.
A visitor that recursively visits all the sub-selects of an ISelectStatement.
The abstract base class for non-blocking registrations.
Helper class which is used with IRegistration.
Base logic defining a remote transaction.
A read-only IColumn that delegates all calls to an underlying column 'c'.
Base implementation to visit resolved expressions.
Implementation of resource pool that allows to recycle instances of Objects up to a certain number: the pool keeps a cache of a given number of Objects and creates new ones if the pool has been emptied.
Implementation of the abstract response marshaller.
An abstract class for the REST API classes of the content server.
An aggregation procedure that holds its own resulting column, with an associated list of points.
Converts a result set into an aggregate query result.
A node in a PlanningGraph that represents an actual retrieval.
A completer action that performs some retrievals using an execution plan.
A function which rewrites itself into another function.
A function definition which rewrites itself into another function definition.
A simple Formula that only support arithmetical operations.
The arithmetic formula post-processor is backed by an ArithmeticFormula defined into its initialization properties.
 
 
 
Base class for rowset definitions.
A function which takes a selected SQL field and provides an expression provider to create an Array Agg on this field.
Transforms select fields to array agg query select fields.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Allocate array-based chunks, stored in the heap.
A chunk of bit primitives.
Chunk of boolean stored in an array.
Chunk of nullable boolean stored in array.
A chunk of byte primitives.
Chunk of double stored in an array.
Chunk of nullable double stored in array.
Chunk of float stored in an array.
Chunk of nullable float stored in array.
A chunk of hexadecimal primitives.
Chunk of int stored in an array.
Chunk of nullable int stored in array.
Chunk of long stored in an array.
Chunk of nullable long stored in array.
Utilities for nullable array chunks.
Chunk of positive integers, where the internal chunks use native memory.
A chunk of 2 bits primitives.
A chunk of short primitives.
A chunk of three byte primitives.
AArrayCursorWithDefaultValue where the underlying IArrayCursor already contains undictionarized values.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an IVector that stores doubles on heap.
Static dummy class to represent an array block (which is in fact the actual array vector).
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an IVector that stores floats on heap.
Static dummy class to represent an array block (which is in fact the actual array vector).
A formatter for measures returning an array.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an IVector that stores integers on heap.
Static dummy class to represent an array block (which is in fact the actual array vector).
This factory allows to retrieve all the tuples of the jdbc source with the order that has been set into the sql query.
Creates channel which creates message from Object arrays coming from JDBC.
Property used to access the last element of an object array.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an IVector that stores longs on heap.
Static dummy class to represent an array block (which is in fact the actual array vector).
An array-based vector of Objects.
Static dummy class to represent an array block (which is in fact the actual array vector).
Property used to access an element in an array of objects.
Straightforward implementation of a IRecordReader based on a IPositionalReader.
An array reader mapping the read index to another index.
Basic record reader, reading the values of the record fields from an internal array of objects.
A set of utility methods for arrays.
The array variable data type.
Util class to create on heap vectors backed by a simple java array.
 
Class to write an output in Arrow format in one or several files in the cloud.
Class to write an output in Arrow format as an archive file in the cloud.
A cursor wrapping an Arrow table.
 
 
 
 
Class to write an output in Arrow format in one or several files.
 
 
 
 
 
 
 
 
 
 
 
Arrow multi column double vector reader.
Arrow multi column long vector reader.
Arrow multi column object vector reader.
 
 
Utilities for reading Arrow.
RecordBlock wrapping underlying Arrow vectors.
Registry contributor for the arrow module.
Class to write an output in Arrow format in stream.
Special reader for arrays of String as the reader for arrays of object return vector of Text instead of String.
 
 
 
 
Object reader decorator to transform empty toString to default value.
 
Abstract reader wrapping an Arrow vector.
Util class for Arrow vector creation.
Class to write an output in Arrow format in a zip file.
Abstract entity referencing an S3 object or part of an object.
Helper to run ITreeProcedure on the elements of a tree that have the same depth of a given node.
A SAX writer.
 
Simple border builder for non-UTF8 environment.
 
Abstract implementation of the base for a secondary index on records.
 
 
 
Base class for select execution.
 
Directed graph visitor running in sequential order.
Base class for all factories that create a service without any argument.
Base class for services with listeners.
Base class for sets.
Implementation of ISetCoverSolver.
A simple ICalculatedDrillthroughColumn that need only one field to be computed.
Channel factory for source that are simple, meaning they do not have a notion of index whatsoever.
Examples of such sources: KeyValueSource, POJO source, etc.
Contrary to AColumnarMessageChannelFactory which creates an EmptyCalculator if a field cannot be found in the source, the loading here will fail at runtime.
A simple ASingleFieldReAggregationFunction where the pre-aggregation is the same aggregation on the same field.
End point for all websockets.
A re-aggregation function on a single field.
A ASingleInputSqlAggregationFunction which does not support any type of vector.
Abstract aggregation function that only takes a single Database column (this column can still represent several SQL columns).
An aggregation function which only takes a single Database column (including native, multi-rows and multi-columns arrays).
Class representing a function definition that accepts one and only one optional argument.
Class representing a function definition that accepts a last optional argument in a form of a keyword.
An operation happening on a single query, for instance resolving it.
Single index result set reader.
A factory to create singleton instance, lazily initialized.
Also known as malloQ, this allocator is optimized for NUMA systems that supports huge pages.
Generic implementation for snapshot query.
Snapshot refresh task.
IAsOfEpoch implementation.
Context value translator for IAsOfEpoch.
Abstract class for a configuration that will create the server delivering static resources.
Object for configuring resources to serve and redirections to make.
Abstract SQL aggregation.
Abstract SQL aggregation function.
Abstract SQL flavor handling the aggregation functions.
Sql database.
 
Abstract immutable implementation of an ISqlField.
Abstract SQL flavor.
Abstract implementation of an SQL query runner.
Abstract generator of SELECT IExecutableQuery from SqlQuery.
Abstract version accessor for SQL databases.
Abstract class that should be preferred when implementing an IStatisticAttribute.
Abstract base for JsonDeserializer for Memory statistics.
A post processor that runs, for each location it is evaluated at, a get-by-key query on the database using the dictionarized coordinates of the location.
Abstract store message, the basis for messages that are sent into the datastore.
Base class to implement message channels.
Abstract message channel factory IStoreMessageChannelFactory for channels that convey data towards a datastore.
Topic - Store pair used as a key to identify channels and their configuration elements.
Implementation of IStorePartitionWorkUnit for work units containing records, either adding them or removing them.
Generic implementation for IStorePartitionWorkUnit with the mechanism to manage the read-only logic of the work unit, see AStorePartitionWorkUnit.markReadOnly() and AStorePartitionWorkUnit.consume(Object, IStorePartitionWorkUnit.WorkType).
A stream listening to a given store.
Abstract implementation of every IStream class.
Stream agent.
The stream to position converts a stream aggregated measures to a position based on a configurable time axis.
Abstract implementation of IStreamInfo.
A basic implementation of stream listener.
Abstract class helping the implementations of IStreamNode.
Abstract class helping the implementations of IStreamNode for continuousQueries.
Register to manage IStream in IStreamNode.
Abstract implementation of a structural transaction.
Abstract implementation of ISubCubeDimension.
Base sub cube element.
Extension of IHierarchy adapting to the current state of the context to decide of its levels and members visibility.
Extension of ILevel adapting to the current state of the context to decide of its members visibility.
 
 
A vector pool that swaps its vectors on disk using MappedByteBuffer.
The pool responsible for allocating BufferDoubleVectorBlocks.
The pool responsible for allocating BufferFloatVectorBlocks.
The pool responsible for allocating BufferIntegerVectorBlocks.
The pool responsible for allocating BufferLongVectorBlocks.
An IAsyncAttachedQuery that is in fact executed synchronously.
Base class for Broadcast messages operating asynchronously.
Base implementation of an IContinuousCompositeSelection, over a given schema with the given view.
 
Builder for the table description.
 
A CancellableCountedCompleter for components that can collect tasks to bind on NUMA nodes, and then run them all.
Abstract class for parsers for Java 8 TemporalAccessor objects.
Abstract time bucketer, that organizes time buckets separated by their time boundary.
The boundary between two time buckets is expressed as a long integer, following the "java time in milliseconds" convention.
The static list of available time buckets are contributed with the createBucket(...) method.
Relative time bucket.
A TimePostprocessor builds its query evaluation by applying a logic along a time hierarchy.
 
Time travel information for system that have a table version based approach.
Base class of timing information about queries or updates, for monitoring purposes.
A completer that will record the time elapsed between this completer's creation and its completion.
A TIntIterator taking another iterator as underlying and filtering some values out of the ones returned by the underlying iterator.
Common implementation for TopCount, BottomCount, TopPercent, BottomPercent, TopSum, BottomSum.
Common implementation for TopCount, BottomCount, TopPercent, BottomPercent, TopSum, BottomSum.
Configuration properties for the Atoti Admin UI.
 
Use a preshared token that is encrypted for authentication purposes.
Automatically imports ContextValueManagerConfig.
CORS configuration of atoti.
Default CORS configuration of atoti.
This annotation is to be used to describe a plugin.
One will indicate for a class, that a value of this class (default constructor) is to be inserted in the plugin whose registry name is indicate by pluginName.
Autoconfiguration to set up the various filters used by Atoti Server's security.
Imports the SpreadsheetRestServiceController controller unless a similar controller is already loaded.
Autoconfiguration setting up JMX beans for the standard components.
Imports the JwtConfig unless a similar config is already loaded.
This annotation is to be used to describe a plugin.
One will indicate for a class, that a value of this class (default constructor) is to be inserted in the plugin whose registry name is indicate by pluginName.
Static configuration of the thread pools used in Atoti components.
A transaction pool and a query pool with similar configuration and NUMA bindings, so that they can be used for mixed-workload operations over the same data structures.
Root configuration class for all automatic configurations related the Atoti registry.
Extension of ResourceHandlerRegistration to encapsulate the creation of a mapping to resources.
Annotation to mark a class as a REST controller.
Automatically imports all configs for REST services.
Configuration properties for the Atoti security.
 
The page properties.
 
Configuration for the Atoti security utilities.
Record passing the common internal filters to security DSLs.
A base implementation of HumanToMachineSecurityDsl with opinionated defaults.
A base implementation of MachineToMachineSecurityDsl with opinionated defaults.
A base implementation of XmlaSecurityDsl with opinionated defaults.
Automatically creates every service that has not been instantiated manually.
Class containing logger names constants, as well as the loggers.
Automatically imports classes declaring system beans, like JMX beans.
Atoti fork/join worker thread, placed on a NUMA node.
Atoti Thread Pool.
AtotiType annotation.
Autoconfiguration installing the authentication flow for the Atoti UI in the underlying Spring application.
Automatically imports AtotiUiResourceServerConfig, and sets up a security rule to allow access to the necessary endpoints.
Utility class to configure the IContentService to work with Atoti UI.
Marker interface for a component providing the Spring resource containing the env.js file content for Atoti UI.
 
Spring configuration for Atoti web application.
Factory of Atoti threads.
Automatically imports all WS services.
Automatically imports ActivePivotXmlaConfig.
The basic abstract class for implementing a multiversion mechanism for a type of Object.
The abstract implementation of a IVersion using a mask for its content with regard to the base.
A immutable object that contains a version.
 
Common abstract parent of both initial and regular transactions' content.
Abstract base implementation of an ITransactionOperation.
Parent class for all implementations of ITransactionPublishingScheduler.
Deprecated, for removal: This API element is subject to removal in a future version.
Use the ATranslatorWithColumnCalculators class instead.
An abstract translator based on calculators.
Base class to implement procedures that use an underlying procedure.
A ITreeVisitor that can rewrite a part of the tree it visits.
Explicit implementation of the IAttachedQuery extended plugin.
Attribute token implementation.
 
Describes the data stored in Records.
Base class for tuples.
Class to perform recursive operation on tree.
Basic implementation of ITypedDto.
The audit stored in the database.
The audit stored in the database.
Implementation of a content service based on a Hibernate database.
Implementation of an IAuditAction for a Hibernate database.
The audit data access object.
The audit data transfer object.
A set which adds hierarchies to an underlying set.
A prefetcher that always retrieves the same underlying measures.
A visitor for traversing a IUndirectedTree without any context.
Abstract implementation of the base for a unique index on records.
Adapter used for record flattening during structural transaction.
Implementation of an IUniqueRecordIndexTransaction.
An IUpdateActionVisitor abstraction with helper methods to execute operations on the correct thread pool.
Parent class for actions that operate on a cube.
Abstract object that implements generic functions of POJO of IUpdateWhereInfo.
Abstract class to easily implement IUserDefinedAggregateFunction.
Abstract class to easily implement an IUserDefinedAggregateFunction that supports all aggregate providers.
Base class for implementing IUserDefinedAggregation classes.
 
A simple authentication configuration used to connect to a server protected by Authentication.
Basic implementation of IAuthenticatedExecutor.
Spring configuration defining the standard authentication compatible with Atoti UI 5.2+.
Properties configuring the authentication flow required by Atoti UI.
Unlike TuplePublisher, this implementation of the ITuplePublisher contract does NOT expect the third party code to control the transaction flow: this publisher always manages one transaction (from start to commit) per call to its publish method.
ITuplePublisher which changes the format of the tuples sent to the datastore if the schema of the datastore has changed since creation.
A Post-Processor that retrieves values computed by the underlying measure, at the queried location, shifted to one of the extrema members of the defined shifting level, and whether there are associated contributions in the underlying facts.
Base class for function definition with a variable number of arguments of a single type.
Abstract class defining a IUserDefinedAggregateFunction to calculate variance and standard deviation.The aggregation buffer in this class contains the values necessary to calculate the variance using either the population or the sample formulas.
Abstract class for all variance-related aggregation functions: STD and VAR (sample and population based).
Base implementation of a vector, that doesn't support any read or write operation.
Aggregation Binding specialized for IVector.
The base implementation of a vector allocator, that simply knows about the IAllocationSettings it needs to allocate vectors with.
Abstract implementation of a vector binding, ready to be extended by a specialized binding.
Abstract vector parser for vector fields.
Implementation of ILinkageStrategy.
Sql Aggregation for average.
Sql Aggregation for average of multi-columns vectors.
Base abstract implementation of a IVersion.
Abstract implementation of the version delegating all calls to an underlying instance of Version.
 
Light plugin value for the Average IAggregationFunction.
AVG History generic vector abstract implementation.
AVG History Double vector implementation.
AVG History Float vector implementation.
AVG History Long vector implementation.
AVG History Long vector implementation.
AVG History Number implementation.
A re-aggregation function for an AVG.
A virtual array is an abstract class which simplifies the implementation of post-evaluated columns.
Basic class for configuring a websocket engine.
Object for configuring mapping between a WebSocket handlers and the paths.
Abstract base for window reducers.
A query runner capable of handling timeouts.
Basic implementation of a process executor for classic actions requiring a workflow execution.
Base implementation of a Workflow service.
Base abstract implementation of a IWritableArray.
Abstract cell that is ready for typed specialization.
A ARecordBlock that is also writable.
Editable structure of a cube.
 
Implementation of a topic end point for feeds.
Abstract implementation of a websocket session multiplexer.
Basic implementation of default methods of an end point.
The axis data.
The axis data builder.
The axis data builder.
AxisDimension that holds IAxisHierarchy.
AxisDimensionDescription is the description class for the AxisDimensions.
The description for axis dimensions.
DTO representing an axis in the pivot table.
AxisHierarchy is the base implementation for all axis hierarchies.
A hierarchy which holds members from different epochs.
Factory for multi-versioned members for a given hierarchy.
The description for an AxisHierarchy.
Standard implementation of IAxisHierarchyExchanger.
Implementation of a IHierarchyTransaction.
A hierarchy version for axis hierarchies.
The axis level implementation.
AxisLevelDescription is the description class for the AxisLevel.
This class implements the IAxisMember interface.
An ActivePivot Member in the context of a cell set.
Standard implementation of IAxisMemberExchanger.
 
A position on a cell set axis (one or several members).
RangeProperty once the size of the axis is known, so that we can know the default values The only way it can be null is if the corresponding axis is not defined, therefore its length is 1.
Basic implementation of IAxisRanges.
 
Monitor for XMLA Servlet.
Object referencing an AppendBlobClient.
Implementation of AConcurrentlyFetchingChannel for Azure.
Object referencing a BlobClient, a non-specialized blob client that exposes generic operations.
Object referencing a BlockBlobClient.
Wrapper on an Azure Storage's directory.
 
Object referencing an EncryptedBlobClient.
Wrapper on an Azure Storage's directory.
Wrapper on Azure's BlobClientBase.
Object referencing a PageBlobClient.
 
Internal component converting a public Database into an internal Database.
An input stream buffer that relies on background tasks to consume data from an underlying stream concurrently with stream consumer operations.
A partition operation that retrieves all rows referencing a given holder.
Class exception for requests containing a value considered as invalid by the service.
 
Entry Point to define a database query ICondition.
 
Contains the code common to all IInternalCopperMeasure implementations.
Base class for the Copper measure factories.
Partial builder for all attributes contained in IMeasureMemberDescription.
The visitor that occurs in first place and sets up the underlying bases of multiversion components of the Datastore for the next visitor that will actually be able to apply the structural changes on prepared bases.
Multiple purpose, dynamic implementation of the IProperty contract.
Builds a ASingleResultSetReader from a jdbc index.
The object holding information about versioned object's bases before and after the structural transaction.
The visitor that occurs in second position and applies cross-version structural changes to the underlying bases of multi-version components of the Datastore, previously prepared by the first visitor.
 
Single column vector reader provider.
Basic implementation of IApplicationDictionaryProvider.
The cell plan executor is responsible for actually executing the calculations.
Basic condition Factory for Equal, Lesser, LesserOrEqual, Greater, GreaterOrEqual.
Base class for creating/updating sessions execution.
 
Base class for creating sessions execution.
Basic repository of ActivePivot roles.
Json column calculator for basic types (primitive types and their wrapping classes).
Wrapper of BasicPathlessContentEntry adding annotations to be able to serialize as JSON.
Class representing a MDX formula used as a property of an KPI.
This class is used in order to display an bean through JMX.
 
Non filtered axis.
Continuous handler associated with one measure (aggregated measure or post processed measure).
A basic message to send to one or more recipients, that did not expect any answer.
Implementation of IMessageBuilder producing BasicMessages.
Simple implementation of BasicPathlessContentEntry.
Default implementation of a basic post processor, that delegates location evaluation to an IEvaluator.
An executor which evaluate ISelectStatement and returns MdxCellSet.
Basic implementation of CopperStoreField.
A collection of data that handle concurrent add.
Accumulate a batch of rows to process and process the batch when it is full.
Utility class that compiles bean properties on the fly using the Javassist byte code library.
An IRecordFlattener that can flatten a record and the elements it references before having added it to the datastore.
This can walk a ITree following a Breadth-first search approach, showing around an ITreeVisitor the traversed nodes.
Represents an operation that accepts two int-valued argument and returns no result.
Extension of default Java predicate to support Int predicates with two values.
Binary operator whose inputs and outputs are numerical: they contain either scalars or vectors.
BinaryNumericalFunction whose inputs are a scalar and a vector, and whose output is a IVector.
BinaryNumericalFunction whose inputs and outputs are scalars.
BinaryNumericalFunction whose inputs are a vector and a scalar, and whose output is a IVector.
BinaryNumericalFunction whose inputs and outputs are IVector.
Implementation of the BinXml response marshaller.
XML related constants.
A SAX writer.
A bin xml handler.
A binXML SAX writer.
Utils class.
Utility class translating between integer and a multi-byte representation.
Simple implementation of a bitmap, without any compression.
Aggregate storage using bitmap indexes to optimize query executions.
Only the leaf aggregates are materialized, the higher level aggregates are computed on the fly with the help of the bitmap index.
Leafs are also indexed exactly with a dictionary whose keys are the explicit locations of the leafs.
A AIndexedAggregateProviderTransaction specialized for the BITMAP aggregate provider.
This class provides helper methods to check the validity of bitmap operations.
Specify the level of checks.
Specialization of ABitmapAggregateCollector for the contributions.
A procedure used to expand a given location using the current hierarchies and the points stored in a BITMAP aggregates collector.
A filter visitor that can compile an ICubeFilter into a IBitmap.
A helper class construct an BitmapMatcherBuilder.IBitmapMatcher in an optimized fashion.
A pattern that can be matched against its underlying bitmap index.
An implementation of AIndexedPartitionedAggregateProviderTransaction.AIndexedCompiledFilter for the Bitmap Aggregate Provider, associated with the BitmapFilterCompiler class.
A primitive retrieval that is executed on a single provider partition.
Specialization of ABitmapAggregateCollector for the removals.
Collection of methods for bitwise operations.
Utility class on Azure Storage.
ABlockAllocator on direct memory.
Does implement IBlockAllocator but it delegate all its call to a IBlockAllocator within a list of IBlockAllocator it manages.
A cursor over a boolean array with specialized methods.
Wrapper for an Arrow Vector of Boolean.
Implementation of a read-write cell supporting data of type boolean.
Type representing a boolean field.
 
 
Condition tree visitor simplifying the TRUE and FALSE leaves.
A boolean operator.
Boolean operators implementations.
 
 
 
Parser for boolean fields.
 
Special parser for vectors of doubles.
 
 
 
An action to be executed on some data that can be divided into ranges.
Inner exception class grouping multiple exceptions encountered while executing the BoundedAction inside the suppressed exception list.
A helper Object that creates sub-tasks used for processing a range of the data.
An task to be executed on some data that can be divided into ranges.
A helper Object that creates sub-tasks used for processing a range of the data.
Braces.
IBranch implementation.
Simple implementation of IBranchCreationDescription.
Simple implementation of IBranchDescription.
Immutable implementation of IBranchInfo.
A simple implementation of IBranchPermissions with only two fields: the set of owners and the set of readers of the given branch.
Simple implementation of the IBranchPermissionsManager, with a map associating a BranchPermissions to each branch name.
Utility class to print the relationships between branches.
Utility class for helper methods related to branches, subcubes and permissions.
The base implementation of an IBroadcastResult.
Introduces static methods to define copper measures that are specific to FPinvalid input: '&A' projects.
 
Pojo class representing a path of a hierarchy member.
A dictionary of fixed length points, that can be stored off-heap.
The procedure for N to 1 bucketing.
Plugin factory.
Utility class for Amazon S3's buckets.
Utility class on Google Storage buckets.
Allocate chunks that store their data in buffers.
A chunk of bit primitives.
Chunk to store primitive boolean values that can be null.
A chunk of double primitives, stored in a buffer.
Chunk to store primitive double values that can be null.
A chunk that contains float primitives, stored in a buffer.
Chunk to store primitive float values that can be null.
A chunk that contains long primitives stored in a direct memory buffer.
Chunk to store primitive long values that can be null.
A chunk storing primitive integers.
A chunk of bit primitives.
A chunk of byte primitives.
A chunk of hexadecimal primitives.
A chunk of int primitives, stored in a direct memory buffer.
Chunk to store primitive int values that can be null.
A chunk of 2 bits primitives.
A chunk of short primitives.
A chunk of three byte primitives.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an ABufferVectorBlock based on DoubleBuffer.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an ABufferVectorBlock based on FloatBuffer.
A dictionary of integers that stores its data in buffers (so that there it can be off-heap).
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an ABufferVectorBlock based on IntBuffer.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of an ABufferVectorBlock based on LongBuffer.
Static methods for creating buffer allocators and buffer serialization.
Object packaging multiple events.
Explicit implementation of the IByteBufferConverter extended plugin.
Class that convert double arrays to or from ByteBuffers.
Class that convert float arrays to or from ByteBuffers.
Implementation of an InputStream pulling its data from a ByteBuffer.
Class that convert integer arrays to or from ByteBuffers.
Class that convert JsonNode objects to or from ByteBuffers.
Class that convert long arrays to or from ByteBuffers.
Implementation of an OutputStream writing its content to a ByteBuffer.
Class that convert a String to or from ByteBuffers.
ByteString.
Implementation of IAgentService keeping registered agents in a cache.
Cache layer on top of an IAlertService.
An AggregatesRetrievalCreator that creates retrievals which will look for aggregated values in the pivot's aggregates cache before actually trying to compute them.
The possible status of a ICachedAggregates retrieved from the cache for a given query.
A retrieval for the primitive aggregates that gets its result from the completion of a (unique) child retrieval.
Represents cached aggregates for a single location and a single measure.
Implementation of IBranchPermissionsManager which wraps another branch permissions manager, essentially delegating all methods to it, except for CachedBranchPermissionsManager.getBranchPermissions(String) which keeps previous calls in a cache.
A PpNode whose result is already available in the IAggregatesCache.
A PrimitiveAggregationNode whose result is already available in the IAggregatesCache.
A PrimitiveNode whose result is already available in the IAggregatesCache.
Instance that will automatically run all cached queries.
The interceptor that sets our global cache policy.
A class to accumulate and compute the aggregates that could not be found in the IAggregatesCache for one given scope.
 
CalculatedDrillthroughColumnDescription is the description class for a ICalculatedDrillthroughColumn.
Explicit implementation of the calculated drillthrough columns extended plugin.
CalculatedDrillthroughColumnSetDescription is the description class for a CalculatedDrillthroughColumnSet.
Explicit implementation of the calculated drillthrough column sets extended plugin.
A Copper measure representing the result of a calculation based on other Copper measures.
Factory for CalculatedMeasure.
ACopperTreeRewriter that can change the tree of a CalculatedMeasure that depends on others CalculatedMeasure or when one of its dependencies is a ContextValueMeasure or ConstantValueMeasure.
A new ICopperFunction created from the combination of other ICopperFunction.
A new ICopperOperator created from the combination of other operators.
Basic implementation of an ICalculatedMemberDescription.
An analysis hierarchy whose members are computed.
A type of command that can be found within an IExecute element, and that is used to cancel a query that is currently running.
Wrapper around a Broadcast message, to make it cancellable.
A BroadcastResult able to cancel its serialization if it takes too long.
A CountedCompleter that keeps record of the first exception thrown by its children or itself and propagate it back to its parent only when all children have finished.
A CancellableCountedCompleter that keeps track of all its pending tasks, in addition of keeping track of its parent task/completion action, like an ordinary CountedCompleter.
Basic implementation of a CountedCompleter performing an action as part of its execution.
A custom DataOutput that checks for interruption.
This is an implementation of an interruptible ForkJoinTask.
An IInterruptor that checks for cancellation and for timeout.
A cancellable RecursiveAction.
A cancellable RecursiveBoundedAction.
A cancellable RecursiveBoundedTask.
A cancellable RecursiveTask.
Contains all static utilities for cancellable tasks.
Drillthrough calculator returning a formatted caption of the value.
A partitioning over several fields, each associated with a partitioning functions.
Visitor to check if a partitioning by Cartesian product is implied by another partitioning.
Visitor to retrieve the partition id of a partitioning by Cartesian product, knowing the id of the partition of another partitioning by which the partitioning by Cartesian product partitioning is implied.
Visitor to retrieve the partition ids of a partitioning by Cartesian product, knowing the id of the partition of another partitioning which is the reduced partitioning of the partitioning by Cartesian product.
Implementation of AGreatestCommonPartitioningCalculator for this partitioning.
A values supplier that computes a Cartesian product of all values produced by its underlying IDistinctValuesSupplier.
 
Plugin implementation for storing plugin values and their case insensitive counter values.
This class implements the ICatalog interface.
Definition of a catalog in the structure of a manager.
This class implements the ICatalogDescription interface.
Catalog Discovery for SOAP webservices.
The catalog discovery.
The catalog discovery.
A ACatchUpListener that runs one FastForward and then delta queries, to catch up with the current state.
A ACatchUpListener that runs a delta query while it is not up-to-date with the stores it listens to.
Cell tester matching a cell by its coordinates.
The cell data.
The cell data builder.
DTO representing a cell of a MDX cellset.
An iterator for CellDTO based on a cellSet DTO.
Cell event implementation.
The cell plan is a component through which planning flows.
 
Stores a list of columns along with a dictionary whose keys are the column indexes.
Wraps a column with a lock, to provide the ability to perform thread-safe accesses to it.
Base class for cell plan execution tasks.
Base class for Aggregate tasks (they should only contain aggregate formulas or none).
CellPlan's task visitor.
A task which evaluates a named set.
Tuple execution tasks.
Captures dependencies from mdx engine to ActivePivot.
Storage for cell plan execution result.
Interface for CellPlanResult's cursors.
Iterator on a cell plan result.
Interface for cursor based on an axis driven traversal of the result.
Interface for writer.
Write callback.
Header for cell plan execution results.
Helper for cell plan execution results.
A complete cell set, with axis and cells.
CellSet event implementation.
This class may be used for printing CellSetDTO.
Basic implementation of a ICellSetNotificationEvent.
 
The iterator to visit the axes stores in a CellSetState, used to build CellSetDTO from a CellSetState.
Class responsible for computing an update of a MDX cellset based on the received changes.
A cell set including the result and its subsequent query plans.
Responsible of following Cell updates across multiple CellSets, even if their ordinal changed.
Class representing a table cell with content displayed at the center of the cell.
Change description to describe updates that happened in the external database.
 
 
Internal equivalent to ChangeType API.
 
The task of parsing a channel.
 
Simple bean to build a SubSequence around a char[].
List of special chars recognized by the CSV source.
ChildPrefetcher aims at prefetching the children of a location along a given hierarchy.
 
A AChristmasDictionary that can handle any kinds of Objects.
A AChristmasDictionary specialized for storing String keys.
A AChristmasDictionary specialized for storing primitive double values.
A AChristmasDictionary specialized for storing primitive float values.
A AChristmasDictionary specialized for storing primitive int values.
A AChristmasDictionary specialized for storing primitive long keys.
Holds the ChristmasDictionaryResizeAction.RehashActions that will initialize the ChristmasDictionaryResizeAction.resizedDictionary.
 
Atoti stores the in-memory data in chunks.
A table with columnar layout, the columns are chunks.
A dynamic compiler of chunk bindings that uses the javassist byte code generation library.
A chunk implementation for the purpose of performing user-defined aggregations.
Sparse implementation if IChunkComposite.
Custom implementations of the IChunk.compress(IRowMapping, int[], int, IChunkFactory) method for the classes that do not rely on the default method.
Implementation of a cell on top of an underlying IChunk.
A chunk of dictionarized values.
A simple chunked bitmap with ordered read and write operations.
A generic AChunkedColumn.
An AIntegerArray that stores its values in a ColumnInteger.
An ALongArray that stores its values in a ColumnLong.
A custom implementation of OutputStream that writes data in chunks using a ByteBuffer.
 
Default implementation of an IChunkFactory.
A chunk that contains aggregate histories.
History for SparseChunk.
A listener interface for handling chunks of data written to a ChunkedOutputStream.
A special chunk implementation that holds data elements that can be marked with a boolean flag.
A special implementation of a ChunkMarked to hold vectors.
A chunk that contains objects.
A chunk of integers that offset all the values of the underlying chunk.
A chunk of longs that offset all the values of the underlying chunk.
A record reader backed up by chunks for storing the data.
An object used for writing a record into a ChunkSet.
Global (singleton-based) chunk allocator.
Base class to implement IChunkSet.
Data structure holding the configuration for a new column to create.
Data structure holding the configuration for a column to transform.
Binding between two compatible chunk sets.
Efficient reader to data stored in the chunks of a chunk-set.
A record block using a ChunkSet structure, used to fire records to the datastore's listeners.
A view on a record at a given row in a ChunkSet.
Custom class for statistics on an com.qfs.store.IChunkSet.
Builder for the special class of ChunkStatistic.
A chunk where each position contains the same boolean value.
A chunk where each position contains the same double value.
A chunk where each position contains the same float value.
A chunk where each position contains the same int value.
A chunk where each position contains the same long value.
A chunk where each position contains the same K value.
A chunk whose each slot contains a constant time stamp.
A chunk where each position contains the same IVector value.
Registry contributor for the chunks module.
 
Builder for the special class of ChunkStatistic.
The base implementation for a chunk that is able to store vectors.
CircularBuffer is a First In First Out queue which only keeps its most recent elements.
Helper that maps classes to objects, providing ClassMap.get(Class) and ClassMap.put(Class, Object) removing the "unchecked" warnings.
ClasspathContributionProvider.
A set of utility methods for classes.
C Library constants, retrieved from mman.h files for libc.so.6.
 
A wrapper for closed Atoti web socket session.
This class is used by the ACloudCsvTopic to specify the cloud platform and configure how the entity is downloaded.
Factory to use with implementations of ACloudCsvTopic to retrieve objects from a cloud storage.
Autocloseable Executor service for JDK17 compatibility.
 
Implementation of IDataExportService that save the result in a cloud storage.
Topic based on the content of an ICloudDirectory.
Topic based on the content of a remote entity.
Configuration to download files from the cloud.
 
Base class to store cloud file information.
Topic based on the content of several remote entity files.
Implementation of ICluster.
Base class for IClusterDefinition.
Index elements referring to cluster members.
Represents a pair of Clusters and the distance separating them.
A ILocalityIdentifier that supports several applications.
A ILocalityIdentifierFactory that works with branches to support what-it simulations and query the right cube data nodes i.e.
Event fired when a cluster member is notified about a view change.
An Object holding all the location translator factories for the data cubes in the cluster.
Default implementation of IClusterView.
Event triggered by a cluster view change.
 
Utility class for Collections.
Component to walk along the elements of a Collection with a window frame defined by a CopperRange.
 
A directed acyclic graph implementation with colored node.
Interface of a factory.
Interface for ColoredDirectedAcyclicGraph visitor.
Generates a unique incremental name for a given column.
Models unique reference of a field in a SQL projection and the expression that must be used in the query.
Implementation for int[] dictionaries that store the arrays in columns.
An AColumnChunkSet of integer columns.
A set of records stored in chunks following a columnar layout.
Adapter used for record flattening during structural transaction.
Create the record sets in partitions for stores using a column
invalid reference
storage
.
Column implementation of an ARecordSetTransaction.
A AChunkedColumn specialized for boolean values.
The actual implementation of a IColumnCalculator.IColumnCalculationContext.
Transforms if possible IColumnConditionInternal to ICondition.
An AChunkedColumn specialized for int values.
A IRowMapping powered by a IChunkInteger.
An AChunkedColumn specialized for long values.
A AChunkReader used for sparse chunk sets that use ColumnIntegerRowMapping.
A AChunkedColumn specialized in storing positive int values.
Implementation of an row cursor over an array of IPositionalReader simulating a table.
A IPointList that simply wraps existing int columns.
Resolver wrapping several resolvers and picking the first which can resolve.
Generator of comments to be injected within the SQL query.
Continuous handler of events published on transactions on an isolated store.
A stream that fires an empty event when a transaction is committed on the associated database store.
Contains definition of columns that are common to different rowsets.
 
 
Compares two objects implementing the Comparable interface.
Aggregation function returning the maximum value of any comparable object.
Binding for the ComparableMaxFunction.
ComparatorDescription is the description class for the Comparator.
Base comparator extended plugin.
ComparatorOrderDescription is the special orders for the IComparatorPivot.
Compiled condition for conditions performing equality tests or comparisons.
Matcher testing the result of a comparison using Comparable.compareTo(Object).
Class holding various implementations of ComparisonFunctions.ComparisonFunction.
Function testing if two values are equal.
Function testing that the first provided value is greater than or equal to the second provided value.
Function testing that the first provided value is strictly greater than the second provided value.
Function testing that the first provided value is less than or equal to the second provided value.
Function testing that the first provided value is strictly less than the second provided value.
Function testing that two values are not equal.
Base class for comparison matching conditions.
A compiled property that is really a compiled property followed by a chained property.
Implementation of a IDatabaseRetrievalResult.ICompiledQuery for a database retrieval.
Helper class performing filter operations from an existing selection of matching rows.
Default implementation of ICompiledGetByKey.
Base abstract class for compiled properties.
Base class for all compiled queries.
Task to complete partitions not selected by the partitioning selector.
Task to create result cursor for a partition and call IPartitionedResultAcceptor.onResult(int, ICursor).
The compiled query plan.
Compiled operation performing a search on a search in one of the datastore stores.
Condition normalizer applying the complement law.
A top-level parent completer used to transform a CountedCompleter-style of continuation into a CompletionStage.
A CompletionStage specialized for handling exceptions in answers of IBroadcastMessage.
Exception thrown when receiving and processing the answers of a given IBroadcastMessage.
Class implementing a workflow process.
Implementation of ILinkageStrategy.
Helper based on CountedCompleters to execute tasks that can be divided into ranges.
ForkJoin tool to create a chain of CountedCompleter to execute operations requiring iteration loop such as for-loops or while-loop.
Collection of utility functions on CountedCompleter and its ActiveViam derivates.
Definition of a visitor for CancellableCountedCompleterWithChildren.
Basic implementation of a ICompletionSync.
Registry contributor listing all the default plugins of composer-core.
A composite transaction info specialized for remote transaction info.
A composite transaction info specialized for regular transaction info.
Resolves an aggregate query with multiple sub queries parts.
Decoration listener which notifies the wrapped listener of a transaction starting only (not of its closing).
Decoration listener which notifies the wrapped listener of everything except the first transaction starting.
Specific underlying listener able to translate underlying epoch to composite epoch.
Decoration listener that could switch from one listener to another listener.
Adapter for performing read/write operations on a line of a ChunkSet.
 
Custom distinct query builder for the Composite Database.
Wrapper which delegates everything to the underlying and knows the database ID.
Custom get-by-key query builder for the Composite Database.
 
Custom list-query builder for the Composite Database.
 
This implementation wraps an external database and a local database (datastore).
Custom feeding policy for an ICompositeDatabase.
Immutable description of a composite schema.
Composite version of an IDatabaseSchemaUpdater.
Database service for ICompositeDatabase.
 
Composite implementation of IInternalDataStreamer.
Composite implementation of IInternalDataStreamer.
Composite database's transaction manager for data changes in an external SQL database.
Resolves a list query on multiple sub queries.
Message channel composed of several message channels of the same family.
 
 
 
Composite implementation of an IRecompilableDistinctQuery.
Composite implementation of an IRecompilableGetByKeyQuery.
Composite implementation of an IRecompilableListQuery.
Implementation of the base of a secondary index when the indexed points are based on multiple fields.
The base implementation of an ICompositeSelection.
This component resolved stream need from cube attributes (hierarchies, providers...) and their source nature (external or local).
Composite statistics query runner delegating the calls to the corresponding underlying database.
Message channel composed of several message channels of the same family.
Composite streaming transaction to perform atomically several single transactions.
Composite implementation of an IStreamListenerRegistration.
Composite implementation of an AStructuralSchemaTransaction.
Information links to Composite transaction.
Composite lock to manage datastore and external database synchronization.
Implementation of the base for a unique index when the indexed points are made of several fields.
A UserDetailsService which can retrieve users from several UserDetailsServices.
Version accessor of a ICompositeDatabase.
Composite Sax writer.
A group of indentifiers.
The compression output stream.
Statistics about compressed data.
Defines the computation intensity of an IHealthCheck, including all resources (CPU, memory, IO, ...).
Class defining all information required for a query with named parameters to be run.
Class defining all information required for a query with positional parameters to be run.
Helper methods to create concurrency constructs and run concurrent tasks.
 
Thread-Safe implementation of IConcurrentDirectedGraph.
Class tracking usages of objects based on their object identity.
A concurrent, thread-safe stack data structure.
The base implementation of a stack's node.
The interface that represents an element that can be stored in this stack.
A stack that accepts an element only if the element is not already in the stack i.e if two concurrent calls try to insert the same element in the stack, only one will succeed.
Responsible for creating the ICompiledCondition from the ICondition.
Some utility functions used by ConditionCompiler.
A cursor evaluating at iteration time a condition on the records it flattens before sending the record to the users.
ICursorFactory in use when there are condition to evaluate on cursor iteration.
Runtime exception throws when the evaluation of a condition fails.
Factory for all IColumnCondition.
Plugin for factories of conditions.
A node of a ConditionTree.
 
Split an ICondition over multiple stores into ICondition for each store, and an ICondition over the flattened record to be lazily evaluated on the cursor.
A visitor made for ConditionPerLevelExtractor.extractConditionPerLevel(IActivePivot, Collection, ICubeFilter) extracting} conditions contained in a filter for several hierarchies.
Operation scanning a whole store to find rows matching a series of conditions.
A record set scanning procedure that will collect all the rows matching the condition.
Helper to create JsonNode from a condition written as a map.
A tree representation of an ICondition.
Utility methods for ConditionTree.
Utilities for conditions.
A ConditionUtils.IConditionMerger to merge conditions with ImplementationCode.AND relation.
The condition merge, capable of merging the conditions according to a given relation ( AND or OR).
A ConditionUtils.IConditionMerger to merge conditions with ImplementationCode.OR relation.
Exception thrown when the configuration of the datastore is incorrect and code execution cannot continue while this configuration is not changed.
The configuration rest service.
Implementations of the IConfigurationService interface.
Implementation of a IAggregatesContinuousQueryEngine conflating events and recomputing the locations impacted by the events.
Implementation of an AAggregatesContinuousQueryEngine.IEventPolicy conflating received events to reduce the amounts of updated computed.
An AAggregatesContinuousQueryEngine that asynchronously conflates and processes its received events.
The default ConflationEventEngine.IConflatedEventProcessingListener that simply logs the provided timings.
Listener that allows logging the time spent in the conflation queue and in the event processing.
Definition of consumers for conflated events produced this engine.
Class exception for a call that conflicts with the current state of the resource.
Class providing connector implementation of thread pools.
Special operand marking the operand as constant in the query.
Constant column calculator that returns a constant.
Implementation of IConstantCondition.
Utilities to compare a constant condition with another.
ICopperFunction that returns a constant value.
Description of a function that produces a constant.
A leaf node of a ConditionTree that holds a constant condition.
A logging policy logging all messages in the same level.
Constant partitioning that attributes any record to partition 0.
Visitor to check if a constant partitioning is implied by another partitioning.
Visitor to retrieve the partition id of a constant partitioning, knowing the id of the partition of another partitioning by which the constant partitioning is implied.
Visitor to retrieve the partition ids of a constant partitioning, knowing the id of the partition of another partitioning which is the reduced partitioning of the constant partitioning.
Implementation of AGreatestCommonPartitioningCalculator for this partitioning.
Description of a constant partitioning, i.e.
Gathers all constants used in distributed component's descriptions.
 
SQL provider which can simply return an SQL string without any prepared param.
ACopperTreeRewriter that can change the tree of a StoreLookupMeasure that depends only on ConstantValueMeasure orContextValueMeasure as dependencies.
Copper measure representing a constant value.
Factory for the ConstantValueMeasure.
A basic post-processor that always returns the same value.
Special implementation of the IProperty contract that returns a constant value property.
Utilities to generate generic SQL for validating data.
A filter only accepting tuples that are contained in some set.
A record set scanning procedure that will collect all the rows matching the condition.
A Type of action that can be performed during a content update.
An entry of the content service.
Holds the listeners to a Content Service.
String comparator specifically created for stringified paths in the content server.
Configuration class exposing REST service for Content Service.
Implementation of content service notification manager as a web socket client.
The server side of notification service using web socket.
WebSocket content server configuration.
Autoconfiguration of the content service.
A IBranchPermissionsManager using an underlying content service to store the permissions.
Implementation of IContentListener which notifies the ContentServiceBranchPermissionsManager whenever a permission was created, updated or deleted in the content server.
Builder to create a IBranchPermissionsManager using an underlying content service to store the permissions.
Class holding a series of helper methods to create instances of Content Services.
Configuration of the content service.
Utility class for the content service configuration.
Content service locking strategy based on database locks, thus able to handle concurrency when content services are in different processes.
Util class containing helper methods to navigate the content service.
Initialize the cube formatters with the supported locale defined in the Content service.
Helper class containing the various error message patterns used throughout the Content Service.
Properties of the content service.
Pivot integration property.
Cache-related properties.
Roles-related properties.
Remote content service properties.
Properties for various UI integration.
Content service locking strategy based on a ReadWriteLock.
Configuration importing REST services based on Content Service instances.
Class defining information about REST services related to the Content Service.
Utility class used to export and import a sub-tree of the Content Server.
The content service type - embedded or remote.
A wrapper class to enable tracing in the content service.
Configuration importing WS services based on Content Service instances.
Base implementation of the IContentTree interface.
 
A basic representation of types, simpler than a data class.
An update on an entry of the content server.
This is the implementation of the IContext interface.
Implementation of expression dependency and helper methods.
 
A crossed-stream monitor on a context group.
A monitor to regroup context group monitors under a query engine.
A crossed-stream statistics collector for a context group.
Helps maintaining the activepivot and mdx contexts when working with multiple threads.
Context node that links a query execution context with a parent stream node and all the continuous queries that are registered for that stream and that execution context.
This monitor regroup all monitors for context nodes under a stream node.
A statistics collector for a context node under a stream node.
An immutable snapshot of a Context.
A wrapper to deserialize context values with imports.
A contextual version of a BoundedAction using CancellableCountedCompleters.
An action to be executed asynchronously on some data that can be divided into ranges.
Specialization of a CancellableCountedCompleter when a context has to be propagated to the forked completers that are eventually run on another thread.
Specialization of CancellableForkJoinTask when a context has to be propagated to the task eventually forked on another thread.
A cancellable RecursiveAction that automatically inherits the context of its parent task.
A contextual and cancellable RecursiveBoundedAction.
A contextual and cancellable RecursiveBoundedTask.
A cancellable RecursiveTask that automatically inherits the context of its parent task.
Utility class for the Copper context.
Helper methods for IContext instances.
Default implementation of the context value adapter.
Translator adaptor.
Exposes the available translators.
Default factory for ContextValueDescription.
Default factory for IContextValueDescriptionCreator.
Possible context values in a JsonDiscovery.
A servlet filter in charge of propagating the context values into the underlying ActivePivot Manager instances.
ICopperFunction that returns the value of context.
Default implementation for IContextValueManager.
 
Class to use as key for context values in ContextValueManager.
A measure containing the context values of a given type.
Factory for the ContextValueMeasure.
Context value merger.
Context value metadata service.
A basic post-processor that returns the context value of a given type in the evaluation phase.
Core implementation of IContextValuePropagator.
Context value request.
The description for context values.
Thrown when a context value cannot be converted from or to its flat representation.
Context value translator plugin, contains the plugin values that are available by default.
A set of utility methods for context value translators.
Timing for a continuous GetAggregatesQuery.
Timing for continuous mdx query.
Explicit implementation of the IContinuousQuery extended plugin.
Embedding of continuous query handlers parameters.
Continuous query manager.
Constants and helper methods for generating statistics report and statistics calculation.
Monitor for continuous GAQ for a specific stream.
Implementation of AContinuousQueryMonitorsGrouper to regroup continuous GAQ monitor under a context node.
A statistics collector for a continuous GetAggregates query under a context node.
Registry keeping track of the registered continuous queries, along with their stream and handler dependencies.
Standard continuous query update.
Continuous query update bound to a particular branch represented by a version of ActivePivot and which contains the other heads.
Implementation of an IContinuousSelection that wraps an IContinuousCompositeSelection.
The component in charge of dealing with the subscription to the parameter store.
 
 
Contribution.
Exception that marks the inability of an object to be inserted into the pivot.
ContributionProvider.
ContributionProviderChain.
Contributors count measure member.
 
 
 
 
 
 
 
 
 
 
 
 
Helper class to convert values.
Utility class creating converters from internal MDX results to DTOs.
 
 
 
Utility class for common operations done in IConverter.
The expressed coordinates implementation of @Link ICoordinates.
The Serializable version of @Link Coordinates.
The format of an aggregate point coordinates.
Hibernate Type to persist Coordinate object as string.
Some utilities for the coordinates.
Starting point to describe calculations and then build measures and hierarchies performing the calculations in ActivePivot.
Copper measure representing an aggregated measure based on multiple source fields.
Configuration interface for Copper analytic functions.
Enum used to decide how the filters must be handled by the measure.
A ICopperAggregationProcedure made for bucketing.
Bucketing copper hierarchy builder.
Plugin of factories to instantiate the ICopperContext.
General representation of elements in Copper, such as levels or measures that can be used to express calculations.
Internal representation of CopperMultipleElements.
Interface that represents a hierarchy that can be used in copper.
Internal representation of a CopperHierarchy.
Contains the additional information required to publish a hierarchy.
Flags for user-specified metadata.
ICopperFunction that reads the coordinates of the current member of a hierarchy.
Aggregation Procedure for Copper Joins.
A Copper Join Hierarchy.
Object that accumulates hierarchies that are ready to be published.
Builder used to create join hierarchy from a CopperStore.
Builder used to create join hierarchy from a CopperStoreField.
Copper representation of a cube level.
Component that allows to restrict the view to a cube by only granting specific members of one or several levels.
Level builder.
Internal representation of a CopperLevel.
Contains the additional information required to publish this level into a cube.
Flags for user-specified metadata.
Marker interface for shift operations.
ICopperFunction that reads the coordinates of a particular level.
Copper object representing the result of applying a lambda to a level's values.
Copper representation of an ActivePivot measure.
Copper object representing the combination of Copper measures.
A partially defined analytic measure.
Representation of a Copper measure on which CopperMeasure.per(CopperLevel...) has been called, defining leaf levels for a dynamic aggregation.
Copper object representing a measure on which to specify an aggregation function or no aggregation at all, to implement dynamic aggregation.
Copper representation of the combination of various Copper elements, such as measures and levels.
Specific interface for CopperMeasure representing a native measure such as IMeasureHierarchy.COUNT_ID.
Class that represents a node in a CopperTree.
Interface for representing a CopperMeasure which returns the value of its underlying measure for the parent member on the given hierarchy.
Interface for CopperMeasure representing a post processor.
Definition of a range [a, b], with both ends a and b included in the range.
Ensure all plugin values used by Copper are registered into the IRegistry.
Registry contributor for the copper module.
Internal representation of a Bucketing Hierarchy using InternalCopperLevelValues.
Copper representation of an isolated store joined to the cube.
Interface that represents the field of a CopperStore.
A store lookup is a post processor that runs a get-by-key query on the given store.
Marker interface that embraces the sub builders.
Builder for a store lookup, adding key fields associations.
Builder interface for a store look up that has mapped all key fields to a CopperElement and can combine the values of the selected fields together into the final value of the measure.
Copper measure used to perform switch operations.
The tree representing the measure dependencies of the measure for which the tree is built.
Configuration interface for measures which support setting an output type.
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
Common interfaces for the builders required to implements Copper.userDefinedAgg(String...) and Copper.userDefinedAgg(CopperMeasure...).
 
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
Interface for dynamic User-Defined Aggregate Function measure builder classes.
 
Interface for User-Defined Aggregate Function (UDAF)-based aggregated measure builder classes.
An IAggregationFunction that can only copy data from a column to another.
Copy binding for the 'boolean' data type.
Copy binding for the 'double' data type.
Copy binding for the 'float' data type.
Copy binding for the 'int' data type.
Copy binding for the 'long' data type.
Copy binding for plain Objects.
The copy binding for vectors.
Reads the result of the CopyMeasure.underlyingMeasure at the location specified by the source scope, and writes the result to all query locations that lie in the specified target scope.
Factory for the CopyMeasure.
An writable array that lazily create the record written to.
Reads the result of the underlying measure at the location obtained by shifting the query location on the members specified by CopyPostProcessor.sourceMemberPaths, and writes the result to all query locations that lie in the specified CopyPostProcessor.targetScope.
Factory for UpdateWheres that copy the value from a field to another.
 
 
Counted object in observability.
Counter monitor that supports counting for multiple keys.
COUNT(field) returns the number of rows with non-null values for the given field.
COUNT(field) for a multi-columns vectors.
COUNT(field) for a multi-columns vectors.
 
Plugin value for the Count aggregation function, basically a renamed SUM function that considers every elementary contributions as +1.
Standard aggregation.
Count aggregation that must handle null source values.
Count binding.
Log handler that counts published messages by log level.
Basic implementation counting the number of times a name is generated and using this count as a suffix.
 
A counting procedure.
A re-aggregation function for a COUNT.
 
 
 
 
Statement for CREATE MEMBER or UPDATE MEMBER.
Statement for CREAT SET.
 
Creation context to be used when creating internal components.
Builder class for the CreationContext.
A crossed-context monitor for a IAggregatesContinuousHandler under a stream node.
Implementation of AContinuousHandlerMonitorsGrouper to regroup handler node monitors under a stream node.
 
Crossjoin set.
An entry for the HibernateContentService.
Some utilities methods used with a Content Server.
Error listing created when the content of file cannot be parsed due to a charset error.
A simple column calculator that directly parses a source data field.
This event notifies the end of the parsing of a file.
This event notifies of a full failure to parse a CSV file.
These events notify the progress of the parsing of a CSV file.
Class centralizing all the error listings caused by a specific file.
Error listing created when a vector has a different size than specified.
Notifies of the failure of parsing one line of a CSV file.
Example implementation of a Message Channel Factory.
Listing created when a line in the CSV file has fewer columns than expected.
Configuration for the CSV Parser.
Builder for the CsvParserConfiguration.
 
 
Info about the reading mode which is basically a tuple of three integers.
Error listing created when the content of a column cannot be parsed to the expected data type.
Implementation of the CSV Source, relies on nio, memory buffers and multi-threading to speed-up character decoding and object parsing.
Listener for changes on one file or one directory and its inner elements.
Builder to create a new ICsvSource.
Holds the default configuration of a CSV Source.
Builder for a CsvSourceConfiguration.
Deprecated, for removal: This API element is subject to removal in a future version.
Use ICsvSource.builder() to configure the source instead
Utility class for CsvSource metrics observability.
Log record formatter that log in a CSV file.
Listing created when the CSV file has more columns than expected.
Centralizes the parsing reports of all the files in a specific topic.
 
Catch-all listing encapsulating unidentifiable errors.
The base version of a cube.
Cube Discovery for SOAP webservices.
The cube discovery.
The cube discovery builder.
A promise for the data to be retrieved from the external database.
This implementation of ICubeFilter relies on a sub-cube to work.
Result of the intersection of a ICubeFilter with a ISubCubeProperties.
Translator for ICubeFilter.
Class containing static helper methods for the Cube Filter.
ICubeFormatter that uses a Map<String, Map<String, String>> as dictionaries.
 
Base implementation of ICubeFormatterFactory that loads the dictionaries from the Content Service.
Data object representing the metadata of the cube analyzed by a SmartAggregationEngine.
Description of a change to the structure of the cube.
The version of the cube object.
Factory for UpdateWhere that set the current date.
A custom function which returns the current epoch.
 
 
Visitor that extract from a 'range' tuple (i.e tuple that does not contain range locations) the location designated by it.
The function that extract the measure(s) from the current context.
 
 
Aggregator that transforms cursors into aggregate results.
An acceptor to convert cursors into point aggregate stores.
This class is used for collecting data from an ICursor.
Print content of the cursor.
Iterate on the elements of a cursor, following the java Iterator API, and presenting records through the IRecordReader interface.
Iterate on the elements of a cursor, following the java Iterator API, and presenting records as tuples.
An iterable cursor wrapper.
CustomComparator Default implementation of the ICustomComparator interface, also available as a light plugin value of the comparator plugin.
ICompiledCondition wrapping ICondition that are not instance of IBaseCondition.
A node of a ConditionTree that holds a condition which is not an instance of IBaseCondition.
 
This is the default class for custom member properties (when a member property is defined without a plugin key, this class will be chosen).
 
 
Describes a custom reader for a field.
The type of data read by the custom reader.
Class to read a double and transform it into the type T, based on the readerFunction.
Class to read an int and transform it into the type T, based on the readerFunction.
Class to read a long and transform it into the type T, based on the readerFunction.
Class to read an Object and transform it into the type T, based on the readerFunction.
This class stores the config for a custom type.
This class adds custom types (if any) to an existing SqlDataTable.
A planning graph visitor that detects cycles within the planning graph.
 
 
 
 
The class representing the local database.
Do not use this class as a shortcut to convert the internal database into a public IDatabase when you do not have access to the public database.
Implementation of IAlertService persisting all information inside a database.
An IFilterVisitor that can compile an ICubeFilter into a database condition.
Utility class used to print the content of a generic database.
Simple implementation of IDatabaseDiscovery.
Record implementation of the interface IDatabaseFieldDescription.
Field permissions for the database rest service.
Implementation of IDatabaseHelper based on an IDatabaseSchema.
Unique identifier for a database.
Basic immutable implementation of an IDatabaseJoinDescription.
Class containing logger names constants, as well as the loggers.
 
 
 
Copper Database measure builder.
Copper Database measure builder.
Copper Database measure builder.
Copper Database measure builder.
A combining function.
Helper class with methods assisting for the generation of database memory statistics.
Implementation of IMonitorService persisting all information inside a database.
Node representing a query on an external store of the datastore.
A post processor that access the database.
Request for prefetching data in the Database to complete aggregation retrievals.
Print content of a database version: tables.
Implementation of an ICompletionSync that will send observability metrics when the completion of the associated work is signaled.
Utilities for queries on databases.
Validator for database queries.
Exception thrown when a database query is not valid.
Helper methods to create Database listener registrations.
Configuration importing REST services based on Database instances.
Implementation of the REST API controller for an ActivePivot database.
Class defining information about Database REST services.
Configuration class exposing REST services for Database.
Implementation of the REST API controller for an ActivePivot database.
Implementation of the REST API controller for an ActivePivot database.
Database retrieval, outside the scope of an ActivePivot selection.
Database retrieval's DTO.
 
Basic implementation of IDatabaseRetrievalInfo.
Special class implementing a key to register an IDatabaseRetrieval when walking the execution graph.
Class holding the result of a datastore prefetch request.
Helper methods for common operations on IDatabaseSchema.
Helper object for the Copper context, containing additional information about the underlying database such as its selection and schema.
Class for storing prefetched results about a table metadata, used by the Json datatable service.
Builder creating metadata about a whole database.
Utilities to run statistics on database with a IStatisticsQueryRunner.
 
Pulls new version from database.
The monitor data cache stores the information related to the monitors.
ClusterDefinition for DATA cube.
 
Basic implementation of IDataCubeAdapter.
The data cube implementation of an ICopperContext.
Factory creating DataCubeContext.
Data cube implementation of an ICubeHelper.
Class used to update IMultiVersionDataActivePivot instances.
REST service to export or download mdx query.
Implementation of IDataExportService that save the result on the local file system.
Builder for the IDataExportService in the cloud or in local.
Timings for the DataExportService.
A custom InputStream that uses an underlying DataInput.
This class takes care when new members (of type IAddress.NodeType.QUERY join the cluster or/and when a new transaction is committed in a "data" cube.
DataMember function.
This class represents a data node in an ActivePivot cluster.
Implementation of IDataNodePriorityPolicy where the priority level of a node is equal to the product of the cardinalities of the distributing levels for this node.
Component associated to a data node and can tell if aggregates (locations + measures) can be computed on this instance.
The content of a data node seen by a query node.
A IEpochManager.IVersionLifecycleHandler to attach to a local pivot used in a distributed architecture.
Life cycle handler for data cubes.
Data size serialized in a trace tag.
Implementation of an IDatastore.
This object is used to update the bases of the different IMultiVersion components.
 
 
Base implementation of the datastore builder.
 
Utility class used to print the content of a datastore.
IDataContributor for the Datastore.
 
Datastore implementation of IDistinctQueryBuilder.IDistinctQueryRunner.
Datastore implementation of IGetByKeyQueryBuilder.IGetByKeyQueryRunner.
Datastore implementation of IListQueryBuilder.IListQueryRunner.
Datastore implementation of an IPreparedAggregateQuery.
Datastore implementation of an IInternalPreparedDistinctQuery.
Datastore implementation of an IInternalPreparedGetByKeyQuery.
Datastore implementation of an IInternalPreparedListQuery.
A DatabaseQueryCompleterWithObservability for the datastore, handling the closing of a span.
A helper class that contains static utility methods for running queries on a datastore.
A query results acceptor that can return a global (i.e.
Implementation for IDatastoreQueryMonitor.
Entry point for any query that can be run on the datastore.
A datastore query runner with acceptor to either run a ListQuery, a DistinctQuery or an AggregateQuery asynchronously on a datastore.
Keep timing (compilation and execution) for a datastore query.
Json Serializable representation of a selection field.
Datastore implementation of an IRecompilableAggregateQuery.
Datastore implementation of an IRecompilableDistinctQuery.
Datastore implementation of an IRecompilableGetByKeyQuery.
Datastore implementation of an IRecompilableListQuery.
Registry contributor for the datastore module.
Default implementation of IDatastoreRepositoryCache.
Default implementation of IDatastoreRepositoryCacheConfiguration.
Component responsible for holding the database retrieval results held in the ActivePivotAggregatesRetriever columns.
Multiversion schema implementation.
Default immutable implementation of IDatastoreSchemaDescription.
Basic implementation of IDatastoreSchemaDescriptionBuilder.
Utility class to make transformations on an IDatastoreSchemaDescription.
IDatastoreSchemaFactory relying on an IInternalDatastoreStructure to create the schema.
The schema metadata contains all the information that is independent of the data.
Basic implementation of IDatastoreSchemaQueryMetadata.
This class will execute the IStructureUpdatePlan for on IMultiVersionDatastoreSchema.
 
TransactionInformation over a schema.
Keep the transaction statistics on a store: the number of records added, updated and removed.
Component handling transactions over a datastore schema.
Editable implementation of an IDatastoreStructure.
Special implementation of IInternalDatastoreSchemaUpdater that caches the current schema.
Implementation of a single version of the Datastore Schema.
Full implementation of IDatabaseService on an IDatastore.
Direct implementation of a transaction on the structure.
Immutable representation of the datastore.
 
Utility methods related to the structure.
The event created when a datastore transaction is committed.
 
An exception thrown when something goes wrong with a transaction on the Datastore.
A query runner able to run a query in the current transaction.
A query runner able to run a query in the current transaction.
The event created when a datastore transaction is started.
Object containing all the necessary information to execute an updateWhere call later on.
Basic implementation of IDatastoreVersion.
 
Identifier for a secondary index.
Identifier for a unique index.
Identifier for a partition.
Identifier for a concrete reference.
Identifier for a store.
Context used to allow a version to rewrite itself, specialized for the datastore, and accounting for deleted partitions.
Identifier for a partition in a store.
Basic immutable description of a table.
Basic immutable description of a table field.
Configuration class for the data validation of external tables in DirectQuery.
 
 
 
Form field to input a date.
Use method format(Object) to format a date object with the wanted pattern.
Parser for date fields.
DatePart function evaluates a date and return a specific interval of time.
 
 
Utility class to handle date/time objects.
Entity storing any information about the database.
Entity storing any information about the database.
DAO providing information about the application database.
DAO providing information about the application database.
Internal class handling operations on the PointValue table in a single transaction.
Http://technet.microsoft.com/en-us/library/ms126314.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126208.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126200.aspx.
 
Http://technet.microsoft.com/en-us/library/ms131488.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126299.aspx.
This is necessary for MSOLAP client.
As copied from http://msdn.microsoft.com/en-us/library/ms711251%28v=VS.85%29.aspx.
A SAX writer.
A SAX writer.
Decompression Implementation for the Nibble Algorithm.
Handles data and structural changes of local database.
This class is used to assign a standard behavior to the cell properties.
Simple implementation of ITransactionPublishingScheduler.
Default location interpreter.
The default member discovery.
The default member discovery builder.
 
A default memory statistic implementation.
 
An IPartitionedResultAcceptor that will accumulate the result from each partition without modifying it, and produce an ICursor that simply iterates over the various partition results.
Default pool factory.
Implementation of the Default Property Resolver that sequentially fetches property from the System Properties, then the Environment.
Default implementation of IRTImpactCalculator.
Resolve an aggregated query on a single multi row vector table.
Static class containing the default implementations for the SQL dialect methods.
 
Default implementation of workflow unit.
A queue specialized for executing deferred actions in the order they were submitted.
A RecursiveAction that will try to execute all the pending actions in a SingleConsumerQueue.
A procedure for batching the execution of multiple actions.
 
This context is used in data cubes to guarantee that the measures named by Copper have the same names in all the Data cubes whatever their order of publication.
Sets of helpers to work with definitions of ActivePivot components - hierarchies, measures, comparators, etc.
Implementation of an IActivePivotManager that delegates all its calls to an underlying one.
A member property base on another one with the ability to change the hierarchy or the level.
Simple wrapper around SimpleCubeDescriptionBuilder to implement the step IHasAtLeastOneMeasure that cannot be directly implemented by SimpleCubeDescriptionBuilder because of conflicting generic types for ICanStartBuildingEpochDimension also needed by the IQueryCubeDescriptionBuilder.
Implementation of IOpenedTransaction delegating all writes to a full-fledged ITransactionManager.
Builder for a query cube description.
Structural updater based of an underlying transaction.
DTO notifying of a message being deleted.
Query the updates (records added, updated and deleted) from a version to another.
Internal annotation marking code as deprecated and to be removed in a future version.
Deprecated methods of the Database API.
 
Flag description.
 
Exception raised by invalid descriptions.
 
Class packaging the logic for grouping several columns under one InternalTableDescription representing a vector of values.
Basic implementation of a description managed with permissions.
This can walk a ITree following a Depth-first search approach, showing around an
invalid reference
IDfsTreeVisitor
the traversed nodes.
Automatically imports all configs for REST services.
Rest Service to run diagnostics (e.g.
A service called by the diagnostics REST controller to retrieve information about the measures of a cube.
Reads an underlying record, encoding plain values into dictionary codes.
A post processor that runs, for each location it is evaluated at, a get-by-key query on the database using the dictionarized coordinates of the location.
An IAsyncCompositeSelectionListener that undictionarize its input records.
Wraps a cursor of dictionarized values and transparently decodes fields with dictionaries when necessary.
Decorates an IRecordBlock to undictionarize it.
Adapter class returning the plain values from the content of a ITableCursor containing dictionary-encoded values.
An IFilterVisitor that takes care of dictionarizing the discriminators of the underlying visit.
Default implementation of an append only dictionary.
Record containing the information required to provide to an IDictionaryFactory in order to create a specific dictionary instance.
Operand holder for a IConstantCondition on a field dictionarized, when operand is NOT a set.
Operand holder for an IConstantCondition on a field dictionarized, when operand is a set.
Operand holder for a IDynamicCondition on a field dictionarized, when operand is NOT a set.
Operand holder for an IDynamicCondition on a field dictionarized, when operand is a set.
Implementation of IDictionaryFactory.
Identifier for a dictionary.
A factory responsible for creating a dictionary on a single field, for a given partition.
Get the dictionary of the field from an array of dictionaries.
Get the dictionary of the field from a selection.
AArrayCursorWithDefaultValue where the underlying IArrayCursor contains dictionarized values.
Proxy to read un-dictionarize values from an underlying (dictionarized) IArrayReader.
Proxy to write un-dictionarized values to an underlying (dictionarized) IWritableArray.
Proxy to write un-dictionarized values to an underlying (dictionarized) IWritableRecordBlock.
Utility class to resolve dictionaries.
Dictionary backed set.
Memory statistics specialized for dictionaries.
 
Computed impact of an action on a list of dictionary keys.
Domain dictionary utilities.
Utilities for dictionaries.
Express a difference between two sets of data where one of the two sets represents the new data and the other the old data.
Dimensionality.
Dimension Discovery for SOAP webservices.
The dimension discovery.
The discovery dimension builder.
 
The identifier of a dimension in a cube.
Default implementation of IDimensionInfo.
 
The Dimensions.Count MDX function.
 
Dimension factory for ActivePivot.
 
Converts a dimension to hierarchy.
DimensionVersion is version of the dimension.
Allocator of direct buffers (allocated in the direct memory pool).
Allocates chunks that store their data in buffers.
A buffer pool providing DirectByteBuffer.
An implementation of ADirectChunkAllocator that uses Unsafe to allocate its memory.
A chunk of bit primitives.
A chunk of boolean primitives.
Chunk of booleans allocated in native memory, with support for null values.
A chunk of byte primitives.
Chunk of doubles allocated in native memory.
Chunk of doubles allocated in native memory, with support for null values.
Chunk of float primitive allocated in native memory.
Chunk of floats allocated in native memory, with support for null values.
A chunk of hexadecimal primitives.
Chunk of int primitive allocated in native memory.
Chunk of ints allocated in native memory, with support for null values.
Chunk of longs allocated in native memory.
Chunk of longs allocated in native memory, with support for null values.
Chunk of positive integers, where the internal chunks use native memory.
A chunk of 2 bits primitives.
A chunk of short primitives.
A chunk of three byte primitives.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of a direct vector chunk.
Implementation of a IDirectedGraph.
Responsible for letting an IDirectedGraphVisitor visit an IDirectedGraph following an order defined by the directed edges of the IDirectedGraph.
Base implementation of IDirectedMultiGraph.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of a direct vector chunk.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of a direct vector chunk.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Specialized implementation of an AVectorBinding.
Implementation of a direct vector chunk.
Utility class to track the direct memory used.
Topic based on the content of a directory.
The main DirectQuery class allowing to connect to the external database.
 
Utils class related to IDirectQueryBaseSettings.
 
The exception that is thrown when trying to access data that has already been discarded.
The exception that is thrown when trying to access an epoch that has already been discarded.
Http://technet.microsoft.com/en-us/library/ms126129.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126315.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126228.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126063.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126236.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126045.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126280.aspx.
 
Settings for the discovery of external tables in DirectQuery.
 
Implementation of Discovery.
Explicit implementation of the XMLA IDiscoveryHandler extended plugin.
The discovery rest service.
Plans disjoined index lookups to evaluate disjunctions of conjunctions all matching finite values on the fields of the same index.
 
Distinct count aggregation function.
Distinct count Aggregation function history.
 
 
Distinct count aggregation function that supports removal.
Distinct count Aggregation function history.
Utility for converting cursors to cursor with unique records.
 
A query to retrieve a distinct projection of fields from a base table IDataTable and its linked tables.
 
Distinct query ready to be run.
ActiveViam Function which returns a set of members with unique value based on the second argument.
Definition of a query cube in the structure of a manager.
An ActivePivotAggregatesRetriever on a distributed query node.
base for query node.
IActivePivotContext for QUERY cube.
 
The basic implementation of an IDistributedActivePivotInstanceDescription.
An ActivePivotVersion specialized for distributed cubes.
Explicit implementation of the IDistributedAgent extended plugin.
An empty aggregates provider that does not contain any data and cannot process any query.
 
A retrieval associated with an aggregate retrieval.
A distributed aggregates retrieval that will send a message to remote instances through a DistributedExecutionPlan.RetrieveAggregatesMessageAction to retrieve the requested aggregated values.
A post-processed retrieval that waits for its underlying distributed retrieval to be performed and extracts its requested aggregated values from it.
A hierarchy which hold members from different epochs and remote addresses.
Factory for multiversionned distributed members.
Class to use to merge multiple deltas into a single change.
A builder to create a new base.
Stores the data about a transaction in a IDistributedHierarchyTransaction.
A AxisHierarchyVersion specialized for distributed query cube.
Branch existing in the query node.
Distributed context value getter.
Continuous query manager for distribution.
IDataContributor for the distributed cubes.
Factory for the distributed ActivePivot.
The distributed drillthrough engine that listens to the pivot transactions.
IDrillthroughExecutor for QUERY (distributed cube).
The distributed drillthrough session.
Distributed implementation of IAdvancedEpochManager.
An ExecutionPlan for planning and executing distributed retrievals.
Action sending the message retrieving aggregates from an underlying data node.
A ForkJoinPool used for parallel and asynchronous message handling.
Core implementation of IDistributedHierarchyManager.
Object attached to a IDistributedHierarchyManager recording treatment informations regarding the messages received from remote instances (DATA cubes).
Implementation of a memory quantifier for ActivePivot hierarchy members.
Implementation of the measure hierarchy.
Base implementation of an IDistributedMeasureHierarchyTransaction for the query cubes.
The IMeasureHierarchyVersion for distributed query cubes.
A wrapper around another IMeasuresProvider that can handle distributed suffix when asking for a measure without it.
Set of utility methods to manage measures in a distributed application.
Utility class to create descriptions of distributed cube elements.
Util class/method for distributed messages.
Explicit implementation of the IDistributedMessenger plugin.
Statistics class for the distributed messenger.
Class to tack the number of messages received by remote peer addresses and by type of messages.
A place holder that contains an item of type T for an entry corresponding to a remote address instance and for a message type.
An aggregate provider holder for a distributed ActivePivot.
A "fake" partitioning that is only equals to itself.
Placeholder for distributed partitioning Manager.
Definition of an IActivePivot.
Distributed pivot metadata.
 
Distributed version of PlanningGraph, taking account distribution constraints.
Planner responsible for the part of the distributed query planning.
Planner responsible for the initial part of the distributed query planning.
Visitor that visit the distributed planning graph after it has been processed and look for incorrectly planned operations.
Distributed pool.
A PostProcessedMeasure that comes from a remote data cube.
Description
To be used only for DistributedPostProcessedMeasure only! This PostProcessorCreationContext returns a IMeasuresProvider that is able to handle measures with a distributed suffix.
A RangeAxisHierarchy specialized for distributed query cube.
Default implementation of IDistributedSecurityManager.
Extended plugin for IDistributedSecurityManager implementations.
A dedicated instance of IVersionHistory to be used in a query cube.
Distributed base for virtual hierarchies.
Predicate to test if a level is a distributing level.
Base implementation of IDistributionInformation.
 
A set of utility methods for managing Distributed Cubes.
Function class for the Divide() mdx function.
This definitions corresponds to the Divide(num, den [, alternateResult]) function of MDX.
The mdx divide operator /.
A post-processor that divides, for each point location at which it is evaluated, the underlying measure by the number of descendants under the evaluation location on the selected levels.
 
Http://technet.microsoft.com/en-us/library/ms126080.aspx.
 
Implementation for an IDomainDictionaryProvider which can be observed by multiple IDictionaryDomainObservers and notify them when a change occurs.
Dictionary transaction which encapsulates the domain key.
Class grouping a series of stream events to broadcast for a given domain.
Wrapper for an Arrow Vector of Double arrays.
A cursor over a double array with specialized methods.
An array reader wrapping several other readers to expose their content as a double array.
 
Wrapper for an Arrow Vector of Double.
Basic implementation for a double blocked vector.
Implementation of a read-write cell supporting data of type double.
Compares two Double objects.
Base class for translators of double context values.
Basic implementation for a double fixed block vector.
DoubleFormatter use method format(Object) to format double object to the value which you want.
 
Parser for double fields.
 
Special parser for vectors of doubles.
 
 
 
 
 
 
Attached query implementation of the IDrillthroughQuery.
Basic class for native a.k.a simple field from the database.
The drillthrough columns discovery.
The drillthrough columns discovery.
Continuous query implementation of the IDrillthroughQuery.
The drillthrough engine that registers to the continuous selection.
Extended plugin for IDrillthroughConverter.
Implementation of IDrillthroughEvent.
The drillthrough executor implementation IDrillthroughExecutor.
Component receiving the facts from the IDatabase and modify them to generate the drillthrough rows.
Class recording every name used, generating a suffixed label when the same value is provided.
Extended plugin for IDrillthroughExecutor.
Basic implementation of IDrillthroughHeader.
Serialization adapter for the drill through header interface.
DTO for the drillthrough headers.
Attached query implementation of the IDrillthroughHeadersQuery.
The message for retrieving headers.
Action computing the headers of a Drillthrough query.
Internal class to merge the results of a drillthrough query performed on several remote instances.
Implementation of the IDrillthroughHeadersQuery interface.
Monitor for location-based drill-through header query action.
Monitor for streaming of location-based drill-through headers query action.
Custom exception raised when too many rows are returned by a Drillthrough query.
Message exchanged during a Drillthrough query to retrieved headers.
Message containing the result of a drillthrough query.
Action performing a Drillthrough query retrieving headers and values.
When receiving the records, the acceptor - computes the post processed columns - converts into object all the dictionarized fields.
This class implements the IDrillthroughProperties interface.
The context value translator associated with the IDrillthroughProperties context value.
A DTO for a calculated column description.
 
A DTO for a calculated column set description.
 
Implementation of the IDrillthroughQuery interface.
Base implementation of IDrillthroughQueryContext that simply contains relevant objects that can be used by ICalculatedDrillthroughColumnSet to generate ICalculatedDrillthroughColumn.
Monitor for location-based drill-through query action.
Monitor for streaming of location-based drill-through query action.
The result of a drillthrough query, contains the rows to return, and the total count of rows that matched the drillthrough query.
This class implements the IDrillthroughRow interface.
DTO for a drillthrough row.
Default implementation for IDrillthroughResultDTOState.
The default drillthrough session when an underlying database is available.
Drillthrough.
Stream to handle drillthrough continuous queries.
Default implementation of IDrillthroughStreamNode.
Specialization of AStreamRegister for IDrillthroughStream.
A translator for drillthrough stream.
Drillthrough continuous query update.
Implementation of the drillthrough update event.
 
Max rows calculation result encapsulation.
 
Copper measure which uses the value of its underlying measure at the parent or top-level member for the specified hierarchies.
Factory for the DrillupMeasure.
 
A post-processor that goes "up" along one or several hierarchies to fetch the value of its underlying measure for parent (or higher level) members.
Responsible for dropping the partitions that:
Transaction content representing a partition drop.
A reader of IPartitionTransactionContent specialized in dropped partitions.
Statement for DROP operation.
Collection of helper methods about DTOs.
The "DUMMY" aggregate provider is used for tests purpose.
 
A dummy IInterruptor that can never be interrupted.
A dummy logger that log in console when there is a GET or EDIT query.
A basic record block based on a list of record reader.
Build a human-readable duplicate key within transaction message, from the human-readable details.
This class exposes various handlers.
Exception that happens when we try to add a post-processed measure with a name that already exists for another measure.
Implementation of IEventAlertAggregator that consider the during attribute of IMonitor to delay alert creation.
KPI formula implementation for the additional KPI member providing expiry information.
KPI formula implementation for the additional KPI member providing start information.
Formula to handle a KPI status with during time.
Formula implementation for the instant status.
The during task.
MBean implementation exposing various methods on a ActivePivotContentService.
This class is used in order to display an IActivePivotManager bean through JMX.
This class is used in order to display an IActivePivot bean through JMX.
This class is used in order to display an IActivePivotSchema bean through JMX.
Default implementation of a dynamic aggregation post processor, that delegates the evaluation of leaf locations to an IEvaluator.
Preview API for the Dynamic classification use-case.
 
An implementation of IBaseCondition whose operand is given at run time.
MBean exposing the internal attributes of a Content service.
This MBean represents the monitored components under a continuous query engine.
The MBean represents a continuous query engine through JMX.
A leaf node of a ConditionTree that holds a dynamic condition.
Multiple purpose, dynamic implementation of the IProperty contract.
The MBean represents a streaming service through JMX.
A AbstractUrlHandlerMapping that support registering URL handlers and interceptors after it is initialized.
Standard implementation of IEither.
Element token.
Element Object.
Starting point to create empty immutable collections.
An empty aggregate store.
Special column calculator that calculates no value and leaves the column empty.
An empty cell set.
An empty chunk that contains null when read, and cannot be written into.
An empty IClusterView.
Node representing the retrievals for Join Measures whose results are always null.
Class holding the result of a database prefetch request that did not match any record in the database.
An empty or "fake" IInitialDiscoveryMessage used to sent to a cube of query after a cube of data has left and joined again the cluster whereas nothing happened (no transaction).
An resettable iterator that has no elements.
Empty cell set.
Empty axis.
Empty axis iterator.
Node representing a retrieval whose results are always null.
Empty query plan DTO.
 
A query plan that consists of general information, the list of all the retrievals and their dependencies.
 
A cursor representing an empty result.
An empty set.
 
A vector of size 0.
Description of the emulated time-travel to be used.
Builder for creating a EmulatedTimeTravelDescription.
Description of the emulated time-travel for a given table.
Time travel information for systems that have an emulated time-travel.
Service retrieving the time travel information for databases using emulated time-travel.
Util class for emulated time-travel.
An encoding context.
Encoding token implementation.
EndAttributes token.
EndElement token.
Manages end of line detection with respect to a given charset decoder.
Provide statistics about the Websocket end point.
A mapped tuple enriched with additional key-value entries.
Default implementation of IPivotPointValue.
Utility class to build an IEntitlementsProvider.
Implementation of executor applied to entity workflow configuration.
Object representing a workflow configuration.
DTO encoding a parameter workflow configuration.
The alert data access object.
A list of (key,value) entries.
Exception throws when an entry is not found in a key-value database.
Converts an IJnaEnum to the corresponding native int, and the other way around.
A form field type with a range of specified values.
The Type mapper to add to the library to be able to use IJnaEnum as native method arguments and return type.
Property Resolver for Environment variables.
Tool class controlling the environment.
Implementation of IEpoch for the transaction log.
Sorts the epochs, from the oldest to the most recent.
Creates epochs in a natural order by incrementing an AtomicLong.
Implementation for IEpochDimensionDescription.
A formatter for epochs which uses IEpoch.getTimestamp() and IEpoch.getName().
Base implementation of IAdvancedEpochManager.
Basic implementation of IEpochMapper.
A set of utility methods for Epoch, VersionHistory.
A condition to test equality on a given value for a given column.
A condition to test equality on a given value for a given column.
A condition to test equality on a given object.
A condition to test equality on a given value for a given level.
Implementation of Erasure working with the JSON list of the sorted level names.
The list of Solaris error numbers.
Class representing a cell with errors.
Error function.
 
 
Error report containing the query and the keys of the rows with errors.
Helper class for methods on Errors and Exceptions.
Context used during evaluation.
Default implementation of a IEventAlertAggregator.
Cache for ISentinelEvent keeping only the relevant events making a monitor status.
The data transfer object for an event.
Implementation of executor applied to events.
Thread safe event duration statistics collector.
Extends the EventStatistics with the use of local thread variable to keep the starting timestamp.
A concurrent map with a LRU eviction policy.
Registry contributor for the Excel addin module.
Imports the SpreadsheetRestServiceController controller unless a similar controller is already loaded.
 
 
An interruptor implementation storing the underlying exception.
Specific Json serializer for exceptions, so that we know the exception type and we don't serialize all added fields in custom exceptions.
An MDX member to exclude via a cube filter without computing it.
A recursive action that exposes the ExecJoinAction.execJoin() method.
Query ready to be executed against a database supporting named parameters.
Query ready to be executed against a database supporting positional parameters.
Implementation of the execute request.
 
Flags that have a meaning before an operation (Top/down approach).
A IRetrievalGraphVisitor of the execution graph that builds the query plan and creates its retrievals.
A IRetrievalGraphVisitor of the execution graph that prints the query plan.
Default implementation of an IExecutionPlan, that holds the primitive and post-processed retrievals to execute for each partition.
The execution plan containing the compiled tasks to execute in order to run the datastore query.
IExecutionPlanBuilder to build parallel execution plan.
 
An IIterableAggregatesRetrievalResult that expands an underlying result by expanding its point locations along some levels and replicating their associated values.
Simple implementation of an IExpandLocationsResult.
Attached query implementation of the IExpandLocationsQuery.
Implementation of the IExpandLocationsQuery interface.
Class exposing experimental features in Copper.
List of the experimental properties used by this starter.
MDX function compute the exponential for any value.
Modified version of JGroups ExposedByteArrayOutputStream, which optimizes the write function to limit unnecessary transient array copies when the buffer gets large.
Defines how to "evaluate" an IExpression, for example to order members.
Abstract implementation of IExpressionExecutor which provide methods shared by plan and evaluation.
An IExpressionExecutor for the plan.
Parser for custom boolean fields.
An extension of GossipRouter.
Extension of the JNA Kernel32 interface.
ExtendedPlugin.
ExtendedPluginContribution.
Adds support for ExtendedPlugin injection of properties or services using the setters exposed on the ExtendedPlugin implementation class.
The injector can produce an instance of ITransfer that exposes the same setters than the target ExtendedPlugin, and that will transfer its state to all new instances of that ExtendedPlugin.
ExtendedPluginValueContribution.
External field description in a JDBC database.
Field type description in a JDBC database.
Internal description of an external table.
Identifies a table in an external database.
 
Identifies a table by its SqlTableId.
 
Identifies a table by a SQL expression.
 
Spring JavaConfig for additional beans to further log info of any custom ActivePivot server.
Copper measure used to calculate the argmax or argmin of a measure on a given level.
Factory for the ExtremaMemberMeasure.
Post processor that calculates the extrema member for a measure on a given level.
Structure to hold a collection of contributions efficiently.
Helper class to define filtering conditions.
Condition tree visitor performing factorization (inverse distributive law).
An SQL aggregation which is factorized on some fields.
Resolves query in an optimized way when we know how to factorize the aggregation functions.
Default implementation of the factory interface.
FactoryValue.
Failure event that signifies a failure in an underlying stream operation.
Column false condition.
Column false condition.
Implementation of a condition always returning false.
A ICompiledConditionInstance always evaluating to false.
Representing a False condition which always evaluates to false.
A leaf node of a ConditionTree representing a condition always evaluated to FALSE.
Level false condition.
A process that will publish an InitialPartitionTransactionContent to a listener.
Implementation of ITransactionContent specialized to fast forward the content of the store to new listeners.
Performance oriented implementation of a LocalDate parser, which does not use a DateTimeFormatter as opposed to the children classes of ATemporalParser.
Library of fast logical operations on bitmaps.
Feature flag utilities.
 
Exception thrown when a feature is not supported by the SQL Dialect.
A factory whose feeds will contribute to the hierarchies and the aggregate provider.
The base implementation of a fence that delegates all of its calls to a PhantomFence.
A ColumnarRecordSetTransaction managing the fencing.
An implementation of a ColumnarRecordSetVersion that fences access to its methods.
Fetch data from a data source and into several stores, using a channel factory.
Statistics about the loading of a Cloud resource.
A condition comparing, for a given record, the values of two of its attributes, using the condition's comparator.
Definition of a field of a store.
Default immutable implementation of IFieldDescription.
Immutable description of a field in a table.
 
Builder for specifying optional field properties.
Builder for the field description.
Builder for specifying the field external name and its nullability.
Builder for specifying the local field type.
Builder for specifying the field local name.
Basic POJO implementing IFieldDetails.
Definition of a dictionary used to dictionarize one or several fields.
Implementation of IApplicationDictionaryProvider.IDomainDictionaryKey for Field-related dictionaries.
 
Identifier for a field in a store.
Compiled operation testing the value of a single field by scanning a whole store.
Represent the relative path to a specific table field, starting from an arbitrary and unknown table.
Utilities to transform an ISqlField.
Basic implementation of IFieldTransformer.
Basic implementation of an IFieldType.
Simple builder for an IFieldType that prevents from most consistency errors.
 
Standard file watcher event.
Column calculator that returns the full name of the file currently being parsed.
This MessageHandler is dedicated to print out information about data parsing and translating file data source.
Log messages for source processing operations.
Column calculator that returns the last modified date of the file currently parsed.
Column calculator that returns the file name of the file currently being parsed.
Deprecated, for removal: This API element is subject to removal in a future version.
Use
invalid reference
CsvParserConfiguration#builder(int)
instead
Monitoring for file system CSV topics.
A factory to create file system CSV topics.
Base class to store file information when the file comes from a classical file system.
A utility class to help with the file system.
Task to process one file.
Helper class which adds a temporary cache to the LeafBitmapMatcher, to keep track of the compilation of similar filters for one query.
The JSON query filter data.
 
This class implements the IFilterDescription interface.
An IAggregateStore that is a filtered view of an underlying AggregateStore.
A list implementation that allows to access and manipulate only the elements of a given subtype of a list and reflect any change on the latter.
Filtered axis.
Iterator for filtered axis.
A parameter event filtering some resources based on listener needs.
A point list whose points are restricted to a selection of coordinates.
A filtered view of an underlying IRecordBlock that exposes a subset of its records.
Procedure reducing a result to a limited set of points matching the given filter.
 
A IAsyncCompositeSelectionListener that filters its input records and only forwards to its delegate listener the one matching a given condition.
Basic implementation of a AFilteringIterator that relies on a Predicate to choose which elements can be returned.
A post-processor which filters on specific members for given levels by editing the query filter during prefetch.
When the user wants to add a filter, they type a pattern and we display the members of the FilteringPostProcessorOnTheFlyPattern.filteredHierarchy that correspond to this pattern.
An utility class that provides methods to visit filters.
This can walk a filter, showing around an IFilterVisitor what is to see, and in particular allowing the visitor to construct an alternate and equivalent version of the filter by visiting the conditions for a set of hierarchies.
 
Analytic navigation measure.
Factory for the FirstLastMeasure.
Builder to create a FirstLastMeasure.
The position to read in the window.
Post processor that shift aggregates toward the first/last aggregate.
 
Maintains a dictionary of integer arrays.
Common function definition for the WTDFunction, MTDFunction, QTDFunction MTDFunction and YTDFunction.
 
Resolves simple agnostic SQL queries without multi-rows vectors.
Component that generates, given a database schema and some conditions to select records within this database, instructions to execute to materialize each fully flattened that are being requested.
Automatically imports the AtotiRuntimeConfig.
Wrapper for an Arrow Vector of Float arrays.
A cursor over a float array with specialized methods.
Wrapper for an Arrow Vector of Float.
Represents an operation upon two float-valued operands and producing a float-valued result.
Basic implementation for a float blocked vector.
Implementation of a read-write cell supporting data of type float.
Compares two Float objects.
Basic implementation for a float fixed block vector.
Parser for float fields.
 
Represents an operation on a single float-valued operand that produces a float-valued result.
Special parser for vectors of floats.
Flush the work units in the store, which should be update where.
Class when a request is made to a restricted area.
Completion sync designed to prevent ForkJoinPool's work-stealing and actually block on query.
Explicit formatter extended plugin implementation.
Implementation of IPresentationExpression based on IFormatter.
Utility class for formatters.
Field to display in an Interactive Form.
DTO representing any field of an Activiti form.
DTO representing the type of one field in an Activiti form.
Base implementation of IFormula interface.
Keeps track of executed tasks.
Tracks a tuple and an expression.
The formula extractor visitor It extracts the formulas on the sides of < or > or <= or >= in a case of if or case function.
The formula post-processor is backed by an IFormula defined into its initialization properties.
 
Enum controlling the activation of frequency-compression depending on the type of chunks.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
Basic implementation of IFromClause.
An extension of the DELAY protocol that delay ALL messages.
Internal class to create the manager of branch permissions, to be removed in favor of some implementation in the spring boot starters.
Extension of ScopedCellSet keeping track of the original scope locations and measures specified in the corresponding query, even if no values were retrieved for them.
An event representing a full refresh of some locations, represented by a map of scopeLocation to List&lt;AggregatesDTO&gt; (one aggregate DTO for each point location).
A PartialCellSet whose parent is a FullRefreshCellSet.
Implementation of IFunctionCall.
Category of functions.
Class defining a match of a function definition for a set of arguments.
 
Plugin implementation for storing function plugin values.
Plugin implementation for storing function plugin values.
Utility functions for Mdx functions.
A value that will be set in the future, and whose value can be awaited by other threads for synchronization purpose.
A future representing a value that will be set later on.
Keeps the timing of a GetAggregatesQuery.
 
 
 
Explicit declaration of the IGenericAggregationFunction plugin values.
Serializer class for implementations of IGenericAggregation.
Sql Flavor for a generic JDBC database.
Jdbc Type Matcher for a generic JDBC database.
This is a JAXB and java serializable list.
Factory implementing how to create ResultSet readers for a generic JDBC database.
Configuration importing standard REST services, present in all applications.
A generic, non-optimized vector binding.
Attached query implementation of the IGetAggregatesQuery.
Continuous query implementation of the IGetAggregatesQuery.
A crossed-stream monitor for continuous GetAggregates query under a context group.
Implementation of AContinuousQueryMonitorsGrouper to regroup continuous GAQ monitor under a context group.
Crossed-stream statistics collector for continuous GetAggregates query.
Implementation of the IGetAggregatesQuery interface.
Monitor for location-based get aggregates query action.
Monitor for streaming of location-based get aggregates query action.
Result of GetAggregatesQuery, wrapped for testing and easier reading.
Testable version of ICellSet.
Basic implementation of ICellSetResultWithPlans for GAQ results.
Stream to handle GetAggregates continuous queries.
For grouping GetAggregates streams on JMX.
A translator for GetAggregates stream.
A query to retrieve a single record from its key.
 
Utility class for get-by-key queries.
Get-by-key query ready to be run.
The collector holder for IAggregateProviderHolderTransaction.
Implementation of a IGlobalContributionHolder.
Representation of all the dictionary key that are impacted by a transaction's commit.
A GlobalEntitlement instance lists the context values common to all pivots.
A simple goodbye message that notifies the the query cube when a data node leaves the cluster or is being shutdown.
Event triggered in the Query Node when removing contribution of a remote instance following the reception of a message succeeds.
Event triggered in the Query Node when the contribution removal of a remote instance following the reception of a message fails.
Implementation of AConcurrentlyFetchingChannel for Google.
Wrapper on a Google storage's directory.
 
Entity wrapping a Blob.
Object referencing a Blob.
The graph websocket topic.
Provide utilities to manipulate graphs.
The graph web socket sessions holder.
Greater than comparison.
Greater than or equal to comparison.
A solver of the set cover problem based on a greedy approach iteratively selecting the most efficient subset until the input proportion of the universe is covered.
Selects the most efficient subset of a SetCoverInstance.
A re-aggregation function for a GROSS_SUM.
GROSS_SUM aggregation function, that is, the sum of the absolute values.
The gross sum binding for vectors.
A factory responsible for creating a dictionary on multiple fields, for a given partition.
Stream information container that handles simultaneously multiple statuses at a time.
Lazy initialized holder for a readable byte channel, that will close an associated stream.
A monitor for a continuous handler under a context node.
Implementation of AContinuousHandlerMonitorsGrouper to regroup handler node monitors under a context node.
A statistics collector for a handler under a context node.
The default implementation for a handler token It simply unregisters the given listener from the list of listeners.
Factory to create a HandshakeHandler independently of the web server used.
Plugin configuring the core handshake handlers.
A AChunkReader used for sparse chunk sets that use HashMapRowMapping.
HashMapConverter converts a hashmap to a database entity (Map<String, String>.
A IRowMapping powered by a TIntIntHashMap.
Set of functionality for elements that have dimensionality (IHasDimensionality).
A Translator that configures itself automatically by parsing header lines.
A basic drillthrough executor that only retrieves all headers during the first step of the executor execution.
 
Head(Set_Expression[, Start ]).
A wrapper around a head version of a branch (strong reference) with additional information.
The health agent properties.
A converter to convert the source into a computation intensity.
 
The health check agent checks the health of an ActivePivot application.
Dispatches events to all of its registered handlers.
Default implementation of a Health Event Handler.
AutoCloseable instance to help to propagate extra information to health event logs.
Allocator of heap buffers (buffers allocated in the java heap).
Allocates chunks that store their data in buffers.
Utility class to periodically send heartbeat messages to websocket remote endpoints.
A simple hello message that is sent to all members in the cluster to make sure that we can talk to them.
Response of the computation of a HelloMessage.
Implementation of IContentService which relies on Hibernate.
Helper on top of Properties for Hibernate configuration.
Helper class to run Hibernate queries with JPA objects.
Hierarchical mapping between an integer point representation and an object based location representation.
A hierarchical partitioning has multiple sub partitionings among which user can define a hierarchy.
Implementation of AGreatestCommonPartitioningCalculator for this partitioning.
Visitor to check if a hierarchical partitioning is implied by another partitioning.
Visitor to retrieve the partition id of a hierarchical partitioning, knowing the id of the partition of another partitioning by which the hierarchical partitioning is implied.
Visitor to retrieve the partition ids of a hierarchical partitioning, knowing the id of the partition of another partitioning which is the reduced partitioning of the hierarchical partitioning.
A set of utilities for IHierarchys.
 
Hierarchize Order - Only Non Range Tuples can be ordered.
Store all information about a hierarchy (basically a IHierarchyInfo and its ILevelInfo).
A comparator to compare locations or axis members over the hierarchy, with respect to the comparators of each level in the hierarchy.
Comparator for a given level members.
Pipeline to contribute into a list of dimensions.
The hierarchy data.
Class used to fill hierarchies added by the alterable API.
Hierarchy Discovery for SOAP webservices.
The hierarchy discovery.
The hierarchy discovery builder.
DTO for a Hierarchy of an ActivePivot.
Simple implementation of IHierarchyBuilder.
 
The identifier of a hierarchy in a cube.
Default implementation of IHierarchyInfo.
 
Object that gathers IAxisHierarchyDescription of given hierarchy as well as the IAxisDimensionDescription it belongs.
Implementation of a memory quantifier for ActivePivot hierarchy members.
Data object representing a hierarchy of the cube analyzed by a SmartAggregationEngine.
A Copper object that handles the publication of analysis hierarchies (and their aggregation procedures) for a given context.
Helper class to configure the partial providers.
The coordinate of a hierarchy among the whole IActivePivotSchema.
Class encapsulating topological difference, that is, missing levels between a query cube hierarchy and its corresponding hierarchy in a data node.
Copper measure representing the values of the members on a given hierarchy.
An operator that produces a function able to read the coordinates of a given hierarchy from an ILocation.
 
A class able to give a legend for the given value.
Generic aggregation for IHistory based aggregation functions.
Generic aggregation for IHistory based aggregation functions.
Acceptor when estimating a column cardinality with HyperLogLog.
Dispatcher calculated by the HorizontalQueryDispatcherFactory and indicating which members must be retrieved from which data node when the IQueryClusterDefinition.HORIZONTAL_DATA_DUPLICATION_PROPERTY is enabled.
Spring Security filter that adds a login form authentication to the filter chain.
Utility class to handle exceptions thrown by the REST controllers.
Record containing all relevant elements about the error to report to http callers.
Component interfacing with lib hugelbfs.
A DSL to configure the security for human interactions with an Atoti application.
Iterates over a crossjoin of 2 ranges with 2 iterators of different nature.
Utility class for all HyperLogLog related classes.
An accessor allows accessing to values from an input object.
A result-less action.
Interface of a monitor for a particular transient action, which has 'start' and 'stop' boundaries and might succeed or fail (with exception) within those boundaries (e.g.
An IActiveCollector is a component that can protect a piece of code using a fence, acquired via IActiveCollector.acquireFence() and released via IActiveCollector.releaseFence(Object).
Interface defining required beans that users must defined to completely use ActiveMonitor.
Spring configuration class defining all available DAOs in ActiveMonitor.
Spring configuration class defining available ActiveMonitor services.
ActivePivot component main interface
An object used to retrieve aggregated values held by an IActivePivot.
Class defining the bean for the branch permissions manager.
ActivePivot spring configuration interface.
Service used to store the ActivePivot descriptions and the entitlements (i.e.
Description of a calculated member or KPI with its permissions.
ActivePivot content service spring interface.
Specialization of IContext for a IActivePivot.
 
Most ActivePivot continuous query implements this interface which gives the id of the underlying activepivot.
This holder exposes the feed which contributes to the aggregate store and the hierarchies.
This describes an IActivePivot instance.
A stream event produced by ActivePivot.
Policy defining the way an ActivePivot is fed from its underlying Database.
An health event handler dedicated to handling health events declared in the activepivot project.
Marks event from the activepivot project.
Description of an IActivePivot running instance inside a IActivePivotSchema.
An ActivePivot's manager holds a set of IActivePivotSchema and ICatalog instances.
This is the highest level component of an ActivePivot environment and is entirely defined by an IActivePivotManagerDescription.
A manager description fully describes an IActivePivotManager.
Step of the manager builder when the mandatory parameters have been set.
Step of the schema builder when the mandatory parameters have been set.
Step of the builder when a selection has been given to the schema.
A Configuration class used to expose the IActivePivotManagerDescription.
Interface defining a structure representing the entire ActivePivot Manager.
Interfaces to easily update an IActivePivotManager.
Starting point of the updater.
Interface to start changing cubes.
Interface to update a catalog.
Interface to start updating a cube.
Interface to start updating a dimension.
Interface to update a manager.
Interface to start updating a measure metadata.
Interface to update a schema.
Interface to update a selection.
Interface to indicate that an object holds the object that created it and can return it back.
Base interface for a query executor.
A helper object used to create and run queries on an ActivePivot.
An IActivePivotQueryRunner that already defined the level coordinates and measures to query.
An IActivePivotQueryRunner that already defined some level coordinates to query and can now specify which measures should be queried.
The starting state of an IActivePivotQueryRunner for which coordinates need to be defined.
The starting state of an IActivePivotQueryRunner for which coordinates need to be defined.
An IActivePivotQueryRunner that already defined some level coordinates to query and can now specify which measures should be queried.
An IActivePivotTransactionInfo coming from a remote instance.
Interface of an ActivePivot Schema, a collection of ActivePivot instances that share the same selection on the underlying database.
A schema description that fully defines an IActivePivotSchema instance.
This class fully defines an IActivePivotSchema instance running into a IActivePivotManager.
This database session references the main database session for one activepivot schema.
Interface implemented by components that interact with the session and need a reference to its instance.
The structure of an IActivePivotSchema.
The transaction info sent by the ActivePivot's schema.
Interface of a Schema Transaction Manager, with support for synchronization with the pending notification tasks.
Responsible for updating the schema and its selection based on a structure change.
ActivePivot services spring configuration interface.
Definition of an identifier for a IActivePivotStreamNode.
Interface for a stream node attached to an ActivePivot.
Instances of this interface give you information about a realized transaction.
A version associated with a multi-version pivot.
An interface used to tag an Object that is aware or related to the existence of an IActivePivotVersion.
Interface for ActiveViam properties.
Interface to handle the Properties defined in ActiveViam products.
Interface for Property Resolvers.
Activity type for form elements.
 
Add dimension action.
Implement this plugin value to provide additional metadata for your context value.
This action is created to add new reference between two stores.
Class representing a network address of a cluster node.
Type of node in an ActivePivot distributed cluster.
This action is created to add new stores in the schema.
The administration service allows to administer an IActivePivotManager and all its child components.
Interface for measure based on User-Defined Aggregate Function (UDAF).
The description for a measure based on User-Defined Aggregate Function (UDAF).
An aggregate retriever is a facade to retrieve aggregates based on a collection of locations and a selection of aggregated measures.
Globally manages the epochs for an application instance.
Interface for components defining their own partitioning.
API to test the Collection of query plans returned by the execution of a query.
API to easily test a IRetrievalInfo .
API to easily test a IQueryPlan .
Enum type for types of retrievals.
An agent is a state machine.
Business logic performed during an agent state transition.
Enumeration of the possible states of an agent.
Connection details about a ActiveMonitor agent.
Description of a ActiveMonitor agent.
Listener that will be notified of agent check in or check out.
The REST IAgentService Controller.
Agent service.
A collector used to contribute to an aggregate provider.
The expansion context of an aggregates collector used to expand locations.
Definition of a cursor over an Aggregate result.
Definition of a reader over a single row of an Aggregate result.
Holder for contributions made of pre-aggregated values.
Marking interface for elements that contains aggregated values.
This is the most common type of Aggregation.
Description for a IAggregatedMeasure.
Description of a selection on a Database retrieving aggregated values group by a series of fields.
A provider of aggregated values.
The base structure of a multi-version aggregate provider.
Definition of an aggregate provider.
The execution context of an aggregates provider used to execute aggregates retrievals.
Contains all the aggregate providers for the ActivePivot.
 
 
A transaction on an aggregate provider.
A version of an aggregate provider.
Interface defining the steps to build an AggregateQuery or IPreparedAggregateQuery.
 
 
 
 
 
 
 
 
 
 
 
 
 
Interface representing the results of an aggregate query.
A query plan retrieval information.
A retrieval location.
A cache for computed aggregates is a map with a limit size where the least recently used aggregate is discarded when space is required to cache a new aggregate.
A key for this cache.
The context that needs to be in the IQueryCache for this IAggregatesCache to function.
This describes an IAggregatesCache instance.
Step of the IAggregatesCacheDescription builder when enough information has been provided to be able to create a description.
Builder for the aggregates cache definition.
Continuous handler of events published by a stream.
Isolates the subset of the state of IAggregatesContinuousHandler that uniquely identifies instances of that class.
A registry that creates and stores all the continuous query handlers associated with a version of an ActivePivot.
Each ActivePivot defines a single aggregates continuous query engine.
An aggregates event corresponds to the update of a set of aggregates.
Aggregates result for a single location.
The task that will execute the retrieval of aggregated values and expose its result.
A description of an aggregates retrieval that defines both the location (possibly a range location) and the measures for which we are requesting aggregated values.
A retrieval result that provides random access to its point locations.
An Object used to transport a IAggregatesRetrievalResult from one instance to another.
A columnar and writable table that can bind itself to a source to copy and aggregate data in its columns.
The binding between two aggregate stores.
Helper to create an aggregate table based on the definition of a cube's Aggregate provider.
The Builder for this interface implementation.
Generator of SQL queries to create and feed an Aggregate Table.
 
 
Listen to updates received from a single IStreamedView as individual facts.
An aggregation that is binding a single-field source with its destination aggregates.
Aggregation binding between two data structures of type 'array': the source and the destination.
Aggregation function based on a single field.
Context provided to each IAnalysisAggregationProcedure.IFactory to build to the procedure.
Interface defining the state machine to build the description of an analysis hierarchy procedure for aggregation.
Step interface where the plugin key to the factory building the procedure is referenced.
Step interface configuring the hierarchies handled by the procedure.
Step interface configuring optional join measures offered by this procedure.
Step interface configuring optional underlying levels for the procedure.
Builder interface grouping all steps to define a complete procedure description.
Meta step interface for builder based on a hierarchy.
Meta step interface allowing user to optionally define join measures and/or underlying levels for the procedure.
End interface to complete the building process of a procedure definition.
Construct representing aggregation of events that creates an alert.
Definition of a simple cache for alerts, storing only alerts that are currently running.
Definition of a listener on alert changes in the system.
Interface for plugin values implementing IWorkflowProcessExecutor from ISentinelAlert.
The alerts rest service.
The alert service.
Alert service for websockets.
The interface for the aliased sets.
This interface is intended to pass further details on how to allocate a chunk of a given type.
A database which schema can be altered.
Object that handle updates on getAlternateMapping().
Procedure computing aggregated values for members of analysis hierarchies.
Definition for a factory generating an instance of IAnalysisAggregationProcedure.
Description of a procedure to aggregate values on members of one or many analysis hierarchies.
Marker interface for Analysis hierarchies.
Interface for building an analysis hierarchy.
Description for an Analysis hierarchy.
Interface to use to simplify the code adding analysis hierarchy to the cube description with the builder API.
Interface for children of IMonitoredComponent that use our annotations (JmxOperation, JmxAttribute, JmxChildren or JmxOperation) and do not want to implement the methods of IMonitoredComponent.
A whole application.
Definition of the data session accessible to an ActivePivot.
Global provider interface for all the non-transient dictionaries of an ActivePivot application as well as its Database(s).
Global coordinates for a dictionary in a IApplicationDictionaryProvider.
Marker interface for the local coordinates of a dictionary inside a IDomainDictionaryProvider.
Manages the messages received.
Elements of data available following the array layout.
An IReadableArrayCursor that can write in its underlying array.
Marker interface for arrays that may contain null values.
Like IPositionalReader with a size.
Interface to write into a structure with an array layout.
Wrapper around an Arrow vector that knows how to cast to the correct type to write.
'As of epoch' context value that in a multi-version environment determines the version (or epoch) that must be considered.
An attached query that can be executed asynchronously using IAsyncAttachedQuery.executeAsync(CountedCompleter).
Async listener over a composite selection.
Interface for a listener on transactions on the Database.
Listener receiving aggregated contributions about the data that has been updated.
Listener receiving contributions about the data that has been updated.
An even that is being processed asynchronously by various executors using ForkJoinTasks.
Simple result acceptor.
A transaction on a multi-versioned Object that performs its operations in an asynchronous way.
Transactional multi-version component that can commit asynchronously.
Marker interface for internal data classes providing filters.
A query that is attached to some session.
The audit contains all the data related to a certain limit.
Interface for a table that can be audited.
Interface for a write action into a database that needs to be audited.
The audit data access object interface.
A message that must be authorized in each instance in which it is being executed.
Utility class offering to execute an action in the context of a given user.
Interface for comparators used to sort the authorities.
IAxisDimensionDescription is the description for the IAxisDimension.
The description for axis dimensions.
An axis hierarchy.
A hierarchy which holds members from different epochs.
Component collecting created members and deleted members during a transaction on an Axis hierarchy.
Description of a hierarchy whose levels come from the fact selection.
A collector specialized for dimensions ' exchange between several IDistributedActivePivot.
Interface representing a version of an Axis Hierarchy.
IAxisLevelDescription is the description for the IAxisLevel.
Axis Members are members defined inside an axis hierarchy.
Special member for IAxisHierarchyExchanger.
Interface used to name the axes.
Enumeration of the default axes specified by the MDX Standards.
Interface for a group of IRangeProperty.
 
Interface representing a directory in Azure cloud.
Marker interface representing an AzureEntity without its generic.
This interface is used to find all the objects that match in the past.
A condition known by the datastore which can be evaluated based on its ImplementationCode.
Base interface to be implemented by all datastore query runners.
Aggregated measure with a single input field.
The description for a IBasicAggregatedMeasure.
An extension of IBasicPathlessContentEntry where the entry knows the absolute path where it is or should be stored in the content service.
A wrapping interface to abstract content entries from their paths.
Capable of flattening a record before even adding it to the store.
A bitmap is a possibly large sequence of bits on which logical operations like AND, OR, XOR can be efficiently applied.
An object which is able to perform searches on tuplized data structures, and returns results using bitmaps.
An iterator over all the ints set to true in a bitmap.
An atomic group of data that servers as backing structure for vectors.
An allocator effective to allocate a fixed amount of memory among a reserved and sized block of memory.
Interface for a vector that is based on blocks to retrieve its underlying data.
Interface for boolean context metadata.
Parser of boolean fields.
Interface defining a builder to draw borders around a table and its cells.
Direction of the border.
Style of a border.
Context value containing details about the current branch.
Object used to describe the creation of a branch, containing the name of the branch, its permissions, and the epoch at which it was created.
Object used to describe a branch, containing its permissions, and the epoch at which it was created.
Information about a branch.
An object containing the read and write permissions for a given branch.
A hook that can be run when a specific branch's permissions are updated.
A service which keeps track of branch permissions: owner and reader rights.
A message that can be broadcast to all instances.
The answer of a remote instance to an IBroadcastMessage.
A bucketer is a component that can uniquely split a set of objects into buckets.
Allocator of data buffers.
Buffered cellset writer.
An object that can create IBufferedCellSetWriter on an underlying IScopedCellSet.
The step of the builder when the aggregate provider description has been built.
Initial step of the build of an aggregate provider description.
Step of the builder when collecting multiple levels for a higher builder.
Initial step of the build of a partial aggregate provider description.
Step of the partial aggregate description builder when only hierarchies restrictions have been provided.
Step of the partial aggregate description builder when only measures restrictions have been provided.
Interface for a partial aggregate provider description builder that has no hierarchies restrictions.
Interface for a partial aggregate provider description builder that has no measures restrictions.
Step of the partial aggregate description builder when no restriction have been provided.
The step of the aggregate provider description builder having received a type and at least one property.
Step of the partial aggregate description builder when the type and at least one property has been provided.
The step of the aggregate provider description builder having received a type.
Step of the partial aggregate description builder when the type has been provided.
Step of the builder for IPropertyInfo when all mandatory parameters have been set.
Step of the builder when a name and expressions have been provided.
Step of the builder when a name has been provided.
Initial step of the builder.
Builder interface.
A group of stream events from different streams and different domains, multiplexed together for efficient communication.
IByteBufferConverterInterface, that takes care of converting data of type <T> to or from a ByteBuffer.
A buffer pool interface.
A record storing its information in byte arrays.
Ordered store of multiple records.
A record format for creating IByteRecords.
A cached aggregate stored in a IAggregatesCache.
Interface of MBean which the return value should be cached and updated only when necessary.
A functional interface representing a supplier function that calculates IBitmap from FilterCache.
A calculated drillthrough column that can be used in drillthrough queries.
Description of a Drillthrough column computed from values.
A ICalculatedDrillthroughColumnSet can generate several new ICalculatedDrillthroughColumn when a drillthrough query is launched.
Description of a set of calculated columns.
Description of an Mdx calculated member.
Step of a builder when a shared context value can be specified.
Provides method to mark a hierarchy as the default hierarchy of its dimension.
Step of description builder to describe a factless hierarchy.
A ready-to-build description for a level in a hierarchy coming from a store.
Step of an analysis hierarchy coming from a store that can start describing its level.
A hierarchy having the name of the store it will introspect.
Description for a level in a hierarchy coming from a store.
 
Step of a builder that can build an IActivePivotManagerDescription.
Provides method to build a cube.
Builder definition to create the descriptions of aggregation procedures.
Provides method to build a cube.
A hierarchy builder with at least one level.
 
This interface purpose is solely to flag types of messages that have a cancellable serialization method.
This interface purpose is solely to flag types of messages that have a cancellable serialization RESPONSE method.
Task that can be cancelled.
Provides default implements to help customize the range sharing of an aggregate provider.
A IChunk that can store IVector (directly or through underlying chunks) that can be collected.
Provides method to configure the caption of a component in the cube.
Provides method to give a comparator to a built item.
Provides method to configure the expression of a component in the cube.
Step of a cube description builder when a fact filter can be specified.
Provides method to configure the folder of a component in the cube.
Provides method to configure the formatter of a component in the cube.
Provides method to give a level type to a built item.
Provides methods to configure the measure group of a component in the cube.
Provides method to put a property that contributes to the initialization of a component in the cube.
Utils to define the entitlements for the roles of user.
Ready to build.
Ready to build.
Ready to build.
Steps of an entitlement builder that can add context value.
Provides method to build the entitlement provider.
Steps of an entitlement builder that can set the user role.
Steps of the builder that can describe an entitlement.
First step of builder of IGlobalEntitlement.
First step of builder of IPivotEntitlement.
First step for the builder of an entitlement provider.
Step of builder of IPivotEntitlement where the role is given.
Step of the provider builder where at least one entitlement is defined.
Step of builder of IPivotEntitlement where the pivot id is given.
Step of builder of IPivotEntitlement where the role is given.
Provides method to mark a built item hidden.
Add a partitioning directive on the store.
Step of the builder that can start building an aggregate provider.
Step of a builder that starts defining a ICalculatedDrillthroughColumnDescription.
Builder having the column name.
Ready to build.
Step of a builder that starts describing a ICalculatedDrillthroughColumnSetDescription.
Ready to build.
Step of a builder that starts describing a calculated member.
Steps of the builder having a unique name.
Ready-to-build step.
Step of a builder that can start building a catalog.
Builder of catalogs.
Step of a builder that can start building a cube.
Step of the builder when a data cube can be built.
Step of a cube builder that can start describing the cube dimensions.
Shorter type for the function creating the dimensions descriptions.
Step of a builder that can start building a distributed cube.
Step for a builder that can start defining a drillthrough properties.
Step where we can finish defining the IDrillthroughProperties.
Step to add calculated column.
Step to add a set of calculated columns.
Step to set the header comparator.
Step to set the maximum of returned rows.
Step to hide column from the drillthrough.
Step to enable/disable ignoring queried measure.
Step to set the behavior of the drillthrough in case of error.
Step to set the behavior of the drillthrough in case of unknown column.
Provides methods to define the drillthrough properties.
Step of a builder that can start to customize the epoch dimension of its cube.
Step of a cube description builder that can start describing a cube's hierarchy.
Step of a builder that starts defining a IKpiDescription.
Steps of the builder having a unique name.
Ready-to-build step.
Builder for IKpiDescription.
Step of a cube description builder that can start describing a cube's level.
Step of a cube description builder that describes fully a cube's level when not part of an analysis hierarchy.
Common interface for the builders of a cube's level.
Step for a builder that can start defining a MDX context.
Step to add default member for a hierarchy.
Step to add formatter.
Step to add the measure alias.
Step where we can finish defining the IMdxContext.
Step to enable/disable MDX compilation.
Step to enable/disable aggressive formula evaluation.
Step to enable/disable MDX engine's case sensitivity.
Step to enabled/disable the light cross join.
Step to enable/disable member path style.
Step to add additional property.
Step to add calculated member.
Step to add kpi.
Step to add named set.
Step to hide subtotals.
Step to enable/disable ignoring invalid member in the MDX engine.
Step to override visibilities for dimensions.
Step to override visibilities for hierarchies.
Step to set axis position limit.
Step to set the cube formatter.
Step to set the result limit.
Step to define the default member of a hierarchy.
Provides method to describe the default member path.
Provides methods to define an MDX context.
Step of a cube description builder that can start describing measures.
Ready-to-build post-processor description.
Step of the pre-aggregated measures builder when all mandatory information has been given.
Builder for native measure customizations.
Builder for post-processor description.
First step of the pre-aggregated measures builder.
Second step of the pre-aggregated measures builder.
Step of a builder that starts describing a INamedSetDescription.
Steps of the builder having a unique name.
Ready to build.
Step of the builder when a query cube can be built.
Step of a builder that can start building a IActivePivotSchemaDescription.
Steps for a builder that can start defining a sub cube properties.
Builder for ISubCubeProperties with denied access.
Step where we can finish defining the ISubCubeProperties.
Steps to grant access to a measure.
Steps to grant access to some members.
An empty builder.
Builder for ISubCubeProperties with some granted measures or members.
Granting some members.
Granting members of a dimension.
Granting members of a hierarchy.
Granting members on a path.
Provides methods to define ISubCubeProperties.
Step of a builder that can start building a partial aggregate provider.
Expression representing case statement.
A catalog has an id and contains a list of ActivePivot instances.
Description of a catalog.
A listener wrapper to catch up with the current version of a single branch.
A cell to be displayed in the User Interface.
 
A cell event corresponds to the update of a set of cells.
Equivalent of a Function accepting a cell as its input and producing a result as the value of another cell.
A procedure that executes itself on cells.
Navigable set of cells.
A cell set event is an event corresponding to a full cellset (axis + cells).
Definition of an event that corresponds to the update potentially impacting a cellset.
A procedure that executes itself over a cell set.
Wrapper around multidimensional queries results performed in test environment.
Extension of IQueryPlan able to return the underlying IQueryPlan of the query execution.
Interface for objects representing a cellSetState to keep the current view of a continuous query in MdxStream and MdxStreamNode.
API to easily test the content of a CellSet.
Builder for a filter to find a single cell in a CellSet.
API to easily test the content of a Cell belonging to CellSet.
Common interface for all tester steps that target a single cell.
Component responsible for writing values in a cell set.
A procedure that applies a transformation to the values of an inputCell attached to a IPointLocationReader and writes the result into a resultCell.
Definition of a write-only component linked to a cell containing some data.
Interface of a dictionary that stores some type of character sequence.
A chunk of data within a column.
Allocator of chunks.
 
Represent the binding between two chunks.
A chunk of data that stores boolean values.
Interface for chunks used for performing user-defined aggregations.
A functional interface for creating a chunk given a IChunkAllocator, some IAllocationSettings and the chunk size.
Specialized chunk that stores double primitive data.
Represents a factory to create chunks.
Specialized chunk that stores float primitive data.
Specialized chunk that stores integer primitive data.
Specialized chunk that stores long primitive data.
A chunk that can store null values.
A chunk that stores positive integer of variable bit length.
A chunk of data that stores primitive integers (bytes, shorts, ints).
A chunkSet represents a set of chunks that correspond to the columns of a table.
A chunk that stores a single value.
A bitmap which supports random writing and deleting.
An extension to Cloneable returning the real interface.
Interface for cloud ICsvDataProvider factory.
Deprecated, for removal: This API element is subject to removal in a future version.
It will be become a marker interface in 6.2, and thus be removed
Interface representing a directory in the cloud.
Facade on an object stored in the cloud.
Reference on an object stored in the cloud.
A cluster that is part of the clustering task performed by VectorizedQueriesClustering.
The definition of the cluster to which a DATA or QUERY cube belongs.
Contains the common interface for the query and data cluster definitions builder.
Builder of a distributed application definition with an id.
Builder for the messenger description when all mandatory parameters have been set.
Builder for the query cluster definition when all mandatory parameters have been given.
Builder for a data cluster definition with all mandatory parameters given.
Builder for a data cluster definition that provides an option to conceal branches from the distributed application.
Builder for a data cluster definition that chooses whether to conceal some hierarchies from the distributed application or not.
Builder for a data cluster definition that chooses whether to conceal some of its measures from the distributed application.
Step of a builder that can start building a distributed application.
Builder for a data cluster definition with an id.
Builder for a data cluster definition with an id and a messenger definition.
Builder for a data cluster definition that chooses to conceal a part of its hierarchies.
Builder for the messenger description.
Builder for the query cluster definition.
Builder for the query cluster definition when an id has been given.
Builder for the query cluster definition when an id and a messenger definition has been given.
An health event handler dedicated to handling health events declared in the activepivot project.
Cluster health event interface.
An object that stores the state of a cluster (cluster members, associated viewId).
A column is a writable array of elements that all have the same type.
A columnar table where each column is identified by a distinct name.
Deprecated, for removal: This API element is subject to removal in a future version.
This is becoming a marker interface that is not part of the public API.
A column calculator is responsible for the calculation of the values for one of the output columns.
The context of a column calculation.
Table condition describes a condition tree on a table.
Table condition describes a condition tree on a table.
An IColumn specialized for storing int values.
This interface represent a command as associate to an execute request.
Common interface for the builders of a cube's hierarchies.
IComparator is an interface which can specify an ordering between objects in ActivePivot.
IComparatorDescription is the description of an IComparator extended plugin.
This interface describe specific order for an IComparatorDescription.
Extension of the IProperty interface that adds support for compiled properties.
The arguments selected by an ICompilationMatcher, and whether the ICompilationMatcher matched.
Matches an expression, selecting arguments in the process.
Interface defining a visitor rewriting an expression using post-processors.
A compilation visitor that transforms the visited expression into a new expression based on the arguments provided by its children.
A compilation visitor relies on its children to help him build the result of its visit.
The result of compiling an ICondition.
An instance of an ICompiledCondition.
Prepared statement for get-by-key query.
Operation to execute on the target store of some references, to find/filter all rows in this store that are referenced by matching rows in owner store.
One of the compiled operation of a condition query.
Operation to execute on the owner store of a reference, to find/filter all rows in this store that reference matching rows in target store.
Operation to search in a store.
The result of the compilation of a IPartitionOperation.
A compiled property, compiled specifically for the instances of a target class.
A query ready to be run, including all optimizations that could be done depending on input query.
The operation to find referencing/referenced rows.
An IPostProcessedRetrievalResultWriter with a ICompletablePostProcessedRetrievalResultWriter.complete() method that can be invoked to complete the writes and return the final result.
Group of interfaces for completer chain components.
Interface representing a chain requiring an operation to be defined.
Functional interface defining a simple action generating tasks requiring a completer.
Function interface defining a loop operation that returns a collection of tasks to run at each iteration.
Function interface defining a loop operation that creates and starts tasks.
Interface representing a runnable chain.
A completion is a type of continuation to be executed at the end of an activity.
A synchronization Object associated with a task that can be used to wait for the task to complete.
An health event handler dedicated to handling health events declared in the composer project.
Marks event from the composer project.
A composite IActivePivotTransactionInfo that contains multiple underlying info that will be processed together as one by the continuous query engine.
A column which contains IChunkComposite instead of simple IChunk.
A cursor on an ICompositeColumn used to read and write rows.
Composite database is an external IAlterableDatabase with an extra IDatastore to store local data.
A composite IDatabaseSchema.
A composite of several readable columns.
ICompositeSelection are used when one need to listen to the updates of several selections.
Listen to updates received by a IContinuousCompositeSelection.
Structural transaction exposing its two underlying transactions.
A group of IIdentifier.
A component whose data can be compressed.
A IMultiVersion that supports the compression methods like ICompressible.compress(boolean) and ICompressible.compress() to reduce the direct memory used.
Generic compressor interface.
Computed query ready to be executed against a database and with a result handling model.
The concrete reference between two store partitions.
Interface for bases of IMultiVersionConcreteReference.
Factory building practical instances of the IMultiVersionConcreteReference references between stores.
A transaction on this reference.
An IChunkInteger that supports some additional operations that are relevant for concurrent programming.
An IChunkLong that supports some additional operations that are relevant for concurrent programming.
An IDictionary that supports multiple concurrent writers and readers without any needs for outside synchronization.
A Single-Abstract-Method interface used to provide a callback in response to a dictionary action.
A IDirectedGraph providing thread safety and atomicity guarantees.
Describes a condition of a IQuery.
Base interface for conditions in pivot queries.
Class carrying information about the context in which a condition is compiled.
Object capable of creating a condition from a JSON object.
A key identifying a ConditionNode regardless of its parent.
Description of REST API to configure an ActivePivot application.
The configuration services allows to add mdx calculated members and KPIs to a pivot.
A FunctionalInterface used to create a Connection to the associated database.
Factory to create a DirectQueryConnector from a set of properties.
A IBaseCondition whose operand is defined at the construction time.
Operand holder for IConstantCondition.
An entry of the content server.
Listen to update on a content service file or folder.
Interface used to print the content of a database.
Interface for a hierarchical key-value store with read/write permissions.
Content Service spring configuration interface.
Locking strategy used to enforce atomicity of changes in a content service.
An interface for content service trees, defined recursively: a content tree holds an entry node as root, and children subtrees mapped to the name of their own root entry in its parent directory.
A context is bound to every ActivePivot's instance and be reached thanks to IActivePivot.getContext().
Base execution context functionalities.
Base interface for contexts.
The ultimate goal of context expression dependency is to describe how an expression depends on the underlying context.
An immutable snapshot of a IContext.
Interface for queries containing contextual information stored in a list of context value.
All context values implement this interface, because a context value is uniquely identified by its interface.
The context value adapter provides services to convert series of context values from or to a repository of simple Properties.
The context value adapter contains a collection of registered context value translators to which it delegates decode and encode operations.
Generic interface for builder of IContextValue.
Ready to build.
Decorator adding extra properties to ContextValueDescription.
Interface for context value getters.
A context value manager gives access to the context values associated with some or all ActivePivot instances and visible by the current user.
The manager also allows to write context values (in the private scope of the current user) to override the values that may already exist, and defined more globally.
Interface defining the contract for an operator applying context values before an action.
 
Component able to retrieve roles of the current user and apply his context values into the underlying ActivePivot Manager instances.
The description for context values.
Interface of a component that stores context values.
A context value translator can convert IContextValue instances into a simple generic representation based on Map.
Utility to register listeners on a given set of selections over an IMultiVersionDatastoreSchema.
A queryable service that can be continuously queried.
A continuous query is a mechanism by which one can define a logical set of data.
A Listener interface to continuous query.
Update received by a IContinuousQueryListener.
ActivePivot versioned branch-aware continuous query update.
An IContinuousQueryUpdate that exposes a pseudo-unique ID associated with its event.
Utility to register listeners on a given ISelection over an IMultiVersionDatastoreSchema.
Base interface for all Atoti contributions.
Record class containing the contributed points and values.
Contribution pipeline to accumulate and aggregate contributions into an ActivePivot structure.
A contribution provider using some source of contributions (classpath parsing, explicitly provided contributions, contributions parsed from annotations...).
A task that contributes some data in collectors.
Class to convert the result of a query into a specific output format.
A ICoordinates represent a location (either point or range location) It holds a list of levels and their associated member value In case of a range location, the value will be the wildcard.
Format of a set of coordinates used in IPointAggregateStore.
Interface for components that are able to create IAnalysisAggregationProcedureDescription to enrich the cube.
Interface for Copper hierarchies that can enrich a cube description.
Interface for bucketing copper hierarchy that can enrich a cube description.
Objects used to collects all the objects created with the Copper API and publish them to the cube it is tied to.
Interface for factory creating IInternalCopperContext.
A function to be used within a postprocessor to compute its values from the values of other measures.
An internal copper join hierarchy.
Operator that produces a function to operate on aggregated values.
Spring configuration for a 'Cross-Origin Resource Sharing' (CORS) filter.
Interface representing a DAO that can perform create actions.
Interface marking a statement creating a named set.
Evaluation type (STATIC or DYNAMIC).
Interface defining a statement creating a MDX element.
Interface that all parsing error listings should implement.
CSV anomaly types enum.
Definition of a component providing CSV data.
Interface of monitors for CSV export actions.
 
Interface of a parsing report specific to a single CSV file.
Interface for anomalies occurring when parsing a line.
Deprecated, for removal: This API element is subject to removal in a future version.
Not used, this was initially intended for the Python API
Deprecated, for removal: This API element is subject to removal in a future version.
Use directly the concrete implementation CsvParserConfiguration and its builder
Interface of a ISource that can fetch data from, and listen for changes in CSV files.
Deprecated, for removal: This API element is subject to removal in a future version.
Use directly the concrete implementation CsvSourceConfiguration and its builder
An health event handler dedicated to handling health events declared in the CSV Source project.
Marks event from the CSV Source project.
A topic of the CSV Source.
 
An ICube instance is used to manage: The cube structure.
Step of the cube builder when a name has been given to the cube.
A cube filter is a component that allows to restrict the view to a cube, either by only granted specific members, or by denying them.
This interface allows to construct a new ICubeFilter.
Result of the intersection of a ICubeFilter with a ISubCubeProperties.
Central point to manage all captions and formatters for a given cube.
A factory of ICubeFormatter.
Helper object for the Copper context, containing additional information about the underlying cube such as its measures and hierarchies.
A version of a cube.
Interface for an object that needs to be aware of the instance on which its code is being executed.
A cursor with no information about the dictionaries of its contained records.
Converts a line of the cursor into a user specific object T.
Create cursors that iterate on the rows of a store.
Creates an instance of ICursorFactory.
Special IComparator where the user provides an optional list of objects he always wants to be ordered first in any set, and another optional list of objects the user always wants to be ordered last in any set.
Interface defining a custom condition created by the user.
Interface that any custom property must implement to be recognized as a plugin.
Definition of a component capable of providing data, at different versions in time.
Interface implemented by components that interact with the database and need a reference to its instance.
Database spring configuration.
A database discovery contains branches with their descriptions, tables with their descriptions, and joins between tables.
Description of a field of a table of the database.
Helper object for the Copper context, containing information about the underlying database.
Description of a database join.
 
Marker interface regrouping all the objects that are declaring one or more Meter.
Definition of REST API on the IDatabase.
Definition of a retrieval to the database outside of a pivot selection.
Data structure holding the defining characteristics of an IDatabaseRetrieval.
Representation of an aggregation result coming from a database query.
Class represented a query compiled against a IDatabaseRetrievalResult, used to access the result rows of the retrieval.
Interface for a procedure consuming each row in a IDatabaseRetrievalResult.
Definition of the schema of a Database.
An updater for an IDatabaseSchema.
Service for the database able to provide features for the Database REST API.
Configuration for the database service.
Common settings for connecting to a database via DirectQuery.
 
 
Common settings for a DirectQuery application on top of a database supporting time-travel.
Database transaction information.
Definition of a given version of the Database.
Interface implemented by components that need a reference to a version of a the underlying Database.
Database which can generate SQL for Aggregate Tables.
The definition of the cluster to which a data cube belongs.
Information about a data cube's REST endpoint.
Data contributor contract.
 
Component that links the current data node to the topology it exposes to the distributed application.
Builder of a data cube.
Interface to let code from activepivot-impl update objects from activepivot-dist-impl.
The REST API to use an IDataExportService.
The Data Export Service.
A data feed is responsible to forward to other components the records it will receive.
Interface for factories which create IActivePivotDataFeedHolder.
Description of REST API of the Data Loading Service.
Priority policy to select the data node from which data must be retrieved when it is duplicated in distinct data nodes.
Component in charge of building the appropriate data source for the ActiveMonitor databases.
Component in charge of providing a builder for the several ActiveMonitor data sources namely repository, ActiveMonitor and activiti.
The root component of the datastore.
Builder for an IInternalDatastore.
Builder for a datastore.
Represent all calls that can be made on a builder of the datastore that return the same instance as before.
Datastore spring configuration interface.
An health event handler dedicated to handling health events declared in the datastore project.
Marks event from the datastore project.
Marker interface regrouping all the objects that are declaring one or more Meter.
Specific type of NUMA node selector for the datastore.
A monitor for queries executed on datastore.
The repository cache stocks into the IDatastore the values retrieved from the repository on some specific coordinates.
The configuration object dedicated to the IDatastoreRepositoryCache.
The description of a datastore schema.
Version of the IDatastoreSchemaDescriptionBuilder ready to be built since it contains at least one store.
A Configuration class used to expose the IDatastoreSchemaDescription.
Create a schema.
The schema metadata allows the retrieval of general information from the schema.
Interface for components used in IDatastore queries.
Additional information about a transaction over a datastore schema.
Responsible of pushing the updated data to the views of the schema.
Updater for IDatastoreStructure.
Procedure used to compute the values of a new field from a selection.
A stable version of the schema.
Marker interface for structural schema transaction on a IDatastore.
A transaction manager for the schema of a Datastore.
The Datastore structure is an object containing the configuration of the datastore (stores, fields, references...).
Type of the nodes in the IDatastoreStructure.
 
 
The version of a datastore.
Facade providing access to parts of the Datastore.
Component managing streaming from a Database to listeners.
Definition of a table of data from the IDatabaseSchema.
A column that is part of a table.
Data transaction manager which allows to command data operation on the IInternalDatabase.
Validates different assumptions made by DirectQuery about the external data.
Interface of DAO managing ADbInfo.
 
An array of decorated values.
A chunk of decorated values.
This interface is used to assign the various cell properties to the cells.
The interface that should implement the returned objects generated by the IDefaultCellPropertiesHandler.get(String propName) method.
The common interface for the aliased sets and the named sets.
An implementation of a vector that decorates another vector by wrapping it.
The delta contribution.
 
A structure that maps identifiers be they compound or not to integers.
ICubeFormatter that applies nothing at all.
A IDataCubeAdapter that readies the data node's elements for serialization, without hiding any of them.
Description of an identity function.
Utility class to create hash sets using reference-equality in place of object-equality when comparing objects.
The name provider to use to assign a name to a measure.
Condition tree visitor applying the identity law of boolean algebra.
A mapping that maps the rows to their exact same position.
An identity translator that returns the given tuple.
Basic interface which defines a description.
Interface for a description that can have multiple nested imports.
Id generation exception.
A class helping at implementing unique naming patterns.
Small utility class generating new ids for database objects to store.
An id factory allows to create an id of type T from the key and a long.
Similar to IFilterVisitor, with the notable difference that discriminators are already dictionarized.
A dictionary dynamically maintains a collection of key objects Once inserted, the dictionary guarantees that each key remains at its insertion position, even when new keys are inserted or when the dictionary buffer is expanded.
A dictionary allows to reference objects by their position (efficiently using a primitive integer) instead of a costlier object reference.
Interface for internal actions performed when running the two-phase commit of a IDictionaryProviderTransaction.
Interface used to declare that some levels and fields (must) have the same dictionary.
Interface for a component that is being notified when the IDomainDictionaryProvider domains it's attached to are impacted by changes in the structure of the IApplicationDictionaryProvider.
A factory that creates dictionary factories, able to create a dictionary for a given partition.
Responsible for creating dictionaries for the stores and sharing them among different correlated stores.
IOperand for dictionarized columns.
Provider of store's dictionaries.
Transaction of the IApplicationDictionaryProvider.
Resolver for field dictionary.
IDictionaryOperand when operand is a set.
A dimension that holds multiple hierarchies.
Possible dimension types.
Builds a dimension description.
Expression representing a dimension.
Base description of a dimension.
The dimension version interface.
CellSet writer based on a binding between aggregate stores.
Represent a mutable directed graph.
Implement this interface to traverse a directed graph following the direction of the edges.
Given a directed graph.
Represent a mutable directed graph that can have multiple edges between two vertices.
A DirectQuery database.
Factory for all the DirectQuery services specific to a database.
Discover table in an external database.
A chunk-based component whose data can be discarded on a chunk basis.
Interface that must be implemented by a version that can be forcefully discarded.
A callback procedure used to notify a component that one of its chunk will never be accessed anymore and can therefore be discarded.
This interface represents a request of type discovery.
This interface represents a component responsible for handing a discovery request.
Rest Service providing the discovery information.
Interface for discrete context metadata.
Interface defining the steps to build a DistinctQuery or IPreparedDistinctQuery.
 
 
 
 
 
 
 
Gives the list of distinct values a level contains.
A proxy IActivePivot that distributes a local IActivePivot.
In different distributed applications, the data cubes are allowed to have different hierarchies and levels.
Extension of IActivePivotContext for distributed applications.
This describes an QUERY cube instance.
This describes a QUERY cube instance.
Available info types.
A version associated with a multi-version pivot.
An IAgent that needs to talk to remote instances using an IDistributedMessenger.
A distributed hierarchy which holds members from different epochs.
 
The distributed axis hierarchy transaction.
Interface representing a given version of a hierarchy in a Query Node.
The builder for IClusterDefinition.
A kind of ForkJoinPool used for parallel and asynchronous message handling.
A hierarchy in a distributed cube that contains the data from all the distributed instances in the distributed cluster.
Component of query cube that can handle IInitialDiscoveryMessage, ITransactionCommittedMessage or members (cube of data) leaving the cluster and apply associated changes into the cube.
Interface for exception handlers to process an exception raised when consuming a message.
An IHierarchyTransaction specialized for distributed hierarchies.
Interface representing a Version of a Hierarchy for a Distributed ActivePivot.
Interface representing a transaction for the measure hierarchy in a Query Node.
Interface representing a version of the measure Hierarchy in a Query Node.
A measure member in a distributed query cube that comes from a remote data cube.
An object used to broadcast messages to other instances and process remote messages.
A partitioned post-processor whose computation may be horizontally distributed on each data cube regardless of its partitioning levels.
A security manager for authenticating remote authenticated messages sent to this instance.
Provides information about the distribution of the cluster.
Provider for component-specific dictionaries.
Narrowed domain dictionary transaction used inside structural transactions.
A domain event is a list of stream events (possibly from different streams) that belong to a specific domain.
Marker interface for the Private key of a IDomainDictionaryProvider.
Interface for listening domain life cycle events.
Interface for double context metadata.
Parser of double fields.
Interface for the drillthrough attached query.
A drillthrough column that can be used in drillthrough queries.
 
The drillthrough continuous query interface.
The drillthrough continuous query engine interface We can register and unregister queries.
Specialization of IConverter to convert Drillthrough statement.
A drillthrough event is an event corresponding to a full drillthrough (headers + rows).
The drillthrough executor, created for each new IActivePivotVersion.
A drillthrough header represents a column of a IDrillthroughQuery.
A drillthrough headers query returns the list of IDrillthroughHeader corresponding to each column of a IDrillthroughQuery.
Drill-through properties are used to customize content and presentation of drillthrough results.
The possible behaviors of the query engine upon an exception with a calculated column in the drillthrough.
A drillthrough query returns all the facts (represented by IDrillthroughRow) contains into a range of selected locations.
A drillthrough query context is computed when a drillthrough query is launched.
State for a IDrillthroughStream, storing the current result of the IDrillthroughQuery.
A drillthrough row is the elementary result of a IDrillthroughQuery.
The session used the execution of a drillthrough query.
Represents a drillthrough.
Interface describing a node attaching several IDrillthroughStream to a single drill through query.
ActivePivot versioned and enriched continuous query update.
A drillthrough update event is an event corresponding to an addition or update of a drillthrough row or removal of one.
Marker interface for components that can be dropped.
The necessary info to roll back a partition drop.
A record stream specialized for holding dropped partitions content.
Statement used to drop Mdx elements.
Discriminate between two records with the same key fields.
Leaf condition whose operand is given at run time.
A dynamic MBean used to monitor a component, that can register and unregister itself from the platform MBean server.
The block of code containing all the instructions to perform within a datastore transaction in order to edit the datastore content.
An object containing two objects, where .
Retrieves the EmulatedTimeTravelInformation from the external database.
Encrypt any object using java security.
An entitlement, defined by a collection of context values.
A repository of entitlements.
Interface for plugin values implementing IWorkflowProcessExecutor from IEntityWorkflowConfiguration.
Class representing the workflow configuration for any entity.
DAO managing workflow configuration for entities.
Definition of an enumarator.
An enumerator value.
Represents an epoch.
Creator of epochs and IVersionHistory.
The builder for a level of the epoch dimension description (branches or epochs).
The description of an additional dimension which allows to retrieve values from different versions of the pivot within a single Mdx query.
User interface for epochs management of a component.
Policy of global epochs and memory management.
User interface for versions management of all components.
Handler containing callbacks for the different events triggered during a version's lifecycle.
This component is used to convert the epochs existing before the structure change into new ones.
The erasure interface.
An execution context specialized for the final evaluation.
Evaluates a IAggregatesRetrievalResult, aggregated at a given point location.
Construct that aggregates monitor events that contribute to alerts.
Interface for plugin values implementing IWorkflowProcessExecutor from ISentinelEvent.
A cache with a limited number of entries.
An entry to be stored in an eviction cache.
A concurrent map with an eviction policy for which we can set a maximum number of elements.
A value to be stored in this map.
Query ready to be executed against a database.
This interface represents a request of type execute.
Interface describing the components responsible for processing execute requests.
The execute statement that executes any Mdx query at a certain epoch.
Base execution context functionalities.
An execution plan contains all the retrievals that were planned by an IActivePivotAggregatesRetriever for a given partitioning.
Execution plan builder, is responsible for creating query tasks and for managing their dependencies.
Base interface for objects that can evaluate a statement.
 
Query which expands a collection of locations in the context of some measures.
The result of a location expansion.
The base interface for the nodes of an Mdx statement.
 
Interface for visitor computing the dependency of Mdx expressions.
Interface providing methods for the evaluation step.
Base interface for planning and evaluation.
Interface providing methods for the planning step.
A component responsible for resolving MDX expressions.
Interface for IExpression visitors.
IExtendedPlugin.
Contribution of an extended plugin as a whole (coming with its own plugin values).
Interface of an extended plugin value.
Contribution of an extended plugin value to the extended plugin identified by the contribution interface.
Interface representing a column in an external database.
Table in external database.
Holder for contributions made of granular values.
Factory to create objects of a given type.
Interface of a factory that is at the same time a plugin value.
A failure event.
A fence is a an Object that is acquired and released by an IActiveCollector.
Description of a field in a store of the Datastore.
Details about the field being tested or modified by requests against the IDatabaseService.
Definition of a field belonging to a Selection.
Information about the selection fields for an IActivePivot.
Interface representing a component capable of providing the name of a field from its position.
Component storing the roles that have read or write permission over a table column.
Create the function that transforms the chunks when a field is being updated.
Definition of a Data Type.
An event that allows knowing which files have changed inside a given topic.
This interface aims at giving access to the parsed file and some of its attributes.
The type of the file.
Interface of components that listen to file events.
Deprecated, for removal: This API element is subject to removal in a future version.
Use
invalid reference
CsvParserConfiguration#builder(int)
instead
Interface for tuple filtering.
Representation of a condition used by a Leaf Aggregate Provider.
The definition of a filter on input facts.
An interface for a component that can visit an ICubeFilter.
A dictionary storing arrays that have all the same length.
A IWritableIntegerArrayDictionary that stores int[] of a specific length.
Interface for flags used by the Mdx engine.
Context value used between ActivePivot Live Server and ActivePivot Server to transfer flat context values.
Parser of float fields.
Interface of a format service that can parse or format an object.
Definition of a form field.
Type of the form field.
A formula object is able to evaluate complex mathematical expressions (and other) on a given IActivePivot instance and cell location.
A formula specification makes the link between an identifier and an expression.
 
Marker interface identifying a chunk compressed using the frequent-value algorithm.
Represents a from clause.
Interface for cell sets representing full new views for some locations.
An event corresponding to a full new view for some locations.
Interface for Mdx functions.
Expression representing the call of a function i.e.
A function definition.
Helper interface to link a function definition and an associated match result.
Expression representing a function keyword.
The Future result of a IQuery.
An aggregation can bind an input data structure called the source with a destination data structure that contains aggregates.
information about the chunks used to store the data such as whether the chunk must be marked or not to allow lazy cloning of large cloneable data.
 
Generic Aggregation function based on an arbitrary number of data sources.
Information about a MDX result.
This interface must be implemented by the continuous query implementation of the IGetAggregatesQuery.
This query aims to retrieve all the aggregates defined by a set of locations and measures.
Interface defining the steps to build a GetByKey query or IPreparedGetByKeyQuery.
 
 
 
 
 
A global collector is an IAggregateCollector that is used to contribute to a global aggregate provider.
The base structure of global multi-version aggregate provider.
A version of a global aggregate provider.
Interface for components holding raw contributions of newly added/removed/updated records before their processing into aggregate providers.
A cross-all-ActivePivot entitlement defined by a collection of context values.
The global health event handler with specialized methods for each type possible types of events.
This ANTLRStringStream ignore the case of tokens.
A visitor on a graph of nodes.
A IGraphVisitor.IVisitorContext that keeps some additional contextual arguments with each node to visit.
A node that can be visited by an IGraphVisitor.
The context associated with a visitor.
A simple IGraphVisitor.IVisitorContext that does not contain any contextual information and simply keeps track of the next nodes to visit.
The graph websocket session holder.
Interface to be implemented to use a custom implementation of HandshakeHandler for ActiveViam's websocket endpoints.
Step of the measure build when at least one measure is defined.
A component whose rows can be deleted.
Represents an object that has the characteristic of having a "dimensionality".
Interface describing the fact of exposing a formula specification.
This interfaces defines a hashing + equals strategy.
A component that has an id.
Interface marking a ADependencyNode as having levels on which it can be partitioned and levels which are forbidden.
Interface marking a ADependencyNode as having levels on which it can be partitioned.
Deprecated, for removal: This API element is subject to removal in a future version.
This interface is useless has it is tied to its concrete implementations
Information about a branch head.
An health check is run on a regular basis, and if the dispatcher is interested, generates an event.
The health check agent checks the health of an ActivePivot application.
Defines a basic health event.
Dispatches health events to its registered handlers.
This interface is notified of all health events.
Hierarchical mapping.
Contract for contributor to hierarchies added on the fly.
The hierarchy is the basic axis of data analysis in the OLAP system, and represents one edge of the multidimensional cube.
Interface grouping the info of a hierarchy with the information of each of its levels.
Builds a hierarchy.
Component collecting created members and deleted members during a transaction on a hierarchy.
The description for the IHierarchy.
Expression representing a hierarchy.
Base description of a hierarchy.
A transaction on an IHierarchy that contains the transient, writable state of the hierarchy.
Some aggregation functions require to keep track of their history.
Describes an aggregation function that works over historical representations.
Describes a generic aggregation function that works over historical representations.
Describes a multi source aggregation function that works over historical representations.
A node containing meta-informations about a given epoch of a given history.
Provides methods to monitor an horizontal query dispatcher.
Json convertible object mapping distributing level members duplicated in several data nodes to the IHorizontalDispatcherExporter.PrioritizedDataNodes in which they are included.
Json convertible object representing data nodes of same priority ordered by decreasing priority.
Dispatching indicating which data must be retrieved from which data node when it is possible to contribute the same distributing level values into distinct data nodes.
Base interface for all models having an id.
Base interface for all DAO that manage elements that have numeric ids.
Interface representing a DAO that can perform get actions.
Interface representing a DAO that can perform read actions.
An IIdentifier is the name of object like dimensions, levels, members...
 
Unique Id generator service.
IIf function.
For an originating location (a location subscribed by some continuous query) an impact encapsulates all the results implied by a stream event: The point locations or range locations that may have changed and must be refreshed The point locations (cells) that may have been removed from the subscribed view Impacts are computed by IAggregatesContinuousHandler instances.
An IImpactComputationTask is responsible for calculating the impact on a given set of locations.
Incremental atomic operation applied to a stream.
An index that associates a bitmap of integer values to a key.
A Coordinate that can be indexed in order to perform easy lookup based on its erasure.
An execution context for an Indexed Aggregate Provider.
Interface to declare that a column calculator is able to read values from its context by accessing directly to the value of the context at the given index.
Indexed set.
Interface for query plan operation that uses an index for its execution.
A procedure that is being executed on each element of an indexed collection (typically a list).
A version of an IIndex.
Interface for referencing and reading information from a IFormField.IType.
Definition of a REST service providing information about the current user or the server.
Message sent by a data node to initially share its structure to the rest of the distributed application.
This action is created to initialize a new field with an IDatastoreSchemaUpdater.IInitializeFieldProcedure.
Action to initialize an index on an existing store.
Action to initialize a concrete reference on a an existing store.
An IWritableRecordSet that performs in-place modification on a given row, if it is supported.
POJO that contains the information to execute a insertion-time update where action.
This class takes care when new members join the cluster and when a transaction is committed.
Interface for an integer array.
A dictionary specialized for storing int[] Objects.
A transaction on an IIntegerArray that contains the transient, writable state of the array.
Interface for integer context metadata.
Parser of integer fields.
Interface for internal usage of an IActivePivotAggregatesRetriever.
Internal manager interface.
 
 
Interface exposing more details than IActivePivotVersion.
 
Interface exposing more details than IAggregateProviderVersion.
An aggregates retrieval result that is used internally in ActivePivot's query engine.
 
Interface exposing more details than IConcreteReferenceVersion.
This interface is necessary for tracing.
Internal interface for the Copper context.
Internal representation of a Copper hierarchy.
Internal representation of a Copper level.
Base implementation class for CopperLevelCondition.
The internal version of a Copper measure.
Interface exposing more details than ICubeVersion.
Definition of a component capable of providing data, at different versions in time.
Internal interface for IDatabaseSchemaUpdater.
Definition of a given version of the Database.
Interface exposing more details than IDatastore.
The internal version of IDatastoreSchemaUpdater.
Interface exposing more details than IDatastoreSchemaVersion.
The internal version of IDatastoreStructure.
Enum representing the type of an index.
Component managing streaming from a Database to listeners.
Interface exposing more details than IDimensionVersion.
 
A distributed IActivePivotVersion.
The internal version of IHierarchicalMapping.
Interface exposing more details than IHierarchyVersion.
Interface exposing more details than IIndexVersion.
The internal version of IIterableAggregatesRetrievalResult.
 
Internal builder exposing the partitioning and numa node selection settings.
Interface that must be extended by all the implementations of IMeasuresProvider.
Sub-interface exposing the internal type for memory statistics.
Collector that ensure blocks are visited only once.
Internal interface of a multi-version pivot.
 
 
 
A compiled DistinctQuery with underlying query.
Internal interface for obtaining the dictionaries used by a database query prior to running it.
A compiled ListQuery with internal information such as the IPartitioning and INumaNodeSelector.
Responsible for validating and compiling.
Able to run queries on a database with multiple parameters.
Interface exposing more details than IRecordSetVersion.
A scopedaggregates result that is used internally in ActivePivot's query engine.
A procedure to be executed on each result of an IInternalScopedAggregatesRetrievalResult.
Interface exposing more details than ISecondaryRecordIndexVersion.
Interface exposing more details than IStorePartitionVersion.
Interface exposing more details than IStoreVersion.
Information about the way the drop occurred.
Transition for IStoreVersion.
The internal version of IStreamingService.
Internal version of ITransactionManager exposing similar methods but with store id parameter instead of store name.
Interface exposing more details than IUniqueRecordIndexVersion.
 
Interface exposing more details than IVersionHistory.
Internal interface for the mutable structure representing an entire ActivePivotManager.
Definition of an object checking task interruption.
An interruptor for an entire task computation tree.
This interface is extended by intersectable components.
A collection similar to a TIntIntMap, but which may associate multiple values with a single key.
A simple iterator over integer values.
The result of an aggregates retrieval.
An iteration procedure.
JDBC reader which converts a JDBC value, representing an array, to an Atoti IVector.
 
Interface to hold a JDBC connection.
Interface for a pool of JDBC connections.
Report of fetch operation in the JDBC source.
Features specific to a JDBC database.
Interface creating parsing tasks from result set.
Information about the publication of a JDBC message.
Describes Jdbc query runner needed components.
Builds a result from a SqlComputedQuery.
Interface of a Jdbc source that loads data from a database, each channel has its own specific query to scan the database.
Fluent builder interface to create an IJdbcSource.
The IJdbcSourceBuilder.IJdbcRowCreator and the IConnectionSupplier have been given, now the IJdbcSource can be built after providing some optional information.
Only the IJdbcSourceBuilder.IJdbcRowCreator of the IJdbcSource has been given, now the IConnectionSupplier must be provided.
FunctionalInterface to create a record with the given type.
An health event handler dedicated to handling health events declared in the JDBC source.
Marks event from the JDBC source.
Deprecated, for removal: This API element is subject to removal in a future version.
Fluent builder interface to create a new JdbcTopic.
Fluent builder that can build the JdbcTopic.
Fluent builder requiring to define a query.
Fluent builder requiring to define a topic name.
Interface used to match a JDBC type to an Atoti type.
Interface marking a class as capable of producing a JMX Bean.
An interface to be implemented by enum in order to be passed as arguments to native calls made using JNA.
Constraints that must be fulfilled by all joins.
Interface for join-related IAnalysisAggregationProcedure context types.
Measure produced by joining field levels and using them as field values in a store.
Description of a measure coming from a join between ActivePivot levels and fields of an isolated store.
Interface to define output configuration.
Interface to define output configuration.
Interface of monitors for json query actions.
 
The service responsible for computing REST queries.
Interface which should be used by Authentication based on JWT so that Atoti components can reuse the token.
JWT spring configuration interface.
Definition of REST API for JWT authentication.
A service which generates JSON Web Token (JWT).
Provide store partition context for a key event.
The record format of a record key.
Statistics about a batch.
A key value batch result contains a list of entries returned by a batch operation to a given key-value database, and the corresponding information of the execution of the batch.
KeyValue connection pool interface.
The key-value connector.
Declares methods that enables consumption of key-value entries.
An ISource that can fetch data from a key-value database.
Defines the configuration of the key-value source.
The Key-Value topic interface.
The description of a KPI as defined in http://technet.microsoft.com/en-us/library/ms126258.aspx.
Interface describing the member expiry of a KPI.
Interface defining an expression in a KPI.
Interface defining filter actions on KPIs.
Interface for formula resulting of KPI member definitions (value, goal, ...).
Interface describing the goal of a KPI.
Interface defining an expression in a KPI that returns a numeric value but that will be represented by a graphical item.
Interface describing the member start of a KPI.
Interface describing the status of a KPI.
Interface describing the trend of a KPI.
Interface describing the value of a KPI.
Simple latch with dynamic increment/decrement.
Supplier for an object which lazily initialize it.
A Level in a hierarchy.
Level condition describes a condition tree on a level tabular structure.
Visitor of ILevelCondition.
Expression representing a level.
Base description of a level.
Type for classification : indicates how the level should be treated while feeding (e.g.
Possible level types.
The licensing service is associated with an ActivePivot Manager and exposes some attributes of the current license.
Flag interface to specify that the results of a post-processor can be aggregated linearly: the post processor applied on a 'big' aggregate gives the same result as the aggregation of the outputs of the post processor on each element of any partition of the 'big' aggregates.
Interface for line reading.
Defines the strategy used to calculate the distance between two Clusters.
Key attributed to the listener of source events.
A IPartitionedResultAcceptor that forward the result of the query to a ISelectionListener.
Responsible of handling the exceptions that occur on listeners of the datastore continuous selections.
Class representing a query returning a list.
Interface defining the steps to build an ListQuery or IPreparedListQuery.
 
 
 
 
 
 
 
Listen to updates received from a single IStreamedView as individual record.
Interface for expressions whose values are known during parsing or resolution.
Interface that describes a literal.
The literal type interface.
Exception thrown when the operand of an ICondition is not of the type requested by the type of the field it is run against.
An object used to find the relevant cluster members to send messages to, considering the given locations or measures.
A factory for creating locality identifier for IDistributedActivePivot.
 
Can update the schema of a datastore through a local structural transaction - datastore either held solely, or in a DirectQuery context jointly with an external database.
Definition of a located resource.
An ILocation represents the path to one or several cells in a cube.
Simple location builder to build a location.
Flags controlling the authorized operations for the builders.
A component in charge of translating a map of coordinates into a list of locations.
The factory used to create ILocationConverter.
A location discriminator is built upon a collection of locations and operates a discrimination amongst to produce a collection of locations resulting of the collision of the initial locations with some input discriminating values.
An object used for expanding locations based on some underlying data.
Resettable interruptible iterator over locations of the given scope.
A procedure used to expand a location on some levels.
The iterator performing the actual expansion.
Format locations into a text representation.
Interprets the locations for drillthrough queries.
List of locations.
A pattern location is an intermediate data structure for easy creation of light-weight locations.
A procedure that executes itself for each of the locations within a cell set.
This interface decorates IHealthEventHandler and provides it additional methods to log the events.
A logical condition interface.
Interface for service classes with set of predefined JMX attributes/operations regarding logging setup.
Interface for a long array.
A transaction on an ILongArray that contains the transient, writable state of the array.
Parser of long fields.
A long polling service provides the possibility to implement a server push using the long polling paradigm.
Token interface for long primitive.
Context value controlling the lookup post processor evaluation.
A component in charge of intercepting the properties the LookUpPostProcessor is initialized with.
Definition of a service performing maintenance operations on ActiveMonitor database.
Marker interface for classes to be registered with a JMX server.
Update plan for manager structural transaction.
Sugar for IDrillthroughQuery relying on a collection of maps of coordinates instead of a collection of ILocation.
 
Sugar for IGetAggregatesQuery relying on a collection of maps of coordinates instead of a collection of ILocation.
A mapped tuple contains a collection of key-value pairs, mapped with the java.util.Map semantics.
An enricher of mapped tuples.
A factory of mapped tuples.
Base interface for queries based on a map of coordinates instead of ILocation.
Deprecated, for removal: This API element is subject to removal in a future version.
Use directly the implementation MapTranslator instead
A matching condition It represents matching operation on an input object.
Contains the current matching rows matching for each pair of query tree node and partition id.
A procedure that is called iteratively for each match within an index.
Interface used in the process of finding the correct signature of a function given a list of arguments.
This interface describes a multi-dimensional data set.
Property on a multidimensional member or cell.
An object which can be used by Mdx functions to specify which IMdxRegistrationDecorator should be created upon query registration.
Iterator on all axes of a MDX Cellset.
Used to filter which properties are required when iterating over this axis.
Iterator on the cell of an Mdx result.
Interface for Cell properties.
Definition of an axis in a MDX cellset.
Iterator over the tuples of CellSet MDX axes.
An interface to build component linked to the compilation of MDX.
Utility methods that need to be accessible by both MDX and post-processors to handle MDX compilation properly.
Configure the Mdx engine.
Cube reader.
Interface of an entry point to subscribe to IMdxCube changes.
Interface for all notifications that a listener of IMdxCube can receive.
Interface completing IMdxCubeNotifier to show operations triggering notifications.
Represents a dimension in a cube.
A mdx drillthrough headers query returns the list of IDrillthroughHeader corresponding to each column of a IMDXDrillthroughQuery.
MDX Query defined by an MDX string and some optional context values.
Interface for range members that dynamically compute their discriminators.
Description of a generic MDX element.
Interface for epoch management in Mdx queries.
Interface defining a plugin testing the equality of two MDX statements.
An health event handler dedicated to handling health events related to Mdx statements that induce a modification of the MDX context.
 
Represents a fixed member (i.e.
A calculated member.
Represents a hierarchy in a cube.
Base class for String index.
Meta information on IMdxResult.
Represents a level in a hierarchy.
Represents a member of a hierarchy in a cube.
IMdxMember factory and memorizer.
An mdx property.
Named set.
Base class for mdx olap elements.
Represents a member that exists in the pivot.
Interface for components which can retrieve IMdxPivotMember.
Base interface for Mdx properties.
MDX Query defined by an MDX string and some optional context values.
Mdx range member.
A component attached to Mdx continuous queries registrations and notified upon registration life cycle.
Interface representing the result of an Mdx query.
This class represents the slicer of an Mdx query.
Definition of a component checking a MDX statement.
Stream to handle MDX continuous queries.
Mdx stream identifier.
Interface describing a node attaching several IMdxStream to a single mdx registration.
Extension of IStreamRegister for IMdxStream and IMDXQuery.
This restriction is used by the Mdx engine to find the versions on which the queries must be executed and if they must be registered in real time.
Represent an operation which accepts versions from an IMdxVersionRestriction.
Marker interface for IAggregatesContinuousHandler that depends on the measure.
Factory to create Copper measures.
Interface for the measure formatters.
The singleton measure hierarchy.
Interface defining the collector of changes for the transaction on the Measure Hierarchy.
Interface defining a transaction over the Measure Hierarchy.
A stable version of the measure hierarchy.
A measure Level in the measure hierarchy.
Measure Members are members defined inside an IMeasureHierarchy.
The description for a IMeasureMember.
 
 
Component that handles the publication of measures for a given context.
A container for IMeasureMember and IPostProcessor.
A member is a known value for a level in the pivot cube.
Expression representing a fixed member.
Definition of a service providing methods to perform memory analysis.
This interface describes a statistics available on a monitored component whose memory is monitored.
Interface for a statistic on the application memory usage.
Builder for AMemoryStatistic.
The visitor associated with the different implementations of IMemoryStatistic.
An event that can be merged into another one.
This procedure is used to merge axis members.
A message contains data loaded from a data source, and transferred to a destination through a message channel.
Definition of a message.
Interface of a builder to create fluently messages.
Builder with enough information to build the message.
Builder of messages with configured sender.
Builder of messages with configured title.
The message channel interface.
A chunk of data within a message.
Callback when there is an event on the message.
The message REST service.
Messaging service allowing to send messages to ActiveMonitor users and get the ones received.
IMessageBox interface represents ActiveMonitor Messages.
A component listening to events on messages.
The interface for a message service for websockets.
The authorized type of message fetching when a socket connects to the service.
Definition of a messenger to be used with a Data cube or a Query cube.
A context value that can alter the state of other context values.
Marker interface regrouping all the objects that are declaring one or more Metrics.
An IContextValue that describes the behavior of the ActivePivot query engine when it detects that an IPostProcessor does not correctly expose its prefetchers.
The possible behaviors of the query engine upon the detection of a missed prefetch.
A wrapper for some string-defined ILocation that cannot be resolved to actual Object ILocation for the moment.
The result of a IMissingLocationsQuery, that will receive the associated notifications and provide methods to manage the lifecycle of the associated query.
A listener to a IMissingLocationsQuery Typically, the object that originally wanted to execute the underlying query but could not because of missing locations.
A singleton for each IActivePivot that listen to transactions and tries to resolve string paths to actual discriminators.
A transaction pool and a query pool with similar configuration and NUMA bindings, so that they can be used for mixed-workload operations over the same data structures.
Starting point to create immutable collections.
An ImmutableList backing its data in an object array.
Immutable collections with a functional API.
Implementation of ImmutableMap backing its data in a HashMap.
Implementation of ImmutableSet backing its data in a HashSet.
Contains utility methods to work with non functional collections.
Immutable map with a functional API.
Immutable set with a functional API.
An immutable ASubPointLocation.
A monitor that records events and internally, atomically maintains some statistics.
Class representing an monitor.
Builder to ease creation of IMonitor.
 
Builder representation of a monitor with a site.
Builder representation of a named monitor.
Builder representation of a monitor with a creator.
Service performing Database operations for monitors.
This interface describes statistics, attributes and operations available on a monitored component.
Interface to add the capability to keep the monitoring information.
Representation of a monitor execution.
Monitoring REST service.
Service managing the executions of monitoring operations.
Representation of a stream providing monitoring information.
Interface for listeners on IMonitorService.
Interface for plugin values implementing IWorkflowProcessExecutor from IMonitor.
A report about a monitor.
The list of possible statuses for a given monitor.
The monitors rest service.
The monitor service.
Store a list of added and deleted monitors.
Websocket service for monitors.
Base implementation of the IImpact interface.
A utility class to hold the compiled security and filters and impacted points bitmaps and merge them together.
A BoundedAction for computing the impacts for a given set of locations.
Enum listing the current valid types of impacts broadcast by a IDictionaryProviderTransaction.
Facade always returning a predefined user and roles.
 
List of implementation known by the datastore and whose evaluation will be optimized.
Constraints that must be fulfilled by all tables containing multi-columns vectors.
Marker interface for a column representing a vector over several SQL columns.
Interface to represent how to aggregate several fields.
This query allows its listeners to be notified after all the listeners of the underlying IAggregatesContinuousQuery queries are notified.
This type of query is only used to create IMultiGetAggregatesNotificationContinuousQuery.
Accessor that gives access to a multiple properties of the input object.
Multiple aggregate provider that contains one or several partial providers to delegate queries that fall into the right scope.
Constraints that must be fulfilled by all multi-rows vector tables.
An aggregation that is binding a multi-column data sources with a destination aggregates structure.
Aggregate functions based on multiple data sources.
Interface of a multiversion component.
Contains and manages all the aggregate providers for the ActivePivot.
The multiversion axis dimension interface.
A IMultiVersionHierarchy specialized for axis hierarchies.
A multiversion axis member.
This interface add additional operations related to distribution for the Data cubes.
This is an INTERNAL component: use rather an IDatabase.
The multiversion dimension interface.
A distributed IMultiVersionActivePivot, also called a Query cube.
Interface representing a hierarchy in a Query Node.
A IMultiVersionAxisMember made for distributed architecture.
The multiversion distributed dimension.
A hierarchy in a multi-version distributed cube.
The multiversion distributed dimension.
Interface representing the Measure Hierarchy in a Query Node.
A global aggregate provider which can process queries for a whole ActivePivot.
Multiversion main index.
Multiversion integer array.
A procedure that is invoked whenever the garbage stored in a version of an array is collected.
Multiversion long array.
A procedure that is invoked whenever the garbage stored in a version of an array is collected.
The multiversion measure dimension.
A IMultiVersionHierarchy specialized for measure hierarchies.
The commit and rollback operations.
Represent a multi-version record index.
A multiversion record set.
A multi-version secondary index.
The multiversion store.
The multiversion store partition.
Marker and basic API for a component capable of rewriting an IMultiVersion component and all the underlying IMultiVersion components involved.
Description of an MDX named set.
Interface for a Node that represents named set.
Convention to rename a table and its fields.
 
A memory allocator.
Natural java comparator.
A condition to test whether a given column belongs to a set of values.
A condition to test whether a given column belongs to a set of values.
Exception thrown when trying to join tables from different databases.
IncompatiblePathsException.
IncompatibleSetsException.
Version of the IN condition on an undictionarized operated field.
Set presence.
Compile condition for $in.
Incremental add on an aggregate view.
Load new data and stream them to an aggregate view.
Incremental add on a list view.
Load new data and streams them data to a list view.
 
 
Stream a remove where to listener.
Representation of the transaction for an incremental commit on a Remote Server.
Default implementation of IDroppedRecordStream.
 
 
Stream a remove where to listener.
The basic implementation of AIncrementalPartitionTransactionContent, in which the IncrementalPartitionTransactionContent.createPublishTask(Collection, CountedCompleter) function will publish in this order: The dropped partitions; The added records; The updated records; The deleted records.
An alternate implementation of AIncrementalPartitionTransactionContent, in which the IncrementalPartitionTransactionContentDeleteFirst.createPublishTask(Collection, CountedCompleter) function will publish in this order: The dropped partitions; The deleted records.
An IRecordStream specialized for publishing the content of a regular transaction.
A cursor providing the ability to navigate an underlying collection by producing sublists without modifying it.
 
Plan to refresh incrementally a collection of stream.
Plan to refresh a stream.
Remove where operation.
Operation to perform the computation of update where triggers in an incremental transaction.
The procedure that collects the new rows (whether added or updated) from the update.
ITransactionContent specialized for the regular transactions.
Sends a data change event to the fact view.
Incremental view refresh task executing an ordered list of task to refresh listener of a view.
An annotation that allows marking a field as a timestamp that is generated in the database when the object is created.
Allows to select the "current_timestamp" method of the database into a field annotated with InDatabaseTimestampAtInsertTime at object insertion time.
The expressed coordinates implementation.
Helper class with methods for operations on Indexes.
Group of operands to use in the Range operation family.
Definition of an index used in a store.
Definition for dictionary used for indexes.
A version of an Indexed Aggregate Provider, that points to the associated version of the aggregate store.
 
 
 
This wrapper class is needed to override the behavior of CubeFilter.equals(Object) for this particular map.
The context associated with this provider.
The cache of bitmaps retrieved during filter compilation.
An Indexed retriever over a single partition.
An indexed set.
An indexed shuffled set.
Subset of a random access set.
Identifier for an index in a store.
Memory statistics specialized for indexes.
 
Version of the IN condition on a dictionarized operated field.
A ActiveViamRuntimeException thrown when the query engine detects an inefficient prefetch declaration for an IPostProcessor.
Interface defining a handler intercepting the messages sent through the Netty layer.
Basic implementation of IInformationReader.
This service will be removed as soon as we move to spring security 4.0.0.
Representation of the transaction for the initial commit on a Remote Server.
Initial discovery message sent by a data node to a query node, and enclosing information about its topology, current epoch and application.
Basic implementation of IInitializeFieldAction.
Basic implementation of IInitializeIndexAction.
Basic Implementation of IInitializeReferenceAction.
Operation to initialize a reference.
Operation to initialize a secondary index.
Operation to initialize a unique index.
Holder for the content of an initial transaction on a partition.
Reader specialized for InitialPartitionTransactionContent.
An IRecordStream specialized for publishing the content of the initial transaction.
Operation to perform the computation of update where triggers in an initial transaction.
ITransactionContent specialized for the initial transaction : it publishes the whole content of the store.
A condition to test equality on a given value for a given level.
Builder for a Content Service storing its data in memory.
An In-memory content service.
In memory repository of ActivePivot role entitlements.
The scheme holder for workflows.
The actual dictionary structure that holds the keys and hash table of a AChristmasDictionary.
The procedure for joining (inner join) an isolated store to the cube's selection.
Plugin factory.
Context IAnalysisAggregationProcedure to make joins between an ActivePivot result and Database results easy.
Context value working as a security filter on MDX members' values.
A procedure that can be run on a IVersionNode.
Component for optimized insertion in a set.
 
Explicit implementation of the IInstanceDistributionManager extended plugin.
Parser for Instant objects.
Utility to create instructions for a IRecordFlattener.
An IPositionalReader wrapping an int array.
Represents a function that accepts two int-valued arguments and produces a result.
Compares two Integer objects.
An AIntegerArray that stores its values in an IChunkInteger.
Wrapper for an Arrow Vector of Integer arrays.
A cursor over an int array with specialized methods.
Maintains a dictionary of integer arrays.
Simple implementation of the point list interface, where points are stored in integer arrays.
A dictionary for a permuted integer arrays: this is a wrapper class around an AFixedLengthIntegerArrayDictionary that maps an int array with permuted fields.
The base implementation of an IIntegerArrayTransaction.
An integer array version defined by a base reference array and some delta mappings that override the mappings in the base array.
Wrapper for an Arrow Vector of Integer.
Basic implementation for an integer blocked vector.
Implementation of a read-write cell supporting data of type integer.
Base class for translators of integer context values.
Dictionary implementation specialized for Integer data type.
Basic implementation for an integer fixed block vector.
invalid reference
IStatistics
of type AttributeTypes.TYPE_INT.
Special parser for vectors of Integers.
This configuration file creates a manager using the Manager description and a Datastore using the schema description.
Immutable table in an external database built from pre-aggregated data.
 
Internal aggregation functions.
Custom annotation marking an API element as internal.
 
Chunk allocators which are not recommended in production.
Internal implementation of a CopperLevelValues when a lambda is applied to multiple Copper elements.
Internal interface for CopperStoreLookup.
Internal builder class for the Copper Store Look Up Measures.
Intermediate builder.
Intermediate builder.
Builder implementation for CopperUserDefinedAggregateFunctionBuilder.
Builder implementation for CopperUserDefinedAggregateFunctionBuilder.
Internal description for a custom reader on a field.
 
 
Internal DrillthroughHeadersMessage that modifies the return of AQueryBroadcastMessage.executeAsync(IActivePivotVersion) to not send the entire result but only the header names for the visible columns.
A DrillthroughHeadersMessageAction that is used internally by the distributed query engine to retrieve only the name and the visibility of the headers.
Description of the emulated time travel properties for each table.
Description of the columns used for time travel for a given table.
Basic immutable implementation of an AInternalFieldDescription.
 
Internal methods related to hierarchies.
A CancellableRecursiveTask for recursively merging together a bunch of IHierarchys list.
A query to retrieve several records from an IDataTable.
 
 
 
 
Internal utility methods related to the usage of locations.
The result of a call to InternalLocationUtil.convertLocations(List, Collection), that exposes the converted locations as well as the ones that could not be converted.
This class expands a location pattern using the given hierarchies.
This class expands a range location into point locations.
Mapping between an aggregation on fields of the schema to the columns of the aggregate table.
Basic internal immutable implementation of a vector AInternalFieldDescription.
 
Internal immutable description of a table containing vectors stored on multiple rows.
 
Internal immutable description of an IDatabaseSchema with only external tables and joins.
 
Class exception for requests leading to an invalid state of the service or managed resources.
Internal immutable description of a table.
 
Utility to convert internal schema objects to schema descriptions.
This exception is thrown whenever a thread has been interrupted during its execution.
Class providing methods to check if the current task has been cancelled.
Thread and task interruption utilities.
This class represents and handles the behavior of a set of intersected subCubeProperties.
 
IntFormatter use method format(Object) to format integer object to the value which you want.
Reads an integer from a reader containing a JDBCType.DECIMAL.
 
An IIntIntMultiMap which stores the values in a TIntArrayList.
Functions that take an integer as argument and return an integer.
An IIntIntMultiMap which stores the values in a TIntLinkedList.
Parser for integer fields.
 
Member property which uses an IProperty on the member's discriminator to retrieve the property value.
Special parser for vectors of doubles.
The NUMA node selector associated with a partitioned component such as a store or aggregate provider, capable of deciding on which NUMA node a partition of this component should be located.
Specifies the partitioning binding to the NUMA nodes.
This exception is used to indicate that there is a problem with a TAR archive header.
InvalidLicenseException.
RuntimeException thrown when the given query is not valid.
Accumulate problems that can be found in a IRecordQuery and is capable of creating the InvalidQueryException representing these problems.
A task designed to execute sequentially multiple other actions in a pool and return upon completion of all these actions or when one of them encountered an exception.
Base interface for Olap elements (dimensions, hierarchies, levels, members).
Expression representing an Mdx Olap element that is known at resolution time.
Represents the olap info part of a multi-dimensional dataset.
Class defining plugin values responsible for evaluating the on-heap memory consumption of internal ActivePivot structures.
Represent a transaction already started in which writes can be performed to change the content of an IDatastore.
Database data transaction.
An operand is an extended plugin that can be created from a string representation of:
Give at query run time the value of a condition to be matched against the content of the field it is run against.
Base interface for objects holding operand data.
Root operations composing a IQueryPlan created when a IQueryPlanner plans a IRecordQuery.
This interface define a description of an operation.
An operator is a light plugin which has a string representation of:
Describe an index to create on a field or a group of fields.
Type of optimization.
A comparator that needs to know when the sorting begins and ends.
This interface represents a ordering set.
An outer reference is a reference that has right to fail in a query.
Interface to handle the outputs of the DataExportRestServiceController.
Interface to handle output in Arrow format.
Marker interface for output managers writing files.
Interface to handle a text output.
A pair of two elements, identified as 'left' and 'right'.
Definition of a parameter.
Extension of datastore spring configuration interface.
Base interface for components listening to parameter changes.
An event holding parameter changes.
Interface for components dealing with IParameterEvent.
Interface for plugin values implementing IWorkflowProcessExecutor from String.
Interface for plugin values implementing IWorkflowProcessExecutor from ParameterUpdateDto.
Configuration object dedicated to the store used by the IDatastoreRepositoryCache.
A stream that enables to notify listener for real time update.
Interface representing a partial update of a parameter.
Definition of a builder to create a parameter change definition programmatically.
The interface for parameter service for websockets.
Parent Axis Members are members defined inside a parent axis hierarchy.
Interface defining a component responsible from parsing a CSV data source.
Component that can parse a char sequence of a field into an object.
Resources used for parsing.
Factory of parser resources.
The result of a parsing task.
Parser task.
Report of parsing operation.
Executes the processing of files and publishes them to the channel.
Procedure called to process the content of one channel stored in the workload.
Execution of a parsing workload.
A partial aggregate collector handling a subset of aggregates, with respect to a partial list of hierarchies.
A partial aggregate provider handling a subset of aggregates, with respect to a partial list of hierarchies.
A version of a partial aggregate provider.
A partial storage handling a subset of aggregates, with respect to a partial list of hierarchies.
A partial aggregate storage definition, that contains a restricted list of hierarchies for which aggregates are materialised.
Interface containing the filters applied to an Aggregate Provider.
An Object used to select the best partial provider to answer a query.
Creates objects required when a new partition on a store is created.
An operation on the content of the partition.
An IPartitionContentFactory responsible for creating the dictionary of the indexes for each partition.
Listener on a query that is called back for each partition a query is run on as soon as this partition was finished by the query.
A post-processor whose computation can be split across multiple partitions and then reduced back into a final result.
An IPartitionedGenericResultAcceptor specialized for ICursor results.
Factory to create a group of IMultiVersionRecordIndex.
The partitioning strategy of a store that can dispatch a record to its partition.
Extends IPartitioning for the partitioning based on multiple sub partitionings.
Immutable description of a partitioning.
Format defining the context in which a partitioning is defined.
Extension of a IPartitioningFormat for partitionings built for stores.
Immutable description of a partitioning function.
Manager handling the generation of new partitionings.
Define a partitioning node in a hierarchical partitioning.
A definition that has at least one special partitioning rule.
The default partitioning rule of a node can be based on only one field, in which it acts like single field partitioning, or it can be based on multiple fields: the field of the node and other fields, in which case it acts like a partitioning by Cartesian product.
A definition where user defines the default partitioning rule.
A definition that can have a partitioning field.
A definition that can have a special partitioning rule for records having a field value matching one or some decision values.
All definitions of a partitioning node.
An object that holds the partitioning algorithm as well as partitioning state.
An updater for INumaSelectorDescription.
The visitor of a visitor pattern, capable of acting on a visited IPartitioning and performing some operations based on the internal data of the partitioning.
Function to map a record to a partition ID.
An operation used inside a store search, so inside a partition.
Component of a query responsible for determining on which partitions of the base store the query should be run.
Holder for all the records belonging to a partition and modified by a transaction.
An object responsible for reading an IPartitionTransactionContent.
Interface to retrieve the past performance of queries.
An extension of ITimestampedPathlessContentEntry providing some additional information about read/write access and editing on an entry.
Specialization of IFormatter configured with a pattern.
A pattern matcher can match a pattern.
Interface for factory that create {@link IPatternMatcher}.
Description of REST API for ping.
Marker and basic API for "base" components of the pivot capable of rewriting itself and all its underlying "base" components according to the structural change.
 
An ActivePivot entitlement defined by a collection of context values.
Marker interface regrouping all the objects that are declaring one or more Meter.
 
Marker and basic API for multi-version components of the pivot capable of rewriting itself and all its underlying multi-version components according to the structural change.
A point value whose coordinates are related to a specific IActivePivot.
Update plan for schema structural transaction.
Type of the nodes in a schema structure.
Element that can deduce new pivot structural constraints from measures.
An execution context specialized for planning.
Interface for query plan info data.
Interface providing access to numa capabilities, like binding a thread to a node.
Interface of a plugin, that enumerates plugin values registered in this plugin.
Contribution of a plugin as a whole (coming with its own plugin values).
IPluginDefinition is the description for the plugin to add.
Implementation code can define specific plug-ins, such as indexer, storage, calculator, cache for each IActivePivot instance.
Builder for IPluginDefinition.
Builder step when a plugin key has been provided.
Builder step when at least one property has been provided.
ActiveViam Light Plugin Value Base interface.
Contribution of a plugin value to the plugin identified by the contribution interface.
Interface of an immutable point, expressed by its integer coordinates.
An aggregate store where each aggregate row is associated with a point in a point list.
Aggregates data from a point aggregate store into a reduced point aggregate store.
List of points with methods to access the internals of the stored points.
Filter retaining points to process.
An immutable IPointLocationReader.
A point location builder, based on a pattern.
A collection of location points.
An Object used to transport a IPointLocationList from one instance to another.
A pattern based on a range location.
A point (non-range) location reader.
A procedure that is executed on selected rows of a IAggregatesRetrievalResult.
The Point Value interface.
The key of a point value.
The point value dao interface.
Definition of a query for update on a parameter.
Container for point value updates.
Plugin interface for thread pool factory plugin.
Elements of data available following the array layout.
IPostProcessedAggregation.
Represents an aggregates retrieval for a post-processed measure.
A writer into the result of a post-processor evaluation.
IPostProcessor.
Container for the additional parameters of the constructor of a post-processor.
IPostProcessorDescription is the description class for a IPostProcessedMeasure.
A prefetcher is responsible for computing the dependencies for a post-processor execution.
This is the interface used by a post-processor to notify the core products that it needs the given aggregates to compute its result: this defines a request to the core product to prefetch the given aggregates.
An IContentService which stores its data in a subdirectory of an underlying IContentService.
A compiled AggregateQuery.
A compiled DistinctQuery.
A compiled GetByKeyQuery.
A compiled ListQuery.
Parent interface for all the prepared queries.
A FunctionalInterface used to prepare a statement associated with a JdbcTopic.
An object that holds a PreparedStatement.
Interface for expression that just transform a value into another value.
A primitive iterator interface.
An IAggregatesRetrieval specialized for primitive measures.
Interface to export and import the primitive retrievals computed by a pivot.
 
Interface of descriptions that support the capture of custom properties.
The IProperty interface generalizes the concept of properties that you can read or write to an object.
Interface to store an IProperty metadata.
Information about the publication of a message.
A store with some of its fields targeted by ICondition from an IRecordQuery.
Interface of monitors for query actions.
 
Internal interface for the query service.
Map queries executor.
Definition of REST API to query data from ActivePivot.
Context value to limit the results sizes.
A queries service allows to execute queries on the IActivePivot instances contained into the bound IActivePivotManager.
This context sets a time limit for queries execution.
Generic query to retrieve single or multiple objects.
IQueryable.
Specific type of IStreamedView based on a compiled query.
 
 
The query cache is a component instantiated by ActivePivot at execution of a query (and cleared after it).
The definition of the cluster to which a query cube belongs.
Description of a distributed application.
Contains the API to simplify setting the most common query cube properties.
Interface of monitors for query executor action.
 
Component responsible for query executions.
Responsible for validating and compiling.
Responsible for validating, compiling and running queries.
A context value keeping the logging level to monitor the query execution using Logger.
An object used for translating globals (query node) ILocations to local (data node) ILocations received from other IActivePivot's instances.
Component to translate a location list coming from a data cube to a location list in the query cube format.
The result of the translation.
A factory for creating translator allowing to translate locations and filters expressed on a global scope (query node) to local scope (data node).
A query plan retriever information.
A list of IOperation to perform to get the result of an IRecordQuery.
Enum of the different timing info for the query planning.
Find the plan with the minimal cost for an IRecordQuery.
API to easily test how measures are executed in the distributed layer.
Format of a query exposing records.
Able to run queries on a database with multiple parameters.
Able to run queries on a datastore with multiple parameters.
We can be run, producing a ICompletionSync.
We can run the query, producing a ICursor.
We have an acceptor, we can now run the query or set the other optional parameters.
Now that we have a compiled query, we need to define which parameters it should run with.
Now that the query base store and condition have been chosen, we need to decide which fields should be retrieved from the matching records.
We now have enough information to run the query.
Now that the query base store has been chosen, we need to choose a condition.
We have now a timeout, we can now run the query.
We can be run, producing nothing as an IPartitionedResultAcceptor will receive the results.
The tree containing all IQueriedStore.
Timer for an associated query.
Defines a handler for query timing.
Set allowing for random accesses.
Marker interface used by IVector implementations to indicate that they support fast random access: on such vectors, it is possible to use coordinate accesses instead of bulk methods at little performance cost.
Interface describing a range .
Interface to represent a range.
Union of disjoint closed ranges.
Interface representing a cursor over the content of an array.
Interface to hold a readable byte channel.
Definition of a read-only component linked to a cell containing some data.
Action to make a reference points to the new (point) dictionary of the target store.
A re-buildable component implements a rebuild method.
Action to rebuild an index dictionary (whatever the index type was and is now).
Represent a prepared aggregate query wrapper with a prepared query and the schema version at the time of compilation.
Represent a recompilable distinct query that wraps a prepared query and the schema version at the time of compilation.
Represent a prepared get-by-key query that wraps a prepared query and the schema version at the time of compilation.
Represent a prepared list query that wraps a prepared query and the schema version at the time of compilation.
Represent a prepared query wrapper with a prepared query and the schema version at the time of compilation.
A record of data.
Accepts the content of a record.
A block of records packed together in a compact structure.
Perform flattening of record via instruction.
The format of a record, how many fields, and the type of each field.
An interface for processing records from a transaction.
Interface for the base of an IMultiVersionRecordIndex.
Definition of a transaction on a Record Index.
Interface for virtual record representing the data of an underlying record.
Create procedures to find the rows having a given value in a IMultiVersionStorePartition.
Procedure executed over a collection of matching records.
A query that need to get the records that matched its selection criteria.
Record reader interface.
A store holds tuples of data that share the same attributes (the same columns).
An IVersionedRecordReader that can navigate through a set.
The base version of a multi-version IRecordSet.
An IRecordReader that can navigate through a set.
A view over a record set.
A stream of records which can be read by an IWritableRecordBlock.
Description of a reference that an owner store makes to a target store.
Builder interface for references.
 
 
 
 
Metadata of an IConcreteReference.
An application which can be refreshed.
 
Description of an agent registered to the ActiveMonitor server.
Represents a IGetAggregatesContinuousQuery that has been registered to the IAggregatesContinuousQueryEngine.
Interface for components which try to attach continuous queries to a IMultiVersionActivePivot.
Notify the end of registration attachment process.
Stream listeners can register and unregister their interest for the stream events published on a particular domain.
Base interface of a ActiveViam Registry Provides method to instantiate Types and retrieve plugins.
Lists a number of registry contributions.
Class responsible for creating a registry.
vectors that takes note of how many times its data is written to the datastore.
The dao interface for repository audit.
The repository cache rest service.
The repository cache service.
The daemon that connects to the repository to get all the parameters.
A component in charge of managing IParameterChangeListener for the IRepositoryService.
Spring configuration interface defining all DAOs available in Repository.
The repository rest service.
The repository result interface.
Definition of a repository service.
Spring configuration interface defining all services offered by Repository.
Definition of REST service of the Repository simplified for workflows.
This interface represents an XML/A request.
Extended plug-in responsible for unmarshalling requests.
An event that can reset the continuous query engine.
A context specialized for resolution.
 
 
Interface for a class that allow its user to reuse the same instances of Objects over time, thus avoiding too many instantiations, and sharing of resources across threads.
Reads a field value from the Response object (such as a ResultSet).
Extended plugin responsible for marshalling a result set to the response stream.
An interface to read the response to a query, received from an external database.
Functional interface to create an IResponseReader from the index of the field in the response.
A daemon dedicated to the IRepositoryService in charge of periodically checking effective parameters.
 
Base interface for result sets.
Reads a field value from a ResultSet current row.
Factory implementing how to create ResultSet readers.
Enumeration of external and local field type nullability states.
Interface that should be implemented by retrievals.
A visitor on an execution graph of aggregates retrievals.
A query plan retrieval information.
Enum of the different timing information for retrievals execution.
A merger retrieval for partitioned IAggregatesRetrieval retrievals.
Component that tracks retrievals results.
The base interface for the nodes of the RETURN clause of an mdx drillthrough statement.
A group of IIdentifier use for the RETURN part of an mdx drillthrough statement.
Interface for Mdx drillthrough functions.
Role context values spring configuration interface.
Mapping between rows numbers.
The modifiable mapping.
Describe which store should have its matching rows updated by cross-check when matching rows on a related store are found.
Tabular formatted result set.
Definition of a column.
Definition of the rowset.
A simple iterator on a rows list.
 
The ultimate goal of RT expression dependency is to describe how an expression depends on updates.
A component holding updated resources and able to compute their impact on Mdx continuous queries.
A cube which can be used for real time queries.
 
Interface representing a directory in AWS S3.
Interface representing an object in AWS S3.
Marker interface for vectors that contain a single value.
 
Represents an SQL identifier containing valid characters.
Saw writer.
Provider of IDatastoreSchemaVersion's dictionaries.
A session wrapper around a database selection that contains all the necessary data for each pivot of a schema.
Holds the selection session for an IActivePivotSchema and all the parts that can change together while the schema is running.
Interface for schema supporting aggregate tables.
Interface for schema supporting emulated time travel.
An IScopedAggregatesRetrievalResult contains multiple underlying IAggregatesRetrievalResult associated with different scope locations.
A procedure to be executed on each result of an IScopedAggregatesRetrievalResult.
The scoped cell set is the underlying storage for aggregates (post or pre) queries.
A location used as the scope location of a primitive retrieval.
 
Secondary index on fields of the records.
A transaction on this index.
A stable version of this index.
Interface for classes representing a snapshot of the security for a given user.
Security Facade interface.
Security webSocket handler Factory.
Interface representing the base of a select statement.
Specialization of IConverter to convert Select statement.
Represents a store having a set of its fields selected in a IRecordQuery.
Interface for executor that execute ISelectStatement.
Observes a set of fields belonging to several tables in a database and is notified when the content of these fields is updated.
The description of an ISelection.
Builder for a ISelectionDescription.
Step of the builder when it can alias fields.
Step of the builder when it is able to build a description.
Step of the builder when it has fields and can use other references.
Step of the builder that can chose between starting to describe an additional store reference to use for this selection, or building the current selection.
A FunctionalInterface used to handle field name collisions when retrieving all reachable fields.
Step of the builder when no fields were added, and some are required before it can build.
Listen to updates received by a IContinuousSelection.
A manager of selections, acting as an interface between listeners and transaction events.
A listener on a composite selection that is notified when the selections of this composite selection are altered.
Mapping between selections and their associated stream views.
 
Builder of ISelectionMapping.
Contains metadata about an ISelection.
Definition of a complete SELECT statement.
 
Class representing an alert.
The ActiveMonitor alert data access object.
Definitions of the actions that the ActiveMonitor daemon is asked to perform.
Class representing a ActiveMonitor event.
The ActiveMonitor event data access object.
ActiveMonitor event batch service.
Class representing a ActiveMonitor state.
Service helper providing methods to converts JSON values to Java objects in the context of fields from the underlying Database.
Interface for services accepting listeners on the information they managed.
Set of properties parameterizing the behavior of the XMLA Servlet.
This interface represents a set as computed as output of an mdx function.
The solution calculated by a ISetCoverSolver.
Solves an instance of the set cover problem.
Expander that is responsible for expanding possibly range tuples and sets into sets.
Action that enables the dictionary factory of the unique index used by a reference in the target store to create concurrent dictionaries.
 
A listener that can receive updates corresponding to shadow commits.
A selection listener that can receive updates corresponding to shadow commits.
A marker interface for listeners that can receive updates corresponding to shadow commits.
Class updating the shared members subtree at each transaction.
Parser of short fields.
Accessor that gives access to a single property of the input object.
A table column based on a single SQL column.
Interface to represent how to aggregate a single field.
 
A IRecordProcedure reading only one field of the record it processes.
Resolves the query for a single multi row vector table.
Format a single section of a number format.
Factory that of singleton instance.
Definition of an element that exists within a particular site.
Interface to track memory usage.
IsLeaf function.
 
 
Source interface that allows to fetch and listen data from a underlying source.
An ICubeFilter, compiled into a predicate using the IsPointGrantedFilterVisitor that can tell whether or not a point is granted.
This visitor returns a predicate that tells you whether or not a point is granted by the visited ICubeFilter.
Interface for spreadsheet service.
 
 
Composite database where the external part is a ISqlDatabase so it can expose their SQL generator for Aggregate Table.
 
A database based on an underlying SQL database.
A SQL data table.
Visitor interface implementing a workaround solution while waiting for support of pattern matching in switch in the JDK.
A version of a SQL database.
Factory of ISqlDataVersion.
SQL dialect used to build SQL queries.
SQL expression provider.
SQL Aggregation which can be factorised, i.e.
Field reference in a SqlQuery.
A field of a SqlDataTable.
Visitor interface implementing a workaround solution while waiting for support of pattern matching in switch in the JDK.
SQL flavor.
An operator which transforms fields into a SQL operation.
A part of an SQL query: it can be either some SQL string or a placeholder for data such as a column or a default value.
A re-aggregation function is used to transform an aggregate element (the one originally requested in the query) into a list of aggregated elements on the columns of the aggregate table.
Resolved query field.
A writable definition of a SQL database schema.
Field in select part of SqlQuery.
Visitor interface implementing a workaround solution while waiting for support of pattern matching in switch in the JDK.
Generate a SELECT IExecutableQuery from a SqlQuery.
Transaction manager for SQL database.
Factory to build a ITimeTravelService.
Accessor to the versions of a SQL database.
SQL table in query context which could wrapped a table or a sub query result.
A IAggregateProviderHolderVersion that supports squash operations.
An aggregates provider partition that contains both the underlying provider version and its associated thread pool.
A IVersion that supports the squash operation.
A custom function which returns whether the current version is the latest.
 
 
 
 
Definition of an attribute for a IMemoryStatistic.
This interface defines a generic statistic accessor.
Interface exposing methods to retrieve statistics on the database.
Exception thrown when the query runner cannot estimate the cardinality of a table column.
Utility to measure time required for certain tasks.
Indicate for a given duration the Level to be used by the logger.
Represent the static (not versioned) part of a store.
An action that can be run on a store.
The base version of an IMultiVersionStore that contains its current state.
A composite message channel in which each channel's destination is a different store.
Description of a table of the datastore.
Provide a smooth way to create an IStoreDescription.
The interface to show that one can add field to the description.
The interface to add statically defined keys.
Tag that the description can now be built if needed.
Tag to tell the builder that the store can compress its indexes.
Tag to tell builder to add some additional properties to the store description.
Enrich a store description with secondary index.
The interface to show that one can set the previous field as a key field.
Tag to enrich the store description with a NUMA selector.
The interface that allows to handle duplicate Key Fields.
Enrich the store description with the chunk size within a partition of the store.
Tag to define the store behavior when removing an unknown key.
Tag to tell the builder that the store should only take updates into account when the newly added record is different from the previously existing record with the same key-field values.
The interface to show that one can tag a field of the description.
A step of the fluent store builder.
A step of the fluent store builder.
A step of the fluent store builder.
A description of a vector field that is also an IStoreDescriptionBuilder.IKeyedTaggable.
Only the name of the store has been given, fields can be added.
The interface to specify what policy to use to pick on which NUMA nodes the data will be stored.
A remove unknown key listener can be added to the description.
The listener that receives unknown key events: whenever one tries to remove a key that does not exist in the store, this listener is called.
A step of the fluent store builder.
A step of the fluent store builder.
A step of the fluent store builder.
A description of a vector field that is also an IStoreDescriptionBuilder.IUnkeyedTaggable.
The description of a vector field.
The format of a store.
This interface is used to lock the the stores that are being used in a transaction.
A message that accumulates its data into a list of tuples.
A message channel whose destination is a store.
The factory that creates the channels between the topics of a data source and the stores of a datastore.
A message chunk that collects its data into tuples.
Represent the metadata of the store.
The content of a store partition.
A transaction over a partition, with access to the transactions of the components in the partition.
Materializes an update to a store partition, an update is composed of new added records, deleted records, or updated records.
Procedure to iterate over the impacts stored in a partition impact.
A stable version of a partition.
A view over the content of a partition.
A unit of work to be processed by the partition worker.
The type of work contained in a StorePartitionWorkUnit.
A partition operation validating the rows of the partition against the rows of another partition via references.
Builds an IOperation corresponding to a store search.
Statistics on a store modified by the transaction.
The store version interface.
A Stream is a registered component that publishes real-time events into the ActivePivot continuous query engine.
A stream is a stateful component publishing events to a publisher.
View of the database, allowing joins on table, streaming its content and changes to listeners.
Interface representing the registration of a IStreamListViewListener to a list query.
Base interface for events occurring on a stream.
Identifier used as key in IStreamRegister.
Container for information about a given location in the context of a Stream.
Procedure to call on each event published by the information container.
Keep snapshot stream information.
Interface of monitors for streaming actions.
 
Service providing control over streams.
The monitor for streaming service.
A listener that can register to a stream to receive its published events.
A stream listener listens to stream events from multiple streams, and from multiple domains.
Interface representing the registration of a IAsyncCompositeViewListener or IListViewListener to a series of IStreamedView.
Listen to updates received from a IPreparedListQuery.
Defines a stream node that is attached to a continuous query.
Specialization of IStreamIdentifier for IStreamNode querying a IContinuouslyQueryable.
Specialization of IStreamNode following a IContinuouslyQueryable.
A stream definition contains all the data necessary to the creation of a stream.
The various initial publication modes.
An enumeration that defines the initial state of the stream.
A stream publisher is a sort of sink specialized for stream publication.
A stream register can subscribe and unsubscribe IStream, arranging them into IStreamNode.
Helper service for dumping / reloading continuous queries from file.
A stream translator helps converting a stream to and fro a JSON representation.
A stream whose result can be filtered with IAxisRanges.
A formula specification makes the link between an identifier and an expression.
String literal interface.
 
A key-value property where the key and the value are strings.
Interface for queries whose content can be represented as a String.
An interface / plugin value to be able to instantiate a serializer which converts objets to string at execution time.
Transaction changing the Schema of the Datastore.
Transaction manager to edit the schema of the database.
The structural transaction listener is an object that allows to add custom triggers called when a structural transaction is committed.
Structural updater specific to an underlying transaction of a composite transaction.
Marker interface for objects used as key in the graph of an IDatabaseSchemaUpdater.
The plan is generated by an IDatastoreSchemaUpdater and contains the IUpdateActions to apply on the datastore.
A condition that asserts that part of the input object (as resulting of the accessor's introspection) respects a given condition.
Interface of a sub cube dimension, a dimension filtered with the restrictions of a sub cube.
Interface of a sub cube hierarchy, a hierarchy filtered with the restrictions of a sub cube.
The main component of the SubCube functionality.
A subCubeTree handles allowed path of operands defined for a given hierarchy.
An interface for a component that can visit ISubCubeProperties.
Interface for IntegerArray-based secondary indexes with a simple iterating method.
Definition of a sub-select within a global SELECT statement.
Whether this member represents one Unknown Member on its level.
Data elements organized in a table layout.
Provide utilities to create text tables.
The alignment of the content in the cells.
Constraints that must be fulfilled by all tables.
 
Interface representing a cursor over the content of a ITable.
Representation of a join between two tables.
A mapping between a field of the source table and a field of the target table.
SQL Generator for table management: create, insert, drop.
Permissions for the tables of the database.
Security for the tables of the database.
Builder for the ITableSecurity.
Description of the security applied to a given table of the database.
Error report of an external table.
Error report with additional information on rows causing issues.
This interface describes a tabular data set.
Interface for a component that has tags that it is interested in at a given level.
Interface managing task assignment to users.
Component in charge of publishing user tasks.
Service managing tasks created by workflows.
 
Service rendering templates for workflow messages.
An IThreadPoolSelector is able to return a ForkJoinPool for a given NUMA node ID.
Representation of a custom thread with vector allocators to it.
High level interface for time container classes that can export the time as a Java long.
A TimePostprocessor builds its query evaluation by applying a logic along a time hierarchy.
Kinds of "position type".
Definition of a time period.
Measure time elapsed between invocations of ITimer.start() and ITimer.stop().
A timestamp as produced by a TIMESTAMP aggregation function.
The raw data of the content entry with timestamp and lastEditor information, without any utility methods.
An extension of IBasicPathlessContentEntry which provides additional information about the last update on the entry: the last editor and the update timestamp.
An object providing a representation of the time.
Interface containing time=travel information.
Interface for a service to retrieve time-travel information from the external database.
Interface for database with arbitrary timestamp time-travel (BigQuery, Snowflake).
Utility fetching the related information.
Utility fetching the related information.
Interface for database with table version based time-travel (Databricks).
Token interface that is generic.
Contract for a data topic representing a particular type of data content (e.g.
A topic-wide parsing report, that contains the file-wide parsing reports for each file in the topic.
An interface for objects that need to be aware of the cube topology.
Interface for netty broadcast message that need to carry trace context.
Marker interface for queries that can be traced.
A transaction on a versioned Object.
Interface for members used axis hierarchy's transaction.
Interface of a multiversion component.
Internal base interface for View listeners.
A component that can write in an IDatastore via transactions.
Message exchanged between nodes in a distributed cluster, that represents a committed transaction in the sending node.
Holder for all the records modified by a transaction.
Handle the exceptions that can occur when executing transactions instructions and the transaction code around it.
Information about a transaction over an ActivePivot multiversioned component.
Details about the transaction.
A transaction listener is listening transaction managers in order to intercept every important action: When a transaction is started.
A transaction listener is listening transaction managers in order to intercept every important action: When a transaction is started.
The transaction manager handles the transactions for a transactional component.
The transaction manager of the data store.
The user-defined procedure used in an updateWhere method to perform the actual update in the selected store.
An operation that occurs during a transaction.
The component responsible for fetching an ITransactionContent and publishing it.
Interface of an object that can accumulate data in its own state and transfer this state into a target object.
A reader that can only read the value that has been set using the latest call to ITransformedReader.setTransformedValue(int, com.activeviam.activepivot.core.intf.api.location.IPointLocationReader, com.activeviam.tech.records.api.IRecordReader), which will typically transform the given underlying values into a single value to be read.
A procedure that transforms a record of underlying values attached to a location into a single transformed value.
Marker interface for aggregates that are only transiently stored in the cache (typically as placeholders).
Interface implemented by context values which should not be serialized.
A special interface for transient vectors.
The transition of a ATransactionalVersion.
Translates an input object into an output object.
Represent a tree.
A factory that create a node iterator from a given node.
A procedure for execution within a tree.
Unique identifier for a store in a query filtering or selection tree.
Interface for visitor to use when traversing a ITree.
Represent an element that can walk a ITree showing around an
invalid reference
IDfsTreeVisitor
the traversed nodes.
A tuple represents a multi-dimensional selection of members (possibly range).
Encapsulates the business logic to publish a series of tuples in the context of one message.
A tuple translator is a columnar translator that returns raw tuples (Object[] instances).
A Type contributions just defines the association of an interface and its implementation class.
Interface for elements that contains aggregated values and give the types of the inputs.
A table which knows the column types.
Common interface for all the DTOs with a custom data content identified by a key.
Member supplier with a custom output type.
Interface for plugin values implementing IWorkflowProcessExecutor from IEntityWorkflowConfiguration.
Base interface representing a rooted tree that does not give any particular meaning to its edges.
A tree node that can access both its parent and its children.
Unique index on fields of the records.
A transaction on this index.
A stable version of this index.
Expression representing a member that does not exist in the pivot.
Interface for checked and unchecked exceptions to be thrown when searching for an olap element (see IUnknownOlapElementException.OlapElementType) in the cube that does not exist or is currently missing.
The type of olap element that is missing.
A table with a columnar layout, that exposes its columns as arrays.
Extends the
invalid reference
com.activeviam.database.internal.schema.IInternalDatabase.IVersionAccessor
to allow it to manipulate unpublished version.
Interface representing a function call after the parsing of the Mdx.
Represents a string path that cannot be matched to actual members of a IHierarchy.
An action that throws an UnsupportedCubeAlterationOperation.
This interface checks if an ITuple should have the UPDATEABLE cell property.
Context value for IUpdateableCalculator.
Actions created by the IDatastoreSchemaUpdater to update the datastore.
Annotation for methods that can only be called once all the actions are created.
Interface for IUpdateAction visitors.
Interface representing a DAO that can perform update actions.
This action is created when fields are added to/removed from/transformed in a store.
Interface for actions related to a store index.
This action is created when indexes are added/rebuilt/removed from a store.
An action to update measures and/or procedure in a cube.
Action to update the partitioning of the datastore.
A sub partition version contains an IStorePartitionVersion, its parent version, and the DatastoreVersionKeys.VersionPartitionKey.
An action to update a cube.
Visitor for manager structural updates.
An action to update an IActivePivotSchema.
The object that decides what to do with the actions.
An update request provides: from: the known or origin state of the data when the update is requested to: the new state of the data that is requested.
Update selection action.
Marker interface for actions that update a store.
Class carrying information about the context in which an update-where operation is compiled.
POJO that contains the information to execute an update where action.
Factory to build update where procedures.
Definition of a URL builder following Atoti conventions.
Interface representing a builder with enough information and options to build an URL.
Interface for a buildable builder with at least API type.
Interface for a buildable builder with at least prefix.
Interface for a buildable builder with at least service name.
Interface for a buildable builder with at least path information.
Interface for a buildable builder with at least API version.
Base interface for an URL Builder.
Interface offering to set the hostname in an URL.
Interface allowing to define the path parts of the URL.
Recursive interface allowing to define prefix for the URL.
Interface to define the name of the service API exposed.
Interface offering a method to define the version of an API.
Interface allowing to choose the type of API to target.
Interface offering option for a trailing / in the URL.
Class tracking usages of objects.
Context value carrying the name of the current user.
Interface for aggregate functions whose aggregation handle multiple fields as source.
Interface for user-defined aggregations.
This interface wraps the UserDetailsService provided by spring.
Atoti definition of user task provided by Actitivi.
Extract a value from context.
A procedure that is executed on each non-null value of a IAggregatesRetrievalResult.
A procedure that is executed on selected rows of a IAggregatesRetrievalResult.
Specialization of IParser managing parameterised key (e.g.
A plugin that can change on some parameters provided in the description.
A vector is equivalent to a standard Java array in terms of interface.
A vector allocator is responsible for allocating vectors of a given length.
An IArrayWriter that can store vectors.
A static binding between two types of vector implementations.
An Object used to create vector bindings between two implementation classes of vectors.
A chunk that is able to store vectors.
Creates calculator which convert result set array to IVector.
An IFieldDescription for a vector field.
A consistent version of a base Object.
Access to database versions.
ActivePivot versioned continuous query update.
Procedure executed over a collection of matching versioned records.
A record holding the version number at which it has been inserted or removed.
An ordered history of versions, with the ability to retrieve the version that is valid at a given epoch.
A node containing a version.
A procedure that can be run on a IVersion.
Pivot latest version provider.
Definition of the REST service returning the list of services exposed by an application.
Marker and basic API of an IVersion component capable of rewriting itself and all its underlying version components at a new epoch.
Marker interface.
General interface for components that can process the events of a WatchKey.
Watcher service to subscribe to the events of a path.
Interface of monitors for WebSocket actions.
 
Interface for configuring a websocket engine.
Factory for wrapping Spring's websocket sessions into ActivePivot's own websocket sessions.
Part of a ICaseExpression.
Interface for the step after providing the IAnalysisHierarchyDescription.
Interface for the step after providing the IHierarchyDescription.
Interface providing query plans.
Interface for classes representing a workflow configuration.
Interface defining a way to retrieve workflow configurations for custom objects that internally stores a workflow schema.
Definition of the payload passed along with each workflow.
List of possible variable names used in the workflow.
Definition of workflow process.
Completion Call Back.
Interface for an executor that fluently leads a user to execute a workflow for a given entity.
Executor with all information for execution.
Executor step to configure an action to execute, as well as the mandatory aspect of the action.
The workflow rest service.
Representation of a workflow schema.
DAO for workflow schemas.
Service orchestrating all operations related to workflows.
List of ActiveMonitor predefined workflow entities.
List of ActiveMonitor predefined Workflow actions.
Instance handling the execution of a workflow.
An editable manager structure.
Editable structure of an IActivePivotSchema.
An analysis hierarchy info with the interface to write elements into it.
An array with the interface to write elements into it.
An indexing structure using bitmaps to resolve point queries and range queries.
An array with the interface to write elements into it.
A IByteRecord that is also a IWritableRecord.
Definition of a read/write component linked to a cell containing some data.
A dictionary into which new keys can be written, using the map function.
Specialized dictionary interface for dictionaries of Doubles.
Specialized dictionary interface for dictionaries of Floats.
Specialized dictionary interface for dictionaries of integers.
Specialized dictionary interface for dictionaries of Longs.
Read and write permissions for the fields of the datastore.
A writable IIndex.
A writable IIntegerArray.
A writable ILongArray.
Editable structure of a cube.
A record that can be written into, using its IArrayWriter interface.
A writable IRecordBlock.
A shared IWritableRecord to be used on a set, to save memory.
A table with an interface to write elements.
Editable permissions for the tables of the database.
Measure provider supporting the definition of new measures on the fly.
A web socket session.
A component in charge of handling various IWsSession of a user registered through a single websocket.
Interface of a socket endpoint for a specific topic.
Represents an attribute of a complex entity like a rowset.
Represents a complex xmla type (i.e.
Context of execution of an xmla request.
Type of XMLA Session Request.
 
 
This is a temporary class to help with the migration from mondrian to the new engine.
Class intercepting XMLA queries to offer the possibility to rewrite the query.
Plain object defining a rewritten query.
 
Definition of a provider property.
Access type for the property.
Usage for the property.
Describing listeners to be called at different state of a Xmla Request processing.
Interface representing simple (as in not complex) types.
A type in XMLA.
Jackson's serialization.
 
Executes a AggregateRunnableQuery delivering result in an acceptor.
 
JDBC SQL Generator for InternalAggregateTable.
 
Jdbc default column calculator for array rows.
JDBC discoverer for array types.
Column calculator which converts a JDBC Array to an Atoti IVector.
 
Wrapper around a Connection.
 
Counted completer which executes a runnable query and feeds the ICursor result to provided IAsyncResultAcceptor.
Generates an ICursor from a result set.
An database based on data stored in a JDBC database.
 
 
 
JDBC data validator.
Version for a JDBC database.
Jdbc default column calculator for native rows.
Discoverer for JDBC databases.
 
Reads a JDBC array into an Atoti IVector of doubles.
Class fetching the time-travel information from a JDBC database.
Class representing a column in a JDBC database.
Event notifying that a JDBC resource has been successfully fetched.
Event notifying that the fetching of a JDBC resource has failed.
POJO holding information about a fetch on a Jdbc source.
 
Reads a JDBC array into an Atoti IVector of floats.
Class used to run a get-by-key query for JDBC databases.
Reads a JDBC array into an Atoti IVector of integers.
Validates a join between 2 tables.
 
Reads a JDBC array into an Atoti IVector of longs.
This factory allows to retrieve only the tuples that are present in the store fields.
Validates a multi-rows vector table in a JDBC database.
Execute a multi-step AggregateRunnableQuery delivering result in acceptor.
Represents a JDBC object, with its value and its optional JDBC type.
Reads a JDBC array into an Atoti IVector of Object.
Component creating parsing tasks from result set.
Information about the publication of a JDBC message.
Generic implementation of AQueryComputer for JDBC databases without time-travel.
Task producing a ResultSetHolder from a given jdbcWorker.
Factory and executor of a JdbcQueryExecutionTask.
Implementation of an SQL query runner for JDBC databases.
Utilities for JDBC queries.
Functional interface to represent a Consumer of ResultSet which can throw SQLException.
Executes asynchronously a JDBC query in a specified executor with an external timeout.
 
Utilities for JDBC Calculators.
Enum indicating the behavior when reading an array full of nulls, to produce a vector of primitives.
 
 
 
Executes a runnable query and return JdbcRunnableQueryExecutor in synchronous fashion.
A basic IJdbcSource implementation.
 
Basic implementation of IJdbcSourceBuilder.
Util class for JdbcSource metrics observability.
Class transforming a query into a statement.
 
An ITopic for Jdbc source.
Deprecated, for removal: This API element is subject to removal in a future version.
This class is deprecated and will be removed in a future version, it is considered an internal API.
Deprecated, for removal: This API element is subject to removal in a future version.
This class is deprecated and will be removed in a future version, it is considered an internal API.
 
Default implementation of a tuplizer for JDBC.
Version accessor of a Jdbc Database.
A specialized ClusterView for AJGroupsMessenger, which enables to link cluster's members' names and their IAddress.
A point aggregator specialized for JustInTime retrievals.
A retrieval for a Just In Time aggregate provider.
An acceptor for the results of the JIT query on each partition that completes the associated retrievals using the query results.
Annotation marking a method returning a value to expose as a bean attribute.
 
Annotation marking a method that exposes the children MBeans.
JMX Enabler that can expose a monitored component as a dynamic JMX bean, and register it automatically from an MBean server.
Holds a map of children monitor component so that with respect to their parent monitored component, they appear nested below a common name.
Annotation marking a method exposing a MBean operation.
Annotation defining additional JMX information for a parameter of a JmxOperation.
Aggregated measure based on the standard aggregation of input values.
Basic implementation of CopperStore.
Immutable description of a join between two tables.
 
Implementation of CopperStoreField where the mapping is fully materialized through the join key.
Representation of a Copper join with a fully resolved mapping.
Description of a Join Measure.
Represents the path from an initial table to another table that is reachable through table joins.
Comparator sorting JoinPath setting first values with short paths then sorting the join names.
Represents an edge of join tree, in between two JoinTreeNode.
Represents a node of a join tree.
SQL Join types.
 
The JSON Arrow output configuration.
The required description of a branch for its creation.
Description of a branch of the datastore.
The permissions (readers and writers) for a branch.
The JSON cell data.
The cell set data builder.
The JSON cell set data.
The cell set data builder.
Class in charge of transforming a condition written as a series of JSON objects into a Database condition.
Wrapper of entries adding annotations to be able to serialize as JSON.
An extension of ContentTree that can be serialized as JSON.
DTO representing a update of an entry in the Content Server.
DTO encoding a context value.
Json represents a continuous mdx query in a request from Atoti UI.
 
The JSON CSV pivotTable output configuration.
The JSON CSV tabular output configuration.
Action to edit a table.
Enum of the various possible actions.
DTO encoding the structure of a database.
The description of an edit of the database.
Context for the edit query.
Object representing the characteristics of a given field of the database, for JSON usage.
Object representing a database join for JSON usage.
Object representing a query for the REST API, for JSON usage.
Object representing a query result from the database REST API, for JSON usage.
Utility class which contains static methods for translating REST API related Json DTO's to their database equivalent.
The JSON Data export order.
DTO defining the locale to use.
The JSON permissions data.
JSON representation of the discovery and its catalogs.
The JSON discovery builder.
Reads a JDBC String, representing a Json array, to an Atoti IVector of doubles.
 
The drillthrough data.
The drillthrough data builder.
Utility class to create JsonTabularHeader objects.
Monitor for location-based drill-through header query action.
Monitor for location-based drill-through query action.
A data object for JSON streaming of updates for a continuous drillthrough query.
The drillthrough data builder.
Implementation of ASingleEndpoint using JsonWsSessionMultiplexer.
Our standard error, that can be easily serialized as a JSON object.
The minimal info about an error, e.g.
Class handling all exceptions raised in any REST method.
Monitor for Executor Statement query action.
 
Class to define file configuration.
Reads a JDBC String, representing a Json array, to an Atoti IVector of floats.
 
 
Reads a JDBC String, representing a Json array, to an Atoti IVector of integers.
A serializer which is based on the JacksonSerializer, and which is specialized for monitoring logs.
Reads a JDBC String, representing a Json array, to an Atoti IVector of longs.
 
The JSON mdx definition statement.
The JSON MDX query.
Monitor for Json MDX query action.
Request DTO to execute an MDX query and return its query plans.
Monitor for Json MDX query plan action.
Basic implementation of the helper interface.
Reads a JDBC String, representing a Json array, to an Atoti IVector of Objects.
 
 
Describe the pagination of a query result.
The JSON query plan data.
Query plan DTO builder.
The JSON query service.
The JSON containing a range of indexes for an axis.
The response that should wrap any object returned by our JSON api.
A Json response that also contains the query id that is at the origin of this response.
Annotation to mark a class as a REST controller.
Helper to convert streams and queries to JSON-friendly objects and vice-versa.
A query that represents an action on the streaming websocket : register a query, unregister, pause, resume.
Enumerates the actions that can be done.
DTO defining the registration of a Continuous Query running an MDX query.
JSON-friendly holder for a list of streams indexed by their id.
A holder for a JsonStreams for JSON conversion.
DTO encoding an update request for a given stream.
Object representing the metadata of a table, for JSON usage.
Result of the update for a specific table.
Simple java object that represents tabular data, e.g.
Simple data object for JSON representation of a table header.
DTO for JSON message received by the websocket centralized endpoint.
The span log data.
The trace data.
An interface for json objects that explicitly give their type, so that it can be used in the json enclosing the serialization of that particular object, as a hint to how to deserialize this object.
Default implementation of AWsSessionMultiplexer using Json messages.
A retrieval for a Just In Time aggregate provider.
Base of the Just In Time aggregate provider.
The context of the execution for a query on a JustInTimeAggregateProviderBase.
Version of the Just In Time aggregate provider.
Utility class for handling the conditions of the JIT.
Builder for Just In Time queries.
A procedure used to expand a given location using the current hierarchies and the points stored in an aggregates collector.
 
A transaction on a Just In Time aggregates provider.
Check the health of the current JVM, reporting various statistics about memory usage and garbage collection.
Snapshot of the monitored statistics.
An Authentication implementation for JWT authentication.
AuthenticationProvider which supports the token created by JwtService.
 
An authenticator which uses the JWT method to authenticate the calls.
Spring declaration of the IJwtService and its associated AuthenticationProvider based on RSA key pair.
Processes a HTTP request's JWT authorization headers, putting the result into the SecurityContextHolder.
Configuration properties for the legacy JWT authentication.
Properties related to the claims in the JWT.
 
Properties related to the keys used to sign and verify the JWT.
 
Configuration properties for the JWT authentication.
 
Properties related to the claims used in the JWT.
 
 
Properties related to the keys used to sign and verify the JWT.
 
Configuration class exposing REST services for JWT authentication.
Wrapper for a IJwtService which exposes a REST API.
Object used to create the JSON response of JwtRestServiceController.Token.getToken().
A IJwtService which creates Signed JSON Web Tokens with RSA keys.
 
Authenticator based on JWT with a predefined user.
Utility methods related to the JWT authentication.
A IEpochManagementPolicy that does nothing automatically.
A IEpochManagementPolicy that intents to keep only some latest epochs, according creation time criteria and/or number epochs criteria.
Exception thrown when an attempt is made to store two records with the same values on a unique index different from the key index.
Build a human-readable key constraint violation message, from the human-readable details.
Basic implementation of IKeyEventContext based on an IStoreMetadata.
The key of a record.
The record format of a record key.
Statistics about a batch.
A key-value batch result implementation.
A column calculator that computes the value part of a key-value entry.
A class that contains both the key and the value of an entry.
Base POJO channel factory IStoreMessageChannelFactory.
A result batch.
Basic implementation of IKeyValueSource.
Class containing the configuration elements of a KeyValue source.
Factory to create a new IKeyValueSource.
Registry contributor for the key-value-source module.
Statistics handler for the key-value source.
Topic for a Key/Value source.
Component transforming a key-value pair into a tuple.
A collection of keywords.
Implementation for IKpiDescription.
Enum of the properties available for a KPI.
The kpi discovery.
The kpi discovery builder.
Quick implementation of the description.
KPI Function returning the expiry measure of the KPI if defined.
The root point for plugin values on IKpiFilter.
Class defining the core KPI filters availables.
Definition of the formula used to compute the goal of a KPI.
 
Class describing a KPI that contains MDX expressions.
The kpi monitor config contains the initial config in order to create a kpi monitor.
The modes for this kpi type.
Implementation of AKpiMonitoringStream with default handling of errors.
Quick implementation of the description.
KPI Function returning the start measure of the KPI if defined.
Definition of the formula used to compute the status of a KPI.
 
Description for the formula used to compute a KPI trend.
 
Set of utility classes and functions to work on KPIs.
Utility for KPIs whose status will be mapped to a 3-level scale.
Definition of the formula used to compute the value of a KPI.
 
Lag function.
A solver of the set cover problem based on the lagrangian relaxation.
 
The LastPeriods MDX function.
 
An implementation of ILatch.
A pool that can be used to allocate and recycle resources.
A ChunkedColumn where the underlying chunks are lazily allocated the first time they are written to.
A generic LazyChunkedColumn that is fully defined by the IGenericAggregation it holds.
A composite column with chunks.
Implementation of the base for a MultiVersionLazyDeleteLinkedIndex.
Single version of an MultiVersionLazyDeleteLinkedIndex.
Lazily builds an Object of type T, if and only if LazyObject.get() is called and the constructor returned a non null result.
 
 
A simple iterable window over a collection of tuples (possibly not materialized).
 
Cursor.
 
 
Lead function.
Analytic navigation measure.
Factory for the LeadLagMeasure.
Builder to create a LeadLagMeasure.
Post processor that shift aggregates toward a relative position along a hierarchy.
Aggregate provider base similar to BitmapAggregateProviderBase, but using only the point index (no actual bitmap index).
A AIndexedAggregateProviderTransaction specialized for the LEAF aggregate provider.
Copper measure with dynamic aggregation on some levels.
A bitmap matcher which internally uses a point index and calculates the bitmaps instead of storing and retrieving them like the QfsBitmapIndex does.
Dynamic aggregation post processor that for each queried aggregate counts the number of leaves that contribute to that aggregate.
A procedure used to expand a given location using the current hierarchies and the points stored in a BITMAP aggregates collector.
A filter visitor that can compile an ICubeFilter into a IBitmap.
A post-processor used to retrieve a measure at a lower level and aggregate it with a SUM up to the location it has been asked for.
LeafLevels prefetcher aims to prefetch all leaves aggregated values on a dynamic aggregation context.
Leaf operations of a ConditionTree.
An implementation of AIndexedPartitionedAggregateProviderTransaction.AIndexedCompiledFilter for the Leaf Aggregate Provider, associated with the LeafFilterCompiler class.
The procedure for joining (left join) an isolated store to the cube's selection.
Plugin factory.
Context IAnalysisAggregationProcedure to make joins between an ActivePivot result and Database results easy.
Class representing a cell with content displayed with a padding of n chars on the left.
Represent an old ActiveViamProperty that no longer exists (i.e.
 
Level Discovery for SOAP webservices.
The level discovery.
The level discovery builder.
Implementation of IApplicationDictionaryProvider.IDomainDictionaryKey for Level-related dictionaries.
Explicit implementation of the ILevel plugin.
A measure which filters values of another measure based on one condition on cube levels.
Factory for the LevelFilteringMeasure.
A filtering post-processor which filters locations based on one condition per level.
 
The identifier of a level in a cube.
Default implementation of ILevelInfo.
This comparator wraps a given comparator that may not support DataMembers and makes it possible to handle them too.
Builder for LevelInfo.
A Comparator for level info based on their ordinal's natural order.
Object that gathers IAxisLevelDescription of given level as well as the IAxisHierarchyDescription, IAxisDimensionDescription it belongs.
Object representing a level of the cube analyzed by a SmartAggregationEngine.
The Levels.Count MDX function.
 
Levels function.
Representation of the mapping between a cube level and a field reachable from a store.
Data class to hold a level name and its type.
Wrapper class to hold the levels and their types grouped per tuple member.
Copper measure representing the values of the members on a given level.
Factory for LevelValueMeasure.
An operator that produces a function able to read the coordinates of a given level from an ILocation.
Mapping to the C lgrp_affinity enum available in lgrp_user.h.
Mapping to the C lgrp_content enum available in lgrp_user.h.
Mapping to the C lgrp_lat_between enum available in lgrp_user.h.
Mapping to the C lgrp_mem_size_flag enum available in lgrp_user.h.
Mapping to the C lgrp_view enum available in lgrp_user.h.
Default implementation of ILicensingService.
A condition that will check, for a given record, if its attribute at the selected index matches this condition's operand, regex wise.
Regular Expression matching condition.
Compile condition for $like.
A ConditionScanProcedure that limits the number of rows that can be returned.
A ByteArrayOutputStream that throws an ActiveViamRuntimeException when reaching the selected size limit in order to avoid OOM Errors when the underlying byte buffer overflows.
Deprecated, for removal: This API element is subject to removal in a future version.
Not used, this was initially intended for the Python API
Column calculator that returns the index of the line that is being parsed (within the current file).
Line reader implementation.
An object representing a link.
Object containing the data necessary to update the distance between a target cluster and a new cluster resulting from the agglomeration of the two closest clusters.
Object containing all the cluster pairs ordered by intra-pair distance.
The LinRegPoint MDX function.
This class provide access to native Linux NUMA functions.
Utility class to listen to channels for real-time updates.x.
POJO contains listener notification.
A POJO that contains required information for IContentService.register(String, String, IContentListener) or IContentService.unregister(String, boolean) a listener to the content service.
Component managing streaming from a Database to listeners.
 
Property used to access the last element of a list.
Property used to access an element in a list at a specific index.
A query to retrieve several records from an IDataTable.
 
 
 
 
 
List query ready to be run.
A set of utility methods for lists.
ListIterator class providing a crossing of a list in reverse order with the same API as a classic list iterator.
Builds a ArrowVectorReader from a list vector.
 
 
Implementation of literal.
Implementation of the literal plugin for ActivePivot.
Base implementation of the literal type.
The literal type plugin.
A cluster of messengers that enables them to communicate together.
A specialized ClusterView for LocalCluster, which enables to link cluster's members and their localAddress.
Context values getter for local use.
Wrapper for an Arrow Vector of LocalDate.
JDBC calculator to change a Date into a LocalDate.
Parser for LocalDate objects.
Wrapper for an Arrow Vector of LocalDateTime.
JDBC calculator to change a Timestamp into a LocalDateTime.
Parser for LocalDateTime objects.
Representation of all the dictionary keys of a given domain dictionary provider that are impacted by a transaction's commit.
Implementation of AI18nConfig that uses the internationalization files from the resources.
A distributed messenger that only supports local communications.
IAddress use by the local messenger.
Parser for LocalTime objects.
This class implements the ILocation interface with a plain array representation of the coordinates.
Simple builder of location.
Cell set implementation relying on a map of locations linked with an aggregate store.
Implementation of ILocationConverter.
Implementation of ILocationConverterFactory.
The location data.
 
A dictionary that maps locations.
Helper class for location impact computation.
Iterates over expansion levels using ordinary member iterators on the hierarchies.
Generates all the point locations associated with a range location using a custom expansion procedure.
Standard location formatter, used by default by ActivePivot to convert locations into text.
A parent location with respect to which child delta locations can be expressed.
Helper class to convert locations to MDX tuples based on an MDX cube and a tuple template.
Utility methods related to the usage of locations.
 
Deprecated, for removal: This API element is subject to removal in a future version.
Use the logback logger directly
 
Implementation of the IMessageHandler to log the feed loading in an external file upon completion.
MDX function compute the natural log - base e - for any value.
Unique definiton of Log function.
A wrapper around a ForkJoinTask that logs any Exception thrown by the underlying ForkJoinTask.
A completer to log a Get Aggregates Query timing, after it completes.
Class containing logger names constants.
The health event handler responsible for logging activepivot health events.
Automatically sets up APM logging, unless disabled by property.
The health event handler responsible for logging cluster health events.
The health event handler responsible for logging composer health events.
Configuration class to initiate the necessary tracing components.
Class for holding the argument keys in json logs.
The health event handler responsible for logging CSV Source health events.
The health event handler responsible for logging datastore health events.
This handler logs all health events using JUL.
Implementation of a IHealthEventHandler focusing on JDBC source events to log them.
Implementation of IListenersExceptionsHandler that logs as severe the exception thrown by the listener.
Basic implementation of the IMdxEventHandler interface.
Miscellaneous utilities for logging purpose.
 
Base class for the logical conditions.
Explicit implementation of the ILogicalCondition plugin.
A combination of two CopperLevelCondition represented by a logical operation on two sub-conditions.
A condition node that holds a boolean operator (OR, AND or NOT).
Condition tree visitor flattening AND(A, AND(B, C)) (same with OR) following the associativity of boolean algebra.
Rest controller serving resources related to the login / logout process.
Class of constants for routes related to the login and logout standard configuration.
Logback converter to retrieve the instance name of the pivot.
A log message handler.
Override to add more logging when a query is sent and when we receive the results.
Logback converter to retrieve the current thread generating the log.
Logback converter to retrieve the current user generating the log.
An ALongArray that stores its values in an IChunkLong.
Wrapper for an Arrow Vector of Long arrays.
A cursor over a long array with specialized methods.
 
The base implementation of an ILongArrayTransaction.
 
A long array version defined by a base reference array and some delta mappings that override the mappings in the base array.
Wrapper for an Arrow Vector of Long.
Basic implementation for a long blocked vector.
An action to be executed on some data that can be divided into ranges.
A helper Object that creates sub-tasks used for processing a range of the data.
Inner exception class grouping multiple exceptions encountered while executing the LongBoundedAction inside the suppressed exception list.
Implementation of a read-write cell supporting data of type long.
Compares two Long objects.
A contextual and cancellable RecursiveBoundedAction.
Base class for translators of long integer context values.
Dictionary implementation specialized for Long data type.
Basic implementation for a long fixed block vector.
Reads a Long from a reader containing a JDBCType.DECIMAL.
 
LONG aggregation function.
The long sum binding for vectors.
Parser for long fields.
Offers local streaming registration, while relying on a long polling service.
Factory implementation of the long polling service.
Exception thrown by the Long Polling Web Service.
Properties for configuring the Long Polling Service.
A re-aggregation function for a LONG.
 
Special parser for vectors of Integers.
Default implementation of ILookupBehavior.
Translator for the ILookupBehavior context value.
The MDX look up function.
Class defining the LookUp function with one extra optional argument allowing to define the default value.
Handler dedicated to the LookUpPostProcessor.
Implementation of IMdxRegistrationDecorator specialized for the LookUpFunction.
LookUp Post-processor.
Stream listening on any change in the parameter repository.
Implementation of a IMdxEqualityTester discarding white spaces when test MDX statements for equality.
The complement of the GreaterEqualCondition.
The complement of the GreaterCondition.
An eviction cache with a LRU policy.
An eviction cache entry destined to be the head of the eviction list.
An entry that doesn't hold any values.
Compression using LZF algorithm.
Matcher that uses a hashtable of integers.
A DSL to configure the security for interactions between client applications and Atoti applications.
Usage scopes for the machine-to-machine DSL.
Service allowing to clear stored data.
Implementation of IWorkflowService adding workflows on operations changing data.
Immutable graph representation of a Manager.
A plan which makes a sequential visit of the
invalid reference
actions
.
Converts the cursor in a map containing the field name as a key and the value as the value.
Default implementation of IMapDrillthroughQuery.
Converter to convert a IMapDrillthroughQuery can be converted into IDrillthroughQuery.
Monitor for map coordinates-based drill-through query action.
The stream for IMapDrillthroughQuery.
A simple parser that retrieves a value from a map by its key.
Default implementation of IMapGetAggregatesQuery.
Converter to convert a IMapGetAggregatesQuery can be converted into IGetAggregatesQuery.
Monitor for map coordinates-based GetAggregatesQuery.
The stream for IMapGetAggregatesQuery.
A Tuple (array of Objects) that is accessible from the java.util.Map interface.
Mapped tuple enricher implementation.
Mapped tuple factory implementation.
A post-processor that applies a function on its underlying measures.
Representation of the join mapping between store field and cube levels.
Class containing JoinType and default values for a given Copper join operation.
Property used to access an element in a map.
Deprecated, for removal: This API element is subject to removal in a future version.
This is an internal API that should not be used by clients.
This procedure is similar to the LISP function map.
Deprecated, for removal: This API element is subject to removal in a future version.
This is an internal API that should not be used by clients.
A values supplier mapping the values of an underlying values supplier.
Copper measure which aggregates the value of its underlying measure up to the top-level default member for all hierarchies, except for a few specified hierarchies (called the marginalized hierarchies).
Factory for the MarginalDrillupMeasure.
An file input stream class that supports marking, using its underlying channel.
Print a cell set in a markdown format that can be understood by Confluence to quickly add tables representing these cellSets in Confluence articles.
Proxy to know if the specified positions has been written to.
A Copper measure that creates MaskPostProcessor to only compute aggregates if the required levels of its underlying measure are expressed in query's location.
Factory for the MaskMeasure.
A post processor masking its underlying measure if some levels are not provided in the input location.
Base class for matching conditions.
Explicit implementation of the IDimension plugin.
HashMap based implementation of an IMatchingRowsHolder.
Basic implementation of a IMatchResult.
IRowMergingPolicy used when performing a query.
Append only MAX aggregation function.
Max function.
Append only MAX aggregation function.
A heap with the ability to store primitive doubles.
A heap with the ability to store primitive doubles.
A heap with the ability to store primitive floats.
A heap with the ability to store primitive floats.
A heap with the ability to store primitive ints.
A heap with the ability to store primitive ints.
A heap with the ability to store primitive longs.
A heap with the ability to store primitive longs.
Light plugin value for the Max IAggregationFunction.
MAX Aggregation function history.
A re-aggregation function for a MAX.
Simple comparator for sorting MBeanAttributes alphabetically.
Simple comparator for sorting MBeanOperations alphabetically.
Print a MDDataSet into a table.
 
 
Implementation of multidimentional elements (members or cells) properties.
Http://technet.microsoft.com/en-us/library/ms126032.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126271.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126180.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126257.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126062.aspx.
 
 
Http://technet.microsoft.com/en-us/library/ms126243.aspx.
Http://msdn.microsoft.com/en-us/library/ms126258.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126038.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126192.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126178.aspx.
 
 
 
Http://technet.microsoft.com/en-us/library/ms126046.aspx.
 
Http://technet.microsoft.com/en-us/library/ms126309.aspx.
 
 
Http://technet.microsoft.com/en-us/library/ms126290.aspx.
 
A measure that has been added on the fly.
Iterator on the cell of a MDX result.
 
Plugin implementation for storing mdx cell properties plugin values.
The basic result of an Mdx query.
Axes iterator for MdxCellSet which returns IMdxMemberProperty property.
Axis in a select result.
Provide information on MDX result based on MdxCellSet and return property of type IMdxMemberProperty.
A class to build an ICompilationMatcher.
Parses a compilation pattern and transform it into an ICompilationMatcher.
The class responsible for compiling some MDX patterns into a postprocessor.
A matcher that accepts mathematical formulas and builds the corresponding expression for the formula post-pro, and store the result in MdxCompilers.FormulaMatcher.FORMULA_ARG.
A basic transformer that transforms its child matcher into a postprocessor using the arguments retrieved by the matcher.
Implementation of the IMdxContext context value used to configure the MDX engine.
 
Utility class for MdxContext's properties.
The context value translator associated with the IMdxContext context value.
A set of utilities for IMdxContext.
An exception indicating that an MDX continuous query has failed.
Listener for the IMultiGetAggregatesNotificationQuery created by the MdxRegistration.
Base implementation of IMdxCube.
Implementation of an index for expressions.
Factory of CubeFormatter that only used formatters and captions defined in the mdx context.
Basic implementation of a notifier.
Utility functions on IMdxCube.
A component in charge of handling the main listener of an MdxRegistration and additional decorators.
Base implementation for IMdxDimension.
DTO class representing an MDX drillthrough headers query.
Monitor for location-based MDX drill-through header query action.
Monitor for streaming of MDX drill-through headers query action.
DTO class representing an MDX drillthrough query.
Monitor for location-based MDX drill-through query action.
Monitor for streaming of MDX drill-through query action.
 
 
The stream for IMDXDrillthroughQuery.
 
A translator for mdx drillthrough stream.
 
Converter to write the result of a mdx drillthrough query in a csv format.
 
 
 
 
Health event fired when a MDX statement affecting the mdx context was performed.
This event is used to know if axes with NON EMPTY must be recomputed.
MdxException.
A formula member.
Base implementation for IMdxHierarchy.
Registry contributor for the MDX impl module.
Base class for case insensitive indexes.
Base implementation for IMdxLevel.
 
 
 
 
 
 
 
The DisplayInfo property contains informations about an AxisMember.
 
 
 
 
 
Since we do not support composite key, the result of this property is always the same as the KEY property.
 
 
 
 
 
 
 
 
Statistics about the continuous queries registered for monitors.
Base implementation for IMdxNamedSet.
 
Listener producing notification for each change to the Query.
An index of olap elements.
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
 
Dynamic range member for epochs in a given time period.
Visitor looking for usage of the IFunction.PAST_PERIODS function.
Represents a member that exists in the pivot.
Helper to print Mdx query results.
 
 
 
 
DTO class representing an MDX query.
A bouncer limiting the number of concurrently running queries.
Monitor for MDX query action.
Monitor for streaming of MDX query action.
Utility class for running MDX queries.
Converter contract from Mdx format to standardized dto format.
A range hierarchy location.
IRegistration for MDX queries.
A Listener interface.
The result of an Mdx query.
MdxCellSet having the ICellSetResult test API.
A tester for MDX cellSets.
Iterator on cells that also maintains the current tuple for each axis while iterating.
Tester for a single cell in a cellSet.
Used to print a String table from a IMdxResult.
 
 
This class holds the MDX rewriters to apply to all calculated members.
Advanced implementation of an ICompilationMatcher that allows for children to return a different type.
Basic implementation of an ICompilationVisitor.
Basic implementation of an ICompilationMatcher: its children return the same type as itself.
A Matcher that accepts any resolved expression.
A matcher that accepts any hierarchy expression.
A matcher that accepts any level expression.
A matcher that accepts any literal expression.
A matcher that accepts any non-calculated measure, and any calculated member whose expression is accepted by this matcher (so any calculated member who is equivalent to a measure).
A matcher that accepts any member expression unless this expression corresponds to An unknown member A calculated member
Basic implementation of an ICompilationRewriter.
Basic implementation of an ICompilationTransformer, with only one child.
A class holding the arguments that have been selected when compiling some MDX.
A class that selects an expression as argument if its child matches.
Matches the name and the arguments of a function against its children matchers.
A matcher that accepts the literal with the given value.
A specific MdxRewriters.FunctionMatcher that matchers the IFunction.PAREN function.
Goes down the expression tree and replaces each matching patterns by the first non null expression returned by its children.
MdxRuntimeException.
Wrapper class to hold the different elements created when executing a mdx select query.
 
Converter to write the result of a mdx select query in an Arrow format.
Converter to write the result of a mdx select query in an Arrow format.
A modified version of the MdxSelectToCsvTabularFormatConverter which supports the old export format where measure names are written at the beginning of each row.
 
 
 
 
Contains all plugins of type IMdxStatementChecker defined in the core.
The stream handling MDX continuous queries.
Common util function to execute MdxQuery, update ICellSetDTOState and compute CellSetDTO.
Cell iterator used for streaming.
Extension of the MdxCellSetInfo enforcing that the property MdxMemberProperties.DISPLAY_INFO be returned in the resulting cell set.
Stream node identifier for an IMdxStreamNode.
Default implementation of IMdxStreamNode.
Specialization of AStreamRegister for IMdxStream.
A translator for Mdx stream.
Timing information about an MDX or MDX_Drillthough query.
Class used to maintain a mapping between XMLA MD property and MDX engine property for members and cells.
Exception that indicates that the maximum number of cells has been exceeded when evaluating the MDX query.
A utility class to trace mdx queries.
Common util function for mdx project.
 
A representation of an Atoti Server measure.
MeasureDimension that holds IMeasureHierarchy.
Measure Discovery for SOAP webservices.
DTO representing all measures in a cube.
The measure discovery builder.
A formatter relying on an ICubeFormatter to retrieve the captions of the measures.
Extended plugin for IMeasureFormatter.
Https://msdn.microsoft.com/fr-fr/library/ms126178(v=sql.90).aspx.
 
Implementation of the measure hierarchy.
Implementation of a memory quantifier for ActivePivot Measures Hierarchy.
Base implementation of an IMeasureHierarchyTransaction based on the abstract AHierarchyTransaction.
A IMeasureHierarchyVersion that fully copies the base MeasureHierarchy.
Implementation of the measure level.
Mapping between an aggregation on the fields of a schema and the column of the aggregate table.
Implementation of an IMeasureMemberDescription.
Contains the additional information required to publish a measure into a cube.
Object representing a single value measure of the cube analyzed by a SmartAggregationEngine.
Flags for user-specified metadata.
Component that can give an optimized version of a IInternalCopperMeasure if detects a better version can be built.
Concrete implementation of an IMeasurePublisher for all cubes.
The description for measures.
A set of utility methods to work with measures.
 
 
This aggregation function computes the median of the data, ignoring any encountered null values.
Comparable class for values and members pairs using a custom comparator.
A member comparator aims to compare axis members of same depth.
An ActivePivot Member.
Visitor searching for a member's unique name in an unresolved Expression.
 
 
 
This class keeps track of count of each member in the data cube.
Deprecated, for removal: This API element is subject to removal in a future version.
Represents the mapping of members to data nodes.
A set of utility functions for manipulating members.
 
Members function.
 
 
The various MDX functions based on Members properties.
CHILDREN_CARDINALITY function.
Is_DataMember function.
LEVEL_NUMBER function.
MEMBER_CAPTION function.
MEMBER_KEY function.
MEMBER_NAME function.
MEMBER_TYPE function.
MEMBER_UNIQUE_NAME function.
MemberValue function.
PARENT_COUNT function.
PARENT_LEVEL function.
PARENT_UNIQUE_NAME function.
Class corresponding to the MDX function MembersCaptionSearch.
Class corresponding to the MDX function MembersNameSearch.
Drillthrough calculator returning the exact value of a member.
Implementation of a function that can memoize the result of an underlying function.
Basic implementation of the IMemoryAnalysisService.
 
Utility class for memory monitoring.
Simple bean for holding statistics related to memory management.
Object ready for JSON serialization.
Holds constants related to memory statistics.
JsonDeserializer for IMemoryStatistic.
Utility class to serialize/deserialize IMemoryStatistics.
Utility class to get info about direct memory consumption.
Merge the result of multiple cursors into a unique cursor.
A ITransactionCommittedMessage resulting from a merged of several ITransactionCommittedMessage.
Event to record the merge of shared deltas.
Exception that marks the inability of an object to be merged into another.
 
An IDictionarizedFilterVisitor that delegates its visit to two child visitors, and whose result is a pair of the two results.
Incrementally built partition impact.
A box that will hold all messages received by a given recipient.
DTO representation of a message.
The various levels of messages.
The messages rest service.
MSG.
MessagesCore.
Messages used by the various implementation classes of the messaging-csv project.
Messages published by the ActivePivot components in charge of data distribution and distributed queries.
Basic implementation of a message service.
MdxMessages
Messages related to MVCC.
MessagesQueries.
MessagesServer This class is used for logging purpose.
This class is used for logging purposes.
MessagesTransaction.
Helper methods for messages.
MessagesXMLA.
Default implementation of AMessageTaskPublisher.
Topic for websockets listening to messages.
Message utility class, to build messages from a message key, and parameters.
The message ws service.
Configuration of beans with message purposes.
Basic implementation of IMessengerDefinition.
Exception thrown when message sizes exceed the allowed limits.
Set of utility functions to manage cluster messengers.
Metadata repository.
This provides utilities needed for metrics instrumentation.
Information about the gauges.
Append only MIN aggregation function.
Min function.
Append only MIN aggregation function.
A heap with the ability to store primitive doubles.
A heap with the ability to store primitive doubles.
A heap with the ability to store primitive floats.
A heap with the ability to store primitive floats.
A heap with the ability to store primitive ints.
A heap with the ability to store primitive ints.
A heap with the ability to store primitive longs.
A heap with the ability to store primitive longs.
Light plugin value for the Min IAggregationFunction.
Some aggregation functions require to keep track of their history.
Hides measures that are higher than some given levels in their respective hierarchies.
The minimum levels prefetcher.
A re-aggregation function for a MIN.
 
Basic implementation of IMissedPrefetchBehavior.
Basic implementation of IMissingLocationsQuery.
 
 
An implementation of ADirectChunkAllocator that uses JNI call to mmap to allocate its memory on Linux, or VirtualAlloc on Windows.
A memory allocator that allocates memory via MMAP instead of Unsafe, above allocation size threshold.
 
An ILocation that wraps another ILocation, modifying some of its coordinates.
Wrapper around a message to be able to mark it as read.
Modulos implementations encapsulate algorithms to map between integral ordinals and position arrays.
 
 
 
 
 
 
Description of a modulo function.
The monitor stored in database.
Informations about the monitor agents declared by ActivePivot.
The monitor builder.
 
The monitor data access object.
The serializable version of the @Link Monitor.
Replaces the default ActivePivotQueryExecutor with added ability to monitor query execution.
Wrapper around an agent description to make it available in MBeans.
Automatically sets up the data loading monitoring if the required properties are present.
Spring JavaConfig definition of the basic components for the data loading.
An dispatcher that registers the context of the current event before dispatching it to the subsequent listeners.
JsonQueryService with extra logging/monitoring capabilities.
The health event handler responsible for logging ActivePivot health events.
The health event handler responsible for logging cluster health events.
The health event handler responsible for logging composer health events.
The health event handler responsible for logging composer health events.
The health event handler responsible for logging composer health events.
APM global handler replacing every core handler by its respective monitored version.
MdxStream with monitoring ability.
APM distributed pool factory.
A monitored queries executor.
QueriesService with extra logging/monitoring capabilities.
Class extending class with tracing capabilities.
Entity class for passing streaming result to action result monitor.
StreamingService with extra logging/monitoring capabilities.
APM StreamPublisher with additional methods helping to get streaming status and result.
An extended SynchronousAggregatesContinuousQueryEngine with extra logs on event handling and tracing capability covering all the subsequence activities.
Extending Spring WebSocketSessionDecorator to capture the size of reply message for a stream.
Traceable websocket session factory.
Extension of WsSession with monitoring support.
Instrumenting IXmlaRequestListener with custom logs and monitoring capabilities.
Automatically sets up JMX beans.
Addition monitoring JMX beans.
Visitor looking for status measures in a MDX statement.
Registry contributor for the monitoring module.
 
Service managing monitoring execution from monitor definitions.
Class holding a view on different query related flattened context values.
 
JsonDeserializer for
invalid reference
IMonitoringStatistic
.
Serializer used for attributes of memory monitoring statistics.
Extended plugin centralizing registration of all core-product monitoring streams.
Implementation of executor applied to monitors.
A decorator for a monitor that contains the aggregated value of number of members in the kpi that are red, orange and green.
The monitor report DTO.
Default implementation of the monitors REST Service.
Websocket topic returning monitor updates.
Default implementation of IMonitorUpdates.
The Serializable version of the @Link MonitorUpdates object.
DTO to configure a WebSocket connection observing monitors.
DTO representing a source of monitors.
WebSocket Service managing notifications on monitors.
 
Continuous handler associated with a measure that needs to be updated on one or multiple analysis hierarchies.
A CancellableCountedCompleter that can complete multiple parent completers.
Wrapper around several tables.
An aggregation applied on a multi-columns vector.
Immutable description of a vector field.
Builder final step.
Builder for the field description.
Builder for specifying the field external names.
Builder for specifying the field local type.
Builder for specifying the field local name.
An immutable ASqlField representing a vector over several SQL columns.
 
POJO representing an aggregation on multiple fields.
Attached query implementation of the IMultiGetAggregatesNotificationQuery.
Continuous query implementation of the IMultiGetAggregatesNotificationQuery.
A monitor formulti query.
Implementation of AContinuousQueryMonitorsGrouper to regroup continuous MDX query monitors under a continuous query engine.
Statistics collector for multi query.
Implementation of the IMultiGetAggregatesNotificationQuery interface.
An Iterator that produces the Cartesian product of all the members that match the specified paths on each hierarchy.
Interfaces to defined hierarchies in Copper.
 
Interface to configure attributes common to all hierarchies.
Interface to configure attributes common to all levels.
The interface to implement to create the beginning of a hierarchy builder.
The single interface to implement to create a hierarchy builder.
The single interface to implement to create a hierarchy builder.
The single interface to implement to create a hierarchy builder.
 
 
Builder to define the levels.
Builder to define the levels (at least one level has already been defined).
 
Builder to add only one level to a hierarchy defined by MultiLevelHierarchyBuilder.SelectHierarchyType.fromStore(CopperStore).
Starting point to build the hierarchy.
Member property which uses a IProperty on the member's discriminator to retrieve the property value.
Joint ordering.
Default implementation of the multiple accessor.
Base class for a translator encoding a single context value with multiple intermediate values.
Define a modulo partitioning over the value of multiple partitioning fields.
Implementation of AGreatestCommonPartitioningCalculator for this partitioning.
A partitioning function that applies over the value of multiple fields of a record.
Visitor to check if a multiple fields modulo partitioning is implied by another partitioning.
Visitor to retrieve the partition id of a multiple fields modulo partitioning, knowing the id of the partition of another partitioning by which the multiple fields modulo partitioning is implied.
Visitor to retrieve the partition ids of a multiple fields modulo partitioning, knowing the id of the partition of another partitioning which is the reduced partitioning of the multiple fields modulo partitioning.
Immutable description for a multiple fields modulo partitioning function.
Topic based on the content of several CSV files.
 
Default implementation of a multiplexed IWsSession using Json messages.
Plugin value for the Multiply aggregation function.
Implementation of
invalid reference
APositionUniquePartitionSelector
, which selects the partition ids based on the first position stored in each record of a list of records.
Implementation of IPartitionSelector for operations performing multiple range operations with underlying multiple-value operands.
ResultSet reader producing a value from the content of multiple underlying columns.
Multi-row vector column name and its target name after vectorization.
A column representing an unnested vector (made of an index and value column).
 
Immutable description of a table containing vectors stored on multiple rows.
Builder for specifying optional field properties.
Builder for the table description.
Builder for specifying the vectorized columns.
Builder for specifying the external table.
Builder for specifying the table local name.
Builder for specifying the fields.
Builder for specifying the index field.
Builder for specifying the key field names.
A MultiScope is the union of several ValueScope.
Monitors quantities from different sources through time.
Utility methods for multi-step queries.
Implementation of a read-write cell supporting data of any primitive or Object type.
Implementation of an IMultiVersionActivePivot.
Callback methods for the different lifecycle events of this version.
Experimental class that could be merged in the future into AggregatesCacheDescription.
Explicit implementation of the IMultiVersionActivePivot extended plugin.
Explicit implementation of the IMultiVersionAggregateProvider extended plugin.
aggregate provider holder which contains a default provider as well as multiple partial provider to retrieve requested aggregates.
MultiVersionAxisDimension that holds IMultiVersionAxisHierarchy.
A multi-version structure for hierarchies.
Implementation of an IMultiVersionAxisMember.
An implementation of AMultiVersionIndexedAggregateProvider for the Bitmap Aggregate Provider.
Implementation of an IMultiVersionRecordSet based on a ColumnarRecordSet.
Implementation of an AMultiVersionSecondaryRecordIndex, when the index is on multiple fields.
Implementation of an AMultiVersionUniqueRecordIndex when the index is on multiple fields.
This instance of IMultiVersionActivePivot is made for the distributed architecture.
Multiversion schema implementation.
MultiVersionDimension is the multiversion implementation of dimensions.
The base implementation for a distributed ActivePivot.
Explicit implementation of the IMultiVersionDistributedActivePivot extended plugin.
It holds the remote address that we are currently removing for the current transaction, as it is only used in ACommitRemoteTransaction.
A MultiVersionAxisHierarchy specialized for query cubes.
In this class contributorsCount is the number of addresses where the member exists.
A specialized Range adapted to the distributed architecture.
MultiVersionDistributedDimension is the distributed multi-version class for a dimension.
Stores the data about a transaction in a MultiVersionDistributedDimension.
Stores the information about a transaction in a MultiVersionDistributedDimension.
MultiVersionDistributedMeasureDimension that holds IMultiVersionDistributedMeasureHierarchy.
Implementation of the Measure Hierarchy in a Query Node.
Explicit implementation of the IMultiVersionGlobalAggregateProvider extended plugin.
Explicit implementation of the IHierarchy plugin.
Implementation of an IMultiVersionIntegerArray.
Just In Time provider which can adapt its partitioning depending on the query.
An implementation of a IMultiVersionIndex that resemble a linked list.
An implementation of AMultiVersionIndexedAggregateProvider for the Leaf Aggregate Provider.
Implementation of an IMultiVersionLongArray.
MultiVersionAxisDimension that holds IMultiVersionAxisHierarchy.
Implementation of an IMultiVersionMeasureHierarchy that implements a copy-on-write scheme.
Implementation of AMultiVersionConcreteReference for a reference from a non-indexed point to a unique index.
 
Partitioned aggregate provider specialized for bitmap provider partitions.
 
Implementation of AMultiVersionConcreteReference for a reference from a secondary index to a unique index.
 
Base implementation of an AMultiVersionSecondaryRecordIndex, when the index is only on one field.
Multiversion store.
JMX Monitor of a multi-version store.
The multiversion store partition implementation.
Implementation of AMultiVersionConcreteReference for a reference from a unique index to a unique index.
Base implementation of a AMultiVersionUniqueRecordIndex when the index is only in one field.
A tuple that joins multiple tuples as a single one.
A wrapper over tuples that behaves as if any underlying tuple had reduced dimensionality.
Implementation of IRTExpressionDependency used by the MDx engine to save some memory when doing operations mixing several dependencies.
An AbstractSubLocation derived from a location pattern.
A mutable tuple containing all the hierarchies.
This class is similar to MutableTuple.
A ChunkSet with named columns (allows to emulate an aggregate store for bindings tests).
NameDef token.
Class representing a column in an external database.
 
A Copper measure representing another measure, already present in the cube or previously published by Copper, by its name.
This rewriter replaces nodes generated by Copper.measure(String) with the expression of the measure.
The named numeric format defined by the MDX documentation.
Drillthrough calculator returning the name of the member.
Basic implementation of an INamedSetDescription.
Named set expression.
Atoti fork/join worker thread.
Named thread factory.
Factory of AtotiThreads.
A worker thread factory that supports custom naming of the worker threads.
 
Constants for the namespaces used in the Atoti server configuration.
Classic naming conventions used in utilities to ease renaming.
 
A Copper measure representing a native measure.
JDBC reader for native arrays of doubles.
JDBC reader for native arrays of floats.
JDBC reader for native arrays of ints.
JDBC reader for native arrays of longs.
 
Class util for INativeMemoryAllocator.
JDBC reader for native arrays of Objects.
Natural java Comparator.
Controls whether the measure searches for the value at the exact requested location or searches for a non-null value at least at the requested distance.
Visitor to rewrite where clause.
The expression that is being visited returns true if - it is a set with only one hierarchy and many members - it is a crossjoin with many hierarchies It returns false in all other cases.
A cell set describing the deleted location from the cube.
A wrapper around an IVector that only sees the negative values: it returns 0 for the coordinates where the underlying vector is negative.
The binding between any vector and a negative vector.
This Post Processor, given a time hierarchy and a location, returns the previous or next value along the time hierarchy if it exists.
Prefetcher for the NeighborValuePostProcessor.
Visitor to detect if the select statement has non empty on all axis of the top select.
Generator of addresses for a Netty cluster.
Implementation of IAddress that is used with NettyMessenger.
Handles a NettyRequestMessage ONLY.
The number of threads within each EventLoopGroup can be changed by setting: -Dio.netty.eventLoopThreads.
An InputStream that decodes data sent using a NettyOutputStream.
This class defines the keys to set the maximum size for different netty message types.
A distributed messenger JGroups-based for cluster management and Netty-based for exchanging messages.
An OutputStream that sends the data using Netty's ChannelHandlerContext.
Wrapper around an object that represents a message to identify it with a long id automatically generated.
Wrapper around an object that represents a response to the message NettyRequestMessage with the same ANettyMessage.requestId.
Some constants and utility methods used by both NettyInputStream and NettyOutputStream.
An enumeration representing each type of message sent over the network and its default maximum size.
For TCP/IP connection (accepts incoming TCP/IP connections).
DTO notifying a new message for the connected user.
NextMember function.
This filter is defined with a list of included members and a list of excluded members.
Object used for the serialization.
Translator for NoAccessCubeFilter.
Implementation of IAlternateMappingFeeder that does not perform any operation.
ICursorFactory in use when no cursor-iteration time condition exist.
A concrete reference factory for references from a non-indexed point to a unique index.
A non-empty cross-join set.
 
 
 
Non-reentrant lock.
Filters used for Non Visual subselects.
 
A retrieval associated with an aggregate retrieval This class represents the case of empty retrievals.
Implementation of IAggregateStoreBinding that does nothing.
An external primitive aggregates retrieval that does not perform any computation and/or datastore request and contains an initially empty result.
Implementation of IHorizontalDispatcherExporter corresponding to an empty dispatching.
Implementation of IHorizontalQueryDispatcher not performing any dispatching.
Validator for tables of multi-columns vectors, which does not perform any actual check and returns an empty error report.
Validator for tables of multi-rows vectors, which does not perform any actual check and returns an empty error report for all checks related to multi-rows vectors.
A primitive aggregates retrieval that does not perform any computation and contains an initially empty result.
 
A no-operation timer in use when IStopWatch is disabled.
A handler that does not change the records it handles.
A unit that does nothing.
Implementation not performing any override of the queries.
Base class for procedures that do not allow recycling tuples.
Class handling logout of users.
Deprecated, for removal: This API element is subject to removal in a future version.
Not used, this was initially intended for the Python API
Implementation of ADatabaseServiceConfig which does not set up the table security and does not define any formatters or parsers.
Implementation of ISharedMemberSubTreesContributor that does not perform any contribution.
Implementation of an IEvictionConcurrentMap not implementing any policy of eviction.
Negate a condition.
Negate a condition.
A NOT logical condition.
Negate a condition.
 
Class exception for requests to a non-existing resource.
 
The notification event type.
Create the notification group tasks that will notify the listener of a continuous query when the view of that continuous query was updated.
Stateless implementation of an IMdxStream producing notifications only for updates of the cellset.
Stateless stream node designed to produce notifications for MDX streams.
Message used to notify that a transaction committed to a data cube has been correctly applied to a query cube.
Create the notification tasks that will notify the listener of a continuous query when the view of that continuous query was updated.
The completer that will actually process the event and create the notification tasks.
Class exception for requests targeting a method of a service that is not currently implemented.
Negate a condition.
Condition tree visitor applying the de Morgan's theorem and removing double negations.
Exception reporting that there is no transaction while the current operation requires a transaction to exist.
Class representing a cell with irrelevant content.
 
Retrieve the n th siblings of a member.
Retrieve the n th child of a member.
Reader wrapping another reader to perform the nullity checks.
 
A nullable dictionary is a dictionary which allows null as a key.
 
 
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
A chunk that has one value that takes the majority of the chunk, while the others are only slightly used.
 
 
Implementation of ICluster representing a null cluster having no child and containing no query vector.
A compiled condition instance searching all records having a given field null.
The JNA library for the NUMA methods.
A INativeMemoryAllocator on a given NUMA node.
A helper class to select NUMA nodes for a partition.
An INumaNodeSelector that always returns the partition id as NUMA node for a given partition.
A INumaNodeSelector induced by an owned reference.
Use the same INumaNodeSelector as the target store of the reference.
Use the fields of the table for partitioning.
Form field type implementation to input numbers.
Basic single threaded number format relying on an underlying decimal format for each section of the format.
Number formatter that can be configured to support multiple integer and decimal formatting.
JDBC calculator to change from any Number such as BigDecimal to the desired type.
A cursor over an underlying IWritableArray.
Implementation of a read-write cell supporting data of all types.
 
Operand holder for a IConstantCondition on a field NON dictionarized, when operand is a set.
Object count serialized in a trace tag.
Operand holder for a IDynamicCondition on a field NON dictionarized, when operand is NOT a set.
Operand holder for a IDynamicCondition on a field NON dictionarized, when operand is a set.
Basic implementation of an Object vector based on a fixed block.
 
Parser for a vector of objects.
This provides utilities needed for observability instrumentation.
 
A throwing function used in tracing methods that trace methods throwing exceptions.
A throwing runnable used in tracing methods that trace methods throwing exceptions.
A throwing supplier used in tracing methods that trace methods throwing exceptions.
Special implementation designed to wrap an existing CountedCompleter to intercept completion operations to complete a span with the correct state and information.
Configuration class to initiate the necessary observability components.
Utility class for observability.
Observability utilities.
A IWritableRecordBlock that offsets the record indexes of an underlying record block.
Axes iterator based on MdxCellSet.
Base Olap element.
Helper class used to retrieve hierarchies, members...
 
Provide information based on MdxCellSet and provide IMDProperty.
Component performing the registration of an Aggregated Listener.
 
Class grouping all plugin values of ActivePivot defining an implementation of IOnHeapMemoryQuantifier.
 
 
This operand return the aggregated value on the current location.
Data holder class for an aggregated value on a specific location.
Regroup all query operand casting methods and their exception handling.
This operand returns the list of children aggregated values of a defined aggregated measure for a given hierarchy.
This operand return the double given value.
This operand triggers a dynamic aggregation.
Explicit implementation of the IOperand extended plugin.
This operand return the float given value.
This operand returns the int value.
This operand return the level value of the current location.
This operand return the long given value.
This operand always returns null.
This operand returns the parent aggregated value of the current location for a given hierarchy.
This operand return the string value given as a parameter.
Immutable implementation of IOperationInfo.
Absolute operator : the operand is a scalar number, there is only one operand.
This operator returns a double value whichever the type of the input number.
The simple add operator which: Takes an infinite number of operands.
The simple aggregation operator which: Takes an infinite number of operands.
The simple concatenation operator which takes an indefinite number of operands and concatenates them all together.
The simple disaggregation operator which: Takes an infinite number of operands.
The simple divide operator which: Takes in 2 operands: the numerator and the denominator.
The simple minus operator which: Takes 2 operands.
The simple multiply operator which: Takes an infinite number of operands.
Percentile operator : first operand is the vector, second operand is the percentile (e.g.
Explicit implementation of the IOperator plugin.
Utility class that gathers several implementation of ICopperOperator.
Arithmetic binary operators.
Enumeration that is ready for switch statement, and states both the output type of the operation, and the operand that has the widest primitive type of the two operands.
Square root operator : the operand is a positive scalar number, there is only one operand.
An operator that extracts a sub vector from a vector operand, between an included 'from' index up to an excluded 'to' index.
A ternary divide operator which: Takes in 2 or 3 operands: the numerator and the denominator, and an optional third operand, the value to return when the numerator is not null, and the denominator is null or 0.
Default immutable implementation of IOptimizationDescription.
A wrapper for a visitor that recognizes simple logical patterns and simplify them.
Result structure inspired from Haskell's Maybe or Rust 's Option.
Logical OR combination of other conditions.
Logical OR combination of other conditions.
OR logical condition, between two or more sub conditions.
 
Logical OR combination of other conditions.
Compile condition for $or.
An ordered set, sorted using the policy provided by an IOrder.
An orderer that wraps another one and adds interruption checks to prevent expensive calls (like Arrays.sort) to ignore timeouts.
 
Ordinal function.
Logical OR combination of other conditions.
Condition tree grouping the leaf children of an OR condition into an IN condition if they express the same field.
 
An overflow exception that happens when too many watch events happened before being processed.
A specialization of the LongDictionary when the stored longs represent two packed integers.
Pair implementation.
A dictionary that stores pairs of Objects.
Utility class for lists of IPair.
Implementation of the ParallelPeriod MDX function.
A bounded task that implements the parallel rehash of a hash table into another hash table.
Hash tables must have a length that is a power of 2.
The size of the original hash table must at least be MINIMAL_BLOCK_SIZE or the algorithm will produce inconsistent results.
A transaction operation that executes an underlying collection of operations in parallel.
Represent a parameter.
Represent a parameter with all its current point values.
Default implementation of IParameterEvent.
Implementation of executor for parameter name.
Implementation of executor for parameters.
Default implementation of IParameterStoreConfiguration.
Default implementation of IParameterStream.
Topic dedicated to parameters feed.
Basic implementation of an parameter update.
Default implementation of a builder for parameter change definition.
DTO holding all the updates requests for a given parameter.
Configuration objects use by IParameterWsService to register web sockets.
Fetching mode for parameters.
Default implementation of IParameterWsService.
Parent function.
 
Prefetch the parent location of the target locations, with respect to the chosen reference hierarchy.
Intermediate builder.
Implementation keeping a reference to the parent builder.
Data cube builder delegating all its calls to a SimpleCubeDescriptionBuilder.
Parent value post processor.
Component that parses a char buffer into records.
Parser context that defines a homogeneous set of parsing operations, with scheduling entry points and completion awaiting.
Data type explicit plugin, loads a data type instance from a String representation of the data type.
Parser for vectors of Integers with the legacy plugin key.
The resources involved for a pass of parsing.
Factory creating parser resources.
The result of a parser task.
CSV Source parser task.
Initial state of a parser task.
A parser thread that holds a byte buffer and a character buffer.
Parser thread factory.
Special thread pool for parsing CSV files.
A parsing exception in the csv file.
Information about the parsing operation for a given resource.
The implementation of the parsing workload.
The implementation of the parsing workload.
Aggregate collector collecting aggregates for a partial provider.
Implementation of an IPartialAggregateProvider.
A APrimitiveAggregatesRetrieval specialized for retrieving values on a partial provider.
A wrapper around a partial provider version that knows how to convert from global to partial locations.
 
Iterates over expansion levels using ordinary member iterators on the hierarchies.
A location based on a child location produced by a PartialAggregateProvider.
A location based on a child location produced by a PartialAggregateProvider and its parent scope.
IPartitioning implementation that works when partially knowing the partitioning fields.
Definition of a partial aggregate provider.
Object representing the configuration of a partial aggregate provider recommended by the AI-based optimizer.
Record representing filters on Partial Aggregate Providers.
Estimates the memory footprint of partial aggregate providers.
Retrieval information for retrievals on a PartialAggregateProvider.
Core implementation of a IPartialProviderSelector.
Base class that registers Atoti vanilla implementations of an IPartialProviderSelector.
The partial provider vector is the concatenation of a vector representing for each hierarchy (without the measure hierarchy) the ordinal of the deepest level supported by the partial provider and a bitmap containing 1 for each measure included in the partial provider.
Implementation of ISetCoverSolution representing a solution covering only a subset of the universe of the solved SetCoverInstance.
Partitioned provider aggregates retriever.
A PpNode that includes its partitioning in its key.
Class checking a partitioning to assert his definition.
Creator for the IPartitioning.
Gateway class between a parent builder and the builder of the partitioning.
 
Implementation of IPartitioningManager that records every created partitioning for reuse.
Define a node in a hierarchical partitioning.
Creator for the APartitioningNode.
Immutable description of a partitioning node in the hierarchical partitioning.
 
Utility to validate a PartitioningNodeDescription.
Provide the walkers for a partitioning tree.
A walker to visits the partitioning nodes in a partitioning tree.
Calculate the partitioning cardinality of a partitioning node.
Retrieve the id of the partitions that potentially contains the partial record where the value of some fields of the record is not known.
Retrieve the id of the partitions that potentially contains the records of a partition defined in a reduced partitioning of a partitioning node.
Retrieve all the partitioning fields used to define the partitioning rule of a node and its children (if any).
A partitioning node in the hierarchical partitioning, which has a multiple fields modulo function in its default partitioning rule.
Description of a partitioning node in the hierarchical partitioning, which has a multiple fields modulo function in its default partitioning rule.
Utility class providing methods to parse a stringified partitioning.
An object that holds the partitioning algorithm as well as partitioning state.
Utility for datastore partitioning.
The function that transforms x to 0 (it plays the role as a partitioning function of a Constant partitioning).
The function that transforms x to x.
Function that transforms x to x % modulo.
Faster version of PartitioningUtil.ModuloFunction when the modulo is a power of two.
A function that reduces a partitioning by removing some of its partitioning fields.
Utility to validate a IPartitioningDescription.
A partition mapper with a translation on the indices.
Marker class.
Object storing the statistics of a partition.
Provide the thread pools associated with partitions.
A Pass is a layer of execution.
Graph of tasks to execute.
Individual task.
Task executor.
A pass visitor which execute the passes.
The pass manager is the DAG of passes.
Class for IIf pass.
Enum of the different types of Pass that can be created.
 
The subselect pass.
Class for top select pass.
Class for Visual total pass.
Visitor to update the @{link Pass passes} of the PassManager.
Decorator upon the a continuous query listener that will add real-time updates on MDX data based on time conditions.
Real-time calculator triggering updates of a MDX cellset due to changes to PastPeriod results.
An IMdxAddon specialized for the PastPeriodsFunction.
Function returning a set of Epochs before the given one (included in the set), all epochs being younger than the given duration.
Procedure iterating over all versions of the pivot to compute the smallest delay to the next update, with respect to the usages of IFunction.PAST_PERIODS.
Path of member names.
Basic comparator for Paths.
A ICsvDataProvider that deals with files on the file system.
Simple implementation of IPathlessContentEntry.
Simple implementation of IPatternMatcherFactory that creates simple case-insensitive matcher.
A matcher that uses the
invalid reference
String#equalsIgnoreCase(Object)
method of @link String}.
Simple implementation of IPatternMatcherFactory that creates simple case-sensitive matcher.
A matcher that uses the String.equals(Object) method on String.
Class exception for requests containing a value considered as invalid by the service.
Main ChannelHandler handling NettyRequestMessage and NettyResponseMessage.
A class responsible to limit the number of forked tasks.
The Percentile aggregation Function.
An enum of methods to compute the theoretical index of a given percentile.
When the theoretical percentile index returned by the PercentileFunction.IndexCalculationMode is not whole, some interpolation is needed to compute the percentile.
The post-processor for the compilation of the percent of member MDX formula for a given measure and a given hierarchy in a dimension.
The post-processor for the compilation of the percent of parent MDX formula for a given measure and a given hierarchy in a dimension.
Basic implementation of an interruption checker testing periodically the interruption.
 
A DTO which holds permissions.
Builder for a Content Service storing its data into a Database supported by Hibernate.
A PhantomReference to a Fence to which one can register a Runnable to run on collection.
 
 
 
 
Definition of an activepivot in the structure of a manager.
Registry contributor for the pivot dist impl module.
PivotRole class list of contexts per pivot.
This class is the entry point for XMLA execute of MDX statements.
Registry contributor for the pivot ext module.
Registry contributor for the pivot impl module.
Key in the graph of a IActivePivotManagerStructure that represents a cube.
Key in the graph of a IActivePivotManagerStructure that represents a query cube.
Key in the graph of a IActivePivotManagerStructure that represents a data cube, or simply a regular cube.
Listener for the GetAgg queries.
Pivot's metadata.
 
Pojo including dimensions and hierarchies info.
The storage of the changes made to the pivot hierarchies during the structural transaction.
A plan which makes a sequential visit of the actions.
Utility extracting information from a pivot schema.
Registry contributor for the pivot server spring module.
Methods to handle locations and measures issues.
Holder class for new subversion of a cube structural transaction.
 
 
 
 
 
The available thread placement policies.
Reads an underlying record, resolving dictionary codes stored in the record into their associated keys.
Wraps a cursor of plain values and transparently encodes fields with dictionaries when necessary.
Context used during plan.
 
The query plan data.
 
The planning graph creates a dependency graph between the various retrieval descriptions of a query.
Standard dependency key for ARetrievalNode.
Interface for keys to ADependencyNode.
Key to a PpNode.
Key to a PrimitiveNode.
Planning services operating on a PlanningGraph.
PlanningGraph module optimizing a graph to use ActivePivot AggregatesCache to retrieve data instead of using providers.
A IPlanningGraphVisitor that actually plans the execution of its nodes, starting with the top-level ExecutionPlan.
Planner responsible for finalizing the first version of the PlanningGraph.
Planner responsible for the initial part of the query planning.
Planner responsible for a subpart of the graph.
PlanningGraph component that walks the planned graph for the query and selects providers for primitive measures and define the partitioning for all retrievals from this.
Planning graph processor merging primitive nodes with the equivalent primitive aggregation nodes.
An Object used to print a PlanningGraph.
PlanningGraph module optimizing a graph to use range-sharing between nodes whenever possible.
Utilities.
DTO representing Retrieval operations.
A helper class to retrieve the current platform.
Class regrouping operations that must be executed on the host VM and are potential hacks.
Utilities about the platform.
Implementation of a Plugin.
PluginContribution.
PluginDescription is the description for the plugin to add, we can define specified plugin, like indexer, storage, calculator, cache for ActivePivot.
Base implementation of a light plugin value.
PluginValueContribution.
 
Point, an immutable collection of integer coordinates.
An aggregate store where each aggregate row is associated with a unique point in a point index.
Point hashing library.
A record block specialized for holding the data of a cursor associated with a query.
A factory that is able to create IPointListReductionFilter from a point list and a reduced scope.
A IPointListReductionFilter that always accepts the point location it is given.
A IPointListReductionFilter that is based on a PointLocationList and a dictionarized values filter.
A IPointListReductionFilter that always rejects all inputs.
Base implementation of an IInternalAggregatesRetrievalResult that uses a location list and an aggregates store to store the retrievals result.
A transformation procedure that returns a boolean value.
Class storing all information related to additional measures added to a PointListRetrievalResult.
A transformation procedure that returns a double value.
A transformation procedure that returns a float value.
A transformation procedure that returns a int value.
A transformation procedure that returns a long value.
A transformation procedure that returns an Object value.
Helper class used to join a PointListRetrievalResult with other results using analysis aggregation procedures.
 
A location backed by a point.
Default implementation for IPointLocationBuilder.
List of points that represent locations belonging to a given scope.
A point location reader on top of a point location list.
An immutable point location that points to a position in a point location list.
A IQueryNodeQueryTranslator.IPointLocationListTransporterTranslator made for translating locations from data cube to query cube when their topologies differ (not the same hierarchies).
Predicate that tests whether the member of the the given hierarchy with coordinates extracted by a given ILocation is granted (true) or not (false).
A dictionary of point references.
Maintains a dictionary of points, a point is a fixed size array of integers.
The point value of a variable at a given coordinates that is stored in the database.
The point value data access object.
Sets of helper methods on a PointValueDao.
The Serializable version of @Link PointValue.
DTO of a point value key.
The point value query.
The DTO for point value queries.
Default implementation of IPointValueUpdates.
The serializable version of the @Link PointValueUpdates.
A column calculator to retrieve data from a POJO, given an attribute name.
Base POJO channel factory IStoreMessageChannelFactory.
Deprecated, for removal: This API element is subject to removal in a future version.
This is an internal API that should not be used by clients, use the factory PojoMessageChannelFactory.createTranslator(List) to create such object.
Explicit declaration of the IPoolFactory plugin values.
Thread pool utility class.
 
A IUserDefinedAggregateFunction which calculates the standard deviation using the population formula.
A IUserDefinedAggregateFunction which calculates the variance using the sample formula.
The position data.
The position data builder.
Implementation of IPartitionSelector for a partitioning on a unique field on which multiple values are selected thus potentially selecting multiple partitions.
Dummy name supplier for Partitionings that returns a field index as its name.
A wrapper around an IVector that only sees the positive values: it returns 0 for the coordinates where the underlying vector is positive.
The binding between any vector and a positive vector.
Base implementation of a post-processed retrieval that executes its associated post-processor once all its underlying retrievals are done.
Some measures/facts are best to be calculated on a need basis because they may depend on external factors (e.g.
Component used by a Post-Processor to write the computed values of the measure.
An interface storing all post-processor constants for post-processors that need to be accessed by artifacts that do not depend on activepivot-ext, notably MDX compilation.
A Copper measure representing a legacy post-processor.
Default implementation of IPostProcessorCreationContext.
The description class for a PostProcessedMeasure.
Exception thrown by a post processor during the evaluation of a location.
Exception thrown by a post processor.
Explicit implementation of the post processor extended plugin.
Exception thrown by a post processor during its initialization.
Utility methods for PostProcessors.
 
A ARetrievalNode specialized for a post-processed retrieval.
Data contributor working with pre-aggregated inputs.
 
Builder creating selections returning aggregated results to feed ActivePivot components.
This class contains all the necessary data to retrieve the aggregates associated to a prefetch request.
Implementation of IContentService which relies on an other IContentService.
This class will take care of transforming a Iterator pointing reference data into a pivot table.
 
PostProcessor which, given a cell and a time hierarchy, returns the previous underlying along the time hierarchy.
PrevMember function.
Error report for checking if tables have duplicated key fields (as they are only declarative).
A PrimitiveNode whose result is already available in the IAggregatesCache.
Specialized root used by PrimitiveAggregationNode to plan a sub-graph.
Retrieval performing the aggregation on analysis hierarchies.
Utilities to encode and decode primitive data from an array of bytes.
A ARetrievalNode specialized for a primitive retrieval.
A RangeLocationPlan specialized for computing coverage between locations in the context of a primitive measure retrieval.
Planning Graph visitor that walks through the leaf nodes of the planning graph, and accumulates the queries found in each node.
Implementation of IPrimitiveRetrievalExporter to export and import the primitive retrievals computed by a pivot to and from a local file.
This task is responsible for executing all primitive retrievals of a given execution plan that are to be executed in a given IMixedWorkloadPool.
This task is responsible for executing all primitive retrievals in the given array that are to be executed in a given IMixedWorkloadPool.
Monitoring components to control the print of the data loading timing statistics for the intra-day files.
The event processing steps.
This class holds information about processors available to the system running under Windows.
Read and write post processor information in Properties.
Properties function.
List of the properties used by this starter.
A set of static methods used to manipulate Java Properties.
Default implementation of the IProperty contract.
The base implementation of an IPropertyInfo.
 
List of the properties used by this starter.
 
The registry of the ActiveViam properties.
The protocol configuration It contains the name of the protocol and all the necessary configuration for that specific controller.
Object identifying a unique Aggregate Provider for a given ActivePivot.
Record format based on an aggregate provider mapping.
A proxy measure specialized for IAdvancedAggregatedMeasure.
A proxy measure specialized for IAggregatedMeasure.
A proxy measure specialized for IPostProcessedMeasure.
Visitor that processes the distributed planning graph by removing nodes that can be delegated to the data cubes.
Internal annotation marking code as part of the public API when it is not yet in an "api" package.
Publication queue with mechanisms to register, unregister and await parser tasks associated with each subject.
Provide statistics about event publication.
An OLAP element that can be published (i.e added to) into a cube.
Interface that represents a hierarchy that can be used in Copper and published.
Usually one of the last operations in the transaction plan, this operation iterates on the view impact, and materializes records that have changed before pushing them to a view.
Send the records produced by the initial transaction to the continuous selections.
Implementation of a bitmap compressed using Qfs encoding.
Bitmap index implementation using QfsBitmaps internally.
An iterator over a compressed bitmap that supports two levels of iterations: Jump to the next run (using the nextRun() or safeNextRun() methods) Progress in the current run by discarding words
An primitive integer list based on a TIntArrayList.
An empty TIntSet.
Utility class to create TIntIntHashMap with null values not conflicting with the values that can be stored in this map.
An primitive integer list based on a TIntLinkedList.
A TIntList that exposes an additional QIntList.getQuick(int) method.
A map with Object values and primitive int keys based on a TIntObjectHashMap.
An primitive integer set based on a TIntHashSet.
An unmodifiable set that only contains one value.
A set of long primitive values.
QNameDef token.
A map with Object keys and primitive int values based on a TObjectIntHashMap.
A map with Object keys and primitive int values based on a TObjectIntHashMap.
A TSynchronizedIntObjectMap that exposes its underlying map.
 
Monitor a quantity through time (total sum, count, average, min, max...).
A Datastore table that is targeted by a query.
Executor for the queries service.
Object representing the queries history analyzed by the aggregate provider optimizer.
Filters a QueriesHistory to exclude queries including forbidden levels.
The queries rest service.
Context value for queries results size limit.
Context value translator for IQueriesResultLimit.
Implementation of the IQueriesService interface.
Monitor recording queries statistics.
 
Recording query execution status, such as count of running query, long running query.
This context set a time limit for queries execution.
Basic implementation of IntegerContextValueTranslator.
Monitor for location-based drill-through query action.
Utility class to block queries on a IActivePivotManager.
Helper class to build queries.
A unique sequence number is associated with each new query cache instance.
The query has been canceled.
Definition of a distributed cluster.
Deprecated, for removal: This API element is subject to removal in a future version.
 
Compile a query into a runnable ICompiledQuery.
Configuration of a planning graph, on a per-query basis.
 
The context to put in the query cache for the lifetime of a query.
The query cube implementation of an ICopperContext.
Factory creating DataCubeContext.
A ITransactionListener to be attached to a QUERY cube to be notified when its topology changes (QueryCubeListener.topologyChanged(), QueryCubeListener.topologyUnchanged()) and when it has received all the underlying measures and hierarchies of the DATA cubes within its cluster (QueryCubeListener.discoveryComplete()).
Data object representing a query made by a user.
 
 
 
An exception that occurs dealing with a query.
Exception management utilities.
The query has failed during execution.
A help class for extracting query information for monitoring.
Monitor for query executor.
Explicit implementation of the IQuery extended plugin.
The query has been interrupted before it completed its execution.
Store name mapping aware implementation of the query manager.
Adapter implementing the Database query manager on top of the existing Datastore compiled queries.
An implementation of query plan printing level context value.
Helper class to manage QueryExecutorMonitor and help to monitor on all executing queries.
The context value translator associated with the IQueryMonitoring context value.
The default implementation of an IQueryNodeQueryTranslator.
Direct implementation of an IQueryNodeQueryTranslatorFactory.
The identity IQueryNodeQueryTranslator that simply always returns the original ILocation.
Query parameters to either run a ListQuery, a DistinctQuery or an AggregateQuery on a datastore.
A resolved query part with a state to map a selection field or an aggregation to a field of the SQL query part.
Mapping between the queried AliasedField or IAggregatedElement to their ISqlSelectField in the query.
 
A completer that is used as the parent of all the per-partition tasks of a single query.
Default implementation of Query Performance Evaluator.
Configuration class to initiate query performance evaluator.
A query plan that consists of general information, the list of all the aggregate retrievals, external retrievals and their dependencies.
Base implementation of a IQueryPlan.
A monitored component used to expose the query plan related operations of a pivot.
Basic implementation of IQueryPlansTester.
Utilities for query resolution.
Resolves an agnostic SQL query from an UnifiedApiQuery.
Basic implementation of IQueryResultFormat.
Result of a query which had its select part reworked.
A query runner able to run a query in a specific version.
A query runner capable of handling query timeouts.
Implementation of an IQueryStoreTree.
Implementation which is based on the Stream query.
The JSON query plan summary data.
 
Core tags which can be passed to a query.
QueryTimeoutException triggered when the query time is exceeded.
Collects timing for query on datastore and pivot.
Enum giving the type of query whose timing will be collected.
Enum giving the category of a query on ActivePivot.
Util to log query timing.
Utilities around queries.
Validates a query.
The query vector is the concatenation of a vector representing the ordinal of the deepest level queried for each hierarchy (without the measure hierarchy) and a bitmap representing the queried measures.
A BeanPostProcessor replacing Activepivot services Beans by their equivalent monitored services.
Base class to register a continuous query by using websocket.
Class holding the two ids uniquely identifying a user query.
The query web socket service.
Special component deciding when to fetch context values for a given WebSocket query action.
A random access list backed random access set.
A random access shuffled set.
Definition of a range [a, b], with both ends a and b included in the range.
A hierarchy implementation which retrieves members which exist between 2 versions.
DTO encoding the range of a cellset to read.
DTO representing a range of indices in a result.
 
 
A range location plan organizes locations determining if there are coverage rules between them.
An object containing two indexes defining a range for a given axis, before knowing any information on the axis it will be applied on.
A range sharing aggregates retrieval for a linear post processor.
A range sharing aggregates retrieval for primitive measures only.
A simple implementation of IRangeUnion.
Collection of utility functions on ranges.
 
Class representing a field in the database that is reachable from a base table following a path of joins.
An array cursor that can move above any type of IArray without any restrictions.
A specific cell that will not move away from its initial position.
 
 
DTO notifying of a message being read.
Implementation of IDatabaseService which does not support operations changing the state of the database.
Shortcut annotation for Spring to annotate a method that performs a transaction that only reads data.
Shortcut annotation for Spring to annotate a method that performs a transaction that reads ond writes data.
Shortcut annotation for Spring to annotate a method that performs a transaction that reads ond writes data.
Shortcut annotation for Spring to annotate a method that performs a transaction that reads ond writes data.
Some utilities methods regarding Re-Agggregation.
 
Utils for real time.
Basic implementation of IRebindTargetDictionaryAction.
A special and limited IActivePivotRemoteTransactionInfo whose only purpose is to indicate to the IAggregatesContinuousQueryEngine that it needs to be reset due to the associated transaction.
Basic implementation of IRebuildIndexDictionaryAction.
 
Generates the java code of the partial aggregate providers recommended by the smart aggregation engine.
Standard record implementation.
A cursor backed by an array of records.
A simple IWritableRecordBlock backed by an ArrayList.
A wrapper implementing IColumnarTable for record blocks.
Stack based implementation of IRecordFlattener.
Factory for a record flattener that can, from a given store and partition id in that store, materialize flattened records, with their additional information from referenced stores.
Standard record format implementation.
Static helper methods to use for operations on Record indexes.
Implementation of IListenersExceptionsHandler recording in an AssertionError the failures of the listeners.
The basic implementation of an IRecordQuery.
When RecordQuery.AutoDetectOuterReference is used, the QueryCompiler takes the responsibility to detect the set of outer references.
Direct implementation of IOuterReferencePolicy.
No outer reference is used in the query.
A record reader delegating to an IPositionalReader.
A virtual record representing the data of an underlying record but changing the indexes at which this data can be found.
Implementation of the record mapper, without any mapping.
Implementation of a record based on a RecordReaderMapper.
Contains utilities for handling IRecord.
A result processing task.
Provide all rows from a record list ordered and traversable by a procedure.
An IRowsIterator that iterates over all the existing rows in an IRecordSet.
A recursive action that works on a bounded section of some data structure.
A recursive task that works on a bounded section of some data structure.
Implementation of an ARecursiveSelectVisitor that takes care of planning and evaluating an ISelectStatement, and builds the corresponding passes.
Interceptor redirecting some URLs to others.
A set that hides hierarchies of an underlying set.
An aggregation procedure that transforms the underlying results before reducing them.
Reentrant read lock non-reentrant write lock implementation.
Definition of a reference that holds a reference metadata.
Default immutable implementation of IReferenceDescription.
A fluent builder class, that will assist you in creating a ReferenceDescription.
Representation of a field referenced after a series of joins.
Representation of a table referenced after a series of joins.
 
Class used on the edge of the datastore structure.
Identifier for a reference between 2 stores.
Basic implementation of a reference metadata.
Memory statistics specialized for references.
 
The referent is the pivot corresponding to a data node.
Reflection utilities.
Converts public refresh API object to internal objects.
 
 
Data transfer object for IRegisteredAgentDescription.
Simple implementation of IRegisteredGetAggregatesContinuousQuery.
Registration instructions.
Options associated to an IStreamListViewListener registration.
 
Options associated to an IAsyncCompositeViewListener registration.
 
Basic implementation of a IRegistrationService.
Exception thrown by the Registration Web Service.
The state of the registration.
This class provides methods to execute IRegistration on IMultiVersionActivePivot.
The result of a registration.
Provides static accessors and shortcuts to the Registry currently configured in the System.
Indicates to the registry which contributions to use.
 
Completes the methods available in Registry with methods we do not want to expose.
Describes the relationship fulfilled by the underlying data.
Spring configuration class creating remote ActiveMonitor services.
Implementation of IAgentService to be used by the ActivePivot's agents.
Branch from a data node exposed to the query node.
A content service that uses REST client for content operations and Web Socket client for the update.
Builder creating a service matching the specification of IContentService through remote calls.
Remote context value getter.
Remote implementation of IDatabaseService using the REST API of the Database defined by IDatabaseRestService to perform all the service actions.
Enum of the supported target versions for the Database REST API.
Builder creating a service matching the specification of IDatabaseService through remote calls.
Remote version of a IMonitorService.
Spring configuration class defining Repository services available in ActivePivot through remote calls.
Spring configuration class defining remote services connecting to the Repository.
Transaction containing the members removed in a Data Node.
A read-only IAggregateStore that simulates the replication of each row of each column of another store.
Same as ReplicatedColumn but the underlying column also implements IDecoratedArray.
Spring configuration class for services offered by Repository extension for ActivePivot.
Default implementation of IRepositoryAuditDao.
The repository cache rest services configuration.
The repository cache rest service implementation.
Helper for the repository cache.
The repository daemon task that runs in the background.
The repository cache daemon actions implementation which is responsible for updating the cache to reflect repository data updates.
Helper class enabling starting the repository daemon once the distribution is stable.
The Hibernate configuration for the repository persistence.
Collection of JavaTypes that are serialized and sent by the remote Service.
Default implementation of IRepositoryListenerManager.
Spring configuration class defining Repository REST services configuration.
The repository rest service implementation.
Class defining information about Repository REST services.
The repository result class.
DTO class representing a result from the ActivePivot Repository cache.
Helper with security shortcut methods.
The repository service implementation.
The repository service configuration.
Spring configuration class defining the beans related to WebSocket services.
Basic implementation of services to handle workflows on parameters.
Explicit implementation of the request unmarshaller extended plugin.
An iterator that can be reset back to an initial state.
A max heap with the ability to store primitive doubles.
A max heap with the ability to store primitive floats.
A max heap with the ability to store primitive ints.
A max heap with the ability to store primitive longs.
A min heap with the ability to store primitive doubles.
A min heap with the ability to store primitive floats.
A min heap with the ability to store primitive ints.
A min heap with the ability to store primitive longs.
Context used during resolution.
Sql model of a query ready to be remodeled or optimized.
Builds a ResolvedQuery from a UnifiedApiQuery.
Configuration class that provides the resource mapping bean, that manages the dispatching of resources request.
Explicit implementation of the IResponseMarshaller extended plugin.
Message to sent to one or several instances to order a restart of their messenger.
A class holding the available JSON parameters for RestBulkApiServerController.
The JSON parameter to call PUT as a bulk action and create or update all the given entries.
Implementation of the REST Bulk API of the content server.
A class holding the available JSON parameters for RestContentServerController.
The JSON parameter to call POST and import the whole given sub-tree in a single bulk action.
The JSON parameter to call POST on a given path and move an entry to a different path.
The JSON parameter to call POST on a given path and create a new child entry.
The JSON parameter to call PUT on a given path.
The JSON parameter to update the permissions of an entry.
Implementation of the REST API of the content server.
A class to extract the namespace and the version from a rest prefix following the default format.
 
A restricted view of a HierarchicalMapping that masks certain hierarchies and levels.
This implementation of an IMeasuresProvider relies on another IMeasuresProvider, but giving access to only some of the measures.
Helper class for manipulating restrictions.
Monitored factory implementation for .
Helper class for REST services.
Common functions and variables used by REST services.
Wraps an IPartitionedGenericResultAcceptor into a simple IAsyncResultAcceptor by providing 0 as the partition when required.
Implementation of ICanStartBuildingCalculatedDrillthroughColumnDescription.ICalculatedDrillthroughColumnDescriptionBuilder holding a callback with its result to propagate it to its parent builder.
Implementation of ICanStartBuildingCalculatedDrillthroughColumnSetDescription.ICalculatedDrillthroughColumnSetDescriptionBuilder holding a callback with its result to propagate it to its parent builder.
Implementation of ICanStartBuildingCalculatedMember.ICalculatedMemberDescriptionBuilder holding a callback with its result to propagate it to its parent builder.
Implementation with a result consumer to go back to the parent builder.
Implementation of ICanStartBuildingDrillthroughProperties.IDrillthroughPropertiesBuilder holding a callback with its result to propagate it to its parent builder.
Implementation of ICanStartBuildingKpiDescription.IKpiDescriptionBuilder holding a callback with its result to propagate it to its parent builder.
Implementation of ICanStartBuildingMdxContext.IMdxContextBuilder holding a callback with its result to propagate it to its parent builder.
Implementation of ICanStartBuildingNamedSetDescription.INamedSetDescriptionBuilder holding a callback with its result to propagate it to its parent builder.
Simple implementation of IPluginDescriptionBuilder keeping a reference to the function integrating this builder's result to provide the next builder.
Builder for ISubCubeProperties.
Flag that have a meaning after an operation (Bottom/up approach).
A class to create and merge IClearableBitmap.
Result wrapper which transforms SQLException to ActiveViamRuntimeException.
An array reader wrapping a ResultSet.
Task which converts SQL ResultSet into PointAggregateStore.
A cursor wrapping a ResultSet.
Array reader which is only capable of reading one field value.
Wrapper holding both a ResultSet and the IJdbcConnectionHolder used to obtain the ResultSet to be able to close them both at the same time.
Lighter internal wrapping method of a JDBC result set.
 
 
Abstract converter to PointAggregateStore.
 
Component responsible for result translation from data nodes to query node.
The retrieval data.
 
An exception that occurs when retrieving aggregates.
Special class implementing a key to register an IAggregatesRetrieval when walking the execution graph.
Component responsible for holding the results of the corresponding retrievals held in the ExecutionPlan columns, and keeps track of their usages as underlying dependencies of other retrievals.
Exception thrown when a retrieval result exceeds the size limit.
Basic implementation of IRetrievalResultTracker.
Message sent from a query cube to the data nodes involved in a given GetAggregatesQuery.
Procedure to collect recorded versions, starting from the given epoch id.
An ICompiledPartitionContentOperation that always returns all the rows in the partition.
 
Basic implementation of a IReturnFunction.
Plugin implementation for storing drillthrough function plugin values.
Compares two objects implementing the Comparable interface, but the order implied by this comparator is the reverse of the order implied by the Comparable interface.
Compares two Double objects, but according to the descending order.
Sorts the epochs, from the most recent to the oldest.
Compares two Float objects, in descending order.
A comparator to compare locations or axis members over the hierarchy, with respect to the reversed comparators of each level in the hierarchy.
Compares two Integer objects, in descending order.
Compares two Long objects, in descending order.
Reverse natural order java Comparator.
 
This function calculates the RGB color Ex : RGB(255,0,0) RGB(255,[Measure].[contributors.COUNT],0) if the count exceeds 255 or is negative we make it 255 or zero (This is what MSAS does).
Class representing a cell with content displayed with a padding of n chars on the right.
A graph's root node.
 
Cursor creating records from rows by following flattening instructions.
A records iterator that flattens by batch.
A IRowsIterator over a bitmap of rows.
Operation that merges the rows of the results of the query from either side of a reference and keep only the result rows where the referenced row is also a result row (cross-validation).
A rowset implementation.
Rowset definition column.
Is the column optional.
Is the column a restriction.
Explicit implementation of the XMLA IRowsetDefinition plugin.
This class contains utility methods for the rowset.
Updates a cell plan result and produces an mdx event.
Updates a cell plan result and produces an mdx event.
RTScope used during real time updates.
Implementation of real-time expression dependency.
A visitor dedicated to the computation of real time dependencies.
A cube which can be used for real time queries.
Class used by the RTCellPlanExecutor.RTIntermediateResultHandler during the first execution of a real-time query.
There are 4 cases after updating an mdx result: Nothing change It was not possible to update the result The result of the update is an MdxResult The result of the update is an CellPlanResult.ICellPlanResultIterator
An object containing the updates of the continuous queries and information about hierarchy members.
Exception wrapper around ParseException to be able to use functional interface for methods normally throwing it.
Class defining all security filters for HTTP services specifically exported by Atoti Runtime.
Wrapper on an Amazon S3's directory.
Entity referencing an S3 object.
Object referencing an object on S3.
Entity referencing a range of bytes of an S3 object.
Implementation of AConcurrentlyFetchingChannel for AWS S3.
 
A RecursiveTask that safely executes an action that relies on the broadcasting infrastructure by allowing a few error and retry iterations before giving up.
Simple wrapper around Native and its versions of loadLibrary(..).
A vector of doubles whose values are all identical.
A vector of floats whose values are all identical.
A vector of integers whose values are all identical.
A vector of longs whose values are all identical.
A vector whose values are all identical.
Util class to create on heap vectors containing a unique value, repeated n times.
A IUserDefinedAggregateFunction which calculates the standard deviation using the sample formula.
A IUserDefinedAggregateFunction which calculates the variance using the sample formula.
Represent the field identifier used in an SQL string.
Represent a sanitized identifier.
 
 
Validate the configuration of the schema and throws ConfigurationException when inconsistencies are found.
Immutable description of the schema of a database.
 
Utility to convert schema description to internal schema description.
Utilities to transform an InternalSchemaDescription.
 
 
 
 
 
 
Modifies a field by changing its type.
 
 
 
 
 
Dictionary provider based on the schema.
An IInitialDiscoveryMessage whose hierarchies are sent empty of all their members, except for the measure hierarchy.
Contain code for common operations involving IDatastoreSchemaMetadata.
 
Data transfer object for MBean monitoring.
Print content of the datastore: stores, records, dictionaries.
Basic implementation of a ISchemaSelectionSession.
The ISchemaSelectionSessionHolder that supports updates in the selection via IActivePivotSchemaUpdater.
Immutable graph representation of a Schema.
Implementation of the IActivePivotSchemaTransactionInfo interface.
Utilities to transform an SqlDataSchema.
 
 
 
 
 
 
 
Modifies a field by changing its type.
Modifies a SqlDataSchema.
 
 
 
 
 
Schema utilities.
Utilities to validate a IDatabaseSchema.
 
 
An Object used to transport a IScopedAggregatesRetrievalResult from one instance to another.
Scoped CellSet implementation.
A scope defines which locations among the global location list belong to the scope.
Range scope.
Base implementation of a IScopeLocation.
Collection of search cost constants.
A concrete reference factory for references from a secondary index to a unique index.
Implementation of AIndexDisjoinedLookupCompiledOperation for secondary indexes.
An IPartitionContentFactory used for creating IMultiVersionSecondaryRecordIndex for a given store.
Implementation of AIndexRangeDisjoinedLookupCompiledOperation for a secondary index.
Implementation of an ISecondaryRecordIndexTransaction.
Implementation of an ISecondaryRecordIndexVersion.
Wraps another WebSocketHandler instance, sets the authenticated user in SecurityContext before delegating messages to the underlying WebSocketHandler.
Default implementation of a security details token, exposing a user name and a set of granted authorities (roles).
A Spring Authentication based on an ISecurityDetails.
 
Helper class setting the security for the application.
Default implementation of the Factory provided by the core product.
 
Extended plugin for ISelectConverter.
Base implementation of ISelectedStore.
Abstract selection referencing a store and defining AliasedFields.
Definition of a selection in the structure of a manager.
The description of an ISelection.
 
The basic implementation of an ISelectionMapping.
A helper class to create the SelectionMapping.
Selection mapping creator.
Implementation of an ISelectionMetadata.
Enumeration representing an estimated number of lines returned by an operation.
 
 
 
The Select statement resolver, that takes care of resolving a select statement.
The ActiveMonitor alert stored in the database.
The alert data access object.
Implementation of a ISentinelPublisher.
Custom comparator for ActiveMonitor events.
ActiveMonitor daemon task that runs in the background and perform SentinelDaemonActions periodically.
ActiveMonitor actions called by the SentinelDaemon to periodically retrieve the monitors updates performed on ActiveMonitor server, in order to adapt their registration with the mdx engine.
The ActiveMonitor event stored in the database.
The ActiveMonitor event data access object.
Override for ActiveMonitor project.
Extension of the MDX post-processor compiler to support ActiveMonitor special functions.
Stream query for KPI monitoring.
Stream performing the MDX monitoring for ActiveMonitor.
Parent Monitoring MBean for information about AP connection with ActiveMonitor.
Override for ActiveMonitor project.
ActiveMonitor Activiti entity manager to cache all definition entities.
Factory class for the containing manager.
Implementation of a IRepositoryService over a remote server using the REST API defined by IRepositoryRestService.
Helper with security shortcut methods.
The ActiveMonitor state stored in the database.
Stream event publishing monitoring events.
Tuple designed for SentinelMdxStream streaming.
Class representing the location of a tuple, i.e.
Implementation of IUserDefinedAggregateFunction where all the steps of the aggregation are given in the constructor.
 
 
Serializable user defined vector aggregate function with removal.
Implementation of a custom serialization It is used to avoid a lot of transient memory generated by the serialization of objects.
This class contains a set of static utility methods for efficient serialization.
ActiveViam custom serialization keys - or codes - to flag the type of the content to come.
Exception type for serialization exceptions.
Visitor in charge of adapting IMemoryStatistic for serialization process.
Registry contributor for the server impl module.
Registry contributor for the activepivot-server-json module.
Exception class for requests whose completion depends on a another service that returned an error and cannot be reached.
Class exception for services implemented by ActiveViam.
Class exception for services implemented by ActiveViam.
A contribution provider that uses the Java Service Provider Interface to populate the registry.
Provide an instance of the read-only service to the database.
Various utilities for webservices.
Class exception for situations where the server cannot handle the request (because it is overloaded or down for maintenance).
Properties for the XMLA Servlet.
 
The session data that keeps all the information of the continuous queries (streams) within a given session.
JSON object containing the list of id of the streams that have been garbage-collected.
Structure storing needed configuration for a stream that executes a continuous query.
MBean to monitor hibernate session factory.
Allow to access statistics about a hibernate session factory.
A set builder.
An instance of the set cover problem.
Implementation of ISetCoverSolution representing a solution covering the whole universe of the solved SetCoverInstance.
A subset of a SetCoverInstance.
The set discovery.
The set discovery builder.
Implementation of ISetExpander for the CellPlanResult.
Factory for procedure that set a field to a given value.
Basic implementation of ISetIndexDictionariesConcurrentAction.
Utility functions for set manipulation.
An iteration procedure.
Large set compaction procedure.
 
 
Result of converting a set to a range set.
 
 
Values supplier when the list of values is explicitly known.
A task that can be divided into ranges to spawn sub-tasks.
Wrapper class for an IWritableDictionary that synchronizes write accesses to it.
Main implementation of ISharedMemberSubTreesContributor.
Utility embedding for subtree contribution
Wrapper for an OutputStream that should not be closed.
A shared span that can be used by multiple tasks to record events and exceptions.
A shared queue in which available threads/joining threads can help themselves to a task.
To SharedTaskQueue.SharedTask.execute() this task, a thread will have to set its SharedTaskQueue.SharedTask.executing flag to true.
The default platform to use when on an unknown system.
A PpNode that will be eventually computed through range-sharing of one of its children.
A PrimitiveNode that will be eventually computed through range-sharing of one of its children.
Copper measure used to perform location shift operations.
Operation defined via a constant value to shift to apply on a cube's level.
Copper object to define a condition shift.
Copper object to define a lambda shift.
Copper object to define a level-based shift.
Factory for the ShiftMeasure.
Operation defined via a lambda function to apply on cube's levels.
Operation defined via a constant value to shift to apply on a cube's level.
A Shift PP which handles shifting a level to the current value of another level.
Prefetcher of the read cell set for the ShiftPostProcessor.
SHORT aggregation function.
The short sum binding for vectors.
Parser for short fields.
A re-aggregation function for a SHORT.
 
Abstract service which generates SignedJWT.
Plain record acting as a Contribution Holder.
Simple implementation for IOperationInfo which takes no input argument.
Tester for a GetAggregatesResultCellset on a simple cell.
A simple implementation of the ICompositeReadableColumn.
A SimpleCompositeReadableColumn which also fake the implementation of IPositionalReader so it can be passed into AggregateStore.bindAggregates(IPositionalReader, int).
Base class for simple translators that encode context values into a single property.
Simple implementation of ICubeDescriptionBuilder.
Simple implementation of IDimensionBuilder.
Builder for a global entitlement.
Builder for a pivot entitlement.
Simple implementation.
Simple immutable implementation of IActivePivotManagerDescriptionBuilder.
Alternate class with the same API but different generic types, delegating all its calls to a SimpleManagerDescriptionBuilder.
Default measure formatter.
Simple measures provider that has no additional measures.
A simple ThreadFactory that names each Thread using a prefix and an incrementing counter.
 
A simple IGraphVisitor.IVisitorContext that does not contain any contextual information and simply keeps track of the next nodes to visit.
Basic implementation of a builder for Partitioning descriptions.
Basic implementation of a Partitioning format taking the available list of fields as a parameter.
 
A simple query planner that always makes operations in target stores to be executed before those of owner stores.
Simple implementation of an IActivePivotSchemaInstanceDescription builder, with a IActivePivotManagerDescriptionBuilder parent.
Simple implementation of the selection description builder.
Default implementation of the single accessor.
Implementation of an async view listener monitoring a single aggregate streamed View and dispatching all updates to an underlying specialized listener.
An immutable ASqlField representing a single SQL column.
 
A composite listener that wraps a single ISelectionListener over one selection id.
A FIFO queue of items that supports concurrent contributions but single-threaded polling.
A consumer procedure that directly receives the items stored in the queue.
Interface representing a Node in this SingleConsumerQueue.
A consumer procedure that receives each node.
A CopperLevelCondition on one single level.
 
Used for version using a single digit scheme versioning for forward compatibility.
Contribution holder containing all alerts related to a given monitor.
POJO representing an aggregation on a single field.
An operator which applies to a single field.
Topic based on a single CSV file.
A simple SQL aggregation on a single database column representing a single SQL column.
Implementation of ILinkageStrategy where the distance between two clusters C1 and C2 is equal to the minimum of the distance between query vectors V_i and V_j such that V_i belongs to C1 and V_j belongs to C2.
Implementation of an async view listener monitoring a single list view and dispatching all updates to an underlying specialized listener.
Single hierarchy location set.
Generate list query on a single unnested vector table.
Class implementing partitioning over a single field.
Implementation of AGreatestCommonPartitioningCalculator for this partitioning.
Visitor to check if a single-field partitioning is implied by another partitioning.
Visitor to retrieve the partition id of a single-field partitioning, knowing the id of the partition of another partitioning by which the single-field partitioning is implied.
Visitor to retrieve the partition ids of a single-field partitioning, knowing the id of the partition of another partitioning which is the reduced partitioning of the single-field partitioning.
A PartitioningNode that produces only one partition and that is associated with a decision value of its parent node.
Description of a partitioning node that produces only one partition, and thus has no partitioning rule.
An optimized implementation of IPointLocationList when the list contains only one element.
A single row IRecordBlock that exposes an underlying record.
A record block that holds a single element.
A formatter that transforms any value to the same constant string.
Basic formatter for a single section format.
Take the opposite of the number before formatting it.
Stream information holding data about a single status.
A IExecutionPlanBuilder that builds single thread execution plan.
An iterator iterating over only one instance of a given class.
Singleton location list.
Set made of a single tuple.
Aggregation function that holds a single value.
Binding for the 'array of objects' data type.
Binding for the 'boolean' data type.
Binding for the 'double' data type.
Binding for the nullable 'double' data type.
Binding for the 'float' data type.
Binding for the nullable 'float' data type.
Binding for the 'int' data type.
Binding for the nullable 'int' data type.
Binding for the 'long' data type.
Binding for the nullable 'long' data type.
Binding for the 'object' data type.
A generic cache with time to live for a unique value.
Builds a ArrowVectorReader from a field vector.
Helper class with method to build and parse sites of monitors.
cursor with a size limit.
Implementation of IPartitionSelector selecting all partitions.
A chunk allocator using SlabMemoryAllocator as native memory allocator.
Also known as malloQ, this allocator is optimized for NUMA systems that supports huge pages.
Event fired when an activepivot query fails because of a timeout.
Engine that recommends an optimized configuration of partial providers to cover a given queries history.
A description that specifies the configuration of a SmartAggregationEngine.
Utility class for the smart aggregation engine.
Smartly printing the content of a version.
SnapshotContentTree is an extension of ContentTree with some fields specified as JSON properties for serialization.
Process a context node snapshot, refresh subscribed query results, and return a collection of tasks that will notify listeners.
 
Create snapshot refresh task from registered listeners and version to snapshot.
 
Perform a reset and a snapshot refresh task on all listeners.
DOM based implementation of the input soap message parsing.
Implementation of the XML response marshaller.
Class implementing a message subscriber providing the updates to the user through websocket.
This class provide access to native Linux NUMA functions.
Observability utilities.
Span levels.
A IChunk whose only a small part of rows is actually used.
A ChunkSet whose chunks are of type sparse chunks.
Implementation of ISpreadsheetRestService.
Extension of the ABasicAuthenticator where the credentials of the spring security context will be used when communicating with the remote service.
Property Resolver retrieving properties from the Spring Environment.
A security facade relying on the Spring Security framework, expecting a security context statically installed.
SQL select which are computed from an aggregation.
Projection element of an ISqlAggregation.
Utilities for Aggregation in SQL.
 
SQL Aggregation function for Approx Distinct Count.
 
SQL-Int token implementation.
 
Class representing a reference to a column in an SQL query.
Class representing a reference of a column in the ResultSet.
A CompositeDatabase with an SQL external database.
Class defining all information required for a query to be run.
Class adding the conditions into the query builder.
Count aggregation.
Immutable implementation of an IDatabaseSchema for a SQL database.
 
 
Stream registration.
Default immutable implementation of an ISqlDataTable.
 
Transaction manager for data changes in an external SQL database.
SQL-Date time token implementation.
Interface representing a function for a single column.
Static class containing some enum values used in the SQL dialect.
 
A param indicating where the limit for the result size should be placed.
 
SQL equality predicate defining how to join one table to another.
 
SQL-Float token implementation.
A fragment of an SQL query, which can be later transformed into an IExecutableQuery.
 
Sql Aggregation function for gross (i.e.
SQL-Int token implementation.
Immutable implementation of an ITableJoin for a SQL database.
 
This class generates the SQL join conditions from a SqlQuery, based on the following contract:
Sql Aggregation function for long (i.e.
Sql Aggregation function for max.
Sql Aggregation function for max.
Sql Aggregation function for min.
Sql Aggregation function for min.
SQL-Money token implementation.
Sql Aggregation function for multiply (i.e.
Immutable implementation of a table containing a vector where each value is on a different row.
 
Generator for databases using named parameters in their SQL queries.
SQLNChar token implementation.
SQLNVarChar token implementation.
 
A placeholder for data such as a column or a default value.
A string representing a part of an SQL query.
Representation of a prepared query returning aggregated values.
Representation of a prepared query returning distinct row values.
Representation of a prepared query returning a single record from its key.
Representation of a prepared query returning row values.
SQL query which could be used as a table (sub query) in a wrapping query.
 
SQL query field which is not bond to ISqlDataTable.
Representation of a directed SQL join from a source table to a target table.
 
SQL optimization utilities.
SQL query field which exists in schema.
Utilities around SqlQuery.
Check API queries validity.
SQL-Real token implementation.
SQL implementation of an IRecompilableAggregateQuery.
SQL implementation of an IRecompilableDistinctQuery.
SQL implementation of an IRecompilableGetByKeyQuery.
SQL implementation of an IRecompilableListQuery.
Resolved AliasedField.
SQL column in query result.
Expected query result model.
 
Helper for schema modeling mappings.
 
Sql schema transaction manager.
Updater for an SqlDataSchema.
 
SQL select field which is just a selection from a query table .
Sql Aggregation function for long (i.e.
SQLSmallInt token implementation.
Sql Aggregation function for the sum of squares.
Statistics on SQL database.
Sql Aggregation function for sum.
Sql Aggregation function for sum product.
SQL persistent table which exists in schema.
SQL persistent table column which exists in schema.
Simple representation of a database table ID which is agnostic to the database.
 
 
Class for all variance-based aggregation functions (STD and VAR).
SQUARE SUM aggregation function.
Square Sum binding for the 'double' data type.
Square Sum binding for the nullable 'double' data type.
Square Sum binding for the 'float' data type.
Square Sum binding for the nullable 'float' data type.
Square Sum binding for the 'long' data type.
Square Sum binding for the nullable 'long' data type.
A re-aggregation function for a SQ_SUM.
Utility methods for VersionHistory.
Runtime exception thrown when it becomes impossible to retrieve data from an external database at a given point in time (time travel window is too short and external database has been updated).
A listener to a stream that increments a stamp for each event that we receive.
This configuration exposes all the REST services that are required when the Content Service runs separately from ActivePivot.
Configuration of the content service with no pivot.
Standard compressor.
 
 
 
Proof of concept implementation done in order to understand how the compression is done.
Standard merge procedure that merges two axis members The own member sees its count updated by adding the count of the target member.
Standard implementation of IRegistry.
Implementation for creating the standard ActiveViam registry.
A location that has been cleansed and from which the analysis coordinates have been removed.
Name of timers that will exist in almost any project based on the datastore.
List of standard types for Fields in Data Tables.
Contains all entry points to start create an ActivePivot with a Datastore.
 
Error report for checking if vector tables have all the same start index.
The state data transfer object.
Class converting a state to JSON in hibernate.
Command defined by a IStatement.
Helper used to efficiently expand range tuples/members.
A IOperand that knows at query compile time the position of the value it is looking for.
 
Version of StaticOperand for IN conditions.
 
A StopWatch using StatTimer instead of traditional Timer.
Timer for statistics.
Stdev function.
StdevP function.
Base implementation of IStopWatch.
Utilities for IStopWatch.
 
The base version of an IMultiVersionStore that contains its current state.
An action to be executed on each one of this store's partitions.
Definition of a store.
 
Default immutable implementation of IStoreDescription.
A simple IStoreDescription builder.
A fluent builder class, that will assist you in creating a StoreDescription.
This class exposes various listeners.
This class represent the field of a store/table.
A Copper measure which can use data from a store outside of the Cube selection, provided this store has been joined to the Cube through a UnlinkedCopperStore.joinToCube() call.
Monitor of the field of a store.
Points to a field of a store by names.
Store format.
Monitors an index (unique index, secondary index) on a store.
Class used on the edge of the datastore structure.
Object used to carry components used by store.
Identifier for a store.
Implementation of the Store locker.
Lookup measure.
StoreLookupMeasure Factory.
Updates the structure of a database given an IPostProcessorDescription associated with a DictionarizedStoreLookupPostProcessor.
A post processor that runs, for each location it is evaluated at, a get-by-key query on the database.
A CSV message whose content is parsed from text.
StoreMessage channel to create and publish CSV messages.
Store metadata that contains all the static data.
Holder for datastore metadata and internals.
Provides the list of member tuples contained in a selection of fields for a given store.
The base store partition.
The content of a partition.
Monitors the unique index or secondary index of a partition of a store.
Monitors a store's partition.
A IStorePartitionWorkUnit that simply tries to trigger the completion of a completer.
IStorePartitionWorkUnit to add records to a partition.
IStorePartitionWorkUnit to remove records from a partition.
A work unit to execute a remove where operation asynchronously.
A work unit that updates the fact for a new version that is equivalent to a given version.
The store partition transaction.
An implementation of IStorePartitionUpdate designed for use by a DeltaQuery.
Execute the update where inside a transaction.
A work unit to execute an update where operation asynchronously.
POJO that contains information about an execution instance of an update where procedure.
Version of a given store partition.
Worker that processes records for a store partition.
Component that synchronizes the addition of work to be done on a partition by a given worker.
Describe a search on a store.
The base implementation of a IStoreSearchBuilder.
A full scan condition evaluation.
Always return all the rows in the partition.
Give the list of members contained in a store field.
A POJO containing summary information about the direct memory consumption of a store.
A POJO containing summary information about the direct memory consumption of a store partition.
Implementation of an IStoreTransaction.
Utility class on the stores.
Simple data class containing a partitioning and a mapping.
A version of a store.
A dictionary that lets override the hashing strategy.
Cumulative measure along a time axis.
Implementation of AContinuousQueryMonitorsGrouper to regroup continuous GAQ monitors under a stream node.
Stream view info needed by an incremental refresh task.
Abstract stream event.
A query that wraps the processing of a stream event, including the update of the continuous queries whose handlers depend on this stream.
Attached query associated with stream event processing queries.
Class with helper methods on Streams.
Explicit implementation of the IStream plugin.
Explicit implementation of the IStream extended plugin.
Stream impact.
A holder of information of a stream.
Registry contributor for the streaming module.
String configuration for monitor of streaming service.
A decoder which deserializes the received ByteBufs into Java objects.
An encoder which serializes a Java object into a ByteBuf asynchronously neither spending a lot of memory nor getting OutOfMemoryError.
Implementation of a IStreamingService.
A BeanPostProcessor that substitutes an IStreamingService by the corresponding MonitoredStreamingService.
Exception thrown by the Streaming Service Web Service.
Monitor for the streaming service component.
Unique identifier for a stream need (Fact feeding, Provider feeding...).
Within the Continuous Query Registry, a stream node represents the current registration context for one stream.
Explicit implementation of the IStreamNode extended plugin.
This monitor regroup all monitors for registered streams on the continuous query engine.
Statistics for a stream node.
Statistics collected at the level of a stream node.
Implementation of IStreamProperties.
Implementation of IStreamPublisher.
Implementation of IStreamSnapshotService.
Stream state data.
Stream translator plugin, contains the plugin values that are available by default.
Helper methods for common operations on Stream.
IStatistics of type STRING_ARRAY.
Wrapper for an Arrow Vector of Strings.
Build string with indentation.
Implementation of a read-write cell supporting data of type String.
Provide utilities for creating Collection of strings.
Basic comparator for strings.
Base class for translators of string context values.
Dictionary implementation specialized for storing strings.
A form field for text values.
 
Helper to read file line by line.
 
 
 
 
String compare function http://msdn.microsoft.com/en-ie/library/9s233cfc%28v=vs.90%29.aspx.
Class converting a map to JSON in hibernate.
Adapter to convert an object tree to a Map<String, String> representation.
Parser for string fields.
A key-value property where the key and the value are strings.
A list of string properties.
 
invalid reference
IStatistics
of type AttributeTypes.TYPE_STRING.
Class providing utility methods to manipulate strings.
Special parser for vectors of Integers.
 
 
Transaction for the DelegateActivePivotManager.
Structural manager transaction.
 
 
 
A plan which makes a sequential visit of the actions.
Validates the configuration of the schema and throws ConfigurationException when inconsistencies are found.
Implementation of sub condition.
A sub cube axis dimension ISubCubeProperties.
Implementation of IHierarchy which handles ISubCubeProperties.
SubCube Walker restricting a given subCube by removing conditions on missing levels for each hierarchy.
A measure hierarchy which handles ISubCubeProperties.
A measure hierarchy which is automatically filtered using the current context.
Node of the sub cube tree.
Helper class for intersection of several sub-cube nodes.
This class is an implementation of the ISubCubeProperties interface.
Translator for ISubCubeProperties.
Implementation of ISubCubeTree.
Type of location's states.
This can walk a subcube, showing around an ISubCubeVisitor what is to see, and in particular allowing the visitor to construct an alternate and equivalent version of the subcube by visiting the conditions for a set of hierarchies.
A sub-location derived from a location pattern.
An index to quickly access to a subset of points stored in a dictionary 'P'.
ISubPointIntegerArrayIndex implementation wrapping a list of small underlying secondary indices into a "merged" index.
A SELECT statement inside a FROM clause.
Checks that the expression can be written as a CrossJoin of single hierarchy sets.
 
 
Mutable object to express a subsequence.
Subset of a random access set.
 
Subset(Set_Expression, Start [ ,Count ] ).
 
SUM aggregation function.
Sum binding for the 'double' data type.
Sum binding for the nullable 'double' data type.
Sum binding for the 'float' data type.
Sum binding for the nullable 'float' data type.
Sum binding for the 'int' data type.
Sum binding for the nullable 'int' data type.
Sum binding for the 'long' data type.
Sum binding for the nullable 'long' data type.
An aggregation function that does the sum product of all the sources it is given.
Sum Product aggregation for the double vector type.
Sum Product aggregation for the float vector type.
Sum Product aggregation for the long vector type.
Sum Product binding for double aggregated type.
Sum Product binding for nullable double aggregated type.
Sum Product binding for float aggregated type.
Sum Product binding for nullable float aggregated type.
Sum Product binding for long aggregated type.
Sum Product binding for nullable long aggregated type.
A SumProductFunction.ASumProductBindingVector that scales the source vector by a factor of type double.
A SumProductFunction.ASumProductBindingVector that scales the source vector by a factor of type float.
A SumProductFunction.ASumProductBindingVector that scale the source vector by a factor of type long.
Sum product aggregation between multiple scalar fields, for instance SUM(a * b * c).
A re-aggregation function for a Sum Product, which just needs to sum the pre-aggregated values.
A sum product over a bunch of scalar columns and a multi-columns vector column.
Sql Aggregation for sum product with a native vector column.
A re-aggregation function for a SUM.
SQL sum aggregation.
Factor properties of sum-like vector aggregations.
PostProcessor used to perform switch operations based on the depth on a hierarchy.
Copper measure used to perform switch operations based on the current location.
SwitchOnMeasure Factory.
PostProcessor used to perform switch operations based on the current location.
An AAggregatesContinuousQueryEngine that synchronously processes its received events, recomputing the locations impacted by received events.
Implementation of an AAggregatesContinuousQueryEngine.IEventPolicy processing events synchronously.
IPointAggregator implementation that synchronously reduces points and performs aggregations.
 
Spring configuration of the core ActivePivot Components.
Property Resolver for System properties.
Implementation of ITimeSupplier delegating all time interactions to the system.
An implementation of an ITableBuilder.
Basic implementation of a column as an IArray.
Straightforward implementation of a cursor on top of a table.
Implementation of a record cursor on top of a table of data, readable from its cursor.
Default immutable description of a table.
Builder for specifying optional field properties.
Builder for specifying the external table.
Builder for specifying the fields.
Builder for specifying the table local name.
Builder for the table description.
Utilities to transform InternalTableDescription.
Utilities for TableDescription.
Provide low-level API to draw a table on an OutputStream.
Table defined with a Sql expression.
Basic immutable implementation of ITableJoin.
SQL Generator for table management: create, insert, drop.
Represents the information that are monitored.
Read and write permissions for a table.
Data class implementation of the spec of table security.
Builder for TableSecurity.
Basic immutable implementation of an ITableSecurityDescription.
Utilities to transform ISqlDataTable.
Description of a change on an external table.
 
The tabular representation of a crossjoin of books and underlyings on rows, plus counterparties on columns | {CP1, measure} | {CP2, measure} | {EUR, DeskA} | 10 | 20 | {USD, DeskB} | 11 | 30 | is The row definition : - currency.properties - desk.properties - cp1.measure - cp2.measure The first row is - currency.properties = EUR - desk.properties = DeskA - cp1.measure = 10 - cp2.measure = 20 The second row is - currency.properties = USD - desk.properties = DeskB - cp1.measure = 11 - cp2.measure = Measures are always on the columns The Allmember level on the rows must not be included in the definition The only cell property that is returned is VALUE.
 
Tabular row set column.
Select executor specialized for tabular XMLA execution.
The default implementation of a tag acceptor.
 
Subset(Set_Expression, Start [ ,Count ] ).
A ChannelInboundHandlerAdapter which discards inbound messages and logs exceptions.
The TarBuffer class implements the tar archive concept of a buffered input stream.
This class represents an entry in a Tar archive.
Information about an entry of a tar archive file.
This class encapsulates the Tar Entry Header used in Tar Archives.
The TarInputStream reads a UNIX tar archive as an InputStream.
This interface is provided, with the method setEntryFactory(), to allow the programmer to have their own TarEntry subclass instantiated for the entries return from getNextEntry().
DTO representing a user task to perform.
Message describing a workflow task to perform.
Forwarding implementation of tasks service.
An implementation of ATasksPerNumaNode, that registers a set of TasksPerNumaNode.tasks bound to NUMA nodes.
An implementation of ATasksPerNumaNode, that registers a set of TasksPerNumaNodeExecutor.tasks bound to NUMA nodes.
A utility object to use with any class that requires exporting metrics and/or traces.
Supplier for the default tags to apply to the metrics and span exported by this exporter.
A simple reusable procedure testing if the values it processes are included in a given set.
Class to write a text output in one or several files.
Class to write a text output in a zip file in the cloud.
Class to write a text output in one or several files.
Class to write a text output in stream.
Class to write a text output in a zip file.
Utilities around thread dump.
 
Lazy thread-safe initialization wrapper.
 
JMX monitoring MBean for threads' status, such as blocked, waiting and long running threads.
Monitor the throughput at which a quantity changes.
Time bucket hierarchy.
Factory to create instances of TimeBucketHierarchy.TimeBucketProcedure.
Aggregation procedure dynamically contributing time members to the time buckets.
This class generates the description of the TimeBucketHierarchy.
Aggregates continuous Handler specialized for timeline based post processors.
A strategy for the arrays.
 
Utility class for timeline post-processors.
A location key is a key based on a location and subset of targeted levels.
Class exception for requests whose execution time out.
Effective implementation of ITimePeriod.
DTO representing a time period.
In case of concurrent calls only the sum of timings when the timer is not running anymore is relevant, not what is returned by Timer.stop().
A simple query executor that times each queries that get through it, and logs the timings at the Level.INFO level.
 
 
Implementation of a timestamp using a Java date.
Binding from a timestamp column to a timestamp column.
Timestamp Binding from an long column to a long column.
An immutable snapshot of a
invalid reference
Context
.
Time-travel related information.
Class specialized for database supporting queries with an arbitrary timestamp.
Light plugin value for the Timestamp IAggregationFunction.
 
 
 
 
Class to share some useful code between the various implementations of ITimeTravelService.
The type of agregration on timing statistics.
Utility to measure the total time spending on the components (identified by 'timeName') under a specific group (identified by 'identifier') in a multithreaded environment.
 
A timing (in ms) with an identifier.
Function associated to the ToBooleanRecordMapOperator.
Operator that applies a given function to multiple measure values and produces new values which content type is Types.TYPE_BOOLEAN.
Function associated to the ToBooleanUnaryOperator.
A specialized operator that only accepts a single operand, and returns a new measure of type Types.TYPE_BOOLEAN.
Function associated to the ToDoubleRecordMapOperator.
Operator that applies a given function to multiple measure values and produces new values which content type is Types.TYPE_DOUBLE.
Function associated to the ToDoubleUnaryOperator.
A specialized operator that only accepts a single operand, and returns a new measure of type Types.TYPE_DOUBLE.
Represents a function that produces a float-valued result.
Function associated to the ToFloatRecordMapOperator.
Operator that apply a given function to multiple measure values and produces new values whose content type is Types.TYPE_FLOAT.
Function associated to the ToFloatUnaryOperator.
A specialized operator that only accepts a single operand, and returns a new measure of type Types.TYPE_FLOAT.
Function associated to the ToIntRecordMapOperator.
Operator that applies a given function to multiple measure values and produces new values which content type is Types.TYPE_INT.
Function associated to the ToIntUnaryOperator.
A specialized operator that only accepts a single operand, and returns a new measure of type Types.TYPE_INT.
Function associated to the ToLongRecordMapOperator.
Operator that applies a given function to multiple measure values and produces new values which content type is Types.TYPE_LONG.
Function associated to the ToLongUnaryOperator.
A specialized operator that only accepts a single operand, and returns a new measure of type Types.TYPE_LONG.
A dead block.
A dead chunk.
Placeholder column for discarded results.
Function associated with ToObjectRecordMapOperator.
A non-specialized operator that only accepts a single operand, and provides a cell into which the new measure can write any result.
Function associated with the ToObjectUnaryOperator.
A specialized operator that only accepts one operand, and returns a new measure of the specified type (by default, it is Types.TYPE_OBJECT).
Common implementation for TopCount, BottomCount, TopPercent, BottomPercent, TopSum, BottomSum.
Common implementation for TopCount, BottomCount, TopPercent, BottomPercent, TopSum, BottomSum.
 
Filter visitor converting conditions on levels expressed as described in ICubeFilterBuilder into a condition.
A holder for a top K result.
Sorter for continuous query monitoring to calculate top K.
Dimensions/Hierarchies subversion.
 
 
Compares java objects with respect to their toString() representation.
A condition that states that an object has a toString equals to the given parameter.
This visitor returns a String representation of an ICubeFilter or ISubCubeProperties.
A formatter which call Object.toString() on the received objects.
Object reader decorator to transform empty toString to default value.
A AtotiThreadPool with extra tracing capabilities.
Store current trace context information for broadcast.
Deprecated, for removal: This API element is subject to removal in a future version.
from 6.1.0; Project should have their own tooling around the general Tracer object.
A wrapper of INativeMemoryAllocator for sampling memory allocations.
This class implements the IParentAxisMember interface.
Two axis members are equal when their parent is the same and their discriminator is the same.
Base implementation of ITransactionalBase.
Utility to access the base of the a ATransactionalMultiVersion
An IStorePartitionView over a partition.
The content of a message sent on a commit.
Event fired in the Query Cube when the received TransactionCommittedMessage fails to be applied.
Event fired in the Query Node when applying one or several remote transactions from one remote instance.
Event fired when a data node successfully commits a transaction and broadcasts its content to the distributed application.
Event fired when a data node successfully commits a transaction and broadcasts its content to the distributed application.
Holder for transaction operations organized as a plan of action to apply transaction impacts to listeners.
Generic transaction information object.
Base implementation of ITransactionManager.
A bounded action used to concurrently transform tuples into record blocks.
Util class for ITransactionManager.
Util class for ITransactionManager.
Class to manage a datastore transaction with a try-with-resource.
Component that is responsible for the creation and compilation, once and for all, of a plan of action to execute when the contents of the datastore are updated.
A query runner which handles query timeouts.
The option to tune the collection of transaction statistics in datastore.
This encapsulates the stream of ActivePivot's transactions.
A simple handler that always return a full impact (i.e.
The type of a transaction.
Support class that can compile transfer classes for deferred attribute injection into a target class.
The target class is introspected for its setters, and each setter is reproduced on the transfer class.
The default implementation of the ITransformedReader : uses an ITransformProcedure to transform the underlying retrieval result into the transformed value.
AgentException for all for agents attempting a transition when the state is transient.
 
 
Task that processes the batch and contributes the result to the acceptor.
KPI filter discarding all events where status does not change.
A dictionary built by IQueryNodeQueryTranslator.IPointLocationListTransporterTranslator made for data replication in distributed cubes.
A translation exception that happens in the csv parsing.
The result of the translation that holds the replication factor and the global point location list.
Implementation of a ITree using a directed graph.
A node in a store tree, representing a single store.
Provide utilities to manipulate trees.
Represents an operation that accepts two int-valued argument and returns no result.
A function which can take three arguments.
Column true condition.
Column true condition.
A compiled condition that acts as a logical statement that is always true.
A ICompiledConditionInstance always evaluating to false.
Representing a True condition which always evaluates to true.
A leaf node of a ConditionTree representing a condition always evaluated to TRUE.
Level true condition.
A predicate which always returns true.
A wait-less try-lock that is acquired with a simple Compare-And-Swap (CAS).
A generic cache with time to live.
Adds timestamp information to the cached values.
Serialization bridge for the TtlCache to serialize only what is needed and keep final fields.
Base implementation for a tuple.
Accumulates (tuple, value) records.
Tuple accumulator that keeps the (up to) maxCount tuples associated with the smallest values.
Tuple accumulator that sorts the tuples by their associated value (ascending) and keeps the first 'n' tuples whose aggregated value equals the target percentage.
Tuple accumulator that sorts the tuples by their associated value (ascending) and keeps the first 'n' tuples whose aggregated value equals the target aggregated value.
A dictionary specialized for tuple instances (Object[]).
Helper used to find the hierarchies of the members that change on several tuples.
Tuple hashing library.
A message chunk whose content is extracted from a java object using a translator.
Standard implementation of a tuple publisher, that writes the tuple directly into one store, using a transactional writer.
Set of utility functions for tuples manipulation.
Translator that produces raw tuples from parsed CSV fields.
 
 
A logging policy having a unique time limit and logging in a level events that went faster that this time limit and in another level events that were slower.
To create the instructions for two flatteners that can be executed in a same record block.
Enumeration of all the types of the IExpression.
Visitor which verifies the type and potentially casts the operands of a ConditionTree.
TypeContribution.
A Copper measure representing another measure, with additional type info given by the user.
Utility class to infer a IFieldType from a ExternalFieldDescriptor.
Exception thrown when a Java data type is not supported by the SQL Dialect.
Implementation of executor applied to entity workflow configurations for changes on types themselves.
Describe the data stored in Records.
Characteristics of a type.
A builder for fluently creating types.
 
 
Serializer for IUserDefinedAggregation aggregations.
Utility class for Udaf.
Builder used to create a Copper hierarchy.
Implementation of the base for a secondary index when the indexed point is based on a single field.
Implementation of the base of a unique index when the indexed points are made of exactly one field.
Class when a request is made to an unauthorized resource.
Wrapper around an acceptor, preventing it from being completed.
Simple evaluator that returns the underlying measure without any modification.
The underlying measures prefetcher aims to pre-loads all required pre-aggregated values on current locations.
Provide utilities to manipulate undirected trees.
Unified modeling of an API query.
 
Optimizer for a UnifiedApiQuery.
Union function.
Helper class to merge several sets.
A concrete reference factory for references from a unique index to a unique index.
Implementation of AIndexDisjoinedLookupCompiledOperation for unique indexes.
An IPartitionContentFactory used to create IMultiVersionUniqueRecordIndex for a given store.
Implementation of AIndexRangeDisjoinedLookupCompiledOperation for a unique index.
 
Implementation of an IUniqueRecordIndexVersion.
Implementation of IListenersExceptionsHandler re-throwing in an AssertionError the failures of the listeners.
Runtime exception thrown when a reader requires a branch which never existed or has already been abandoned by the multiversion holder.
Use unknown condition if you are not able to accurately express the changes for a given table.
Use unknown condition if you are not able to accurately express the changes for a given table.
Runtime exception thrown when a reader requires a version at an epoch in the past and that version has already been abandoned by the multiversion holder.
Thrown when operations fail because of an unknown record key.
Exception thrown when an Mdx query references a cube which does not exist.
Retrieve the unknown member for a member or a hierarchy.
The definition for the unknown member function on a hierarchy.
The definition for the unknown member function on a member.
A PostProcessorInitializationException that is thrown when a post-processor detects that one of its dependency does not exist.
The runtime version of UnknownOlapElementException.
Exception thrown when we are trying to do an action on a stream but the stream does not exist.
A PostProcessorInitializationException that is thrown when a post-processor detects that one of its underlying measure does not exist.
A retrieval result tracker without size limits.
Interface for representing a store in Copper that is not joined to the cube.
Enum of the types of supported joins in Copper.
An unmodifiable implementation of IDirectedMultiGraph.
Unorder function.
 
Wrapper class around a database version to highlight the fact it is not published yet.
Expression representing a function call before the resolution.
Represents a string path that cannot be matched to actual members of a hierarchy.
For allocating small amount of off-heap memory using Unsafe, i.e.
A memory allocator that allocates everything via Unsafe.
A wrapper class with some extra utilities on top of Unsafe.
Basic implementation of IUnsupportedCubeAlterationAction.
Exception thrown for operations not supported by the alterable cube.
Exception thrown for operations not supported by the alterable cube.
UnsupportedQueryException.
Implementation of IUpdateableCalculator based on level depths and leaves.
Basic implementation of IUpdateableCellContext.
 
Preliminary action to a structural change.
Basic implementation of IUpdateFieldsAction.
Update the materialized references of stores that target an initial store and propagate the impacts.
Basic implementation of IUpdateIndexesAction.
Basic implementation of IUpdateMeasuresAndProceduresAction.
Basic implementation of IUpdatePartitioningAction.
Visitor for manager structural updates.
Class defining an update on a given value.
Serializable object that hold an update request of point values.
Update schema action.
This Enum is used to know if axes with NON EMPTY must be recomputed.
Update timestamp measure member.
 
Implementation of IUpdateWhereInfo.
A wrapper to contain the result of the @IUpdateWhereProcedureFactory.
Front-end implementation of IUrlBuilder.IBuilder.
Helper class containing methods to deal with URLs.
This context set the user name and the encrypted password.
Translator for IUserAuthentication context values.
Simple authenticator with a predefined user and password.
Exception raised for a wanted context value not available in the context.
Helper class for user defined aggregate functions.
Generic binding implementation for binding underlying aggregates when performing user-defined aggregations.
Generic binding implementation for binding sources to buffers in user-defined aggregation functions.
A post-processor with support for high performance dynamic aggregation relying on an aggregation to retrieves measures at a lower level and apply the underlying user defined aggregation function on these measure values to compute the final result.
Binding implementation for binding sources to buffers in user-defined aggregation functions that supports that support removal operations (for usage in indexed aggregate providers).
Copper measure with dynamic aggregation on some levels.
This class contains the constants that are used to define the user-defined metadata headers.
User defined Sql aggregation function.
Builder final step.
Builder for the inputs number.
Builder for the output types.
Builder for plugin key.
Builder for re-aggregation capability.
Builder for expressions providers.
Generic binding implementation for binding underlying aggregates when performing user-defined aggregations.
Generic binding implementation for binding sources to buffers in user-defined aggregation functions.
Binding implementation for binding sources to buffers in user-defined aggregation functions that supports that support removal operations (for usage in indexed aggregate providers).
The wrapper of the spring security bean user details service.
DTO providing information about the user currently connected.
A list of PivotEntitlements.
An exception due to an incorrect usage of the API by the user.
A IRecordSetVersion that keeps a reference to the DatastoreSchemaVersion.
A graph of stores versions that keeps strong reference to IDatastoreSchemaVersion.
A StorePartitionVersion that keeps a strong reference to a DatastoreSchemaVersion.
A IStoreVersion that keeps a strong reference to the IDatastoreSchemaVersion.
Basic implementation of a user task.
Border builder for UTF8 environment.
.
Value function.
An implementation of a tuple comparator that compares the values associated with the tuples (usually a measure) to sort them.
Available sorting options to compare tuples.
A ValueScope is associated to a value index (which is a pair (measure, expression).
A ValueScope implementation based on BitSet.
Enum defining the different types of merge between scopes.
Var function.
VariableExtendedPlugin.
Utility class that can provide an additional variable to an underlying factory value when constructing the plugin instance.
Class representing a variable literal type, i.e.
Implementation of a Variable Plugin.
Class for all variance-related aggregation functions: STD and VAR (sample and population based).
VarP function.
A generator of IVectorBinding implementation classes.
 
Provide two strings, a before and an after one.
Basic implementation of a IVectorBindingCreator based on the classes generated by the VectorBindingCompiler.
A class used to register the various IVector implementations and provide bindings between the different implementations.
Utilities class regarding vector bindings.
Creates calculator which convert result set array to IVector.
Format of the array in JDBC result set.
Drillthrough calculator displaying only one index of a vector.
A ICalculatedDrillthroughColumnSet made to generate N columns; one for each index of a IVector.
A transfer object to allow the XMLA serialization of vectors.
Immutable implementation of an IVectorFieldDescription.
Class in charge of cleaning optionally abandoned IVectorChunks.
A formatter for IVector of numbers.
Utility class to vectorize tables.
Component performing the clustering of a list of vectors representing the queries executed by the application user.
Class packaging the logic for grouping several columns under one IDataTableField representing a vector of values.
Utility to vectorize fields, either from a description or in the schema.
Object representing a vector measure of the cube analyzed by a SmartAggregationEngine.
Utility class that provides utility functions for vectors, and default values for their configuration.
The settings to allocate a chunk.
A template engine based on Velocity tools and the Velocity engine.
 
DTO providing information about a deployed version of an API.
DTO providing information about ActiveMonitor server.
A versioned record reader backed up by chunks for storing the data.
Continuous query update bound to a version of ActivePivot.
Base implementation of IVersionHistory.
Hold a version and a reference to the previous node.
The visitor that occurs in third position and creates then records versions of new components in the VersionRewriteContext.
Operation to rewrite versions.
 
Simple java class containing Versions.VERSION, providing the version of Atoti Server.
Configuration creating a service and a server describing deployed REST APIs.
Exposes the Version Rest Service used by Atoti UI.
Versions Service holding the versions of each Rest Endpoint.
A hierarchy that's not aware of its members.
Exception representing an unsupported operation done on a virtual hierarchy.
Helper class to retrieve the members of a virtual hierarchy with a GAQ.
This post-processor is used for the levels of the virtual hierarchies to search members matching a pattern.
A virtualization of a given IPlatform that only exposes a part of the current machine.
An Exception class for Graphs.
The visual totals container holds visual totals information for the visual totals state of a pass.
 
Visitor to improve performance of multiselection when done through Excel/Live Instead of evaluating the complete set of Ascending(X) invalid input: '&' Descending(X) to grant any children/parents of X, we just need to grant X.
Implementation of ILinkageStrategy.
Standard implementation of the watcher service.
Monitoring of the ActiveMonitor Websocket.
Configurable implementation of IWebSocketEngineConfig.
Monitor for Web Socket.
A BeanPostProcessor replacing Activepivot webSocket Beans by their equivalent monitored services.
Default factory for websocket session.
Stream listener associated with one query and one websocket session.
Registry contributor for the web spring module.
 
Autoconfiguration to set up the filters for widgets used by Atoti Server's security.
A window specification for analytic (window) functions.
Implementation of Window that memoizes the window frame user description.
A provider of partitionBy levels that always returns the same list of partitionBy levels.
A provider of partitionBy levels that can only give its result at query time because the result depends on the depth of the requested location for the hierarchy involved in the Window.
Analytic aggregation measure.
Factory for WindowReduceMeasure.
Builder to create a WindowReduceMeasure.
Compute aggregation over a range of aggregated values along a given IHierarchy.
Funnels the logic of an IAggregationFunction applied as a reduction function over an array.
Special implementation of WindowBuilder made for Window.siblings(CopperHierarchy).
Windows Platform.
Nullable boolean with default value reader.
Nullable boolean with default value reader.
Nullable double with default value reader.
Nullable double with default value reader.
Nullable float with default value reader.
Nullable float with default value reader.
Nullable int with default value reader.
Nullable int with default value reader.
Nullable long with default value reader.
Nullable long with default value reader.
Nullable Object with default value reader.
Nullable Object with default value reader.
Reader for Arrow vector using an associated Dictionary.
Class describing a workflow configuration.
Basic POJO to create a compound key to store workflow configs in a map.
Resolver for workflow configuration for monitors.
Class implementing an IMonitorService with a layer of workflows for validation and other actions.
Basic implementation of a workflow payload as a Map.
Class referencing all payloads used by ActiveMonitor components.
Class implementing a process wrapper.
Class grouping all definitions of extended plugins for workflow process executions.
Extended plugin registering the core implementation of IAlertProcessExecutor.
Extended plugin registering the core implementation of IEventProcessExecutor.
Extended plugin registering the core implementation of IEventProcessExecutor.
Extended plugin registering the core implementation of IMonitorProcessExecutor.
Extended plugin registering the core implementation of IParameterNameProcessExecutor.
Extended plugin registering the core implementation of IParameterNameProcessExecutor.
Extended plugin registering the core implementation of ITypeProcessExecutor.
The workflows rest service implementation.
Basic implementation of a workflow schema.
DTO representing a workflow schema.
Provide some statistics about process completion.
Heavy class checking that BMPN are correctly defined for being used by ActiveMonitor.
A chunk that wraps an internal chunk.
Writable manager structure.
Editable structure of an IActivePivotSchema.
Basic implementation for field permission.
Editable structure of a cube.
A IRecordAcceptor that write a record into a IWritableRecordBlock.
This class is responsible for coordination of the ACellPlanExecutor.WriteTask.
DTO notifying of monitor updates through a WebSocket.
Wrapper around a Spring WebSocketSession.
Inner exception marking that the session was already closed when the message was sent.
DTO notifying of changes in monitor statistics through a WebSocket.
 
Implementation of the Xmla attribute.
Constants for the XMLA servlet.
 
 
 
 
 
Implementation of the Xmla context.
 
 
 
 
Xmla Exception.
Explicit implementation of the IXmlaHandler extended plugin.
Registry contributor for the xmla impl module.
A BeanPostProcessor replacing Activepivot XMLA Beans by their equivalent monitored services.
 
 
Registry contributor for the xmla pivot module.
Collection of Xmla Properties (http://msdn.microsoft.com/en-us/library/ms977626.aspx#xmlanalysis_topic8) and associated values http://msdn.microsoft.com/en-us/library/ms186627.aspx.
Axis format values.
Content values.
Format values.
MDXSupport values.
State support values.
Implementation of XmlaProperty.
Helper class for handling Xmla properties.
Property resulting of overriding another property.
Implementation of the literal plugin for ActivePivot http://msdn.microsoft.com/en-us/library/ms186627.aspx.
Monitor for XMLA query (discovery/execute) action.
A SAX writer.
A special DSL to configure the security for the XMLA endpoint of Atoti applications.
Select executor specialized for XMLA execution.
Atoti Server XMLA engine fulfilling the various XMLA operations and queries.
Collection of XmlaTypes.
Base class for array enum based types.
Base class for enum based types.
Base class for simple types.
A set of functions to help working with XMLA.
XML related constants.
XMLDecl token implementation.
Handles exceptions thrown by controllers annotated with XmlRestController and returns an XML error message.
Annotation to mark a class as a REST controller.
Various static methods to convert an xml string to a Node object and reversely, navigate to a particular Node...
XSDBoolean token implementation.
XSDUnsignedInt token implementation.
XSDUnsignedShort token implementation.
 
An atomic integer staying in the positive integer range with runnables that are called when going from 0 to 1 and from 1 to 0.
Deprecated, for removal: This API element is subject to removal in a future version.
Information about an entry of a zip compressed file.
 
Wrapper for an Arrow Vector of ZonedDateTime.
Parser for ZonedDateTime objects.