| ColumnAggregationEndpoint |
The aggregation implementation at a region.
|
| ColumnAggregationEndpointNullResponse |
Test coprocessor endpoint that always returns null for requests to the last region
in the table.
|
| ColumnAggregationEndpointWithErrors |
Test coprocessor endpoint that always throws a DoNotRetryIOException for requests on
the last region in the table.
|
| ProtobufCoprocessorService |
Test implementation of a coprocessor endpoint exposing the
TestRpcServiceProtos.TestProtobufRpcProto
service methods.
|
| SampleRegionWALCoprocessor |
Class for testing WALObserver coprocessor.
|
| SimpleRegionObserver |
A sample region observer that tests the RegionObserver interface.
|
| TestAppendTimeRange |
|
| TestAppendTimeRange.MyObserver |
|
| TestAsyncCoprocessorEndpoint |
|
| TestAsyncCoprocessorEndpoint.DummyRegionServerEndpoint |
|
| TestBatchCoprocessorEndpoint |
TestEndpoint: test cases to verify the batch execution of coprocessor Endpoint
|
| TestClassLoading |
Test coprocessors class loading.
|
| TestClassLoading.TestMasterCoprocessor |
|
| TestCoprocessorConfiguration |
Tests for global coprocessor loading configuration
|
| TestCoprocessorConfiguration.SystemCoprocessor |
|
| TestCoprocessorConfiguration.TableCoprocessor |
|
| TestCoprocessorEndpoint |
TestEndpoint: test cases to verify coprocessor Endpoint
|
| TestCoprocessorHost |
|
| TestCoprocessorHost.CoprocessorHostForTest<E extends org.apache.hadoop.hbase.Coprocessor> |
|
| TestCoprocessorHost.SimpleRegionObserverV2 |
|
| TestCoprocessorHost.SimpleRegionObserverV3 |
|
| TestCoprocessorHost.TestAbortable |
An Abortable implementation for tests.
|
| TestCoprocessorInterface |
|
| TestCoprocessorInterface.CoprocessorII |
|
| TestCoprocessorInterface.CoprocessorImpl |
|
| TestCoprocessorInterface.CustomScanner |
|
| TestCoprocessorMetrics |
Testing of coprocessor metrics end-to-end.
|
| TestCoprocessorMetrics.CustomMasterObserver |
MasterObserver that has a Timer metric for create table operation.
|
| TestCoprocessorMetrics.CustomRegionEndpoint |
RegionEndpoint to test metrics from endpoint calls
|
| TestCoprocessorMetrics.CustomRegionObserver |
RegionObserver that has a Counter for preGet()
|
| TestCoprocessorMetrics.CustomRegionObserver2 |
|
| TestCoprocessorMetrics.CustomRegionServerObserver |
RegionServerObserver that has a Counter for rollWAL requests.
|
| TestCoprocessorMetrics.CustomWALObserver |
WALObserver that has a Counter for walEdits written.
|
| TestCoprocessorServiceBackwardCompatibility |
Tests to ensure that 2.0 is backward compatible in loading CoprocessorService.
|
| TestCoprocessorServiceBackwardCompatibility.DummyCoprocessorService |
|
| TestCoprocessorShortCircuitRPC |
Ensure Coprocessors get ShortCircuit Connections when they get a Connection from their
CoprocessorEnvironment.
|
| TestCoprocessorShortCircuitRPC.TestMasterCoprocessor |
|
| TestCoprocessorShortCircuitRPC.TestRegionCoprocessor |
|
| TestCoprocessorShortCircuitRPC.TestRegionServerCoprocessor |
|
| TestCoprocessorStop |
Tests for master and regionserver coprocessor stop method
|
| TestCoprocessorStop.FooCoprocessor |
|
| TestCoprocessorTableEndpoint |
|
| TestCoreMasterCoprocessor |
Test CoreCoprocessor Annotation works giving access to facility not usually available.
|
| TestCoreMasterCoprocessor.CoreMasterCoprocessor |
Annotate with CoreCoprocessor.
|
| TestCoreMasterCoprocessor.NotCoreMasterCoprocessor |
No annotation with CoreCoprocessor.
|
| TestCoreRegionCoprocessor |
Test CoreCoprocessor Annotation works giving access to facility not usually available.
|
| TestCoreRegionCoprocessor.CoreRegionCoprocessor |
Annotate with CoreCoprocessor.
|
| TestCoreRegionCoprocessor.NotCoreRegionCoprocessor |
No annotation with CoreCoprocessor.
|
| TestCoreRegionServerCoprocessor |
Test CoreCoprocessor Annotation works giving access to facility not usually available.
|
| TestCoreRegionServerCoprocessor.CoreRegionServerCoprocessor |
Annotate with CoreCoprocessor.
|
| TestCoreRegionServerCoprocessor.NotCoreRegionServerCoprocessor |
No annotation with CoreCoprocessor.
|
| TestImportExport |
|
| TestIncrementAndAppendWithNullResult |
|
| TestIncrementAndAppendWithNullResult.MyObserver |
|
| TestIncrementTimeRange |
This test runs batch mutation with Increments which have custom TimeRange.
|
| TestIncrementTimeRange.MyObserver |
|
| TestMasterCoprocessorExceptionWithAbort |
Tests unhandled exceptions thrown by coprocessors running on master.
|
| TestMasterCoprocessorExceptionWithAbort.BuggyMasterObserver |
|
| TestMasterCoprocessorExceptionWithAbort.CreateTableThread |
|
| TestMasterCoprocessorExceptionWithAbort.MasterTracker |
|
| TestMasterCoprocessorExceptionWithRemove |
Tests unhandled exceptions thrown by coprocessors running on master.
|
| TestMasterCoprocessorExceptionWithRemove.BuggyMasterObserver |
|
| TestMasterCoprocessorExceptionWithRemove.MasterTracker |
|
| TestMasterObserver |
Tests invocation of the MasterObserver
interface hooks at all appropriate times during normal HMaster operations.
|
| TestMasterObserver.CPMasterObserver |
|
| TestMasterObserverToModifyTableSchema |
|
| TestMasterObserverToModifyTableSchema.OnlyOneVersionAllowedMasterObserver |
|
| TestMetaTableMetrics |
|
| TestNegativeMemStoreSizeWithSlowCoprocessor |
Test that verifies we do not have memstore size negative when a postPut/Delete hook is
slow/expensive and a flush is triggered at the same time the coprocessow is doing its work.
|
| TestNegativeMemStoreSizeWithSlowCoprocessor.FlushingRegionObserver |
|
| TestOpenTableInCoprocessor |
Test that a coprocessor can open a connection and write to another table, inside a hook.
|
| TestOpenTableInCoprocessor.CustomThreadPoolCoprocessor |
Coprocessor that creates an HTable with a pool to write to another table
|
| TestOpenTableInCoprocessor.SendToOtherTableCoprocessor |
Custom coprocessor that just copies the write to another table.
|
| TestPassCustomCellViaRegionObserver |
|
| TestPassCustomCellViaRegionObserver.RegionObserverImpl |
|
| TestPostIncrementAndAppendBeforeWAL |
Test coprocessor methods
RegionObserver.postIncrementBeforeWAL(ObserverContext, Mutation, List) and
RegionObserver.postAppendBeforeWAL(ObserverContext, Mutation, List).
|
| TestPostIncrementAndAppendBeforeWAL.ChangeCellWithDifferntColumnFamilyObserver |
|
| TestPostIncrementAndAppendBeforeWAL.ChangeCellWithNotExistColumnFamilyObserver |
|
| TestReadOnlyConfiguration |
|
| TestRegionCoprocessorHost |
|
| TestRegionObserverBypass |
|
| TestRegionObserverBypass.TestCoprocessor |
|
| TestRegionObserverBypass.TestCoprocessor2 |
Calls through to TestCoprocessor.
|
| TestRegionObserverBypass.TestCoprocessor3 |
Calls through to TestCoprocessor.
|
| TestRegionObserverForAddingMutationsFromCoprocessors |
|
| TestRegionObserverForAddingMutationsFromCoprocessors.TestDeleteCellCoprocessor |
|
| TestRegionObserverForAddingMutationsFromCoprocessors.TestDeleteFamilyCoprocessor |
|
| TestRegionObserverForAddingMutationsFromCoprocessors.TestDeleteRowCoprocessor |
|
| TestRegionObserverForAddingMutationsFromCoprocessors.TestMultiMutationCoprocessor |
|
| TestRegionObserverForAddingMutationsFromCoprocessors.TestPutWithTTLCoprocessor |
|
| TestRegionObserverForAddingMutationsFromCoprocessors.TestWALObserver |
|
| TestRegionObserverInterface |
|
| TestRegionObserverInterface.EvenOnlyCompactor |
|
| TestRegionObserverInterface.PreWALAppendWALActionsListener |
|
| TestRegionObserverPreFlushAndPreCompact |
Test that we fail if a Coprocessor tries to return a null scanner out
RegionObserver.preFlush(ObserverContext, Store, InternalScanner, FlushLifeCycleTracker)
or RegionObserver.preCompact(ObserverContext, Store, InternalScanner, ScanType,
CompactionLifeCycleTracker, CompactionRequest)
|
| TestRegionObserverPreFlushAndPreCompact.TestRegionObserver |
Coprocessor that returns null when preCompact or preFlush is called.
|
| TestRegionObserverScannerOpenHook |
|
| TestRegionObserverScannerOpenHook.CompactionCompletionNotifyingRegion |
|
| TestRegionObserverScannerOpenHook.EmptyRegionObsever |
Do the default logic in RegionObserver interface.
|
| TestRegionObserverScannerOpenHook.NoDataFilter |
|
| TestRegionObserverScannerOpenHook.NoDataFromCompaction |
Don't allow any data to be written out in the compaction by creating a custom
StoreScanner.
|
| TestRegionObserverScannerOpenHook.NoDataFromFlush |
Don't allow any data in a flush by creating a custom StoreScanner.
|
| TestRegionObserverScannerOpenHook.NoDataFromScan |
Don't return any data from a scan by creating a custom StoreScanner.
|
| TestRegionObserverStacking |
|
| TestRegionObserverStacking.ObserverA |
|
| TestRegionObserverStacking.ObserverB |
|
| TestRegionObserverStacking.ObserverC |
|
| TestRegionServerCoprocessorEndpoint |
|
| TestRegionServerCoprocessorEndpoint.DummyRegionServerEndpoint |
|
| TestRegionServerCoprocessorExceptionWithAbort |
Tests unhandled exceptions thrown by coprocessors running on a regionserver..
|
| TestRegionServerCoprocessorExceptionWithAbort.BuggyRegionObserver |
|
| TestRegionServerCoprocessorExceptionWithAbort.FailedInitializationObserver |
|
| TestRegionServerCoprocessorExceptionWithRemove |
Tests unhandled exceptions thrown by coprocessors running on regionserver.
|
| TestRegionServerCoprocessorExceptionWithRemove.BuggyRegionObserver |
|
| TestRowProcessorEndpoint |
Verifies ProcessEndpoint works.
|
| TestRowProcessorEndpoint.RowProcessorEndpoint<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> |
This class defines two RowProcessors:
IncrementCounterProcessor and FriendsOfFriendsProcessor.
|
| TestRowProcessorEndpoint.RowProcessorEndpoint.FriendsOfFriendsProcessor |
|
| TestRowProcessorEndpoint.RowProcessorEndpoint.IncrementCounterProcessor |
|
| TestRowProcessorEndpoint.RowProcessorEndpoint.RowSwapProcessor |
|
| TestRowProcessorEndpoint.RowProcessorEndpoint.TimeoutProcessor |
|
| TestSecureExport |
|
| TestWALObserver |
Tests invocation of the
MasterObserver interface hooks at
all appropriate times during normal HMaster operations.
|