Note: This is a duplicate of
test_named_graphs_ticket_888b() - Method in class com.bigdata.rdf.sparql.ast.eval.
TestNamedGraphs
test_named_subquery() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedSubQuery
test_named_subquery_bindings() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedSubQuery
Unit test verifies that the BINDINGS clause is presented to the named
subquery.
test_named_subquery_bindings_2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedSubQuery
Unit test verifies that the named subquery is considering the
exogenous variables when it's the first operator in the query and
choosing the appropriate join variables to build the hash index.
test_named_subquery_scope() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedSubQuery
Test that only projected variables are included in named-subquery
results.
test_namedGraphs_01a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedGraphs
A series of quads mode unit tests for named and default graph query of a
data set containing a single triple.
test_namedGraphs_01b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedGraphs
This version of the query specifies a FROM clause and hence causes the
Dataset
to become non-null
but does not specify any
FROM NAMED clauses.
test_namedGraphs_01c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedGraphs
test_namedGraphs_01d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNamedGraphs
test_namedIndexScan() - Method in class com.bigdata.journal.TestName2Addr
Test the ability to register and use named index, including whether the
named index is restart safe.
test_namedSubquery() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
Unit test for WITH {subquery} AS "name" and INCLUDE.
test_namedSubquery746() - Method in class com.bigdata.rdf.sail.TestNoExceptions
Unit test for WITH {subquery} AS "name" and INCLUDE.
test_negativeByteValues() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
Test with byte values which are negative values when interpreted as as
signed 8 bit integers.
test_nested_optionals() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
select ?s ?label ?comment
where {
?s rdf:type :Person .
test_nested_values01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
test_nested_values02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
test_nested_values03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
test_nested_values04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
test_nested_values05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
test_nestedAggregates() - Method in class com.bigdata.bop.solutions.TestGroupByState
SELECT SUM(?x+MIN(?y)) as ?z
GROUP BY ?a
test_nestedAggregates() - Method in class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
SELECT SUM(?x+MIN(?y)) as ?z
GROUP BY ?a
test_nestedOptionals01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_nestedOptionals02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_nestedOptionals03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_nestedSubselectsWithUnion737() - Method in class com.bigdata.rdf.sail.TestNoExceptions
SELECT *
WHERE {
{ FILTER ( false ) }
UNION
{
{ SELECT ?Subject_A
WHERE {
{ SELECT $j__5 ?Subject_A
{
} ORDER BY $j__5
}
} GROUP BY ?Subject_A
}
}
OPTIONAL {
{ SELECT ?Subject_A
WHERE {
{ SELECT $j__8 ?Subject_A
{
} ORDER BY $j_8
}
} GROUP BY ?Subject_A
}
}
}
test_newTx_nothingCommitted_readOnlyTx() - Method in class com.bigdata.journal.TestTransactionService
test_newTx_nothingCommitted_readWriteTx() - Method in class com.bigdata.journal.TestTransactionService
test_newTx_readCommitted01() - Method in class com.bigdata.journal.TestTransactionService
Test ability to start a read-committed tx when [lastCommitTime] is
non-zero.
test_newTx_readCommitted02() - Method in class com.bigdata.journal.TestTransactionService
Unit test when [lastCommitTime] is zero.
test_newTx_readOnly() - Method in class com.bigdata.journal.TestTransactionService
Unit test for a new read-only transaction.
test_newTx_readOnly_contention() - Method in class com.bigdata.journal.TestTransactionService
Unit test in which all possible start times for a read-only transaction
are used, forcing the caller to block.
test_newTx_readOnly_historyGone() - Method in class com.bigdata.journal.TestTransactionService
Verify that a request for an historical state that is no longer available
will be rejected.
test_newTx_readOnly_historyGone2() - Method in class com.bigdata.journal.TestTransactionService
test_newTx_readOnly_releaseTimeRespectsReadsOnCommitTime() - Method in class com.bigdata.journal.TestTransactionService
Unit test verifies that the release time does NOT advance when the
earliest running transaction terminates but a second transaction is still
active which reads on the same commit time.
test_newTx_readOnly_timestamp_is_lastCommitTime() - Method in class com.bigdata.journal.TestTransactionService
Verify that you can create a read-only transaction by providing the
lastCommitTime as the timestamp.
test_newTx_readOnly_timestampInFuture() - Method in class com.bigdata.journal.TestTransactionService
Verify that you can create a read-only transaction using a timestamp that
is in the future.
test_newTx_readOnly_txComplete_postConditions() - Method in class com.bigdata.journal.TestTransactionService
Create a read-only transaction, commit it, and then attempt to re-commit
it and to abort it - those operations should fail with an
IllegalStateException
.
test_newTx_readWrite_01() - Method in class com.bigdata.journal.TestTransactionService
Create a new read-write tx and then abort it.
test_newTx_readWrite_02() - Method in class com.bigdata.journal.TestTransactionService
Create a new read-write tx and then commit it.
test_newTx_readWrite_03() - Method in class com.bigdata.journal.TestTransactionService
Create two read-write transactions and commit both.
test_newTx_readWrite_txComplete_postConditions() - Method in class com.bigdata.journal.TestTransactionService
Create a read-write transaction, commit it, and then attempt to re-commit
it and to abort it - those operations should fail with an
IllegalStateException
.
test_nextPartitionId() - Method in class com.bigdata.service.TestMetadataIndex
test_niceErrors() - Method in class com.bigdata.btree.TestTransientBTree
Tests various methods that deal with persistence and makes sure that we
have reasonable error messages.
test_no_dups1() - Method in class com.bigdata.bop.rdf.filter.TestSameVariableConstraint
test_no_intersection_1() - Method in class com.bigdata.util.httpd.TestMIMEType
test_no_intersection_2() - Method in class com.bigdata.util.httpd.TestMIMEType
test_no_intersection_3() - Method in class com.bigdata.util.httpd.TestMIMEType
test_no_property_paths() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTwoPropertyPaths734
test_no_using_workaround_property_paths() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTwoPropertyPaths734
test_NoAxioms() - Method in class com.bigdata.rdf.axioms.TestAxioms
test_noCycles_001() - Method in class com.bigdata.concurrent.TestTxDag
Verify that the DAG state is correctly updated when adding a variety of
WAITS_FOR relationships that do NOT form cycles.
test_noCycles__batch_001() - Method in class com.bigdata.concurrent.TestTxDag
Verify that the DAG state is correctly updated when adding a variety of
WAITS_FOR relationships that do NOT form cycles (using the batch
operation to add edges).
test_node_findChild01() - Method in class com.bigdata.btree.TestFindChild
A test of Node#findChild(int searchKeyOffset, byte[] searchKey)
with zero offsets.
test_nodeOrLeafFlag() - Method in class com.bigdata.btree.data.AbstractNodeOrLeafDataRecordTestCase
Verify methods that recognize a node vs a leaf based on a byte.
test_noIndicesRegistered() - Method in class com.bigdata.journal.TestTx
Test verifies that a transaction may start when there are (a) no commits
on the journal; and (b) no indices have been registered.
test_non_matching_optional_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
test_non_matching_optional_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
test_None() - Method in class com.bigdata.io.compression.TestUnicodeCompressor
test_noneBound() - Method in class com.bigdata.rdf.rules.TestBackchainTypeResourceIterator
Test when the triple pattern has no bound variables.
test_NoneBound_pattern() - Method in class com.bigdata.rdf.lexicon.TestLexAccessPatternEnum
test_nonEmptyJournal() - Method in class com.bigdata.journal.TestSnapshotJournal
Verifies exception if there are no commits on the journal (the
lastCommitTime will be zero which does not identify a valid commit
point).
test_noResourcesDoesNotWait() - Method in class com.bigdata.concurrent.TestLockManager
test_noResourcesDoesNotWait_predeclareLocks_synchronousQueue() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithPredeclaredLocks
Test where no locks are declared.
test_noResourcesDoesNotWait_predeclareLocks_unboundedQueue() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithPredeclaredLocks
Test where no locks are declared.
test_NoSuchIndexException() - Method in class com.bigdata.journal.TestAddDropIndexTask
Test attempt operations against a new journal (nothing committed) and
verify that we see
NoSuchIndexException
s rather than something
odder.
test_not_equals_1() - Method in class com.bigdata.util.httpd.TestMIMEType
test_not_equals_2() - Method in class com.bigdata.util.httpd.TestMIMEType
test_not_equals_3() - Method in class com.bigdata.util.httpd.TestMIMEType
test_not_equals_4() - Method in class com.bigdata.util.httpd.TestMIMEType
This case shows that the default parameter "q" is NOT
recognized by the base
MIMEType
class.
test_not_exists() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
Unit test for NOT EXISTS.
test_not_exists_01() - Method in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase
Unit tests for NOT EXISTS based on Sesame sparql11-exists-05
.
test_notgraph_uri() - Method in class com.bigdata.rdf.sparql.ast.eval.TestGraphEmptyPattern709_429
test_nothing() - Method in class com.bigdata.striterator.TestDechunkerator
Unit test with a single empty chunk.
test_nothingBound() - Method in class com.bigdata.bop.ap.TestPredicateAccessPath
Using a predicate with nothing bound, verify that we get the
right range count on the relation and that we read the correct elements
from the relation.
test_notSoSimpleIsolatedReset() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Tests semantics of a more complex isolated reset
Primarily the same as the simple isolated but ensuring
more unisolated interactions after isolation is
established.
test_NoVocabulary() - Method in class com.bigdata.rdf.lexicon.TestVocabulary
test_NoVocabulary() - Method in class com.bigdata.rdf.vocab.TestVocabulary
test_NSI01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_NSI01X() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_nsymbolsOne() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
Test with a single byte value (nsymbols:=1).
test_nsymbolsOne_nulls() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
Test with a single byte value (nsymbols=1) and some nulls.
test_ntriples_sids_00() - Method in class com.bigdata.rdf.rio.TestNTriplesWithSids
The "terse" syntax:
test_ntriples_sids_01() - Method in class com.bigdata.rdf.rio.TestNTriplesWithSids
The "terse" syntax:
test_null_bnode_uri_literal() - Method in class com.bigdata.bop.solutions.TestIVComparator
Unit test verifies the broad ordering which puts unbound values LT blank
nodes LT uris LT literals.
test_null_lt_anything() - Method in class com.bigdata.bop.solutions.TestIVComparator
Unit test verifies that an unbound value (a null
) is LT
anything else.
test_NullIV_decode_as_null_reference() - Method in class com.bigdata.rdf.internal.TestTermIV
test_nullValues() - Method in class com.bigdata.btree.TestNullValues
Tests the ability to store a
null
in a tuple of a
BTree
, to reload the
BTree
and find the
null
value still under the tuple, and to build an
IndexSegmentBuilder
from the
BTree
and find the
null
value under the
tuple.
test_nullValues() - Method in class com.bigdata.htree.TestNullValues
Tests the ability to store a
null
in a tuple of a
HTree
, to reload the
HTree
and find the
null
value still under the tuple.
test_object_list() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for an object list with variables.
test_object_list_where_objects_are_constants() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for an object list with constants.
test_objectCache() - Method in class com.bigdata.journal.TestCommitHistory
Test of the canonicalizing object cache used to prevent distinct
instances of a historical index from being created.
test_offsetSamplers() - Method in class com.bigdata.bop.ap.TestSampleIndex
test_one_dup() - Method in class com.bigdata.bop.rdf.filter.TestSameVariableConstraint
test_oneChunk() - Method in class com.bigdata.bop.engine.TestLocalChunkMessage
Unit test for a message with a single chunk of binding sets.
test_oneChunk() - Method in class com.bigdata.bop.engine.TestLocalNativeChunkMessage
Unit test for a message with a single chunk of binding sets.
test_oneChunk() - Method in class com.bigdata.bop.fed.TestNIOChunkMessage
Unit test for a message with a single chunk of binding sets.
test_oneChunk() - Method in class com.bigdata.bop.fed.TestThickChunkMessage
Unit test for a message with a single chunk of binding sets.
test_oneChunk() - Method in class com.bigdata.btree.TestChunkedIterators
Test correct traversal when all the data fits into a single chunk.
test_oneChunkWithEmptyBindingSet() - Method in class com.bigdata.bop.engine.TestLocalChunkMessage
Unit test for a message with a single chunk containing a single empty
binding set.
test_oneChunkWithEmptyBindingSet() - Method in class com.bigdata.bop.engine.TestLocalNativeChunkMessage
Unit test for a message with a single chunk containing a single empty
binding set.
test_oneChunkWithEmptyBindingSet() - Method in class com.bigdata.bop.fed.TestThickChunkMessage
Unit test for a message with a single chunk containing a single empty
binding set.
test_oneElement() - Method in class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
Unit test with a single chunk with one element.
test_oneElement() - Method in class com.bigdata.striterator.TestDechunkerator
Unit test with a single chunk with one element.
test_onePartition() - Method in class com.bigdata.btree.TestIndexPartitionFencePosts
Tests basics with an index partition.
test_onePartition() - Method in class com.bigdata.service.TestBasicIndexStuff
Tests basics with a single scale-out index having a single partition.
test_onePrefix() - Method in class com.bigdata.btree.filter.TestPrefixFilter
Unit tests with a single prefix.
test_oneTrial_readAll_writeAll() - Method in class com.bigdata.io.TestFileChannelUtility
A single trial testing the behavior of readAll() and writeAll()
test_oneTuple() - Method in class com.bigdata.btree.AbstractBTreeCursorTestCase
test_oneTuple() - Method in class com.bigdata.btree.TestIndexSegmentCursors
test_Op() - Method in class com.bigdata.bfs.TestRandomBlockOps.TestOp
test_Op() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase.TestOp
test_Op2() - Method in class com.bigdata.bfs.TestRandomBlockOps.TestOp
test_Op2() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase.TestOp
test_open_eq_12() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
DAWG test ("find pairs that don't value-compare").
test_openIndexPartition() - Method in class com.bigdata.resources.TestResourceManagerBootstrap
test_opt_complex_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
Complex optional semantics: 1.
test_opt_complex_2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
Complex optional semantics: 2 (dawg-optional-complex-2).
test_opt_filter_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK.TCKStressTests
Optional-filter - 1
test_opt_filter_1() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTBottomUpOptimizer
Optional-filter - 1
test_optimizer() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTLiftPreFiltersOptimizer
FIXME Write the optimizer and write this test suite.
test_OPTIONAL_FILTER() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
DAWG test (FILTER inside an OPTIONAL does not block an entire solution).
test_optional_SERVICE() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
A unit test for an OPTIONAL wrapping a SERVICE.
test_optional_subSelect() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
Unit test for simple optional subquery without anything else in the outer
join group.
test_optional_with_filter() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
Unit test for an optional which is too complex to be handled as a simple
optional (it uses a filter which can not be lifted since it requires a
materialized variable).
test_optional_with_filter_that_fails() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
The FILTER will always fail.
test_optionalJoin() - Method in class com.bigdata.bop.join.TestPipelineJoin
Unit tests for optional joins.
test_optionalJoin_and_constraint() - Method in class com.bigdata.bop.join.AbstractHashJoinOpTestCase
Unit tests for optional joins, including a constraint on solutions which
join.
test_optionalJoin_withAltSink() - Method in class com.bigdata.bop.join.AbstractHashJoinOpTestCase
test_optionalJoin_withAltSink() - Method in class com.bigdata.bop.join.TestPipelineJoin
test_optionalJoin_withConstraint() - Method in class com.bigdata.bop.join.TestPipelineJoin
Unit tests for optional joins with a constraint.
test_optionals() - Method in class com.bigdata.rdf.rules.TestRuleExpansion
Test the various access paths for backchaining the property collection
normally done through owl:sameAs {2,3}.
test_optionals_emptyWhereClause() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
Test case for issue #1079.
test_optionals_pipeline() - Method in class com.bigdata.rdf.rules.TestOptionals
test_optionals_simplest() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
select *
where {
?a :knows ?b .
test_optionals_simplestWithConditional() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
select *
where {
?a :knows ?b .
test_optionals_simplestWithFilter() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
select *
where {
?a :knows ?b .
test_orderBy() - Method in class com.bigdata.rdf.rules.TestOrderBy
test_orderBy() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for ORDER BY in SELECT query.
test_orderBy_expr() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for ORDER BY in SELECT query using a value expression rather
than a bare variable (this exercises the delegation to the
ValueExprBuilder
).
test_orderBy_threadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_SortOp
Unit test for ORDER BY.
test_orderByAggregateFlatteningOptimizer_high_coverage_case_1() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTOrderByAggregateFlatteningOptimizer
Covers DESC and ASC, mixing aggregates and plain variables in ORDER BY,
multiple aggregates in ORDER BY, aggregates before plain variables in
ORDER BY, multiple projection variables.
test_orderByAggregateFlatteningOptimizer_simple_case_1() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTOrderByAggregateFlatteningOptimizer
test_orderedInsert_addressBits10() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_orderedInsert_addressBits2() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_orderedInsert_addressBits4() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_orderedInsert_addressBits8() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_ordering() - Method in class com.bigdata.rdf.internal.TestIVUnicode
IVs must be able to report their correct mutual order.
test_original_ticket() - Method in class com.bigdata.rdf.sparql.ast.eval.TestGearingQueryHint
Query in the style of the original ticket triggering this feature:
https://jira.blazegraph.com/browse/BLZG-2089
The test makes sure that the query hint is properly attached.
test_otherBound_01() - Method in class com.bigdata.rdf.rules.TestBackchainTypeResourceIterator
Test for other triple patterns (all bound, predicate bound, object bound,
etc).
test_overflow() - Method in class com.bigdata.journal.AbstractBufferStrategyTestCase
test_overflow() - Method in class com.bigdata.journal.TestTemporaryStore
test_overflow() - Method in class com.bigdata.resources.TestOverflow
test_overflowPage() - Method in class com.bigdata.htree.TestHTree
FIXME Write a unit test in which we insert duplicate tuples forcing the
overflow of a bucket page.
test_overflowPage_addressBits10() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_overflowPage_addressBits3() - Method in class com.bigdata.htree.TestHTreeWithMemStore
Stress test for handling of overflow pages.
test_OwlAxioms() - Method in class com.bigdata.rdf.axioms.TestAxioms
test_owlEquivalentClass() - Method in class com.bigdata.rdf.rules.TestRuleOwlEquivalentClass
Test where the data satisifies the rule exactly once.
test_owlEquivalentProperty() - Method in class com.bigdata.rdf.rules.TestRuleOwlEquivalentProperty
Test where the data satisifies the rule exactly once.
test_OwlHasValue() - Method in class com.bigdata.rdf.rules.TestRuleOwlHasValue
Test where the data satisifies the rule exactly once.
test_owlInverseOf1() - Method in class com.bigdata.rdf.rules.TestRuleOwlInverseOf
Test where the data satisifies the rule exactly once.
test_owlInverseOf2() - Method in class com.bigdata.rdf.rules.TestRuleOwlInverseOf
Test where the data satisifies the rule exactly once.
test_owlSameAs1() - Method in class com.bigdata.rdf.rules.TestRuleOwlSameAs
Test where the data satisifies the rule exactly once.
test_owlSameAs1b() - Method in class com.bigdata.rdf.rules.TestRuleOwlSameAs
Test where the data satisifies the rule exactly once.
test_owlSameAs2() - Method in class com.bigdata.rdf.rules.TestRuleOwlSameAs
Test where the data satisifies the rule exactly once.
test_owlSameAs3() - Method in class com.bigdata.rdf.rules.TestRuleOwlSameAs
Test where the data satisifies the rule exactly once.
test_OwlTranstitiveProperty1() - Method in class com.bigdata.rdf.rules.TestRuleOwlTransitiveProperty
Test where the data satisifies the rule exactly once.
test_packValues() - Method in class com.bigdata.rdf.internal.TestInlineLocalNameIntegerURIHandler
test_parallelRangeIterator() - Method in class com.bigdata.service.TestRangeQuery
Basic unit tests for the parallel range iterator.
test_paramHasEmptyStringValue() - Method in class com.bigdata.util.httpd.TestDecodeParams
test_parse() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDD
Test suite for parsing coordinates expressed in decimal degrees.
test_parse() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDDM
Tests of the ability to parse a decimal minutes coordinate from text.
test_parse01() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
Test parsing of coordinates represented as degrees, minutes, and seconds.
test_parse_osx_yosemite() - Method in class com.bigdata.counters.osx.TestParse_vm_stat
Mach Virtual Memory Statistics: (page size of 4096 bytes)
free active specul inactive throttle wired prgable faults copy 0fill reactive purged file-backed anonymous cmprssed cmprssor dcomprs comprs pageins pageout swapins swapouts
17656 1502912 110218 1329298 0 783121 32302 1122834K 22138464 897721K 4538117 2220029 382716 2559712 1093181 449012 1856773 4298532 67248050 263644 779970 886296
41993 1479331 110174 1329290 0 782241 33940 2115 1 1316 0 0 382671 2536124 1093181 449012 0 0 24 0 0 0
test_parser() - Method in class com.bigdata.service.TestEventParser
test_parseTenthsOfSecond() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
Test the routine that parses text containing seconds and optional tenths
of a second.
test_parsing_iostat_cpu_only() - Method in class com.bigdata.counters.osx.TestParse_iostat
Test parsing of a CPU only report from
iostat -d -C -n 0 -w 1 | cat
test_parsing_iostat_devices_plus_cpu() - Method in class com.bigdata.counters.osx.TestParse_iostat
Test parsing of the output of iostat -d -C -n 999 -w 60
test_partitionedCounter_pid0() - Method in class com.bigdata.btree.TestIndexCounter
test_partitionedCounter_pidMaxSignedInt() - Method in class com.bigdata.btree.TestIndexCounter
test_partitionedCounter_pidMinSignedInt() - Method in class com.bigdata.btree.TestIndexCounter
test_partitionedCounter_pidMinusOne() - Method in class com.bigdata.btree.TestIndexCounter
test_pathSemantics1() - Method in class com.bigdata.counters.TestCounters
Tests of path construction.
test_pattern_ddm_groups() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDDM
Test verifies the groups into which the pattern breaks the parsed text.
test_pattern_dms1_groups() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
test_perf_getBits10() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_getBits21() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_getBits47() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_getBits7() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_tstGetBits10() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_tstGetBits21() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_tstGetBits47() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_perf_tstGetBits7() - Static method in class com.bigdata.btree.TestGetBitsApplication
test_persistence() - Method in class com.bigdata.btree.TestBTreeWithBloomFilter
Simple test that the bloom filter is persisted with the btree and
reloaded from the store.
test_persistence_bloomFilterDiscarded() - Method in class com.bigdata.btree.TestBTreeWithBloomFilter
Simple test that the bloom filter is discarded if the btree is closed
without writing a checkpoint.
test_pessimistic() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
?producer bsbm:country .
test_pid_stat_collector(String) - Method in class com.bigdata.counters.linux.TestParsing
test_pid_stat_collector_extra_column() - Method in class com.bigdata.counters.linux.TestParsing
test_pid_stat_collector_valid() - Method in class com.bigdata.counters.linux.TestParsing
test_pidStat_data_parse() - Method in class com.bigdata.counters.linux.TestParsing
Test parse of the sysstat ISO date format.
test_pipelineAddRemove() - Method in class com.bigdata.quorum.TestSingletonQuorumSemantics
Unit test for write pipeline add/remove.
test_pipelineAddRemove3() - Method in class com.bigdata.quorum.TestHA3QuorumSemantics
Unit test for write pipeline add/remove, including the
PipelineState
of the downstream service as maintained by the
MockQuorumFixture.MockQuorumMember
.
test_pipelineReorganization() - Method in class com.bigdata.quorum.TestHA3QuorumSemantics
Unit tests for pipeline reorganization when the leader is elected.
test_pipelineReorganization2() - Method in class com.bigdata.quorum.TestHA3QuorumSemantics
Variations on standard pipelineReorganization to test conditions that
occasionally fail in TestHA3
test_plain_literal_ordering() - Method in class com.bigdata.bop.solutions.TestIVComparator
Unit test of order among plain literals.
test_plain_vs_languageCode_literal() - Method in class com.bigdata.rdf.lexicon.TestLexiconKeyBuilder
test_plainLiteral() - Method in class com.bigdata.rdf.lexicon.TestLexiconKeyBuilder
test_plainLiterals() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
Test round trip of some plain literals.
test_plan_m10_n10_everythingInTheRootLeaf() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=10) and (n=10) entries (everything fits into the root leaf)
test_plan_m3_n0_emptyRootLeaf() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=3) and (n=0) entries.
test_plan_m3_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=3) and (n=10) entries.
test_plan_m3_n20() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=3) and (n=20) entries.
test_plan_m4_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=4) and (n=10) entries.
test_plan_m5_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=5) and (n=10) entries.
test_plan_m6_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=6) and (n=10) entries.
test_plan_m7_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=7) and (n=10) entries.
test_plan_m8_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=8) and (n=10) entries.
test_plan_m9_n10() - Method in class com.bigdata.btree.TestIndexSegmentPlan
Tests
IndexSegmentPlan
for a tree with a branching factor of
(m=9) and (n=10) entries.
test_pool_is_null() - Method in class com.bigdata.rwstore.sector.TestMemoryManager2
Verify that pool must not be null
.
test_post_application_octet_stream_usingOutputStream() - Method in class com.bigdata.util.httpd.TestNanoHTTPD
Post with a non-empty request body using
application/octet-stream
.
test_post_application_octet_stream_usingWriter() - Method in class com.bigdata.util.httpd.TestNanoHTTPD
Post with a non-empty request body using
application/octet-stream
.
test_post_application_x_www_form_urlencoded() - Method in class com.bigdata.util.httpd.TestNanoHTTPD
Post with application/x-www-form-urlencoded
parameters in a
request body.
test_POST_DESCRIBE_N3() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
test_POST_DESCRIBE_NTRIPLES() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
test_POST_DESCRIBE_RDFXML() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
test_POST_DESCRIBE_TRIG() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
test_POST_DESCRIBE_TRIX() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
test_POST_DESCRIBE_TURTLE() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
test_post_emptyBody() - Method in class com.bigdata.util.httpd.TestNanoHTTPD
Post with an empty request body.
test_POST_INSERT_withBody_NQUADS() - Method in class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository
test_postOrderIterator() - Method in class com.bigdata.bop.util.TestBOpUtility
test_postOrderIterator01() - Method in class com.bigdata.btree.TestIterators
Test ability to visit the nodes of the tree in a post-order traversal.
test_postOrderIteratorWithAnnotations() - Method in class com.bigdata.bop.util.TestBOpUtility
test_precedence_order_1() - Method in class com.bigdata.util.httpd.TestMIMEType
This test series is based on an example in RFC 1616, section
14.1, page 63.
test_precedence_order_2() - Method in class com.bigdata.util.httpd.TestMIMEType
test_precedence_order_3() - Method in class com.bigdata.util.httpd.TestMIMEType
test_predicate_eval() - Method in class com.bigdata.bop.ap.TestPredicateAccessPath
test_predicate_list() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for a triples block using a predicate list where the predicate
is a variable.
test_predicate_list_where_predicate_is_constant() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for a triples block using a predicate list where the predicate
is a constant (this is interpreted as a property path).
test_prefixMatchLength() - Method in class com.bigdata.btree.raba.TestKeyBufferSearch
test_prefixNamespaceOverride() - Method in class com.bigdata.config.TestConfiguration
Unit test where the property override is applied at the parent level in
the namespace ("foo" vs "foo.baz").
test_prefixSearch() - Method in class com.bigdata.search.TestPrefixSearch
test_preOrderIterator() - Method in class com.bigdata.bop.util.TestBOpUtility
test_preOrderIteratorWithAnnotations() - Method in class com.bigdata.bop.util.TestBOpUtility
test_PreparedPropertiesContainNewValues() - Method in class com.bigdata.rdf.sail.webapp.TestMultiTenancyAPI
Test verifies properties were renamed correctly.
test_PreparedPropertiesNotContainOldValues() - Method in class com.bigdata.rdf.sail.webapp.TestMultiTenancyAPI
Test verifies prepared properties
do not contain old properties.
test_primitive_long() - Method in class com.bigdata.sparse.TestKeyEncodeDecode
Test for primitive data types where we can round trip the primary key
value.
test_problem2_buildOrder3() - Method in class com.bigdata.btree.TestIndexSegmentBuilderWithSmallTree
This case results in a single root leaf filled to capacity.
test_problem3_buildOrder3() - Method in class com.bigdata.btree.TestIndexSegmentBuilderWithSmallTree
Note: This problem requires us to short a node in the level above the
leaves so that the last node in that level does not underflow.
test_PropertiesBlackList() - Method in class com.bigdata.rdf.sail.webapp.TestMultiTenancyAPI
Test verifies prepared properties
do not contain blacklisted properties.
test_propertyCache() - Method in class com.bigdata.relation.locator.TestDefaultResourceLocator
Unit test for property caching for locatable resources.
test_prune_groups() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
select *
where {
?s rdf:type :Person .
test_pureAlloc() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
The pureAlloc test is to test the allocation aspect of the memory
management rather than worrying about writing the data
test_purgesHistory() - Method in class com.bigdata.service.TestEventReceiver
Pumps a bunch of events through and then verifies that the start events
are correlated with the end events and that the size of the
LinkedHashMap
is bounded by the #of incomplete events no older
than the configured eventHistoryMillis.
test_putGet() - Method in class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
Unit test for saving an empty named solution set and then reading it
back.
test_putGet2() - Method in class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
Unit test for saving a two empty solutions into a named solution set and
then reading it back.
test_putGet3() - Method in class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
Unit test for saving some non-empty solutions into a named solution set
and then reading it back.
test_putGet4() - Method in class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
Unit test for saving some non-empty solutions in multiple chunks into a
named solution set and then reading it back.
test_putIfAbsent_01() - Method in class com.bigdata.btree.TestPutIfAbsent
Basic putIfAbsent() test when delete markers are not enabled.
test_putIfAbsent_01_deleteMarkers() - Method in class com.bigdata.btree.TestPutIfAbsent
Variant test when delete markers are enabled.
test_qname_escape_01() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
PrefixName with backslash-escaped colons.
test_qname_escape_01b() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
PrefixName with backslash-escaped colon (qname in select).
test_qname_escape_02() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
PrefixName with hex-encoded colon.
test_quadStoreKeyOrders_iterator() - Method in class com.bigdata.rdf.spo.TestSPOKeyOrder
test_query() - Method in class com.bigdata.rdf.sail.TestProvenanceQuery
test_query_closeIterator() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test verifies the ability close the iterator draining a result set before
the query has finished executing and also verify that the query is
correctly terminated.
test_query_hints() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
Unit test for binding query hints.
test_query_hints_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
A simple SELECT query with some query hints.
test_query_hints_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
Unit test for correct rejection of an unknown query hint.
test_query_hints_04a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_04b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
Unit test for the query hints AST2BOpBase.Annotations#HASH_JOIN
and IPredicate.Annotations#KEY_ORDER
.
test_query_hints_05a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
Unit test for the IPredicate.Annotations#KEY_ORDER
query hint on
a pipeline join (versus a hash join).
test_query_hints_06() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_07() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_08() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_08b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_09() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_10() - Method in class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
test_query_hints_2() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
test_query_hints_3() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
Test verifies that a query hint with "group" scope is applied to the
top-level group.
test_query_hints_4() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
Test verifies that we can enable native DISTINCT, native HASH JOINS, and
MERGE JOINs using query hints.
test_query_hints_5() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
test_query_hints_6() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
test_query_join1() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test the ability run a simple join.
test_query_join1_multipleChunksIn() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test the ability run a simple join when multiple binding sets are
submitted as the initial input.
test_query_join1_without_StartOp() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test the ability run a simple join without a
StartOp
.
test_query_join2() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test the ability run a query requiring two joins.
test_query_join2() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Test the ability run a query requiring two joins.
test_query_join2_conditionalRoutingFalse() - Method in class com.bigdata.bop.engine.TestQueryEngine
test_query_join2_conditionalRoutingTrue() - Method in class com.bigdata.bop.engine.TestQueryEngine
test_query_join2_optionals() - Method in class com.bigdata.bop.controller.TestSubqueryOp
Unit test for optional join group.
test_query_join2_optionals() - Method in class com.bigdata.bop.engine.TestQueryEngine
Unit test for optional join.
test_query_join2_optionals() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Unit test for optional join.
test_query_join_1shard() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Test the ability to run a simple join reading on a single shard.
test_query_join_2shards_nothingBoundOnAccessPath() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Test the ability run a simple join which is mapped across two index
partitions.
test_query_join_2shards_nothingBoundOnAccessPath_withConstraint() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Test the ability run a simple join which is mapped across two index
partitions.
test_query_join_withConstraint() - Method in class com.bigdata.bop.engine.TestQueryEngine
test_query_optionals_filter() - Method in class com.bigdata.bop.controller.TestSubqueryOp
Unit test for optional join group with a filter.
test_query_optionals_filter2() - Method in class com.bigdata.bop.controller.TestSubqueryOp
Unit test for optional join group with a filter on a variable outside the
optional join group.
test_query_slice() - Method in class com.bigdata.bop.engine.TestQueryEngine
Run a join with a slice.
test_query_slice_noLimit() - Method in class com.bigdata.bop.engine.TestQueryEngine
Unit test runs chunks into a slice without a limit.
test_query_startRun() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test the ability to run a query which does nothing and produces no
solutions.
test_query_startRun() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Test the ability to run a query which does nothing and produces no
solutions.
test_query_startThenSlice_noJoins() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Unit test uses a
StartOp
to copy some binding sets through a
SliceOp
without involving any joins or access path reads.
test_queryJoin2_concurrentStressTest() - Method in class com.bigdata.bop.engine.TestQueryEngine
Concurrent stress test of #test_queryJoin2()
which runs a fixed
number of trials on a pool of N=10 threads.
test_queryJoin2_stressTest() - Method in class com.bigdata.bop.engine.TestQueryEngine
test_randomDenseKeys() - Method in class com.bigdata.btree.TestIndexSegmentBuilderWithLargeTrees
test_randomDenseKeys() - Method in class com.bigdata.btree.TestIndexSegmentWithBloomFilter
test_randomOnce() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
test_randomSparseKeys() - Method in class com.bigdata.btree.TestIndexSegmentBuilderWithLargeTrees
test_randomSparseKeys() - Method in class com.bigdata.btree.TestIndexSegmentWithBloomFilter
test_randomURIs() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
Test using a sequence of random URIs (formed with successive prefixes).
test_rangeCheck() - Method in class com.bigdata.io.TestFixedByteArrayBuffer
test_rangeCount_staticPartitions_01() - Method in class com.bigdata.service.TestRangeQuery
Range count tests with two (2) static partitions where the successor of a
key is found in the next partition (tests the fence post for the mapping
of the rangeCount operation over the different partitions).
test_rangeCounts_toldBNodes() - Method in class com.bigdata.rdf.store.TestTripleStore
test_rangeDelete() - Method in class com.bigdata.bfs.TestRangeDelete
test_rangeIterator() - Method in class com.bigdata.btree.view.TestFusedView
Test verifies some of the basic principles of the fused view, including
that a deleted entry in the first source will mask an undeleted entry in
a secondary source.
test_rangeQuery_staticPartitions_unbounded_1entry_2partitions_01() - Method in class com.bigdata.service.TestRangeQuery
Test unbounded range query with one entry in the index and two index
partitions.
test_rangeQuery_staticPartitions_unbounded_1entry_2partitions_02() - Method in class com.bigdata.service.TestRangeQuery
Test unbounded range query with one entry in the index and two index
partitions.
test_rangeQuery_staticPartitions_unbounded_2entries_2partitions_01() - Method in class com.bigdata.service.TestRangeQuery
Test unbounded range query with two entries in the index and two index
partitions.
test_rangeQuery_staticPartitions_unbounded_2entries_2partitions_02() - Method in class com.bigdata.service.TestRangeQuery
Test unbounded range query with two entries in the index and two index
partitions.
test_rangeQuery_staticPartitions_unbounded_emptyIndex_2partitions() - Method in class com.bigdata.service.TestRangeQuery
Test unbounded range query with an empty index and two partitions.
test_rangeScan() - Method in class com.bigdata.bfs.TestRangeScan
test_rdf01() - Method in class com.bigdata.rdf.rules.TestRuleRdf01
Basic test of rule semantics.
test_rdf01_distinctPrefixScan() - Method in class com.bigdata.rdf.rules.TestRuleRdf01
Test that can be used to verify that we are doing an efficient scan for
the distinct predicates (distinct key prefix scan).
test_rdf_collections_01() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for the RDF Collections syntax (from SPARQL 1.1 Last Call
Working Draft).
test_rdf_collections_02() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for the RDF Collections syntax (from SPARQL 1.1 Last Call
Working Draft).
test_rdf_collections_03() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for the RDF Collections syntax.
test_rdf_collections_04() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
PREFIX :
SELECT ?p ?v { :x ?p (?v) .
test_rdf_collections_05() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
PREFIX :
SELECT ?p ?v ?w { :x ?p (?v ?w) .
test_rdfs07_01() - Method in class com.bigdata.rdf.rules.TestRuleRdfs07
Test of
RuleRdfs07
where the data satisifies the rule exactly
once.
test_rdfs07_02() - Method in class com.bigdata.rdf.rules.TestRuleRdfs07
Test of
RuleRdfs07
where the data satisifies the rule twice --
there are two matches in the subquery for the same binding on "?a".
test_rdfs07_03() - Method in class com.bigdata.rdf.rules.TestRuleRdfs07
Test of
RuleRdfs07
where the data satisifies the rule twice --
there are two matches on the first triple pattern that have the same
subject.
test_rdfs10_01() - Method in class com.bigdata.rdf.rules.TestRuleRdfs10
Test of
RuleRdfs10
where the data satisifies the rule exactly
once.
test_rdfs10_02() - Method in class com.bigdata.rdf.rules.TestRuleRdfs10
Test of
RuleRdfs10
where the data satisifies the rule exactly
twice.
test_rdfs11() - Method in class com.bigdata.rdf.rules.TestRuleRdfs11
Simple test verifies inference of a subclassof entailment.
test_rdfs3_01() - Method in class com.bigdata.rdf.rules.TestRuleRdfs03
test_rdfs3_filterLiterals() - Method in class com.bigdata.rdf.rules.TestRuleRdfs03
Literals may not appear in the subject position, but an rdfs4b entailment
can put them there unless you explicitly filter it out.
test_rdfs4a() - Method in class com.bigdata.rdf.rules.TestRuleRdfs04
Test of the basic semantics.
test_rdfs4b() - Method in class com.bigdata.rdf.rules.TestRuleRdfs04
Test of the basic semantics.
test_rdfs4b_filterLiterals() - Method in class com.bigdata.rdf.rules.TestRuleRdfs04
Literals may not appear in the subject position, but an rdfs4b entailment
can put them there unless you explicitly filter it out.
test_RdfsAxioms() - Method in class com.bigdata.rdf.axioms.TestAxioms
test_RdfsVocabulary() - Method in class com.bigdata.rdf.lexicon.TestVocabulary
test_read() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
test_read_correctRejection() - Method in class com.bigdata.sparse.TestSparseRowStore
Test of correct rejection of illegal parameters for logical row read
operations.
test_read_correctRejection_0L() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
A read with a 0L address is always an error.
test_read_correctRejection_zeroLength() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
A delete with an address encoding a zero length component is an error
(the address is ill-formed since we do not allow writes of zero length
records).
test_read_noSuchRow() - Method in class com.bigdata.sparse.TestSparseRowStore
Test that a read for a row that does not exist returns null
.
test_readAll_writeAll() - Method in class com.bigdata.io.TestFileChannelUtility
A sequence of trials testing the behavior of readAll() and writeAll().
test_readCommitted() - Method in class com.bigdata.journal.TestReadCommittedTx
test_readImmutable() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Test verifies that read does not permit changes to the store state by
modifying the returned buffer.
test_readIsolation() - Method in class com.bigdata.journal.TestTx
Create a journal, setup an index, write an entry on that index, and
commit the store.
test_readOnly() - Method in class com.bigdata.journal.TestReadOnlyTx
test_readOnlyTx() - Method in class com.bigdata.journal.TestTx
Unit test written to verify that a read-only tx gets the same view of an
index when it has the same ground state as another read-only tx.
test_readPastLimit() - Method in class com.bigdata.io.TestByteArrayBuffer
Test of reading past the limit on the buffer.
test_readPastLimit2() - Method in class com.bigdata.io.TestByteArrayBuffer
test_readWrite() - Method in class com.bigdata.sparse.TestSparseRowStore
Simple test of write and read back of logical rows.
test_reallocate() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Reallocates the same object several times, then commits and tests
read back.
test_reallocation() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Reallocation tests the freeing of allocated address and the re-use
within a transaction.
test_reallocationWithReadAndReopen() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_realMetersLongitude() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateUtility
Cross check for meters per unit of longitude at some known latitudes on
Earth.
test_rebuildIndex() - Method in class com.bigdata.rdf.lexicon.TestFullTextIndex
Unit test for LexiconRelation#rebuildTextIndex()
.
test_rebuildTextIndex() - Method in class com.bigdata.rdf.sail.webapp.TestRebuildTextIndex
Test force create full text index.
test_receiveBuffer() - Method in class com.bigdata.service.TestReceiveBuffer
test_receiveBuffer_stress() - Method in class com.bigdata.service.TestReceiveBuffer
Stress test for concurrent receive of buffers.
test_receiveFile() - Method in class com.bigdata.service.TestReceiveFile
Test the ability to receive a file.
test_recordCompressor01() - Method in class com.bigdata.io.compression.AbstractRecordCompressorTestCase
Test ability to compress and decompress data.
test_recordCompressor02() - Method in class com.bigdata.io.compression.AbstractRecordCompressorTestCase
Test ability to compress and decompress data using a de-serialized
compression provider.
test_recordCompressor03() - Method in class com.bigdata.io.compression.AbstractRecordCompressorTestCase
Test ability to compress and decompress zero-length data.
test_recordCompressor_stressTest() - Method in class com.bigdata.io.compression.AbstractRecordCompressorTestCase
Stress test ability to compress and decompress data.
test_recoverCommitRecord() - Method in class com.bigdata.journal.TestCommitHistory
test_recoverCommitRecordNoHistory() - Method in class com.bigdata.journal.TestCommitHistory
test_recyclingIndices() - Method in class com.bigdata.concurrent.TestTxDag
Verify that we can recycle the internal transaction identifiers when a
transaction is removed from the DAG (either through abort or commit
actions).
test_redirectStressTest() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTaskWithRedirect
Stress test for redirects.
test_redirectStressTestWithSplits() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTaskWithSplits
Stress test for redirects.
test_reduceFunctionToConstant() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSetValueExpressionOptimizer
Given
test_redundant_filter() - Method in class com.bigdata.rdf.sparql.ast.eval.TestFilters
Test correct behavior of redundant filters (fix of issue #972)
test_redundantFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTAttachJoinFiltersOptimizer
Assert proper handling of redundant (identical) filter expressions.
test_regex_lat() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
Test of the regular expression used to match a multipart latitude.
test_regex_long() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
Test of the regular expression used to match a multipart longitude.
test_regionEnum_encodeDecode() - Method in class com.bigdata.btree.TestIndexSegmentAddressManager
Test encoding and decoding of the region code and the offset.
test_register1ThenOverflow() - Method in class com.bigdata.service.TestOverflow
Sets the forceOverflow flag and then registers a scale-out index.
test_registerAndUseBTree() - Method in class com.bigdata.journal.TestNamedIndices
Test the ability to register and use named
BTree
, including
whether the named
BTree
is restart safe.
test_registerAndUseBTree() - Method in class com.bigdata.journal.TestTemporaryStore
Test the ability to register and use named
BTree
, including
whether the named
BTree
is restart safe.
test_registerAndUseHTree() - Method in class com.bigdata.journal.TestNamedIndices
Test the ability to register and use named
HTree
, including
whether the named
HTree
is restart safe.
test_registerAndUseHTree() - Method in class com.bigdata.journal.TestTemporaryStore
Test the ability to register and use named
HTree
, including
whether the named
HTree
is restart safe.
test_registerIndex() - Method in class com.bigdata.service.TestEmbeddedClient
Test ability to register a scale-out index, access it, and then drop the
index.
test_reificationDoneRight_00() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Bootstrap test.
test_reificationDoneRight_00_loadDataFromFile() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Version of the above where the data are read from a file rather than being
built up by hand.
test_reificationDoneRight_00a() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Bootstrap test.
test_reificationDoneRight_00a_loadFromFile() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Version of the above where the data are read from a file rather than being
built up by hand.
test_reificationDoneRight_01() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Simple query involving alice, bob, and an information extractor.
test_reificationDoneRight_01_usingRDRData() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Simple query involving alice, bob, and an information extractor.
test_reificationDoneRight_01a() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Same data, but the query uses the BIND() syntax and pulls out some more
information.
test_reificationDoneRight_01a_usingRDRData() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Same data, but the query uses the BIND() syntax and pulls out some more
information and RDR syntax for the data.
test_reificationDoneRight_02() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Simple query ("who bought sybase").
test_reificationDoneRight_02_usingRDRData() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Simple query ("who bought sybase") using RDR syntax for the data.
test_reificationDoneRight_02a() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Same data, but the query uses the BIND() syntax and pulls out some more
information.
test_reificationDoneRight_02a_usingRDRData() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Same data, but the query uses the BIND() syntax and pulls out some more
information and RDR syntax for the data.
test_reificationDoneRight_03() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
prefix :
SELECT ?a {
BIND( <> AS ?ignored )
}
test_reificationDoneRight_03a() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
prefix :
SELECT ?a ?e {
BIND( <> AS ?sid ) .
test_reificationDoneRight_04() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
test_reificationDoneRight_05a() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Test loading of RDR triples from file ttl file containing standard
reification that contains three unordered reified triples, with query
specified in Standard RDF Reification.
test_reificationDoneRight_05b() - Method in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Test loading of RDR triples from file ttl file containing standard
reification that contains three unordered reified triples, with query
specified in RDR.
test_reificationDoneRight_disabled() - Method in class com.bigdata.rdf.rio.TestStatementBuffer
A unit test in which the translation of reified statements into inline
statements disabled.
test_reificationDoneRight_enabled() - Method in class com.bigdata.rdf.rio.TestStatementBuffer
Unit test verifies that triples which look like part of a reified model
of a statement are collected and then reported using SIDs.
test_rejectNegatives() - Method in class com.bigdata.io.ShortPackerTestCase
test_rejectNegatives() - Method in class com.bigdata.io.TestShortPacker
test_remoteAccessPath_readsOnBothPartitions() - Method in class com.bigdata.bop.fed.TestRemoteAccessPath
test_remoteAccessPath_readsOnPartition0() - Method in class com.bigdata.bop.fed.TestRemoteAccessPath
test_remoteAccessPath_readsOnPartition1() - Method in class com.bigdata.bop.fed.TestRemoteAccessPath
test_remove() - Method in class com.bigdata.btree.view.TestFusedView
test_remove_not_allowed() - Method in class com.bigdata.btree.TestReadOnlyBTreeCursors
test_removeAll() - Method in class com.bigdata.btree.filter.TestTupleFilters
test_removeAll() - Method in class com.bigdata.btree.TestBTreeWithBloomFilter
test_removeAll() - Method in class com.bigdata.btree.TestChunkedIterators
test_removeAll() - Method in class com.bigdata.btree.TestRemoveAll
test_removeAll() - Method in class com.bigdata.btree.view.TestFusedView
test_removeAll() - Method in class com.bigdata.service.TestRangeQuery
test_removeAll_02() - Method in class com.bigdata.btree.TestRemoveAll
test_removeAll_filter() - Method in class com.bigdata.btree.view.TestFusedView
Test of
IRangeQuery.REMOVEALL
with a filter verifies that only
those tuples which satisify the filter are visited and removed.
test_removeAll_limit1() - Method in class com.bigdata.btree.TestChunkedIterators
test_removeAll_limit1_twoPartitions() - Method in class com.bigdata.service.TestRangeQuery
test_removeAll_rawRecords() - Method in class com.bigdata.btree.TestRemoveAll
Unit test for
BTree.removeAll()
which verifies that the tuples
are actually deleted one-by-one and the backing raw records released if
the index supports raw records.
test_removeAll_rootLeaf() - Method in class com.bigdata.btree.TestDeleteMarkers
Test verifies that
BTree.removeAll()
causes deletion markers to
be written for each undeleted entry in the B+Tree.
test_removeAll_with_TupleFilter() - Method in class com.bigdata.btree.filter.TestTupleFilters
test_removeAllRWStore() - Method in class com.bigdata.rwstore.TestRWJournal
Unit tests for optimization when using the
RWStore
but not using
delete markers.
test_removeNotAllowed() - Method in class com.bigdata.btree.TestDeleteMarkers
Test that BTree#remove(byte[],ITuple)
is disabled when delete
markers are enabled.
test_removeOrder3a() - Method in class com.bigdata.btree.TestSplitJoinThreeLevels
Test ability to split and join a tree of order m == 3 driven by the
insertion and then the removal of a known sequence of keys.
test_removeOrder3b() - Method in class com.bigdata.btree.TestSplitJoinThreeLevels
test_removeOrder3c() - Method in class com.bigdata.btree.TestSplitJoinThreeLevels
test_removeStatements() - Method in class com.bigdata.rdf.store.TestTripleStore
Test of
IRawTripleStore#removeStatements(com.bigdata.relation.accesspath.IChunkedOrderedIterator)
test_reopen01() - Method in class com.bigdata.btree.TestReopen
Test close on a new tree - should force the root to the store since a new
root is dirty (if empty).
test_reopen01() - Method in class com.bigdata.htree.TestReopen
Test close on a new tree - should force the root to the store since a new
root is dirty (if empty).
test_reopen02() - Method in class com.bigdata.btree.TestReopen
Test with a btree containing both branch nodes and leaves.
test_reopen02() - Method in class com.bigdata.htree.TestReopen
Test with a btree containing both branch nodes and leaves.
test_reopen03() - Method in class com.bigdata.btree.TestReopen
Stress test comparison with ground truth btree when
AbstractBTree.close()
is randomly invoked during mutation operations.
test_reopen03() - Method in class com.bigdata.htree.TestReopen
Stress test comparison with ground truth htree when
AbstractHTree.close()
is randomly invoked during mutation operations.
test_reopenAfterInterrupt() - Method in class com.bigdata.journal.AbstractInterruptsTestCase
test_reopenAfterInterrupt_checkWriteBuffer() - Method in class com.bigdata.journal.AbstractInterruptsTestCase
test_reopenPseudoRandom() - Method in class com.bigdata.htree.TestReopen
test_reopenReset() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Tests semantics of a simple reset after reopen to emulate
an HAJournal reopen
As for simple reset but also re-open, then write and abort.
test_reportMutation() - Method in class com.bigdata.rdf.store.TestIsModified
test_requiredJoins() - Method in class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup
A test based loosely on LUBM Q2.
test_requiredVars() - Method in class com.bigdata.relation.rule.eval.TestRuleState
test_reset() - Method in class com.bigdata.io.TestDataOutputBuffer
Test ability to reset the key buffer (simply zeros the #of valid bytes in
the buffer without touching the buffer itself).
TEST_RESOURCE_PATH - Static variable in class com.bigdata.rdf.sail.webapp.TestFederatedQuery
TEST_RESOURCE_PREFIX - Static variable in class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
Test_REST_ASK<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
Test_REST_ASK() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ASK
Test_REST_ASK(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ASK
Test_REST_DELETE_BY_ACCESS_PATH<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for the DELETE_BY_ACCESS_PATH method.
Test_REST_DELETE_BY_ACCESS_PATH() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_DELETE_BY_ACCESS_PATH
Test_REST_DELETE_BY_ACCESS_PATH(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_DELETE_BY_ACCESS_PATH
Test_REST_DELETE_WITH_BODY<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
Test_REST_DELETE_WITH_BODY() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_DELETE_WITH_BODY
Test_REST_DELETE_WITH_BODY(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_DELETE_WITH_BODY
Test_REST_DESCRIBE<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
Test_REST_DESCRIBE() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
Test_REST_DESCRIBE(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_DESCRIBE
Test_REST_ESTCARD<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
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()).
Test_REST_ESTCARD() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ESTCARD
Test_REST_ESTCARD(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ESTCARD
Test_REST_ESTCARD.ReadWriteTx<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Test_REST_ESTCARD.ReadWriteTx() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ESTCARD.ReadWriteTx
Test_REST_HASSTMT<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for the HASSTMT
REST API method.
Test_REST_HASSTMT() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_HASSTMT
Test_REST_HASSTMT(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_HASSTMT
Test_REST_HASSTMT.ReadWriteTx<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
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).
Test_REST_HASSTMT.ReadWriteTx() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_HASSTMT.ReadWriteTx
Test_REST_HASSTMT.TruthMaintenance<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Test suite for the semantics of includeInferred (this requires setting up
a namespace with truth maintenance).
Test_REST_HASSTMT.TruthMaintenance() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_HASSTMT.TruthMaintenance
Test_REST_ServiceDescription<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
Test_REST_ServiceDescription() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ServiceDescription
Test_REST_ServiceDescription(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_ServiceDescription
Test_REST_Structure<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for bootstrap and basic structure tests for the REST API.
Test_REST_Structure() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_Structure
Test_REST_Structure(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_Structure
Test_REST_TX_API<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for testing the transaction management API.
Test_REST_TX_API() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_TX_API
Test_REST_TX_API(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_TX_API
Test_REST_TX_API.NoReadWriteTx<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
An *extension* of the test suite that uses a namespace that is NOT
configured to support read/write transactions.
Test_REST_TX_API.NoReadWriteTx() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_TX_API.NoReadWriteTx
Test_REST_TX_API.NoReadWriteTx(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_TX_API.NoReadWriteTx
Test_REST_TX_API.ReadWriteTx<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
An *extension* of the test suite that uses a namespace that is configured
to support read/write transactions.
Test_REST_TX_API.ReadWriteTx() - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_TX_API.ReadWriteTx
Test_REST_TX_API.ReadWriteTx(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_REST_TX_API.ReadWriteTx
test_restart() - Method in class com.bigdata.rdf.sail.TestSearchQuery
Unit test used to track down a commit problem.
test_restartSafe() - Method in class com.bigdata.rdf.store.TestRestartSafe
test_restartSafe() - Method in class com.bigdata.service.TestRestartSafe
Test creates a new embedded federation (this is done in setUp() by the
super class), registers a scale-out index with the metadata service
having an index partition on each of the data services and then writes
some data such that there is data for that scale-out index on each of the
data services.
test_restartSafe01() - Method in class com.bigdata.journal.TestRestartSafe
test_restartSafe_multipleWrites() - Method in class com.bigdata.journal.AbstractRestartSafeTestCase
Test writes a bunch of records and verifies that each can be read after
it is written.
test_restartSafe_offsetBits() - Method in class com.bigdata.journal.TestRestartSafe
Test verifies that the journal can be correctly reopened when using a
non-default value for offsetBits
.
test_restartSafe_oneWrite() - Method in class com.bigdata.journal.AbstractRestartSafeTestCase
Writes a record, verifies the write then commits the store.
test_restartSafe_oneWriteNoCommit() - Method in class com.bigdata.journal.AbstractRestartSafeTestCase
Writes a record, verifies the write but does NOT commit the store.
test_restartSafeCounter() - Method in class com.bigdata.journal.TestRestartSafe
Test verifies that the
ICounter
is restart-safe.
test_restartSafeSubclass() - Method in class com.bigdata.journal.TestRestartSafe
test_restartWithIndexSegments() - Method in class com.bigdata.resources.TestResourceManagerBootstrap
test_restartWithTwoJournals() - Method in class com.bigdata.resources.TestResourceManagerBootstrap
test_retractAll_01() - Method in class com.bigdata.rdf.rules.TestTruthMaintenance
A simple test of
TruthMaintenance
in which some statements are
asserted, their closure is computed and aspects of that closure are
verified, and then an explicit statement is removed and the closure is
updated and we verify that an entailment known to depend on the remove
statement has also been removed (this is based on rdfs11).
test_retractionOfStatementsAboutStatements() - Method in class com.bigdata.rdf.store.TestStatementIdentifiers
Test creates a statement (a) and then a statement (b) about statement (a)
using the statement identifier for (a) and then retracts (a) and verifies
that (b) is also retracted.
test_retractionOfStatementsAboutStatements2() - Method in class com.bigdata.rdf.store.TestStatementIdentifiers
Test creates a statement (a), a statement (b) about statement (a), and a
statement (c) about statement (b) and then retracts (a) and verifies that
both (b) and (c) are also retracted.
test_retractWhenStatementSupportsExplicitStatement() - Method in class com.bigdata.rdf.rules.TestTruthMaintenance
Given three explicit statements:
test_reverse_traversal() - Method in class com.bigdata.btree.filter.TestReverserator
test_reverse_with_branching_factor() - Method in class com.bigdata.btree.filter.TestReverserator
Stress test written in an attempt to find a spin lock in the reverse
cursor traversal.
test_reverseReference_allowed_aka_select_dependency() - Method in class com.bigdata.bop.solutions.TestGroupByState
Verify that a reference to a variable defined by a previous select
expression is allowed and that the select dependency is recognized.
test_reverseReference_allowed_aka_select_dependency() - Method in class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
Verify that a reference to a variable defined by a previous select
expression is allowed and that the select dependency is recognized.
test_reverseScan() - Method in class com.bigdata.btree.TestBTreeLeafCursors
test_reverseScan() - Method in class com.bigdata.btree.TestChunkedIterators
Test progression of a chunked iterator scan in reverse order.
test_reverseScan() - Method in class com.bigdata.btree.view.TestFusedView
This tests the ability to traverse the tuples in the
FusedView
in
reverse order.
test_reverseScan() - Method in class com.bigdata.service.TestRangeQuery
Test the ability to scan a partitioned index in forward and reverse
order.
test_reverseTraversal() - Method in class com.bigdata.btree.AbstractBTreeCursorTestCase
test_rewrite1() - Method in class com.bigdata.rdf.rules.TestTMUtility
Test mapping of a rule with a single predicate in the tail across two
relations for truth maintenance.
test_rewrite2() - Method in class com.bigdata.rdf.rules.TestTMUtility
Test mapping of a rule with a two predicates in the tail across two
relations for truth maintenance.
test_rewrite_lift_bare_aggregate_expression() - Method in class com.bigdata.bop.solutions.TestGroupByRewriter
test_rewriteComplexOptional() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTComplexOptionalOptimizer
This unit test is a based on
bigdata-perf/CI/govtrack/queries/query10.rq
test_rollback() - Method in class com.bigdata.journal.TestAbort
test_rollback() - Method in class com.bigdata.journal.TestRollbackCommit
Deprecated.
test_rootLeaf() - Method in class com.bigdata.btree.TestIndexSegmentWithBloomFilter
Test when the input tree is a root leaf with three values.
test_roundMinutes() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
test_roundRobin_2DataServices() - Method in class com.bigdata.service.TestLoadBalancerRoundRobin
Test when minCount=maxCount=1 and there are N=2 data services to verify
correct round robin assignment.
test_roundRobin_NDataServices() - Method in class com.bigdata.service.TestLoadBalancerRoundRobin
Test when minCount=maxCount=1 and there are N GT 2 data services to
verify correct round robin assignment.
test_roundSeconds() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
test_roundTrip() - Method in class com.bigdata.btree.keys.TestICUVersionRecord
test_roundTrip() - Method in class com.bigdata.ha.msg.TestHASendState
test_roundTrip01() - Method in class com.bigdata.sparse.TestTPS
Tests a series of bindings for one property.
test_roundTrip02() - Method in class com.bigdata.sparse.TestTPS
Tests a series of bindings for one property where each binding of the
property uses a different
ValueType
.
test_roundTrip2() - Method in class com.bigdata.btree.keys.TestICUVersionRecord
test_roundTrip_BNode() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_roundTrip_langCodeLiterals() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_roundTrip_plainLiteral() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_roundTrip_URI() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_roundTrip_veryLargeLiteral() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_roundTrip_xsd_int() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_roundTrip_xsd_string() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
test_rowScan() - Method in class com.bigdata.sparse.TestSparseRowStore
Test of a logical row scan.
test_rowScan_continuationQuery_fixedLengthPrimaryKey() - Method in class com.bigdata.sparse.TestSparseRowStore
Test of a logical row scan requiring continuation queries by forcing the
capacity to 1 when there are in fact two logical rows.
test_rowScan_continuationQuery_variableLengthPrimaryKey() - Method in class com.bigdata.sparse.TestSparseRowStore
Test of a logical row scan requiring continuation queries by forcing the
capacity to 1 when there are in fact two logical rows.
test_rowScan_withKeyRange() - Method in class com.bigdata.sparse.TestSparseRowStore
Test of a logical row scan using a key range limit.
test_rule() - Method in class com.bigdata.rdf.rules.TestRuleFastClosure_3_5_6_7_9
Unit test of
RuleFastClosure6
where the data allow the rule to
fire exactly twice, once where the predicate is
rdfs:Range
and once where the predicate is an
rdfs:subPropertyOf
rdfs:Range
, and tests
that the rule correctly filters out a possible entailment that would
simply conclude its own support.
test_Rule() - Method in class com.bigdata.rdf.rules.TestRuleOwlSymmetricProperty
test_ruleBindings() - Method in class com.bigdata.relation.rule.TestRule
Verify variable binding stuff for a rule.
test_RuleFastForwardClosure11() - Method in class com.bigdata.rdf.rules.TestRuleFastClosure_11_13
Tests
RuleFastClosure11
with the minimum data required to compute
a single entailment.
test_RuleFastForwardClosure13() - Method in class com.bigdata.rdf.rules.TestRuleFastClosure_11_13
Tests
RuleFastClosure13
with the minimum data required to compute
a single entailment.
test_RuleOwlFunctionalProperty() - Method in class com.bigdata.rdf.rules.TestRuleOwlFunctionalProperty
test_RuleOwlInverseFunctionalProperty() - Method in class com.bigdata.rdf.rules.TestRuleOwlFunctionalProperty
test_ruleState() - Method in class com.bigdata.rdf.spo.TestSPORelation
test_run1() - Method in class com.bigdata.concurrent.TestNonBlockingLockManager
Test ability to run a
Callable
on the service, get() the result,
and then shutdown the service.
test_run1() - Method in class com.bigdata.quorum.TestMockQuorumFixture
A simple quorum run.
test_run1WithLock() - Method in class com.bigdata.concurrent.TestNonBlockingLockManager
Test ability to obtain a lock, run a
Callable
on the service,
get() the result, and then shutdown the service.
test_runFirst() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTRunFirstRunLastOptimizer
Given:
test_runFirst2() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTRunFirstRunLastOptimizer
Unit test with non-SP joins.
test_runFirstRunLast_01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_runFirstRunLast_02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_runOne() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test ability to run a
Callable
on the service, get() the result,
and then shutdown the service.
test_runOneThrowsException() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test ability to run a
Callable
on the service which throws an
exception, get() the result, and then shutdown the service.
test_runOneWithLock() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test ability to obtain a lock, run a
Callable
on the service,
get() the result, and then shutdown the service.
test_runOneWithLockAndReleaseLockFromTask() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test ability to obtain a lock, run a
Callable
on the service that
releases its locks during its computation, verify that the locks were
released, get() the result, and then shutdown the service.
test_runRule() - Method in class com.bigdata.rdf.spo.TestSPORelation
A simple test of rule execution, including query against an empty kb,
insert of some elements into the kb, query to verify that the data is in
the kb, insert driven by a rule set, and query to verify that insert.
test_runScanner() - Method in class com.bigdata.service.ndx.pipeline.TestFileSystemScanner
test_runSingleOperatorQuery() - Method in class com.bigdata.bop.engine.TestRunState
Very simple unit test for the RunState
API.
test_runTwoOperatorQuery() - Method in class com.bigdata.bop.engine.TestRunState
Run a two operator query where the first operator produces a single
output message and the second operator consumes that message.
test_sameIndexObject() - Method in class com.bigdata.journal.TestTx
Test verifies that you always get the same object back when you ask for
an isolated named index.
test_sameVariableConstraint_quads() - Method in class com.bigdata.rdf.spo.TestSPOAccessPath
Unit test for predicate patterns in which the same variable appears in
more than one position of a quad pattern.
test_sameVariableConstraint_triples() - Method in class com.bigdata.rdf.spo.TestSPOAccessPath
Unit test for predicate patterns in which the same variable appears in
more than one position of a triple pattern.
test_sample() - Method in class com.bigdata.bop.rdf.aggregate.TestSAMPLE
test_sample_with_complex_inner_value_expression() - Method in class com.bigdata.bop.rdf.aggregate.TestSAMPLE
test_sample_with_null() - Method in class com.bigdata.bop.rdf.aggregate.TestSAMPLE
test_scan() - Method in class com.bigdata.bop.ap.TestPredicateAccessPath
Using a predicate which binds the [name] position, verify that we get the
right range count on the relation and verify the actual element pulled
back from the access path.
test_scatterSplit() - Method in class com.bigdata.service.TestScatterSplit
Test writes on a scale-out index until it has enough data to undergo a
scatter split, validates that the index was distributed into N shards per
DS and validates the scale-out index after the scatter split against
ground truth.
test_Schedule01() - Method in class com.bigdata.btree.isolation.TestAccount
test_schema_change_complex() - Method in class com.bigdata.rdf.internal.encoder.TestIVBindingSetEncoder
https://jira.blazegraph.com/browse/BLZG-4476:
Assert that encoding does not change when schema changes incrementally
test_schema_change_simple() - Method in class com.bigdata.rdf.internal.encoder.TestIVBindingSetEncoder
https://jira.blazegraph.com/browse/BLZG-4476:
Assert that encoding does not change when schema changes incrementally
test_search01() - Method in class com.bigdata.btree.raba.TestKeyBufferSearch
Test search for keys using both a mutable and an immutable key buffer and
a known set of keys.
test_search02() - Method in class com.bigdata.btree.raba.TestKeyBufferSearch
Tests with non-zero offset into a key buffer with a shared prefix
of 3 bytes.
test_search03() - Method in class com.bigdata.btree.raba.TestKeyBufferSearch
Test with prefixLength of zero and various search keys.
test_search04() - Method in class com.bigdata.btree.raba.TestKeyBufferSearch
Test search on empty key buffer.
test_search_1() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
A simple full text search query.
test_search_2() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
A full text search query based on the in-depth example in the full
text index core package ("child proofing" example).
test_search_3() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
An example with an additional join in the named query and a join in the
main query as well.
test_search_main_where_clause() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test for a query with magic search predicates in the main WHERE
clause.
test_search_match_all_terms() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test for a search where all tokens in the query must match.
test_search_min_relevance() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test with explicit BD#MIN_RELEVANCE
of zero and a prefix
match search.
test_search_named_graphs1() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test with named graphs (quads) using graph graph pattern and a
subject join in the named subquery.
test_search_named_graphs10a() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Run the query with no graphs specified.
test_search_named_graphs10b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Run the query with graphA specified as the default graph.
test_search_named_graphs10c() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Run the query with graphB specified as the default graph
test_search_named_graphs10d() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Run the query with graphB specified as the default graph and also pull
out the subject from the search variable.
test_search_named_graphs10e() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Run the query with graphA specified as the default graph and also pull
out the subject from the search variable.
test_search_named_graphs2() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Variant of the test above in which the graph variable is bound to the
graph in which the search result is visible.
test_search_named_graphs3() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Variant of the test above in which the graph variable is bound to a graph
in which the search result is not visible.
test_search_named_graphs4() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Variant of the test above in there are search results in more than one
graph.
test_search_named_graphs5() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test with named graphs (quads) using a graph graph pattern but not
having a subject join in the named subquery.
test_search_not_supported() - Method in class com.bigdata.htree.raba.TestMutableKeyBuffer
test_search_not_supported() - Method in class com.bigdata.htree.raba.TestMutableValueBuffer
test_search_prefix_match() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test for a prefix match ("mi*").
test_search_prefix_match2() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Unit test for a prefix match ("mi*").
test_search_query() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
Ported from TestNamedGraphs in the sails package.
test_search_service_1() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
A simple full text search query (variant of the above using the
SPARQL 1.1
SERVICE syntax).
test_searchServiceOptimizer_01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFulltextSearchOptimizer
Test rewriting of
FTS
magiv predicates into SERVICE node.
test_searchServiceOptimizer_01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSearchOptimizer
Given
test_second_property_path() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTwoPropertyPaths734
test_second_using_workaround_property_path() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTwoPropertyPaths734
test_seek() - Method in class com.bigdata.btree.TestBTreeLeafCursors
test_select_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBasicQuery
A SELECT query consisting of a single statement pattern.
test_select_2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBasicQuery
A simple SELECT query.
test_SELECT_ALL() - Method in class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository
Select everything in the kb using a GET.
test_select_bind() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
Simple variable rename in select expression.
test_select_bnode() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
Unit test with BNode.
test_select_coalesce() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (coalesce(?s,?p,?o) as ?x) where {?s ?p ?o}
test_select_compare_expr() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
Select using comparison expression.
test_select_count_distinct_foo() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (COUNT(DISTINCT ?s) as ?x) where {?s ?p ?o}
test_select_count_distinct_star() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (COUNT(DISTINT *) as ?x) where {?s ?p ?o}
test_select_count_foo() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (COUNT(?s) as ?x) where {?s ?p ?o}
test_select_count_star() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (COUNT(*) as ?x) where {?s ?p ?o}
test_select_distinct() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for SELECT DISTINCT
test_select_foo_IN_bar() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
IN with a non-empty arg list
test_select_foo_IN_none() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
IN with empty arg list
test_select_function_call() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (FunctionCall(?s) as ?x) where {?s ?p ?o}
test_select_if_then_else() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (if(?s,?p,?o) as ?x) where {?s ?p ?o}
test_select_literal() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
Simple unit test for a value expression which is a plain literal.
test_select_math_expr() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT using math expression.
test_select_reduced() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for SELECT REDUCED
test_select_regex() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (regex(?o, "^ali") as ?x) where {?s ?p ?o}
test_select_regex_flags() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
SELECT (regex(?o, "^ali", "i") as ?x) where {?s ?p ?o}
test_select_s_where_s_p_o() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for simple SELECT query
test_select_star() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for SELECT query with a wildcard (*
).
test_select_star_select_star_s_p_o() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
SELECT * { SELECT * { ?s ?p ?o } }
test_select_uri() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
Simple unit test for a value expression which is a URI.
test_select_xsd_int() - Method in class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
Simple unit test for a value expression which is a xsd:int
.
test_selfTransitionOk() - Method in class com.bigdata.journal.TestRunState
Verify that a NOP state change is allowed (this is used when there are
multiple committers for a distributed transaction since (as a
convenience) more than one may instruct us to make the same state
change).
test_separator_1() - Method in class com.bigdata.util.httpd.TestMIMEType
Tests for correct rejection of trailing semicolon.
test_serializable() - Method in class com.bigdata.rdf.spo.TestSPO
test_serializable_sidIV() - Method in class com.bigdata.rdf.spo.TestSPO
test_serialization() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
test_serialization() - Method in class com.bigdata.bop.engine.TestBOpStats
test_serialization() - Method in class com.bigdata.bop.engine.TestHaltOpMessage
test_serialization() - Method in class com.bigdata.bop.engine.TestStartOpMessage
test_serialization() - Method in class com.bigdata.btree.TestBloomFilter
test_serialization() - Method in class com.bigdata.rdf.load.TestLockDeserialization
test_serialization_throwable() - Method in class com.bigdata.bop.engine.TestHaltOpMessage
test_serializationSize() - Method in class com.bigdata.rdf.spo.TestSPOKeyOrder
Writes the serialized size of an instance on stdout.
test_server() - Method in class com.bigdata.counters.httpd.TestCounterSetHTTPDServer
test_service02() - Method in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase
test_service02b() - Method in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase
test_service04a() - Method in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase
test_service04b() - Method in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase
test_service_001() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Simple SERVICE graph pattern.
test_service_001() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestBigdataNativeServiceEvaluation
A simple SERVICE query against an INTERNAL service.
test_service_001() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestOpenrdfNativeServiceEvaluation
A simple SERVICE query.
test_service_001() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A simple test with nothing bound and NO source solution.
test_service_001() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A simple test with nothing bound and NO source solution.
test_service_001() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A simple test with nothing bound and NO source solution.
test_service_001b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A simple test with nothing bound and a single empty source
solution.
test_service_001b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A simple test with nothing bound and a single empty source
solution.
test_service_001b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A simple test with nothing bound and a single empty source
solution.
test_service_002() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Simple SERVICE graph pattern with SILENT keyword.
test_service_002() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestBigdataNativeServiceEvaluation
A simple SERVICE query against an INTERNAL service.
test_service_002() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestOpenrdfNativeServiceEvaluation
A simple SERVICE query.
test_service_002() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A test where a single fully bound triple pattern is presented.
test_service_002() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A test where a single fully bound triple pattern is presented.
test_service_002() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A test where a single fully bound triple pattern is presented.
test_service_003() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Simple SERVICE graph pattern with variable for the URI.
test_service_003() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A variant test in which there are some BINDINGS to be passed through.
test_service_003() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A variant test in which there are some BINDINGS to be passed through.
test_service_003() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A variant test in which there are some BINDINGS to be passed through.
test_service_004() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Simple SERVICE graph pattern with variable for the URI and prefix
declarations.
test_service_004() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_004() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_004() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_005() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_005() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_005() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_006() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_006() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_006() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_007() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_007() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_007() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_008() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_008() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_008() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
A variant test in there is a blank node in the BINDINGS to be flowed
through to the remote SERVICE.
test_service_009() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
test_SERVICE_DESCRIPTION() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_ServiceDescription
Request the SPARQL SERVICE DESCRIPTION for the end point.
test_serviceAlias() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestServiceRegistry
Unit test service alias.
test_serviceAlias2() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestServiceRegistry
Unit test verifies that you MAY register an alias for a URI which is NOT
associated with an explicitly registered service.
test_serviceJoin() - Method in class com.bigdata.quorum.TestSingletonQuorumSemantics
Unit test for the protocol up to a service join, which triggers a leader
election.
test_serviceJoin3_simple() - Method in class com.bigdata.quorum.TestHA3QuorumSemantics
Unit test for service join/leave where services vote in the pipeline
order so the leader does not need to reorganize the pipeline when the
number of joined services reaches (k+1)/2.
test_serviceJoin3_simpleForceRemove() - Method in class com.bigdata.quorum.TestHA3QuorumSemantics
test_serviceJoin_terminateClient() - Method in class com.bigdata.quorum.TestSingletonQuorumSemantics
Unit test verifying that we clear down the quorum's reflection of the
distributed quorum state where we first have a quorum meet and then
terminate the quorum client.
test_ServiceNode01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_ServiceNode02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_serviceNodeOptimizer_01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTServiceNodeOptimizer
Given
test_serviceNodeOptimizer_02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTServiceNodeOptimizer
Unit test for correct rejection of the lift into a named subquery.
test_sessionProtection() - Method in class com.bigdata.rwstore.sector.TestMemStore.TestRawStore
Tests whether tasks are able to access and modify data safely by
emulating transactions by calling activateTx and deactivateTx
directly.
test_sessionProtection() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Tests whether tasks are able to access and modify data safely by
emulating transactions by calling activateTx and deactivateTx
directly.
test_setReleaseTime() - Method in class com.bigdata.service.TestDistributedTransactionServiceRestart
Unit tests verifies that the head of the commit time index is truncated
when the release time is advanced and that it is still possible to obtain
a read-only tx as of the timestamp immediately after the current release
time.
test_shortestSeparatorKey() - Method in class com.bigdata.btree.TestLeafSplitShortestSeparatorKey
On reflection, I suspect that this is an edge case which is simply not
covered by the code.
test_shutdown() - Method in class com.bigdata.concurrent.TestNonBlockingLockManager
Test startup and normal shutdown.
test_shutdown() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test startup and normal shutdown.
test_shutdown() - Method in class com.bigdata.journal.TestConcurrentJournal
Test ability to create a
Journal
and then shut it down (in
particular this is testing shutdown of the thread pool on the
ConcurrencyManager
).
test_shutdown_interrupted() - Method in class com.bigdata.journal.TestTransactionService
Test that shutdown() may be interrupted while waiting for a tx to
complete and that it will convert to shutdownNow() which does not wait.
test_shutdown_newTxNotAllowed() - Method in class com.bigdata.journal.TestTransactionService
Test that shutdown() does not permit new tx to start (a variety of things
are not permitted during shutdown).
test_shutdown_nothingRunning() - Method in class com.bigdata.journal.TestTransactionService
Verifies that we can shutdown() the service when there are no
active transactions.
test_shutdown_waitsForReadOnlyTx_aborts() - Method in class com.bigdata.journal.TestTransactionService
Test that the service will wait for a read-only tx to abort.
test_shutdown_waitsForReadOnlyTx_commits() - Method in class com.bigdata.journal.TestTransactionService
Test that the service will wait for a read-only tx to commit.
test_shutdown_waitsForReadWriteTx_aborts() - Method in class com.bigdata.journal.TestTransactionService
Test that the service will wait for a read-write tx to abort.
test_shutdown_waitsForReadWriteTx_commits() - Method in class com.bigdata.journal.TestTransactionService
Test that the service will wait for a read-write tx to commit.
test_shutdownNow() - Method in class com.bigdata.concurrent.TestNonBlockingLockManager
Test startup and fast shutdown.
test_shutdownNow() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test startup and fast shutdown.
test_shutdownNow() - Method in class com.bigdata.journal.TestConcurrentJournal
test_silent_add_default_to_graph() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
add silent default to
test_silent_add_graph_to_graph() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
add silent to
test_silent_copy_default_to_graph() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
copy silent default to
test_silent_copy_graph_to_graph() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
copy silent to
test_silent_move_default_to_graph() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
move silent default to
test_silent_move_graph_to_graph() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
move silent to
test_simple() - Method in class com.bigdata.btree.TestIndexSegmentMultiBlockIterators
Test build around an
IndexSegment
having a branching factor of
THREE (3) and three leaves, which are fully populated.
test_simple() - Method in class com.bigdata.rdf.sail.webapp.Test_Ticket_1893
Execute an ASK query including a SERVICE keyword which gets sent back to this server.
test_simple() - Method in class com.bigdata.rdf.sail.webapp.Test_Ticket_2091
Execute a query including constants in projection expression.
test_simple() - Method in class com.bigdata.search.TestSearchRestartSafe
test_simple_join() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple join of two triple patterns.
test_simple_optional_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestOptionals
Unit test for a simple optional (one where the statement pattern can
be lifted into the parent group).
test_simple_triple_pattern_with_bind_and_filter() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Unit test for simple triple pattern in the default context with a BIND
and a FILTER.
test_simple_triple_pattern_with_filter() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Unit test for simple triple pattern in the default context with a FILTER.
test_simple_triple_pattern_with_IN_filter() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
IN with empty arg list in a FILTER.
test_simple_triple_pattern_with_IN_filter_constants() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
IN with a non-empty arg list in a FILTER.
test_simple_triple_pattern_with_IN_filter_singletonSet() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
IN with an arg list in a FILTER.
test_simple_triple_pattern_with_IN_filter_variables() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
IN with a non-empty arg list in a FILTER.
test_simple_triple_pattern_with_let_and_filter() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Unit test for simple triple pattern in the default context with a LET
and a FILTER (LET is an alternative syntax for BIND).
test_simpleAbortFailure() - Method in class com.bigdata.journal.TestJournalAbort
In this test we want to run through some data inserts, commits and aborts.
test_simpleAggregate() - Method in class com.bigdata.bop.solutions.TestGroupByState
Unit test with simple aggregate function in SELECT clause.
test_simpleAggregate() - Method in class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
Unit test with simple aggregate function in SELECT clause.
test_simpleAggregate_noGroupBy() - Method in class com.bigdata.bop.solutions.TestGroupByState
Unit test with simple aggregate function in SELECT clause and no GROUP BY
clause (the aggregation is taken across all solutions as if they were a
single group).
test_simpleAggregate_noGroupBy() - Method in class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
Unit test with simple aggregate function in SELECT clause and no GROUP BY
clause (the aggregation is taken across all solutions as if they were a
single group).
test_simpleBindingsOptimizer_quads_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer.TestQuadsModeAPs
SELECT * WHERE {
BIND ( as ?type )
?personId rdf:type ?type
}
test_simpleBindingsOptimizer_triples_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer.TestTriplesModeAPs
SELECT * WHERE {
BIND ( as ?type )
?personId rdf:type ?type
}
test_simpleBindingsOptimizer_triples_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer
Complex patterns like
test_simpleBindingsOptimizer_triples_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer.TestTriplesModeAPs
Complex patterns like
test_simpleCoder() - Method in class com.bigdata.rdf.spo.TestSPOKeyCoders
test_simpleCoder() - Method in class com.bigdata.rdf.spo.TestSPOValueCoders
test_simpleConcurrentReadersWithResets() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Concurrent readers should no longer be an issue now that
reset() is not re-initializing from the root block.
test_simpleDataRWService() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
test_simpleFixPoint() - Method in class com.bigdata.rdf.rules.TestDatabaseAtOnceClosure
Example using only
RuleRdfs11
that requires multiple rounds to
compute the fix point closure of a simple data set.
test_simpleGroupByAndCount_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
Optimization applies to pattern:
test_simpleGroupByAndCount_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
Optimization applies to pattern:
test_simpleGroupByAndCount_03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
Optimization applies to pattern:
test_simpleGroupByAndCount_04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
Optimization only partially applies to pattern:
test_simpleGroupByAndCount_delete_markers() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
The optimization must *not* be applied in the presence of delete
markers.
test_simpleHavingClause() - Method in class com.bigdata.bop.solutions.TestGroupByState
SELECT SUM(?y) as ?x
GROUP BY ?z
HAVING ?x > 10
test_simpleHavingClause() - Method in class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
SELECT SUM(?y) as ?x
GROUP BY ?z
HAVING ?x > 10
test_simpleOptional() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSimpleOptionalOptimizer
Unit test for recognizing a "simple optional" and lifting it into the
parent join group.
test_simpleOptional01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_simpleOptional01A() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_simpleProgram() - Method in class com.bigdata.relation.rule.TestProgram
test_SimpleRange() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTRangeOptimizer
test_SimpleRange_justLower() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTRangeOptimizer
test_SimpleRange_justUpper() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTRangeOptimizer
test_simpleRemoval() - Method in class com.bigdata.htree.TestRemovals
Just insert and remove a single key
test_simpleRemovalWithRawRecords() - Method in class com.bigdata.htree.TestRemovals
Test removal with raw records.
test_simpleRemoveAll() - Method in class com.bigdata.htree.TestRemovals
Insert and remove several copies of the same key.
test_simpleReorder01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_simpleReorder02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_simpleReorder03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_simpleReorder04() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
Given
test_simpleReset() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Tests semantics of a simple reset
Commit some data
Delete committed and allocate new data
Reset
Test that deletion and new allocation are void
test_simpleRWService() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
test_singleEmptyChunk2() - Method in class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
Unit test with a single empty chunk.
test_singleResourceLocking_defaultConcurrency20() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource (default concurrency).
test_singleResourceLocking_highConcurrency100() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource (high concurrency).
test_singleResourceLocking_lowConcurrency5() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource (low concurrency
condition w/ 5 threads).
test_singleResourceLocking_serialized_highConcurrency() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized.
test_singleResourceLocking_serialized_highConcurrency_lockTimeout() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized with
a non-zero lock timeout.
test_singleResourceLocking_serialized_lowConcurrency2() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource and there is only one
resource to be locked so that all operations MUST be serialized.
test_singleResourceLocking_serialized_lowConcurrency5() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized.
test_singleResourceLocking_serialized_lowConcurrency5_withTaskDeath() - Method in class com.bigdata.concurrent.TestLockManager
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized and
where 10% of all tasks die a horrid death.
test_singleResourceLocking_serialized_waitsFor_highConcurrency() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized.
test_singleResourceLocking_serialized_waitsFor_highConcurrency_taskTimeout() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized.
test_singleResourceLocking_serialized_waitsFor_lowConcurrency2() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource and there is only one
resource to be locked so that all operations MUST be serialized.
test_singleResourceLocking_serialized_waitsFor_lowConcurrency5_withTaskDeath() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource and there is only
one resource to be locked so that all operations MUST be serialized and
where 10% of all tasks die a horrid death.
test_singleResourceLocking_waitsFor_defaultConcurrency20() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource using a thread
pool with 20 core threads.
test_singleResourceLocking_waitsFor_highConcurrency100() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource (high concurrency
condition with 100 threads).
test_singleResourceLocking_waitsFor_lowConcurrency5() - Method in class com.bigdata.concurrent.StressTestNonBlockingLockManagerWithTxDag
Test where each operation locks only a single resource (low concurrency
condition w/ 5 threads).
test_SingleSubject() - Method in class com.bigdata.rdf.lexicon.TestSubjectCentricFullTextIndex
Deprecated.
test_singleThreadIndexCreationRate() - Method in class com.bigdata.journal.StressTestGroupCommit
Measures the maximum rate at which a single thread can register named
indices.
test_singleValueIterator() - Method in class com.bigdata.relation.accesspath.TestThickAsynchronousIterator
test_singleValueIterator() - Method in class com.bigdata.relation.accesspath.TestThickCloseableIterator
test_size() - Method in class com.bigdata.btree.TestIndexSegmentCheckpoint
test_slice() - Method in class com.bigdata.rdf.rules.TestSlice
Tests various slices on an
IRule
using a single JOIN with 3
solutions.
test_slice() - Method in class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
Unit test for SLICE in SELECT query.
test_slice() - Method in class com.bigdata.rdf.spo.TestSPOAccessPath
test_slice_correctRejection_badLimit() - Method in class com.bigdata.bop.solutions.TestSliceOp
test_slice_correctRejection_badOffset() - Method in class com.bigdata.bop.solutions.TestSliceOp
test_slice_ctor() - Method in class com.bigdata.relation.rule.TestSlice
Tests some fence posts for the
Slice
ctor, verifies the
computation of
ISlice.getLast()
, and the reporting of the
properties specified to the ctor.
test_slice_ctor_correctRejection() - Method in class com.bigdata.relation.rule.TestSlice
test_slice_offset0_limitAll() - Method in class com.bigdata.bop.solutions.TestSliceOp
Unit test where the slice accepts everything.
test_slice_offset1_limit3() - Method in class com.bigdata.bop.solutions.TestSliceOp
Unit test for correct visitation for a variety of offset/limit values.
test_slice_offset2_limit3() - Method in class com.bigdata.bop.solutions.TestSliceOp
Unit test for correct visitation for a variety of offset/limit values.
test_slice_offsetNeverSatisfied() - Method in class com.bigdata.bop.solutions.TestSliceOp
Unit test where the offset is never satisfied.
test_slice_offsetPlusLimitNeverSatisfied() - Method in class com.bigdata.bop.solutions.TestSliceOp
Unit test where the offset plus the limit is never satisfied.
test_slice_read() - Method in class com.bigdata.io.TestSliceInputStream
test_slice_read_byteArray() - Method in class com.bigdata.io.TestSliceInputStream
test_slice_threadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine
test_slice_threadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_Slice
test_slice_threadSafe() - Method in class com.bigdata.bop.solutions.TestSliceOp
test_small() - Method in class com.bigdata.rdf.store.TestInsertRate
test_smallBlobFile() - Method in class com.bigdata.btree.TestIndexSegmentBuilderWithBlobCapacity
test_smallSlotRecycling() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Tests the recycling of small slot alloctors and outputs statistics related
to contiguous allocations indicative of reduced IOPS.
test_smallSlotWasteRecylcing() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
At scale the small slot handling can lead to large amounts of store
waste, tending to the small slot allocation thresholds of 50%,
dependent on use case.
test_snapshotCommitIndex() - Method in class com.bigdata.service.TestDistributedTransactionServiceRestart
Unit test of the ability to snapshot the commit index.
test_snapshotData() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_snapshotIterator() - Method in class com.bigdata.relation.accesspath.TestUnsynchronizedUnboundedChunkBuffer
Verify that the iterator has snapshot semantics.
test_snapshots() - Method in class com.bigdata.service.TestSnapshotHelper
test_solutionSetHashJoin_ctor() - Method in class com.bigdata.bop.join.TestHTreeSolutionSetHashJoin
Unit tests for the constructor.
test_solutionWithAllMockIVs() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test with all mock IVs.
test_solutionWithMockIVAndOthersToo() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test with all mix of MockIVs, TermIds, and BlobIVs.
test_solutionWithMockIVsPreservesFlagsBits() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
This issue showed up as part of BLZG-533 (vector query engine on native
heap) where the flags bits (which indicate URI or BNode or Literal) were
not being preserved for a MockIV.
test_solutionWithOneMockIV() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test with one mock IV.
test_solutionWithSameValueBoundTwice() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
test_solutionWithThreeBindings1() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test of a solution with 3 bindings.
test_solutionWithThreeBindings2() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test of a solution with 3 bindings in a different order.
test_solutionWithThreeBindingsSomeNotCached1() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test of a solution with 3 bindings, some of which do not have an
IVCache
association.
test_solutionWithThreeBindingsSomeNotCachedSomeInline() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test of a solution with 3 bindings, some of which do not have an
IVCache
association and some of which have an inline IV.
test_solutionWithVeryLargeObject() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
test_solutionWithVeryLargeObject2() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test of a solution having a
BlobIV
with a
BigdataLiteral
which is very large plus a few other bindings.
test_solutionWithVeryLargeObject3() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
Unit test of a solution having a
BlobIV
with a
BigdataLiteral
which is very large plus a few other bindings
(different order from the test above).
test_something() - Method in class com.bigdata.bop.ap.filter.TestFilter
TODO Write tests.
test_something() - Method in class com.bigdata.bop.ap.filter.TestResolver
TODO Write tests.
test_something() - Method in class com.bigdata.bop.ap.TestSampleIndex
Unit test verifies some aspects of a sample taken from a local index
(primarily that the sample respects the limit).
test_something() - Method in class com.bigdata.bop.fed.nodes.TestMapBindingSetsOverNodes
test_something() - Method in class com.bigdata.bop.join.TestNestedLoopJoinOp
Note: There are some tests at the data-driven level.
test_something() - Method in class com.bigdata.bop.mutation.TestDelete
TODO Write tests.
test_something() - Method in class com.bigdata.bop.mutation.TestInsert
TODO Write tests.
test_something() - Method in class com.bigdata.bop.rdf.filter.TestStripContextFilter
TODO Write tests for the StringContextFilter
.
test_something() - Method in class com.bigdata.bop.rdf.join.TestDataSetJoin
test_something() - Method in class com.bigdata.btree.raba.TestMutableValuesRaba
test_something() - Method in class com.bigdata.counters.query.TestTimeRange
test_something() - Method in class com.bigdata.relation.accesspath.TestArrayBuffer
test_something_distinct_threadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_DistinctOp
test_something_groupBy_threadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_GroupByOp
test_something_StressThreadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_DistinctOp
test_something_StressThreadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_GroupByOp
test_sort_3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
PREFIX foaf:
SELECT ?name ?mbox
WHERE { ?x foaf:name ?name .
test_spaceCurve() - Method in class com.bigdata.btree.TestBloomFilter
This is not really a unit test.
test_spans_A_equals_B_with_extra_params_on_B() - Method in class com.bigdata.util.httpd.TestMIMEType
Tests that A spans B
and that B does not
span A
when B has same type and subtype but also
specifies one or more parameters which are not included in A.
test_spans_subtype_1() - Method in class com.bigdata.util.httpd.TestMIMEType
Tests that a subtype wildcard spans any specific subtype.
test_spans_subtype_2() - Method in class com.bigdata.util.httpd.TestMIMEType
test_spans_subtype_3() - Method in class com.bigdata.util.httpd.TestMIMEType
test_spans_when_A_equals_B() - Method in class com.bigdata.util.httpd.TestMIMEType
Tests that A spans B
when A == B
.
test_spans_when_A_equals_B_same_params() - Method in class com.bigdata.util.httpd.TestMIMEType
Tests that A spans B
and B spans A
when A == B
and A and B both specify the same MIME
type parameters (same MIME type expressions).
test_spans_will_ingore_parameters_when_asked_to() - Method in class com.bigdata.util.httpd.TestMIMEType
Tests that the spans implementation correctly ignores the
specified MIME type parameters when we ask it to.
test_sparql11_bindings_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
TCK test for the BINDINGS clause.
test_sparql11_bindings_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
TCK test for the BINDINGS clause.
test_sparql11_bindings_04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
This is a variant of Federated Query service04
where the
remote end point is treated as a named graph.
test_sparql11_count_03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is not a DAWG test.
test_sparql11_count_subquery_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
A unit test from the Sesame 2.5 TCK.
test_sparql11_exists_05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
Sesame Unit sparql11-exists-05
.
test_sparql11_exists_06() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
Sesame Unit sparql11-exists-06
, which appears to be the same
as an example in the LCWD.
test_sparql11_having_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestAggregationQuery
A basic aggregation query.
test_sparql11_in_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is not a DAWG test.
test_sparql11_minus_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
A Sesame test.
test_sparql11_minus_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
A Sesame test based on the SPARQL 1.1 LCWD.
test_sparql11_minus_05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
A Sesame test.
test_sparql11_minus_06() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
A Sesame test.
test_sparql11_minus_07() - Method in class com.bigdata.rdf.sparql.ast.eval.TestNegation
A Sesame test.
test_sparql11_order_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
TCK (non-DAWG) query we picked up with Sesame 2.6.3
.
test_sparql11_order_03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
TCK (non-DAWG) query we picked up with Sesame 2.6.3
test_sparql11_subquery_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
A unit test from the Sesame 2.5 TCK.
test_sparql11_subquery_04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is sesame TCK test sparql11-subquery-04
.
test_sparql11_subquery_filter_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
In this test variant, the FILTER winds up attached to a
NamedSubqueryRoot
(there are no shared variables projected out of
the sub-select) and does not require RDF
Value
materialization.
test_sparql11_subquery_filter_01b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
Variant where the FILTER requires RDF Value materialization and the
sub-select is lifted out as a named subquery.
test_sparql11_subquery_scope() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
Test that only projected variables are included in subquery results.
test_sparql11_sum_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is not a DAWG test.
test_sparql11_sum_03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is not a DAWG test.
test_sparql11_sum_04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is not a DAWG test.
test_sparql_bev_5() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
Test effective boolean value - optional.
test_sparql_bev_5() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSimpleOptionalOptimizer
Test effective boolean value - optional.
test_sparql_bev_5_withFilterInOptionalGroup() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSimpleOptionalOptimizer
A variant of the TCK test where the filter is in the optional group and
uses BOUND() to wrap the variable.
test_sparql_subquery_limiting_resource_pattern() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
PREFIX :
SELECT *
WHERE {
?s :p ?o .
test_sparql_subquery_slice_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
Unit test of a SPARQL 1.1 subquery with a SLICE on the subquery.
test_sparql_subselect() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
Simple Sub-Select unit test
test_SPARQL_UPDATE_Tx_Properly_Closed() - Method in class com.bigdata.rdf.sail.webapp.TestRWStoreTxBehaviors
Unit test verifies that the native journal transaction counter for the
RWStore is properly closed for SPARQL UPDATE.
test_specializeRule() - Method in class com.bigdata.relation.rule.TestRule
Test case for specializing a rule by binding some of its variables.
test_split_applicationConstraint_acceptAllSplits() - Method in class com.bigdata.resources.TestSegSplitter
Unit test using an
ISimpleSplitHandler
which accepts all splits
(the behavior should be the same as if there were no override).
test_split_applicationConstraint_nbytePrefix() - Method in class com.bigdata.resources.TestFixedLengthPrefixShardSplits
Unit test for the logic handling application constraints on the choice of
the separator key, which can also change the #of splits which may be
generated from a given input B+Tree.
test_split_applicationConstraint_rejectAllSplits() - Method in class com.bigdata.resources.TestSegSplitter
test_split_applicationConstraint_remainerGoesIntoSplit() - Method in class com.bigdata.resources.TestSegSplitter
Unit test when the application specifies a split handler which accepts
the first N splits of a multiway split but then rejects all other split
points.
test_split_applicationConstraint_rowStore() - Method in class com.bigdata.resources.TestSparseRowStoreSplitHandler
test_split_fromToKeyConstraints() - Method in class com.bigdata.resources.TestSegSplitter
A unit test which examines correctness when the fromKey and/or toKey are
non-null
.
test_split_lower_bounds() - Method in class com.bigdata.resources.TestSegSplitter
A unit test when the split would create two or three index segments (both
cases are tested here to cover the lower bound and the near lower bound).
test_split_segment_underflow() - Method in class com.bigdata.resources.TestSegSplitter
Unit test the edge cases surrounding when an index partition is split.
test_split_stress() - Method in class com.bigdata.resources.TestSegSplitter
A stress test which increases the target number of splits until each
split would have only one tuple.
test_split_upper_bound() - Method in class com.bigdata.resources.TestSegSplitter
A unit test for fence posts when nominal shard size is so small that we
will get only one tuple into each generated split.
test_splitDataLine01() - Method in class com.bigdata.counters.linux.TestParsing
test_splitDataLine02() - Method in class com.bigdata.counters.linux.TestParsing
test_splitDataLineLeadingSpaces() - Method in class com.bigdata.counters.linux.TestParsing
test_splitJoin() - Method in class com.bigdata.service.TestSplitJoin
Test registers a scale-out index, writes data onto the initial index
partition, forces a split, verifies that the scale-out index has been
divided into two index partitions, and verifies that a range scan of the
scale-out index agrees with the ground truth.
test_splitJoinLeafBranchingFactor3_01() - Method in class com.bigdata.btree.TestSplitJoinRootLeaf
A series of tests of the mechanisms for splitting and joining a leaf with
a branching factor of three (3).
test_splitJoinLeafBranchingFactor3_02() - Method in class com.bigdata.btree.TestSplitJoinRootLeaf
test_splitJoinLeafBranchingFactor3_03() - Method in class com.bigdata.btree.TestSplitJoinRootLeaf
test_splitJoinLeafBranchingFactor3_04() - Method in class com.bigdata.btree.TestSplitJoinRootLeaf
test_splitJoinLeafBranchingFactor4_01() - Method in class com.bigdata.btree.TestSplitJoinRootLeaf
Note: with a branching factor greater than (3) it is possible for
AbstractNode.join()
to trigger
Leaf#redistributeKeys(Leaf)
rather
than
Leaf#merge(Leaf)
.
test_splitJoinLeafBranchingFactor4_02() - Method in class com.bigdata.btree.TestSplitJoinRootLeaf
This test triggers the redistribution of a key from (a) to (b).
test_splitKeys_staticPartitions01() - Method in class com.bigdata.service.TestEmbeddedClient
Test of the routine responsible for identifying the split points in an
ordered set of keys for a batch index operation.
test_splitRootLeaf_decreasingKeySequence() - Method in class com.bigdata.btree.TestBTree
A stress test for sequential decreasing key insertions that runs with a
variety of branching factors and #of keys to insert.
test_splitRootLeaf_increasingKeySequence() - Method in class com.bigdata.btree.TestBTree
A stress test for sequential key insertion that runs with a variety of
branching factors and #of keys to insert.
test_splitRootLeaf_randomKeySequence() - Method in class com.bigdata.btree.TestBTree
A stress test for random key insertion using a that runs with a variety
of branching factors and #of keys to insert.
test_splitter_correctRejection() - Method in class com.bigdata.service.ndx.TestSplitter
API error checking for args.
test_splitter_correctSplits_01() - Method in class com.bigdata.service.ndx.TestSplitter
Test computing the correct splits with a single key and a single index
partition.
test_splitter_correctSplits_02() - Method in class com.bigdata.service.ndx.TestSplitter
Test with more than one key in the same index partition.
test_splitter_correctSplits_03() - Method in class com.bigdata.service.ndx.TestSplitter
Test with one key into each of two index partitions.
test_splitter_duplicateKeys() - Method in class com.bigdata.service.ndx.TestSplitter
Recognizing duplicate keys, which are OK as long as the do not violate
the key ordering.
test_splitter_keysOutOfOrder() - Method in class com.bigdata.service.ndx.TestSplitter
Correct detection when the keys are not fully ordered.
test_spocOnlyKeyOrder_iterator() - Method in class com.bigdata.rdf.spo.TestSPOKeyOrder
test_spoOnlyKeyOrder_iterator() - Method in class com.bigdata.rdf.spo.TestSPOKeyOrder
test_sssp_linkType_constraint() - Method in class com.bigdata.rdf.graph.impl.bd.TestSSSP
A unit test based on graph with link weights - in this version of the
test we constrain the link type but do not specify the link attribute
type.
test_sssp_weightedGraph() - Method in class com.bigdata.rdf.graph.impl.bd.TestSSSP
A unit test based on graph with link weights.
test_stack() - Method in class com.bigdata.btree.TestBTreeLeafCursors
Unit tests for the node stack impl.
test_start_end() - Method in class com.bigdata.service.TestEventReceiver
test_start_stop() - Method in class com.bigdata.rdf.sail.webapp.TestNanoSparqlServer
Simple start/kill in which we verify that the default KB was NOT created
and that the explicitly create KB instance can still be resolved.
test_start_terminate() - Method in class com.bigdata.quorum.TestMockQuorumFixture
Simple start()/terminate() test.
test_startEmptyWriteStop() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTask
Unit test writes an empty chunk and then stops the master.
test_startQueryTwice() - Method in class com.bigdata.bop.engine.TestRunState
Unit test verifies that attempting to start a query twice is an error.
test_startShutdown() - Method in class com.bigdata.util.httpd.TestNanoHTTPD
test_startShutdownNow() - Method in class com.bigdata.util.httpd.TestNanoHTTPD
test_startStop() - Method in class com.bigdata.bop.engine.TestQueryEngine
Starts and stops the
QueryEngine
, but does not validate the
semantics of shutdown() versus shutdownNow() since we need to be
evaluating query mixes in order to verify the semantics of those
operations.
test_startStop() - Method in class com.bigdata.bop.fed.TestFederatedQueryEngine
Starts and stops the
QueryEngine
, but does not validate the
semantics of shutdown() versus shutdownNow() since we need to be
evaluating query mixes in order to verify the semantics of those
operations.
test_startStop() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTask
Test verifies start/stop of the master.
test_startup() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
test_startWriteErrorStop() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTaskWithErrors
Unit test verifies correct shutdown and error reporting when a subtask
fails.
test_startWriteRedirectStop() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTaskWithRedirect
Unit test verifies correct redirect of a write.
test_startWriteRedirectWithReopenStop() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTaskWithRedirect
Unit test verifies correct redirect of a write arising during awaitAll()
in the master and occurring after there has already been a write on the
partition which is the target of the redirect.
test_startWriteStop1() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTask
Unit test writes a chunk and then stops the master.
test_startWriteStop2() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTask
Unit test writes a chunk that is split onto two subtasks and then stops
the master.
test_startWriteWriteStop2() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTask
Unit test writes 2 chunks that are each split onto two subtasks and then
stops the master.
test_stateMachine() - Method in class com.bigdata.journal.TestRunState
Unit tests for legal and illegal state transitions.
test_statementBuffer() - Method in class com.bigdata.rdf.rio.TestStatementBuffer
test_statementIdentifiers() - Method in class com.bigdata.rdf.store.TestStatementIdentifiers
Some validation of the logic for assigning statement identifiers to
explicit statements.
test_statementOrder() - Method in class com.bigdata.rdf.spo.TestSPOTupleSerializer
test_statements() - Method in class com.bigdata.rdf.store.TestTripleStore
test_static_analysis01() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test of static analysis for variables which must be bound by a
query.
test_static_analysis02() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test of static analysis for variables which must be bound by a
query.
test_static_analysis03() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test of static analysis for variables with a named subquery.
test_static_analysis04() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test of static analysis for variables with a SPARQL 1.1 subquery.
test_static_analysis05() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test of static analysis for a SERVICE call.
test_static_analysis_filter_nested_1() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Static analysis of TCK query:
test_static_analysis_filter_nested_2() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Static analysis of TCK query:
test_static_analysis_filter_scope_1() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Static analysis of TCK query:
test_static_analysis_filters() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test(s) for the correct identification of pre-, join-, post-, and
prune- filters.
test_static_analysis_getMaybeProducedBindings() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
test_static_analysis_getProjectedVars() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
test_static_analysis_join_scope_1() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Join-scope - 1 (aka var-scope-join-1).
test_static_analysis_join_vars() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer
Unit test for computing the join variables for a named subquery based on
the analysis of the bindings which MUST be produced by the subquery and
those which MUST be bound on entry into the group in which the subquery
solution set is included within the main query.
test_static_analysis_join_vars() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test for computing the join variables for a named subquery based on
the analysis of the bindings which MUST be produced by the subquery and
those which MUST be bound on entry into the group in which the subquery
solution set is included within the main query.
test_static_analysis_minus_and_optional() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Variant test for query mixing MINUS and OPTIONAL groups.
test_static_analysis_minus_nothingShared() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Variant test for a MINUS operator without shared variables.
test_static_analysis_minus_sharedVariables() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test of static analysis methods as they pertain to a MINUS group.
test_static_analysis_no_join_vars() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer
test_static_analysis_projection_01() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test for static analysis of the MUST and MIGHT bound variables for a
subquery.
test_static_analysis_projection_02() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Variant with optional group binding ?a
(so ?b
is MIGHT be bound).
test_static_analysis_projection_03() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test where the SELECT expression includes the bind of a constant
onto a variable.
test_static_analysis_projection_04() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test for static analysis of the MUST and MIGHT bound variables for a
query involving a select expression which could result in an error.
test_static_analysis_projection_05() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test for static analysis of the MUST and MIGHT bound variables for a
query involving a select expression which depends on a variable which is
not definitely bound.
test_static_analysis_projection_06() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Unit test for static analysis of the MUST and MIGHT bound variables for a
subquery involving aggregation and a select expression ("The result of an
Aggregate which returns an error, is an error, but the SELECT expression
result of projecting an error is unbound").
test_static_analysis_serviceCall() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
test_static_analysis_serviceCall2() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Test suite for predicting the join variables for a SERVICE call.
test_static_analysis_subGroups_and_optional() - Method in class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
Variant test for query mixing normal child join groups and OPTIONAL
join groups.
test_static_getMaxByteCount() - Method in class com.bigdata.rawstore.TestWormAddressManager
test_staticPartitioning() - Method in class com.bigdata.service.TestEmbeddedClient
Tests the ability to statically partition a scale-out index.
test_stats() - Method in class com.bigdata.bop.engine.TestBOpStats
test_stored_query_001() - Method in class com.bigdata.rdf.sparql.ast.service.storedquery.TestStoredQueryService
Simple stored query test.
test_stored_query_002() - Method in class com.bigdata.rdf.sparql.ast.service.storedquery.TestStoredQueryService
Simple stored query test verifies that the stored query has access to the
ServiceParams
.
test_stored_query_003() - Method in class com.bigdata.rdf.sparql.ast.service.storedquery.TestStoredQueryService
test_streamAPI() - Method in class com.bigdata.rdf.internal.encoder.TestIVSolutionSetEncoder
Unit test of the stream-oriented API.
test_streamAPI2() - Method in class com.bigdata.rdf.internal.encoder.TestIVSolutionSetEncoder
Multiple solutions where an empty solution appears in the middle of the
sequence.
test_stress() - Method in class com.bigdata.bfs.TestRandomBlockOps
A small stress test for a single file version.
test_stress() - Method in class com.bigdata.journal.TestCommitRecordSerializer
test_stress() - Method in class com.bigdata.rdf.internal.TestIVUnicode
test_stress() - Method in class com.bigdata.rdf.rules.TestTruthMaintenance
This is a stress test for truth maintenance.
test_stress() - Method in class com.bigdata.rdf.store.StressTestCentos
test_stress_InputBitStream_compatible() - Method in class com.bigdata.btree.raba.codec.TestCanonicalHuffmanRabaCoder
test_stress_InputBitStream_compatible() - Method in class com.bigdata.btree.TestGetBitsFromByteArray
test_stress_removeStructure() - Method in class com.bigdata.btree.TestBTree
Stress test for building up a tree and then removing all keys in a random
order.
test_stress_split() - Method in class com.bigdata.btree.TestBTree
Stress test inserts random permutations of keys into btrees of order m
for several different btrees, #of keys to be inserted, and permutations
of keys.
test_stress_startWriteStop2() - Method in class com.bigdata.service.ndx.pipeline.TestMasterTask
Stress test for the atomic termination condition.
test_stressAlloc() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_stressBlobBlobHeaderBlobDataDeferredFrees() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Repeats the BlobBlobHeader of deferred frees, but also with blob data.
test_stressBlobBlobHeaderDeferredFrees() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
This test releases over a blobs worth of deferred frees where the
blob requires a blob header.
test_stressBlobDeferredFrees() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
This is the test that was able to reproduce the recycler failure for
BLZG-1236 when run with 10M deferred frees.
test_stressBlobReadBack() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_stressBlockingAllocation() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
test_stressCommit() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_stressCommitIndexNoRetention() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_stressCommitIndexWithRetention() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
test_stressDataRWService() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
test_stressInsert_addressBits1() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits10() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits2() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits3() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits4() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits5() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits6() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_addressBits8() - Method in class com.bigdata.htree.TestHTreeWithMemStore
test_stressInsert_noEviction_addressBits1() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBits10() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBits2() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBits3() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBits4() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBits6() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBits8() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressInsert_noEviction_addressBitsMAX() - Method in class com.bigdata.htree.TestHTree_stressInsert
test_stressReallocationWithRead() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Adjust tcount to increase stress levels
test_stressSessionProtection() - Method in class com.bigdata.rwstore.sector.TestMemStore.TestRawStore
test_stressSessionProtection() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
To stress the session protection, we will allocate a batch of
addresses, then free half with protection.
test_stressTest2() - Method in class com.bigdata.service.StressTestConcurrent
Test of N concurrent operations.
test_stressTestAbort() - Method in class com.bigdata.journal.TestAbort
test_stressTests() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInclude
Execute the stress tests a couple of times.
test_stressTests() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
Execute the stress tests a couple of times.
test_stressTicket473() - Method in class com.bigdata.rdf.sail.TestTicket473
This seems to hinge on simple updates, commits and re-opens.
test_STRESSwriteCacheService_HA_WORM_1record_1buffer_k3_size3_reorganizePipeline() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
Martyn wrote:
TEST_STRING - Static variable in class com.bigdata.jsr166.JSR166TestCase
test_stripedCounters() - Method in class com.bigdata.counters.striped.TestStripedCounters
A basic unit test verifies that a child "strip" is accessed by acquire()
and that the updates are only pushed to the parent counters object every
batchSize release()s.
test_subjectBound() - Method in class com.bigdata.rdf.rules.TestBackchainTypeResourceIterator
Test when only the subject of the triple pattern is bound.
test_subjectBound2() - Method in class com.bigdata.rdf.rules.TestBackchainTypeResourceIterator
Variant test where there is an explicit ( s rdf:type rdfs:Resource ) in
the database for the given subject.
test_submit_interrupt01() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits an unisolated task to the write service.
test_submit_interrupt02() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits an unisolated task to the write service.
test_submit_readService_01() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits an unisolated task to the read service and verifies that it executes.
test_submit_txService_readCommitted_01() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits a read-committed task to the transaction service and verifies
that it executes.
test_submit_txService_readOnly_01() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits an read-only task to the transaction service and verifies that it
executes.
test_submit_txService_readWrite_01() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits a read-write task with an empty write set to the transaction
service and verifies that it executes.
test_submit_writeService_01() - Method in class com.bigdata.journal.TestConcurrentJournal
Submits an unisolated task to the write service and verifies that it
executes.
test_submitOneThenCancel() - Method in class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
Test ability to submit a
Callable
to the service and verify that
is reported at ready(Runnable) and that we can cancel the
Future
.
test_subRangeRaba_01() - Method in class com.bigdata.btree.raba.TestSubRangeRaba
test_subRangeRaba_constructor_correctRejection_01() - Method in class com.bigdata.btree.raba.TestSubRangeRaba
test_subSelect() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
Unit test for simple subquery without anything else in the outer join
group.
test_subSelectNotLifted() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
Unit test verifies that a sub-select is not lifted when there is no
reason to lift that sub-select.
test_subSelectWithAggregation() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
Unit test verifies that a sub-select involving an aggregation is lifted
into a named subquery.
test_subSelectWithLimitAndOrderBy() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
PREFIX :
SELECT *
WHERE {
?s :p ?o .
test_subSelectWithNoJoinVars() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
Unit test verifies that we lift out a
SubqueryRoot
which does not
share any variables with the join group in which it appears.
test_subSelectWithRunOnceAnnotation() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
Unit test verifies that we lift out a
SubqueryRoot
which is
marked by the
SubqueryRoot.Annotations#RUN_ONCE
annotation.
test_substr() - Method in class com.bigdata.rdf.internal.constraints.TestSubstrBOp
test_subSubSelect() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
Unit test for sub-SubSelect.
test_successor() - Method in class com.bigdata.btree.TestBytesUtil
test_sum() - Method in class com.bigdata.bop.rdf.aggregate.TestSUM
test_sum_with_complex_inner_value_expression() - Method in class com.bigdata.bop.rdf.aggregate.TestSUM
test_sum_with_errors() - Method in class com.bigdata.bop.rdf.aggregate.TestSUM
test_sum_with_null() - Method in class com.bigdata.bop.rdf.aggregate.TestSUM
test_syn_bad_01() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Select * Not allowed with GROUP BY
test_syn_bad_02() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
required syntax error : out of scope variable in SELECT from group.
test_syn_bad_03() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Same variable can not be projected more than once.
test_syncWrites_rdd() - Method in class com.bigdata.journal.TestRandomAccessFileSynchronousWrites
Test verifies whether or not the platform appears to perform synchronous
IOs when creating a
RandomAccessFile
with mode
rws
.
test_syncWrites_rds() - Method in class com.bigdata.journal.TestRandomAccessFileSynchronousWrites
Test verifies whether or not the platform appears to perform synchronous
IOs when creating a
RandomAccessFile
with mode
rws
.
test_syntax_update_01() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Positive test (originally failed because it was being passed to
parseQuery() rather than parseUpdate()).
test_syntax_update_30() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
PREFIX but otherwise empty UPDATE.
test_syntax_update_38() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Empty UPDATE.
test_syntax_update_39() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
BASE but otherwise empty UPDATE.
test_syntax_update_bad_03() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Variable in DELETE DATA's data.
test_syntax_update_bad_04() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Variable in INSERT DATA's data.
test_syntax_update_bad_08() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Too many separators (in UPDATE request)
test_syntax_update_bad_09() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
Too many separators (in UPDATE request)
test_syntax_update_bad_10() - Method in class com.bigdata.rdf.sail.sparql.BigdataSPARQL2ASTParserTest
BNode in DELETE WHERE
test_t_1() - Method in class com.bigdata.rdf.sail.webapp.AbstractNamedGraphUpdateTest
test_t_2() - Method in class com.bigdata.rdf.sail.webapp.AbstractNamedGraphUpdateTest
test_t_3() - Method in class com.bigdata.rdf.sail.webapp.AbstractNamedGraphUpdateTest
test_t_5() - Method in class com.bigdata.rdf.sail.webapp.AbstractNamedGraphUpdateTest
test_tasksAreNotThreadSafe() - Method in class com.bigdata.journal.TestConcurrentJournal
Verify that an
AbstractTask
correctly rejects an attempt to
submit the same instance twice.
test_TempTripleStore_noLexicon() - Method in class com.bigdata.rdf.store.TestSharedLexiconTempStore
test_TempTripleStore_oneAccessPath() - Method in class com.bigdata.rdf.store.TestSharedLexiconTempStore
test_TermId() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_BNode() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_Literal() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_mockIV() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_URI() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_URI_Counter_MAX_VALUE() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_URI_Counter_MIN_VALUE() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_URI_Counter_MINUS_ONE() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermId_URI_Counter_ONE() - Method in class com.bigdata.rdf.internal.TestTermIV
test_termIdComparator() - Method in class com.bigdata.rdf.lexicon.TestTermIVComparator
test_TermIV_isExtensionIV() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TermIV_isNullIV() - Method in class com.bigdata.rdf.internal.TestTermIV
test_TERMS_accessPaths() - Method in class com.bigdata.rdf.lexicon.TestAccessPaths
test_termsIndex_addLookupValue_with_toldBNodesMode() - Method in class com.bigdata.rdf.lexicon.TestBlobsIndex
Unit test for lookup and adding values to the TERMS index when blank
nodes are stored in the TERMS index (told bnodes semantics).
test_termsIndex_addLookupValues_with_standard_bnode_semantics() - Method in class com.bigdata.rdf.lexicon.TestBlobsIndex
Unit test for lookup and adding values to the TERMS index when blank
nodes are NOT stored in the TERMS index.
test_TermsTupleSerializer() - Method in class com.bigdata.rdf.lexicon.TestBlobsIndex
Create a TERMS index, put some data into it, and verify that we can use
the
BlobsTupleSerializer
to access that data, including handling
of the NullIV.
test_termTypeOrder() - Method in class com.bigdata.rdf.lexicon.TestLexiconKeyBuilder
Test verifies the ordering among URIs, Literals, and BNodes.
test_TestVocabularyInlineValues() - Method in class com.bigdata.rdf.internal.TestMultiInlineURIHandlersSingleNamespace
test_text_index_datatype_literals() - Method in class com.bigdata.rdf.lexicon.TestFullTextIndex
Unit text for full text indexing of xsd datatype literals.
test_text_index_inline_unicode_literals() - Method in class com.bigdata.rdf.lexicon.TestFullTextIndex
Unit test for indexing fully inline plain, language code, and datatype
literals which using a Unicode representation in the
IV
.
test_threadSafe() - Method in class com.bigdata.service.TestEventReceiver
Unit tests verifies that the APIs are thread-safe.
test_threeChunks_1_0_1() - Method in class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
Unit test with three chunks two of which have one element each and
one of which is empty.
test_threeChunks_1_0_1() - Method in class com.bigdata.striterator.TestDechunkerator
Unit test with three chunks two of which have one element each and
one of which is empty.
test_threeChunks_1_2_1() - Method in class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
Unit test with three chunks, none of which is empty.
test_threeChunks_1_2_1() - Method in class com.bigdata.striterator.TestDechunkerator
Unit test with three chunks two of which have one element each and
one of which is empty.
test_threeChunks_2_0_2() - Method in class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
Unit test with three chunks two of which have two elements each and one
of which is empty.
test_ticket416() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTEmptyGroupOptimizer
Top-level UNION optimizations.
test_ticket416() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTUnionFiltersOptimizer
https://sourceforge.net/apps/trac/bigdata/ticket/416
test_ticket538() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
Unit test for isolation semantics for a sequences of updates.
test_ticket767_case2() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTUnionFiltersOptimizer
test_ticket905() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTUnionFiltersOptimizer
This optimizer cannot help in this case.
test_ticket_1007() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
Original query as defined in bug report, reusing a URI constructed in a
BIND clause in a join:
PREFIX :
SELECT * WHERE
{
GRAPH
{
:aProperty ?literal .
test_ticket_1007_boolean1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?o
BIND (?s=?s AS ?o)
}
test_ticket_1007_boolean2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?o
BIND (?s= AS ?o)
}
test_ticket_1007_empty1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
BIND (URI("http://untypedString") AS ?o)
}
test_ticket_1007_empty2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
BIND ("10" AS ?o)
}
test_ticket_1007_freshUri() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT DISTINCT ?z
WHERE
{
?s ?p ?o
BIND (URI("http://untypedUri") AS ?z)
}
test_ticket_1007_number1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
BIND (10 AS ?o)
}
test_ticket_1007_number2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
{
?s ?o
BIND ("10.00"^^ AS ?o)
}
test_ticket_1007_number3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
{
?s ?o
BIND (10 AS ?o)
}
test_ticket_1007_number4() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
{
?s ?o
BIND (2*5 AS ?o)
}
test_ticket_1007_number5() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
{
?s ?o
BIND (xsd:integer("10") AS ?o)
}
Note: originally this query failed.
test_ticket_1007_number6() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
{
?s ?o .
test_ticket_1007_string1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
BIND ("untypedString" AS ?o)
}
test_ticket_1007_string2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
BIND (CONCAT("untyped","String") AS ?o)
}
Note: originally this query failed.
test_ticket_1007_string3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
BIND (STRAFTER("XuntypedString","X") AS ?o)
}
Note: originally this query failed.
test_ticket_1007_string4() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
?s ?p ?o
{
SELECT ?o
WHERE
{
BIND (CONCAT("untyped","String") AS ?o)
}
}
}
Note: originally this query failed.
test_ticket_1007_string5() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
SELECT ?o
WHERE
{
BIND (CONCAT("untyped","String") AS ?o)
}
Note: originally this query failed.
test_ticket_1007_subquery() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
Test problems with BIND inside and reuse of variable outside of
subquery.
test_ticket_1007b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
Modified query with join "on top", enforced through outer VALUES clause.
test_ticket_1071a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071g() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1071i() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BIND + UNION + OPTIONAL combination fails,
as reported in bug #1071 (associated test)
test_ticket_1087_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1087
Verify correct result for query:
test_ticket_1087_2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1087
Verify correct result for query:
test_ticket_1105_quads_select1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
SELECT ?s ?p ?o
FROM NAMED
WHERE { ?s ?p ?o }
runs fine in quads mode.
test_ticket_1105_quads_select2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
SELECT ?s ?p ?o
WHERE { GRAPH { ?s ?p ?o } }
runs fine in quads mode.
test_ticket_1105_quads_select3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
SELECT ?s ?p ?o
WHERE { GRAPH ?g { ?s ?p ?o } }
runs fine in quads mode.
test_ticket_1105_quads_update1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
INSERT DATA
{
GRAPH
{ }
}
is parsed successfully in quads mode.
test_ticket_1105_quads_update2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
INSERT
{ }
WHERE
{
GRAPH
{ }
}
is parsed successfully in quads mode.
test_ticket_1105_quads_update3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
INSERT
{ }
WHERE
{
GRAPH ?g
{ }
}
is parsed successfully in quads mode.
test_ticket_1105_quads_update4() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
DELETE
{ }
WHERE
{
GRAPH
{ }
}
is parsed successfully in quads mode.
test_ticket_1105_quads_update5() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
DELETE
{ }
WHERE
{
GRAPH ?g
{ }
}
is parsed successfully in quads mode.
test_ticket_1105_quads_update6() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
Query:
INSERT { }
USING
WHERE { }
is parsed successfully in quads mode.
test_ticket_1105_triples_select1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_select2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_select3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_update1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_update2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_update3() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_update4() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_update5() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1105_triples_update6() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
test_ticket_1200a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
Test for REGEX on a non-string literal (Inline IPv4)
BLZG-1780
test_ticket_1200b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
Test for REGEX on a string literal
test_ticket_1200c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
Test for REGEX on a non-string literal (Inline IPv4) with conversion
test_ticket_1200d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
Test for REGEX on a string literal with language annotation
test_ticket_1200e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
Test for REGEX on a string literal with language annotation
test_ticket_1202a() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT ?w (SAMPLE(?v) AS ?S)
{
?s :p ?v .
test_ticket_1202a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202b() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?s ?w
{
?s :p ?v .
test_ticket_1202b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202c() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (COUNT(DISTINCT ?v) AS ?S)
{
?s :p ?v .
test_ticket_1202c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202d() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?s ?w (COUNT(DISTINCT ?v) AS ?c)
{
?s :p ?v .
test_ticket_1202d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202e() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (SAMPLE(?v) AS ?S) (STR(?w) AS ?wstr)
{
?s :p ?v .
test_ticket_1202e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202f() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (COUNT(DISTINCT ?v) AS ?S) (STR(?w) AS ?wstr)
{
?s :p ?v .
test_ticket_1202f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202g() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?s ?w (STR(?w) AS ?wstr)
{
?s :p ?v .
test_ticket_1202g() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202h() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?s ?w (COUNT(DISTINCT ?v) AS ?c) (STR(?w) AS ?wstr)
{
?s :p ?v .
test_ticket_1202h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202i() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (SAMPLE(?v) AS ?S) (?w AS ?u)
{
?s :p ?v .
test_ticket_1202i() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202j() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (COUNT(DISTINCT ?v) AS ?S) (?w AS ?u)
{
?s :p ?v .
test_ticket_1202j() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202k() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?s ?w (?w AS ?u)
{
?s :p ?v .
test_ticket_1202k() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202l() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?s ?w (COUNT(DISTINCT ?v) AS ?c) (?w AS ?u)
{
?s :p ?v .
test_ticket_1202l() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202m() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT(COUNT(?w) AS ?wcnt) (SAMPLE(?v) AS ?S)
{
?s :p ?v .
test_ticket_1202m() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202n() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT(COUNT(?w) AS ?wcnt) (COUNT(DISTINCT ?v) AS ?S)
{
?s :p ?v .
test_ticket_1202n() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202o() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (COUNT(*) AS ?c)
{
?s :p ?v .
test_ticket_1202o() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202p() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT?w (COUNT(DISTINCT *) AS ?c)
{
?s :p ?v .
test_ticket_1202p() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202q() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT(COUNT(?w) AS ?u) (COUNT(*) AS ?c)
{
?s :p ?v .
test_ticket_1202q() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1202r() - Method in class com.bigdata.bop.solutions.TestGroupByOp
SELECT(COUNT(?w) AS ?u) (COUNT(DISTINCT *) AS ?c)
{
?s :p ?v .
test_ticket_1202r() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Test_Ticket_1207<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
GETSTMTS test suite for includeInferred.
Test_Ticket_1207() - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_1207
Test_Ticket_1207(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_1207
test_ticket_1207() - Method in class com.bigdata.rdf.sail.webapp.Test_Ticket_1207
Test supposed to check if remote call for getStatements properly handle includeInferred flag
test_ticket_1267a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1267a: Unable to bind result of EXISTS operator
-> query with exists evaluating to true
test_ticket_1267b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1267b: Unable to bind result of EXISTS operator
-> query with exists evaluating to false
test_ticket_1267c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1267c: Unable to bind result of EXISTS operator
-> query with two EXISTS that compare equal
test_ticket_1267d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1267d: Unable to bind result of EXISTS operator
-> query with two NOT EXISTS that compare unequal
test_ticket_1346a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
DistinctTermScanOp is not retrieving all data.
test_ticket_1346b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
DistinctTermScanOp is not retrieving all data.
test_ticket_1346c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
DistinctTermScanOp is not retrieving all data.
test_ticket_1346d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
DistinctTermScanOp is not retrieving all data.
test_ticket_1346e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
DistinctTermScanOp is not retrieving all data.
test_ticket_1346f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
DistinctTermScanOp is not retrieving all data.
test_ticket_1395a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1395: Multiple OPTIONAL statements in a UNION fail to retrieve results
-> https://jira.blazegraph.com/browse/BLZG-1395
test_ticket_1395b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1395: Multiple OPTIONAL statements in a UNION fail to retrieve results
-> https://jira.blazegraph.com/browse/BLZG-1395
test_ticket_1395c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1395: Multiple OPTIONAL statements in a UNION fail to retrieve results
-> https://jira.blazegraph.com/browse/BLZG-1395
test_ticket_1463a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Query having *no* bottom-up issues.
test_ticket_1463b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Query having bottom-up issues.
test_ticket_1463c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Same as 1463a, just nested into subquery.
test_ticket_1463d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Same as 1463b, just nested into subquery.
test_ticket_1498() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1498: Query hint optimizer:None ignored for property
path queries.
test_ticket_1542a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1542b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1524: MINUS being ignored.
test_ticket_1591a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1591
test_ticket_1591b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1591
test_ticket_1627a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1627: minus fails when preceded by property path.
test_ticket_1627b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1627b: minus fails when preceded by property path.
test_ticket_1627c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1627c: minus fails when preceded by property path
- variant of 1627a with different style of property path.
test_ticket_1627d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1627d: minus fails when preceded by property path
- variant of 1627d with different style of property path.
test_ticket_1643a_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
with literal in object position (analytic version).
test_ticket_1643a_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service,
with literal in object position (non-analytic equivalent).
test_ticket_1643b_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
with URI in object position (analytic version).
test_ticket_1643b_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service,
with URI in object position (non-analytic equivalent).
test_ticket_1643c_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(analytic mode).
test_ticket_1643c_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(non-analytic equivalent).
test_ticket_1643d_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(analytic mode).
test_ticket_1643d_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(non-analytic equivalent).
test_ticket_1643e_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(analytic mode).
test_ticket_1643e_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(non-analytic equivalent).
test_ticket_1643f_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(analytic mode).Version with literal where FILTER does not apply
because of datatype in literal.
test_ticket_1643f_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(non-analytic equivalent).
test_ticket_1643g_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(analytic mode).Version with literal where FILTER applies
because of datatype in literal.
test_ticket_1643g_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1643: DELETE does not delete properly with Wikidata Query service
(non-analytic equivalent).
test_ticket_1648a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1648: proper handling of join constraints in merge join.
test_ticket_1648b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 1648: proper handling of join constraints in merge join.
test_ticket_1683a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1683: Required property relationName for HTreeDistinctBindingSetsOp
(analytic version).
test_ticket_1683b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1683: Required property relationName for HTreeDistinctBindingSetsOp
(non-analytic version).
Test_Ticket_1717<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
GETSTMTS test suite for not resolved numeric IVs in Bind.
Test_Ticket_1717() - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_1717
Test_Ticket_1717(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_1717
test_ticket_1717() - Method in class com.bigdata.rdf.sail.webapp.Test_Ticket_1717
Test supposed to check if constants in BIND expressions will be resolved
test_ticket_1748a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1748: Regressions in date comparison
test_ticket_1748b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1748: Regressions in date comparison
test_ticket_1750() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1750: DESCRIBE and UNION.
test_ticket_1760a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1760: HAVING incorrectly says "Non-aggregate variable in select expression"
test_ticket_1760b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1760: HAVING incorrectly says "Non-aggregate variable in select expression"
test_ticket_1760c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1760: HAVING incorrectly says "Non-aggregate variable in select expression"
test_ticket_1763a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1763: Wildcard projection was not rewritten
-> original example without data, producing the empty result
test_ticket_1763b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1763: Wildcard projection was not rewritten
-> modified example with data
test_ticket_1780a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
Test that the query without the query hint fails.
test_ticket_1817() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1817: reordering inside complex subqueries that will
be translated into NSIs.
test_ticket_1892b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1892c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1892d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1892e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1892f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_1892h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Test_Ticket_1893 - Class in com.bigdata.rdf.sail.webapp
This test checks if plain literals and string literals are properly indexed in FTS,
and also rebuild text index produces properly indexed FTS.
Test_Ticket_1893(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_1893
test_ticket_1957() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-1957: PipelinedHashJoin defect in combination with VALUES clause
test_ticket_2066() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket: https://jira.blazegraph.com/browse/BLZG-2066
AssertionError in path query with MINUS
=> testing a variant of the query given in the test case
Test_Ticket_2091 - Class in com.bigdata.rdf.sail.webapp
This test checks if constants in projection expressions are properly resolved.
Test_Ticket_2091(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_2091
test_ticket_384() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
SELECT * WHERE {{}}
test_ticket_429a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Covering GRAPH {} with in dictionary existing and matching URI
test_ticket_429b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Covering GRAPH {} with non-existing and (thus) non-matching URI
test_ticket_429c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Covering GRAPH {} with in dictionary existing but non-matching URI
test_ticket_4323a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket4323
Test case asserting proper treatment of runFirst query hint for subquery.
test_ticket_4323b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket4323
Test case asserting proper treatment of runFirst query hint for complex
subquery, which is transformed into a named subquery include.
test_ticket_5590a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket5590
ORIGINAL QUERY:
SELECT * WHERE {
?item // ?x .
test_ticket_562() - Method in class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
INSERT {
GRAPH { ?s ?p ?v .
test_ticket_563() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
PREFIX ex:
SELECT DISTINCT ?sub WHERE {
?sub ex:hasName ?name.
Test_Ticket_605<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Test_Ticket_605() - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_605
Test_Ticket_605(String) - Constructor for class com.bigdata.rdf.sail.webapp.Test_Ticket_605
test_ticket_605() - Method in class com.bigdata.rdf.sail.webapp.Test_Ticket_605
A Java version of the scala example.
test_ticket_611a_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(analytic mode).
test_ticket_611a_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(non-analytic equivalent).
test_ticket_611b_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(analytic mode).
test_ticket_611b_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(non-analytic equivalent).
test_ticket_611c_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(analytic mode).
test_ticket_611c_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(non-analytic equivalent).
test_ticket_611d_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(analytic mode).
test_ticket_611d_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(non-analytic equivalent).
test_ticket_611e_analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(analytic mode).
test_ticket_611e_nonanalytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket 611: Mock IV / TermId hashCode()/equals() problems
(non-analytic equivalent).
test_ticket_618a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_618b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_618c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_618d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_618e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_709() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Covering GRAPH ?x {}
test_ticket_739() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_739a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_739b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_739c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_739d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_739e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_740() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBlockingBufferPerformance740
This test measures the percent utilization by comparing CPU time
with wall clock time.
test_ticket_747() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_747a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_747b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_747c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_747d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_748() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_748a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_765() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_792a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Propagation of named graph specifications inside FILTER NOT EXISTS
clauses, as reported in bug #792/#888
test_ticket_792b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Propagation of named graph specifications inside FILTER NOT EXISTS
clauses, as reported in bug #792/#888 (inverse test)
test_ticket_792c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Propagation of named graph specifications inside FILTER EXISTS
clauses, as reported in bug #792/#888 (associated test)
test_ticket_792d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Propagation of named graph specifications inside FILTER EXISTS
clauses, as reported in bug #792/#888 (associated test)
test_ticket_801a_complex_optionals() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
test_ticket_801b_complex_optionals() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
In this variant, one of the child join groups is OPTIONAL rather than
required.
test_ticket_806() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_832a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Original test case associated with ticket 832.
test_ticket_832b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Propagation of named graph specification inside subqueries,
simple one level propagation.
test_ticket_832c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Propagation of named graph specifications inside subqueries,
advanced two-level propagation.
test_ticket_835a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_835b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_835c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_835d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_852a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-852: MINUS and UNION.
test_ticket_852b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-852: MINUS and UNION.
test_ticket_887_bind() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket887
SELECT *
WHERE {
GRAPH ?g {
BIND( "hello" as ?hello ) .
test_ticket_911a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-911: FROM NAMED clause doesn't work properly
test_ticket_911b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
BLZG-911: FROM NAMED clause doesn't work properly
test_ticket_933a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Nested OPTIONAL-BIND construct
test_ticket_933b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Nested OPTIONAL-BIND construct, advanced
test_ticket_933c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Similiar to 933a, but with statement patterns instead of BIND clause.
test_ticket_933d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Similiar to 933b, but with statement patterns instead of BIND clause.
test_ticket_933e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Optional translation approach issues mentioned in ticket #933.
test_ticket_946_empty_projection() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket946
SELECT ?x
{ BIND(1 as ?x)
{ SELECT * { FILTER (true) } }
}
test_ticket_bad_projection_748() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_bg1141() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Strategies for VALUES+BIND queries
test_ticket_bg1256() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Combination of VALUES clause and SERVICE keyword
test_ticket_bg1296a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Testing proper use of VALUES clause inside named subqueries.
test_ticket_bg1296b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Testing proper use of VALUES clause inside named subqueries.
test_ticket_bg1296c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Testing proper use of VALUES clause inside named subqueries.
test_ticket_bg1296d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Testing proper use of VALUES clause inside named subqueries.
test_ticket_bg1299() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Duplicate in VALUES get replicated problem
test_ticket_bg1899_a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for property paths induced hash index.
test_ticket_bg1899_b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for subquery induced hash index.
test_ticket_bg1899_c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for complex join group induced hash index.
test_ticket_bg1899_d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for FILTER EXISTS induced hash index.
test_ticket_bg1899_e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for proper reconstruction of cache from HTree
index for URIs.
test_ticket_bg1899_f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for proper reconstruction of cache from HTree
index for literals.
test_ticket_bg1899_g() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for proper reconstruction of cache from HTree
index for large literals (BLOBS).
test_ticket_bg1899_h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for proper reconstruction of cache from HTree
index for numerics.
test_ticket_bg1899_i() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for OPTIONAL join, where we have no materialization
guarantees at all.
test_ticket_bg1899_j() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
Test case for EXISTS join, where we have no materialization
guarantees at all.
test_ticket_bg48a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Problem with multiple VALUES clauses, as described in
test_ticket_bg48b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Problem with multiple VALUES clauses, as described in
test_ticket_bg48c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Problem with multiple VALUES clauses, as described in
test_ticket_bg50a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Problem with multiple VALUES clauses, as described in
test_ticket_bg50b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Problem with multiple VALUES clauses, as described in
test_ticket_bg50c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Problem with multiple VALUES clauses, as described in
test_ticket_bg876c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Isues with placement of BIND.
test_ticket_bg876d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Isues with placement of BIND.
test_ticket_bg876e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Isues with placement of BIND.
test_ticket_blzg_1021a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Unsound translation of FILTER (NOT) EXISTS.
test_ticket_blzg_1021b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Unsound translation of FILTER (NOT) EXISTS.
test_ticket_blzg_1021c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Unsound translation of FILTER (NOT) EXISTS.
test_ticket_blzg_1021d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Unsound translation of FILTER (NOT) EXISTS.
test_ticket_blzg_1021e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021g() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021i() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021j() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021k() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1021l() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Translation of complex FILTER expressions.
test_ticket_blzg_1113a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
* does not include var only set in values
test_ticket_blzg_1113b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
* does not include var only set in values
test_ticket_blzg_1113c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
* does not include var only set in values
test_ticket_blzg_1113d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
* does not include var only set in values
test_ticket_blzg_1281a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Double nesting of FILTER NOT EXISTS.
test_ticket_blzg_1281b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Double nesting of FILTER NOT EXISTS.
test_ticket_blzg_1284a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Placement of filters in presence of other FILTER NOT EXISTS
clauses.
test_ticket_blzg_1284b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Placement of filters in presence of other FILTER NOT EXISTS
clauses.
test_ticket_blzg_1300() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1331a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1331b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1380() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Filter Not Exists RC1 Broken.
test_ticket_blzg_1475a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475g() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1475h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1493() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1494a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1494b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_blzg_1495() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_max736() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_max736_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_max736_2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_min736() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_min736_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_min736_2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_two_subselects_748() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_ticket_two_subselects_748a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
test_timestampSemantics() - Method in class com.bigdata.sparse.TestSparseRowStore
Test the semantics of timestamps associated with property values by
atomic row writes.
test_tiny() - Method in class com.bigdata.rdf.store.TestInsertRate
test_toAddr_correctRejection_byteCount() - Method in class com.bigdata.rawstore.TestWormAddressManager
test_toAddr_correctRejection_byteOffset() - Method in class com.bigdata.rawstore.TestWormAddressManager
test_toBitString_correctRejection() - Method in class com.bigdata.btree.TestBytesUtil
test_toBitString_emptyByteArray() - Method in class com.bigdata.btree.TestBytesUtil
test_toBitString_oneByte() - Method in class com.bigdata.btree.TestBytesUtil
test_toBitString_twoBytes() - Method in class com.bigdata.btree.TestBytesUtil
test_toDD() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDDM
test_toDD() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateDMS
Test conversion to decimal degrees.
test_toDegrees() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateUtility
test_toldBNodes() - Method in class com.bigdata.rdf.lexicon.TestAddTerms
The "told bnodes" mode uses the blank node ID as specified rather than
assigning one based on a UUID.
test_toRadians() - Method in class com.bigdata.rdf.internal.gis.TestCoordinateUtility
test_touch01() - Method in class com.bigdata.btree.TestTouch
Test verifies that the reference counter is incremented when a node is
appended to the hard reference queue (the scan of the tail of the queue
is disabled for this test).
test_touch02() - Method in class com.bigdata.btree.TestTouch
test_touch03() - Method in class com.bigdata.btree.TestTouch
Test verifies that touching a node when the queue is full and the node is
the next reference to be evicted from the queue does NOT cause the node
to be made persistent.
test_transferAllFrom() - Method in class com.bigdata.io.TestFileChannelUtility
Test of
FileChannelUtility#transferAll(FileChannel, long, long, RandomAccessFile)
on 20M of random data using a bunch of transfer of different sizes from
different positions in the source file.
test_trim() - Method in class com.bigdata.io.TestByteArrayBuffer
test_triple_pattern_const_const_const() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting
of a constant, a variable, and a constant.
test_triple_pattern_const_const_var() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting
of a constant, a constant, and a variable.
test_triple_pattern_const_var_const() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting
of a constant, a variable, and a constant.
test_triple_pattern_const_var_var() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting
of a constant, a variable, and a variable.
test_triple_pattern_var_const_var() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting
of a variable, a constant, and a variable.
test_triple_pattern_var_var_const() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting
of a variable, a variable, and a constant.
test_triple_pattern_var_var_var() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for simple triple pattern in the default context consisting of
three variables.
test_triple_pattern_with_named_graph_group() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Unit test for the join of a triple pattern with a join group containing
only a single triple pattern.
test_triple_pattern_with_simple_join_group() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Unit test for the join of a triple pattern with a join group containing
only a single triple pattern.
test_triple_ref_pattern_all_vars() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
A unit test when the triple reference pattern is a constant.
test_triple_ref_pattern_all_vars2() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
A unit test when the triple reference pattern is a constant.
test_triple_ref_pattern_all_vars_with_explicit_bind() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
A unit test when the triple reference pattern is a constant.
test_triple_ref_pattern_blankNodesAreNotAllowed_objectPosition() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
Unit test verifies that blank nodes may not appear in a triple pattern
reference (the semantics of this are explicitly ruled out by the
extension).
test_triple_ref_pattern_blankNodesAreNotAllowed_subjectPosition() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
Unit test verifies that blank nodes may not appear in a triple pattern
reference (the semantics of this are explicitly ruled out by the
extension).
test_triple_ref_pattern_is_constant() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
A unit test when the triple reference pattern is a constant.
test_triple_ref_pattern_nested_in_object_position() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
A unit test when the triple reference pattern recursively embeds another
triple reference pattern in the object position.
test_triple_ref_pattern_nested_in_subject_position() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
A unit test when the triple reference pattern recursively embeds another
triple reference pattern in the subject position.
test_triple_ref_pattern_no_vars() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
Unit test for a triple reference pattern without variables.
test_triple_ref_pattern_var_const_const() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
Unit test for a triple reference pattern using an explicit BIND().
test_triplePattern_join_subSelect() - Method in class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
Unit test for simple subquery joined with a triple pattern in the outer
join group.
test_tripleStoreKeyOrders_iterator() - Method in class com.bigdata.rdf.spo.TestSPOKeyOrder
test_tupleCount1() - Method in class com.bigdata.btree.data.AbstractNodeDataRecordTestCase
This the minimum legal node for a branching factor of 3.
test_tupleCount1_emptyKey_deleted() - Method in class com.bigdata.btree.data.AbstractLeafDataRecordTestCase
A single, empty key (byte[0]) paired with a delete marker.
test_tupleCount1_emptyKey_largeVal() - Method in class com.bigdata.btree.data.AbstractLeafDataRecordTestCase
A single empty key (byte[0]) paired with a large value represented as a
raw record.
test_tupleCount1_emptyKey_nullVal() - Method in class com.bigdata.btree.data.AbstractLeafDataRecordTestCase
A single empty key (byte[0]) paired with a null
value.
test_tupleCount1WithVersionTimestamps() - Method in class com.bigdata.btree.data.AbstractNodeDataRecordTestCase
This the minimum legal node for a branching factor of 3.
test_tupleCount2VersionTimestamps() - Method in class com.bigdata.btree.data.AbstractLeafDataRecordTestCase
A leaf w/ two keys and version timestamps.
test_two_dups() - Method in class com.bigdata.bop.rdf.filter.TestSameVariableConstraint
test_two_nested_opt() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
Nested Optionals - 1
.
test_two_nested_opt2() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
This is the same query, except we are running the rewritten version of
the query (that is, the version that we have to produce for the query
above with the badly designed left join).
test_two_simple_join_groups() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Unit test for two groups, each consisting of one triple pattern.
test_twoChunks() - Method in class com.bigdata.btree.TestChunkedIterators
Test where the iterator has to fetch a second
ResultSet
.
test_twoChunks_oneElementEach() - Method in class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
Unit test with two chunks with one element each.
test_twoChunks_oneElementEach() - Method in class com.bigdata.striterator.TestDechunkerator
Unit test with two chunks with one element each.
test_TwoNamespaceCreation() - Method in class com.bigdata.rdf.internal.TestMultiInlineURIHandlersSingleNamespace
test_twoPartitions() - Method in class com.bigdata.service.TestBasicIndexStuff
Tests a variety of operations on a scale-out index with two index
partitions.
test_twothreadIndexCreationRate() - Method in class com.bigdata.journal.StressTestGroupCommit
Measures the maximum rate at which two threads can register named
indices.
test_tx_begin_addStatement_commit() - Method in class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository.ReadWriteTx
Basic test creates a read/write connection, issues begin(), and then
issues commit() on the connection.
test_tx_begin_commit() - Method in class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository
Basic test creates a read/write connection, issues begin(), and then
issues commit() on the connection.
test_tx_begin_rollback() - Method in class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository
Basic test creates a read/write connection, issues begin(), and then
issues rollback() on the connection.
test_tx_begin_UPDATE_commit() - Method in class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository.ReadWriteTx
Basic test creates a read/write connection, issues begin(), and then
issues commit() on the connection.
test_tx_create() - Method in class com.bigdata.rdf.sail.TestTxCreate
Version of the test with data time inlining disabled.
test_tx_create_withInlineDateTimes() - Method in class com.bigdata.rdf.sail.TestTxCreate
Version of the test with data time inlining enabled.
test_TX_STUFF() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_TX_API.NoReadWriteTx
test_TX_STUFF() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_TX_API.ReadWriteTx
test_txIsolation() - Method in class com.bigdata.rdf.store.TestLocalTripleStoreTransactionSemantics
A unit test for some of the basic functionality for a triple store or
quad store using full transactions.
test_type_casts_long() - Method in class com.bigdata.rdf.sparql.ast.eval.TestCustomTypeCasts
Casting to xsd:long (non-standard extension).
test_type_casts_unsigned_long() - Method in class com.bigdata.rdf.sparql.ast.eval.TestCustomTypeCasts
Casting to xsd:unsignedLong (non-standard extension).
test_union() - Method in class com.bigdata.bop.controller.TestUnion
Verifies that the UNION of two operators is computed.
test_union() - Method in class com.bigdata.rdf.rules.TestUnion
test_union_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
SELECT ?p ?o
WHERE {
{
?p ?o .
test_union_01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTEmptyGroupOptimizer
A test case where we can not eliminate an empty join group in a UNION.
test_union_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
select distinct ?s
where { {
?s a foaf:Person .
test_union_03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
select distinct ?s
where { {
?s a foaf:Person .
test_union_04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
select distinct ?s
where { {
?s a foaf:Person .
test_union_05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
SELECT ?p ?o ?s
WHERE {
{
?p ?o .
test_union_06() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
test_union_07() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
test_union_08() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
test_union_consumesSource() - Method in class com.bigdata.bop.controller.TestUnion
test_union_defaultInputs() - Method in class com.bigdata.bop.controller.TestUnion
Verifies that the UNION of two operators is computed.
test_union_four_groups() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Test union of four groups.
test_union_minus_02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnionMinus
test_union_minus_09() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnionMinus
test_union_three_groups() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Test union of three groups.
test_union_ticket_831() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
test_union_ticket_874() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
The original query.
test_union_ticket_874b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
A rewrite of the original query that works.
test_union_ticket_944() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
This is DAWG sparql11-subquery-05.
test_union_trac684_A() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_union_trac684_B() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_union_trac684_C() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
test_union_two_groups() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Test union of two groups.
test_union_two_groups_with_embedded_union() - Method in class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
Test union of two groups with an embedded union in the third group.
test_union_with_empty() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnions
PREFIX dc:
PREFIX :
PREFIX ns:
SELECT ?book
{
{}
UNION
{ ?book dc:title ?title }
}
test_units() - Method in class com.bigdata.io.TestIO
test_unsigned() - Method in class com.bigdata.rdf.lexicon.TestInlining
Unsigned numerics should not be inlined at this time.
test_unsigned_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnsigned
test_unsignedByteInc() - Method in class com.bigdata.btree.TestBytesUtil
Test logic to add one to an unsigned byte in Java.
test_unsynchronizedBuffer1() - Method in class com.bigdata.relation.accesspath.TestUnsynchronizedArrayBuffer
test_unsynchronizedBuffer2() - Method in class com.bigdata.relation.accesspath.TestUnsynchronizedArrayBuffer
test_unused() - Method in class com.bigdata.journal.TestRootBlockView
Unit test verifies that we have not run out of space in the root block
record.
test_update_insert_data_RDR() - Method in class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
INSERT DATA {
<:s> <:p> "d" .
test_updateClosure_001() - Method in class com.bigdata.concurrent.TestTxDag
Tests of the update to the internal matrix M[u,v].
test_updateClosure_002() - Method in class com.bigdata.concurrent.TestTxDag
A sequence of tests of the internal state of the
TxDag
with a
capacity of
4
after adding an edge.
test_updateLargeValueWithLargeValue() - Method in class com.bigdata.btree.TestRawRecords
Unit test in which we update a large value (represented directly on the
backing store) with another large value (also represented directly on the
store).
test_updateLargeValueWithSmallValue() - Method in class com.bigdata.btree.TestRawRecords
Unit test in which we update a large value (represented directly on the
backing store) with a small value (inline within the leaf).
test_updateReleaseTime_noTxRemaining() - Method in class com.bigdata.journal.TestTransactionService
Test verifies the advance of the release time when the earliest running
transaction completes.
test_updateReleaseTime_otherTxStillActive() - Method in class com.bigdata.journal.TestTransactionService
A unit test of advancing the last release time for the case where there
are still active transactions running once the earliest active
transaction commits.
test_updateSmallValueWithLargeValue() - Method in class com.bigdata.btree.TestRawRecords
Unit test in which we update a small value (inline within the leaf) with
a large value (stored as a raw record).
test_uri() - Method in class com.bigdata.rdf.lexicon.TestLexiconKeyBuilder
test_uri_ordering() - Method in class com.bigdata.bop.solutions.TestIVComparator
Unit test of the relative ordering of URIs.
test_URIs() - Method in class com.bigdata.rdf.model.TestBigdataValueSerialization
Test round trip of some URIs.
test_UUID() - Method in class com.bigdata.rdf.internal.TestDTE
test_validate() - Method in class com.bigdata.btree.isolation.TestIsolatedFusedView
Unit test for validating a write set against the current ground state.
test_ValueBound_pattern() - Method in class com.bigdata.rdf.lexicon.TestLexAccessPatternEnum
test_valueOf() - Method in class com.bigdata.bop.TestNamedSolutionSetRef
test_valueRabaSetup() - Method in class com.bigdata.btree.raba.codec.TestCanonicalHuffmanRabaCoder
Unit test for processing an
IRaba
representing B+Tree values
suitable to setup the data for compression.
test_var_scope_join_1() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTCK
Classic badly designed left join.
test_variable_not_rewritten() - Method in class com.bigdata.bop.solutions.TestGroupByRewriter
Test that a bare variable is NOT rewritten.
test_variableSingletonDeserialization() - Method in class com.bigdata.bop.TestVar
test_variableSingletonFactory() - Method in class com.bigdata.bop.TestVar
Test the singleton factory for
Var
s.
test_verifyunsigned() - Method in class com.bigdata.rdf.lexicon.TestInlining
Verify inlined unsigned numeric values
test_versionedSerialization() - Method in class com.bigdata.rdf.lexicon.TestId2TermTupleSerializer
A unit test of the proposal for introducing backward compatible
versioning into an unversioned class.
test_virtualGraphs_01() - Method in class com.bigdata.rdf.sail.sparql.TestVirtualGraphs
PREFIX foaf:
PREFIX dc:
SELECT ?who ?g ?mbox
FROM
FROM NAMED VIRTUAL GRAPH :vg
WHERE
{
?g dc:publisher ?who .
test_virtualGraphs_02() - Method in class com.bigdata.rdf.sail.sparql.TestVirtualGraphs
PREFIX foaf:
PREFIX dc:
SELECT ?who ?g ?mbox
FROM
FROM VIRTUAL GRAPH :vg
WHERE
{
?g dc:publisher ?who .
test_virtualGraphs_default_graphs_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestVirtualGraphs
This test was developed from default-graphs-01f
.
test_virtualGraphs_named_graphs_01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestVirtualGraphs
This test is a named graphs variant on the test above.
test_vmstat_header_and_data_parse() - Method in class com.bigdata.counters.linux.TestParsing
Test based on some sample data.
test_vmstat_header_and_data_parse() - Method in class com.bigdata.counters.osx.TestParse_vm_stat
Test based on some sample data.
test_voting() - Method in class com.bigdata.quorum.TestSingletonQuorumSemantics
Unit test for the voting protocol for a singleton quorum.
test_voting3() - Method in class com.bigdata.quorum.TestHA3QuorumSemantics
Unit test for the voting protocol.
test_VTE_decodeNoErrors() - Method in class com.bigdata.rdf.internal.TestVTE
Unit test for
VTE
verifies that all legal byte
values decode to an internal value type enum (basically, this checks that
we mask the two lower bits).
test_VTE_selfConsistent() - Method in class com.bigdata.rdf.internal.TestVTE
Unit test for
VTE
verifies that the
correspondence between the enumerated types and the internal values is
correct (self-consistent).
test_webapp_structure_contextPath() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
URL with correct context path
test_webapp_structure_contextPath() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
URL with correct context path
test_webapp_structure_contextPath_html_indexHtml() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
The fully qualified URL for index.html
test_webapp_structure_contextPath_html_indexHtml() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
The fully qualified URL for index.html
test_webapp_structure_contextPath_indexHtml() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
URL with context path and index.html reference
test_webapp_structure_contextPath_indexHtml() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
URL with context path and index.html reference
test_webapp_structure_counters() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
The /counters
servlet responds.
test_webapp_structure_counters() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
The /counters
servlet responds.
test_webapp_structure_favicon() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
The favicon.ico
file.
test_webapp_structure_favicon() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
The favicon.ico
file.
test_webapp_structure_rootURL() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
bare URL of the server
test_webapp_structure_rootURL() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
bare URL of the server
test_webapp_structure_status() - Method in class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
The /status
servlet responds.
test_webapp_structure_status() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
The /status
servlet responds.
test_wellDesigned01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTBottomUpOptimizer
test_wellDesigned02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTBottomUpOptimizer
Slight variation on the structure of the query in the test above which
should not be recognized as a badly designed left join.
test_wellDesigned03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTBottomUpOptimizer
Slight variation on the structure of the query in the test above which
should not be recognized as a badly designed left join.
test_wildcard_nestedSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
SELECT *
JoinGroupNode {
SELECT (*) {
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(2U)[http://example/p]), VarNode(o), DEFAULT_CONTEXTS)
}
}
StatementPatternNode(VarNode(s), ConstantNode(TermId(3U)[http://example/q]), VarNode(x), DEFAULT_CONTEXTS)
}
test_wildcardProjectionOptimizer00() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
SELECT *
JoinGroupNode {
UnionNode {
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(2U)[http://example/p]), VarNode(o), DEFAULT_CONTEXTS)
}
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(3U)[http://example/q]), VarNode(o), DEFAULT_CONTEXTS)
}
}
}
test_wildcardProjectionOptimizer01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
SELECT DISTINCT *
JoinGroupNode {
UnionNode {
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(2U)[http://example/p]), VarNode(o), DEFAULT_CONTEXTS)
}
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(3U)[http://example/q]), VarNode(o), DEFAULT_CONTEXTS)
}
}
}
test_wildcardProjectionOptimizer02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
SELECT REDUCED *
JoinGroupNode {
UnionNode {
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(2U)[http://example/p]), VarNode(o), DEFAULT_CONTEXTS)
}
JoinGroupNode {
StatementPatternNode(VarNode(s), ConstantNode(TermId(3U)[http://example/q]), VarNode(o), DEFAULT_CONTEXTS)
}
}
}
test_wildcardProjectionOptimizer03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
Given the query:
test_with_constant() - Method in class com.bigdata.bop.solutions.TestGroupByState
Unit test when projecting a constant
test_with_constant() - Method in class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
Unit test when projecting a constant
test_with_having() - Method in class com.bigdata.bop.solutions.TestGroupByRewriter
Test that
IAggregate
expressions are also lifted out of a HAVING
clause.
test_with_predicate_list_and_object_list() - Method in class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
Unit test for a complex triples block using both a predicate list and an
object list.
test_with_subselect() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubSelectFilterExist725
test_withNulls() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
Test with a null value.
test_withNulls2() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
Test with a single value, which is null.
test_withOptionalJoins() - Method in class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup
A test when there are optional joins involved.
test_without_subselect() - Method in class com.bigdata.rdf.sparql.ast.eval.TestSubSelectFilterExist725
test_work_around_graph_var() - Method in class com.bigdata.rdf.sparql.ast.eval.TestGraphEmptyPattern709_429
test_wrapTempTripleStore() - Method in class com.bigdata.rdf.sail.TestTicket422
test_write01() - Method in class com.bigdata.bfs.TestRandomBlockOps
Tests random write of a block, read back of the data, overwrite of the
same block, atomic append after the random write, and random delete.
test_write02() - Method in class com.bigdata.bfs.TestRandomBlockOps
Unit test where a block is written using a random write, replaced with an
empty block, and then replaced with a non-empty block.
test_write_correctRejection_emptyRecord() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Test verifies correct rejection of a write operation when the caller
supplies an empty buffer (no bytes remaining).
test_write_correctRejection_null() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Test verifies correct rejection of a write operation when the caller
supplies a [null] buffer.
test_write_flush_update() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Ttest write() + flush() + update() - for this case the data have been
flushed from the write cache so the update will be a random write on
the file rather than being buffered by the write cache.
test_write_read01() - Method in class com.bigdata.btree.TestIndexSegmentCheckpoint
Test the ability to create an
IndexSegmentCheckpoint
record, write
it on a file, and read back the same data from the file.
test_writeCache01() - Method in class com.bigdata.io.writecache.TestWriteCache
Exercises most of the API.
test_writeCacheChecksums() - Method in class com.bigdata.io.writecache.TestWriteCache
Confirm checksum errors
test_writeCacheScatteredWrites() - Method in class com.bigdata.io.writecache.TestWriteCache
Similar to writeCache01 but uses the ScatteredWrite.
test_writeCacheService_HA_RW_1buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, one buffer
and the default #of records written and the default percentage of large
records.
test_writeCacheService_HA_RW_1record_1buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, one buffer,
and one record written.
test_writeCacheService_HA_RW_2buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, two buffers
and the default #of records written and the default percentage of large
records.
test_writeCacheService_HA_RW_2buffer_k3_size3() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 3 running services, six buffers
and the default #of records written and the default percentage of large
records.
test_writeCacheService_HA_RW_7buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, two buffers
and the default #of records written and the default percentage of large
records.
test_writeCacheService_HA_WORM_1buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, one buffer
and the default #of records written and the default percentage of large
records.
test_writeCacheService_HA_WORM_1record_1buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, one buffer,
and one record written.
test_writeCacheService_HA_WORM_1record_1buffer_k3_size2_reorganizePipeline() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, one buffer,
and one record written where the leader must reorganize the write
pipeline when it is elected.
test_writeCacheService_HA_WORM_1record_1buffer_k3_size3_reorganizePipeline() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 3 running services, one buffer,
and one record written where the leader must reorganize the write
pipeline when it is elected.
test_writeCacheService_HA_WORM_2buffer_k3_size2() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 2 running services, two buffers
and the default #of records written and the default percentage of large
records.
test_writeCacheService_HA_WORM_2buffer_k3_size3() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test of the write pipeline driving from the
WriteCacheService
of the leader using a quorum with k := 3, 3 running services, six buffers
and the default #of records written and the default percentage of large
records.
test_writeCacheService_RW_1buffer() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test which looks for deadlock conditions (one buffer).
test_writeCacheService_RW_2buffers() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test which looks for starvation conditions (2 buffers).
test_writeCacheService_RW_6buffers_recordChecksums() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A high throughput configuration with record level checksums.
test_writeCacheService_RW_6buffers_recordChecksums_wholeBufferChecksums() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A high throughput configuration with record level checksums and whole
buffer checksums.
test_writeCacheService_WORM_1buffer() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test which looks for deadlock conditions (one buffer).
test_writeCacheService_WORM_2buffers() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A test which looks for starvation conditions (2 buffers).
test_writeCacheService_WORM_6buffers_recordChecksums() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A high throughput configuration with record level checksums.
test_writeCacheService_WORM_6buffers_recordChecksums_wholeBufferChecksums() - Method in class com.bigdata.io.writecache.TestWORMWriteCacheService
A high throughput configuration with record level checksums and whole
buffer checksums.
test_writeCacheStressScatteredWrites() - Method in class com.bigdata.io.writecache.TestWriteCache
Generate large number of scattered writes to force flushing
test_writeCheckpoint_btree() - Method in class com.bigdata.btree.TestBTreeRecycle
Unit test examines case of a
BTree
without a bloom filter.
test_writeCheckpoint_btree_bloomFilter() - Method in class com.bigdata.btree.TestBTreeRecycle
Unit test examines case of a
BTree
with a bloom filter.
test_writeImmutable() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Test verifies that write does not permit changes to the store state by
modifying the supplied buffer after the write operation (i.e., a copy
is made of the data in the buffer).
test_writeIsolation() - Method in class com.bigdata.journal.TestTx
Test verifies that an isolated write is visible inside of a transaction
(tx1) but not in a concurrent transaction (tx2) and not in the unisolated
index until the tx1 commits.
test_writeManyIndices() - Method in class com.bigdata.journal.TestUnisolatedWriteTasks
This is an N index stress test designed to verify that all indices
receive their writes in a large commit group.
test_writeNoExtend() - Method in class com.bigdata.journal.AbstractBufferStrategyTestCase
Test verifies that a write up to the remaining extent does not trigger
an overflow.
test_writeNoExtend() - Method in class com.bigdata.journal.TestTemporaryStore
Test verifies that a write up to the remaining extent does not trigger an
overflow.
test_writeOneIndex() - Method in class com.bigdata.journal.TestUnisolatedWriteTasks
Test creates a named index and writes a set of entries on that index
using an unisolated write task.
test_writeRead() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Test verifies that we can write and then read back a record.
test_writeReadRead() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Test verifies that we can write and then read back a record twice.
test_writeReadRetract() - Method in class com.bigdata.rdf.rules.TestJustifications
test_writeServiceCheckpointDirtyIndex() - Method in class com.bigdata.journal.TestConcurrentJournal
Test verifies that a write on an index will cause the index to be
checkpointed when the task completes.
test_writeSetIsolation() - Method in class com.bigdata.btree.isolation.TestIsolatedFusedView
Unit test examines the propagation of timestamps from the ground state
into the isolated write set with both insert() and remove() operations.
test_writeTwoIndex() - Method in class com.bigdata.journal.TestUnisolatedWriteTasks
Test creates two named indices and writes a set of distinct entries on
each index using a single unisolated write task to write on both indices.
test_writeWithExtend() - Method in class com.bigdata.journal.AbstractBufferStrategyTestCase
Test verifies that a write over the remaining extent triggers an
overflow.
test_writeWithExtend() - Method in class com.bigdata.journal.TestTemporaryStore
Test verifies that a write over the remaining extent triggers an
overflow.
test_writeWithPrecondition() - Method in class com.bigdata.sparse.TestSparseRowStore
test_writeWriteConflict_conflictIsResolved() - Method in class com.bigdata.btree.isolation.TestConflictResolution
Test correct detection and resolution of a write-write conflict.
test_writeWriteConflict_correctDetection() - Method in class com.bigdata.btree.isolation.TestConflictResolution
Test correct detection of a write-write conflict.
test_XML() - Method in class com.bigdata.counters.store.TestCounterSetBTree
Unit test reads some known data from a local test resource.
test_xml() - Method in class com.bigdata.counters.TestCounters
Test of XML (de-)serialization.
test_xpath_abs_01() - Method in class com.bigdata.rdf.internal.TestXPathFunctions
test_xpath_ceiling_01() - Method in class com.bigdata.rdf.internal.TestXPathFunctions
test_xpath_floor_01() - Method in class com.bigdata.rdf.internal.TestXPathFunctions
test_xpath_round_01() - Method in class com.bigdata.rdf.internal.TestXPathFunctions
Unit test for FunctionRegistry#round
.
test_xsd_nonPositiveInteger() - Method in class com.bigdata.rdf.internal.TestUnsignedIntegerIVs
test_xsd_unsignedByte() - Method in class com.bigdata.rdf.internal.TestUnsignedIVs
xsd:unsignedByte.
test_xsd_unsignedInt() - Method in class com.bigdata.rdf.internal.TestUnsignedIVs
test_xsd_unsignedLong() - Method in class com.bigdata.rdf.internal.TestUnsignedIVs
test_xsd_unsignedShort() - Method in class com.bigdata.rdf.internal.TestUnsignedIVs
Unit test for xsd:unsignedShort.
test_XSDBoolean() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDByte() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDDecimal() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDDouble() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDFloat() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDInt() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDInteger() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDLong() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDShort() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDString() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDUnsignedByte() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDUnsignedInt() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDUnsignedLong() - Method in class com.bigdata.rdf.internal.TestDTE
test_XSDUnsignedShort() - Method in class com.bigdata.rdf.internal.TestDTE
test_xxxCShardSplitHandler() - Method in class com.bigdata.rdf.spo.TestXXXCShardSplitHandler
TestAbort - Class in com.bigdata.journal
Test the ability to abort (discard an uncommitted write set).
TestAbort() - Constructor for class com.bigdata.journal.TestAbort
TestAbort(String) - Constructor for class com.bigdata.journal.TestAbort
TestAbstractHostLBSPolicy - Class in com.bigdata.rdf.sail.webapp.lbs
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.
TestAbstractHostLBSPolicy() - Constructor for class com.bigdata.rdf.sail.webapp.lbs.TestAbstractHostLBSPolicy
TestAbstractHostLBSPolicy(String) - Constructor for class com.bigdata.rdf.sail.webapp.lbs.TestAbstractHostLBSPolicy
testAbstractLiteralIVs() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
testAccept() - Method in class com.bigdata.bop.constraint.TestEQConstant
Unit test for EQConstant#accept(IBindingSet)
testAccept() - Method in class com.bigdata.bop.constraint.TestInBinarySearch
Unit test for INConstraint#accept(IBindingSet)
testAccept() - Method in class com.bigdata.bop.constraint.TestINConstraint
Unit test for INConstraint#accept(IBindingSet)
testAccept() - Method in class com.bigdata.bop.constraint.TestNEConstant
testAccept() - Method in class com.bigdata.bop.constraint.TestOR
testAccept1_audio_basic() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept1_text_xml() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept# : basic test suite for correct parsing of type,
subtype and parameters.
testAccept2() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept3() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept4() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept5() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept6() - Method in class com.bigdata.util.httpd.TestMIMEType
testAccept_wildcard_subtype() - Method in class com.bigdata.util.httpd.TestMIMEType
Basic acceptance tests for type and subtype wildcards.
testAccept_wildcard_type_and_subtype() - Method in class com.bigdata.util.httpd.TestMIMEType
testAcceptMultipart_1() - Method in class com.bigdata.util.httpd.TestMIMEType
multipart/mixed mime type test.
testAcceptMultipart_2() - Method in class com.bigdata.util.httpd.TestMIMEType
multipart/signed mime type test.
testAcceptMultipleDatatypeConfigs() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testAcceptSingleDatatypeConfig() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
TestAccessPaths - Class in com.bigdata.rdf.lexicon
TestAccessPaths() - Constructor for class com.bigdata.rdf.lexicon.TestAccessPaths
TestAccessPaths(String) - Constructor for class com.bigdata.rdf.lexicon.TestAccessPaths
TestAccessSemaphore - Class in com.bigdata.concurrent
TestAccessSemaphore() - Constructor for class com.bigdata.concurrent.TestAccessSemaphore
TestAccount - Class in com.bigdata.btree.isolation
This test case demonstrates a state-based validation technique described in
http://www.cs.brown.edu/~mph/Herlihy90a/p96-herlihy.pdf for a "bank account"
data type.
TestAccount() - Constructor for class com.bigdata.btree.isolation.TestAccount
TestAccount(String) - Constructor for class com.bigdata.btree.isolation.TestAccount
TestAccount.Account - Class in com.bigdata.btree.isolation
An implementation of a bank account data type used to test state-based
validation.
TestAccount.Account() - Constructor for class com.bigdata.btree.isolation.TestAccount.Account
TestAccount.TxAccount - Class in com.bigdata.btree.isolation
TestAccount.TxAccount(TestAccount.Account) - Constructor for class com.bigdata.btree.isolation.TestAccount.TxAccount
TestAccount.TxAccount.OverdraftException - Exception in com.bigdata.btree.isolation
TestAccount.TxAccount.OverdraftException() - Constructor for exception com.bigdata.btree.isolation.TestAccount.TxAccount.OverdraftException
testAdd() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
add succeeds if not full; throws ISE if full
testAdd() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
add succeeds if not full; throws ISE if full
testAddAll1() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
addAll(null) throws NPE
testAddAll1() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
addAll(null) throws NPE
testAddAll2() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
addAll of a collection with null elements throws NPE
testAddAll2() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
addAll of a collection with null elements throws NPE
testAddAll3() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
addAll of a collection with any null elements throws NPE after
possibly adding some elements
testAddAll3() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
addAll of a collection with any null elements throws NPE after
possibly adding some elements
testAddAll4() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
addAll throws ISE if not enough room
testAddAll4() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
addAll throws ISE if not enough room
testAddAll5() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Deque contains all elements, in traversal order, of successful addAll
testAddAll5() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Queue contains all elements, in traversal order, of successful addAll
testAddAllSelf() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
addAll(this) throws IAE
testAddAllSelf() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
addAll(this) throws IAE
testAddAndRemove() - Method in class com.bigdata.rdf.sail.TestRDRHistory
Test basic add/remove.
testAddData() - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
Modified to test SPARQL instead of Serql.
testAddData() - Method in class org.openrdf.sail.RDFStoreTest
TestAddDeleteResource - Class in com.bigdata.resources
Unit test of the
StoreManager
when adding and deleting journals and
index segments.
TestAddDeleteResource() - Constructor for class com.bigdata.resources.TestAddDeleteResource
TestAddDeleteResource(String) - Constructor for class com.bigdata.resources.TestAddDeleteResource
TestAddDropIndexTask - Class in com.bigdata.journal
TestAddDropIndexTask() - Constructor for class com.bigdata.journal.TestAddDropIndexTask
TestAddDropIndexTask(String) - Constructor for class com.bigdata.journal.TestAddDropIndexTask
testAddFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
peekFirst returns element inserted with addFirst
testAddFromDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testAddFromDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testAddFromDefaultToDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testAddFromDefaultToDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testAddGzipInputStream() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddInputStream() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
peekLast returns element inserted with addLast
testAddLiteralWithNewline() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddMalformedLiteralsDefaultConfig() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddMalformedLiteralsStrictConfig() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
add(null) throws NPE
testAddNull() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
add(null) throws NPE
testAddReader() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddRemove() - Method in class org.openrdf.repository.RepositoryConnectionTest
testAddressMappings() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
The address mappings are between the integer allocation address and
the sector index (16 signed bits) and offset (16 unsigned bits).
testAddStatement() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestAddTerms - Class in com.bigdata.rdf.lexicon
Test suite for adding terms to the lexicon.
TestAddTerms() - Constructor for class com.bigdata.rdf.lexicon.TestAddTerms
TestAddTerms(String) - Constructor for class com.bigdata.rdf.lexicon.TestAddTerms
testAddToDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testAddToDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testAddToExistingNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testAddToExistingNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testAddToNewNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testAddToNewNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testAddWhileQuerying() - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
Modified to test SPARQL instead of Serql.
testAddWhileQuerying() - Method in class org.openrdf.sail.RDFStoreTest
testAddZipFile() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestAggregationQuery - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for aggregation queries.
TestAggregationQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestAggregationQuery
TestAggregationQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestAggregationQuery
TestAll - Class in com.bigdata.bfs
Aggregates test suites in increase dependency order.
TestAll() - Constructor for class com.bigdata.bfs.TestAll
TestAll(String) - Constructor for class com.bigdata.bfs.TestAll
TestAll - Class in com.bigdata.bop.ap.filter
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.ap.filter.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.ap.filter.TestAll
TestAll - Class in com.bigdata.bop.ap
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.ap.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.ap.TestAll
TestAll - Class in com.bigdata.bop.bindingSet
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.bindingSet.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.bindingSet.TestAll
TestAll - Class in com.bigdata.bop.bset
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.bset.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.bset.TestAll
TestAll - Class in com.bigdata.bop.constraint
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.constraint.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.constraint.TestAll
TestAll - Class in com.bigdata.bop.controller
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.controller.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.controller.TestAll
TestAll - Class in com.bigdata.bop.engine
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.engine.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.engine.TestAll
TestAll - Class in com.bigdata.bop.fed.nodes
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.fed.nodes.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.fed.nodes.TestAll
TestAll - Class in com.bigdata.bop.fed.shards
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.fed.shards.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.fed.shards.TestAll
TestAll - Class in com.bigdata.bop.fed
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.fed.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.fed.TestAll
TestAll - Class in com.bigdata.bop.join
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.join.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.join.TestAll
TestAll - Class in com.bigdata.bop.joinGraph.fast
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.joinGraph.fast.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.joinGraph.fast.TestAll
TestAll - Class in com.bigdata.bop.joinGraph.rto
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.joinGraph.rto.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.joinGraph.rto.TestAll
TestAll - Class in com.bigdata.bop.joinGraph
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.joinGraph.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.joinGraph.TestAll
TestAll - Class in com.bigdata.bop.mutation
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.mutation.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.mutation.TestAll
TestAll - Class in com.bigdata.bop.ndx
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.ndx.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.ndx.TestAll
TestAll - Class in com.bigdata.bop.rdf.aggregate
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.rdf.aggregate.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestAll
TestAll - Class in com.bigdata.bop.rdf.filter
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.rdf.filter.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.rdf.filter.TestAll
TestAll - Class in com.bigdata.bop.rdf.join
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.rdf.join.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.rdf.join.TestAll
TestAll - Class in com.bigdata.bop.rdf
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.rdf.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.rdf.TestAll
TestAll - Class in com.bigdata.bop.solutions
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.solutions.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.solutions.TestAll
TestAll - Class in com.bigdata.bop
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.TestAll
TestAll - Class in com.bigdata.bop.util
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.bop.util.TestAll
TestAll(String) - Constructor for class com.bigdata.bop.util.TestAll
TestAll - Class in com.bigdata.btree.data
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.data.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.data.TestAll
TestAll - Class in com.bigdata.btree.filter
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.filter.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.filter.TestAll
TestAll - Class in com.bigdata.btree.isolation
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.isolation.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.isolation.TestAll
TestAll - Class in com.bigdata.btree.keys
TestAll() - Constructor for class com.bigdata.btree.keys.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.keys.TestAll
TestAll - Class in com.bigdata.btree.proc
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.proc.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.proc.TestAll
TestAll - Class in com.bigdata.btree.raba.codec
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.raba.codec.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.raba.codec.TestAll
TestAll - Class in com.bigdata.btree.raba
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.raba.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.raba.TestAll
TestAll - Class in com.bigdata.btree
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.TestAll
TestAll - Class in com.bigdata.btree.view
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.btree.view.TestAll
TestAll(String) - Constructor for class com.bigdata.btree.view.TestAll
TestAll - Class in com.bigdata.concurrent
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.concurrent.TestAll
TestAll(String) - Constructor for class com.bigdata.concurrent.TestAll
TestAll - Class in com.bigdata.config
Aggregates unit tests into dependency order.
TestAll() - Constructor for class com.bigdata.config.TestAll
TestAll(String) - Constructor for class com.bigdata.config.TestAll
TestAll - Class in com.bigdata.counters.ganglia
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.ganglia.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.ganglia.TestAll
TestAll - Class in com.bigdata.counters.linux
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.linux.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.linux.TestAll
TestAll - Class in com.bigdata.counters.osx
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.osx.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.osx.TestAll
TestAll - Class in com.bigdata.counters.query
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.query.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.query.TestAll
TestAll - Class in com.bigdata.counters.store
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.store.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.store.TestAll
TestAll - Class in com.bigdata.counters.striped
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.striped.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.striped.TestAll
TestAll - Class in com.bigdata.counters
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.counters.TestAll
TestAll(String) - Constructor for class com.bigdata.counters.TestAll
TestAll - Class in com.bigdata.gom
TestAll() - Constructor for class com.bigdata.gom.TestAll
TestAll(String) - Constructor for class com.bigdata.gom.TestAll
TestAll - Class in com.bigdata.ha.halog
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.ha.halog.TestAll
TestAll(String) - Constructor for class com.bigdata.ha.halog.TestAll
TestAll - Class in com.bigdata.ha.msg
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.ha.msg.TestAll
TestAll(String) - Constructor for class com.bigdata.ha.msg.TestAll
TestAll - Class in com.bigdata.ha.pipeline
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.ha.pipeline.TestAll
TestAll(String) - Constructor for class com.bigdata.ha.pipeline.TestAll
TestAll - Class in com.bigdata.ha
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.ha.TestAll
TestAll(String) - Constructor for class com.bigdata.ha.TestAll
TestAll - Class in com.bigdata.htree.data
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.htree.data.TestAll
TestAll(String) - Constructor for class com.bigdata.htree.data.TestAll
TestAll - Class in com.bigdata.htree.raba
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.htree.raba.TestAll
TestAll(String) - Constructor for class com.bigdata.htree.raba.TestAll
TestAll - Class in com.bigdata.htree
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.htree.TestAll
TestAll(String) - Constructor for class com.bigdata.htree.TestAll
TestAll - Class in com.bigdata.io.compression
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.io.compression.TestAll
TestAll(String) - Constructor for class com.bigdata.io.compression.TestAll
TestAll - Class in com.bigdata.io
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.io.TestAll
TestAll(String) - Constructor for class com.bigdata.io.TestAll
testAll() - Method in class com.bigdata.io.TestManagedReads
TestAll - Class in com.bigdata.io.writecache
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.io.writecache.TestAll
TestAll(String) - Constructor for class com.bigdata.io.writecache.TestAll
TestAll - Class in com.bigdata.journal
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.journal.TestAll
TestAll(String) - Constructor for class com.bigdata.journal.TestAll
TestAll - Class in com.bigdata.jsr166
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.jsr166.TestAll
TestAll(String) - Constructor for class com.bigdata.jsr166.TestAll
TestAll - Class in com.bigdata.mdi
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.mdi.TestAll
TestAll(String) - Constructor for class com.bigdata.mdi.TestAll
TestAll - Class in com.bigdata.net
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.net.TestAll
TestAll(String) - Constructor for class com.bigdata.net.TestAll
TestAll - Class in com.bigdata.nio
Aggregates tests in dependency order.
TestAll() - Constructor for class com.bigdata.nio.TestAll
TestAll(String) - Constructor for class com.bigdata.nio.TestAll
TestAll - Class in com.bigdata.quorum
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.quorum.TestAll
TestAll(String) - Constructor for class com.bigdata.quorum.TestAll
TestAll - Class in com.bigdata.rawstore
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.rawstore.TestAll
TestAll(String) - Constructor for class com.bigdata.rawstore.TestAll
TestAll - Class in com.bigdata.rdf.axioms
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.axioms.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.axioms.TestAll
TestAll - Class in com.bigdata.rdf.graph.impl.bd
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.graph.impl.bd.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.graph.impl.bd.TestAll
TestAll - Class in com.bigdata.rdf.internal.constraints
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.internal.constraints.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.internal.constraints.TestAll
TestAll - Class in com.bigdata.rdf.internal.encoder
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.internal.encoder.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.internal.encoder.TestAll
TestAll - Class in com.bigdata.rdf.internal.gis
TestAll() - Constructor for class com.bigdata.rdf.internal.gis.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.internal.gis.TestAll
TestAll - Class in com.bigdata.rdf.internal.impl.uri
TestAll() - Constructor for class com.bigdata.rdf.internal.impl.uri.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.internal.impl.uri.TestAll
TestAll - Class in com.bigdata.rdf.internal
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.internal.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.internal.TestAll
TestAll - Class in com.bigdata.rdf.lexicon
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.lexicon.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.lexicon.TestAll
TestAll - Class in com.bigdata.rdf.load
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.load.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.load.TestAll
TestAll - Class in com.bigdata.rdf.model
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.model.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.model.TestAll
TestAll - Class in com.bigdata.rdf.rio.ntriples
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.rio.ntriples.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.rio.ntriples.TestAll
TestAll - Class in com.bigdata.rdf.rio
RIO integration tests.
TestAll() - Constructor for class com.bigdata.rdf.rio.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.rio.TestAll
TestAll - Class in com.bigdata.rdf.rules
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.rules.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.rules.TestAll
TestAll - Class in com.bigdata.rdf.sail.sparql
Test suite.
TestAll() - Constructor for class com.bigdata.rdf.sail.sparql.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestAll
TestAll - Class in com.bigdata.rdf.sail.tck
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sail.tck.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sail.tck.TestAll
TestAll - Class in com.bigdata.rdf.sail
Test suite.
TestAll() - Constructor for class com.bigdata.rdf.sail.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sail.TestAll
TestAll - Class in com.bigdata.rdf.sail.webapp.lbs
Test suite.
TestAll() - Constructor for class com.bigdata.rdf.sail.webapp.lbs.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sail.webapp.lbs.TestAll
TestAll - Class in com.bigdata.rdf.sail.webapp
Test suite.
TestAll() - Constructor for class com.bigdata.rdf.sail.webapp.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.cache
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.cache.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.cache.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.eval.rto
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.eval.service
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.eval
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.eval.update
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.eval.update.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.update.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.optimizers
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.service.storedquery
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.service.storedquery.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.service.storedquery.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast.ssets
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.ssets.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.ssets.TestAll
TestAll - Class in com.bigdata.rdf.sparql.ast
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.ast.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestAll
TestAll - Class in com.bigdata.rdf.sparql
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.sparql.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.sparql.TestAll
TestAll - Class in com.bigdata.rdf.spo
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.spo.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.spo.TestAll
TestAll - Class in com.bigdata.rdf.store
TestAll() - Constructor for class com.bigdata.rdf.store.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.store.TestAll
TestAll - Class in com.bigdata.rdf
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.rdf.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.TestAll
TestAll - Class in com.bigdata.rdf.vocab
TestAll() - Constructor for class com.bigdata.rdf.vocab.TestAll
TestAll(String) - Constructor for class com.bigdata.rdf.vocab.TestAll
TestAll - Class in com.bigdata.relation.accesspath
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.relation.accesspath.TestAll
TestAll(String) - Constructor for class com.bigdata.relation.accesspath.TestAll
TestAll - Class in com.bigdata.relation.ddl
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.relation.ddl.TestAll
TestAll(String) - Constructor for class com.bigdata.relation.ddl.TestAll
TestAll - Class in com.bigdata.relation.locator
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.relation.locator.TestAll
TestAll(String) - Constructor for class com.bigdata.relation.locator.TestAll
TestAll - Class in com.bigdata.relation.rule.eval
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.relation.rule.eval.TestAll
TestAll(String) - Constructor for class com.bigdata.relation.rule.eval.TestAll
TestAll - Class in com.bigdata.relation.rule
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.relation.rule.TestAll
TestAll(String) - Constructor for class com.bigdata.relation.rule.TestAll
TestAll - Class in com.bigdata.relation
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.relation.TestAll
TestAll(String) - Constructor for class com.bigdata.relation.TestAll
TestAll - Class in com.bigdata.resources
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.resources.TestAll
TestAll(String) - Constructor for class com.bigdata.resources.TestAll
TestAll - Class in com.bigdata.rwstore.sector
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.rwstore.sector.TestAll
TestAll(String) - Constructor for class com.bigdata.rwstore.sector.TestAll
TestAll - Class in com.bigdata.rwstore
Runs all tests for all journal implementations.
TestAll() - Constructor for class com.bigdata.rwstore.TestAll
TestAll(String) - Constructor for class com.bigdata.rwstore.TestAll
TestAll - Class in com.bigdata.search
TestAll() - Constructor for class com.bigdata.search.TestAll
TestAll(String) - Constructor for class com.bigdata.search.TestAll
TestAll - Class in com.bigdata.service.ndx.pipeline
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.service.ndx.pipeline.TestAll
TestAll(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestAll
TestAll - Class in com.bigdata.service.ndx
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.service.ndx.TestAll
TestAll(String) - Constructor for class com.bigdata.service.ndx.TestAll
TestAll - Class in com.bigdata.service
Test suite for embedded services.
TestAll() - Constructor for class com.bigdata.service.TestAll
TestAll(String) - Constructor for class com.bigdata.service.TestAll
TestAll - Class in com.bigdata.sparse
Test suite for the spare row store facility (aka key-value store).
TestAll() - Constructor for class com.bigdata.sparse.TestAll
TestAll(String) - Constructor for class com.bigdata.sparse.TestAll
TestAll - Class in com.bigdata.striterator
Aggregates test suites into increasing dependency order.
TestAll() - Constructor for class com.bigdata.striterator.TestAll
TestAll(String) - Constructor for class com.bigdata.striterator.TestAll
TestAll - Class in com.bigdata
Aggregates test suites in increase dependency order.
TestAll() - Constructor for class com.bigdata.TestAll
TestAll(String) - Constructor for class com.bigdata.TestAll
TestAll - Class in com.bigdata.util.concurrent
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.util.concurrent.TestAll
TestAll(String) - Constructor for class com.bigdata.util.concurrent.TestAll
TestAll - Class in com.bigdata.util.httpd
Aggregates test suites in increasing dependency order.
TestAll() - Constructor for class com.bigdata.util.httpd.TestAll
TestAll(String) - Constructor for class com.bigdata.util.httpd.TestAll
TestAll2 - Class in com.bigdata.rdf.sail.webapp
A version of the test suite that is intended for local debugging and is NOT
run in CI.
TestAll2() - Constructor for class com.bigdata.rdf.sail.webapp.TestAll2
TestAll2(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestAll2
TestAll_AST - Class in com.bigdata.rdf.sail.sparql
Test suite.
TestAll_AST() - Constructor for class com.bigdata.rdf.sail.sparql.TestAll_AST
TestAll_AST(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestAll_AST
TestAll_BTreeBasics - Class in com.bigdata.btree
Aggregates the unit tests for the core B+Tree operations, all of which are in
the same package as the
BTree
.
TestAll_BTreeBasics() - Constructor for class com.bigdata.btree.TestAll_BTreeBasics
TestAll_BTreeBasics(String) - Constructor for class com.bigdata.btree.TestAll_BTreeBasics
TestAll_Buffers - Class in com.bigdata.io
Aggregates test suites in increasing dependency order.
TestAll_Buffers() - Constructor for class com.bigdata.io.TestAll_Buffers
TestAll_Buffers(String) - Constructor for class com.bigdata.io.TestAll_Buffers
TestAll_DynamicSharding - Class in com.bigdata.service
Test suite for dynamic sharding.
TestAll_DynamicSharding() - Constructor for class com.bigdata.service.TestAll_DynamicSharding
TestAll_DynamicSharding(String) - Constructor for class com.bigdata.service.TestAll_DynamicSharding
TestAll_HTree - Class in com.bigdata.htree
Aggregates test suites into increasing dependency order.
TestAll_HTree() - Constructor for class com.bigdata.htree.TestAll_HTree
TestAll_HTree(String) - Constructor for class com.bigdata.htree.TestAll_HTree
TestAll_IndexSegment - Class in com.bigdata.btree
Aggregates the unit tests for the
IndexSegment
and its related
classes, all of which are in the same package as the
BTree
.
TestAll_IndexSegment() - Constructor for class com.bigdata.btree.TestAll_IndexSegment
TestAll_IndexSegment(String) - Constructor for class com.bigdata.btree.TestAll_IndexSegment
TestAll_IndexSegmentBuilderWithSmallTrees - Class in com.bigdata.btree
TestAll_IndexSegmentBuilderWithSmallTrees() - Constructor for class com.bigdata.btree.TestAll_IndexSegmentBuilderWithSmallTrees
TestAll_IndexSegmentBuilderWithSmallTrees(String) - Constructor for class com.bigdata.btree.TestAll_IndexSegmentBuilderWithSmallTrees
TestAll_Iterators - Class in com.bigdata.btree
Aggregates the unit tests for the
IndexSegment
and its related
classes, all of which are in the same package as the
BTree
.
TestAll_Iterators() - Constructor for class com.bigdata.btree.TestAll_Iterators
TestAll_Iterators(String) - Constructor for class com.bigdata.btree.TestAll_Iterators
TestAll_Packers - Class in com.bigdata.io
TestAll_Packers() - Constructor for class com.bigdata.io.TestAll_Packers
TestAll_Packers(String) - Constructor for class com.bigdata.io.TestAll_Packers
TestAll_ResourceService - Class in com.bigdata.service
TestAll_ResourceService() - Constructor for class com.bigdata.service.TestAll_ResourceService
TestAll_ResourceService(String) - Constructor for class com.bigdata.service.TestAll_ResourceService
TestAll_RIO - Class in com.bigdata.rdf.rio
Test suite for RIO extensions but NOT the integration tests.
TestAll_RIO() - Constructor for class com.bigdata.rdf.rio.TestAll_RIO
TestAll_RIO(String) - Constructor for class com.bigdata.rdf.rio.TestAll_RIO
testAllocationContexts() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
testAllocationContexts() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
testAllocationContextsStreams() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
testAllocationReserves() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Not so much a test as a code coverage exercise.
TestAllocBits - Class in com.bigdata.rwstore
TestAllocBits() - Constructor for class com.bigdata.rwstore.TestAllocBits
TestALPPinTrac773 - Class in com.bigdata.rdf.sparql.ast.optimizers
Trac733 shows some strange behavior, this test case is intended
to explore that.
TestALPPinTrac773() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
TestALPPinTrac773(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
TestAltHALogWriter - Class in com.bigdata.ha.althalog
TestAltHALogWriter() - Constructor for class com.bigdata.ha.althalog.TestAltHALogWriter
testAnd() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
testApacheUpdate() - Method in class com.bigdata.rdf.sail.webapp.TestMultipartContent
TestAppendBlock - Class in com.bigdata.bfs
TestAppendBlock() - Constructor for class com.bigdata.bfs.TestAppendBlock
TestAppendBlock(String) - Constructor for class com.bigdata.bfs.TestAppendBlock
TestAppendFilter - Class in com.bigdata.striterator
TestAppendFilter() - Constructor for class com.bigdata.striterator.TestAppendFilter
TestAppendFilter(String) - Constructor for class com.bigdata.striterator.TestAppendFilter
testArbitraryLengthPathWithBinding1() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding2() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding3() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding4() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding5() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding6() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding7() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithBinding8() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithFilter1() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithFilter2() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testArbitraryLengthPathWithFilter3() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
TestArrayBuffer - Class in com.bigdata.relation.accesspath
TestArrayBuffer() - Constructor for class com.bigdata.relation.accesspath.TestArrayBuffer
TestArrayBuffer(String) - Constructor for class com.bigdata.relation.accesspath.TestArrayBuffer
testArraySampling(int, int) - Static method in class cern.jet.random.sampling.RandomSamplingAssistant
Tests the methods of this class.
testAskGetJSON() - Method in class com.bigdata.rdf.sail.webapp.TestAskJsonTrac704
This does not work - trac 704
testAskGetXML() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
TestAskJsonTrac704 - Class in com.bigdata.rdf.sail.webapp
TestAskJsonTrac704(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestAskJsonTrac704
testAskPostEncodeJSON() - Method in class com.bigdata.rdf.sail.webapp.TestAskJsonTrac704
This does not work - trac 704
testAskPostEncodeXML() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testAskPostJSON() - Method in class com.bigdata.rdf.sail.webapp.TestPostNotURLEncoded
testAskPostXML() - Method in class com.bigdata.rdf.sail.webapp.TestPostNotURLEncoded
testAskSubquery01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test case for ASK subqueries, as they emerge from FILTER (NOT) EXISTS
clauses.
testAskSubquery02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test case for ASK subqueries, as they emerge from FILTER (NOT) EXISTS
clauses.
testAskSubquery03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test case for ASK subqueries, as they emerge from FILTER (NOT) EXISTS
clauses.
testAssertSameEdges() - Method in class com.bigdata.concurrent.TestTxDag
Some tests to verify #assertSameEdges(Edge[], Edge[])
.
testAssignmentNode() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for assignment nodes.
TestAST - Class in com.bigdata.rdf.sparql.ast.eval
Port of unit tests originally written at the AST layer.
TestAST() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestAST
TestAST(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestAST
TestAST - Class in com.bigdata.rdf.sparql.ast
TODO This does not really "test" much, just exercises some basic aspects of
the API.
TestAST() - Constructor for class com.bigdata.rdf.sparql.ast.TestAST
TestAST(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestAST
TestASTAttachJoinFiltersOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTAttachJoinFiltersOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTAttachJoinFiltersOptimizer
TestASTAttachJoinFiltersOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTAttachJoinFiltersOptimizer
TestASTBatchResolveTermsOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTBatchResolveTermsOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTBatchResolveTermsOptimizer
TestASTBatchResolveTermsOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTBatchResolveTermsOptimizer
TestASTBottomUpOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTBottomUpOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTBottomUpOptimizer
TestASTBottomUpOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTBottomUpOptimizer
TestASTComplexOptionalOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTComplexOptionalOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTComplexOptionalOptimizer
TestASTComplexOptionalOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTComplexOptionalOptimizer
TestASTConstructOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTConstructOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTConstructOptimizer
TestASTConstructOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTConstructOptimizer
TestASTDescribeOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTDescribeOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDescribeOptimizer
TestASTDescribeOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDescribeOptimizer
TestASTDistinctTermScanOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTDistinctTermScanOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDistinctTermScanOptimizer
TestASTDistinctTermScanOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDistinctTermScanOptimizer
TestASTDistinctTermScanOptimizer.AbstractASTDistinctTermScanTest - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTDistinctTermScanOptimizer.AbstractASTDistinctTermScanTest() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDistinctTermScanOptimizer.AbstractASTDistinctTermScanTest
TestASTDistinctTermScanOptimizer.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.optimizers
Quads mode specific test suite.
TestASTDistinctTermScanOptimizer.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDistinctTermScanOptimizer.TestQuadsModeAPs
TestASTDistinctTermScanOptimizer.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.optimizers
Quads mode specific test suite.
TestASTDistinctTermScanOptimizer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTDistinctTermScanOptimizer.TestTriplesModeAPs
TestASTEmptyGroupOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTEmptyGroupOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTEmptyGroupOptimizer
TestASTEmptyGroupOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTEmptyGroupOptimizer
TestASTExistsAndJoinOrderByTypeOptimizers - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTExistsAndJoinOrderByTypeOptimizers() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTExistsAndJoinOrderByTypeOptimizers
TestASTExistsAndJoinOrderByTypeOptimizers(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTExistsAndJoinOrderByTypeOptimizers
TestASTFastRangeCountOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTFastRangeCountOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFastRangeCountOptimizer
TestASTFastRangeCountOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFastRangeCountOptimizer
TestASTFastRangeCountOptimizer.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.optimizers
Quads mode specific test suite.
TestASTFastRangeCountOptimizer.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFastRangeCountOptimizer.TestQuadsModeAPs
TestASTFastRangeCountOptimizer.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.optimizers
Triples mode test suite.
TestASTFastRangeCountOptimizer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFastRangeCountOptimizer.TestTriplesModeAPs
TestASTFastRangeCountOptimizer.TestTriplesModeAPs(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFastRangeCountOptimizer.TestTriplesModeAPs
TestASTFilterNormalizationOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTFilterNormalizationOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
TestASTFilterNormalizationOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
TestASTFlattenJoinGroupsOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTFlattenJoinGroupsOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenJoinGroupsOptimizer
TestASTFlattenJoinGroupsOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenJoinGroupsOptimizer
TestASTFlattenUnionsOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTFlattenUnionsOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenUnionsOptimizer
TestASTFlattenUnionsOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenUnionsOptimizer
TestASTFulltextSearchOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTFulltextSearchOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFulltextSearchOptimizer
TestASTFulltextSearchOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTFulltextSearchOptimizer
TestASTGraphGroupOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTGraphGroupOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTGraphGroupOptimizer
TestASTGraphGroupOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTGraphGroupOptimizer
TestASTHashJoinOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTHashJoinOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTHashJoinOptimizer
TestASTHashJoinOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTHashJoinOptimizer
TestASTJoinGroupOrderOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTJoinGroupOrderOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
TestASTJoinGroupOrderOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
TestASTJoinGroupPartitioning - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTJoinGroupPartitioning() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
TestASTJoinGroupPartitioning(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
TestASTLiftPreFiltersOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTLiftPreFiltersOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTLiftPreFiltersOptimizer
TestASTLiftPreFiltersOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTLiftPreFiltersOptimizer
TestASTMassagedServiceNodeOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTMassagedServiceNodeOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTMassagedServiceNodeOptimizer
TestASTMassagedServiceNodeOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTMassagedServiceNodeOptimizer
TestASTNamedSubqueryOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTNamedSubqueryOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer
TestASTNamedSubqueryOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer
TestASTNamedSubqueryOptimizer2 - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTNamedSubqueryOptimizer2() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer2
TestASTOrderByAggregateFlatteningOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTOrderByAggregateFlatteningOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTOrderByAggregateFlatteningOptimizer
TestASTOrderByAggregateFlatteningOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTOrderByAggregateFlatteningOptimizer
TestASTPropertyPathOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTPropertyPathOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTPropertyPathOptimizer
TestASTPropertyPathOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTPropertyPathOptimizer
TestASTQueryHintOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTQueryHintOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
TestASTQueryHintOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTQueryHintOptimizer
TestASTRangeOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTRangeOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTRangeOptimizer
TestASTRangeOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTRangeOptimizer
TestASTRunFirstRunLastOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTRunFirstRunLastOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTRunFirstRunLastOptimizer
TestASTRunFirstRunLastOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTRunFirstRunLastOptimizer
TestASTSearchOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTSearchOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSearchOptimizer
TestASTSearchOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSearchOptimizer
TestASTServiceNodeOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTServiceNodeOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTServiceNodeOptimizer
TestASTServiceNodeOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTServiceNodeOptimizer
TestASTSetValueExpressionOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTSetValueExpressionOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSetValueExpressionOptimizer
TestASTSetValueExpressionOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSetValueExpressionOptimizer
TestASTSimpleOptionalOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTSimpleOptionalOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSimpleOptionalOptimizer
TestASTSimpleOptionalOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSimpleOptionalOptimizer
TestASTSparql11SubqueryOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTSparql11SubqueryOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
TestASTSparql11SubqueryOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSparql11SubqueryOptimizer
TestASTStaticBindingsOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTStaticBindingsOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
TestASTStaticBindingsOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
TestASTStaticJoinOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTStaticJoinOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
TestASTStaticJoinOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticJoinOptimizer
TestASTSubGroupJoinVarOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTSubGroupJoinVarOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSubGroupJoinVarOptimizer
TestASTSubGroupJoinVarOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTSubGroupJoinVarOptimizer
TestASTUnionFiltersOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTUnionFiltersOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTUnionFiltersOptimizer
TestASTUnionFiltersOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTUnionFiltersOptimizer
TestASTWildcardProjectionOptimizer - Class in com.bigdata.rdf.sparql.ast.optimizers
TestASTWildcardProjectionOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
TestASTWildcardProjectionOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestASTWildcardProjectionOptimizer
TestAsynchronousStatementBufferFactory - Class in com.bigdata.rdf.rio
TestAsynchronousStatementBufferFactory() - Constructor for class com.bigdata.rdf.rio.TestAsynchronousStatementBufferFactory
TestAsynchronousStatementBufferFactory(String) - Constructor for class com.bigdata.rdf.rio.TestAsynchronousStatementBufferFactory
testAutoCommit() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestAVERAGE - Class in com.bigdata.bop.rdf.aggregate
TestAVERAGE() - Constructor for class com.bigdata.bop.rdf.aggregate.TestAVERAGE
TestAVERAGE(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestAVERAGE
TestAxioms - Class in com.bigdata.rdf.axioms
TestAxioms() - Constructor for class com.bigdata.rdf.axioms.TestAxioms
TestAxioms(String) - Constructor for class com.bigdata.rdf.axioms.TestAxioms
TestBackchainOwlSameAsPropertiesIterator - Class in com.bigdata.rdf.rules
TestBackchainOwlSameAsPropertiesIterator() - Constructor for class com.bigdata.rdf.rules.TestBackchainOwlSameAsPropertiesIterator
TestBackchainOwlSameAsPropertiesIterator(String) - Constructor for class com.bigdata.rdf.rules.TestBackchainOwlSameAsPropertiesIterator
TestBackchainTypeResourceIterator - Class in com.bigdata.rdf.rules
TestBackchainTypeResourceIterator() - Constructor for class com.bigdata.rdf.rules.TestBackchainTypeResourceIterator
TestBackchainTypeResourceIterator(String) - Constructor for class com.bigdata.rdf.rules.TestBackchainTypeResourceIterator
TestBackupServlet<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
TestBackupServlet() - Constructor for class com.bigdata.rdf.sail.webapp.TestBackupServlet
TestBackupServlet(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestBackupServlet
testBadLike() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testBasicFlattening() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenJoinGroupsOptimizer
TestBasicIndexStuff - Class in com.bigdata.service
Test of basic index operations.
TestBasicIndexStuff() - Constructor for class com.bigdata.service.TestBasicIndexStuff
TestBasicIndexStuff(String) - Constructor for class com.bigdata.service.TestBasicIndexStuff
TestBasicQuery - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite.
TestBasicQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBasicQuery
TestBasicQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBasicQuery
testBasicSkin() - Method in class com.bigdata.gom.TestGOM
This tests both the usability and functionality of the Skinning mechanism
TestBFS - Class in com.bigdata.rdf.graph.impl.bd
Test class for Breadth First Search (BFS) traversal.
TestBFS() - Constructor for class com.bigdata.rdf.graph.impl.bd.TestBFS
TestBFS(String) - Constructor for class com.bigdata.rdf.graph.impl.bd.TestBFS
testBFS() - Method in class com.bigdata.rdf.graph.impl.bd.TestBFS
testBFS_directed_forward() - Method in class com.bigdata.rdf.graph.impl.bd.TestBFS
Variant test in which we choose a vertex (foaf:person
) in
the middle of the graph and insist on forward directed edges.
testBFS_directed_reverse() - Method in class com.bigdata.rdf.graph.impl.bd.TestBFS
Variant test in which we choose a vertex (foaf:person
) in
the middle of the graph and insist on reverse directed edges.
testBFS_undirected() - Method in class com.bigdata.rdf.graph.impl.bd.TestBFS
Variant test in which we choose a vertex (foaf:person
) in
the middle of the graph and insist on directed edges.
TestBigdataExprBuilder - Class in com.bigdata.rdf.sail.sparql
TestBigdataExprBuilder() - Constructor for class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
TestBigdataExprBuilder(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestBigdataExprBuilder
TestBigdataMap - Class in com.bigdata.btree
TestBigdataMap() - Constructor for class com.bigdata.btree.TestBigdataMap
TestBigdataMap(String) - Constructor for class com.bigdata.btree.TestBigdataMap
TestBigdataNativeServiceEvaluation - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for SPARQL 1.1 Federated Query against an internal,
bigdata "aware" service (similar to our integrated full text search
facility).
TestBigdataNativeServiceEvaluation() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestBigdataNativeServiceEvaluation
TestBigdataNativeServiceEvaluation(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestBigdataNativeServiceEvaluation
TestBigdataSailEmbeddedFederationWithQuads - Class in com.bigdata.rdf.sail
TestBigdataSailEmbeddedFederationWithQuads() - Constructor for class com.bigdata.rdf.sail.TestBigdataSailEmbeddedFederationWithQuads
TestBigdataSailEmbeddedFederationWithQuads(String) - Constructor for class com.bigdata.rdf.sail.TestBigdataSailEmbeddedFederationWithQuads
TestBigdataSailRemoteRepository<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
TestBigdataSailRemoteRepository() - Constructor for class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository
TestBigdataSailRemoteRepository(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository
TestBigdataSailRemoteRepository.ReadWriteTx<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
An *extension* of the test suite that uses a namespace that is configured
to support read/write transactions.
TestBigdataSailRemoteRepository.ReadWriteTx() - Constructor for class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository.ReadWriteTx
TestBigdataSailRemoteRepository.ReadWriteTx(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestBigdataSailRemoteRepository.ReadWriteTx
TestBigdataSailWithoutSids - Class in com.bigdata.rdf.sail
Test suite for the
BigdataSail
with statement identifiers enabled.
TestBigdataSailWithoutSids() - Constructor for class com.bigdata.rdf.sail.TestBigdataSailWithoutSids
TestBigdataSailWithoutSids(String) - Constructor for class com.bigdata.rdf.sail.TestBigdataSailWithoutSids
TestBigdataSailWithQuads - Class in com.bigdata.rdf.sail
TestBigdataSailWithQuads() - Constructor for class com.bigdata.rdf.sail.TestBigdataSailWithQuads
TestBigdataSailWithQuads(String) - Constructor for class com.bigdata.rdf.sail.TestBigdataSailWithQuads
TestBigdataSailWithSids - Class in com.bigdata.rdf.sail
Test suite for the
BigdataSail
with statement identifiers enabled.
TestBigdataSailWithSids() - Constructor for class com.bigdata.rdf.sail.TestBigdataSailWithSids
TestBigdataSailWithSids(String) - Constructor for class com.bigdata.rdf.sail.TestBigdataSailWithSids
TestBigdataSet - Class in com.bigdata.btree
TestBigdataSet() - Constructor for class com.bigdata.btree.TestBigdataSet
TestBigdataSet(String) - Constructor for class com.bigdata.btree.TestBigdataSet
TestBigdataValueReplacer - Class in com.bigdata.rdf.sail
Test suite for the logic which rewrites a query, replacing
Value
constants with
BigdataValue
constants which have been resolved
against the database.
TestBigdataValueReplacer() - Constructor for class com.bigdata.rdf.sail.TestBigdataValueReplacer
TestBigdataValueReplacer(String) - Constructor for class com.bigdata.rdf.sail.TestBigdataValueReplacer
TestBigdataValueSerialization - Class in com.bigdata.rdf.model
TestBigdataValueSerialization() - Constructor for class com.bigdata.rdf.model.TestBigdataValueSerialization
TestBigdataValueSerialization(String) - Constructor for class com.bigdata.rdf.model.TestBigdataValueSerialization
testBigMinCalculation2Dim() - Method in class com.bigdata.rdf.internal.TestZOrderRangeScanUtility
We implement the test case from Wikipedia: https://en.wikipedia.org/wiki/Z-order_curve,
implementing bigmin calculation in a two-dimensional setting.
testBigMinCalculation3Dim() - Method in class com.bigdata.rdf.internal.TestZOrderRangeScanUtility
Test for BigMin calculation in a three-dimensional setting.
TestBind - Class in com.bigdata.bop.rdf
Test suite for logic which "joins" two solutions, propagating bindings,
verifying constraints, and dropping bindings which are not to be kept.
TestBind() - Constructor for class com.bigdata.bop.rdf.TestBind
TestBind(String) - Constructor for class com.bigdata.bop.rdf.TestBind
TestBind - Class in com.bigdata.bop
TestBind() - Constructor for class com.bigdata.bop.TestBind
TestBind(String) - Constructor for class com.bigdata.bop.TestBind
TestBindHeisenbug708 - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for a hesienbug involving BIND.
TestBindHeisenbug708() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBindHeisenbug708
TestBindHeisenbug708(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBindHeisenbug708
TestBindings - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for SPARQL 1.1 BIND & VALUES clause.
TestBindings() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBindings
TestBindings(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBindings
testBindingsAndBottomUp01a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp01b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp01c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp01d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp02a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp02b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
SELECT ?s WHERE {
BIND(1 AS ?s)
OPTIONAL {
OPTIONAL {
?s ?p ?o
}
}
}
over singleton graph.
testBindingsAndBottomUp03a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
SELECT * WHERE {
BIND(1 AS ?s)
{
BIND(2 AS ?s2)
FILTER(!bound(?s))
}
}
over empty graph.
testBindingsAndBottomUp03b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03g() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03h() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03i() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03j() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp03k() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp04a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp04b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp04c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp04d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp04e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp05a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp05b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndBottomUp05c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndValuesMix01a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndValuesMix01b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndValuesMix01c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndValuesMix01d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndValuesMix01e() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsAndValuesMix01f() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
TestBindingsClause - Class in com.bigdata.rdf.sail.sparql
Test suite for the BINDINGS clause.
TestBindingsClause() - Constructor for class com.bigdata.rdf.sail.sparql.TestBindingsClause
TestBindingsClause(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestBindingsClause
testBindingsClause() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for assignment nodes.
testBindingsWithSubquery01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsWithSubquery02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsWithSubquery03a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsWithSubquery03b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsWithSubquery04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsWithSubquery05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindingsWithSubquery06() - Method in class com.bigdata.rdf.sparql.ast.eval.TestBindings
Evaluation of query
testBindPlacement01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testBindPlacement02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testBindPlacement03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test complex pattern, including inter- and intra-partition reordering,
with focus on BIND and ASSIGNMENT nodes.
testBitCounts() - Method in class com.bigdata.rwstore.TestAllocBits
TestBlobIV - Class in com.bigdata.rdf.internal
TestBlobIV() - Constructor for class com.bigdata.rdf.internal.TestBlobIV
TestBlobIV(String) - Constructor for class com.bigdata.rdf.internal.TestBlobIV
testBlobObjectStreams() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
Writing a blob sized object stream is an excellent test since the ObjectInputStream
will likely throw an exception if there is a data error.
TestBlobsConfiguration - Class in com.bigdata.rdf.store
Test suite for configuration of the BLOBS index support.
TestBlobsConfiguration() - Constructor for class com.bigdata.rdf.store.TestBlobsConfiguration
TestBlobsConfiguration(String) - Constructor for class com.bigdata.rdf.store.TestBlobsConfiguration
TestBlobsIndex - Class in com.bigdata.rdf.lexicon
Test suite for low-level operations on the BLOBS index.
TestBlobsIndex() - Constructor for class com.bigdata.rdf.lexicon.TestBlobsIndex
TestBlobsIndex(String) - Constructor for class com.bigdata.rdf.lexicon.TestBlobsIndex
testBlobStreamBoundaries() - Method in class com.bigdata.rwstore.sector.TestMemoryManagerStreams
testBlobStreams() - Method in class com.bigdata.rwstore.sector.TestMemoryManagerStreams
testBlobStreamScale() - Method in class com.bigdata.rwstore.sector.TestMemoryManagerStreams
TestBlobsWriteTask - Class in com.bigdata.rdf.lexicon
TestBlobsWriteTask() - Constructor for class com.bigdata.rdf.lexicon.TestBlobsWriteTask
TestBlobsWriteTask(String) - Constructor for class com.bigdata.rdf.lexicon.TestBlobsWriteTask
TestBlockingBuffer - Class in com.bigdata.relation.accesspath
TestBlockingBuffer() - Constructor for class com.bigdata.relation.accesspath.TestBlockingBuffer
TestBlockingBuffer(String) - Constructor for class com.bigdata.relation.accesspath.TestBlockingBuffer
TestBlockingBufferPerformance740 - Class in com.bigdata.rdf.sparql.ast.eval
TestBlockingBufferPerformance740() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBlockingBufferPerformance740
TestBlockingBufferPerformance740(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBlockingBufferPerformance740
TestBlockingBufferWithChunks - Class in com.bigdata.relation.accesspath
TestBlockingBufferWithChunks() - Constructor for class com.bigdata.relation.accesspath.TestBlockingBufferWithChunks
TestBlockingBufferWithChunks(String) - Constructor for class com.bigdata.relation.accesspath.TestBlockingBufferWithChunks
TestBlockingBufferWithChunksDeque - Class in com.bigdata.relation.accesspath
TestBlockingBufferWithChunksDeque() - Constructor for class com.bigdata.relation.accesspath.TestBlockingBufferWithChunksDeque
TestBlockingBufferWithChunksDeque(String) - Constructor for class com.bigdata.relation.accesspath.TestBlockingBufferWithChunksDeque
testBlockingPut() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
put blocks interruptibly if full
testBlockingPut() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
put blocks interruptibly if full
testBlockingPutFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
putFirst blocks interruptibly if full
testBlockingPutLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
putLast blocks interruptibly if full
testBlockingTake() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Take removes existing elements until empty, then blocks interruptibly
testBlockingTake() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Take removes existing elements until empty, then blocks interruptibly
testBlockingTakeFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
TakeFirst removes existing elements until empty, then blocks interruptibly
testBlockingTakeLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
TakeLast removes existing elements until empty, then blocks interruptibly
TestBloomFilter - Class in com.bigdata.btree
Test suite for bloom filter functionality.
TestBloomFilter() - Constructor for class com.bigdata.btree.TestBloomFilter
TestBloomFilter(String) - Constructor for class com.bigdata.btree.TestBloomFilter
TestBLZG1943 - Class in com.bigdata.rdf.sail.webapp
TestBLZG1943() - Constructor for class com.bigdata.rdf.sail.webapp.TestBLZG1943
TestBLZG1943(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestBLZG1943
testBNodeReuse() - Method in class org.openrdf.sail.RDFStoreTest
testBNodeSerialization() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestBootstrapBigdataSail - Class in com.bigdata.rdf.sail
TestBootstrapBigdataSail() - Constructor for class com.bigdata.rdf.sail.TestBootstrapBigdataSail
TestBootstrapBigdataSail(String) - Constructor for class com.bigdata.rdf.sail.TestBootstrapBigdataSail
TestBOps - Class in com.bigdata.rdf.sail
TestBOps() - Constructor for class com.bigdata.rdf.sail.TestBOps
TestBOps(String) - Constructor for class com.bigdata.rdf.sail.TestBOps
TestBOpStats - Class in com.bigdata.bop.engine
TestBOpStats() - Constructor for class com.bigdata.bop.engine.TestBOpStats
TestBOpStats(String) - Constructor for class com.bigdata.bop.engine.TestBOpStats
TestBOpUtility - Class in com.bigdata.bop.rdf
TestBOpUtility() - Constructor for class com.bigdata.bop.rdf.TestBOpUtility
TestBOpUtility(String) - Constructor for class com.bigdata.bop.rdf.TestBOpUtility
TestBOpUtility - Class in com.bigdata.bop.util
TestBOpUtility() - Constructor for class com.bigdata.bop.util.TestBOpUtility
TestBOpUtility(String) - Constructor for class com.bigdata.bop.util.TestBOpUtility
TestBOpUtility_sharedVariables - Class in com.bigdata.bop.util
TestBOpUtility_sharedVariables() - Constructor for class com.bigdata.bop.util.TestBOpUtility_sharedVariables
TestBOpUtility_sharedVariables(String) - Constructor for class com.bigdata.bop.util.TestBOpUtility_sharedVariables
testBottomUpSemanticsExplainHint01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for FILTER scope issues.
testBottomUpSemanticsExplainHint02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for FILTER scope issues.
testBottomUpSemanticsExplainHint03() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for BIND scope issues.
testBottomUpSemanticsExplainHint04() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for BIND scope issues.
testBottomUpSemanticsExplainHint05() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for VALUES scope issues.
testBottomUpSemanticsExplainHint06() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is not attached, using an example with
BIND where no bottom-up semantics issues arise.
testBound() - Method in class com.bigdata.gom.TestGPO
TestBrokenDatetimeParsing - Class in com.bigdata.rdf.sparql.ast.eval
Test case fot date time parsing in queries when specifying dates containing a numerical time zone spec.
TestBrokenDatetimeParsing() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestBrokenDatetimeParsing
TestBsbmBIQuery - Class in com.bigdata.rdf.sparql.ast.eval.bsbm.bi
Data driven test suite for complex queries.
TestBsbmBIQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.bsbm.bi.TestBsbmBIQuery
TestBsbmBIQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.bsbm.bi.TestBsbmBIQuery
TestBsbmExploreQuery - Class in com.bigdata.rdf.sparql.ast.eval.bsbm.explore
Data driven test suite for complex queries.
TestBsbmExploreQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.bsbm.explore.TestBsbmExploreQuery
TestBsbmExploreQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.bsbm.explore.TestBsbmExploreQuery
TestBTree - Class in com.bigdata.btree
Stress tests for basic tree operations (insert, lookup, and remove) without
causing node or leaf evictions (IO is disabled).
TestBTree() - Constructor for class com.bigdata.btree.TestBTree
TestBTree(String) - Constructor for class com.bigdata.btree.TestBTree
TestBTreeBranchingFactors - Class in com.bigdata.btree
Unit tests of non-default B+Tree branching factors.
TestBTreeBranchingFactors() - Constructor for class com.bigdata.btree.TestBTreeBranchingFactors
TestBTreeBranchingFactors(String) - Constructor for class com.bigdata.btree.TestBTreeBranchingFactors
TestBTreeLeafCursors - Class in com.bigdata.btree
TestBTreeLeafCursors() - Constructor for class com.bigdata.btree.TestBTreeLeafCursors
TestBTreeLeafCursors(String) - Constructor for class com.bigdata.btree.TestBTreeLeafCursors
TestBTreeRecycle - Class in com.bigdata.btree
Test suite for recycling of B+Tree records.
TestBTreeRecycle() - Constructor for class com.bigdata.btree.TestBTreeRecycle
TestBTreeRecycle(String) - Constructor for class com.bigdata.btree.TestBTreeRecycle
TestBTreeWithBloomFilter - Class in com.bigdata.btree
Unit tests for a
BTree
with its bloom filter enabled.
TestBTreeWithBloomFilter() - Constructor for class com.bigdata.btree.TestBTreeWithBloomFilter
TestBTreeWithBloomFilter(String) - Constructor for class com.bigdata.btree.TestBTreeWithBloomFilter
TestBucketDataRecord_CanonicalHuffman_CanonicalHuffman - Class in com.bigdata.htree.data
Test suite for the HTree
ILeafData
records (accessing coded data in
place).
TestBucketDataRecord_CanonicalHuffman_CanonicalHuffman() - Constructor for class com.bigdata.htree.data.TestBucketDataRecord_CanonicalHuffman_CanonicalHuffman
TestBucketDataRecord_CanonicalHuffman_CanonicalHuffman(String) - Constructor for class com.bigdata.htree.data.TestBucketDataRecord_CanonicalHuffman_CanonicalHuffman
TestBucketDataRecord_Simple_Simple - Class in com.bigdata.htree.data
Test with simple coding for keys and values (no compression).
TestBucketDataRecord_Simple_Simple() - Constructor for class com.bigdata.htree.data.TestBucketDataRecord_Simple_Simple
TestBucketDataRecord_Simple_Simple(String) - Constructor for class com.bigdata.htree.data.TestBucketDataRecord_Simple_Simple
testBufferCapacity() - Method in class com.bigdata.rdf.sail.TestTicket1889
testBug() - Method in class com.bigdata.rdf.sail.TestMillisecondPrecisionForInlineDateTimes
testBug() - Method in class com.bigdata.rdf.sail.TestTemplate
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1681
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1682
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1716
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1747
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1753
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1755
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1785
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1788
testBug() - Method in class com.bigdata.rdf.sail.TestTicket1875
Test succeeds if all updates executed without any exceptions
testBug() - Method in class com.bigdata.rdf.sail.TestTicket2043
testBug() - Method in class com.bigdata.rdf.sail.TestTicket2043b
testBug() - Method in class com.bigdata.rdf.sail.TestTicket2083
testBug() - Method in class com.bigdata.rdf.sail.TestTicket275
testBug() - Method in class com.bigdata.rdf.sail.TestTicket276
testBug() - Method in class com.bigdata.rdf.sail.TestTicket348
testBug() - Method in class com.bigdata.rdf.sail.TestTicket353
testBug() - Method in class com.bigdata.rdf.sail.TestTicket355
testBug() - Method in class com.bigdata.rdf.sail.TestTicket4249
testBug() - Method in class com.bigdata.rdf.sail.TestTicket581
testBug() - Method in class com.bigdata.rdf.sail.TestTicket610
testBug() - Method in class com.bigdata.rdf.sail.TestTicket647
testBug() - Method in class com.bigdata.rdf.sail.TestTicket669
testBug() - Method in class com.bigdata.rdf.sail.TestTicket967
testBug1() - Method in class com.bigdata.rdf.sail.TestTicket693
TestBuildTask - Class in com.bigdata.resources
Basic test of building an index segment from an index partition on overflow.
TestBuildTask() - Constructor for class com.bigdata.resources.TestBuildTask
TestBuildTask(String) - Constructor for class com.bigdata.resources.TestBuildTask
TestBuildTask2 - Class in com.bigdata.resources
Basic test of building an index segment from an index partition on overflow.
TestBuildTask2() - Constructor for class com.bigdata.resources.TestBuildTask2
TestBuildTask2(String) - Constructor for class com.bigdata.resources.TestBuildTask2
testBuiltinLatLon01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary latitude only.
testBuiltinLatLon02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary longitude only.
testBuiltinLatLonTime01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary latitude only.
testBuiltinLatLonTime02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary longitude only.
testBuiltinLatLonTime03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary time only.
TestBulkFilter - Class in com.bigdata.rdf.store
Test bulk filter API.
TestBulkFilter() - Constructor for class com.bigdata.rdf.store.TestBulkFilter
TestBulkFilter(String) - Constructor for class com.bigdata.rdf.store.TestBulkFilter
TestByteArrayBuffer - Class in com.bigdata.io
TestByteArrayBuffer() - Constructor for class com.bigdata.io.TestByteArrayBuffer
TestByteArrayBuffer(String) - Constructor for class com.bigdata.io.TestByteArrayBuffer
TestByteBufferStreams - Class in com.bigdata.io
TestByteBufferStreams() - Constructor for class com.bigdata.io.TestByteBufferStreams
TestByteBufferStreams(String) - Constructor for class com.bigdata.io.TestByteBufferStreams
testByteBufferStreams00() - Method in class com.bigdata.io.TestByteBufferStreams
testByteBufferStreams02() - Method in class com.bigdata.io.TestByteBufferStreams
testByteBufferStreams03() - Method in class com.bigdata.io.TestByteBufferStreams
testByteBufferStreams04() - Method in class com.bigdata.io.TestByteBufferStreams
TestBytesUtil - Class in com.bigdata.btree
Test suite for low-level operations on variable length byte[]s.
TestBytesUtil() - Constructor for class com.bigdata.btree.TestBytesUtil
TestBytesUtil(String) - Constructor for class com.bigdata.btree.TestBytesUtil
testCache - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
TestCacheConnectionFactory - Class in com.bigdata.rdf.sparql.ast.cache
TestCacheConnectionFactory() - Constructor for class com.bigdata.rdf.sparql.ast.cache.TestCacheConnectionFactory
TestCacheConnectionFactory(String) - Constructor for class com.bigdata.rdf.sparql.ast.cache.TestCacheConnectionFactory
TestCanonicalHuffmanRabaCoder - Class in com.bigdata.btree.raba.codec
TestCanonicalHuffmanRabaCoder() - Constructor for class com.bigdata.btree.raba.codec.TestCanonicalHuffmanRabaCoder
TestCanonicalHuffmanRabaCoder(String) - Constructor for class com.bigdata.btree.raba.codec.TestCanonicalHuffmanRabaCoder
testCantAlwaysHaveDefaultStopWords() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testCantAlwaysHaveStopWords() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testCantFindStopWords() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
TestCase2 - Class in junit.framework
Extension of TestCase
that supports logging, loading test
resources, and hierarchical properties.
TestCase2() - Constructor for class junit.framework.TestCase2
TestCase2(String) - Constructor for class junit.framework.TestCase2
TestCase2.MyProperties - Class in junit.framework
Helper class gives us access to the default
Properties
.
TestCase2.MyProperties(String) - Constructor for class junit.framework.TestCase2.MyProperties
TestCase2.MyProperties(String, TestCase2.MyProperties) - Constructor for class junit.framework.TestCase2.MyProperties
TestCase2.RandomType - Class in junit.framework
Used to create objects of random type.
TestCase2.RandomType() - Constructor for class junit.framework.TestCase2.RandomType
TestCase3 - Class in com.bigdata.io
Base class for some
assertEquals
methods not covered by
TestCase
or
TestCase2
.
TestCase3() - Constructor for class com.bigdata.io.TestCase3
TestCase3(String) - Constructor for class com.bigdata.io.TestCase3
TestCase3 - Class in com.bigdata.service
Deprecated.
This is currently duplicating a class by the same name in
com.bigdata.io in the JOURNAL_HA_BRANCH. Those classes should be
reconciled.
I have added TestCase3.fillBufferWithRandomData(ByteBuffer)
to
this version of the class. That method should make it into the
original version of this class when they are reconciled.
TestCase3() - Constructor for class com.bigdata.service.TestCase3
Deprecated.
TestCase3(String) - Constructor for class com.bigdata.service.TestCase3
Deprecated.
testCast() - Method in class com.bigdata.rdf.sail.TestStrBOp
testCastAndDatatype() - Method in class com.bigdata.rdf.sail.TestLexJoinOps
TestCBD731<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
TestCBD731() - Constructor for class com.bigdata.rdf.sail.webapp.TestCBD731
TestCBD731(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestCBD731
TestChangeSets - Class in com.bigdata.rdf.sail
TestChangeSets() - Constructor for class com.bigdata.rdf.sail.TestChangeSets
TestChangeSets(String) - Constructor for class com.bigdata.rdf.sail.TestChangeSets
testChecksumError() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
TestChecksumUtility - Class in com.bigdata.io
TestChecksumUtility() - Constructor for class com.bigdata.io.TestChecksumUtility
TestChecksumUtility(String) - Constructor for class com.bigdata.io.TestChecksumUtility
TestChunkedFilter - Class in com.bigdata.striterator
TestChunkedFilter() - Constructor for class com.bigdata.striterator.TestChunkedFilter
TestChunkedFilter(String) - Constructor for class com.bigdata.striterator.TestChunkedFilter
TestChunkedIterators - Class in com.bigdata.btree
TestChunkedIterators() - Constructor for class com.bigdata.btree.TestChunkedIterators
TestChunkedIterators(String) - Constructor for class com.bigdata.btree.TestChunkedIterators
testCircleOutOfBounds01a() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that a circle query with illegal center point latitude
value fails.
testCircleOutOfBounds01b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that a circle query with illegal center point longitude
value fails.
testCircleOutOfBounds02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that a query that spans over the max lat + lon
values does not fail, but yields all data in the database.
testClear() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testClear() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
clear removes all elements
testClear() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
clear removes all elements
testClear() - Method in class org.openrdf.repository.RepositoryConnectionTest
testClearAll() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testClearAll() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testClearAll() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testClearDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testClearDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testClearGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testClearGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testClearNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testClearNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testClearNamespaces() - Method in class org.openrdf.sail.RDFStoreTest
TestClientException - Class in com.bigdata.service
Class written to verify the stack trace printing behavior of
ClientException
.
TestClientException() - Constructor for class com.bigdata.service.TestClientException
TestClientException(String) - Constructor for class com.bigdata.service.TestClientException
TestClockSkewDetection - Class in com.bigdata.journal
TestClockSkewDetection() - Constructor for class com.bigdata.journal.TestClockSkewDetection
TestClockSkewDetection(String) - Constructor for class com.bigdata.journal.TestClockSkewDetection
testClone() - Method in class com.bigdata.bop.bindingSet.TestListBindingSet
testClose() - Method in class org.openrdf.sail.RDFStoreTest
TestCloseableChunkedIteratorWrapperConverter - Class in com.bigdata.striterator
TestCloseableChunkedIteratorWrapperConverter() - Constructor for class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
TestCloseableChunkedIteratorWrapperConverter(String) - Constructor for class com.bigdata.striterator.TestCloseableChunkedIteratorWrapperConverter
testClosureOfMappedRuleWithOneTail() - Method in class com.bigdata.rdf.rules.TestMappedProgram
testClosureOfMappedRuleWithTwoTails() - Method in class com.bigdata.rdf.rules.TestMappedProgram
TestCnxnCreate - Class in com.bigdata.rdf.sail
Test suite for BLZG-2056 BigdataSailConnections not always closed by
BigdataSail.shutdown()
TestCnxnCreate() - Constructor for class com.bigdata.rdf.sail.TestCnxnCreate
TestCnxnCreate(String) - Constructor for class com.bigdata.rdf.sail.TestCnxnCreate
TestComboJoins - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite.
TestComboJoins() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestComboJoins
TestComboJoins(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestComboJoins
TestCommit - Class in com.bigdata.btree
Unit tests for commit functionality that do not trigger copy-on-write.
TestCommit() - Constructor for class com.bigdata.btree.TestCommit
TestCommit(String) - Constructor for class com.bigdata.btree.TestCommit
TestCommit - Class in com.bigdata.htree
Unit tests for commit functionality that do not trigger copy-on-write.
TestCommit() - Constructor for class com.bigdata.htree.TestCommit
TestCommit(String) - Constructor for class com.bigdata.htree.TestCommit
TestCommitCounterUtility - Class in com.bigdata.journal
TestCommitCounterUtility() - Constructor for class com.bigdata.journal.TestCommitCounterUtility
TestCommitCounterUtility(String) - Constructor for class com.bigdata.journal.TestCommitCounterUtility
TestCommitHistory - Class in com.bigdata.journal
Test the ability to get (exact match) and find (most recent less than or
equal to) historical commit records in a
Journal
.
TestCommitHistory() - Constructor for class com.bigdata.journal.TestCommitHistory
TestCommitHistory(String) - Constructor for class com.bigdata.journal.TestCommitHistory
TestCommitList - Class in com.bigdata.journal
TestCommitList() - Constructor for class com.bigdata.journal.TestCommitList
TestCommitList(String) - Constructor for class com.bigdata.journal.TestCommitList
TestCommitRecordIndex - Class in com.bigdata.journal
TestCommitRecordIndex() - Constructor for class com.bigdata.journal.TestCommitRecordIndex
TestCommitRecordIndex(String) - Constructor for class com.bigdata.journal.TestCommitRecordIndex
TestCommitRecordSerializer - Class in com.bigdata.journal
TestCommitRecordSerializer() - Constructor for class com.bigdata.journal.TestCommitRecordSerializer
TestCommitRecordSerializer(String) - Constructor for class com.bigdata.journal.TestCommitRecordSerializer
TestCompactingByteArrayBuffer - Class in com.bigdata.btree
Test harness used to develop a compacting buffer for maintaining branch nodes
and leaves in a B+Tree that minimizes copying on mutation of the node, helps
to minimize heap churn and GC latency related to long lived allocations, and
maintains the data in a serializable format.
TestCompactingByteArrayBuffer() - Constructor for class com.bigdata.btree.TestCompactingByteArrayBuffer
TestCompactingByteArrayBuffer(String) - Constructor for class com.bigdata.btree.TestCompactingByteArrayBuffer
testCompactingCopy() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
Test simple compaction of WriteCache
TestCompactJournal - Class in com.bigdata.journal
TestCompactJournal() - Constructor for class com.bigdata.journal.TestCompactJournal
TestCompactJournal(String) - Constructor for class com.bigdata.journal.TestCompactJournal
testCompareDates() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestCompareFullAndFastClosure - Class in com.bigdata.rdf.rules
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).
TestCompareFullAndFastClosure() - Constructor for class com.bigdata.rdf.rules.TestCompareFullAndFastClosure
TestCompareFullAndFastClosure(String) - Constructor for class com.bigdata.rdf.rules.TestCompareFullAndFastClosure
testCompletion() - Method in class com.bigdata.rdf.store.TestBulkFilter
Simple test of bulk SPO completion (value lookup).
TestCompletionScan - Class in com.bigdata.rdf.lexicon
TestCompletionScan() - Constructor for class com.bigdata.rdf.lexicon.TestCompletionScan
TestCompletionScan(String) - Constructor for class com.bigdata.rdf.lexicon.TestCompletionScan
testComplexALPNode() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
testComplexJoinGroup01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for more complex join groups.
testComplexJoinGroup02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for more complex join groups.
testComplexMultiplePartitions() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
Test multiple partitions including constructs other than simple
statement patterns.
testComplexOptimization01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test complex pattern, including inter- and intra-partition reordering,
excluding BIND and ASSIGNMENT nodes.
testComplexOptimization02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test complex pattern, including inter- and intra-partition reordering,
with focus on BIND and ASSIGNMENT nodes.
TestComplexQuery - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for complex queries.
TestComplexQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestComplexQuery
TestComplexQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestComplexQuery
testComplexWithQuery() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Test case comprising a complex WITH query that puts everything
together.
TestCompressedTimestampExtensionSPARQL - Class in com.bigdata.rdf.sparql.ast.eval
TestCompressedTimestampExtensionSPARQL() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestCompressedTimestampExtensionSPARQL
TestCompressedTimestampExtensionSPARQL(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestCompressedTimestampExtensionSPARQL
TestCompressorRegistry - Class in com.bigdata.io.compression
TestCompressorRegistry() - Constructor for class com.bigdata.io.compression.TestCompressorRegistry
testComputedValueExpressions() - Method in class com.bigdata.bop.solutions.TestMemorySortOp
Test with computed value expressions.
testCon - Variable in class org.openrdf.repository.RepositoryConnectionTest
testCon2 - Variable in class org.openrdf.repository.RepositoryConnectionTest
testConcat() - Method in class com.bigdata.rdf.sail.TestBOps
TestConcurrentJournal - Class in com.bigdata.journal
TestConcurrentJournal() - Constructor for class com.bigdata.journal.TestConcurrentJournal
TestConcurrentJournal(String) - Constructor for class com.bigdata.journal.TestConcurrentJournal
TestConcurrentKBCreate - Class in com.bigdata.rdf.sail
Test suite for the concurrent create and discovery of a KB instance.
TestConcurrentKBCreate() - Constructor for class com.bigdata.rdf.sail.TestConcurrentKBCreate
TestConcurrentKBCreate(String) - Constructor for class com.bigdata.rdf.sail.TestConcurrentKBCreate
TestConcurrentKBCreate.TestWithGroupCommit - Class in com.bigdata.rdf.sail
TestConcurrentKBCreate.TestWithGroupCommit() - Constructor for class com.bigdata.rdf.sail.TestConcurrentKBCreate.TestWithGroupCommit
TestConcurrentKBCreate.TestWithGroupCommit(String) - Constructor for class com.bigdata.rdf.sail.TestConcurrentKBCreate.TestWithGroupCommit
TestConcurrentKBCreate.TestWithoutGroupCommit - Class in com.bigdata.rdf.sail
TestConcurrentKBCreate.TestWithoutGroupCommit() - Constructor for class com.bigdata.rdf.sail.TestConcurrentKBCreate.TestWithoutGroupCommit
TestConcurrentKBCreate.TestWithoutGroupCommit(String) - Constructor for class com.bigdata.rdf.sail.TestConcurrentKBCreate.TestWithoutGroupCommit
testConcurrentRWWriterReader() - Method in class com.bigdata.ha.halog.TestHALogWriter
While a writer thread writes a number of HALogs, readers are opened
to process them.
TestConditionalRabaCoder_keys_simple_frontCoded - Class in com.bigdata.btree.raba.codec
TestConditionalRabaCoder_keys_simple_frontCoded() - Constructor for class com.bigdata.btree.raba.codec.TestConditionalRabaCoder_keys_simple_frontCoded
TestConditionalRabaCoder_keys_simple_frontCoded(String) - Constructor for class com.bigdata.btree.raba.codec.TestConditionalRabaCoder_keys_simple_frontCoded
TestConditionalRabaCoder_values_simple_canonical - Class in com.bigdata.btree.raba.codec
TestConditionalRabaCoder_values_simple_canonical() - Constructor for class com.bigdata.btree.raba.codec.TestConditionalRabaCoder_values_simple_canonical
TestConditionalRabaCoder_values_simple_canonical(String) - Constructor for class com.bigdata.btree.raba.codec.TestConditionalRabaCoder_values_simple_canonical
TestConditionalRoutingOp - Class in com.bigdata.bop.bset
TestConditionalRoutingOp() - Constructor for class com.bigdata.bop.bset.TestConditionalRoutingOp
TestConditionalRoutingOp(String) - Constructor for class com.bigdata.bop.bset.TestConditionalRoutingOp
TestConfigurableAnalyzerFactory - Class in com.bigdata.search
TestConfigurableAnalyzerFactory() - Constructor for class com.bigdata.search.TestConfigurableAnalyzerFactory
TestConfigurableAnalyzerFactory(String) - Constructor for class com.bigdata.search.TestConfigurableAnalyzerFactory
TestConfigurableAnalyzerFactory.NoStopWordsAnalyzer - Class in com.bigdata.search
TestConfigurableAnalyzerFactory.NoStopWordsAnalyzer() - Constructor for class com.bigdata.search.TestConfigurableAnalyzerFactory.NoStopWordsAnalyzer
TestConfigurableAsDefaultAnalyzerFactory - Class in com.bigdata.search
TestConfigurableAsDefaultAnalyzerFactory() - Constructor for class com.bigdata.search.TestConfigurableAsDefaultAnalyzerFactory
TestConfigurableAsDefaultAnalyzerFactory(String) - Constructor for class com.bigdata.search.TestConfigurableAsDefaultAnalyzerFactory
TestConfiguration - Class in com.bigdata.config
TestConfiguration() - Constructor for class com.bigdata.config.TestConfiguration
TestConfiguration(String) - Constructor for class com.bigdata.config.TestConfiguration
testConfiguredLanguages() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testConfiguredLanguages() - Method in class com.bigdata.search.TestUnconfiguredAnalyzerFactory
TestConflictResolution - Class in com.bigdata.btree.isolation
Tests of write-write conflict resolution.
TestConflictResolution() - Constructor for class com.bigdata.btree.isolation.TestConflictResolution
TestConflictResolution(String) - Constructor for class com.bigdata.btree.isolation.TestConflictResolution
TestConflictResolution.SingleValueConflictResolver - Class in com.bigdata.btree.isolation
Helper class used to resolve a predicted conflict to a known value.
TestConflictResolution.SingleValueConflictResolver(byte[], byte[]) - Constructor for class com.bigdata.btree.isolation.TestConflictResolution.SingleValueConflictResolver
TestConneg - Class in com.bigdata.rdf.sail.webapp
Test suite for content negotiation helper class.
TestConneg() - Constructor for class com.bigdata.rdf.sail.webapp.TestConneg
TestConneg(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestConneg
testConsecutiveUpdatesInSameTransaction() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
This test fails for two reasons.
TestConstant - Class in com.bigdata.bop
TestConstant() - Constructor for class com.bigdata.bop.TestConstant
TestConstant(String) - Constructor for class com.bigdata.bop.TestConstant
TestConstrainKeys - Class in com.bigdata.btree
Test imposing constraint on a fromKey or toKey based on an index partition's
boundaries.
TestConstrainKeys() - Constructor for class com.bigdata.btree.TestConstrainKeys
TestConstrainKeys(String) - Constructor for class com.bigdata.btree.TestConstrainKeys
TestConstruct - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for CONSTRUCT queries.
TestConstruct() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestConstruct
TestConstruct(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestConstruct
testConstructFiltersForValueExpressionNodeMethod() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
testConstructionAndUtilities() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestGroupNodeVarBindingInfo
Test interface implementation for statement patterns nodes.
testConstructor() - Method in class com.bigdata.bop.constraint.TestEQConstant
testConstructor() - Method in class com.bigdata.bop.constraint.TestINConstraint
Unit test for INHashMap#INHashMap(IVariable,IConstant[])
testConstructor() - Method in class com.bigdata.bop.constraint.TestNE
testConstructor() - Method in class com.bigdata.bop.constraint.TestNEConstant
testConstructor() - Method in class com.bigdata.bop.constraint.TestOR
Unit test for OR#OR(IConstraint,IConstraint)
testConstructor1() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
A new deque has the indicated capacity, or Integer.MAX_VALUE if
none given
testConstructor1() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
A new queue has the indicated capacity, or Integer.MAX_VALUE if
none given
testConstructor2() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Constructor throws IAE if capacity argument nonpositive
testConstructor2() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Constructor throws IAE if capacity argument nonpositive
testConstructor3() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Initializing from null Collection throws NPE
testConstructor3() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Initializing from null Collection throws NPE
testConstructor4() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Initializing from Collection of null elements throws NPE
testConstructor4() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Initializing from Collection of null elements throws NPE
testConstructor5() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Initializing from Collection with some null elements throws NPE
testConstructor5() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Initializing from Collection with some null elements throws NPE
testConstructor6() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Deque contains all elements of collection used to initialize
testConstructor6() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Queue contains all elements of collection used to initialize
testConstructor7() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
testConstructor8() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Initializing from null Lock throws NPE
testConstructorHashBindingSet() - Method in class com.bigdata.bop.bindingSet.TestHashBindingSet
testConstructorHashBindingSetHashBindingSet() - Method in class com.bigdata.bop.bindingSet.TestHashBindingSet
Unit test for HashBindingSet#HashBindingSet(HashBindingSet)
testConstructorHashBindingSetIBindingSet() - Method in class com.bigdata.bop.bindingSet.TestHashBindingSet
testConstructorListBindingSet() - Method in class com.bigdata.bop.bindingSet.TestListBindingSet
testConstructorVariablesConstants() - Method in class com.bigdata.bop.bindingSet.TestHashBindingSet
testConstructorVariablesConstants() - Method in class com.bigdata.bop.bindingSet.TestListBindingSet
testContains() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
contains(x) reports true when elements added but not yet removed
testContains() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
contains(x) reports true when elements added but not yet removed
testContainsAll() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
containsAll(c) is true when c contains a subset of elements
testContainsAll() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
containsAll(c) is true when c contains a subset of elements
TestContextAdvancer - Class in com.bigdata.rdf.rules
TestContextAdvancer() - Constructor for class com.bigdata.rdf.rules.TestContextAdvancer
TestContextAdvancer(String) - Constructor for class com.bigdata.rdf.rules.TestContextAdvancer
testContextChange() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenJoinGroupsOptimizer
testContexts() - Method in class org.openrdf.sail.RDFStoreTest
TestCoordinateDD - Class in com.bigdata.rdf.internal.gis
TestCoordinateDD() - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateDD
TestCoordinateDD(String) - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateDD
TestCoordinateDDM - Class in com.bigdata.rdf.internal.gis
TestCoordinateDDM() - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateDDM
TestCoordinateDDM(String) - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateDDM
TestCoordinateDMS - Class in com.bigdata.rdf.internal.gis
TestCoordinateDMS() - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateDMS
TestCoordinateDMS(String) - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateDMS
testCoordinateSystemInLatLonDatatype() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
testCoordinateSystemInNonLatLonDatatype() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
TestCoordinateUtility - Class in com.bigdata.rdf.internal.gis
TestCoordinateUtility() - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateUtility
TestCoordinateUtility(String) - Constructor for class com.bigdata.rdf.internal.gis.TestCoordinateUtility
testCopy() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
TestCopyBindingSets - Class in com.bigdata.bop.bset
TestCopyBindingSets() - Constructor for class com.bigdata.bop.bset.TestCopyBindingSets
TestCopyBindingSets(String) - Constructor for class com.bigdata.bop.bset.TestCopyBindingSets
testCopyFromDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCopyFromDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testCopyFromDefaultToDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCopyFromDefaultToDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
TestCopyOnWrite - Class in com.bigdata.btree
Test suite for copy-on-write semantics.
TestCopyOnWrite() - Constructor for class com.bigdata.btree.TestCopyOnWrite
TestCopyOnWrite(String) - Constructor for class com.bigdata.btree.TestCopyOnWrite
TestCopyStream - Class in com.bigdata.bfs
Unit tests for copying streams into the repository and reading them back.
TestCopyStream() - Constructor for class com.bigdata.bfs.TestCopyStream
TestCopyStream(String) - Constructor for class com.bigdata.bfs.TestCopyStream
testCopyToDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCopyToDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testCopyToExistingNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCopyToExistingNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testCopyToNewNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCopyToNewNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
TestCOUNT - Class in com.bigdata.bop.rdf.aggregate
TestCOUNT() - Constructor for class com.bigdata.bop.rdf.aggregate.TestCOUNT
TestCOUNT(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestCOUNT
testCountCommits() - Method in class com.bigdata.rdf.sail.TestSparqlUpdateCommit
Test whether sparql update results in auto-commit.
TestCounters - Class in com.bigdata.counters
TestCounters() - Constructor for class com.bigdata.counters.TestCounters
TestCounters(String) - Constructor for class com.bigdata.counters.TestCounters
TestCounterSetBTree - Class in com.bigdata.counters.store
TestCounterSetBTree() - Constructor for class com.bigdata.counters.store.TestCounterSetBTree
TestCounterSetBTree(String) - Constructor for class com.bigdata.counters.store.TestCounterSetBTree
TestCounterSetHTTPDServer - Class in com.bigdata.counters.httpd
TestCounterSetHTTPDServer() - Constructor for class com.bigdata.counters.httpd.TestCounterSetHTTPDServer
testCRCustomFieldsValueButNoCustomFields() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the time value, but the index contains no time.
testCRDistanceButNoGeospatialComponent() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the distance, but the index contains no latitude/longitude.
testCRDistanceButRectangleQuery() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the distance, but the index contains no latitude/longitude.
testCreateExistingGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCreateExistingGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testCreateNewGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testCreateNewGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testCreateURI1() - Method in class org.openrdf.sail.RDFStoreTest
testCreateURI2() - Method in class org.openrdf.sail.RDFStoreTest
testCRInCircleInvalidCenterGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where circle query is given with an invalid center
testCRInCircleInvalidRadiusGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where circle query is given with an invalid radius
testCRInCircleNoCenterGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where circle query is given but no circle center is specified.
testCRInCircleNoRadiusGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where circle query is given but no radius is specified.
testCRInCircleNorthEastGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where circle query is given in combination with a north-east coordinate.
testCRInCircleSouthWestGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where circle query is given in combination with a south-west coordinate.
testCRIncompleteCustomFields() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields specification being incomplete.
testCRInRectangleCenterGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where rectangle query is given in combination with a circle center.
testCRInRectangleInvalidNorthEast() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where rectangle query is given and north-east is not a valid coordinate.
testCRInRectangleInvalidSouthWest() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where rectangle query is given and south-west is not a valid coordinate.
testCRInRectangleNoNorthEast() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where rectangle query is given, but no north-east coordinate is specified.
testCRInRectangleNoSouthWest() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where rectangle query is given, but no south-west coordinate is specified.
testCRInRectangleRadiusGiven() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where rectangle query is given in combination with a circle radius.
testCRInvalidGeoFunction() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where geo function is invalid.
testCRLatValueButNoLocation() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the latitude value, but the index contains no location.
testCRLocationAndTimeValueButNoLocation() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the locationAndTime value, but the index contains no location.
testCRLocationAndTimeValueButNoTime() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the locationAndTime value, but the index contains no time.
testCRLocationValueButNoLocation() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the location value, but the index contains no location.
testCRLonValueButNoLocation() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the longitude value, but the index contains no location.
testCRMissingCoordSystem() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where coordinate system is given, but index requires it.
testCRMissingCustomFields01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields specification missing.
testCRMissingCustomFields02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields specification missing.
testCRMissingCustomFields03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields specification missing.
testCRMissingCustomFields04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields specification missing.
testCRMissingGeoFunction() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where geo function is not given, but index requires it.
testCRMissingTimeEnd() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with timeEnd specification missing.
testCRMissingTimeStart() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with timeStart specification missing.
testCRTimeValueButNoTime() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we aim at extracting the time value, but the index contains no time.
testCRTooManyCustomFields() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields specification containing too many elements.
testCRUnknownGeoSpatialDatatype() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where we query a datatype that is not a geospatial one.
testCRUnusableCoordSystem() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where coordinate system is given, but index cannot use it.
testCRUnusableCustomFields() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with customFields given, but no custom fields being defined in the index.
testCRUnusableGeoFunction() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case where geo function is given, but index cannot use it.
testCRUnusableTimeEnd() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with timeEnd specification missing, but not present in index.
testCRUnusableTimeStart() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with timeStart specification given, but not present in index.
testCRWrongDataFormat01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with geospatial literal that has too many elements.
testCRWrongDataFormat02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with geospatial literal that has not enough elements.
testCRWrongDataFormat03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
Test case with geospatial literal that is not numerical.
testCustomDatatypeCircle01LatLonTime() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Circle query over lat+lon+time datatype and database containing
lat+lon+time only data.
testCustomDatatypeCircle01LatLonTimeMixedData() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Circle query over lat+lon+time datatype and database containing mixed data.
testCustomDatatypeCircle01LatTimeLon() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Circle query over lat+time+lon datatype and database containing
lat+time+lon only data.
testCustomDatatypeCircle01LatTimeLonMixedData() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over lat+lon+time datatype and database containing mixed data.
testCustomDatatypeCircle01TimeLatLon() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Circle query over lat+time+lon datatype and database containing
lat+time+lon only data.
testCustomDatatypeCircle01TimeLatLonMixedData() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Circle query over time+lat+lon datatype and database containing mixed data.
testCustomDatatypePrecision() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Verify precision handling, which is changed in the configuration to be 6 for
the first component and 5 for the second one.
testCustomDatatypeRect01LatLonTime() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over lat+lon+time datatype and database containing
lat+lon+time only data.
testCustomDatatypeRect01LatLonTimeMixedData() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over lat+lon+time datatype and database containing mixed data.
testCustomDatatypeRect01LatTimeLon() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over lat+time+lon datatype and database containing
lat+time+lon only data.
testCustomDatatypeRect01LatTimeLonMixedData() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over lat+lon+time datatype and database containing mixed data.
testCustomDatatypeRect01TimeLatLon() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over lat+time+lon datatype and database containing
lat+time+lon only data.
testCustomDatatypeRect01TimeLatLonMixedData() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Rectangle query over time+lat+lon datatype and database containing mixed data.
testCustomFieldsBindingInjection01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Test bindings injection in custom fields values from outside.
testCustomFieldsBindingInjection02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Test bindings injection in custom fields values from outside.
testCustomFieldsMixed01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Test mixing up service keywords for different datatypes.
testCustomFieldsTimeXYZ01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (TIME,x,y,z) index
testCustomFieldsTimeXYZ02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (TIME,x,y,z) index, where we additionally
extract values from the index.
testCustomFieldsTimeXYZ03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (TIME,x,y,z) index, with just the field
order definition inverted in the query.
testCustomFieldsTimeXYZ04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (TIME,x,y,z) index with full literal value extraction.
testCustomFieldsXYZ01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z) index
testCustomFieldsXYZ02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z) index, where we additionally
extract values from the index.
testCustomFieldsXYZ03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z) index, with just the field
order definition inverted in the query.
testCustomFieldsXYZ04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z) index, with full literal extraction.
testCustomFieldsXYZLatLonTime01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index
testCustomFieldsXYZLatLonTime02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract values from the index.
testCustomFieldsXYZLatLonTime02b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime02c() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime02d() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime02e() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime02f() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime02g() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime02h() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, where we
additionally extract a single value from the index.
testCustomFieldsXYZLatLonTime03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index, with just the field
order definition inverted in the query.
testCustomFieldsXYZLatLonTime04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index.
testCustomFieldsXYZLatLonTime05() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
Simple basic test case for (x,y,z,TIME,LAT,LON) index.
TestCustomFunction - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for registering and evaluating custom functions.
TestCustomFunction() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestCustomFunction
TestCustomFunction(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestCustomFunction
testCustomHistory() - Method in class com.bigdata.rdf.sail.TestRDRHistory
Test custom history handler.
TestCustomTypeCasts - Class in com.bigdata.rdf.sparql.ast.eval
TestCustomTypeCasts() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestCustomTypeCasts
TestCustomTypeCasts(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestCustomTypeCasts
testCustomUUIDNamespace() - Method in class com.bigdata.rdf.store.TestInlineURIs
testCustomXYZLatLonTimeCoord01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary x only.
testCustomXYZLatLonTimeCoord02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary y only.
testCustomXYZLatLonTimeCoord03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary z only.
testCustomXYZLatLonTimeCoord04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary latitude only.
testCustomXYZLatLonTimeCoord05() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary longitude only.
testCustomXYZLatLonTimeCoord06() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary time only.
testCustomXYZLatLonTimeCoord07() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
Vary coordinate system only.
TestDatabaseAtOnceClosure - Class in com.bigdata.rdf.rules
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).
TestDatabaseAtOnceClosure() - Constructor for class com.bigdata.rdf.rules.TestDatabaseAtOnceClosure
TestDatabaseAtOnceClosure(String) - Constructor for class com.bigdata.rdf.rules.TestDatabaseAtOnceClosure
TestDataLoader - Class in com.bigdata.rdf.store
TestDataLoader() - Constructor for class com.bigdata.rdf.store.TestDataLoader
TestDataLoader(String) - Constructor for class com.bigdata.rdf.store.TestDataLoader
TestDataLoaderServlet<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
TestDataLoaderServlet() - Constructor for class com.bigdata.rdf.sail.webapp.TestDataLoaderServlet
TestDataLoaderServlet(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestDataLoaderServlet
TestDataOutputBuffer - Class in com.bigdata.io
TestDataOutputBuffer() - Constructor for class com.bigdata.io.TestDataOutputBuffer
TestDataOutputBuffer(String) - Constructor for class com.bigdata.io.TestDataOutputBuffer
testDataset() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestDataSetJoin - Class in com.bigdata.bop.rdf.join
TestDataSetJoin() - Constructor for class com.bigdata.bop.rdf.join.TestDataSetJoin
TestDataSetJoin(String) - Constructor for class com.bigdata.bop.rdf.join.TestDataSetJoin
testDateFunction() - Method in class com.bigdata.rdf.sail.TestTicket1388
When loading quads into a triple store, the context is striped away by
default.
TestDechunkerator - Class in com.bigdata.striterator
TestDechunkerator() - Constructor for class com.bigdata.striterator.TestDechunkerator
TestDechunkerator(String) - Constructor for class com.bigdata.striterator.TestDechunkerator
testDecimalRoundTrip() - Method in class org.openrdf.sail.RDFStoreTest
TestDecodeParams - Class in com.bigdata.util.httpd
TestDecodeParams() - Constructor for class com.bigdata.util.httpd.TestDecodeParams
TestDecodeParams(String) - Constructor for class com.bigdata.util.httpd.TestDecodeParams
TestDeepCopy - Class in com.bigdata.bop
Unit tests for the existence of the required deep copy semantics for
BOp
s.
TestDeepCopy() - Constructor for class com.bigdata.bop.TestDeepCopy
TestDeepCopy(String) - Constructor for class com.bigdata.bop.TestDeepCopy
TestDefaultAnalyzerFactory - Class in com.bigdata.search
TestDefaultAnalyzerFactory() - Constructor for class com.bigdata.search.TestDefaultAnalyzerFactory
TestDefaultAnalyzerFactory(String) - Constructor for class com.bigdata.search.TestDefaultAnalyzerFactory
testDefaultContext() - Method in class org.openrdf.repository.RepositoryConnectionTest
testDefaultDatatypeExplicit() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
Query against default datatype explicitly naming default.
testDefaultDatatypeImplicit() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
Query against default datatype explicitly not naming default.
TestDefaultDuplicateRemover - Class in com.bigdata.service.ndx.pipeline
TestDefaultDuplicateRemover() - Constructor for class com.bigdata.service.ndx.pipeline.TestDefaultDuplicateRemover
TestDefaultDuplicateRemover(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestDefaultDuplicateRemover
TestDefaultEvaluationPlan - Class in com.bigdata.bop.joinGraph.fast
TestDefaultEvaluationPlan() - Constructor for class com.bigdata.bop.joinGraph.fast.TestDefaultEvaluationPlan
TestDefaultEvaluationPlan(String) - Constructor for class com.bigdata.bop.joinGraph.fast.TestDefaultEvaluationPlan
TestDefaultGraphs - Class in com.bigdata.rdf.sparql.ast.eval
Unit tests for default graph semantics ported from the old
TestDefaultGraphAccessPath class.
TestDefaultGraphs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDefaultGraphs
TestDefaultGraphs(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDefaultGraphs
testDefaultInsertContext() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestDefaultResourceLocator - Class in com.bigdata.relation.locator
Test suite for location relations, etc.
TestDefaultResourceLocator() - Constructor for class com.bigdata.relation.locator.TestDefaultResourceLocator
TestDefaultResourceLocator(String) - Constructor for class com.bigdata.relation.locator.TestDefaultResourceLocator
TestDelete - Class in com.bigdata.bop.mutation
Test suite for DeleteOp
.
TestDelete() - Constructor for class com.bigdata.bop.mutation.TestDelete
TestDelete(String) - Constructor for class com.bigdata.bop.mutation.TestDelete
testDeleteData() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteData() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteDataFromGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteDataFromGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteDataFromWrongGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteDataFromWrongGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteDataMultiplePatterns() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteDataMultiplePatterns() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteDefaultGraph() - Method in class org.openrdf.repository.RepositoryConnectionTest
testDeleteInsertWhere() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteInsertWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteInsertWhereLoopingBehavior() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteInsertWhereLoopingBehavior() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteInsertWhereWithBindings() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteInsertWhereWithBindings2() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
TestDeleteMarkers - Class in com.bigdata.btree
Test of basic btree operations when delete markers are maintained.
TestDeleteMarkers() - Constructor for class com.bigdata.btree.TestDeleteMarkers
TestDeleteMarkers(String) - Constructor for class com.bigdata.btree.TestDeleteMarkers
testDeleteTransformedWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteWhere() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteWhereOptional() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteWhereShortcut() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDeleteWhereShortcut() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDeleteWhereShortcut2() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
DELETE WHERE {GRAPH ?g {?x foaf:name ?y} }
testDescendingIterator() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Descending iterator iterates through all elements
testDescendingIteratorOrdering() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Descending iterator ordering is reverse FIFO
testDescendingIteratorRemove() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
descendingIterator.remove removes current element
TestDescribe - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for DESCRIBE queries, including the interaction with
the optional DESCRIBE cache.
TestDescribe() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDescribe
TestDescribe(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDescribe
testDescribeA() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testDescribeA() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testDescribeAWhere() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testDescribeAWhere() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testDescribeB() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testDescribeB() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testDescribeD() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testDescribeD() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testDescribeF() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testDescribeF() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testDescribeWhere() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testDeviceAddress() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testDimensionValueExtracion01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that location value is properly extracted.
testDimensionValueExtracion02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that time value is properly extracted.
testDimensionValueExtracion03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that location + time value is properly extracted.
testDimensionValueExtracion04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify that all dimension values are extracted properly
when respective output variables are present
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
TestDirectBufferPool - Class in com.bigdata.io
TestDirectBufferPool() - Constructor for class com.bigdata.io.TestDirectBufferPool
TestDirectBufferPool(String) - Constructor for class com.bigdata.io.TestDirectBufferPool
TestDirectBufferPoolAllocator - Class in com.bigdata.io
TestDirectBufferPoolAllocator() - Constructor for class com.bigdata.io.TestDirectBufferPoolAllocator
TestDirectBufferPoolAllocator(String) - Constructor for class com.bigdata.io.TestDirectBufferPoolAllocator
TestDirectJournal - Class in com.bigdata.journal
TestDirectJournal() - Constructor for class com.bigdata.journal.TestDirectJournal
TestDirectJournal(String) - Constructor for class com.bigdata.journal.TestDirectJournal
TestDirectJournal.TestInterrupts - Class in com.bigdata.journal
TestDirectJournal.TestInterrupts() - Constructor for class com.bigdata.journal.TestDirectJournal.TestInterrupts
TestDirectJournal.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestDirectJournal.TestInterrupts
TestDirectJournal.TestMRMW - Class in com.bigdata.journal
TestDirectJournal.TestMRMW() - Constructor for class com.bigdata.journal.TestDirectJournal.TestMRMW
TestDirectJournal.TestMRMW(String) - Constructor for class com.bigdata.journal.TestDirectJournal.TestMRMW
TestDirectJournal.TestMROW - Class in com.bigdata.journal
TestDirectJournal.TestMROW() - Constructor for class com.bigdata.journal.TestDirectJournal.TestMROW
TestDirectJournal.TestMROW(String) - Constructor for class com.bigdata.journal.TestDirectJournal.TestMROW
TestDirectJournal.TestRawStore - Class in com.bigdata.journal
TestDirectJournal.TestRawStore() - Constructor for class com.bigdata.journal.TestDirectJournal.TestRawStore
TestDirectJournal.TestRawStore(String) - Constructor for class com.bigdata.journal.TestDirectJournal.TestRawStore
testDirectSockets() - Method in class com.bigdata.ha.pipeline.TestSocketsDirect
The use of threaded tasks in the send/receive service makes it difficult to
observer the socket state changes.
testDirectSockets_exceptionIfPortNotOpen() - Method in class com.bigdata.ha.pipeline.TestSocketsDirect
Simple test of connecting to a server socket and the failure to connect
to a port not associated with a server socket.
testDirectSockets_largeWrite_NotAccepted() - Method in class com.bigdata.ha.pipeline.TestSocketsDirect
Test of a large write on a socket to understand what happens when the
write is greater than the combined size of the client send buffer and the
server receive buffer and the server side of the socket is either not
accepted or already shutdown.
TestDirtyIterators - Class in com.bigdata.btree
Test suite for iterators that visit only dirty nodes or leaves.
TestDirtyIterators() - Constructor for class com.bigdata.btree.TestDirtyIterators
TestDirtyIterators(String) - Constructor for class com.bigdata.btree.TestDirtyIterators
TestDirtyIterators - Class in com.bigdata.htree
Test suite for iterators that visit only dirty nodes or leaves.
TestDirtyIterators() - Constructor for class com.bigdata.htree.TestDirtyIterators
TestDirtyIterators(String) - Constructor for class com.bigdata.htree.TestDirtyIterators
TestDirtyListener - Class in com.bigdata.btree
TestDirtyListener() - Constructor for class com.bigdata.btree.TestDirtyListener
TestDirtyListener(String) - Constructor for class com.bigdata.btree.TestDirtyListener
TestDirtyListener - Class in com.bigdata.htree
TestDirtyListener() - Constructor for class com.bigdata.htree.TestDirtyListener
TestDirtyListener(String) - Constructor for class com.bigdata.htree.TestDirtyListener
testDisableBuiltin01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDisableBuiltinDatatypes
Verify that built-in lat+lon datatype is disabled
testDisableBuiltin02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDisableBuiltinDatatypes
Verify that built-in lat+lon+time datatype is disabled
testDisableBuiltin03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDisableBuiltinDatatypes
Verify that specifically registered datatypes is working properly.
testDisableLogFile() - Method in class com.bigdata.ha.althalog.TestAltHALogWriter
TestDiskJournal - Class in com.bigdata.journal
TestDiskJournal() - Constructor for class com.bigdata.journal.TestDiskJournal
Deprecated.
TestDiskJournal(String) - Constructor for class com.bigdata.journal.TestDiskJournal
Deprecated.
TestDiskJournal.TestInterrupts - Class in com.bigdata.journal
Deprecated.
TestDiskJournal.TestInterrupts() - Constructor for class com.bigdata.journal.TestDiskJournal.TestInterrupts
Deprecated.
TestDiskJournal.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestDiskJournal.TestInterrupts
Deprecated.
TestDiskJournal.TestMRMW - Class in com.bigdata.journal
Deprecated.
TestDiskJournal.TestMRMW() - Constructor for class com.bigdata.journal.TestDiskJournal.TestMRMW
Deprecated.
TestDiskJournal.TestMRMW(String) - Constructor for class com.bigdata.journal.TestDiskJournal.TestMRMW
Deprecated.
TestDiskJournal.TestMROW - Class in com.bigdata.journal
Deprecated.
TestDiskJournal.TestMROW() - Constructor for class com.bigdata.journal.TestDiskJournal.TestMROW
Deprecated.
TestDiskJournal.TestMROW(String) - Constructor for class com.bigdata.journal.TestDiskJournal.TestMROW
Deprecated.
TestDiskJournal.TestRawStore - Class in com.bigdata.journal
Deprecated.
TestDiskJournal.TestRawStore() - Constructor for class com.bigdata.journal.TestDiskJournal.TestRawStore
Deprecated.
TestDiskJournal.TestRawStore(String) - Constructor for class com.bigdata.journal.TestDiskJournal.TestRawStore
Deprecated.
TestDistinct - Class in com.bigdata.rdf.rules
TestDistinct() - Constructor for class com.bigdata.rdf.rules.TestDistinct
TestDistinct(String) - Constructor for class com.bigdata.rdf.rules.TestDistinct
TestDistinctFilter - Class in com.bigdata.striterator
TestDistinctFilter() - Constructor for class com.bigdata.striterator.TestDistinctFilter
TestDistinctFilter(String) - Constructor for class com.bigdata.striterator.TestDistinctFilter
TestDistinctTermScan - Class in com.bigdata.rdf.rules
TestDistinctTermScan() - Constructor for class com.bigdata.rdf.rules.TestDistinctTermScan
TestDistinctTermScan(String) - Constructor for class com.bigdata.rdf.rules.TestDistinctTermScan
TestDistinctTermScanOp - Class in com.bigdata.bop.join
TestDistinctTermScanOp() - Constructor for class com.bigdata.bop.join.TestDistinctTermScanOp
TestDistinctTermScanOp(String) - Constructor for class com.bigdata.bop.join.TestDistinctTermScanOp
TestDistinctTermScanOptimizer - Class in com.bigdata.rdf.sparql.ast.eval
TestDistinctTermScanOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDistinctTermScanOptimizer
TestDistinctTermScanOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDistinctTermScanOptimizer
TestDistinctTermScanOptimizer.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
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.
TestDistinctTermScanOptimizer.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDistinctTermScanOptimizer.TestQuadsModeAPs
TestDistinctTermScanOptimizer.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Triples mode test suite.
TestDistinctTermScanOptimizer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestDistinctTermScanOptimizer.TestTriplesModeAPs
TestDistributedTransactionService - Class in com.bigdata.service
TestDistributedTransactionService() - Constructor for class com.bigdata.service.TestDistributedTransactionService
TestDistributedTransactionService(String) - Constructor for class com.bigdata.service.TestDistributedTransactionService
TestDistributedTransactionServiceRestart - Class in com.bigdata.service
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).
TestDistributedTransactionServiceRestart() - Constructor for class com.bigdata.service.TestDistributedTransactionServiceRestart
TestDistributedTransactionServiceRestart(String) - Constructor for class com.bigdata.service.TestDistributedTransactionServiceRestart
TestDistributedTransactionServiceRestart.MockDistributedTransactionService - Class in com.bigdata.service
TestDistributedTransactionServiceRestart.MockDistributedTransactionService(Properties) - Constructor for class com.bigdata.service.TestDistributedTransactionServiceRestart.MockDistributedTransactionService
testDocumentationBuiltin01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
Built-in datatype example
testDocumentationBuiltin01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryIfGeospatialDisabled
Submit a query and make sure it fails with proper exception if
geospatial SERVCIE is not enabled.
testDocumentationBuiltin02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
Built-in datatype example
testDocumentationBuiltin03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
Built-in datatype example
testDocumentationBuiltin04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
Built-in datatype example
testDocumentationCustomLLTT01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
latitude-longitude-starttime-endtime example from documentation
testDocumentationCustomWHL01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
width-height-length datatype example from documentation
TestDoubleOpen - Class in com.bigdata.journal
Test the ability to rollback a commit.
TestDoubleOpen() - Constructor for class com.bigdata.journal.TestDoubleOpen
TestDoubleOpen(String) - Constructor for class com.bigdata.journal.TestDoubleOpen
testDrainTo() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo(c) empties deque into another collection c
testDrainTo() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo(c) empties queue into another collection c
testDrainToN() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo(c, n) empties first min(n, size) elements of queue into c
testDrainToN() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo(c, n) empties first min(n, size) elements of queue into c
testDrainToNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo(null) throws NPE
testDrainToNull() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo(null) throws NPE
testDrainToNullN() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo(null, n) throws NPE
testDrainToNullN() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo(null, n) throws NPE
testDrainToSelf() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo(this) throws IAE
testDrainToSelf() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo(this) throws IAE
testDrainToSelfN() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo(this, n) throws IAE
testDrainToSelfN() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo(this, n) throws IAE
testDrainToWithActivePut() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
drainTo empties full deque, unblocking a waiting put.
testDrainToWithActivePut() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
drainTo empties full queue, unblocking a waiting put.
testDropAll() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDropAll() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDropDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDropDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDropGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDropGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testDropNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testDropNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
TestDTE - Class in com.bigdata.rdf.internal
TestDTE() - Constructor for class com.bigdata.rdf.internal.TestDTE
TestDTE(String) - Constructor for class com.bigdata.rdf.internal.TestDTE
TestDTEFlags - Class in com.bigdata.rdf.internal
TestDTEFlags() - Constructor for class com.bigdata.rdf.internal.TestDTEFlags
TestDTEFlags(String) - Constructor for class com.bigdata.rdf.internal.TestDTEFlags
testDualConnections() - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
Bigdata uses snapshot isolation for transactions while openrdf assumes
that any writes committed by a transaction become immediately visible to
transactions which are already running.
testDualConnections() - Method in class org.openrdf.sail.RDFStoreTest
TestDumpJournal - Class in com.bigdata.journal
TestDumpJournal() - Constructor for class com.bigdata.journal.TestDumpJournal
TestDumpJournal(String) - Constructor for class com.bigdata.journal.TestDumpJournal
testDuplicateFilter() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestDuplicates - Class in com.bigdata.htree
Test
HTree
with duplicate keys.
TestDuplicates() - Constructor for class com.bigdata.htree.TestDuplicates
TestDuplicates(String) - Constructor for class com.bigdata.htree.TestDuplicates
testEchoBackHeader() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
TestEDS - Class in com.bigdata.service
TestEDS() - Constructor for class com.bigdata.service.TestEDS
TestEDS(String) - Constructor for class com.bigdata.service.TestEDS
testElement() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
element returns next element, or throws NSEE if empty
testElement() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
element returns next element, or throws NSEE if empty
TestEmbeddedClient - Class in com.bigdata.service
TestEmbeddedClient() - Constructor for class com.bigdata.service.TestEmbeddedClient
TestEmbeddedClient(String) - Constructor for class com.bigdata.service.TestEmbeddedClient
testEmpty() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
isEmpty is true before add, false after
testEmptyAnalyzer() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testEmptyCommit() - Method in class org.openrdf.repository.RepositoryConnectionTest
testEmptyFull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Deque transitions from empty to full when elements added
testEmptyFull() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Queue transitions from empty to full when elements added
testEmptyPartitions() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
Test empty partition.
TestEmptyRabaCoder - Class in com.bigdata.btree.raba.codec
TestEmptyRabaCoder() - Constructor for class com.bigdata.btree.raba.codec.TestEmptyRabaCoder
TestEmptyRabaCoder(String) - Constructor for class com.bigdata.btree.raba.codec.TestEmptyRabaCoder
testEmptyRepository() - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
Modified to test SPARQL instead of Serql.
testEmptyRepository() - Method in class org.openrdf.sail.RDFStoreTest
testEmptyRollback() - Method in class org.openrdf.repository.RepositoryConnectionTest
testEmptyServiceBlock() - Method in class com.bigdata.rdf.sail.webapp.TestFederatedQuery
testEmptyStream() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
TestEncodeDecodeGeoSpatialLiteralIVs - Class in com.bigdata.rdf.internal
TestEncodeDecodeGeoSpatialLiteralIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
TestEncodeDecodeGeoSpatialLiteralIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
TestEncodeDecodeIPv4AddrIV - Class in com.bigdata.rdf.internal
TestEncodeDecodeIPv4AddrIV() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeIPv4AddrIV
TestEncodeDecodeIPv4AddrIV(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeIPv4AddrIV
TestEncodeDecodeKeys - Class in com.bigdata.rdf.internal
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.
TestEncodeDecodeKeys() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeKeys
TestEncodeDecodeKeys(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeKeys
TestEncodeDecodeLiteralArrayIVs - Class in com.bigdata.rdf.internal
TestEncodeDecodeLiteralArrayIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeLiteralArrayIVs
TestEncodeDecodeLiteralArrayIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeLiteralArrayIVs
TestEncodeDecodeMixedIVs - Class in com.bigdata.rdf.internal
Test of encode/decode and especially
comparator semantics for mixed
IV
s.
TestEncodeDecodeMixedIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeMixedIVs
TestEncodeDecodeMixedIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeMixedIVs
TestEncodeDecodePackedLongIVs - Class in com.bigdata.rdf.internal
TestEncodeDecodePackedLongIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodePackedLongIVs
TestEncodeDecodePackedLongIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodePackedLongIVs
TestEncodeDecodeUnicodeIVs - Class in com.bigdata.rdf.internal
Unit tests for
IV
s which inline Unicode data.
TestEncodeDecodeUnicodeIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeUnicodeIVs
TestEncodeDecodeUnicodeIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeUnicodeIVs
TestEncodeDecodeXSDDateIVs - Class in com.bigdata.rdf.internal
TestEncodeDecodeXSDDateIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeXSDDateIVs
TestEncodeDecodeXSDDateIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeXSDDateIVs
TestEncodeDecodeXSDDecimalIVs - Class in com.bigdata.rdf.internal
TestEncodeDecodeXSDDecimalIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeXSDDecimalIVs
TestEncodeDecodeXSDDecimalIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeXSDDecimalIVs
TestEncodeDecodeXSDIntegerIVs - Class in com.bigdata.rdf.internal
TestEncodeDecodeXSDIntegerIVs() - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeXSDIntegerIVs
TestEncodeDecodeXSDIntegerIVs(String) - Constructor for class com.bigdata.rdf.internal.TestEncodeDecodeXSDIntegerIVs
testEnglishFilterStopWords() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testEnglishNoFilter() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testEOFStreams() - Method in class com.bigdata.rdf.sail.webapp.TestMultiTenancyAPI
TestEQ - Class in com.bigdata.bop.constraint
TestEQ() - Constructor for class com.bigdata.bop.constraint.TestEQ
TestEQ(String) - Constructor for class com.bigdata.bop.constraint.TestEQ
TestEQConstant - Class in com.bigdata.bop.constraint
TestEQConstant() - Constructor for class com.bigdata.bop.constraint.TestEQConstant
TestEQConstant(String) - Constructor for class com.bigdata.bop.constraint.TestEQConstant
testEquals() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
TestEquals - Class in com.bigdata.rdf.model
Test suite for equals() semantics for
BigdataValue
implementations.
TestEquals() - Constructor for class com.bigdata.rdf.model.TestEquals
TestEquals(String) - Constructor for class com.bigdata.rdf.model.TestEquals
TestEventParser - Class in com.bigdata.service
Unit tests for parsing
Event
s.
TestEventParser() - Constructor for class com.bigdata.service.TestEventParser
TestEventParser(String) - Constructor for class com.bigdata.service.TestEventParser
TestEventReceiver - Class in com.bigdata.service
TestEventReceiver() - Constructor for class com.bigdata.service.TestEventReceiver
TestEventReceiver(String) - Constructor for class com.bigdata.service.TestEventReceiver
testEverything() - Method in class com.bigdata.rdf.sparql.ast.TestAST
testExactMatch() - Method in class com.bigdata.rdf.sail.TestSearchQuery
FIXME This should be migrated to the data-driven test suite in
TestSearch
.
testExclusiveNullContext() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestExplainHints - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for EXPLAIN hints.
TestExplainHints() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
TestExplainHints(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
testExplicitDefaultAndNamedGraphNoGraphKeyword() - Method in class com.bigdata.rdf.sail.DavidsTestBOps
testExplicitDefaultGraph() - Method in class com.bigdata.rdf.sail.DavidsTestBOps
testExtractTopLevelConjunctsMethod() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test the ASTFilterNormalizationOptimizer#extractToplevelConjuncts(
com.bigdata.rdf.sparql.ast.IValueExpressionNode, List)
method.
TestFactory - Class in com.bigdata.rdf.model
TestFactory() - Constructor for class com.bigdata.rdf.model.TestFactory
TestFactory(String) - Constructor for class com.bigdata.rdf.model.TestFactory
TestFastRangeCountOp - Class in com.bigdata.bop.join
TestFastRangeCountOp() - Constructor for class com.bigdata.bop.join.TestFastRangeCountOp
TestFastRangeCountOp(String) - Constructor for class com.bigdata.bop.join.TestFastRangeCountOp
TestFastRangeCountOptimizer - Class in com.bigdata.rdf.sparql.ast.eval
TestFastRangeCountOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestFastRangeCountOptimizer
TestFastRangeCountOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestFastRangeCountOptimizer
TestFastRangeCountOptimizer.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Quads mode test suite.
TestFastRangeCountOptimizer.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestFastRangeCountOptimizer.TestQuadsModeAPs
TestFastRangeCountOptimizer.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
TestFastRangeCountOptimizer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestFastRangeCountOptimizer.TestTriplesModeAPs
TestFederatedQuery<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for SPARQL 1.1 Federated Query.
TestFederatedQuery() - Constructor for class com.bigdata.rdf.sail.webapp.TestFederatedQuery
TestFederatedQuery(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestFederatedQuery
TestFederatedQueryEngine - Class in com.bigdata.bop.fed
TestFederatedQueryEngine() - Constructor for class com.bigdata.bop.fed.TestFederatedQueryEngine
TestFederatedQueryEngine(String) - Constructor for class com.bigdata.bop.fed.TestFederatedQueryEngine
TestFileChannelUtility - Class in com.bigdata.io
TestFileChannelUtility() - Constructor for class com.bigdata.io.TestFileChannelUtility
TestFileChannelUtility(String) - Constructor for class com.bigdata.io.TestFileChannelUtility
testFileDoesNotExist() - Method in class com.bigdata.rdf.sail.sparql.TestPrefixDeclProcessor
TestFileLockUtility - Class in com.bigdata.io
TestFileLockUtility() - Constructor for class com.bigdata.io.TestFileLockUtility
TestFileLockUtility(String) - Constructor for class com.bigdata.io.TestFileLockUtility
TestFileMetadataIndex - Class in com.bigdata.bfs
TestFileMetadataIndex() - Constructor for class com.bigdata.bfs.TestFileMetadataIndex
TestFileMetadataIndex(String) - Constructor for class com.bigdata.bfs.TestFileMetadataIndex
TestFileSystemScanner - Class in com.bigdata.service.ndx.pipeline
TestFileSystemScanner() - Constructor for class com.bigdata.service.ndx.pipeline.TestFileSystemScanner
TestFileSystemScanner(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestFileSystemScanner
TestFileVersionOutputStream - Class in com.bigdata.bfs
TestFileVersionOutputStream() - Constructor for class com.bigdata.bfs.TestFileVersionOutputStream
TestFileVersionOutputStream(String) - Constructor for class com.bigdata.bfs.TestFileVersionOutputStream
TestFilter - Class in com.bigdata.bop.ap.filter
TestFilter() - Constructor for class com.bigdata.bop.ap.filter.TestFilter
TestFilter(String) - Constructor for class com.bigdata.bop.ap.filter.TestFilter
testFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for FILTER nodes (simple).
testFilterAndBindInlinedBindAddedToExogeneous() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
testFilterDecompositionNoOp() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
The FILTER
testFilterExistsAndNotExists() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for FILTER EXISTS and FILTER NOT EXISTS
nodes.
testFilterOfFulltextSearch() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify that a subsequent filter applied to a keyword result
returns the desired result.
testFilterPlacement01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testFilterPlacement02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testFilterPlacement03() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testFilterPlacement04() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test filter placement where one filter variables is bound in the first,
one in the join group
testFilterRegexBoolean() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
TestFilters - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for FILTER evaluation.
TestFilters() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestFilters
TestFilters(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestFilters
TestFindChild - Class in com.bigdata.btree
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.
TestFindChild() - Constructor for class com.bigdata.btree.TestFindChild
TestFindChild(String) - Constructor for class com.bigdata.btree.TestFindChild
testFirstElement() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
getFirst() returns first element, or throws NSEE if empty
TestFixedByteArrayBuffer - Class in com.bigdata.io
TestFixedByteArrayBuffer() - Constructor for class com.bigdata.io.TestFixedByteArrayBuffer
TestFixedByteArrayBuffer(String) - Constructor for class com.bigdata.io.TestFixedByteArrayBuffer
TestFixedLengthPrefixShardSplits - Class in com.bigdata.resources
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.
TestFixedLengthPrefixShardSplits() - Constructor for class com.bigdata.resources.TestFixedLengthPrefixShardSplits
TestFixedLengthPrefixShardSplits(String) - Constructor for class com.bigdata.resources.TestFixedLengthPrefixShardSplits
TestFixedLengthValueRabaCoder - Class in com.bigdata.btree.raba.codec
TestFixedLengthValueRabaCoder() - Constructor for class com.bigdata.btree.raba.codec.TestFixedLengthValueRabaCoder
TestFixedLengthValueRabaCoder(String) - Constructor for class com.bigdata.btree.raba.codec.TestFixedLengthValueRabaCoder
testFixedWidthIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testFixedWidthIntegerURIHandlerFail() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testFoo() - Method in class com.bigdata.util.httpd.TestHTTPHeaderUtility
testForwardScan(IndexSegment) - Static method in class com.bigdata.btree.AbstractIndexSegmentTestCase
Test forward leaf scan.
TestFrontCodedRabaCoderRatio2 - Class in com.bigdata.btree.raba.codec
TestFrontCodedRabaCoderRatio2() - Constructor for class com.bigdata.btree.raba.codec.TestFrontCodedRabaCoderRatio2
TestFrontCodedRabaCoderRatio2(String) - Constructor for class com.bigdata.btree.raba.codec.TestFrontCodedRabaCoderRatio2
TestFrontCodedRabaCoderRatio32 - Class in com.bigdata.btree.raba.codec
TestFrontCodedRabaCoderRatio32() - Constructor for class com.bigdata.btree.raba.codec.TestFrontCodedRabaCoderRatio32
TestFrontCodedRabaCoderRatio32(String) - Constructor for class com.bigdata.btree.raba.codec.TestFrontCodedRabaCoderRatio32
TestFrontCodedRabaCoderRatio8 - Class in com.bigdata.btree.raba.codec
TestFrontCodedRabaCoderRatio8() - Constructor for class com.bigdata.btree.raba.codec.TestFrontCodedRabaCoderRatio8
TestFrontCodedRabaCoderRatio8(String) - Constructor for class com.bigdata.btree.raba.codec.TestFrontCodedRabaCoderRatio8
testFullCompactingCopy() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
TestFullTextIndex - Class in com.bigdata.rdf.lexicon
Test of adding terms with the full text index enabled and of lookup of terms
by tokens which appear within those terms.
TestFullTextIndex() - Constructor for class com.bigdata.rdf.lexicon.TestFullTextIndex
TestFullTextIndex(String) - Constructor for class com.bigdata.rdf.lexicon.TestFullTextIndex
TestFulltextSearch - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for external full text search.
TestFulltextSearch() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
TestFulltextSearch(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
TestFullyInlineTypedLiteralIV - Class in com.bigdata.rdf.internal
TestFullyInlineTypedLiteralIV() - Constructor for class com.bigdata.rdf.internal.TestFullyInlineTypedLiteralIV
TestFullyInlineTypedLiteralIV(String) - Constructor for class com.bigdata.rdf.internal.TestFullyInlineTypedLiteralIV
testFullyInlineUriIV() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
TestFullyInlineURIIV - Class in com.bigdata.rdf.internal
TestFullyInlineURIIV() - Constructor for class com.bigdata.rdf.internal.TestFullyInlineURIIV
TestFullyInlineURIIV(String) - Constructor for class com.bigdata.rdf.internal.TestFullyInlineURIIV
testFullyRedundantEvents() - Method in class com.bigdata.rdf.sail.TestRDRHistory
Test whether the RDRHistory can handle statements that are added
and removed in the same commit.
TestFusedView - Class in com.bigdata.btree.view
TestFusedView() - Constructor for class com.bigdata.btree.view.TestFusedView
TestFusedView(String) - Constructor for class com.bigdata.btree.view.TestFusedView
TestFuzzySSSP - Class in com.bigdata.rdf.graph.impl.bd
TODO.
TestFuzzySSSP() - Constructor for class com.bigdata.rdf.graph.impl.bd.TestFuzzySSSP
TestFuzzySSSP(String) - Constructor for class com.bigdata.rdf.graph.impl.bd.TestFuzzySSSP
TestGather - Class in com.bigdata.rdf.graph.impl.bd
Test class for GATHER.
TestGather() - Constructor for class com.bigdata.rdf.graph.impl.bd.TestGather
TestGather(String) - Constructor for class com.bigdata.rdf.graph.impl.bd.TestGather
testGather_inEdges() - Method in class com.bigdata.rdf.graph.impl.bd.TestGather
testGE() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestGearingQueryHint - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for https://jira.blazegraph.com/browse/BLZG-2089, which
introduces a fresh query hint to select the gearing choice for property
paths.
TestGearingQueryHint() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestGearingQueryHint
TestGearingQueryHint(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestGearingQueryHint
TestGeoSpatialCorrectRejection - Class in com.bigdata.rdf.sparql.ast.eval.service
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.
TestGeoSpatialCorrectRejection() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
TestGeoSpatialCorrectRejection(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCorrectRejection
TestGeoSpatialCustomFields - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for GeoSpatial service feature aiming at the definition of
custom fields (possibly combined with predefined fields).
TestGeoSpatialCustomFields() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
TestGeoSpatialCustomFields(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomFields
TestGeoSpatialCustomSerializer - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for custom serializer.
TestGeoSpatialCustomSerializer() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializer
TestGeoSpatialCustomSerializer(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializer
TestGeoSpatialCustomSerializerWKT - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for custom serializer, testing basic feasibility
for WKT literals (not strictly following the standard).
TestGeoSpatialCustomSerializerWKT() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
TestGeoSpatialCustomSerializerWKT(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
TestGeoSpatialDefaults - Class in com.bigdata.rdf.sparql.ast.eval.service
Tests covering the geospatial default configuration, i.e.
TestGeoSpatialDefaults() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
TestGeoSpatialDefaults(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
TestGeoSpatialDisableBuiltinDatatypes - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite testing configurability of GeoSpatial service.
TestGeoSpatialDisableBuiltinDatatypes() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDisableBuiltinDatatypes
TestGeoSpatialDisableBuiltinDatatypes(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDisableBuiltinDatatypes
TestGeoSpatialExamplesFromDocumentation - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite asserting that the examples in the geospatial
documentation are running through properly.
TestGeoSpatialExamplesFromDocumentation() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
TestGeoSpatialExamplesFromDocumentation(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialExamplesFromDocumentation
TestGeoSpatialQueryIfGeospatialDisabled - Class in com.bigdata.rdf.sparql.ast.eval.service
Test case asserting that geospatial SERVICE query fails with proper
exception if geospatial submodue is turned off.
TestGeoSpatialQueryIfGeospatialDisabled() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryIfGeospatialDisabled
TestGeoSpatialQueryIfGeospatialDisabled(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryIfGeospatialDisabled
TestGeoSpatialQueryVaryOneDimension - Class in com.bigdata.rdf.sparql.ast.eval.service
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.
TestGeoSpatialQueryVaryOneDimension() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
TestGeoSpatialQueryVaryOneDimension(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialQueryVaryOneDimension
TestGeoSpatialServiceConfiguration - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite testing configurability of GeoSpatial service.
TestGeoSpatialServiceConfiguration() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfiguration
TestGeoSpatialServiceConfiguration(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfiguration
TestGeoSpatialServiceConfigurationCustomDatatype - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite testing configurability of GeoSpatial service.
TestGeoSpatialServiceConfigurationCustomDatatype() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
TestGeoSpatialServiceConfigurationCustomDatatype(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
TestGeoSpatialServiceConfigurationParsing - Class in com.bigdata.rdf.sparql.ast.eval.service
Test suite testing the form-JSON parsing facilities for the GeoSpatial service configuration.
TestGeoSpatialServiceConfigurationParsing() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
TestGeoSpatialServiceConfigurationParsing(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
TestGeoSpatialServiceEvaluation - Class in com.bigdata.rdf.sparql.ast.eval.service
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.
TestGeoSpatialServiceEvaluation() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
TestGeoSpatialServiceEvaluation(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
TestGeoSpatialServiceEvaluationQuads - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for GeoSpatial service feature, GeoSpatial in
triples vs.
TestGeoSpatialServiceEvaluationQuads() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
TestGeoSpatialServiceEvaluationQuads(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
testGermanFilterStopWords() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testGermanNoStopWords() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testGet() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testGet() - Method in class com.bigdata.bop.constraint.TestNE
TestGetBitsApplication - Class in com.bigdata.btree
Rather than run in a JUnit, the performance tests are best run
standalone.
TestGetBitsApplication() - Constructor for class com.bigdata.btree.TestGetBitsApplication
TestGetBitsFromByteArray - Class in com.bigdata.btree
TestGetBitsFromByteArray() - Constructor for class com.bigdata.btree.TestGetBitsFromByteArray
TestGetBitsFromByteArray(String) - Constructor for class com.bigdata.btree.TestGetBitsFromByteArray
TestGetBitsFromInt32 - Class in com.bigdata.btree
Unit tests for {@link BytesUtil#getBits(int, int, int)
TestGetBitsFromInt32() - Constructor for class com.bigdata.btree.TestGetBitsFromInt32
TestGetBitsFromInt32(String) - Constructor for class com.bigdata.btree.TestGetBitsFromInt32
testGetContextIDs() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetContextIDs() - Method in class org.openrdf.sail.RDFStoreTest
testGetNamespace() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetNamespace() - Method in class org.openrdf.sail.RDFStoreTest
testGetNamespaces() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetNamespaces() - Method in class org.openrdf.sail.RDFStoreTest
TestGetRequestTimeout - Class in com.bigdata.rdf.sail.webapp
TestGetRequestTimeout() - Constructor for class com.bigdata.rdf.sail.webapp.TestGetRequestTimeout
testGetRequestTimeout() - Method in class com.bigdata.rdf.sail.webapp.TestGetRequestTimeout
testGetRequestTimeout1() - Method in class com.bigdata.rdf.sail.webapp.TestGetRequestTimeout
testGetRequestTimeout2() - Method in class com.bigdata.rdf.sail.webapp.TestGetRequestTimeout
testGetRequestTimeout3() - Method in class com.bigdata.rdf.sail.webapp.TestGetRequestTimeout
testGetSet() - Method in class com.bigdata.bop.constraint.TestINConstraint
testGetStatements() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetStatementsInMultipleContexts() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetStatementsInSingleContext() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetStatementsMalformedLanguageLiteral() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetStatementsMalformedTypedLiteral() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGetVariable() - Method in class com.bigdata.bop.constraint.TestINConstraint
testGlobalOverride() - Method in class com.bigdata.config.TestConfiguration
Unit test for the override of the default by specifying a global value
for a property.
TestGOM - Class in com.bigdata.gom
Base test suite for the embedded (local) GOM.
TestGOM() - Constructor for class com.bigdata.gom.TestGOM
TestGPO - Class in com.bigdata.gom
TestGPO() - Constructor for class com.bigdata.gom.TestGPO
TestGPO(String) - Constructor for class com.bigdata.gom.TestGPO
testGRAPHConstructInQueryBody() - Method in class com.bigdata.rdf.sail.TestTicket1518
Test using of GRAPH construct in query body.
TestGraphEmptyPattern709_429 - Class in com.bigdata.rdf.sparql.ast.eval
Tests concerning "SELECT GRAPH XXXX {}" with XXXX and the dataset varying.
TestGraphEmptyPattern709_429() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestGraphEmptyPattern709_429
TestGraphEmptyPattern709_429(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestGraphEmptyPattern709_429
testGraphSerialization() - Method in class org.openrdf.repository.RepositoryConnectionTest
testGrid180x5vCircle01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Circle test q query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
testGrid180x5vCircle02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Circle test query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
testGrid180x5vCircle03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Circle test q query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
testGrid180x5vCircle04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Circle test q query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
testGrid180x5vRectangle01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Rectangle test q query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
testGrid180x5vRectangle02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Rectangle test query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
testGrid180x5vRectangle03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Rectangle test query on grid ranging from [-179;180] longitude
and [-5;5] latitude and fixed "0" timestamp, aiming
covering edge cases overlapping the -180 and +180
longitude values.
TestGROUP_CONCAT - Class in com.bigdata.bop.rdf.aggregate
TestGROUP_CONCAT() - Constructor for class com.bigdata.bop.rdf.aggregate.TestGROUP_CONCAT
TestGROUP_CONCAT(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestGROUP_CONCAT
TestGroupByOp - Class in com.bigdata.bop.solutions
A collection of tests for various implementations of GroupByOp.
TestGroupByOp() - Constructor for class com.bigdata.bop.solutions.TestGroupByOp
TestGroupByOp(String) - Constructor for class com.bigdata.bop.solutions.TestGroupByOp
TestGroupByRewriter - Class in com.bigdata.bop.solutions
TestGroupByRewriter() - Constructor for class com.bigdata.bop.solutions.TestGroupByRewriter
TestGroupByRewriter(String) - Constructor for class com.bigdata.bop.solutions.TestGroupByRewriter
TestGroupByState - Class in com.bigdata.bop.solutions
TestGroupByState() - Constructor for class com.bigdata.bop.solutions.TestGroupByState
TestGroupByState(String) - Constructor for class com.bigdata.bop.solutions.TestGroupByState
testGroupConcatDistinct() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testGroupConcatNonDistinct() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
TestGroupGraphPatternBuilder - Class in com.bigdata.rdf.sail.sparql
Test suite for translating the openrdf SPARQL AST nodes for
GroupGraphPattern
into the bigdata AST (join groups, union,
etc).
TestGroupGraphPatternBuilder() - Constructor for class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
TestGroupGraphPatternBuilder(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestGroupGraphPatternBuilder
TestGroupNodeVarBindingInfo - Class in com.bigdata.rdf.sparql.ast.optimizers
Test suite for the GroupNodeVarBindingInfo class.
TestGroupNodeVarBindingInfo() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestGroupNodeVarBindingInfo
TestGroupNodeVarBindingInfo(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestGroupNodeVarBindingInfo
testGT() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestHA3QuorumSemantics - Class in com.bigdata.quorum
Test the quorum semantics for a highly available quorum of 3 services.
TestHA3QuorumSemantics() - Constructor for class com.bigdata.quorum.TestHA3QuorumSemantics
TestHA3QuorumSemantics(String) - Constructor for class com.bigdata.quorum.TestHA3QuorumSemantics
TestHALogWriter - Class in com.bigdata.ha.halog
TestHALogWriter() - Constructor for class com.bigdata.ha.halog.TestHALogWriter
TestHaltable - Class in com.bigdata.util.concurrent
TestHaltable() - Constructor for class com.bigdata.util.concurrent.TestHaltable
TestHaltable(String) - Constructor for class com.bigdata.util.concurrent.TestHaltable
TestHaltOpMessage - Class in com.bigdata.bop.engine
TestHaltOpMessage() - Constructor for class com.bigdata.bop.engine.TestHaltOpMessage
TestHaltOpMessage(String) - Constructor for class com.bigdata.bop.engine.TestHaltOpMessage
TestHASendAndReceive - Class in com.bigdata.ha.pipeline
TestHASendAndReceive() - Constructor for class com.bigdata.ha.pipeline.TestHASendAndReceive
TestHASendAndReceive(String) - Constructor for class com.bigdata.ha.pipeline.TestHASendAndReceive
TestHASendAndReceive3Nodes - Class in com.bigdata.ha.pipeline
TestHASendAndReceive3Nodes() - Constructor for class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
TestHASendAndReceive3Nodes(String) - Constructor for class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
TestHASendState - Class in com.bigdata.ha.msg
TestHASendState() - Constructor for class com.bigdata.ha.msg.TestHASendState
TestHASendState(String) - Constructor for class com.bigdata.ha.msg.TestHASendState
TestHashBindingSet - Class in com.bigdata.bop.bindingSet
TestHashBindingSet() - Constructor for class com.bigdata.bop.bindingSet.TestHashBindingSet
TestHashBindingSet(String) - Constructor for class com.bigdata.bop.bindingSet.TestHashBindingSet
testHashCode() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testHashCode() - Method in class com.bigdata.gom.TestGPO
TestHashJoin - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for queries designed to exercise a hash join against an access
path.
TestHashJoin() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestHashJoin
TestHashJoin(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestHashJoin
TestHAWriteMessage - Class in com.bigdata.ha.msg
TestHAWriteMessage() - Constructor for class com.bigdata.ha.msg.TestHAWriteMessage
TestHelper - Class in com.bigdata.journal
Some helper methods for CI.
TestHelper() - Constructor for class com.bigdata.journal.TestHelper
TestHelper - Class in com.bigdata.rdf.sail.webapp
Helper class to debug the NSS by issuing commands that we can not issue
from the index.html page (HTTP DELETEs, etc).
TestHelper() - Constructor for class com.bigdata.rdf.sail.webapp.TestHelper
testHexUUIDURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
TestHierarchicalLockingTasks - Class in com.bigdata.journal
Test suite for hierarchical locking of indices based on namespace prefixes.
TestHierarchicalLockingTasks() - Constructor for class com.bigdata.journal.TestHierarchicalLockingTasks
TestHierarchicalLockingTasks(String) - Constructor for class com.bigdata.journal.TestHierarchicalLockingTasks
testHighBit() - Method in class com.bigdata.io.LongPackerTestCase
testHighBit() - Method in class com.bigdata.io.ShortPackerTestCase
testHighBit() - Method in class com.bigdata.io.TestLongPacker
testHighBit() - Method in class com.bigdata.io.TestShortPacker
TestHistoryIndex - Class in com.bigdata.rdf.sail
TestHistoryIndex() - Constructor for class com.bigdata.rdf.sail.TestHistoryIndex
TestHistoryIndex(String) - Constructor for class com.bigdata.rdf.sail.TestHistoryIndex
TestHistoryInstrument - Class in com.bigdata.counters
TestHistoryInstrument() - Constructor for class com.bigdata.counters.TestHistoryInstrument
TestHistoryInstrument(String) - Constructor for class com.bigdata.counters.TestHistoryInstrument
TestHostMetricsCollector - Class in com.bigdata.counters.ganglia
TestHostMetricsCollector() - Constructor for class com.bigdata.counters.ganglia.TestHostMetricsCollector
TestHostMetricsCollector(String) - Constructor for class com.bigdata.counters.ganglia.TestHostMetricsCollector
TestHTree - Class in com.bigdata.htree
TestHTree() - Constructor for class com.bigdata.htree.TestHTree
TestHTree(String) - Constructor for class com.bigdata.htree.TestHTree
TestHTree_addLevel - Class in com.bigdata.htree
Unit test which explores a simple add level case.
TestHTree_addLevel() - Constructor for class com.bigdata.htree.TestHTree_addLevel
TestHTree_addLevel(String) - Constructor for class com.bigdata.htree.TestHTree_addLevel
TestHTree_init - Class in com.bigdata.htree
Unit tests for bootstrap of an
HTree
instance.
TestHTree_init() - Constructor for class com.bigdata.htree.TestHTree_init
TestHTree_init(String) - Constructor for class com.bigdata.htree.TestHTree_init
TestHTree_stressInsert - Class in com.bigdata.htree
A stress test which inserts a series of integer keys and then verifies the
state of the index.
TestHTree_stressInsert() - Constructor for class com.bigdata.htree.TestHTree_stressInsert
TestHTree_stressInsert(String) - Constructor for class com.bigdata.htree.TestHTree_stressInsert
TestHTreeDistinctBindingSets - Class in com.bigdata.bop.solutions
TestHTreeDistinctBindingSets() - Constructor for class com.bigdata.bop.solutions.TestHTreeDistinctBindingSets
TestHTreeDistinctBindingSets(String) - Constructor for class com.bigdata.bop.solutions.TestHTreeDistinctBindingSets
TestHTreeHashIndexOp - Class in com.bigdata.bop.join
TestHTreeHashIndexOp() - Constructor for class com.bigdata.bop.join.TestHTreeHashIndexOp
TestHTreeHashIndexOp(String) - Constructor for class com.bigdata.bop.join.TestHTreeHashIndexOp
TestHTreeHashJoinOp - Class in com.bigdata.bop.join
TestHTreeHashJoinOp() - Constructor for class com.bigdata.bop.join.TestHTreeHashJoinOp
TestHTreeHashJoinOp(String) - Constructor for class com.bigdata.bop.join.TestHTreeHashJoinOp
TestHTreeHashJoinUtility - Class in com.bigdata.bop.join
TestHTreeHashJoinUtility() - Constructor for class com.bigdata.bop.join.TestHTreeHashJoinUtility
TestHTreeHashJoinUtility(String) - Constructor for class com.bigdata.bop.join.TestHTreeHashJoinUtility
TestHTreeRecycle - Class in com.bigdata.htree
Tests recycling of HTree storage.
TestHTreeRecycle() - Constructor for class com.bigdata.htree.TestHTreeRecycle
TestHTreeRecycle(String) - Constructor for class com.bigdata.htree.TestHTreeRecycle
TestHTreeSolutionSetHashJoin - Class in com.bigdata.bop.join
TestHTreeSolutionSetHashJoin() - Constructor for class com.bigdata.bop.join.TestHTreeSolutionSetHashJoin
TestHTreeSolutionSetHashJoin(String) - Constructor for class com.bigdata.bop.join.TestHTreeSolutionSetHashJoin
TestHTreeUtil - Class in com.bigdata.htree
TestHTreeUtil() - Constructor for class com.bigdata.htree.TestHTreeUtil
TestHTreeUtil(String) - Constructor for class com.bigdata.htree.TestHTreeUtil
TestHTreeWithMemStore - Class in com.bigdata.htree
Integration test with a persistence store.
TestHTreeWithMemStore() - Constructor for class com.bigdata.htree.TestHTreeWithMemStore
TestHTreeWithMemStore(String) - Constructor for class com.bigdata.htree.TestHTreeWithMemStore
TestHTTPHeaderUtility - Class in com.bigdata.util.httpd
TestHTTPHeaderUtility() - Constructor for class com.bigdata.util.httpd.TestHTTPHeaderUtility
TestHuffmanEncoder - Class in com.bigdata.io.compression
Explores the built-in huffman coding support in the Deflate library.
TestHuffmanEncoder() - Constructor for class com.bigdata.io.compression.TestHuffmanEncoder
TestHuffmanEncoder(String) - Constructor for class com.bigdata.io.compression.TestHuffmanEncoder
TestHuffmanEncoder.HuffmanDecoder - Class in com.bigdata.io.compression
Decoder for ZLIB.
TestHuffmanEncoder.HuffmanDecoder() - Constructor for class com.bigdata.io.compression.TestHuffmanEncoder.HuffmanDecoder
TestHuffmanEncoder.HuffmanEncoder - Class in com.bigdata.io.compression
Class provides only the huffman encoding aspect of the ZLIB compression
standard.
TestHuffmanEncoder.HuffmanEncoder() - Constructor for class com.bigdata.io.compression.TestHuffmanEncoder.HuffmanEncoder
TestIBindingSet - Class in com.bigdata.bop.bindingSet
TestIBindingSet() - Constructor for class com.bigdata.bop.bindingSet.TestIBindingSet
TestIBindingSet(String) - Constructor for class com.bigdata.bop.bindingSet.TestIBindingSet
TestICUPortabilityBug - Class in com.bigdata.btree.keys
This is a unit test for a possible ICU portability bug.
TestICUPortabilityBug() - Constructor for class com.bigdata.btree.keys.TestICUPortabilityBug
TestICUPortabilityBug(String) - Constructor for class com.bigdata.btree.keys.TestICUPortabilityBug
TestICUUnicodeKeyBuilder - Class in com.bigdata.btree.keys
TestICUUnicodeKeyBuilder() - Constructor for class com.bigdata.btree.keys.TestICUUnicodeKeyBuilder
TestICUUnicodeKeyBuilder(String) - Constructor for class com.bigdata.btree.keys.TestICUUnicodeKeyBuilder
TestICUVersionRecord - Class in com.bigdata.btree.keys
TestICUVersionRecord() - Constructor for class com.bigdata.btree.keys.TestICUVersionRecord
TestICUVersionRecord(String) - Constructor for class com.bigdata.btree.keys.TestICUVersionRecord
TestId2TermTupleSerializer - Class in com.bigdata.rdf.lexicon
TestId2TermTupleSerializer() - Constructor for class com.bigdata.rdf.lexicon.TestId2TermTupleSerializer
TestId2TermTupleSerializer(String) - Constructor for class com.bigdata.rdf.lexicon.TestId2TermTupleSerializer
testIdenticalVariablesInStatementPattern() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testImplementationDefinedDefaultGraph() - Method in class com.bigdata.rdf.sail.DavidsTestBOps
TestInBinarySearch - Class in com.bigdata.bop.constraint
TestInBinarySearch() - Constructor for class com.bigdata.bop.constraint.TestInBinarySearch
TestInBinarySearch(String) - Constructor for class com.bigdata.bop.constraint.TestInBinarySearch
testInCircleQuery01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
Test query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery01a() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Test query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery01b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Test query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery01c() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Test query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery01d() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Test query
PREFIX geo:
SELECT * WHERE {
?res geo:search "inCircle" .
testInCircleQuery02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfiguration
Compared to the circle01* queries, the query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Compared to the circle01* queries, the query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
Test query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
A variant of circle02 where the unit is specified in miles rather
than kilometers (delivering the same result).
testInCircleQuery04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Compared to queries circle02 and circle03, the query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery05() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Compared to queries circle04, the query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery06a() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Query similar in spirit to circle04, but settled at the corner of our
gred (top left):
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testInCircleQuery06b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Query similar in spirit to circle06a, but top-right corner.
testInCircleQuery06c() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Query similar in spirit to circle06a, but lower-left corner.
testInCircleQuery06d() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Query similar in spirit to circle06a, but lower-right corner.
testInCircleQueryParallel01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Test query
PREFIX geo:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
TestInclude - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for INCLUDE of named solution sets NOT generated by a
NamedSubqueryRoot
.
TestInclude() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestInclude
TestInclude(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestInclude
TestInclude.IncludeStressTests - Class in com.bigdata.rdf.sparql.ast.eval
Tests to be executed in a stress test fashion, i.e.
TestInclude.IncludeStressTests() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestInclude.IncludeStressTests
TestInclude.IncludeStressTests(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestInclude.IncludeStressTests
testInComparison1() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testInComparison1() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testInComparison2() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testInComparison2() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testInComparison3() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testInComparison3() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
TestINConstraint - Class in com.bigdata.bop.constraint
TestINConstraint() - Constructor for class com.bigdata.bop.constraint.TestINConstraint
TestINConstraint(String) - Constructor for class com.bigdata.bop.constraint.TestINConstraint
TestIncrementalWrite - Class in com.bigdata.btree
Test suite for the logic performing incremental writes of nodes and leaves
onto the store.
TestIncrementalWrite() - Constructor for class com.bigdata.btree.TestIncrementalWrite
TestIncrementalWrite(String) - Constructor for class com.bigdata.btree.TestIncrementalWrite
TestIncrementalWrite - Class in com.bigdata.htree
Test suite for the logic performing incremental writes of nodes and leaves
onto the store.
TestIncrementalWrite() - Constructor for class com.bigdata.htree.TestIncrementalWrite
TestIncrementalWrite(String) - Constructor for class com.bigdata.htree.TestIncrementalWrite
TestIndexCounter - Class in com.bigdata.btree
TestIndexCounter() - Constructor for class com.bigdata.btree.TestIndexCounter
TestIndexCounter(String) - Constructor for class com.bigdata.btree.TestIndexCounter
TestIndexCounter - Class in com.bigdata.htree
TestIndexCounter() - Constructor for class com.bigdata.htree.TestIndexCounter
TestIndexCounter(String) - Constructor for class com.bigdata.htree.TestIndexCounter
TestIndexPartitionFencePosts - Class in com.bigdata.btree
Tests for some fence posts for an index supporting delete markers and having
a
LocalPartitionMetadata
that declares its legal key range.
TestIndexPartitionFencePosts() - Constructor for class com.bigdata.btree.TestIndexPartitionFencePosts
TestIndexPartitionFencePosts(String) - Constructor for class com.bigdata.btree.TestIndexPartitionFencePosts
TestIndexSegmentAddressManager - Class in com.bigdata.btree
TestIndexSegmentAddressManager() - Constructor for class com.bigdata.btree.TestIndexSegmentAddressManager
TestIndexSegmentAddressManager(String) - Constructor for class com.bigdata.btree.TestIndexSegmentAddressManager
TestIndexSegmentBuilder_EmptyIndex - Class in com.bigdata.btree
TestIndexSegmentBuilder_EmptyIndex() - Constructor for class com.bigdata.btree.TestIndexSegmentBuilder_EmptyIndex
TestIndexSegmentBuilder_EmptyIndex(String) - Constructor for class com.bigdata.btree.TestIndexSegmentBuilder_EmptyIndex
TestIndexSegmentBuilderWithBlobCapacity - Class in com.bigdata.btree
TestIndexSegmentBuilderWithBlobCapacity() - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithBlobCapacity
TestIndexSegmentBuilderWithCompactingMerge - Class in com.bigdata.btree
A test of the
IndexSegmentBuilder
in which there are some deleted
tuples in the source
BTree
and a compacting merge is performed.
TestIndexSegmentBuilderWithCompactingMerge() - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithCompactingMerge
TestIndexSegmentBuilderWithCompactingMerge(String) - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithCompactingMerge
TestIndexSegmentBuilderWithIncrementalBuild - Class in com.bigdata.btree
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).
TestIndexSegmentBuilderWithIncrementalBuild() - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithIncrementalBuild
TestIndexSegmentBuilderWithIncrementalBuild(String) - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithIncrementalBuild
TestIndexSegmentBuilderWithLargeTrees - Class in com.bigdata.btree
Test build trees on the journal, evicts them into an
IndexSegment
,
and then compares the trees for the same total ordering.
TestIndexSegmentBuilderWithLargeTrees() - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithLargeTrees
TestIndexSegmentBuilderWithLargeTrees(String) - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithLargeTrees
TestIndexSegmentBuilderWithSmallTree - Class in com.bigdata.btree
Test suite based on a small btree with known keys and values.
TestIndexSegmentBuilderWithSmallTree() - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithSmallTree
TestIndexSegmentBuilderWithSmallTree(String) - Constructor for class com.bigdata.btree.TestIndexSegmentBuilderWithSmallTree
TestIndexSegmentCheckpoint - Class in com.bigdata.btree
TestIndexSegmentCheckpoint() - Constructor for class com.bigdata.btree.TestIndexSegmentCheckpoint
TestIndexSegmentCheckpoint(String) - Constructor for class com.bigdata.btree.TestIndexSegmentCheckpoint
TestIndexSegmentCursors - Class in com.bigdata.btree
TestIndexSegmentCursors() - Constructor for class com.bigdata.btree.TestIndexSegmentCursors
TestIndexSegmentCursors(String) - Constructor for class com.bigdata.btree.TestIndexSegmentCursors
TestIndexSegmentMultiBlockIterators - Class in com.bigdata.btree
TestIndexSegmentMultiBlockIterators() - Constructor for class com.bigdata.btree.TestIndexSegmentMultiBlockIterators
TestIndexSegmentMultiBlockIterators(String) - Constructor for class com.bigdata.btree.TestIndexSegmentMultiBlockIterators
TestIndexSegmentPlan - Class in com.bigdata.btree
Test suite for efficient post-order rebuild of an index in an external index
segment.
TestIndexSegmentPlan() - Constructor for class com.bigdata.btree.TestIndexSegmentPlan
TestIndexSegmentPlan(String) - Constructor for class com.bigdata.btree.TestIndexSegmentPlan
TestIndexSegmentWithBloomFilter - Class in com.bigdata.btree
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.
TestIndexSegmentWithBloomFilter() - Constructor for class com.bigdata.btree.TestIndexSegmentWithBloomFilter
TestIndexSegmentWithBloomFilter(String) - Constructor for class com.bigdata.btree.TestIndexSegmentWithBloomFilter
TestInetAddressUtil - Class in com.bigdata.net
TestInetAddressUtil() - Constructor for class com.bigdata.net.TestInetAddressUtil
TestInetAddressUtil(String) - Constructor for class com.bigdata.net.TestInetAddressUtil
testInferredStatementCount() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestInHashMap - Class in com.bigdata.bop.constraint
TestInHashMap() - Constructor for class com.bigdata.bop.constraint.TestInHashMap
TestInHashMap(String) - Constructor for class com.bigdata.bop.constraint.TestInHashMap
testInlineArray() - Method in class com.bigdata.rdf.store.TestInlineURIs
TestInlineConstraints - Class in com.bigdata.rdf.sparql.ast.eval
TestInlineConstraints() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestInlineConstraints(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
testInlineFromBind() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set.
testInlineFromBindInComplexFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set.
testInlineFromBindInFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set.
testInlineFromBindNested1() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set in a nested setting.
testInlineFromBindNested2() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set in a nested setting.
testInlineFromExogeneousBindings() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
testInlineFromTopLevelValues() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from top-level VALUES
clause, including the removal of the clause and putting the values into
the exogeneous mapping set.
testInlineFromValues() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from top-level VALUES
clause, including the removal of the clause and putting the values into
the exogeneous mapping set.
testInlineIPv4s() - Method in class com.bigdata.rdf.store.TestInlineURIs
testInlineIVs() - Method in class com.bigdata.bop.solutions.TestMemorySortOp
Unit test with inline
IV
.
TestInlineLocalNameIntegerURIHandler - Class in com.bigdata.rdf.internal
TestInlineLocalNameIntegerURIHandler(String) - Constructor for class com.bigdata.rdf.internal.TestInlineLocalNameIntegerURIHandler
testInlineSimpleFilterEqURI() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
testInlineSimpleFilterEqURIRev() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test testInlineSimpleFilterEqURI with FILTER conditions reversed.
testInlineSimpleFilterINURI() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
TestInlineURIHandlers - Class in com.bigdata.rdf.internal
TestInlineURIHandlers() - Constructor for class com.bigdata.rdf.internal.TestInlineURIHandlers
TestInlineURIHandlers(String) - Constructor for class com.bigdata.rdf.internal.TestInlineURIHandlers
TestInlineURIs - Class in com.bigdata.rdf.store
Integration test suite for
InlineURIFactory
(the inline IVs are also
tested in their own package without the triple store integration).
TestInlineURIs() - Constructor for class com.bigdata.rdf.store.TestInlineURIs
TestInlineURIs(String) - Constructor for class com.bigdata.rdf.store.TestInlineURIs
TestInlineURIs.CustomInlineURIFactory - Class in com.bigdata.rdf.store
TestInlineURIs.CustomInlineURIFactory() - Constructor for class com.bigdata.rdf.store.TestInlineURIs.CustomInlineURIFactory
TestInlineURIs.CustomVocab - Class in com.bigdata.rdf.store
Note: Must be public for access patterns.
TestInlineURIs.CustomVocab() - Constructor for class com.bigdata.rdf.store.TestInlineURIs.CustomVocab
TestInlineURIs.CustomVocab(String) - Constructor for class com.bigdata.rdf.store.TestInlineURIs.CustomVocab
TestInlineURIs.InlineArrayFactory - Class in com.bigdata.rdf.store
TestInlineURIs.InlineArrayFactory() - Constructor for class com.bigdata.rdf.store.TestInlineURIs.InlineArrayFactory
TestInlineURIs.InlineArrayHandler - Class in com.bigdata.rdf.store
TestInlineURIs.InlineArrayHandler(String) - Constructor for class com.bigdata.rdf.store.TestInlineURIs.InlineArrayHandler
TestInlineURIs.MultipurposeInlineIDFactory - Class in com.bigdata.rdf.store
TestInlineURIs.MultipurposeInlineIDFactory() - Constructor for class com.bigdata.rdf.store.TestInlineURIs.MultipurposeInlineIDFactory
TestInlineURIs.MultipurposeInlineIDHandler - Class in com.bigdata.rdf.store
TestInlineURIs.MultipurposeInlineIDHandler(String) - Constructor for class com.bigdata.rdf.store.TestInlineURIs.MultipurposeInlineIDHandler
testInlineUUIDs() - Method in class com.bigdata.rdf.store.TestInlineURIs
TestInlineValues - Class in com.bigdata.rdf.sail
TestInlineValues() - Constructor for class com.bigdata.rdf.sail.TestInlineValues
TestInlineValues(String) - Constructor for class com.bigdata.rdf.sail.TestInlineValues
testInlineValuesGT() - Method in class com.bigdata.rdf.sail.TestInlineValues
testInlineValuesLT() - Method in class com.bigdata.rdf.sail.TestInlineValues
testInlineWithSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set.
TestInlining - Class in com.bigdata.rdf.lexicon
Test suite for adding terms to the lexicon.
TestInlining() - Constructor for class com.bigdata.rdf.lexicon.TestInlining
TestInlining(String) - Constructor for class com.bigdata.rdf.lexicon.TestInlining
TestInlining.MyVocabulary - Class in com.bigdata.rdf.lexicon
TestInlining.MyVocabulary() - Constructor for class com.bigdata.rdf.lexicon.TestInlining.MyVocabulary
De-serialization ctor.
TestInlining.MyVocabulary(String) - Constructor for class com.bigdata.rdf.lexicon.TestInlining.MyVocabulary
testInliningForComplexExogeneousMapping() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Assert that even for complex exogeneous mappings, variables that map
to the same value in all cases are inlined properly.
testInRectangleQuery01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfiguration
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery02a() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery02b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery05() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testInRectangleQuery06() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query (not wrapped into service):
PREFIX geo:
SELECT ?res WHERE {
?res geo:search "inRectangle" .
testInRectangleQuery07() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple query and subsequent join of result.
testInRectangleQuery08() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify precision handling.
testInRectangleQuery08mod() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfiguration
Verify precision handling, which is changed in the configuration to be 6 for
the first component and 5 for the second one.
TestInsert - Class in com.bigdata.bop.mutation
TestInsert() - Constructor for class com.bigdata.bop.mutation.TestInsert
TestInsert(String) - Constructor for class com.bigdata.bop.mutation.TestInsert
testInsertAndLookupDups() - Method in class com.bigdata.htree.TestHTree
Insert data into the BTRee, making sure that data previously
inserted is found in later stages when looking it up.
testInsertCBD() - Method in class com.bigdata.rdf.sail.webapp.TestCBD731
testInsertData() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertData() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertData2() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertDataBlankNode() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertDataInGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertDataInGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertDataInGraph2() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertDataInGraph2() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertDataMultiplePatterns() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertDataMultiplePatterns() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertEmptyWhere() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertEmptyWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertEmptyWhereWithBinding() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
TestInsertFilterFalse727<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
TestInsertFilterFalse727() - Constructor for class com.bigdata.rdf.sail.webapp.TestInsertFilterFalse727
TestInsertFilterFalse727(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestInsertFilterFalse727
TestInsertLookupRemoveKeysInRootLeaf - Class in com.bigdata.btree
Test insert, lookup, and value scan for leaves.
TestInsertLookupRemoveKeysInRootLeaf() - Constructor for class com.bigdata.btree.TestInsertLookupRemoveKeysInRootLeaf
TestInsertLookupRemoveKeysInRootLeaf(String) - Constructor for class com.bigdata.btree.TestInsertLookupRemoveKeysInRootLeaf
testInsertNonMatchingWhere() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertNonMatchingWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertNonMatchingWhereWithBindings() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
TestInsertRate - Class in com.bigdata.rdf.store
A test for measuring the possible insert rate for a triple store based on a
journal and btree using a synthetic data generator.
TestInsertRate() - Constructor for class com.bigdata.rdf.store.TestInsertRate
TestInsertRate(String) - Constructor for class com.bigdata.rdf.store.TestInsertRate
TestInsertRate.XMLSchema - Class in com.bigdata.rdf.store
Defines a variety of URIs relevant to the XML Schema Datatypes
specification.
TestInsertRate.XMLSchema() - Constructor for class com.bigdata.rdf.store.TestInsertRate.XMLSchema
testInsertSCBD() - Method in class com.bigdata.rdf.sail.webapp.TestCBD731
testInsertTransformedWhere() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertTransformedWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhere() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertWhere() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereFalse() - Method in class com.bigdata.rdf.sail.webapp.TestInsertFilterFalse727
testInsertWhereGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertWhereGraph() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereOptionallyFalse() - Method in class com.bigdata.rdf.sail.webapp.TestInsertFilterFalse727
testInsertWhereOptionallyTrue() - Method in class com.bigdata.rdf.sail.webapp.TestInsertFilterFalse727
testInsertWhereTrue() - Method in class com.bigdata.rdf.sail.webapp.TestInsertFilterFalse727
testInsertWhereUsing() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertWhereUsing() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereWith() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertWhereWith() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereWithBinding() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereWithBindings() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereWithBindings2() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereWithBlankNode() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInsertWhereWithOptional() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testInsertWhereWithOptional() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testInterruptedTimedPoll() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Interrupted timed poll throws InterruptedException instead of
returning timeout status
testInterruptedTimedPoll() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Interrupted timed poll throws InterruptedException instead of
returning timeout status
testInterruptedTimedPollFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Interrupted timed pollFirst throws InterruptedException instead of
returning timeout status
testInterruptedTimedPollLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Interrupted timed pollLast throws InterruptedException instead of
returning timeout status
testInvalidAdditionalPrefixes() - Method in class com.bigdata.rdf.sail.sparql.TestPrefixDeclProcessor
testInvalidDateTime() - Method in class org.openrdf.sail.RDFStoreTest
TestIO - Class in com.bigdata.io
Low level IO performance tests in support of bigdata design options.
TestIO() - Constructor for class com.bigdata.io.TestIO
TestIO(String) - Constructor for class com.bigdata.io.TestIO
testIPAddress() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddress1() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddress2() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddress3() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddressBad() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddressBad2() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddressBadCIDR() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddressCIDR() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIPAddressCIDR2() - Method in class com.bigdata.rdf.internal.impl.uri.IPv4AddrIVTest
testIsBound() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testIsBroken() - Method in class com.bigdata.search.TestDefaultAnalyzerFactory
Given legacy concerns, we should preserve the incorrect behavior!
testIsLiteral() - Method in class com.bigdata.rdf.sail.TestInlineValues
TestIsModified - Class in com.bigdata.rdf.store
TestIsModified() - Constructor for class com.bigdata.rdf.store.TestIsModified
TestIsModified(String) - Constructor for class com.bigdata.rdf.store.TestIsModified
TestIsolatedFusedView - Class in com.bigdata.btree.isolation
TestIsolatedFusedView() - Constructor for class com.bigdata.btree.isolation.TestIsolatedFusedView
TestIsolatedFusedView(String) - Constructor for class com.bigdata.btree.isolation.TestIsolatedFusedView
testIsolatedIndexWriteRate() - Method in class com.bigdata.journal.BenchmarkJournalWriteRate
Test the index write rate for a fully isolated transaction using 32 bit
integer keys and 128 byte values for the index entries.
testIterator() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testIterator() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
iterator iterates through all elements
testIterator() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
iterator iterates through all elements
testIteratorOrdering() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
iterator ordering is FIFO
testIteratorOrdering() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
iterator ordering is FIFO
testIteratorRemove() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
iterator.remove removes current element
testIteratorRemove() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
iterator.remove removes current element
TestIterators - Class in com.bigdata.btree
Test suite for iterators.
TestIterators() - Constructor for class com.bigdata.btree.TestIterators
TestIterators(String) - Constructor for class com.bigdata.btree.TestIterators
TestIVariableBindingRequirements - Class in com.bigdata.rdf.sparql.ast.optimizers
TestIVariableBindingRequirements() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
TestIVariableBindingRequirements(String) - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
TestIVBindingSetEncoder - Class in com.bigdata.rdf.internal.encoder
TestIVBindingSetEncoder() - Constructor for class com.bigdata.rdf.internal.encoder.TestIVBindingSetEncoder
TestIVBindingSetEncoder(String) - Constructor for class com.bigdata.rdf.internal.encoder.TestIVBindingSetEncoder
TestIVBindingSetEncoderWithCache - Class in com.bigdata.rdf.internal.encoder
Deprecated.
TestIVBindingSetEncoderWithCache() - Constructor for class com.bigdata.rdf.internal.encoder.TestIVBindingSetEncoderWithCache
Deprecated.
TestIVBindingSetEncoderWithCache(String) - Constructor for class com.bigdata.rdf.internal.encoder.TestIVBindingSetEncoderWithCache
Deprecated.
TestIVCache - Class in com.bigdata.rdf.lexicon
TestIVCache() - Constructor for class com.bigdata.rdf.lexicon.TestIVCache
TestIVCache(String) - Constructor for class com.bigdata.rdf.lexicon.TestIVCache
TestIVComparator - Class in com.bigdata.bop.solutions
TestIVComparator() - Constructor for class com.bigdata.bop.solutions.TestIVComparator
TestIVComparator(String) - Constructor for class com.bigdata.bop.solutions.TestIVComparator
TestIVSolutionSetEncoder - Class in com.bigdata.rdf.internal.encoder
TestIVSolutionSetEncoder() - Constructor for class com.bigdata.rdf.internal.encoder.TestIVSolutionSetEncoder
TestIVSolutionSetEncoder(String) - Constructor for class com.bigdata.rdf.internal.encoder.TestIVSolutionSetEncoder
TestIVUnicode - Class in com.bigdata.rdf.internal
TestIVUnicode() - Constructor for class com.bigdata.rdf.internal.TestIVUnicode
TestIVUnicode(String) - Constructor for class com.bigdata.rdf.internal.TestIVUnicode
testJapanese() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
TestJavaScriptGOM - Class in com.bigdata.gom
Note: Java6 embeds JavaScript support based on Mozilla Rhino version 1.6R2.
TestJavaScriptGOM() - Constructor for class com.bigdata.gom.TestJavaScriptGOM
TestJavaScriptGOM(String) - Constructor for class com.bigdata.gom.TestJavaScriptGOM
TestJDKUnicodeKeyBuilder - Class in com.bigdata.btree.keys
TestJDKUnicodeKeyBuilder() - Constructor for class com.bigdata.btree.keys.TestJDKUnicodeKeyBuilder
TestJDKUnicodeKeyBuilder(String) - Constructor for class com.bigdata.btree.keys.TestJDKUnicodeKeyBuilder
testJettyUpdate() - Method in class com.bigdata.rdf.sail.webapp.TestMultipartContent
TestJGraph - Class in com.bigdata.bop.joinGraph.rto
Test suite for
JGraph
, which is the core implementation of the
runtime query optimizer logic.
TestJGraph() - Constructor for class com.bigdata.bop.joinGraph.rto.TestJGraph
TestJGraph(String) - Constructor for class com.bigdata.bop.joinGraph.rto.TestJGraph
TestJoinGraph - Class in com.bigdata.bop.joinGraph.rto
TestJoinGraph() - Constructor for class com.bigdata.bop.joinGraph.rto.TestJoinGraph
TestJoinGraph(String) - Constructor for class com.bigdata.bop.joinGraph.rto.TestJoinGraph
testJoinGroupOrderExplainHint01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for non-reorderable join groups.
testJoinGroupOrderExplainHint02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is not attached for reorderable join groups.
TestJoinOrder - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for SPARQL 1.1 BIND & VALUES clause.
TestJoinOrder() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestJoinOrder
TestJoinOrder(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestJoinOrder
testJoinOrderOptional01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestJoinOrder
Query
testJoinOrderOptional02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestJoinOrder
Query
TestJoinScope - Class in com.bigdata.rdf.sail
Unit tests the quads aspects of the
BigdataSail
implementation.
TestJoinScope() - Constructor for class com.bigdata.rdf.sail.TestJoinScope
TestJoinScope(String) - Constructor for class com.bigdata.rdf.sail.TestJoinScope
testJoinScope() - Method in class com.bigdata.rdf.sail.TestJoinScope
TestJoinSetUtil - Class in com.bigdata.rdf.sparql.ast
TestJoinSetUtil() - Constructor for class com.bigdata.rdf.sparql.ast.TestJoinSetUtil
TestJoinSetUtil(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestJoinSetUtil
testJoinWithFulltextSearch() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify that a subsequent join with a keyword result returns the
desired results.
TestJournal - Class in com.bigdata.service
TestJournal() - Constructor for class com.bigdata.service.TestJournal
TestJournal(String) - Constructor for class com.bigdata.service.TestJournal
TestJournalAbort - Class in com.bigdata.journal
Test suite for a failure to handle errors inside of abort() by marking the
journal as requiring abort().
TestJournalAbort() - Constructor for class com.bigdata.journal.TestJournalAbort
TestJournalAbort(String) - Constructor for class com.bigdata.journal.TestJournalAbort
TestJournalBasics - Class in com.bigdata.journal
Aggregates all tests into something approximately increasing dependency
order.
TestJournalBasics() - Constructor for class com.bigdata.journal.TestJournalBasics
TestJournalBasics(String) - Constructor for class com.bigdata.journal.TestJournalBasics
TestJournalShutdown - Class in com.bigdata.journal
Stress test for correct shutdown of journals based on weak reference
semantics.
TestJournalShutdown() - Constructor for class com.bigdata.journal.TestJournalShutdown
TestJournalShutdown(String) - Constructor for class com.bigdata.journal.TestJournalShutdown
TestJustifications - Class in com.bigdata.rdf.rules
Test suite for writing, reading, chasing and retracting
Justification
s.
TestJustifications() - Constructor for class com.bigdata.rdf.rules.TestJustifications
TestJustifications(String) - Constructor for class com.bigdata.rdf.rules.TestJustifications
TestJVMDistinctBindingSets - Class in com.bigdata.bop.solutions
TestJVMDistinctBindingSets() - Constructor for class com.bigdata.bop.solutions.TestJVMDistinctBindingSets
TestJVMDistinctBindingSets(String) - Constructor for class com.bigdata.bop.solutions.TestJVMDistinctBindingSets
TestJVMHashIndexOp - Class in com.bigdata.bop.join
TestJVMHashIndexOp() - Constructor for class com.bigdata.bop.join.TestJVMHashIndexOp
TestJVMHashIndexOp(String) - Constructor for class com.bigdata.bop.join.TestJVMHashIndexOp
TestJVMHashJoinOp - Class in com.bigdata.bop.join
TestJVMHashJoinOp() - Constructor for class com.bigdata.bop.join.TestJVMHashJoinOp
TestJVMHashJoinOp(String) - Constructor for class com.bigdata.bop.join.TestJVMHashJoinOp
TestJVMHashJoinUtility - Class in com.bigdata.bop.join
TestJVMHashJoinUtility() - Constructor for class com.bigdata.bop.join.TestJVMHashJoinUtility
TestJVMHashJoinUtility(String) - Constructor for class com.bigdata.bop.join.TestJVMHashJoinUtility
TestKernelVersion - Class in com.bigdata.counters.linux
TestKernelVersion() - Constructor for class com.bigdata.counters.linux.TestKernelVersion
TestKernelVersion(String) - Constructor for class com.bigdata.counters.linux.TestKernelVersion
TestKeyBufferSearch - Class in com.bigdata.btree.raba
Unit tests for IKeyBuffer#search(byte[] searchKey)
.
TestKeyBufferSearch() - Constructor for class com.bigdata.btree.raba.TestKeyBufferSearch
TestKeyBufferSearch(String) - Constructor for class com.bigdata.btree.raba.TestKeyBufferSearch
TestKeyBuilder - Class in com.bigdata.btree.keys
Test suite for high level operations that build variable length _unsigned_
byte[] keys from various data types and unicode strings.
TestKeyBuilder() - Constructor for class com.bigdata.btree.keys.TestKeyBuilder
TestKeyBuilder(String) - Constructor for class com.bigdata.btree.keys.TestKeyBuilder
TestKeyBuilder - Class in com.bigdata.search
TestKeyBuilder() - Constructor for class com.bigdata.search.TestKeyBuilder
TestKeyBuilder(String) - Constructor for class com.bigdata.search.TestKeyBuilder
TestKeyEncodeDecode - Class in com.bigdata.sparse
TestKeyEncodeDecode() - Constructor for class com.bigdata.sparse.TestKeyEncodeDecode
TestKeyEncodeDecode(String) - Constructor for class com.bigdata.sparse.TestKeyEncodeDecode
testLang() - Method in class com.bigdata.rdf.sail.TestLexJoinOps
TestLanguageRange - Class in com.bigdata.search
TestLanguageRange() - Constructor for class com.bigdata.search.TestLanguageRange
TestLanguageRange(String) - Constructor for class com.bigdata.search.TestLanguageRange
testLastElement() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
getLast() returns last element, or throws NSEE if empty
TestLatch - Class in com.bigdata.util.concurrent
TestLatch() - Constructor for class com.bigdata.util.concurrent.TestLatch
TestLatch(String) - Constructor for class com.bigdata.util.concurrent.TestLatch
testLatchExecutorProgression() - Method in class com.bigdata.bop.engine.TestQueryEngine
Test the LatchExecutor to verify reliable progression with multiple threads contending
to add tasks.
testLE() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestLeafDataRecord_CanonicalHuffman_CanonicalHuffman - Class in com.bigdata.btree.data
Test suite for the B+Tree
ILeafData
records (accessing coded data in
place).
TestLeafDataRecord_CanonicalHuffman_CanonicalHuffman() - Constructor for class com.bigdata.btree.data.TestLeafDataRecord_CanonicalHuffman_CanonicalHuffman
TestLeafDataRecord_CanonicalHuffman_CanonicalHuffman(String) - Constructor for class com.bigdata.btree.data.TestLeafDataRecord_CanonicalHuffman_CanonicalHuffman
TestLeafDataRecord_FrontCoded_CanonicalHuffman - Class in com.bigdata.btree.data
Test suite for the B+Tree
ILeafData
records (accessing coded data in
place).
TestLeafDataRecord_FrontCoded_CanonicalHuffman() - Constructor for class com.bigdata.btree.data.TestLeafDataRecord_FrontCoded_CanonicalHuffman
TestLeafDataRecord_FrontCoded_CanonicalHuffman(String) - Constructor for class com.bigdata.btree.data.TestLeafDataRecord_FrontCoded_CanonicalHuffman
TestLeafDataRecord_Simple_Simple - Class in com.bigdata.btree.data
Test with simple coding for keys and values (no compression).
TestLeafDataRecord_Simple_Simple() - Constructor for class com.bigdata.btree.data.TestLeafDataRecord_Simple_Simple
TestLeafDataRecord_Simple_Simple(String) - Constructor for class com.bigdata.btree.data.TestLeafDataRecord_Simple_Simple
TestLeafSplitShortestSeparatorKey - Class in com.bigdata.btree
TestLeafSplitShortestSeparatorKey() - Constructor for class com.bigdata.btree.TestLeafSplitShortestSeparatorKey
TestLeafSplitShortestSeparatorKey(String) - Constructor for class com.bigdata.btree.TestLeafSplitShortestSeparatorKey
testLeaveBindBeforeService() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTMassagedServiceNodeOptimizer
testLeftJoins() - Method in class com.bigdata.rdf.sail.TestOptionals
Tests mapping of left joins in SPARQL onto optionals in bigdata rules.
TestLexAccessPatternEnum - Class in com.bigdata.rdf.lexicon
TestLexAccessPatternEnum() - Constructor for class com.bigdata.rdf.lexicon.TestLexAccessPatternEnum
TestLexAccessPatternEnum(String) - Constructor for class com.bigdata.rdf.lexicon.TestLexAccessPatternEnum
TestLexiconKeyBuilder - Class in com.bigdata.rdf.lexicon
TestLexiconKeyBuilder() - Constructor for class com.bigdata.rdf.lexicon.TestLexiconKeyBuilder
TestLexiconKeyBuilder(String) - Constructor for class com.bigdata.rdf.lexicon.TestLexiconKeyBuilder
TestLexJoinOps - Class in com.bigdata.rdf.sail
TestLexJoinOps() - Constructor for class com.bigdata.rdf.sail.TestLexJoinOps
TestLexJoinOps(String) - Constructor for class com.bigdata.rdf.sail.TestLexJoinOps
testLikeAndClass() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testLikeAndStopwords() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
TestLinearListMethods - Class in com.bigdata.btree
TestLinearListMethods() - Constructor for class com.bigdata.btree.TestLinearListMethods
TestLinearListMethods(String) - Constructor for class com.bigdata.btree.TestLinearListMethods
testLinkSetConsistency1() - Method in class com.bigdata.gom.TestGPO
Checks for reverse linkset referential integrity when property removed
testLinkSetConsistency2() - Method in class com.bigdata.gom.TestGPO
Checks for reverse linkset referential integrity when property replaced
testLinkSetConsistency3() - Method in class com.bigdata.gom.TestGPO
Checks for consistency as link set is created and modified
Dependent: setValue, getValue, removeValue, getLinksIn
testLinkSetsIn() - Method in class com.bigdata.gom.TestGPO
testLinkSetsOut() - Method in class com.bigdata.gom.TestGPO
Checks consistency with added and removed values
TestListBindingSet - Class in com.bigdata.bop.bindingSet
TestListBindingSet() - Constructor for class com.bigdata.bop.bindingSet.TestListBindingSet
TestListBindingSet(String) - Constructor for class com.bigdata.bop.bindingSet.TestListBindingSet
TestLiteralDatatypeIV - Class in com.bigdata.rdf.internal
TestLiteralDatatypeIV() - Constructor for class com.bigdata.rdf.internal.TestLiteralDatatypeIV
TestLiteralDatatypeIV(String) - Constructor for class com.bigdata.rdf.internal.TestLiteralDatatypeIV
testLiteralExtensionIV() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
testLiteralSerialization() - Method in class org.openrdf.repository.RepositoryConnectionTest
testLoad() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
TestLoadAndVerify - Class in com.bigdata.rdf.rio
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.
TestLoadAndVerify() - Constructor for class com.bigdata.rdf.rio.TestLoadAndVerify
TestLoadAndVerify(String) - Constructor for class com.bigdata.rdf.rio.TestLoadAndVerify
TestLoadBalancerRoundRobin - Class in com.bigdata.service
Unit tests for the round robin behaviors of the load balancer in isolation
(not an integration test).
TestLoadBalancerRoundRobin() - Constructor for class com.bigdata.service.TestLoadBalancerRoundRobin
TestLoadBalancerRoundRobin(String) - Constructor for class com.bigdata.service.TestLoadBalancerRoundRobin
testLoadFunction() - Method in class com.bigdata.rdf.internal.TestZOrderRangeScanUtility
testLoadGZip() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
Verify ability to load data from a gzip resource.
testLoadGZip() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
Verify ability to load data from a gzip resource.
testLoadIntoGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testLoadSilent() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
TestLocalChunkMessage - Class in com.bigdata.bop.engine
TestLocalChunkMessage() - Constructor for class com.bigdata.bop.engine.TestLocalChunkMessage
TestLocalChunkMessage(String) - Constructor for class com.bigdata.bop.engine.TestLocalChunkMessage
TestLocalNativeChunkMessage - Class in com.bigdata.bop.engine
TestLocalNativeChunkMessage() - Constructor for class com.bigdata.bop.engine.TestLocalNativeChunkMessage
TestLocalNativeChunkMessage(String) - Constructor for class com.bigdata.bop.engine.TestLocalNativeChunkMessage
TestLocalQuadStore - Class in com.bigdata.rdf.store
TestLocalQuadStore() - Constructor for class com.bigdata.rdf.store.TestLocalQuadStore
TestLocalQuadStore(String) - Constructor for class com.bigdata.rdf.store.TestLocalQuadStore
TestLocalTripleStore - Class in com.bigdata.rdf.store
TestLocalTripleStore() - Constructor for class com.bigdata.rdf.store.TestLocalTripleStore
TestLocalTripleStore(String) - Constructor for class com.bigdata.rdf.store.TestLocalTripleStore
TestLocalTripleStoreDestroy - Class in com.bigdata.rdf.store
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.
TestLocalTripleStoreDestroy() - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreDestroy
TestLocalTripleStoreDestroy(String) - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreDestroy
TestLocalTripleStoreTransactionSemantics - Class in com.bigdata.rdf.store
TestLocalTripleStoreTransactionSemantics() - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreTransactionSemantics
TestLocalTripleStoreTransactionSemantics(String) - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreTransactionSemantics
TestLocalTripleStoreWithoutInlining - Class in com.bigdata.rdf.store
TestLocalTripleStoreWithoutInlining() - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreWithoutInlining
TestLocalTripleStoreWithoutInlining(String) - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreWithoutInlining
TestLocalTripleStoreWithoutStatementIdentifiers - Class in com.bigdata.rdf.store
TestLocalTripleStoreWithoutStatementIdentifiers() - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreWithoutStatementIdentifiers
TestLocalTripleStoreWithoutStatementIdentifiers(String) - Constructor for class com.bigdata.rdf.store.TestLocalTripleStoreWithoutStatementIdentifiers
TestLockDeserialization - Class in com.bigdata.rdf.load
This is a test suite for the
ReentrantLock
deserialization pattern
used by the
MappedRDFFileLoadTask
when it executes on a remote
ClientService
.
TestLockDeserialization() - Constructor for class com.bigdata.rdf.load.TestLockDeserialization
TestLockDeserialization(String) - Constructor for class com.bigdata.rdf.load.TestLockDeserialization
TestLockManager - Class in com.bigdata.concurrent
Suite of stress tests of the concurrency control mechanisms (without the
database implementation) - See
LockManager
.
TestLockManager() - Constructor for class com.bigdata.concurrent.TestLockManager
TestLockManager(String) - Constructor for class com.bigdata.concurrent.TestLockManager
TestLockManager.Generate - Class in com.bigdata.concurrent
Generates an XML file that can be used to (re-)run the concurrency
control tests.
TestLockManager.Generate() - Constructor for class com.bigdata.concurrent.TestLockManager.Generate
TestLockManager.TestOptions - Class in com.bigdata.concurrent
TestLockManager.TestOptions() - Constructor for class com.bigdata.concurrent.TestLockManager.TestOptions
TestLockManager.Wait10ResourceTask - Class in com.bigdata.concurrent
Waits 10ms once it acquires its locks.
TestLockManager.Wait10ResourceTask() - Constructor for class com.bigdata.concurrent.TestLockManager.Wait10ResourceTask
testLongLangRoundTrip() - Method in class org.openrdf.sail.RDFStoreTest
testLongLiteralRoundTrip() - Method in class org.openrdf.sail.RDFStoreTest
TestLongPacker - Class in com.bigdata.io
TestLongPacker() - Constructor for class com.bigdata.io.TestLongPacker
TestLongPacker(String) - Constructor for class com.bigdata.io.TestLongPacker
testLongURIRoundTrip() - Method in class org.openrdf.sail.RDFStoreTest
testLT() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestManagedReads - Class in com.bigdata.io
Investigates the benefits (if any) of managed concurrent reads with the aim of developing
metrics on which to base a ConcurrentReadManager for use by the Disk based strategies.
TestManagedReads() - Constructor for class com.bigdata.io.TestManagedReads
TestManagedReads(String) - Constructor for class com.bigdata.io.TestManagedReads
testManyShortRuns() - Method in class com.bigdata.rdf.sail.TestRollbacks
Stress test for abort/rollback semantics consisting of many short
runs of the basic test.
testMap() - Method in class com.bigdata.btree.TestBigdataMap
Basic tests of isEmpty(), size(), containsKey(), put(), and remove().
TestMapBindingSetsOverNodes - Class in com.bigdata.bop.fed.nodes
Unit tests for mapping binding sets over nodes.
TestMapBindingSetsOverNodes() - Constructor for class com.bigdata.bop.fed.nodes.TestMapBindingSetsOverNodes
TestMapBindingSetsOverNodes(String) - Constructor for class com.bigdata.bop.fed.nodes.TestMapBindingSetsOverNodes
TestMapBindingSetsOverShards - Class in com.bigdata.bop.fed.shards
TestMapBindingSetsOverShards() - Constructor for class com.bigdata.bop.fed.shards.TestMapBindingSetsOverShards
TestMapBindingSetsOverShards(String) - Constructor for class com.bigdata.bop.fed.shards.TestMapBindingSetsOverShards
TestMappedJournal - Class in com.bigdata.journal
TestMappedJournal() - Constructor for class com.bigdata.journal.TestMappedJournal
TestMappedJournal(String) - Constructor for class com.bigdata.journal.TestMappedJournal
TestMappedJournal.TestInterrupts - Class in com.bigdata.journal
TestMappedJournal.TestInterrupts() - Constructor for class com.bigdata.journal.TestMappedJournal.TestInterrupts
TestMappedJournal.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestMappedJournal.TestInterrupts
TestMappedJournal.TestMRMW - Class in com.bigdata.journal
TestMappedJournal.TestMRMW() - Constructor for class com.bigdata.journal.TestMappedJournal.TestMRMW
TestMappedJournal.TestMRMW(String) - Constructor for class com.bigdata.journal.TestMappedJournal.TestMRMW
TestMappedJournal.TestMROW - Class in com.bigdata.journal
TestMappedJournal.TestMROW() - Constructor for class com.bigdata.journal.TestMappedJournal.TestMROW
TestMappedJournal.TestMROW(String) - Constructor for class com.bigdata.journal.TestMappedJournal.TestMROW
TestMappedJournal.TestRawStore - Class in com.bigdata.journal
TestMappedJournal.TestRawStore() - Constructor for class com.bigdata.journal.TestMappedJournal.TestRawStore
TestMappedJournal.TestRawStore(String) - Constructor for class com.bigdata.journal.TestMappedJournal.TestRawStore
TestMappedProgram - Class in com.bigdata.rdf.rules
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.
TestMappedProgram() - Constructor for class com.bigdata.rdf.rules.TestMappedProgram
TestMappedProgram(String) - Constructor for class com.bigdata.rdf.rules.TestMappedProgram
testMappedRuleWithOneTail() - Method in class com.bigdata.rdf.rules.TestMappedProgram
testMappedRuleWithTwoTails() - Method in class com.bigdata.rdf.rules.TestMappedProgram
testMaskOffLSB() - Method in class com.bigdata.btree.TestBytesUtil
testMassageServiceNested2Call() - Method in class com.bigdata.rdf.sail.webapp.TestService794
testMassageServiceNested3Call() - Method in class com.bigdata.rdf.sail.webapp.TestService794
TestMasterTask - Class in com.bigdata.service.ndx.pipeline
TestMasterTask() - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTask
TestMasterTask(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTask
TestMasterTaskIdleTimeout - Class in com.bigdata.service.ndx.pipeline
TestMasterTaskIdleTimeout() - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskIdleTimeout
TestMasterTaskIdleTimeout(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskIdleTimeout
TestMasterTaskWithErrors - Class in com.bigdata.service.ndx.pipeline
Unit tests for error handling in the control logic used by
AbstractMasterTask
and friends.
TestMasterTaskWithErrors() - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskWithErrors
TestMasterTaskWithErrors(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskWithErrors
TestMasterTaskWithRedirect - Class in com.bigdata.service.ndx.pipeline
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).
TestMasterTaskWithRedirect() - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskWithRedirect
TestMasterTaskWithRedirect(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskWithRedirect
TestMasterTaskWithSplits - Class in com.bigdata.service.ndx.pipeline
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.
TestMasterTaskWithSplits() - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskWithSplits
TestMasterTaskWithSplits(String) - Constructor for class com.bigdata.service.ndx.pipeline.TestMasterTaskWithSplits
TestMatch - Class in com.bigdata.rdf.rules
TestMatch() - Constructor for class com.bigdata.rdf.rules.TestMatch
TestMatch(String) - Constructor for class com.bigdata.rdf.rules.TestMatch
TestMaterialization - Class in com.bigdata.rdf.sail
TestMaterialization() - Constructor for class com.bigdata.rdf.sail.TestMaterialization
TestMaterialization(String) - Constructor for class com.bigdata.rdf.sail.TestMaterialization
testMaterializedIVs() - Method in class com.bigdata.bop.solutions.TestMemorySortOp
Test with materialized IVs.
testMath() - Method in class com.bigdata.rdf.internal.TestPackedLongIVs
Test math operations such as +, -, *, /, MIN and MAX over the datatype.
testMath() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
TestMAX - Class in com.bigdata.bop.rdf.aggregate
TestMAX() - Constructor for class com.bigdata.bop.rdf.aggregate.TestMAX
TestMAX(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestMAX
testMembership() - Method in class com.bigdata.gom.TestGPO
Checks linkSet membership
TestMemoryGroupByOp - Class in com.bigdata.bop.solutions
TestMemoryGroupByOp() - Constructor for class com.bigdata.bop.solutions.TestMemoryGroupByOp
TestMemoryGroupByOp(String) - Constructor for class com.bigdata.bop.solutions.TestMemoryGroupByOp
TestMemoryManager - Class in com.bigdata.rwstore.sector
TestMemoryManager() - Constructor for class com.bigdata.rwstore.sector.TestMemoryManager
TestMemoryManager2 - Class in com.bigdata.rwstore.sector
Some additional tests for the
MemoryManager
which look at the effect
of the #of buffers it is allowed to allocate.
TestMemoryManager2() - Constructor for class com.bigdata.rwstore.sector.TestMemoryManager2
TestMemoryManager2(String) - Constructor for class com.bigdata.rwstore.sector.TestMemoryManager2
TestMemoryManagerStreams - Class in com.bigdata.rwstore.sector
TestMemoryManagerStreams() - Constructor for class com.bigdata.rwstore.sector.TestMemoryManagerStreams
TestMemorySortOp - Class in com.bigdata.bop.solutions
TestMemorySortOp() - Constructor for class com.bigdata.bop.solutions.TestMemorySortOp
TestMemorySortOp(String) - Constructor for class com.bigdata.bop.solutions.TestMemorySortOp
TestMemStore - Class in com.bigdata.rwstore.sector
TestMemStore() - Constructor for class com.bigdata.rwstore.sector.TestMemStore
TestMemStore(String) - Constructor for class com.bigdata.rwstore.sector.TestMemStore
TestMemStore.TestMRMW - Class in com.bigdata.rwstore.sector
TestMemStore.TestMRMW() - Constructor for class com.bigdata.rwstore.sector.TestMemStore.TestMRMW
TestMemStore.TestMRMW(String) - Constructor for class com.bigdata.rwstore.sector.TestMemStore.TestMRMW
TestMemStore.TestMROW - Class in com.bigdata.rwstore.sector
TestMemStore.TestMROW() - Constructor for class com.bigdata.rwstore.sector.TestMemStore.TestMROW
TestMemStore.TestMROW(String) - Constructor for class com.bigdata.rwstore.sector.TestMemStore.TestMROW
TestMemStore.TestRawStore - Class in com.bigdata.rwstore.sector
TestMemStore.TestRawStore() - Constructor for class com.bigdata.rwstore.sector.TestMemStore.TestRawStore
TestMemStore.TestRawStore(String) - Constructor for class com.bigdata.rwstore.sector.TestMemStore.TestRawStore
testMerge() - Method in class com.bigdata.io.TestMergeMapOutput
TestMergeFilter - Class in com.bigdata.striterator
TestMergeFilter() - Constructor for class com.bigdata.striterator.TestMergeFilter
TestMergeFilter(String) - Constructor for class com.bigdata.striterator.TestMergeFilter
TestMergeJoin - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite.
TestMergeJoin() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestMergeJoin
TestMergeJoin(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestMergeJoin
TestMergeMapOutput - Class in com.bigdata.io
Tests the utility to merge an input stream with a sorted set of
TestMergeMapOutput() - Constructor for class com.bigdata.io.TestMergeMapOutput
TestMergeTask - Class in com.bigdata.resources
Basic test of compacting merge for an index partition on overflow.
TestMergeTask() - Constructor for class com.bigdata.resources.TestMergeTask
TestMergeTask(String) - Constructor for class com.bigdata.resources.TestMergeTask
testMergeUtility() - Method in class com.bigdata.rdf.sail.TestTicket1889
testMergeWithComplexExogeneousMapping() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
testMergeWithSimpleExogeneousMapping() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from top-level VALUES
clause, including the removal of the clause and putting the values into
the exogeneous mapping set.
TestMetadataIndex - Class in com.bigdata.service
TestMetadataIndex() - Constructor for class com.bigdata.service.TestMetadataIndex
TestMetadataIndex(String) - Constructor for class com.bigdata.service.TestMetadataIndex
TestMillisecondPrecisionForInlineDateTimes - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestMillisecondPrecisionForInlineDateTimes() - Constructor for class com.bigdata.rdf.sail.TestMillisecondPrecisionForInlineDateTimes
TestMillisecondPrecisionForInlineDateTimes(String) - Constructor for class com.bigdata.rdf.sail.TestMillisecondPrecisionForInlineDateTimes
TestMIMEType - Class in com.bigdata.util.httpd
TestMIMEType() - Constructor for class com.bigdata.util.httpd.TestMIMEType
TestMIMEType.AssertionFailedError2 - Error in com.bigdata.util.httpd
Helper class.
TestMIMEType.AssertionFailedError2(String, Throwable) - Constructor for error com.bigdata.util.httpd.TestMIMEType.AssertionFailedError2
TestMIMEType.Criteria - Class in com.bigdata.util.httpd
Note: This class is reused by TestAcceptMIMEType
.
TestMIMEType.Criteria() - Constructor for class com.bigdata.util.httpd.TestMIMEType.Criteria
TestMIN - Class in com.bigdata.bop.rdf.aggregate
TestMIN() - Constructor for class com.bigdata.bop.rdf.aggregate.TestMIN
TestMIN(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestMIN
testMissingClass() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
TestMixedModeOperations - Class in com.bigdata.btree.isolation
This is a test suite for mixing full transactions with unisolated operations
on the same indices.
TestMixedModeOperations() - Constructor for class com.bigdata.btree.isolation.TestMixedModeOperations
TestMixedModeOperations(String) - Constructor for class com.bigdata.btree.isolation.TestMixedModeOperations
TestMockQuorumFixture - Class in com.bigdata.quorum
TestMockQuorumFixture() - Constructor for class com.bigdata.quorum.TestMockQuorumFixture
TestMockQuorumFixture(String) - Constructor for class com.bigdata.quorum.TestMockQuorumFixture
TestMockUtility - Class in com.bigdata.bop
Mock utility for test cases.
TestMockUtility() - Constructor for class com.bigdata.bop.TestMockUtility
TestModelsEqual - Class in com.bigdata.rdf.rules
TestModelsEqual() - Constructor for class com.bigdata.rdf.rules.TestModelsEqual
TestModelsEqual(String) - Constructor for class com.bigdata.rdf.rules.TestModelsEqual
testModerateDuration() - Method in class com.bigdata.rdf.sail.TestRollbacks
Stress test for abort/rollback semantics consisting of one moderate
duration run of the basic test.
TestMove - Class in com.bigdata.service
Some unit tests for moving an index partition.
TestMove() - Constructor for class com.bigdata.service.TestMove
TestMove(String) - Constructor for class com.bigdata.service.TestMove
testMoveFromDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testMoveFromDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testMoveFromDefaultToDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testMoveFromDefaultToDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testMoveToDefault() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testMoveToDefault() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testMoveToNewNamed() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testMoveToNewNamed() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testMRMW() - Method in class com.bigdata.journal.AbstractMRMWTestCase
Correctness/stress test verifies that the implementation supports
Multiple Readers, Multiple Writers.
testMROW() - Method in class com.bigdata.journal.AbstractMROWTestCase
Correctness/stress test verifies that the implementation supports
Multiple Readers One Writer (MROW).
TestMROWTransactions - Class in com.bigdata.rdf.sail
TestCase to test single writer/mutiple transaction committed readers with
SAIL interface.
TestMROWTransactions.MyBTree - Class in com.bigdata.rdf.sail
Helper class for force abort of a B+Tree write.
TestMROWTransactions.MyBTree(IRawStore, Checkpoint, IndexMetadata, boolean) - Constructor for class com.bigdata.rdf.sail.TestMROWTransactions.MyBTree
TestMROWTransactionsNoHistory - Class in com.bigdata.rdf.sail
TestCase to test single writer/mutiple transaction committed readers with
SAIL interface.
TestMROWTransactionsNoHistory() - Constructor for class com.bigdata.rdf.sail.TestMROWTransactionsNoHistory
TestMROWTransactionsNoHistory(String) - Constructor for class com.bigdata.rdf.sail.TestMROWTransactionsNoHistory
TestMROWTransactionsWithHistory - Class in com.bigdata.rdf.sail
TestCase to test single writer/mutiple transaction committed readers with
SAIL interface.
TestMROWTransactionsWithHistory() - Constructor for class com.bigdata.rdf.sail.TestMROWTransactionsWithHistory
TestMROWTransactionsWithHistory(String) - Constructor for class com.bigdata.rdf.sail.TestMROWTransactionsWithHistory
testMultiBlockIterator(BTree, IndexSegment) - Static method in class com.bigdata.btree.AbstractIndexSegmentTestCase
testMultiFulltextSearch() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify passing of query via variable, which leads to multiple keyword
search requests.
TestMultiGraphs - Class in com.bigdata.rdf.sail
TestMultiGraphs() - Constructor for class com.bigdata.rdf.sail.TestMultiGraphs
TestMultiGraphs(String) - Constructor for class com.bigdata.rdf.sail.TestMultiGraphs
testMultiGraphs() - Method in class com.bigdata.rdf.sail.TestMultiGraphs
testMultiInlineFromExogeneousBindings() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
TestMultiInlineURIFactory - Class in com.bigdata.rdf.vocab
TestMultiInlineURIFactory() - Constructor for class com.bigdata.rdf.vocab.TestMultiInlineURIFactory
TestMultiInlineURIHandlersSingleNamespace - Class in com.bigdata.rdf.internal
Test case for multiple InlineURIHandlers at a single namespace.
TestMultiInlineURIHandlersSingleNamespace() - Constructor for class com.bigdata.rdf.internal.TestMultiInlineURIHandlersSingleNamespace
TestMultipartContent - Class in com.bigdata.rdf.sail.webapp
The Jetty HttpClient does not provide "out of the box" support for multipart
content similar to the Apache MultipartEntity.
TestMultipartContent() - Constructor for class com.bigdata.rdf.sail.webapp.TestMultipartContent
testMultipleClients() - Method in class com.bigdata.ha.pipeline.TestSocketsDirect
Confirms that multiple clients can communicate with same Server
testMultipleFixtures() - Method in class com.bigdata.rdf.sail.webapp.Test_REST_Structure
testMultiplePartitionsWithStatementPattern() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
Test multiple partitions (all of which are made out of statement
patterns).
TestMultiplexBlockingBuffer - Class in com.bigdata.relation.accesspath
TestMultiplexBlockingBuffer() - Constructor for class com.bigdata.relation.accesspath.TestMultiplexBlockingBuffer
TestMultiplexBlockingBuffer(String) - Constructor for class com.bigdata.relation.accesspath.TestMultiplexBlockingBuffer
testMultipurposeIDNamespace() - Method in class com.bigdata.rdf.store.TestInlineURIs
TestMultiSourceSequentialCloseableIterator - Class in com.bigdata.relation.accesspath
TestMultiSourceSequentialCloseableIterator() - Constructor for class com.bigdata.relation.accesspath.TestMultiSourceSequentialCloseableIterator
TestMultiSourceSequentialCloseableIterator(String) - Constructor for class com.bigdata.relation.accesspath.TestMultiSourceSequentialCloseableIterator
TestMultiTenancyAPI<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for the Multi-Tenancy API.
TestMultiTenancyAPI() - Constructor for class com.bigdata.rdf.sail.webapp.TestMultiTenancyAPI
TestMultiTenancyAPI(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestMultiTenancyAPI
TestMultiVocabulary - Class in com.bigdata.rdf.vocab
TestMultiVocabulary() - Constructor for class com.bigdata.rdf.vocab.TestMultiVocabulary
De-serialization ctor.
TestMultiVocabulary(String) - Constructor for class com.bigdata.rdf.vocab.TestMultiVocabulary
TestMutableBTreeCursors - Class in com.bigdata.btree
Test ability to traverse tuples using an
ITupleCursor
while the SAME
THREAD is used to insert, update, or remove tuples from a mutable
BTree
.
TestMutableBTreeCursors() - Constructor for class com.bigdata.btree.TestMutableBTreeCursors
TestMutableBTreeCursors(String) - Constructor for class com.bigdata.btree.TestMutableBTreeCursors
TestMutableKeyBuffer - Class in com.bigdata.btree.raba
TestMutableKeyBuffer() - Constructor for class com.bigdata.btree.raba.TestMutableKeyBuffer
TestMutableKeyBuffer(String) - Constructor for class com.bigdata.btree.raba.TestMutableKeyBuffer
TestMutableKeyBuffer - Class in com.bigdata.htree.raba
TestMutableKeyBuffer() - Constructor for class com.bigdata.htree.raba.TestMutableKeyBuffer
TestMutableKeyBuffer(String) - Constructor for class com.bigdata.htree.raba.TestMutableKeyBuffer
TestMutableValueBuffer - Class in com.bigdata.htree.raba
Test suite for MutableValuesBuffer
.
TestMutableValueBuffer() - Constructor for class com.bigdata.htree.raba.TestMutableValueBuffer
TestMutableValueBuffer(String) - Constructor for class com.bigdata.htree.raba.TestMutableValueBuffer
TestMutableValuesRaba - Class in com.bigdata.btree.raba
TestMutableValuesRaba() - Constructor for class com.bigdata.btree.raba.TestMutableValuesRaba
TestMutableValuesRaba(String) - Constructor for class com.bigdata.btree.raba.TestMutableValuesRaba
TestName2Addr - Class in com.bigdata.journal
Test suite for the
index
used to name index names to the
named indices.
TestName2Addr() - Constructor for class com.bigdata.journal.TestName2Addr
TestName2Addr(String) - Constructor for class com.bigdata.journal.TestName2Addr
TestNameAndExtensionFilter - Class in com.bigdata.io
TestNameAndExtensionFilter() - Constructor for class com.bigdata.io.TestNameAndExtensionFilter
TestNameAndExtensionFilter(String) - Constructor for class com.bigdata.io.TestNameAndExtensionFilter
testNamedGraphNoGraphKeyword1() - Method in class com.bigdata.rdf.sail.DavidsTestBOps
testNamedGraphNoGraphKeyword2() - Method in class com.bigdata.rdf.sail.DavidsTestBOps
testNamedGraphReferencedThroughWITHClause() - Method in class com.bigdata.rdf.sail.TestTicket1518
Test named graph referenced through WITH clause.
TestNamedGraphs - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for named and default graph stuff.
TestNamedGraphs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestNamedGraphs
TestNamedGraphs(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestNamedGraphs
TestNamedIndices - Class in com.bigdata.journal
Test suite for api supporting registration, lookup, use, and atomic commit of
named indices.
TestNamedIndices() - Constructor for class com.bigdata.journal.TestNamedIndices
TestNamedIndices(String) - Constructor for class com.bigdata.journal.TestNamedIndices
testNamedSolutionSetInsideNamedSubQuery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer2
See https://jira.blazegraph.com/browse/BLZG-856
testNamedSolutionSetLimit() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTNamedSubqueryOptimizer2
See https://jira.blazegraph.com/browse/BLZG-1862
TestNamedSolutionSetRef - Class in com.bigdata.bop
TestNamedSolutionSetRef() - Constructor for class com.bigdata.bop.TestNamedSolutionSetRef
TestNamedSolutionSetRef(String) - Constructor for class com.bigdata.bop.TestNamedSolutionSetRef
TestNamedSubQuery - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite for named subquery evaluation (that is, for queries
which are explicitly written using the named subquery syntax).
TestNamedSubQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestNamedSubQuery
TestNamedSubQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestNamedSubQuery
testNamedSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
testNamedSubqueryPlacement01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test placement of named subquery at the beginning of the associated
partition.
testNamedSubqueryPlacement02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test placement of named subquery at the beginning of the previous
partition (where intra-partition optimization is possible).
TestNamespaceMultiURIHandler - Class in com.bigdata.rdf.vocab
TestNamespaceMultiURIHandler() - Constructor for class com.bigdata.rdf.vocab.TestNamespaceMultiURIHandler
TestNanoHTTPD - Class in com.bigdata.util.httpd
TestNanoHTTPD() - Constructor for class com.bigdata.util.httpd.TestNanoHTTPD
TestNanoHTTPD(String) - Constructor for class com.bigdata.util.httpd.TestNanoHTTPD
TestNanoSparqlClient<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
TestNanoSparqlClient() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlClient
TestNanoSparqlClient(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlClient
TestNanoSparqlServer - Class in com.bigdata.rdf.sail.webapp
Unit tests for the
NanoSparqlServer
with a focus on the ability to
override the init parameters, the default http port, etc.
TestNanoSparqlServer() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServer
TestNanoSparqlServerWithProxyIndexManager<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Test suite for
RESTServlet
(SPARQL end point and REST API for RDF
data).
TestNanoSparqlServerWithProxyIndexManager() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager
Run in triples mode on a temporary journal.
TestNanoSparqlServerWithProxyIndexManager(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager
Run in triples mode on a temporary journal.
TestNanoSparqlServerWithProxyIndexManager.Test_NSS_quads - Class in com.bigdata.rdf.sail.webapp
The TestMode.quads
test suite.
TestNanoSparqlServerWithProxyIndexManager.Test_NSS_quads() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager.Test_NSS_quads
TestNanoSparqlServerWithProxyIndexManager.test_NSS_RWStore - Class in com.bigdata.rdf.sail.webapp
TestNanoSparqlServerWithProxyIndexManager.test_NSS_RWStore() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager.test_NSS_RWStore
TestNanoSparqlServerWithProxyIndexManager.Test_NSS_sids - Class in com.bigdata.rdf.sail.webapp
The TestMode.sids
test suite.
TestNanoSparqlServerWithProxyIndexManager.Test_NSS_sids() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager.Test_NSS_sids
TestNanoSparqlServerWithProxyIndexManager.test_NSS_triples - Class in com.bigdata.rdf.sail.webapp
The TestMode.triples
test suite.
TestNanoSparqlServerWithProxyIndexManager.test_NSS_triples() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager.test_NSS_triples
TestNanoSparqlServerWithProxyIndexManager2<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
A version of the test suite that is intended for local debugging and is NOT
run in CI.
TestNanoSparqlServerWithProxyIndexManager2() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager2
Run in triples mode on a temporary journal.
TestNanoSparqlServerWithProxyIndexManager2(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager2
Run in triples mode on a temporary journal.
TestNanoSparqlServerWithProxyIndexManager2.Test_NSS_quads - Class in com.bigdata.rdf.sail.webapp
The TestMode.quads
test suite.
TestNanoSparqlServerWithProxyIndexManager2.Test_NSS_quads() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager2.Test_NSS_quads
TestNanoSparqlServerWithProxyIndexManager2.Test_NSS_sids - Class in com.bigdata.rdf.sail.webapp
The TestMode.sids
test suite.
TestNanoSparqlServerWithProxyIndexManager2.Test_NSS_sids() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager2.Test_NSS_sids
TestNanoSparqlServerWithProxyIndexManager2.test_NSS_triples - Class in com.bigdata.rdf.sail.webapp
The TestMode.triples
test suite.
TestNanoSparqlServerWithProxyIndexManager2.test_NSS_triples() - Constructor for class com.bigdata.rdf.sail.webapp.TestNanoSparqlServerWithProxyIndexManager2.test_NSS_triples
TestNativeDistinctFilter - Class in com.bigdata.bop.rdf.filter
TestNativeDistinctFilter() - Constructor for class com.bigdata.bop.rdf.filter.TestNativeDistinctFilter
TestNativeDistinctFilter(String) - Constructor for class com.bigdata.bop.rdf.filter.TestNativeDistinctFilter
TestNativeDistinctFilter.JoinSetup - Class in com.bigdata.bop.rdf.filter
Setup for a problem used by many of the join test suites.
TestNativeDistinctFilter.JoinSetup(String) - Constructor for class com.bigdata.bop.rdf.filter.TestNativeDistinctFilter.JoinSetup
testNBytes() - Method in class com.bigdata.io.LongPackerTestCase
testNBytes() - Method in class com.bigdata.io.TestLongPacker
TestNE - Class in com.bigdata.bop.constraint
TestNE() - Constructor for class com.bigdata.bop.constraint.TestNE
TestNE(String) - Constructor for class com.bigdata.bop.constraint.TestNE
TestNEConstant - Class in com.bigdata.bop.constraint
TestNEConstant() - Constructor for class com.bigdata.bop.constraint.TestNEConstant
TestNEConstant(String) - Constructor for class com.bigdata.bop.constraint.TestNEConstant
testNegAlphaInv(String[]) - Static method in class cern.jet.random.sampling.RandomSampler
Tests different values for negaalphainv.
TestNegation - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for SPARQL negation (EXISTS and MINUS).
TestNegation() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestNegation
TestNegation(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestNegation
testNegationLeafRewriting01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test rewriting of negated leaves, such as !(?x=?y) -> ?x!=?y,
!(?a ?a>=?b, etc.
testNegationLeafRewriting02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test rewriting of negated leaves, such as !(?x=?y) -> ?x!=?y,
!(?a ?a>=?b, etc.
testNestedAllocationContexts() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
Rather than creating contexts directly, instead associate with
externally created context.
TestNestedLoopJoinOp - Class in com.bigdata.bop.join
TestNestedLoopJoinOp() - Constructor for class com.bigdata.bop.join.TestNestedLoopJoinOp
TestNestedLoopJoinOp(String) - Constructor for class com.bigdata.bop.join.TestNestedLoopJoinOp
testNestedNegationRewriting() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test level three pushing of negation.
testNestedNegationRewritingAndSplit() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test level three pushing of negation.
testNestedPartway() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNestedPlus() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNestedQuestionMark() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNestedStar() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNestedUnion() - Method in class com.bigdata.rdf.sparql.ast.TestAST
select *
where {
predicate1 .
TestNIOChunkMessage - Class in com.bigdata.bop.fed
TestNIOChunkMessage() - Constructor for class com.bigdata.bop.fed.TestNIOChunkMessage
TestNIOChunkMessage(String) - Constructor for class com.bigdata.bop.fed.TestNIOChunkMessage
TestNodeDataRecord_CanonicalHuffman - Class in com.bigdata.btree.data
TestNodeDataRecord_CanonicalHuffman() - Constructor for class com.bigdata.btree.data.TestNodeDataRecord_CanonicalHuffman
TestNodeDataRecord_CanonicalHuffman(String) - Constructor for class com.bigdata.btree.data.TestNodeDataRecord_CanonicalHuffman
TestNodeDataRecord_FrontCoded - Class in com.bigdata.btree.data
TestNodeDataRecord_FrontCoded() - Constructor for class com.bigdata.btree.data.TestNodeDataRecord_FrontCoded
TestNodeDataRecord_FrontCoded(String) - Constructor for class com.bigdata.btree.data.TestNodeDataRecord_FrontCoded
TestNodeDataRecord_Simple - Class in com.bigdata.btree.data
Test suite without key compression.
TestNodeDataRecord_Simple() - Constructor for class com.bigdata.btree.data.TestNodeDataRecord_Simple
TestNodeDataRecord_Simple(String) - Constructor for class com.bigdata.btree.data.TestNodeDataRecord_Simple
TestNoExceptions - Class in com.bigdata.rdf.sail
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.
TestNoExceptions() - Constructor for class com.bigdata.rdf.sail.TestNoExceptions
TestNoExceptions(String) - Constructor for class com.bigdata.rdf.sail.TestNoExceptions
testNoIsolation() - Method in class com.bigdata.journal.BenchmarkJournalWriteRate.AbstractBenchmarkOptimium
TestNonBlockingLockManager - Class in com.bigdata.concurrent
basic unit tests.
TestNonBlockingLockManager() - Constructor for class com.bigdata.concurrent.TestNonBlockingLockManager
TestNonBlockingLockManager(String) - Constructor for class com.bigdata.concurrent.TestNonBlockingLockManager
TestNonBlockingLockManager.Wait10ResourceTask<T> - Class in com.bigdata.concurrent
Waits 10ms once it acquires its locks.
TestNonBlockingLockManager.Wait10ResourceTask() - Constructor for class com.bigdata.concurrent.TestNonBlockingLockManager.Wait10ResourceTask
TestNonBlockingLockManagerWithNewDesign - Class in com.bigdata.concurrent
basic unit tests.
TestNonBlockingLockManagerWithNewDesign() - Constructor for class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
TestNonBlockingLockManagerWithNewDesign(String) - Constructor for class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign
TestNonBlockingLockManagerWithNewDesign.Wait10ResourceTask<T> - Class in com.bigdata.concurrent
Waits 10ms once it acquires its locks.
TestNonBlockingLockManagerWithNewDesign.Wait10ResourceTask() - Constructor for class com.bigdata.concurrent.TestNonBlockingLockManagerWithNewDesign.Wait10ResourceTask
testNonDefaultDatatype() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
testNonGeoSpatialQuery01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
Non-geospatial ?s ?p ?o query retrieving ?s
testNonGeoSpatialQuery02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialDefaults
Non-geospatial ?s ?p ?o query with FILTER retrieving ?s and ?o
testNonIsolatableIndexWriteRate() - Method in class com.bigdata.journal.BenchmarkJournalWriteRate
Test the index write rate using an index that does NOT support
transactional isolation using 32 bit integer keys and 128 byte values for
the index entries.
TestNOPRecordCompressor - Class in com.bigdata.io.compression
TestNOPRecordCompressor() - Constructor for class com.bigdata.io.compression.TestNOPRecordCompressor
TestNOPRecordCompressor(String) - Constructor for class com.bigdata.io.compression.TestNOPRecordCompressor
testNotInlineSimpleFilterEqLiteral() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
testNotInlineSimpleFilterEqLiteralRev() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test testNotInlineSimpleFilterEqLiteral with filter reversed.
testNotNestedPartway() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNotNestedPlus() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNotNestedQuestionMark() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
testNotNestedStar() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
TestNSSHealthCheck - Class in com.bigdata.rdf.sail.webapp.health
Utility test suite provides a health check for a deployed instance.
TestNSSHealthCheck(String) - Constructor for class com.bigdata.rdf.sail.webapp.health.TestNSSHealthCheck
testNTriplesFile() - Method in class com.bigdata.rdf.rio.ntriples.BigdataNTriplesParserTestCase
testNTriplesFileWithReification() - Method in class com.bigdata.rdf.rio.ntriples.BigdataNTriplesParserTestCase
testNTriplesFileWithSIDS() - Method in class com.bigdata.rdf.rio.ntriples.BigdataNTriplesParserTestCase
TestNTriplesWithSids - Class in com.bigdata.rdf.rio
Test suite for SIDS support with NTRIPLES data.
TestNTriplesWithSids() - Constructor for class com.bigdata.rdf.rio.TestNTriplesWithSids
TestNTriplesWithSids(String) - Constructor for class com.bigdata.rdf.rio.TestNTriplesWithSids
testNullContext1() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testNullContext1() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testNullContext2() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testNullNamespaceDisallowed() - Method in class org.openrdf.sail.RDFStoreTest
testNullPrefixDisallowed() - Method in class org.openrdf.sail.RDFStoreTest
TestNullValues - Class in com.bigdata.btree
Test of storing null values under a key with persistence.
TestNullValues() - Constructor for class com.bigdata.btree.TestNullValues
TestNullValues(String) - Constructor for class com.bigdata.btree.TestNullValues
TestNullValues - Class in com.bigdata.htree
Test of storing null values under a key with persistence.
TestNullValues() - Constructor for class com.bigdata.htree.TestNullValues
TestNullValues(String) - Constructor for class com.bigdata.htree.TestNullValues
TestNumericBNodes - Class in com.bigdata.gom
Test suite for numeric bnodes parsing.
TestNumericBNodes() - Constructor for class com.bigdata.gom.TestNumericBNodes
testObject() - Method in class com.bigdata.rdf.sail.TestSparqlStar
Test SPARQL* syntax for object.
testOffer() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Offer succeeds if not full; fails if full
testOffer() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Offer succeeds if not full; fails if full
testOfferFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
OfferFirst succeeds
testOfferFirstNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
offer(null) throws NPE
testOfferInExecutor() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
offer transfers elements across Executor tasks
testOfferInExecutor() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
offer transfers elements across Executor tasks
testOfferLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
OfferLast succeeds
testOfferNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
offer(null) throws NPE
testOfferNull() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
offer(null) throws NPE
testOldURI() - Method in class org.openrdf.sail.RDFStoreTest
testOOM() - Method in class com.bigdata.rdf.sail.contrib.TestOOMBug
TestOOMBug - Class in com.bigdata.rdf.sail.contrib
Unit test template for use in submission of bugs.
TestOOMBug() - Constructor for class com.bigdata.rdf.sail.contrib.TestOOMBug
TestOOMBug(String) - Constructor for class com.bigdata.rdf.sail.contrib.TestOOMBug
testOpen() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestOpenrdfNativeServiceEvaluation - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for SPARQL 1.1 Federated Query against an openrdf
aware SERVICE implementation running in the same JVM.
TestOpenrdfNativeServiceEvaluation() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestOpenrdfNativeServiceEvaluation
TestOpenrdfNativeServiceEvaluation(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestOpenrdfNativeServiceEvaluation
testOpenWorldEq() - Method in class com.bigdata.bop.rdf.TestBOpUtility
testOptional() - Method in class com.bigdata.rdf.sail.TestOptionals
testOptional01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test OPTIONAL inter-partition reordering.
testOptional02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Test OPTIONAL inter-partition reordering.
testOptionalFilter() - Method in class com.bigdata.rdf.sail.TestSingleTailRule
testOptionalFilter() - Method in class org.openrdf.repository.RepositoryConnectionTest
testOptionalJoinGroup() - Method in class com.bigdata.rdf.sparql.ast.TestAST
select *
where {
predicate1 .
TestOptionals - Class in com.bigdata.rdf.rules
TestOptionals() - Constructor for class com.bigdata.rdf.rules.TestOptionals
TestOptionals(String) - Constructor for class com.bigdata.rdf.rules.TestOptionals
TestOptionals - Class in com.bigdata.rdf.sail
Unit tests the optionals aspects of the
BigdataSail
implementation.
TestOptionals() - Constructor for class com.bigdata.rdf.sail.TestOptionals
TestOptionals(String) - Constructor for class com.bigdata.rdf.sail.TestOptionals
TestOptionals - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for OPTIONAL groups.
TestOptionals() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestOptionals
TestOptionals(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestOptionals
TestOR - Class in com.bigdata.bop.constraint
TestOR() - Constructor for class com.bigdata.bop.constraint.TestOR
TestOR(String) - Constructor for class com.bigdata.bop.constraint.TestOR
testOr() - Method in class com.bigdata.rdf.sparql.ast.eval.TestInlineConstraints
testOrAndSwitchRecursive() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test recursive optimization of OR - AND - OR - AND pattern.
testOrAndSwitchWithNegation() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test switch of OR over AND expression with top-level negation expression.
TestOrderBy - Class in com.bigdata.rdf.rules
TestOrderBy() - Constructor for class com.bigdata.rdf.rules.TestOrderBy
TestOrderBy(String) - Constructor for class com.bigdata.rdf.rules.TestOrderBy
TestOrderBy - Class in com.bigdata.rdf.sail
TestOrderBy() - Constructor for class com.bigdata.rdf.sail.TestOrderBy
TestOrderBy(String) - Constructor for class com.bigdata.rdf.sail.TestOrderBy
testOrderBy() - Method in class com.bigdata.rdf.sail.TestOrderBy
testOrderByQueriesAreInterruptable() - Method in class com.bigdata.rdf.sail.tck.BigdataConnectionTest
testOrderByQueriesAreInterruptable() - Method in class org.openrdf.repository.RepositoryConnectionTest
testOrEquals() - Method in class com.bigdata.rdf.sail.TestBOps
testOrExists() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTExistsAndJoinOrderByTypeOptimizers
testOrOrAndSwitch() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test recursive optimization of OR - OR - AND pattern.
testOrPredicate() - Method in class org.openrdf.repository.RepositoryConnectionTest
testOrWithPropertyPath() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTExistsAndJoinOrderByTypeOptimizers
TestOverflow - Class in com.bigdata.resources
Basic tests for ResourceManager#overflow(boolean, boolean)
TestOverflow() - Constructor for class com.bigdata.resources.TestOverflow
TestOverflow(String) - Constructor for class com.bigdata.resources.TestOverflow
TestOverflow - Class in com.bigdata.service
Simple test verifies that a scale-out index is preserved across both
synchronous and asynchronous overflow events.
TestOverflow() - Constructor for class com.bigdata.service.TestOverflow
TestOverflow(String) - Constructor for class com.bigdata.service.TestOverflow
TestOverflowGRS - Class in com.bigdata.service
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).
TestOverflowGRS() - Constructor for class com.bigdata.service.TestOverflowGRS
TestOverflowGRS(String) - Constructor for class com.bigdata.service.TestOverflowGRS
TestOwlGOM - Class in com.bigdata.gom
This tests a skin to help process an OWL specification.
TestOwlGOM() - Constructor for class com.bigdata.gom.TestOwlGOM
testOwlLoad1() - Method in class com.bigdata.gom.TestOwlGOM
testOwlLoad2() - Method in class com.bigdata.gom.TestOwlGOM
TestOwlSameAsPropertiesExpandingIterator - Class in com.bigdata.rdf.rules
TestOwlSameAsPropertiesExpandingIterator() - Constructor for class com.bigdata.rdf.rules.TestOwlSameAsPropertiesExpandingIterator
TestOwlSameAsPropertiesExpandingIterator(String) - Constructor for class com.bigdata.rdf.rules.TestOwlSameAsPropertiesExpandingIterator
TestOWLSkin - Class in com.bigdata.gom
TestOWLSkin() - Constructor for class com.bigdata.gom.TestOWLSkin
testOWLwithProperties() - Method in class com.bigdata.gom.TestOWLSkin
testPack() - Method in class com.bigdata.io.LongPackerTestCase
testPack() - Method in class com.bigdata.io.ShortPackerTestCase
testPack() - Method in class com.bigdata.io.TestLongPacker
testPack() - Method in class com.bigdata.io.TestShortPacker
testPackedLongIVOutOfRange() - Method in class com.bigdata.rdf.internal.TestEncodeDecodePackedLongIVs
TestPackedLongIVs - Class in com.bigdata.rdf.internal
TestPackedLongIVs() - Constructor for class com.bigdata.rdf.internal.TestPackedLongIVs
TestPackedLongIVs(String) - Constructor for class com.bigdata.rdf.internal.TestPackedLongIVs
TestPageServer - Class in com.bigdata.nio
Test class uses non-blocking I/O to communicate between collection of clients
and a single page server backed by test data.
TestPageServer() - Constructor for class com.bigdata.nio.TestPageServer
TestParse_iostat - Class in com.bigdata.counters.osx
OSX does have an iostat
.
TestParse_iostat() - Constructor for class com.bigdata.counters.osx.TestParse_iostat
TestParse_iostat(String) - Constructor for class com.bigdata.counters.osx.TestParse_iostat
TestParse_vm_stat - Class in com.bigdata.counters.osx
Test suite for parsing the output of the vm_stat
utility under
OSX.
TestParse_vm_stat() - Constructor for class com.bigdata.counters.osx.TestParse_vm_stat
TestParse_vm_stat(String) - Constructor for class com.bigdata.counters.osx.TestParse_vm_stat
TestParsing - Class in com.bigdata.counters.linux
TestParsing() - Constructor for class com.bigdata.counters.linux.TestParsing
TestParsing(String) - Constructor for class com.bigdata.counters.linux.TestParsing
testPartiallyRedundantEvents() - Method in class com.bigdata.rdf.sail.TestRDRHistory
Test whether the RDRHistory can handle statements that are added
and removed in the same commit.
TestPartitionedJoinGroup - Class in com.bigdata.bop.joinGraph
TestPartitionedJoinGroup() - Constructor for class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup
TestPartitionedJoinGroup(String) - Constructor for class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup
TestPartitionedJoinGroup_canJoin - Class in com.bigdata.bop.joinGraph
TestPartitionedJoinGroup_canJoin() - Constructor for class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup_canJoin
TestPartitionedJoinGroup_canJoin(String) - Constructor for class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup_canJoin
TestPartitionedJoinGroup_canJoinUsingConstraints - Class in com.bigdata.bop.joinGraph
This test suite is built around around BSBM Q5.
TestPartitionedJoinGroup_canJoinUsingConstraints() - Constructor for class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup_canJoinUsingConstraints
TestPartitionedJoinGroup_canJoinUsingConstraints(String) - Constructor for class com.bigdata.bop.joinGraph.TestPartitionedJoinGroup_canJoinUsingConstraints
TestPaths - Class in com.bigdata.rdf.sail.graph
TestPaths() - Constructor for class com.bigdata.rdf.sail.graph.TestPaths
TestPaths(String) - Constructor for class com.bigdata.rdf.sail.graph.TestPaths
testPeek() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
peek returns next element, or null if empty
testPeek() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
peek returns next element, or null if empty
testPeekFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
peekFirst returns next element, or null if empty
testPeekLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
peekLast returns next element, or null if empty
testPerformanceCompression() - Method in class com.bigdata.io.compression.TestCompressorRegistry
testPipelineChange_largeMessage() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
Variant test with a message size that we expect to be larger than will be
received by the OS before it hands control back to our code through the
Selector
.
testPipelineChange_smallMessage() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
Unit test verifies that we can reconfigure the downstream target in an
HA3 setting.
TestPipelinedAggregationOp - Class in com.bigdata.bop.solutions
TestPipelinedAggregationOp() - Constructor for class com.bigdata.bop.solutions.TestPipelinedAggregationOp
TestPipelinedAggregationOp(String) - Constructor for class com.bigdata.bop.solutions.TestPipelinedAggregationOp
testPipelinedHashDisabledByQueryHintALP() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of ALP and enablement by query hint.
testPipelinedHashDisabledByQueryHintExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of EXISTS and enablement by query hint.
testPipelinedHashDisabledByQueryHintMinus() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of MINUS and enablement by query hint.
testPipelinedHashDisabledByQueryHintNotExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of NOT EXISTS and enablement by query hint.
testPipelinedHashDisabledByQueryHintOptional() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of OPTIONAL and enablement by query hint.
testPipelinedHashDisabledByQueryHintOptionalAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of OPTIONAL and enablement by query hint and analytic mode.
testPipelinedHashDisabledByQueryHintSubquery() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of subquery and enablement by query hint.
testPipelinedHashDisabledByQueryHintValues() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of VALUES and enablement by query hint.
testPipelinedHashDistinctProjectionBufferThreshold() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Test query affected by
PipelinedHashIndexAndSolutionSetOp.DISTINCT_PROJECTION_BUFFER_THRESHOLD
testPipelinedHashDistinctProjectionBufferThresholdAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Test query affected by
PipelinedHashIndexAndSolutionSetOp.DISTINCT_PROJECTION_BUFFER_THRESHOLD
testPipelinedHashEnabledByQueryHintALP() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of ALP and enablement by query hint.
testPipelinedHashEnabledByQueryHintExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of EXISTS and enablement by query hint.
testPipelinedHashEnabledByQueryHintMinus() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of MINUS and enablement by query hint.
testPipelinedHashEnabledByQueryHintNotExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of NOT EXISTS and enablement by query hint.
testPipelinedHashEnabledByQueryHintOptional() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of OPTIONAL and enablement by query hint.
testPipelinedHashEnabledByQueryHintOptionalAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of OPTIONAL and enablement by query hint and analytic mode.
testPipelinedHashEnabledByQueryHintSubquery() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of subquery and enablement by query hint.
testPipelinedHashEnabledByQueryHintValues() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Combination of VALUES and enablement by query hint.
testPipelinedHashIncomingBindingsBufferThreshold() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Test query affected by
PipelinedHashIndexAndSolutionSetOp.INCOMING_BINDINGS_BUFFER_THRESHOLD.
testPipelinedHashIncomingBindingsBufferThresholdAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Test query affected by
PipelinedHashIndexAndSolutionSetOp.INCOMING_BINDINGS_BUFFER_THRESHOLD.
TestPipelinedHashJoin - Class in com.bigdata.rdf.sparql.ast.eval
TestPipelinedHashJoin() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
TestPipelinedHashJoin(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
testPipelinedHashJoinDefaultUsedForALP01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do not use pipelined hash join for ALP "*" node if no LIMIT in query.
testPipelinedHashJoinDefaultUsedForALP02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do not use pipelined hash join for ALP "+" node if no LIMIT in query.
testPipelinedHashJoinDefaultUsedForExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do *not* use pipelined hash join for EXISTS clause if no LIMIT in query.
testPipelinedHashJoinDefaultUsedForMinus() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for MINUS is not specified when no LIMIT is
present in the query.
testPipelinedHashJoinDefaultUsedForNotExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do *not* use pipelined hash join for NOT EXISTS clause if no LIMIT in query.
testPipelinedHashJoinDefaultUsedForSubquery() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do *not* use pipelined hash join for SPARQL 1.1 subquery if no LIMIT in query.
testPipelinedHashJoinDefaultUsedForValues() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do *not* use pipelined hash join for VALUES clause if no LIMIT in query.
testPipelinedHashJoinDefaultUsedOptional01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Make sure the pipelined hash join operator is not used as a standard for
non-LIMIT query.
testPipelinedHashJoinDefaultUsedOptional01Analytic() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Make sure the pipelined hash join operator is not used as a standard for
non-LIMIT query.
testPipelinedHashJoinDefaultUsedOptionald02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Make sure the pipelined hash join operator is not used as a standard for
LIMIT+OFFSET queries.
testPipelinedHashJoinDisabledMinusBug01aAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, just making sure that the non-pipelined version
for the test case (i.e., query without LIMIT) is working as expected in analytic mode.
testPipelinedHashJoinDisabledMinusBug01aNonAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, just making sure that the non-pipelined version
for the test case (i.e., query without LIMIT) is working as expected in non-analytic mode.
testPipelinedHashJoinDisabledMinusBug01bAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, just making sure that the non-pipelined version
for the test case (i.e., query without LIMIT) is working as expected in analytic mode.
testPipelinedHashJoinDisabledMinusBug01bNonAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, just making sure that the non-pipelined version
for the test case (i.e., query without LIMIT) is working as expected in non-analytic mode.
testPipelinedHashJoinDisabledMinusBug02AnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, just making sure that the non-pipelined version
for the test case (i.e., query without LIMIT) is working as expected in analytic mode.
testPipelinedHashJoinDisabledMinusBug02NonAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, just making sure that the non-pipelined version
for the test case (i.e., query without LIMIT) is working as expected in non-analytic mode.
testPipelinedHashJoinExistsMultiplicity() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Check correct multiplicity for EXISTS.
testPipelinedHashJoinExistsMultiplicityAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Check correct multiplicity for EXISTS in analytic mode.
testPipelinedHashJoinMinusBug01aAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, test case for analytic mode.
testPipelinedHashJoinMinusBug01aNonAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, test case for non-analytic mode.
testPipelinedHashJoinMinusBug01bAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, test case for analytic mode.
testPipelinedHashJoinMinusBug01bNonAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, test case for non-analytic mode.
testPipelinedHashJoinMinusBug02AnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, test case for analytic mode.
testPipelinedHashJoinMinusBug02NonAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Bug reporting MINUS pipelined hash join being broken, test case for non-analytic mode.
testPipelinedHashJoinNotExistsMultiplicity() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Check correct multiplicity for NOT EXISTS.
testPipelinedHashJoinNotExistsMultiplicityAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Check correct multiplicity for NOT EXISTS in analytic mode.
testPipelinedHashJoinUsedForALP01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for ALP "*" node.
testPipelinedHashJoinUsedForALP01AnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for ALP "*" node and analytic mode.
testPipelinedHashJoinUsedForALP02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for ALP "+" node.
testPipelinedHashJoinUsedForALP02AnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for ALP "+" node and analytic mode.
testPipelinedHashJoinUsedForExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do use pipelined hash join for EXISTS clause if LIMIT in query.
testPipelinedHashJoinUsedForExistsAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do use pipelined hash join for EXISTS clause if LIMIT in query
and analytic mode.
testPipelinedHashJoinUsedForMinus() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for MINUS when LIMIT specified.
testPipelinedHashJoinUsedForMinusAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for MINUS when LIMIT specified and analytic mode.
testPipelinedHashJoinUsedForNotExists() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do use pipelined hash join for NOT EXISTS clause if LIMIT in query.
testPipelinedHashJoinUsedForNotExistsAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Do use pipelined hash join for NOT EXISTS clause if LIMIT in query
and analytic mode.
testPipelinedHashJoinUsedForOptional() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for OPTIONAL when LIMIT specified.
testPipelinedHashJoinUsedForOptionalAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for OPTIONAL when LIMIT specified
and analytic mode.
testPipelinedHashJoinUsedForSubquery() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for SPARQL 1.1 subquery.
testPipelinedHashJoinUsedForSubqueryAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for SPARQL 1.1 subquery and analytic mode.
testPipelinedHashJoinUsedForValues() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for inlined VALUES node.
testPipelinedHashJoinUsedForValuesAnalyticMode() - Method in class com.bigdata.rdf.sparql.ast.eval.TestPipelinedHashJoin
Use pipelined hash join for inlined VALUES node and analytic mode.
TestPipelineJoin - Class in com.bigdata.bop.join
TestPipelineJoin() - Constructor for class com.bigdata.bop.join.TestPipelineJoin
TestPipelineJoin(String) - Constructor for class com.bigdata.bop.join.TestPipelineJoin
testPlacementInContextOfNamedSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testPlacementInContextOfOptional() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testPlacementInContextOfSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testPlacementInContextOfUnions() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testPoll() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
poll succeeds unless empty
testPoll() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
poll succeeds unless empty
testPollFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
pollFirst succeeds unless empty
testPollInExecutor() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
poll retrieves elements across Executor threads
testPollInExecutor() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
poll retrieves elements across Executor threads
testPollLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
pollLast succeeds unless empty
testPop() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
pop removes next element, or throws NSEE if empty
TestPostNotURLEncoded - Class in com.bigdata.rdf.sail.webapp
See trac 711 for discussion.
TestPostNotURLEncoded(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestPostNotURLEncoded
TestPredicate - Class in com.bigdata.bop.ap
TestPredicate() - Constructor for class com.bigdata.bop.ap.TestPredicate
TestPredicate(String) - Constructor for class com.bigdata.bop.ap.TestPredicate
TestPredicateAccessPath - Class in com.bigdata.bop.ap
Unit test for reading on an access path using a
Predicate
.
TestPredicateAccessPath() - Constructor for class com.bigdata.bop.ap.TestPredicateAccessPath
TestPredicateAccessPath(String) - Constructor for class com.bigdata.bop.ap.TestPredicateAccessPath
TestPredicateAccessPath.MockPipelineOp - Class in com.bigdata.bop.ap
TestPredicateAccessPath.MockPipelineOp(BOp[], NV...) - Constructor for class com.bigdata.bop.ap.TestPredicateAccessPath.MockPipelineOp
TestPrefixDeclProcessor - Class in com.bigdata.rdf.sail.sparql
TestPrefixDeclProcessor() - Constructor for class com.bigdata.rdf.sail.sparql.TestPrefixDeclProcessor
testPrefixedInteger() - Method in class com.bigdata.rdf.store.TestInlineURIs
testPrefixedIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testPrefixedSuffixedHexUUIDURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testPrefixedSuffixedUUIDURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testPrefixedSuffixFixedWidthIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testPrefixedSuffixIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
TestPrefixFilter - Class in com.bigdata.btree.filter
TestPrefixFilter() - Constructor for class com.bigdata.btree.filter.TestPrefixFilter
TestPrefixFilter(String) - Constructor for class com.bigdata.btree.filter.TestPrefixFilter
testPrefixFixedWidthIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
TestPrefixSearch - Class in com.bigdata.search
Unit test for prefix and exact match searches.
TestPrefixSearch() - Constructor for class com.bigdata.search.TestPrefixSearch
TestPrefixSearch(String) - Constructor for class com.bigdata.search.TestPrefixSearch
testPreparedBooleanQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
testPreparedGraphQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
testPreparedTupleQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
testPreparedTupleQuery2() - Method in class org.openrdf.repository.RepositoryConnectionTest
testPrepareSPARQLQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestProgram - Class in com.bigdata.relation.rule
Test suite for
Program
and common rule/program re-writes.
TestProgram() - Constructor for class com.bigdata.relation.rule.TestProgram
TestProgram(String) - Constructor for class com.bigdata.relation.rule.TestProgram
testPropertyPathInTree() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
TestPropertyPaths - Class in com.bigdata.rdf.sparql.ast.eval
TestPropertyPaths() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestPropertyPaths
TestPropertyPaths(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestPropertyPaths
TestProtocolAll - Class in com.bigdata.rdf.sail.webapp
A collection of proxied tests for the SPARQL 1.1 protocol.
TestProtocolAll() - Constructor for class com.bigdata.rdf.sail.webapp.TestProtocolAll
TestProvenanceQuery - Class in com.bigdata.rdf.sail
Test suite for high-level query against a graph containing statements about
statements.
TestProvenanceQuery() - Constructor for class com.bigdata.rdf.sail.TestProvenanceQuery
TestProvenanceQuery(String) - Constructor for class com.bigdata.rdf.sail.TestProvenanceQuery
TestPruneBindingSets - Class in com.bigdata.rdf.sail
TestPruneBindingSets() - Constructor for class com.bigdata.rdf.sail.TestPruneBindingSets
TestPruneBindingSets(String) - Constructor for class com.bigdata.rdf.sail.TestPruneBindingSets
testPruneBindingSets() - Method in class com.bigdata.rdf.sail.TestPruneBindingSets
Tests adding query hints in SPARQL.
testPush() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
push succeeds if not full; throws ISE if full
TestPushbackIterator - Class in com.bigdata.striterator
TestPushbackIterator() - Constructor for class com.bigdata.striterator.TestPushbackIterator
TestPushbackIterator(String) - Constructor for class com.bigdata.striterator.TestPushbackIterator
testPushNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
push(null) throws NPE
testPushWithPeek() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
peekFirst returns element inserted with push
testPut() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
all elements successfully put are contained
testPut() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
all elements successfully put are contained
testPutBindBeforeService() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTMassagedServiceNodeOptimizer
testPutFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
all elements successfully putFirst are contained
testPutFirstNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
putFirst(null) throws NPE
testPutFirstWithTake() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
putFirst blocks waiting for take when full
TestPutIfAbsent - Class in com.bigdata.btree
Test of basic btree operations when delete markers are maintained.
TestPutIfAbsent() - Constructor for class com.bigdata.btree.TestPutIfAbsent
TestPutIfAbsent(String) - Constructor for class com.bigdata.btree.TestPutIfAbsent
testPutLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
all elements successfully putLast are contained
testPutLastNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
putLast(null) throws NPE
testPutLastWithTake() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
putLast blocks waiting for take when full
testPutNull() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
put(null) throws NPE
testPutNull() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
put(null) throws NPE
testPutWithTake() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
put blocks waiting for take when full
testPutWithTake() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
put blocks waiting for take when full
TestQuadsAPI - Class in com.bigdata.rdf.sail
Unit tests the quads aspects of the
BigdataSail
implementation.
TestQuadsAPI() - Constructor for class com.bigdata.rdf.sail.TestQuadsAPI
TestQuadsAPI(String) - Constructor for class com.bigdata.rdf.sail.TestQuadsAPI
testQuadsInSPARQLDeleteDataBlock() - Method in class com.bigdata.rdf.sail.TestTicket1518
Quads in SPARQL update data block (DELETE clause).
testQuadsInSPARQLInsertBlock() - Method in class com.bigdata.rdf.sail.TestTicket1518
Quads in SPARQL update data block (INSERT clause).
testQuadStripping() - Method in class com.bigdata.rdf.sail.TestTicket1086
When loading quads into a triple store, the context is striped away by
default.
testQuadStrippingRejected() - Method in class com.bigdata.rdf.sail.TestTicket1086
When loading quads into a triple store and the BigdataSail option
REJECT_QUADS_IN_TRIPLE_MODE is set to true, an exception will be thrown.
testQueryBaseURI() - Method in class org.openrdf.repository.RepositoryConnectionTest
testQueryBindings() - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
Modified to test SPARQL instead of Serql.
testQueryBindings() - Method in class org.openrdf.sail.RDFStoreTest
TestQueryDeadlineOrder - Class in com.bigdata.bop.engine
Test suite for QueryDeadline
ordering.
TestQueryDeadlineOrder() - Constructor for class com.bigdata.bop.engine.TestQueryDeadlineOrder
TestQueryDeadlineOrder(String) - Constructor for class com.bigdata.bop.engine.TestQueryDeadlineOrder
testQueryDeadlineOrder01() - Method in class com.bigdata.bop.engine.TestQueryDeadlineOrder
Verify the semantics of QueryDeadline.compareTo(QueryDeadline)
.
testQueryDefaultGraph() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestQueryEngine - Class in com.bigdata.bop.engine
Test suite for the
QueryEngine
against a local database instance.
TestQueryEngine() - Constructor for class com.bigdata.bop.engine.TestQueryEngine
TestQueryEngine(String) - Constructor for class com.bigdata.bop.engine.TestQueryEngine
TestQueryEngine_DistinctOp - Class in com.bigdata.bop.engine
Test suite for DISTINCT solution operators when integrated with the query
engine.
TestQueryEngine_DistinctOp() - Constructor for class com.bigdata.bop.engine.TestQueryEngine_DistinctOp
TestQueryEngine_DistinctOp(String) - Constructor for class com.bigdata.bop.engine.TestQueryEngine_DistinctOp
TestQueryEngine_GroupByOp - Class in com.bigdata.bop.engine
Test suite for GROUP_BY operators when integrated with the query engine.
TestQueryEngine_GroupByOp() - Constructor for class com.bigdata.bop.engine.TestQueryEngine_GroupByOp
TestQueryEngine_GroupByOp(String) - Constructor for class com.bigdata.bop.engine.TestQueryEngine_GroupByOp
TestQueryEngine_Slice - Class in com.bigdata.bop.engine
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.
TestQueryEngine_Slice() - Constructor for class com.bigdata.bop.engine.TestQueryEngine_Slice
TestQueryEngine_Slice(String) - Constructor for class com.bigdata.bop.engine.TestQueryEngine_Slice
TestQueryEngine_SortOp - Class in com.bigdata.bop.engine
Test suite ORDER BY operators when integrated with the query engine.
TestQueryEngine_SortOp() - Constructor for class com.bigdata.bop.engine.TestQueryEngine_SortOp
TestQueryEngine_SortOp(String) - Constructor for class com.bigdata.bop.engine.TestQueryEngine_SortOp
TestQueryEngineFactory - Class in com.bigdata.bop.fed
Stress test for correct shutdown of query controllers as allocated by the
QueryEngineFactory
.
TestQueryEngineFactory() - Constructor for class com.bigdata.bop.fed.TestQueryEngineFactory
TestQueryEngineFactory(String) - Constructor for class com.bigdata.bop.fed.TestQueryEngineFactory
TestQueryHints - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for SPARQL queries with embedded query hints.
TestQueryHints() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
TestQueryHints(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestQueryHints
testQuorumTransitions() - Method in class com.bigdata.quorum.TestSingletonQuorumSemantics
Check all valid quorum transitions with:
currentToken,
nextToken,
isJoined state
haReady token.
TestRandomAccessFileSynchronousWrites - Class in com.bigdata.journal
Test suite for conformance with synchronous IO write requests made on a
RandomAccessFile
opened using
rss
or
rdd
mode.
TestRandomAccessFileSynchronousWrites() - Constructor for class com.bigdata.journal.TestRandomAccessFileSynchronousWrites
TestRandomAccessFileSynchronousWrites(String) - Constructor for class com.bigdata.journal.TestRandomAccessFileSynchronousWrites
TestRandomBlockOps - Class in com.bigdata.bfs
Unit tests for random block IO include read, write, overwrite (aka update),
and delete.
TestRandomBlockOps() - Constructor for class com.bigdata.bfs.TestRandomBlockOps
TestRandomBlockOps(String) - Constructor for class com.bigdata.bfs.TestRandomBlockOps
TestRandomBlockOps.StressTest - Class in com.bigdata.bfs
Stress test helper class.
TestRandomBlockOps.StressTest(BigdataFileSystem, int, TestRandomBlockOps.Op) - Constructor for class com.bigdata.bfs.TestRandomBlockOps.StressTest
TestRandomBlockOps.TestOp - Class in com.bigdata.bfs
Tests of the Op
test helper class.
TestRandomBlockOps.TestOp() - Constructor for class com.bigdata.bfs.TestRandomBlockOps.TestOp
TestRangeDelete - Class in com.bigdata.bfs
TestRangeDelete() - Constructor for class com.bigdata.bfs.TestRangeDelete
TestRangeDelete(String) - Constructor for class com.bigdata.bfs.TestRangeDelete
TestRangeQuery - Class in com.bigdata.service
TestRangeQuery() - Constructor for class com.bigdata.service.TestRangeQuery
TestRangeQuery(String) - Constructor for class com.bigdata.service.TestRangeQuery
TestRangeScan - Class in com.bigdata.bfs
TestRangeScan() - Constructor for class com.bigdata.bfs.TestRangeScan
TestRangeScan(String) - Constructor for class com.bigdata.bfs.TestRangeScan
TestRawRecords - Class in com.bigdata.btree
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).
TestRawRecords() - Constructor for class com.bigdata.btree.TestRawRecords
TestRawRecords(String) - Constructor for class com.bigdata.btree.TestRawRecords
TestRawRecords - Class in com.bigdata.htree
Unit tests for a
HTree
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).
TestRawRecords() - Constructor for class com.bigdata.htree.TestRawRecords
TestRawRecords(String) - Constructor for class com.bigdata.htree.TestRawRecords
testRawRecordWriteRate() - Method in class com.bigdata.journal.BenchmarkJournalWriteRate
TestRDRHistory - Class in com.bigdata.rdf.sail
TestRDRHistory() - Constructor for class com.bigdata.rdf.sail.TestRDRHistory
TestRDRHistory(String) - Constructor for class com.bigdata.rdf.sail.TestRDRHistory
TestRDRHistory.CustomRDRHistory - Class in com.bigdata.rdf.sail
TestRDRHistory.CustomRDRHistory(AbstractTripleStore) - Constructor for class com.bigdata.rdf.sail.TestRDRHistory.CustomRDRHistory
TestRDROperations<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Test of RDR specific data interchange and query.
TestRDROperations() - Constructor for class com.bigdata.rdf.sail.webapp.TestRDROperations
TestRDROperations(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestRDROperations
TestReadCommittedTx<S extends Journal> - Class in com.bigdata.journal
Test suite for transactions reading from a start time corresponding to the
last commit time on the database.
TestReadCommittedTx() - Constructor for class com.bigdata.journal.TestReadCommittedTx
TestReadCommittedTx(String) - Constructor for class com.bigdata.journal.TestReadCommittedTx
testReadOfAddedStatement1() - Method in class org.openrdf.repository.RepositoryConnectionTest
testReadOfAddedStatement2() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestReadOnlyBTreeCursors - Class in com.bigdata.btree
TestReadOnlyBTreeCursors() - Constructor for class com.bigdata.btree.TestReadOnlyBTreeCursors
TestReadOnlyBTreeCursors(String) - Constructor for class com.bigdata.btree.TestReadOnlyBTreeCursors
TestReadOnlyTx<S extends Journal> - Class in com.bigdata.journal
Test suite for fully isolated read-only transactions reading from a caller
specified start time.
TestReadOnlyTx() - Constructor for class com.bigdata.journal.TestReadOnlyTx
TestReadOnlyTx(String) - Constructor for class com.bigdata.journal.TestReadOnlyTx
TestReadWriteTransactions - Class in com.bigdata.rdf.sail
TestReadWriteTransactions() - Constructor for class com.bigdata.rdf.sail.TestReadWriteTransactions
TestReadWriteTransactions(String) - Constructor for class com.bigdata.rdf.sail.TestReadWriteTransactions
testReallyLongLiteralRoundTrip() - Method in class org.openrdf.sail.RDFStoreTest
testReallyLongQueryString() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testRealWordCircle01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Real world test against geo coordinates of few cities.
testRealWordCircle02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Real world test against geo coordinates of few cities.
testRealWordCircleWithDistance01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Real world test against geo coordinates of few cities,
including distance calculation.
testRealWordCircleWithDistance02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Real world test against geo coordinates of few cities,
including distance calculation and ORDER BY over distances.
testRealWordRectangle01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Real world test against geo coordinates of few cities.
TestRebuildTextIndex<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite for rebuilding full text index.
TestRebuildTextIndex() - Constructor for class com.bigdata.rdf.sail.webapp.TestRebuildTextIndex
TestRebuildTextIndex(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestRebuildTextIndex
TestReceiveBuffer - Class in com.bigdata.service
TestReceiveBuffer() - Constructor for class com.bigdata.service.TestReceiveBuffer
TestReceiveBuffer(String) - Constructor for class com.bigdata.service.TestReceiveBuffer
TestReceiveFile - Class in com.bigdata.service
TestReceiveFile() - Constructor for class com.bigdata.service.TestReceiveFile
TestReceiveFile(String) - Constructor for class com.bigdata.service.TestReceiveFile
TestRecordCompressor_BestCompression - Class in com.bigdata.io.compression
TestRecordCompressor_BestCompression() - Constructor for class com.bigdata.io.compression.TestRecordCompressor_BestCompression
TestRecordCompressor_BestCompression(String) - Constructor for class com.bigdata.io.compression.TestRecordCompressor_BestCompression
TestRecordCompressor_BestSpeed - Class in com.bigdata.io.compression
TestRecordCompressor_BestSpeed() - Constructor for class com.bigdata.io.compression.TestRecordCompressor_BestSpeed
TestRecordCompressor_BestSpeed(String) - Constructor for class com.bigdata.io.compression.TestRecordCompressor_BestSpeed
testRecoverFromParseError() - Method in class org.openrdf.repository.RepositoryConnectionTest
testRectangleOutOfBounds01a() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Assert failing in case of invalid rectangle coordinates (in upper left).
testRectangleOutOfBounds01b() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Assert failing in case of invalid rectangle coordinates (in lower right).
testRectangleQueryParallel01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Verify rectangle search with simple:
PREFIX geo:
SELECT ?res WHERE {
SERVICE geo:search {
?res geo:search "inRectangle" .
testRectangleQueryParallel02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Variant of testRectangleQueryParallel01.
testRectangleQueryParallel03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Variant of testRectangleQueryParallel01.
testRectangleQueryParallel04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Variant of testRectangleQueryParallel01.
testRectangleQueryParallel05() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
Variant of testRectangleQueryParallel01.
testRectangleRealworld() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
BLZG-1719: test rectangle for real-world example
testRecursion() - Method in class com.bigdata.rdf.sail.TestSparqlStar
Test recursive SPARQL* syntax.
testRecycle() - Method in class com.bigdata.htree.TestHTreeRecycle
testRegex() - Method in class com.bigdata.rdf.sail.TestLexJoinOps
testRegex() - Method in class com.bigdata.rdf.sail.TestMaterialization
testRegex() - Method in class com.bigdata.rdf.sail.TestSesameFilters
testRegex() - Method in class com.bigdata.rdf.sail.TestStrBOp
TestRegexBOp - Class in com.bigdata.rdf.internal.constraints
TestRegexBOp() - Constructor for class com.bigdata.rdf.internal.constraints.TestRegexBOp
TestRegexBOp(String) - Constructor for class com.bigdata.rdf.internal.constraints.TestRegexBOp
TestReificationDoneRightEval - Class in com.bigdata.rdf.sparql.ast.eval.reif
Reification Done Right test suite.
TestReificationDoneRightEval() - Constructor for class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
TestReificationDoneRightEval(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.reif.TestReificationDoneRightEval
TestReificationDoneRightParser - Class in com.bigdata.rdf.sail.sparql
Test suite for the proposed standardization of "reification done right".
TestReificationDoneRightParser() - Constructor for class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
TestReificationDoneRightParser(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestReificationDoneRightParser
testReject_wildcard_type_only() - Method in class com.bigdata.util.httpd.TestMIMEType
testRejectConfigWithNoFields() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testRejectEmptyEndpoint() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Make sure an exception is thrown in case the endpoint is empty
testRejectEmptySearchString() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Make sure an exception is thrown in case the query string is empty.
testRejectInvalidUri() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testRejectMappingConflict() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testRejectMissingDatatypeConfiguration() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testRejectMissingServiceMappingConfiguration() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testRejectNoEndpoint() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Make sure an exception is thrown in case the endpoint is empty
testRejectNoSearchString() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Make sure an exception is thrown in case the query string is empty.
testRejectSyntacticallyInvalidConfig() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
testRejectUriConflict() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationParsing
TestRelationLocator - Class in com.bigdata.rdf.store
TestRelationLocator() - Constructor for class com.bigdata.rdf.store.TestRelationLocator
TestRelationLocator(String) - Constructor for class com.bigdata.rdf.store.TestRelationLocator
TestRelease123Protocol - Class in com.bigdata.rdf.sail.webapp
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
TestRelease123Protocol(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
TestReleaseResources - Class in com.bigdata.resources
Test release (aka purge) of old resources.
TestReleaseResources() - Constructor for class com.bigdata.resources.TestReleaseResources
TestReleaseResources(String) - Constructor for class com.bigdata.resources.TestReleaseResources
TestReleaseResources.TestWithCopy_NonZeroMinReleaseAge - Class in com.bigdata.resources
Test where the indices are copied during synchronous overflow processing
and where a non-zero [minReleaseAge] was specified.
TestReleaseResources.TestWithCopy_NonZeroMinReleaseAge() - Constructor for class com.bigdata.resources.TestReleaseResources.TestWithCopy_NonZeroMinReleaseAge
TestReleaseResources.TestWithCopy_NonZeroMinReleaseAge(String) - Constructor for class com.bigdata.resources.TestReleaseResources.TestWithCopy_NonZeroMinReleaseAge
TestReleaseResources.TestWithCopyImmediateRelease - Class in com.bigdata.resources
Test where the index view is copied in its entirety onto the new journal
and the [minReleaseAge] is ZERO(0).
TestReleaseResources.TestWithCopyImmediateRelease() - Constructor for class com.bigdata.resources.TestReleaseResources.TestWithCopyImmediateRelease
TestReleaseResources.TestWithCopyImmediateRelease(String) - Constructor for class com.bigdata.resources.TestReleaseResources.TestWithCopyImmediateRelease
TestReleaseResources.TestWithCopyNoRelease - Class in com.bigdata.resources
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).
TestReleaseResources.TestWithCopyNoRelease() - Constructor for class com.bigdata.resources.TestReleaseResources.TestWithCopyNoRelease
TestReleaseResources.TestWithCopyNoRelease(String) - Constructor for class com.bigdata.resources.TestReleaseResources.TestWithCopyNoRelease
testRemainingCapacity() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
remainingCapacity decreases on add, increases on remove
testRemainingCapacity() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
remainingCapacity decreases on add, increases on remove
TestRemoteAccessPath - Class in com.bigdata.bop.fed
Unit tests of a remote access path.
TestRemoteAccessPath() - Constructor for class com.bigdata.bop.fed.TestRemoteAccessPath
TestRemoteAccessPath(String) - Constructor for class com.bigdata.bop.fed.TestRemoteAccessPath
TestRemoteAccessPath.MockPipelineOp - Class in com.bigdata.bop.fed
TestRemoteAccessPath.MockPipelineOp(BOp[], NV...) - Constructor for class com.bigdata.bop.fed.TestRemoteAccessPath.MockPipelineOp
TestRemoteGOM - Class in com.bigdata.gom
Similar to TestGOM but is setup to connect to the NanoSparqlServer using a
RemoteRepository
TestRemoteGOM() - Constructor for class com.bigdata.gom.TestRemoteGOM
TestRemoteSparql10QueryBuilder - Class in com.bigdata.rdf.sparql.ast.eval.service
TestRemoteSparql10QueryBuilder() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
TestRemoteSparql10QueryBuilder(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql10QueryBuilder
TestRemoteSparql11QueryBuilder - Class in com.bigdata.rdf.sparql.ast.eval.service
Test suite for the
RemoteSparql11QueryBuilder
, including some correct
rejection tests when the solutions to be vectored to the remote end point can
not be represented using the
BINDINGS
clause.
TestRemoteSparql11QueryBuilder() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
TestRemoteSparql11QueryBuilder(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparql11QueryBuilder
TestRemoteSparqlBuilderFactory - Class in com.bigdata.rdf.sparql.ast.eval.service
TestRemoteSparqlBuilderFactory() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
TestRemoteSparqlBuilderFactory(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestRemoteSparqlBuilderFactory
TestRemovals - Class in com.bigdata.htree
TestRemovals() - Constructor for class com.bigdata.htree.TestRemovals
TestRemovals(String) - Constructor for class com.bigdata.htree.TestRemovals
testRemove() - Method in class com.bigdata.gom.TestGPO
testRemove() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
remove removes next element, or throws NSEE if empty
testRemove() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
remove removes next element, or throws NSEE if empty
TestRemoveAll - Class in com.bigdata.btree
TestRemoveAll() - Constructor for class com.bigdata.btree.TestRemoveAll
TestRemoveAll(String) - Constructor for class com.bigdata.btree.TestRemoveAll
testRemoveAll() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
removeAll(c) removes only those elements of c and reports true if changed
testRemoveAll() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
removeAll(c) removes only those elements of c and reports true if changed
testRemoveAndClear() - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
Modified to test SPARQL instead of Serql.
testRemoveAndClear() - Method in class org.openrdf.sail.RDFStoreTest
testRemoveDuplicateFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test removal of duplicate filter.
testRemoveDuplicateGeneratedFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test removal of duplicate filter, where the duplicate is introduced
through the CNF based decomposition process.
testRemoveElement() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
remove(x) removes x and returns true if present
testRemoveElement() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
remove(x) removes x and returns true if present
testRemoveElementAndAdd() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
An add following remove(x) succeeds
testRemoveFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
removeFirst() removes first element, or throws NSEE if empty
testRemoveFirstOccurrence() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
removeFirstOccurrence(x) removes x and returns true if present
testRemoveLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
removeLast() removes last element, or throws NSEE if empty
testRemoveLastOccurrence() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
removeLastOccurrence(x) removes x and returns true if present
testRemoveNamespaces() - Method in class org.openrdf.sail.RDFStoreTest
TestRemoverator - Class in com.bigdata.btree.filter
Test suite for the Removerator
.
TestRemoverator() - Constructor for class com.bigdata.btree.filter.TestRemoverator
TestRemoverator(String) - Constructor for class com.bigdata.btree.filter.TestRemoverator
testRemoveStatementCollection() - Method in class org.openrdf.repository.RepositoryConnectionTest
testRemoveStatementIteration() - Method in class org.openrdf.repository.RepositoryConnectionTest
testRemoveStatements() - Method in class org.openrdf.repository.RepositoryConnectionTest
testRemoveUnsatisfiableFilters() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test removal of unsatisfiable filters.
testRemoveValue() - Method in class com.bigdata.gom.TestGPO
testRemoveValues() - Method in class com.bigdata.gom.TestGPO
TestReopen - Class in com.bigdata.btree
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).
TestReopen() - Constructor for class com.bigdata.btree.TestReopen
TestReopen(String) - Constructor for class com.bigdata.btree.TestReopen
TestReopen - Class in com.bigdata.htree
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).
TestReopen() - Constructor for class com.bigdata.htree.TestReopen
TestReopen(String) - Constructor for class com.bigdata.htree.TestReopen
testReopenerInputStream() - Method in class com.bigdata.io.TestFileChannelUtility
testRepeatedHeaders() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
TestReplaceBOp - Class in com.bigdata.rdf.internal.constraints
TestReplaceBOp() - Constructor for class com.bigdata.rdf.internal.constraints.TestReplaceBOp
TestReplaceBOp(String) - Constructor for class com.bigdata.rdf.internal.constraints.TestReplaceBOp
testRepository - Variable in class org.openrdf.repository.RepositoryConnectionTest
testRequiredValues() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
TODO Write optimizer to pull this BindingsClause out of the join
group and make it global.
testResetHARootBlock() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
TestResolver - Class in com.bigdata.bop.ap.filter
TestResolver() - Constructor for class com.bigdata.bop.ap.filter.TestResolver
TestResolver(String) - Constructor for class com.bigdata.bop.ap.filter.TestResolver
TestResolver - Class in com.bigdata.striterator
TestResolver() - Constructor for class com.bigdata.striterator.TestResolver
TestResolver(String) - Constructor for class com.bigdata.striterator.TestResolver
TestResourceManagerBootstrap - Class in com.bigdata.resources
TestResourceManagerBootstrap() - Constructor for class com.bigdata.resources.TestResourceManagerBootstrap
TestResourceManagerBootstrap(String) - Constructor for class com.bigdata.resources.TestResourceManagerBootstrap
TestResourceManagerBootstrap.MyResourceManager - Class in com.bigdata.resources
TestResourceManagerBootstrap.MyResourceManager(Properties) - Constructor for class com.bigdata.resources.TestResourceManagerBootstrap.MyResourceManager
TestRestartSafe - Class in com.bigdata.journal
TestRestartSafe() - Constructor for class com.bigdata.journal.TestRestartSafe
TestRestartSafe(String) - Constructor for class com.bigdata.journal.TestRestartSafe
TestRestartSafe - Class in com.bigdata.rdf.store
Test restart safety for the various indices.
TestRestartSafe() - Constructor for class com.bigdata.rdf.store.TestRestartSafe
TestRestartSafe(String) - Constructor for class com.bigdata.rdf.store.TestRestartSafe
TestRestartSafe - Class in com.bigdata.service
TestRestartSafe() - Constructor for class com.bigdata.service.TestRestartSafe
TestRestartSafe(String) - Constructor for class com.bigdata.service.TestRestartSafe
TestRestartSafe.MyBTree - Class in com.bigdata.journal
TestRestartSafe.MyBTree(IRawStore, Checkpoint, IndexMetadata, boolean) - Constructor for class com.bigdata.journal.TestRestartSafe.MyBTree
testRetainAll() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
retainAll(c) retains only those elements of c and reports true if changed
testRetainAll() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
retainAll(c) retains only those elements of c and reports true if changed
TestReverserator - Class in com.bigdata.btree.filter
TestReverserator() - Constructor for class com.bigdata.btree.filter.TestReverserator
TestReverserator(String) - Constructor for class com.bigdata.btree.filter.TestReverserator
testReverseScan(IndexSegment) - Static method in class com.bigdata.btree.AbstractIndexSegmentTestCase
Test reverse leaf scan.
testRFC4647() - Method in class com.bigdata.search.TestLanguageRange
testRollback() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestRollbackCommit - Class in com.bigdata.journal
TestRollbackCommit() - Constructor for class com.bigdata.journal.TestRollbackCommit
Deprecated.
TestRollbackCommit(String) - Constructor for class com.bigdata.journal.TestRollbackCommit
Deprecated.
TestRollbacks - Class in com.bigdata.rdf.sail
This is a stress test for abort/rollback semantics.
TestRollbacks() - Constructor for class com.bigdata.rdf.sail.TestRollbacks
TestRollbacks(String) - Constructor for class com.bigdata.rdf.sail.TestRollbacks
TestRollbacksTM - Class in com.bigdata.rdf.sail
Concrete instance of
TestRollbacks
which overrides the properties to
enable truth maintenance support in the SAIL.
TestRollbacksTM() - Constructor for class com.bigdata.rdf.sail.TestRollbacksTM
TestRollbacksTM(String) - Constructor for class com.bigdata.rdf.sail.TestRollbacksTM
TestRollbacksTx - Class in com.bigdata.rdf.sail
Concrete instance of
TestRollbacks
which overrides the properties to
enable full transaction support in the SAIL.
TestRollbacksTx() - Constructor for class com.bigdata.rdf.sail.TestRollbacksTx
TestRollbacksTx(String) - Constructor for class com.bigdata.rdf.sail.TestRollbacksTx
TestRootBlockView - Class in com.bigdata.journal
TestRootBlockView() - Constructor for class com.bigdata.journal.TestRootBlockView
TestRootBlockView(String) - Constructor for class com.bigdata.journal.TestRootBlockView
testRoundTripAndCompareCompressedTimestamp() - Method in class com.bigdata.rdf.internal.TestEncodeDecodePackedLongIVs
testRoundTripAndComparePackedLongIV() - Method in class com.bigdata.rdf.internal.TestEncodeDecodePackedLongIVs
testRoundTripAsByte() - Method in class com.bigdata.rdf.internal.TestEncodeDecodeLiteralArrayIVs
testRoundTripLiteralArrayIV() - Method in class com.bigdata.rdf.internal.TestEncodeDecodeLiteralArrayIVs
TestRTO_BAR - Class in com.bigdata.rdf.sparql.ast.eval.rto
Data driven test suite for the Runtime Query Optimizer (RTO) using BAR data
and queries.
TestRTO_BAR() - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_BAR
TestRTO_BAR(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_BAR
TestRTO_BSBM - Class in com.bigdata.rdf.sparql.ast.eval.rto
Data driven test suite for the Runtime Query Optimizer (RTO) using BSBM data
and queries based on BSBM.
TestRTO_BSBM() - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_BSBM
TestRTO_BSBM(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_BSBM
TestRTO_FOAF - Class in com.bigdata.rdf.sparql.ast.eval.rto
Deprecated.
None of these test queries are complicated enough to trigger the
RTO. The class and its queries should just be dropped.
TestRTO_FOAF() - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_FOAF
Deprecated.
TestRTO_FOAF(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_FOAF
Deprecated.
TestRTO_LUBM - Class in com.bigdata.rdf.sparql.ast.eval.rto
Data driven test suite for the Runtime Query Optimizer (RTO) using LUBM data
and queries based on LUBM.
TestRTO_LUBM() - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_LUBM
TestRTO_LUBM(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.rto.TestRTO_LUBM
TestRule - Class in com.bigdata.relation.rule
Test suite for basic
Rule
mechanisms.
TestRule() - Constructor for class com.bigdata.relation.rule.TestRule
TestRule(String) - Constructor for class com.bigdata.relation.rule.TestRule
TestRuleExpansion - Class in com.bigdata.rdf.rules
TestRuleExpansion() - Constructor for class com.bigdata.rdf.rules.TestRuleExpansion
TestRuleExpansion(String) - Constructor for class com.bigdata.rdf.rules.TestRuleExpansion
TestRuleFastClosure_11_13 - Class in com.bigdata.rdf.rules
TestRuleFastClosure_11_13() - Constructor for class com.bigdata.rdf.rules.TestRuleFastClosure_11_13
TestRuleFastClosure_11_13(String) - Constructor for class com.bigdata.rdf.rules.TestRuleFastClosure_11_13
TestRuleFastClosure_3_5_6_7_9 - Class in com.bigdata.rdf.rules
TestRuleFastClosure_3_5_6_7_9() - Constructor for class com.bigdata.rdf.rules.TestRuleFastClosure_3_5_6_7_9
TestRuleFastClosure_3_5_6_7_9(String) - Constructor for class com.bigdata.rdf.rules.TestRuleFastClosure_3_5_6_7_9
TestRuleOwlEquivalentClass - Class in com.bigdata.rdf.rules
TestRuleOwlEquivalentClass() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlEquivalentClass
TestRuleOwlEquivalentClass(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlEquivalentClass
TestRuleOwlEquivalentProperty - Class in com.bigdata.rdf.rules
TestRuleOwlEquivalentProperty() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlEquivalentProperty
TestRuleOwlEquivalentProperty(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlEquivalentProperty
TestRuleOwlFunctionalProperty - Class in com.bigdata.rdf.rules
Test suite for owl:FunctionalProperty processing.
TestRuleOwlFunctionalProperty() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlFunctionalProperty
TestRuleOwlFunctionalProperty(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlFunctionalProperty
TestRuleOwlHasValue - Class in com.bigdata.rdf.rules
Test suite for owl:hasValue processing.
TestRuleOwlHasValue() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlHasValue
TestRuleOwlHasValue(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlHasValue
TestRuleOwlInverseOf - Class in com.bigdata.rdf.rules
Test suite for owl:inverseOf processing.
TestRuleOwlInverseOf() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlInverseOf
TestRuleOwlInverseOf(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlInverseOf
TestRuleOwlSameAs - Class in com.bigdata.rdf.rules
Test suite for owl:sameAs processing.
TestRuleOwlSameAs() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlSameAs
TestRuleOwlSameAs(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlSameAs
TestRuleOwlSymmetricProperty - Class in com.bigdata.rdf.rules
Test suite for owl:SymmetricProperty processing.
TestRuleOwlSymmetricProperty() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlSymmetricProperty
TestRuleOwlSymmetricProperty(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlSymmetricProperty
TestRuleOwlTransitiveProperty - Class in com.bigdata.rdf.rules
Test suite for owl:transtitiveProperty processing.
TestRuleOwlTransitiveProperty() - Constructor for class com.bigdata.rdf.rules.TestRuleOwlTransitiveProperty
TestRuleOwlTransitiveProperty(String) - Constructor for class com.bigdata.rdf.rules.TestRuleOwlTransitiveProperty
TestRuleRdf01 - Class in com.bigdata.rdf.rules
TestRuleRdf01() - Constructor for class com.bigdata.rdf.rules.TestRuleRdf01
TestRuleRdf01(String) - Constructor for class com.bigdata.rdf.rules.TestRuleRdf01
TestRuleRdfs03 - Class in com.bigdata.rdf.rules
TestRuleRdfs03() - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs03
TestRuleRdfs03(String) - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs03
TestRuleRdfs04 - Class in com.bigdata.rdf.rules
TestRuleRdfs04() - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs04
TestRuleRdfs04(String) - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs04
TestRuleRdfs07 - Class in com.bigdata.rdf.rules
Note: rdfs 2, 3, 7, and 9 use the same base class.
TestRuleRdfs07() - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs07
TestRuleRdfs07(String) - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs07
TestRuleRdfs10 - Class in com.bigdata.rdf.rules
Note: rdfs 6, 8, 10, 12, and 13 use the same base clase.
TestRuleRdfs10() - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs10
TestRuleRdfs10(String) - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs10
TestRuleRdfs11 - Class in com.bigdata.rdf.rules
Note: rdfs 5 and 11 use the same base class.
TestRuleRdfs11() - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs11
TestRuleRdfs11(String) - Constructor for class com.bigdata.rdf.rules.TestRuleRdfs11
TestRuleState - Class in com.bigdata.relation.rule.eval
TestRuleState() - Constructor for class com.bigdata.relation.rule.eval.TestRuleState
TestRuleState(String) - Constructor for class com.bigdata.relation.rule.eval.TestRuleState
TestRuleState.RuleState2 - Class in com.bigdata.relation.rule.eval
TestRuleState.RuleState2(IRule, int[]) - Constructor for class com.bigdata.relation.rule.eval.TestRuleState.RuleState2
testRunFirstExpanders() - Method in class com.bigdata.bop.joinGraph.fast.TestDefaultEvaluationPlan
TestRunState - Class in com.bigdata.bop.engine
Test suite for RunState
.
TestRunState() - Constructor for class com.bigdata.bop.engine.TestRunState
TestRunState(String) - Constructor for class com.bigdata.bop.engine.TestRunState
TestRunState - Class in com.bigdata.journal
TestRunState() - Constructor for class com.bigdata.journal.TestRunState
TestRunState(String) - Constructor for class com.bigdata.journal.TestRunState
testRussianFilterStopWords() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testRussianNoStopWords() - Method in class com.bigdata.search.AbstractDefaultAnalyzerFactoryTest
testRWBits() - Method in class com.bigdata.rwstore.TestRWJournal
The RWStore relies on several bit manipulation methods to manage both FixedAllocators
and meta allocations.
TestRWJournal - Class in com.bigdata.rwstore
TestRWJournal() - Constructor for class com.bigdata.rwstore.TestRWJournal
TestRWJournal(String) - Constructor for class com.bigdata.rwstore.TestRWJournal
TestRWJournal.TestInterrupts - Class in com.bigdata.rwstore
TestRWJournal.TestInterrupts() - Constructor for class com.bigdata.rwstore.TestRWJournal.TestInterrupts
TestRWJournal.TestInterrupts(String) - Constructor for class com.bigdata.rwstore.TestRWJournal.TestInterrupts
TestRWJournal.TestMRMW - Class in com.bigdata.rwstore
TestRWJournal.TestMRMW() - Constructor for class com.bigdata.rwstore.TestRWJournal.TestMRMW
TestRWJournal.TestMRMW(String) - Constructor for class com.bigdata.rwstore.TestRWJournal.TestMRMW
TestRWJournal.TestMROW - Class in com.bigdata.rwstore
TestRWJournal.TestMROW() - Constructor for class com.bigdata.rwstore.TestRWJournal.TestMROW
TestRWJournal.TestMROW(String) - Constructor for class com.bigdata.rwstore.TestRWJournal.TestMROW
TestRWJournal.TestRawStore - Class in com.bigdata.rwstore
TestRWJournal.TestRawStore() - Constructor for class com.bigdata.rwstore.TestRWJournal.TestRawStore
TestRWJournal.TestRawStore(String) - Constructor for class com.bigdata.rwstore.TestRWJournal.TestRawStore
TestRWStoreTxBehaviors<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Tests that are RWStore specific.
TestRWStoreTxBehaviors() - Constructor for class com.bigdata.rdf.sail.webapp.TestRWStoreTxBehaviors
TestRWStoreTxBehaviors(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestRWStoreTxBehaviors
TestRWWriteCacheService - Class in com.bigdata.io.writecache
TestRWWriteCacheService() - Constructor for class com.bigdata.io.writecache.TestRWWriteCacheService
TestRWWriteCacheService(String) - Constructor for class com.bigdata.io.writecache.TestRWWriteCacheService
testSameTermRepeatInOptional() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testSameTermRepeatInOptional() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSameTermRepeatInUnion() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSameTermRepeatInUnionAndOptional() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testSameTermRepeatInUnionAndOptional() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
TestSameVariableConstraint - Class in com.bigdata.bop.rdf.filter
TestSameVariableConstraint() - Constructor for class com.bigdata.bop.rdf.filter.TestSameVariableConstraint
TestSameVariableConstraint(String) - Constructor for class com.bigdata.bop.rdf.filter.TestSameVariableConstraint
TestSAMPLE - Class in com.bigdata.bop.rdf.aggregate
TestSAMPLE() - Constructor for class com.bigdata.bop.rdf.aggregate.TestSAMPLE
TestSAMPLE(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestSAMPLE
TestSampleIndex - Class in com.bigdata.bop.ap
TestSampleIndex() - Constructor for class com.bigdata.bop.ap.TestSampleIndex
TestSampleIndex(String) - Constructor for class com.bigdata.bop.ap.TestSampleIndex
TestScaleOutTripleStoreWithEmbeddedFederation - Class in com.bigdata.rdf.store
TestScaleOutTripleStoreWithEmbeddedFederation() - Constructor for class com.bigdata.rdf.store.TestScaleOutTripleStoreWithEmbeddedFederation
TestScaleOutTripleStoreWithEmbeddedFederation(String) - Constructor for class com.bigdata.rdf.store.TestScaleOutTripleStoreWithEmbeddedFederation
TestScatterSplit - Class in com.bigdata.service
Some unit tests for moving an index partition.
TestScatterSplit() - Constructor for class com.bigdata.service.TestScatterSplit
TestScatterSplit(String) - Constructor for class com.bigdata.service.TestScatterSplit
testSCequality() - Method in class com.bigdata.rdf.sail.TestQuadsAPI
Matt, do you recognize this unit test: TestQuadsAPI#testSCequality()? I
think that this may have been something from you dealing with the binding
on the S and C positions.
testScriptExceptionThrown() - Method in class com.bigdata.gom.TestJavaScriptGOM
Verify that the scripting engine will throw an exception if there is an
error.
testScriptRuns() - Method in class com.bigdata.gom.TestJavaScriptGOM
Verify that the scripting engine is running.
TestSearch - Class in com.bigdata.rdf.sparql.ast.eval.service
Data driven test suite for full text search.
TestSearch() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
TestSearch(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestSearch
TestSearch - Class in com.bigdata.search
TestSearch() - Constructor for class com.bigdata.search.TestSearch
TestSearch(String) - Constructor for class com.bigdata.search.TestSearch
TestSearchQuery - Class in com.bigdata.rdf.sail
Test suite for high-level query against a graph containing statements about
statements.
TestSearchQuery() - Constructor for class com.bigdata.rdf.sail.TestSearchQuery
TestSearchQuery(String) - Constructor for class com.bigdata.rdf.sail.TestSearchQuery
TestSearchRestartSafe - Class in com.bigdata.search
Simple test verifies that the
FullTextIndex
data are restart safe.
TestSearchRestartSafe() - Constructor for class com.bigdata.search.TestSearchRestartSafe
TestSearchRestartSafe(String) - Constructor for class com.bigdata.search.TestSearchRestartSafe
TestSegSplitter - Class in com.bigdata.resources
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.
TestSegSplitter() - Constructor for class com.bigdata.resources.TestSegSplitter
TestSegSplitter(String) - Constructor for class com.bigdata.resources.TestSegSplitter
testSelectGetJSON() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testSelectGetXML() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testSelectPostEncodeJSON() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testSelectPostEncodeXML() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testSelectPostJSON() - Method in class com.bigdata.rdf.sail.webapp.TestPostNotURLEncoded
testSelectPostXML() - Method in class com.bigdata.rdf.sail.webapp.TestPostNotURLEncoded
testSerialization() - Method in class com.bigdata.ha.msg.TestHAWriteMessage
Simple test to verify HAWriteMessage serialization
testSerialization() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
A deserialized serialized deque has same elements in same order
testSerialization() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
A deserialized serialized queue has same elements in same order
testSerializerCircle01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializer
testSerializerRectangle01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializer
TestService794 - Class in com.bigdata.rdf.sail.webapp
TestService794(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestService794
testServiceBDS() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for internal
BDS
service.
testServiceBindDependencyOrdering() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
Interaction of BIND/SPARQL SERVICE keyword.
testServiceEndpointUrl(String) - Static method in class com.bigdata.rdf.sail.remote.BigdataSailFactory
Deprecated.
testServiceFTS() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for internal
FTS
service.
testServiceNodeBindings() - Method in class com.bigdata.rdf.sail.webapp.TestNanoSparqlClient
testServicePlacementServiceBDS() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testServicePlacementServiceFTS01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testServicePlacementServiceFTS02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testServicePlacementSparql11a() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testServicePlacementSparql11b() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testServicePlacementSparql11c() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
TestServiceRegistry - Class in com.bigdata.rdf.sparql.ast.eval.service
TestServiceRegistry() - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestServiceRegistry
TestServiceRegistry(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.service.TestServiceRegistry
testServiceSparql11Constant() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for SPARQL 1.1 SERVICE with constant
specifying service endpoint.
testServiceSparql11Variable() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for SPARQL 1.1 SERVICE with variable
specifying service endpoint.
TestServiceWhiteList - Class in com.bigdata.rdf.sail.webapp
TestServiceWhiteList() - Constructor for class com.bigdata.rdf.sail.webapp.TestServiceWhiteList
testServiceWhiteList() - Method in class com.bigdata.rdf.sail.webapp.TestServiceWhiteList
testServiceWithBindingArg() - Method in class com.bigdata.rdf.sail.TestTicket632
testSES1073InverseSymmetricPattern() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1081SameTermWithValues() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1121VarNamesInOptionals() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1898LeftJoinSemantics1() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testSES1898LeftJoinSemantics1() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1898LeftJoinSemantics2() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1970CountDistinctWildcard() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1991NOWEvaluation() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1991RANDEvaluation() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
testSES1991RANDEvaluation() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1991STRUUIDEvaluation() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES1991UUIDEvaluation() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES2024PropertyPathAnonVarSharing() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testSES713() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestSesameFilters - Class in com.bigdata.rdf.sail
TestSesameFilters() - Constructor for class com.bigdata.rdf.sail.TestSesameFilters
TestSesameFilters(String) - Constructor for class com.bigdata.rdf.sail.TestSesameFilters
testSesameFilters() - Method in class com.bigdata.rdf.sail.TestUnions
Tests mapping of UNIONS in SPARQL onto unions in bigdata rules.
TestSesameMultiGraphs - Class in com.bigdata.rdf.sail
TestSesameMultiGraphs() - Constructor for class com.bigdata.rdf.sail.TestSesameMultiGraphs
testSet() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testSet() - Method in class com.bigdata.btree.TestBigdataSet
basic tests of add(), isEmpty(), size(), contains(), and remove().
TestSetBinding - Class in com.bigdata.rdf.sail
Test suite for AbstractOperation.setBinding(String, Value)
TestSetBinding() - Constructor for class com.bigdata.rdf.sail.TestSetBinding
TestSetBinding(String) - Constructor for class com.bigdata.rdf.sail.TestSetBinding
testSetBinding() - Method in class com.bigdata.rdf.sail.TestSetBinding
TestSharedLexiconTempStore - Class in com.bigdata.rdf.store
TestSharedLexiconTempStore() - Constructor for class com.bigdata.rdf.store.TestSharedLexiconTempStore
TestSharedLexiconTempStore(String) - Constructor for class com.bigdata.rdf.store.TestSharedLexiconTempStore
TestShortPacker - Class in com.bigdata.io
TestShortPacker() - Constructor for class com.bigdata.io.TestShortPacker
TestShortPacker(String) - Constructor for class com.bigdata.io.TestShortPacker
testSids() - Method in class com.bigdata.rdf.sail.TestChangeSets
TestSids - Class in com.bigdata.rdf.sail
Test case for reverse lookup from SID to statement.
TestSids() - Constructor for class com.bigdata.rdf.sail.TestSids
TestSids(String) - Constructor for class com.bigdata.rdf.sail.TestSids
testSids() - Method in class com.bigdata.rdf.sail.TestSids
testSids2() - Method in class com.bigdata.rdf.sail.TestSids
testSignedInteger() - Method in class com.bigdata.rdf.store.TestInlineURIs
testSimpleAccess() - Method in class com.bigdata.concurrent.TestAccessSemaphore
testSimpleAdd() - Method in class com.bigdata.rdf.sail.TestChangeSets
testSimpleAllocations() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
testSimpleAllocations() - Method in class com.bigdata.rwstore.sector.TestMemoryManagerStreams
testSimpleALPNode() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for ALP nodes.
testSimpleALPP() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestALPPinTrac773
TestSimpleBindingsOptimizer - Class in com.bigdata.rdf.sparql.ast.eval
SPARQL level test suite for the ASTSimpleBindingsOptimizer
.
TestSimpleBindingsOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer
TestSimpleBindingsOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer
TestSimpleBindingsOptimizer.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
TestSimpleBindingsOptimizer.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer.TestQuadsModeAPs
TestSimpleBindingsOptimizer.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Triples mode test suite.
TestSimpleBindingsOptimizer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleBindingsOptimizer.TestTriplesModeAPs
testSimpleBlob() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
testSimpleBooleanQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
testSimpleClassObjects() - Method in class com.bigdata.gom.TestGOM
SimpleClassObjects tests navigation around a constructed network of GPOs.
testSimpleCompression() - Method in class com.bigdata.io.compression.TestCompressorRegistry
Simple test to confirm standard compress/expand utilities on
HAWriteMesage
testSimpleConjunctiveFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
The FILTER
testSimpleConstraint() - Method in class com.bigdata.rdf.sail.TestBOps
testSimpleCreate() - Method in class com.bigdata.gom.TestGOM
Creates a simple GPO within a transaction.
testSimpleCreate() - Method in class com.bigdata.gom.TestRemoteGOM
testSimpleDirectData() - Method in class com.bigdata.gom.TestGOM
Simple test loads data from a file and navigates around
testSimpleDirectData() - Method in class com.bigdata.gom.TestRemoteGOM
testSimpleDisjunctiveFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
The FILTER
testSimpleExchange() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive
Should we expect concurrency of the Socket send and RMI? It seems that we
should be able to handle it whatever the logical argument.
testSimpleExchange() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
testSimpleExists() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTExistsAndJoinOrderByTypeOptimizers
TestSimpleFileRawStore - Class in com.bigdata.rawstore
TestSimpleFileRawStore() - Constructor for class com.bigdata.rawstore.TestSimpleFileRawStore
TestSimpleFileRawStore(String) - Constructor for class com.bigdata.rawstore.TestSimpleFileRawStore
testSimpleFormContent() - Method in class com.bigdata.rdf.sail.webapp.TestMultipartContent
testSimpleGraphQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestSimpleGroupByAndCountOptimizer - Class in com.bigdata.rdf.sparql.ast.eval
TestSimpleGroupByAndCountOptimizer() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer
TestSimpleGroupByAndCountOptimizer(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer
TestSimpleGroupByAndCountOptimizer.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Quads mode test suite.
TestSimpleGroupByAndCountOptimizer.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestQuadsModeAPs
TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Triples mode test suite.
TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSimpleGroupByAndCountOptimizer.TestTriplesModeAPs
testSimpleJoin() - Method in class com.bigdata.rdf.sail.TestBOps
testSimpleJoin() - Method in class com.bigdata.rdf.sparql.ast.TestAST
select *
where {
predicate1 .
testSimpleJoinGroup() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for simple statement pattern only
join groups.
testSimpleJSON() - Method in class com.bigdata.gom.TestRemoteGOM
TestSimpleMemoryRawStore - Class in com.bigdata.rawstore
TestSimpleMemoryRawStore() - Constructor for class com.bigdata.rawstore.TestSimpleMemoryRawStore
TestSimpleMemoryRawStore(String) - Constructor for class com.bigdata.rawstore.TestSimpleMemoryRawStore
testSimpleOptional() - Method in class com.bigdata.rdf.sail.TestBOps
testSimpleOptional() - Method in class com.bigdata.rdf.sparql.ast.TestAST
select *
where {
predicate1 .
testSimpleOrAndSwitch() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test switch of OR over AND expression expression.
testSimpleOWL() - Method in class com.bigdata.gom.TestOWLSkin
testSimpleProperties() - Method in class com.bigdata.gom.TestGOM
Checks getPropertyURIs of committed GPO
TestSimpleRabaCoder - Class in com.bigdata.btree.raba.codec
TestSimpleRabaCoder() - Constructor for class com.bigdata.btree.raba.codec.TestSimpleRabaCoder
TestSimpleRabaCoder(String) - Constructor for class com.bigdata.btree.raba.codec.TestSimpleRabaCoder
TestSimpleReleaseTimes - Class in com.bigdata.journal
Example of Commit History usage.
TestSimpleReleaseTimes() - Constructor for class com.bigdata.journal.TestSimpleReleaseTimes
testSimpleRemove() - Method in class com.bigdata.rdf.sail.TestChangeSets
testSimpleReplication() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Test low level RWStore add/removeAddress methods as used in HA
WriteCache replication to ensure Allocation consistency
testSimpleReset() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
testSimpleReverseLinkProperties() - Method in class com.bigdata.gom.TestGOM
testSimpleRWWriter() - Method in class com.bigdata.ha.althalog.TestAltHALogWriter
Simple writelog test, open file, write data and commit.
testSimpleRWWriter() - Method in class com.bigdata.ha.halog.TestHALogWriter
Simple writelog test, open file, write data and commit.
testSimpleRWWriterReader() - Method in class com.bigdata.ha.althalog.TestAltHALogWriter
Simple WriteReader, no concurrency, confirms non-delayed responses.
testSimpleRWWriterReader() - Method in class com.bigdata.ha.halog.TestHALogWriter
Simple WriteReader, no concurrency, confirms non-delayed responses.
testSimpleSameTermFilter() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Given
testSimpleServiceCall() - Method in class com.bigdata.rdf.sail.webapp.TestService794
testSimpleServiceQuery() - Method in class com.bigdata.rdf.sail.webapp.TestFederatedQuery
testSimpleSSSP() - Method in class com.bigdata.rdf.sail.graph.TestPaths
testSimpleStartStopRWService() - Method in class com.bigdata.io.writecache.TestWriteCacheServiceLifetime
testSimpleStartStopRWService2() - Method in class com.bigdata.io.writecache.TestWriteCacheServiceLifetime
The first genuine lifetime test, sets 20 concurrent writer tasks
to output to the service and a final task to close the service
concurrently.
testSimpleStreams() - Method in class com.bigdata.rwstore.sector.TestMemoryManagerStreams
testSimpleStringStream() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
testSimpleStringStreamFromStandardAllocation() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
testSimpleTupleQuery() - Method in class org.openrdf.repository.RepositoryConnectionTest
testSimpleTxAdd() - Method in class com.bigdata.rdf.sail.TestChangeSets
Unit test with a full read/write transaction.
testSimpleUnisolatedAllocationContextRecycling() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
testSingleALPP() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFlattenJoinGroupsOptimizer
testSingleCompactingCopy() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
testSingleFulltextSearchMax() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify simple fulltext search with full configuration.
testSingleFulltextSearchMin() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify simple fulltext search with small configuration.
testSingleFulltextSearchUsingService() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify simple fulltext search with full configuration, where the
magic vocabulary is already encapsulated into a SERVICE node.
testSinglePartitionWithOneStatementPattern() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
Test partition with a single triple pattern.
testSinglePartitionWithThreeStatementPattern() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
Test partition with three statement patterns, where the last one
is optional.
testSinglePartitionWithTwoStatementPattern() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupPartitioning
Test partition with two statement patterns (both not optional).
testSingleTail() - Method in class com.bigdata.rdf.sail.TestSingleTailRule
TestSingleTailRule - Class in com.bigdata.rdf.sail
TestSingleTailRule() - Constructor for class com.bigdata.rdf.sail.TestSingleTailRule
TestSingleTailRule(String) - Constructor for class com.bigdata.rdf.sail.TestSingleTailRule
testSingleTailSearch() - Method in class com.bigdata.rdf.sail.TestSingleTailRule
TestSingletonQuorumSemantics - Class in com.bigdata.quorum
Test the quorum semantics for a singleton quorum.
TestSingletonQuorumSemantics() - Constructor for class com.bigdata.quorum.TestSingletonQuorumSemantics
TestSingletonQuorumSemantics(String) - Constructor for class com.bigdata.quorum.TestSingletonQuorumSemantics
testSize() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
testSize() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
size changes when elements added and removed
testSize() - Method in class org.openrdf.sail.RDFStoreTest
testSizeCommit() - Method in class org.openrdf.repository.RepositoryConnectionTest
testSizeRollback() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestSlice - Class in com.bigdata.rdf.rules
TestSlice() - Constructor for class com.bigdata.rdf.rules.TestSlice
TestSlice(String) - Constructor for class com.bigdata.rdf.rules.TestSlice
TestSlice - Class in com.bigdata.relation.rule
TestSlice() - Constructor for class com.bigdata.relation.rule.TestSlice
TestSlice(String) - Constructor for class com.bigdata.relation.rule.TestSlice
TestSliceInputStream - Class in com.bigdata.io
TestSliceInputStream() - Constructor for class com.bigdata.io.TestSliceInputStream
TestSliceInputStream(String) - Constructor for class com.bigdata.io.TestSliceInputStream
TestSliceOp - Class in com.bigdata.bop.solutions
TestSliceOp() - Constructor for class com.bigdata.bop.solutions.TestSliceOp
TestSliceOp(String) - Constructor for class com.bigdata.bop.solutions.TestSliceOp
TestSnapshotHelper - Class in com.bigdata.service
TestSnapshotHelper() - Constructor for class com.bigdata.service.TestSnapshotHelper
TestSnapshotHelper(String) - Constructor for class com.bigdata.service.TestSnapshotHelper
TestSnapshotJournal - Class in com.bigdata.journal
Test suite for
Journal#snapshot(com.bigdata.journal.Journal.ISnapshotFactory)
.
TestSnapshotJournal() - Constructor for class com.bigdata.journal.TestSnapshotJournal
TestSnapshotJournal(String) - Constructor for class com.bigdata.journal.TestSnapshotJournal
TestSocketsDirect - Class in com.bigdata.ha.pipeline
Test suite for basic socket behaviors.
TestSocketsDirect() - Constructor for class com.bigdata.ha.pipeline.TestSocketsDirect
TestSocketsDirect(String) - Constructor for class com.bigdata.ha.pipeline.TestSocketsDirect
TestSolutionSetManager - Class in com.bigdata.rdf.sparql.ast.ssets
Test suite for managing named solution sets.
TestSolutionSetManager() - Constructor for class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
TestSolutionSetManager(String) - Constructor for class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
TestSolutionSetStats - Class in com.bigdata.rdf.sparql.ast
TestSolutionSetStats() - Constructor for class com.bigdata.rdf.sparql.ast.TestSolutionSetStats
TestSolutionSetStats(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestSolutionSetStats
TestSolutionSetStatserator - Class in com.bigdata.rdf.sparql.ast
TestSolutionSetStatserator() - Constructor for class com.bigdata.rdf.sparql.ast.TestSolutionSetStatserator
TestSolutionSetStatserator(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestSolutionSetStatserator
testSparqlIntegration() - Method in class com.bigdata.rdf.sail.TestRDRHistory
Test the SPARQL integration.
TestSparqlStar - Class in com.bigdata.rdf.sail
Test suite for SPARQL* features
TestSparqlStar() - Constructor for class com.bigdata.rdf.sail.TestSparqlStar
TestSparqlStar(String) - Constructor for class com.bigdata.rdf.sail.TestSparqlStar
TestSparqlUpdate<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
Proxied test suite.
TestSparqlUpdate() - Constructor for class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
TestSparqlUpdate(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
TestSparqlUpdateCommit - Class in com.bigdata.rdf.sail
TestSparqlUpdateCommit() - Constructor for class com.bigdata.rdf.sail.TestSparqlUpdateCommit
TestSparqlUpdateCommit(String) - Constructor for class com.bigdata.rdf.sail.TestSparqlUpdateCommit
TestSparqlUpdateCommit.CommitCounter - Class in com.bigdata.rdf.sail
TestSparqlUpdateCommit.CommitCounter() - Constructor for class com.bigdata.rdf.sail.TestSparqlUpdateCommit.CommitCounter
TestSparqlUpdateSuppressTruthMaintenance<S extends IIndexManager> - Class in com.bigdata.rdf.sail.webapp
TestSparqlUpdateSuppressTruthMaintenance() - Constructor for class com.bigdata.rdf.sail.webapp.TestSparqlUpdateSuppressTruthMaintenance
TestSparqlUpdateSuppressTruthMaintenance(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestSparqlUpdateSuppressTruthMaintenance
TestSparseRowStore - Class in com.bigdata.sparse
TestSparseRowStore() - Constructor for class com.bigdata.sparse.TestSparseRowStore
TestSparseRowStore(String) - Constructor for class com.bigdata.sparse.TestSparseRowStore
TestSparseRowStoreSplitHandler - Class in com.bigdata.resources
TestSparseRowStoreSplitHandler() - Constructor for class com.bigdata.resources.TestSparseRowStoreSplitHandler
TestSparseRowStoreSplitHandler(String) - Constructor for class com.bigdata.resources.TestSparseRowStoreSplitHandler
TestSplitJoin - Class in com.bigdata.service
Test suite verifies that inserts eventually split an index and that deletes
eventually cause the index partitions to be joined.
TestSplitJoin() - Constructor for class com.bigdata.service.TestSplitJoin
TestSplitJoin(String) - Constructor for class com.bigdata.service.TestSplitJoin
TestSplitJoinRootLeaf - Class in com.bigdata.btree
Test split and join of the root leaf (the tree never has more than two
levels).
TestSplitJoinRootLeaf() - Constructor for class com.bigdata.btree.TestSplitJoinRootLeaf
TestSplitJoinRootLeaf(String) - Constructor for class com.bigdata.btree.TestSplitJoinRootLeaf
TestSplitJoinThreeLevels - Class in com.bigdata.btree
TestSplitJoinThreeLevels() - Constructor for class com.bigdata.btree.TestSplitJoinThreeLevels
TestSplitJoinThreeLevels(String) - Constructor for class com.bigdata.btree.TestSplitJoinThreeLevels
TestSplitRootLeaf - Class in com.bigdata.btree
Test split of the root leaf.
TestSplitRootLeaf() - Constructor for class com.bigdata.btree.TestSplitRootLeaf
TestSplitRootLeaf(String) - Constructor for class com.bigdata.btree.TestSplitRootLeaf
TestSplitter - Class in com.bigdata.service.ndx
TestSplitter() - Constructor for class com.bigdata.service.ndx.TestSplitter
TestSplitter(String) - Constructor for class com.bigdata.service.ndx.TestSplitter
TestSPO - Class in com.bigdata.rdf.spo
Test suite for the
SPO
class.
TestSPO() - Constructor for class com.bigdata.rdf.spo.TestSPO
TestSPO(String) - Constructor for class com.bigdata.rdf.spo.TestSPO
TestSPOAccessPath - Class in com.bigdata.rdf.spo
TestSPOAccessPath() - Constructor for class com.bigdata.rdf.spo.TestSPOAccessPath
TestSPOAccessPath(String) - Constructor for class com.bigdata.rdf.spo.TestSPOAccessPath
TestSPOKeyCoders - Class in com.bigdata.rdf.spo
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).
TestSPOKeyCoders() - Constructor for class com.bigdata.rdf.spo.TestSPOKeyCoders
TestSPOKeyCoders(String) - Constructor for class com.bigdata.rdf.spo.TestSPOKeyCoders
TestSPOKeyOrder - Class in com.bigdata.rdf.spo
TestSPOKeyOrder() - Constructor for class com.bigdata.rdf.spo.TestSPOKeyOrder
TestSPOKeyOrder(String) - Constructor for class com.bigdata.rdf.spo.TestSPOKeyOrder
TestSPOPredicate - Class in com.bigdata.rdf.spo
TestSPOPredicate() - Constructor for class com.bigdata.rdf.spo.TestSPOPredicate
TestSPOPredicate(String) - Constructor for class com.bigdata.rdf.spo.TestSPOPredicate
TestSPORelation - Class in com.bigdata.rdf.spo
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).
TestSPORelation() - Constructor for class com.bigdata.rdf.spo.TestSPORelation
TestSPORelation(String) - Constructor for class com.bigdata.rdf.spo.TestSPORelation
TestSPORelation.P - Class in com.bigdata.rdf.spo
TestSPORelation.P(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.spo.TestSPORelation.P
Required shallow copy constructor.
TestSPORelation.P(TestSPORelation.P) - Constructor for class com.bigdata.rdf.spo.TestSPORelation.P
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
TestSPORelation.P(String, IVariableOrConstant<IV>, IVariableOrConstant<IV>, IVariableOrConstant<IV>) - Constructor for class com.bigdata.rdf.spo.TestSPORelation.P
TestSPORelation.TestRuleRdfs9 - Class in com.bigdata.rdf.spo
this is rdfs9:
TestSPORelation.TestRuleRdfs9(String) - Constructor for class com.bigdata.rdf.spo.TestSPORelation.TestRuleRdfs9
TestSPOStarJoin - Class in com.bigdata.rdf.spo
TestSPOStarJoin() - Constructor for class com.bigdata.rdf.spo.TestSPOStarJoin
TestSPOStarJoin(String) - Constructor for class com.bigdata.rdf.spo.TestSPOStarJoin
TestSPOTupleSerializer - Class in com.bigdata.rdf.spo
TestSPOTupleSerializer() - Constructor for class com.bigdata.rdf.spo.TestSPOTupleSerializer
TestSPOTupleSerializer(String) - Constructor for class com.bigdata.rdf.spo.TestSPOTupleSerializer
TestSPOValueCoders - Class in com.bigdata.rdf.spo
Test suite for approaches to value compression for statement indices.
TestSPOValueCoders() - Constructor for class com.bigdata.rdf.spo.TestSPOValueCoders
TestSPOValueCoders(String) - Constructor for class com.bigdata.rdf.spo.TestSPOValueCoders
TestSSSP - Class in com.bigdata.rdf.graph.impl.bd
Test class for SSP traversal.
TestSSSP() - Constructor for class com.bigdata.rdf.graph.impl.bd.TestSSSP
TestSSSP(String) - Constructor for class com.bigdata.rdf.graph.impl.bd.TestSSSP
testSSSP() - Method in class com.bigdata.rdf.graph.impl.bd.TestSSSP
testStandaloneBigdataNTriplesParser() - Method in class com.bigdata.rdf.rio.TestStandaloneRDRParsers
testStandaloneBigdataTurtleParser() - Method in class com.bigdata.rdf.rio.TestStandaloneRDRParsers
TestStandaloneRDRParsers - Class in com.bigdata.rdf.rio
Test suite for standalone usage of Bigdata RDF Parsers.
TestStandaloneRDRParsers() - Constructor for class com.bigdata.rdf.rio.TestStandaloneRDRParsers
TestStartOpMessage - Class in com.bigdata.bop.engine
TestStartOpMessage() - Constructor for class com.bigdata.bop.engine.TestStartOpMessage
TestStartOpMessage(String) - Constructor for class com.bigdata.bop.engine.TestStartOpMessage
TestStatementBuffer - Class in com.bigdata.rdf.rio
TestStatementBuffer() - Constructor for class com.bigdata.rdf.rio.TestStatementBuffer
TestStatementBuffer(String) - Constructor for class com.bigdata.rdf.rio.TestStatementBuffer
TestStatementBuffer.TestTriplesModeAPs - Class in com.bigdata.rdf.rio
Triples mode test suite.
TestStatementBuffer.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.rio.TestStatementBuffer.TestTriplesModeAPs
TestStatementEnum - Class in com.bigdata.rdf.spo
TestStatementEnum() - Constructor for class com.bigdata.rdf.spo.TestStatementEnum
TestStatementEnum(String) - Constructor for class com.bigdata.rdf.spo.TestStatementEnum
testStatementEquals() - Method in class org.openrdf.sail.RDFStoreTest
TestStatementIdentifiers - Class in com.bigdata.rdf.store
Test of the statement identifier semantics.
TestStatementIdentifiers() - Constructor for class com.bigdata.rdf.store.TestStatementIdentifiers
TestStatementIdentifiers(String) - Constructor for class com.bigdata.rdf.store.TestStatementIdentifiers
testStatementPatternNode() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for statement patterns nodes.
testStatements() - Method in class com.bigdata.gom.TestGPO
testStatementSerialization() - Method in class org.openrdf.repository.RepositoryConnectionTest
testStatementSerialization() - Method in class org.openrdf.sail.RDFStoreTest
TestStaticAnalysis - Class in com.bigdata.rdf.sparql.ast
Test suite for methods supporting static analysis of the variables, including
whether a variable MUST be bound, MIGHT be bound, or is NOT bound.
TestStaticAnalysis() - Constructor for class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
TestStaticAnalysis(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestStaticAnalysis
TestStaticAnalysis_CanJoin - Class in com.bigdata.rdf.sparql.ast
TestStaticAnalysis_CanJoin() - Constructor for class com.bigdata.rdf.sparql.ast.TestStaticAnalysis_CanJoin
TestStaticAnalysis_CanJoin(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestStaticAnalysis_CanJoin
TestStaticAnalysis_CanJoinUsingConstraints - Class in com.bigdata.rdf.sparql.ast
This test suite is built around around BSBM Q5.
TestStaticAnalysis_CanJoinUsingConstraints() - Constructor for class com.bigdata.rdf.sparql.ast.TestStaticAnalysis_CanJoinUsingConstraints
TestStaticAnalysis_CanJoinUsingConstraints(String) - Constructor for class com.bigdata.rdf.sparql.ast.TestStaticAnalysis_CanJoinUsingConstraints
testStopWordSwitch() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
TestStoredQueryService - Class in com.bigdata.rdf.sparql.ast.service.storedquery
Test suite for stored query evaluation.
TestStoredQueryService() - Constructor for class com.bigdata.rdf.sparql.ast.service.storedquery.TestStoredQueryService
TestStoredQueryService(String) - Constructor for class com.bigdata.rdf.sparql.ast.service.storedquery.TestStoredQueryService
testStr() - Method in class com.bigdata.rdf.sail.TestLexJoinOps
testStr() - Method in class com.bigdata.rdf.sail.TestMaterialization
testStr() - Method in class com.bigdata.rdf.sail.TestStrBOp
TestStrAfterBOp - Class in com.bigdata.rdf.internal.constraints
TestStrAfterBOp() - Constructor for class com.bigdata.rdf.internal.constraints.TestStrAfterBOp
TestStrAfterBOp(String) - Constructor for class com.bigdata.rdf.internal.constraints.TestStrAfterBOp
TestStrBeforeBOp - Class in com.bigdata.rdf.internal.constraints
TestStrBeforeBOp() - Constructor for class com.bigdata.rdf.internal.constraints.TestStrBeforeBOp
TestStrBeforeBOp(String) - Constructor for class com.bigdata.rdf.internal.constraints.TestStrBeforeBOp
TestStrBOp - Class in com.bigdata.rdf.sail
TestStrBOp() - Constructor for class com.bigdata.rdf.sail.TestStrBOp
TestStrBOp(String) - Constructor for class com.bigdata.rdf.sail.TestStrBOp
testStress() - Method in class com.bigdata.btree.data.AbstractNodeOrLeafDataRecordTestCase
De-serialization stress test conducted for a variety of and branching
factors.
testStress() - Method in class com.bigdata.btree.raba.codec.AbstractRabaCoderTestCase
testStress() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive
Sends a large number of random buffers, confirming successful
transmission.
testStress() - Method in class com.bigdata.journal.TestTx
Stress test for concurrent transactions against a single named index.
testStressAccess() - Method in class com.bigdata.concurrent.TestAccessSemaphore
testStressAllocationContextRecycling() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
This tests whether AllocationContexts efficiently recycle transient
allocations.
testStressAllocations() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
testStressCompactingCopy() - Method in class com.bigdata.io.writecache.TestRWWriteCacheService
1) Creates five WriteCaches and writes until four full.
testStressConcurrent() - Method in class com.bigdata.rwstore.sector.TestMemoryManager
testStressConcurrentRWWriterReader() - Method in class com.bigdata.ha.althalog.TestAltHALogWriter
While a writer thread writes a number of HALogs, readers are opened to
process them.
testStressDirectBuffers() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive
Sends a large number of random buffers, confirming successful
transmission.
testStressDirectBuffers() - Method in class com.bigdata.ha.pipeline.TestHASendAndReceive3Nodes
Note: This appears to work now. This test has been observed to
deadlock CI and is disabled until we finish debugging the HA pipeline and
quorums.
testStressInsertWhereGraph() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
A stress test written to look for stochastic behaviors in SPARQL UPDATE
for GROUP COMMIT.
testStressRandom() - Method in class com.bigdata.io.LongPackerTestCase
Run a large #of random pack/unpack operations to sample the space while
showing correctness on those samples.
testStressRandom() - Method in class com.bigdata.io.ShortPackerTestCase
Run a large #of random pack/unpack operations to sample the space while
showing correctness on those samples.
testStressRandom() - Method in class com.bigdata.io.TestLongPacker
Run a large #of random pack/unpack operations to sample the space while
showing correctness on those samples.
testStressRandom() - Method in class com.bigdata.io.TestShortPacker
Run a large #of random pack/unpack operations to sample the space while
showing correctness on those samples.
testStressRandomNonNegativeLeadingZeros() - Method in class com.bigdata.io.TestLongPacker
Run a large #of random pack/unpack operations to sample the space while
showing correctness on those samples.
testStressReplication() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Test low level RWStore add/removeAddress methods as used in HA
WriteCache replication to ensure Allocation consistency
testStressSequence() - Method in class com.bigdata.io.LongPackerTestCase
Run a large #of pack/unpack operations on a sequence of long values to
demonstrate correctness in that sequence.
testStressSequence() - Method in class com.bigdata.io.ShortPackerTestCase
Run a large #of pack/unpack operations on a sequence of short values to
demonstrate correctness in that sequence.
testStressSequence() - Method in class com.bigdata.io.TestLongPacker
Run a large #of pack/unpack operations on a sequence of long values to
demonstrate correctness in that sequence.
testStressSequence() - Method in class com.bigdata.io.TestShortPacker
Run a large #of pack/unpack operations on a sequence of short values to
demonstrate correctness in that sequence.
testStressThreadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_Slice
testStressThreadSafe() - Method in class com.bigdata.bop.engine.TestQueryEngine_SortOp
testStressUnisolatedAllocationContextRecycling() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
This tests whether AllocationContexts efficiently recycle transient
allocations with an Unisolated AllocationContext.
TestStripContextFilter - Class in com.bigdata.bop.rdf.filter
TestStripContextFilter() - Constructor for class com.bigdata.bop.rdf.filter.TestStripContextFilter
TestStripContextFilter(String) - Constructor for class com.bigdata.bop.rdf.filter.TestStripContextFilter
TestStripedCounters - Class in com.bigdata.counters.striped
TestStripedCounters() - Constructor for class com.bigdata.counters.striped.TestStripedCounters
TestStripedCounters(String) - Constructor for class com.bigdata.counters.striped.TestStripedCounters
testSubject() - Method in class com.bigdata.rdf.sail.TestSparqlStar
Test SPARQL* syntax for subject.
TestSubjectCentricFullTextIndex - Class in com.bigdata.rdf.lexicon
Deprecated.
Feature was never completed due to scalability issues. See
BZLG-1548, BLZG-563.
TestSubjectCentricFullTextIndex() - Constructor for class com.bigdata.rdf.lexicon.TestSubjectCentricFullTextIndex
Deprecated.
TestSubjectCentricFullTextIndex(String) - Constructor for class com.bigdata.rdf.lexicon.TestSubjectCentricFullTextIndex
Deprecated.
TestSubQuery - Class in com.bigdata.rdf.sparql.ast.eval
Data driven test suite.
TestSubQuery() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
TestSubQuery(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSubQuery
testSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for UNION nodes.
TestSubqueryOp - Class in com.bigdata.bop.controller
Test suite for handling of optional join groups during query evaluation
against a local database instance.
TestSubqueryOp() - Constructor for class com.bigdata.bop.controller.TestSubqueryOp
TestSubqueryOp(String) - Constructor for class com.bigdata.bop.controller.TestSubqueryOp
TestSubqueryPatterns - Class in com.bigdata.rdf.sail.sparql
TestSubqueryPatterns() - Constructor for class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
TestSubqueryPatterns(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestSubqueryPatterns
testSubqueryWithValues() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause of static bindings from BIND clause,
including the removal of the clause and putting the values into the
exogeneous mapping set.
TestSubRangeRaba - Class in com.bigdata.btree.raba
TestSubRangeRaba() - Constructor for class com.bigdata.btree.raba.TestSubRangeRaba
TestSubRangeRaba(String) - Constructor for class com.bigdata.btree.raba.TestSubRangeRaba
TestSubSelectFilterExist725 - Class in com.bigdata.rdf.sparql.ast.eval
Test for trac725
TestSubSelectFilterExist725() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSubSelectFilterExist725
TestSubSelectFilterExist725(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestSubSelectFilterExist725
TestSubstrBOp - Class in com.bigdata.rdf.internal.constraints
TestSubstrBOp() - Constructor for class com.bigdata.rdf.internal.constraints.TestSubstrBOp
TestSubstrBOp(String) - Constructor for class com.bigdata.rdf.internal.constraints.TestSubstrBOp
TestSuccessorUtil - Class in com.bigdata.btree.keys
TestSuccessorUtil() - Constructor for class com.bigdata.btree.keys.TestSuccessorUtil
TestSuccessorUtil(String) - Constructor for class com.bigdata.btree.keys.TestSuccessorUtil
testSuffixedHexUUIDURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testSuffixedInteger() - Method in class com.bigdata.rdf.store.TestInlineURIs
testSuffixedIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testSuffixedUUIDURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testSuffixFixedWidthIntegerURIHandler() - Method in class com.bigdata.rdf.internal.TestInlineURIHandlers
testSuite() - Method in class com.bigdata.jsr166.BlockingQueueTest
Like suite(), but non-static
TestSUM - Class in com.bigdata.bop.rdf.aggregate
TestSUM() - Constructor for class com.bigdata.bop.rdf.aggregate.TestSUM
TestSUM(String) - Constructor for class com.bigdata.bop.rdf.aggregate.TestSUM
testSuppressTruthMaintenance() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdateSuppressTruthMaintenance
testSyapseExample1() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample2() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample3() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample4() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample5() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample6() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample7() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample8() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSyapseExample9() - Method in class com.bigdata.search.TestConfigurableAnalyzerFactory
testSymmetricOperations() - Method in class com.bigdata.concurrent.TestTxDag
Test adds N random edges to the graph and then removes them and verifies
that removal correctly reproduces each intermediate state following an
edge addition.
testTake() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
take retrieves elements in FIFO order
testTake() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
take retrieves elements in FIFO order
testTakeFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
take retrieves elements in FIFO order
testTakeFirstFromEmpty() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
takeFirst blocks interruptibly when empty
testTakeFromEmptyAfterInterrupt() - Method in class com.bigdata.jsr166.BlockingQueueTest
take() throws InterruptedException immediately if interrupted
before waiting
testTakeFromEmptyBlocksInterruptibly() - Method in class com.bigdata.jsr166.BlockingQueueTest
take() blocks interruptibly when empty
testTakeLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
takeLast retrieves elements in FIFO order
testTakeLastFromEmpty() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
takeLast blocks interruptibly when empty
TestTCK - Class in com.bigdata.rdf.sparql.ast.eval
Test driver for debugging Sesame or DAWG manifest tests.
TestTCK() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTCK
TestTCK(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTCK
TestTCK.TCKStressTests - Class in com.bigdata.rdf.sparql.ast.eval
Tests to be executed in a stress test fashion, i.e.
TestTCK.TCKStressTests() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTCK.TCKStressTests
TestTCK.TCKStressTests(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTCK.TCKStressTests
TestTemplate - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTemplate() - Constructor for class com.bigdata.rdf.sail.TestTemplate
TestTemplate(String) - Constructor for class com.bigdata.rdf.sail.TestTemplate
TestTemporaryStore - Class in com.bigdata.journal
TestTemporaryStore() - Constructor for class com.bigdata.journal.TestTemporaryStore
TestTemporaryStore(String) - Constructor for class com.bigdata.journal.TestTemporaryStore
TestTemporaryStore.TestInterrupts - Class in com.bigdata.journal
TestTemporaryStore.TestInterrupts() - Constructor for class com.bigdata.journal.TestTemporaryStore.TestInterrupts
TestTemporaryStore.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestTemporaryStore.TestInterrupts
TestTemporaryStore.TestMRMW - Class in com.bigdata.journal
TestTemporaryStore.TestMRMW() - Constructor for class com.bigdata.journal.TestTemporaryStore.TestMRMW
TestTemporaryStore.TestMRMW(String) - Constructor for class com.bigdata.journal.TestTemporaryStore.TestMRMW
TestTemporaryStore.TestMROW - Class in com.bigdata.journal
TestTemporaryStore.TestMROW() - Constructor for class com.bigdata.journal.TestTemporaryStore.TestMROW
TestTemporaryStore.TestMROW(String) - Constructor for class com.bigdata.journal.TestTemporaryStore.TestMROW
TestTemporaryStore.TestRawStore - Class in com.bigdata.journal
TestTemporaryStore.TestRawStore() - Constructor for class com.bigdata.journal.TestTemporaryStore.TestRawStore
TestTemporaryStore.TestRawStore(String) - Constructor for class com.bigdata.journal.TestTemporaryStore.TestRawStore
TestTempTripleStore - Class in com.bigdata.rdf.store
TestTempTripleStore() - Constructor for class com.bigdata.rdf.store.TestTempTripleStore
TestTempTripleStore(String) - Constructor for class com.bigdata.rdf.store.TestTempTripleStore
TestTermIdEncoder - Class in com.bigdata.rdf.lexicon
Unit test for unified encoding / decoding for partitioned and unpartitioned
long counters as assigned by the
ICounter
for a TERM2ID index or
index partition.
TestTermIdEncoder() - Constructor for class com.bigdata.rdf.lexicon.TestTermIdEncoder
TestTermIdEncoder(String) - Constructor for class com.bigdata.rdf.lexicon.TestTermIdEncoder
TestTermIV - Class in com.bigdata.rdf.internal
TestTermIV() - Constructor for class com.bigdata.rdf.internal.TestTermIV
TestTermIV(String) - Constructor for class com.bigdata.rdf.internal.TestTermIV
TestTermIVComparator - Class in com.bigdata.rdf.lexicon
TestTermIVComparator() - Constructor for class com.bigdata.rdf.lexicon.TestTermIVComparator
TestTermIVComparator(String) - Constructor for class com.bigdata.rdf.lexicon.TestTermIVComparator
TestThickAsynchronousIterator - Class in com.bigdata.relation.accesspath
TestThickAsynchronousIterator() - Constructor for class com.bigdata.relation.accesspath.TestThickAsynchronousIterator
TestThickAsynchronousIterator(String) - Constructor for class com.bigdata.relation.accesspath.TestThickAsynchronousIterator
TestThickChunkMessage - Class in com.bigdata.bop.fed
TestThickChunkMessage() - Constructor for class com.bigdata.bop.fed.TestThickChunkMessage
TestThickChunkMessage(String) - Constructor for class com.bigdata.bop.fed.TestThickChunkMessage
TestThickCloseableIterator - Class in com.bigdata.relation.accesspath
TestThickCloseableIterator() - Constructor for class com.bigdata.relation.accesspath.TestThickCloseableIterator
TestThickCloseableIterator(String) - Constructor for class com.bigdata.relation.accesspath.TestThickCloseableIterator
TestTicket1007 - Class in com.bigdata.rdf.sparql.ast.eval
Various tests covering different constellations where values are constructed
using BIND and reused in other parts of the query, such as
- testing inlined vs.
TestTicket1007() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
TestTicket1007(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1007
TestTicket1086 - Class in com.bigdata.rdf.sail
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.
TestTicket1086() - Constructor for class com.bigdata.rdf.sail.TestTicket1086
TestTicket1086(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1086
TestTicket1087 - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for an issue where ill designed patterns consisting of a
combination of UNION and nested OPTIONAL cause problems.
TestTicket1087() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1087
TestTicket1087(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1087
TestTicket1105 - Class in com.bigdata.rdf.sparql.ast.eval
Test suite asserting that queries containint quads constructs (named graphs)
are rejected in triples mode (at parsing phase), but go through in quads
mode.
TestTicket1105() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1105
TestTicket1105(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1105
TestTicket1105.TestQuadsModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Quads mode test suite.
TestTicket1105.TestQuadsModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestQuadsModeAPs
TestTicket1105.TestTriplesModeAPs - Class in com.bigdata.rdf.sparql.ast.eval
Triples mode test suite.
TestTicket1105.TestTriplesModeAPs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1105.TestTriplesModeAPs
TestTicket1200_1780 - Class in com.bigdata.rdf.sparql.ast.eval
Test case for https://jira.blazegraph.com/browse/BLZG-1200:
REGEX does not use SPARQL spec for conversion of literals with a language type
TestTicket1200_1780() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
TestTicket1200_1780(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1200_1780
testTicket1363a() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
A UNION node usually has precedence over subqueries.
testTicket1363b() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
In case the UNION node has binding requirements that cannot be satisified
internally, it must be evaluated after the subquery.
testTicket1363c() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
In the following variant, the union node has binding requirements but
can (and does) internally satisfy them.
TestTicket1388 - Class in com.bigdata.rdf.sail
Test suite for ticket #1388: xsd:date function
TestTicket1388() - Constructor for class com.bigdata.rdf.sail.TestTicket1388
TestTicket1388(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1388
TestTicket1518 - Class in com.bigdata.rdf.sail
Test suite for ticket #1518: tests for quad-mode SPARQL features with triplestore not supporting quads
TestTicket1518() - Constructor for class com.bigdata.rdf.sail.TestTicket1518
TestTicket1518(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1518
TestTicket1591 - Class in com.bigdata.rdf.sparql.ast.eval
Test case for https://jira.blazegraph.com/browse/BLZG-1591:
NotMaterializedException
with ORDER BY clause (for InlineURIIvs).
TestTicket1591() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1591
TestTicket1591(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1591
TestTicket1681 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket1681() - Constructor for class com.bigdata.rdf.sail.TestTicket1681
TestTicket1681(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1681
TestTicket1682 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket1682() - Constructor for class com.bigdata.rdf.sail.TestTicket1682
TestTicket1682(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1682
TestTicket1716 - Class in com.bigdata.rdf.sail
Test suite for an issue where IV resolution of invalid numeric literal fails
TestTicket1716() - Constructor for class com.bigdata.rdf.sail.TestTicket1716
TestTicket1716(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1716
testTicket1738() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
Variant of scenario sketched in https://jira.blazegraph.com/browse/BLZG-1738,
the problem being that PropertyPathNodes in UPDATE queries are not treated properly.
TestTicket1747 - Class in com.bigdata.rdf.sail
Test suite for an issue where IV resolution of vocabulary terms
interferes with query parsing and deferred IV resolution (
ASTDeferredIVResolution
.
TestTicket1747() - Constructor for class com.bigdata.rdf.sail.TestTicket1747
TestTicket1747(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1747
TestTicket1753 - Class in com.bigdata.rdf.sail
Test suite for an issue where IV resolution of having clause fails
TestTicket1753() - Constructor for class com.bigdata.rdf.sail.TestTicket1753
TestTicket1753(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1753
TestTicket1755 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket1755() - Constructor for class com.bigdata.rdf.sail.TestTicket1755
TestTicket1755(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1755
TestTicket1785 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket1785() - Constructor for class com.bigdata.rdf.sail.TestTicket1785
TestTicket1785(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1785
TestTicket1788 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket1788() - Constructor for class com.bigdata.rdf.sail.TestTicket1788
TestTicket1788(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1788
TestTicket1875 - Class in com.bigdata.rdf.sail
Test suite for an issue where IV resolution of RDR statements was not completed
TestTicket1875() - Constructor for class com.bigdata.rdf.sail.TestTicket1875
TestTicket1875(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1875
TestTicket1889 - Class in com.bigdata.rdf.sail
This test case covers 2 ArrayIndexOutOfBoundsException occurrences:
1.
TestTicket1889() - Constructor for class com.bigdata.rdf.sail.TestTicket1889
TestTicket1889(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1889
TestTicket1889_2 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket1889_2() - Constructor for class com.bigdata.rdf.sail.TestTicket1889_2
TestTicket1889_2(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1889_2
TestTicket1893 - Class in com.bigdata.rdf.sail
TestTicket1893() - Constructor for class com.bigdata.rdf.sail.TestTicket1893
TestTicket1893(String) - Constructor for class com.bigdata.rdf.sail.TestTicket1893
TestTicket1899 - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for a NotMaterializedException caused by HTree hash index built.
TestTicket1899() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
TestTicket1899(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket1899
TestTicket2043 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket2043() - Constructor for class com.bigdata.rdf.sail.TestTicket2043
TestTicket2043(String) - Constructor for class com.bigdata.rdf.sail.TestTicket2043
TestTicket2043b - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket2043b() - Constructor for class com.bigdata.rdf.sail.TestTicket2043b
TestTicket2043b(String) - Constructor for class com.bigdata.rdf.sail.TestTicket2043b
TestTicket2083 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket2083() - Constructor for class com.bigdata.rdf.sail.TestTicket2083
TestTicket2083(String) - Constructor for class com.bigdata.rdf.sail.TestTicket2083
TestTicket275 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket275() - Constructor for class com.bigdata.rdf.sail.TestTicket275
TestTicket275(String) - Constructor for class com.bigdata.rdf.sail.TestTicket275
TestTicket276 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket276() - Constructor for class com.bigdata.rdf.sail.TestTicket276
TestTicket276(String) - Constructor for class com.bigdata.rdf.sail.TestTicket276
TestTicket348 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket348() - Constructor for class com.bigdata.rdf.sail.TestTicket348
TestTicket348(String) - Constructor for class com.bigdata.rdf.sail.TestTicket348
TestTicket353 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket353() - Constructor for class com.bigdata.rdf.sail.TestTicket353
TestTicket353(String) - Constructor for class com.bigdata.rdf.sail.TestTicket353
TestTicket355 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket355() - Constructor for class com.bigdata.rdf.sail.TestTicket355
TestTicket355(String) - Constructor for class com.bigdata.rdf.sail.TestTicket355
TestTicket422 - Class in com.bigdata.rdf.sail
TestTicket422() - Constructor for class com.bigdata.rdf.sail.TestTicket422
TestTicket422(String) - Constructor for class com.bigdata.rdf.sail.TestTicket422
TestTicket4249 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket4249() - Constructor for class com.bigdata.rdf.sail.TestTicket4249
TestTicket4249(String) - Constructor for class com.bigdata.rdf.sail.TestTicket4249
TestTicket4323 - Class in com.bigdata.rdf.sparql.ast.eval
TestTicket4323() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket4323
TestTicket4323(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket4323
TestTicket473 - Class in com.bigdata.rdf.sail
TestTicket473() - Constructor for class com.bigdata.rdf.sail.TestTicket473
TestTicket473(String) - Constructor for class com.bigdata.rdf.sail.TestTicket473
TestTicket5590 - Class in com.bigdata.rdf.sparql.ast.eval
Problems with negated path expressions.
TestTicket5590() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket5590
TestTicket5590(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket5590
testTicket567() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
Unit test for
testTicket567() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
Unit test for
testTicket571() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
In the ticket, the source file contains the following triples.
testTicket571b() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
Variant of test 571 without blank nodes.
testTicket571Standalone() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTestv2
TestTicket581 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket581() - Constructor for class com.bigdata.rdf.sail.TestTicket581
TestTicket581(String) - Constructor for class com.bigdata.rdf.sail.TestTicket581
TestTicket610 - Class in com.bigdata.rdf.sail
To run this test case, specify the following JVM property:
-DtestClass=com.bigdata.rdf.sail.TestBigdataSailWithoutSids
TestTicket610() - Constructor for class com.bigdata.rdf.sail.TestTicket610
TestTicket610(String) - Constructor for class com.bigdata.rdf.sail.TestTicket610
TestTicket632 - Class in com.bigdata.rdf.sail
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.
TestTicket632() - Constructor for class com.bigdata.rdf.sail.TestTicket632
TestTicket632(String) - Constructor for class com.bigdata.rdf.sail.TestTicket632
TestTicket647 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket647() - Constructor for class com.bigdata.rdf.sail.TestTicket647
TestTicket647(String) - Constructor for class com.bigdata.rdf.sail.TestTicket647
testTicket653() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Tests rewriting of a modified form of ticket #653 (i.e., the
corresponding SELECT query).
TestTicket669 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket669() - Constructor for class com.bigdata.rdf.sail.TestTicket669
TestTicket669(String) - Constructor for class com.bigdata.rdf.sail.TestTicket669
TestTicket693 - Class in com.bigdata.rdf.sail
Unit test template for use in submission of bugs.
TestTicket693() - Constructor for class com.bigdata.rdf.sail.TestTicket693
TestTicket693(String) - Constructor for class com.bigdata.rdf.sail.TestTicket693
TestTicket887 - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for a heisenbug involving BIND.
TestTicket887() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket887
TestTicket887(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket887
TestTicket946 - Class in com.bigdata.rdf.sparql.ast.eval
TestTicket946() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket946
TestTicket946(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTicket946
TestTicket967 - Class in com.bigdata.rdf.sail
Ticket 967 is an EOF exception on high load of HttpClient requests
TestTicket967() - Constructor for class com.bigdata.rdf.sail.TestTicket967
TestTicket967(String) - Constructor for class com.bigdata.rdf.sail.TestTicket967
testTicketBigdataGPU368() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Ticket: https://github.com/SYSTAP/bigdata-gpu/issues/368
ClassCast Exception when Loading LUBM: com.bigdata.rdf.internal.impl.literal.XSDBooleanIV
cannot be cast to com.bigdata.rdf.internal.impl.literal.NumericIV
testTicketBlzg1943() - Method in class com.bigdata.rdf.sail.webapp.TestBLZG1943
testTicketBLZG2042() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Test inlining from BIND clause into property paths, inspired by the case
reported in https://jira.blazegraph.com/browse/BLZG-2042.
testTicketBlzg2079() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Tickets: https://jira.blazegraph.com/browse/BLZG-2079
(duplicate of https://jira.blazegraph.com/browse/BLZG-2085)
=> property path pred+ always delivering results even though there is no matching data
testTicketBlzg2082() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
https://jira.blazegraph.com/browse/BLZG-2082:
one-argument substr produces NPE when combined with GROUP By
testTicketBlzg2085() - Method in class com.bigdata.rdf.sparql.ast.eval.TestTickets
Tickets: https://jira.blazegraph.com/browse/BLZG-2085
(duplicate of https://jira.blazegraph.com/browse/BLZG-2079)
=> property path pred+ always delivering results even though there is no matching data
testTicketBlzg463a() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Explain hint rendering & bottom up rewriting broken for subqueries,
see https://jira.blazegraph.com/browse/BLZG-1463.
testTicketBlzg463b() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Explain hint rendering & bottom up rewriting broken for subqueries,
see https://jira.blazegraph.com/browse/BLZG-1463.
testTicketBlzg463c() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Explain hint rendering & bottom up rewriting broken for subqueries,
see https://jira.blazegraph.com/browse/BLZG-1463.
testTicketBlzg463d() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Variant of testBottomUpSemanticsExplainHint06, motivated by the fix
made in https://jira.blazegraph.com/browse/BLZG-1463: the idea is to
test a non-complex BIND expression (not containing CONCAT etc.) and
whether this is reported correctly.
TestTickets - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for tickets at
trac .
TestTickets() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTickets
TestTickets(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTickets
testTimedOffer() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed offer times out if full and elements not taken
testTimedOffer() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
timed offer times out if full and elements not taken
testTimedOfferFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed offerFirst times out if full and elements not taken
testTimedOfferLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed offerLast times out if full and elements not taken
testTimedPoll() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed poll with nonzero timeout succeeds when non-empty, else times out
testTimedPoll() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
timed poll with nonzero timeout succeeds when non-empty, else times out
testTimedPoll0() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed poll with zero timeout succeeds when non-empty, else times out
testTimedPoll0() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
timed poll with zero timeout succeeds when non-empty, else times out
testTimedPollFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed pollFirst with nonzero timeout succeeds when non-empty, else times out
testTimedPollFirst0() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed pollFirst with zero timeout succeeds when non-empty, else times out
testTimedPollFirstWithOfferFirst() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed pollFirst before a delayed offerFirst fails; after offerFirst succeeds;
on interruption throws
testTimedPollLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed pollLast with nonzero timeout succeeds when non-empty, else times out
testTimedPollLast0() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed pollLast with zero timeout succeeds when non-empty, else times out
testTimedPollWithOffer() - Method in class com.bigdata.jsr166.BlockingQueueTest
timed poll before a delayed offer fails; after offer succeeds;
on interruption throws
testTimedPollWithOfferLast() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
timed poll before a delayed offerLast fails; after offerLast succeeds;
on interruption throws
TestTimeRange - Class in com.bigdata.counters.query
TestTimeRange() - Constructor for class com.bigdata.counters.query.TestTimeRange
TestTimeRange(String) - Constructor for class com.bigdata.counters.query.TestTimeRange
testTimeZoneRoundTrip() - Method in class org.openrdf.sail.RDFStoreTest
testTMAdd() - Method in class com.bigdata.rdf.sail.TestChangeSets
testTMRetract() - Method in class com.bigdata.rdf.sail.TestChangeSets
testTMUpdate() - Method in class com.bigdata.rdf.sail.TestChangeSets
TestTMUtility - Class in com.bigdata.rdf.rules
Test suite for rule re-writes supporting truth maintenance for the RDF DB.
TestTMUtility() - Constructor for class com.bigdata.rdf.rules.TestTMUtility
TestTMUtility(String) - Constructor for class com.bigdata.rdf.rules.TestTMUtility
testToArray() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
toArray contains all elements in FIFO order
testToArray() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
toArray contains all elements in FIFO order
testToArray1_BadArg() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
toArray(incompatible array type) throws ArrayStoreException
testToArray1_BadArg() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
toArray(incompatible array type) throws ArrayStoreException
testToArray2() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
toArray(a) contains all elements in FIFO order
testToArray2() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
toArray(a) contains all elements in FIFO order
testToArray_NullArg() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
toArray(null) throws NullPointerException
testToArray_NullArg() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
toArray(null) throws NullPointerException
testToConjunctiveValueExpressionMethod() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTFilterNormalizationOptimizer
Test the ASTFilterNormalizationOptimizer#toConjunctiveValueExpression(List)
method.
testToString() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
toString contains toStrings of elements
testToString() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
toString contains toStrings of elements
TestTouch - Class in com.bigdata.btree
TestTouch() - Constructor for class com.bigdata.btree.TestTouch
TestTouch(String) - Constructor for class com.bigdata.btree.TestTouch
TestTPS - Class in com.bigdata.sparse
Test of
TPS
(property timestamp set implementation).
TestTPS() - Constructor for class com.bigdata.sparse.TestTPS
TestTPS(String) - Constructor for class com.bigdata.sparse.TestTPS
testTransactionIsolation() - Method in class org.openrdf.repository.RepositoryConnectionTest
testTransactionIsolationForRead() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestTransactionService - Class in com.bigdata.journal
TestTransactionService() - Constructor for class com.bigdata.journal.TestTransactionService
TestTransactionService(String) - Constructor for class com.bigdata.journal.TestTransactionService
TestTransactionService.MockTransactionService - Class in com.bigdata.journal
TestTransactionService.MockTransactionService(Properties) - Constructor for class com.bigdata.journal.TestTransactionService.MockTransactionService
TestTransactionSupport - Class in com.bigdata.journal
TestTransactionSupport() - Constructor for class com.bigdata.journal.TestTransactionSupport
TestTransactionSupport(String) - Constructor for class com.bigdata.journal.TestTransactionSupport
TestTransientBTree - Class in com.bigdata.btree
Unit tests for transient
BTree
s (no backing store).
TestTransientBTree() - Constructor for class com.bigdata.btree.TestTransientBTree
TestTransientBTree(String) - Constructor for class com.bigdata.btree.TestTransientBTree
TestTransientHTree - Class in com.bigdata.htree
Unit tests for transient
HTree
s (no backing store).
TestTransientHTree() - Constructor for class com.bigdata.htree.TestTransientHTree
TestTransientHTree(String) - Constructor for class com.bigdata.htree.TestTransientHTree
TestTransientJournal - Class in com.bigdata.journal
TestTransientJournal() - Constructor for class com.bigdata.journal.TestTransientJournal
TestTransientJournal(String) - Constructor for class com.bigdata.journal.TestTransientJournal
TestTransientJournal.TestMRMW - Class in com.bigdata.journal
TestTransientJournal.TestMRMW() - Constructor for class com.bigdata.journal.TestTransientJournal.TestMRMW
TestTransientJournal.TestMRMW(String) - Constructor for class com.bigdata.journal.TestTransientJournal.TestMRMW
TestTransientJournal.TestMROW - Class in com.bigdata.journal
TestTransientJournal.TestMROW() - Constructor for class com.bigdata.journal.TestTransientJournal.TestMROW
TestTransientJournal.TestMROW(String) - Constructor for class com.bigdata.journal.TestTransientJournal.TestMROW
TestTransientJournal.TestRawStore - Class in com.bigdata.journal
TestTransientJournal.TestRawStore() - Constructor for class com.bigdata.journal.TestTransientJournal.TestRawStore
TestTransientJournal.TestRawStore(String) - Constructor for class com.bigdata.journal.TestTransientJournal.TestRawStore
TestTriplePatternBuilder - Class in com.bigdata.rdf.sail.sparql
Test suite for building up triple patterns, including those which are covered
by the property paths extension in SPARQL 1.1 (a triple pattern which a
constant in the predicate position is treated by the sesame SPARQL grammar as
a degenerate case of a property path.)
TestTriplePatternBuilder() - Constructor for class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
TestTriplePatternBuilder(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestTriplePatternBuilder
TestTripleStore - Class in com.bigdata.rdf.store
TestTripleStore() - Constructor for class com.bigdata.rdf.store.TestTripleStore
TestTripleStore(String) - Constructor for class com.bigdata.rdf.store.TestTripleStore
TestTripleStoreBasics - Class in com.bigdata.rdf.store
Aggregates test that are run for each
ITripleStore
implementation.
TestTripleStoreBasics() - Constructor for class com.bigdata.rdf.store.TestTripleStoreBasics
TestTruthMaintenance - Class in com.bigdata.rdf.rules
TestTruthMaintenance() - Constructor for class com.bigdata.rdf.rules.TestTruthMaintenance
TestTruthMaintenance(String) - Constructor for class com.bigdata.rdf.rules.TestTruthMaintenance
TestTuple<E> - Class in com.bigdata.btree
Test helper for a tuple with static data.
TestTuple(Object, E) - Constructor for class com.bigdata.btree.TestTuple
TestTuple(int, Object, E) - Constructor for class com.bigdata.btree.TestTuple
TestTuple(int, Object, E, boolean, long) - Constructor for class com.bigdata.btree.TestTuple
TestTuple(int, ITupleSerializer<Object, E>, Object, E, boolean, long) - Constructor for class com.bigdata.btree.TestTuple
TestTuple(int, ITupleSerializer<Object, E>, byte[], byte[], boolean, long) - Constructor for class com.bigdata.btree.TestTuple
TestTupleFilters - Class in com.bigdata.btree.filter
TestTupleFilters() - Constructor for class com.bigdata.btree.filter.TestTupleFilters
TestTupleFilters(String) - Constructor for class com.bigdata.btree.filter.TestTupleFilters
TestTwoPropertyPaths734 - Class in com.bigdata.rdf.sparql.ast.eval
Tests concerning:
TestTwoPropertyPaths734() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTwoPropertyPaths734
TestTwoPropertyPaths734(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestTwoPropertyPaths734
TestTx - Class in com.bigdata.journal
Test suite for fully-isolated read-write transactions.
TestTx() - Constructor for class com.bigdata.journal.TestTx
TestTx(String) - Constructor for class com.bigdata.journal.TestTx
TestTxCreate - Class in com.bigdata.rdf.sail
Unit test for the creation of a Sail with isolatable indices.
TestTxCreate() - Constructor for class com.bigdata.rdf.sail.TestTxCreate
TestTxCreate(String) - Constructor for class com.bigdata.rdf.sail.TestTxCreate
TestTxDag - Class in com.bigdata.concurrent
Test suite for online transaction deadlock algorithm.
TestTxDag() - Constructor for class com.bigdata.concurrent.TestTxDag
TestTxDag(String) - Constructor for class com.bigdata.concurrent.TestTxDag
testTypeCastException() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Casting of non-URI to URI results in proper exception.
TestUnconfiguredAnalyzerFactory - Class in com.bigdata.search
TestUnconfiguredAnalyzerFactory() - Constructor for class com.bigdata.search.TestUnconfiguredAnalyzerFactory
TestUnconfiguredAnalyzerFactory(String) - Constructor for class com.bigdata.search.TestUnconfiguredAnalyzerFactory
testUnicodeCleanAndRegex() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
This test is based on a forum post.
testUnicodeCleanAndRegex() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
This test is based on a forum post.
TestUnicodeCompressor - Class in com.bigdata.io.compression
TestUnicodeCompressor() - Constructor for class com.bigdata.io.compression.TestUnicodeCompressor
TestUnicodeCompressor(String) - Constructor for class com.bigdata.io.compression.TestUnicodeCompressor
TestUnicodeHelper - Class in com.bigdata.io.compression
TestUnicodeHelper() - Constructor for class com.bigdata.io.compression.TestUnicodeHelper
TestUnicodeHelper(String) - Constructor for class com.bigdata.io.compression.TestUnicodeHelper
TestUnion - Class in com.bigdata.bop.controller
TestUnion() - Constructor for class com.bigdata.bop.controller.TestUnion
TestUnion(String) - Constructor for class com.bigdata.bop.controller.TestUnion
TestUnion - Class in com.bigdata.rdf.rules
Unit test for processing of queries consisting of
IProgram
s
comprised of more than one
IRule
.
TestUnion() - Constructor for class com.bigdata.rdf.rules.TestUnion
TestUnion(String) - Constructor for class com.bigdata.rdf.rules.TestUnion
testUnion() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestIVariableBindingRequirements
Test interface implementation for UNION nodes.
testUnion() - Method in class com.bigdata.rdf.sparql.ast.TestAST
select *
where {
{
predicate1 .
TestUnionMinus - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for UNION and MINUS combined, see
https://sourceforge.net/apps/trac/bigdata/ticket/767
TestUnionMinus() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestUnionMinus
TestUnionMinus(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestUnionMinus
TestUnions - Class in com.bigdata.rdf.sail
Unit tests the UNION aspects of the
BigdataSail
implementation.
TestUnions() - Constructor for class com.bigdata.rdf.sail.TestUnions
TestUnions(String) - Constructor for class com.bigdata.rdf.sail.TestUnions
testUnions() - Method in class com.bigdata.rdf.sail.TestUnions
Tests mapping of UNIONS in SPARQL onto unions in bigdata rules.
TestUnions - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for UNION.
TestUnions() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestUnions
TestUnions(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestUnions
testUnisolatedAllocationContextRecycling() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Need to test the handling of aborted Unisolated connections and specifically the
logic behind freed addresses.
testUnisolatedIndexWriteRate() - Method in class com.bigdata.journal.BenchmarkJournalWriteRate
Test the index write rate using an index that supports transactional
isolation but without transactional isolation using 32 bit integer keys
and 128 byte values for the index entries.
TestUnisolatedWriteTasks - Class in com.bigdata.journal
Correctness test suite for unisolated writes on one or more indices.
TestUnisolatedWriteTasks() - Constructor for class com.bigdata.journal.TestUnisolatedWriteTasks
TestUnisolatedWriteTasks(String) - Constructor for class com.bigdata.journal.TestUnisolatedWriteTasks
testUnivBenchOWL() - Method in class com.bigdata.gom.TestOWLSkin
testUnknownDatatypeRejected() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceConfigurationCustomDatatype
Correct rejection test with search query for datatype that is not registered.
testUnknwonPredicate() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluation
BLZG-1718: exception if search predicate is unknown
testUnpack() - Method in class com.bigdata.io.LongPackerTestCase
testUnpack() - Method in class com.bigdata.io.ShortPackerTestCase
testUnpack() - Method in class com.bigdata.io.TestLongPacker
testUnpack() - Method in class com.bigdata.io.TestShortPacker
testUnsatisfiableMinusExplainHint01() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is attached for unsatisfiable MINUS:
SELECT * WHERE { ?s ?p ?o MINUS { ?a ?b ?c } }
testUnsatisfiableMinusExplainHint02() - Method in class com.bigdata.rdf.sparql.ast.eval.TestExplainHints
Assert that the explain hint is not attached for satisfiable MINUS:
SELECT * WHERE { ?s ?p ?o MINUS { ?s ?b ?c } }
TestUnsigned - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for xsd:unsigned handling.
TestUnsigned() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestUnsigned
TestUnsigned(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestUnsigned
testUnsignedInteger() - Method in class com.bigdata.rdf.store.TestInlineURIs
TestUnsignedIntegerIVs - Class in com.bigdata.rdf.internal
Test suite for xsd:nonPositiveInteger, xsd:negativeInteger,
xsd:nonNegativeInteger, and xsd:positiveInteger.
TestUnsignedIntegerIVs() - Constructor for class com.bigdata.rdf.internal.TestUnsignedIntegerIVs
TestUnsignedIntegerIVs(String) - Constructor for class com.bigdata.rdf.internal.TestUnsignedIntegerIVs
TestUnsignedIVs - Class in com.bigdata.rdf.internal
Test suite for the xsd:unsigned IV which are internally represented by Java
primitives (xsd:unsignedByte, xsd:unsignedShort, xsd:unsignedInt, and
xsd:unsignedLong).
TestUnsignedIVs() - Constructor for class com.bigdata.rdf.internal.TestUnsignedIVs
TestUnsignedIVs(String) - Constructor for class com.bigdata.rdf.internal.TestUnsignedIVs
TestUnsynchronizedArrayBuffer - Class in com.bigdata.relation.accesspath
TestUnsynchronizedArrayBuffer() - Constructor for class com.bigdata.relation.accesspath.TestUnsynchronizedArrayBuffer
TestUnsynchronizedArrayBuffer(String) - Constructor for class com.bigdata.relation.accesspath.TestUnsynchronizedArrayBuffer
TestUnsynchronizedUnboundedChunkBuffer - Class in com.bigdata.relation.accesspath
TestUnsynchronizedUnboundedChunkBuffer() - Constructor for class com.bigdata.relation.accesspath.TestUnsynchronizedUnboundedChunkBuffer
TestUnsynchronizedUnboundedChunkBuffer(String) - Constructor for class com.bigdata.relation.accesspath.TestUnsynchronizedUnboundedChunkBuffer
testUpdateBaseURI() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestUpdateBootstrap - Class in com.bigdata.rdf.sparql.ast.eval.update
Bootstrapped test suite for core UPDATE functionality based on BOP
evaluation.
TestUpdateBootstrap() - Constructor for class com.bigdata.rdf.sparql.ast.eval.update.TestUpdateBootstrap
TestUpdateBootstrap(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.update.TestUpdateBootstrap
TestUpdateExprBuilder - Class in com.bigdata.rdf.sail.sparql
TestUpdateExprBuilder() - Constructor for class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
TestUpdateExprBuilder(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder
TestUpdateExprBuilder2 - Class in com.bigdata.rdf.sail.sparql
TestUpdateExprBuilder2() - Constructor for class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder2
TestUpdateExprBuilder2(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestUpdateExprBuilder2
testUpdateGet() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testUpdateLiteralsWithLanguageTags() - Method in class com.bigdata.rdf.sail.tck.BigdataSPARQLUpdateTest
SPARQL update test for literals with language tags, cf.
testUpdatePost() - Method in class com.bigdata.rdf.sail.webapp.TestPostNotURLEncoded
testUpdatePostEncode() - Method in class com.bigdata.rdf.sail.webapp.TestRelease123Protocol
testUpdateSequenceDeleteInsert() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testUpdateSequenceInsertDelete() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testUpdateSequenceInsertDelete2() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testUpdateSequenceInsertDelete2() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testUpdateSequenceInsertDeleteExample9() - Method in class com.bigdata.rdf.sail.webapp.TestSparqlUpdate
testUpdateSequenceInsertDeleteExample9() - Method in class org.openrdf.query.parser.sparql.SPARQLUpdateTest
testUpdateThroughput() - Method in class com.bigdata.gom.TestGOM
Throughput test for updates.
testUpdateThroughput() - Method in class com.bigdata.gom.TestRemoteGOM
Throughput test for updates.
testURI - Variable in class org.openrdf.query.parser.sparql.manifest.SPARQLQueryTest
testURI - Variable in class org.openrdf.query.parser.sparql.manifest.SPARQLUpdateConformanceTest
testUriExtensionIV() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
TestURIExtensionIV - Class in com.bigdata.rdf.internal
TestURIExtensionIV() - Constructor for class com.bigdata.rdf.internal.TestURIExtensionIV
TestURIExtensionIV(String) - Constructor for class com.bigdata.rdf.internal.TestURIExtensionIV
TestURIExtensionIV.MockVocabulary - Class in com.bigdata.rdf.internal
TestURIExtensionIV.MockVocabulary() - Constructor for class com.bigdata.rdf.internal.TestURIExtensionIV.MockVocabulary
De-serialization.
TestURIExtensionIV.MockVocabulary(String) - Constructor for class com.bigdata.rdf.internal.TestURIExtensionIV.MockVocabulary
TestUriInlineFactory_BLZG1591 - Class in com.bigdata.rdf.vocab
TestUriInlineFactory_BLZG1591() - Constructor for class com.bigdata.rdf.vocab.TestUriInlineFactory_BLZG1591
testURIs - Static variable in class com.bigdata.rdf.sail.tck.BigdataSparqlTest
An array of URIs for tests to be run.
testURISerialization() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestUtilMethods - Class in com.bigdata.btree
Test suite for various utility methods, both static and instance, on
AbstractNode
.
TestUtilMethods() - Constructor for class com.bigdata.btree.TestUtilMethods
TestUtilMethods(String) - Constructor for class com.bigdata.btree.TestUtilMethods
testValidAdditionalPrefixes() - Method in class com.bigdata.rdf.sail.sparql.TestPrefixDeclProcessor
testValidationWithIncomingBindings() - Method in class com.bigdata.rdf.sail.TestSearchQuery
FIXME This should be migrated to the data-driven test suite in
TestSearch
.
TestValueExprBuilder - Class in com.bigdata.rdf.sail.sparql
TestValueExprBuilder() - Constructor for class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
TestValueExprBuilder(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestValueExprBuilder
testValueExtraction() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialServiceEvaluationQuads
Test extraction of index dimensions in quads mode:
SELECT * WHERE {
SERVICE geo:search {
?res geo:search "inCircle" .
testValueRoundTrip(Resource, URI, Value) - Method in class com.bigdata.rdf.sail.tck.BigdataStoreTest
testValueRoundTrip(Resource, URI, Value) - Method in class org.openrdf.sail.RDFStoreTest
testValueRoundTrip1() - Method in class org.openrdf.sail.RDFStoreTest
testValueRoundTrip2() - Method in class org.openrdf.sail.RDFStoreTest
testValueRoundTrip3() - Method in class org.openrdf.sail.RDFStoreTest
testValueRoundTrip4() - Method in class org.openrdf.sail.RDFStoreTest
testValueRoundTrip5() - Method in class org.openrdf.sail.RDFStoreTest
testValues() - Method in class com.bigdata.gom.TestGPO
testValuesComplexExogeneousMappingInSubquery() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTStaticBindingsOptimizer
Assert that even for complex exogeneous mappings, variables that map
to the same value in all cases are inlined properly.
testValuesInOptional() - Method in class com.bigdata.rdf.sail.tck.BigdataComplexSparqlQueryTest
The one is fixed now.
testValuesInOptional() - Method in class org.openrdf.query.parser.sparql.ComplexSPARQLQueryTest
testValuesPlacement01() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
testValuesPlacement02() - Method in class com.bigdata.rdf.sparql.ast.optimizers.TestASTJoinGroupOrderOptimizer
VALUES claused placed early whenever it binds values that are reused
by other nodes such as BINDs.
TestValueType - Class in com.bigdata.sparse
TestValueType() - Constructor for class com.bigdata.sparse.TestValueType
TestValueType(String) - Constructor for class com.bigdata.sparse.TestValueType
TestVar - Class in com.bigdata.bop
TestVar() - Constructor for class com.bigdata.bop.TestVar
TestVar(String) - Constructor for class com.bigdata.bop.TestVar
testVariableInjectionFailing() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestFulltextSearch
Verify that there is a proper error message when injection variable
is not yet bound.
testVars() - Method in class com.bigdata.bop.bindingSet.TestIBindingSet
TestVerifyAggregates - Class in com.bigdata.rdf.sail.sparql
TestVerifyAggregates() - Constructor for class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
TestVerifyAggregates(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestVerifyAggregates
testVerifyCommitRecordIndex() - Method in class com.bigdata.rwstore.sector.TestMemStore.TestRawStore
Can be tested by removing RWStore call to journal.removeCommitRecordEntries
in freeDeferrals.
testVerifyCommitRecordIndex() - Method in class com.bigdata.rwstore.TestRWJournal.TestRawStore
Can be tested by removing RWStore call to journal.removeCommitRecordEntries
in freeDeferrals.
TestVirtualGraphs - Class in com.bigdata.rdf.sail.sparql
Test suite for the VIRTUAL GRAPHS
SPARQL extension.
TestVirtualGraphs() - Constructor for class com.bigdata.rdf.sail.sparql.TestVirtualGraphs
TestVirtualGraphs(String) - Constructor for class com.bigdata.rdf.sail.sparql.TestVirtualGraphs
TestVirtualGraphs - Class in com.bigdata.rdf.sparql.ast.eval
Test suite for VIRTUAL GRAPHS support.
TestVirtualGraphs() - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestVirtualGraphs
TestVirtualGraphs(String) - Constructor for class com.bigdata.rdf.sparql.ast.eval.TestVirtualGraphs
TestVocabulary - Class in com.bigdata.rdf.lexicon
TestVocabulary() - Constructor for class com.bigdata.rdf.lexicon.TestVocabulary
TestVocabulary(String) - Constructor for class com.bigdata.rdf.lexicon.TestVocabulary
TestVocabulary - Class in com.bigdata.rdf.vocab
TestVocabulary() - Constructor for class com.bigdata.rdf.vocab.TestVocabulary
TestVocabulary(String) - Constructor for class com.bigdata.rdf.vocab.TestVocabulary
TestVocabulary_BLZG1591 - Class in com.bigdata.rdf.vocab
A
Vocabulary
covering the ontologies used by LUBM.
TestVocabulary_BLZG1591() - Constructor for class com.bigdata.rdf.vocab.TestVocabulary_BLZG1591
De-serialization ctor.
TestVocabulary_BLZG1591(String) - Constructor for class com.bigdata.rdf.vocab.TestVocabulary_BLZG1591
TestVocabularyDecl_BLZG1591 - Class in com.bigdata.rdf.vocab
TestVocabularyDecl_BLZG1591() - Constructor for class com.bigdata.rdf.vocab.TestVocabularyDecl_BLZG1591
testVocabUriByteIV() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
TestVocabURIByteIV - Class in com.bigdata.rdf.internal
TestVocabURIByteIV() - Constructor for class com.bigdata.rdf.internal.TestVocabURIByteIV
TestVocabURIByteIV(String) - Constructor for class com.bigdata.rdf.internal.TestVocabURIByteIV
testVocabUriShortIV() - Method in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
TestVTE - Class in com.bigdata.rdf.internal
TestVTE() - Constructor for class com.bigdata.rdf.internal.TestVTE
TestVTE(String) - Constructor for class com.bigdata.rdf.internal.TestVTE
TestWarmupJournal - Class in com.bigdata.journal
TestWarmupJournal() - Constructor for class com.bigdata.journal.TestWarmupJournal
TestWarmupJournal(String) - Constructor for class com.bigdata.journal.TestWarmupJournal
testWeaklyConsistentIteration() - Method in class com.bigdata.jsr166.LinkedBlockingDequeTest
Modifications do not cause iterators to fail
testWeaklyConsistentIteration() - Method in class com.bigdata.jsr166.LinkedBlockingQueueTest
Modifications do not cause iterators to fail
testWhileIgnoringExplainHints() - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
testWithMetadata() - Method in class com.bigdata.rdf.sail.TestSearchQuery
FIXME This should be migrated to the data-driven test suite in
TestSearch
.
testWKTLiteral01() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Simple rectangle query looking for WKT-style literals.
testWKTLiteral02() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Simple rectangle query looking for WKT-style literal, with
custom deserialization of geo:locationValue.
testWKTLiteral03() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Simple rectangle query looking for WKT-style literals.
testWKTLiteral04() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Simple circle query looking for WKT-style literal, with
custom deserialization of geo:locationValue.
testWKTLiteral05() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Simple circle query looking for WKT-style literal, with
custom deserialization of full literal.
testWKTLiteral06() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Test passing in of WKT point as parameter of geo:spatialCircleCenter.
testWKTLiteral07() - Method in class com.bigdata.rdf.sparql.ast.eval.service.TestGeoSpatialCustomSerializerWKT
Test passing in of WKT point as parameter of geo:spatialRectangleSouthWest
and geo:spatialRectangleNorthEast.
TestWormAddressManager - Class in com.bigdata.rawstore
TestWormAddressManager() - Constructor for class com.bigdata.rawstore.TestWormAddressManager
TestWormAddressManager(String) - Constructor for class com.bigdata.rawstore.TestWormAddressManager
TestWORMStrategy - Class in com.bigdata.journal
TestWORMStrategy() - Constructor for class com.bigdata.journal.TestWORMStrategy
TestWORMStrategy(String) - Constructor for class com.bigdata.journal.TestWORMStrategy
TestWORMStrategy.TestInterrupts - Class in com.bigdata.journal
TestWORMStrategy.TestInterrupts() - Constructor for class com.bigdata.journal.TestWORMStrategy.TestInterrupts
TestWORMStrategy.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestWORMStrategy.TestInterrupts
TestWORMStrategy.TestMRMW - Class in com.bigdata.journal
TestWORMStrategy.TestMRMW() - Constructor for class com.bigdata.journal.TestWORMStrategy.TestMRMW
TestWORMStrategy.TestMRMW(String) - Constructor for class com.bigdata.journal.TestWORMStrategy.TestMRMW
TestWORMStrategy.TestMROW - Class in com.bigdata.journal
TestWORMStrategy.TestMROW() - Constructor for class com.bigdata.journal.TestWORMStrategy.TestMROW
TestWORMStrategy.TestMROW(String) - Constructor for class com.bigdata.journal.TestWORMStrategy.TestMROW
TestWORMStrategy.TestRawStore - Class in com.bigdata.journal
TestWORMStrategy.TestRawStore() - Constructor for class com.bigdata.journal.TestWORMStrategy.TestRawStore
TestWORMStrategy.TestRawStore(String) - Constructor for class com.bigdata.journal.TestWORMStrategy.TestRawStore
TestWORMStrategyNoCache - Class in com.bigdata.journal
Test suite for
WORMStrategy
journal with the write cache disabled.
TestWORMStrategyNoCache() - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache
TestWORMStrategyNoCache(String) - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache
TestWORMStrategyNoCache.TestInterrupts - Class in com.bigdata.journal
TestWORMStrategyNoCache.TestInterrupts() - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestInterrupts
TestWORMStrategyNoCache.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestInterrupts
TestWORMStrategyNoCache.TestMRMW - Class in com.bigdata.journal
TestWORMStrategyNoCache.TestMRMW() - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestMRMW
TestWORMStrategyNoCache.TestMRMW(String) - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestMRMW
TestWORMStrategyNoCache.TestMROW - Class in com.bigdata.journal
TestWORMStrategyNoCache.TestMROW() - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestMROW
TestWORMStrategyNoCache.TestMROW(String) - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestMROW
TestWORMStrategyNoCache.TestRawStore - Class in com.bigdata.journal
TestWORMStrategyNoCache.TestRawStore() - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestRawStore
TestWORMStrategyNoCache.TestRawStore(String) - Constructor for class com.bigdata.journal.TestWORMStrategyNoCache.TestRawStore
TestWORMStrategyOneCacheBuffer - Class in com.bigdata.journal
TestWORMStrategyOneCacheBuffer() - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer
TestWORMStrategyOneCacheBuffer(String) - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer
TestWORMStrategyOneCacheBuffer.TestInterrupts - Class in com.bigdata.journal
TestWORMStrategyOneCacheBuffer.TestInterrupts() - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestInterrupts
TestWORMStrategyOneCacheBuffer.TestInterrupts(String) - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestInterrupts
TestWORMStrategyOneCacheBuffer.TestMRMW - Class in com.bigdata.journal
TestWORMStrategyOneCacheBuffer.TestMRMW() - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestMRMW
TestWORMStrategyOneCacheBuffer.TestMRMW(String) - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestMRMW
TestWORMStrategyOneCacheBuffer.TestMROW - Class in com.bigdata.journal
TestWORMStrategyOneCacheBuffer.TestMROW() - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestMROW
TestWORMStrategyOneCacheBuffer.TestMROW(String) - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestMROW
TestWORMStrategyOneCacheBuffer.TestRawStore - Class in com.bigdata.journal
TestWORMStrategyOneCacheBuffer.TestRawStore() - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestRawStore
TestWORMStrategyOneCacheBuffer.TestRawStore(String) - Constructor for class com.bigdata.journal.TestWORMStrategyOneCacheBuffer.TestRawStore
TestWORMWriteCacheService - Class in com.bigdata.io.writecache
TestWORMWriteCacheService() - Constructor for class com.bigdata.io.writecache.TestWORMWriteCacheService
TestWORMWriteCacheService(String) - Constructor for class com.bigdata.io.writecache.TestWORMWriteCacheService
TestWriteCache - Class in com.bigdata.io.writecache
TestWriteCache() - Constructor for class com.bigdata.io.writecache.TestWriteCache
TestWriteCache(String) - Constructor for class com.bigdata.io.writecache.TestWriteCache
TestWriteCacheServiceLifetime - Class in com.bigdata.io.writecache
These tests exercise the lifetime semantics of a WriteCacheService.
TestWriteCacheServiceLifetime() - Constructor for class com.bigdata.io.writecache.TestWriteCacheServiceLifetime
TestWriteCacheServiceLifetime(String) - Constructor for class com.bigdata.io.writecache.TestWriteCacheServiceLifetime
TestXMLBuilder - Class in com.bigdata.rdf.sail.webapp
TestXMLBuilder() - Constructor for class com.bigdata.rdf.sail.webapp.TestXMLBuilder
TestXMLBuilder(String) - Constructor for class com.bigdata.rdf.sail.webapp.TestXMLBuilder
testXMLBuilder() - Method in class com.bigdata.rdf.sail.webapp.TestXMLBuilder
testXmlCalendarZ() - Method in class org.openrdf.repository.RepositoryConnectionTest
TestXPathFunctions - Class in com.bigdata.rdf.internal
Test suite for various xpath numeric functions.
TestXPathFunctions() - Constructor for class com.bigdata.rdf.internal.TestXPathFunctions
TestXPathFunctions(String) - Constructor for class com.bigdata.rdf.internal.TestXPathFunctions
testXsdStr() - Method in class com.bigdata.rdf.sail.TestMaterialization
TestXXXCShardSplitHandler - Class in com.bigdata.rdf.spo
TestXXXCShardSplitHandler() - Constructor for class com.bigdata.rdf.spo.TestXXXCShardSplitHandler
TestXXXCShardSplitHandler(String) - Constructor for class com.bigdata.rdf.spo.TestXXXCShardSplitHandler
testZIndexOrderingMixed() - Method in class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
Test z-order string construction by means of a simple, two dimensional
index with mixed negative and positive integer values.
testZIndexOrderingMixedWithRangeAdjustment() - Method in class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
Test z-order string construction by means of a simple, two dimensional
index with mixed negative and positive integer values, with range
adjustment encoded in the datatype.
testZIndexOrderingPositive() - Method in class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
Test z-order string construction by means of a simple, two dimensional
index with positive integer values.
testZIndexOrderingPositiveWithRangeAdjustment() - Method in class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
Test z-order string construction by means of a simple, two dimensional
index with positive integer values, with range adjustment encoded in
the datatype.
testZipStreams() - Method in class com.bigdata.rawstore.AbstractRawStoreTestCase
This test exercises the stream interface and serves as an example of
stream usage for compressed IO.
testZipStreams() - Method in class com.bigdata.rwstore.sector.TestMemoryManagerStreams
TestZOrderRangeScanUtility - Class in com.bigdata.rdf.internal
Test for utility functionalities required for zOrder index construction,
such as
ZOrderRangeScanUtil
.
TestZOrderRangeScanUtility() - Constructor for class com.bigdata.rdf.internal.TestZOrderRangeScanUtility
TeV - Static variable in class cern.clhep.Units
TEXT - Static variable in class com.bigdata.counters.format.CounterSetFormat
Text properties file using text/plain
and
UTF-8
.
TEXT - Static variable in class com.bigdata.rdf.properties.PropertiesFormat
Text properties file using text/plain
and
UTF-8
.
text(String) - Method in class com.bigdata.rdf.sail.webapp.XMLBuilder.Node
Write out the text.
text - Static variable in class com.bigdata.rdf.vocab.decls.DCTermsVocabularyDecl
TEXT - Static variable in class it.unimi.dsi.parser.Attribute
text - Variable in class it.unimi.dsi.parser.callback.TextExtractor
The text resulting from the parsing process.
TEXT_INDEX - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
Boolean option (default
"true") enables support
for a full text index that may be used to lookup literals by tokens
found in the text of those literals.
TEXT_INDEX_DATATYPE_LITERALS - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
Boolean option enables support for a full text index that may be used
to lookup datatype literals by tokens found in the text of those
literals (default
"true").
TEXT_INDEXER_CLASS - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
TEXTAREA - Static variable in class it.unimi.dsi.parser.Element
TextExtractor - Class in it.unimi.dsi.parser.callback
A callback extracting text and titles.
TextExtractor() - Constructor for class it.unimi.dsi.parser.callback.TextExtractor
TextIndexSubjectCentric - Static variable in class com.bigdata.rdf.sail.webapp.SD
TextIndexValueCentric - Static variable in class com.bigdata.rdf.sail.webapp.SD
TextIndexWriteProc - Class in com.bigdata.search
Writes on the text index.
TextIndexWriteProc() - Constructor for class com.bigdata.search.TextIndexWriteProc
De-serialization constructor.
TextIndexWriteProc(IRabaCoder, IRabaCoder, int, int, byte[][], byte[][], boolean) - Constructor for class com.bigdata.search.TextIndexWriteProc
TextIndexWriteProc.IndexWriteProcConstructor - Class in com.bigdata.search
textNoEncode(String) - Method in class com.bigdata.rdf.sail.webapp.XMLBuilder.Node
Write out the text without encoding for (X)HTML.
TextPattern - Class in it.unimi.dsi.util
QuickSearch matching against a constant string.
TextPattern(CharSequence) - Constructor for class it.unimi.dsi.util.TextPattern
Creates a new case-sensitive
TextPattern
object that can be used to search for the given pattern.
TextPattern(CharSequence, int) - Constructor for class it.unimi.dsi.util.TextPattern
Creates a new
TextPattern
object that can be used to search for the given pattern.
TextRenderer - Class in com.bigdata.counters.render
TextRenderer(URLQueryModel, ICounterSelector) - Constructor for class com.bigdata.counters.render.TextRenderer
TextValueFormatter - Class in com.bigdata.counters.render
TextValueFormatter(URLQueryModel) - Constructor for class com.bigdata.counters.render.TextValueFormatter
TFOOT - Static variable in class it.unimi.dsi.parser.Element
TH - Static variable in class it.unimi.dsi.parser.Element
THEAD - Static variable in class it.unimi.dsi.parser.Element
ThickAsynchronousIterator<E> - Class in com.bigdata.relation.accesspath
ThickAsynchronousIterator(E[]) - Constructor for class com.bigdata.relation.accesspath.ThickAsynchronousIterator
Create a thick iterator.
ThickChunkMessage<E> - Class in com.bigdata.bop.fed
A thick version of this interface in which the chunk is sent inline with the
RMI message.
ThickChunkMessage() - Constructor for class com.bigdata.bop.fed.ThickChunkMessage
De-serialization constructor.
ThickChunkMessage(IQueryClient, UUID, int, int, IBindingSet[]) - Constructor for class com.bigdata.bop.fed.ThickChunkMessage
ThickCloseableIterator<E> - Class in com.bigdata.relation.accesspath
ThickCloseableIterator(E[]) - Constructor for class com.bigdata.relation.accesspath.ThickCloseableIterator
Create a thick iterator.
ThickCloseableIterator(E[], int) - Constructor for class com.bigdata.relation.accesspath.ThickCloseableIterator
Create a thick iterator.
ThickFuture<V> - Class in com.bigdata.service.proxy
ThickFuture(Future<V>) - Constructor for class com.bigdata.service.proxy.ThickFuture
Awaits the
Future
and then makes a serializable record of the
Future
's state.
thisHost - Variable in class com.bigdata.rdf.sail.webapp.lbs.HostTable
The most recent score for this host -or- null
iff there
is not score for this host.
thousandthsOfMinutesEast - Variable in class com.bigdata.rdf.internal.gis.CoordinateDDM
thousandthsOfMinutesNorth - Variable in class com.bigdata.rdf.internal.gis.CoordinateDDM
threadAssertEquals(long, long) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like assertEquals(x, y), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
threadAssertEquals(Object, Object) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like assertEquals(x, y), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
threadAssertFalse(boolean) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like assertFalse(b), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
threadAssertNull(Object) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like assertNull(x), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
threadAssertSame(Object, Object) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like assertSame(x, y), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
threadAssertTrue(boolean) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like assertTrue(b), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
threadChk - Static variable in class com.bigdata.io.ChecksumUtility
threadDump(Appendable) - Static method in class com.bigdata.BigdataStatics
Write a thread dump onto the caller's object.
threadFail(String) - Method in class com.bigdata.jsr166.JSR166TestCase
Just like fail(reason), but additionally recording (using
threadRecordFailure) any AssertionFailedError thrown, so that
the current testcase will fail.
ThreadGuard - Class in com.bigdata.util.concurrent
Pattern used to guard critical regions that await
Condition
s when a
concurrent event may cause the
Condition
to become unsatisfiable.
ThreadGuard() - Constructor for class com.bigdata.util.concurrent.ThreadGuard
ThreadGuard.Guard - Class in com.bigdata.util.concurrent
ThreadGuard.Guard() - Constructor for class com.bigdata.util.concurrent.ThreadGuard.Guard
ThreadLocalBufferFactory<T extends IBuffer<E>,E> - Class in com.bigdata.relation.accesspath
A factory pattern for per-thread objects whose life cycle is tied to some
container.
ThreadLocalBufferFactory() - Constructor for class com.bigdata.relation.accesspath.ThreadLocalBufferFactory
ThreadLocalBufferFactory(int, float, int) - Constructor for class com.bigdata.relation.accesspath.ThreadLocalBufferFactory
threadLocalBuffers - Static variable in class com.bigdata.BigdataStatics
Deprecated.
This is ugly. Remove once the issue has been resolved.
ThreadLocalKeyBuilderFactory - Class in com.bigdata.btree.keys
A thread-local implementation.
ThreadLocalKeyBuilderFactory(IKeyBuilderFactory) - Constructor for class com.bigdata.btree.keys.ThreadLocalKeyBuilderFactory
ThreadLocalRecordCompressorFactory<A extends RecordCompressor> - Class in com.bigdata.io.compression
ThreadLocalRecordCompressorFactory(IRecordCompressorFactory<A>) - Constructor for class com.bigdata.io.compression.ThreadLocalRecordCompressorFactory
ThreadPoolExecutorBaseStatisticsTask - Class in com.bigdata.util.concurrent
Class tracks a variety of information about a
ThreadPoolExecutor
including the moving average of its queue length, queue size, average active
count, etc.
ThreadPoolExecutorBaseStatisticsTask(ThreadPoolExecutor) - Constructor for class com.bigdata.util.concurrent.ThreadPoolExecutorBaseStatisticsTask
ThreadPoolExecutorBaseStatisticsTask(ThreadPoolExecutor, double) - Constructor for class com.bigdata.util.concurrent.ThreadPoolExecutorBaseStatisticsTask
Core impl.
ThreadPoolExecutorStatisticsTask - Class in com.bigdata.util.concurrent
Class tracks a variety of information about a
ThreadPoolExecutor
including the moving average of its queue length, queuing times, etc.
ThreadPoolExecutorStatisticsTask(String, ThreadPoolExecutor) - Constructor for class com.bigdata.util.concurrent.ThreadPoolExecutorStatisticsTask
ThreadPoolExecutorStatisticsTask(String, ThreadPoolExecutor, TaskCounters) - Constructor for class com.bigdata.util.concurrent.ThreadPoolExecutorStatisticsTask
ThreadPoolExecutorStatisticsTask(String, ThreadPoolExecutor, TaskCounters, double) - Constructor for class com.bigdata.util.concurrent.ThreadPoolExecutorStatisticsTask
Core impl.
threadRecordFailure(Throwable) - Method in class com.bigdata.jsr166.JSR166TestCase
Records an exception so that it can be rethrown later in the test
harness thread, triggering a test case failure.
threadShouldThrow() - Method in class com.bigdata.jsr166.JSR166TestCase
Calls threadFail with message "should throw exception".
threadShouldThrow(String) - Method in class com.bigdata.jsr166.JSR166TestCase
Calls threadFail with message "should throw" + exceptionName.
threadUnexpectedException(Throwable) - Method in class com.bigdata.jsr166.JSR166TestCase
three - Variable in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase.NotExistsSetup
three - Static variable in class com.bigdata.jsr166.JSR166TestCase
throwCauses() - Method in class com.bigdata.ha.CommitResponse
Throw out the exception(s).
thumbnail - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
TIME_END - Static variable in interface com.bigdata.service.geospatial.GeoSpatial
End time of the time interval to scan for.
TIME_START - Static variable in interface com.bigdata.service.geospatial.GeoSpatial
Start time of the time interval to scan for.
TIME_VALUE - Static variable in interface com.bigdata.service.geospatial.GeoSpatial
Output variable; if set, this variable is bound to the time component of the search result.
TIMEOUT - Static variable in interface com.bigdata.bop.BOp.Annotations
The timeout for the operator evaluation (milliseconds).
timeout() - Method in class com.bigdata.cache.SynchronizedHardReferenceQueueWithTimeout
The timeout (in nanoseconds) for an entry in the queue.
TIMEOUT - Static variable in class com.bigdata.concurrent.AbstractStressTestNonBlockingLockManager.TestOptions
Maximum amount of time that the test will run (seconds) or ZERO (0)
if there is no timeout.
TIMEOUT - Static variable in class com.bigdata.concurrent.TestLockManager.TestOptions
Maximum amount of time that the test will run (seconds).
TIMEOUT - Static variable in interface com.bigdata.journal.AbstractMRMWTestCase.TestOptions
The timeout for the test.
TIMEOUT - Static variable in interface com.bigdata.journal.StressTestConcurrentTx.TestOptions
The timeout for the test.
TIMEOUT - Static variable in interface com.bigdata.journal.StressTestConcurrentUnisolatedIndices.TestOptions
The timeout for the test (seconds).
TIMEOUT - Static variable in interface com.bigdata.journal.StressTestGroupCommit.TestOptions
The timeout for the test (seconds).
TIMEOUT - Static variable in interface com.bigdata.journal.StressTestUnisolatedReadWriteIndex.TestOptions
The timeout for the test (seconds).
timeout - Variable in class com.bigdata.rdf.sail.bench.NanoSparqlClient.QueryOptions
The connection timeout (ms).
TIMEOUT - Static variable in interface com.bigdata.rdf.sparql.ast.QueryBase.Annotations
The
Long
value giving the time limit for the query
(milliseconds).
TIMEOUT - Static variable in interface com.bigdata.service.fts.FTS
Magic predicate used to query for free text search metadata to set a
deadline in milliseconds on the full text index search (
).
timeout - Static variable in class com.bigdata.service.proxy.ClientAsynchronousIterator
TIMEOUT - Static variable in interface com.bigdata.service.StressTestConcurrent.TestOptions
The timeout for the test.
TimeoutException - Exception in com.bigdata.concurrent
An instance of this class is thrown when a lock could not be obtained within
a specified timeout.
TimeoutException() - Constructor for exception com.bigdata.concurrent.TimeoutException
TimeoutException(String) - Constructor for exception com.bigdata.concurrent.TimeoutException
TimeoutException(String, Throwable) - Constructor for exception com.bigdata.concurrent.TimeoutException
TimeoutException(Throwable) - Constructor for exception com.bigdata.concurrent.TimeoutException
Timer - Class in cern.colt
A handy stopwatch for benchmarking.
Timer() - Constructor for class cern.colt.Timer
Constructs a new timer, initially not started.
TimeRange - Class in com.bigdata.counters.query
Utility class to interpret URL query parameters as a time range.
TimeRange(String) - Constructor for class com.bigdata.counters.query.TimeRange
times(int) - Method in class cern.colt.list.AbstractBooleanList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractByteList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractCharList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractDoubleList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractFloatList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractIntList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractLongList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.AbstractShortList
Returns a list which is a concatenation of times
times the receiver.
times(int) - Method in class cern.colt.list.ObjectArrayList
Returns a list which is a concatenation of times
times the receiver.
TIMESTAMP - Static variable in interface com.bigdata.bop.controller.ServiceCallJoin.Annotations
timestamp - Variable in class com.bigdata.bop.fed.shards.MapBindingSetsOverShardsBuffer
The timestamp associated with the operation on the target access path.
TIMESTAMP - Static variable in interface com.bigdata.bop.ITimestampAnnotations
The timestamp (or transaction identifier) used by this operator if it
reads or writes on the database (no default).
TIMESTAMP - Static variable in interface com.bigdata.bop.rdf.join.ChunkedMaterializationOp.Annotations
TIMESTAMP - Static variable in interface com.bigdata.bop.rdf.join.MockTermResolverOp.Annotations
timestamp - Variable in class com.bigdata.counters.store.CounterSetBTree.Entry
timestamp - Variable in class com.bigdata.journal.AbstractTask
The transaction identifier -or-
ITx.UNISOLATED
if the operation
is NOT isolated by a transaction, -or-
ITx.READ_COMMITTED
, -or-
timestamp
to read from the most recent commit point not
later than
timestamp.
TIMESTAMP - Static variable in interface com.bigdata.rdf.internal.constraints.IVValueExpression.Annotations
The timestamp of the query.
timestamp - Variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext.AbstractQueryTask
The timestamp of the view for that namespace against which the query
will be run.
timestamp - Variable in class com.bigdata.rdf.sail.webapp.SparqlEndpointConfig
The default timestamp used to query the default namespace.
timestamp - Variable in class com.bigdata.rdf.sparql.ast.GlobalAnnotations
The timestamp of the view of the lexicon relation.
timestamp - Variable in class com.bigdata.rdf.task.AbstractApiTask
The timestamp of the view of that KB instance.
timestamp - Variable in class com.bigdata.relation.accesspath.AccessPath
Timestamp of the view.
timestamp - Variable in class com.bigdata.service.CacheOnceMetadataIndex
Timestamp of the view.
timestamp - Variable in class com.bigdata.service.ndx.AbstractScaleOutClientIndexView
The timestamp from the ctor.
timestamp - Variable in class com.bigdata.service.ndx.pipeline.IndexPartitionWriteTask
The timestamp associated with the index view.
timestamp - Variable in class com.bigdata.sparse.KeyDecoder
The decoded timestamp on the column value.
timestamp - Variable in class com.bigdata.sparse.TPS.TP
TIMESTAMP_FORMAT - Static variable in class com.bigdata.counters.query.URLQueryModel
Name of the URL query parameter specifying that the format for the first
column of the history counter table view.
TimestampChooser - Class in com.bigdata.sparse
Utility class for choosing timestamps for the
SparseRowStore
on the
server.
TimestampChooser() - Constructor for class com.bigdata.sparse.TimestampChooser
timestampFormat - Variable in class com.bigdata.counters.query.URLQueryModel
TimestampFormatEnum - Enum in com.bigdata.counters.query
Type-safe enum for the options used to render the timestamp of the
row in a history or correlated history.
TimestampMetricValue - Class in com.bigdata.ganglia
A reported or observed metric value with a timestamp.
TimestampMetricValue(IGangliaMetadataMessage) - Constructor for class com.bigdata.ganglia.TimestampMetricValue
TimestampOrderException - Exception in com.bigdata.counters
Used to reject samples that arrive way out of timestamp order.
TimestampOrderException() - Constructor for exception com.bigdata.counters.TimestampOrderException
TimestampOrderException(String) - Constructor for exception com.bigdata.counters.TimestampOrderException
TimestampOrderException(Throwable) - Constructor for exception com.bigdata.counters.TimestampOrderException
TimestampOrderException(String, Throwable) - Constructor for exception com.bigdata.counters.TimestampOrderException
TimestampServiceUtil - Class in com.bigdata.journal
TimestampServiceUtil() - Constructor for class com.bigdata.journal.TimestampServiceUtil
TimestampUtility - Class in com.bigdata.journal
Some static helper methods for timestamps.
TimestampUtility() - Constructor for class com.bigdata.journal.TimestampUtility
timezone(BigdataLiteral) - Method in class com.bigdata.rdf.internal.constraints.DateBOp
Timezone() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TIMEZONE - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
RegularExpression Id.
TIMEZONE - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
tipjar - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
title - Static variable in class com.bigdata.rdf.vocab.decls.DCElementsVocabularyDecl
title - Static variable in class com.bigdata.rdf.vocab.decls.DCTermsVocabularyDecl
title - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
TITLE - Static variable in class it.unimi.dsi.parser.Attribute
title - Variable in class it.unimi.dsi.parser.callback.TextExtractor
The title resulting from the parsing process.
TITLE - Static variable in class it.unimi.dsi.parser.Element
TLScheduler - Class in com.bigdata.rdf.graph.impl.bd
This scheduler uses thread-local buffers (
LinkedHashSet
) to track the
distinct vertices scheduled by each execution thread.
TLScheduler(GASEngine) - Constructor for class com.bigdata.rdf.graph.impl.bd.TLScheduler
TLScheduler2 - Class in com.bigdata.rdf.graph.impl.bd
This scheduler uses thread-local buffers (
LinkedHashSet
) to track the
distinct vertices scheduled by each execution thread.
TLScheduler2(GASEngine) - Constructor for class com.bigdata.rdf.graph.impl.bd.TLScheduler2
tmax - Variable in class com.bigdata.ganglia.AbstractMetrics
tmp - Variable in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
Field for construction of arbitrary AST nodes.
TMP_DIR - Static variable in interface com.bigdata.journal.Options
The property whose value is the name of the directory in which temporary
files will be created.
TMP_DIR - Static variable in interface com.bigdata.journal.TemporaryStoreFactory.Options
tmpDir - Variable in class com.bigdata.journal.AbstractJournal
The directory that should be used for temporary files.
TmpDir - Static variable in interface com.bigdata.resources.StoreManager.IStoreManagerCounters
The configured tmp directory.
tmpDir - Variable in class com.bigdata.resources.StoreManager
The directory in which the temporary files will reside.
TmpDirBytesAvailable - Static variable in interface com.bigdata.resources.StoreManager.IStoreManagerCounters
The #of bytes available on the disk volume on which the temporary
directory is located.
tmpKb - Variable in class com.bigdata.rdf.sail.bench.NanoSparqlClient.QueryOptions
Temp KB provided to the parser.
TMUtility - Class in com.bigdata.rdf.rules
A utility class for performing rule re-writes for RDF truth maintenance using
a "focusStore" in addition to the primary database.
TMUtility(boolean) - Constructor for class com.bigdata.rdf.rules.TMUtility
to() - Method in class com.bigdata.rdf.internal.constraints.Range
TO - Static variable in interface com.bigdata.rdf.internal.constraints.RangeBOp.Annotations
The exclusive upper bound.
to() - Method in class com.bigdata.rdf.internal.constraints.RangeBOp
TO - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
RegularExpression Id.
TO - Static variable in interface com.bigdata.rdf.sparql.ast.RangeNode.Annotations
The exclusive upper bound.
to() - Method in class com.bigdata.rdf.sparql.ast.RangeNode
to - Variable in class it.unimi.dsi.bits.AbstractBitVector.SubBitVector
to - Variable in class it.unimi.dsi.util.AbstractLongBigList.LongSubBigList
Final (exclusive) index of this sublist.
to - Variable in class org.openrdf.repository.RepositoryConnectionTest
Timeout all individual tests after 1 minute.
to - Variable in class org.openrdf.sail.RDFStoreTest
Timeout all individual tests after 1 minute.
toAddr(int, long) - Method in class com.bigdata.btree.IndexSegmentStore
toAddr(int, long) - Method in class com.bigdata.journal.AbstractJournal
toAddr(int, long) - Method in class com.bigdata.journal.JournalDelegate
toAddr(int, long) - Method in class com.bigdata.journal.RWAddressManager
toAddr(int, long) - Method in class com.bigdata.journal.RWStrategy
toAddr(int, long) - Method in class com.bigdata.rawstore.AbstractRawWormStore
toAddr(int, long) - Method in interface com.bigdata.rawstore.IAddressManager
Converts a byte count and offset into a long integer.
toAddr(int, long) - Method in class com.bigdata.rawstore.RawStoreDelegate
toAddr(int, long) - Method in class com.bigdata.rawstore.WormAddressManager
toAddr(int, long) - Method in class com.bigdata.rwstore.sector.MemStore
toAddr(int, long) - Method in class com.bigdata.rwstore.sector.MemStrategy
toArray(Object[]) - Method in class cern.colt.list.ObjectArrayList
Returns an array containing all of the elements in the receiver in the
correct order.
toArray() - Method in class cern.colt.matrix.DoubleMatrix1D
Constructs and returns a 1-dimensional array containing the cell values.
toArray(double[]) - Method in class cern.colt.matrix.DoubleMatrix1D
Fills the cell values into the specified 1-dimensional array.
toArray() - Method in class cern.colt.matrix.DoubleMatrix2D
Constructs and returns a 2-dimensional array containing the cell values.
toArray() - Method in class cern.colt.matrix.DoubleMatrix3D
Constructs and returns a 2-dimensional array containing the cell values.
toArray(double[]) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix1D
Fills the cell values into the specified 1-dimensional array.
toArray(Object[]) - Method in class cern.colt.matrix.impl.DenseObjectMatrix1D
Fills the cell values into the specified 1-dimensional array.
toArray() - Method in class cern.colt.matrix.ObjectMatrix1D
Constructs and returns a 1-dimensional array containing the cell values.
toArray(Object[]) - Method in class cern.colt.matrix.ObjectMatrix1D
Fills the cell values into the specified 1-dimensional array.
toArray() - Method in class cern.colt.matrix.ObjectMatrix2D
Constructs and returns a 2-dimensional array containing the cell values.
toArray() - Method in class cern.colt.matrix.ObjectMatrix3D
Constructs and returns a 2-dimensional array containing the cell values.
toArray() - Method in interface com.bigdata.bop.BOp
A shallow copy of the operator's arguments.
toArray(T[]) - Method in interface com.bigdata.bop.BOp
A shallow copy of the operator's arguments using the generic type of the
caller's array.
toArray() - Method in class com.bigdata.bop.BOpBase
toArray(T[]) - Method in class com.bigdata.bop.BOpBase
toArray(Iterator<IVariable<?>>) - Static method in class com.bigdata.bop.BOpUtility
Return an array containing the
IVariable
s visited by the
iterator.
toArray(Iterator<IBindingSet[]>, BOpStats) - Static method in class com.bigdata.bop.BOpUtility
Combine chunks drawn from an iterator into a single chunk.
toArray() - Method in class com.bigdata.bop.join.JVMHashIndex
toArray() - Method in class com.bigdata.bop.ModifiableBOpBase
toArray(T[]) - Method in class com.bigdata.bop.ModifiableBOpBase
toArray() - Method in class com.bigdata.cache.RingBuffer
Return the buffer elements in MRU (head) to LRU (tail) order.
toArray(TX[]) - Method in class com.bigdata.cache.RingBuffer
Return the buffer elements in MRU (head) to LRU (tail) order.
toArray() - Method in class com.bigdata.gom.gpo.LinkSet
Eagerly streams materialized objects into an array
toArray(T[]) - Method in class com.bigdata.gom.gpo.LinkSet
toArray() - Method in class com.bigdata.jsr166.LinkedBlockingDeque
Returns an array containing all of the elements in this deque, in
proper sequence (from first to last element).
toArray(T[]) - Method in class com.bigdata.jsr166.LinkedBlockingDeque
Returns an array containing all of the elements in this deque, in
proper sequence; the runtime type of the returned array is that of
the specified array.
toArray() - Method in class com.bigdata.jsr166.LinkedBlockingQueue
Returns an array containing all of the elements in this queue, in
proper sequence.
toArray(T[]) - Method in class com.bigdata.jsr166.LinkedBlockingQueue
Returns an array containing all of the elements in this queue, in
proper sequence; the runtime type of the returned array is that of
the specified array.
toArray() - Method in interface com.bigdata.rdf.graph.impl.util.IArraySlice
Return a copy of the data in the slice.
toArray() - Method in interface com.bigdata.rdf.graph.impl.util.IIntArraySlice
Return a copy of the data in the slice.
toArray() - Method in class com.bigdata.rdf.graph.impl.util.ManagedArray
toArray() - Method in class com.bigdata.rdf.graph.impl.util.ManagedIntArray
toArray() - Method in interface com.bigdata.relation.rule.IProgram
An array containing the steps in the program (non-recursive).
toArray() - Method in class com.bigdata.relation.rule.Program
toArray(ByteBuffer) - Static method in class com.bigdata.util.BytesUtil
toArray(ByteBuffer, boolean, byte[]) - Static method in class com.bigdata.util.BytesUtil
toArray() - Method in interface it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList.BackingBuffer
Return a copy of the data in the backing buffer.
toBigdataPredicate(Predicate) - Static method in enum com.bigdata.blueprints.BigdataPredicate
toBitString(byte[]) - Static method in class com.bigdata.util.BytesUtil
Return the binary representation of the unsigned byte[].
toBitVector() - Method in class cern.colt.bitvector.BitMatrix
Converts the receiver to a bitvector.
toBitVector() - Method in class cern.colt.list.MinMaxNumberList
Returns the receiver seen as bitvector.
toBitVector(CharSequence) - Method in class it.unimi.dsi.bits.PrefixCoderTransformationStrategy
toBitVector(T) - Method in interface it.unimi.dsi.bits.TransformationStrategy
Returns a bit vector representation of the given object.
toBitVector(CharSequence) - Method in class it.unimi.dsi.bits.Utf16TransformationStrategy
Deprecated.
toBooleans(ModifiedEnum[], int) - Static method in enum com.bigdata.rdf.spo.ModifiedEnum
toByteArray() - Method in interface com.bigdata.btree.keys.IKeyBuilder
toByteArray() - Method in class com.bigdata.btree.keys.KeyBuilder
toByteArray() - Method in class com.bigdata.io.AbstractFixedByteArrayBuffer
toByteArray() - Method in class com.bigdata.io.ByteArrayBuffer
Return a copy of the data written on the buffer (the bytes in [0:pos]).
toByteArray() - Method in interface com.bigdata.io.IByteArraySlice
Return a copy of the data in the slice.
toCharArray() - Method in class it.unimi.dsi.lang.MutableString
Converts this string to a new character array.
toCharArray(char[], int, int) - Method in class it.unimi.dsi.util.CircularCharArrayBuffer
Copies the content of the buffer to an array.
toCharArray(char[]) - Method in class it.unimi.dsi.util.CircularCharArrayBuffer
Copies the content of the buffer to an array.
toCharArray() - Method in class it.unimi.dsi.util.CircularCharArrayBuffer
Returns a new array containing a copy of the buffer content.
toCNF(IValueExpressionNode) - Static method in class com.bigdata.rdf.sparql.ast.StaticAnalysis
Returns the corresponding (equivalent) value expression in CNF.
toComponentArray(LiteralExtensionIV) - Method in class com.bigdata.rdf.internal.impl.extensions.GeoSpatialLiteralExtension
Conversion of a an IV into its component array.
toComponents(String) - Method in class com.bigdata.rdf.sparql.ast.eval.service.BLZG1943LiteralSerializer
toComponents(String) - Method in class com.bigdata.rdf.sparql.ast.eval.service.GeoSpatialTestWKTLiteralSerializer
toComponents(String) - Method in class com.bigdata.service.geospatial.GeoSpatialDefaultLiteralSerializer
toComponents(String) - Method in interface com.bigdata.service.geospatial.IGeoSpatialLiteralSerializer
Decomposes a string[] into an array of strings identifying the
individual components.
toComponentString(GeoSpatialUtility.PointLatLon) - Static method in class com.bigdata.service.geospatial.impl.GeoSpatialUtility.PointLatLon
Splits a given point into its component string.
toComponentString(GeoSpatialUtility.PointLatLonTime) - Static method in class com.bigdata.service.geospatial.impl.GeoSpatialUtility.PointLatLonTime
Splits a given point into its component string.
toConjunctiveValueExpression(List<IValueExpressionNode>) - Static method in class com.bigdata.rdf.sparql.ast.StaticAnalysis
Constructs an (unbalanced) tree out of the list of conjuncts.
toDD() - Method in class com.bigdata.rdf.internal.gis.CoordinateDD
toDD() - Method in class com.bigdata.rdf.internal.gis.CoordinateDDM
Convert to decimal degrees.
toDD() - Method in class com.bigdata.rdf.internal.gis.CoordinateDMS
Convert to decimal degrees.
toDD() - Method in interface com.bigdata.rdf.internal.gis.ICoordinate
Convert to decimal degrees.
toDDM() - Method in class com.bigdata.rdf.internal.gis.CoordinateDD
toDDM() - Method in class com.bigdata.rdf.internal.gis.CoordinateDDM
toDDM() - Method in class com.bigdata.rdf.internal.gis.CoordinateDMS
toDDM() - Method in interface com.bigdata.rdf.internal.gis.ICoordinate
Convert to degrees and decimal minutes.
toDecimalDegrees(int, int, double) - Static method in class com.bigdata.rdf.internal.gis.CoordinateUtility
Convert Degrees, Minutes, and Seconds to Decimal Degrees.
toDegrees(double) - Static method in class com.bigdata.rdf.internal.gis.CoordinateUtility
Convert radians to degrees.
toDMS() - Method in class com.bigdata.rdf.internal.gis.CoordinateDD
Convert to degrees, minutes and (tenths of) seconds.
toDMS() - Method in class com.bigdata.rdf.internal.gis.CoordinateDDM
Convert to degrees, minutes and (tenths of) seconds.
toDMS() - Method in class com.bigdata.rdf.internal.gis.CoordinateDMS
toDMS() - Method in interface com.bigdata.rdf.internal.gis.ICoordinate
Convert to degrees, minutes and (tenths of) seconds.
toDummyIV(BigdataValue) - Static method in class com.bigdata.rdf.sparql.ast.DummyConstantNode
toEdgeURI(Object) - Method in interface com.bigdata.blueprints.BlueprintsValueFactory
Create an edge URI from a blueprints edge id.
toEdgeURI(Object) - Method in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
Create an edge URI from a blueprints edge id.
toExternal(Value) - Method in class com.bigdata.rdf.sail.webapp.client.AST2SPARQLUtil
Return an external form for the Value
suitable for direct
embedding into a SPARQL query.
toExternal(BNode) - Method in class com.bigdata.rdf.sail.webapp.client.AST2SPARQLUtil
toExternal(URI) - Method in class com.bigdata.rdf.sail.webapp.client.AST2SPARQLUtil
toExternal(Literal) - Method in class com.bigdata.rdf.sail.webapp.client.AST2SPARQLUtil
toFlags(VTE, boolean, boolean, DTE) - Static method in class com.bigdata.rdf.internal.impl.AbstractIV
Return the
flags
byte that encodes the provided metadata
about an
internal value
.
toFlags(VTE) - Static method in class com.bigdata.rdf.internal.impl.BlobIV
Return the
flags
byte for a
BlobIV
.
toFlags() - Static method in class com.bigdata.rdf.internal.impl.bnode.SidIV
Return the
flags
byte for a
SidIV
.
toGeoSpatialQuery(IBindingSet) - Method in class com.bigdata.rdf.sparql.ast.eval.GeoSpatialServiceFactory.GeoSpatialServiceCallConfiguration
Converts the configuration into a query over the given binding set
toGraphAtom(Statement) - Method in class com.bigdata.blueprints.BigdataGraph
Convert a unit of RDF data to an atomic unit of PG data.
toGraphAtom(URI, URI, Value) - Method in class com.bigdata.blueprints.BigdataGraph
Convert a unit of RDF data to an atomic unit of PG data.
toGraphEdit(IChangeRecord) - Method in class com.bigdata.blueprints.BigdataGraphEmbedded
Turn a bigdata change record into a graph edit.
toHexString(byte[]) - Static method in class com.bigdata.rdf.internal.constraints.DigestBOp
toHexString(int[]) - Static method in class com.bigdata.util.BytesUtil
Utility to convert an int array to a hex string
toHexString(byte[]) - Static method in class com.bigdata.util.BytesUtil
Utility to convert a byte array to a hex string.
toHexString(byte[], int) - Static method in class com.bigdata.util.BytesUtil
Utility to display byte array of maximum i bytes as hexString.
toIndex - Variable in class com.bigdata.btree.raba.AbstractRaba
The exclusive upper bound of the view.
toIndex - Variable in class com.bigdata.service.Split
Index of the first key NOT included in this split.
toInt(boolean) - Static method in class cern.colt.list.AbstractBooleanList
Transforms a boolean value to an integer (false --> 0, true --> 1)
toInternalValues(Set<URI>) - Static method in class com.bigdata.rdf.sparql.ast.eval.DataSetSummary
tok - Static variable in class com.bigdata.util.httpd.HTTPHeaderUtility
Matches an HTTP token
, which consists of one or
more of any CHAR except CTL
or
separator
.
token() - Method in class com.bigdata.ha.HAPipelineResetRequest
token() - Method in interface com.bigdata.ha.IHAPipelineResetRequest
The quorum token in effect on the leader when this request was generated.
token() - Method in class com.bigdata.ha.msg.HAGatherReleaseTimeRequest
token() - Method in interface com.bigdata.ha.msg.IHAGatherReleaseTimeRequest
The token for which this request is valid.
token() - Method in class com.bigdata.quorum.AbstractQuorum.E
token() - Method in class com.bigdata.quorum.AbstractQuorum
token() - Method in interface com.bigdata.quorum.Quorum
The current token for the quorum.
token() - Method in interface com.bigdata.quorum.QuorumEvent
The current quorum token at the time the event was generated.
token - Variable in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
Current token.
Token - Class in com.bigdata.rdf.sail.sparql.ast
Describes the input token stream.
Token() - Constructor for class com.bigdata.rdf.sail.sparql.ast.Token
No-argument constructor
Token(int) - Constructor for class com.bigdata.rdf.sail.sparql.ast.Token
Constructs a new token for the specified Image.
Token(int, String) - Constructor for class com.bigdata.rdf.sail.sparql.ast.Token
Constructs a new token for the specified Image and Kind.
token_source - Variable in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
Generated Token Manager.
TokenBuffer<V extends Comparable<V>> - Class in com.bigdata.search
A buffer holding tokens extracted from one or more documents / fields.
TokenBuffer(int, FullTextIndex<V>) - Constructor for class com.bigdata.search.TokenBuffer
Ctor.
tokenImage - Variable in exception com.bigdata.rdf.sail.sparql.ast.ParseException
This is a reference to the "tokenImage" array of the generated
parser within which the parse error occurred.
tokenImage - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
Literal token values.
tokenize(String, Reader) - Method in class com.bigdata.btree.raba.codec.TokenizeKeysGenerator
tokenize(ITextIndexer.FullTextQuery) - Method in class com.bigdata.search.FullTextIndex
TokenizeKeysGenerator - Class in com.bigdata.btree.raba.codec
Tokenize an input file, collect the set of distinct keywords, and encode
those keywords as unsigned byte[]s.
TokenizeKeysGenerator(String) - Constructor for class com.bigdata.btree.raba.codec.TokenizeKeysGenerator
TokenMgrError - Error in com.bigdata.rdf.sail.sparql.ast
Token Manager Error.
TokenMgrError() - Constructor for error com.bigdata.rdf.sail.sparql.ast.TokenMgrError
No arg constructor.
TokenMgrError(String, int) - Constructor for error com.bigdata.rdf.sail.sparql.ast.TokenMgrError
Constructor with message and reason.
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error com.bigdata.rdf.sail.sparql.ast.TokenMgrError
Full Constructor.
toKey - Variable in class com.bigdata.btree.AbstractBTreeTupleCursor
from the ctor.
toKey - Variable in class com.bigdata.btree.AbstractChunkedTupleIterator
The first key to NOT visit -or- null iff no upper bound.
toKey - Variable in class com.bigdata.btree.proc.AbstractKeyRangeIndexProcedure
toKey - Variable in class com.bigdata.search.AbstractIndexTask
toldTriples - Variable in class com.bigdata.bop.rdf.update.ParserStats
toldTriples - Variable in class com.bigdata.rdf.rio.LoadStats
tolerance - Variable in class cern.colt.matrix.linalg.Property
tolerance() - Method in class cern.colt.matrix.linalg.Property
Returns the current tolerance.
toList() - Method in class cern.colt.list.AbstractBooleanList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractByteList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractCharList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractCollection
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractDoubleList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractFloatList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractIntList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractLongList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.AbstractShortList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList() - Method in class cern.colt.list.ObjectArrayList
Returns a java.util.ArrayList
containing all the elements in the receiver.
toList(DoubleMatrix1D) - Method in class cern.colt.matrix.DoubleFactory1D
Constructs a list from the given matrix.
toList(ObjectMatrix1D) - Method in class cern.colt.matrix.ObjectFactory1D
Constructs a list from the given matrix.
toList(Iterator<T>) - Static method in class com.bigdata.bop.BOpUtility
Return an
List
containing the
IVariable
s visited by the
iterator.
toList(BOp, Class<C>) - Static method in class com.bigdata.bop.BOpUtility
Return a list containing references to all nodes of the given type
(recursive, including annotations).
toLiteral(Object) - Method in interface com.bigdata.blueprints.BlueprintsValueFactory
Create a datatyped literal from a blueprints property value.
toLiteral(Object) - Method in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
Create a datatyped literal from a blueprints property value.
toLiterals(Object) - Method in class com.bigdata.blueprints.BigdataGraph
toLong(String) - Static method in class com.bigdata.rdf.sail.webapp.client.StringUtil
Convert String to an long.
toLowerCase() - Method in class it.unimi.dsi.lang.MutableString
Converts all of the characters in this mutable string to lower
case using the rules of the default locale.
topConceptOf - Static variable in class com.bigdata.rdf.vocab.decls.SKOSVocabularyDecl
topic - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
topic_interest - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
toPredicate(StatementPatternNode, AST2BOpContext) - Static method in class com.bigdata.rdf.sparql.ast.eval.AST2BOpUtility
toPropertyURI(String) - Method in interface com.bigdata.blueprints.BlueprintsValueFactory
Create a property URI from a blueprints property name.
toPropertyURI(String) - Method in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
Create a property URI from a blueprints property name.
toQueryStr(URI) - Method in class com.bigdata.blueprints.BigdataGraphQuery
Generate the SPARQL query.
toRadians(double) - Static method in class com.bigdata.rdf.internal.gis.CoordinateUtility
Convert degrees to radians.
toRangeBOp(BOpContextBase, RangeNode, GlobalAnnotations) - Static method in class com.bigdata.rdf.sparql.ast.optimizers.ASTRangeOptimizer
Public static facilitates the test cases.
toSeparatedString(BigdataValueFactory, Object...) - Method in class com.bigdata.service.geospatial.GeoSpatialDefaultLiteralSerializer
Converts the input passed via args into string using its toString() method,
separating the components via {GeoSpatial#CUSTOM_FIELDS_SEPARATOR}.
toServiceCall(AbstractTripleStore, HttpClient, URI, ServiceNode, BaseJoinStats) - Method in class com.bigdata.rdf.sparql.ast.service.ServiceRegistry
toShortString() - Method in interface com.bigdata.bop.BOp
Return a short (non-recursive) representation of the
BOp
.
toShortString() - Method in class com.bigdata.bop.CoreBaseBOp
General contract is a short (non-recursive) representation of the
BOp
.
toShortString() - Method in class com.bigdata.btree.PO
Returns a short representation of the class, identity (if assigned), the
object instance, and whether or not the
PO
is deleted.
toShortString() - Method in class com.bigdata.rdf.internal.constraints.SPARQLConstraint
Overridden to provide a little bit of information about the attached
constraint.
toShortString() - Method in class com.bigdata.rdf.sparql.ast.PropertyPathNode
toShortString() - Method in class com.bigdata.rdf.sparql.ast.StatementPatternNode
toShortString() - Method in class com.bigdata.rdf.sparql.ast.ValueExpressionNode
toSourceCode(DoubleMatrix1D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string s such that Object[] m = s is a legal Java statement.
toSourceCode(DoubleMatrix2D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string s such that Object[] m = s is a legal Java statement.
toSourceCode(DoubleMatrix3D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string s such that Object[] m = s is a legal Java statement.
toSourceCode(ObjectMatrix1D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string s such that Object[] m = s is a legal Java statement.
toSourceCode(ObjectMatrix2D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string s such that Object[] m = s is a legal Java statement.
toSourceCode(ObjectMatrix3D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string s such that Object[] m = s is a legal Java statement.
toSpec() - Method in class it.unimi.dsi.io.DelimitedWordReader
toSpec() - Method in class it.unimi.dsi.io.FastBufferedReader
toSpec(Object) - Static method in class it.unimi.dsi.lang.ObjectParser
Generates a parseable representation of an object fetching by reflection a toSpec()
method, or using the class name.
toString(byte[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(char[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(double[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(float[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(int[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(long[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(Object[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(short[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString(boolean[]) - Static method in class cern.colt.Arrays
Returns a string representation of the specified array.
toString() - Method in class cern.colt.bitvector.BitMatrix
Returns a (very crude) string representation of the receiver.
toString() - Method in class cern.colt.bitvector.BitVector
Returns a string representation of the receiver.
toString() - Method in class cern.colt.list.AbstractBooleanList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractByteList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractCharList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractCollection
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractDoubleList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractFloatList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractIntList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractLongList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.AbstractShortList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.list.ObjectArrayList
Returns a string representation of the receiver, containing
the String representation of each element.
toString() - Method in class cern.colt.map.AbstractDoubleIntMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by key.
toString() - Method in class cern.colt.map.AbstractIntDoubleMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by key.
toString() - Method in class cern.colt.map.AbstractIntIntMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by key.
toString() - Method in class cern.colt.map.AbstractIntObjectMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by key.
toString() - Method in class cern.colt.map.AbstractLongObjectMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by key.
toString(DoubleMatrix1D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string representation of the given matrix.
toString(DoubleMatrix2D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string representation of the given matrix.
toString(DoubleMatrix3D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string representation of the given matrix.
toString(AbstractMatrix2D) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string representation of the given matrix.
toString() - Method in class cern.colt.matrix.DoubleMatrix1D
Returns a string representation using default formatting.
toString() - Method in class cern.colt.matrix.DoubleMatrix2D
Returns a string representation using default formatting.
toString() - Method in class cern.colt.matrix.DoubleMatrix3D
Returns a string representation using default formatting.
toString(String[][]) - Method in class cern.colt.matrix.impl.AbstractFormatter
Returns a single string representation of the given string matrix.
toString(AbstractMatrix2D) - Method in class cern.colt.matrix.impl.AbstractFormatter
Returns a string representation of the given matrix.
toString(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Algebra
Returns a String with (propertyName, propertyValue) pairs.
toString() - Method in class cern.colt.matrix.linalg.CholeskyDecomposition
Returns a String with (propertyName, propertyValue) pairs.
toString() - Method in class cern.colt.matrix.linalg.EigenvalueDecomposition
Returns a String with (propertyName, propertyValue) pairs.
toString() - Method in class cern.colt.matrix.linalg.LUDecomposition
Returns a String with (propertyName, propertyValue) pairs.
toString() - Method in class cern.colt.matrix.linalg.LUDecompositionQuick
Returns a String with (propertyName, propertyValue) pairs.
toString(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Property
Returns summary information about the given matrix A.
toString() - Method in class cern.colt.matrix.linalg.QRDecomposition
Returns a String with (propertyName, propertyValue) pairs.
toString() - Method in class cern.colt.matrix.linalg.SingularValueDecomposition
Returns a String with (propertyName, propertyValue) pairs.
toString(AbstractMatrix2D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string representation of the given matrix.
toString(ObjectMatrix1D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string representation of the given matrix.
toString(ObjectMatrix2D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string representation of the given matrix.
toString(ObjectMatrix3D) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string representation of the given matrix.
toString() - Method in class cern.colt.matrix.ObjectMatrix1D
Returns a string representation using default formatting.
toString() - Method in class cern.colt.matrix.ObjectMatrix2D
Returns a string representation using default formatting.
toString() - Method in class cern.colt.matrix.ObjectMatrix3D
Returns a string representation using default formatting.
toString() - Method in class cern.colt.Timer
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Beta
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Binomial
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.BreitWigner
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.ChiSquare
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Empirical
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.EmpiricalWalker
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Exponential
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.ExponentialPower
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Gamma
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Hyperbolic
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.HyperGeometric
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Logarithmic
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.NegativeBinomial
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Normal
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Poisson
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.PoissonSlow
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.StudentT
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Uniform
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.VonMises
Returns a String representation of the receiver.
toString() - Method in class cern.jet.random.Zeta
Returns a String representation of the receiver.
toString() - Method in class com.bigdata.blueprints.BigdataBindingSet
toString() - Method in class com.bigdata.blueprints.BigdataEdge
toString() - Method in class com.bigdata.blueprints.BigdataElement
toString() - Method in class com.bigdata.blueprints.BigdataGraph
For some reason this is part of the specification (i.e.
toString() - Method in class com.bigdata.blueprints.BigdataGraphAtom.EdgeAtom
toString() - Method in class com.bigdata.blueprints.BigdataGraphAtom.EdgeLabelAtom
toString() - Method in class com.bigdata.blueprints.BigdataGraphAtom.ExistenceAtom
toString() - Method in class com.bigdata.blueprints.BigdataGraphAtom.PropertyAtom
toString() - Method in class com.bigdata.blueprints.BigdataGraphEdit
toString() - Method in class com.bigdata.blueprints.BigdataVertex
toString() - Method in class com.bigdata.blueprints.PartialEdge
toString() - Method in class com.bigdata.blueprints.PartialElement
toString() - Method in class com.bigdata.bop.ap.E
toString() - Method in class com.bigdata.bop.ap.filter.SameVariableConstraint
toString() - Method in class com.bigdata.bop.ap.Predicate
toString(IBindingSet) - Method in class com.bigdata.bop.ap.Predicate
toString() - Method in class com.bigdata.bop.ap.R.KeyOrder
toString() - Method in class com.bigdata.bop.bindingSet.HashBindingSet
toString() - Method in class com.bigdata.bop.bindingSet.ListBindingSet
toString() - Method in interface com.bigdata.bop.BOp
Return a
toString(int) - Method in interface com.bigdata.bop.BOp
The contract of this method at this level is under-specified.
toString(BOp) - Static method in class com.bigdata.bop.BOpUtility
Pretty print a bop.
toString() - Method in class com.bigdata.bop.Constant
toString() - Method in class com.bigdata.bop.ContextBindingSet
toString() - Method in interface com.bigdata.bop.controller.INamedSolutionSetRef
toString() - Method in class com.bigdata.bop.CoreBaseBOp
Return a non-recursive representation of the arguments and annotations
for this
BOp
.
toString(int) - Method in class com.bigdata.bop.CoreBaseBOp
The contract of this method at this level is under-specified.
toString() - Method in class com.bigdata.bop.cost.ScanCostReport
Human readable representation.
toString() - Method in class com.bigdata.bop.cost.SubqueryCostReport
Human readable representation.
toString() - Method in class com.bigdata.bop.DefaultQueryAttributes
toString() - Method in class com.bigdata.bop.engine.AbstractRunningQuery
toString() - Method in class com.bigdata.bop.engine.BOpStats
toString(StringBuilder) - Method in class com.bigdata.bop.engine.BOpStats
toString() - Method in class com.bigdata.bop.engine.BSBundle
toString() - Method in class com.bigdata.bop.engine.HaltOpMessage
toString() - Method in class com.bigdata.bop.engine.LocalChunkMessage
toString() - Method in class com.bigdata.bop.engine.LocalNativeChunkMessage
toString() - Method in class com.bigdata.bop.engine.StartOpMessage
toString() - Method in class com.bigdata.bop.engine.StaticAnalysisStat
toString() - Method in class com.bigdata.bop.engine.StaticAnalysisStats
toString() - Method in class com.bigdata.bop.fed.EmptyChunkMessage
toString() - Method in class com.bigdata.bop.fed.FederatedQueryEngine
toString() - Method in class com.bigdata.bop.fed.NIOChunkMessage
toString() - Method in class com.bigdata.bop.fed.ThickChunkMessage
toString() - Method in interface com.bigdata.bop.IPredicate
Representation of the predicate without variable bindings.
toString(IBindingSet) - Method in interface com.bigdata.bop.IPredicate
Representation of the predicate with variable bindings.
toString(int) - Method in interface com.bigdata.bop.IValueExpression
A string representation of a recursive structure with pretty-print indent.
toString(StringBuilder) - Method in class com.bigdata.bop.join.BaseJoinStats
toString() - Method in class com.bigdata.bop.join.HTreeHashJoinUtility.BS
toString() - Method in class com.bigdata.bop.join.HTreeHashJoinUtility
Human readable representation of the
IHashJoinUtility
metadata
(but not the solutions themselves).
toString() - Method in class com.bigdata.bop.join.HTreePipelinedHashJoinUtility
Human readable representation of the
IHashJoinUtility
metadata
(but not the solutions themselves).
toString() - Method in class com.bigdata.bop.join.JVMHashIndex.Bucket
toString() - Method in class com.bigdata.bop.join.JVMHashIndex.SolutionHit
toString() - Method in class com.bigdata.bop.join.JVMHashJoinUtility
Human readable representation of the
IHashJoinUtility
metadata
(but not the solutions themselves).
toString() - Method in class com.bigdata.bop.join.JVMPipelinedHashJoinUtility
Human readable representation of the
IHashJoinUtility
metadata
(but not the solutions themselves).
toString(StringBuilder) - Method in class com.bigdata.bop.join.NamedSolutionSetStats
toString(StringBuilder) - Method in class com.bigdata.bop.join.PipelineJoinStats
toString() - Method in class com.bigdata.bop.joinGraph.fast.DefaultEvaluationPlan2
toString(StringBuilder) - Method in class com.bigdata.bop.joinGraph.rto.EdgeSample
toString() - Method in class com.bigdata.bop.joinGraph.rto.JGraph
toString() - Method in class com.bigdata.bop.joinGraph.rto.Path
toString() - Method in class com.bigdata.bop.joinGraph.rto.PathIds
Return the path id array as a string.
toString(StringBuilder) - Method in class com.bigdata.bop.joinGraph.rto.SampleBase
toString() - Method in class com.bigdata.bop.joinGraph.rto.SampleBase
toString() - Method in class com.bigdata.bop.joinGraph.rto.Vertex
toString() - Method in class com.bigdata.bop.NamedSolutionSetRef
toString() - Method in class com.bigdata.bop.NV
toString(StringBuilder) - Method in class com.bigdata.bop.rdf.update.ParserStats
toString() - Method in class com.bigdata.bop.solutions.GroupByRewriter
toString() - Method in class com.bigdata.bop.solutions.GroupByState
toString(StringBuilder) - Method in class com.bigdata.bop.solutions.SliceOp.SliceStats
toString() - Method in class com.bigdata.bop.solutions.SortOrder
Either ASC ( expr ) or DESC ( expr )
.
toString() - Method in class com.bigdata.bop.Var
toString() - Method in class com.bigdata.btree.AbstractBTree
Fast summary information about the B+Tree.
toString() - Method in class com.bigdata.btree.AbstractBTreeTupleCursor
toString() - Method in class com.bigdata.btree.AbstractChunkedTupleIterator.ResultSetTuple
toString() - Method in class com.bigdata.btree.AbstractTuple
toString(ITuple) - Static method in class com.bigdata.btree.AbstractTuple
Utility method returns a
String
representation of an
ITuple
.
toString() - Method in class com.bigdata.btree.AsynchronousIndexWriteConfiguration
toString() - Method in class com.bigdata.btree.BloomFilter.BloomFilterCounters
toString() - Method in class com.bigdata.btree.BloomFilter
toString() - Method in class com.bigdata.btree.BloomFilterFactory
toString() - Method in class com.bigdata.btree.BTreeCounters
toString() - Method in class com.bigdata.btree.BTreeStatistics
Human readable representation.
toString() - Method in class com.bigdata.btree.BTreeUtilizationReport
Human readable representation.
toString() - Method in class com.bigdata.btree.Checkpoint
A human readable representation of the state of the
Checkpoint
record.
toString() - Method in class com.bigdata.btree.data.DefaultLeafCoder
toString(ILeafData, StringBuilder) - Static method in class com.bigdata.btree.data.DefaultLeafCoder
toString() - Method in class com.bigdata.btree.data.DefaultNodeCoder
toString(INodeData, StringBuilder) - Static method in class com.bigdata.btree.data.DefaultNodeCoder
toString() - Method in class com.bigdata.btree.data.MockLeafData
toString() - Method in class com.bigdata.btree.DefaultTupleSerializer
toString() - Method in class com.bigdata.btree.DelegateIndex
toString() - Method in class com.bigdata.btree.DelegateTuple
toString(StringBuilder) - Method in class com.bigdata.btree.HTreeIndexMetadata
toString() - Method in class com.bigdata.btree.IndexMetadata
A human readable representation of the metadata record.
toString(StringBuilder) - Method in class com.bigdata.btree.IndexMetadata
toString() - Method in class com.bigdata.btree.IndexSegment
Fast summary information about the B+Tree.
toString(long) - Method in class com.bigdata.btree.IndexSegmentAddressManager
Returns a representation of the address with the decoded offset and
the region to which that offset is relative.
toString() - Method in class com.bigdata.btree.IndexSegmentCheckpoint
toString() - Method in class com.bigdata.btree.IndexSegmentMultiBlockIterator
toString() - Method in class com.bigdata.btree.IndexSegmentPlan
A summary representation of the index build plan.
toString() - Method in class com.bigdata.btree.IndexSegmentStore
toString(long) - Method in class com.bigdata.btree.IndexSegmentStore
toString() - Method in class com.bigdata.btree.isolation.TestAccount.TxAccount
toString() - Method in class com.bigdata.btree.keys.ASCIIKeyBuilderFactory
Representation includes all aspects of the
Serializable
state.
toString() - Method in class com.bigdata.btree.keys.DefaultKeyBuilderFactory
Representation includes all aspects of the
Serializable
state.
toString() - Method in class com.bigdata.btree.keys.ICUVersionRecord
A human readable representation of the data record.
toString() - Method in class com.bigdata.btree.keys.KVO
toString() - Method in class com.bigdata.btree.Leaf
Human readable representation of the
ILeafData
plus transient
information associated with the
Leaf
.
toString() - Method in class com.bigdata.btree.Node
Human readable representation of the
Node
.
toString() - Method in class com.bigdata.btree.PageStats
toString() - Method in class com.bigdata.btree.PO
Extends the basic behavior to display the persistent identity of the
object iff the object is persistent and to mark objects that have been
deleted.
toString() - Method in class com.bigdata.btree.raba.AbstractRaba
toString(IRaba) - Static method in class com.bigdata.btree.raba.AbstractRaba
If
IRaba.isKeys()
is
true
then represents the
elements as
unsigned byte[]
s.
toString() - Method in class com.bigdata.btree.raba.codec.AbstractCodedRaba
toString() - Method in class com.bigdata.btree.raba.codec.FrontCodedRabaCoder
toString() - Method in class com.bigdata.btree.raba.MutableKeyBuffer
toString() - Method in class com.bigdata.btree.raba.MutableValueBuffer
toString() - Method in class com.bigdata.btree.raba.SubRangeRaba
toString() - Method in class com.bigdata.btree.ScatterSplitConfiguration
toString() - Method in class com.bigdata.btree.SimpleEntry
toString() - Method in class com.bigdata.btree.TestTuple
toString() - Method in class com.bigdata.btree.UnisolatedReadWriteIndex
toString() - Method in class com.bigdata.btree.view.FusedView
toString() - Method in class com.bigdata.cache.ConcurrentWeakValueCache.WeakRef
toString() - Method in class com.bigdata.cache.WeakCacheEntry
toString() - Method in class com.bigdata.concurrent.LockCallableImpl
toString() - Method in class com.bigdata.concurrent.LockManager
Deprecated.
toString() - Method in class com.bigdata.concurrent.LockManagerTask
toString() - Method in class com.bigdata.concurrent.NonBlockingLockManager.LockFutureTask
toString() - Method in class com.bigdata.concurrent.NonBlockingLockManager.ResourceQueue
toString() - Method in class com.bigdata.concurrent.NonBlockingLockManager
toString() - Method in class com.bigdata.concurrent.NonBlockingLockManagerWithNewDesign.LockFutureTask
toString() - Method in class com.bigdata.concurrent.NonBlockingLockManagerWithNewDesign.ResourceQueue
toString() - Method in class com.bigdata.concurrent.NonBlockingLockManagerWithNewDesign
toString() - Method in class com.bigdata.concurrent.ResourceQueue
toString() - Method in class com.bigdata.concurrent.TxDag.Edge
Human readable representation of the edge.
toString() - Method in class com.bigdata.concurrent.TxDag
Returns a representation of the state of the graph suitable for debugging
the algorithm.
toString() - Method in class com.bigdata.counters.AbstractCounterSet
toString(Pattern) - Method in class com.bigdata.counters.AbstractCounterSet
toString() - Method in class com.bigdata.counters.CAT
Return the current value of the counter.
toString() - Method in class com.bigdata.counters.History
Return a representation of a snapshot of the samples in buffer.
toString() - Method in class com.bigdata.counters.HistoryInstrument
toString() - Method in interface com.bigdata.counters.ICounterSet
A human readable representation of all counters in the hierarchy together
with their current value.
toString(Pattern) - Method in interface com.bigdata.counters.ICounterSet
A human readable representation of the counters in the hierarchy together
with their current value.
toString() - Method in class com.bigdata.counters.linux.KernelVersion
toString() - Method in class com.bigdata.counters.query.CSet
toString() - Method in class com.bigdata.counters.query.QueryUtil.ReadCounterSetXMLFileTask
toString() - Method in class com.bigdata.counters.query.URLQueryModel
toString() - Method in class com.bigdata.counters.store.CounterSetBTree.Entry
toString() - Method in class com.bigdata.counters.striped.StripedCounters
Return a serialization of the performance counters.
toString() - Method in class com.bigdata.ganglia.GangliaMetadataMessage
toString() - Method in class com.bigdata.ganglia.GangliaMetricMessage
toString() - Method in class com.bigdata.ganglia.GangliaRequestMessage
toString() - Method in class com.bigdata.ganglia.HostReport
toString() - Method in class com.bigdata.ganglia.TimestampMetricValue
Human readable representation.
toString(byte[]) - Static method in class com.bigdata.ganglia.util.BytesUtil
Formats a key as a series of comma delimited unsigned bytes.
toString(byte[], int, int) - Static method in class com.bigdata.ganglia.util.BytesUtil
Formats a key as a series of comma delimited unsigned bytes.
toString() - Method in class com.bigdata.ha.althalog.HALogFile.HALogWriter
toString() - Method in interface com.bigdata.ha.althalog.IHALogWriter
toString() - Method in class com.bigdata.ha.CommitRequest
toString() - Method in class com.bigdata.ha.halog.HALogWriter
toString() - Method in class com.bigdata.ha.HAPipelineResetRequest
toString() - Method in class com.bigdata.ha.JoinedAndNonJoinedServices
toString() - Method in class com.bigdata.ha.msg.HA2PhaseCommitMessage
toString() - Method in class com.bigdata.ha.msg.HA2PhasePrepareMessage
toString() - Method in class com.bigdata.ha.msg.HAAwaitServiceJoinRequest
toString() - Method in class com.bigdata.ha.msg.HADigestRequest
toString() - Method in class com.bigdata.ha.msg.HADigestResponse
toString() - Method in class com.bigdata.ha.msg.HAGatherReleaseTimeRequest
toString() - Method in class com.bigdata.ha.msg.HALogDigestRequest
toString() - Method in class com.bigdata.ha.msg.HALogDigestResponse
toString() - Method in class com.bigdata.ha.msg.HALogRequest
toString() - Method in class com.bigdata.ha.msg.HALogRootBlocksRequest
toString() - Method in class com.bigdata.ha.msg.HALogRootBlocksResponse
toString() - Method in class com.bigdata.ha.msg.HANotifyReleaseTimeRequest
toString() - Method in class com.bigdata.ha.msg.HANotifyReleaseTimeResponse
toString() - Method in class com.bigdata.ha.msg.HARebuildRequest
toString() - Method in class com.bigdata.ha.msg.HASendState
toString() - Method in class com.bigdata.ha.msg.HASendStoreResponse
toString() - Method in class com.bigdata.ha.msg.HASnapshotDigestRequest
toString() - Method in class com.bigdata.ha.msg.HASnapshotDigestResponse
toString() - Method in class com.bigdata.ha.msg.HAWriteMessage
toString() - Method in class com.bigdata.ha.msg.HAWriteMessageBase
toString() - Method in class com.bigdata.ha.msg.HAWriteSetStateResponse
toString() - Method in class com.bigdata.ha.pipeline.HAReceiveService
toString() - Method in class com.bigdata.ha.pipeline.HASendService
toString() - Method in class com.bigdata.ha.PrepareRequest
toString() - Method in class com.bigdata.ha.PrepareResponse
toString() - Method in class com.bigdata.htree.AbstractHTree
Fast summary information about the B+Tree.
toString(IDirectoryData, StringBuilder) - Static method in class com.bigdata.htree.data.DefaultDirectoryPageCoder
toString() - Method in class com.bigdata.htree.raba.MutableKeyBuffer
toString() - Method in class com.bigdata.htree.raba.MutableValueBuffer
toString() - Method in class com.bigdata.io.compression.DefaultRecordCompressorFactory
toString() - Method in class com.bigdata.io.compression.RecordCompressor
toString() - Method in interface com.bigdata.io.IReopenChannel
Should include the name of the backing file (if known).
toString() - Method in class com.bigdata.io.writecache.WriteCache.RecordMetadata
toString() - Method in class com.bigdata.io.writecache.WriteCache
Adds some debugging information.
toString() - Method in class com.bigdata.io.writecache.WriteCacheCounters
toString(long) - Method in class com.bigdata.journal.AbstractJournal
toString() - Method in class com.bigdata.journal.AbstractTask.DelegateTask
toString() - Method in class com.bigdata.journal.AbstractTask
Returns Task{taskName,timestamp,elapsed,resource[]}
toString() - Method in class com.bigdata.journal.CommitRecord
toString() - Method in class com.bigdata.journal.CommitRecordIndex.Entry
toString() - Method in enum com.bigdata.journal.ForceEnum
toString() - Method in interface com.bigdata.journal.ITask
Returns Task{taskName,timestamp,resource[]}
toString(long) - Method in class com.bigdata.journal.JournalDelegate
toString() - Method in class com.bigdata.journal.Name2Addr.Entry
toString() - Method in class com.bigdata.journal.RootBlockView
toString(long) - Static method in class com.bigdata.journal.RootBlockView
Format a commit time as the raw milliseconds since the epoch value plus a
fully expressed date and time.
toString() - Method in enum com.bigdata.journal.RunState
toString(long) - Method in class com.bigdata.journal.RWAddressManager
toString(long) - Method in class com.bigdata.journal.RWStrategy
toString() - Method in class com.bigdata.journal.StressTestConcurrentTx.Task
toString() - Method in class com.bigdata.journal.StressTestUnisolatedReadWriteIndex.WriteTask
toString() - Method in class com.bigdata.journal.TemporaryRawStore
toString(long) - Static method in class com.bigdata.journal.TimestampUtility
Formats the timestamp as a String.
toString() - Method in class com.bigdata.journal.Tx
Returns a string representation of the transaction start time.
toString() - Method in class com.bigdata.journal.WriteExecutorService
A snapshot of the executor state.
toString() - Method in class com.bigdata.jsr166.LinkedBlockingDeque
toString() - Method in class com.bigdata.jsr166.LinkedBlockingQueue
toString() - Method in class com.bigdata.mdi.AbstractResourceMetadata
A human readable representation of the resource metadata.
toString() - Method in class com.bigdata.mdi.IndexPartitionCause
toString() - Method in class com.bigdata.mdi.LocalPartitionMetadata
toString() - Method in class com.bigdata.mdi.PartitionLocator
toString() - Method in class com.bigdata.quorum.AbstractQuorum.E
toString() - Method in class com.bigdata.quorum.AbstractQuorum
Return a human readable representation of the local copy of the
distributed quorum state (non-blocking).
toString(Map<Long, UUID[]>) - Static method in class com.bigdata.quorum.AbstractQuorumTestCase
Helper method provides nice rendering of a votes snapshot.
toString() - Method in class com.bigdata.quorum.MockQuorumFixture
toString() - Method in class com.bigdata.quorum.QCE
toString() - Method in class com.bigdata.quorum.QuorumTokenTransitions
toString(long) - Method in class com.bigdata.rawstore.AbstractRawWormStore
toString(long) - Method in interface com.bigdata.rawstore.IAddressManager
A human readable representation of the address.
toString(long) - Method in class com.bigdata.rawstore.RawStoreDelegate
toString(long) - Method in class com.bigdata.rawstore.WormAddressManager
toString() - Method in class com.bigdata.rawstore.WormAddressManager
toString() - Method in class com.bigdata.rdf.changesets.ChangeRecord
toString() - Method in class com.bigdata.rdf.changesets.DelegatingChangeLog
toString() - Method in class com.bigdata.rdf.graph.analytics.BFS.VS
toString() - Method in class com.bigdata.rdf.graph.analytics.CC.VS
toString() - Method in class com.bigdata.rdf.graph.analytics.FuzzySSSP.FuzzySSSPResult
TODO Also show the reachability matrix and perhaps the visited
vertices in level sets.
toString() - Method in class com.bigdata.rdf.graph.analytics.PR.VS
toString() - Method in class com.bigdata.rdf.graph.analytics.SSSP.VS
toString(Statement) - Method in interface com.bigdata.rdf.graph.IGASState
Return a useful representation of an edge (non-batch API, debug only).
toString(Statement) - Method in class com.bigdata.rdf.graph.impl.bd.BigdataGASState
toString() - Method in class com.bigdata.rdf.graph.impl.bd.PATHS.VS
toString() - Method in class com.bigdata.rdf.graph.impl.frontier.StaticFrontier2
toString(Statement) - Method in class com.bigdata.rdf.graph.impl.GASState
toString() - Method in class com.bigdata.rdf.graph.impl.GASStats
Return a useful summary of the collected statistics.
toString() - Method in class com.bigdata.rdf.graph.impl.util.ManagedArray
toString() - Method in class com.bigdata.rdf.graph.impl.util.VertexDistribution
toString() - Method in class com.bigdata.rdf.inf.AbstractSPOBuffer
Deprecated.
toString() - Method in class com.bigdata.rdf.inf.ClosureStats
toString() - Method in class com.bigdata.rdf.inf.Justification
toString(AbstractTripleStore) - Method in class com.bigdata.rdf.inf.Justification
toString() - Method in class com.bigdata.rdf.internal.constraints.DateBOp
toString() - Method in class com.bigdata.rdf.internal.constraints.DigestBOp
toString() - Method in class com.bigdata.rdf.internal.constraints.InterruptibleCharSequence
toString() - Method in class com.bigdata.rdf.internal.constraints.MathBOp
toString() - Method in class com.bigdata.rdf.internal.constraints.NowBOp
toString() - Method in class com.bigdata.rdf.internal.constraints.NumericBOp
toString() - Method in class com.bigdata.rdf.internal.constraints.UUIDBOp
toString() - Method in class com.bigdata.rdf.internal.encoder.IVBindingSetEncoderWithIVCache
Deprecated.
toString() - Method in class com.bigdata.rdf.internal.encoder.IVSolutionSetDecoder
toString() - Method in class com.bigdata.rdf.internal.encoder.IVSolutionSetEncoder
toString() - Method in class com.bigdata.rdf.internal.gis.CoordinateDD
Returns the coordinate in decimal degrees as
toString() - Method in class com.bigdata.rdf.internal.gis.CoordinateDDM
Representation of the coordinate in degrees and (thousandths of) decimal
minutes.
toString() - Method in class com.bigdata.rdf.internal.gis.CoordinateDMS
Representation of the coordinate in degrees, minutes, and (tenths of)
seconds.
toString() - Method in class com.bigdata.rdf.internal.impl.BlobIV
Human readable representation includes the term identifier, whether this
is a URI, Literal, Blank node, or Statement identifier and the datatype
URI if one is assigned.
toString() - Method in class com.bigdata.rdf.internal.impl.bnode.FullyInlineUnicodeBNodeIV
toString() - Method in class com.bigdata.rdf.internal.impl.bnode.SidIV
toString() - Method in class com.bigdata.rdf.internal.impl.literal.AbstractLiteralIV
toString() - Method in class com.bigdata.rdf.internal.impl.literal.IPv4AddrIV
toString() - Method in class com.bigdata.rdf.internal.impl.literal.LiteralExtensionIV
toString() - Method in class com.bigdata.rdf.internal.impl.literal.PackedLongIV
toString() - Method in class com.bigdata.rdf.internal.impl.literal.PartlyInlineTypedLiteralIV
Human readable representation includes the datatype
IV
and
the
label
.
toString() - Method in class com.bigdata.rdf.internal.impl.literal.XSDBooleanIV
toString() - Method in class com.bigdata.rdf.internal.impl.TermId
Human readable representation includes the term identifier, whether this
is a URI, Literal, Blank node, or Statement identifier and the datatype
URI if one is assigned.
toString() - Method in class com.bigdata.rdf.internal.impl.uri.FullyInlineURIIV
toString() - Method in class com.bigdata.rdf.internal.impl.uri.PartlyInlineURIIV
Human readable representation includes the namespace
IV
and the
localName
.
toString() - Method in class com.bigdata.rdf.internal.impl.uri.URIExtensionIV
toString() - Method in class com.bigdata.rdf.internal.impl.uri.VocabURIByteIV
toString() - Method in class com.bigdata.rdf.internal.impl.uri.VocabURIShortIV
toString() - Method in class com.bigdata.rdf.internal.IPv4Address
Return printable version of the IP address
toString() - Method in class com.bigdata.rdf.internal.LexiconConfiguration
toString() - Method in class com.bigdata.rdf.lexicon.LexiconKeyOrder
toString() - Method in class com.bigdata.rdf.lexicon.TermIdEncoder
toString() - Method in class com.bigdata.rdf.lexicon.WriteTaskStats
toString() - Method in class com.bigdata.rdf.load.SingleResourceReaderTask
toString() - Method in class com.bigdata.rdf.model.BigdataBNodeImpl
toString() - Method in class com.bigdata.rdf.model.BigdataLiteralImpl
toString() - Method in class com.bigdata.rdf.model.BigdataStatementImpl
toString(IRawTripleStore) - Method in class com.bigdata.rdf.model.BigdataStatementImpl
toString() - Method in class com.bigdata.rdf.model.BigdataURIImpl
toString() - Method in class com.bigdata.rdf.model.BigdataValueFactoryImpl
toString() - Method in class com.bigdata.rdf.rio.AsynchronousStatementBufferFactory
toString() - Method in class com.bigdata.rdf.rio.LoadStats
Human readable representation.
toString() - Method in class com.bigdata.rdf.rio.RDFParserOptions
toString() - Method in class com.bigdata.rdf.rio.StatementBuffer
toString() - Method in class com.bigdata.rdf.rules.BackchainAccessPath
toString(StringBuilder) - Method in class com.bigdata.rdf.rules.RDFJoinNexusFactory
toString() - Method in class com.bigdata.rdf.sail.BigdataSail.BigdataSailConnection
toString() - Method in class com.bigdata.rdf.sail.BigdataSailBooleanQuery
toString() - Method in class com.bigdata.rdf.sail.BigdataSailGraphQuery
toString() - Method in class com.bigdata.rdf.sail.BigdataSailRepositoryConnection
toString() - Method in class com.bigdata.rdf.sail.BigdataSailTupleQuery
toString() - Method in class com.bigdata.rdf.sail.BigdataSailUpdate
toString() - Method in class com.bigdata.rdf.sail.SailBase
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTBaseDecl
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTBlankNode
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTBlankNodePropertyList
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTCollection
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTCompare
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTDatasetClause
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTDescribe
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTIRI
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTLimit
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTMath
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTNumericLiteral
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTOffset
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTOrderCondition
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTPrefixDecl
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTQName
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTRDFLiteral
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTSelect
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTString
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.ASTVar
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.SimpleNode
toString(String) - Method in class com.bigdata.rdf.sail.sparql.ast.SimpleNode
toString() - Method in class com.bigdata.rdf.sail.sparql.ast.Token
Returns the image.
toString() - Method in class com.bigdata.rdf.sail.sparql.VerifyAggregates
toString() - Method in class com.bigdata.rdf.sail.webapp.AbstractRestApiTask
toString() - Method in class com.bigdata.rdf.sail.webapp.client.AbstractConnectOptions
toString() - Method in class com.bigdata.rdf.sail.webapp.client.RemoteRepository
toString() - Method in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryManager
toString() - Method in class com.bigdata.rdf.sail.webapp.ConnegScore
toString() - Method in class com.bigdata.rdf.sail.webapp.ConnegUtil
toString(ServletContext) - Static method in class com.bigdata.rdf.sail.webapp.HALoadBalancerServlet
toString() - Method in class com.bigdata.rdf.sail.webapp.HALoadBalancerServlet
toString() - Method in exception com.bigdata.rdf.sail.webapp.HttpOperationException
toString(StringBuilder) - Method in class com.bigdata.rdf.sail.webapp.lbs.AbstractHostLBSPolicy
toString() - Method in class com.bigdata.rdf.sail.webapp.lbs.AbstractLBSPolicy
Note: implementation is non-blocking!
toString(StringBuilder) - Method in class com.bigdata.rdf.sail.webapp.lbs.AbstractLBSPolicy
toString() - Method in class com.bigdata.rdf.sail.webapp.lbs.HostScore
toString() - Method in class com.bigdata.rdf.sail.webapp.lbs.HostTable
toString() - Method in class com.bigdata.rdf.sail.webapp.lbs.policy.counters.CounterSetHostMetricsWrapper
toString(StringBuilder) - Method in class com.bigdata.rdf.sail.webapp.lbs.policy.counters.CountersLBSPolicy
toString() - Method in class com.bigdata.rdf.sail.webapp.lbs.policy.ganglia.GangliaHostMetricWrapper
toString(StringBuilder) - Method in class com.bigdata.rdf.sail.webapp.lbs.policy.ganglia.GangliaLBSPolicy
toString(StringBuilder) - Method in class com.bigdata.rdf.sail.webapp.lbs.policy.RoundRobinLBSPolicy
toString() - Method in class com.bigdata.rdf.sail.webapp.lbs.ServiceScore
toString() - Method in class com.bigdata.rdf.sail.webapp.XMLBuilder.Node
toString(int) - Method in class com.bigdata.rdf.sparql.ast.AbstractFromToGraphManagement
toString(int) - Method in class com.bigdata.rdf.sparql.ast.AbstractGraphDataUpdate
toString(int) - Method in class com.bigdata.rdf.sparql.ast.AbstractOneGraphManagement
toString(int) - Method in class com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.AssignmentNode
toString() - Method in class com.bigdata.rdf.sparql.ast.ASTContainer
toString(int) - Method in class com.bigdata.rdf.sparql.ast.BindingsClause
toString() - Method in class com.bigdata.rdf.sparql.ast.CompiledSolutionSetStats
toString() - Method in class com.bigdata.rdf.sparql.ast.ComputedMaterializationRequirement
toString() - Method in class com.bigdata.rdf.sparql.ast.ConstantNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.ConstructNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.CreateEntailments
toString(int) - Method in class com.bigdata.rdf.sparql.ast.DatasetNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.DeleteInsertGraph
toString(int) - Method in class com.bigdata.rdf.sparql.ast.DisableEntailments
toString(int) - Method in class com.bigdata.rdf.sparql.ast.DropEntailments
toString(int) - Method in class com.bigdata.rdf.sparql.ast.EnableEntailments
toString() - Method in class com.bigdata.rdf.sparql.ast.eval.DataSetSummary
toString() - Method in class com.bigdata.rdf.sparql.ast.eval.DGExpander
toString() - Method in class com.bigdata.rdf.sparql.ast.eval.ServiceParams
toString() - Method in class com.bigdata.rdf.sparql.ast.explainhints.ExplainHint
toString() - Method in class com.bigdata.rdf.sparql.ast.explainhints.ExplainHints
toString(int) - Method in class com.bigdata.rdf.sparql.ast.FilterNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.FunctionNode
Provides a pretty print representation with recursive descent.
toString(int) - Method in class com.bigdata.rdf.sparql.ast.GroupByNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.GroupNodeBase
Simple but robust version of to-String
toString(int) - Method in class com.bigdata.rdf.sparql.ast.HavingNode
toString(int) - Method in interface com.bigdata.rdf.sparql.ast.IQueryNode
A string representation of a recursive structure with pretty-print indent.
toString(int) - Method in interface com.bigdata.rdf.sparql.ast.IValueExpressionNode
A string representation of a recursive structure with pretty-print indent.
toString() - Method in class com.bigdata.rdf.sparql.ast.JoinSetUtil.VertexJoinSet
toString(int) - Method in class com.bigdata.rdf.sparql.ast.LoadGraph
toString(int) - Method in class com.bigdata.rdf.sparql.ast.NamedSubqueriesNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.NamedSubqueryInclude
toString(int) - Method in class com.bigdata.rdf.sparql.ast.NamedSubqueryRoot
toString() - Method in class com.bigdata.rdf.sparql.ast.optimizers.StaticOptimizer
toString(int) - Method in class com.bigdata.rdf.sparql.ast.OrderByNode
toString() - Method in enum com.bigdata.rdf.sparql.ast.PathNode.PathMod
toString(int) - Method in class com.bigdata.rdf.sparql.ast.ProjectionNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.PropertyPathNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.QuadData
toString(int) - Method in class com.bigdata.rdf.sparql.ast.QuadsDataOrNamedSolutionSet
toString(int) - Method in class com.bigdata.rdf.sparql.ast.QueryBase
toString() - Method in class com.bigdata.rdf.sparql.ast.QueryNodeBase
toString(int) - Method in class com.bigdata.rdf.sparql.ast.QueryNodeListBaseNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.QueryRoot
toString(int, IBindingSet[]) - Method in class com.bigdata.rdf.sparql.ast.QueryRoot
toString() - Method in class com.bigdata.rdf.sparql.ast.service.history.HistoryChangeRecord
toString() - Method in class com.bigdata.rdf.sparql.ast.service.RemoteServiceCallImpl
toString() - Method in class com.bigdata.rdf.sparql.ast.service.RemoteServiceOptions
toString(int) - Method in class com.bigdata.rdf.sparql.ast.service.ServiceNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.SliceNode
toString() - Method in class com.bigdata.rdf.sparql.ast.ssets.SolutionSetManager
toString(int) - Method in class com.bigdata.rdf.sparql.ast.StatementPatternNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.SubqueryRoot
The contract of this method at this level is under-specified.
toString(int) - Method in class com.bigdata.rdf.sparql.ast.TermNode
toString(int) - Method in class com.bigdata.rdf.sparql.ast.UpdateRoot
toString() - Method in class com.bigdata.rdf.sparql.ast.VarNode
Overridden to mark metadata about variables.
toString(int) - Method in class com.bigdata.rdf.sparql.ast.ZeroLengthPathNode
Deprecated.
toString() - Method in class com.bigdata.rdf.spo.Binding
toString() - Method in class com.bigdata.rdf.spo.InGraphBinarySearchFilter
toString() - Method in class com.bigdata.rdf.spo.InGraphHashSetFilter
toString(IRawTripleStore) - Method in interface com.bigdata.rdf.spo.ISPO
toString() - Method in class com.bigdata.rdf.spo.SPO
Return a representation of the statement using the term identifiers (the
identifiers are NOT resolved to terms).
toString(IV) - Static method in class com.bigdata.rdf.spo.SPO
Represents the term identifier together with its type (literal, bnode,
uri, or statement identifier).
toString(IRawTripleStore) - Method in class com.bigdata.rdf.spo.SPO
toString() - Method in class com.bigdata.rdf.spo.SPOKeyOrder
toString() - Method in class com.bigdata.rdf.spo.SPOStarJoin.SPOStarConstraint
toString(IBindingSet) - Method in class com.bigdata.rdf.spo.SPOStarJoin.SPOStarConstraint
toString(IBindingSet) - Method in class com.bigdata.rdf.spo.SPOStarJoin
toString(IV, IV, IV) - Method in class com.bigdata.rdf.store.AbstractTripleStore
toString(IV, IV, IV, IV) - Method in class com.bigdata.rdf.store.AbstractTripleStore
toString(ISPO) - Method in class com.bigdata.rdf.store.AbstractTripleStore
toString(IV) - Method in class com.bigdata.rdf.store.AbstractTripleStore
toString() - Method in class com.bigdata.rdf.store.DataLoader.MyLoadStats
toString(IV, IV, IV, IV) - Method in interface com.bigdata.rdf.store.IRawTripleStore
Externalizes a quad or a triple with a statement identifier using an
abbreviated syntax.
toString(IV, IV, IV) - Method in interface com.bigdata.rdf.store.IRawTripleStore
toString(IV) - Method in interface com.bigdata.rdf.store.IRawTripleStore
Externalizes a term using an abbreviated syntax.
toString() - Method in class com.bigdata.rdf.task.AbstractApiTask
toString() - Method in class com.bigdata.rdf.task.ApiTaskForJournal
toString() - Method in class com.bigdata.relation.AbstractResource
The class name, timestamp and namespace for the relation view.
toString() - Method in class com.bigdata.relation.accesspath.AccessPath
toString() - Method in class com.bigdata.relation.accesspath.BlockingBuffer.BlockingIterator
Safe non-blocking representation of the iterator state.
toString() - Method in class com.bigdata.relation.accesspath.BlockingBuffer
toString() - Method in class com.bigdata.relation.accesspath.ElementFilter
Human readable representation of the filter chain.
toString() - Method in class com.bigdata.relation.rule.Binding
toString() - Method in class com.bigdata.relation.rule.eval.AbstractJoinNexusFactory
toString(StringBuilder) - Method in class com.bigdata.relation.rule.eval.AbstractJoinNexusFactory
toString() - Method in class com.bigdata.relation.rule.eval.AbstractStepTask
toString() - Method in interface com.bigdata.relation.rule.eval.IRuleState
Externalizes the rule and the evaluation order.
toString(IBindingSet) - Method in interface com.bigdata.relation.rule.eval.IRuleState
Shows the bindings (if given), the computed evaluation order, and the
computed
IKeyOrder
for each
IPredicate
in the rule.
toString() - Method in class com.bigdata.relation.rule.eval.pipeline.JoinStats
toString(IRule, IRuleState, JoinStats[]) - Static method in class com.bigdata.relation.rule.eval.pipeline.JoinStats
Formats the array of
JoinStats
into a CSV table view.
toString() - Method in class com.bigdata.relation.rule.eval.pipeline.JoinTask.AccessPathTask
toString() - Method in class com.bigdata.relation.rule.eval.pipeline.JoinTask
toString() - Method in class com.bigdata.relation.rule.eval.pipeline.JoinTaskFactoryTask
toString() - Method in class com.bigdata.relation.rule.eval.pipeline.JoinTaskSink
toString() - Method in class com.bigdata.relation.rule.eval.RuleState
Externalizes the rule and the evaluation order.
toString(IBindingSet) - Method in class com.bigdata.relation.rule.eval.RuleState
Shows the bindings (if given), the computed evaluation order, the
computed
IKeyOrder
, and the required variables for each
IPredicate
in the rule.
toString(IPredicate) - Method in class com.bigdata.relation.rule.eval.RuleStats
Return a human readable representation of the predicate.
toString() - Method in class com.bigdata.relation.rule.eval.RuleStats
Reports aggregate and details.
toString(long, boolean) - Method in class com.bigdata.relation.rule.eval.RuleStats
toString() - Method in class com.bigdata.relation.rule.eval.Solution
toString() - Method in class com.bigdata.relation.rule.eval.SolutionFilter
toString() - Method in interface com.bigdata.relation.rule.IRule
Externalizes the rule displaying variable names and constants.
toString(IBindingSet) - Method in interface com.bigdata.relation.rule.IRule
Externalizes the rule displaying variable names, their bindings, and
constants.
toString() - Method in interface com.bigdata.relation.rule.IStep
A human readable representation of the
IStep
.
toString(int) - Method in class com.bigdata.relation.rule.Program
toString() - Method in class com.bigdata.relation.rule.Program
toString() - Method in class com.bigdata.relation.rule.QueryOptions
toString() - Method in class com.bigdata.relation.rule.Rule
toString(IBindingSet) - Method in class com.bigdata.relation.rule.Rule
toString() - Method in class com.bigdata.relation.rule.Slice
toString(String, Object[]) - Static method in class com.bigdata.resources.AbstractResourceManagerTask
Pretty print a resource metadata array or other array of objects with
long string representations by framing the output to have one line
for each element of the array.
toString() - Method in class com.bigdata.resources.AbstractResult
toString() - Method in class com.bigdata.resources.BuildResult
toString() - Method in class com.bigdata.resources.JoinResult
toString() - Method in class com.bigdata.resources.MoveResult
toString() - Method in class com.bigdata.resources.PurgeResult
toString() - Method in class com.bigdata.resources.SplitResult
toString() - Method in class com.bigdata.resources.StoreManager.ManagedJournal
toString(RWStore) - Method in class com.bigdata.rwstore.RWStore.DeleteBlockStats
toString() - Method in class com.bigdata.rwstore.RWStore.RWStoreState
toString() - Method in class com.bigdata.rwstore.sector.MemoryManager
toString(long) - Method in class com.bigdata.rwstore.sector.MemStore
toString(long) - Method in class com.bigdata.rwstore.sector.MemStrategy
toString() - Method in class com.bigdata.rwstore.sector.SectorAllocator
toString() - Method in class com.bigdata.search.Hit
toString() - Method in class com.bigdata.search.Hiterator
toString() - Method in class com.bigdata.search.ReadOnlyTermDocRecord
toString() - Method in class com.bigdata.search.TermMetadata
toString() - Method in class com.bigdata.service.AbstractTransactionService.TxState
Returns a string representation of the transaction state.
toString() - Method in class com.bigdata.service.CacheOnceMetadataIndex
toString() - Method in class com.bigdata.service.Event
Tab-delimited format (with newline).
toString() - Method in class com.bigdata.service.EventResource
Formats the resource (indexName, partitionId, and file) in a manner
designed to give pleasing results when aggregating
Event
s by
EventResource
.
toString() - Method in class com.bigdata.service.fts.FulltextSearchHit
toString() - Method in class com.bigdata.service.fts.FulltextSearchHiterator
toString() - Method in enum com.bigdata.service.geospatial.GeoSpatial.GeoFunction
toString() - Method in class com.bigdata.service.geospatial.impl.GeoSpatialUtility.BoundingBoxLatLonTime
toString() - Method in class com.bigdata.service.geospatial.impl.GeoSpatialUtility.PointLatLon
toString() - Method in class com.bigdata.service.geospatial.impl.GeoSpatialUtility.PointLatLonTime
toString() - Method in class com.bigdata.service.HostScore
toString() - Method in class com.bigdata.service.master.FileSystemScanner
toString() - Method in class com.bigdata.service.ndx.AbstractScaleOutClientIndexView
toString() - Method in class com.bigdata.service.ndx.ClientIndexView
toString() - Method in class com.bigdata.service.ndx.PartitionedTupleIterator
toString() - Method in class com.bigdata.service.ndx.pipeline.AbstractMasterStats
toString() - Method in class com.bigdata.service.ndx.pipeline.AbstractRunnableMasterStats
toString() - Method in class com.bigdata.service.ndx.pipeline.AbstractSubtask
toString() - Method in class com.bigdata.service.ndx.pipeline.AbstractSubtaskStats
toString() - Method in class com.bigdata.service.ndx.pipeline.IndexPartitionWriteTask
toString() - Method in class com.bigdata.service.ndx.pipeline.IndexWriteTask
toString() - Method in class com.bigdata.service.ndx.ScaleOutIndexCounters
toString() - Method in class com.bigdata.service.ServiceScore
toString() - Method in class com.bigdata.service.Split
Human friendly representation.
toString() - Method in class com.bigdata.sparse.KeyDecoder
Shows some of the data that is extracted.
toString() - Method in class com.bigdata.sparse.Schema
toString() - Method in class com.bigdata.sparse.SingleColumnFilter
toString() - Method in class com.bigdata.sparse.TPS
toString() - Method in class com.bigdata.sparse.TPS.TP
toString() - Method in class com.bigdata.sparse.TPS.TPV
toString(StringBuilder) - Method in class com.bigdata.stream.Stream.StreamIndexMetadata
toString(byte) - Static method in class com.bigdata.util.Bits
Useful for debugging.
toString(byte[]) - Static method in class com.bigdata.util.BytesUtil
Formats a key as a series of comma delimited unsigned bytes.
toString(byte[], int, int) - Static method in class com.bigdata.util.BytesUtil
Formats a key as a series of comma delimited unsigned bytes.
toString(byte[][]) - Static method in class com.bigdata.util.BytesUtil
Formats the data into a
String
.
toString() - Method in class com.bigdata.util.concurrent.Latch
toString() - Method in class com.bigdata.util.concurrent.TaskCounters
toString() - Method in class com.bigdata.util.CSVReader.Header
toString(String, String) - Method in class com.bigdata.util.httpd.MIMEType
This method may be extended to produce a specific
represensation of the value of the indicated parameter.
toString() - Method in class com.bigdata.util.httpd.MIMEType
Generates a MIME type string from the parsed data.
toString() - Method in class com.bigdata.util.httpd.TestMIMEType.Criteria
toString() - Method in class com.bigdata.util.NT
toString() - Method in class com.bigdata.util.NV
toString() - Method in class cutthecrap.utils.striterators.FilterBase
Human readable representation of the filter chain.
toString() - Method in class cutthecrap.utils.striterators.Striterator
Human readable representation of the filter chain.
toString() - Method in class it.unimi.dsi.bits.AbstractBitVector
Returns a string representation of this vector.
toString() - Method in class it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList
Modified to dump internal record metadata and to show the byte[]s as
unsigned values.
toString(byte[]) - Static method in class it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList
Formats a key as a series of comma delimited unsigned bytes.
toString(byte[], int, int) - Static method in class it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList
Formats a key as a series of comma delimited unsigned bytes.
toString() - Method in class it.unimi.dsi.io.DelimitedWordReader
toString() - Method in class it.unimi.dsi.io.FastBufferedReader
toString() - Method in class it.unimi.dsi.io.FileLinesCollection
toString() - Method in class it.unimi.dsi.lang.MutableString
toString() - Method in class it.unimi.dsi.logging.ProgressLogger
Converts the data stored in this progress logger to a string.
toString() - Method in class it.unimi.dsi.parser.Attribute
Returns the name of this attribute.
toString() - Method in class it.unimi.dsi.parser.callback.DebugCallbackDecorator
toString() - Method in class it.unimi.dsi.parser.Element
Returns the name of this element.
toString() - Method in class it.unimi.dsi.parser.Entity
Returns the name of this entity.
toString() - Method in class it.unimi.dsi.util.ImmutableBinaryTrie.Node
toString() - Method in class it.unimi.dsi.util.ImmutableBinaryTrie
toString() - Method in class it.unimi.dsi.util.Interval
toString() - Method in class it.unimi.dsi.util.Properties
toString() - Method in class it.unimi.dsi.util.TextPattern
toString2(BOp) - Static method in class com.bigdata.bop.BOpUtility
toStringAtomic() - Method in class com.bigdata.quorum.AbstractQuorum
Return a human readable representation of an atomic snapshot of the local
copy of the distributed quorum state.
toStringByValue() - Method in class cern.colt.map.AbstractDoubleIntMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by value.
toStringByValue() - Method in class cern.colt.map.AbstractIntDoubleMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by value.
toStringByValue() - Method in class cern.colt.map.AbstractIntIntMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by value.
toStringByValue() - Method in class cern.colt.map.AbstractIntObjectMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by value, according to natural ordering.
toStringByValue() - Method in class cern.colt.map.AbstractLongObjectMap
Returns a string representation of the receiver, containing
the String representation of each key-value pair, sorted ascending by value, according to natural ordering.
toStrings(Resource[]) - Static method in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryBase
Convert an array of URIs to an array of URI strings.
toStringShort() - Method in class cern.colt.matrix.impl.AbstractMatrix1D
Returns a string representation of the receiver's shape.
toStringShort() - Method in class cern.colt.matrix.impl.AbstractMatrix2D
Returns a string representation of the receiver's shape.
toStringShort() - Method in class cern.colt.matrix.impl.AbstractMatrix3D
Returns a string representation of the receiver's shape.
toStringSimple(int, boolean, boolean) - Method in class com.bigdata.relation.rule.eval.RuleStats
Reports just the data for this record.
totalBucketSize - Variable in class com.bigdata.rdf.lexicon.BlobsWriteProc.Result
The total size of the hash collision buckets examined across all
Value
s in the request.
totalMemory() - Method in interface cern.jet.stat.quantile.DoubleQuantileFinder
Returns the number of elements currently needed to store all contained elements.
totalTermCount() - Method in class com.bigdata.search.TermFrequencyData
The total #of terms, including duplicates.
totalTime - Variable in class com.bigdata.rdf.rio.LoadStats
totalWaste(long) - Method in class com.bigdata.rwstore.StorageStats.Bucket
toTime - Variable in class com.bigdata.counters.query.URLQueryModel
The exclusive upper bound in milliseconds of the timestamp for the
counters or events to be selected.
toTime - Variable in class com.bigdata.sparse.AbstractAtomicRowReadOrWrite
toTimeUnit() - Method in enum com.bigdata.counters.PeriodEnum
toTitleString(DoubleMatrix2D, String[], String[], String, String, String) - Method in class cern.colt.matrix.doublealgo.Formatter
Returns a string representation of the given matrix with axis as well as rows and columns labeled.
toTitleString(ObjectMatrix2D, String[], String[], String, String, String) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string representation of the given matrix with axis as well as rows and columns labeled.
toTitleString(ObjectMatrix3D, String[], String[], String[], String, String, String, String) - Method in class cern.colt.matrix.objectalgo.Formatter
Returns a string representation of the given matrix with axis as well as rows and columns labeled.
touch(AbstractNode<?>) - Method in class com.bigdata.btree.AbstractBTree
This method is responsible for putting the node or leaf onto the ring
buffer which controls (a) how long we retain a hard reference to the node
or leaf; and (b) for writes, when the node or leaf is evicted with a zero
reference count and made persistent (along with all dirty children).
touch(AbstractPage) - Method in class com.bigdata.htree.AbstractHTree
This method is responsible for putting the node or leaf onto the ring
buffer which controls (a) how long we retain a hard reference to the node
or leaf; and (b) for writes, when the node or leaf is evicted with a zero
reference count and made persistent (along with all dirty children).
toUpperCase() - Method in class it.unimi.dsi.lang.MutableString
Converts all of the characters in this mutable string to upper
case using the rules of the default locale.
toURI(Element) - Method in interface com.bigdata.blueprints.BlueprintsValueFactory
Create an element URI from a blueprints element id.
toURI(Element) - Method in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
Create an element URI from a blueprints element id.
toURI(int) - Static method in exception com.bigdata.rdf.error.SparqlDynamicErrorException
toURI(int) - Static method in exception com.bigdata.rdf.error.SparqlStaticErrorException
toURI(int) - Static method in exception com.bigdata.rdf.error.SparqlTypeErrorException
toURI(W3CQueryLanguageException.LanguageFamily, W3CQueryLanguageException.ErrorCategory, int, NV[]) - Static method in exception com.bigdata.rdf.error.W3CQueryLanguageException
Return the URI for the given error.
toURIs(String[]) - Static method in class com.bigdata.rdf.sail.webapp.BigdataRDFServlet
Convert an array of URI strings to an array of URIs.
toValidatedCustomFieldsConstraints(String[], Object[], Object[]) - Static method in class com.bigdata.service.geospatial.impl.GeoSpatialQuery
Constructs a validated custom fields constraints from the parsed user input.
toValueExpression(VarNode) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
toValueExpression(ConstantNode) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
toVE(BOpContextBase, GlobalAnnotations, IValueExpressionNode) - Static method in class com.bigdata.rdf.sparql.ast.eval.AST2BOpUtility
toVE(BOpContextBase, GlobalAnnotations, URI, Map<String, Object>, ValueExpressionNode...) - Static method in class com.bigdata.rdf.sparql.ast.FunctionRegistry
toVerboseString(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Algebra
Returns the results of toString(A) and additionally the results of all sorts of decompositions applied to the given matrix.
toVertexURI(Object) - Method in interface com.bigdata.blueprints.BlueprintsValueFactory
Create a vertex URI from a blueprints vertex id.
toVertexURI(Object) - Method in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
Create a vertex URI from a blueprints vertex id.
toZOrder(int) - Method in interface com.bigdata.btree.keys.IKeyBuilder
Converts the key into a z-order byte array, assuming numDimensions components
of type Long (i.e., 64bit each).
toZOrder(int) - Method in class com.bigdata.btree.keys.KeyBuilder
toZOrderByteArray(Object[]) - Method in class com.bigdata.rdf.internal.impl.extensions.GeoSpatialLiteralExtension
Create a two-components byte[] from a component array.
toZOrderByteArray(long[], GeoSpatialDatatypeConfiguration) - Method in class com.bigdata.rdf.internal.impl.extensions.GeoSpatialLiteralExtension
Converts a long array representing the components to a z-order byte array.
toZOrderByteArray(BigInteger) - Method in class com.bigdata.rdf.internal.impl.extensions.GeoSpatialLiteralExtension
Decodes a BigInteger into a zOrder byte[] (without leading zero).
toZOrderByteArray(AbstractLiteralIV<BigdataLiteral, ?>) - Method in class com.bigdata.rdf.internal.impl.extensions.GeoSpatialLiteralExtension
Converts an IV to a zOrderByte array (without leading zero).
TPS - Class in com.bigdata.sparse
Default implementation.
TPS() - Constructor for class com.bigdata.sparse.TPS
De-serialization constructor.
TPS(Schema, long) - Constructor for class com.bigdata.sparse.TPS
TPS.TP - Class in com.bigdata.sparse
A {property, timestamp} tuple.
TPS.TP(String, long) - Constructor for class com.bigdata.sparse.TPS.TP
TPS.TPV - Class in com.bigdata.sparse
Helper class models a single property value as of a given timestamp.
TPS.TPV(Schema, String, long, Object) - Constructor for class com.bigdata.sparse.TPS.TPV
TPS.TPVComparator - Class in com.bigdata.sparse
Imposes ordering based on schema, property name, and timestamp.
TPSTupleSerializer - Class in com.bigdata.sparse
TPSTupleSerializer() - Constructor for class com.bigdata.sparse.TPSTupleSerializer
De-serializator ctor.
TPSTupleSerializer(IKeyBuilderFactory) - Constructor for class com.bigdata.sparse.TPSTupleSerializer
TR - Static variable in class it.unimi.dsi.parser.Element
trace(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Algebra
Returns the sum of the diagonal elements of matrix A; Sum(A[i,i]).
trace - Static variable in class com.bigdata.service.proxy.ClientAsynchronousIterator
Enables low-level trace of the ReaderTask
.
traceState() - Method in interface com.bigdata.rdf.graph.IGASState
Conditionally log various interesting information about the state of the
computation.
traceState() - Method in class com.bigdata.rdf.graph.impl.bd.BigdataGASState
Conditionally log various interesting information about the state of the
computation.
traceState() - Method in class com.bigdata.rdf.graph.impl.GASState
trackedRunnable(long) - Static method in class com.bigdata.jsr166.JSR166TestCase
trackSlotSize(long) - Method in class com.bigdata.btree.PageStats
Track the histogram of allocation sizes.
transactionAborted() - Method in class com.bigdata.blueprints.BigdataGraphBulkLoad
transactionAborted() - Method in class com.bigdata.blueprints.BigdataGraphEmbedded
Notification of transaction aborted.
transactionAborted() - Method in interface com.bigdata.blueprints.BigdataGraphListener
transactionAborted() - Method in class com.bigdata.blueprints.MutationListener
transactionAborted() - Method in class com.bigdata.rdf.changesets.DelegatingChangeLog
transactionAborted() - Method in interface com.bigdata.rdf.changesets.IChangeLog
Occurs if the current SAIL transaction is aborted.
transactionAborted() - Method in class com.bigdata.rdf.changesets.InferenceChangeLogReporter
transactionAborted() - Method in class com.bigdata.rdf.changesets.InMemChangeLog
transactionAborted() - Method in class com.bigdata.rdf.sail.RDRHistory
Close out the temp store.
transactionAborted() - Method in class com.bigdata.rdf.sail.TestSparqlUpdateCommit.CommitCounter
transactionBegin() - Method in class com.bigdata.blueprints.BigdataGraphBulkLoad
transactionBegin() - Method in class com.bigdata.blueprints.BigdataGraphEmbedded
Notification of transaction beginning.
transactionBegin() - Method in interface com.bigdata.blueprints.BigdataGraphListener
transactionBegin() - Method in class com.bigdata.blueprints.MutationListener
transactionBegin() - Method in class com.bigdata.rdf.changesets.DelegatingChangeLog
transactionBegin() - Method in interface com.bigdata.rdf.changesets.IChangeLog
Message issued when a new transaction will begin.
transactionBegin() - Method in class com.bigdata.rdf.changesets.InferenceChangeLogReporter
transactionBegin() - Method in class com.bigdata.rdf.changesets.InMemChangeLog
transactionBegin() - Method in class com.bigdata.rdf.sail.RDRHistory
Noop.
transactionBegin() - Method in class com.bigdata.rdf.sail.TestSparqlUpdateCommit.CommitCounter
transactionCommited(long) - Method in class com.bigdata.blueprints.BigdataGraphBulkLoad
transactionCommited(long) - Method in class com.bigdata.blueprints.BigdataGraphEmbedded
Notification of transaction committed.
transactionCommited(long) - Method in interface com.bigdata.blueprints.BigdataGraphListener
transactionCommited(long) - Method in class com.bigdata.blueprints.MutationListener
transactionCommited(long) - Method in class com.bigdata.rdf.changesets.DelegatingChangeLog
transactionCommited(long) - Method in interface com.bigdata.rdf.changesets.IChangeLog
Occurs when the current SAIL transaction is committed.
transactionCommited(long) - Method in class com.bigdata.rdf.changesets.InferenceChangeLogReporter
transactionCommited(long) - Method in class com.bigdata.rdf.changesets.InMemChangeLog
transactionCommited(long) - Method in class com.bigdata.rdf.sail.RDRHistory
Copy the statements from the temp store into the database, replacing the
object position of each statement with the commit time, then close
out the temp store.
transactionCommited(long) - Method in class com.bigdata.rdf.sail.TestSparqlUpdateCommit.CommitCounter
transactionManager - Variable in class com.bigdata.journal.AbstractTask
The object used to manage local transactions.
transactionManager - Static variable in interface com.bigdata.journal.Journal.IJournalCounters
The namespace for the counters pertaining to the ILocalTransactionService
.
transactionManager - Static variable in interface com.bigdata.service.DataService.IDataServiceCounters
The namespace for the counters pertaining to the ILocalTransactionService
.
TransactionNotFoundException - Exception in com.bigdata.journal
Typed exception thrown when a transaction identifier can not be resolved.
TransactionNotFoundException(long) - Constructor for exception com.bigdata.journal.TransactionNotFoundException
transactionPrepare() - Method in class com.bigdata.blueprints.BigdataGraphBulkLoad
transactionPrepare() - Method in class com.bigdata.blueprints.BigdataGraphEmbedded
Notification of transaction preparing for commit.
transactionPrepare() - Method in interface com.bigdata.blueprints.BigdataGraphListener
transactionPrepare() - Method in class com.bigdata.blueprints.MutationListener
transactionPrepare() - Method in class com.bigdata.rdf.changesets.DelegatingChangeLog
transactionPrepare() - Method in interface com.bigdata.rdf.changesets.IChangeLog
Message issued when preparing for a commit.
transactionPrepare() - Method in class com.bigdata.rdf.changesets.InferenceChangeLogReporter
transactionPrepare() - Method in class com.bigdata.rdf.changesets.InMemChangeLog
transactionPrepare() - Method in class com.bigdata.rdf.sail.RDRHistory
Noop.
transactionPrepare() - Method in class com.bigdata.rdf.sail.TestSparqlUpdateCommit.CommitCounter
transfer(InputStream, OutputStream) - Method in class com.bigdata.service.ResourceService.FetchResourceTask
transferAll(FileChannel, long, long, RandomAccessFile, long) - Static method in class com.bigdata.io.FileChannelUtility
FileChannel
to
FileChannel
transfer of
count bytes
from the
sourceChannel starting at the
fromPosition onto
the
out file starting at its current position.
transferFromDiskTo(IDiskBasedStrategy, RandomAccessFile) - Static method in class com.bigdata.journal.AbstractBufferStrategy
transferRate - Variable in class com.bigdata.bop.cost.DiskCostModel
The average disk transfer rate (megabytes per second).
transferTo(RandomAccessFile) - Method in class com.bigdata.journal.BasicBufferStrategy
Note: This is synchronized so that concurrent writers must block during
this operation.
transferTo(RandomAccessFile) - Method in class com.bigdata.journal.DiskBackedBufferStrategy
transferTo(RandomAccessFile) - Method in class com.bigdata.journal.DiskOnlyStrategy
Deprecated.
transferTo(RandomAccessFile) - Method in interface com.bigdata.journal.IBufferStrategy
A block operation that transfers the serialized records (aka the written
on portion of the user extent) en mass from the buffer onto an output
file.
transferTo(RandomAccessFile) - Method in class com.bigdata.journal.RWStrategy
Operation is not supported.
transferTo(RandomAccessFile) - Method in class com.bigdata.journal.WORMStrategy
transferTo(RandomAccessFile) - Method in class com.bigdata.rwstore.sector.MemStrategy
Transform - Class in cern.colt.matrix.doublealgo
Deprecated.
Transform() - Constructor for class cern.colt.matrix.doublealgo.Transform
Deprecated.
Makes this class non instantiable, but still let's others inherit from it.
transform - Static variable in class cern.colt.matrix.doublealgo.Transform
Deprecated.
Little trick to allow for "aliasing", that is, renaming this class.
TransformationStrategies - Class in it.unimi.dsi.bits
A class providing static methods and objects that do useful things with transformation strategies.
TransformationStrategies() - Constructor for class it.unimi.dsi.bits.TransformationStrategies
TransformationStrategy<T> - Interface in it.unimi.dsi.bits
A generic transformation from objects of a given type to bit vector.
TRANSIENT - Static variable in interface com.bigdata.service.LoadBalancerService.Options
When true
the load balancer will not record any state on
the disk (neither events nor counters).
TransientBufferStrategy - Class in com.bigdata.journal
Transient buffer strategy uses a direct buffer but never writes on disk.
TransientResourceMetadata - Class in com.bigdata.rawstore
TransientResourceMetadata(UUID) - Constructor for class com.bigdata.rawstore.TransientResourceMetadata
TRANSITIVITY_VAR_LEFT - Static variable in interface com.bigdata.bop.paths.ArbitraryLengthPathOp.Annotations
The left transitivity variable.
TRANSITIVITY_VAR_LEFT - Static variable in interface com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode.Annotations
The left transitivity variable.
TRANSITIVITY_VAR_RIGHT - Static variable in interface com.bigdata.bop.paths.ArbitraryLengthPathOp.Annotations
The right transitivity variable.
TRANSITIVITY_VAR_RIGHT - Static variable in interface com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode.Annotations
The right transitivity variable.
translateValue(Object) - Method in class com.bigdata.ganglia.GangliaMetadataMessage
Return a value which may have been scaled and/or offset in order to align
the value with the metric declaration.
translateValue(Object) - Method in interface com.bigdata.ganglia.IGangliaMetadataMessage
Return a value which may have been scaled and/or offset in order to align
the value with the metric declaration.
transpose(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Algebra
Constructs and returns a new view which is the transposition of the given matrix A.
trapezoidalLower(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Algebra
Modifies the matrix to be a lower trapezoidal matrix.
TRAVERSAL_DIRECTION - Static variable in interface com.bigdata.rdf.graph.impl.bd.GASService.Options
TraversalDirectionEnum - Enum in com.bigdata.rdf.graph
Typesafe enumeration of manner in which an RDF graph will be traversed by an
IGASProgram
based on its
EdgesEnum
.
TreeDecoder - Class in it.unimi.dsi.compression
A decoder that follows 0/1 labelled paths in a tree.
TreeDecoder(TreeDecoder.Node, int) - Constructor for class it.unimi.dsi.compression.TreeDecoder
Creates a new codeword-based decoder using the given tree.
TreeDecoder(BitVector[], int[]) - Constructor for class it.unimi.dsi.compression.TreeDecoder
Creates a new codeword-based decoder starting from a set
of complete, lexicographically ordered codewords.
TreeDecoder.LeafNode - Class in it.unimi.dsi.compression
A leaf node of the decoding tree.
TreeDecoder.LeafNode(int) - Constructor for class it.unimi.dsi.compression.TreeDecoder.LeafNode
Creates a leaf node.
TreeDecoder.Node - Class in it.unimi.dsi.compression
A internal node of the decoding tree.
TreeDecoder.Node() - Constructor for class it.unimi.dsi.compression.TreeDecoder.Node
TREF_CLOSE - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
RegularExpression Id.
TREF_OPEN - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
RegularExpression Id.
TRefPattern() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TRIG - Static variable in class com.bigdata.rdf.sail.webapp.SD
trigData() - Method in class com.bigdata.rdf.sparql.ast.eval.AbstractInlineSELECTTestCase.Execute
trigData() - Method in class com.bigdata.rdf.sparql.ast.eval.AbstractInlineSELECTTestCase
trigData() - Method in class com.bigdata.rdf.sparql.ast.eval.TestUnionMinus
trim() - Method in class com.bigdata.io.ByteArrayBuffer
Trims the backing byte[] to an exact fit by making a copy of the data in
the buffer and returns the old byte[].
trim(String[]) - Method in class com.bigdata.util.CSVReader
trim() - Method in class it.unimi.dsi.bits.LongArrayBitVector
Reduces as must as possible the size of the backing array.
trim() - Method in class it.unimi.dsi.lang.MutableString
Trims all leading and trailing whitespace from this string.
trimLeft() - Method in class it.unimi.dsi.lang.MutableString
Trims all leading whitespace from this string.
trimmedMean(DoubleArrayList, double, int, int) - Static method in class cern.jet.stat.Descriptive
Returns the trimmed mean of a sorted data sequence.
trimRight() - Method in class it.unimi.dsi.lang.MutableString
Trims all trailing whitespace from this string.
trimSector(long, SectorAllocator) - Method in interface com.bigdata.rwstore.sector.ISectorManager
When a sector is first created, it will remain at the head of the free
list until one of two conditions has been reached:
The allocation has been saturated.
The bit space has been filled.
trimSector(long, SectorAllocator) - Method in class com.bigdata.rwstore.sector.MemoryManager
trimToCapacity(byte[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(char[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(double[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(float[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(int[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(long[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(Object[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(short[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToCapacity(boolean[], int) - Static method in class cern.colt.Arrays
Ensures that the specified array cannot hold more than maxCapacity elements.
trimToSize() - Method in class cern.colt.list.AbstractList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.BooleanArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.ByteArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.CharArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.DistinctNumberList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.DoubleArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.FloatArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.IntArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.LongArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.MinMaxNumberList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.ObjectArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.ShortArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.list.SimpleLongArrayList
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.map.AbstractMap
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.map.OpenDoubleIntHashMap
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.map.OpenIntDoubleHashMap
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.map.OpenIntIntHashMap
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.map.OpenIntObjectHashMap
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.map.OpenLongObjectHashMap
Trims the capacity of the receiver to be the receiver's current
size.
trimToSize() - Method in class cern.colt.matrix.impl.AbstractMatrix
Releases any superfluous internal memory.
trimToSize() - Method in class cern.colt.matrix.impl.RCDoubleMatrix2D
trimToSize() - Method in class cern.colt.matrix.impl.SparseDoubleMatrix1D
Releases any superfluous memory created by explicitly putting zero values into cells formerly having non-zero values;
An application can use this operation to minimize the
storage of the receiver.
trimToSize() - Method in class cern.colt.matrix.impl.SparseDoubleMatrix2D
Releases any superfluous memory created by explicitly putting zero values into cells formerly having non-zero values;
An application can use this operation to minimize the
storage of the receiver.
trimToSize() - Method in class cern.colt.matrix.impl.SparseDoubleMatrix3D
Releases any superfluous memory created by explicitly putting zero values into cells formerly having non-zero values;
An application can use this operation to minimize the
storage of the receiver.
trimToSize() - Method in class cern.colt.matrix.impl.SparseObjectMatrix1D
Releases any superfluous memory created by explicitly putting zero values into cells formerly having non-zero values;
An application can use this operation to minimize the
storage of the receiver.
trimToSize() - Method in class cern.colt.matrix.impl.SparseObjectMatrix2D
Releases any superfluous memory created by explicitly putting zero values into cells formerly having non-zero values;
An application can use this operation to minimize the
storage of the receiver.
trimToSize() - Method in class cern.colt.matrix.impl.SparseObjectMatrix3D
Releases any superfluous memory created by explicitly putting zero values into cells formerly having non-zero values;
An application can use this operation to minimize the
storage of the receiver.
triplePartition(double[], double[], double[], int, int, double[], int, int, int[]) - Static method in class cern.colt.Partitioning
triplePartition(double[], double[], double[], int, int, double) - Static method in class cern.colt.Partitioning
triplePartition(int[], int[], int[], int, int, int[], int, int, int[]) - Static method in class cern.colt.Partitioning
triplePartition(int[], int[], int[], int, int, int) - Static method in class cern.colt.Partitioning
Same as
Partitioning.partition(int[],int,int,int)
except that this method
synchronously partitions three arrays at the same time;
all three arrays are partially sorted according to the elements of the primary array.
TriplePatternExprBuilder - Class in com.bigdata.rdf.sail.sparql
Class handles triple patterns and property paths.
TriplePatternExprBuilder(BigdataASTContext) - Constructor for class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
triples - Static variable in class com.bigdata.rdf.sail.contrib.TestOOMBug
triples - Static variable in class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
TRIPLES_MODE - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
Set up database in triples mode, no provenance.
TRIPLES_MODE_WITH_PROVENANCE - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
Set up database in triples mode with provenance.
TriplesBlock() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TriplesNode() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TriplesNodePath() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
triplesPerSecond() - Method in class com.bigdata.rdf.inf.ClosureStats
triplesPerSecond() - Method in class com.bigdata.rdf.rio.LoadStats
triplesPerSecond() - Method in class com.bigdata.rdf.sail.SPARQLUpdateEvent.LoadProgress
Report the parser rate in triples per second.
TriplesSameSubject() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TriplesSameSubjectPath() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TriplesTemplate() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
tripleStore - Variable in class com.bigdata.rdf.sail.webapp.SD
The KB instance that is being described (from the constructor).
tripleStore - Variable in class com.bigdata.rdf.sparql.AbstractBigdataExprBuilderTestCase
tripleStoreKeyOrderIterator() - Static method in class com.bigdata.rdf.spo.SPOKeyOrder
TripleStoreSchema - Class in com.bigdata.rdf.store
TripleStoreSchema() - Constructor for class com.bigdata.rdf.store.TripleStoreSchema
De-serialization ctor.
TripleStoreUtility - Class in com.bigdata.rdf.store
Utility class for comparing graphs for equality, bulk export, etc.
TripleStoreUtility() - Constructor for class com.bigdata.rdf.store.TripleStoreUtility
TRUE - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
RegularExpression Id.
TrueBOp - Class in com.bigdata.rdf.internal.constraints
Always evaluates to true.
TrueBOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.TrueBOp
Required shallow copy constructor.
TrueBOp(TrueBOp) - Constructor for class com.bigdata.rdf.internal.constraints.TrueBOp
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
truncate() - Method in class com.bigdata.journal.AbstractJournal
Truncate the backing buffer such that there is no remaining free space in
the journal.
truncate(long) - Method in class com.bigdata.journal.BasicBufferStrategy
truncate(long) - Method in class com.bigdata.journal.DirectBufferStrategy
truncate(long) - Method in class com.bigdata.journal.DiskOnlyStrategy
Deprecated.
truncate(long) - Method in interface com.bigdata.journal.IBufferStrategy
Either truncates or extends the journal.
truncate(long) - Method in class com.bigdata.journal.MappedBufferStrategy
Note: Extension and truncation of a mapped file are not possible with the
JDK since there is no way to guarentee that the mapped file will be
unmapped in a timely manner.
truncate(long) - Method in class com.bigdata.journal.RWStrategy
truncate(long) - Method in class com.bigdata.journal.WORMStrategy
truncate(long) - Method in class com.bigdata.rwstore.sector.MemStrategy
TRUTH_MAINTENANCE - Static variable in interface com.bigdata.rdf.sail.BigdataSail.Options
This optional boolean property may be used to specify whether or not
RDFS entailments are maintained by eager closure of the knowledge
base (the default is true
).
TruthMaintenance - Class in com.bigdata.rdf.inf
The
TruthMaintenance
class facilitates maintaining the RDF(S)+
closure on a database as
SPO
s are asserted or retracted.
TruthMaintenance(InferenceEngine) - Constructor for class com.bigdata.rdf.inf.TruthMaintenance
TruthMaintenance - Static variable in class com.bigdata.rdf.sail.webapp.SD
tryAcquireExclusive(long, TimeUnit) - Method in class com.bigdata.concurrent.AccessSemaphore
tryAcquireShared(long, TimeUnit) - Method in class com.bigdata.concurrent.AccessSemaphore
TryBeforeMaterializationConstraint - Class in com.bigdata.rdf.internal.constraints
This is useful when a solution can be filtered out before it goes through the
materialization pipeline.
TryBeforeMaterializationConstraint(IConstraint) - Constructor for class com.bigdata.rdf.internal.constraints.TryBeforeMaterializationConstraint
TryBeforeMaterializationConstraint(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.TryBeforeMaterializationConstraint
Required shallow copy constructor.
TryBeforeMaterializationConstraint(TryBeforeMaterializationConstraint) - Constructor for class com.bigdata.rdf.internal.constraints.TryBeforeMaterializationConstraint
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
tryCancelQuery(QueryEngine, UUID) - Static method in class com.bigdata.rdf.sail.QueryCancellationHelper
Attempt to cancel a running SPARQL Query
tryCancelUpdate(QueryEngine, RunningQuery) - Static method in class com.bigdata.rdf.sail.QueryCancellationHelper
Attempt to cancel a running SPARQL UPDATE request.
tryCancelUpdate(QueryEngine, UUID, Future<Void>) - Static method in class com.bigdata.rdf.sail.QueryCancellationHelper
tryGetRunState(int) - Method in class com.bigdata.bop.engine.AbstractRunningQuery
Attempt to return the RunState.RunStateEnum
for an operator
(non-blocking).
tryLock(long, TimeUnit) - Method in class com.bigdata.journal.WriteExecutorService
Acquires an exclusive lock on the write service.
TT - Static variable in class it.unimi.dsi.parser.Element
ttlPrefixes() - Method in class com.bigdata.rdf.sparql.ast.eval.AbstractInlineSELECTTestCase
tuple - Variable in class com.bigdata.btree.AbstractBTreeTupleCursor
From the ctor.
tuple() - Method in class com.bigdata.btree.AbstractBTreeTupleCursor
tuple() - Method in interface com.bigdata.btree.ITupleCursor2
The tuple reflecting the data in the index at the current cursor
position.
Tuple<E> - Class in com.bigdata.btree
A key-value pair used to facilitate some iterator constructs.
Tuple(AbstractBTree, int) - Constructor for class com.bigdata.btree.Tuple
TupleFilter<E> - Class in com.bigdata.btree.filter
TupleFilter() - Constructor for class com.bigdata.btree.filter.TupleFilter
TupleFilter.TupleFilterator<E> - Class in com.bigdata.btree.filter
Implementation class knows how to avoid side-effects from the reuse of
the same
Tuple
instance by the base
ITupleIterator
impls.
TupleFilter.TupleFilterator(ITupleIterator<E>, Object, TupleFilter<E>) - Constructor for class com.bigdata.btree.filter.TupleFilter.TupleFilterator
TupleObjectResolver<R> - Class in com.bigdata.relation.accesspath
TupleObjectResolver() - Constructor for class com.bigdata.relation.accesspath.TupleObjectResolver
TupleRemover<E> - Class in com.bigdata.btree.filter
Visits all elements visited by the source iterator and removes those
matching the filter.
TupleRemover() - Constructor for class com.bigdata.btree.filter.TupleRemover
tupleResults(ConnectOptions, UUID, IPreparedQueryListener) - Method in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryManager
Extracts the solutions from a SPARQL query.
Tuples - Static variable in interface com.bigdata.btree.AbstractBTree.IBTreeCounters
Counters for tuple-level operations.
tupleSer - Variable in class com.bigdata.btree.filter.TupleTransformer
The serialization provider for the transformed tuples.
tuplesRead - Variable in class com.bigdata.bop.joinGraph.rto.EdgeSample
The #of tuples read from the access path when processing the cutoff join.
TupleTransformer<E,F> - Class in com.bigdata.btree.filter
Abstract base class for an
ITupleFilter
that transforms the data type
of the keys and/or values.
TupleTransformer(ITupleSerializer<? extends Object, F>) - Constructor for class com.bigdata.btree.filter.TupleTransformer
TupleUpdater<E> - Class in com.bigdata.btree.filter
Filter allows mutation of the visited
ITuple
s.
TupleUpdater() - Constructor for class com.bigdata.btree.filter.TupleUpdater
TupleUpdater.Updaterator - Class in com.bigdata.btree.filter
TupleUpdater.Updaterator(ITupleIterator<E>, Object, TupleFilter<E>) - Constructor for class com.bigdata.btree.filter.TupleUpdater.Updaterator
TURTLE - Static variable in class com.bigdata.rdf.sail.webapp.SD
Unique URI for TURTLE
TURTLE_PARSER_FACTORY - Static variable in class com.bigdata.rdf.ServiceProviderHook
TURTLE_RDR - Static variable in class com.bigdata.rdf.sail.webapp.SD
TURTLE_RDR - Static variable in class com.bigdata.rdf.ServiceProviderHook
The extension MIME type for RDR data interchange using the RDR extension
of TURTLE.
TURTLE_WRITER_FACTORY - Static variable in class com.bigdata.rdf.ServiceProviderHook
tVarLeft() - Method in class com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode
Return the left transitivity var.
tVarRight() - Method in class com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode
Return the right transitivity var.
TWELVE - Static variable in class cern.colt.matrix.linalg.Property
A Property object with tolerance()==1.0E-12.
two - Variable in class com.bigdata.bop.join.AbstractHashJoinUtilityTestCase.NotExistsSetup
two - Static variable in class com.bigdata.jsr166.JSR166TestCase
twopi - Static variable in class cern.clhep.PhysicalConstants
twopi_mc2_rcl2 - Static variable in class cern.clhep.PhysicalConstants
tx - Variable in class com.bigdata.journal.AbstractTask
The transaction object iff the operation is isolated by a transaction
and otherwise null
.
Tx - Class in com.bigdata.journal
A transaction.
Tx(AbstractLocalTransactionManager, IResourceManager, long, long) - Constructor for class com.bigdata.journal.Tx
Create a transaction reading from the most recent committed state not
later than the specified startTime.
tx - Variable in class com.bigdata.service.AbstractTransactionService.TxState
The transaction identifier.
TX_SERVICE_CORE_POOL_SIZE - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
The #of threads in the pool handling concurrent transactions.
TxDag - Class in com.bigdata.concurrent
Directed Acyclic Graph (DAG) for detecting and preventing deadlocks in a
concurrent programming system.
TxDag(int) - Constructor for class com.bigdata.concurrent.TxDag
Constructor.
TxDag.Edge - Class in com.bigdata.concurrent
A representation of an edge in the DAG used for export of information to
the caller.
txDeactivate - Variable in class com.bigdata.service.AbstractTransactionService
TxId2CommitTimeIndex - Class in com.bigdata.service
BTree
whose keys are the absolute value of the txIds and whose values
are
ITxState0
tuples for the transaction.
TxId2CommitTimeIndex(IRawStore, Checkpoint, IndexMetadata, boolean) - Constructor for class com.bigdata.service.TxId2CommitTimeIndex
Load from the store.
TxId2CommitTimeIndex.TupleSerializer - Class in com.bigdata.service
Encapsulates key and value formation.
TxId2CommitTimeIndex.TupleSerializer() - Constructor for class com.bigdata.service.TxId2CommitTimeIndex.TupleSerializer
De-serialization ctor.
TxId2CommitTimeIndex.TupleSerializer(IKeyBuilderFactory) - Constructor for class com.bigdata.service.TxId2CommitTimeIndex.TupleSerializer
Ctor when creating a new instance.
TxServiceRunState - Enum in com.bigdata.service
TxServlet - Class in com.bigdata.rdf.sail.webapp
Servlet provides a REST interface for managing stand-off read/write
transaction.
TxServlet() - Constructor for class com.bigdata.rdf.sail.webapp.TxServlet
TXWriteService - Static variable in interface com.bigdata.journal.ConcurrencyManager.IConcurrencyManagerCounters
The service to which isolated write tasks are submitted.
TYPE - Variable in class com.bigdata.blueprints.BigdataGraph
URI used for typing elements.
TYPE - Static variable in interface com.bigdata.blueprints.BigdataGraphConfiguration.Options
Specify the type of bigdata instance to use - embedded or remote.
TYPE - Variable in class com.bigdata.blueprints.BigdataGraphQuery
URI used for typing elements.
TYPE - Variable in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
URI used for typing elements.
TYPE - Static variable in class com.bigdata.rdf.rio.json.SPARQLJSONParserBase
TYPE - Static variable in class com.bigdata.rdf.sail.config.BigdataRepositoryFactory
The type of repositories that are created by this factory.
TYPE - Static variable in class com.bigdata.rdf.sail.config.BigdataSailFactory
The type of sails that are created by this factory.
type - Static variable in class com.bigdata.rdf.vocab.decls.DCElementsVocabularyDecl
TYPE - Static variable in class it.unimi.dsi.parser.Attribute
TYPE_CAST_EXCEPTION - Static variable in exception com.bigdata.service.fts.FulltextSearchException
TYPE_EMBEDDED - Static variable in interface com.bigdata.blueprints.BigdataGraphConfiguration.Options
Specifies that an embedded bigdata instance should be used.
TYPE_REMOTE - Static variable in interface com.bigdata.blueprints.BigdataGraphConfiguration.Options
Specifies that a remote bigdata instance should be used.
TypeBasedASTJoinGroupPartitionReorderer - Class in com.bigdata.rdf.sparql.ast.optimizers
Reorders nodes based on their types.
TypeBasedASTJoinGroupPartitionReorderer() - Constructor for class com.bigdata.rdf.sparql.ast.optimizers.TypeBasedASTJoinGroupPartitionReorderer
TYPED_LITERAL - Static variable in class com.bigdata.rdf.rio.json.SPARQLJSONParserBase
TypeErrorLog - Class in com.bigdata.bop.solutions
A utility class for logging type errors.
TypeErrorLog() - Constructor for class com.bigdata.bop.solutions.TypeErrorLog
typeErrors - Variable in class com.bigdata.bop.engine.BOpStats
The #of error which were masked by the semantics of the query.
typeperf - Variable in class com.bigdata.counters.win.StatisticsCollectorForWindows
reports on host performance counters (CPU, MEM, IO).
TypeperfCollector - Class in com.bigdata.counters.win
Collects per-host performance counters on a Windows platform using
typeperf
and aligns them with those declared by
IRequiredHostCounters
.
TypeperfCollector(int) - Constructor for class com.bigdata.counters.win.TypeperfCollector
tz(BigdataLiteral) - Method in class com.bigdata.rdf.internal.constraints.DateBOp
Tz() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
TZ - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
RegularExpression Id.
TZ - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
U
- u - Variable in class cern.jet.random.Hyperbolic
-
- U - Static variable in class it.unimi.dsi.parser.Element
-
- UCASE - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- UCASE - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- UcaseBOp - Class in com.bigdata.rdf.internal.constraints
-
- UcaseBOp(IValueExpression<? extends IV>, GlobalAnnotations) - Constructor for class com.bigdata.rdf.internal.constraints.UcaseBOp
-
- UcaseBOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.UcaseBOp
-
- UcaseBOp(UcaseBOp) - Constructor for class com.bigdata.rdf.internal.constraints.UcaseBOp
-
- UL - Static variable in class it.unimi.dsi.parser.Element
-
- unary(SimpleNode, URI) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
Handle a simple unary function (the child of the node is the argument to
the function).
- UnaryExpression() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- UnaryMinus() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- UnconstrainedJoinException - Exception in com.bigdata.bop.join
-
An exception thrown when a hash join does not have any join variables and is
considering the cross product of two many solutions as a result.
- UnconstrainedJoinException() - Constructor for exception com.bigdata.bop.join.UnconstrainedJoinException
-
- UnconstrainedJoinException(String) - Constructor for exception com.bigdata.bop.join.UnconstrainedJoinException
-
- UnconstrainedJoinException(Throwable) - Constructor for exception com.bigdata.bop.join.UnconstrainedJoinException
-
- UnconstrainedJoinException(String, Throwable) - Constructor for exception com.bigdata.bop.join.UnconstrainedJoinException
-
- UNDEF - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- UNDEFINED_WORKBENCH_NAMESPACE - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFServlet
-
- UNICODE_CASE - Static variable in class it.unimi.dsi.util.TextPattern
-
Enables Unicode-aware case folding.
- unicodeCase() - Method in class it.unimi.dsi.util.TextPattern
-
Returns whether this pattern uses Unicode case folding.
- UnicodeHelper - Class in com.bigdata.io.compression
-
Utility class for compressed unicode encode/decode.
- UnicodeHelper(IUnicodeCompressor) - Constructor for class com.bigdata.io.compression.UnicodeHelper
-
- UnicodeSortKeyGenerator - Interface in com.bigdata.btree.keys
-
Interface allows us to encapsulate differences between the ICU and JDK
libraries for generating sort keys from Unicode strings.
- unicodeStrengthIdentical - Static variable in class com.bigdata.rdf.sail.tck.BigdataSparqlTest
-
The following tests require Unicode configuration for identical
comparisons.
- UnificationException - Exception in com.bigdata.rdf.rio
-
An instance of this exception is thrown when the same blank node appears
in the context position of two or more statements having a distinct
subject predicate, and object.
- UnificationException(String) - Constructor for exception com.bigdata.rdf.rio.UnificationException
-
- uniform - Variable in class cern.jet.random.BreitWignerMeanSquare
-
- Uniform - Class in cern.jet.random
-
- Uniform(double, double, int) - Constructor for class cern.jet.random.Uniform
-
Constructs a uniform distribution with the given minimum and maximum, using a
MersenneTwister
seeded with the given seed.
- Uniform(double, double, RandomEngine) - Constructor for class cern.jet.random.Uniform
-
Constructs a uniform distribution with the given minimum and maximum.
- Uniform(RandomEngine) - Constructor for class cern.jet.random.Uniform
-
Constructs a uniform distribution with min=0.0 and max=1.0.
- Union - Class in com.bigdata.bop.controller
-
UNION()[maxParallel(default all); subqueries=ops]
- Union(Union) - Constructor for class com.bigdata.bop.controller.Union
-
Deep copy constructor.
- Union(BOp[], Map<String, Object>) - Constructor for class com.bigdata.bop.controller.Union
-
Shallow copy constructor.
- Union(BOp[], NV...) - Constructor for class com.bigdata.bop.controller.Union
-
- UNION - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- UnionDefaultGraph - Static variable in class com.bigdata.rdf.sail.webapp.SD
-
- unionNode(Object...) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
- UnionNode - Class in com.bigdata.rdf.sparql.ast
-
A special kind of group
IGroupNode
that represents the sparql union
operator.
- UnionNode(UnionNode) - Constructor for class com.bigdata.rdf.sparql.ast.UnionNode
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- UnionNode(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.UnionNode
-
Required shallow copy constructor.
- UnionNode() - Constructor for class com.bigdata.rdf.sparql.ast.UnionNode
-
- UniquenessFilter - Class in cutthecrap.utils.striterators
-
UniquenessFilter
Derived from Filter, and ensures no duplication, not to be used with large
sets!
- UniquenessFilter() - Constructor for class cutthecrap.utils.striterators.UniquenessFilter
-
- UNISOLATED - Static variable in interface com.bigdata.journal.ITx
-
The constant that SHOULD used as the timestamp for an unisolated
read-write operation.
- UNISOLATED - Static variable in class com.bigdata.rdf.sail.webapp.client.RemoteTransactionManager
-
The constant that SHOULD used to request a read/write transaction.
- UnisolatedConnectionNotReentrantException - Exception in com.bigdata.rdf.sail
-
An instance of this is thrown if a thread already owning the unisolated
connection for a Sail attempts to acquire a 2nd unisolated connection for
the same Sail.
- UnisolatedConnectionNotReentrantException() - Constructor for exception com.bigdata.rdf.sail.UnisolatedConnectionNotReentrantException
-
- UnisolatedReadWriteIndex - Class in com.bigdata.btree
-
A view onto an unisolated index partition which enforces the constraint that
either concurrent readers -or- a single writer may have access to the
unisolated index at any given time.
- UnisolatedReadWriteIndex(BTree) - Constructor for class com.bigdata.btree.UnisolatedReadWriteIndex
-
Creates a view of an unisolated index that will enforce the concurrency
constraints of the
BTree
class, but only among other instances of
this class for the same underlying index.
- UnisolatedReadWriteIndex(BTree, int) - Constructor for class com.bigdata.btree.UnisolatedReadWriteIndex
-
Creates a view of an unisolated index that will enforce the concurrency
constraints of the
BTree
class, but only among other instances of
this class for the same underlying index.
- unit(int) - Static method in class cern.colt.bitvector.QuickBitVector
-
Returns the index of the unit that contains the given bitIndex.
- unit - Variable in class com.bigdata.counters.query.TimeRange
-
The units in which the duration was specified.
- unit - Static variable in class com.bigdata.service.proxy.ClientAsynchronousIterator
-
- Units - Class in cern.clhep
-
High Energy Physics coherent system of Units.
- Units() - Constructor for class cern.clhep.Units
-
Makes this class non instantiable, but still let's others inherit from it.
- units - Variable in class com.bigdata.counters.query.HistoryTable
-
The label for the units of the history.
- unitsFormat - Variable in class com.bigdata.counters.query.URLQueryModel
-
Used to format the units of time when expressed as elapsed units since
the first sample of a
History
.
- unitsFormat - Variable in class com.bigdata.counters.render.ValueFormatter
-
Used to format the units of time when expressed as elapsed units since
the first sample of a
History
.
- unitsIn - Variable in class com.bigdata.bop.engine.BOpStats
-
#of units sets in (tuples, elements, binding sets, etc).
- unitsOut - Variable in class com.bigdata.bop.engine.BOpStats
-
#of units sets in (tuples, elements, binding sets, etc).
- unitsToMeters(double, ICoordinate.UNITS) - Static method in class com.bigdata.rdf.internal.gis.CoordinateUtility
-
Convert meters to the desired units.
- universe_mean_density - Static variable in class cern.clhep.PhysicalConstants
-
- UNKNOWN - Static variable in class com.bigdata.concurrent.TxDag
-
- UNKNOWN - Static variable in class it.unimi.dsi.parser.Attribute
-
- UNKNOWN - Static variable in class it.unimi.dsi.parser.Element
-
- unknown_N_compute_B_and_K(double, double, int) - Static method in class cern.jet.stat.quantile.QuantileFinderFactory
-
Computes the number of buffers and number of values per buffer such that
quantiles can be determined with an approximation error no more than epsilon with a certain probability.
- unknown_N_compute_B_and_K_raw(double, double, int) - Static method in class cern.jet.stat.quantile.QuantileFinderFactory
-
Computes the number of buffers and number of values per buffer such that
quantiles can be determined with an approximation error no more than epsilon with a certain probability.
- unknownContext - Variable in class org.openrdf.repository.RepositoryConnectionTest
-
- unlock(T) - Method in class com.bigdata.concurrent.ResourceQueue
-
Release the lock held by the tx on the resource.
- unlock() - Method in interface com.bigdata.journal.IResourceLock
-
Release the lock.
- unlock() - Method in class com.bigdata.journal.WriteExecutorService
-
Release the exclusive write lock.
- unlock(IResourceLock) - Method in class com.bigdata.relation.AbstractResource
-
Release the lock.
- unmanagedReads() - Method in class com.bigdata.io.TestManagedReads
-
- unpackId(String) - Method in class com.bigdata.rdf.internal.InlineLocalNameIntegerURIHandler
-
Convenience method to get the packed ID value from an
input
String
.
- unpackId(long) - Method in class com.bigdata.rdf.internal.InlineLocalNameIntegerURIHandler
-
Take a packed long and extract the ID.
- unpackInt() - Method in class com.bigdata.io.DataInputBuffer
-
Convenience method unpacks long and throws an exception if the value
exceeds
Integer.MAX_VALUE
.
- unpackInt(DataInput) - Static method in class com.bigdata.io.LongPacker
-
Convenience method unpacks long and throws an exception if the value
exceeds
Integer.MAX_VALUE
.
- unpackInt(InputStream) - Static method in class com.bigdata.io.LongPacker
-
Convenience method unpacks long and throws an exception if the value
exceeds
Integer.MAX_VALUE
.
- unpackLong() - Method in class com.bigdata.io.DataInputBuffer
-
Unpack a long value from the current buffer position.
- unpackLong(DataInput) - Static method in class com.bigdata.io.LongPacker
-
Unpack a long value from the input stream.
- unpackLong(InputStream) - Static method in class com.bigdata.io.LongPacker
-
Unpack a long value from the input stream.
- unpackLong(byte[], int) - Static method in class com.bigdata.io.LongPacker
-
Unpack a long value from the buffer position.
- unpackShort() - Method in class com.bigdata.io.DataInputBuffer
-
Unpack a non-negative short value from the input stream.
- unpackShort(DataInput) - Static method in class com.bigdata.io.ShortPacker
-
Unpack a non-negative short value from the input stream.
- unpackShort(InputStream) - Static method in class com.bigdata.io.ShortPacker
-
Unpack a non-negative short value from the input stream.
- unpackValue(long) - Method in class com.bigdata.rdf.internal.InlineLocalNameIntegerURIHandler
-
Take a packed long and extract the value.
- unpadLeadingZero(byte[]) - Method in class com.bigdata.rdf.internal.impl.extensions.GeoSpatialLiteralExtension
-
- UnparsedQuadDataBlock() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- unquoteString(String) - Static method in class com.bigdata.util.httpd.HTTPHeaderUtility
-
If the value is an HTTP quoted-string
then we
strip of the quote characters now and translate any escaped
characters into themselves, e.g., '\"' => '"'.
- UnsatisfiableMinusExplainHint - Class in com.bigdata.rdf.sparql.ast.explainhints
-
Explain hint indicating a MINUS expression that is unsatisfiable, i.e.
- UnsatisfiableMinusExplainHint(BOp) - Constructor for class com.bigdata.rdf.sparql.ast.explainhints.UnsatisfiableMinusExplainHint
-
- UNSIGNED_NUMERIC - Static variable in interface com.bigdata.rdf.internal.DTEFlags
-
- unsignedByteIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- unsignedIntIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- unsignedLongIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- unsignedShortIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- UnsignedUtil - Class in com.bigdata.ganglia.util
-
- UnsignedUtil() - Constructor for class com.bigdata.ganglia.util.UnsignedUtil
-
- UnsynchronizedArrayBuffer<E> - Class in com.bigdata.relation.accesspath
-
An unsynchronized buffer backed by a fixed capacity array that migrates
references onto the caller's buffer (which is normally thread-safe) using
IBuffer#add(int)
.
- UnsynchronizedArrayBuffer(IBuffer<E[]>, Class<? extends E>, int) - Constructor for class com.bigdata.relation.accesspath.UnsynchronizedArrayBuffer
-
- UnsynchronizedArrayBuffer(IBuffer<E[]>, int, Class<? extends E>, IElementFilter<E>) - Constructor for class com.bigdata.relation.accesspath.UnsynchronizedArrayBuffer
-
- UnsynchronizedUnboundedChunkBuffer<E> - Class in com.bigdata.relation.accesspath
-
- UnsynchronizedUnboundedChunkBuffer(int, Class<? extends E>) - Constructor for class com.bigdata.relation.accesspath.UnsynchronizedUnboundedChunkBuffer
-
- UnsynchronizedUnboundedChunkBuffer(int, Class<? extends E>, IElementFilter<E>, IKeyOrder<E>) - Constructor for class com.bigdata.relation.accesspath.UnsynchronizedUnboundedChunkBuffer
-
- UnsyncLocalOutputBuffer<E extends IBindingSet> - Class in com.bigdata.relation.accesspath
-
Wraps the base class to update the caller's
BOpStats
.
- UnsyncLocalOutputBuffer(int, IBlockingBuffer<E[]>) - Constructor for class com.bigdata.relation.accesspath.UnsyncLocalOutputBuffer
-
- UnsyncLocalOutputBuffer(int, IBlockingBuffer<E[]>, IElementFilter<E>) - Constructor for class com.bigdata.relation.accesspath.UnsyncLocalOutputBuffer
-
- UnsyncLocalOutputBuffer<E extends IBindingSet> - Class in com.bigdata.relation.rule.eval.pipeline
-
Keeps track of the chunks of binding sets that are generated on the caller's
JoinStats
.
- UnsyncLocalOutputBuffer(JoinStats, int, IBlockingBuffer<E[]>) - Constructor for class com.bigdata.relation.rule.eval.pipeline.UnsyncLocalOutputBuffer
-
- update(Document) - Method in class com.bigdata.bfs.BigdataFileSystem
-
Create a new file version using the supplied file metadata.
- update(IIndex, ITuple<TPS.TPV>) - Method in class com.bigdata.bfs.FileVersionDeleter
-
- update(Document) - Method in interface com.bigdata.bfs.IContentRepository
-
Deprecated.
Update an existing persistent document in this repository based on the
metadata and content in the supplied document object.
- update(String) - Method in class com.bigdata.blueprints.BigdataGraph
-
Update graph using SPARQL Update.
- update(String, String) - Method in class com.bigdata.blueprints.BigdataGraph
-
Update graph using SPARQL Update.
- update(IIndex, ITuple<E>) - Method in class com.bigdata.btree.filter.TupleUpdater
-
You may implement this method to update the state of the visited
tuple in the backing index.
- update() - Method in class com.bigdata.ganglia.TimestampMetricValue
-
Update the timestamp.
- update(ByteBuffer) - Method in class com.bigdata.io.ChecksumUtility
-
Updates the
Adler32
checksum from the data in the buffer.
- update(ByteBuffer, int, int) - Method in class com.bigdata.io.ChecksumUtility
-
Core implementation updates the
Adler32
checksum from the data in
the buffer.
- Update() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- update - Variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext.AbstractQueryTask
-
true
iff this is a SPARQL UPDATE request.
- update - Variable in class com.bigdata.rdf.sail.webapp.client.AbstractConnectOptions
-
When true
, the request is a non-idempotent operation (an
UPDATE request or some kind) and must be directed to the leader for HA.
- update(IRemoteRepository.RemoveOp, IRemoteRepository.AddOp) - Method in interface com.bigdata.rdf.sail.webapp.client.IRemoteRepository
-
- update(RemoteRepository.RemoveOp, RemoteRepository.AddOp) - Method in class com.bigdata.rdf.sail.webapp.client.RemoteRepository
-
- update(RemoteRepository.RemoveOp, RemoteRepository.AddOp, UUID) - Method in class com.bigdata.rdf.sail.webapp.client.RemoteRepository
-
Perform an ACID update
- Update - Class in com.bigdata.rdf.sparql.ast
-
A SPARQL Update operation.
- Update(UpdateType) - Constructor for class com.bigdata.rdf.sparql.ast.Update
-
- Update(Update) - Constructor for class com.bigdata.rdf.sparql.ast.Update
-
- Update(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.Update
-
- update() - Method in class it.unimi.dsi.logging.ProgressLogger
-
Updates the progress logger.
- UPDATE_DELAY - Static variable in interface com.bigdata.service.LoadBalancerService.Options
-
- UPDATE_ICU_VERSION - Static variable in interface com.bigdata.journal.Options
-
WARNING - The use of this option is dangerous. This
option may be used to update the
ICUVersionRecord
associated with
the journal.
- UpdateContainer() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- updateEntryCount(AbstractNode<?>, long) - Method in class com.bigdata.btree.Node
-
Apply the delta to the per-child count for this node and then recursively
ascend up the tree applying the delta to all ancestors of this node.
- updateEvent(SPARQLUpdateEvent) - Method in interface com.bigdata.rdf.sail.ISPARQLUpdateListener
-
Notify the listener of an event.
- UpdateExprBuilder - Class in com.bigdata.rdf.sail.sparql
-
- UpdateExprBuilder(BigdataASTContext) - Constructor for class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- updateFuture - Variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext.AbstractQueryTask
-
The
Future
of the
UpdateTask
and
null
if
this is not a SPARQL UPDATE or if the
UpdateTask
has not
begun execution.
- updateHostScores() - Method in class com.bigdata.service.LoadBalancerService.UpdateTask
-
(Re-)compute the utilization score for each active host.
- updateHostTable() - Method in class com.bigdata.rdf.sail.webapp.lbs.AbstractHostLBSPolicy
-
Update the per-host scoring table.
- updateLeaf(ByteBuffer, long, long) - Method in class com.bigdata.btree.NodeSerializer
-
Update the serialization of a leaf to set the prior and next leaf
references and change its serialization type from #TYPE_LEAF
to
#TYPE_LINKED_LEAF
.
- updateLeaf(ByteBuffer, long, long) - Method in class com.bigdata.htree.NodeSerializer
-
Update the serialization of a leaf to set the prior and next leaf
references and change its serialization type from #TYPE_LEAF
to
#TYPE_LINKED_LEAF
.
- UpdateLineColumn(char) - Method in class com.bigdata.rdf.sail.sparql.ast.JavaCharStream
-
- updateMetadata(String, Map<String, Object>) - Method in class com.bigdata.bfs.BigdataFileSystem
-
Update the metadata for the current file version.
- updateMinMaxVersionTimestamp(AbstractNode<?>) - Method in class com.bigdata.btree.Node
-
- updateReleaseTime(long, AbstractTransactionService.TxState) - Method in class com.bigdata.service.AbstractTransactionService
-
This method MUST be invoked each time a transaction completes with the
absolute value of the transaction identifier that has just been
deactivated.
- updateReleaseTimeConsensus(long, long, UUID[], long, TimeUnit) - Method in class com.bigdata.service.AbstractHATransactionService
-
Coordinate the update of the releaseTime on each service that is
joined with the met quorum.
- updateReleaseTimeForBareCommit(long) - Method in class com.bigdata.service.AbstractTransactionService
-
If there are NO active transactions and the current releaseTime is LT
(commitTime-1) then compute and set the new releaseTime.
- updateReleaseTimeForBareCommit(long) - Method in class com.bigdata.service.TestDistributedTransactionServiceRestart.MockDistributedTransactionService
-
This is overridden to be a NOP for this test suite.
- UpdateRoot - Class in com.bigdata.rdf.sparql.ast
-
The top level container for a sequence of UPDATE operations.
- UpdateRoot() - Constructor for class com.bigdata.rdf.sparql.ast.UpdateRoot
-
- UpdateRoot(UpdateRoot) - Constructor for class com.bigdata.rdf.sparql.ast.UpdateRoot
-
- UpdateRoot(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.UpdateRoot
-
- UpdateRoot.Annotations - Interface in com.bigdata.rdf.sparql.ast
-
- UpdateSequence() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- updateService - Variable in class com.bigdata.service.LoadBalancerService
-
- updateServiceScores() - Method in class com.bigdata.service.LoadBalancerService.UpdateTask
-
(Re-)compute the utilization score for each active service.
- updateServiceTable() - Method in class com.bigdata.rdf.sail.webapp.lbs.AbstractHostLBSPolicy
-
Overridden to also update the hosts table in case we add/remove a service
and the set of hosts that cover the member services is changed as a
result.
- updateServiceTable() - Method in class com.bigdata.rdf.sail.webapp.lbs.AbstractLBSPolicy
-
Update the per-service table.
- UpdateServlet - Class in com.bigdata.rdf.sail.webapp
-
Handler for NanoSparqlServer REST API UPDATE operations (PUT, not SPARQL
UPDATE).
- UpdateServlet() - Constructor for class com.bigdata.rdf.sail.webapp.UpdateServlet
-
- UpdateType - Enum in com.bigdata.rdf.sparql.ast
-
Typesafe enumeration for SPARQL Graph Update and Graph Management operations.
- upload(URI, Resource) - Method in class org.openrdf.query.parser.sparql.manifest.SPARQLQueryTest
-
- uploadDataset(Dataset) - Method in class com.bigdata.rdf.sail.tck.BigdataSparqlTest
-
- uploadDataset(Dataset) - Method in class org.openrdf.query.parser.sparql.manifest.SPARQLQueryTest
-
- UPPER_BOUND - Static variable in interface com.bigdata.bop.paths.ArbitraryLengthPathOp.Annotations
-
The upper bound on the number of rounds to run.
- UPPER_BOUND - Static variable in interface com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode.Annotations
-
The upper bound on the number of rounds to run.
- UPPER_BOUND - Static variable in class com.bigdata.rdf.sparql.ast.optimizers.ASTALPServiceOptimizer
-
- upperBandwidth(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.Property
-
The upper bandwidth of a square matrix A is the
maximum j-i for which A[i,j] is nonzero and j > i.
- upperBound() - Method in class com.bigdata.rdf.sparql.ast.ArbitraryLengthPathNode
-
Return the upper bound.
- UpperCase() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- upperTriangular(DoubleMatrix2D) - Method in class cern.colt.matrix.linalg.LUDecompositionQuick
-
Modifies the matrix to be an upper triangular matrix.
- upperValue - Variable in class com.bigdata.service.geospatial.IGeoSpatialQuery.LowerAndUpperValue
-
- uptime() - Method in class com.bigdata.ganglia.GangliaService
-
Return the time in seconds since the last service start.
- urgent(String, UUID) - Method in interface com.bigdata.service.ILoadBalancerService
-
An urgent warning issued the caller is in immediate danger of depleting
its resources with a consequence of immediate service and/or host
failure(s).
- urgent(String, UUID) - Method in class com.bigdata.service.LoadBalancerService
-
- uri - Variable in class com.bigdata.blueprints.BigdataElement
-
- uri - Variable in class com.bigdata.counters.query.URLQueryModel
-
The URI from the request.
- URI - Static variable in class com.bigdata.rdf.rio.json.SPARQLJSONParserBase
-
- uri(String) - Static method in class com.bigdata.rdf.sail.TestMROWTransactions
-
- URI - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext
-
URL query parameter used to specify the URI(s) from which data will be
loaded for INSERT (POST-WITH-URIs.
- uri - Variable in class com.bigdata.util.httpd.NanoHTTPD.Request
-
Deprecated.
Percent-decoded URI without parameters, for example "/index.cgi"
- uri2key(String) - Method in class com.bigdata.rdf.lexicon.LexiconKeyBuilder
-
Returns the sort key for the URI.
- uriExtensionIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- URIExtensionIV<V extends BigdataURI> - Class in com.bigdata.rdf.internal.impl.uri
-
Class provides support for fully inline
URI
s for which a
Vocabulary
item was registered for the
URI
namespace
.
- URIExtensionIV(AbstractLiteralIV<BigdataLiteral, ?>, IV<?, ?>) - Constructor for class com.bigdata.rdf.internal.impl.uri.URIExtensionIV
-
- uriLookupEndpoint - Static variable in class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
-
- URINamespaceIV - Static variable in interface com.bigdata.rdf.internal.INonInlineExtensionCodes
-
- uriRegexPattern - Static variable in class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
-
- uris - Static variable in class com.blazegraph.vocab.pubchem.PubChemInlineURIFactory
-
- uriSpace - Static variable in class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
-
- urlEncode(String) - Static method in class com.bigdata.rdf.sail.webapp.client.AbstractConnectOptions
-
Apply a UTF8 encoding to a component of a URL.
- URLQueryModel - Class in com.bigdata.counters.query
-
- URLQueryParam - Class in com.bigdata.counters.query
-
The ordered set of values bound for a URL query parameter.
- URLQueryParam(String, String) - Constructor for class com.bigdata.counters.query.URLQueryParam
-
- URLQueryParam(String, String[]) - Constructor for class com.bigdata.counters.query.URLQueryParam
-
- urls - Variable in class it.unimi.dsi.parser.callback.LinkExtractor
-
The URLs resulting from the parsing process.
- usage() - Static method in class cern.colt.matrix.bench.BenchmarkMatrix
-
Overall usage.
- usage(String) - Static method in class cern.colt.matrix.bench.BenchmarkMatrix
-
Usage of a specific command.
- usage() - Static method in class com.bigdata.btree.DumpIndexSegment
-
- usage(String[], String, int) - Static method in class com.bigdata.btree.IndexSegmentBuilder
-
Prints the usage and then exits.
- usage() - Static method in class com.bigdata.journal.CompactJournalUtility
-
- usage(int, String) - Method in class com.bigdata.rdf.graph.impl.util.GASRunnerBase.OptionData
-
Print the optional message on stderr, print the usage information on
stderr, and then force the program to exit with the given status code.
- usage(int, String) - Static method in class com.bigdata.rdf.sail.webapp.NanoSparqlServer
-
Print the optional message on stderr, print the usage information on
stderr, and then force the program to exit with the given status code.
- usage() - Static method in class com.bigdata.rdf.util.DumpLexicon
-
- USD - Static variable in class com.bigdata.rdf.vocab.decls.BSBMVocabularyDecl
-
- USDFloatExtension<V extends BigdataValue> - Class in com.bigdata.rdf.internal.impl.extensions
-
Adds inlining for the
http://www4.wiwiss.fu-berlin.de/bizer/bsbm/v01/vocabulary/USD
datatype, which is treated as xsd:float
.
- USDFloatExtension(IDatatypeURIResolver) - Constructor for class com.bigdata.rdf.internal.impl.extensions.USDFloatExtension
-
- USE_DIRECT_BUFFERS - Static variable in interface com.bigdata.journal.Options
-
A boolean property whose value controls whether a direct (native) or
heap-based
ByteBuffer
will be allocated by the selected
BufferMode
.
- useCaches - Variable in class com.bigdata.rdf.sail.bench.NanoSparqlClient.QueryOptions
-
When false
, the http connection will be directed to
ignore caches.
- useChecksums - Variable in class com.bigdata.btree.IndexSegmentCheckpoint
-
true
iff record level checksums are in use for the
IndexSegment
.
- useChecksums() - Method in class com.bigdata.journal.AbstractBufferStrategy
-
- useChecksums() - Method in interface com.bigdata.journal.IBufferStrategy
-
Return true
if the store uses per-record checksums.
- useChecksums() - Method in class com.bigdata.journal.RWStrategy
-
- useChecksums() - Method in class com.bigdata.journal.WORMStrategy
-
- useChecksums() - Method in class com.bigdata.rwstore.sector.MemStrategy
-
- usedSlots() - Method in class com.bigdata.rwstore.StorageStats.Bucket
-
SlotsInUse: SlotsAllocated - SlotsRecycled (net slots in use for this slot size).
- usedStore() - Method in class com.bigdata.rwstore.StorageStats.Bucket
-
BytesAppData: The #of bytes in the allocated slots which are used by
application data (including the record checksum).
- usedVars - Variable in class com.bigdata.rdf.sparql.ast.AbstractSolutionSetStatsTestCase.MySolutionStats
-
The set of variables observed across all solutions.
- usedVars - Variable in class com.bigdata.rdf.sparql.ast.SolutionSetStatserator
-
The set of variables observed across all solutions.
- useLBS - Variable in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryManager
-
When true
, the REST API methods will use the load balancer
aware requestURLs.
- USEMAP - Static variable in class it.unimi.dsi.parser.Attribute
-
- USER_COUNTRY - Static variable in interface com.bigdata.btree.keys.KeyBuilder.Options
-
The pre-defined System property "user.country" determines the
country for the default
Locale
.
- USER_LANGUAGE - Static variable in interface com.bigdata.btree.keys.KeyBuilder.Options
-
The pre-defined System property "user.language" determines
the
language for the default
Locale
.
- USER_VARIANT - Static variable in interface com.bigdata.btree.keys.KeyBuilder.Options
-
The pre-defined System property "user.variant" determines the
variant for the default
Locale
.
- useRawRecords() - Method in class com.bigdata.btree.AbstractBTreeTestCase
-
Provide hook to allow specific test cases to determine if rawRecords
should be used, failing any overide the value is random.
- useRawRecords() - Method in class com.bigdata.btree.TestIndexSegmentBuilderWithBlobCapacity
-
- userExtent - Variable in class com.bigdata.journal.BasicBufferStrategy
-
The size of the user data space in bytes.
- username - Variable in class com.bigdata.rdf.sail.bench.NanoSparqlClient.QueryOptions
-
- USES_CACHE - Static variable in interface com.bigdata.bop.rdf.update.ParseOp.Annotations
-
true
iff HTTP requests may use cached responses.
- USING - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- USING_GRAPH_URI - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext
-
URL query parameter used to specify a URI in the default graph for SPARQL
UPDATE.
- USING_GRAPH_URI - Static variable in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryDecls
-
URL query parameter used to specify a URI in the default graph for SPARQL
UPDATE.
- USING_NAMED_GRAPH_URI - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext
-
URL query parameter used to specify a URI in the set of named graphs for
SPARQL UPDATE.
- USING_NAMED_GRAPH_URI - Static variable in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryDecls
-
URL query parameter used to specify a URI in the set of named graphs for
SPARQL UPDATE.
- UsingClause() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- utf16() - Static method in class it.unimi.dsi.bits.TransformationStrategies
-
A trivial transformation from strings to bit vectors that concatenates the bits of the UTF-16 representation.
- Utf16TransformationStrategy - Class in it.unimi.dsi.bits
-
- Utf16TransformationStrategy() - Constructor for class it.unimi.dsi.bits.Utf16TransformationStrategy
-
Deprecated.
Creates a prefix-free UTF16 transformation strategy.
- UTF8 - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFServlet
-
The name of the UTF-8
character encoding.
- UTF8 - Static variable in class com.bigdata.rdf.sail.webapp.client.RemoteRepositoryDecls
-
The name of the UTF-8
character encoding.
- UTF8 - Static variable in class com.bigdata.util.httpd.NanoHTTPD
-
Deprecated.
UTF-8
- utf8 - Variable in class it.unimi.dsi.util.FrontCodedStringList
-
Whether this front-coded list is UTF-8 encoded.
- utf8() - Method in class it.unimi.dsi.util.FrontCodedStringList
-
Returns whether this front-coded string list is storing its strings as UTF-8 encoded bytes.
- util - Variable in class com.bigdata.rdf.sparql.ast.service.RemoteSparql11QueryBuilder
-
- Util - Class in it.unimi.dsi
-
All-purpose static-method container class.
- UUID - Static variable in class com.bigdata.rdf.internal.XSD
-
- UUID() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- UUID - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- uuid - Variable in class com.bigdata.rdf.sail.webapp.AbstractRestApiTask
-
The
UUID
associated with this task.
- UUID - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- UUIDBNodeIV<V extends BigdataBNode> - Class in com.bigdata.rdf.internal.impl.bnode
-
Class for inline RDF blank nodes.
- UUIDBNodeIV(UUID) - Constructor for class com.bigdata.rdf.internal.impl.bnode.UUIDBNodeIV
-
- UUIDBOp - Class in com.bigdata.rdf.internal.constraints
-
Implements the now() operator.
- UUIDBOp(GlobalAnnotations, boolean) - Constructor for class com.bigdata.rdf.internal.constraints.UUIDBOp
-
- UUIDBOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.UUIDBOp
-
Required shallow copy constructor.
- UUIDBOp(UUIDBOp) - Constructor for class com.bigdata.rdf.internal.constraints.UUIDBOp
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- UUIDBOp.Annotations - Interface in com.bigdata.rdf.internal.constraints
-
- uuidLiteralIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- UUIDLiteralIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline
UUID
s (there is no corresponding XML
Schema Datatype).
- UUIDLiteralIV(UUID) - Constructor for class com.bigdata.rdf.internal.impl.literal.UUIDLiteralIV
-
V
- v - Variable in class cern.jet.random.Hyperbolic
-
- v() - Method in enum com.bigdata.rdf.internal.DTE
-
An
byte
value whose whose lower 6 bits code the
DTE
.
- v() - Method in enum com.bigdata.rdf.internal.DTEExtension
-
An
byte
value whose whose lower 6 bits code the
DTE
.
- v() - Method in enum com.bigdata.rdf.internal.VTE
-
Return the code for the value type.
- val - Variable in class com.bigdata.btree.keys.KVO
-
The serialized byte[] value (optional).
- val - Variable in class com.bigdata.btree.proc.SplitValuePair
-
- VAL - Static variable in interface com.bigdata.rdf.sparql.ast.eval.ValuesServiceFactory.ValuesParams
-
The seed on the sample.
- val - Variable in class com.bigdata.rdf.spo.Binding
-
The value;
- val - Variable in class com.bigdata.relation.rule.Binding
-
The value;
- valid() - Method in interface com.bigdata.journal.IRootBlockView
-
Assertion throws exception unless the root block is valid.
- valid() - Method in class com.bigdata.journal.RootBlockView
-
- validate() - Method in class com.bigdata.btree.IndexSegmentCheckpoint
-
- validate(AbstractBTree[]) - Method in class com.bigdata.btree.isolation.IsolatedFusedView
-
Validate changes made to the index within a transaction against the last
committed state of the index in the global scope.
- validate() - Method in class com.bigdata.btree.isolation.TestAccount.TxAccount
-
Validate the transaction against the current account balance.
- validate(String) - Method in class com.bigdata.rdf.sparql.ast.hints.AbstractBooleanQueryHint
-
- validate(String) - Method in class com.bigdata.rdf.sparql.ast.hints.AbstractStringQueryHint
-
- validate(String) - Method in interface com.bigdata.rdf.sparql.ast.hints.IQueryHint
-
Validate the value, returning an object of the appropriate type.
- validate(String) - Method in class com.bigdata.rdf.sparql.ast.hints.OptimizerQueryHint
-
- VALIDATE_CHECKSUM - Static variable in interface com.bigdata.journal.Options
-
An optional boolean property (default
"true").
- validateIndexMetadata(String, IndexMetadata) - Method in class com.bigdata.journal.AbstractJournal
-
Provides an opportunity to validate some aspects of the
IndexMetadata
for an index partition.
- validateIndexMetadata(String, IndexMetadata) - Method in class com.bigdata.resources.StoreManager.ManagedJournal
-
Extended to set the
IResourceMetadata
to this journal if it
is
null
since a remote caller can not have the correct
metadata on hand when they formulate the request.
- validateNewRootBlock(boolean, IRootBlockView, IRootBlockView) - Method in class com.bigdata.journal.AbstractJournal.BasicHA
-
Validate the new root block against the current root block.
- validateSplits(IIndex, Split[]) - Static method in class com.bigdata.resources.SplitUtility
-
Validate splits, including: that the separator keys are strictly
ascending, that the separator keys perfectly cover the source key range
without overlap, that the rightSeparator for each split is the
leftSeparator for the prior split, that the fromIndex offsets are
strictly ascending, etc.
- validateSplits(LocalPartitionMetadata, Split[], boolean) - Static method in class com.bigdata.resources.SplitUtility
-
Validate splits, including: that the separator keys are strictly
ascending, that the separator keys perfectly cover the source key range
without overlap, that the rightSeparator for each split is the
leftSeparator for the prior split, that the fromIndex offsets are
strictly ascending, etc.
- validateWriteSets() - Method in class com.bigdata.journal.Tx
-
Invoked when a writable transaction prepares in order to validate its
write sets (one per isolated index).
- ValidationError - Exception in com.bigdata.journal
-
An instance of this class is thrown when a transaction
ITx#prepare(long)
s if there is a write-write conflict that can not
be resolved.
- ValidationError() - Constructor for exception com.bigdata.journal.ValidationError
-
- ValidationError(String) - Constructor for exception com.bigdata.journal.ValidationError
-
- ValidationError(Throwable) - Constructor for exception com.bigdata.journal.ValidationError
-
- ValidationError(String, Throwable) - Constructor for exception com.bigdata.journal.ValidationError
-
- VALIGN - Static variable in class it.unimi.dsi.parser.Attribute
-
- VALS - Static variable in interface com.bigdata.btree.IRangeQuery
-
Flag specifies that values in the key range will be returned.
- value(Object) - Static method in class cern.colt.list.adapter.DoubleListAdapter
-
Transforms an object element to a primitive data type.
- value(Object) - Static method in class cern.colt.list.adapter.FloatListAdapter
-
Transforms an object element to a primitive data type.
- value(Object) - Static method in class cern.colt.list.adapter.IntListAdapter
-
Transforms an object element to a primitive data type.
- value(Object) - Static method in class cern.colt.list.adapter.LongListAdapter
-
Transforms an object element to a primitive data type.
- value() - Method in enum com.bigdata.concurrent.NonBlockingLockManager.RunState
-
- value - Variable in class com.bigdata.counters.Instrument
-
The current value -or- null
if there is no current value.
- value(ICounter, Object) - Method in class com.bigdata.counters.render.TextValueFormatter
-
- value(ICounter, Object) - Method in class com.bigdata.counters.render.ValueFormatter
-
Formats a counter value as a String.
- value(ICounter, Object) - Method in class com.bigdata.counters.render.XHTMLRenderer.HTMLValueFormatter
-
Formats a counter value as a String AND performs any escaping necessary
for inclusion in a CDATA section (we do both operations together so that
we can format
IServiceCounters.LOCAL_HTTPD
as a link anchor.
- value(ICounter<?>, Object) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Deprecated.
Move into formatter objects.
- value - Variable in class com.bigdata.counters.store.CounterSetBTree.Entry
-
- value() - Method in enum com.bigdata.ganglia.GangliaMessageTypeEnum
-
The byte value used in the wire format.
- value() - Method in enum com.bigdata.ganglia.GangliaSlopeEnum
-
- VALUE - Static variable in class com.bigdata.rdf.rio.json.SPARQLJSONParserBase
-
- value() - Method in enum com.bigdata.service.TxServiceRunState
-
- VALUE - Static variable in class com.bigdata.sparse.GlobalRowStoreSchema
-
The name of the property whose value is the object associated with
the name.
- VALUE - Static variable in class it.unimi.dsi.parser.Attribute
-
- value2Key(Value) - Method in class com.bigdata.rdf.lexicon.LexiconKeyBuilder
-
Return an unsigned byte[] that locates the value within a total ordering
over the RDF value space.
- VALUE_COMPARATOR - Static variable in interface com.bigdata.bop.solutions.SortOp.Annotations
-
The
Comparator
used to compare individual as-bound / computed
values within binding sets.
- VALUE_FACTORY_CLASS - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
-
- VALUE_LIMIT - Static variable in interface com.bigdata.bop.rdf.aggregate.GROUP_CONCAT.Annotations
-
The maximum #of values to concatenate (positive integer and
-1
to indicate no bound) (default
-1)
- valueAt(long) - Method in class com.bigdata.btree.AbstractBTree
-
- valueAt(long, Tuple) - Method in class com.bigdata.btree.AbstractBTree
-
- valueAt(long, Tuple) - Method in class com.bigdata.btree.AbstractNode
-
Recursive search locates the entry at the specified index position in the
btree and returns the value for that entry.
- valueAt(long) - Method in class com.bigdata.btree.DelegateBTree
-
- valueAt(long) - Method in interface com.bigdata.btree.ILinearList
-
Return the value for the identified entry.
- valueAt(long, Tuple) - Method in class com.bigdata.btree.Leaf
-
- valueAt(long, Tuple) - Method in class com.bigdata.btree.Node
-
Recursive search for the value at the specified entry index.
- valueAt(long) - Method in class com.bigdata.btree.UnisolatedReadWriteIndex
-
- valueAt(long, Tuple<T>) - Method in class com.bigdata.journal.AbstractCommitTimeIndex
-
- ValueExprBuilder - Class in com.bigdata.rdf.sail.sparql
-
- ValueExprBuilder(BigdataASTContext) - Constructor for class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- ValueExpressionListBaseNode<E extends IValueExpressionNode> - Class in com.bigdata.rdf.sparql.ast
-
Base class for AST nodes which model an ordered list of value expressions.
- ValueExpressionListBaseNode(ValueExpressionListBaseNode) - Constructor for class com.bigdata.rdf.sparql.ast.ValueExpressionListBaseNode
-
Deep copy constructor.
- ValueExpressionListBaseNode(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.ValueExpressionListBaseNode
-
Shallow copy constructor.
- ValueExpressionListBaseNode() - Constructor for class com.bigdata.rdf.sparql.ast.ValueExpressionListBaseNode
-
- ValueExpressionNode - Class in com.bigdata.rdf.sparql.ast
-
AST node for value expressions.
- ValueExpressionNode(IValueExpression<? extends IV>) - Constructor for class com.bigdata.rdf.sparql.ast.ValueExpressionNode
-
Deprecated.
This was just for compatibility with SOp2ASTUtility. It is
only used by the test suite now. It should be removed now
that we are done with the SPARQL to AST direct translation.
- ValueExpressionNode(ValueExpressionNode) - Constructor for class com.bigdata.rdf.sparql.ast.ValueExpressionNode
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- ValueExpressionNode(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.ValueExpressionNode
-
Required shallow copy constructor.
- valueFactory - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
The value factory for that namespace.
- valueFactory - Variable in class com.bigdata.rdf.rio.StatementBuffer
-
- valueFactory - Variable in class com.bigdata.rdf.sail.sparql.BigdataASTContext
-
- valueFactory - Variable in class com.bigdata.rdf.sparql.AbstractBigdataExprBuilderTestCase
-
- valueFactory - Variable in class com.bigdata.rdf.sparql.ast.AbstractASTEvaluationTestCase
-
- valueFactory - Variable in class com.bigdata.rdf.sparql.ast.ssets.TestSolutionSetManager
-
The value factory for that namespace.
- ValueFormatter - Class in com.bigdata.counters.render
-
Datum specific formatting of
ICounter
values (not thread-safe since
the
Format
objects are not thread-safe).
- ValueFormatter(URLQueryModel) - Constructor for class com.bigdata.counters.render.ValueFormatter
-
- ValueLogical() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- valueOf(String) - Static method in enum com.bigdata.blueprints.BigdataGraphAtom.ElementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.blueprints.BigdataGraphEdit.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.blueprints.BigdataPredicate
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.bop.ap.SampleIndex.SampleType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.bop.BOpEvaluationContext
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.bop.join.JoinTypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.bop.joinGraph.rto.EstimateEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.bigdata.bop.NamedSolutionSetRefUtility
-
- valueOf(String) - Static method in enum com.bigdata.btree.IndexSegmentRegion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.btree.IndexTypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(short) - Static method in enum com.bigdata.btree.IndexTypeEnum
-
- valueOf(String) - Static method in enum com.bigdata.btree.keys.CollatorEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.btree.keys.DecompositionEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.btree.keys.StrengthEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.btree.SeekEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.concurrent.NonBlockingLockManager.RunState
-
Returns the enum constant of this type with the specified name.
- valueOf(double) - Method in class com.bigdata.counters.History
-
Convert a double to an instance of the generic type parameter for
this class.
- valueOf(String) - Static method in enum com.bigdata.counters.PeriodEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.counters.query.ReportEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.counters.query.TimestampFormatEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.counters.render.DoctypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.ganglia.GangliaMessageTypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum com.bigdata.ganglia.GangliaMessageTypeEnum
-
Return the type safe enum for the record type value.
- valueOf(String) - Static method in enum com.bigdata.ganglia.GangliaSlopeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum com.bigdata.ganglia.GangliaSlopeEnum
-
- valueOf(String) - Static method in enum com.bigdata.ha.HAStatusEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.ha.RunState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.journal.BufferMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.journal.ForceEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.journal.RunState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.journal.StoreTypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.journal.StoreTypeEnum
-
- valueOf(String) - Static method in enum com.bigdata.mdi.IndexPartitionCause.CauseEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.quorum.QuorumEventEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.quorum.QuorumStateChangeEventEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.changesets.ChangeAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.error.W3CQueryLanguageException.ErrorCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.error.W3CQueryLanguageException.LanguageFamily
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.graph.EdgesEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.graph.FrontierEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.graph.TraversalDirectionEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.ColorsEnumExtension.Color
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.rdf.internal.ColorsEnumExtension.Color
-
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.constraints.DateBOp.DateOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.constraints.DigestBOp.DigestOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.constraints.INeedsMaterialization.Requirement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.constraints.MathBOp.MathOp
-
Returns the enum constant of this type with the specified name.
- valueOf(MathExpr.MathOp) - Static method in enum com.bigdata.rdf.internal.constraints.MathBOp.MathOp
-
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.constraints.NumericBOp.NumericOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.DTE
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.rdf.internal.DTE
-
- valueOf(URI) - Static method in enum com.bigdata.rdf.internal.DTE
-
Return the
DTE
for the datatype
URI
.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.DTEExtension
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.rdf.internal.DTEExtension
-
- valueOf(URI) - Static method in enum com.bigdata.rdf.internal.DTEExtension
-
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.gis.ICoordinate.UNITS
-
Returns the enum constant of this type with the specified name.
- valueOf(boolean) - Static method in class com.bigdata.rdf.internal.impl.literal.XSDBooleanIV
-
Return a
strong new instance of an
XSDBooleanIV
whose
cache
is not set.
- valueOf(String) - Static method in enum com.bigdata.rdf.internal.VTE
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.rdf.internal.VTE
-
Return the
VTE
identified by the LOW TWO (2) bits in the caller's
value.
- valueOf(char) - Static method in enum com.bigdata.rdf.internal.VTE
-
- valueOf(Value) - Static method in enum com.bigdata.rdf.internal.VTE
-
Determine the VTE based on the type of Value - URI, Literal, or BNode.
- valueOf(String) - Static method in enum com.bigdata.rdf.lexicon.LexAccessPatternEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(IPredicate<?>) - Static method in enum com.bigdata.rdf.lexicon.LexAccessPatternEnum
-
- valueOf(int) - Static method in class com.bigdata.rdf.lexicon.LexiconKeyOrder
-
Returns the singleton corresponding to the index.
- valueOf(String) - Static method in enum com.bigdata.rdf.model.StatementEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.rules.RuleContextEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sail.remote.BigdataSailFactory.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sail.webapp.client.RemoteRepositoryManager.ComputeMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.DescribeModeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.explainhints.IExplainHint.ExplainHintCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.explainhints.IExplainHint.ExplainHintSeverity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.FilterExistsModeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.hints.QueryEngineChunkHandlerEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(Class<? extends IChunkHandler>) - Static method in enum com.bigdata.rdf.sparql.ast.hints.QueryEngineChunkHandlerEnum
-
Return the type safe enumeration corresponding to a specific
implementation class.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.hints.QueryHintScope
-
Returns the enum constant of this type with the specified name.
- valueOf(URI) - Static method in enum com.bigdata.rdf.sparql.ast.hints.QueryHintScope
-
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.PathNode.PathMod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.QueryOptimizerEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.QueryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.service.SPARQLVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.sparql.ast.UpdateType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.spo.ModifiedEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.spo.SPOIndexMutation
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in class com.bigdata.rdf.spo.SPOKeyOrder
-
Returns the singleton corresponding to the index.
- valueOf(String) - Static method in enum com.bigdata.rdf.store.DatabaseMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.store.DataLoader.ClosureEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.rdf.store.DataLoader.CommitEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.relation.rule.eval.ActionEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.resources.OverflowActionEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.resources.OverflowSubtaskEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.resources.StaleLocatorReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.AbstractScaleOutClient.MetadataIndexCachePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.fts.FTS.EndpointType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.fts.FTS.SearchResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.geospatial.GeoSpatial.GeoFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.geospatial.GeoSpatialDatatypeFieldConfiguration.ServiceMapping
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.geospatial.GeoSpatialDatatypeFieldConfiguration.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.service.ResourceService.ResourceTypeEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.service.ResourceService.ResourceTypeEnum
-
- valueOf(String) - Static method in enum com.bigdata.service.ResourceService.StatusEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.bigdata.service.ResourceService.StatusEnum
-
- valueOf(String) - Static method in enum com.bigdata.service.TxServiceRunState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.sparse.KeyType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.bigdata.sparse.ValueType
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum com.bigdata.sparse.ValueType
-
- valueOf(String) - Static method in enum com.bigdata.stream.Stream.CompressionEnum
-
Returns the enum constant of this type with the specified name.
- valueOf(int, int) - Static method in class it.unimi.dsi.util.Interval
-
Returns an interval with given extremes.
- valueOf(int) - Static method in class it.unimi.dsi.util.Interval
-
Returns a one-point interval.
- valueOf(String) - Static method in enum org.infinispan.eviction.EvictionStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.infinispan.util.concurrent.BufferedConcurrentHashMap.Eviction
-
Returns the enum constant of this type with the specified name.
- values() - Method in class cern.colt.map.AbstractDoubleIntMap
-
Returns a list filled with all values contained in the receiver.
- values(IntArrayList) - Method in class cern.colt.map.AbstractDoubleIntMap
-
Fills all values contained in the receiver into the specified list.
- values() - Method in class cern.colt.map.AbstractIntDoubleMap
-
Returns a list filled with all values contained in the receiver.
- values(DoubleArrayList) - Method in class cern.colt.map.AbstractIntDoubleMap
-
Fills all values contained in the receiver into the specified list.
- values() - Method in class cern.colt.map.AbstractIntIntMap
-
Returns a list filled with all values contained in the receiver.
- values(IntArrayList) - Method in class cern.colt.map.AbstractIntIntMap
-
Fills all values contained in the receiver into the specified list.
- values() - Method in class cern.colt.map.AbstractIntObjectMap
-
Returns a list filled with all values contained in the receiver.
- values(ObjectArrayList) - Method in class cern.colt.map.AbstractIntObjectMap
-
Fills all values contained in the receiver into the specified list.
- values() - Method in class cern.colt.map.AbstractLongObjectMap
-
Returns a list filled with all values contained in the receiver.
- values(ObjectArrayList) - Method in class cern.colt.map.AbstractLongObjectMap
-
Fills all values contained in the receiver into the specified list.
- values - Variable in class cern.colt.map.OpenDoubleIntHashMap
-
The hash table values.
- values(IntArrayList) - Method in class cern.colt.map.OpenDoubleIntHashMap
-
Fills all values contained in the receiver into the specified list.
- values - Variable in class cern.colt.map.OpenIntDoubleHashMap
-
The hash table values.
- values(DoubleArrayList) - Method in class cern.colt.map.OpenIntDoubleHashMap
-
Fills all values contained in the receiver into the specified list.
- values - Variable in class cern.colt.map.OpenIntIntHashMap
-
The hash table values.
- values(IntArrayList) - Method in class cern.colt.map.OpenIntIntHashMap
-
Fills all values contained in the receiver into the specified list.
- values - Variable in class cern.colt.map.OpenIntObjectHashMap
-
The hash table values.
- values(ObjectArrayList) - Method in class cern.colt.map.OpenIntObjectHashMap
-
Fills all values contained in the receiver into the specified list.
- values - Variable in class cern.colt.map.OpenLongObjectHashMap
-
The hash table values.
- values(ObjectArrayList) - Method in class cern.colt.map.OpenLongObjectHashMap
-
Fills all values contained in the receiver into the specified list.
- values - Variable in class cern.colt.matrix.impl.RCDoubleMatrix2D
-
- values() - Static method in enum com.bigdata.blueprints.BigdataGraphAtom.ElementType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.blueprints.BigdataGraphEdit.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.blueprints.BigdataPredicate
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.bop.ap.SampleIndex.SampleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.bop.BOpEvaluationContext
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.bop.join.JoinTypeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.bop.joinGraph.rto.EstimateEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.btree.IndexSegmentRegion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.btree.IndexTypeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.btree.keys.CollatorEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.btree.keys.DecompositionEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.btree.keys.StrengthEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in class com.bigdata.btree.raba.EmptyRaba
-
An empty, immutable B+Tree values
IRaba
instance.
- values - Variable in class com.bigdata.btree.raba.MutableValueBuffer
-
The backing array.
- values() - Static method in enum com.bigdata.btree.SeekEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.concurrent.NonBlockingLockManager.RunState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.counters.PeriodEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.counters.query.ReportEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.counters.query.TimestampFormatEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class com.bigdata.counters.query.URLQueryParam
-
- values() - Static method in enum com.bigdata.counters.render.DoctypeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.ganglia.GangliaMessageTypeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.ganglia.GangliaSlopeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.ha.HAStatusEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.ha.RunState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.bigdata.htree.AbstractHTree
-
Visits the values stored in the
HTree
in order by the effective
prefix of their keys.
- values - Variable in class com.bigdata.htree.raba.MutableValueBuffer
-
An array containing the values.
- values() - Static method in enum com.bigdata.journal.BufferMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.journal.ForceEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.journal.RunState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.journal.StoreTypeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.mdi.IndexPartitionCause.CauseEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.quorum.QuorumEventEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.quorum.QuorumStateChangeEventEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.changesets.ChangeAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.error.W3CQueryLanguageException.ErrorCategory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.error.W3CQueryLanguageException.LanguageFamily
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.graph.EdgesEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.graph.FrontierEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.graph.TraversalDirectionEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.ColorsEnumExtension.Color
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.constraints.DateBOp.DateOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.constraints.DigestBOp.DigestOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.constraints.INeedsMaterialization.Requirement
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.constraints.MathBOp.MathOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.constraints.NumericBOp.NumericOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.DTE
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.DTEExtension
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.gis.ICoordinate.UNITS
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.internal.VTE
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.lexicon.LexAccessPatternEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.model.StatementEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class com.bigdata.rdf.rio.StatementBuffer
-
Buffer for parsed RDF Value
s.
- values() - Static method in enum com.bigdata.rdf.rules.RuleContextEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sail.remote.BigdataSailFactory.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- values() - Static method in enum com.bigdata.rdf.sail.webapp.client.RemoteRepositoryManager.ComputeMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.DescribeModeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.explainhints.IExplainHint.ExplainHintCategory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.explainhints.IExplainHint.ExplainHintSeverity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.FilterExistsModeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.hints.QueryEngineChunkHandlerEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.hints.QueryHintScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.PathNode.PathMod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.QueryOptimizerEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.QueryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.service.SPARQLVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.sparql.ast.UpdateType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.spo.ModifiedEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.spo.SPOIndexMutation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.store.DatabaseMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.store.DataLoader.ClosureEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.rdf.store.DataLoader.CommitEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.bigdata.rdf.vocab.BaseVocabulary
-
- values() - Method in class com.bigdata.rdf.vocab.BaseVocabularyDecl
-
Return an iterator which will visit the declared values.
- values() - Method in class com.bigdata.rdf.vocab.decls.BSBMVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.DCAllVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.DCElementsVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.DCTermsVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.GeoSpatialVocabularyDecl
-
Deprecated.
- values() - Method in class com.bigdata.rdf.vocab.decls.LUBMVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.OPVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.OWLVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.RDFSVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.RDFVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.SesameVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.SKOSVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.decls.XMLSchemaVocabularyDecl
-
- values() - Method in class com.bigdata.rdf.vocab.TestVocabularyDecl_BLZG1591
-
- values() - Method in interface com.bigdata.rdf.vocab.Vocabulary
-
The Value
s in an arbitrary order.
- values() - Method in interface com.bigdata.rdf.vocab.VocabularyDecl
-
Return an iterator which will visit the declared values.
- values() - Static method in enum com.bigdata.relation.rule.eval.ActionEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.resources.OverflowActionEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.resources.OverflowSubtaskEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.resources.StaleLocatorReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.AbstractScaleOutClient.MetadataIndexCachePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.fts.FTS.EndpointType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.fts.FTS.SearchResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.geospatial.GeoSpatial.GeoFunction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.geospatial.GeoSpatialDatatypeFieldConfiguration.ServiceMapping
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.geospatial.GeoSpatialDatatypeFieldConfiguration.ValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.ResourceService.ResourceTypeEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.ResourceService.StatusEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.service.TxServiceRunState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.sparse.KeyType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.sparse.ValueType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.bigdata.stream.Stream.CompressionEnum
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.blazegraph.vocab.pubchem.PubChemVocabularyDecl
-
- values() - Static method in enum org.infinispan.eviction.EvictionStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.infinispan.util.concurrent.BufferedConcurrentHashMap.Eviction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.infinispan.util.concurrent.BufferedConcurrentHashMap
-
Returns a
Collection
view of the values contained in this map.
- ValuesServiceFactory - Class in com.bigdata.rdf.sparql.ast.eval
-
A factory for a service that simulates the VALUES syntax in SPARQL:
service bd:values {
# service params
bd:serviceParam bd:values.var ?var .
- ValuesServiceFactory() - Constructor for class com.bigdata.rdf.sparql.ast.eval.ValuesServiceFactory
-
- ValuesServiceFactory.ValuesParams - Interface in com.bigdata.rdf.sparql.ast.eval
-
The service params for this service.
- ValueType - Enum in com.bigdata.sparse
-
A type safe enumeration of value types.
- VALUETYPE - Static variable in class it.unimi.dsi.parser.Attribute
-
- VAR - Static variable in interface com.bigdata.bop.Constant.Annotations
-
The
IVariable
which is bound to that constant value
(optional).
- var() - Method in interface com.bigdata.bop.IVariableFactory
-
Return a new anonymous variable.
- VAR - Static variable in interface com.bigdata.bop.rdf.join.DataSetJoin.Annotations
-
The variable to be bound.
- var() - Method in class com.bigdata.bop.solutions.AbstractAggregationTestCase.MockVariableFactory
-
- var() - Method in class com.bigdata.bop.solutions.GroupByRewriter
-
Return a new anonymous variable (this is overridden by some unit tests in
order to have predictable variable names).
- Var<E> - Class in com.bigdata.bop
-
A variable.
- var() - Static method in class com.bigdata.bop.Var
-
Generate an anonymous random variable.
- var(String) - Static method in class com.bigdata.bop.Var
-
Singleton factory for
Var
s.
- Var() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- VAR - Static variable in interface com.bigdata.rdf.sparql.ast.eval.ValuesServiceFactory.ValuesParams
-
The limit on the sample.
- VAR - Static variable in interface com.bigdata.rdf.sparql.ast.RangeNode.Annotations
-
- var() - Method in class com.bigdata.rdf.sparql.ast.RangeNode
-
- var - Variable in class com.bigdata.rdf.spo.Binding
-
The variable.
- var - Variable in class com.bigdata.relation.rule.Binding
-
The variable.
- var(String) - Static method in class com.bigdata.relation.rule.Rule
-
- VAR - Static variable in class it.unimi.dsi.parser.Element
-
- VAR1 - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- VAR2 - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- VAR3 - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- VAR_CHAR - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- VARIABLE - Static variable in interface com.bigdata.bop.constraint.INConstraint.Annotations
-
The variable against which the constraint is applied.
- VARIABLES - Static variable in interface com.bigdata.bop.solutions.DistinctAnnotations
-
The variables on which the distinct constraint will be imposed.
- variablesToKeep() - Method in class com.bigdata.bop.join.PipelineJoin
-
- VariableUnificationOp - Class in com.bigdata.bop.rdf.join
-
Operator computing a join over two variables already bound variables in the
mapping set (for which the IV has been computed already).
- VariableUnificationOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.bop.rdf.join.VariableUnificationOp
-
- VariableUnificationOp(BOp[], NV...) - Constructor for class com.bigdata.bop.rdf.join.VariableUnificationOp
-
- VariableUnificationOp(VariableUnificationOp) - Constructor for class com.bigdata.bop.rdf.join.VariableUnificationOp
-
- VariableUnificationOp.Annotations - Interface in com.bigdata.bop.rdf.join
-
- variance - Variable in class cern.jet.random.Normal
-
- variance(double) - Static method in class cern.jet.stat.Descriptive
-
Returns the variance from a standard deviation.
- variance(int, double, double) - Static method in class cern.jet.stat.Descriptive
-
Returns the variance of a data sequence.
- VarList() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- VARNAME - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- varNode(String) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
- VarNode - Class in com.bigdata.rdf.sparql.ast
-
Used to represent a variable in the AST.
- VarNode(VarNode) - Constructor for class com.bigdata.rdf.sparql.ast.VarNode
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- VarNode(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.VarNode
-
Required shallow copy constructor.
- VarNode(String) - Constructor for class com.bigdata.rdf.sparql.ast.VarNode
-
- VarNode(IVariable<IV>) - Constructor for class com.bigdata.rdf.sparql.ast.VarNode
-
- VarNode.Annotations - Interface in com.bigdata.rdf.sparql.ast
-
- varNodes(String...) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
- VarOrIRIref() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- VarOrIRIrefOrIsA() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- VarOrTerm() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- VarOrTermOrTRefP() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- vars() - Method in class com.bigdata.bop.bindingSet.EmptyBindingSet
-
- vars() - Method in class com.bigdata.bop.bindingSet.HashBindingSet
-
- vars() - Method in class com.bigdata.bop.bindingSet.ListBindingSet
-
- vars() - Method in class com.bigdata.bop.ContextBindingSet
-
- vars() - Method in interface com.bigdata.bop.IBindingSet
-
Visits the bound variables.
- VARS - Static variable in interface com.bigdata.bop.rdf.join.ChunkedMaterializationOp.Annotations
-
The
IVariable
[] identifying the variables to be materialized.
- VARS - Static variable in interface com.bigdata.bop.rdf.join.MockTermResolverOp.Annotations
-
The
IVariable
[] identifying the variables for which the
referenced values in binding sets are joined with the dictionary
(whenever they are bound to mocked IDs).
- VARS - Static variable in interface com.bigdata.bop.rdf.join.VariableUnificationOp.Annotations
-
- VARS - Static variable in interface com.bigdata.bop.rdf.update.ChunkedResolutionOp.Annotations
-
An optional
IVariable
[] identifying the variables to be
resolved.
- VARS - Static variable in class com.bigdata.rdf.rio.json.SPARQLJSONParserBase
-
- vars - Variable in class com.bigdata.rdf.sparql.ast.JoinSetUtil
-
The set of variables which are bound be each of the vertices for the
required joins.
- varSet(String...) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCaseWithUtilityMethods
-
- varUsed(IVariable<?>) - Method in class com.bigdata.rdf.sparql.ast.optimizers.ASTStaticBindingsOptimizer.VariableUsageInfo
-
Returns true iff usage records for the var are available.
- varUsedInFilterOrAssignment(IVariable<?>) - Method in class com.bigdata.rdf.sparql.ast.optimizers.ASTStaticBindingsOptimizer.VariableUsageInfo
-
Returns true if a usage record for the given variable inside a FILTER
or BIND/VALUES node has been recorded.
- vcols - Variable in class com.bigdata.counters.query.PivotTable
-
The ordered set of distinct counter names.
- vColumnFlip() - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Self modifying version of viewColumnFlip().
- vColumnFlip() - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Self modifying version of viewColumnFlip().
- vDice() - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Self modifying version of viewDice().
- vDice(int, int, int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Self modifying version of viewDice().
- ve(int) - Method in class com.bigdata.rdf.sparql.ast.TestAST
-
- vector(IBindingSet[], IVariable<?>[], IVariable<?>[], boolean, AtomicInteger) - Method in class com.bigdata.bop.join.HTreeHashJoinUtility
-
Vector a chunk of solutions.
- Verb() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- verbose - Variable in class com.bigdata.rdf.sail.bench.NanoSparqlClient.QueryOptions
-
- VERBOSE - Static variable in interface com.bigdata.rdf.store.DataLoader.Options
-
When greater than ZERO (0), significant information may be reported
at each commit point.
- VerbPath() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- VerbSimple() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- verifiedRecord(AbstractMRMWTestCase.Record) - Method in class com.bigdata.journal.AbstractMRMWTestCase.GroundTruth
-
- VERIFY - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- verify(int) - Method in interface com.bigdata.rwstore.Allocator
-
- verify(int, int) - Method in class com.bigdata.rwstore.AllocBlock
-
- verify(int) - Method in class com.bigdata.rwstore.FixedAllocator
-
- verify(long) - Method in class com.bigdata.rwstore.RWStore
-
Given a physical address (byte offset on the store), return true if that
address could be managed by an allocated block.
- VERIFY_DATA - Static variable in interface com.bigdata.rdf.rio.RDFParserOptions.Options
-
Optional boolean property may be used to turn on data verification in
the RIO parser (default is
"false").
- VERIFY_DATA - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- VERIFY_DATA - Static variable in interface com.bigdata.rdf.sparql.ast.LoadGraph.Annotations
-
- verifyAggregate(QueryBase) - Static method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
Verify the various conditions that must be met when a query uses GROUP BY
or when a query uses aggregates in a PROJECTION.
- verifyAggregate(QueryBase) - Static method in class com.bigdata.rdf.sail.sparql.VerifyAggregates
-
Verify the various conditions that must be met when a query uses GROUP BY
or when a query uses aggregates in a PROJECTION.
- VerifyAggregates - Class in com.bigdata.rdf.sail.sparql
-
An object which encapsulates the validation and state of an aggregation
operation with an optional GROUP BY clause, SELECT expressions, and an
optional HAVING clause.
- VerifyAggregates(ProjectionNode, GroupByNode, HavingNode) - Constructor for class com.bigdata.rdf.sail.sparql.VerifyAggregates
-
- verifyAllocatedAddress(long) - Method in class com.bigdata.rwstore.FixedAllocator
-
Determines if the provided physical address is within an allocated slot
- verifyAllocatedAddress(long) - Method in class com.bigdata.rwstore.RWStore
-
Can be used to determine if an address is within an allocated slot.
- VerifyCommitRecordIndex - Class in com.bigdata.journal
-
Given an existing journal, ensure that any commitRecords that reference a
time prior to the last deferred release time are removed.
- VerifyCommitRecordIndex() - Constructor for class com.bigdata.journal.VerifyCommitRecordIndex
-
- verifyData - Variable in class com.bigdata.rdf.sail.sparql.ast.ASTLoad
-
- verifyQueryResult(CloseableIteration<? extends BindingSet, QueryEvaluationException>, int) - Method in class org.openrdf.sail.RDFStoreTest
-
- VerifyStatementBuffer - Class in com.bigdata.rdf.load
-
Statements inserted into the buffer are verified against the database.
- VerifyStatementBuffer(AbstractTripleStore, int, AtomicLong, AtomicLong, AtomicLong, AtomicLong) - Constructor for class com.bigdata.rdf.load.VerifyStatementBuffer
-
- VerifyStatementBufferFactory - Class in com.bigdata.rdf.load
-
- VerifyStatementBufferFactory(AbstractTripleStore, int) - Constructor for class com.bigdata.rdf.load.VerifyStatementBufferFactory
-
- Version - Class in cern.colt
-
Information about the current release.
- VERSION - Static variable in class com.bigdata.bfs.FileMetadataSchema
-
The file version number.
- version - Variable in class com.bigdata.bfs.FileVersionInputStream
-
- version - Variable in class com.bigdata.bfs.FileVersionOutputStream
-
- version - Variable in class com.bigdata.counters.linux.KernelVersion
-
- VERSION - Static variable in class it.unimi.dsi.parser.Attribute
-
- VERSION0 - Static variable in class com.bigdata.btree.data.AbstractReadOnlyNodeData
-
The initial version.
- VERSION0 - Static variable in class com.bigdata.btree.IndexSegmentCheckpoint
-
Version 0 of the serialization format.
- VERSION0 - Static variable in class com.bigdata.btree.raba.codec.CanonicalHuffmanRabaCoder
-
The original serialization version for the coded data record.
- VERSION0 - Static variable in class com.bigdata.btree.ResultSet
-
- VERSION0 - Static variable in class com.bigdata.journal.CommitRecordSerializer
-
- VERSION1 - Static variable in class com.bigdata.btree.data.AbstractReadOnlyNodeData
-
This version introduces:
spannedTupleCount
Both the #of children spanned by the node (nentries
) and
the #of children spanned by each child of the node (
childEntryCount
) are int64 integers in this version.
- VERSION1 - Static variable in class com.bigdata.btree.IndexSegmentCheckpoint
-
Version 1 of the serialization format introduces an option for record
level checksums.
- VERSION1 - Static variable in class com.bigdata.ha.halog.HALogWriter
-
HA log version number (version 1).
- VERSION1 - Static variable in class com.bigdata.journal.FileMetadata
-
The original journal version number (version 1).
- VERSION2 - Static variable in class com.bigdata.btree.IndexSegmentCheckpoint
-
Version 2 of the serialization format replaced the int32 value for
nentries with an int64 value.
- VERTEX - Variable in class com.bigdata.blueprints.BigdataGraph
-
URI used to represent a Vertex.
- VERTEX - Variable in class com.bigdata.blueprints.BigdataGraphQuery
-
URI used to represent a Vertex.
- VERTEX - Static variable in class com.bigdata.blueprints.BigdataRDFFactory
-
URI used to represent a Vertex.
- VERTEX - Variable in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
-
URI used to represent a Vertex.
- Vertex - Class in com.bigdata.bop.joinGraph.rto
-
A vertex of the join graph is an annotated relation (this corresponds to an
IPredicate
with additional annotations to support the adaptive query
optimization algorithm).
- VERTEX_NAMESPACE - Static variable in class com.bigdata.blueprints.BigdataRDFFactory
-
Namesace for vertices.
- VERTEX_NAMESPACE - Variable in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
-
Namespace for vertices.
- VertexDistribution - Class in com.bigdata.rdf.graph.impl.util
-
Utility class for sampling vertices from a graph.
- VertexDistribution(Random) - Constructor for class com.bigdata.rdf.graph.impl.util.VertexDistribution
-
- VertexSample - Class in com.bigdata.bop.joinGraph.rto
-
A sample of a
Vertex
(an access path).
- VertexSample(long, int, EstimateEnum, IBindingSet[]) - Constructor for class com.bigdata.bop.joinGraph.rto.VertexSample
-
Note: For a
Vertex
, the estimatedCardinality is the fast range
count.
- vertexState - Variable in class com.bigdata.rdf.graph.impl.GASState
-
The state associated with each visited vertex.
- VertexTaskFactory<T> - Interface in com.bigdata.rdf.graph.impl
-
A factory for tasks that are applied to each vertex in the frontier.
- vertices() - Method in class com.bigdata.blueprints.BigdataGraphQuery
-
Execute the query and return the vertices on the other end of the matching edges.
- VERTICES - Static variable in interface com.bigdata.bop.joinGraph.rto.JoinGraph.Annotations
-
The vertices of the join graph, expressed an an
IPredicate
[]
(required).
- vertices - Variable in class com.bigdata.rdf.sparql.ast.JoinSetUtil.VertexJoinSet
-
The set of verticies in this join set.
- vf - Variable in class com.bigdata.blueprints.DefaultBlueprintsValueFactory
-
The Sesame value factory for URIs and Literals.
- vf - Variable in class com.bigdata.bop.rdf.aggregate.GROUP_CONCAT
-
- vf() - Method in class com.bigdata.rdf.internal.constraints.MathBOp
-
- vf - Variable in class com.bigdata.rdf.internal.encoder.IVBindingSetEncoder
-
Value factory
- vf - Variable in class org.openrdf.repository.RepositoryConnectionTest
-
- vf - Variable in class org.openrdf.sail.RDFStoreTest
-
- vFlip() - Method in class cern.colt.matrix.impl.AbstractMatrix1D
-
Self modifying version of viewFlip().
- view() - Method in class cern.colt.matrix.DoubleMatrix1D
-
Constructs and returns a new view equal to the receiver.
- view() - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new view equal to the receiver.
- view() - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new view equal to the receiver.
- view() - Method in class cern.colt.matrix.ObjectMatrix1D
-
Constructs and returns a new view equal to the receiver.
- view() - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new view equal to the receiver.
- view() - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new view equal to the receiver.
- viewColumn(int) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new slice view representing the rows of the given column.
- viewColumn(int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new 2-dimensional slice view representing the slices and rows of the given column.
- viewColumn(int) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new slice view representing the rows of the given column.
- viewColumn(int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new 2-dimensional slice view representing the slices and rows of the given column.
- viewColumnFlip() - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new flip view along the column axis.
- viewColumnFlip() - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new flip view along the column axis.
- viewColumnFlip() - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new flip view along the column axis.
- viewColumnFlip() - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new flip view along the column axis.
- viewDice() - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new dice (transposition) view; Swaps axes; example: 3 x 4 matrix --> 4 x 3 matrix.
- viewDice(int, int, int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new dice view; Swaps dimensions (axes); Example: 3 x 4 x 5 matrix --> 4 x 3 x 5 matrix.
- viewDice() - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new dice (transposition) view; Swaps axes; example: 3 x 4 matrix --> 4 x 3 matrix.
- viewDice(int, int, int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new dice view; Swaps dimensions (axes); Example: 3 x 4 x 5 matrix --> 4 x 3 x 5 matrix.
- viewFlip() - Method in class cern.colt.matrix.DoubleMatrix1D
-
Constructs and returns a new flip view.
- viewFlip() - Method in class cern.colt.matrix.ObjectMatrix1D
-
Constructs and returns a new flip view.
- viewPart(int, int) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Constructs and returns a new sub-range view that is a width sub matrix starting at index.
- viewPart(int, int, int, int) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new sub-range view that is a height x width sub matrix starting at [row,column].
- viewPart(int, int, int, int, int, int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new sub-range view that is a depth x height x width sub matrix starting at [slice,row,column];
Equivalent to view().part(slice,row,column,depth,height,width); Provided for convenience only.
- viewPart(int, int) - Method in class cern.colt.matrix.ObjectMatrix1D
-
Constructs and returns a new sub-range view that is a width sub matrix starting at index.
- viewPart(int, int, int, int) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new sub-range view that is a height x width sub matrix starting at [row,column].
- viewPart(int, int, int, int, int, int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new sub-range view that is a depth x height x width sub matrix starting at [slice,row,column];
Equivalent to view().part(slice,row,column,depth,height,width); Provided for convenience only.
- viewRow(int) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new slice view representing the columns of the given row.
- viewRow(int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new 2-dimensional slice view representing the slices and columns of the given row.
- viewRow(int) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new slice view representing the columns of the given row.
- viewRow(int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new 2-dimensional slice view representing the slices and columns of the given row.
- viewRowFlip() - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new flip view along the row axis.
- viewRowFlip() - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new flip view along the row axis.
- viewRowFlip() - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new flip view along the row axis.
- viewRowFlip() - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new flip view along the row axis.
- views() - Method in class com.bigdata.resources.OverflowMetadata
-
The views that are being processed in index name order.
- viewSample(DoubleMatrix1D, double, RandomEngine) - Static method in class cern.colt.matrix.doublealgo.Statistic
-
Constructs and returns a sampling view with a size of round(matrix.size() * fraction).
- viewSample(DoubleMatrix2D, double, double, RandomEngine) - Static method in class cern.colt.matrix.doublealgo.Statistic
-
Constructs and returns a sampling view with round(matrix.rows() * rowFraction) rows and round(matrix.columns() * columnFraction) columns.
- viewSample(DoubleMatrix3D, double, double, double, RandomEngine) - Static method in class cern.colt.matrix.doublealgo.Statistic
-
Constructs and returns a sampling view with round(matrix.slices() * sliceFraction) slices and round(matrix.rows() * rowFraction) rows and round(matrix.columns() * columnFraction) columns.
- viewSelection(int[]) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Constructs and returns a new selection view that is a matrix holding the indicated cells.
- viewSelection(DoubleProcedure) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Constructs and returns a new selection view that is a matrix holding the cells matching the given condition.
- viewSelection(int[], int[]) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new selection view that is a matrix holding the indicated cells.
- viewSelection(DoubleMatrix1DProcedure) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new selection view that is a matrix holding all rows matching the given condition.
- viewSelection(int[], int[], int[]) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new selection view that is a matrix holding the indicated cells.
- viewSelection(DoubleMatrix2DProcedure) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new selection view that is a matrix holding all slices matching the given condition.
- viewSelection(int[]) - Method in class cern.colt.matrix.ObjectMatrix1D
-
Constructs and returns a new selection view that is a matrix holding the indicated cells.
- viewSelection(ObjectProcedure) - Method in class cern.colt.matrix.ObjectMatrix1D
-
Constructs and returns a new selection view that is a matrix holding the cells matching the given condition.
- viewSelection(int[], int[]) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new selection view that is a matrix holding the indicated cells.
- viewSelection(ObjectMatrix1DProcedure) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new selection view that is a matrix holding all rows matching the given condition.
- viewSelection(int[], int[], int[]) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new selection view that is a matrix holding the indicated cells.
- viewSelection(ObjectMatrix2DProcedure) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new selection view that is a matrix holding all slices matching the given condition.
- viewSelectionLike(int[]) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[]) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[], int[]) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Construct and returns a new selection view.
- viewSelectionLike(int[]) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix1D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[]) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix2D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[], int[]) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix3D
-
Construct and returns a new selection view.
- viewSelectionLike(int[]) - Method in class cern.colt.matrix.impl.DenseObjectMatrix1D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[]) - Method in class cern.colt.matrix.impl.DenseObjectMatrix2D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[], int[]) - Method in class cern.colt.matrix.impl.DenseObjectMatrix3D
-
Construct and returns a new selection view.
- viewSelectionLike(int[]) - Method in class cern.colt.matrix.impl.SparseDoubleMatrix1D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[]) - Method in class cern.colt.matrix.impl.SparseDoubleMatrix2D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[], int[]) - Method in class cern.colt.matrix.impl.SparseDoubleMatrix3D
-
Construct and returns a new selection view.
- viewSelectionLike(int[]) - Method in class cern.colt.matrix.impl.SparseObjectMatrix1D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[]) - Method in class cern.colt.matrix.impl.SparseObjectMatrix2D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[], int[]) - Method in class cern.colt.matrix.impl.SparseObjectMatrix3D
-
Construct and returns a new selection view.
- viewSelectionLike(int[]) - Method in class cern.colt.matrix.ObjectMatrix1D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[]) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Construct and returns a new selection view.
- viewSelectionLike(int[], int[], int[]) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Construct and returns a new selection view.
- viewSlice(int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new 2-dimensional slice view representing the rows and columns of the given slice.
- viewSlice(int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new 2-dimensional slice view representing the rows and columns of the given slice.
- viewSliceFlip() - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new flip view along the slice axis.
- viewSliceFlip() - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new flip view along the slice axis.
- viewSorted() - Method in class cern.colt.matrix.DoubleMatrix1D
-
Sorts the vector into ascending order, according to the natural ordering.
- viewSorted(int) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Sorts the matrix rows into ascending order, according to the natural ordering of the matrix values in the given column.
- viewSorted(int, int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Sorts the matrix slices into ascending order, according to the natural ordering of the matrix values in the given [row,column] position.
- viewSorted() - Method in class cern.colt.matrix.ObjectMatrix1D
-
Sorts the vector into ascending order, according to the natural ordering.
- viewSorted(int) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Sorts the matrix rows into ascending order, according to the natural ordering of the matrix values in the given column.
- viewSorted(int, int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Sorts the matrix slices into ascending order, according to the natural ordering of the matrix values in the given [row,column] position.
- ViewStatistics - Class in com.bigdata.btree
-
- ViewStatistics(ILocalBTreeView) - Constructor for class com.bigdata.btree.ViewStatistics
-
Collects some statistics about the view.
- viewStrides(int) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Constructs and returns a new stride view which is a sub matrix consisting of every i-th cell.
- viewStrides(int, int) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Constructs and returns a new stride view which is a sub matrix consisting of every i-th cell.
- viewStrides(int, int, int) - Method in class cern.colt.matrix.DoubleMatrix3D
-
Constructs and returns a new stride view which is a sub matrix consisting of every i-th cell.
- viewStrides(int) - Method in class cern.colt.matrix.ObjectMatrix1D
-
Constructs and returns a new stride view which is a sub matrix consisting of every i-th cell.
- viewStrides(int, int) - Method in class cern.colt.matrix.ObjectMatrix2D
-
Constructs and returns a new stride view which is a sub matrix consisting of every i-th cell.
- viewStrides(int, int, int) - Method in class cern.colt.matrix.ObjectMatrix3D
-
Constructs and returns a new stride view which is a sub matrix consisting of every i-th cell.
- VIRTUAL_GRAPH - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- VIRTUAL_GRAPH - Static variable in interface com.bigdata.rdf.store.BD
-
A predicate used to model the membership of a virtual graph.
- visit(AbstractBTree, AbstractNode<?>) - Method in class com.bigdata.btree.BTreePageStats
-
- visit(ITuple<E>) - Method in class com.bigdata.btree.filter.TupleFilter.TupleFilterator
-
Hook for subclasses.
- visit(ITuple<E>) - Method in class com.bigdata.btree.filter.TupleUpdater.Updaterator
-
- visit(ISimpleTreeIndexAccess, IAbstractNodeData) - Method in class com.bigdata.btree.PageStats
-
Visit a node or leaf, updating the
PageStats
.
- visit(AbstractHTree, AbstractPage) - Method in class com.bigdata.htree.HTreePageStats
-
- visit(int, Value) - Method in class com.bigdata.rdf.graph.analytics.BFS.VS
-
Note: This marks the vertex at the current traversal depth.
- visit(IGASState<CC.VS, CC.ES, Value>, Value) - Method in class com.bigdata.rdf.graph.analytics.CC.ConnectedComponentsReducer
-
- visit(IGASState<PR.VS, PR.ES, Double>, Value) - Method in class com.bigdata.rdf.graph.analytics.PR.PageRankReducer
-
- visit(int, Value, URI) - Method in class com.bigdata.rdf.graph.impl.bd.PATHS.VS
-
Note: This marks the vertex at the current traversal depth.
- visit(IGASState<VS, ES, ST>, Value) - Method in interface com.bigdata.rdf.graph.IReducer
-
Method is invoked for each result and is responsible for combining the
results in whatever manner is meaningful for the procedure.
- visit(SimpleNode, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTUpdateSequence, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTUpdateContainer, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTQueryContainer, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBaseDecl, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPrefixDecl, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSelectQuery, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSelect, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTProjectionElem, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTConstructQuery, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTConstruct, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDescribeQuery, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDescribe, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTAskQuery, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNamedSubquery, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDatasetClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTWhereClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBindingsClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTInlineData, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBindingSet, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBindingValue, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGroupClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTOrderClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGroupCondition, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTHavingClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTOrderCondition, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTLimit, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTOffset, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGraphPatternGroup, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBasicGraphPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNamedSubqueryInclude, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTOptionalGraphPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGraphGraphPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTUnionGraphPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMinusGraphPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTServiceGraphPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTConstraint, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTFunctionCall, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTTriplesSameSubject, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPropertyList, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTObjectList, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTTriplesSameSubjectPath, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPropertyListPath, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPathAlternative, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPathSequence, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPathElt, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIRI, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPathOneInPropertySet, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTPathMod, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBlankNodePropertyList, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCollection, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTVar, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTOr, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTAnd, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCompare, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTInfix, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMath, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNot, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNumericLiteral, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCount, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSum, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMin, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMax, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTAvg, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSample, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGroupConcat, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMD5, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSHA1, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSHA224, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSHA256, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSHA384, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSHA512, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNow, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTYear, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMonth, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDay, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTHours, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMinutes, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSeconds, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTTimezone, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTTz, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTRand, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTAbs, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCeil, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTFloor, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTRound, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSubstr, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrLen, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTUpperCase, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTLowerCase, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrStarts, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrEnds, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrBefore, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrAfter, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTReplace, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTConcat, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTContains, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTEncodeForURI, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIf, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIn, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNotIn, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCoalesce, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStr, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTLang, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTLangMatches, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDatatype, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBound, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSameTerm, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIsIRI, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIsBlank, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIsLiteral, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIsNumeric, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBNodeFunc, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTIRIFunc, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrDt, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTStrLang, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTUUID, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSTRUUID, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBind, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTLet, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTRegexExpression, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTExistsFunc, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTNotExistsFunc, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTRDFLiteral, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTTrue, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTFalse, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTString, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTQName, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTBlankNode, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGraphRefAll, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTGraphOrDefault, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTSolutionsRef, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTUnparsedQuadDataBlock, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTQuadsNotTriples, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTLoad, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDropEntailments, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCreateEntailments, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTEnableEntailments, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDisableEntailments, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTClear, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDrop, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTAdd, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTMove, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCopy, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTCreate, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTInsertData, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDeleteData, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDeleteWhere, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTDeleteClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTInsertClause, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTModify, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTTRefPattern, Object) - Method in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderVisitor
-
- visit(ASTAbs, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUpdateSequence, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBindingValue, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTInlineData, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUnparsedQuadDataBlock, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUpdateContainer, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTAdd, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBindingSet, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTClear, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCopy, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCreate, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDeleteClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDeleteData, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDeleteWhere, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDrop, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGraphOrDefault, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGraphRefAll, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTInfix, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTInsertClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTInsertData, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTLoad, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTModify, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMove, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNow, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTYear, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMonth, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDay, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTHours, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTTz, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMinutes, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSeconds, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTTimezone, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTAnd, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTAskQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTAvg, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMD5, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSHA1, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSHA224, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSHA256, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSHA384, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSHA512, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBaseDecl, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBasicGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBind, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTLet, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBindingsClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBlankNode, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBlankNodePropertyList, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBNodeFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTBound, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCeil, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCoalesce, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTConcat, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTContains, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCollection, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCompare, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTConstraint, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTConstruct, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTConstructQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCount, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDatasetClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDatatype, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDescribe, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDescribeQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTExistsFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTEncodeForURI, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTFalse, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTFloor, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTFunctionCall, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGraphGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGraphPatternGroup, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGroupClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGroupConcat, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTGroupCondition, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTHavingClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIf, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIn, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIRI, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIRIFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIsBlank, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIsIRI, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIsLiteral, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTIsNumeric, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTLang, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTLangMatches, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTLimit, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTLowerCase, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMath, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMax, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMin, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTMinusGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNot, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNotExistsFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNotIn, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNumericLiteral, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTObjectList, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTOffset, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTOptionalGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTOr, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTOrderClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTOrderCondition, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPathAlternative, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPathElt, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPathMod, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPathOneInPropertySet, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPathSequence, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPrefixDecl, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTProjectionElem, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPropertyList, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTPropertyListPath, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTQName, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTQueryContainer, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTRand, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTRDFLiteral, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTRegexExpression, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTReplace, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTRound, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSameTerm, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSample, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSelect, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSelectQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTServiceGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStr, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrAfter, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrBefore, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrDt, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrEnds, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTString, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUUID, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSTRUUID, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrLang, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrLen, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTStrStarts, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSubstr, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSum, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTTriplesSameSubject, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTTriplesSameSubjectPath, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTQuadsNotTriples, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTTrue, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUnionGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUpdate, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTUpperCase, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTVar, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTWhereClause, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(SimpleNode, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNamedSubquery, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTNamedSubqueryInclude, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTSolutionsRef, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTTRefPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTCreateEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDisableEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTDropEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTEnableEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.ASTVisitorBase
-
- visit(ASTVar, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
Note: openrdf uses the
BlankNodeVarProcessor
create anonymous
variables from blank nodes and then flags those as anonymous variables in
this step.
- visit(ASTQName, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTBlankNode, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTIRI, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTRDFLiteral, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTNumericLiteral, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTTrue, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTFalse, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTString, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataASTVisitorBase
-
- visit(ASTQueryContainer, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
This is the top-level entry point for a SPARQL query.
- visit(ASTSelectQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
This is the entry point for both a top-level SELECT and a SubSelect.
- visit(ASTAskQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
ASK query.
- visit(ASTDescribeQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
DESCRIBE query.
- visit(ASTDescribe, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
This is the "projection" part of the DESCRIBE query.
- visit(ASTConstructQuery, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
Handle a CONSTRUCT query.
- visit(ASTGroupClause, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTOrderClause, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTOrderCondition, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTLimit, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTOffset, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTBindingsClause, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTBindingSet, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTBindingValue, Object) - Method in class com.bigdata.rdf.sail.sparql.BigdataExprBuilder
-
- visit(ASTConstruct, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
CONSTRUCT (handled as a TriplesBlock).
- visit(ASTGraphPatternGroup, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
( SelectQuery | GraphPattern )
- this is the common path for
SubSelect and graph patterns.
- visit(ASTOptionalGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
Note: while openrdf lifts the filters out of the optional, we do not need
to do this per MikeP.
- visit(ASTMinusGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
MINUS is modeled very much like OPTIONAL in the bigdata AST.
- visit(ASTGraphGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
- visit(ASTUnionGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
Given
- visit(ASTBind, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
- visit(ASTInlineData, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
- visit(ASTLet, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
A LET is just an alternative syntax for BIND
- visit(ASTConstraint, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
A FILTER.
- visit(ASTNamedSubqueryInclude, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
INCLUDE for a named subquery result set.
- visit(ASTServiceGraphPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.GroupGraphPatternBuilder
-
SPARQL 1.1 SERVICE.
- visit(ASTPropertyList, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTPropertyListPath, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTPathAlternative, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTPathSequence, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTPathElt, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTPathOneInPropertySet, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTObjectList, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTBlankNodePropertyList, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
- visit(ASTCollection, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
Handle the RDF Collection syntax.
- visit(ASTTRefPattern, Object) - Method in class com.bigdata.rdf.sail.sparql.TriplePatternExprBuilder
-
This is invoked in two different contexts.
- visit(ASTInsertData, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
Note: Variables in QuadDatas are disallowed in INSERT DATA requests (see
Notes 8 in the grammar).
- visit(ASTDeleteData, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
Note: For DELETE DATA, QuadData denotes triples to be removed and is as
described in INSERT DATA, with the difference that in a DELETE DATA
operation neither variables nor blank nodes are allowed (see Notes 8+9 in
the grammar).
- visit(ASTQuadsNotTriples, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTDeleteWhere, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
This handles the "DELETE WHERE" syntax short hand.
- visit(ASTLoad, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTClear, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
Note: DROP and CLEAR have the identical semantics for bigdata since it
does not support empty graphs.
- visit(ASTDrop, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
Note: DROP and CLEAR have the identical semantics for bigdata since it
does not support empty graphs.
- visit(ASTCreate, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTCopy, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTMove, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTAdd, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTModify, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
The DELETE/INSERT operation can be used to remove or add triples from/to
the Graph Store based on bindings for a query pattern specified in a
WHERE clause:
- visit(ASTDeleteClause, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTInsertClause, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTSolutionsRef, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTDropEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTCreateEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTEnableEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTDisableEntailments, Object) - Method in class com.bigdata.rdf.sail.sparql.UpdateExprBuilder
-
- visit(ASTOr, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTAnd, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTNot, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTCoalesce, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTCompare, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSubstr, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTConcat, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTAbs, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTCeil, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTContains, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTFloor, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTRound, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTRand, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSameTerm, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTMath, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTFunctionCall, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
ASTFunctionCall (IRIRef, ArgList).
- visit(ASTEncodeForURI, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStr, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrDt, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrStarts, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrEnds, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrLen, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrAfter, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrBefore, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTUpperCase, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTLowerCase, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTStrLang, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTNow, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTYear, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTMonth, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTDay, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTHours, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTMinutes, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSeconds, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTTimezone, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTTz, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTMD5, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSHA1, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSHA224, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSHA256, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSHA384, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSHA512, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTUUID, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSTRUUID, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTIRIFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTLang, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTDatatype, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTLangMatches, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTBound, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTIsIRI, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTIsBlank, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTIsLiteral, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTIsNumeric, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTBNodeFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
TODO Same functionURI for BNode() and BNode(Literal)?
- visit(ASTRegexExpression, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTReplace, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTExistsFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
Note: EXISTS is basically an ASK subquery.
- visit(ASTNotExistsFunc, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
See EXISTS above.
- visit(ASTIf, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTInfix, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTIn, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
"IN" and "NOT IN" are infix notation operators.
- visit(ASTNotIn, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
See IN above.
- visit(ASTGroupCondition, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
Aggregate value expressions in GROUP BY clause.
- visit(ASTCount, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTMax, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTMin, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSum, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTAvg, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTSample, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
- visit(ASTGroupConcat, Object) - Method in class com.bigdata.rdf.sail.sparql.ValueExprBuilder
-
TODO additional scalar values (sparql.jjt specifies "separator EQ" as a
constant in the grammar, but we support additional scalar values for
GROUP_CONCAT
.
- visit(Object) - Method in class cutthecrap.utils.striterators.Visitor
-
- visitAll(BOp, Class<C>) - Static method in class com.bigdata.bop.BOpUtility
-
Return an iterator visiting references to all nodes of the given type
(recursive, including annotations).
- visitDeleted - Variable in class com.bigdata.btree.AbstractBTreeTupleCursor
-
true iff the cursor was provisioned to visit deleted tuples.
- VISITED - Static variable in interface com.bigdata.rdf.graph.impl.BaseGASProgram.Bindings
-
The visited vertex identifier.
- Visitor - Class in cutthecrap.utils.striterators
-
- Visitor() - Constructor for class cutthecrap.utils.striterators.Visitor
-
- Visitorator - Class in cutthecrap.utils.striterators
-
- Visitorator(Iterator, Object, Visitor) - Constructor for class cutthecrap.utils.striterators.Visitorator
-
- VisitorException - Exception in com.bigdata.rdf.sail.sparql.ast
-
- VisitorException() - Constructor for exception com.bigdata.rdf.sail.sparql.ast.VisitorException
-
- VisitorException(String) - Constructor for exception com.bigdata.rdf.sail.sparql.ast.VisitorException
-
- VisitorException(String, Throwable) - Constructor for exception com.bigdata.rdf.sail.sparql.ast.VisitorException
-
- VisitorException(Throwable) - Constructor for exception com.bigdata.rdf.sail.sparql.ast.VisitorException
-
- visitPredecessors(IGASState<PATHS.VS, PATHS.ES, Void>, Value, Set<Value>) - Method in class com.bigdata.rdf.graph.impl.bd.PATHS
-
- VLINK - Static variable in class it.unimi.dsi.parser.Attribute
-
- vmd - Variable in class com.bigdata.resources.CompactingMergeTask
-
- vmd - Variable in class com.bigdata.resources.JoinIndexPartitionTask
-
- vmd - Variable in class com.bigdata.resources.ScatterSplitTask
-
- vmd - Variable in class com.bigdata.resources.SplitIndexPartitionTask
-
- vmstat - Variable in class com.bigdata.counters.linux.StatisticsCollectorForLinux
-
Reports on the host page faults, swap space and can report CPU
utilization.
- VMStatCollector - Class in com.bigdata.counters.linux
-
Collects some counters using vmstat
.
- VMStatCollector(int, boolean) - Constructor for class com.bigdata.counters.linux.VMStatCollector
-
- VMStatCollector - Class in com.bigdata.counters.osx
-
Collects some counters using vmstat
.
- VMStatCollector(int) - Constructor for class com.bigdata.counters.osx.VMStatCollector
-
- VMStatCollector.VMStatReader - Class in com.bigdata.counters.osx
-
Sample output for vm_stat 60
, where 60
is the
interval.
- VMStatCollector.VMStatReader() - Constructor for class com.bigdata.counters.osx.VMStatCollector.VMStatReader
-
- vocab - Variable in class com.bigdata.rdf.rules.BaseClosure
-
Various term identifiers that we need to construct the rules.
- vocab - Variable in class com.bigdata.rdf.sail.sparql.BigdataASTContext
-
A mapping of parsed RDF Values and well known vocabulary items used when
generating the AST to resolved
BigdataValue
s.
- VocabBuilder - Class in com.bigdata.rdf.util
-
Utility class scans some RDF data, builds up a distribution over the distinct
predicates, and generates a
VocabularyDecl
for the source data.
- VOCABULARY - Static variable in class com.bigdata.rdf.store.TripleStoreSchema
-
- VOCABULARY - Static variable in class com.bigdata.rdf.vocab.decls.BSBMVocabularyDecl
-
- vocabulary - Static variable in class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
-
- Vocabulary - Interface in com.bigdata.rdf.vocab
-
Interface for a pre-defined vocabulary.
- VOCABULARY_CLASS - Static variable in interface com.bigdata.rdf.store.AbstractTripleStore.Options
-
The name of the class that will establish the pre-defined
Vocabulary
for the database (default
).
- VocabularyDecl - Interface in com.bigdata.rdf.vocab
-
- vocabUriByteIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
Other IVs requiring materialization
- VocabURIByteIV<V extends BigdataURI> - Class in com.bigdata.rdf.internal.impl.uri
-
A fully inlined representation of a URI based on a byte
code.
- VocabURIByteIV(byte) - Constructor for class com.bigdata.rdf.internal.impl.uri.VocabURIByteIV
-
- vocabUriShortIV - Variable in class com.bigdata.rdf.internal.encoder.AbstractBindingSetEncoderTestCase
-
- VocabURIShortIV<V extends BigdataURI> - Class in com.bigdata.rdf.internal.impl.uri
-
A fully inlined representation of a URI based on a short
code.
- VocabURIShortIV(short) - Constructor for class com.bigdata.rdf.internal.impl.uri.VocabURIShortIV
-
- VoID - Class in com.bigdata.rdf.sail.webapp
-
Helper class for VoID descriptions.
- VoID(Graph, AbstractTripleStore, String[], Resource) - Constructor for class com.bigdata.rdf.sail.webapp.VoID
-
- VoID.IVCount - Class in com.bigdata.rdf.sail.webapp
-
An
IV
and a counter for that
IV
.
- VoID.IVCount(IV<?, ?>, long) - Constructor for class com.bigdata.rdf.sail.webapp.VoID.IVCount
-
- VoidVocabularyDecl - Class in com.bigdata.rdf.vocab.decls
-
Vocabulary and namespace for VOID.
- VoidVocabularyDecl() - Constructor for class com.bigdata.rdf.vocab.decls.VoidVocabularyDecl
-
- volt - Static variable in class cern.clhep.Units
-
- VonMises - Class in cern.jet.random
-
Von Mises distribution.
- VonMises(double, RandomEngine) - Constructor for class cern.jet.random.VonMises
-
Constructs a Von Mises distribution.
- voteNo() - Method in class com.bigdata.ha.msg.HA2PhasePrepareMessage
-
When true
, always vote note.
- voteNo() - Method in interface com.bigdata.ha.msg.IHA2PhasePrepareMessage
-
When true
, always vote note.
- vPart(int, int) - Method in class cern.colt.matrix.impl.AbstractMatrix1D
-
Self modifying version of viewPart().
- vPart(int, int, int, int) - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Self modifying version of viewPart().
- vPart(int, int, int, int, int, int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Self modifying version of viewPart().
- vRowFlip() - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Self modifying version of viewRowFlip().
- vRowFlip() - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Self modifying version of viewRowFlip().
- vSliceFlip() - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Self modifying version of viewSliceFlip().
- VSPACE - Static variable in class it.unimi.dsi.parser.Attribute
-
- vStrides(int) - Method in class cern.colt.matrix.impl.AbstractMatrix1D
-
Self modifying version of viewStrides().
- vStrides(int, int) - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Self modifying version of viewStrides().
- vStrides(int, int, int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Self modifying version of viewStrides().
- VTE - Enum in com.bigdata.rdf.internal
-
Value Type Enumeration (IVTE) is a class with methods for interpreting and
setting the bit flags used to identify the type of an RDF Value (URI,
Literal, Blank Node, SID, etc).
- VTE(byte) - Static method in class com.bigdata.rdf.lexicon.Term2IdWriteProc
-
W
- w - Variable in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
Variables
- w - Variable in class com.bigdata.util.concurrent.MovingAverageTask
-
The weight used to compute the moving average.
- w - Variable in class com.bigdata.util.concurrent.ThreadPoolExecutorBaseStatisticsTask
-
The weight used to compute the moving average.
- W3CQueryLanguageException - Exception in com.bigdata.rdf.error
-
Exception Base class for errors defined by the W3C for XQuery, XPath, and
SPARQL.
- W3CQueryLanguageException(W3CQueryLanguageException.LanguageFamily, W3CQueryLanguageException.ErrorCategory, int) - Constructor for exception com.bigdata.rdf.error.W3CQueryLanguageException
-
- W3CQueryLanguageException(W3CQueryLanguageException.LanguageFamily, W3CQueryLanguageException.ErrorCategory, int, String) - Constructor for exception com.bigdata.rdf.error.W3CQueryLanguageException
-
- W3CQueryLanguageException(W3CQueryLanguageException.LanguageFamily, W3CQueryLanguageException.ErrorCategory, int, NV[]) - Constructor for exception com.bigdata.rdf.error.W3CQueryLanguageException
-
- W3CQueryLanguageException.ErrorCategory - Enum in com.bigdata.rdf.error
-
Error category.
- W3CQueryLanguageException.LanguageFamily - Enum in com.bigdata.rdf.error
-
Language family for errors.
- waitsFor - Variable in class com.bigdata.concurrent.NonBlockingLockManager
-
Used to track dependencies among transactions.
- warmUp(List<String>) - Method in class com.bigdata.journal.Journal
-
Warmup the indicated namespaces.
- WARMUP_NAMESPACE_LIST - Static variable in interface com.bigdata.rdf.sail.webapp.ConfigParams
-
A comma delimited list of namespaces to be processed during the warmup
procedure (optional).
- WARMUP_THREAD_POOL_SIZE - Static variable in interface com.bigdata.rdf.sail.webapp.ConfigParams
-
The size of the thread pool used to warmup the journal (default
20).
- WARMUP_TIMEOUT - Static variable in interface com.bigdata.rdf.sail.webapp.ConfigParams
-
When non-zero, this specifies the timeout (milliseconds) for a warmup
period when the NSS starts up (warmup is disabled when this is ZERO).
- WarmUpTask - Class in com.bigdata.journal
-
Helper class to warm up the indices associated with various namespaces on the
journal.
- WarmUpTask(Journal, List<String>, long, int, boolean) - Constructor for class com.bigdata.journal.WarmUpTask
-
- WARN - Static variable in class com.bigdata.journal.AbstractBufferStrategy
-
- WARN - Static variable in class com.bigdata.relation.rule.eval.pipeline.JoinTask
-
- warn(String, UUID) - Method in interface com.bigdata.service.ILoadBalancerService
-
A warning issued by a client when it is in danger of depleting its
resources.
- warn(String, UUID) - Method in class com.bigdata.service.LoadBalancerService
-
- WARN - Variable in class com.bigdata.service.ndx.AbstractScaleOutClientIndexView
-
- WARN - Variable in class com.bigdata.service.ndx.ClientIndexView
-
- watt - Static variable in class cern.clhep.Units
-
- WeakCacheEntry<K,T> - Class in com.bigdata.cache
-
- WeakCacheEntry(K, T, ReferenceQueue<T>) - Constructor for class com.bigdata.cache.WeakCacheEntry
-
- WeakCacheEntryFactory<K,T> - Class in com.bigdata.cache
-
- WeakCacheEntryFactory() - Constructor for class com.bigdata.cache.WeakCacheEntryFactory
-
- WeakValueCache<K,T> - Class in com.bigdata.cache
-
A memory sensitive cache using weak references for its values and object ids
for its keys and backed by the CRUD operations of the persistence layer,
which is assumed to implement a hard reference LRU or similar cache policy.
- WeakValueCache(ICachePolicy<K, T>) - Constructor for class com.bigdata.cache.WeakValueCache
-
- WeakValueCache(ICachePolicy<K, T>, IWeakRefCacheEntryFactory<K, T>) - Constructor for class com.bigdata.cache.WeakValueCache
-
- WeakValueCache(int, float, ICachePolicy<K, T>, IWeakRefCacheEntryFactory<K, T>) - Constructor for class com.bigdata.cache.WeakValueCache
-
Designated constructor.
- WeakValueCache(int, float, ICachePolicy<K, T>, IWeakRefCacheEntryFactory<K, T>, WeakValueCache.IClearReferenceListener<K>) - Constructor for class com.bigdata.cache.WeakValueCache
-
- WeakValueCache.IClearReferenceListener<K> - Interface in com.bigdata.cache
-
An optional listener that is invoked when we notice a cleared reference.
- weber - Static variable in class cern.clhep.Units
-
- weblog - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
-
- weight - Variable in class cern.jet.random.sampling.WeightedRandomSampler
-
- weightedMean(DoubleArrayList, DoubleArrayList) - Static method in class cern.jet.stat.Descriptive
-
Returns the weighted mean of a data sequence.
- WeightedRandomSampler - Class in cern.jet.random.sampling
-
Conveniently computes a stable subsequence of elements from a given input sequence;
Picks (samples) exactly one random element from successive blocks of weight input elements each.
- WeightedRandomSampler() - Constructor for class cern.jet.random.sampling.WeightedRandomSampler
-
Calls BlockedRandomSampler(1,null).
- WeightedRandomSampler(int, RandomEngine) - Constructor for class cern.jet.random.sampling.WeightedRandomSampler
-
Chooses exactly one random element from successive blocks of weight input elements each.
- weightedRMS(double, double) - Static method in class cern.jet.stat.Descriptive
-
Returns the weighted RMS (Root-Mean-Square) of a data sequence.
- WellFormedXmlFactory - Class in it.unimi.dsi.parser
-
A factory for well-formed XML documents.
- WellFormedXmlFactory() - Constructor for class it.unimi.dsi.parser.WellFormedXmlFactory
-
- WHERE - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- where(IGroupMemberNode...) - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
Wrap the triple patterns in a WHERE clause (aka join group).
- WhereClause() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- whereNanos - Variable in class com.bigdata.rdf.sail.SPARQLUpdateEvent.DeleteInsertWhereStats
-
- WHITESPACE - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- width - Variable in class it.unimi.dsi.bits.AbstractBitVector.LongBigListView
-
The width in bit of an element of this list view.
- WIDTH - Static variable in class it.unimi.dsi.parser.Attribute
-
- width - Variable in class it.unimi.dsi.util.ShiftAddXorSignedStringMap
-
The width in bits of each signature.
- wildcard() - Method in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
- willCommit() - Method in class com.bigdata.ha.PrepareResponse
-
Return true
iff the transaction will commit based on the
responses to the prepare requests.
- willCommit(String) - Method in class com.bigdata.journal.Name2Addr
-
Return true
iff the named index is on the commit list.
- willRemove(ICacheEntry<K, T>) - Method in interface com.bigdata.cache.LRUCache.ICacheOrderChangeListener
-
- willShutdown() - Method in class com.bigdata.service.ndx.pipeline.AbstractMasterTask
-
- Windows2000 - Class in org.apache.system
-
Parses the Windows 2000 environment--the same class should work for other
Windows versions, but I only have one to test.
- Windows2000() - Constructor for class org.apache.system.Windows2000
-
- Windows95 - Class in org.apache.system
-
Parses the Windows 95 environment--the same class should work for other
Windows versions, but I only have one to test.
- Windows95() - Constructor for class org.apache.system.Windows95
-
- Windows98 - Class in org.apache.system
-
Parses the Windows 98 environment--the same class should work for other
Windows versions, but I only have one to test.
- Windows98() - Constructor for class org.apache.system.Windows98
-
- WindowsNT - Class in org.apache.system
-
Parses the Windows 2000 environment--the same class should work for other
Windows versions, but I only have one to test.
- WindowsNT() - Constructor for class org.apache.system.WindowsNT
-
- WindowsXP - Class in org.apache.system
-
Parses the Windows XP environment.
- WindowsXP() - Constructor for class org.apache.system.WindowsXP
-
Create this instance of CPUParser and gather information from
the Windows XP system.
- winsorizedMean(DoubleArrayList, double, int, int) - Static method in class cern.jet.stat.Descriptive
-
Returns the winsorized mean of a sorted data sequence.
- WITH - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- withdrawVote() - Method in class com.bigdata.quorum.AbstractQuorum.QuorumActorBase
-
- withdrawVote(UUID) - Method in class com.bigdata.quorum.AbstractQuorum.QuorumWatcherBase
-
Method is invoked by the
QuorumWatcher
when a service has
withdrawn its vote for some
lastCommitTime.
- withdrawVote() - Method in interface com.bigdata.quorum.QuorumActor
-
Withdraw the vote cast by the service (a service has only one vote).
- withinByteIndexForBit(long) - Method in class com.bigdata.util.ByteBufferBitVector
-
Return the offset within the byte in which the bit is coded of the bit
(this is just the remainder bitIndex % 8
).
- withinByteIndexForBit(long) - Static method in class com.bigdata.util.BytesUtil
-
Return the offset within the byte in which the bit is coded of the bit
(this is just the remainder bitIndex % 8
).
- word(long) - Static method in class it.unimi.dsi.bits.LongArrayBitVector
-
Return the index of the word that holds a bit of specified index.
- word - Variable in class it.unimi.dsi.util.ImmutableBinaryTrie.Node
-
If nonnegative, this node represent the word
-th word.
- WORD_BOUNDARY - Static variable in interface com.bigdata.search.ConfigurableAnalyzerFactory.AnalyzerOptions
-
- WORD_MASK - Static variable in class it.unimi.dsi.bits.LongArrayBitVector
-
- wordConstituents - Variable in class it.unimi.dsi.io.FastBufferedReader
-
- WordReader - Interface in it.unimi.dsi.io
-
An interface providing methods to break the input from a reader into words.
- work1 - Variable in class cern.colt.matrix.linalg.LUDecompositionQuick
-
- work2 - Variable in class cern.colt.matrix.linalg.LUDecompositionQuick
-
- WorkbenchServlet - Class in com.bigdata.rdf.sail.webapp
-
Helper servlet for workbench requests.
- WorkbenchServlet() - Constructor for class com.bigdata.rdf.sail.webapp.WorkbenchServlet
-
- workDouble - Variable in class cern.colt.matrix.linalg.LUDecompositionQuick
-
- workInfoHomepage - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
-
- workplaceHomepage - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
-
- WormAddressManager - Class in com.bigdata.rawstore
-
Encapsulates logic for operations on an opaque long integer comprising an
byte offset and a byte count suitable for use in a WORM (Write Once, Read
Many)
IRawStore
.
- WormAddressManager(int) - Constructor for class com.bigdata.rawstore.WormAddressManager
-
Construct an
IAddressManager
that will allocate a specified #of
bits to the offset and use the remaining bits for the byte count
component.
- WORMStrategy - Class in com.bigdata.journal
-
Disk-based Write Once Read Many (WORM) journal strategy.
- WORMStrategy.StoreCounters<T extends WORMStrategy.StoreCounters<T>> - Class in com.bigdata.journal
-
Striped performance counters for
IRawStore
access, including
operations that read or write through to the underlying media.
- WORMStrategy.StoreCounters() - Constructor for class com.bigdata.journal.WORMStrategy.StoreCounters
- WORMStrategy.StoreCounters(int) - Constructor for class com.bigdata.journal.WORMStrategy.StoreCounters
- WORMStrategy.StoreCounters(int, int) - Constructor for class com.bigdata.journal.WORMStrategy.StoreCounters
- WORMStrategy.WormStoreState - Class in com.bigdata.journal
-
- WORMStrategy.WormStoreState() - Constructor for class com.bigdata.journal.WORMStrategy.WormStoreState
-
- wrap(BooleanValueExpression) - Static method in class com.bigdata.bop.constraint.Constraint
-
Convenience method to generate a constraint from a value expression.
- wrap(AbstractBTree, long, IAbstractNodeData) - Method in class com.bigdata.btree.NodeSerializer
-
- wrap(AbstractHTree, long, IAbstractNodeData) - Method in class com.bigdata.htree.NodeSerializer
-
- wrap(byte[]) - Static method in class com.bigdata.io.AbstractFixedByteArrayBuffer
-
A slice wrapping the entire array.
- wrap(IValueExpression<? extends IV>) - Static method in class com.bigdata.rdf.internal.constraints.XSDBooleanIVValueExpression
-
If the operand is not known to evaluate to a boolean, wrap it with an
EBVBOp
.
- wrap(BooleanList) - Static method in class it.unimi.dsi.bits.BooleanListBitVector
-
- wrap(long[], long) - Static method in class it.unimi.dsi.bits.LongArrayBitVector
-
Wraps the given array of longs in a bit vector for the given number of bits.
- wrap(long[]) - Static method in class it.unimi.dsi.bits.LongArrayBitVector
-
Wraps the given array of longs in a bit vector.
- wrap(Iterator<T>, TransformationStrategy<? super T>) - Static method in class it.unimi.dsi.bits.TransformationStrategies
-
Wraps a given iterator, returning an iterator that emits
bit vectors.
- wrap(Iterable<T>, TransformationStrategy<? super T>) - Static method in class it.unimi.dsi.bits.TransformationStrategies
-
Wraps a given iterable, returning an iterable that contains
bit vectors.
- wrap(List<T>, TransformationStrategy<? super T>) - Static method in class it.unimi.dsi.bits.TransformationStrategies
-
Wraps a given list, returning a list that contains
bit vectors.
- wrap(char[]) - Static method in class it.unimi.dsi.lang.MutableString
-
Wraps a given character array in a compact mutable string.
- wrap(char[], int) - Static method in class it.unimi.dsi.lang.MutableString
-
Wraps a given character array for a given length in a loose mutable string.
- wrapInputStream(InputStream) - Method in class com.bigdata.stream.Stream
-
Wrap for decompression.
- wrapOutputStream(OutputStream) - Method in class com.bigdata.stream.Stream
-
- WrappedAsynchronousIterator<E,F> - Class in com.bigdata.relation.accesspath
-
- WrappedAsynchronousIterator(IChunkedIterator<F>) - Constructor for class com.bigdata.relation.accesspath.WrappedAsynchronousIterator
-
- WrappedRemoteChunkedIterator<E> - Class in com.bigdata.service.proxy
-
- WrappedRemoteChunkedIterator(IRemoteChunkedIterator<E>) - Constructor for class com.bigdata.service.proxy.WrappedRemoteChunkedIterator
-
- WrappedTupleIterator<E> - Class in com.bigdata.btree.filter
-
- WrappedTupleIterator(Iterator<E>) - Constructor for class com.bigdata.btree.filter.WrappedTupleIterator
-
- wrapping - Variable in class it.unimi.dsi.io.InputBitStream
-
True if we are wrapping an array.
- wrapping - Variable in class it.unimi.dsi.io.OutputBitStream
-
True if we are wrapping an array.
- write(int) - Method in class com.bigdata.bfs.FileVersionOutputStream
-
Buffers the byte.
- write(ICloseableIterator<?>) - Method in class com.bigdata.bop.solutions.SolutionSetStream
-
- write(IRawStore) - Method in class com.bigdata.btree.BloomFilter
-
- write(IRawStore) - Method in class com.bigdata.btree.Checkpoint
-
- write(IRawStore) - Method in class com.bigdata.btree.IndexMetadata
-
Write out the metadata record for the btree on the store and return the
address.
- write(RandomAccessFile) - Method in class com.bigdata.btree.IndexSegmentCheckpoint
-
Write the checkpoint record at the start of the file.
- write(ByteBuffer) - Method in class com.bigdata.btree.IndexSegmentStore
-
- write(IHAWriteMessage, ByteBuffer) - Method in class com.bigdata.ha.althalog.HALogFile.HALogWriter
-
- write(IHAWriteMessage, ByteBuffer) - Method in interface com.bigdata.ha.althalog.IHALogWriter
-
Writes the message to the file and the associated data if the
backing store is not a WORM.
- write(Channel) - Method in class com.bigdata.io.AllocationData
-
- write(int) - Method in class com.bigdata.io.ByteArrayBuffer
-
- write(byte[]) - Method in class com.bigdata.io.ByteArrayBuffer
-
- write(byte[], int, int) - Method in class com.bigdata.io.ByteArrayBuffer
-
- write(int) - Method in class com.bigdata.io.ByteBufferOutputStream
-
Write a byte on the buffer.
- write(byte[], int, int) - Method in class com.bigdata.io.ByteBufferOutputStream
-
Write an array of bytes on the buffer.
- write(int) - Method in class com.bigdata.io.ByteCountOutputStream
-
- write(byte[]) - Method in class com.bigdata.io.ByteCountOutputStream
-
- write(byte[], int, int) - Method in class com.bigdata.io.ByteCountOutputStream
-
- write(DataInput, int) - Method in class com.bigdata.io.DataOutputBuffer
-
Read len bytes into the buffer.
- write(int) - Method in class com.bigdata.io.ManagedByteArrayOutputStream
-
- write(byte[]) - Method in class com.bigdata.io.ManagedByteArrayOutputStream
-
- write(byte[], int, int) - Method in class com.bigdata.io.ManagedByteArrayOutputStream
-
- write(int) - Method in class com.bigdata.io.NullOutputStream
-
- write(byte[]) - Method in class com.bigdata.io.NullOutputStream
-
- write(byte[], int, int) - Method in class com.bigdata.io.NullOutputStream
-
- write(ByteBuffer) - Method in class com.bigdata.io.ObjectSocketChannelStream
-
- write(long, ByteBuffer, IReopenChannel<FileChannel>) - Method in class com.bigdata.io.writecache.BufferedWrite
-
Buffer a write.
- write(long, ByteBuffer, int) - Method in interface com.bigdata.io.writecache.IWriteCache
-
Write the record on the cache.
- write(long, ByteBuffer, int) - Method in class com.bigdata.io.writecache.WriteCache
-
Write the record on the cache.
- write(long, ByteBuffer, int) - Method in class com.bigdata.io.writecache.WriteCacheService
-
- write(long, ByteBuffer, int, boolean, int) - Method in class com.bigdata.io.writecache.WriteCacheService
-
Write the record onto the cache.
- write(ByteBuffer) - Method in class com.bigdata.journal.AbstractJournal
-
- write(ByteBuffer, IAllocationContext) - Method in class com.bigdata.journal.AbstractJournal
-
- write() - Method in class com.bigdata.journal.AbstractMRMWTestCase.WriterTask
-
Write a random record and record it in #records
.
- write() - Method in class com.bigdata.journal.AbstractMROWTestCase.WriterTask
-
- write(ByteBuffer) - Method in class com.bigdata.journal.BasicBufferStrategy
-
- write(ByteBuffer) - Method in class com.bigdata.journal.DirectBufferStrategy
-
Extends the basic behavior to write through to the backing file.
- write(ByteBuffer) - Method in class com.bigdata.journal.DiskOnlyStrategy
-
Deprecated.
- write(ByteBuffer) - Method in class com.bigdata.journal.JournalDelegate
-
- write(ByteBuffer) - Method in class com.bigdata.journal.RWStrategy
-
- write(ByteBuffer, IAllocationContext) - Method in class com.bigdata.journal.RWStrategy
-
Overridden to integrate with the shadow allocator support of the
RWStore
.
- write(ByteBuffer) - Method in class com.bigdata.journal.TemporaryRawStore
-
- write(ByteBuffer) - Method in class com.bigdata.journal.WORMStrategy
-
- write(ByteBuffer, IAllocationContext) - Method in interface com.bigdata.rawstore.IAllocationManagerStore
-
Write the data within the allocation context.
- write(ByteBuffer) - Method in interface com.bigdata.rawstore.IRawStore
-
Write the data (unisolated).
- write(ByteBuffer) - Method in class com.bigdata.rawstore.RawStoreDelegate
-
- write(ByteBuffer) - Method in class com.bigdata.rawstore.SimpleFileRawStore
-
- write(ByteBuffer) - Method in class com.bigdata.rawstore.SimpleMemoryRawStore
-
- write(Properties) - Method in interface com.bigdata.rdf.properties.PropertiesWriter
-
Write the properties object.
- write(Properties) - Method in class com.bigdata.rdf.properties.text.PropertiesTextWriter
-
- write(Properties) - Method in class com.bigdata.rdf.properties.xml.PropertiesXMLWriter
-
- write() - Method in interface com.bigdata.rwstore.Allocator
-
- write() - Method in class com.bigdata.rwstore.FixedAllocator
-
write called on commit, so this is the point when "transient frees" - the
freeing of previously committed memory can be made available since we
are creating a new commit point - the condition being that m_freeBits
was zero and m_freeTransients not.
- write(int) - Method in class com.bigdata.rwstore.FixedOutputStream
-
- write(byte[], int, int) - Method in class com.bigdata.rwstore.FixedOutputStream
-
- write(int) - Method in class com.bigdata.rwstore.PSOutputStream
-
write a single byte
this is the one place where the blob threshold is handled
and its done one byte at a time so should be easy enough,
We no longer store continuation addresses, instead we allocate
blob allocations via a blob header block.
- write(byte[], int, int) - Method in class com.bigdata.rwstore.PSOutputStream
-
write byte array to the buffer
we need to be able to efficiently handle large arrays beyond size
of the blobThreshold, so
- write(InputStream) - Method in class com.bigdata.rwstore.PSOutputStream
-
utility method that extracts data from the input stream
- write(ByteBuffer, IAllocationContext) - Method in class com.bigdata.rwstore.sector.AllocationContext
-
- write(ByteBuffer, IAllocationContext) - Method in class com.bigdata.rwstore.sector.MemoryManager
-
- write(ByteBuffer) - Method in class com.bigdata.rwstore.sector.MemStore
-
- write(ByteBuffer, IAllocationContext) - Method in class com.bigdata.rwstore.sector.MemStore
-
- write(ByteBuffer) - Method in class com.bigdata.rwstore.sector.MemStrategy
-
- write(ByteBuffer, IAllocationContext) - Method in class com.bigdata.rwstore.sector.MemStrategy
-
FIXME There are two unit tests for the
MemStore
which are failing
due to this method not being implemented.
- write(DataOutputStream) - Method in class com.bigdata.rwstore.StorageStats.BlobBucket
-
- write(DataOutputStream) - Method in class com.bigdata.rwstore.StorageStats.Bucket
-
- write(CommitTimeIndex, File) - Static method in class com.bigdata.service.DistributedTransactionService.SnapshotHelper
-
- write(CommitTimeIndex, DataOutputStream) - Static method in class com.bigdata.service.DistributedTransactionService.SnapshotHelper
-
- write(Schema, Map<String, Object>) - Method in class com.bigdata.sparse.SparseRowStore
-
Atomic write with atomic read-back of the post-update state of the
logical row.
- write(Schema, Map<String, Object>, long) - Method in class com.bigdata.sparse.SparseRowStore
-
Atomic write with atomic read-back of the post-update state of the
logical row.
- write(Schema, Map<String, Object>, long, INameFilter, IPrecondition) - Method in class com.bigdata.sparse.SparseRowStore
-
Atomic write with atomic read of the then current post-condition state of
the logical row.
- write(Schema, Map<String, Object>, long, long, long, INameFilter, IPrecondition) - Method in class com.bigdata.sparse.SparseRowStore
-
Atomic write with atomic read of the post-condition state of the logical
row.
- write(ICloseableIterator<?>) - Method in class com.bigdata.stream.Stream
-
Write entries onto the stream.
- write(byte[], long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- write(int) - Method in class it.unimi.dsi.io.NullOutputStream
-
- write(A, DataOutputStream) - Method in interface it.unimi.dsi.io.OfflineIterable.Serializer
-
Writes out an element.
- write(byte[], long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a sequence of bits.
- write(byte[], long, long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a sequence of bits, starting from a given offset.
- write(BooleanIterator) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a sequence of bits emitted by a boolean iterator.
- write(Writer) - Method in class it.unimi.dsi.lang.MutableString
-
Writes this mutable string to a
Writer
.
- WRITE_CACHE_BUFFER_COUNT - Static variable in interface com.bigdata.journal.Options
-
- WRITE_CACHE_COMPACTION_THRESHOLD - Static variable in interface com.bigdata.journal.Options
-
Option specifies the minimum percentage of empty space in a
WriteCache
buffer that could be recovered before we will attempt
to compact the buffer (in [0:100], default
"20").
- WRITE_CACHE_ENABLED - Static variable in interface com.bigdata.journal.Options
-
- WRITE_CACHE_MIN_CLEAN_LIST_SIZE - Static variable in interface com.bigdata.journal.Options
-
Option may be used to control the maximum number of buffers on the
WriteCacheService
dirty list (default
"0", which means that an
intelligent policy used).
- WRITE_RETENTION_QUEUE_CAPACITY - Static variable in interface com.bigdata.bop.IndexAnnotations
-
- WRITE_RETENTION_QUEUE_CAPACITY - Static variable in interface com.bigdata.btree.IndexMetadata.Options
-
The capacity of the hard reference queue used to retain recently
touched nodes (nodes or leaves) and to defer the eviction of dirty
nodes (nodes or leaves).
- WRITE_RETENTION_QUEUE_SCAN - Static variable in interface com.bigdata.btree.IndexMetadata.Options
-
The #of entries on the write retention queue that will be scanned for
a match before a new reference is appended to the queue.
- WRITE_SECS - Static variable in interface com.bigdata.io.writecache.IWriteCacheCounters
-
The elapsed time (in seconds) writing on the backing channel.
- WRITE_SERVICE_CORE_POOL_SIZE - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
The minimum #of threads in the pool handling concurrent unisolated
write on named indices (default is
"10").
- WRITE_SERVICE_GROUP_COMMIT_TIMEOUT - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
The timeout in milliseconds that the the
WriteExecutorService
will await other tasks to join the commit group (default
"100").
- WRITE_SERVICE_KEEP_ALIVE_TIME - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
The time in milliseconds that the
WriteExecutorService
will
keep alive excess worker threads (those beyond the core pool size).
- WRITE_SERVICE_MAXIMUM_POOL_SIZE - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
The maximum #of threads allowed in the pool handling concurrent
unisolated write on named indices (default is
"10".
- WRITE_SERVICE_OVERFLOW_LOCK_REQUEST_TIMEOUT - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
The time in milliseconds that a group commit will await an exclusive
lock on the write service in order to perform synchronous overflow
processing (default
"120000").
- WRITE_SERVICE_PRESTART_ALL_CORE_THREADS - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
When true, the write service will be prestart all of its worker
threads (default
"false").
- WRITE_SERVICE_QUEUE_CAPACITY - Static variable in interface com.bigdata.journal.ConcurrencyManager.Options
-
The maximum capacity of the write service queue before newly
submitted tasks will be rejected -or- ZERO (0) to use a
SynchronousQueue
(default
).
- writeAll(FileChannel, ByteBuffer, long) - Static method in class com.bigdata.io.FileChannelUtility
-
- writeAll(IReopenChannel<FileChannel>, ByteBuffer, long) - Static method in class com.bigdata.io.FileChannelUtility
-
Write bytes in data from the position to the limit on the channel
starting at pos.
- writeBit(boolean) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeBit(int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeBit(boolean) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a bit.
- writeBit(int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a bit.
- writeBlock(String, int, long, byte[], int, int) - Method in class com.bigdata.bfs.BigdataFileSystem
-
Atomic write of a block for a file version.
- writeBNode(BNode) - Method in class com.bigdata.rdf.rio.turtle.BigdataTurtleWriter
-
- writeBody(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
- writeBoolean(boolean) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeByte(int) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeByteOffset(byte[], int, long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a sequence of bits, starting from a given byte offset.
- writeBytes(String) - Method in class com.bigdata.io.DataOutputBuffer
-
- WriteCache - Class in com.bigdata.io.writecache
-
This class provides a write cache with read-through for NIO writes on a
FileChannel
(and potentially on a remote service).
- WriteCache(IBufferAccess, boolean, boolean, boolean, boolean, long) - Constructor for class com.bigdata.io.writecache.WriteCache
-
- WriteCache.FileChannelScatteredWriteCache - Class in com.bigdata.io.writecache
-
The scattered write cache is used by the
RWStore
since the writes
can be made to any part of the file assigned for data allocation.
- WriteCache.FileChannelScatteredWriteCache(IBufferAccess, boolean, boolean, boolean, IReopenChannel<FileChannel>, long, BufferedWrite) - Constructor for class com.bigdata.io.writecache.WriteCache.FileChannelScatteredWriteCache
-
- WriteCache.FileChannelWriteCache - Class in com.bigdata.io.writecache
-
- WriteCache.FileChannelWriteCache(long, IBufferAccess, boolean, boolean, boolean, IReopenChannel<FileChannel>, long) - Constructor for class com.bigdata.io.writecache.WriteCache.FileChannelWriteCache
-
- WriteCache.HAPackage - Class in com.bigdata.io.writecache
-
- WriteCache.ReadCache - Class in com.bigdata.io.writecache
-
- WriteCache.ReadCache(IBufferAccess) - Constructor for class com.bigdata.io.writecache.WriteCache.ReadCache
-
- WriteCache.RecordMetadata - Class in com.bigdata.io.writecache
-
The metadata associated with a record in the
WriteCache
.
- WriteCache.RecordMetadata(long, int, int, int) - Constructor for class com.bigdata.io.writecache.WriteCache.RecordMetadata
-
- writeCacheBufferCount - Variable in class com.bigdata.journal.FileMetadata
-
The #of write cache buffers to be used if the write cache is enabled.
- WriteCacheCounters - Class in com.bigdata.io.writecache
-
- WriteCacheCounters() - Constructor for class com.bigdata.io.writecache.WriteCacheCounters
-
- WriteCacheService - Class in com.bigdata.io.writecache
-
- WriteCacheService(int, int, int, boolean, int, int, int, boolean, long, IReopenChannel<? extends Channel>, Quorum, IBackingReader) - Constructor for class com.bigdata.io.writecache.WriteCacheService
-
- WriteCacheService.AsynchronousCloseException - Exception in com.bigdata.io.writecache
-
An instance of this exception is thrown if a thread notices that the
WriteCacheService
was closed by a concurrent process.
- WriteCacheService.AsynchronousCloseException() - Constructor for exception com.bigdata.io.writecache.WriteCacheService.AsynchronousCloseException
-
- WriteCacheServiceCounters - Class in com.bigdata.io.writecache
-
- WriteCacheServiceCounters(int, int, int) - Constructor for class com.bigdata.io.writecache.WriteCacheServiceCounters
-
- writeChar(int) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeChars(String) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeCheckpoint() - Method in class com.bigdata.btree.BTree
-
Checkpoint operation must
#flush()
dirty nodes, dirty persistent
data structures, etc, write a new
Checkpoint
record on the
backing store, save a reference to the current
Checkpoint
, and
return the address of that
Checkpoint
record.
- writeCheckpoint() - Method in interface com.bigdata.btree.ICheckpointProtocol
-
Checkpoint operation must
#flush()
dirty nodes, dirty persistent
data structures, etc, write a new
Checkpoint
record on the
backing store, save a reference to the current
Checkpoint
, and
return the address of that
Checkpoint
record.
- writeCheckpoint() - Method in class com.bigdata.btree.IndexSegment
-
- writeCheckpoint() - Method in class com.bigdata.htree.HTree
-
Checkpoint operation must
#flush()
dirty nodes, dirty persistent
data structures, etc, write a new
Checkpoint
record on the
backing store, save a reference to the current
Checkpoint
, and
return the address of that
Checkpoint
record.
- writeCheckpoint() - Method in class com.bigdata.stream.Stream
-
- writeCheckpoint2() - Method in class com.bigdata.btree.BTree
-
Checkpoint operation must
#flush()
dirty nodes, dirty persistent
data structures, etc, write a new
Checkpoint
record on the
backing store, save a reference to the current
Checkpoint
, and
return the address of that
Checkpoint
record.
- writeCheckpoint2() - Method in interface com.bigdata.btree.ICheckpointProtocol
-
Checkpoint operation must
#flush()
dirty nodes, dirty persistent
data structures, etc, write a new
Checkpoint
record on the
backing store, save a reference to the current
Checkpoint
, and
return the address of that
Checkpoint
record.
- writeCheckpoint2() - Method in class com.bigdata.btree.IndexSegment
-
- writeCheckpoint2() - Method in class com.bigdata.htree.HTree
-
Checkpoint operation must
#flush()
dirty nodes, dirty persistent
data structures, etc, write a new
Checkpoint
record on the
backing store, save a reference to the current
Checkpoint
, and
return the address of that
Checkpoint
record.
- writeCheckpoint2() - Method in class com.bigdata.stream.Stream
-
- writeCodedValues(PrefixCoder, IRaba, CanonicalHuffmanRabaCoder.Byte2Symbol, long[], OutputBitStream) - Method in class com.bigdata.btree.raba.codec.CanonicalHuffmanRabaCoder
-
Write out the coded values.
- writeCounter(Writer, ICounter) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Writes details on a single counter using a
HistoryTable
view.
- writeCounterSet(Writer, CounterSet, int) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Writes all counters in the hierarchy starting with the specified
CounterSet
in a single table (this is the navigational view of
the counter set hierarchy).
- writeCurrent(Iterator<ICounter>) - Method in class com.bigdata.counters.store.CounterSetBTree
-
Writes the
current value of each visited
ICounter
on the store.
- writeDecoderInputs(HuffmanCodec.DecoderInputs, OutputBitStream, StringBuilder) - Static method in class com.bigdata.btree.raba.codec.CanonicalHuffmanRabaCoder
-
Write a compact minimum representation of the data required to
reconstruct the decoder (bit lengths and correlated symbols).
- writeDelta(int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeDelta(int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in δ coding.
- writeDocType(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
- writeDouble(double) - Method in class com.bigdata.ganglia.xdr.XDROutputBuffer
-
Puts a double into the buffer as 8 bytes, big-endian.
- writeDouble(double) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeErrorCount - Variable in class com.bigdata.service.ResourceService.Counters
-
#of errors for responses where we attempt to write the requested data
on the socket.
- writeEventFlyover(Writer, Event) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Pretty up an event by rendering onto the
Writer
as an (X)HTML
table.
- writeEvents(Writer, IEventReportingService) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Plots events using flot
.
- WriteExecutorService - Class in com.bigdata.journal
-
- WriteExecutorService(IResourceManager, int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, long, long) - Constructor for class com.bigdata.journal.WriteExecutorService
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.bfs.AtomicBlockAppendProc
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.bfs.AtomicBlockWriteProc
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.bop.ap.filter.SameVariableConstraint
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.bop.engine.HaltOpMessage
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.bop.engine.StartOpMessage
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.bop.fed.ThickChunkMessage
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.AsynchronousIndexWriteConfiguration
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.BloomFilter
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.Checkpoint
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.data.DefaultLeafCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.data.DefaultNodeCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.DefaultTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.FixedLengthPrefixSplits
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.HTreeIndexMetadata
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.IndexMetadata
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.keys.ASCIIKeyBuilderFactory
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.keys.ICUVersionRecord
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.NOPTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.proc.AbstractKeyArrayIndexProcedure.ResultBitBuffer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.proc.AbstractKeyArrayIndexProcedure.ResultBuffer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.proc.AbstractKeyArrayIndexProcedure
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.proc.AbstractKeyRangeIndexProcedure
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.proc.RangeCountProcedure
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.codec.CanonicalHuffmanRabaCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.codec.EmptyRabaValueCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.codec.FixedLengthValueRabaCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.codec.FrontCodedRabaCoder.DefaultFrontCodedRabaCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.codec.FrontCodedRabaCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.codec.SimpleRabaCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.ConditionalRabaCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.raba.EmptyRaba
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.ResultSet
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.btree.ScatterSplitConfiguration
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.counters.CAT
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.ha.msg.HASendState
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.ha.msg.HAWriteMessage
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.ha.msg.HAWriteMessageBase
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.htree.data.DefaultDirectoryPageCoder
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.io.compression.DefaultRecordCompressorFactory
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.io.compression.NOPRecordCompressor
-
NOP
- writeExternal(ObjectOutput) - Method in class com.bigdata.io.compression.RecordCompressor
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.journal.CommitRecordIndex.CommitRecordIndexTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.journal.Name2Addr.Name2AddrTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.AbstractResourceMetadata
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.IndexPartitionCause
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.LocalPartitionMetadata
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.MetadataIndex.MetadataIndexCheckpoint
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.MetadataIndex.MetadataIndexMetadata
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.MetadataIndex.PartitionLocatorTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.mdi.PartitionLocator
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.axioms.BaseAxioms
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.inf.RdfTypeRdfsResourceFilter
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.BlobsTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.BlobsWriteProc.Result
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.Id2TermTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.RDFFullTextIndexTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.Term2IdTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.Term2IdWriteProc.Result
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.sparql.ast.service.history.HistoryIndexTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.spo.FastRDFValueCoder2
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.spo.InGraphBinarySearchFilter
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.spo.JustificationTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.spo.SPOTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.rdf.vocab.BaseVocabulary
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.relation.rule.eval.DefaultRuleTaskFactory
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.relation.rule.Slice
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.resources.JournalIndex.TupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.search.FullTextIndexTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.service.CommitTimeIndex.TupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.service.proxy.RemoteChunk
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.service.TxId2CommitTimeIndex.TupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.AbstractAtomicRowReadOrWrite
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.AtomicRowDelete
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.AtomicRowWriteRead
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.LogicalRowSplitHandler
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.Schema
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.TPS
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.sparse.TPSTupleSerializer
-
- writeExternal(ObjectOutput) - Method in class com.bigdata.stream.Stream.StreamIndexMetadata
-
- writeExternal(ObjectOutput) - Method in class it.unimi.dsi.util.BloomFilter2
-
- writeFast(BitVector, DataOutputStream) - Static method in class it.unimi.dsi.bits.BitVectors
-
- writeFloat(float) - Method in class com.bigdata.ganglia.xdr.XDROutputBuffer
-
Puts a float into the buffer as 4 bytes, big-endian.
- writeFloat(float) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeFlot(Writer, IEventReportingService) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Write the html to render the Flot-based time-series chart, plotting the
supplied events.
- writeFullPath(Writer, String) - Method in class com.bigdata.counters.render.TextValueFormatter
-
- writeFullPath(Writer, String) - Method in class com.bigdata.counters.render.ValueFormatter
-
Write the full counter path.
- writeFullPath(Writer, String) - Method in class com.bigdata.counters.render.XHTMLRenderer.HTMLValueFormatter
-
A clickable trail of the path from the root.
- writeFullPath(Writer, String) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Deprecated.
by refactor inside of a rendering object.
- writeGamma(int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeGamma(int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in γ coding.
- writeGolomb(int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeGolomb(int, int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeGolomb(int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in Golomb coding.
- writeGolomb(int, int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in Golomb coding.
- writeHead(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
- writeHistory(Iterator<ICounter>) - Method in class com.bigdata.counters.store.CounterSetBTree
-
Handles efficient writes of counters with
History
data.
- writeHistory(Writer, History, String) - Method in class com.bigdata.counters.XMLUtility
-
- writeHistoryTable(Writer, ICounter[], PeriodEnum, TimestampFormatEnum) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Writes out a table containing the histories for the selected counters.
- writeHtml(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
The start html
tag.
- writeIndexSegment(FileChannel, long) - Method in class com.bigdata.btree.IndexSegmentBuilder
-
Writes the complete file format for the index segment.
- writeInt(int) - Method in class com.bigdata.ganglia.xdr.XDROutputBuffer
-
Puts an integer into the buffer as 4 bytes, big-endian.
- writeInt(int) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeInt(int) - Method in class com.bigdata.rwstore.FixedOutputStream
-
write a single 4 byte integer
- writeInt(int) - Method in class com.bigdata.rwstore.PSOutputStream
-
write a single 4 byte integer
- writeInt(int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeInt(int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a fixed number of bits from an integer.
- writeKeys(ObjectOutput) - Method in class com.bigdata.btree.proc.AbstractKeyRangeIndexProcedure
-
- writeLargeRecord(long, ByteBuffer, int, boolean) - Method in class com.bigdata.io.writecache.WriteCacheService
-
Write a record whose size (when combined with the optional checksum) is
larger than the capacity of an individual
WriteCache
buffer.
- writeLeaf(IndexSegmentBuilder.SimpleLeafData) - Method in class com.bigdata.btree.IndexSegmentBuilder
-
Code the leaf, obtaining its address, update the prior/next addr of the
previous leaf, and write that previous leaf onto the output file.
- writeLock() - Method in class com.bigdata.btree.AbstractBTree
-
- writeLock() - Method in interface com.bigdata.btree.IReadWriteLockManager
-
Return a
Lock
that may be used to obtain an exclusive write lock
which is used (in the absence of other concurrency control mechanisms) to
serialize all processes accessing an unisolated index when a writer must
run.
- writeLock() - Method in class com.bigdata.btree.ReadWriteLockManager
-
- writeLock() - Method in class com.bigdata.btree.UnisolatedReadWriteIndex
-
- writeLock() - Method in class com.bigdata.htree.AbstractHTree
-
- writeLock() - Method in class com.bigdata.journal.AbstractCommitTimeIndex
-
- writeLock() - Method in class com.bigdata.stream.Stream
-
- writeLong(long) - Method in class com.bigdata.ganglia.xdr.XDROutputBuffer
-
Puts a long into the buffer as 8 bytes, big-endian.
- writeLong(long) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeLong(long) - Method in class com.bigdata.rwstore.FixedOutputStream
-
- writeLong(long) - Method in class com.bigdata.rwstore.PSOutputStream
-
- writeLong(long, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLong(long, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a fixed number of bits from a long.
- writeLongDelta(long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongDelta(long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in δ coding.
- writeLongGamma(long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongGamma(long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in γ coding.
- writeLongGolomb(long, long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongGolomb(long, long, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongGolomb(long, long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in Golomb coding.
- writeLongGolomb(long, long, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in Golomb coding.
- writeLongMinimalBinary(long, long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongMinimalBinary(long, long, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongMinimalBinary(long, long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in a limited range using a minimal binary coding.
- writeLongMinimalBinary(long, long, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in a limited range using a minimal binary coding.
- writeLongNibble(long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongNibble(long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in variable-length nibble coding.
- writeLongShiftedGamma(long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in shifted γ coding.
- writeLongSkewedGolomb(long, long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongSkewedGolomb(long, long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in skewed Golomb coding.
- writeLongUnary(long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongUnary(long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in unary coding.
- writeLongZeta(long, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeLongZeta(long, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a long natural number in ζ coding.
- writeMetadata(ObjectOutput) - Method in class com.bigdata.btree.proc.AbstractKeyArrayIndexProcedure
-
Writes metadata (not the keys or values, but just other metadata used by
the procedure).
- writeMetadata(ObjectOutput) - Method in class com.bigdata.btree.proc.BatchInsert
-
- writeMetadata(ObjectOutput) - Method in class com.bigdata.btree.proc.BatchPutIfAbsent
-
- writeMetadata(ObjectOutput) - Method in class com.bigdata.btree.proc.BatchRemove
-
- writeMetadata(XDROutputBuffer, IGangliaMetadataMessage) - Method in class com.bigdata.ganglia.GangliaMessageEncoder25
-
NOP.
- writeMetadata(XDROutputBuffer, IGangliaMetadataMessage) - Method in class com.bigdata.ganglia.GangliaMessageEncoder31
-
- writeMetadata(XDROutputBuffer, IGangliaMetadataMessage) - Method in interface com.bigdata.ganglia.IGangliaMessageEncoder
-
Ganglia metadata record.
- writeMetadata(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.BlobsWriteProc
-
Writes metadata (not the keys or values, but just other metadata used by
the procedure).
- writeMetadata(ObjectOutput) - Method in class com.bigdata.rdf.lexicon.Term2IdWriteProc
-
Writes metadata (not the keys or values, but just other metadata used by
the procedure).
- writeMetadata(ObjectOutput) - Method in class com.bigdata.rdf.spo.SPOIndexWriteProc
-
- writeMetadata(ObjectOutput) - Method in class com.bigdata.search.TextIndexWriteProc
-
- writeMetric(XDROutputBuffer, IGangliaMetadataMessage, IGangliaMetricMessage) - Method in class com.bigdata.ganglia.GangliaMessageEncoder25
-
- writeMetric(XDROutputBuffer, IGangliaMetadataMessage, IGangliaMetricMessage) - Method in class com.bigdata.ganglia.GangliaMessageEncoder31
-
- writeMetric(XDROutputBuffer, IGangliaMetadataMessage, IGangliaMetricMessage) - Method in interface com.bigdata.ganglia.IGangliaMessageEncoder
-
Generate a metric record.
- writeMinimalBinary(int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeMinimalBinary(int, int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeMinimalBinary(int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in a limited range using a minimal binary coding.
- writeMinimalBinary(int, int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in a limited range using a minimal binary coding.
- writeNanos - Variable in class com.bigdata.btree.BTreeCounters
-
- writeNibble(int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeNibble(int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in variable-length nibble coding.
- writeNode(IndexSegmentBuilder.SimpleNodeData) - Method in class com.bigdata.btree.IndexSegmentBuilder
-
- writeNodeOrLeaf(AbstractNode<?>) - Method in class com.bigdata.btree.AbstractBTree
-
Codes the node and writes the coded record on the store (non-recursive).
- writeNodeOrLeaf(IndexSegmentBuilder.AbstractSimpleNodeData) - Method in class com.bigdata.btree.IndexSegmentBuilder
-
Write the node or leaf onto the appropriate output channel.
- writeNodeOrLeaf(AbstractPage) - Method in class com.bigdata.htree.AbstractHTree
-
Codes the node and writes the coded record on the store (non-recursive).
- writeNodeOrLeaf(AbstractNode<?>) - Method in class com.bigdata.rdf.sail.TestMROWTransactions.MyBTree
-
- writeNodeRecursive(AbstractNode<?>) - Method in class com.bigdata.btree.AbstractBTree
-
Write a dirty node and its children using a post-order traversal that
first writes any dirty leaves and then (recursively) their parent nodes.
- writeNodeRecursive(AbstractPage) - Method in class com.bigdata.htree.AbstractHTree
-
Write a dirty node and its children using a post-order traversal that
first writes any dirty leaves and then (recursively) their parent nodes.
- writeNodeRecursiveCallersThread(AbstractNode<?>) - Method in class com.bigdata.btree.AbstractBTree
-
This is the historical implementation and runs entirely in the caller's
thread.
- writeNodeRecursiveCallersThread(AbstractPage) - Method in class com.bigdata.htree.AbstractHTree
-
- writeNodeRecursiveConcurrent(AbstractNode<?>) - Method in class com.bigdata.btree.AbstractBTree
-
Writes the dirty nodes and leaves in level sets (one level at a time)
with up to one thread per dirty node/leave in a given level.
- writeNodeRecursiveConcurrent(AbstractPage) - Method in class com.bigdata.htree.AbstractHTree
-
Writes the dirty nodes and leaves in level sets (one level at a time)
with up to one thread per dirty node/leave in a given level.
- writeObject(Object) - Method in class com.bigdata.io.ObjectSocketChannelStream
-
- writeOn(PrintWriter, Map<String, BaseIndexStats>) - Static method in class com.bigdata.btree.BaseIndexStats
-
Helper method may be used to write out a tab-delimited table of the
statistics.
- writeOn(OutputStream) - Method in class com.bigdata.io.AbstractFixedByteArrayBuffer
-
- writeOn(DataOutput) - Method in class com.bigdata.io.AbstractFixedByteArrayBuffer
-
- writeOn(OutputStream, int, int) - Method in class com.bigdata.io.AbstractFixedByteArrayBuffer
-
- writeOn(OutputStream) - Method in interface com.bigdata.io.IFixedDataRecord
-
Write the slice on the output stream.
- writeOn(DataOutput) - Method in interface com.bigdata.io.IFixedDataRecord
-
Write the slice on the output stream.
- writeOn(OutputStream, int, int) - Method in interface com.bigdata.io.IFixedDataRecord
-
Write part of the slice on the output stream.
- writeOn(OutputStream) - Method in interface it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList.BackingBuffer
-
Write the data on the output stream.
- writeOn(OutputStream, int, int) - Method in interface it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList.BackingBuffer
-
Write len bytes starting at off onto the caller's
stream.
- writeOn(OutputStream, int) - Method in class it.unimi.dsi.fastutil.bytes.custom.CustomByteArrayFrontCodedList
-
Write the specified byte[] onto a stream.
- writeOnBuffer(RDFFormat, Graph) - Static method in class com.bigdata.rdf.sail.webapp.AbstractTestNanoSparqlClient
-
Write a graph on a buffer suitable for sending as an HTTP request body.
- writeOnChannel(ByteBuffer, long, Map<Long, WriteCache.RecordMetadata>, long) - Method in class com.bigdata.io.writecache.WriteCache.FileChannelScatteredWriteCache
-
Called by WriteCacheService to process a direct write for large
blocks and also to flush data from dirty caches.
- writeOnChannel(ByteBuffer, long, Map<Long, WriteCache.RecordMetadata>, long) - Method in class com.bigdata.io.writecache.WriteCache.FileChannelWriteCache
-
- writeOnChannel(ByteBuffer, long, Map<Long, WriteCache.RecordMetadata>, long) - Method in class com.bigdata.io.writecache.WriteCache.ReadCache
-
- writeOnChannel(ByteBuffer, long, Map<Long, WriteCache.RecordMetadata>, long) - Method in class com.bigdata.io.writecache.WriteCache
-
Write the data from the buffer onto the channel.
- writeOnHALog(IHAWriteMessage, ByteBuffer) - Method in class com.bigdata.ha.halog.HALogWriter
-
Write the message and the data on the live HALog.
- writeOnHALog(IHAWriteMessage, ByteBuffer) - Method in interface com.bigdata.ha.halog.IHALogWriter
-
Write the message and the data on the live HALog.
- writeOnIndex(int, byte[][], byte[][]) - Method in class com.bigdata.search.TokenBuffer
-
Writes on the index.
- writeOnStream(OutputStream, AbstractJournal.ISnapshotData, Quorum<HAGlue, QuorumService<HAGlue>>, long) - Method in interface com.bigdata.journal.IHABufferStrategy
-
Write a consistent snapshot of the committed state of the backing store.
- writeOnStream(OutputStream, AbstractJournal.ISnapshotData, Quorum<HAGlue, QuorumService<HAGlue>>, long) - Method in class com.bigdata.journal.RWStrategy
-
- writeOnStream(OutputStream, AbstractJournal.ISnapshotData, Quorum<HAGlue, QuorumService<HAGlue>>, long) - Method in class com.bigdata.journal.WORMStrategy
-
- writeOnStream(OutputStream, AbstractJournal.ISnapshotData, Quorum<HAGlue, QuorumService<HAGlue>>, long) - Method in class com.bigdata.rwstore.RWStore
-
- writeOnStream2(OutputStream, Set<Map.Entry<Long, byte[]>>, Quorum<HAGlue, QuorumService<HAGlue>>, long) - Method in class com.bigdata.rwstore.RWStore
-
- writePath(Writer, String, int) - Method in class com.bigdata.counters.render.TextValueFormatter
-
- writePath(Writer, String, int) - Method in class com.bigdata.counters.render.ValueFormatter
-
Write a partial counter path.
- writePath(Writer, String, int) - Method in class com.bigdata.counters.render.XHTMLRenderer.HTMLValueFormatter
-
A clickable trail of the path.
- writePath(Writer, String, int) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Deprecated.
by refactor inside of a rendering object.
- writePivotTable(Writer, ICounter[], PeriodEnum, TimestampFormatEnum) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Writes out a pivot table view.
- writePivotTable(Writer, ICounter[]) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Writes data in a format suitable for use in a pivot table.
- writer(String, int, String) - Method in class com.bigdata.bfs.BigdataFileSystem
-
Return a
Writer
that will
append character data on the
file version.
- writeRandomData(Journal, long, boolean) - Method in class com.bigdata.journal.AbstractBufferStrategyTestCase
-
Write random bytes on the store.
- writeRandomData(TemporaryRawStore, long) - Method in class com.bigdata.journal.TestTemporaryStore
-
Write random bytes on the store.
- writeRaw(long, ByteBuffer) - Method in class com.bigdata.rwstore.RWStore
-
Used as part of the rebuild protocol
- writeRawBuffer(IHAWriteMessage, IBufferAccess) - Method in interface com.bigdata.journal.IHABufferStrategy
-
Write a buffer containing data replicated from the master onto the local
persistence store.
- writeRawBuffer(HARebuildRequest, IHAWriteMessage, ByteBuffer) - Method in interface com.bigdata.journal.IHABufferStrategy
-
Used to support the rebuild protocol
- writeRawBuffer(IHAWriteMessage, IBufferAccess) - Method in class com.bigdata.journal.RWStrategy
-
- writeRawBuffer(HARebuildRequest, IHAWriteMessage, ByteBuffer) - Method in class com.bigdata.journal.RWStrategy
-
- writeRawBuffer(IHAWriteMessage, IBufferAccess) - Method in class com.bigdata.journal.WORMStrategy
-
- writeRawBuffer(HARebuildRequest, IHAWriteMessage, ByteBuffer) - Method in class com.bigdata.journal.WORMStrategy
-
- writeRawBuffer(IHAWriteMessage, IBufferAccess) - Method in class com.bigdata.rwstore.RWStore
-
- writeRequest(XDROutputBuffer, IGangliaRequestMessage) - Method in class com.bigdata.ganglia.GangliaMessageEncoder25
-
TODO I am not sure whether or not there was a request message in this
protocol version.
- writeRequest(XDROutputBuffer, IGangliaRequestMessage) - Method in class com.bigdata.ganglia.GangliaMessageEncoder31
-
- writeRequest(XDROutputBuffer, IGangliaRequestMessage) - Method in interface com.bigdata.ganglia.IGangliaMessageEncoder
-
Generate a request record.
- writeResource(Writer, String) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
Write a text file into the html.
- WriteRetentionQueue - Static variable in interface com.bigdata.btree.AbstractBTree.IBTreeCounters
-
- writeRetentionQueue - Variable in class com.bigdata.btree.AbstractBTree
-
Nodes (that is nodes or leaves) are added to a hard reference queue when
they are created or read from the store.
- writeRetentionQueue - Variable in class com.bigdata.htree.AbstractHTree
-
Nodes (that is nodes or leaves) are added to a hard reference queue when
they are created or read from the store.
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.journal.DiskBackedBufferStrategy
-
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.journal.DiskOnlyStrategy
-
Deprecated.
- writeRootBlock(IRootBlockView, ForceEnum) - Method in interface com.bigdata.journal.IBufferStrategy
-
Write the root block onto stable storage (ie, flush it through to disk).
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.journal.RWStrategy
-
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.journal.TransientBufferStrategy
-
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.journal.WORMStrategy
-
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.rwstore.RWStore
-
This can be called as part of the HA downstream replication.
- writeRootBlock(IRootBlockView, ForceEnum) - Method in class com.bigdata.rwstore.sector.MemStrategy
-
- writeRunningQueryList(Writer, List<RunningQuery>) - Static method in class com.bigdata.rdf.sail.model.JsonHelper
-
- writeScripts(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
- writeSelfDelimUTF8(DataOutput) - Method in class it.unimi.dsi.lang.MutableString
-
Writes this mutable string to a
DataOutput
as a
length followed by a UTF-8 encoding.
- writeSelfDelimUTF8(OutputStream) - Method in class it.unimi.dsi.lang.MutableString
-
Writes this mutable string to an
OutputStream
as a
length followed by a UTF-8 encoding.
- writeService - Static variable in interface com.bigdata.journal.ConcurrencyManager.IConcurrencyManagerCounters
-
- writeShiftedGamma(int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in shifted γ coding.
- writeShort(short) - Method in class com.bigdata.ganglia.xdr.XDROutputBuffer
-
Puts a short integer into the buffer as 2 bytes, big-endian but w/
leading zeros (e.g., as if an int32 value).
- writeShort(int) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeSid(BigdataBNode) - Method in class com.bigdata.rdf.rio.json.BigdataSPARQLResultsJSONWriter
-
- writeSid(BigdataBNode) - Method in class com.bigdata.rdf.rio.turtle.BigdataTurtleWriter
-
- writeSkewedGolomb(int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeSkewedGolomb(int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in skewed Golomb coding.
- writeString(String) - Method in class com.bigdata.ganglia.xdr.XDROutputBuffer
-
Puts a string into the buffer by first writing the size of the string as
an int, followed by the bytes of the string, padded if necessary to a
multiple of 4.
- writeSymbolTable(CanonicalHuffmanRabaCoder.Symbol2Byte, OutputBitStream) - Method in class com.bigdata.btree.raba.codec.CanonicalHuffmanRabaCoder
-
Write out the optional packed symbol table (symbol2byte).
- WriteTaskCounters - Class in com.bigdata.util.concurrent
-
- WriteTaskCounters() - Constructor for class com.bigdata.util.concurrent.WriteTaskCounters
-
- WriteTaskStats - Class in com.bigdata.rdf.lexicon
-
Class for reporting various timings for writes on the lexicon indices.
- WriteTaskStats() - Constructor for class com.bigdata.rdf.lexicon.WriteTaskStats
-
- writeTitle(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
- writeUnary(int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeUnary(int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in unary coding.
- writeUTF(String) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeUTF2(String) - Method in class com.bigdata.io.DataOutputBuffer
-
- writeUTF8(DataOutput) - Method in class it.unimi.dsi.lang.MutableString
-
Writes this mutable string in UTF-8 encoding.
- writeUTF8(OutputStream) - Method in class it.unimi.dsi.lang.MutableString
-
Writes this mutable string in UTF-8 encoding.
- writeValid(Writer) - Method in enum com.bigdata.counters.render.DoctypeEnum
-
Writes the W3C "valid" icon into the page for the
DoctypeEnum
.
- writeValue(Value) - Method in class com.bigdata.rdf.rio.json.BigdataSPARQLResultsJSONWriter
-
- writeXML(CounterSet, Writer, Pattern) - Method in class com.bigdata.counters.XMLUtility
-
- writeXmlDecl(Writer) - Method in class com.bigdata.counters.render.XHTMLRenderer
-
- writeZeta(int, int) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writeZeta(int, int) - Method in class it.unimi.dsi.io.OutputBitStream
-
Writes a natural number in ζ coding.
- writtenBits() - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writtenBits(long) - Method in class it.unimi.dsi.io.DebugOutputBitStream
-
- writtenBits() - Method in class it.unimi.dsi.io.OutputBitStream
-
Returns the number of bits written to this bit stream.
- writtenBits(long) - Method in class it.unimi.dsi.io.OutputBitStream
-
Sets the number of bits written to this bit stream.
- WS_CHAR - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
X
- x - Variable in class cern.jet.random.Hyperbolic
-
- x - Variable in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
Variables
- xdr - Variable in class com.bigdata.ganglia.GangliaSender
-
- XDRInputBuffer - Class in com.bigdata.ganglia.xdr
-
A class for reading XDR data from an internal buffer.
- XDRInputBuffer(byte[], int, int) - Constructor for class com.bigdata.ganglia.xdr.XDRInputBuffer
-
- XDROutputBuffer - Class in com.bigdata.ganglia.xdr
-
A class for writing XDR data onto an internal buffer.
- XDROutputBuffer(int) - Constructor for class com.bigdata.ganglia.xdr.XDROutputBuffer
-
- xElements - Variable in class cern.colt.buffer.DoubleBuffer2D
-
- xElements - Variable in class cern.colt.buffer.DoubleBuffer3D
-
- xElements - Variable in class cern.colt.buffer.IntBuffer2D
-
- xElements - Variable in class cern.colt.buffer.IntBuffer3D
-
- XHTML - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext
-
URL Query parameter used to request an XHTML response for SPARQL
QUERY or SPARQL UPDATE.
- XHTMLRenderer - Class in com.bigdata.counters.render
-
- XHTMLRenderer(URLQueryModel, ICounterSelector) - Constructor for class com.bigdata.counters.render.XHTMLRenderer
-
- XHTMLRenderer.HTMLPivotTableRenderer - Class in com.bigdata.counters.render
-
- XHTMLRenderer.HTMLPivotTableRenderer(PivotTable, ValueFormatter) - Constructor for class com.bigdata.counters.render.XHTMLRenderer.HTMLPivotTableRenderer
-
- XHTMLRenderer.HTMLValueFormatter - Class in com.bigdata.counters.render
-
- XHTMLRenderer.HTMLValueFormatter(URLQueryModel) - Constructor for class com.bigdata.counters.render.XHTMLRenderer.HTMLValueFormatter
-
- xList - Variable in class cern.colt.buffer.DoubleBuffer2D
-
- xList - Variable in class cern.colt.buffer.DoubleBuffer3D
-
- xList - Variable in class cern.colt.buffer.IntBuffer2D
-
- xList - Variable in class cern.colt.buffer.IntBuffer3D
-
- xminimum() - Method in class cern.colt.list.MinMaxNumberList
-
Deprecated.
- XML - Static variable in class com.bigdata.counters.format.CounterSetFormat
-
XML properties file using application/xml
and
UTF-8
.
- XML - Static variable in class com.bigdata.rdf.properties.PropertiesFormat
-
XML properties file using application/xml
and
UTF-8
.
- XMLBuilder - Class in com.bigdata.rdf.sail.webapp
-
Utility Java class for outputting XML.
- XMLBuilder(Writer) - Constructor for class com.bigdata.rdf.sail.webapp.XMLBuilder
-
- XMLBuilder(boolean, String, Writer) - Constructor for class com.bigdata.rdf.sail.webapp.XMLBuilder
-
- XMLBuilder.Node - Class in com.bigdata.rdf.sail.webapp
-
- XMLLANG - Static variable in class com.bigdata.rdf.rio.json.SPARQLJSONParserBase
-
- XMLRenderer - Class in com.bigdata.counters.render
-
Renders the selected counters using the counter set XML representation - the
client can apply XSLT as desired to style the XML.
- XMLRenderer(URLQueryModel, ICounterSelector, String) - Constructor for class com.bigdata.counters.render.XMLRenderer
-
- XMLSchemaVocabularyDecl - Class in com.bigdata.rdf.vocab.decls
-
Vocabulary and namespace for XMLSchema
.
- XMLSchemaVocabularyDecl() - Constructor for class com.bigdata.rdf.vocab.decls.XMLSchemaVocabularyDecl
-
- XMLUtility - Class in com.bigdata.counters
-
- xor(BitMatrix) - Method in class cern.colt.bitvector.BitMatrix
-
Performs a logical XOR of the receiver with another bit matrix.
- xor(BitVector) - Method in class cern.colt.bitvector.BitVector
-
Performs a logical XOR of the receiver with another bit vector (A = A ^ B).
- xor - Static variable in class cern.jet.math.IntFunctions
-
Function that returns a ^ b.
- xor(int) - Static method in class cern.jet.math.IntFunctions
-
Constructs a function that returns a | b.
- xor(BitVector) - Method in class it.unimi.dsi.bits.AbstractBitVector
-
- xor(BitVector) - Method in interface it.unimi.dsi.bits.BitVector
-
Performs a logical xor between this bit vector and another one, leaving the result in this vector.
- xor(BitVector) - Method in class it.unimi.dsi.bits.LongArrayBitVector
-
- XPATH_FUNCTIONS - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XPathMathFunctions - Class in com.bigdata.rdf.internal
-
Support for the picky xpath math functions: abs, ceiling, floor, and round.
- XPathMathFunctions() - Constructor for class com.bigdata.rdf.internal.XPathMathFunctions
-
- XProperty - Class in cutthecrap.utils.striterators
-
A property key/value pair
- XProperty(String, Object) - Constructor for class cutthecrap.utils.striterators.XProperty
-
- XPropertyIterator - Class in cutthecrap.utils.striterators
-
XPropertyIterator
- XPropertyIterator(Iterator) - Constructor for class cutthecrap.utils.striterators.XPropertyIterator
-
- xsAnyURI - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "anyURI".
- xsBoolean - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "boolean".
- xsByte - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "byte".
- XSD - Class in com.bigdata.rdf.internal
-
Collects various XSD URIs as constants.
- XSD() - Constructor for class com.bigdata.rdf.internal.XSD
-
- xsd - Static variable in class com.bigdata.rdf.model.BigdataValueFactoryImpl
-
- XSD_BOOL - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_DATE - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_DBL - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_DEC - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_DT - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_FLT - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_INT - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_LONG - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_STR - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSD_UNSIGNED_LONG - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- XSDBooleanIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:boolean
.
- XSDBooleanIV(boolean) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDBooleanIV
-
- XSDBooleanIVValueExpression - Class in com.bigdata.rdf.internal.constraints
-
Base class for RDF value expression BOps that happen to evaluate to an
XSDBooleanIV
.
- XSDBooleanIVValueExpression(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.XSDBooleanIVValueExpression
-
Required shallow copy constructor.
- XSDBooleanIVValueExpression(XSDBooleanIVValueExpression) - Constructor for class com.bigdata.rdf.internal.constraints.XSDBooleanIVValueExpression
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- XSDDecimalIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:decimal
.
- XSDDecimalIV(BigDecimal) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDDecimalIV
-
- xsDecimal - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "decimal" - used for
BigDecimal
- XSDIntegerIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:integer
.
- XSDIntegerIV(BigInteger) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDIntegerIV
-
- XsdLongBOp - Class in com.bigdata.rdf.internal.constraints
-
Convert the
IV
to a
xsd:long
.
- XsdLongBOp(IValueExpression<? extends IV>, GlobalAnnotations) - Constructor for class com.bigdata.rdf.internal.constraints.XsdLongBOp
-
- XsdLongBOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.XsdLongBOp
-
Required shallow copy constructor.
- XsdLongBOp(XsdLongBOp) - Constructor for class com.bigdata.rdf.internal.constraints.XsdLongBOp
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- XSDNumericIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:byte
, xsd:short
,
xsd:int
, xsd:long
, xsd:float
,
xsd:decimal
.
- XSDNumericIV(byte) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- XSDNumericIV(short) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- XSDNumericIV(int) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- XSDNumericIV(long) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- XSDNumericIV(float) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- XSDNumericIV(double) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- xsDouble - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "double".
- XsdStrBOp - Class in com.bigdata.rdf.internal.constraints
-
Convert the
IV
to a
xsd:string
.
- XsdStrBOp(IValueExpression<? extends IV>, GlobalAnnotations) - Constructor for class com.bigdata.rdf.internal.constraints.XsdStrBOp
-
- XsdStrBOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.XsdStrBOp
-
Required shallow copy constructor.
- XsdStrBOp(XsdStrBOp) - Constructor for class com.bigdata.rdf.internal.constraints.XsdStrBOp
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- XSDStringExtension<V extends BigdataValue> - Class in com.bigdata.rdf.internal.impl.extensions
-
This implementation of
IExtension
supports fully inlined
xsd:string
values.
- XSDStringExtension(IDatatypeURIResolver, int) - Constructor for class com.bigdata.rdf.internal.impl.extensions.XSDStringExtension
-
- XSDUnsignedByteIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:unsignedByte
.
- XSDUnsignedByteIV(byte) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDUnsignedByteIV
-
- XSDUnsignedIntIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:unsignedInt
.
- XSDUnsignedIntIV(int) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDUnsignedIntIV
-
- XsdUnsignedLongBOp - Class in com.bigdata.rdf.internal.constraints
-
Convert the
IV
to a
xsd:unsignedLong
.
- XsdUnsignedLongBOp(IValueExpression<? extends IV>, GlobalAnnotations) - Constructor for class com.bigdata.rdf.internal.constraints.XsdUnsignedLongBOp
-
- XsdUnsignedLongBOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.internal.constraints.XsdUnsignedLongBOp
-
Required shallow copy constructor.
- XsdUnsignedLongBOp(XsdUnsignedLongBOp) - Constructor for class com.bigdata.rdf.internal.constraints.XsdUnsignedLongBOp
-
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- XSDUnsignedLongIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:unsignedLong
.
- XSDUnsignedLongIV(long) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDUnsignedLongIV
-
- XSDUnsignedShortIV<V extends BigdataLiteral> - Class in com.bigdata.rdf.internal.impl.literal
-
Implementation for inline xsd:unsignedShort
.
- XSDUnsignedShortIV(short) - Constructor for class com.bigdata.rdf.internal.impl.literal.XSDUnsignedShortIV
-
- xsFloat - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "float".
- xsInt - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "int".
- xsInteger - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "integer" - used for
BigInteger
and natively by the XSD library for
com.sun.msv.datatype.xsd.IntegerValueType
.
- XSL_STYLESHEET - Static variable in class com.bigdata.rdf.sail.webapp.BigdataRDFContext
-
URL Query parameter used to specify an XSL style sheet to be associated
with the response in combination with the
BigdataRDFContext.XHTML
URL query
parameter.
- xsLong - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "lomg".
- xsShort - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "short".
- xsString - Static variable in class com.bigdata.rdf.store.TestInsertRate.XMLSchema
-
The XSDatatype URI for "string".
- xtestMassageServiceCall() - Method in class com.bigdata.rdf.sail.webapp.TestService794
-
This one is currently broken, see trac794
Note also there is something unintersting with syntax
going wrong with some expressions like
SERVICE <> {
{ SELECT * {
?x eg:q ?y
}
}
}
- xtestMassageServiceNested1Call() - Method in class com.bigdata.rdf.sail.webapp.TestService794
-
- xtestServiceSyntaxError() - Method in class com.bigdata.rdf.sail.webapp.TestService794
-
- XXXCShardSplitHandler - Class in com.bigdata.rdf.spo
-
A split handler for the xxxC quads indices which ensures that all quads for
the same "triple" are in the same shard.
- XXXCShardSplitHandler() - Constructor for class com.bigdata.rdf.spo.XXXCShardSplitHandler
-
- XXXXtestFails() - Method in class com.bigdata.jsr166.BlockingQueueTest
-
For debugging.
Y
- y - Variable in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
Variables
- y0(double) - Static method in class cern.jet.math.Bessel
-
Returns the Bessel function of the second kind of order 0 of the argument.
- y1(double) - Static method in class cern.jet.math.Bessel
-
Returns the Bessel function of the second kind of order 1 of the argument.
- yahooChatID - Static variable in class com.bigdata.rdf.vocab.decls.FOAFVocabularyDecl
-
- Year() - Method in class com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilder
-
- YEAR - Static variable in interface com.bigdata.rdf.sail.sparql.ast.SyntaxTreeBuilderConstants
-
RegularExpression Id.
- YEAR - Static variable in class com.bigdata.rdf.sparql.ast.FunctionRegistry
-
- yElements - Variable in class cern.colt.buffer.DoubleBuffer2D
-
- yElements - Variable in class cern.colt.buffer.DoubleBuffer3D
-
- yElements - Variable in class cern.colt.buffer.IntBuffer2D
-
- yElements - Variable in class cern.colt.buffer.IntBuffer3D
-
- yList - Variable in class cern.colt.buffer.DoubleBuffer2D
-
- yList - Variable in class cern.colt.buffer.DoubleBuffer3D
-
- yList - Variable in class cern.colt.buffer.IntBuffer2D
-
- yList - Variable in class cern.colt.buffer.IntBuffer3D
-
- yn(int, double) - Static method in class cern.jet.math.Bessel
-
Returns the Bessel function of the second kind of order n of the argument.
Z
- z - Variable in class com.bigdata.rdf.sparql.ast.optimizers.AbstractOptimizerTestCase.Helper
-
Variables
- zAssign27Neighbors(DoubleMatrix3D, Double27Function) - Method in class cern.colt.matrix.DoubleMatrix3D
-
27 neighbor stencil transformation.
- zAssign27Neighbors(DoubleMatrix3D, Double27Function) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix3D
-
27 neighbor stencil transformation.
- zAssign8Neighbors(DoubleMatrix2D, Double9Function) - Method in class cern.colt.matrix.DoubleMatrix2D
-
8 neighbor stencil transformation.
- zAssign8Neighbors(DoubleMatrix2D, Double9Function) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix2D
-
8 neighbor stencil transformation.
- zdemo1() - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates advanced sorting.
- zdemo2() - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates advanced sorting.
- zdemo3() - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates advanced sorting.
- zdemo4() - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates applying functions.
- zdemo5(int, int, boolean) - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates sorting with precomputation of aggregates (median and sum of logarithms).
- zdemo6() - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates advanced sorting.
- zdemo7(int, int, boolean) - Static method in class cern.colt.matrix.doublealgo.Sorting
-
Demonstrates sorting with precomputation of aggregates, comparing mergesort with quicksort.
- zDotProduct(DoubleMatrix1D) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Returns the dot product of two vectors x and y, which is Sum(x[i]*y[i]).
- zDotProduct(DoubleMatrix1D, int, int) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Returns the dot product of two vectors x and y, which is Sum(x[i]*y[i]).
- zDotProduct(DoubleMatrix1D, int, int, IntArrayList) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Returns the dot product of two vectors x and y, which is Sum(x[i]*y[i]).
- zDotProduct(DoubleMatrix1D, IntArrayList) - Method in class cern.colt.matrix.DoubleMatrix1D
-
Returns the dot product of two vectors x and y, which is Sum(x[i]*y[i]).
- zDotProduct(DoubleMatrix1D, int, int) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix1D
-
Returns the dot product of two vectors x and y, which is Sum(x[i]*y[i]).
- zElements - Variable in class cern.colt.buffer.DoubleBuffer3D
-
- zElements - Variable in class cern.colt.buffer.IntBuffer3D
-
- zero - Variable in class cern.colt.matrix.impl.AbstractMatrix1D
-
the index of the first element
- ZERO - Static variable in class cern.colt.matrix.linalg.Algebra
-
A default Algebra object; has
Property.ZERO
attached for tolerance.
- ZERO - Static variable in class cern.colt.matrix.linalg.Property
-
A Property object with tolerance()==0.0.
- ZERO - Static variable in class com.bigdata.bop.aggregate.AggregateBase
-
A ZERO.
- zero - Static variable in class com.bigdata.jsr166.JSR166TestCase
-
- ZERO - Static variable in class it.unimi.dsi.bits.BitVectors
-
An immutable bit vector of length one containing a zero.
- ZeroLengthPathNode - Class in com.bigdata.rdf.sparql.ast
-
Deprecated.
Does not work - leads to cardinality problems and can be removed.
Zero Length Paths are integrated into the ALP node /
ArbitraryLengthPathOp now.
- ZeroLengthPathNode(ZeroLengthPathNode) - Constructor for class com.bigdata.rdf.sparql.ast.ZeroLengthPathNode
-
Deprecated.
Constructor required for com.bigdata.bop.BOpUtility#deepCopy(FilterNode)
.
- ZeroLengthPathNode(BOp[], Map<String, Object>) - Constructor for class com.bigdata.rdf.sparql.ast.ZeroLengthPathNode
-
Deprecated.
Required shallow copy constructor.
- ZeroLengthPathNode() - Constructor for class com.bigdata.rdf.sparql.ast.ZeroLengthPathNode
-
Deprecated.
- ZeroLengthPathNode(TermNode, TermNode) - Constructor for class com.bigdata.rdf.sparql.ast.ZeroLengthPathNode
-
Deprecated.
- ZeroLengthPathOp - Class in com.bigdata.bop.paths
-
Deprecated.
Does not work. Leads to cardinality problems and can be removed.
Zero Length Paths are integrated into the ALP node /
ArbitraryLengthPathOp now.
- ZeroLengthPathOp(ZeroLengthPathOp) - Constructor for class com.bigdata.bop.paths.ZeroLengthPathOp
-
Deprecated.
Deep copy constructor.
- ZeroLengthPathOp(BOp[], Map<String, Object>) - Constructor for class com.bigdata.bop.paths.ZeroLengthPathOp
-
Deprecated.
Shallow copy constructor.
- ZeroLengthPathOp(BOp[], NV...) - Constructor for class com.bigdata.bop.paths.ZeroLengthPathOp
-
Deprecated.
- ZeroLengthPathOp.Annotations - Interface in com.bigdata.bop.paths
-
Deprecated.
- Zeta - Class in cern.jet.random
-
Zeta distribution.
- Zeta(double, double, RandomEngine) - Constructor for class cern.jet.random.Zeta
-
Constructs a Zeta distribution.
- ZETA_3 - Static variable in class it.unimi.dsi.io.InputBitStream
-
- ZETA_3 - Static variable in class it.unimi.dsi.io.OutputBitStream
-
- zIndexOrderingMixedBase(BigdataValueFactory, GeoSpatialLiteralExtension<BigdataValue>, URI) - Method in class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
-
- zIndexOrderingPositiveBase(BigdataValueFactory, GeoSpatialLiteralExtension<BigdataValue>, URI) - Method in class com.bigdata.rdf.internal.TestEncodeDecodeGeoSpatialLiteralIVs
-
- zList - Variable in class cern.colt.buffer.DoubleBuffer3D
-
- zList - Variable in class cern.colt.buffer.IntBuffer3D
-
- zMult(DoubleMatrix1D, DoubleMatrix1D) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Linear algebraic matrix-vector multiplication; z = A * y;
Equivalent to return A.zMult(y,z,1,0);
- zMult(DoubleMatrix1D, DoubleMatrix1D, double, double, boolean) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Linear algebraic matrix-vector multiplication; z = alpha * A * y + beta*z.
- zMult(DoubleMatrix2D, DoubleMatrix2D) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Linear algebraic matrix-matrix multiplication; C = A x B;
Equivalent to A.zMult(B,C,1,0,false,false).
- zMult(DoubleMatrix2D, DoubleMatrix2D, double, double, boolean, boolean) - Method in class cern.colt.matrix.DoubleMatrix2D
-
Linear algebraic matrix-matrix multiplication; C = alpha * A x B + beta*C.
- zMult(DoubleMatrix1D, DoubleMatrix1D, double, double, boolean) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix2D
-
- zMult(DoubleMatrix2D, DoubleMatrix2D, double, double, boolean, boolean) - Method in class cern.colt.matrix.impl.DenseDoubleMatrix2D
-
- zMult(DoubleMatrix1D, DoubleMatrix1D, double, double, boolean) - Method in class cern.colt.matrix.impl.RCDoubleMatrix2D
-
- zMult(DoubleMatrix2D, DoubleMatrix2D, double, double, boolean, boolean) - Method in class cern.colt.matrix.impl.RCDoubleMatrix2D
-
- zMult(DoubleMatrix1D, DoubleMatrix1D, double, double, boolean) - Method in class cern.colt.matrix.impl.SparseDoubleMatrix2D
-
- zMult(DoubleMatrix2D, DoubleMatrix2D, double, double, boolean, boolean) - Method in class cern.colt.matrix.impl.SparseDoubleMatrix2D
-
- ZOrderIndexBigMinAdvancer - Class in com.bigdata.service.geospatial
-
Advances the cursor to the next zOrderKey that is greater or equal than the
first point in the next region.
- ZOrderIndexBigMinAdvancer(byte[], byte[], GeoSpatialLiteralExtension<BigdataValue>, int, GeoSpatialCounters) - Constructor for class com.bigdata.service.geospatial.ZOrderIndexBigMinAdvancer
-
- zOrderIndexHits - Variable in class com.bigdata.service.geospatial.GeoSpatialCounters
-
The #of values that matched the search range
and were returned by the zOrderIndex advancer.
- zOrderIndexMisses - Variable in class com.bigdata.service.geospatial.GeoSpatialCounters
-
The #of misses when scanning the search range.
- zOrderIndexScannedValues - Variable in class com.bigdata.service.geospatial.GeoSpatialCounters
-
The #of values scanned
- ZOrderRangeScanUtil - Class in com.bigdata.service.geospatial
-
Class providing utility functions for efficient zOrder-based multi-dimensional
range scans, such as efficient range checks and functionality for BigMin calculation.
- ZOrderRangeScanUtil(byte[], byte[], int) - Constructor for class com.bigdata.service.geospatial.ZOrderRangeScanUtil
-
- zSum() - Method in class cern.colt.matrix.DoubleMatrix1D
-
Returns the sum of all cells; Sum( x[i] ).
- zSum() - Method in class cern.colt.matrix.DoubleMatrix2D
-
Returns the sum of all cells; Sum( x[i,j] ).
- zSum() - Method in class cern.colt.matrix.DoubleMatrix3D
-
Returns the sum of all cells; Sum( x[i,j,k] ).
- zSum() - Method in class cern.colt.matrix.impl.DenseDoubleMatrix1D
-
Returns the sum of all cells; Sum( x[i] ).
- zSum() - Method in class cern.colt.matrix.impl.DenseDoubleMatrix2D
-
Returns the sum of all cells; Sum( x[i,j] ).
_
- _120 - Variable in class com.bigdata.rdf.sparql.ast.BSBMQ5Setup
-
- _170 - Variable in class com.bigdata.rdf.sparql.ast.BSBMQ5Setup
-
- __replaceArg(int, BOp) - Method in class com.bigdata.bop.BOpBase
-
Effectively overwrites the specified argument with the provided value.
- __tearDownUnitTest() - Method in class com.bigdata.rdf.sail.BigdataSail
-
DO NOT INVOKE FROM APPLICATION CODE - this method
deletes the KB instance and destroys the backing database instance.
- __tearDownUnitTest() - Method in class com.bigdata.rdf.store.AbstractTripleStore
-
DO NOT INVOKE FROM APPLICATION CODE - this method
deletes the KB instance and destroys the backing database instance.
- _accept(int, Compare.CompareOp) - Static method in class com.bigdata.rdf.internal.constraints.CompareBOp
-
- _asBound(IBindingSet) - Method in class com.bigdata.bop.ap.Predicate
-
Override any unbound variables for which we were giving bindings.
- _binarySearch(int, byte[]) - Method in class com.bigdata.btree.raba.AbstractKeyBuffer
-
Binary search.
- _binarySearch(int, byte[]) - Method in class com.bigdata.btree.raba.MutableKeyBuffer
-
- _clear() - Method in class com.bigdata.rdf.rio.StatementBuffer
-
- _clearProperty(String) - Method in class com.bigdata.bop.BOpBase
-
Clear an annotation.
- _clearProperty(String) - Method in class com.bigdata.bop.ImmutableBOp
-
- _close() - Method in class com.bigdata.journal.AbstractJournal
-
Core implementation of immediate shutdown handles event reporting.
- _close() - Method in class com.bigdata.journal.Journal
-
Core implementation of immediate shutdown handles event reporting.
- _columnOffset(int) - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Returns the position of the given absolute rank within the (virtual or non-virtual) internal 1-dimensional array.
- _columnOffset(int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Returns the position of the given absolute rank within the (virtual or non-virtual) internal 1-dimensional array.
- _columnRank(int) - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Returns the absolute rank of the given relative rank.
- _columnRank(int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Returns the absolute rank of the given relative rank.
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.AbstractIV
-
Compare two
IV
s having the same intrinsic datatype.
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.AbstractNonInlineExtensionIVWithDelegateIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.BlobIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.bnode.FullyInlineUnicodeBNodeIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.bnode.NumericBNodeIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.bnode.SidIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.bnode.UUIDBNodeIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.FullyInlineTypedLiteralIV
-
Compare two
IV
s having the same intrinsic datatype.
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.IPv4AddrIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.LiteralArrayIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.LiteralExtensionIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.MockedValueIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.PackedLongIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.UUIDLiteralIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDBooleanIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDDecimalIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDIntegerIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDNumericIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDUnsignedByteIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDUnsignedIntIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDUnsignedLongIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.literal.XSDUnsignedShortIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.TermId
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.uri.FullyInlineURIIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.uri.URIExtensionIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.uri.VocabURIByteIV
-
- _compareTo(IV) - Method in class com.bigdata.rdf.internal.impl.uri.VocabURIShortIV
-
- _CSPO - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _get(int) - Method in class com.bigdata.cache.RingBuffer
-
Return the reference at the specified index in the backing array.
- _getName2Addr() - Method in class com.bigdata.journal.AbstractJournal
-
Return the "live" BTree mapping index names to the last metadata record
committed for the named index.
- _init(IDatatypeURIResolver, ILexiconConfiguration<BigdataValue>, Collection<IExtension<? extends BigdataValue>>) - Method in class com.bigdata.rdf.internal.BSBMExtensionFactory
-
- _init(IDatatypeURIResolver, ILexiconConfiguration<BigdataValue>, Collection<IExtension<? extends BigdataValue>>) - Method in class com.bigdata.rdf.internal.CompressedTimestampExtensionFactory
-
- _init(IDatatypeURIResolver, ILexiconConfiguration<BigdataValue>, Collection<IExtension<? extends BigdataValue>>) - Method in class com.bigdata.rdf.internal.DefaultExtensionFactory
-
Give subclasses a chance to add extensions.
- _linearSearch(int, byte[]) - Method in class com.bigdata.btree.raba.AbstractKeyBuffer
-
Linear search.
- _linearSearch(int, byte[]) - Method in class com.bigdata.btree.raba.MutableKeyBuffer
-
- _NULL_ - Static variable in class com.bigdata.rawstore.WormAddressManager
-
- _OCSP - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _offset(int) - Method in class cern.colt.matrix.impl.AbstractMatrix1D
-
Returns the position of the given absolute rank within the (virtual or non-virtual) internal 1-dimensional array.
- _OSP - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _PCSO - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _POCS - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _POS - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _prefixMatchLength(int, byte[]) - Method in class com.bigdata.btree.raba.AbstractKeyBuffer
-
Test the search key against the leading prefix shared by all bytes in the
key buffer.
- _prefixMatchLength(int, byte[]) - Method in class com.bigdata.btree.raba.MutableKeyBuffer
-
- _randomType - Variable in class junit.framework.TestCase2
-
- _rank(int) - Method in class cern.colt.matrix.impl.AbstractMatrix1D
-
Returns the absolute rank of the given relative rank.
- _readFromCache(long, int) - Method in class com.bigdata.io.writecache.WriteCacheService
-
Attempt to read record from cache (either write cache or read cache
depending on the service map state).
- _reopen() - Method in class com.bigdata.btree.AbstractBTree
-
This method is responsible for setting up the root leaf (either new or
read from the store), the bloom filter, etc.
- _reopen() - Method in class com.bigdata.btree.BTree
-
- _reopen() - Method in class com.bigdata.btree.IndexSegment
-
- _reopen() - Method in class com.bigdata.htree.AbstractHTree
-
This method is responsible for setting up the root leaf (either new or
read from the store), the bloom filter, etc.
- _reopen() - Method in class com.bigdata.htree.HTree
-
- _rowOffset(int) - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Returns the position of the given absolute rank within the (virtual or non-virtual) internal 1-dimensional array.
- _rowOffset(int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Returns the position of the given absolute rank within the (virtual or non-virtual) internal 1-dimensional array.
- _rowRank(int) - Method in class cern.colt.matrix.impl.AbstractMatrix2D
-
Returns the absolute rank of the given relative rank.
- _rowRank(int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Returns the absolute rank of the given relative rank.
- _search(ITextIndexer.FullTextQuery) - Method in class com.bigdata.search.FullTextIndex
-
- _set(int, BOp) - Method in class com.bigdata.bop.BOpBase
-
Set the value of an operand.
- _setAnnotation(IEvaluationContext, QueryHintScope, ASTBase, String, T) - Method in class com.bigdata.rdf.sparql.ast.hints.AbstractQueryHint
-
Set an annotation on the AST node.
- _setProperty(String, Object) - Method in class com.bigdata.bop.BOpBase
-
Set an annotation.
- _setProperty(String, Object) - Method in class com.bigdata.bop.ImmutableBOp
-
- _setQueryHint(IEvaluationContext, QueryHintScope, ASTBase, String, T) - Method in class com.bigdata.rdf.sparql.ast.hints.AbstractQueryHint
-
Set the query hint.
- _sliceOffset(int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Returns the position of the given absolute rank within the (virtual or non-virtual) internal 1-dimensional array.
- _sliceRank(int) - Method in class cern.colt.matrix.impl.AbstractMatrix3D
-
Returns the absolute rank of the given relative rank.
- _SOPC - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _SPO - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _SPOC - Static variable in class com.bigdata.rdf.spo.SPOKeyOrder
-
- _test_multiple_csem_transaction_no_history_stress() - Method in class com.bigdata.rdf.sail.TestMROWTransactionsNoHistory
-
I do observe problems with the "no-history" version of this test.
- _testStress_blockingBuffer_close() - Method in class com.bigdata.relation.accesspath.TestBlockingBuffer
-
- _testStress_dumpJournal_concurrent_updates() - Method in class com.bigdata.journal.TestDumpJournal
-
Stress test to look for different failure modes.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _