- W - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'W'
- WAIT_ON_REGIONSERVERS_INTERVAL - Static variable in class org.apache.hadoop.hbase.master.ServerManager
-
- WAIT_ON_REGIONSERVERS_MAXTOSTART - Static variable in class org.apache.hadoop.hbase.master.ServerManager
-
- WAIT_ON_REGIONSERVERS_MINTOSTART - Static variable in class org.apache.hadoop.hbase.master.ServerManager
-
- WAIT_ON_REGIONSERVERS_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.ServerManager
-
- waitBackupMaster(HBaseTestingUtility, HMaster) - Static method in class org.apache.hadoop.hbase.master.procedure.TestMasterFailoverWithProcedures
-
- Waiter - Class in org.apache.hadoop.hbase
-
A class that provides a standard waitFor pattern
See details at https://issues.apache.org/jira/browse/HBASE-7384
- Waiter.ExplainingPredicate<E extends Exception> - Interface in org.apache.hadoop.hbase
-
A mixin interface, can be used with
Waiter
to explain failed state.
- Waiter.Predicate<E extends Exception> - Interface in org.apache.hadoop.hbase
-
- waitFor(<any>, int, int) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
- waitFor(long, Waiter.Predicate<E>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitFor(long, long, Waiter.Predicate<E>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitFor(long, long, boolean, Waiter.Predicate<E>) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitFor(MasterProcedureEnv, String, ProcedureSyncWait.Predicate<T>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitFor(MasterProcedureEnv, long, long, String, ProcedureSyncWait.Predicate<T>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitFor(long) - Method in class org.apache.hadoop.hbase.MultithreadedTestUtil.TestContext
-
- waitFor(Configuration, long, Waiter.Predicate<E>) - Static method in class org.apache.hadoop.hbase.Waiter
-
- waitFor(Configuration, long, long, Waiter.Predicate<E>) - Static method in class org.apache.hadoop.hbase.Waiter
-
- waitFor(Configuration, long, long, boolean, Waiter.Predicate<E>) - Static method in class org.apache.hadoop.hbase.Waiter
-
Waits up to the duration equal to the specified timeout multiplied by the
Waiter.getWaitForRatio(Configuration)
for the given
Waiter.Predicate
to become
true
, failing the test if the timeout is reached, the Predicate is still
false
and failIfTimeout is set as
true
.
- waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
-
- waitForActiveAndReadyMaster() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Blocks until there is an active master and that master has completed
initialization.
- waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Blocks until there is an active master and that master has completed
initialization.
- waitForActiveAndReadyMaster(long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Blocks until there is an active master and that master has completed
initialization.
- waitForAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Waits until the specified region has completed assignment.
- waitForAssignment(Collection<HRegionInfo>, boolean, int, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Waits until the specified region has completed assignment, or the deadline is reached.
- waitForAssignment(Collection<HRegionInfo>, boolean, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Waits until the specified region has completed assignment, or the deadline is reached.
- waitForBaseZNode(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Waits for HBase installation's base (parent) znode to become available.
- waitForBlocking() - Method in class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker
-
- waitForCall() - Method in class org.apache.hadoop.hbase.GenericTestUtils.DelayAnswer
-
Wait until the method is called.
- waitForCompactionToBlock() - Method in class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion
-
- waitForCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Waits until the entire procedure has globally completed, or has been aborted.
- waitForCompletedWithRet() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Waits until the entire procedure has globally completed, or has been aborted.
- waitForCreation() - Method in class org.apache.hadoop.hbase.regionserver.TestMasterAddressTracker.NodeCreationListener
-
- waitForCreation() - Method in class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.TestingZKListener
-
- waitForDataChange() - Method in class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.TestingZKListener
-
- waitForDatanodesRegistered(int) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
- waitForDeletion() - Method in class org.apache.hadoop.hbase.master.TestActiveMasterManager.NodeDeletionListener
-
- waitForDeletion() - Method in class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.TestingZKListener
-
- waitForFinish() - Method in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
-
- waitForFinish() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- waitForFinish() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
-
- waitForFinish() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter
-
- waitForFirstPut() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegion.PutThread
-
Block until this thread has put at least one row.
- waitForFlushesAndCompactions() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- waitForFlushesAndCompactions() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Wait for all current flushes and compactions of the region to complete
- waitForHostPort(String, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitForLabelsRegionAvailability(HRegionServer) - Method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabels
-
- waitForLatch(CountDownLatch, ForeignExceptionSnare, long, String) - Static method in class org.apache.hadoop.hbase.procedure.Procedure
-
Wait for latch to count to zero, ignoring any spurious wake-ups, but waking periodically to
check for errors
- waitForLocallyCompleted() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Waits until the entire procedure has globally completed, or has been aborted.
- waitForMasterActive() - Method in class org.apache.hadoop.hbase.master.HMaster
-
If configured to put regions on active master,
wait till a backup master becomes active.
- waitForMasterActive() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
-
- waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Wait for the specified master to stop the thread / process.
- waitForMasterToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
- waitForNamenodeAvailable() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Wait for the namenode.
- waitForNumReplicas(int) - Method in class org.apache.hadoop.hbase.master.procedure.TestWALProcedureStoreOnHDFS
-
- waitForOutstandingTasks() - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager.SimpleSubprocedurePool
-
- waitForPreviousTransactionsComplete() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Wait for all previous MVCC transactions complete
- waitForPreviousTransactionsComplete(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- waitForProcedureToComplete(ProcedureExecutor<MasterProcedureEnv>, long) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitForRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Get everything ready for region merge
- waitForRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
Wait for the merging node to be transitioned from pending_merge
to merging by master.
- waitForRegionServers(MonitoredTask) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Wait for the region servers to report in.
- waitForRegionServerToStart(String, int, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Wait for the specified region server to join the cluster
- waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
-
- waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Wait for the specified region server to stop the thread / process.
- waitForRegionServerToStop(ServerName, long) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
- waitForReplication() - Method in class org.apache.hadoop.hbase.test.IntegrationTestReplication.VerifyReplicationLoop
-
- waitForResult() - Method in class org.apache.hadoop.hbase.GenericTestUtils.DelayAnswer
-
After calling proceed(), this will wait until the call has
completed and a result has been returned to the caller.
- waitForServerOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- waitForServerOnline() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
Block until the region server has come online, indicating it is ready
to be used.
- waitForSnapshotToComplete(HMaster, HBaseProtos.SnapshotDescription, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Helper method for testing async snapshot operations.
- waitForSplitTransaction(RegionServerServices, Region, HRegionInfo, HRegionInfo, SplitTransactionCoordination.SplitTransactionDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
Wait while coordination process the transaction
- waitForSplitTransaction(RegionServerServices, Region, HRegionInfo, HRegionInfo, SplitTransactionCoordination.SplitTransactionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
Wait for the splitting node to be transitioned from pending_split to splitting by master.
- waitForState(long, HBaseAdmin.ProcedureFuture.WaitForStateCallable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- waitForStop() - Method in class org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
-
- waitForStop() - Method in class org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
-
- waitForStop() - Method in class org.apache.hadoop.hbase.chaos.monkies.PolicyBasedChaosMonkey
-
Wait for ChaosMonkey to stop.
- waitForTableToBeOnline(HBaseTestingUtility, TableName) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- waitForUpdate(long) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Wait for the state map to be updated by assignment manager.
- waitForWaiters(long, int) - Method in class org.apache.hadoop.hbase.util.IdLock
-
- waitForWaiters(long, int) - Method in class org.apache.hadoop.hbase.util.IdReadWriteLock
-
- waitForWork() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- WAITING_TIMEOUT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
WAITING_TIMEOUT = 4;
- WAITING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
WAITING = 3;
- waitingTimeForEvents - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- waitInterval() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- waitInterval(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- waitLabelAvailable(long, String...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Wait until labels is ready in VisibilityLabelsCache.
- waitMetaRegionLocation(ZooKeeperWatcher, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available, and waits for up to the
specified timeout if not immediately available.
- waitMetaRegionLocation(ZooKeeperWatcher, int, long) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available, and waits for up to the
specified timeout if not immediately available.
- waitMetaRegionLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Waits indefinitely for availability of hbase:meta
.
- waitMetaRegions(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitNoProcedureRunning(ProcedureExecutor<TEnv>) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- waitOnMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified master to stop
Removes this thread from list of running threads.
- waitOnMaster(JVMClusterUtil.MasterThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified master to stop
Removes this thread from list of running threads.
- waitOnMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Wait for the specified master to stop.
- waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified region server to stop
Removes this thread from list of running threads.
- waitOnRegionServer(JVMClusterUtil.RegionServerThread) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Wait for the specified region server to stop
Removes this thread from list of running threads.
- waitOnRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Wait for the specified region server to stop.
- waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Wait on region to clear regions-in-transition.
- waitOnRegionToClearRegionsInTransition(HRegionInfo, long) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Wait on region to clear regions-in-transition or time out
- waitOnRegionToClearRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Wait on region to clear regions-in-transition.
- waitOnSafeMode(Configuration, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
If DFS, check safe mode and if so, wait until we clear it.
- waitOperationResult(long) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
Fallback implementation in case the procedure is not supported by the server.
- waitProcedure(ProcedureExecutor<TEnv>, long) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- waitRegionInTransition(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- waitRegionInTransition(MasterProcedureEnv, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitRegionServers(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- waitTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Wait until all regions in a table have been assigned.
- waitTableAvailable(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitTableAvailable(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Wait until all regions in a table have been assigned
- waitTableAvailable(Admin, byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Waits for a table to be 'disabled'.
- waitTableDisabled(Admin, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitTableDisabled(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Waits for a table to be 'disabled'.
- waitTableDisabled(Admin, byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Waits for a table to be 'enabled'.
- waitTableEnabled(byte[], long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Waits for a table to be 'enabled'.
- waitTableEnabled(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- waitToBecomeLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
Blocks until this instance has claimed the leader ZNode in ZooKeeper
- WaitToBeMasterThread(ZooKeeperWatcher, ServerName) - Constructor for class org.apache.hadoop.hbase.master.TestActiveMasterManager.WaitToBeMasterThread
-
- WaitToGetDataThread(ZooKeeperWatcher, String) - Constructor for class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.WaitToGetDataThread
-
- WaitToGetDataThread(ZooKeeperWatcher, String, TestZooKeeperNodeTracker.TestTracker) - Constructor for class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.WaitToGetDataThread
-
- waitUntilAllRegionsAssigned(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Wait until all regions for a table in hbase:meta have a non-empty
info:server, up to 60 seconds.
- waitUntilAllRegionsAssigned(TableName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Wait until all regions for a table in hbase:meta have a non-empty
info:server, or until timeout.
- waitUntilAssigned(Admin, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
- waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
Wait until bulk assign is done.
- waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.BulkReOpen
-
Reopen the regions asynchronously, so always returns true immediately.
- waitUntilDone(long) - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- waitUntilDrained() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
-
- waitUntilNoRegionsInTransition(long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Wait until no regions in transition.
- waitUntilShutDown() - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
-
- waitUntilShutDown() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Wait for HBase Cluster to shut down.
- waitUntilShutDown() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
- waitUtilTriggered() - Method in class org.apache.hadoop.hbase.namespace.TestNamespaceAuditor.CPRegionServerObserver
-
- wakeFrequency - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
frequency to check for errors (ms)
- wakeFrequency - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
frequency to check for errors (ms)
- WAL - Interface in org.apache.hadoop.hbase.wal
-
A Write Ahead Log (WAL) provides service for reading, writing waledits.
- WAL.Entry - Class in org.apache.hadoop.hbase.wal
-
Utility class that lets us keep track of the edit with it's key.
- WAL.Reader - Interface in org.apache.hadoop.hbase.wal
-
When outside clients need to consume persisted WALs, they rely on a provided
Reader.
- WAL_CELL_CODEC_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Configuration key for the class to use when encoding cells in the WAL
- WAL_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- WAL_DURABILITY - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- WAL_FILE_NAME_DELIMITER - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- WAL_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- WAL_OFF - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
Property value to disable write-ahead logging
- WAL_ON - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
Property value to use write-ahead logging
- WAL_PROPERTY - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- WAL_SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration name of WAL storage policy
Valid values are:
NONE: no preference in destination of block replicas
ONE_SSD: place only one block replica in SSD and the remaining in default storage
and ALL_SSD: place all block replicas on SSD
See http://hadoop.apache.org/docs/r2.6.0/hadoop-project-dist/hadoop-hdfs/ArchivalStorage.html
- WAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
WAL = 2;
- WALActionsListener - Interface in org.apache.hadoop.hbase.regionserver.wal
-
Get notification of WAL events.
- WALActionsListener.Base - Class in org.apache.hadoop.hbase.regionserver.wal
-
- WALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
-
Compression in this class is lifted off Compressor/KeyValueCompression.
- WALCellCodec() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
All subclasses must implement a no argument constructor
- WALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Default constructor - all subclasses must implement a constructor with this signature
if they are to be dynamically loaded from the Configuration
.
- WALCellCodec.ByteStringCompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
-
- WALCellCodec.ByteStringUncompressor - Interface in org.apache.hadoop.hbase.regionserver.wal
-
- WALCellCodec.EnsureKvEncoder - Class in org.apache.hadoop.hbase.regionserver.wal
-
- WALCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- WALCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver.wal
-
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
WAL
.
- WALCoprocessorHost(WAL, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
Constructor
- WALEdit - Class in org.apache.hadoop.hbase.regionserver.wal
-
WALEdit: Used in HBase's transaction log (WAL) to represent
the collection of edits (KeyValue objects) corresponding to a
single transaction.
- WALEdit() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- WALEdit(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- WALEditCopro() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpointNoMaster.WALEditCopro
-
- WALEditsReplaySink - Class in org.apache.hadoop.hbase.regionserver.wal
-
This class is responsible for replaying the edits coming from a failed region server.
- WALEditsReplaySink(Configuration, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
-
Create a sink for WAL log entries replay
- WALEntryFilter - Interface in org.apache.hadoop.hbase.replication
-
A Filter for WAL entries before being sent over to replication.
- walFactory - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- WALFactory - Class in org.apache.hadoop.hbase.wal
-
Entry point for users of the Write Ahead Log.
- WALFactory(Configuration, List<WALActionsListener>, String) - Constructor for class org.apache.hadoop.hbase.wal.WALFactory
-
- WALFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- WALFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- WALFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- WALFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- WALInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Simple
InputFormat
for
WAL
files.
- WALInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- WALKey - Class in org.apache.hadoop.hbase.wal
-
A Key for an entry in the change log.
- WALKey() - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
- WALKey(byte[], TableName, long, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
Create the log key for writing to somewhere.
- WALKey(byte[], TableName, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
Create the log key for writing to somewhere.
- WALKey(byte[], TableName, long, long, long) - Constructor for class org.apache.hadoop.hbase.wal.WALKey
-
Create the log key for writing to somewhere.
- WALKey.Version - Enum in org.apache.hadoop.hbase.wal
-
- WALLink - Class in org.apache.hadoop.hbase.io
-
WALLink describes a link to a WAL.
- WALLink(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.io.WALLink
-
- WALLink(Path, String, String) - Constructor for class org.apache.hadoop.hbase.io.WALLink
-
- WALLink(Path, Path) - Constructor for class org.apache.hadoop.hbase.io.WALLink
-
- WALMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- WALMapperSearcher() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher.WALMapperSearcher
-
- WALObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
It's provided to have a way for coprocessors to observe, rewrite,
or skip WALEdits as they are being written to the WAL.
- WALPerformanceEvaluation - Class in org.apache.hadoop.hbase.wal
-
This class runs performance benchmarks for
WAL
.
- WALPerformanceEvaluation() - Constructor for class org.apache.hadoop.hbase.wal.WALPerformanceEvaluation
-
- WALPlayer - Class in org.apache.hadoop.hbase.mapreduce
-
A tool to replay WAL files as a M/R job.
- WALPlayer(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- WALPlayer.WALMapper - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that writes out
Mutation
to be directly applied to
a running HBase instance.
- WALPrettyPrinter - Class in org.apache.hadoop.hbase.wal
-
WALPrettyPrinter prints the contents of a given WAL with a variety of
options affecting formatting and extent of content.
- WALPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Basic constructor that simply initializes values to reasonable defaults.
- WALPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
Fully specified constructor.
- WALProcedureStore - Class in org.apache.hadoop.hbase.procedure2.store.wal
-
WAL implementation of the ProcedureStore.
- WALProcedureStore(Configuration, FileSystem, Path, WALProcedureStore.LeaseRecovery) - Constructor for class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- WALProcedureStore.LeaseRecovery - Interface in org.apache.hadoop.hbase.procedure2.store.wal
-
- WALProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.BulkLoadDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadDescriptor
- WALProtos.BulkLoadDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadDescriptor
- WALProtos.BulkLoadDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.CompactionDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CompactionDescriptor
- WALProtos.CompactionDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CompactionDescriptor
- WALProtos.CompactionDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.FamilyScope - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FamilyScope
- WALProtos.FamilyScope.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FamilyScope
- WALProtos.FamilyScopeOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.FlushDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushDescriptor
- WALProtos.FlushDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushDescriptor
- WALProtos.FlushDescriptor.FlushAction - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum FlushDescriptor.FlushAction
- WALProtos.FlushDescriptor.StoreFlushDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushDescriptor.StoreFlushDescriptor
- WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushDescriptor.StoreFlushDescriptor
- WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.FlushDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.RegionEventDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionEventDescriptor
- WALProtos.RegionEventDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionEventDescriptor
- WALProtos.RegionEventDescriptor.EventType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum RegionEventDescriptor.EventType
- WALProtos.RegionEventDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.ScopeType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum ScopeType
- WALProtos.StoreDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StoreDescriptor
- WALProtos.StoreDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StoreDescriptor
- WALProtos.StoreDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.WALHeader - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALHeader
- WALProtos.WALHeader.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALHeader
- WALProtos.WALHeaderOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.WALKey - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALKey
- WALProtos.WALKey.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALKey
- WALProtos.WALKeyOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProtos.WALTrailer - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALTrailer
- WALProtos.WALTrailer.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALTrailer
- WALProtos.WALTrailerOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- WALProvider - Interface in org.apache.hadoop.hbase.wal
-
The Write Ahead Log (WAL) stores all durable edits to the HRegion.
- WALProvider.Writer - Interface in org.apache.hadoop.hbase.wal
-
- wals - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestProtobufLog
-
- wals - Variable in class org.apache.hadoop.hbase.wal.TestWALFactory
-
- WALSearcher(Configuration) - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher
-
- WALSplitter - Class in org.apache.hadoop.hbase.wal
-
This class is responsible for splitting up a bunch of regionserver commit log
files that are no longer being written to, into new files, one per region for
region to replay on startup.
- WALSplitter.EntryBuffers - Class in org.apache.hadoop.hbase.wal
-
Class which accumulates edits and separates them into a buffer per region
while simultaneously accounting RAM usage.
- WALSplitter.MutationReplay - Class in org.apache.hadoop.hbase.wal
-
A struct used by getMutationsFromWALEntry
- WALSplitter.OutputSink - Class in org.apache.hadoop.hbase.wal
-
The following class is an abstraction class to provide a common interface to support both
existing recovered edits file sink and region server WAL edits replay sink
- WALSplitter.PipelineController - Class in org.apache.hadoop.hbase.wal
-
Contains some methods to control WAL-entries producer / consumer interactions
- WALSplitter.RegionEntryBuffer - Class in org.apache.hadoop.hbase.wal
-
A buffer of some number of edits for a given region.
- WALSplitter.SinkWriter - Class in org.apache.hadoop.hbase.wal
-
Class wraps the actual writer which writes data out and related statistics
- WALSplitter.WriterThread - Class in org.apache.hadoop.hbase.wal
-
- WALSplitterHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles log splitting a wal
- WALSplitterHandler(Server, SplitLogWorkerCoordination, SplitLogWorkerCoordination.SplitTaskDetails, CancelableProgressable, AtomicInteger, SplitLogWorker.TaskExecutor, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.WALSplitterHandler
-
- WALStoreLeaseRecovery(HMaster) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.WALStoreLeaseRecovery
-
- WALUtil - Class in org.apache.hadoop.hbase.regionserver.wal
-
Helper methods to ease Region Server integration with the write ahead log.
- WALUtil() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
- warmupHRegion(HRegionInfo, HTableDescriptor, WAL, Configuration, RegionServerServices, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- warmupRegion(com.google.protobuf.RpcController, AdminProtos.WarmupRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- warmupRegion(com.google.protobuf.RpcController, AdminProtos.WarmupRegionRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc WarmupRegion(.WarmupRegionRequest) returns (.WarmupRegionResponse);
- warmupRegion(com.google.protobuf.RpcController, AdminProtos.WarmupRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- warmupRegion(com.google.protobuf.RpcController, AdminProtos.WarmupRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc WarmupRegion(.WarmupRegionRequest) returns (.WarmupRegionResponse);
- warmupRegion(AdminProtos.AdminService.BlockingInterface, HRegionInfo) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to warmup a region given a region name
using admin protocol
- warmupRegion(RpcController, AdminProtos.WarmupRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Wamrmup a region on this server.
- wasAbortProcedureCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasAddColumnCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasAddColumnHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasAssignCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasBalanceCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasBalanceSwitchCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasCloneSnapshotCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasClosed() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasCompacted() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasCreateNamespaceCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasCreateTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithAbort.BuggyMasterObserver
-
- wasCreateTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithRemove.BuggyMasterObserver
-
- wasCreateTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasCreateTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasCreateTableHandlerCalledOnly() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteColumnCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteColumnHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteNamespaceCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteSnapshotCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDeleteTableHandlerCalledOnly() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDisableTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasDisableTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasEnableTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasEnableTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasExecuted() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- wasFlushed() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasGetNamespaceDescriptorCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasGetTableDescriptorsCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasGetTableNamesCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasListNamespaceDescriptorsCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasListProceduresCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasListSnapshotCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasMasterInitializationCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasModifyColumnCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasModifyColumnHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasModifyNamespaceCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasModifyTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasModifyTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasModifyTableHandlerCalledOnly() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasMoveCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasOpened() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasOperationAttemptedByServer() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
- wasPostMergeCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasPostMergeCommit() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasPostRollBackMerge() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasPreAbortProcedureCalledOnly() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasPreCreateTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasPreListProceduresCalledOnly() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasPreMergeCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasPreMergeCommit() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasPreRollBackMerge() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasRegionMergeCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- wasRegionOfflineCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasRegionOnDeadServerByMeta(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- wasRestoreSnapshotCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasRun - Static variable in class org.apache.hadoop.hbase.constraint.TestConstraint.CheckWasRunConstraint
-
- wasScannerCloseCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasScannerNextCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasScannerOpenCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasSnapshotCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasSplit() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasStarted() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithAbort.BuggyMasterObserver
-
- wasStarted() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithRemove.BuggyMasterObserver
-
- wasStarted() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasStartMasterCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithAbort.BuggyMasterObserver
-
- wasStartMasterCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithRemove.BuggyMasterObserver
-
- wasStartMasterCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasStopped() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasStoreFileReaderOpenCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SimpleRegionObserver
-
- wasTruncateTableCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasTruncateTableHandlerCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasTruncateTableHandlerCalledOnly() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- wasUnassignCalled() - Method in class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- watchAndCheckExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Watch the specified znode for delete/create/change events.
- watcher - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- watcher - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
-
- WeakObjectPool<K,V> - Class in org.apache.hadoop.hbase.util
-
A WeakReference
based shared object pool.
- WeakObjectPool(WeakObjectPool.ObjectFactory<K, V>) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
-
Creates a new pool with the default initial capacity (16)
and the default concurrency level (16).
- WeakObjectPool(WeakObjectPool.ObjectFactory<K, V>, int) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
-
Creates a new pool with the given initial capacity
and the default concurrency level (16).
- WeakObjectPool(WeakObjectPool.ObjectFactory<K, V>, int, int) - Constructor for class org.apache.hadoop.hbase.util.WeakObjectPool
-
Creates a new pool with the given initial capacity
and the given concurrency level.
- WeakObjectPool.ObjectFactory<K,V> - Interface in org.apache.hadoop.hbase.util
-
An ObjectFactory
object is used to create
new shared objects on demand.
- webAppContext - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- webServer - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- WEBUI_PORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- WEEK_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Seconds in a week
- WeightComparator() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- whichFanNode(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- WHILE_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
WHILE Array
- WHILE_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- WhileMatchFilter - Class in org.apache.hadoop.hbase.filter
-
- WhileMatchFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- WHITESPACE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for whitespace
- whoAmI(com.google.protobuf.RpcController, AuthenticationProtos.WhoAmIRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.BlockingInterface
-
- whoAmI(com.google.protobuf.RpcController, AuthenticationProtos.WhoAmIRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Interface
-
rpc WhoAmI(.WhoAmIRequest) returns (.WhoAmIResponse);
- whoAmI(com.google.protobuf.RpcController, AuthenticationProtos.WhoAmIRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Stub
-
- whoAmI(com.google.protobuf.RpcController, AuthenticationProtos.WhoAmIRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
rpc WhoAmI(.WhoAmIRequest) returns (.WhoAmIResponse);
- whoAmI(RpcController, AuthenticationProtos.WhoAmIRequest, <any>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- width - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- width - Variable in class org.apache.hadoop.hbase.test.IntegrationTestReplication
-
- WINDOWS - Static variable in class org.apache.hadoop.hbase.util.FSUtils
-
Set to true on Windows platforms
- wipeOutMeta() - Method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRebuildTestCore
-
- withBlockSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withBloomType(BloomType) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withBytesPerCheckSum(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withChecksumType(ChecksumType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withComparator(KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withComparator(KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withCompression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withFavoredNodes(InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withFileContext(HFileContext) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withFilePath(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withHBaseCheckSum(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- withinOrAfterTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the specified timestamp is within this TimeRange.
- withinTimeRange(byte[], int) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the specified timestamp is within this TimeRange.
- withinTimeRange(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if the specified timestamp is within this TimeRange.
- withMaxKeyCount(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withOutputDir(Path) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- withOutputStream(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- withPath(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- WORKER_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Number fo threads for processing the thrift calls
- workingDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- WorksConstraint - Class in org.apache.hadoop.hbase.constraint
-
It just works
- WorksConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.WorksConstraint
-
- WorksConstraint.NameConstraint - Class in org.apache.hadoop.hbase.constraint
-
Constraint to check that the naming of constraints doesn't mess up the
pattern matching.(that constraint $___Constraint$NameConstraint isn't a
problem)
- wrap(byte[]) - Static method in class com.google.protobuf.HBaseZeroCopyByteString
-
Wraps a byte array in a ByteString
without copying it.
- wrap(byte[], int, int) - Static method in class com.google.protobuf.HBaseZeroCopyByteString
-
Wraps a subset of a byte array in a ByteString
without copying it.
- wrap(byte[]) - Static method in class org.apache.hadoop.hbase.util.ByteStringer
-
Wraps a byte array in a ByteString
without copying it.
- wrap(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteStringer
-
Wraps a subset of a byte array in a ByteString
without copying it.
- wrapException(InetSocketAddress, IOException) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
Take an IOException and the address we were trying to connect to
and return an IOException with the input exception as the cause.
- wrapKey(Configuration, byte[], String) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Protect a key by encrypting it with the secret key of the given subject.
- wrapKey(Configuration, String, Key) - Static method in class org.apache.hadoop.hbase.security.EncryptionUtil
-
Protect a key by encrypting it with the secret key of the given subject.
- wrapMultiplier - Variable in class org.apache.hadoop.hbase.test.IntegrationTestReplication
-
- wrapped - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- Writables - Class in org.apache.hadoop.hbase.util
-
Utility class with methods for manipulating Writable objects
- Writables() - Constructor for class org.apache.hadoop.hbase.util.Writables
-
- WritableWithSize - Interface in org.apache.hadoop.hbase.io
-
An optional interface to 'size' writables.
- write(Cell) - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- write(Cell) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
-
- write(Cell) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
-
- write(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- write(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
writing the compiled structure to the OutputStream
- write(DataOutput) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- write(int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- write(byte[]) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- write(Cell) - Method in interface org.apache.hadoop.hbase.io.CellOutputStream
-
Implementation must copy the entire state of the Cell.
- write(int) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- write(int) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
- write(byte[]) - Method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
- write(DataOutput) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- write(ByteBuffer) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- write(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
Transfers data from the given byte buffer to the buffer array
- write(ByteBuffer, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Transfers data from the given byte buffer to file
- write(ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Transfers data from the given byte buffer to IOEngine
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
-
- write(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Writes the Cell to this block
- write(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- write(FileSystem, Path) - Method in class org.apache.hadoop.hbase.io.Reference
-
- write(OutputStream, Message, Message, ByteBuffer) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
Write out header, param, and cell block if there is one.
- write(KeyValue, DataOutput) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
- write(ImmutableBytesWritable, Put) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.EmptySplit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.LinkChain
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.LinkKey
-
- write(ImmutableBytesWritable, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
Writes an action (Put or Delete) to the specified table.
- write(KEY, Mutation) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Writes a key/value pair into the table.
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Writes the field values to the output.
- write(int) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- write(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.EnsureKvEncoder
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- write(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- write(byte[]) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputSplit
-
- write(OutputStream) - Method in class org.apache.hadoop.hbase.rest.ProtobufStreamingUtil
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- write(DataOutput) - Method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Write to out
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- write(DataOutput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.IOError
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- write(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- write(int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Writes the byte to the output stream after converting to/from Base64
notation.
- write(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
- write(OutputStream, ByteRange) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
-
- write(OutputStream, ByteRange, int) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
-
- write(String, String) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
-
- write(MBeanServer, ObjectName, String, boolean) - Method in interface org.apache.hadoop.hbase.util.JSONBean.Writer
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.append_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
-
- write_args(org.apache.thrift.protocol.TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
-
- WRITE_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.client.TableConfiguration
-
- WRITE_BUFFER_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.client.TableConfiguration
-
- WRITE_FLUSH_WAL_MARKER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- WRITE_LOCK_CHILD_NODE_PREFIX - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
ZNode prefix used by processes acquiring writer locks
- WRITE_NUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- WRITE_NUMBER_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
WRITE_NUMBER = 3;
- WRITE_REQUEST_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- WRITE_REQUEST_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- WRITE_REQUESTS_COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- WRITE_SIZE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- WRITE_SIZE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
WRITE_SIZE = 4;
- WRITE_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- WRITE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
WRITE = 1;
- writeAt(int, int) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- writeBlock(HFileBlock.BlockWritable, FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Takes the given
HFileBlock.BlockWritable
instance, creates a new block of
its appropriate type, writes the writable into this block, and flushes
the block into the output stream.
- writeBlock(HFileBlock.BlockWritable, FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
-
Takes the given
HFileBlock.BlockWritable
instance, creates a new block of
its appropriate type, writes the writable into this block, and flushes
the block into the output stream.
- writeBloom(DataOutput) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Writes just the bloom filter to the output array
- writeBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
Override the write buffer size specified by the provided
Connection
's
org.apache.hadoop.conf.Configuration
instance, via the configuration key
hbase.client.write.buffer
.
- writeBulkLoadMarkerAndSync(WAL, HTableDescriptor, HRegionInfo, WALProtos.BulkLoadDescriptor, AtomicLong) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a log marker that a bulk load has succeeded and is about to be committed.
- writeByteArray(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, Tag[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Write KeyValue format into the provided byte array.
- writeByteArray(DataOutput, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write byte-array with a WritableableUtils.vint prefix.
- writeByteArray(DataOutput, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write byte-array to out with a vint length prefix.
- writeByteArray(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write byte-array from src to tgt with a vint length prefix.
- writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
-
- writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- writeBytes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
- writeBytes(int, long, byte[], int) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
-
- writeBytes(int, long, OutputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
-
- writeBytes(int, OutputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
- writeBytes(long, OutputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
-
- writeCellTypes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writeCompactionMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.CompactionDescriptor, AtomicLong) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write the marker that a compaction has succeeded and is about to be committed.
- writeData(int, int, int, long, long) - Method in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
-
- writeDelete(ByteSlot, long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeEntry(ByteSlot, ProcedureProtos.ProcedureWALEntry.Type, Procedure, Procedure[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeFamilyNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
The following methods write data for each cell in the row, mostly consisting of indexes or
offsets into the timestamp/column data structures that are written in the middle of the block.
- writeFan(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
UVInt: numFanBytes/fanOut
bytes: each fan byte
- writeFileInfo(FixedFileTrailer, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Sets the file info offset in the trailer, finishes up populating fields in
the file info, and writes the file info into the given data output.
- writeFlatKey(Cell, DataOutputStream) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Writes the Cell's key part as it would have serialized in a KeyValue.
- writeFlushMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.FlushDescriptor, AtomicLong, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a flush marker indicating a start / abort or a complete of a region flush
- writeHeader(OutputStream, ProcedureProtos.ProcedureWALHeader) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeHeaderAndData(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- writeHeaderAndData(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
-
- writeIdInBytes(OutputStream) - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Writes id in bytes.
- writeIdInBytes(byte[], int) - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Writes id bytes to the given array starting from offset.
- writeIndexBlocks(FSDataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Writes the root level and intermediate levels of the block index into
the output stream, generating the tree from bottom up.
- writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Write out the current inline index block.
- writeInlineBlock(DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Writes the block to the provided stream.
- writeInlineBlock(DataOutput) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- writeInsert(ByteSlot, Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeInsert(ByteSlot, Procedure, Procedure[]) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- writeLock(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessReadWriteLock
-
Obtain a write lock containing given metadata.
- writeLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager.NullTableLockManager
-
- writeLock(TableName, String) - Method in class org.apache.hadoop.hbase.master.TableLockManager
-
Returns a TableLock for locking the table for exclusive access
- writeLock(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadWriteLock
-
Obtain a write lock containing given metadata.
- writeLong(OutputStream, long) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- writeMapAsString(Map<String, Object>) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
-
- writeMvccVersionIndexes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writeMyEphemeralNodeOnDisk(String) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Logs the errors without failing on exception.
- writeNamespaceToZooKeeper(String, TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- writeNextRowTrieNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
If a branch or a nub, the last thing we append are the UFInt offsets to the child row nodes.
- writeNumCells(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
UVInt: numCells, the number of cells in this row which will be 0 for branch nodes
- writeObjectAsString(Object) - Static method in class org.apache.hadoop.hbase.util.JsonMapper
-
- writePermissions(DataOutput, <any>, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TestTablePermissions
-
Writes a set of permissions as org.apache.hadoop.io.Writable
instances
to the given output stream.
- writePermissionsAsBytes(<any>, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Writes a set of permissions as org.apache.hadoop.io.Writable
instances
and returns the resulting byte array.
- writePermissionsAsBytes(<any>, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TestTablePermissions
-
Writes a set of permissions as org.apache.hadoop.io.Writable
instances
and returns the resulting byte array.
- writeQualifierNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnBuilder
-
- Writer(HFileDataBlockEncoder, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- Writer(Compression.Algorithm, HFileDataBlockEncoder, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
-
- Writer(HFileDataBlockEncoder, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
-
- writer - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- Writer() - Constructor for class org.apache.hadoop.hbase.regionserver.TestStripeCompactor.StoreFileWritersCapture.Writer
-
- writer - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
- WRITER_CLS_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- writeRawVInt32(OutputStream, int) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- WriterBase - Class in org.apache.hadoop.hbase.regionserver.wal
-
Context used by our wal dictionary compressor.
- WriterBase() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- WriterBuilder(Configuration, CacheConfig, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- writeRegionEventMarker(WAL, HTableDescriptor, HRegionInfo, WALProtos.RegionEventDescriptor, AtomicLong) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALUtil
-
Write a region open marker indicating that the region is opened
- writeRegionSequenceIdFile(FileSystem, Path, long, long) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a file with name as region open sequence id
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- writeReplace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- writeReplace() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- WRITEREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- writerFactory - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Factory that is used to produce single StoreFile.Writer-s
- writeRowKeyExcludingCommon(Cell, short, int, DataOutputStream) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Write rowkey excluding the common part.
- writeRowToken(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
UVInt: tokenWidth
bytes: token
- writers - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriter
-
- writers - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- writersClosed - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- writerThreads - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- writerThreads - Variable in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- writerThreads - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- writeScanMetrics() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
Publish the scan metrics.
- writeShort(OutputStream, short) - Static method in class org.apache.hadoop.hbase.io.util.StreamUtils
-
- writeSingleLevelIndex(DataOutput, String) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Writes the block index data as a single level only.
- WriteSinkCoprocessor - Class in org.apache.hadoop.hbase.tool
-
This coprocessor 'shallows' all the writes.
- WriteSinkCoprocessor() - Constructor for class org.apache.hadoop.hbase.tool.WriteSinkCoprocessor
-
- writeSnapshotInfo(HBaseProtos.SnapshotDescription, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Write the snapshot description into the working directory of a snapshot
- writeStoreFile(StoreFile.Writer, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.TestStoreFile
-
- writeStringFixedSize(DataOutput, String, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Writes a string as a fixed-size field, padded with zeros.
- writeTableToZooKeeper(TableName, TableAuthManager.PermissionCache<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- writeTagNodeOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writeTime - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- writeTimestampIndexes(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse
-
- writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
Writes the complete contents of this byte buffer output stream to
the specified output stream argument.
- writeTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto
-
- writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- writeTo(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- writeTo(com.google.protobuf.CodedOutputStream) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- writeTo(Object, Class<?>, Type, Annotation[], MediaType, <any>, OutputStream) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- writeTo(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType, <any>, OutputStream) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- writeTo(PrintWriter) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- writeToBlock(DataOutput) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
-
Writes the block to the provided stream.
- writeToStream(OutputStream) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- writeToWAL - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- writeToZookeeper(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
Write a table's access controls to the permissions mirror in zookeeper
- writeToZookeeper(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- writeToZookeeper(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
Write a labels mirror or user auths mirror into zookeeper
- writeTrailer(FSDataOutputStream, ProcedureStoreTracker) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeUpdate(ByteSlot, Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat
-
- writeValueLengths(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writeValueOffsets(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- writeVariableBytesToOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- writeVLong(ByteBuffer, long) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Similar to
WritableUtils#writeVLong(java.io.DataOutput, long)
,
but writes to a
ByteBuffer
.
- writeWithRepeatRow(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
Add a Cell to the output stream but repeat the previous row.
- writeXml(OutputStream) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- WrongRegionException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown when a request contains a key which is not part of this region
- WrongRegionException() - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
-
constructor
- WrongRegionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.WrongRegionException
-
Constructor
- WrongRowIOException - Exception in org.apache.hadoop.hbase.client
-
- WrongRowIOException(String) - Constructor for exception org.apache.hadoop.hbase.client.WrongRowIOException
-
- WrongVersionException - Exception in org.apache.hadoop.hbase.ipc
-
- WrongVersionException() - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
-
- WrongVersionException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
-
- WrongVersionException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.WrongVersionException
-
- WROTE_FLUSH_WAL_MARKER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- wroteKeyQueueSize - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The total size of the temporary inserted/updated key set that have not yet lined
up in a our contiguous sequence starting from startKey.
- wroteKeys - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
A temporary place to keep track of inserted/updated keys.
- wroteUpToKey - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The highest key in the contiguous range of keys .
- wroteUpToKey() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
The max key until which all keys have been inserted/updated (successfully or not).
- WWW_AUTHENTICATE - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
-