AbsFunction | |
Admin | |
Aggregate | |
Aggregate::Window | |
AggregateBoxState | |
AggregateQBox | |
AuroraDOMErrorHandler | |
AuroraException | The base class for all AuroraExceptions |
AuroraNode | An Aurora server node |
AuroraNode::DequeueHandle | A handle that may be used to dequeue tuples |
BinarySem | |
BoxStatsSample | Describes, for some particular second in time, the runtime stats of a some QBox in the Aurora runtime |
BSortQBox | |
BufferList | |
BufferList::node | |
CheckpointTask | A checkpoint task makes a snapshot of the state of all queues and all boxes |
ClosableFifoQueue< T > | |
CombineQBox | |
CombineQBox::StringHash | |
ConfFile | |
ConfFileSkeleton | |
ConsistencyMngr | The ConsistencyMngr listens to control streams coming from sunion boxes |
ConstantExpression< T > | |
ConstantExpression< EString > | |
Contract | Represents one contract between this node and another one |
ContractBasedOptimizer | Contract-based optimizer |
ConverterBox | Converts data received on a network port to tuples on a single stream |
ConverterBoxRunner | |
CountAggregate | |
CountDistinct | This function counts distinct values seen on a given field |
CountingSem | |
CountingSemHolder | |
CP | |
CP::ltstr | |
CPStorage | |
CpuStats | |
CPView | |
CursorScan | |
CursorSelect | |
CursorUpdate | |
DataPath | This class handles all data inputs and outputs |
DataPath::FastDequeueForwarder::ForwardHandler | Handler to attach to event loop |
DbHandle | |
DelayQBox | |
equal_string | |
EString | A lightweight string class that performs no memory management |
EStringPool | A memory pool for string data |
EvalAs< bool > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as a bool |
EvalAs< double > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as a double |
EvalAs< EString > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as an EString |
EvalAs< int32 > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as an int32 |
EvalAs< int64 > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as an int64 |
EvalAs< single > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as a single |
EvalAs< string > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as a string object |
EvalAs< Timestamp > | Used as an argument to an Expression::evalImpl() method to indicate that the expression should be evaluated as a Timestamp object |
EvalContext | Context for use in evaluating an expression |
ExistsQBox | This box is a quick hack that Linear Road needed and Eddie asked for |
ExprContext | Context for use in generating an expression from an AST |
Expression | The base class for expressions |
FairMutexWithCancel | |
FdMultiPool | |
FdMultiPoolLease | |
FidAlarmCounterFunc | |
FidAlarmCounterFunc::Impl | |
FidComplianceLookthroughAndAgg | |
FidLateTrackerFunc | |
FieldExpression< T > | |
FieldExpression< EString > | |
FieldExt | |
FifoCriticalSection | |
FileDescHolder | |
FileDescPool | |
FilterBoxState | |
FilterQBox | |
FixLenTimeSeries | Implements a Fixed Length TimeSeries |
Function | A function factory, capable of returning a function implementation given a statically typed set of arguments |
GenericCheckpointTask | Checkpoint and recovery tasks are exclusive, just like a ModifyNetowrkTask |
GlobalPropsFile | |
HA | The HA component monitors statically assigned primary HA components at remote nodes |
HA::MonitoredNode | Represents one node that we are monitoring |
HA::NodeType | Typesafe enumeration listing the different types of nodes we might want to monitor |
HA::Secondary | The Secondary class represents secondary nodes |
HashForBufferList | |
ILockable | This is an interface that defines something as lockable |
IncrementHolder< T > | |
IndexKeyEqualCursor | Cursor that takes an expression and returns the value for the matching key in the index |
InsertQBox | |
IntegerCounter | An int, protected by a mutex |
IntegerCounterHolder | |
IntFunction | |
JoinBoxState | Captures the state of a join operator |
JoinQBox | TODO: Window by values |
JoinStatic | This box joins streamed data with a static table |
KeyEqualCursor | Cursor that takes an expression and returns the value for the matching key |
LockHolder | |
LockQBox | |
LockSet | |
Lookup | |
LRAccidentAggFunc1 | |
LRAccidentAggFunc2 | |
LRAvg | This function computes the average, discarding anything where its first argument ("car count") is 0 LRAvg(-1,-1,-1,-1,-1) is -1 |
LRCarCount | This function is COUNT()ing how many reports have come in but not counting duplicates (based on carid) ! It is also tracking the average speed, making sure that when a car is seen twice, the speed for that car is the average of both the numbers Note - when you see no cars, the average speed is "-1" |
LRSecToMinFunction | |
LRSecToMinFunction::LRSecToMinFunctionImpl | |
LRSegmentStatisticsFunc2 | |
LRWaitForQBox | |
MapQBox | |
MicroBenchmarkType | |
MinOrMaxFunction< minOrMax > | |
MinOrMaxFunction< minOrMax >::Impl< T > | |
ModifyNetworkTask | |
Monitor< T > | |
MySQLQBox | |
NArgs | A sequence of arguments, each of type ptr<Expression> |
NHOptimizer | Specification for the neighborhood optimizer Only general API |
NodeTable | Container for AuroraNode Table transactions |
OFunction | |
OneToOneMap< T1, T2 > | |
PadFunction | |
PadFunction::Impl | |
PagePool | Thread-safe page pool |
ParallelActions | Generic class that represents a bunch of actions going on in parallel |
ParallelActionsMgr | Manages the completion of the independant parallel tasks |
Params | A set of parameters named by strings |
PendingBatch | |
PendingQuery | |
PriorityScheduler | A simple scheduler implementation that launches only a single thread to run boxes |
PropsFile | This class provides a read-only view of an XML-based properties file |
PseudoScheduler | A simple scheduler implementation that launches only a single thread to run boxes |
PtCondition | |
PtMutex | |
PtThreadPool | |
QBox | A box in the catalog |
QBoxInputPort | |
QBoxInvocation | Runtime parameters for a QBox provided by the scheduler |
QBoxOutputPort | |
QOSOptimizer | QOS optimizer |
QueryProcessor | Facade to the whole QueryProcessor component |
QueryState | |
QueueState | |
RandFunction | |
RandFunction::DoubleRandFunction | |
RandFunction::Int32RandFunction | |
RandFunction::Int64RandFunction | |
RandFunction::SingleRandFunction | |
RecoveryTask | A recovery task re-initializes the state of all queues and boxes from the checkpointed state |
RegexConverterBox | Converts records matching a regular expression to tuples on a single stream |
RegexConverterBox::Subexpr | A subexpression matched by a regular expression |
Registry< BaseClass, _Info, Key > | |
RegistryInfo< BaseClass, Key > | Standard info class for registered objects |
RegistryInfo< void, Key > | |
Remote< Borealis::Admin > | |
Remote< Borealis::CentralLookupServer > | |
Remote< Borealis::HA > | |
Remote< Borealis::Lookup > | |
Remote< Borealis::NHOptimizer > | |
Remote< Borealis::QOSOptimizer > | |
Remote< Borealis::QueryProcessor > | |
ResampleQBox | |
RevisionAggregateQBox | |
RevisionFilterQBox | |
RoomSynchronizer< typename TRoomEnum > | |
Runnable | |
RunnableRunner | |
RuntimeGlobals | |
RWLock | RWLock class implements a readwriteLock template to help user protect data items |
ScanQueryHandle | |
SchedStats | |
Scheduler | A scheduler in charge of running boxes in a catalog |
Scheduler::BoxData | Base class for data about individual boxes |
SchedulerStats | |
SchedulerTask | A task to be performed by the scheduler |
SControlQBox | Defines the generic behavior of control boxes |
SelectQBox | |
SelectQueryHandle | Things to think about in Tables: Do we need to use transactions to make sure updating multiple rows does the right thing? |
SequenceFunction | |
SerializableBitSet | |
SimpleConverterBox | Converts delimited or fixed-length records to tuples on a single stream |
SimpleRegistryInfo< BaseClass, Subclass, Key > | |
SJoinQBox | Same as a join operator but also supports reconciliation with undo/redo or checkpoint redo |
SmAlreadyUnpinnedException | |
SmBufferTooSmallException | |
SmClosedException | |
SmDatabaseClosedException | |
SmDatabaseExistsException | |
SmDatabaseLockedException | |
SmDatabaseNotFoundException | |
SmDifferentRecordTypesException | |
SmEmptyContainerException | |
SmException | |
SmFieldNumInUseException | |
SmFieldNumUndefinedException | |
SmFileFullException | |
SmFilesystemException | |
SmFileSystemFullException | |
SmIllegalFieldLengthException | |
SmIllegalFieldNumException | |
SmIllegalFrameNumException | |
SmIllegalParameterValueException | |
SmInternalException | |
SmInvalidUserLockStateException | |
SmNoFieldDefinedException | |
SmNotAllocatedException | |
SmObjectAlreadyDefinedException | |
SmObjectNotDefinedException | |
SmObjectNotLockedException | |
SmPageListAlreadyActiveException | |
SmQBaseNotHistoricalException | |
SmQueueClosedException | |
SmTooFullException | |
SmTooManyFieldsException | |
SmTrainStepSuspendedException | |
SmWrongFieldTypeException | |
SortedIndex< TValue > | |
SOutputBoxState | Captures the state of an soutput operator Currently, we only use this for checkpoint recovery and not to move load, so we only save the content of the last output tuple |
SOutputQBox | Pass-through filter |
SQLContext | |
SQLInsert | |
SQLSelect | |
SQLUpdate | |
SQLUpdate::SetExpr | |
SQLWhereClause | |
SQLWhereClause::ConjunctionSubClause | |
SQLWhereClause::ExprSubClause | |
SQLWhereClause::FieldEqSubClause | |
SQLWhereClause::SubClause | |
StackTrace | |
StandardAggregate< type > | |
Statistics | This class implemtnes a container that contains all the statistics for a Borealis node |
StatsMgr | Implements a statistics manager |
StockQuoteConverterBox | |
Stream | A flow of tuples, all with the same type |
Stream::EnqIterator | An iterator used to write data into a Stream |
StreamBuffer | Circular buffer to hold input and output tuples |
StreamState | |
StreamState::stream_stats | |
StreamStatsSample | Like BoxStatsSample, but this bears the data for a Stream instead of a QBox |
StrLenFunction | |
SubscribeTask | |
SUnionBoxState | Captures the state of a sunion operator Currently, we only use this for checkpoint recovery and not to move load, so we only save the number of the current interval |
SUnionQBox | Serializing union operator |
Table | |
Table::Cursor | |
TableEnvironment | |
TableIndex | |
TableMap | Map a set of tables by name |
TableScanCursor | Cursor that takes a where clause, and scans a table for matching tuples |
Timestamp | |
TopNMultimap< TKey, TValue > | |
TraceLogger | |
TSStats | This TSStats struct specifies the format of the statistics used in Borealis One TSStats object contain all information of a certain kind of statistics, e.g., stream rate |
TupleGenerator | |
TupleQueue | A tuple queue with a single EnqIterator (for writing into the queue) and a single DeqIterator (for reading from the queue) |
TupleQueue::DeqIterator | An iterator used to read data from a TupleQueue |
TupleQueue::EnqIterator | An iterator used to write data into a TupleQueue |
TupleQueue::RSeekIterator | Same as a seek iterator but in reverse order |
TupleQueue::SeekIterator | |
TupleQueueListener | A listener providing an abstract interface for a TupleQueue to be notified when a TupleQueue becomes non-empty |
TuplesAvailableMailbox | This is a flag system that notifies an observer when a particular TupleQueue goes from non-empty to empty |
TuplesBuffer | |
TypedExpression< bool > | An expression that evaluates to a boolean value |
TypedExpression< double > | An expression that evaluates to a 64 bit floating-point value |
TypedExpression< EString > | An expression that evaluates to a string value |
TypedExpression< int32 > | An expression that evaluates to a 32 bit integer value |
TypedExpression< int64 > | An expression that evaluates to a 64 bit integer value |
TypedExpression< single > | An expression that evaluates to a 32 bit floating-point value |
TypedExpression< Timestamp > | An expression that evaluates to a Timestamp value |
UnionQBox | |
UnlockQBox | |
UnsubscribeAllTask | |
UnsubscribeTask | |
UpdateQBox | |
UpdateQueryHandle | |
VersionRWLock | The VersionRWLoc class implements a read write Lock that will not block the writers |
WaitForQBox | |
XmlRpcParams | |
XmlRpcRequest | |
XmlRpcResponse | |
XmlTempString | |