Package | Description |
---|---|
com.bigdata.bfs |
This package provides a scale-out content repository (aka distributed file
system) suitable as the backend for a REST-ful service using the bigdata
architecture.
|
com.bigdata.bop |
This package provides an API for query operators.
|
com.bigdata.bop.ap | |
com.bigdata.bop.ap.filter |
These filters are based on the striterator patterns.
|
com.bigdata.bop.bindingSet | |
com.bigdata.bop.bset | |
com.bigdata.bop.constraint |
This package provides implementations for operators which impose constraints
on elements visited by some access path.
|
com.bigdata.bop.controller |
This package provides operators for subquery, including UNION, STEPS,
and STAR (transitive closure).
|
com.bigdata.bop.engine | |
com.bigdata.bop.fed | |
com.bigdata.bop.fed.nodes | |
com.bigdata.bop.fed.shards | |
com.bigdata.bop.join | |
com.bigdata.bop.joinGraph |
This package provides support for join graphs, query optimization,
and generating full query plans from a join graph and the
evaluation order identified by a query optimizer.
|
com.bigdata.bop.joinGraph.fast | |
com.bigdata.bop.joinGraph.rto | |
com.bigdata.bop.mutation | |
com.bigdata.bop.rdf.aggregate | |
com.bigdata.bop.rdf.filter | |
com.bigdata.bop.rdf.join | |
com.bigdata.bop.solutions |
This package provides distinct, sort, and aggregation operators.
|
com.bigdata.bop.util | |
com.bigdata.btree |
The
BTree is a scalable B+-Tree with copy-on-write
semantics mapping variable length unsigned byte[] keys to variable
length byte[] values (null values are allowed). |
com.bigdata.btree.data | |
com.bigdata.btree.filter | |
com.bigdata.btree.isolation | |
com.bigdata.btree.keys | |
com.bigdata.btree.raba | |
com.bigdata.btree.raba.codec | |
com.bigdata.btree.view | |
com.bigdata.counters |
Package supports declaration, collection, and interchange of performance counters
for both hosts and processes on supported platforms.
|
com.bigdata.counters.linux |
Package provides performance counter collection on Linux platforms using the
sysstat suite.
|
com.bigdata.counters.osx |
Package provides performance counter collection on OSX.
|
com.bigdata.counters.query | |
com.bigdata.counters.store |
This package provides a persistence mechanism for performance
counters.
|
com.bigdata.counters.striped | |
com.bigdata.gom |
This module provides a scalable client / server architecture for graph data
management based on the principles of REST, Topic Maps, and RDF.
|
com.bigdata.ha.halog | |
com.bigdata.ha.msg |
Interfaces and implementations for HA message objects.
|
com.bigdata.ha.pipeline |
This package provides services for sending and receiving low-level write cache
blocks among the members of a highly available quorum.
|
com.bigdata.htree | |
com.bigdata.htree.data | |
com.bigdata.htree.raba | |
com.bigdata.io | |
com.bigdata.io.compression | |
com.bigdata.io.writecache |
Low-level write cache service.
|
com.bigdata.journal |
The journal is an append-only persistence capable data structure
supporting atomic commit, named indices, and transactions.
|
com.bigdata.net | |
com.bigdata.quorum |
This package defines interfaces and implementations for a quorum of highly
available services.
|
com.bigdata.rawstore |
A set of interfaces and some simple implementations for a read-write
store without atomic commit or transactions.
|
com.bigdata.rdf.axioms | |
com.bigdata.rdf.internal |
This package provides an internal representation of RDF Values.
|
com.bigdata.rdf.internal.constraints | |
com.bigdata.rdf.internal.encoder | |
com.bigdata.rdf.internal.gis | |
com.bigdata.rdf.lexicon | |
com.bigdata.rdf.load |
Support for concurrent loading of RDF data across one or more clients from
a variety of input sources.
|
com.bigdata.rdf.model |
This package provides a tuned implementation of the Sesame RDF data model
for the RDF database.
|
com.bigdata.rdf.rio |
This package provides an integration with the openrdf RIO parser that supports
fast data loads.
|
com.bigdata.rdf.rio.ntriples | |
com.bigdata.rdf.rules | |
com.bigdata.rdf.sail |
This package contains the SAIL that allow bigdata to be used as a backend for
the Sesame 2.x platform.
|
com.bigdata.rdf.sail.contrib | |
com.bigdata.rdf.sail.graph | |
com.bigdata.rdf.sail.sparql |
This package was imported from the
org.openrdf.query.parser.sparql
package of the openrdf distribution. |
com.bigdata.rdf.sail.tck | |
com.bigdata.rdf.sail.webapp | |
com.bigdata.rdf.sail.webapp.health | |
com.bigdata.rdf.sail.webapp.lbs | |
com.bigdata.rdf.sparql.ast |
This package contains an Abstract Syntax Tree which provides an intermediate translation
target for SPARQL parsers.
|
com.bigdata.rdf.sparql.ast.cache | |
com.bigdata.rdf.sparql.ast.eval | |
com.bigdata.rdf.sparql.ast.eval.bsbm.bi | |
com.bigdata.rdf.sparql.ast.eval.bsbm.explore | |
com.bigdata.rdf.sparql.ast.eval.reif | |
com.bigdata.rdf.sparql.ast.eval.rto | |
com.bigdata.rdf.sparql.ast.eval.service | |
com.bigdata.rdf.sparql.ast.eval.update | |
com.bigdata.rdf.sparql.ast.optimizers | |
com.bigdata.rdf.sparql.ast.service.storedquery |
An embedded SERVICE that permits an application to register and execute
stored queries.
|
com.bigdata.rdf.sparql.ast.ssets | |
com.bigdata.rdf.spo |
This package defines a statement model using long term identifiers rather than
RDF Value objects.
|
com.bigdata.rdf.store |
This package provides several realizations of an RDF database using the bigdata
architecture, including one suitable for temporary data, one suitable for local
processing (single host), and one designed for scale-out on commodity hardware.
|
com.bigdata.rdf.vocab |
This package provides a variety of different pre-compiled
Vocabulary classes. |
com.bigdata.relation.accesspath |
This package includes an abstraction layer for efficient access paths, including
chunked iterators, blocking buffers, and an abstraction corresponding to the natural
order of an index.
|
com.bigdata.relation.locator |
Abstraction layer for identifying relations and relation containers in much
the same manner that indices are identified (unique name and timestamp).
|
com.bigdata.relation.rule |
This package includes an abstraction layer for rules.
|
com.bigdata.relation.rule.eval |
This package supports rule evaluation.
|
com.bigdata.resources |
This package provides the logic to managed the live journal and the
historical journals and index segments for a
DataService . |
com.bigdata.rwstore | |
com.bigdata.rwstore.sector | |
com.bigdata.search |
This package provides full text indexing and search.
|
com.bigdata.service |
This package provides implementations of bigdata services (metadata
service, data service, transaction manager service.
|
com.bigdata.service.ndx | |
com.bigdata.service.ndx.pipeline | |
com.bigdata.sparse |
This package provides support for treating normal B+Trees using a
"sparse row store" pattern and can be applied to both local B+Trees
and scale-out indices.
|
com.bigdata.striterator |
Streaming iterator patterns based on Martyn Cutcher's striterator design
but supporting generics and with extensions for closable, chunked, and
ordered streaming iterators.
|
com.bigdata.util.concurrent |
Utility classes related to java.util.concurrent.
|
com.bigdata.util.httpd |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRepositoryTestCase |
class |
TestAppendBlock
Test atomic append operations on the file data index for the
BigdataFileSystem . |
class |
TestCopyStream
Unit tests for copying streams into the repository and reading them back.
|
class |
TestFileMetadataIndex
Test operations on the file metadata index for the
BigdataFileSystem . |
class |
TestFileVersionOutputStream
Tests some specifics of the
FileVersionOutputStream . |
class |
TestRandomBlockOps
Unit tests for random block IO include read, write, overwrite (aka update),
and delete.
|
class |
TestRangeDelete
Test suite for
BigdataFileSystem.deleteAll(String, String) . |
class |
TestRangeScan
Test suite for
BigdataFileSystem.getDocumentHeaders(String, String) . |
Modifier and Type | Class and Description |
---|---|
class |
TestBind
Unit tests for
Bind . |
class |
TestConstant
Test suite for
Constant . |
class |
TestDeepCopy
Unit tests for the existence of the required deep copy semantics for
BOp s. |
class |
TestNamedSolutionSetRef
Test suite for
NamedSolutionSetRef . |
class |
TestVar
Test suite for
Var . |
Modifier and Type | Class and Description |
---|---|
class |
TestPredicate
Test suite for
Predicate . |
class |
TestPredicateAccessPath
Unit test for reading on an access path using a
Predicate . |
class |
TestSampleIndex
Test suite for
SampleIndex . |
Modifier and Type | Class and Description |
---|---|
class |
TestFilter
Unit tests for
BOpFilter . |
class |
TestResolver
Unit tests for
BOpResolver . |
Modifier and Type | Class and Description |
---|---|
class |
TestHashBindingSet
Unit tests for
HashBindingSet . |
class |
TestIBindingSet
Unit tests for
IBindingSet . |
class |
TestListBindingSet
Unit tests for
ListBindingSet . |
Modifier and Type | Class and Description |
---|---|
class |
TestConditionalRoutingOp
Unit tests for
JVMDistinctBindingSetsOp . |
class |
TestCopyBindingSets
Test suite for
CopyOp . |
Modifier and Type | Class and Description |
---|---|
class |
TestEQ
Test suite for
EQ . |
class |
TestEQConstant
Unit tests for
EQConstant . |
class |
TestInBinarySearch
Unit tests for
INBinarySearch . |
class |
TestINConstraint
Unit tests for
INHashMap . |
class |
TestInHashMap
Unit tests for
INHashMap . |
class |
TestNE
Unit tests for
NE . |
class |
TestNEConstant
Unit tests for
NEConstant . |
class |
TestOR
Unit tests for
OR . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractSubqueryTestCase
Abstract base class for subquery join test suites.
|
class |
TestSubqueryOp
Test suite for handling of optional join groups during query evaluation
against a local database instance.
|
class |
TestUnion
Test suite for
Union . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractQueryEngineTestCase
Base class adds some static methods used with unit tests of the
QueryEngine . |
class |
TestBOpStats
Test suite for
BOpStats . |
class |
TestHaltOpMessage
Test suite for
HaltOpMessage . |
class |
TestLocalChunkMessage
Test suite for
LocalChunkMessage . |
class |
TestLocalNativeChunkMessage
Test suite for
LocalNativeChunkMessage . |
class |
TestQueryDeadlineOrder
Test suite for
QueryDeadline ordering. |
class |
TestQueryEngine
Test suite for the
QueryEngine against a local database instance. |
class |
TestQueryEngine_DistinctOp
Test suite for DISTINCT solution operators when integrated with the query
engine.
|
class |
TestQueryEngine_GroupByOp
Test suite for GROUP_BY operators when integrated with the query engine.
|
class |
TestQueryEngine_Slice
Stress test for
SliceOp in which a large number of small chunks are
fed into the query such that the concurrency constraints of the slice are
stress tested. |
class |
TestQueryEngine_SortOp
Test suite ORDER BY operators when integrated with the query engine.
|
class |
TestRunState
Test suite for
RunState . |
class |
TestStartOpMessage
Test suite for
StartOpMessage . |
Modifier and Type | Class and Description |
---|---|
class |
TestFederatedQueryEngine
Unit tests for
FederatedQueryEngine running against an
EmbeddedFederation having a single DataService . |
class |
TestNIOChunkMessage
Unit tests for
NIOChunkMessage . |
class |
TestQueryEngineFactory
Stress test for correct shutdown of query controllers as allocated by the
QueryEngineFactory . |
class |
TestRemoteAccessPath
Unit tests of a remote access path.
|
class |
TestThickChunkMessage
Unit tests for
ThickChunkMessage . |
Modifier and Type | Class and Description |
---|---|
class |
TestMapBindingSetsOverNodes
Unit tests for mapping binding sets over nodes.
|
Modifier and Type | Class and Description |
---|---|
class |
TestMapBindingSetsOverShards
Unit tests for
MapBindingSetsOverShardsBuffer . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHashJoinOpTestCase
Common base class for hash join with access path unit tests.
|
class |
HashIndexOpTestCase
Abstract test suite for
HashIndexOp implementations. |
class |
TestDistinctTermScanOp
Unit tests for the
DistinctTermScanOp operator. |
class |
TestFastRangeCountOp
Unit tests for the
FastRangeCountOp operator. |
class |
TestHTreeHashIndexOp
Test suite for
HashIndexOp that uses a HTreeHashJoinUtility . |
class |
TestHTreeHashJoinOp
Unit tests for the
HTreeHashJoinOp operator. |
class |
TestHTreeSolutionSetHashJoin
Test suite for
HTreeSolutionSetHashJoinOp . |
class |
TestJVMHashIndexOp
Test suite for
HashIndexOp that uses a JVMHashJoinUtility |
class |
TestJVMHashJoinOp
Test suite for
JVMHashJoinOp . |
class |
TestNestedLoopJoinOp
Test suite the
NestedLoopJoinOp |
class |
TestPipelineJoin
Unit tests for the
PipelineJoin operator. |
Modifier and Type | Class and Description |
---|---|
class |
TestPartitionedJoinGroup
Unit tests for
PartitionedJoinGroup . |
class |
TestPartitionedJoinGroup_canJoin
Unit tests for
PartitionedJoinGroup.canJoin(IPredicate, IPredicate) |
class |
TestPartitionedJoinGroup_canJoinUsingConstraints
This test suite is built around around BSBM Q5.
|
Modifier and Type | Class and Description |
---|---|
class |
TestDefaultEvaluationPlan
Test harness for
DefaultEvaluationPlan2 . |
Modifier and Type | Class and Description |
---|---|
class |
TestJGraph
Test suite for
JGraph , which is the core implementation of the
runtime query optimizer logic. |
class |
TestJoinGraph
Unit tests for the
JoinGraph operator. |
Modifier and Type | Class and Description |
---|---|
class |
TestDelete
Test suite for
DeleteOp . |
class |
TestInsert
Test suite for
InsertOp . |
Modifier and Type | Class and Description |
---|---|
class |
TestAVERAGE
Unit tests for
AVERAGE . |
class |
TestCOUNT
Unit tests for
COUNT . |
class |
TestGROUP_CONCAT
Unit tests for
GROUP_CONCAT |
class |
TestMAX
Unit tests for
MAX . |
class |
TestMIN
Unit tests for
MIN . |
class |
TestSAMPLE
Unit tests for
SAMPLE . |
class |
TestSUM
Unit tests for
SUM . |
Modifier and Type | Class and Description |
---|---|
class |
TestNativeDistinctFilter
Unit tests for
NativeDistinctFilter . |
class |
TestSameVariableConstraint
Test suite for
SameVariableConstraint . |
class |
TestStripContextFilter
Test suite for
StripContextFilter . |
Modifier and Type | Class and Description |
---|---|
class |
TestDataSetJoin
Test
DataSetJoin . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAggregationTestCase
Abstract base class for testing
GroupByOp operator implementations. |
class |
AbstractDistinctSolutionsTestCase
Abstract base class for DISTINCT SOLUTIONS test suites.
|
class |
TestGroupByOp
A collection of tests for various implementations of GroupByOp.
|
class |
TestGroupByRewriter
Test suite for
GroupByRewriter . |
class |
TestGroupByState
Test suite for
GroupByState . |
class |
TestHTreeDistinctBindingSets
Unit tests for
HTreeDistinctBindingSetsOp . |
class |
TestIVComparator
Test suite for
IVComparator . |
class |
TestJVMDistinctBindingSets
Unit tests for
JVMDistinctBindingSetsOp . |
class |
TestMemoryGroupByOp
Unit tests for
MemoryGroupByOp . |
class |
TestMemorySortOp
Unit tests for the
MemorySortOp . |
class |
TestPipelinedAggregationOp
Unit tests for
PipelinedAggregationOp . |
class |
TestSliceOp
Unit tests for
SliceOp . |
Modifier and Type | Class and Description |
---|---|
class |
TestBOpUtility
Unit tests for
BOpUtility . |
class |
TestBOpUtility_sharedVariables
Unit tests for
BOpUtility.getSharedVars(BOp, BOp) . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBTreeCursorTestCase
Abstract base class for some unit tests that can only be run against a
BTree . |
class |
AbstractBTreeTestCase
Abstract test case for
BTree tests. |
class |
AbstractIndexSegmentTestCase
Adds some methods for testing an
IndexSegment for consistency. |
class |
AbstractTupleCursorTestCase
Abstract base class for
ITupleCursor test suites. |
class |
StressTestBTreeRemove |
class |
TestBloomFilter
Test suite for bloom filter functionality.
|
class |
TestBTree
Stress tests for basic tree operations (insert, lookup, and remove) without
causing node or leaf evictions (IO is disabled).
|
class |
TestBTreeBranchingFactors
Unit tests of non-default B+Tree branching factors.
|
class |
TestBTreeLeafCursors
Test suite for the
BTree 's ILeafCursor implementation. |
class |
TestBTreeRecycle
Test suite for recycling of B+Tree records.
|
class |
TestBTreeWithBloomFilter
Unit tests for a
BTree with its bloom filter enabled. |
class |
TestBytesUtil
Test suite for low-level operations on variable length byte[]s.
|
class |
TestChunkedIterators
Test suite for
AbstractChunkedTupleIterator and its concrete
ChunkedLocalRangeIterator implementation which depends on the
ResultSet . |
class |
TestCommit
Unit tests for commit functionality that do not trigger copy-on-write.
|
class |
TestConstrainKeys
Test imposing constraint on a fromKey or toKey based on an index partition's
boundaries.
|
class |
TestCopyOnWrite
Test suite for copy-on-write semantics.
|
class |
TestDeleteMarkers
Test of basic btree operations when delete markers are maintained.
|
class |
TestDirtyIterators
Test suite for iterators that visit only dirty nodes or leaves.
|
class |
TestDirtyListener
Test suite for the
IDirtyListener protocol. |
class |
TestFindChild
Test code that chooses the child to search during recursive traversal of the
separator keys to find a leaf in which a key would be found.
|
class |
TestGetBitsFromByteArray
Unit tests for
BytesUtil.getBits(byte[], int, int) |
class |
TestGetBitsFromInt32
Unit tests for {@link BytesUtil#getBits(int, int, int)
|
class |
TestIncrementalWrite
Test suite for the logic performing incremental writes of nodes and leaves
onto the store.
|
class |
TestIndexCounter
Test suite for the
IIndexLocalCounter.getCounter() interface. |
class |
TestIndexPartitionFencePosts
Tests for some fence posts for an index supporting delete markers and having
a
LocalPartitionMetadata that declares its legal key range. |
class |
TestIndexSegmentAddressManager
Tests logic to encode and decode the offsets within regions in an
IndexSegmentStore . |
class |
TestIndexSegmentBuilder_EmptyIndex
Test suite for building an
IndexSegment from an empty BTree . |
class |
TestIndexSegmentBuilderWithBlobCapacity |
class |
TestIndexSegmentBuilderWithCompactingMerge
A test of the
IndexSegmentBuilder in which there are some deleted
tuples in the source BTree and a compacting merge is performed. |
class |
TestIndexSegmentBuilderWithIncrementalBuild
A test of the
IndexSegmentBuilder in which there are some deleted
tuples in the source BTree which are to be copied to the destination
IndexSegment (this is really a test of the incremental build scenario
since deleted tuples are never copied for a compacting merge). |
class |
TestIndexSegmentBuilderWithLargeTrees
Test build trees on the journal, evicts them into an
IndexSegment ,
and then compares the trees for the same total ordering. |
class |
TestIndexSegmentBuilderWithSmallTree
Test suite based on a small btree with known keys and values.
|
class |
TestIndexSegmentCursors
Test suite for
IndexSegment.IndexSegmentTupleCursor . |
class |
TestIndexSegmentMultiBlockIterators
Test suite for
IndexSegmentMultiBlockIterator . |
class |
TestIndexSegmentPlan
Test suite for efficient post-order rebuild of an index in an external index
segment.
|
class |
TestIndexSegmentWithBloomFilter
Test build trees on the journal, evicts them into an
IndexSegment ,
and then compares the performance and correctness of index point tests with
and without the use of the bloom filter. |
class |
TestInsertLookupRemoveKeysInRootLeaf
Test insert, lookup, and value scan for leaves.
|
class |
TestIterators
Test suite for iterators.
|
class |
TestLeafSplitShortestSeparatorKey |
class |
TestLinearListMethods
Test suite for the
ILinearList access methods. |
class |
TestMutableBTreeCursors
Test ability to traverse tuples using an
ITupleCursor while the SAME
THREAD is used to insert, update, or remove tuples from a mutable
BTree . |
class |
TestNullValues
Test of storing null values under a key with persistence.
|
class |
TestPutIfAbsent
Test of basic btree operations when delete markers are maintained.
|
class |
TestRawRecords
Unit tests for a B+Tree with raw record support enabled (this is where a
large
byte[] value is written directly onto the backing store
rather than being stored within the leaf). |
class |
TestReadOnlyBTreeCursors
Unit tests for
ITupleCursor for a read-only BTree . |
class |
TestRemoveAll
Test suite for
BTree.removeAll() . |
class |
TestReopen
Unit tests for the close/checkpoint/reopen protocol designed to manage the
resource burden of indices without invalidating the index objects (indices
opens can be reopened as long as their backing store remains available).
|
class |
TestSplitJoinRootLeaf
Test split and join of the root leaf (the tree never has more than two
levels).
|
class |
TestSplitJoinThreeLevels
Test suite using
AbstractBTree.insert(Object, Object) to split a tree to
height two (2) (three levels) and then using AbstractBTree.remove(Object) to
reduce the tree back to a single, empty root leaf. |
class |
TestSplitRootLeaf
Test split of the root leaf.
|
class |
TestTouch
Test suite for
AbstractBTree.touch(AbstractNode) . |
class |
TestTransientBTree
Unit tests for transient
BTree s (no backing store). |
class |
TestUtilMethods
Test suite for various utility methods, both static and instance, on
AbstractNode . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLeafDataRecordTestCase
Test suite for the B+Tree
ILeafData records (accessing coded data in
place). |
class |
AbstractNodeDataRecordTestCase
Test suite for the B+Tree
INodeData records (accessing coded data in
place). |
class |
AbstractNodeOrLeafDataRecordTestCase |
class |
TestLeafDataRecord_CanonicalHuffman_CanonicalHuffman
Test suite for the B+Tree
ILeafData records (accessing coded data in
place). |
class |
TestLeafDataRecord_FrontCoded_CanonicalHuffman
Test suite for the B+Tree
ILeafData records (accessing coded data in
place). |
class |
TestLeafDataRecord_Simple_Simple
Test with simple coding for keys and values (no compression).
|
class |
TestNodeDataRecord_CanonicalHuffman
Test suite using the
CanonicalHuffmanRabaCoder to provide key
compression. |
class |
TestNodeDataRecord_FrontCoded
Test suite using the
FrontCodedRabaCoder to provide key compression. |
class |
TestNodeDataRecord_Simple
Test suite without key compression.
|
Modifier and Type | Class and Description |
---|---|
class |
TestPrefixFilter
Test suite for the
PrefixFilter . |
class |
TestRemoverator
Test suite for the
Removerator . |
class |
TestReverserator
Test suite for the
Reverserator . |
class |
TestTupleFilters |
Modifier and Type | Class and Description |
---|---|
class |
TestConflictResolution
Tests of write-write conflict resolution.
|
class |
TestIsolatedFusedView
Test suite for
IsolatedFusedView . |
class |
TestMixedModeOperations
This is a test suite for mixing full transactions with unisolated operations
on the same indices.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractUnicodeKeyBuilderTestCase
Base class for the test suites that examine support for Unicode sort keys in
KeyBuilder . |
class |
TestICUUnicodeKeyBuilder
Tests for Unicode support in
KeyBuilder . |
class |
TestICUVersionRecord
Test suite for
ICUVersionRecord |
class |
TestJDKUnicodeKeyBuilder |
class |
TestKeyBuilder
Test suite for high level operations that build variable length _unsigned_
byte[] keys from various data types and unicode strings.
|
class |
TestSuccessorUtil
Test suite for
SuccessorUtil . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyBufferTestCase |
class |
TestKeyBufferSearch
Unit tests for
IKeyBuffer#search(byte[] searchKey) . |
class |
TestMutableValuesRaba
Test suite for
MutableValuesRaba . |
class |
TestSubRangeRaba
Test suite for
SubRangeRaba . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractFrontCodedRabaCoderTestCase
Test suite for the
FrontCodedRabaCoder . |
class |
AbstractRabaCoderTestCase
Abstract test suite for
IRabaCoder implementations. |
class |
TestCanonicalHuffmanRabaCoder
Test suite for the
CanonicalHuffmanRabaCoder . |
class |
TestConditionalRabaCoder_keys_simple_frontCoded
Test suite for the
ConditionalRabaCoder . |
class |
TestConditionalRabaCoder_values_simple_canonical
Test suite for the
ConditionalRabaCoder . |
class |
TestEmptyRabaCoder
Unit tests for the
EmptyRabaValueCoder . |
class |
TestFixedLengthValueRabaCoder
Test suite for the
FixedLengthValueRabaCoder . |
class |
TestFrontCodedRabaCoderRatio2
Test suite for the
FrontCodedRabaCoder . |
class |
TestFrontCodedRabaCoderRatio32
Test suite for the
FrontCodedRabaCoder . |
class |
TestFrontCodedRabaCoderRatio8
Test suite for the
FrontCodedRabaCoder . |
class |
TestSimpleRabaCoder
Test suite for the
SimpleRabaCoder . |
Modifier and Type | Class and Description |
---|---|
class |
TestFusedView
Test suite for
FusedView . |
Modifier and Type | Class and Description |
---|---|
class |
TestHistoryInstrument |
Modifier and Type | Class and Description |
---|---|
class |
TestKernelVersion |
class |
TestParsing |
Modifier and Type | Class and Description |
---|---|
class |
AbstractParserTestCase |
class |
TestParse_iostat
OSX does have an
iostat . |
class |
TestParse_vm_stat
Test suite for parsing the output of the
vm_stat utility under
OSX. |
Modifier and Type | Class and Description |
---|---|
class |
TestTimeRange |
Modifier and Type | Class and Description |
---|---|
class |
TestCounterSetBTree |
Modifier and Type | Class and Description |
---|---|
class |
TestStripedCounters
Unit tests for
StripedCounters . |
Modifier and Type | Class and Description |
---|---|
class |
TestJavaScriptGOM
Note: Java6 embeds JavaScript support based on Mozilla Rhino version 1.6R2.
|
Modifier and Type | Class and Description |
---|---|
class |
TestHALogWriter
Test suite for
HALogWriter and HALogReader . |
Modifier and Type | Class and Description |
---|---|
class |
TestHASendState |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHASendAndReceiveTestCase |
class |
TestHASendAndReceive
Test the raw socket protocol implemented by
HASendService and
HAReceiveService . |
class |
TestHASendAndReceive3Nodes
Test the raw socket protocol implemented by
HASendService and
HAReceiveService against a pipeline of 3 nodes. |
class |
TestSocketsDirect
Test suite for basic socket behaviors.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractHTreeTestCase |
class |
TestDuplicates
Test
HTree with duplicate keys. |
class |
TestHTree
Unit tests for
HTree . |
class |
TestHTree_addLevel
Unit test which explores a simple add level case.
|
class |
TestHTree_init
Unit tests for bootstrap of an
HTree instance. |
class |
TestHTree_stressInsert
A stress test which inserts a series of integer keys and then verifies the
state of the index.
|
class |
TestHTreeRecycle
Tests recycling of HTree storage.
|
class |
TestHTreeUtil
Unit tests for
HTreeUtil . |
class |
TestRemovals |
class |
TestTransientHTree
Unit tests for transient
HTree s (no backing store). |
Modifier and Type | Class and Description |
---|---|
class |
AbstractHashBucketDataRecordTestCase
Abstract class for tests of
ILeafData implementations for a hash
bucket. |
class |
TestBucketDataRecord_CanonicalHuffman_CanonicalHuffman
Test suite for the HTree
ILeafData records (accessing coded data in
place). |
class |
TestBucketDataRecord_Simple_Simple
Test with simple coding for keys and values (no compression).
|
Modifier and Type | Class and Description |
---|---|
class |
TestMutableKeyBuffer
Test suite for
MutableKeyBuffer . |
class |
TestMutableValueBuffer
Test suite for
MutableValuesBuffer . |
Modifier and Type | Class and Description |
---|---|
class |
TestByteArrayBuffer
Test suite for
ByteArrayBuffer . |
class |
TestByteBufferStreams
|
class |
TestCase3
|
class |
TestDataOutputBuffer
Test suite for
DataOutputBuffer . |
class |
TestDirectBufferPool
Test suite for
DirectBufferPool . |
class |
TestDirectBufferPoolAllocator
Test suite for
DirectBufferPoolAllocator . |
class |
TestFileLockUtility
Test suite for
FileLockUtility . |
class |
TestFixedByteArrayBuffer
Test suite for
FixedByteArrayBuffer . |
class |
TestIO
Low level IO performance tests in support of bigdata design options.
|
class |
TestMergeMapOutput
Tests the utility to merge an input stream with a sorted set of
|
class |
TestSliceInputStream
Test suite for
SliceInputStream . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRecordCompressorTestCase
Abstract base class for
IRecordCompressor test suites. |
class |
TestCompressorRegistry |
class |
TestHuffmanEncoder
Explores the built-in huffman coding support in the Deflate library.
|
class |
TestNOPRecordCompressor
Test suite for
NOPRecordCompressor . |
class |
TestRecordCompressor_BestCompression
Test suite for
RecordCompressor . |
class |
TestRecordCompressor_BestSpeed
Test suite for
RecordCompressor . |
class |
TestUnicodeCompressor
Unit tests for Unicode schemes:
Standard Compression for Unicode ()
Byte Order Compression for Unicode ( BOCU ).
|
class |
TestUnicodeHelper
Test suite for
UnicodeHelper . |
Modifier and Type | Class and Description |
---|---|
class |
TestRWWriteCacheService
Test suite for the
WriteCacheService using scattered writes on a
backing file. |
class |
TestWORMWriteCacheService
Test suite for the
WriteCacheService using pure append writes. |
class |
TestWriteCache
Test suite for the
WriteCache . |
class |
TestWriteCacheServiceLifetime
These tests exercise the lifetime semantics of a WriteCacheService.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractBufferStrategyTestCase
Base class for writing test cases for the different
IBufferStrategy
implementations. |
class |
AbstractInterruptsTestCase
Test suite for correct handling of
ClosedByInterruptException s. |
class |
AbstractJournalTestCase
Abstract harness for testing under a variety of configurations.
|
class |
AbstractMRMWTestCase
Test suite for MRMW (Multiple Readers, Multiple Writers) support.
|
static class |
AbstractMRMWTestCase.StressTestMRMW
Concrete instance for running stress tests and comparisons.
|
class |
AbstractMROWTestCase
Test suite for MROW (Multiple Readers, One Writer) support.
|
class |
AbstractRestartSafeTestCase
Test suite for restart-safe (data survives commit and reopen of the store).
|
class |
BenchmarkJournalWriteRate
A benchmark that computes the raw platform write rate for pure sequential IO,
the journal's write rate, and both unisolated and isolated index write rates.
|
static class |
BenchmarkJournalWriteRate.AbstractBenchmarkOptimium
Does N writes of M size data blocks on a pre-extended file using pure
sequential IO.
|
static class |
BenchmarkJournalWriteRate.BenchmarkBlockBasedOptimium
Writes the same amount of data using large blocks on a pre-extended file
using pure sequential IO.
|
static class |
BenchmarkJournalWriteRate.BenchmarkDirectJournal |
static class |
BenchmarkJournalWriteRate.BenchmarkDiskJournal |
static class |
BenchmarkJournalWriteRate.BenchmarkDiskRWJournal |
static class |
BenchmarkJournalWriteRate.BenchmarkMappedJournal |
static class |
BenchmarkJournalWriteRate.BenchmarkSmallRecordOptimium
Writes the same amount of data, using
128 byte records on
a pre-extended file using pure sequential IO. |
static class |
BenchmarkJournalWriteRate.BenchmarkSustainedTransferOptimium
Writes the same amount of data using a single nio "write buffer"
operation on a pre-extended file.
|
static class |
BenchmarkJournalWriteRate.BenchmarkTransientJournal |
class |
StressTestConcurrentTx
Stress tests for concurrent transaction processing.
|
class |
StressTestConcurrentUnisolatedIndices
Stress tests for concurrent processing of operations on named unisolated
indices.
|
class |
StressTestGroupCommit
Stress test of the group commit mechanism.
|
class |
StressTestLockContention
Lock contention results when unisolated writers seek conflicting locks.
|
class |
StressTestUnisolatedReadWriteIndex
Stress tests for concurrent processing of operations on named unisolated
indices where the concurrency is managed by an
UnisolatedReadWriteIndex rather than the ConcurrencyManager . |
class |
TestAbort
Test the ability to abort (discard an uncommitted write set).
|
class |
TestAddDropIndexTask
Test suite for
RegisterIndexTask and DropIndexTask . |
class |
TestClockSkewDetection
Test suite for
ClocksNotSynchronizedException . |
class |
TestCommitCounterUtility
Test suite for the
CommitCounterUtility . |
class |
TestCommitHistory
Test the ability to get (exact match) and find (most recent less than or
equal to) historical commit records in a
Journal . |
class |
TestCommitList
|
class |
TestCompactJournal
Test suite for
Journal.compact(java.io.File) . |
class |
TestConcurrentJournal
Test suite for the
IConcurrencyManager interface on the
Journal . |
class |
TestDirectJournal
Test suite for
BufferMode.Direct journals. |
static class |
TestDirectJournal.TestInterrupts
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestDirectJournal.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestDirectJournal.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestDirectJournal.TestRawStore
Test suite integration for
AbstractRestartSafeTestCase . |
class |
TestDiskJournal
Deprecated.
|
static class |
TestDiskJournal.TestInterrupts
Deprecated.
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestDiskJournal.TestMRMW
Deprecated.
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestDiskJournal.TestMROW
Deprecated.
Test suite integration for
AbstractMROWTestCase . |
static class |
TestDiskJournal.TestRawStore
Deprecated.
Test suite integration for
AbstractRestartSafeTestCase . |
class |
TestDoubleOpen
Test the ability to rollback a commit.
|
class |
TestDumpJournal
Test suite for
DumpJournal . |
class |
TestHierarchicalLockingTasks
Test suite for hierarchical locking of indices based on namespace prefixes.
|
class |
TestJournalAbort
Test suite for a failure to handle errors inside of abort() by marking the
journal as requiring abort().
|
class |
TestJournalShutdown
Stress test for correct shutdown of journals based on weak reference
semantics.
|
class |
TestMappedJournal
Test suite for
BufferMode.Mapped journals. |
static class |
TestMappedJournal.TestInterrupts
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestMappedJournal.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestMappedJournal.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestMappedJournal.TestRawStore
Test suite integration for
AbstractRestartSafeTestCase . |
class |
TestName2Addr
Test suite for the
index used to name index names to the
named indices. |
class |
TestNamedIndices
Test suite for api supporting registration, lookup, use, and atomic commit of
named indices.
|
class |
TestReadCommittedTx<S extends Journal>
Test suite for transactions reading from a start time corresponding to the
last commit time on the database.
|
class |
TestReadOnlyTx<S extends Journal>
Test suite for fully isolated read-only transactions reading from a caller
specified start time.
|
class |
TestRollbackCommit
Deprecated.
Along with
AbstractJournal.rollback() |
class |
TestRootBlockView
Test suite for
RootBlockView . |
class |
TestSnapshotJournal
Test suite for
Journal#snapshot(com.bigdata.journal.Journal.ISnapshotFactory) . |
class |
TestTemporaryStore
Test suite for
TemporaryStore (temporary store with named indices). |
static class |
TestTemporaryStore.TestInterrupts
Test suite integration for
TestTemporaryStore.TestInterrupts . |
static class |
TestTemporaryStore.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestTemporaryStore.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestTemporaryStore.TestRawStore
Test suite integration for
AbstractRawStoreTestCase . |
class |
TestTransactionService
Unit tests of the
AbstractTransactionService using a mock client. |
class |
TestTransactionSupport |
class |
TestTransientJournal
Test suite for
BufferMode.Transient journals. |
static class |
TestTransientJournal.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestTransientJournal.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestTransientJournal.TestRawStore
Test suite integration for
AbstractRawStoreTestCase . |
class |
TestTx
Test suite for fully-isolated read-write transactions.
|
class |
TestUnisolatedWriteTasks
Correctness test suite for unisolated writes on one or more indices.
|
class |
TestWarmupJournal
Test suite for
WarmUpTask . |
class |
TestWORMStrategy
Test suite for
WORMStrategy journal. |
static class |
TestWORMStrategy.TestInterrupts
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestWORMStrategy.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestWORMStrategy.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestWORMStrategy.TestRawStore
Test suite integration for
AbstractRestartSafeTestCase . |
class |
TestWORMStrategyNoCache
Test suite for
WORMStrategy journal with the write cache disabled. |
static class |
TestWORMStrategyNoCache.TestInterrupts
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestWORMStrategyNoCache.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestWORMStrategyNoCache.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestWORMStrategyNoCache.TestRawStore
Test suite integration for
AbstractRestartSafeTestCase . |
class |
TestWORMStrategyOneCacheBuffer
Test suite for
WORMStrategy journals which runs with a single
WriteCache buffer. |
static class |
TestWORMStrategyOneCacheBuffer.TestInterrupts
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestWORMStrategyOneCacheBuffer.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestWORMStrategyOneCacheBuffer.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestWORMStrategyOneCacheBuffer.TestRawStore
Test suite integration for
AbstractRestartSafeTestCase . |
Modifier and Type | Class and Description |
---|---|
class |
TestInetAddressUtil
Test suite for
InetAddressUtil . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractQuorumTestCase
Abstract base class for testing using a
MockQuorumFixture . |
class |
TestHA3QuorumSemantics
Test the quorum semantics for a highly available quorum of 3 services.
|
class |
TestMockQuorumFixture
Test suite for the
MockQuorumFixture . |
class |
TestSingletonQuorumSemantics
Test the quorum semantics for a singleton quorum.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRawStoreTestCase
Base class for writing tests of the
IRawStore interface. |
class |
TestSimpleFileRawStore
Test suite for
SimpleFileRawStore . |
class |
TestSimpleMemoryRawStore
Test suite for
SimpleMemoryRawStore . |
Modifier and Type | Class and Description |
---|---|
class |
TestAxioms
Test suite for the
Axioms . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEncodeDecodeKeysTestCase |
class |
AbstractEncodeDecodeMixedIVsTest
Test of encode/decode and especially comparator semantics for mixed
IV s. |
class |
TestBlobIV
Unit tests for
BlobIV . |
class |
TestEncodeDecodeGeoSpatialLiteralIVs
Unit tests for
GeoSpatialLiteralExtension . |
class |
TestEncodeDecodeIPv4AddrIV
Encode/decode unit tests for
IPv4AddrIV . |
class |
TestEncodeDecodeKeys
Unit tests for encoding and decoding compound keys (such as are used by the
statement indices) in which some of the key components are inline values
having variable component lengths while others are term identifiers.
|
class |
TestEncodeDecodeLiteralArrayIVs
Encode/decode unit tests for
LiteralArrayIV . |
class |
TestEncodeDecodeMixedIVs
Test of encode/decode and especially comparator semantics for mixed
IV s. |
class |
TestEncodeDecodePackedLongIVs
Unit tests for
PackedLongIV and its associated
CompressedTimestampExtension extension. |
class |
TestEncodeDecodeUnicodeIVs
Unit tests for
IV s which inline Unicode data. |
class |
TestEncodeDecodeXSDDateIVs
Unit tests for
XSDIntegerIV . |
class |
TestEncodeDecodeXSDDecimalIVs
Unit tests for
XSDDecimalIV . |
class |
TestEncodeDecodeXSDIntegerIVs
Unit tests for
XSDIntegerIV . |
class |
TestFullyInlineTypedLiteralIV
Test suite for
FullyInlineTypedLiteralIV . |
class |
TestFullyInlineURIIV
Test suite for
FullyInlineURIIV . |
class |
TestInlineLocalNameIntegerURIHandler |
class |
TestInlineURIHandlers
Test suite for
URIExtensionIV . |
class |
TestIVUnicode
Test suite for
IVUnicode . |
class |
TestLiteralDatatypeIV
Test suite for
PartlyInlineTypedLiteralIV . |
class |
TestMultiInlineURIHandlersSingleNamespace
Test case for multiple InlineURIHandlers at a single namespace.
|
class |
TestPackedLongIVs
Test suite for math operations on
PackedLongIV and
CompressedTimestampExtension . |
class |
TestTermIV
Test suite for
TermId . |
class |
TestUnsignedIntegerIVs
Test suite for xsd:nonPositiveInteger, xsd:negativeInteger,
xsd:nonNegativeInteger, and xsd:positiveInteger.
|
class |
TestUnsignedIVs
Test suite for the xsd:unsigned IV which are internally represented by Java
primitives (xsd:unsignedByte, xsd:unsignedShort, xsd:unsignedInt, and
xsd:unsignedLong).
|
class |
TestURIExtensionIV
Test suite for
URIExtensionIV . |
class |
TestVocabURIByteIV |
class |
TestXPathFunctions
Test suite for various xpath numeric functions.
|
class |
TestZOrderRangeScanUtility
Test for utility functionalities required for zOrder index construction,
such as
ZOrderRangeScanUtil . |
Modifier and Type | Class and Description |
---|---|
class |
TestRegexBOp
Test suite for
RegexBOp . |
class |
TestReplaceBOp
Test suite for
ReplaceBOp . |
class |
TestStrAfterBOp
Test suite for
StrAfterBOp . |
class |
TestStrBeforeBOp
Test suite for
StrBeforeBOp . |
class |
TestSubstrBOp
Test suite for
SubstrBOp . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBindingSetEncoderTestCase
Base class for
IBindingSetEncoder and IBindingSetDecoder test
suites. |
class |
TestIVBindingSetEncoder
Test suite for
IVBindingSetEncoder . |
class |
TestIVBindingSetEncoderWithCache
Deprecated.
|
class |
TestIVSolutionSetEncoder
Test suite for
IVSolutionSetEncoder and IVSolutionSetDecoder . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCoordinateTestCase |
class |
TestCoordinateDD
Test suite for
CoordinateDD . |
class |
TestCoordinateDDM
Test suite for
CoordinateDDM . |
class |
TestCoordinateDMS
Test suite for
CoordinateDMS . |
class |
TestCoordinateUtility
Test suite for
CoordinateUtility . |
Modifier and Type | Class and Description |
---|---|
class |
TestAccessPaths
|
class |
TestAddTerms
Test suite for adding terms to the lexicon.
|
class |
TestBlobsIndex
Test suite for low-level operations on the BLOBS index.
|
class |
TestBlobsWriteTask
Test suite for the
BlobsWriteTask . |
class |
TestCompletionScan
Unit tests for
LexiconRelation.prefixScan(org.openrdf.model.Literal[]) . |
class |
TestFullTextIndex
Test of adding terms with the full text index enabled and of lookup of terms
by tokens which appear within those terms.
|
class |
TestId2TermTupleSerializer
Test suite for
Id2TermTupleSerializer . |
class |
TestInlining
Test suite for adding terms to the lexicon.
|
class |
TestIVCache
Test suite for
IVCache.getValue() , which provides a cache on the
IV for a materialized BigdataValue . |
class |
TestLexAccessPatternEnum
Test suite for
LexAccessPatternEnum . |
class |
TestLexiconKeyBuilder
Test suite for
LexiconKeyBuilder . |
class |
TestSubjectCentricFullTextIndex
Deprecated.
Feature was never completed due to scalability issues. See
BZLG-1548, BLZG-563.
|
class |
TestTermIdEncoder
Unit test for unified encoding / decoding for partitioned and unpartitioned
long counters as assigned by the
ICounter for a TERM2ID index or
index partition. |
class |
TestTermIVComparator
Test suite for
TermIVComparator . |
Modifier and Type | Class and Description |
---|---|
class |
TestLockDeserialization
This is a test suite for the
ReentrantLock deserialization pattern
used by the MappedRDFFileLoadTask when it executes on a remote
ClientService . |
Modifier and Type | Class and Description |
---|---|
class |
TestBigdataValueSerialization
Test suite for
BigdataValueImpl serialization semantics, including
the correct recovery of the BigdataValueFactoryImpl reference when
deserialized. |
class |
TestFactory
Unit tests for
BigdataValueFactoryImpl . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRIOTestCase
Abstract base class for unit tests involving the RIO integration.
|
class |
TestAsynchronousStatementBufferFactory
Test suite for
AsynchronousStatementBufferFactory . |
class |
TestLoadAndVerify
Test loads an RDF/XML resource into a database and then verifies by re-parse
that all expected statements were made persistent in the database.
|
class |
TestNTriplesWithSids
Test suite for SIDS support with NTRIPLES data.
|
class |
TestStatementBuffer
Test suite for
StatementBuffer . |
static class |
TestStatementBuffer.TestTriplesModeAPs
Triples mode test suite.
|
Modifier and Type | Class and Description |
---|---|
class |
BigdataNTriplesParserTest
JUnit test for the N-Triples parser.
|
class |
BigdataNTriplesParserTestCase
JUnit test for the N-Triples parser.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractInferenceEngineTestCase
Base class for test suites for inference engine and the magic sets
implementation.
|
class |
TestBackchainOwlSameAsPropertiesIterator
Test suite for
BackchainOwlSameAsPropertiesIterator . |
class |
TestBackchainTypeResourceIterator
Test suite for
BackchainTypeResourceIterator . |
class |
TestCompareFullAndFastClosure
Test suite comparing full fix point closure of RDFS entailments against the
fast closure program for some known data sets (does not test truth
maintenance under assertion and retraction or the justifications).
|
class |
TestContextAdvancer
Test suite for the
ContextAdvancer . |
class |
TestDatabaseAtOnceClosure
Unit tests for database at once closure, fix point of a rule set (does not
test truth maintenance under assertion and retraction or the justifications).
|
class |
TestDistinct
Unit tests for
IQueryOptions.isDistinct() . |
class |
TestDistinctTermScan
Test suite for the
DistinctTermAdvancer . |
class |
TestJustifications
Test suite for writing, reading, chasing and retracting
Justification s. |
class |
TestMappedProgram
MappedProgram is used to produce the full closure and fast closure
programs and is responsible, together with TMUtility , for mapping
those rules across the permutations of the [database/focusStore] views. |
class |
TestMatch
Unit tests for
AbstractTripleStore.match(Literal[], URI[], URI) . |
class |
TestModelsEqual
|
class |
TestOwlSameAsPropertiesExpandingIterator
Test suite for
OwlSameAsPropertiesExpandingIterator . |
class |
TestRuleExpansion |
class |
TestRuleFastClosure_11_13
Test suite for
AbstractRuleFastClosure_11_13 . |
class |
TestRuleFastClosure_3_5_6_7_9
Test suite for
AbstractRuleFastClosure_3_5_6_7_9 . |
class |
TestRuleOwlEquivalentClass
Test suite for
RuleOwlEquivalentClass . |
class |
TestRuleOwlEquivalentProperty
Test suite for
RuleOwlEquivalentProperty |
class |
TestRuleOwlFunctionalProperty
Test suite for owl:FunctionalProperty processing.
|
class |
TestRuleOwlHasValue
Test suite for owl:hasValue processing.
|
class |
TestRuleOwlInverseOf
Test suite for owl:inverseOf processing.
|
class |
TestRuleOwlSameAs
Test suite for owl:sameAs processing.
|
class |
TestRuleOwlSymmetricProperty
Test suite for owl:SymmetricProperty processing.
|
class |
TestRuleOwlTransitiveProperty
Test suite for owl:transtitiveProperty processing.
|
class |
TestRuleRdf01
Test suite for
RuleRdf01 . |
class |
TestRuleRdfs03
Test for
RuleRdfs03 . |
class |
TestRuleRdfs04
Test suite for
RuleRdfs04a and RuleRdfs04b |
class |
TestRuleRdfs07
Note: rdfs 2, 3, 7, and 9 use the same base class.
|
class |
TestRuleRdfs10
Note: rdfs 6, 8, 10, 12, and 13 use the same base clase.
|
class |
TestRuleRdfs11
Note: rdfs 5 and 11 use the same base class.
|
class |
TestTMUtility
Test suite for rule re-writes supporting truth maintenance for the RDF DB.
|
class |
TestTruthMaintenance
Test suite for
TruthMaintenance . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBigdataSailTestCase
Abstract harness for testing under a variety of configurations.
|
class |
DavidsTestBOps
A test suite developed for some bits and pieces of SPARQL 1.0 coverage.
|
class |
ProxyBigdataSailTestCase
This class provides proxy delegation logic for abstract methods declared by
AbstractBigdataSailTestCase and is used to extend the set of tests
that will be applied to all implementations of the generic object model Java
API. |
class |
QuadsTestCase
Unit tests for named graphs.
|
class |
TestBigdataSailEmbeddedFederationWithQuads
Test suite for the
BigdataSail with quads enabled running against an
EmbeddedFederation with a single data service. |
class |
TestBigdataSailWithoutSids
Test suite for the
BigdataSail with statement identifiers enabled. |
class |
TestBigdataSailWithQuads
Test suite for the
BigdataSail with quads enabled. |
class |
TestBigdataSailWithSids
Test suite for the
BigdataSail with statement identifiers enabled. |
class |
TestBigdataValueReplacer
Test suite for the logic which rewrites a query, replacing
Value
constants with BigdataValue constants which have been resolved
against the database. |
class |
TestBootstrapBigdataSail
Bootstrap test case for bringing up the
BigdataSail . |
class |
TestBOps |
class |
TestChangeSets
Test suite for the
IChangeLog feature. |
class |
TestCnxnCreate
Test suite for BLZG-2056 BigdataSailConnections not always closed by
BigdataSail.shutdown()
|
class |
TestConcurrentKBCreate
Test suite for the concurrent create and discovery of a KB instance.
|
static class |
TestConcurrentKBCreate.TestWithGroupCommit |
static class |
TestConcurrentKBCreate.TestWithoutGroupCommit |
class |
TestHistoryIndex
Test the index supporting the
HistoryServiceFactory . |
class |
TestInlineValues |
class |
TestJoinScope
Unit tests the quads aspects of the
BigdataSail implementation. |
class |
TestLexJoinOps |
class |
TestMaterialization |
class |
TestMillisecondPrecisionForInlineDateTimes
Unit test template for use in submission of bugs.
|
class |
TestMROWTransactions
TestCase to test single writer/mutiple transaction committed readers with
SAIL interface.
|
class |
TestMROWTransactionsNoHistory
TestCase to test single writer/mutiple transaction committed readers with
SAIL interface.
|
class |
TestMROWTransactionsWithHistory
TestCase to test single writer/mutiple transaction committed readers with
SAIL interface.
|
class |
TestMultiGraphs |
class |
TestNoExceptions
This test suite is for trac items where the failure mode is a 500 error caused
by a software error, often in the static optimizer.
|
class |
TestOptionals
Unit tests the optionals aspects of the
BigdataSail implementation. |
class |
TestOrderBy |
class |
TestProvenanceQuery
Test suite for high-level query against a graph containing statements about
statements.
|
class |
TestPruneBindingSets |
class |
TestQuadsAPI
Unit tests the quads aspects of the
BigdataSail implementation. |
class |
TestRDRHistory
Test suite
RDRHistory . |
class |
TestReadWriteTransactions |
class |
TestRollbacks
This is a stress test for abort/rollback semantics.
|
class |
TestRollbacksTM
Concrete instance of
TestRollbacks which overrides the properties to
enable truth maintenance support in the SAIL. |
class |
TestRollbacksTx
Concrete instance of
TestRollbacks which overrides the properties to
enable full transaction support in the SAIL. |
class |
TestSearchQuery
Test suite for high-level query against a graph containing statements about
statements.
|
class |
TestSesameFilters |
class |
TestSetBinding
Test suite for
AbstractOperation.setBinding(String, Value) |
class |
TestSids
Test case for reverse lookup from SID to statement.
|
class |
TestSingleTailRule |
class |
TestSparqlStar
Test suite for SPARQL* features
|
class |
TestSparqlUpdateCommit |
class |
TestStrBOp |
class |
TestTemplate
Unit test template for use in submission of bugs.
|
class |
TestTicket1086
Test suite for ticket #1086: when loading quads data into a triples store,
there now is a config option BigdataSail.Options.REJECT_QUADS_IN_TRIPLE_MODE.
|
class |
TestTicket1388
Test suite for ticket #1388: xsd:date function
|
class |
TestTicket1518
Test suite for ticket #1518: tests for quad-mode SPARQL features with triplestore not supporting quads
|
class |
TestTicket1681
Unit test template for use in submission of bugs.
|
class |
TestTicket1682
Unit test template for use in submission of bugs.
|
class |
TestTicket1716
Test suite for an issue where IV resolution of invalid numeric literal fails
|
class |
TestTicket1747
Test suite for an issue where IV resolution of vocabulary terms
interferes with query parsing and deferred IV resolution (
ASTDeferredIVResolution . |
class |
TestTicket1753
Test suite for an issue where IV resolution of having clause fails
|
class |
TestTicket1755
Unit test template for use in submission of bugs.
|
class |
TestTicket1785
Unit test template for use in submission of bugs.
|
class |
TestTicket1788
Unit test template for use in submission of bugs.
|
class |
TestTicket1875
Test suite for an issue where IV resolution of RDR statements was not completed
|
class |
TestTicket1889
This test case covers 2 ArrayIndexOutOfBoundsException occurrences:
1.
|
class |
TestTicket1889_2
Unit test template for use in submission of bugs.
|
class |
TestTicket1893 |
class |
TestTicket2043
Unit test template for use in submission of bugs.
|
class |
TestTicket2043b
Unit test template for use in submission of bugs.
|
class |
TestTicket2083
Unit test template for use in submission of bugs.
|
class |
TestTicket275
Unit test template for use in submission of bugs.
|
class |
TestTicket276
Unit test template for use in submission of bugs.
|
class |
TestTicket348
Unit test template for use in submission of bugs.
|
class |
TestTicket353
Unit test template for use in submission of bugs.
|
class |
TestTicket355
Unit test template for use in submission of bugs.
|
class |
TestTicket422
Test suite for wrapping a
TempTripleStore as a BigdataSail . |
class |
TestTicket4249
Unit test template for use in submission of bugs.
|
class |
TestTicket581
Unit test template for use in submission of bugs.
|
class |
TestTicket610
To run this test case, specify the following JVM property:
-DtestClass=com.bigdata.rdf.sail.TestBigdataSailWithoutSids |
class |
TestTicket632
Test for an error that occurs when a SERVICE (OpenRdf Service) call uses
variables that are assigned as input bindings to the query that holds the
SERVICE call.
|
class |
TestTicket647
Unit test template for use in submission of bugs.
|
class |
TestTicket669
Unit test template for use in submission of bugs.
|
class |
TestTicket693
Unit test template for use in submission of bugs.
|
class |
TestTicket967
Ticket 967 is an EOF exception on high load of HttpClient requests
|
class |
TestTxCreate
Unit test for the creation of a Sail with isolatable indices.
|
class |
TestUnions
Unit tests the UNION aspects of the
BigdataSail implementation. |
Modifier and Type | Class and Description |
---|---|
class |
TestOOMBug
Unit test template for use in submission of bugs.
|
Modifier and Type | Class and Description |
---|---|
class |
TestPaths |
Modifier and Type | Class and Description |
---|---|
class |
TestVerifyAggregates
Test suite for
VerifyAggregates . |
Modifier and Type | Class and Description |
---|---|
class |
BigdataSPARQLUpdateTest2
Test suite for BIGDATA extension to SPARQL UPDATE for NAMED SOLUTION SETS.
|
class |
BigdataSPARQLUpdateTest2DiskRW
A variant of the test suite using
BufferMode.DiskRW . |
class |
BigdataSPARQLUpdateTest2DiskWORM
A variant of the test suite using
BufferMode.DiskWORM . |
class |
BigdataSPARQLUpdateTxTest2
A variant of the test suite using full read/write transactions.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractIndexManagerTestCase<S extends IIndexManager> |
class |
AbstractNamedGraphUpdateTest
This class is concerning the issues raised in trac 804
|
class |
AbstractProtocolTest
This class supports making requests to the server with fairly low level control.
|
class |
AbstractSimpleInsertTest<S extends IIndexManager> |
class |
AbstractTestNanoSparqlClient<S extends IIndexManager>
Proxied test suite.
|
class |
ExampleProtocolTest
This class tests whether its superclass is working (at least a little)
The superclass provides capability to check the request/response protocol,
without actually starting a server.
|
class |
HashDistinctNamedGraphUpdateTest |
class |
NativeDistinctNamedGraphUpdateTest |
class |
ProxyTestCase<S extends IIndexManager>
This class provides proxy delegation logic for abstract methods declared by
AbstractJournalTestCase and is used to extend the set of tests that will be
applied to all implementations of the generic object model Java API. |
class |
StressTest_REST_MultiTenancy<S extends IIndexManager>
Proxied test suite providing a stress test of the multi-tenancy API.
|
class |
StressTestConcurrentRestApiRequests<S extends IIndexManager>
Proxied test suite.
|
class |
Test_REST_ASK<S extends IIndexManager>
Proxied test suite.
|
class |
Test_REST_DELETE_BY_ACCESS_PATH<S extends IIndexManager>
Proxied test suite for the DELETE_BY_ACCESS_PATH method.
|
class |
Test_REST_DELETE_WITH_BODY<S extends IIndexManager>
Proxied test suite.
|
class |
Test_REST_DESCRIBE<S extends IIndexManager>
Proxied test suite.
|
class |
Test_REST_ESTCARD<S extends IIndexManager>
Proxied test suite for the ESTCARD method (estimated cardinality aka fast
range counts) and related operations at the
RepositoryConnection that
tunnel through to the same REST API method (getContexts(), size()). |
static class |
Test_REST_ESTCARD.ReadWriteTx<S extends IIndexManager> |
class |
Test_REST_HASSTMT<S extends IIndexManager>
Proxied test suite for the
HASSTMT REST API method. |
static class |
Test_REST_HASSTMT.ReadWriteTx<S extends IIndexManager>
Adds test coverage using read/write tx and verifies that the behavior is
correct after we delete statements (that is, it is not relying on a fast
range count for read/write tx namespaces).
|
static class |
Test_REST_HASSTMT.TruthMaintenance<S extends IIndexManager>
Test suite for the semantics of includeInferred (this requires setting up
a namespace with truth maintenance).
|
class |
Test_REST_ServiceDescription<S extends IIndexManager>
Proxied test suite.
|
class |
Test_REST_Structure<S extends IIndexManager>
Proxied test suite for bootstrap and basic structure tests for the REST API.
|
class |
Test_REST_TX_API<S extends IIndexManager>
Proxied test suite for testing the transaction management API.
|
static class |
Test_REST_TX_API.NoReadWriteTx<S extends IIndexManager>
An *extension* of the test suite that uses a namespace that is NOT
configured to support read/write transactions.
|
static class |
Test_REST_TX_API.ReadWriteTx<S extends IIndexManager>
An *extension* of the test suite that uses a namespace that is configured
to support read/write transactions.
|
class |
Test_Ticket_1207<S extends IIndexManager>
GETSTMTS test suite for includeInferred.
|
class |
Test_Ticket_1717<S extends IIndexManager>
GETSTMTS test suite for not resolved numeric IVs in Bind.
|
class |
Test_Ticket_1893
This test checks if plain literals and string literals are properly indexed in FTS,
and also rebuild text index produces properly indexed FTS.
|
class |
Test_Ticket_2091
This test checks if constants in projection expressions are properly resolved.
|
class |
Test_Ticket_605<S extends IIndexManager> |
class |
TestAskJsonTrac704 |
class |
TestBackupServlet<S extends IIndexManager>
Proxied test suite for
DataLoaderServlet |
class |
TestBigdataSailRemoteRepository<S extends IIndexManager>
Proxied test suite for
BigdataSailRemoteRepository and
BigdataSailRemoteRepositoryConnection . |
static class |
TestBigdataSailRemoteRepository.ReadWriteTx<S extends IIndexManager>
An *extension* of the test suite that uses a namespace that is configured
to support read/write transactions.
|
class |
TestBLZG1943
Test case for ticket BLZG-1943: thread safety issues related to reuse of
GeoSpatialLiteralExtension 's internal key builder. |
class |
TestCBD731<S extends IIndexManager>
Proxied test suite.
|
class |
TestConneg
Test suite for content negotiation helper class.
|
class |
TestDataLoaderServlet<S extends IIndexManager>
Proxied test suite for
DataLoaderServlet |
class |
TestFederatedQuery<S extends IIndexManager>
Proxied test suite for SPARQL 1.1 Federated Query.
|
class |
TestGetRequestTimeout
Unit tests for the
BigdataRDFContext.getQueryTimeout(javax.servlet.http.HttpServletRequest, long) method. |
class |
TestInsertFilterFalse727<S extends IIndexManager>
Proxied test suite.
|
class |
TestMultiTenancyAPI<S extends IIndexManager>
Proxied test suite for the Multi-Tenancy API.
|
class |
TestNanoSparqlClient<S extends IIndexManager>
Proxied test suite.
|
class |
TestNanoSparqlServer
Unit tests for the
NanoSparqlServer with a focus on the ability to
override the init parameters, the default http port, etc. |
class |
TestNanoSparqlServerWithProxyIndexManager<S extends IIndexManager>
Test suite for
RESTServlet (SPARQL end point and REST API for RDF
data). |
class |
TestNanoSparqlServerWithProxyIndexManager2<S extends IIndexManager>
A version of the test suite that is intended for local debugging and is NOT
run in CI.
|
class |
TestPostNotURLEncoded
See trac 711 for discussion.
|
class |
TestRDROperations<S extends IIndexManager>
Test of RDR specific data interchange and query.
|
class |
TestRebuildTextIndex<S extends IIndexManager>
Proxied test suite for rebuilding full text index.
|
class |
TestRelease123Protocol
This test class exercises protocol issues (mimetypes, parameters etc)
as at release 1.2.3; prior to addressing protocol related trac items such
as 704, 697, 711
|
class |
TestRWStoreTxBehaviors<S extends IIndexManager>
Tests that are RWStore specific.
|
class |
TestService794
While writing this comment, early January 2014,
the status is that the two interesting tests
both fail and are disabled
TestService794.xtestMassageServiceCall() and TestService794.xtestMassageServiceNested1Call()
Also TestService794.xtestServiceSyntaxError() shows some bug some where in that
we take legal SPARQL and make it illegal before the service call .... |
class |
TestServiceWhiteList
Unit tests for the
NanoSparqlServer with a focus on the ability to |
class |
TestSparqlUpdate<S extends IIndexManager>
Proxied test suite.
|
class |
TestSparqlUpdateSuppressTruthMaintenance<S extends IIndexManager> |
class |
TestXMLBuilder
Test suite for
XMLBuilder . |
Modifier and Type | Class and Description |
---|---|
class |
TestNSSHealthCheck
Utility test suite provides a health check for a deployed instance.
|
Modifier and Type | Class and Description |
---|---|
class |
TestAbstractHostLBSPolicy
Test suite for the basic stochastic load balancing mechanism for LBS policies
based on actual host workloads regardless of how those workload metrics are
obtained.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractASTEvaluationTestCase |
class |
AbstractSolutionSetStatsTestCase
Test suite for
ISolutionSetStats . |
class |
TestJoinSetUtil
Test suite for
JoinSetUtil . |
class |
TestSolutionSetStats
Test suite for
SolutionSetStats . |
class |
TestSolutionSetStatserator
Test suite for
SolutionSetStatserator |
class |
TestStaticAnalysis
Test suite for methods supporting static analysis of the variables, including
whether a variable MUST be bound, MIGHT be bound, or is NOT bound.
|
class |
TestStaticAnalysis_CanJoin |
class |
TestStaticAnalysis_CanJoinUsingConstraints
This test suite is built around around BSBM Q5.
|
Modifier and Type | Class and Description |
---|---|
class |
TestCacheConnectionFactory
Stress test for correct shutdown of the
ICacheConnection as allocated
by the CacheConnectionFactory . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDataAndSPARQLTestCase |
class |
AbstractDataDrivenSPARQLTestCase
Abstract base class for data driven test suites.
|
class |
AbstractInlineSELECTTestCase
The idea here is that the subclasses provide the data for the test
(i.e.
|
class |
TestAggregationQuery
Data driven test suite for aggregation queries.
|
class |
TestAST
Port of unit tests originally written at the AST layer.
|
class |
TestBasicQuery
Data driven test suite.
|
class |
TestBindHeisenbug708
Test suite for a hesienbug involving BIND.
|
class |
TestBindings
Data driven test suite for SPARQL 1.1 BIND & VALUES clause.
|
class |
TestBlockingBufferPerformance740 |
class |
TestBrokenDatetimeParsing
Test case fot date time parsing in queries when specifying dates containing a numerical time zone spec.
|
class |
TestComboJoins
Data driven test suite.
|
class |
TestComplexQuery
Data driven test suite for complex queries.
|
class |
TestCompressedTimestampExtensionSPARQL
Data driven test suite
CompressedTimestampExtension , testing
real SPARQL queries including mathematical operations over the extension. |
class |
TestConstruct
Data driven test suite for CONSTRUCT queries.
|
class |
TestCustomFunction
Test suite for registering and evaluating custom functions.
|
class |
TestCustomTypeCasts
Test suite for standard type cast function such as
XsdLongBOp and
XsdUnsignedLongBOp . |
class |
TestDefaultGraphs
Unit tests for default graph semantics ported from the old
TestDefaultGraphAccessPath class.
|
class |
TestDescribe
Data driven test suite for DESCRIBE queries, including the interaction with
the optional DESCRIBE cache.
|
class |
TestDistinctTermScanOptimizer
SPARQL level test suite for the
ASTDistinctTermScanOptimizer and its
physical operator DistinctTermScanOp . |
static class |
TestDistinctTermScanOptimizer.TestQuadsModeAPs
Note: For quads we need to test all of the combinations of default and
named graph modes and both with and without the GRAPH {} wrapping the
triple pattern.
|
static class |
TestDistinctTermScanOptimizer.TestTriplesModeAPs
Triples mode test suite.
|
class |
TestExplainHints
Test suite for EXPLAIN hints.
|
class |
TestFastRangeCountOptimizer |
static class |
TestFastRangeCountOptimizer.TestQuadsModeAPs
Quads mode test suite.
|
static class |
TestFastRangeCountOptimizer.TestTriplesModeAPs |
class |
TestFilters
Test suite for FILTER evaluation.
|
class |
TestGearingQueryHint
Test suite for https://jira.blazegraph.com/browse/BLZG-2089, which
introduces a fresh query hint to select the gearing choice for property
paths.
|
class |
TestGraphEmptyPattern709_429
Tests concerning "SELECT GRAPH XXXX {}" with XXXX and the dataset varying.
|
class |
TestHashJoin
Test suite for queries designed to exercise a hash join against an access
path.
|
class |
TestInclude
Data driven test suite for INCLUDE of named solution sets NOT generated by a
NamedSubqueryRoot . |
static class |
TestInclude.IncludeStressTests
Tests to be executed in a stress test fashion, i.e.
|
class |
TestInlineConstraints |
class |
TestJoinOrder
Data driven test suite for SPARQL 1.1 BIND & VALUES clause.
|
class |
TestMergeJoin
Data driven test suite.
|
class |
TestNamedGraphs
Test suite for named and default graph stuff.
|
class |
TestNamedSubQuery
Data driven test suite for named subquery evaluation (that is, for queries
which are explicitly written using the named subquery syntax).
|
class |
TestNegation
Test suite for SPARQL negation (EXISTS and MINUS).
|
class |
TestPipelinedHashJoin
Test suite for
PipelinedHashIndexAndSolutionSetJoinOp , which implements a
pipelined hash join. |
class |
TestPropertyPaths |
class |
TestQueryHints
Test suite for SPARQL queries with embedded query hints.
|
class |
TestSimpleBindingsOptimizer
SPARQL level test suite for the
ASTSimpleBindingsOptimizer . |
static class |
TestSimpleBindingsOptimizer.TestQuadsModeAPs |
static class |
TestSimpleBindingsOptimizer.TestTriplesModeAPs
Triples mode test suite.
|
class |
TestSimpleGroupByAndCountOptimizer
SPARQL level test suite for the
ASTSimpleGroupByAndCountOptimizer . |
static class |
TestSimpleGroupByAndCountOptimizer.TestQuadsModeAPs
Quads mode test suite.
|
static class |
TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
Triples mode test suite.
|
class |
TestSubQuery
Data driven test suite.
|
class |
TestSubSelectFilterExist725
Test for trac725
|
class |
TestTCK
Test driver for debugging Sesame or DAWG manifest tests.
|
static class |
TestTCK.TCKStressTests
Tests to be executed in a stress test fashion, i.e.
|
class |
TestTicket1007
Various tests covering different constellations where values are constructed
using BIND and reused in other parts of the query, such as
- testing inlined vs.
|
class |
TestTicket1087
Test suite for an issue where ill designed patterns consisting of a
combination of UNION and nested OPTIONAL cause problems.
|
class |
TestTicket1105
Test suite asserting that queries containint quads constructs (named graphs)
are rejected in triples mode (at parsing phase), but go through in quads
mode.
|
static class |
TestTicket1105.TestQuadsModeAPs
Quads mode test suite.
|
static class |
TestTicket1105.TestTriplesModeAPs
Triples mode test suite.
|
class |
TestTicket1200_1780
Test case for https://jira.blazegraph.com/browse/BLZG-1200:
REGEX does not use SPARQL spec for conversion of literals with a language type
|
class |
TestTicket1591
Test case for https://jira.blazegraph.com/browse/BLZG-1591:
NotMaterializedException with ORDER BY clause (for InlineURIIvs). |
class |
TestTicket1899
Test suite for a NotMaterializedException caused by HTree hash index built.
|
class |
TestTicket4323 |
class |
TestTicket5590
Problems with negated path expressions.
|
class |
TestTicket887
Test suite for a heisenbug involving BIND.
|
class |
TestTicket946
Test suite for an issue where an empty projection causes an
IllegalArgumentException . |
class |
TestTickets
Test suite for tickets at
|
class |
TestTwoPropertyPaths734
Tests concerning:
|
class |
TestUnionMinus
Test suite for UNION and MINUS combined, see
https://sourceforge.net/apps/trac/bigdata/ticket/767
|
class |
TestUnsigned
Test suite for xsd:unsigned handling.
|
class |
TestVirtualGraphs
Test suite for VIRTUAL GRAPHS support.
|
Modifier and Type | Class and Description |
---|---|
class |
TestBsbmBIQuery
Data driven test suite for complex queries.
|
Modifier and Type | Class and Description |
---|---|
class |
TestBsbmExploreQuery
Data driven test suite for complex queries.
|
Modifier and Type | Class and Description |
---|---|
class |
TestReificationDoneRightEval
Reification Done Right test suite.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRTOTestCase
Data driven test suite for the Runtime Query Optimizer (RTO).
|
class |
TestRTO_BAR
Data driven test suite for the Runtime Query Optimizer (RTO) using BAR data
and queries.
|
class |
TestRTO_BSBM
Data driven test suite for the Runtime Query Optimizer (RTO) using BSBM data
and queries based on BSBM.
|
class |
TestRTO_FOAF
Deprecated.
None of these test queries are complicated enough to trigger the
RTO. The class and its queries should just be dropped.
|
class |
TestRTO_LUBM
Data driven test suite for the Runtime Query Optimizer (RTO) using LUBM data
and queries based on LUBM.
|
Modifier and Type | Class and Description |
---|---|
class |
TestBigdataNativeServiceEvaluation
Data driven test suite for SPARQL 1.1 Federated Query against an internal,
bigdata "aware" service (similar to our integrated full text search
facility).
|
class |
TestFulltextSearch
Data driven test suite for external full text search.
|
class |
TestGeoSpatialCorrectRejection
Correct rejection test for GeoSpatial data, making sure that appropriate error
messages are thrown in cases where we encounter data format problems or service
calls are not properly configured.
|
class |
TestGeoSpatialCustomFields
Data driven test suite for GeoSpatial service feature aiming at the definition of
custom fields (possibly combined with predefined fields).
|
class |
TestGeoSpatialCustomSerializer
Data driven test suite for custom serializer.
|
class |
TestGeoSpatialCustomSerializerWKT
Data driven test suite for custom serializer, testing basic feasibility
for WKT literals (not strictly following the standard).
|
class |
TestGeoSpatialDefaults
Tests covering the geospatial default configuration, i.e.
|
class |
TestGeoSpatialDisableBuiltinDatatypes
Data driven test suite testing configurability of GeoSpatial service.
|
class |
TestGeoSpatialExamplesFromDocumentation
Data driven test suite asserting that the examples in the geospatial
documentation are running through properly.
|
class |
TestGeoSpatialQueryIfGeospatialDisabled
Test case asserting that geospatial SERVICE query fails with proper
exception if geospatial submodue is turned off.
|
class |
TestGeoSpatialQueryVaryOneDimension
Data driven test suite for querying of (i) our built-in datatypes and (ii) a
comprehensive custom datatype where we restrict only one of the existing dimensions,
in order to make sure that the constraints for all dimensions are properly considered.
|
class |
TestGeoSpatialServiceConfiguration
Data driven test suite testing configurability of GeoSpatial service.
|
class |
TestGeoSpatialServiceConfigurationCustomDatatype
Data driven test suite testing configurability of GeoSpatial service.
|
class |
TestGeoSpatialServiceConfigurationParsing
Test suite testing the form-JSON parsing facilities for the GeoSpatial service configuration.
|
class |
TestGeoSpatialServiceEvaluation
Data driven test suite for GeoSpatial service feature in quads mode,
testing of different service configurations,
as well as correctness of the GeoSpatial service itself.
|
class |
TestGeoSpatialServiceEvaluationQuads
Data driven test suite for GeoSpatial service feature, GeoSpatial in
triples vs.
|
class |
TestOpenrdfNativeServiceEvaluation
Data driven test suite for SPARQL 1.1 Federated Query against an openrdf
aware SERVICE implementation running in the same JVM.
|
class |
TestSearch
Data driven test suite for full text search.
|
Modifier and Type | Class and Description |
---|---|
class |
TestUpdateBootstrap
Bootstrapped test suite for core UPDATE functionality based on BOP
evaluation.
|
Modifier and Type | Class and Description |
---|---|
class |
TestStoredQueryService
Test suite for stored query evaluation.
|
Modifier and Type | Class and Description |
---|---|
class |
TestSolutionSetManager
Test suite for managing named solution sets.
|
Modifier and Type | Class and Description |
---|---|
class |
TestSPO
Test suite for the
SPO class. |
class |
TestSPOAccessPath
Test suite for
SPOAccessPath . |
class |
TestSPOKeyCoders
Test suite for approaches to key compression for statement indices (keys are
permutations on SPOC, logically comprised of long[4] and encoded as byte[]),
the terms index (key is byte[] encoding the URI, literal, or bnode ID), or
the ids index (key is byte[] encoding a long term identifier).
|
class |
TestSPOKeyOrder
Test suite for
SPOKeyOrder . |
class |
TestSPOPredicate
Test suite for
SPOPredicate . |
class |
TestSPORelation
Test ability to insert, update, or remove elements from a relation and the
ability to select the right access path given a predicate for that relation
and query for those elements (we have to test all this stuff together since
testing query requires us to have some data in the relation).
|
class |
TestSPOStarJoin |
class |
TestSPOTupleSerializer
Test suite for
SPOTupleSerializer . |
class |
TestSPOValueCoders
Test suite for approaches to value compression for statement indices.
|
class |
TestXXXCShardSplitHandler
Test suite for the
XXXCShardSplitHandler . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractDistributedBigdataFederationTestCase
An abstract test harness that sets up (and tears down) the metadata and data
services required for a bigdata federation using JINI to handle service
discovery.
|
class |
AbstractDistributedTripleStoreTestCase
Abstract test case that sets up and connects to a bigdata federation and
establishes an RDF database on that federation.
|
class |
AbstractTestCase
Abstract harness for testing under a variety of configurations.
|
class |
AbstractTripleStoreTestCase
Base class for test suites for inference engine
|
class |
StressTestCentos
This is a test class that fails on centos 64bit.
|
class |
TestBlobsConfiguration
Test suite for configuration of the BLOBS index support.
|
class |
TestBulkFilter
Test bulk filter API.
|
class |
TestDataLoader
Test suite for the
DataLoader . |
class |
TestInlineURIs
Integration test suite for
InlineURIFactory (the inline IVs are also
tested in their own package without the triple store integration). |
class |
TestInsertRate
A test for measuring the possible insert rate for a triple store based on a
journal and btree using a synthetic data generator.
|
class |
TestIsModified
Test suite for
ISPO.isModified() . |
class |
TestLocalQuadStore
Proxy test suite for
LocalTripleStore in quad-store mode. |
class |
TestLocalTripleStore
Proxy test suite for
LocalTripleStore when the backing indices are
BTree s. |
class |
TestLocalTripleStoreDestroy
Test suite to verify the semantics of destroying a
LocalTripleStore ,
including verifying that the indices are deleted (gone from Name2Addr), that
the locator is cleared from the DefaultResourceLocator , and that the
entries from the AbstractTripleStore are removed from the global row
store. |
class |
TestLocalTripleStoreTransactionSemantics
Test suite for the transaction semantics of the
LocalTripleStore . |
class |
TestLocalTripleStoreWithoutInlining
Proxy test suite for
LocalTripleStore when the backing indices are
BTree s. |
class |
TestLocalTripleStoreWithoutStatementIdentifiers
Proxy test suite for
LocalTripleStore when the backing indices are
BTree s. |
class |
TestRelationLocator
Test suite for locating an
AbstractTripleStore , locating the
LexiconRelation and SPORelation from the
AbstractTripleStore , and locating the AbstractTripleStore
from its contained relations. |
class |
TestScaleOutTripleStoreWithEmbeddedFederation
Proxy test suite for
ScaleOutTripleStore running against an
EmbeddedFederation . |
class |
TestSharedLexiconTempStore
Test suite for
TempTripleStore s sharing the same
LexiconRelation as the primary AbstractTripleStore . |
class |
TestStatementIdentifiers
Test of the statement identifier semantics.
|
class |
TestTempTripleStore
Proxy test suite for
TempTripleStore . |
class |
TestTripleStore
Test basic features of the
ITripleStore API. |
class |
TestTripleStoreBasics
Aggregates test that are run for each
ITripleStore implementation. |
Modifier and Type | Class and Description |
---|---|
class |
TestVocabulary
Test suite for
BaseVocabulary . |
Modifier and Type | Class and Description |
---|---|
class |
TestDefaultResourceLocator
Test suite for location relations, etc.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractRuleTestCase |
class |
TestProgram
Test suite for
Program and common rule/program re-writes. |
class |
TestRule
Test suite for basic
Rule mechanisms. |
class |
TestSlice
Unit tests for
Slice . |
Modifier and Type | Class and Description |
---|---|
class |
TestRuleState |
Modifier and Type | Class and Description |
---|---|
class |
AbstractResourceManagerBootstrapTestCase |
class |
AbstractResourceManagerTestCase
Base class for
ResourceManager test suites that can use normal
startup and shutdown. |
class |
AbstractTestSegSplitter
Unit tests for splitting an index segment based on its size on the disk, the
nominal size of an index partition, and an optional application level
constraint on the choice of the separator keys.
|
class |
TestAddDeleteResource
Unit test of the
StoreManager when adding and deleting journals and
index segments. |
class |
TestBuildTask
Basic test of building an index segment from an index partition on overflow.
|
class |
TestBuildTask2
Basic test of building an index segment from an index partition on overflow.
|
class |
TestFixedLengthPrefixShardSplits
Unit tests for splitting an index segment based on its size on the disk, the
nominal size of an index partition, and an optional application level
constraint on the choice of the separator keys.
|
class |
TestMergeTask
Basic test of compacting merge for an index partition on overflow.
|
class |
TestReleaseResources
Test release (aka purge) of old resources.
|
static class |
TestReleaseResources.TestWithCopy_NonZeroMinReleaseAge
Test where the indices are copied during synchronous overflow processing
and where a non-zero [minReleaseAge] was specified.
|
static class |
TestReleaseResources.TestWithCopyImmediateRelease
Test where the index view is copied in its entirety onto the new journal
and the [minReleaseAge] is ZERO(0).
|
static class |
TestReleaseResources.TestWithCopyNoRelease
Test where the index view is copied in its entirety onto the new journal
but the
ResourceManager is not permitted to release old resources
(it is configured as an immortal store). |
class |
TestResourceManagerBootstrap
Bootstrap test suite for the
ResourceManager . |
class |
TestSegSplitter
Unit tests for splitting an index segment based on its size on the disk, the
nominal size of an index partition, and an optional application level
constraint on the choice of the separator keys.
|
class |
TestSparseRowStoreSplitHandler
Tetst suite for
LogicalRowSplitHandler . |
Modifier and Type | Class and Description |
---|---|
class |
TestRWJournal
Test suite for
BufferMode.DiskRW journals. |
static class |
TestRWJournal.TestInterrupts
Test suite integration for
AbstractInterruptsTestCase . |
static class |
TestRWJournal.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestRWJournal.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestRWJournal.TestRawStore
Test suite integration for
AbstractRestartSafeTestCase . |
Modifier and Type | Class and Description |
---|---|
class |
TestMemoryManager |
class |
TestMemoryManager2
Some additional tests for the
MemoryManager which look at the effect
of the #of buffers it is allowed to allocate. |
class |
TestMemStore
Test suite for
MemStore . |
static class |
TestMemStore.TestMRMW
Test suite integration for
AbstractMRMWTestCase . |
static class |
TestMemStore.TestMROW
Test suite integration for
AbstractMROWTestCase . |
static class |
TestMemStore.TestRawStore
Test suite integration for
AbstractRawStoreTestCase . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractAnalyzerFactoryTest |
class |
AbstractDefaultAnalyzerFactoryTest |
class |
AbstractSearchTest |
class |
TestConfigurableAnalyzerFactory
Unit tests for
ConfigurableAnalyzerFactory . |
class |
TestConfigurableAsDefaultAnalyzerFactory |
class |
TestDefaultAnalyzerFactory |
class |
TestLanguageRange |
class |
TestPrefixSearch
Unit test for prefix and exact match searches.
|
class |
TestSearchRestartSafe
Simple test verifies that the
FullTextIndex data are restart safe. |
class |
TestUnconfiguredAnalyzerFactory |
Modifier and Type | Class and Description |
---|---|
class |
AbstractEmbeddedFederationTestCase
An abstract test harness that sets up (and tears down) the metadata and data
services required for a bigdata federation using in-process services rather
than service discovery (which means that there is no network IO).
|
class |
StressTestConcurrent
Test suite for concurrent operations on a
DataService . |
class |
TestAll_DynamicSharding
Test suite for dynamic sharding.
|
class |
TestBasicIndexStuff
Test of basic index operations.
|
class |
TestDistributedTransactionService
Unit tests of local (all writes are on a single data service) and distributed
abort and commit protocols for an
IBigdataFederation using the
DistributedTransactionService . |
class |
TestDistributedTransactionServiceRestart
Unit tests of the setReleaseTime, snapshot and restart aspects of the
DistributedTransactionService (all having to do with the maintenance
of the commit time index, including across restart). |
class |
TestEDS
Delegate for
ProxyTestCase s for services running against an
EmbeddedFederation . |
class |
TestEmbeddedClient
Test suite for the
EmbeddedClient . |
class |
TestEventParser
Unit tests for parsing
Event s. |
class |
TestEventReceiver
Unit tests for the
EventReceiver . |
class |
TestJournal
Delegate for
ProxyTestCase s for services running against a
Journal . |
class |
TestLoadBalancerRoundRobin
Unit tests for the round robin behaviors of the load balancer in isolation
(not an integration test).
|
class |
TestMetadataIndex
Some unit tests for the
MetadataIndex as accessed via the
IMetadataService . |
class |
TestMove
Some unit tests for moving an index partition.
|
class |
TestOverflow
Simple test verifies that a scale-out index is preserved across both
synchronous and asynchronous overflow events.
|
class |
TestOverflowGRS
Test drives inserts on the GRS index partition until the data service is
forced to go through an overflow such that an index build is performed for
the GRS index (rather than copying the index into the new live journal).
|
class |
TestRangeQuery
Test suite for the
IRangeQuery API. |
class |
TestReceiveBuffer
Test verifies the ability to transmit a file using the
ResourceService . |
class |
TestReceiveFile
Test verifies the ability to transmit a file using the
ResourceService . |
class |
TestRestartSafe
Test suite for the ability to re-open an
EmbeddedFederation . |
class |
TestScatterSplit
Some unit tests for moving an index partition.
|
class |
TestSnapshotHelper
Unit tests for
DistributedTransactionService.SnapshotHelper . |
class |
TestSplitJoin
Test suite verifies that inserts eventually split an index and that deletes
eventually cause the index partitions to be joined.
|
Modifier and Type | Class and Description |
---|---|
class |
TestSplitter
Unit tests for
ISplitter . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyRangeMasterTestCase
Abstract base class for test suites for the
AbstractMasterTask and
friends using IPartitionMetadata locators. |
class |
AbstractMasterTestCase
Abstract base class for test suites for the
AbstractMasterTask and
friends. |
class |
TestDefaultDuplicateRemover
Test suite for
DefaultDuplicateRemover . |
class |
TestFileSystemScanner |
class |
TestMasterTask
Unit tests for the control logic used by
AbstractMasterTask and
friends. |
class |
TestMasterTaskIdleTimeout
Unit tests of the idle timeout behavior for
AbstractMasterTask and
friends. |
class |
TestMasterTaskWithErrors
Unit tests for error handling in the control logic used by
AbstractMasterTask and friends. |
class |
TestMasterTaskWithRedirect
Test ability to handle a redirect (subtask learns that the target service no
longer accepts data for some locator and instead must send the data somewhere
else).
|
class |
TestMasterTaskWithSplits
Stress test using key-range partitioned index (
IMetadataIndex ), which
allows us to test the AbstractMasterTask under split, move, join and
other kinds of index partition operations. |
Modifier and Type | Class and Description |
---|---|
class |
TestKeyEncodeDecode
Test suite for round trip of keys as encoded by
Schema.fromKey(com.bigdata.btree.keys.IKeyBuilder, Object) , by
AtomicRowWriteRead , and as decoded by the KeyDecoder . |
class |
TestSparseRowStore
Test suite for
SparseRowStore . |
class |
TestTPS
Test of
TPS (property timestamp set implementation). |
class |
TestValueType
Test suite for
ValueType . |
Modifier and Type | Class and Description |
---|---|
class |
TestAppendFilter
Unit tests for
Appender . |
class |
TestChunkedFilter
Unit tests for
ChunkedFilter . |
class |
TestCloseableChunkedIteratorWrapperConverter
Test suite for
CloseableChunkedIteratorWrapperConverter . |
class |
TestDechunkerator
Test suite for
Dechunkerator . |
class |
TestDistinctFilter
Unit tests for
DistinctFilter . |
class |
TestMergeFilter
Unit tests for
MergeFilter . |
class |
TestPushbackIterator
Unit test for
PushbackIterator . |
Modifier and Type | Class and Description |
---|---|
class |
TestHaltable
Test suite for
Haltable . |
class |
TestLatch
Unit tests for
Latch . |
Modifier and Type | Class and Description |
---|---|
class |
TestDecodeParams
Test suite for
NanoHTTPD.decodeParams(String, LinkedHashMap) |
class |
TestNanoHTTPD
Test suite for
NanoHTTPD . |
Copyright © 2006–2019 SYSTAP, LLC DBA Blazegraph. All rights reserved.