@InterfaceAudience.LimitedPrivate(value="Configuration") public class VisibilityController extends BaseMasterAndRegionObserver implements VisibilityLabelsProtos.VisibilityLabelsService.Interface, CoprocessorService
| Modifier and Type | Class and Description | 
|---|---|
| static class  | VisibilityController.VisibilityReplicationA RegionServerObserver impl that provides the custom
 VisibilityReplicationEndpoint. | 
Coprocessor.StateRegionObserver.MutationTypePRIORITY_HIGHEST, PRIORITY_LOWEST, PRIORITY_SYSTEM, PRIORITY_USER, VERSION| Constructor and Description | 
|---|
| VisibilityController() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | addLabels(com.google.protobuf.RpcController controller,
         VisibilityLabelsProtos.VisibilityLabelsRequest request,
         com.google.protobuf.RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse> done)VisibilityEndpoint service related methods | 
| void | clearAuths(com.google.protobuf.RpcController controller,
          VisibilityLabelsProtos.SetAuthsRequest request,
          com.google.protobuf.RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse> done)rpc clearAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse); | 
| void | getAuths(com.google.protobuf.RpcController controller,
        VisibilityLabelsProtos.GetAuthsRequest request,
        com.google.protobuf.RpcCallback<VisibilityLabelsProtos.GetAuthsResponse> done)rpc getAuths(.GetAuthsRequest) returns (.GetAuthsResponse); | 
| com.google.protobuf.Service | getService() | 
| void | listLabels(com.google.protobuf.RpcController controller,
          VisibilityLabelsProtos.ListLabelsRequest request,
          com.google.protobuf.RpcCallback<VisibilityLabelsProtos.ListLabelsResponse> done)rpc listLabels(.ListLabelsRequest) returns (.ListLabelsResponse); | 
| DeleteTracker | postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment> ctx,
                            DeleteTracker delTracker)Called after the ScanQueryMatcher creates ScanDeleteTracker. | 
| void | postLogReplay(ObserverContext<RegionCoprocessorEnvironment> e)Called after the log replay on the region is over. | 
| Cell | postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
                     RegionObserver.MutationType opType,
                     Mutation mutation,
                     Cell oldCell,
                     Cell newCell)Called after a new cell has been created during an increment operation, but before
 it is committed to the WAL or memstore. | 
| void | postOpen(ObserverContext<RegionCoprocessorEnvironment> e)Region related hooks | 
| void | postScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
                InternalScanner s)Called after the client closes a scanner. | 
| RegionScanner | postScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
               Scan scan,
               RegionScanner s)Called after the client opens a new scanner. | 
| void | postStartMaster(ObserverContext<MasterCoprocessorEnvironment> ctx)Master related hooks | 
| void | preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
            TableName tableName,
            HColumnDescriptor column)Called prior to adding a new column family to the table. | 
| Result | preAppend(ObserverContext<RegionCoprocessorEnvironment> e,
         Append append)Called before Append. | 
| void | preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c,
              MiniBatchOperationInProgress<Mutation> miniBatchOp)This will be called for every batch mutation operation happening at the server. | 
| void | preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               byte[] c)Called prior to deleting the entire column family. | 
| void | preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName)Called prior to disabling a table. | 
| void | preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
        Get get,
        List<Cell> results)Called before the client performs a Get | 
| Result | preIncrement(ObserverContext<RegionCoprocessorEnvironment> e,
            Increment increment)Called before Increment. | 
| void | preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx,
               TableName tableName,
               HColumnDescriptor descriptor)Called prior to modifying a column family's attributes. | 
| void | preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
              TableName tableName,
              HTableDescriptor htd)Called prior to modifying a table's properties. | 
| void | prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx,
                                   Mutation delete,
                                   Cell cell,
                                   byte[] byteNow,
                                   Get get)Called before the server updates the timestamp for version delete with latest timestamp. | 
| void | preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
               InternalScanner s)Called before the client closes a scanner. | 
| boolean | preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
              InternalScanner s,
              List<Result> result,
              int limit,
              boolean hasNext)Called before the client asks for the next row on a scanner. | 
| RegionScanner | preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> e,
              Scan scan,
              RegionScanner s)Called before the client opens a new scanner. | 
| void | setAuths(com.google.protobuf.RpcController controller,
        VisibilityLabelsProtos.SetAuthsRequest request,
        com.google.protobuf.RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse> done)rpc setAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse); | 
| void | start(CoprocessorEnvironment env) | 
| void | stop(CoprocessorEnvironment env) | 
postAbortProcedure, postAddColumn, postAddColumnHandler, postAssign, postBalance, postBalanceSwitch, postCloneSnapshot, postCreateNamespace, postCreateTable, postCreateTableHandler, postDeleteColumn, postDeleteColumnHandler, postDeleteNamespace, postDeleteSnapshot, postDeleteTable, postDeleteTableHandler, postDisableTable, postDisableTableHandler, postEnableTable, postEnableTableHandler, postGetNamespaceDescriptor, postGetTableDescriptors, postGetTableDescriptors, postGetTableNames, postListNamespaceDescriptors, postListProcedures, postListSnapshot, postModifyColumn, postModifyColumnHandler, postModifyNamespace, postModifyTable, postModifyTableHandler, postMove, postRegionOffline, postRestoreSnapshot, postSetNamespaceQuota, postSetTableQuota, postSetUserQuota, postSetUserQuota, postSetUserQuota, postSnapshot, postTableFlush, postTruncateTable, postTruncateTableHandler, postUnassign, preAbortProcedure, preAddColumnHandler, preAssign, preBalance, preBalanceSwitch, preCloneSnapshot, preCreateNamespace, preCreateTable, preCreateTableHandler, preDeleteColumnHandler, preDeleteNamespace, preDeleteSnapshot, preDeleteTable, preDeleteTableHandler, preDisableTableHandler, preEnableTable, preEnableTableHandler, preGetNamespaceDescriptor, preGetTableDescriptors, preGetTableDescriptors, preGetTableNames, preListNamespaceDescriptors, preListProcedures, preListSnapshot, preMasterInitialization, preModifyColumnHandler, preModifyNamespace, preModifyTableHandler, preMove, preRegionOffline, preRestoreSnapshot, preSetNamespaceQuota, preSetTableQuota, preSetUserQuota, preSetUserQuota, preSetUserQuota, preShutdown, preSnapshot, preStopMaster, preTableFlush, preTruncateTable, preTruncateTableHandler, preUnassignpostAppend, postBatchMutate, postBatchMutateIndispensably, postBulkLoadHFile, postCheckAndDelete, postCheckAndPut, postClose, postCloseRegionOperation, postCompact, postCompact, postCompactSelection, postCompactSelection, postCompleteSplit, postDelete, postExists, postFlush, postFlush, postGetClosestRowBefore, postGetOp, postIncrement, postIncrementColumnValue, postPut, postRollBackSplit, postScannerFilterRow, postScannerNext, postSplit, postStartRegionOperation, postStoreFileReaderOpen, postWALRestore, postWALRestore, preAppendAfterRowLock, preBulkLoadHFile, preCheckAndDelete, preCheckAndDeleteAfterRowLock, preCheckAndPut, preCheckAndPutAfterRowLock, preClose, preCompact, preCompact, preCompactScannerOpen, preCompactScannerOpen, preCompactSelection, preCompactSelection, preDelete, preExists, preFlush, preFlush, preFlushScannerOpen, preGetClosestRowBefore, preIncrementAfterRowLock, preIncrementColumnValue, preOpen, prePut, preRollBackSplit, preSplit, preSplit, preSplitAfterPONR, preSplitBeforePONR, preStoreFileReaderOpen, preStoreScannerOpen, preWALRestore, preWALRestorepublic void start(CoprocessorEnvironment env) throws IOException
start in interface Coprocessorstart in class BaseMasterAndRegionObserverIOExceptionpublic void stop(CoprocessorEnvironment env) throws IOException
stop in interface Coprocessorstop in class BaseMasterAndRegionObserverIOExceptionpublic void postStartMaster(ObserverContext<MasterCoprocessorEnvironment> ctx) throws IOException
postStartMaster in interface MasterObserverpostStartMaster in class BaseMasterAndRegionObserverIOExceptionpublic void preModifyTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HTableDescriptor htd) throws IOException
MasterObserverpreModifyTable in interface MasterObserverpreModifyTable in class BaseMasterAndRegionObserverctx - the environment to interact with the framework and mastertableName - the name of the tablehtd - the HTableDescriptorIOExceptionpublic void preAddColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor column) throws IOException
MasterObserverpreAddColumn in interface MasterObserverpreAddColumn in class BaseMasterAndRegionObserverctx - the environment to interact with the framework and mastertableName - the name of the tablecolumn - the HColumnDescriptorIOExceptionpublic void preModifyColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, HColumnDescriptor descriptor) throws IOException
MasterObserverpreModifyColumn in interface MasterObserverpreModifyColumn in class BaseMasterAndRegionObserverctx - the environment to interact with the framework and mastertableName - the name of the tabledescriptor - the HColumnDescriptorIOExceptionpublic void preDeleteColumn(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName, byte[] c) throws IOException
MasterObserverpreDeleteColumn in interface MasterObserverpreDeleteColumn in class BaseMasterAndRegionObserverctx - the environment to interact with the framework and mastertableName - the name of the tablec - the columnIOExceptionpublic void preDisableTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableName tableName) throws IOException
MasterObserverpreDisableTable in interface MasterObserverpreDisableTable in class BaseMasterAndRegionObserverctx - the environment to interact with the framework and mastertableName - the name of the tableIOExceptionpublic void postOpen(ObserverContext<RegionCoprocessorEnvironment> e)
postOpen in interface RegionObserverpostOpen in class BaseRegionObservere - the environment provided by the region serverpublic void postLogReplay(ObserverContext<RegionCoprocessorEnvironment> e)
RegionObserverpostLogReplay in interface RegionObserverpostLogReplay in class BaseRegionObservere - the environment provided by the region serverpublic void preBatchMutate(ObserverContext<RegionCoprocessorEnvironment> c, MiniBatchOperationInProgress<Mutation> miniBatchOp) throws IOException
RegionObserverMiniBatchOperationInProgress.setOperationStatus(int, OperationStatus)),
 RegionObserver can make Region to skip these Mutations.preBatchMutate in interface RegionObserverpreBatchMutate in class BaseRegionObserverc - the environment provided by the region serverminiBatchOp - batch of Mutations getting applied to region.IOException - if an error occurred on the coprocessorpublic void prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
prePrepareTimeStampForDeleteVersion in interface RegionObserverprePrepareTimeStampForDeleteVersion in class BaseRegionObserverctx - the environment provided by the region serverdelete - - the parent mutation associated with this delete cellcell - - The deleteColumn with latest version cellbyteNow - - timestamp bytesget - - the get formed using the current cell's row.
 Note that the get does not specify the family and qualifierIOExceptionpublic RegionScanner preScannerOpen(ObserverContext<RegionCoprocessorEnvironment> e, Scan scan, RegionScanner s) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
preScannerOpen in interface RegionObserverpreScannerOpen in class BaseRegionObservere - the environment provided by the region serverscan - the Scan specifications - if not null, the base scannerIOException - if an error occurred on the coprocessorpublic DeleteTracker postInstantiateDeleteTracker(ObserverContext<RegionCoprocessorEnvironment> ctx, DeleteTracker delTracker) throws IOException
RegionObserverpostInstantiateDeleteTracker in interface RegionObserverpostInstantiateDeleteTracker in class BaseRegionObserverctx - the environment provided by the region serverdelTracker - the deleteTracker that is created by the QueryMatcherIOExceptionpublic RegionScanner postScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c, Scan scan, RegionScanner s) throws IOException
RegionObserverCall CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
postScannerOpen in interface RegionObserverpostScannerOpen in class BaseRegionObserverc - the environment provided by the region serverscan - the Scan specifications - if not null, the base scannerIOException - if an error occurred on the coprocessorpublic boolean preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, List<Result> result, int limit, boolean hasNext) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
preScannerNext in interface RegionObserverpreScannerNext in class BaseRegionObserverc - the environment provided by the region servers - the scannerresult - The result to return to the client if default processing
 is bypassed. Can be modified. Will not be returned if default processing
 is not bypassed.limit - the maximum number of results to returnhasNext - the 'has more' indicationIOException - if an error occurred on the coprocessorpublic void preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
preScannerClose in interface RegionObserverpreScannerClose in class BaseRegionObserverc - the environment provided by the region servers - the scannerIOException - if an error occurred on the coprocessorpublic void postScannerClose(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s) throws IOException
RegionObserverCall CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
postScannerClose in interface RegionObserverpostScannerClose in class BaseRegionObserverc - the environment provided by the region servers - the scannerIOException - if an error occurred on the coprocessorpublic void preGetOp(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
preGetOp in interface RegionObserverpreGetOp in class BaseRegionObservere - the environment provided by the region serverget - the Get requestresults - The result to return to the client if default processing
 is bypassed. Can be modified. Will not be used if default processing
 is not bypassed.IOException - if an error occurred on the coprocessorpublic Result preAppend(ObserverContext<RegionCoprocessorEnvironment> e, Append append) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
preAppend in interface RegionObserverpreAppend in class BaseRegionObservere - the environment provided by the region serverappend - Append objectIOException - if an error occurred on the coprocessorpublic Result preIncrement(ObserverContext<RegionCoprocessorEnvironment> e, Increment increment) throws IOException
RegionObserverCall CoprocessorEnvironment#bypass to skip default actions
Call CoprocessorEnvironment#complete to skip any subsequent chained coprocessors
preIncrement in interface RegionObserverpreIncrement in class BaseRegionObservere - the environment provided by the region serverincrement - increment objectIOException - if an error occurred on the coprocessorpublic Cell postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell) throws IOException
RegionObserverObserverContext.bypass() has no
 effect in this hook.postMutationBeforeWAL in interface RegionObserverpostMutationBeforeWAL in class BaseRegionObserverctx - the environment provided by the region serveropType - the operation typemutation - the current mutationoldCell - old cell containing previous valuenewCell - the new cell containing the computed valueIOExceptionpublic com.google.protobuf.Service getService()
getService in interface CoprocessorServicepublic void addLabels(com.google.protobuf.RpcController controller,
             VisibilityLabelsProtos.VisibilityLabelsRequest request,
             com.google.protobuf.RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse> done)
addLabels in interface VisibilityLabelsProtos.VisibilityLabelsService.Interfacepublic void setAuths(com.google.protobuf.RpcController controller,
            VisibilityLabelsProtos.SetAuthsRequest request,
            com.google.protobuf.RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse> done)
VisibilityLabelsProtos.VisibilityLabelsService.Interfacerpc setAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);setAuths in interface VisibilityLabelsProtos.VisibilityLabelsService.Interfacepublic void getAuths(com.google.protobuf.RpcController controller,
            VisibilityLabelsProtos.GetAuthsRequest request,
            com.google.protobuf.RpcCallback<VisibilityLabelsProtos.GetAuthsResponse> done)
VisibilityLabelsProtos.VisibilityLabelsService.Interfacerpc getAuths(.GetAuthsRequest) returns (.GetAuthsResponse);getAuths in interface VisibilityLabelsProtos.VisibilityLabelsService.Interfacepublic void clearAuths(com.google.protobuf.RpcController controller,
              VisibilityLabelsProtos.SetAuthsRequest request,
              com.google.protobuf.RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse> done)
VisibilityLabelsProtos.VisibilityLabelsService.Interfacerpc clearAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);clearAuths in interface VisibilityLabelsProtos.VisibilityLabelsService.Interfacepublic void listLabels(com.google.protobuf.RpcController controller,
              VisibilityLabelsProtos.ListLabelsRequest request,
              com.google.protobuf.RpcCallback<VisibilityLabelsProtos.ListLabelsResponse> done)
VisibilityLabelsProtos.VisibilityLabelsService.Interfacerpc listLabels(.ListLabelsRequest) returns (.ListLabelsResponse);listLabels in interface VisibilityLabelsProtos.VisibilityLabelsService.InterfaceCopyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.