Main Page | Namespace List | Class Hierarchy | Class List | File List | Class Members | File Members

Borealis Class List

Here are the classes, structs, unions and interfaces with brief descriptions:
AbsFunction
Admin
Aggregate
Aggregate::Window
AggregateBoxState
AggregateQBox
AuroraDOMErrorHandler
AuroraExceptionThe base class for all AuroraExceptions
AuroraNodeAn Aurora server node
AuroraNode::DequeueHandleA handle that may be used to dequeue tuples
BinarySem
BoxStatsSampleDescribes, for some particular second in time, the runtime stats of a some QBox in the Aurora runtime
BSortQBox
BufferList
BufferList::node
CheckpointTaskA checkpoint task makes a snapshot of the state of all queues and all boxes
ClosableFifoQueue< T >
CombineQBox
CombineQBox::StringHash
ConfFile
ConfFileSkeleton
ConsistencyMngrThe ConsistencyMngr listens to control streams coming from sunion boxes
ConstantExpression< T >
ConstantExpression< EString >
ContractRepresents one contract between this node and another one
ContractBasedOptimizerContract-based optimizer
ConverterBoxConverts data received on a network port to tuples on a single stream
ConverterBoxRunner
CountAggregate
CountDistinctThis function counts distinct values seen on a given field
CountingSem
CountingSemHolder
CP
CP::ltstr
CPStorage
CpuStats
CPView
CursorScan
CursorSelect
CursorUpdate
DataPathThis class handles all data inputs and outputs
DataPath::FastDequeueForwarder::ForwardHandlerHandler to attach to event loop
DbHandle
DelayQBox
equal_string
EStringA lightweight string class that performs no memory management
EStringPoolA 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
EvalContextContext for use in evaluating an expression
ExistsQBoxThis box is a quick hack that Linear Road needed and Eddie asked for
ExprContextContext for use in generating an expression from an AST
ExpressionThe base class for expressions
FairMutexWithCancel
FdMultiPool
FdMultiPoolLease
FidAlarmCounterFunc
FidAlarmCounterFunc::Impl
FidComplianceLookthroughAndAgg
FidLateTrackerFunc
FieldExpression< T >
FieldExpression< EString >
FieldExt
FifoCriticalSection
FileDescHolder
FileDescPool
FilterBoxState
FilterQBox
FixLenTimeSeriesImplements a Fixed Length TimeSeries
FunctionA function factory, capable of returning a function implementation given a statically typed set of arguments
GenericCheckpointTaskCheckpoint and recovery tasks are exclusive, just like a ModifyNetowrkTask
GlobalPropsFile
HAThe HA component monitors statically assigned primary HA components at remote nodes
HA::MonitoredNodeRepresents one node that we are monitoring
HA::NodeTypeTypesafe enumeration listing the different types of nodes we might want to monitor
HA::SecondaryThe Secondary class represents secondary nodes
HashForBufferList
ILockableThis is an interface that defines something as lockable
IncrementHolder< T >
IndexKeyEqualCursorCursor that takes an expression and returns the value for the matching key in the index
InsertQBox
IntegerCounterAn int, protected by a mutex
IntegerCounterHolder
IntFunction
JoinBoxStateCaptures the state of a join operator
JoinQBoxTODO: Window by values
JoinStaticThis box joins streamed data with a static table
KeyEqualCursorCursor that takes an expression and returns the value for the matching key
LockHolder
LockQBox
LockSet
Lookup
LRAccidentAggFunc1
LRAccidentAggFunc2
LRAvgThis function computes the average, discarding anything where its first argument ("car count") is 0 LRAvg(-1,-1,-1,-1,-1) is -1
LRCarCountThis 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
NArgsA sequence of arguments, each of type ptr<Expression>
NHOptimizerSpecification for the neighborhood optimizer Only general API
NodeTableContainer for AuroraNode Table transactions
OFunction
OneToOneMap< T1, T2 >
PadFunction
PadFunction::Impl
PagePoolThread-safe page pool
ParallelActionsGeneric class that represents a bunch of actions going on in parallel
ParallelActionsMgrManages the completion of the independant parallel tasks
ParamsA set of parameters named by strings
PendingBatch
PendingQuery
PrioritySchedulerA simple scheduler implementation that launches only a single thread to run boxes
PropsFileThis class provides a read-only view of an XML-based properties file
PseudoSchedulerA simple scheduler implementation that launches only a single thread to run boxes
PtCondition
PtMutex
PtThreadPool
QBoxA box in the catalog
QBoxInputPort
QBoxInvocationRuntime parameters for a QBox provided by the scheduler
QBoxOutputPort
QOSOptimizerQOS optimizer
QueryProcessorFacade to the whole QueryProcessor component
QueryState
QueueState
RandFunction
RandFunction::DoubleRandFunction
RandFunction::Int32RandFunction
RandFunction::Int64RandFunction
RandFunction::SingleRandFunction
RecoveryTaskA recovery task re-initializes the state of all queues and boxes from the checkpointed state
RegexConverterBoxConverts records matching a regular expression to tuples on a single stream
RegexConverterBox::SubexprA 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
RWLockRWLock class implements a readwriteLock template to help user protect data items
ScanQueryHandle
SchedStats
SchedulerA scheduler in charge of running boxes in a catalog
Scheduler::BoxDataBase class for data about individual boxes
SchedulerStats
SchedulerTaskA task to be performed by the scheduler
SControlQBoxDefines the generic behavior of control boxes
SelectQBox
SelectQueryHandleThings to think about in Tables: Do we need to use transactions to make sure updating multiple rows does the right thing?
SequenceFunction
SerializableBitSet
SimpleConverterBoxConverts delimited or fixed-length records to tuples on a single stream
SimpleRegistryInfo< BaseClass, Subclass, Key >
SJoinQBoxSame 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 >
SOutputBoxStateCaptures 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
SOutputQBoxPass-through filter
SQLContext
SQLInsert
SQLSelect
SQLUpdate
SQLUpdate::SetExpr
SQLWhereClause
SQLWhereClause::ConjunctionSubClause
SQLWhereClause::ExprSubClause
SQLWhereClause::FieldEqSubClause
SQLWhereClause::SubClause
StackTrace
StandardAggregate< type >
StatisticsThis class implemtnes a container that contains all the statistics for a Borealis node
StatsMgrImplements a statistics manager
StockQuoteConverterBox
StreamA flow of tuples, all with the same type
Stream::EnqIteratorAn iterator used to write data into a Stream
StreamBufferCircular buffer to hold input and output tuples
StreamState
StreamState::stream_stats
StreamStatsSampleLike BoxStatsSample, but this bears the data for a Stream instead of a QBox
StrLenFunction
SubscribeTask
SUnionBoxStateCaptures 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
SUnionQBoxSerializing union operator
Table
Table::Cursor
TableEnvironment
TableIndex
TableMapMap a set of tables by name
TableScanCursorCursor that takes a where clause, and scans a table for matching tuples
Timestamp
TopNMultimap< TKey, TValue >
TraceLogger
TSStatsThis 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
TupleQueueA tuple queue with a single EnqIterator (for writing into the queue) and a single DeqIterator (for reading from the queue)
TupleQueue::DeqIteratorAn iterator used to read data from a TupleQueue
TupleQueue::EnqIteratorAn iterator used to write data into a TupleQueue
TupleQueue::RSeekIteratorSame as a seek iterator but in reverse order
TupleQueue::SeekIterator
TupleQueueListenerA listener providing an abstract interface for a TupleQueue to be notified when a TupleQueue becomes non-empty
TuplesAvailableMailboxThis 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
VersionRWLockThe VersionRWLoc class implements a read write Lock that will not block the writers
WaitForQBox
XmlRpcParams
XmlRpcRequest
XmlRpcResponse
XmlTempString

Generated on Fri Nov 12 15:15:22 2004 for Borealis by doxygen 1.3.8